A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _

A

abort() - Method in class akka.actor.ActorSystemImpl
This kind of shutdown attempts to bring the system down and release its resources more forcefully than plain shutdown.
abort() - Method in class akka.io.TcpConnection
 
abort() - Method in class akka.io.TcpMessage$
An abort operation will not flush pending writes and will issue a TCP ABORT command to the O/S kernel which should result in a TCP_RST packet being sent to the peer.
abort() - Static method in class akka.io.TcpMessage
An abort operation will not flush pending writes and will issue a TCP ABORT command to the O/S kernel which should result in a TCP_RST packet being sent to the peer.
abort(RoleName, RoleName) - Method in interface akka.remote.testconductor.Conductor
Tell the remote support to TCP_RESET the connection to the given remote peer.
abort() - Method in class akka.remote.testconductor.Disconnect
 
abort() - Method in class akka.remote.testconductor.DisconnectMsg
 
Abort_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.FailType
Abort = 3;
aborting() - Method in class akka.actor.ActorSystemImpl
 
AbstractActor - Class in akka.actor
Java API: compatible with lambda expressions
AbstractActor() - Constructor for class akka.actor.AbstractActor
 
AbstractActor$ - Class in akka.actor
Java API: compatible with lambda expressions
AbstractActor$() - Constructor for class akka.actor.AbstractActor$
 
AbstractActorContext - Interface in akka.actor
AbstractActorContext is the AbstractActor equivalent of ActorContext, containing the Java API
AbstractActorWithStash - Class in akka.actor
Java API: compatible with lambda expressions
AbstractActorWithStash() - Constructor for class akka.actor.AbstractActorWithStash
 
AbstractActorWithUnboundedStash - Class in akka.actor
Java API: compatible with lambda expressions
AbstractActorWithUnboundedStash() - Constructor for class akka.actor.AbstractActorWithUnboundedStash
 
AbstractActorWithUnrestrictedStash - Class in akka.actor
Java API: compatible with lambda expressions
AbstractActorWithUnrestrictedStash() - Constructor for class akka.actor.AbstractActorWithUnrestrictedStash
 
AbstractEventsourcedProcessor - Class in akka.persistence
Java API: compatible with lambda expressions (to be used with ReceiveBuilder): command handler.
AbstractEventsourcedProcessor() - Constructor for class akka.persistence.AbstractEventsourcedProcessor
 
AbstractExtensionId<T extends Extension> - Class in akka.actor
Java API for ExtensionId
AbstractExtensionId() - Constructor for class akka.actor.AbstractExtensionId
 
AbstractFSM<S,D> - Class in akka.actor
Java API: compatible with lambda expressions
AbstractFSM() - Constructor for class akka.actor.AbstractFSM
 
AbstractFSM$ - Class in akka.actor
Java API: compatible with lambda expressions
AbstractFSM$() - Constructor for class akka.actor.AbstractFSM$
 
AbstractLoggingActor - Class in akka.actor
Java API: compatible with lambda expressions
AbstractLoggingActor() - Constructor for class akka.actor.AbstractLoggingActor
 
AbstractLoggingFSM<S,D> - Class in akka.actor
Java API: compatible with lambda expressions
AbstractLoggingFSM() - Constructor for class akka.actor.AbstractLoggingFSM
 
AbstractNodeQueue<T> - Class in akka.dispatch
Lock-free MPSC linked queue implementation based on Dmitriy Vyukov's non-intrusive MPSC queue: http://www.1024cores.net/home/lock-free-algorithms/queues/non-intrusive-mpsc-node-based-queue This queue could be wait-free (i.e.
AbstractNodeQueue() - Constructor for class akka.dispatch.AbstractNodeQueue
 
AbstractNodeQueue.Node<T> - Class in akka.dispatch
 
AbstractNodeQueue.Node() - Constructor for class akka.dispatch.AbstractNodeQueue.Node
 
AbstractNodeQueue.Node(T) - Constructor for class akka.dispatch.AbstractNodeQueue.Node
 
AbstractPersistentActor - Class in akka.persistence
Java API: an persistent actor - can be used to implement command or event sourcing.
AbstractPersistentActor() - Constructor for class akka.persistence.AbstractPersistentActor
 
AbstractPersistentActorWithAtLeastOnceDelivery - Class in akka.persistence
Java API compatible with lambda expressions
AbstractPersistentActorWithAtLeastOnceDelivery() - Constructor for class akka.persistence.AbstractPersistentActorWithAtLeastOnceDelivery
 
AbstractPersistentView - Class in akka.persistence
Java API: compatible with lambda expressions (to be used with ReceiveBuilder)
AbstractPersistentView() - Constructor for class akka.persistence.AbstractPersistentView
 
AbstractProcessor - Class in akka.persistence
Java API: compatible with lambda expressions
AbstractProcessor() - Constructor for class akka.persistence.AbstractProcessor
 
AbstractScheduler - Class in akka.actor
An Akka scheduler service.
AbstractScheduler() - Constructor for class akka.actor.AbstractScheduler
 
AbstractSchedulerBase - Class in akka.actor
 
AbstractSchedulerBase() - Constructor for class akka.actor.AbstractSchedulerBase
 
AbstractTransportAdapter - Class in akka.remote.transport
An adapter that wraps a transport and provides interception
AbstractTransportAdapter(Transport, ExecutionContext) - Constructor for class akka.remote.transport.AbstractTransportAdapter
 
AbstractTransportAdapterHandle - Class in akka.remote.transport
 
AbstractTransportAdapterHandle(Address, Address, AssociationHandle, String) - Constructor for class akka.remote.transport.AbstractTransportAdapterHandle
 
AbstractTransportAdapterHandle(AssociationHandle, String) - Constructor for class akka.remote.transport.AbstractTransportAdapterHandle
 
AbstractView - Class in akka.persistence
Java API: compatible with lambda expressions (to be used with ReceiveBuilder)
AbstractView() - Constructor for class akka.persistence.AbstractView
 
acceptableHeartbeatPause() - Method in class akka.remote.DeadlineFailureDetector
 
acceptableHeartbeatPause() - Method in class akka.remote.PhiAccrualFailureDetector
 
acceptAllPending(ChannelRegistration, int) - Method in class akka.io.TcpListener
 
accepting() - Method in class akka.remote.EndpointManager
 
acceptLimit() - Method in class akka.io.TcpListener
 
Ack - Class in akka.camel
Positive acknowledgement message (used for application-acknowledged message receipts).
Ack() - Constructor for class akka.camel.Ack
 
ack() - Method in class akka.contrib.mailbox.PeekMailbox
 
ack(ActorContext) - Method in class akka.contrib.mailbox.PeekMailboxExtension$
 
ack(ActorContext) - Method in class akka.contrib.mailbox.PeekMailboxExtension
 
ack() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Internal$.Subscribed
 
ack() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Internal$.Unsubscribed
 
ack() - Method in class akka.io.Tcp.SimpleWriteCommand
The acknowledgment token associated with this write command.
ack() - Method in class akka.io.Tcp.Write
 
ack() - Method in class akka.io.Tcp.WriteFile
 
ack() - Method in class akka.io.Udp.Send
 
ack() - Method in class akka.io.UdpConnected.Send
 
Ack - Class in akka.remote
Class representing an acknowledgement with selective negative acknowledgements.
Ack(SeqNo, Set<SeqNo>) - Constructor for class akka.remote.Ack
 
ack() - Method in class akka.remote.EndpointWriter.OutboundAck
 
Ack$ - Class in akka.camel
Positive acknowledgement message (used for application-acknowledged message receipts).
Ack$() - Constructor for class akka.camel.Ack$
 
Ack$ - Class in akka.remote
 
Ack$() - Constructor for class akka.remote.Ack$
 
ACK_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
ackDeadline() - Method in class akka.remote.EndpointWriter
 
AckedReceiveBuffer<T extends HasSequenceNumber> - Class in akka.remote
Implements an immutable receive buffer that buffers incoming messages until they can be safely delivered.
AckedReceiveBuffer(SeqNo, SeqNo, SortedSet<T>, Ordering<T>) - Constructor for class akka.remote.AckedReceiveBuffer
 
ackedReceiveBuffer() - Method in class akka.remote.EndpointReader
 
AckedReceiveBuffer$ - Class in akka.remote
 
AckedReceiveBuffer$() - Constructor for class akka.remote.AckedReceiveBuffer$
 
AckedSendBuffer<T extends HasSequenceNumber> - Class in akka.remote
Implements an immutable resend buffer that buffers messages until they have been acknowledged.
AckedSendBuffer(int, IndexedSeq<T>, IndexedSeq<T>, SeqNo) - Constructor for class akka.remote.AckedSendBuffer
 
AckedSendBuffer$ - Class in akka.remote
 
AckedSendBuffer$() - Constructor for class akka.remote.AckedSendBuffer$
 
ackIdleTimer() - Method in class akka.remote.EndpointWriter
 
acknowledge(Ack) - Method in class akka.remote.AckedSendBuffer
Processes an incoming acknowledgement and returns a new buffer with only unacknowledged elements remaining.
acquire() - Method in interface akka.io.BufferPool
 
acquire() - Method in class akka.io.DirectByteBufferPool
 
activated(List<ActorRef>) - Method in class akka.camel.internal.ActivationTracker.ActivationStateMachine
Activated state.
Activation - Interface in akka.camel
Activation trait that can be used to wait on activation or de-activation of Camel endpoints.
activationFutureFor(ActorRef, Timeout, ExecutionContext) - Method in interface akka.camel.Activation
Produces a Future with the specified endpoint that will be completed when the endpoint has been activated, or if it times out, which will happen after the specified Timeout.
activationFutureFor(ActorRef, Timeout, ExecutionContext) - Method in class akka.camel.internal.DefaultCamel
Produces a Future with the specified endpoint that will be completed when the endpoint has been activated, or if it times out, which will happen after the specified Timeout.
ActivationProtocol - Class in akka.camel.internal
Copyright (C) 2009-2014 Typesafe Inc.
ActivationProtocol() - Constructor for class akka.camel.internal.ActivationProtocol
 
ActivationProtocol$ - Class in akka.camel.internal
Copyright (C) 2009-2014 Typesafe Inc.
ActivationProtocol$() - Constructor for class akka.camel.internal.ActivationProtocol$
 
ActivationProtocol.ActivationMessage - Class in akka.camel.internal
Super class of all activation messages.
ActivationProtocol.ActivationMessage(ActorRef) - Constructor for class akka.camel.internal.ActivationProtocol.ActivationMessage
 
ActivationProtocol.ActivationMessage$ - Class in akka.camel.internal
INTERNAL API companion object of ActivationMessage
ActivationProtocol.ActivationMessage$() - Constructor for class akka.camel.internal.ActivationProtocol.ActivationMessage$
 
ActivationProtocol.EndpointActivated - Class in akka.camel.internal
INTERNAL API Event message indicating that a single endpoint has been activated.
ActivationProtocol.EndpointActivated(ActorRef) - Constructor for class akka.camel.internal.ActivationProtocol.EndpointActivated
 
ActivationProtocol.EndpointActivated$ - Class in akka.camel.internal
 
ActivationProtocol.EndpointActivated$() - Constructor for class akka.camel.internal.ActivationProtocol.EndpointActivated$
 
ActivationProtocol.EndpointDeActivated - Class in akka.camel.internal
INTERNAL API Event message indicating that a single endpoint was de-activated.
ActivationProtocol.EndpointDeActivated(ActorRef) - Constructor for class akka.camel.internal.ActivationProtocol.EndpointDeActivated
 
ActivationProtocol.EndpointDeActivated$ - Class in akka.camel.internal
 
ActivationProtocol.EndpointDeActivated$() - Constructor for class akka.camel.internal.ActivationProtocol.EndpointDeActivated$
 
ActivationProtocol.EndpointFailedToActivate - Class in akka.camel.internal
INTERNAL API Event message indicating that a single endpoint failed to activate.
ActivationProtocol.EndpointFailedToActivate(ActorRef, Throwable) - Constructor for class akka.camel.internal.ActivationProtocol.EndpointFailedToActivate
 
ActivationProtocol.EndpointFailedToActivate$ - Class in akka.camel.internal
 
ActivationProtocol.EndpointFailedToActivate$() - Constructor for class akka.camel.internal.ActivationProtocol.EndpointFailedToActivate$
 
ActivationProtocol.EndpointFailedToDeActivate - Class in akka.camel.internal
INTERNAL API Event message indicating that a single endpoint failed to de-activate.
ActivationProtocol.EndpointFailedToDeActivate(ActorRef, Throwable) - Constructor for class akka.camel.internal.ActivationProtocol.EndpointFailedToDeActivate
 
ActivationProtocol.EndpointFailedToDeActivate$ - Class in akka.camel.internal
 
ActivationProtocol.EndpointFailedToDeActivate$() - Constructor for class akka.camel.internal.ActivationProtocol.EndpointFailedToDeActivate$
 
activations() - Method in class akka.camel.internal.ActivationTracker
 
ActivationTimeout() - Method in class akka.camel.CamelSettings
Configured setting for how long the actor should wait for activation before it fails.
activationTimeout() - Method in interface akka.camel.Consumer
How long the actor should wait for activation before it fails.
activationTimeout() - Method in class akka.camel.ConsumerConfig
 
ActivationTracker - Class in akka.camel.internal
INTERNAL API An actor that tracks activation and de-activation of endpoints.
ActivationTracker() - Constructor for class akka.camel.internal.ActivationTracker
 
ActivationTracker.ActivationStateMachine - Class in akka.camel.internal
A state machine that keeps track of the endpoint activation status of an actor.
ActivationTracker.ActivationStateMachine() - Constructor for class akka.camel.internal.ActivationTracker.ActivationStateMachine
 
active() - Method in class akka.cluster.ClusterHeartbeatSender
 
active(ActorRef) - Method in class akka.contrib.pattern.ClusterClient
 
active() - Method in class akka.contrib.pattern.ReliableProxy$
 
active() - Static method in class akka.contrib.pattern.ReliableProxy
 
activeReceivers() - Method in class akka.cluster.ClusterHeartbeatSenderState
 
Actor - Interface in akka.actor
Actor base trait that should be extended by or mixed to create an Actor with the semantics of the 'Actor Model': http://en.wikipedia.org/wiki/Actor_model
actor() - Method in class akka.actor.ActorCell
 
actor(Function0<T>, ClassTag<T>, ActorRefFactory) - Method in interface akka.actor.dsl.Creators
Create an actor from the given thunk which must produce an Actor.
actor(String, Function0<T>, ClassTag<T>, ActorRefFactory) - Method in interface akka.actor.dsl.Creators
Create an actor from the given thunk which must produce an Actor.
actor(ActorRefFactory, String, Function0<T>, ClassTag<T>) - Method in interface akka.actor.dsl.Creators
Create an actor from the given thunk which must produce an Actor.
actor(ActorRefFactory, Function0<T>, ClassTag<T>) - Method in interface akka.actor.dsl.Creators
Create an actor with an automatically generated name from the given thunk which must produce an Actor.
actor() - Method in exception akka.actor.PostRestartException
 
actor() - Method in exception akka.actor.PreRestartException
 
actor() - Method in class akka.actor.Terminated
 
actor() - Method in class akka.actor.TypedActor.SerializedTypedActorInvocationHandler
 
actor() - Method in class akka.actor.TypedActor.TypedActorInvocationHandler
 
actor() - Method in class akka.camel.internal.ActivationProtocol.ActivationMessage
 
actor() - Method in class akka.contrib.pattern.ReliableProxy.ProxyTerminated
 
actor() - Method in class akka.dispatch.Mailbox
 
actor() - Method in class akka.dispatch.sysmsg.DeathWatchNotification
 
actor() - Method in class akka.remote.RemoteDeploymentWatcher.WatchRemote
 
actor() - Method in class akka.remote.transport.AssociationHandle.ActorHandleEventListener
 
actor() - Method in class akka.remote.transport.Transport.ActorAssociationEventListener
 
actor() - Method in class akka.transactor.SendTo
 
Actor$ - Class in akka.actor
 
Actor$() - Constructor for class akka.actor.Actor$
 
Actor.emptyBehavior$ - Class in akka.actor
emptyBehavior is a Receive-expression that matches no messages at all, ever.
Actor.emptyBehavior$() - Constructor for class akka.actor.Actor.emptyBehavior$
 
ActorActivationException - Exception in akka.camel.internal
INTERNAL API Thrown by the registrars to indicate that the actor could not be activated.
ActorActivationException(ActorRef, Throwable) - Constructor for exception akka.camel.internal.ActorActivationException
 
ActorCell - Class in akka.actor
Everything in here is completely Akka PRIVATE.
ActorCell(ActorSystemImpl, InternalActorRef, Props, MessageDispatcher, InternalActorRef) - Constructor for class akka.actor.ActorCell
 
actorCell() - Method in interface akka.actor.StashSupport
 
ActorCell$ - Class in akka.actor
Everything in here is completely Akka PRIVATE.
ActorCell$() - Constructor for class akka.actor.ActorCell$
 
actorClass() - Method in class akka.actor.ArgsReflectConstructor
 
actorClass() - Method in class akka.actor.CreatorConsumer
 
actorClass() - Method in class akka.actor.CreatorFunctionConsumer
 
actorClass() - Method in interface akka.actor.IndirectActorProducer
This method is used by Props to determine the type of actor which will be created.
actorClass() - Method in class akka.actor.NoArgsReflectConstructor
 
actorClass() - Method in class akka.actor.Props
Obtain an upper-bound approximation of the actor class which is going to be created by these Props.
actorClass() - Method in class akka.actor.TypedCreatorFunctionConsumer
 
actorClass() - Method in class akka.actor.UntypedActorFactoryConsumer
 
actorClass() - Method in class akka.routing.RoutedActorCell.RouterActorCreator
 
ActorClassification - Interface in akka.event
Maps ActorRefs to ActorRefs to form an EventBus where ActorRefs can listen to other ActorRefs
ActorClassifier - Interface in akka.event
Can be mixed into an EventBus to specify that the Classifier type is ActorRef
ActorComponent - Class in akka.camel.internal.component
INTERNAL API Creates Camel org.apache.camel.Endpoints that send messages to Consumer actors through an ActorProducer.
ActorComponent(Camel, ActorSystem) - Constructor for class akka.camel.internal.component.ActorComponent
 
ActorContext - Interface in akka.actor
The actor context - the view of the actor cell from the actor.
actorContext() - Method in class akka.actor.LocalActorRef
 
ActorDeActivationException - Exception in akka.camel.internal
INTERNAL API Thrown by registrars to indicate that the actor could not be de-activated.
ActorDeActivationException(ActorRef, Throwable) - Constructor for exception akka.camel.internal.ActorDeActivationException
 
ActorDSL - Class in akka.actor
This object contains elements which make writing actors and related code more concise, e.g.
ActorDSL() - Constructor for class akka.actor.ActorDSL
 
ActorDSL$ - Class in akka.actor
This object contains elements which make writing actors and related code more concise, e.g.
ActorDSL$() - Constructor for class akka.actor.ActorDSL$
 
ActorDSL.Extension - Class in akka.actor
 
ActorDSL.Extension(ExtendedActorSystem) - Constructor for class akka.actor.ActorDSL.Extension
 
ActorDSL.Extension$ - Class in akka.actor
 
ActorDSL.Extension$() - Constructor for class akka.actor.ActorDSL.Extension$
 
ActorEndpoint - Class in akka.camel.internal.component
INTERNAL API Does what an endpoint does, creates consumers and producers for the component.
ActorEndpoint(String, ActorComponent, ActorEndpointPath, Camel) - Constructor for class akka.camel.internal.component.ActorEndpoint
 
ActorEndpointConfig - Interface in akka.camel.internal.component
INTERNAL API Configures the ActorEndpoint.
ActorEndpointPath - Class in akka.camel.internal.component
INTERNAL API An endpoint to an ActorRef param: actorPath the String representation of the path to the actor
ActorEndpointPath$ - Class in akka.camel.internal.component
INTERNAL API Companion of ActorEndpointPath
ActorEndpointPath$() - Constructor for class akka.camel.internal.component.ActorEndpointPath$
 
ActorEventBus - Interface in akka.event
Represents an EventBus where the Subscriber type is ActorRef
ActorEventBus<E> - Class in akka.event.japi
See documentation for ActorClassification An EventBus where the Subscribers are ActorRefs and the Classifier is ActorRef Means that ActorRefs "listen" to other ActorRefs E is the Event type
ActorEventBus() - Constructor for class akka.event.japi.ActorEventBus
 
actorFactory() - Method in class akka.actor.ContextualTypedActorFactory
 
actorFactory() - Method in class akka.actor.TypedActorExtension
 
actorFactory() - Method in interface akka.actor.TypedActorFactory
Underlying dependency is to be able to create normal Actors
actorFor(ActorPath) - Method in interface akka.actor.ActorRefFactory
Look-up an actor by path; if it does not exist, returns a reference to the dead-letter mailbox of the ActorSystem.
actorFor(String) - Method in interface akka.actor.ActorRefFactory
Look-up an actor by path represented as string.
actorFor(Iterable<String>) - Method in interface akka.actor.ActorRefFactory
Look-up an actor by applying the given path elements, starting from the current context, where ".." signifies the parent of an actor.
actorFor(Iterable<String>) - Method in interface akka.actor.ActorRefFactory
Java API: Look-up an actor by applying the given path elements, starting from the current context, where ".." signifies the parent of an actor.
actorFor(ActorPath) - Method in interface akka.actor.ActorRefProvider
Create actor reference for a specified local or remote path.
actorFor(InternalActorRef, String) - Method in interface akka.actor.ActorRefProvider
Create actor reference for a specified local or remote path, which will be parsed using java.net.URI.
actorFor(InternalActorRef, Iterable<String>) - Method in interface akka.actor.ActorRefProvider
Create actor reference for the specified child path starting at the given starting point.
actorFor(InternalActorRef, String) - Method in class akka.actor.LocalActorRefProvider
 
actorFor(ActorPath) - Method in class akka.actor.LocalActorRefProvider
 
actorFor(InternalActorRef, Iterable<String>) - Method in class akka.actor.LocalActorRefProvider
 
actorFor(ActorPath) - Method in class akka.remote.RemoteActorRefProvider
 
actorFor(InternalActorRef, String) - Method in class akka.remote.RemoteActorRefProvider
 
actorFor(InternalActorRef, Iterable<String>) - Method in class akka.remote.RemoteActorRefProvider
 
ActorIdentity - Class in akka.actor
Reply to Identify.
ActorIdentity(Object, Option<ActorRef>) - Constructor for class akka.actor.ActorIdentity
 
ActorIdentity$ - Class in akka.actor
 
ActorIdentity$() - Constructor for class akka.actor.ActorIdentity$
 
ActorInitializationException - Exception in akka.actor
An ActorInitializationException is thrown when the the initialization logic for an Actor fails.
ActorInitializationException(ActorRef, String, Throwable) - Constructor for exception akka.actor.ActorInitializationException
 
ActorInitializationException$ - Class in akka.actor
 
ActorInitializationException$() - Constructor for class akka.actor.ActorInitializationException$
 
actorInstanceId() - Method in class akka.persistence.JournalProtocol.LoopMessage
 
actorInstanceId() - Method in class akka.persistence.JournalProtocol.LoopMessageSuccess
 
actorInstanceId() - Method in class akka.persistence.JournalProtocol.WriteMessageFailure
 
actorInstanceId() - Method in class akka.persistence.JournalProtocol.WriteMessages
 
actorInstanceId() - Method in class akka.persistence.JournalProtocol.WriteMessageSuccess
 
actorInstanceId() - Method in interface akka.persistence.PluginSpec
 
ActorInterruptedException - Exception in akka.actor
When an InterruptedException is thrown inside an Actor, it is wrapped as an ActorInterruptedException as to avoid cascading interrupts to other threads than the originally interrupted one.
ActorInterruptedException(Throwable) - Constructor for exception akka.actor.ActorInterruptedException
 
ActorKilledException - Exception in akka.actor
ActorKilledException is thrown when an Actor receives the Kill message
ActorKilledException(String) - Constructor for exception akka.actor.ActorKilledException
 
ActorKilledException$ - Class in akka.actor
 
ActorKilledException$() - Constructor for class akka.actor.ActorKilledException$
 
ActorLogging - Interface in akka.actor
Scala API: Mix in ActorLogging into your Actor to easily obtain a reference to a logger, which is available under the name "log".
ActorNotFound - Exception in akka.actor
When ActorSelection.resolveOne(akka.util.Timeout) can't identify the actor the Future is completed with this failure.
ActorNotFound(ActorSelection) - Constructor for exception akka.actor.ActorNotFound
 
ActorNotFound$ - Class in akka.actor
 
ActorNotFound$() - Constructor for class akka.actor.ActorNotFound$
 
ActorNotRegisteredException - Exception in akka.camel
Thrown to indicate that the actor referenced by an endpoint URI cannot be found in the actor system.
ActorNotRegisteredException(String) - Constructor for exception akka.camel.ActorNotRegisteredException
 
actorOf(Props) - Method in interface akka.actor.ActorRefFactory
Create new actor as child of this context and give it an automatically generated name (currently similar to base64-encoded integer count, reversed and with &ldquo;$&rdquo; prepended, may change in the future).
actorOf(Props, String) - Method in interface akka.actor.ActorRefFactory
Create new actor as child of this context with the given name, which must not be null, empty or start with &ldquo;$&rdquo;.
actorOf(ActorSystemImpl, Props, InternalActorRef, ActorPath, boolean, Option<Deploy>, boolean, boolean) - Method in interface akka.actor.ActorRefProvider
Actor factory with create-only semantics: will create an actor as described by props with the given supervisor and path (may be different in case of remote supervision).
actorOf(Props, String) - Method in class akka.actor.ActorSystemImpl
 
actorOf(Props) - Method in class akka.actor.ActorSystemImpl
 
actorOf(Props) - Method in interface akka.actor.dungeon.Children
 
actorOf(Props, String) - Method in interface akka.actor.dungeon.Children
 
actorOf(ActorSystemImpl, Props, InternalActorRef, ActorPath, boolean, Option<Deploy>, boolean, boolean) - Method in class akka.actor.LocalActorRefProvider
 
actorOf(ActorSystemImpl, Props, InternalActorRef, ActorPath, boolean, Option<Deploy>, boolean, boolean) - Method in class akka.remote.RemoteActorRefProvider
 
ActorPath - Interface in akka.actor
Actor path is a unique path to an actor that shows the creation path up through the actor tree to the root actor.
actorPath() - Method in class akka.camel.internal.component.ActorEndpointPath
 
ActorPath$ - Class in akka.actor
 
ActorPath$() - Constructor for class akka.actor.ActorPath$
 
ActorPathExtractor - Class in akka.actor
Given an ActorPath it returns the Address and the path elements if the path is well-formed
ActorPathExtractor() - Constructor for class akka.actor.ActorPathExtractor
 
ActorPathExtractor$ - Class in akka.actor
Given an ActorPath it returns the Address and the path elements if the path is well-formed
ActorPathExtractor$() - Constructor for class akka.actor.ActorPathExtractor$
 
ActorProducer - Class in akka.camel.internal.component
Sends the in-message of an exchange to an untyped actor, identified by an akka.camel.internal.component.ActorEndPoint
ActorProducer(ActorEndpoint, Camel) - Constructor for class akka.camel.internal.component.ActorProducer
 
actorProps() - Method in class akka.actor.TypedProps
Returns the akka.actor.Props representation of this TypedProps
ActorRef - Class in akka.actor
Immutable and serializable handle to an actor, which may or may not reside on the local host or inside the same ActorSystem.
ActorRef() - Constructor for class akka.actor.ActorRef
 
actorRef() - Method in class akka.actor.FSM.SubscribeTransitionCallBack
 
actorRef() - Method in class akka.actor.FSM.UnsubscribeTransitionCallBack
 
actorRef() - Method in class akka.camel.internal.ActivationProtocol.EndpointActivated
 
actorRef() - Method in class akka.camel.internal.ActivationProtocol.EndpointDeActivated
 
actorRef() - Method in class akka.camel.internal.ActivationProtocol.EndpointFailedToActivate
 
actorRef() - Method in class akka.camel.internal.ActivationProtocol.EndpointFailedToDeActivate
 
actorRef() - Method in exception akka.camel.internal.ActorActivationException
 
actorRef() - Method in exception akka.camel.internal.ActorDeActivationException
 
actorRef() - Method in class akka.camel.internal.CamelSupervisor.AddWatch
 
actorRef() - Method in class akka.camel.internal.CamelSupervisor.DeRegister
 
actorRef() - Method in class akka.camel.internal.CamelSupervisor.Register
 
actorRef() - Method in class akka.pattern.AskableActorRef
 
actorRef() - Method in class akka.routing.ConsistentActorRef
 
ActorRef$ - Class in akka.actor
 
ActorRef$() - Constructor for class akka.actor.ActorRef$
 
ActorRefFactory - Interface in akka.actor
Interface implemented by ActorSystem and ActorContext, the only two places from which you can get fresh actors.
ActorRefProvider - Interface in akka.actor
Interface for all ActorRef providers to implement.
ActorRefRoutee - Class in akka.routing
Routee that sends the messages to an ActorRef.
ActorRefRoutee(ActorRef) - Constructor for class akka.routing.ActorRefRoutee
 
ActorRefRoutee$ - Class in akka.routing
 
ActorRefRoutee$() - Constructor for class akka.routing.ActorRefRoutee$
 
ActorRefScope - Interface in akka.actor
All ActorRefs have a scope which describes where they live.
ActorRefWithCell - Class in akka.actor
Common trait of all actor refs which actually have a Cell, most notably LocalActorRef and RepointableActorRef.
ActorRefWithCell() - Constructor for class akka.actor.ActorRefWithCell
 
ActorRouteDefinition<T extends > - Class in akka.camel
Wraps a org.apache.camel.model.ProcessorDefinition.
ActorRouteDefinition(<any>) - Constructor for class akka.camel.ActorRouteDefinition
 
actors() - Method in class akka.dispatch.MessageDispatcher$
 
actors() - Static method in class akka.dispatch.MessageDispatcher
 
actorSel() - Method in class akka.pattern.AskableActorSelection
 
actorSelection(String) - Method in interface akka.actor.ActorRefFactory
Construct an ActorSelection from the given path, which is parsed for wildcards (these are replaced by regular expressions internally).
actorSelection(ActorPath) - Method in interface akka.actor.ActorRefFactory
Construct an ActorSelection from the given path, which is parsed for wildcards (these are replaced by regular expressions internally).
ActorSelection - Class in akka.actor
An ActorSelection is a logical view of a section of an ActorSystem's tree of Actors, allowing for broadcasting of messages to that section.
ActorSelection() - Constructor for class akka.actor.ActorSelection
 
ActorSelection$ - Class in akka.actor
An ActorSelection is a logical view of a section of an ActorSystem's tree of Actors, allowing for broadcasting of messages to that section.
ActorSelection$() - Constructor for class akka.actor.ActorSelection$
 
ActorSelectionMessage - Class in akka.actor
INTERNAL API ActorRefFactory.actorSelection returns a ActorSelection which sends these nested path descriptions whenever using ! on them, the idea being that the message is delivered by traversing the various actor paths involved.
ActorSelectionMessage(Object, Iterable<SelectionPathElement>, boolean) - Constructor for class akka.actor.ActorSelectionMessage
 
ActorSelectionMessage$ - Class in akka.actor
 
ActorSelectionMessage$() - Constructor for class akka.actor.ActorSelectionMessage$
 
ActorSelectionRoutee - Class in akka.routing
Routee that sends the messages to an ActorSelection.
ActorSelectionRoutee(ActorSelection) - Constructor for class akka.routing.ActorSelectionRoutee
 
ActorSelectionRoutee$ - Class in akka.routing
 
ActorSelectionRoutee$() - Constructor for class akka.routing.ActorSelectionRoutee$
 
ActorSystem - Class in akka.actor
An actor system is a hierarchical group of actors which share common configuration, e.g.
ActorSystem() - Constructor for class akka.actor.ActorSystem
 
ActorSystem$ - Class in akka.actor
 
ActorSystem$() - Constructor for class akka.actor.ActorSystem$
 
ActorSystem.Settings - Class in akka.actor
Settings are the overall ActorSystem Settings which also provides a convenient access to the Config object.
ActorSystem.Settings(ClassLoader, com.typesafe.config.Config, String) - Constructor for class akka.actor.ActorSystem.Settings
 
ActorSystemActivator - Class in akka.osgi
Abstract bundle activator implementation to bootstrap and configure an actor system in an OSGi environment.
ActorSystemActivator() - Constructor for class akka.osgi.ActorSystemActivator
 
actorSystemConfig(org.osgi.framework.BundleContext) - Method in class akka.osgi.OsgiActorSystemFactory
Strategy method to create the Config for the ActorSystem ensuring that the default/reference configuration is loaded from the akka-actor bundle.
ActorSystemImpl - Class in akka.actor
 
ActorSystemImpl(String, com.typesafe.config.Config, ClassLoader, Option<ExecutionContext>) - Constructor for class akka.actor.ActorSystemImpl
 
ActorSystemImpl.TerminationCallbacks - Class in akka.actor
 
ActorSystemImpl.TerminationCallbacks() - Constructor for class akka.actor.ActorSystemImpl.TerminationCallbacks
 
actorSystemName(Option<String>) - Method in class akka.osgi.OsgiActorSystemFactory
Determine the name for the ActorSystem Returns a default value of bundle--ActorSystem is no name is being specified
ActorTransportAdapter - Class in akka.remote.transport
 
ActorTransportAdapter(Transport, ActorSystem) - Constructor for class akka.remote.transport.ActorTransportAdapter
 
ActorTransportAdapter$ - Class in akka.remote.transport
 
ActorTransportAdapter$() - Constructor for class akka.remote.transport.ActorTransportAdapter$
 
ActorTransportAdapter.AssociateUnderlying - Class in akka.remote.transport
 
ActorTransportAdapter.AssociateUnderlying(Address, Promise<AssociationHandle>) - Constructor for class akka.remote.transport.ActorTransportAdapter.AssociateUnderlying
 
ActorTransportAdapter.AssociateUnderlying$ - Class in akka.remote.transport
 
ActorTransportAdapter.AssociateUnderlying$() - Constructor for class akka.remote.transport.ActorTransportAdapter.AssociateUnderlying$
 
ActorTransportAdapter.DisassociateUnderlying - Class in akka.remote.transport
 
ActorTransportAdapter.DisassociateUnderlying(AssociationHandle.DisassociateInfo) - Constructor for class akka.remote.transport.ActorTransportAdapter.DisassociateUnderlying
 
ActorTransportAdapter.DisassociateUnderlying$ - Class in akka.remote.transport
 
ActorTransportAdapter.DisassociateUnderlying$() - Constructor for class akka.remote.transport.ActorTransportAdapter.DisassociateUnderlying$
 
ActorTransportAdapter.ListenerRegistered - Class in akka.remote.transport
 
ActorTransportAdapter.ListenerRegistered(Transport.AssociationEventListener) - Constructor for class akka.remote.transport.ActorTransportAdapter.ListenerRegistered
 
ActorTransportAdapter.ListenerRegistered$ - Class in akka.remote.transport
 
ActorTransportAdapter.ListenerRegistered$() - Constructor for class akka.remote.transport.ActorTransportAdapter.ListenerRegistered$
 
ActorTransportAdapter.ListenUnderlying - Class in akka.remote.transport
 
ActorTransportAdapter.ListenUnderlying(Address, Future<Transport.AssociationEventListener>) - Constructor for class akka.remote.transport.ActorTransportAdapter.ListenUnderlying
 
ActorTransportAdapter.ListenUnderlying$ - Class in akka.remote.transport
 
ActorTransportAdapter.ListenUnderlying$() - Constructor for class akka.remote.transport.ActorTransportAdapter.ListenUnderlying$
 
ActorTransportAdapter.TransportOperation - Interface in akka.remote.transport
 
ActorTransportAdapterManager - Class in akka.remote.transport
 
ActorTransportAdapterManager() - Constructor for class akka.remote.transport.ActorTransportAdapterManager
 
actorVar() - Method in class akka.actor.TypedActor.TypedActorInvocationHandler
 
Adapters() - Method in class akka.remote.RemoteSettings
 
adaptiveBackoffNanos() - Method in class akka.remote.EndpointWriter
 
AdaptiveLoadBalancingGroup - Class in akka.cluster.routing
A router group that performs load balancing of messages to cluster nodes based on cluster metric data.
AdaptiveLoadBalancingGroup(MetricsSelector, Iterable<String>, String) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingGroup
 
AdaptiveLoadBalancingGroup(com.typesafe.config.Config, DynamicAccess) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingGroup
 
AdaptiveLoadBalancingGroup(MetricsSelector, Iterable<String>) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingGroup
Java API
AdaptiveLoadBalancingGroup$ - Class in akka.cluster.routing
 
AdaptiveLoadBalancingGroup$() - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingGroup$
 
AdaptiveLoadBalancingMetricsListener - Class in akka.cluster.routing
INTERNAL API subscribe to ClusterMetricsChanged and update routing logic
AdaptiveLoadBalancingMetricsListener(AdaptiveLoadBalancingRoutingLogic) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingMetricsListener
 
AdaptiveLoadBalancingPool - Class in akka.cluster.routing
A router pool that performs load balancing of messages to cluster nodes based on cluster metric data.
AdaptiveLoadBalancingPool(MetricsSelector, int, SupervisorStrategy, String, boolean) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingPool
 
AdaptiveLoadBalancingPool(com.typesafe.config.Config, DynamicAccess) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingPool
 
AdaptiveLoadBalancingPool(MetricsSelector, int) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingPool
Java API
AdaptiveLoadBalancingPool$ - Class in akka.cluster.routing
 
AdaptiveLoadBalancingPool$() - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingPool$
 
AdaptiveLoadBalancingRouter - Class in akka.cluster.routing
A Router that performs load balancing of messages to cluster nodes based on cluster metric data.
AdaptiveLoadBalancingRouter(MetricsSelector, int, Iterable<String>, Option<Resizer>, String, SupervisorStrategy) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingRouter
 
AdaptiveLoadBalancingRouter(MetricsSelector, int) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingRouter
Java API: Constructor that sets nrOfInstances to be created.
AdaptiveLoadBalancingRouter(MetricsSelector, Iterable<String>) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingRouter
Java API: Constructor that sets the routees to be used.
AdaptiveLoadBalancingRouter(MetricsSelector, Resizer) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingRouter
Java API: Constructor that sets the resizer to be used.
AdaptiveLoadBalancingRouter$ - Class in akka.cluster.routing
 
AdaptiveLoadBalancingRouter$() - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingRouter$
 
AdaptiveLoadBalancingRoutingLogic - Class in akka.cluster.routing
Load balancing of messages to cluster nodes based on cluster metric data.
AdaptiveLoadBalancingRoutingLogic(ActorSystem, MetricsSelector) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingRoutingLogic
 
AdaptiveLoadBalancingRoutingLogic$ - Class in akka.cluster.routing
 
AdaptiveLoadBalancingRoutingLogic$() - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingRoutingLogic$
 
add(Runnable) - Method in class akka.actor.ActorSystemImpl.TerminationCallbacks
 
add(String, ChildRestartStats) - Method in interface akka.actor.dungeon.ChildrenContainer
 
add(String, ChildRestartStats) - Method in interface akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer
 
add(String, ChildRestartStats) - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
 
add(String, ChildRestartStats) - Method in class akka.actor.dungeon.ChildrenContainer.TerminatedChildrenContainer$
 
add(String, ChildRestartStats) - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
 
add(QItem) - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
add(byte[], long) - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
Add a value to the end of the queue, transactionally.
add(byte[]) - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
add(String, byte[], int) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
Add an item to a named queue.
add(String, byte[]) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
add(Member) - Method in class akka.contrib.pattern.ClusterSingletonProxy
Adds new member if it has the right role.
add(T, boolean) - Method in class akka.contrib.pattern.WorkList
Appends an entry to the work list.
add(T) - Method in class akka.dispatch.AbstractNodeQueue
Add an element to the head of the queue.
add(PersistentRepr) - Method in interface akka.persistence.journal.inmem.InmemMessages
 
add(T) - Method in class akka.routing.ConsistentHash
Java API: Adds a node to the node ring.
addAll(WorkList<T>) - Method in class akka.contrib.pattern.WorkList
Appends another WorkList to this WorkList.
addAllAddresses(ClusterMessages.UniqueAddress) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .UniqueAddress allAddresses = 1;
addAllAddresses(int, ClusterMessages.UniqueAddress) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .UniqueAddress allAddresses = 1;
addAllAddresses(ClusterMessages.UniqueAddress.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .UniqueAddress allAddresses = 1;
addAllAddresses(int, ClusterMessages.UniqueAddress.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .UniqueAddress allAddresses = 1;
addAllAddresses(ClusterMessages.Address) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .Address allAddresses = 1;
addAllAddresses(int, ClusterMessages.Address) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .Address allAddresses = 1;
addAllAddresses(ClusterMessages.Address.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .Address allAddresses = 1;
addAllAddresses(int, ClusterMessages.Address.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .Address allAddresses = 1;
addAllAddressesBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .UniqueAddress allAddresses = 1;
addAllAddressesBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .UniqueAddress allAddresses = 1;
addAllAddressesBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .Address allAddresses = 1;
addAllAddressesBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .Address allAddresses = 1;
addAllAllAddresses(Iterable<? extends ClusterMessages.UniqueAddress>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .UniqueAddress allAddresses = 1;
addAllAllAddresses(Iterable<? extends ClusterMessages.Address>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .Address allAddresses = 1;
addAllAllHashes(Iterable<String>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated string allHashes = 3;
addAllAllHashes(Iterable<String>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
repeated string allHashes = 2;
addAllAllMetricNames(Iterable<String>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated string allMetricNames = 2;
addAllAllRoles(Iterable<String>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated string allRoles = 2;
addAllArgs(Iterable<? extends com.google.protobuf.ByteString>) - Method in class akka.remote.WireFormats.PropsData.Builder
repeated bytes args = 4;
addAllBatch(Iterable<? extends MessageFormats.PersistentMessage>) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
repeated .PersistentMessage batch = 1;
addAllBuckets(Iterable<? extends DistributedPubSubMessages.Delta.Bucket>) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
repeated .Delta.Bucket buckets = 1;
addAllClasses(Iterable<String>) - Method in class akka.remote.WireFormats.PropsData.Builder
repeated string classes = 5;
addAllConfirms(Iterable<String>) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
repeated string confirms = 7;
addAllContent(Iterable<? extends DistributedPubSubMessages.Delta.Entry>) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
repeated .Delta.Entry content = 3;
addAllHashes(String) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated string allHashes = 3;
addAllHashes(String) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
repeated string allHashes = 2;
addAllHashesBytes(com.google.protobuf.ByteString) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated string allHashes = 3;
addAllHashesBytes(com.google.protobuf.ByteString) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
repeated string allHashes = 2;
addAllMembers(Iterable<? extends ClusterMessages.Member>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .Member members = 4;
addAllMetricNames(String) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated string allMetricNames = 2;
addAllMetricNamesBytes(com.google.protobuf.ByteString) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated string allMetricNames = 2;
addAllMetrics(Iterable<? extends ClusterMessages.NodeMetrics.Metric>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
repeated .NodeMetrics.Metric metrics = 3;
addAllNacks(Iterable<? extends Long>) - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
repeated fixed64 nacks = 2;
addAllNodeMetrics(Iterable<? extends ClusterMessages.NodeMetrics>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .NodeMetrics nodeMetrics = 3;
addAllObserverReachability(Iterable<? extends ClusterMessages.ObserverReachability>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
repeated .ObserverReachability observerReachability = 2;
addAllPattern(Iterable<? extends ContainerFormats.Selection>) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
repeated .Selection pattern = 3;
addAllRoles(String) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated string allRoles = 2;
addAllRoles(Iterable<String>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
repeated string roles = 2;
addAllRolesBytes(com.google.protobuf.ByteString) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated string allRoles = 2;
addAllRolesIndexes(Iterable<? extends Integer>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
repeated int32 rolesIndexes = 4 [packed = true];
addAllSeen(Iterable<? extends Integer>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
repeated int32 seen = 1;
addAllSubjectReachability(Iterable<? extends ClusterMessages.SubjectReachability>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
repeated .SubjectReachability subjectReachability = 2;
addAllUnconfirmedDeliveries(Iterable<? extends MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery>) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
addAllVersions(Iterable<? extends ClusterMessages.VectorClock.Version>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
repeated .VectorClock.Version versions = 2;
addAllVersions(Iterable<? extends DistributedPubSubMessages.Status.Version>) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
repeated .Status.Version versions = 1;
addArgs(com.google.protobuf.ByteString) - Method in class akka.remote.WireFormats.PropsData.Builder
repeated bytes args = 4;
addBatch(MessageFormats.PersistentMessage) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
repeated .PersistentMessage batch = 1;
addBatch(int, MessageFormats.PersistentMessage) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
repeated .PersistentMessage batch = 1;
addBatch(MessageFormats.PersistentMessage.Builder) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
repeated .PersistentMessage batch = 1;
addBatch(int, MessageFormats.PersistentMessage.Builder) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
repeated .PersistentMessage batch = 1;
addBatchBuilder() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
repeated .PersistentMessage batch = 1;
addBatchBuilder(int) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
repeated .PersistentMessage batch = 1;
addBuckets(DistributedPubSubMessages.Delta.Bucket) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
repeated .Delta.Bucket buckets = 1;
addBuckets(int, DistributedPubSubMessages.Delta.Bucket) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
repeated .Delta.Bucket buckets = 1;
addBuckets(DistributedPubSubMessages.Delta.Bucket.Builder) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
repeated .Delta.Bucket buckets = 1;
addBuckets(int, DistributedPubSubMessages.Delta.Bucket.Builder) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
repeated .Delta.Bucket buckets = 1;
addBucketsBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
repeated .Delta.Bucket buckets = 1;
addBucketsBuilder(int) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
repeated .Delta.Bucket buckets = 1;
addBuffer() - Method in interface akka.contrib.pattern.Aggregator
 
addChild(String, InternalActorRef) - Method in class akka.actor.VirtualPathContainer
 
addClasses(String) - Method in class akka.remote.WireFormats.PropsData.Builder
repeated string classes = 5;
addClassesBytes(com.google.protobuf.ByteString) - Method in class akka.remote.WireFormats.PropsData.Builder
repeated string classes = 5;
addConfirms(String) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
repeated string confirms = 7;
addConfirmsBytes(com.google.protobuf.ByteString) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
repeated string confirms = 7;
addContent(DistributedPubSubMessages.Delta.Entry) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
repeated .Delta.Entry content = 3;
addContent(int, DistributedPubSubMessages.Delta.Entry) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
repeated .Delta.Entry content = 3;
addContent(DistributedPubSubMessages.Delta.Entry.Builder) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
repeated .Delta.Entry content = 3;
addContent(int, DistributedPubSubMessages.Delta.Entry.Builder) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
repeated .Delta.Entry content = 3;
addContentBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
repeated .Delta.Entry content = 3;
addContentBuilder(int) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
repeated .Delta.Entry content = 3;
addedSchemeIdentifier() - Method in class akka.remote.transport.AbstractTransportAdapterHandle
 
addedSchemeIdentifier() - Method in class akka.remote.transport.AkkaProtocolTransport
 
addedSchemeIdentifier() - Method in class akka.remote.transport.FailureInjectorTransportAdapter
 
addedSchemeIdentifier() - Method in interface akka.remote.transport.SchemeAugmenter
 
addedSchemeIdentifier() - Method in class akka.remote.transport.ThrottlerTransportAdapter
 
addFilter(EventFilter) - Method in class akka.testkit.TestEventListener
 
addKey(K) - Method in class akka.util.SubclassifiedIndex
Add key to this index which inherits its value set from the most specific super-class which is known.
addLogger(ActorSystemImpl, Class<? extends Actor>, Logging.LogLevel, String) - Method in interface akka.event.LoggingBus
INTERNAL API
AddLoggingReceive() - Method in class akka.actor.ActorSystem.Settings
 
addLogServiceListener(org.osgi.framework.BundleContext, ActorSystem) - Method in class akka.osgi.ActorSystemActivator
Adds a LogService Listener that will advertise the ActorSystem on LogService registration and unregistration
addMember(Member) - Method in class akka.cluster.ClusterHeartbeatSender
 
addMember(UniqueAddress) - Method in class akka.cluster.ClusterHeartbeatSenderState
 
addMember(Member) - Method in class akka.cluster.ClusterMetricsCollector
Adds a member to the node ring.
addMember(Member) - Method in interface akka.cluster.routing.ClusterRouterActor
 
addMembers(ClusterMessages.Member) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .Member members = 4;
addMembers(int, ClusterMessages.Member) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .Member members = 4;
addMembers(ClusterMessages.Member.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .Member members = 4;
addMembers(int, ClusterMessages.Member.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .Member members = 4;
addMembersBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .Member members = 4;
addMembersBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .Member members = 4;
addMetrics(ClusterMessages.NodeMetrics.Metric) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
repeated .NodeMetrics.Metric metrics = 3;
addMetrics(int, ClusterMessages.NodeMetrics.Metric) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
repeated .NodeMetrics.Metric metrics = 3;
addMetrics(ClusterMessages.NodeMetrics.Metric.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
repeated .NodeMetrics.Metric metrics = 3;
addMetrics(int, ClusterMessages.NodeMetrics.Metric.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
repeated .NodeMetrics.Metric metrics = 3;
addMetricsBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
repeated .NodeMetrics.Metric metrics = 3;
addMetricsBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
repeated .NodeMetrics.Metric metrics = 3;
addNacks(long) - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
repeated fixed64 nacks = 2;
addNode(AbstractNodeQueue.Node<T>) - Method in class akka.dispatch.AbstractNodeQueue
Add an element to the head of the queue, providing the queue node to be used.
addNodeMetrics(ClusterMessages.NodeMetrics) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .NodeMetrics nodeMetrics = 3;
addNodeMetrics(int, ClusterMessages.NodeMetrics) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .NodeMetrics nodeMetrics = 3;
addNodeMetrics(ClusterMessages.NodeMetrics.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .NodeMetrics nodeMetrics = 3;
addNodeMetrics(int, ClusterMessages.NodeMetrics.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .NodeMetrics nodeMetrics = 3;
addNodeMetricsBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .NodeMetrics nodeMetrics = 3;
addNodeMetricsBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .NodeMetrics nodeMetrics = 3;
addObserverReachability(ClusterMessages.ObserverReachability) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
repeated .ObserverReachability observerReachability = 2;
addObserverReachability(int, ClusterMessages.ObserverReachability) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
repeated .ObserverReachability observerReachability = 2;
addObserverReachability(ClusterMessages.ObserverReachability.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
repeated .ObserverReachability observerReachability = 2;
addObserverReachability(int, ClusterMessages.ObserverReachability.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
repeated .ObserverReachability observerReachability = 2;
addObserverReachabilityBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
repeated .ObserverReachability observerReachability = 2;
addObserverReachabilityBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
repeated .ObserverReachability observerReachability = 2;
addPattern(ContainerFormats.Selection) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
repeated .Selection pattern = 3;
addPattern(int, ContainerFormats.Selection) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
repeated .Selection pattern = 3;
addPattern(ContainerFormats.Selection.Builder) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
repeated .Selection pattern = 3;
addPattern(int, ContainerFormats.Selection.Builder) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
repeated .Selection pattern = 3;
addPatternBuilder() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
repeated .Selection pattern = 3;
addPatternBuilder(int) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
repeated .Selection pattern = 3;
addr() - Method in class akka.remote.testconductor.AddressReply
 
addr() - Method in class akka.remote.testconductor.Controller.NodeInfo
 
addr() - Method in class akka.remote.testconductor.Hello
 
ADDR_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
ADDR_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
addRemoved(Address) - Method in class akka.contrib.pattern.ClusterSingletonManager
 
address() - Method in interface akka.actor.ActorPath
The Address under which this path can be reached; walks up the tree to the RootActorPath.
Address - Class in akka.actor
The address specifies the physical location under which an Actor can be reached.
Address(String, String) - Constructor for class akka.actor.Address
 
Address(String, String, String, int) - Constructor for class akka.actor.Address
 
address() - Method in class akka.actor.AddressTerminated
 
address() - Method in class akka.actor.ChildActorPath
 
address() - Method in class akka.actor.RootActorPath
 
address() - Method in class akka.cluster.ClusterUserAction.Down
 
address() - Method in class akka.cluster.ClusterUserAction.JoinTo
 
address() - Method in class akka.cluster.ClusterUserAction.Leave
 
address() - Method in class akka.cluster.InternalClusterAction.InitJoinAck
 
address() - Method in class akka.cluster.InternalClusterAction.InitJoinNack
 
address() - Method in class akka.cluster.InternalClusterAction.SendGossipTo
 
address() - Method in class akka.cluster.Member
INTERNAL API
address() - Method in class akka.cluster.NodeMetrics
 
address() - Method in class akka.cluster.StandardMetrics.Cpu
 
address() - Method in class akka.cluster.StandardMetrics.HeapMemory
 
address() - Method in class akka.cluster.UniqueAddress
 
address() - Method in class akka.remote.QuarantinedEvent
 
address() - Method in class akka.remote.testconductor.TestConductorExt
Transport address of this Netty-like remote transport.
address() - Method in class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociate
 
address() - Method in class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociateExplicitly
 
address() - Method in class akka.remote.transport.ThrottlerTransportAdapter.SetThrottle
 
address() - Method in class akka.serialization.Serialization.Information
 
Address$ - Class in akka.actor
 
Address$() - Constructor for class akka.actor.Address$
 
address2proto(Address) - Method in class akka.remote.testconductor.MsgEncoder
 
address2scala(TestConductorProtocol.Address) - Method in class akka.remote.testconductor.MsgDecoder
 
ADDRESS_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
 
ADDRESS_FIELD_NUMBER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
 
ADDRESS_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Hello
 
ADDRESS_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
addressChaosTable() - Method in class akka.remote.transport.FailureInjectorTransportAdapter
 
addresses() - Method in class akka.remote.RemoteTransport
Address to be used in RootActorPath of refs generated for this transport.
addresses() - Method in class akka.remote.Remoting
 
addressesPromise() - Method in class akka.remote.EndpointManager.Listen
 
addressesPromise() - Method in class akka.remote.EndpointManager.ListensFailure
 
addressesPromise() - Method in class akka.remote.EndpointManager.ListensResult
 
addressForWriter(ActorRef) - Method in class akka.remote.EndpointManager.EndpointRegistry
 
addressFromSocketAddress(SocketAddress, String, String, Option<String>) - Method in class akka.remote.transport.netty.NettyTransport$
 
addressFromSocketAddress(SocketAddress, String, String, Option<String>) - Static method in class akka.remote.transport.netty.NettyTransport
 
AddressFromURIString - Class in akka.actor
This object serves as extractor for Scala and as address parser for Java.
AddressFromURIString() - Constructor for class akka.actor.AddressFromURIString
 
AddressFromURIString$ - Class in akka.actor
This object serves as extractor for Scala and as address parser for Java.
AddressFromURIString$() - Constructor for class akka.actor.AddressFromURIString$
 
ADDRESSINDEX_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
ADDRESSINDEX_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
ADDRESSINDEX_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
ADDRESSINDEX_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
addressOrdering() - Method in class akka.cluster.Member$
Address ordering type class, sorts addresses by host and port.
addressOrdering() - Static method in class akka.cluster.Member
Address ordering type class, sorts addresses by host and port.
AddressReply - Class in akka.remote.testconductor
 
AddressReply(RoleName, Address) - Constructor for class akka.remote.testconductor.AddressReply
 
AddressReply$ - Class in akka.remote.testconductor
 
AddressReply$() - Constructor for class akka.remote.testconductor.AddressReply$
 
AddressTerminated - Class in akka.actor
INTERNAL API
AddressTerminated(Address) - Constructor for class akka.actor.AddressTerminated
 
addressTerminated(Address) - Method in interface akka.actor.dungeon.DeathWatch
 
addressTerminated() - Method in class akka.actor.Terminated
 
addressTerminated() - Method in class akka.dispatch.sysmsg.DeathWatchNotification
 
AddressTerminated$ - Class in akka.actor
 
AddressTerminated$() - Constructor for class akka.actor.AddressTerminated$
 
AddressTerminatedTopic - Class in akka.event
INTERNAL API
AddressTerminatedTopic() - Constructor for class akka.event.AddressTerminatedTopic
 
AddressTerminatedTopic$ - Class in akka.event
INTERNAL API
AddressTerminatedTopic$() - Constructor for class akka.event.AddressTerminatedTopic$
 
addressToSocketAddress(Address) - Method in class akka.remote.transport.netty.NettyTransport
 
addressUid() - Method in class akka.remote.AddressUidExtension
 
addressUid() - Method in class akka.remote.RemoteWatcher.HeartbeatRsp
 
AddressUidExtension - Class in akka.remote
 
AddressUidExtension(ExtendedActorSystem) - Constructor for class akka.remote.AddressUidExtension
 
AddressUidExtension$ - Class in akka.remote
Extension that holds a uid that is assigned as a random Int.
AddressUidExtension$() - Constructor for class akka.remote.AddressUidExtension$
 
addressUids() - Method in class akka.remote.RemoteWatcher
 
AddressUrlEncoder - Class in akka.remote
INTERNAL API
AddressUrlEncoder() - Constructor for class akka.remote.AddressUrlEncoder
 
AddressUrlEncoder$ - Class in akka.remote
INTERNAL API
AddressUrlEncoder$() - Constructor for class akka.remote.AddressUrlEncoder$
 
addrInterest() - Method in class akka.remote.testconductor.Controller
 
addRoles(String) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
repeated string roles = 2;
addRolesBytes(com.google.protobuf.ByteString) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
repeated string roles = 2;
addRolesIndexes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
repeated int32 rolesIndexes = 4 [packed = true];
AddRoutee - Class in akka.routing
Add a routee by sending this message to the router.
AddRoutee(Routee) - Constructor for class akka.routing.AddRoutee
 
addRoutee(Routee) - Method in class akka.routing.RoutedActorCell
 
addRoutee(Routee) - Method in class akka.routing.Router
Create a new instance with one more routee and the same RoutingLogic.
addRoutee(ActorRef) - Method in class akka.routing.Router
Create a new instance with one more ActorRefRoutee for the specified ActorRef and the same RoutingLogic.
addRoutee(ActorSelection) - Method in class akka.routing.Router
Create a new instance with one more ActorSelectionRoutee for the specified ActorSelection and the same RoutingLogic.
AddRoutee$ - Class in akka.routing
 
AddRoutee$() - Constructor for class akka.routing.AddRoutee$
 
addRoutees() - Method in interface akka.cluster.routing.ClusterRouterActor
Adds routees based on settings
addRoutees() - Method in class akka.cluster.routing.ClusterRouterGroupActor
Adds routees based on totalInstances and maxInstancesPerNode settings
addRoutees() - Method in class akka.cluster.routing.ClusterRouterPoolActor
Adds routees based on totalInstances and maxInstancesPerNode settings
addRoutees(Iterable<Routee>) - Method in class akka.routing.RoutedActorCell
Add routees to the Router.
addSeen(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
repeated int32 seen = 1;
addSelf(String) - Method in interface akka.contrib.pattern.ReliableProxyDebugLogging
 
addSubjectReachability(ClusterMessages.SubjectReachability) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
repeated .SubjectReachability subjectReachability = 2;
addSubjectReachability(int, ClusterMessages.SubjectReachability) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
repeated .SubjectReachability subjectReachability = 2;
addSubjectReachability(ClusterMessages.SubjectReachability.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
repeated .SubjectReachability subjectReachability = 2;
addSubjectReachability(int, ClusterMessages.SubjectReachability.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
repeated .SubjectReachability subjectReachability = 2;
addSubjectReachabilityBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
repeated .SubjectReachability subjectReachability = 2;
addSubjectReachabilityBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
repeated .SubjectReachability subjectReachability = 2;
addTime() - Method in class akka.actor.mailbox.filebased.filequeue.QItem
 
addToBatch(DeliveredByChannel) - Method in class akka.persistence.DeliveredByChannelBatching
 
addToBatch(DeliveredByPersistentChannel) - Method in class akka.persistence.DeliveredByPersistentChannelBatching
 
addToCache(Seq<Tuple2<Object, Set<Object>>>) - Method in interface akka.event.SubchannelClassification
 
addToConfirmationBatch(PersistentConfirmation, org.iq80.leveldb.WriteBatch) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
addToMessageBatch(PersistentRepr, org.iq80.leveldb.WriteBatch) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
addUnconfirmedDeliveries(MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
addUnconfirmedDeliveries(int, MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
addUnconfirmedDeliveries(MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
addUnconfirmedDeliveries(int, MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
addUnconfirmedDeliveriesBuilder() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
addUnconfirmedDeliveriesBuilder(int) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
addValue(K, V) - Method in class akka.util.SubclassifiedIndex
Add value to all keys which are subclasses of the given key.
addVersions(ClusterMessages.VectorClock.Version) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
repeated .VectorClock.Version versions = 2;
addVersions(int, ClusterMessages.VectorClock.Version) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
repeated .VectorClock.Version versions = 2;
addVersions(ClusterMessages.VectorClock.Version.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
repeated .VectorClock.Version versions = 2;
addVersions(int, ClusterMessages.VectorClock.Version.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
repeated .VectorClock.Version versions = 2;
addVersions(DistributedPubSubMessages.Status.Version) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
repeated .Status.Version versions = 1;
addVersions(int, DistributedPubSubMessages.Status.Version) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
repeated .Status.Version versions = 1;
addVersions(DistributedPubSubMessages.Status.Version.Builder) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
repeated .Status.Version versions = 1;
addVersions(int, DistributedPubSubMessages.Status.Version.Builder) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
repeated .Status.Version versions = 1;
addVersionsBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
repeated .VectorClock.Version versions = 2;
addVersionsBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
repeated .VectorClock.Version versions = 2;
addVersionsBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
repeated .Status.Version versions = 1;
addVersionsBuilder(int) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
repeated .Status.Version versions = 1;
addWatcher(ActorRef, ActorRef) - Method in interface akka.actor.dungeon.DeathWatch
 
addWatching(ActorRef, ActorRef) - Method in class akka.remote.RemoteWatcher
 
adjustAdaptiveBackup() - Method in class akka.remote.EndpointWriter
 
adjustedGossipDifferentViewProbability() - Method in class akka.cluster.ClusterCoreDaemon
For large clusters we should avoid shooting down individual nodes.
AdjustPoolSize - Class in akka.routing
Increase or decrease the number of routees in a Pool.
AdjustPoolSize(int) - Constructor for class akka.routing.AdjustPoolSize
 
AdjustPoolSize$ - Class in akka.routing
 
AdjustPoolSize$() - Constructor for class akka.routing.AdjustPoolSize$
 
advance() - Method in interface akka.actor.LoggingFSM
 
AES128CounterInetRNG - Class in akka.remote.security.provider
INTERNAL API This class is a wrapper around the 128-bit AESCounterRNG algorithm provided by http://maths.uncommons.org/ It uses the default seed generator which uses one of the following 3 random seed sources: Depending on availability: random.org, /dev/random, and SecureRandom (provided by Java) The only method used by netty ssl is engineNextBytes(bytes)
AES128CounterInetRNG() - Constructor for class akka.remote.security.provider.AES128CounterInetRNG
 
AES128CounterSecureRNG - Class in akka.remote.security.provider
INTERNAL API This class is a wrapper around the 128-bit AESCounterRNG algorithm provided by http://maths.uncommons.org/ The only method used by netty ssl is engineNextBytes(bytes) This RNG is good to use to prevent startup delay when you don't have Internet access to random.org
AES128CounterSecureRNG() - Constructor for class akka.remote.security.provider.AES128CounterSecureRNG
 
AES256CounterInetRNG - Class in akka.remote.security.provider
INTERNAL API This class is a wrapper around the 256-bit AESCounterRNG algorithm provided by http://maths.uncommons.org/ It uses the default seed generator which uses one of the following 3 random seed sources: Depending on availability: random.org, /dev/random, and SecureRandom (provided by Java) The only method used by netty ssl is engineNextBytes(bytes)
AES256CounterInetRNG() - Constructor for class akka.remote.security.provider.AES256CounterInetRNG
 
AES256CounterSecureRNG - Class in akka.remote.security.provider
INTERNAL API This class is a wrapper around the 256-bit AESCounterRNG algorithm provided by http://maths.uncommons.org/ The only method used by netty ssl is engineNextBytes(bytes) This RNG is good to use to prevent startup delay when you don't have Internet access to random.org
AES256CounterSecureRNG() - Constructor for class akka.remote.security.provider.AES256CounterSecureRNG
 
Affinity - Class in akka.zeromq
The Affinity option shall set the I/O thread affinity for newly created connections on the specified socket.
Affinity(long) - Constructor for class akka.zeromq.Affinity
 
affinity() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its affinity configuration.
affinity() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its affinity configuration.
Affinity$ - Class in akka.zeromq
Gets the Affinity value
Affinity$() - Constructor for class akka.zeromq.Affinity$
 
after(FiniteDuration, Scheduler, Function0<Future<T>>, ExecutionContext) - Method in interface akka.pattern.FutureTimeoutSupport
Returns a Future that will be completed with the success or failure of the provided value after the specified duration.
after(FiniteDuration, Scheduler, ExecutionContext, Callable<Future<T>>) - Method in class akka.pattern.Patterns$
Returns a Future that will be completed with the success or failure of the provided Callable after the specified duration.
after(FiniteDuration, Scheduler, ExecutionContext, Future<T>) - Method in class akka.pattern.Patterns$
Returns a Future that will be completed with the success or failure of the provided value after the specified duration.
after(FiniteDuration, Scheduler, ExecutionContext, Callable<Future<T>>) - Static method in class akka.pattern.Patterns
Returns a Future that will be completed with the success or failure of the provided Callable after the specified duration.
after(FiniteDuration, Scheduler, ExecutionContext, Future<T>) - Static method in class akka.pattern.Patterns
Returns a Future that will be completed with the success or failure of the provided value after the specified duration.
after() - Method in interface akka.transactor.Transactor
A Receive block that runs after the coordinated transaction.
after(Object) - Method in class akka.transactor.UntypedTransactor
A Receive block that runs after the coordinated transaction.
afterAll() - Method in class akka.actor.mailbox.DurableMailboxSpec
 
afterAll() - Method in interface akka.persistence.PluginSpec
 
afterAll() - Method in class akka.testkit.AkkaSpec
 
afterAll() - Method in class akka.testkit.DefaultTimeoutSpec
 
afterAll() - Method in class akka.testkit.ImplicitSenderSpec
 
afterConnect(Socket) - Method in class akka.io.Inet.SO$.SendBufferSize
 
afterConnect(Socket) - Method in class akka.io.Inet.SO$.TrafficClass
 
afterConnect(Socket) - Method in interface akka.io.Inet.SocketOption
Action to be taken for this option after connect returned (i.e.
afterConnect(Socket) - Method in class akka.io.Tcp.SO$.KeepAlive
 
afterConnect(Socket) - Method in class akka.io.Tcp.SO$.OOBInline
 
afterConnect(Socket) - Method in class akka.io.Tcp.SO$.TcpNoDelay
 
afterSendSystemMessage(SystemMessage) - Method in class akka.remote.RemoteActorRefProvider
INTERNAL API
afterTermination() - Method in class akka.actor.mailbox.DurableMailboxSpec
May be implemented in concrete subclass to do additional things once after all test cases have been run.
afterTermination() - Method in class akka.remote.testkit.MultiNodeSpec
Override this method to do something when the whole test is terminating.
afterTermination() - Method in class akka.testkit.AkkaSpec
 
Agent<T> - Class in akka.agent
The Agent class was inspired by agents in Clojure.
Agent() - Constructor for class akka.agent.Agent
 
Agent$ - Class in akka.agent
 
Agent$() - Constructor for class akka.agent.Agent$
 
ageOrdering() - Method in class akka.contrib.pattern.ClusterSingletonProxy
 
ageOrdering() - Method in class akka.contrib.pattern.ShardRegion
 
Aggregator - Interface in akka.contrib.pattern
The aggregator is to be mixed into an actor for the aggregator behavior.
akka - package akka
 
akka.actor - package akka.actor
 
akka.actor.dsl - package akka.actor.dsl
 
akka.actor.dungeon - package akka.actor.dungeon
 
akka.actor.mailbox - package akka.actor.mailbox
 
akka.actor.mailbox.filebased - package akka.actor.mailbox.filebased
 
akka.actor.mailbox.filebased.filequeue - package akka.actor.mailbox.filebased.filequeue
 
akka.actor.mailbox.filebased.filequeue.tools - package akka.actor.mailbox.filebased.filequeue.tools
 
akka.agent - package akka.agent
 
akka.camel - package akka.camel
 
akka.camel.internal - package akka.camel.internal
 
akka.camel.internal.component - package akka.camel.internal.component
 
akka.camel.javaapi - package akka.camel.javaapi
 
akka.cluster - package akka.cluster
 
akka.cluster.protobuf - package akka.cluster.protobuf
 
akka.cluster.protobuf.msg - package akka.cluster.protobuf.msg
 
akka.cluster.routing - package akka.cluster.routing
 
akka.contrib.jul - package akka.contrib.jul
 
akka.contrib.mailbox - package akka.contrib.mailbox
 
akka.contrib.pattern - package akka.contrib.pattern
 
akka.contrib.pattern.protobuf - package akka.contrib.pattern.protobuf
 
akka.contrib.pattern.protobuf.msg - package akka.contrib.pattern.protobuf.msg
 
akka.contrib.throttle - package akka.contrib.throttle
 
akka.dispatch - package akka.dispatch
 
akka.dispatch.sysmsg - package akka.dispatch.sysmsg
 
akka.event - package akka.event
 
akka.event.japi - package akka.event.japi
 
akka.event.slf4j - package akka.event.slf4j
 
akka.io - package akka.io
 
akka.japi - package akka.japi
 
akka.japi.function - package akka.japi.function
 
akka.japi.pf - package akka.japi.pf
 
akka.japi.tuple - package akka.japi.tuple
 
akka.kernel - package akka.kernel
 
akka.osgi - package akka.osgi
 
akka.pattern - package akka.pattern
 
akka.persistence - package akka.persistence
 
akka.persistence.japi.journal - package akka.persistence.japi.journal
 
akka.persistence.japi.snapshot - package akka.persistence.japi.snapshot
 
akka.persistence.journal - package akka.persistence.journal
 
akka.persistence.journal.inmem - package akka.persistence.journal.inmem
 
akka.persistence.journal.japi - package akka.persistence.journal.japi
 
akka.persistence.journal.leveldb - package akka.persistence.journal.leveldb
 
akka.persistence.serialization - package akka.persistence.serialization
 
akka.persistence.snapshot - package akka.persistence.snapshot
 
akka.persistence.snapshot.japi - package akka.persistence.snapshot.japi
 
akka.persistence.snapshot.local - package akka.persistence.snapshot.local
 
akka.remote - package akka.remote
 
akka.remote.routing - package akka.remote.routing
 
akka.remote.security.provider - package akka.remote.security.provider
 
akka.remote.serialization - package akka.remote.serialization
 
akka.remote.testconductor - package akka.remote.testconductor
 
akka.remote.testkit - package akka.remote.testkit
 
akka.remote.transport - package akka.remote.transport
 
akka.remote.transport.netty - package akka.remote.transport.netty
 
akka.routing - package akka.routing
 
akka.serialization - package akka.serialization
 
akka.testkit - package akka.testkit
 
akka.transactor - package akka.transactor
 
akka.util - package akka.util
 
akka.zeromq - package akka.zeromq
 
akkaActorClassLoader() - Method in class akka.osgi.OsgiActorSystemFactory$
Class loader of akka-actor bundle.
akkaActorClassLoader() - Static method in class akka.osgi.OsgiActorSystemFactory
Class loader of akka-actor bundle.
AkkaCamelException - Exception in akka.camel
An exception indicating that the exchange to the camel endpoint failed.
AkkaCamelException(Throwable, Map<String, Object>) - Constructor for exception akka.camel.AkkaCamelException
 
AkkaCamelException(Throwable) - Constructor for exception akka.camel.AkkaCamelException
 
AkkaException - Exception in akka
Akka base Exception.
AkkaException(String, Throwable) - Constructor for exception akka.AkkaException
 
AkkaException(String) - Constructor for exception akka.AkkaException
 
AkkaOverhead() - Method in class akka.remote.transport.AkkaProtocolTransport$
 
AkkaOverhead() - Static method in class akka.remote.transport.AkkaProtocolTransport
 
AkkaPduCodec - Interface in akka.remote.transport
INTERNAL API
AkkaPduCodec$ - Class in akka.remote.transport
INTERNAL API
AkkaPduCodec$() - Constructor for class akka.remote.transport.AkkaPduCodec$
 
AkkaPduCodec.AkkaPdu - Interface in akka.remote.transport
Trait that represents decoded Akka PDUs (Protocol Data Units)
AkkaPduCodec.Associate - Class in akka.remote.transport
 
AkkaPduCodec.Associate(HandshakeInfo) - Constructor for class akka.remote.transport.AkkaPduCodec.Associate
 
AkkaPduCodec.Associate$ - Class in akka.remote.transport
 
AkkaPduCodec.Associate$() - Constructor for class akka.remote.transport.AkkaPduCodec.Associate$
 
AkkaPduCodec.Disassociate - Class in akka.remote.transport
 
AkkaPduCodec.Disassociate(AssociationHandle.DisassociateInfo) - Constructor for class akka.remote.transport.AkkaPduCodec.Disassociate
 
AkkaPduCodec.Disassociate$ - Class in akka.remote.transport
 
AkkaPduCodec.Disassociate$() - Constructor for class akka.remote.transport.AkkaPduCodec.Disassociate$
 
AkkaPduCodec.Heartbeat$ - Class in akka.remote.transport
 
AkkaPduCodec.Heartbeat$() - Constructor for class akka.remote.transport.AkkaPduCodec.Heartbeat$
 
AkkaPduCodec.Message - Class in akka.remote.transport
 
AkkaPduCodec.Message(InternalActorRef, Address, WireFormats.SerializedMessage, Option<ActorRef>, Option<SeqNo>) - Constructor for class akka.remote.transport.AkkaPduCodec.Message
 
AkkaPduCodec.Message$ - Class in akka.remote.transport
 
AkkaPduCodec.Message$() - Constructor for class akka.remote.transport.AkkaPduCodec.Message$
 
AkkaPduCodec.Payload - Class in akka.remote.transport
 
AkkaPduCodec.Payload(ByteString) - Constructor for class akka.remote.transport.AkkaPduCodec.Payload
 
AkkaPduCodec.Payload$ - Class in akka.remote.transport
 
AkkaPduCodec.Payload$() - Constructor for class akka.remote.transport.AkkaPduCodec.Payload$
 
AkkaPduProtobufCodec - Class in akka.remote.transport
INTERNAL API
AkkaPduProtobufCodec() - Constructor for class akka.remote.transport.AkkaPduProtobufCodec
 
AkkaPduProtobufCodec$ - Class in akka.remote.transport
INTERNAL API
AkkaPduProtobufCodec$() - Constructor for class akka.remote.transport.AkkaPduProtobufCodec$
 
AkkaProtocolException - Exception in akka.remote.transport
 
AkkaProtocolException(String, Throwable) - Constructor for exception akka.remote.transport.AkkaProtocolException
 
AkkaProtocolException(String) - Constructor for exception akka.remote.transport.AkkaProtocolException
 
AkkaProtocolHandle - Class in akka.remote.transport
 
AkkaProtocolHandle(Address, Address, Promise<AssociationHandle.HandleEventListener>, AssociationHandle, HandshakeInfo, ActorRef, AkkaPduCodec) - Constructor for class akka.remote.transport.AkkaProtocolHandle
 
AkkaProtocolManager - Class in akka.remote.transport
 
AkkaProtocolManager(Transport, AkkaProtocolSettings) - Constructor for class akka.remote.transport.AkkaProtocolManager
 
AkkaProtocolSettings - Class in akka.remote.transport
 
AkkaProtocolSettings(com.typesafe.config.Config) - Constructor for class akka.remote.transport.AkkaProtocolSettings
 
AkkaProtocolTransport - Class in akka.remote.transport
Implementation of the Akka protocol as a Transport that wraps an underlying Transport instance.
AkkaProtocolTransport(Transport, ActorSystem, AkkaProtocolSettings, AkkaPduCodec) - Constructor for class akka.remote.transport.AkkaProtocolTransport
 
AkkaProtocolTransport$ - Class in akka.remote.transport
 
AkkaProtocolTransport$() - Constructor for class akka.remote.transport.AkkaProtocolTransport$
 
AkkaProtocolTransport.AssociateUnderlyingRefuseUid - Class in akka.remote.transport
 
AkkaProtocolTransport.AssociateUnderlyingRefuseUid(Address, Promise<AssociationHandle>, Option<Object>) - Constructor for class akka.remote.transport.AkkaProtocolTransport.AssociateUnderlyingRefuseUid
 
AkkaProtocolTransport.AssociateUnderlyingRefuseUid$ - Class in akka.remote.transport
 
AkkaProtocolTransport.AssociateUnderlyingRefuseUid$() - Constructor for class akka.remote.transport.AkkaProtocolTransport.AssociateUnderlyingRefuseUid$
 
AkkaProvider - Class in akka.remote.security.provider
A provider that for AES128CounterRNGFast, a cryptographically secure random number generator through SecureRandom
AkkaProvider() - Constructor for class akka.remote.security.provider.AkkaProvider
 
AkkaProvider$ - Class in akka.remote.security.provider
A provider that for AES128CounterRNGFast, a cryptographically secure random number generator through SecureRandom
AkkaProvider$() - Constructor for class akka.remote.security.provider.AkkaProvider$
 
AkkaScheme() - Method in class akka.remote.transport.AkkaProtocolTransport$
 
AkkaScheme() - Static method in class akka.remote.transport.AkkaProtocolTransport
 
AkkaSpec - Class in akka.testkit
 
AkkaSpec(ActorSystem) - Constructor for class akka.testkit.AkkaSpec
 
AkkaSpec(com.typesafe.config.Config) - Constructor for class akka.testkit.AkkaSpec
 
AkkaSpec() - Constructor for class akka.testkit.AkkaSpec
 
AkkaSpec$ - Class in akka.testkit
 
AkkaSpec$() - Constructor for class akka.testkit.AkkaSpec$
 
AkkaSpecSpec - Class in akka.testkit
 
AkkaSpecSpec() - Constructor for class akka.testkit.AkkaSpecSpec
 
all() - Method in class akka.zeromq.Subscribe$
 
all() - Static method in class akka.zeromq.Subscribe
 
ALLADDRESSES_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
ALLADDRESSES_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
allButSelf() - Method in class akka.contrib.pattern.DistributedPubSubMediator.SendToAll
 
ALLBUTSELF_FIELD_NUMBER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
AllDeadLetters - Interface in akka.actor
Subscribe to this class to be notified about all DeadLetters (also the supressed ones).
allEndpoints() - Method in class akka.remote.EndpointManager.EndpointRegistry
 
AllForOneStrategy - Class in akka.actor
Applies the fault handling Directive (Resume, Restart, Stop) specified in the Decider to all children when one fails, as opposed to OneForOneStrategy that applies it only to the child actor that failed.
AllForOneStrategy(int, Duration, boolean, PartialFunction<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.AllForOneStrategy
 
AllForOneStrategy(int, Duration, Function<Throwable, SupervisorStrategy.Directive>, boolean) - Constructor for class akka.actor.AllForOneStrategy
Java API
AllForOneStrategy(int, Duration, Function<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.AllForOneStrategy
Java API
AllForOneStrategy(int, Duration, Iterable<Class<? extends Throwable>>) - Constructor for class akka.actor.AllForOneStrategy
Java API
AllForOneStrategy(int, Duration, PartialFunction<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.AllForOneStrategy
Java API: compatible with lambda expressions This is an EXPERIMENTAL feature and is subject to change until it has received more real world testing.
AllForOneStrategy(boolean, PartialFunction<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.AllForOneStrategy
Java API: compatible with lambda expressions This is an EXPERIMENTAL feature and is subject to change until it has received more real world testing.
AllForOneStrategy(PartialFunction<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.AllForOneStrategy
Java API: compatible with lambda expressions This is an EXPERIMENTAL feature and is subject to change until it has received more real world testing.
AllForOneStrategy() - Method in interface akka.actor.dsl.Creators.Act
 
AllForOneStrategy$ - Class in akka.actor
 
AllForOneStrategy$() - Constructor for class akka.actor.AllForOneStrategy$
 
ALLHASHES_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
ALLHASHES_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
AllLogLevels() - Method in class akka.event.Logging$
 
AllLogLevels() - Static method in class akka.event.Logging
 
ALLMETRICNAMES_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
allObservers() - Method in class akka.cluster.Reachability
 
allocateShard(ActorRef, String, Map<ActorRef, IndexedSeq<String>>) - Method in class akka.contrib.pattern.ShardCoordinator.AbstractShardAllocationStrategy
 
allocateShard(ActorRef, String, Map<ActorRef, IndexedSeq<String>>) - Method in class akka.contrib.pattern.ShardCoordinator.AbstractShardAllocationStrategy
Invoked when the location of a new shard is to be decided.
allocateShard(ActorRef, String, Map<ActorRef, IndexedSeq<String>>) - Method in class akka.contrib.pattern.ShardCoordinator.LeastShardAllocationStrategy
 
allocateShard(ActorRef, String, Map<ActorRef, IndexedSeq<String>>) - Method in interface akka.contrib.pattern.ShardCoordinator.ShardAllocationStrategy
Invoked when the location of a new shard is to be decided.
allocationStrategy() - Method in class akka.contrib.pattern.ClusterShardingGuardian.Start
 
allowCorePoolTimeout() - Method in class akka.dispatch.ThreadPoolConfig
 
allowedTransitions() - Method in class akka.cluster.MemberStatus$
INTERNAL API
allowedTransitions() - Static method in class akka.cluster.MemberStatus
INTERNAL API
allowLocalRoutees() - Method in class akka.cluster.routing.ClusterRouterGroupSettings
 
allowLocalRoutees() - Method in class akka.cluster.routing.ClusterRouterPoolSettings
 
allowLocalRoutees() - Method in class akka.cluster.routing.ClusterRouterSettings
 
allowLocalRoutees() - Method in interface akka.cluster.routing.ClusterRouterSettingsBase
 
allRoles() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
All node roles in the cluster
allRoles() - Method in class akka.cluster.Gossip
 
ALLROLES_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
allUnreachable() - Method in class akka.cluster.Reachability
Doesn't include terminated
allUnreachableFrom(UniqueAddress) - Method in class akka.cluster.Reachability
Doesn't include terminated
allUnreachableOrTerminated() - Method in class akka.cluster.Reachability
 
alone() - Method in interface akka.transactor.Transactor
Default coordination - no other transactors.
alpha(FiniteDuration, FiniteDuration) - Method in class akka.cluster.EWMA$
Calculate the alpha (decay factor) used in EWMA from specified half-life and interval between observations.
alpha() - Method in class akka.cluster.EWMA
 
ALPHA_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
 
alter(T) - Method in class akka.agent.Agent
Dispatch an update to the internal state, and return a Future where that new state can be obtained.
alter(Function1<T, T>) - Method in class akka.agent.Agent
Dispatch a function to update the internal state, and return a Future where that new state can be obtained.
alterOff(Function1<T, T>, ExecutionContext) - Method in class akka.agent.Agent
Dispatch a function to update the internal state but on its own thread, and return a Future where that new state can be obtained.
amendConfig(com.typesafe.config.Config) - Method in class akka.dispatch.BalancingDispatcherConfigurator$
 
amendConfig(com.typesafe.config.Config) - Static method in class akka.dispatch.BalancingDispatcherConfigurator
 
anchor() - Method in class akka.actor.ActorSelection
 
anchorPath() - Method in class akka.actor.ActorSelection
The ActorPath of the anchor actor.
anyEvent(FI.Apply2<Object, D, FSM.State<S, D>>) - Method in class akka.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches on any type of event.
ap() - Method in class akka.testkit.TestActor.SetAutoPilot
 
apiCommand() - Method in class akka.io.SelectionHandler.WorkerForCommand
 
append(Tcp.WriteCommand) - Method in class akka.io.Tcp.SimpleWriteCommand
Java API: appends this command with another WriteCommand to form a CompoundWrite.
append(ByteString) - Method in class akka.util.ByteStringBuilder
Java API: append a ByteString to this builder.
apply(Object) - Method in class akka.actor.Actor.emptyBehavior$
 
apply(ActorRef, String, Throwable) - Method in class akka.actor.ActorInitializationException$
 
apply(String) - Method in class akka.actor.ActorInitializationException$
 
apply(ActorRef, String, Throwable) - Static method in exception akka.actor.ActorInitializationException
 
apply(String) - Static method in exception akka.actor.ActorInitializationException
 
apply(ActorRef, String) - Method in class akka.actor.ActorSelection$
Construct an ActorSelection from the given string representing a path relative to the given target.
apply(ActorRef, Iterable<String>) - Method in class akka.actor.ActorSelection$
Construct an ActorSelection from the given string representing a path relative to the given target.
apply(ActorRef, String) - Static method in class akka.actor.ActorSelection
Construct an ActorSelection from the given string representing a path relative to the given target.
apply(ActorRef, Iterable<String>) - Static method in class akka.actor.ActorSelection
Construct an ActorSelection from the given string representing a path relative to the given target.
apply() - Method in class akka.actor.ActorSystem$
Creates a new ActorSystem with the name "default", obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
apply(String) - Method in class akka.actor.ActorSystem$
Creates a new ActorSystem with the specified name, obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
apply(String, com.typesafe.config.Config) - Method in class akka.actor.ActorSystem$
Creates a new ActorSystem with the specified name, and the specified Config, then obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
apply(String, com.typesafe.config.Config, ClassLoader) - Method in class akka.actor.ActorSystem$
Creates a new ActorSystem with the specified name, the specified Config, and specified ClassLoader
apply(String, Option<com.typesafe.config.Config>, Option<ClassLoader>, Option<ExecutionContext>) - Method in class akka.actor.ActorSystem$
Creates a new ActorSystem with the specified name, the specified ClassLoader if given, otherwise obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
apply() - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the name "default", obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
apply(String) - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the specified name, obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
apply(String, com.typesafe.config.Config) - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the specified name, and the specified Config, then obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
apply(String, com.typesafe.config.Config, ClassLoader) - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the specified name, the specified Config, and specified ClassLoader
apply(String, Option<com.typesafe.config.Config>, Option<ClassLoader>, Option<ExecutionContext>) - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the specified name, the specified ClassLoader if given, otherwise obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
apply(String, String) - Method in class akka.actor.Address$
Constructs a new Address with the specified protocol and system name
apply(String, String, String, int) - Method in class akka.actor.Address$
Constructs a new Address with the specified protocol, system name, host and port
apply(String, String) - Static method in class akka.actor.Address
Constructs a new Address with the specified protocol and system name
apply(String, String, String, int) - Static method in class akka.actor.Address
Constructs a new Address with the specified protocol, system name, host and port
apply(String) - Method in class akka.actor.AddressFromURIString$
Try to construct an Address from the given String or throw a java.net.MalformedURLException.
apply(String) - Static method in class akka.actor.AddressFromURIString
Try to construct an Address from the given String or throw a java.net.MalformedURLException.
apply(ChildStats) - Method in class akka.actor.dungeon.ChildrenContainer.ChildrenIterable
 
apply(ChildStats) - Method in class akka.actor.dungeon.ChildrenContainer.ChildRestartsIterable
 
apply(TreeMap<String, ChildStats>) - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer$
 
apply(ActorSystem) - Method in interface akka.actor.ExtensionId
Returns an instance of the extension identified by this ExtensionId instance.
apply(Object) - Method in class akka.actor.FSM.NullFunction$
 
apply(Class<?>, Seq<Object>) - Method in class akka.actor.IndirectActorProducer$
 
apply() - Method in class akka.actor.mailbox.filebased.filequeue.Counter
 
apply() - Method in class akka.actor.mailbox.filebased.filequeue.OverlaySetting
 
apply() - Method in class akka.actor.mailbox.filebased.filequeue.tools.QueueDumper
 
apply(ClassTag<T>) - Method in class akka.actor.Props$
 
apply(Function0<T>, ClassTag<T>) - Method in class akka.actor.Props$
 
apply(Class<?>, Seq<Object>) - Method in class akka.actor.Props$
 
apply(ClassTag<T>) - Static method in class akka.actor.Props
 
apply(Function0<T>, ClassTag<T>) - Static method in class akka.actor.Props
 
apply(Class<?>, Seq<Object>) - Static method in class akka.actor.Props
 
apply(ActorRef) - Method in class akka.actor.SerializedActorRef$
 
apply(ActorRef) - Static method in class akka.actor.SerializedActorRef
 
apply(ActorContext) - Method in class akka.actor.TypedActor$
Returns a contextual TypedActorFactory of this extension, this means that any TypedActors created by this TypedActorExtension will be children to the specified context, this allows for creating hierarchies of TypedActors.
apply(ActorContext) - Static method in class akka.actor.TypedActor
Returns a contextual TypedActorFactory of this extension, this means that any TypedActors created by this TypedActorExtension will be children to the specified context, this allows for creating hierarchies of TypedActors.
apply(Object) - Method in class akka.actor.TypedActor.MethodCall
Invokes the Method on the supplied instance
apply(Class<T>) - Method in class akka.actor.TypedProps$
Uses the supplied class as the factory for the TypedActor implementation, proxying all the interfaces it implements.
apply(Class<? super T>, Class<T>) - Method in class akka.actor.TypedProps$
Uses the supplied class as the factory for the TypedActor implementation, and that has the specified interface, or if the interface class is not an interface, all the interfaces it implements, appended in the sequence of interfaces.
apply(Class<? super T>, Function0<T>) - Method in class akka.actor.TypedProps$
Uses the supplied thunk as the factory for the TypedActor implementation, and that has the specified interface, or if the interface class is not an interface, all the interfaces it implements, appended in the sequence of interfaces.
apply(ClassTag<T>) - Method in class akka.actor.TypedProps$
Uses the supplied class as the factory for the TypedActor implementation, proxying all the interfaces it implements.
apply(Seq<Class<?>>, Function0<T>) - Method in class akka.actor.TypedProps$
INTERNAL API
apply(Class<T>) - Static method in class akka.actor.TypedProps
Uses the supplied class as the factory for the TypedActor implementation, proxying all the interfaces it implements.
apply(Class<? super T>, Class<T>) - Static method in class akka.actor.TypedProps
Uses the supplied class as the factory for the TypedActor implementation, and that has the specified interface, or if the interface class is not an interface, all the interfaces it implements, appended in the sequence of interfaces.
apply(Class<? super T>, Function0<T>) - Static method in class akka.actor.TypedProps
Uses the supplied thunk as the factory for the TypedActor implementation, and that has the specified interface, or if the interface class is not an interface, all the interfaces it implements, appended in the sequence of interfaces.
apply(ClassTag<T>) - Static method in class akka.actor.TypedProps
Uses the supplied class as the factory for the TypedActor implementation, proxying all the interfaces it implements.
apply(Seq<Class<?>>, Function0<T>) - Static method in class akka.actor.TypedProps
INTERNAL API
apply(T, ExecutionContext) - Method in class akka.agent.Agent$
Factory method for creating an Agent.
apply() - Method in class akka.agent.Agent
Read the internal state of the agent.
apply(FiniteDuration, FiniteDuration, boolean, Function1<org.apache.camel.model.RouteDefinition, <any>>) - Method in class akka.camel.ConsumerConfig$
 
apply(FiniteDuration, FiniteDuration, boolean, Function1<org.apache.camel.model.RouteDefinition, <any>>) - Static method in class akka.camel.ConsumerConfig
 
apply(ActorRef) - Method in class akka.camel.internal.component.ActorEndpointPath$
 
apply(ActorRef) - Static method in class akka.camel.internal.component.ActorEndpointPath
 
apply(SortedSet<Member>) - Method in class akka.cluster.Gossip$
 
apply(SortedSet<Member>) - Static method in class akka.cluster.Gossip
 
apply(UniqueAddress, UniqueAddress, Gossip) - Method in class akka.cluster.GossipEnvelope$
 
apply(UniqueAddress, UniqueAddress, Deadline, Function0<Gossip>) - Method in class akka.cluster.GossipEnvelope$
 
apply(UniqueAddress, UniqueAddress, Gossip) - Static method in class akka.cluster.GossipEnvelope
 
apply(UniqueAddress, UniqueAddress, Deadline, Function0<Gossip>) - Static method in class akka.cluster.GossipEnvelope
 
apply(UniqueAddress, Set<String>) - Method in class akka.cluster.Member$
INTERNAL API Create a new member with status Joining.
apply(UniqueAddress, Set<String>) - Static method in class akka.cluster.Member
INTERNAL API Create a new member with status Joining.
apply(ExtendedActorSystem, ClusterSettings) - Method in class akka.cluster.MetricsCollector$
 
apply(IndexedSeq<Reachability.Record>, Map<UniqueAddress, Object>) - Method in class akka.cluster.Reachability$
 
apply(IndexedSeq<Reachability.Record>, Map<UniqueAddress, Object>) - Static method in class akka.cluster.Reachability
 
apply(int, int, boolean, Option<String>) - Method in class akka.cluster.routing.ClusterRouterSettings$
Settings for create and deploy of the routees
apply(int, int, Option<String>) - Method in class akka.cluster.routing.ClusterRouterSettings$
Settings for remote deployment of the routees, allowed to use routees on own node
apply(int, String, boolean, Option<String>) - Method in class akka.cluster.routing.ClusterRouterSettings$
Settings for lookup of the routees
apply(int, String, Option<String>) - Method in class akka.cluster.routing.ClusterRouterSettings$
Settings for lookup of the routees, allowed to use routees on own node
apply(int, int, boolean, Option<String>) - Static method in class akka.cluster.routing.ClusterRouterSettings
Settings for create and deploy of the routees
apply(int, int, Option<String>) - Static method in class akka.cluster.routing.ClusterRouterSettings
Settings for remote deployment of the routees, allowed to use routees on own node
apply(int, String, boolean, Option<String>) - Static method in class akka.cluster.routing.ClusterRouterSettings
Settings for lookup of the routees
apply(int, String, Option<String>) - Static method in class akka.cluster.routing.ClusterRouterSettings
Settings for lookup of the routees, allowed to use routees on own node
apply(int) - Method in class akka.cluster.routing.WeightedRoutees
Pick the routee matching a value, from 1 to total.
apply(String) - Method in class akka.cluster.VectorClock.Node$
 
apply(String, Object) - Method in class akka.contrib.pattern.DistributedPubSubMediator.Publish$
 
apply(String, ActorRef) - Method in class akka.contrib.pattern.DistributedPubSubMediator.Subscribe$
 
apply(String, ActorRef) - Method in class akka.contrib.pattern.DistributedPubSubMediator.Unsubscribe$
 
apply(Object, ActorRef, ActorSystem) - Method in class akka.dispatch.Envelope$
 
apply(Object, ActorRef, ActorSystem) - Static method in class akka.dispatch.Envelope
 
apply(T) - Method in class akka.dispatch.japi.BooleanFunctionBridge
 
apply(T) - Method in class akka.dispatch.japi.CallbackBridge
 
apply(Throwable) - Method in class akka.dispatch.japi.RecoverBridge
 
apply(T) - Method in class akka.dispatch.japi.UnitFunctionBridge
 
apply(T) - Method in class akka.dispatch.Mapper
Override this method to perform the map operation, by default delegates to "checkedApply" which by default throws an UnsupportedOperationException.
apply(Function1<Object, Object>) - Method in class akka.dispatch.PriorityGenerator$
Creates a PriorityGenerator that uses the supplied function as priority generator
apply(Function1<Object, Object>) - Static method in class akka.dispatch.PriorityGenerator
Creates a PriorityGenerator that uses the supplied function as priority generator
apply(ActorSystem, T, LogSource<T>) - Method in class akka.event.Logging$
Obtain LoggingAdapter for the given actor system and source object.
apply(LoggingBus, T, LogSource<T>) - Method in class akka.event.Logging$
Obtain LoggingAdapter for the given logging bus and source object.
apply(Actor) - Method in class akka.event.Logging$
Obtain LoggingAdapter with MDC support for the given actor.
apply(ActorSystem, T, LogSource<T>) - Static method in class akka.event.Logging
Obtain LoggingAdapter for the given actor system and source object.
apply(LoggingBus, T, LogSource<T>) - Static method in class akka.event.Logging
Obtain LoggingAdapter for the given logging bus and source object.
apply(Actor) - Static method in class akka.event.Logging
Obtain LoggingAdapter with MDC support for the given actor.
apply(String, Class<?>, Object, Map<String, Object>) - Method in class akka.event.Logging.Debug$
 
apply(String, Class<?>, Object) - Method in class akka.event.Logging.Error$
 
apply(Throwable, String, Class<?>, Object, Map<String, Object>) - Method in class akka.event.Logging.Error$
 
apply(String, Class<?>, Object, Map<String, Object>) - Method in class akka.event.Logging.Error$
 
apply(String, Class<?>, Object, Map<String, Object>) - Method in class akka.event.Logging.Info$
 
apply(String, Class<?>, Object, Map<String, Object>) - Method in class akka.event.Logging.Warning$
 
apply(PartialFunction<Object, BoxedUnit>, ActorContext) - Method in class akka.event.LoggingReceive$
Wrap a Receive partial function in a logging enclosure, which sends a debug message to the event bus each time before a message is matched.
apply(Object) - Method in class akka.event.LoggingReceive
 
apply(T, LogSource<T>) - Method in class akka.event.LogSource$
Convenience converter access: given an implicit LogSource, generate the string representation and originating class.
apply(T, ActorSystem, LogSource<T>) - Method in class akka.event.LogSource$
Convenience converter access: given an implicit LogSource and ActorSystem, generate the string representation and originating class.
apply(String) - Method in class akka.event.slf4j.Logger$
 
apply(Class<?>, String) - Method in class akka.event.slf4j.Logger$
 
apply(String) - Static method in class akka.event.slf4j.Logger
 
apply(Class<?>, String) - Static method in class akka.event.slf4j.Logger
 
apply(ExtensionId<T>, ActorSystem) - Method in class akka.io.IO$
Scala API: obtain a reference to the manager actor for the given IO extension, for example Tcp or Udp.
apply(ExtensionId<T>, ActorSystem) - Static method in class akka.io.IO
Scala API: obtain a reference to the manager actor for the given IO extension, for example Tcp or Udp.
apply(ByteString) - Method in class akka.io.Tcp.Write$
Create a new unacknowledged Write command with the given data.
apply(Iterable<Tcp.WriteCommand>) - Method in class akka.io.Tcp.WriteCommand$
Combines the given number of write commands into one atomic WriteCommand.
apply(ByteString, InetSocketAddress) - Method in class akka.io.Udp.Send$
 
apply(ByteString) - Method in class akka.io.UdpConnected.Send$
 
apply() - Method in interface akka.japi.Effect
 
apply(T) - Method in interface akka.japi.Function
 
apply() - Method in interface akka.japi.function.Effect
 
apply(T) - Method in interface akka.japi.function.Function
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Method in interface akka.japi.function.Function10
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Method in interface akka.japi.function.Function11
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Method in interface akka.japi.function.Function12
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Method in interface akka.japi.function.Function13
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Method in interface akka.japi.function.Function14
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Method in interface akka.japi.function.Function15
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Method in interface akka.japi.function.Function16
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Method in interface akka.japi.function.Function17
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Method in interface akka.japi.function.Function18
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Method in interface akka.japi.function.Function19
 
apply(T1, T2) - Method in interface akka.japi.function.Function2
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Method in interface akka.japi.function.Function20
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Method in interface akka.japi.function.Function21
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Method in interface akka.japi.function.Function22
 
apply(T1, T2, T3) - Method in interface akka.japi.function.Function3
 
apply(T1, T2, T3, T4) - Method in interface akka.japi.function.Function4
 
apply(T1, T2, T3, T4, T5) - Method in interface akka.japi.function.Function5
 
apply(T1, T2, T3, T4, T5, T6) - Method in interface akka.japi.function.Function6
 
apply(T1, T2, T3, T4, T5, T6, T7) - Method in interface akka.japi.function.Function7
 
apply(T1, T2, T3, T4, T5, T6, T7, T8) - Method in interface akka.japi.function.Function8
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in interface akka.japi.function.Function9
 
apply(T) - Method in interface akka.japi.function.Procedure
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Method in interface akka.japi.function.Procedure10
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Method in interface akka.japi.function.Procedure11
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Method in interface akka.japi.function.Procedure12
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Method in interface akka.japi.function.Procedure13
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Method in interface akka.japi.function.Procedure14
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Method in interface akka.japi.function.Procedure15
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Method in interface akka.japi.function.Procedure16
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Method in interface akka.japi.function.Procedure17
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Method in interface akka.japi.function.Procedure18
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Method in interface akka.japi.function.Procedure19
 
apply(T1, T2) - Method in interface akka.japi.function.Procedure2
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Method in interface akka.japi.function.Procedure20
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Method in interface akka.japi.function.Procedure21
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Method in interface akka.japi.function.Procedure22
 
apply(T1, T2, T3) - Method in interface akka.japi.function.Procedure3
 
apply(T1, T2, T3, T4) - Method in interface akka.japi.function.Procedure4
 
apply(T1, T2, T3, T4, T5) - Method in interface akka.japi.function.Procedure5
 
apply(T1, T2, T3, T4, T5, T6) - Method in interface akka.japi.function.Procedure6
 
apply(T1, T2, T3, T4, T5, T6, T7) - Method in interface akka.japi.function.Procedure7
 
apply(T1, T2, T3, T4, T5, T6, T7, T8) - Method in interface akka.japi.function.Procedure8
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in interface akka.japi.function.Procedure9
 
apply(T1, T2) - Method in interface akka.japi.Function2
 
apply(A, boolean) - Method in class akka.japi.JavaPartialFunction
 
apply(A) - Method in class akka.japi.JavaPartialFunction
 
apply(F) - Method in class akka.japi.pf.CaseStatement
 
apply(I) - Method in interface akka.japi.pf.FI.Apply
The application to perform.
apply(I1, I2) - Method in interface akka.japi.pf.FI.Apply2
The application to perform.
apply(I) - Method in interface akka.japi.pf.FI.UnitApply
The application to perform.
apply(I1, I2) - Method in interface akka.japi.pf.FI.UnitApply2
The application to perform.
apply(I1, I2, I3) - Method in interface akka.japi.pf.FI.UnitApply3
The application to perform.
apply() - Method in interface akka.japi.pf.FI.UnitApplyVoid
The application to perform.
apply(F) - Method in class akka.japi.pf.UnitCaseStatement
 
apply(T) - Method in interface akka.japi.Procedure
 
apply(org.osgi.framework.BundleContext) - Method in class akka.osgi.BundleDelegatingClassLoader$
Create a bundle delegating ClassLoader for the bundle context's bundle
apply(org.osgi.framework.BundleContext, Option<ClassLoader>) - Method in class akka.osgi.BundleDelegatingClassLoader$
 
apply(org.osgi.framework.BundleContext) - Static method in class akka.osgi.BundleDelegatingClassLoader
Create a bundle delegating ClassLoader for the bundle context's bundle
apply(org.osgi.framework.BundleContext, Option<ClassLoader>) - Static method in class akka.osgi.BundleDelegatingClassLoader
 
apply(org.osgi.framework.BundleContext, com.typesafe.config.Config) - Method in class akka.osgi.OsgiActorSystemFactory$
 
apply(org.osgi.framework.BundleContext, com.typesafe.config.Config) - Static method in class akka.osgi.OsgiActorSystemFactory
 
apply(Scheduler, int, FiniteDuration, FiniteDuration) - Method in class akka.pattern.CircuitBreaker$
Create a new CircuitBreaker.
apply(Scheduler, int, FiniteDuration, FiniteDuration) - Static method in class akka.pattern.CircuitBreaker
Create a new CircuitBreaker.
apply(ActorRefProvider, Timeout, String) - Method in class akka.pattern.PromiseActorRef$
 
apply(ActorRefProvider, Timeout, String) - Static method in class akka.pattern.PromiseActorRef
 
apply(PersistentRepr, Delivered, ActorRef) - Method in class akka.persistence.ConfirmablePersistentImpl$
 
apply(PersistentRepr, Delivered, ActorRef) - Static method in class akka.persistence.ConfirmablePersistentImpl
 
apply(Object, Option<Persistent>) - Method in class akka.persistence.Persistent$
Creates a new persistent message, derived from an implicit current message.
apply(Object, Option<Persistent>) - Static method in class akka.persistence.Persistent
Creates a new persistent message, derived from an implicit current message.
apply(Object, long, String, boolean, int, Seq<String>, boolean, Delivered, ActorRef, ActorRef) - Method in class akka.persistence.PersistentRepr$
Plugin API.
apply(Address) - Method in class akka.remote.AddressUrlEncoder$
 
apply(Address) - Static method in class akka.remote.AddressUrlEncoder
 
apply(String, com.typesafe.config.Config, ActorContext) - Method in class akka.remote.FailureDetectorLoader$
Loads and instantiates a given FailureDetector implementation.
apply(String, com.typesafe.config.Config, ActorContext) - Static method in class akka.remote.FailureDetectorLoader
Loads and instantiates a given FailureDetector implementation.
apply(int) - Method in class akka.remote.HeartbeatHistory$
Create an empty HeartbeatHistory, without any history.
apply(int) - Static method in class akka.remote.HeartbeatHistory
Create an empty HeartbeatHistory, without any history.
apply(Role, InetSocketAddress, int, org.jboss.netty.channel.ChannelUpstreamHandler) - Method in class akka.remote.testconductor.RemoteConnection$
 
apply(Role, InetSocketAddress, int, org.jboss.netty.channel.ChannelUpstreamHandler) - Static method in class akka.remote.testconductor.RemoteConnection
 
apply(ActorContext) - Method in class akka.remote.testconductor.TestConductor$
 
apply(ActorContext) - Static method in class akka.remote.testconductor.TestConductor
 
apply(org.jboss.netty.channel.ChannelFuture) - Method in class akka.remote.transport.netty.NettyFutureBridge$
 
apply(org.jboss.netty.channel.group.ChannelGroupFuture) - Method in class akka.remote.transport.netty.NettyFutureBridge$
 
apply(org.jboss.netty.channel.ChannelFuture) - Static method in class akka.remote.transport.netty.NettyFutureBridge
 
apply(org.jboss.netty.channel.group.ChannelGroupFuture) - Static method in class akka.remote.transport.netty.NettyFutureBridge
 
apply(SSLSettings, LoggingAdapter, boolean) - Method in class akka.remote.transport.netty.NettySSLSupport$
Construct a SSLHandler which can be inserted into a Netty server/client pipeline
apply(SSLSettings, LoggingAdapter, boolean) - Static method in class akka.remote.transport.netty.NettySSLSupport
Construct a SSLHandler which can be inserted into a Netty server/client pipeline
apply(A) - Method in class akka.remote.transport.TestTransport.SwitchableLoggedBehavior
Applies the current behavior, and invokes the callback.
apply() - Method in class akka.routing.BalancingRoutingLogic$
 
apply() - Static method in class akka.routing.BalancingRoutingLogic
 
apply(Iterable<ActorRef>) - Method in class akka.routing.BroadcastRouter$
Creates a new BroadcastRouter, routing to the specified routees
apply(Iterable<ActorRef>) - Static method in class akka.routing.BroadcastRouter
Creates a new BroadcastRouter, routing to the specified routees
apply() - Method in class akka.routing.BroadcastRoutingLogic$
 
apply() - Static method in class akka.routing.BroadcastRoutingLogic
 
apply(Iterable<T>, int, ClassTag<T>) - Method in class akka.routing.ConsistentHash$
 
apply(Iterable<T>, int, ClassTag<T>) - Static method in class akka.routing.ConsistentHash
 
apply(Iterable<ActorRef>) - Method in class akka.routing.ConsistentHashingRouter$
Creates a new ConsistentHashingRouter, routing to the specified routees
apply(Iterable<ActorRef>) - Static method in class akka.routing.ConsistentHashingRouter
Creates a new ConsistentHashingRouter, routing to the specified routees
apply(Object) - Method in class akka.routing.ConsistentHashingRouter.emptyConsistentHashMapping$
 
apply(com.typesafe.config.Config) - Method in class akka.routing.DefaultResizer$
Creates a new DefaultResizer from the given configuration
apply(com.typesafe.config.Config) - Static method in class akka.routing.DefaultResizer
Creates a new DefaultResizer from the given configuration
apply(Option<Resizer>, SupervisorStrategy, String) - Method in class akka.routing.FromConfig$
 
apply(Option<Resizer>, SupervisorStrategy, String) - Static method in class akka.routing.FromConfig
 
apply(Iterable<ActorRef>) - Method in class akka.routing.RandomRouter$
Creates a new RandomRouter, routing to the specified routees
apply(Iterable<ActorRef>) - Static method in class akka.routing.RandomRouter
Creates a new RandomRouter, routing to the specified routees
apply() - Method in class akka.routing.RandomRoutingLogic$
 
apply() - Static method in class akka.routing.RandomRoutingLogic
 
apply(Iterable<ActorRef>) - Method in class akka.routing.RoundRobinRouter$
Creates a new RoundRobinRouter, routing to the specified routees
apply(Iterable<ActorRef>) - Static method in class akka.routing.RoundRobinRouter
Creates a new RoundRobinRouter, routing to the specified routees
apply() - Method in class akka.routing.RoundRobinRoutingLogic$
 
apply() - Static method in class akka.routing.RoundRobinRoutingLogic
 
apply(Iterable<ActorRef>, FiniteDuration) - Method in class akka.routing.ScatterGatherFirstCompletedRouter$
Creates a new ScatterGatherFirstCompletedRouter, routing to the specified routees, timing out after the specified Duration
apply(Iterable<ActorRef>, FiniteDuration) - Static method in class akka.routing.ScatterGatherFirstCompletedRouter
Creates a new ScatterGatherFirstCompletedRouter, routing to the specified routees, timing out after the specified Duration
apply(Iterable<ActorRef>) - Method in class akka.routing.SmallestMailboxRouter$
Creates a new SmallestMailboxRouter, routing to the specified routees
apply(Iterable<ActorRef>) - Static method in class akka.routing.SmallestMailboxRouter
Creates a new SmallestMailboxRouter, routing to the specified routees
apply() - Method in class akka.routing.SmallestMailboxRoutingLogic$
 
apply() - Static method in class akka.routing.SmallestMailboxRoutingLogic
 
apply(A) - Method in class akka.testkit.CachingPartialFunction
 
apply(ClassTag<T>) - Method in class akka.testkit.DeadLettersFilter$
 
apply(ClassTag<T>) - Static method in class akka.testkit.DeadLettersFilter
 
apply(String, String, String, String, int, ClassTag<A>) - Method in class akka.testkit.EventFilter$
Create a filter for Error events.
apply(Logging.LogEvent) - Method in class akka.testkit.EventFilter
 
apply(Function0<T>, ClassTag<T>, ActorSystem) - Method in class akka.testkit.TestActorRef$
 
apply(Function0<T>, String, ClassTag<T>, ActorSystem) - Method in class akka.testkit.TestActorRef$
 
apply(Props, ActorSystem) - Method in class akka.testkit.TestActorRef$
 
apply(Props, String, ActorSystem) - Method in class akka.testkit.TestActorRef$
 
apply(Props, ActorRef, String, ActorSystem) - Method in class akka.testkit.TestActorRef$
 
apply(ClassTag<T>, ActorSystem) - Method in class akka.testkit.TestActorRef$
 
apply(String, ClassTag<T>, ActorSystem) - Method in class akka.testkit.TestActorRef$
 
apply(Function0<T>, ClassTag<T>, ActorSystem) - Static method in class akka.testkit.TestActorRef
 
apply(Function0<T>, String, ClassTag<T>, ActorSystem) - Static method in class akka.testkit.TestActorRef
 
apply(Props, ActorSystem) - Static method in class akka.testkit.TestActorRef
 
apply(Props, String, ActorSystem) - Static method in class akka.testkit.TestActorRef
 
apply(Props, ActorRef, String, ActorSystem) - Static method in class akka.testkit.TestActorRef
 
apply(ClassTag<T>, ActorSystem) - Static method in class akka.testkit.TestActorRef
 
apply(String, ClassTag<T>, ActorSystem) - Static method in class akka.testkit.TestActorRef
 
apply(int) - Method in class akka.testkit.TestBarrier$
 
apply(int) - Static method in class akka.testkit.TestBarrier
 
apply(EventFilter, Seq<EventFilter>) - Method in class akka.testkit.TestEvent.Mute$
 
apply(EventFilter, Seq<EventFilter>) - Method in class akka.testkit.TestEvent.UnMute$
 
apply(Function0<T>, ClassTag<T>, Predef.$less$colon$less<T, FSM<S, D>>, ActorSystem) - Method in class akka.testkit.TestFSMRef$
 
apply(Function0<T>, String, ClassTag<T>, Predef.$less$colon$less<T, FSM<S, D>>, ActorSystem) - Method in class akka.testkit.TestFSMRef$
 
apply(Function0<T>, ClassTag<T>, Predef.$less$colon$less<T, FSM<S, D>>, ActorSystem) - Static method in class akka.testkit.TestFSMRef
 
apply(Function0<T>, String, ClassTag<T>, Predef.$less$colon$less<T, FSM<S, D>>, ActorSystem) - Static method in class akka.testkit.TestFSMRef
 
apply(int, ActorSystem) - Method in class akka.testkit.TestLatch$
 
apply(int, ActorSystem) - Static method in class akka.testkit.TestLatch
 
apply(ActorSystem) - Method in class akka.testkit.TestProbe$
 
apply(ActorSystem) - Static method in class akka.testkit.TestProbe
 
apply(Object, Timeout) - Method in class akka.transactor.Coordinated$
Creates a new Coordinated with the given message and Timeout
apply(Object) - Method in class akka.transactor.Coordinated
Create a new Coordinated object and increment the number of members by one.
apply(Object) - Method in class akka.transactor.EmptyReceive$
 
apply(Object) - Static method in class akka.transactor.EmptyReceive
 
apply(Class<?>) - Method in class akka.util.BoxedType$
 
apply(Class<?>) - Static method in class akka.util.BoxedType
 
apply(byte[]) - Method in class akka.util.ByteIterator.ByteArrayIterator$
 
apply(byte[], int, int) - Method in class akka.util.ByteIterator.ByteArrayIterator$
 
apply(LinearSeq<ByteIterator.ByteArrayIterator>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator$
 
apply(byte[]) - Method in class akka.util.ByteString$
Creates a new ByteString by copying a byte array.
apply(Seq<Object>) - Method in class akka.util.ByteString$
Creates a new ByteString by copying bytes.
apply(Seq<T>, Integral<T>) - Method in class akka.util.ByteString$
Creates a new ByteString by converting from integral numbers to bytes.
apply(ByteBuffer) - Method in class akka.util.ByteString$
Creates a new ByteString by copying bytes from a ByteBuffer.
apply(String) - Method in class akka.util.ByteString$
Creates a new ByteString by encoding a String as UTF-8.
apply(String, String) - Method in class akka.util.ByteString$
Creates a new ByteString by encoding a String with a charset.
apply(int) - Method in class akka.util.ByteString
 
apply(byte[]) - Method in class akka.util.ByteString.ByteString1$
 
apply(byte[], int, int) - Method in class akka.util.ByteString.ByteString1$
 
apply(int) - Method in class akka.util.ByteString.ByteString1
 
apply(byte[]) - Method in class akka.util.ByteString.ByteString1C$
 
apply(int) - Method in class akka.util.ByteString.ByteString1C
 
apply(Vector<ByteString.ByteString1>) - Method in class akka.util.ByteString.ByteStrings$
 
apply(Vector<ByteString.ByteString1>, int) - Method in class akka.util.ByteString.ByteStrings$
 
apply(ByteString.ByteString1, ByteString.ByteString1) - Method in class akka.util.ByteString.ByteStrings$
 
apply(ByteString.ByteString1, ByteString.ByteStrings) - Method in class akka.util.ByteString.ByteStrings$
 
apply(ByteString.ByteStrings, ByteString.ByteString1) - Method in class akka.util.ByteString.ByteStrings$
 
apply(ByteString.ByteStrings, ByteString.ByteStrings) - Method in class akka.util.ByteString.ByteStrings$
 
apply(int) - Method in class akka.util.ByteString.ByteStrings
 
apply(int) - Method in class akka.util.Collections.EmptyImmutableSeq$
 
apply(From) - Method in class akka.util.Collections.PartialImmutableValuesIterable
 
apply(byte[]) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by copying a byte array.
apply(Seq<Object>) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by copying bytes.
apply(Seq<T>, Integral<T>) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by converting from integral numbers to bytes.
apply(ByteBuffer) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by copying bytes from a ByteBuffer.
apply(String) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by encoding a String as UTF-8.
apply(String, String) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by encoding a String with a charset.
apply(byte[]) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by copying a byte array.
apply(Seq<Object>) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by copying bytes.
apply(Seq<T>, Integral<T>) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by converting from integral numbers to bytes.
apply(ByteBuffer) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by copying bytes from a ByteBuffer.
apply(String) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by encoding a String as UTF-8.
apply(String, String) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by encoding a String with a charset.
apply(int, ExecutionContext) - Method in class akka.util.SerializedSuspendableExecutionContext$
 
apply(int, ExecutionContext) - Static method in class akka.util.SerializedSuspendableExecutionContext
 
apply(long) - Method in class akka.util.Timeout$
Construct a Timeout from the given number of milliseconds.
apply(long, TimeUnit) - Method in class akka.util.Timeout$
Construct a Timeout from the given time unit and factor.
apply(long) - Static method in class akka.util.Timeout
Construct a Timeout from the given number of milliseconds.
apply(long, TimeUnit) - Static method in class akka.util.Timeout
Construct a Timeout from the given time unit and factor.
apply() - Method in class akka.util.WildcardTree$
 
apply() - Static method in class akka.util.WildcardTree
 
apply(int) - Method in class akka.zeromq.Context$
 
apply(int) - Static method in class akka.zeromq.Context
 
apply(Seq<ByteString>) - Method in interface akka.zeromq.Deserializer
 
apply(String) - Method in class akka.zeromq.Subscribe$
 
apply(String) - Static method in class akka.zeromq.Subscribe
 
apply(String) - Method in class akka.zeromq.Unsubscribe$
 
apply(String) - Static method in class akka.zeromq.Unsubscribe
 
apply(Seq<ByteString>) - Method in class akka.zeromq.ZMQMessage$
Scala API
apply(Seq<T>, Function1<T, ByteString>) - Method in class akka.zeromq.ZMQMessage$
 
apply(Seq<ByteString>) - Static method in class akka.zeromq.ZMQMessage
Scala API
apply(Seq<T>, Function1<T, ByteString>) - Static method in class akka.zeromq.ZMQMessage
 
apply(Seq<ByteString>) - Method in class akka.zeromq.ZMQMessageDeserializer
 
applyOrElse(A1, Function1<A1, B1>) - Method in class akka.japi.JavaPartialFunction
 
applyState(FSM.State<S, D>) - Method in interface akka.actor.FSM
 
applyUserRouteCustomization(org.apache.camel.model.RouteDefinition) - Method in class akka.camel.internal.ConsumerActorRouteBuilder
 
args() - Method in class akka.actor.Props
 
ARGS_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.PropsData
 
ArgsReflectConstructor - Class in akka.actor
INTERNAL API
ArgsReflectConstructor(Class<? extends Actor>, Seq<Object>) - Constructor for class akka.actor.ArgsReflectConstructor
 
aroundPostRestart(Throwable) - Method in interface akka.actor.Actor
Can be overridden to intercept calls to postRestart.
aroundPostStop() - Method in interface akka.actor.Actor
Can be overridden to intercept calls to postStop.
aroundPostStop() - Method in interface akka.persistence.AtLeastOnceDelivery
INTERNAL API
aroundPostStop() - Method in interface akka.persistence.ProcessorImpl
INTERNAL API.
aroundPreRestart(Throwable, Option<Object>) - Method in interface akka.actor.Actor
Can be overridden to intercept calls to preRestart.
aroundPreRestart(Throwable, Option<Object>) - Method in interface akka.persistence.AtLeastOnceDelivery
INTERNAL API
aroundPreRestart(Throwable, Option<Object>) - Method in interface akka.persistence.Eventsourced
 
aroundPreRestart(Throwable, Option<Object>) - Method in interface akka.persistence.ProcessorImpl
INTERNAL API.
aroundPreStart() - Method in interface akka.actor.Actor
Can be overridden to intercept calls to preStart.
aroundPreStart() - Method in interface akka.persistence.ProcessorImpl
INTERNAL API.
aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.actor.Actor
INTERNAL API.
aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.actor.DiagnosticActorLogging
 
aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.persistence.AtLeastOnceDelivery
INTERNAL API
aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.persistence.Eventsourced
 
aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.persistence.Recovery
INTERNAL API.
aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.persistence.Recovery.State
 
aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in class akka.persistence.RequestWriter
 
ARRAY_OF_BYTE_ARRAY() - Method in class akka.remote.serialization.ProtobufSerializer
 
arrayBlockingQueue(int, boolean) - Method in class akka.dispatch.ThreadPoolConfig$
 
arrayBlockingQueue(int, boolean) - Static method in class akka.dispatch.ThreadPoolConfig
 
arrayHash(Object) - Method in class akka.routing.MurmurHash$
Compute a high-quality hash of an array
arrayHash(Object) - Static method in class akka.routing.MurmurHash
Compute a high-quality hash of an array
arrived() - Method in class akka.remote.testconductor.BarrierCoordinator.Data
 
asByteBuffer() - Method in class akka.util.ByteString
Returns a read-only ByteBuffer that directly wraps this ByteString if it is not fragmented.
asByteBuffer() - Method in class akka.util.ByteString.ByteString1
 
asByteBuffer() - Method in class akka.util.ByteString.ByteString1C
 
asByteBuffer() - Method in class akka.util.ByteString.ByteStrings
 
asByteBuffers() - Method in class akka.util.ByteString
Scala API: Returns an immutable Iterable of read-only ByteBuffers that directly wraps this ByteStrings all fragments.
asByteBuffers() - Method in class akka.util.ByteString.ByteString1
 
asByteBuffers() - Method in class akka.util.ByteString.ByteString1C
 
asByteBuffers() - Method in class akka.util.ByteString.ByteStrings
 
asInputStream() - Method in class akka.util.ByteIterator
Directly wraps this ByteIterator in an InputStream without copying.
asInputStream() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
asInputStream() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
asInt() - Method in class akka.event.Logging.LogLevel
 
ask(Object, Timeout) - Method in class akka.pattern.AskableActorRef
 
ask(Object, Timeout) - Method in class akka.pattern.AskableActorSelection
 
ask(ActorRef) - Method in interface akka.pattern.AskSupport
Import this implicit conversion to gain ? and ask methods on ActorRef, which will defer to the ask(actorRef, message)(timeout) method defined here.
ask(ActorRef, Object, Timeout) - Method in interface akka.pattern.AskSupport
Sends a message asynchronously and returns a Future holding the eventual reply message; this means that the target actor needs to send the result to the sender reference provided.
ask(ActorSelection) - Method in interface akka.pattern.AskSupport
Import this implicit conversion to gain ? and ask methods on ActorSelection, which will defer to the ask(actorSelection, message)(timeout) method defined here.
ask(ActorSelection, Object, Timeout) - Method in interface akka.pattern.AskSupport
Sends a message asynchronously and returns a Future holding the eventual reply message; this means that the target actor needs to send the result to the sender reference provided.
ask(ActorRef, Object, Timeout) - Method in class akka.pattern.Patterns$
Java API for akka.pattern.ask: Sends a message asynchronously and returns a Future holding the eventual reply message; this means that the target actor needs to send the result to the sender reference provided.
ask(ActorRef, Object, long) - Method in class akka.pattern.Patterns$
Java API for akka.pattern.ask: Sends a message asynchronously and returns a Future holding the eventual reply message; this means that the target actor needs to send the result to the sender reference provided.
ask(ActorSelection, Object, Timeout) - Method in class akka.pattern.Patterns$
Java API for akka.pattern.ask: Sends a message asynchronously and returns a Future holding the eventual reply message; this means that the target ActorSelection needs to send the result to the sender reference provided.
ask(ActorSelection, Object, long) - Method in class akka.pattern.Patterns$
Java API for akka.pattern.ask: Sends a message asynchronously and returns a Future holding the eventual reply message; this means that the target ActorSelection needs to send the result to the sender reference provided.
ask(ActorRef, Object, Timeout) - Static method in class akka.pattern.Patterns
Java API for akka.pattern.ask: Sends a message asynchronously and returns a Future holding the eventual reply message; this means that the target actor needs to send the result to the sender reference provided.
ask(ActorRef, Object, long) - Static method in class akka.pattern.Patterns
Java API for akka.pattern.ask: Sends a message asynchronously and returns a Future holding the eventual reply message; this means that the target actor needs to send the result to the sender reference provided.
ask(ActorSelection, Object, Timeout) - Static method in class akka.pattern.Patterns
Java API for akka.pattern.ask: Sends a message asynchronously and returns a Future holding the eventual reply message; this means that the target ActorSelection needs to send the result to the sender reference provided.
ask(ActorSelection, Object, long) - Static method in class akka.pattern.Patterns
Java API for akka.pattern.ask: Sends a message asynchronously and returns a Future holding the eventual reply message; this means that the target ActorSelection needs to send the result to the sender reference provided.
AskableActorRef - Class in akka.pattern
 
AskableActorRef(ActorRef) - Constructor for class akka.pattern.AskableActorRef
 
AskableActorRef$ - Class in akka.pattern
 
AskableActorRef$() - Constructor for class akka.pattern.AskableActorRef$
 
AskableActorSelection - Class in akka.pattern
 
AskableActorSelection(ActorSelection) - Constructor for class akka.pattern.AskableActorSelection
 
AskableActorSelection$ - Class in akka.pattern
 
AskableActorSelection$() - Constructor for class akka.pattern.AskableActorSelection$
 
AskSupport - Interface in akka.pattern
This object contains implementation details of the &ldquo;ask&rdquo; pattern.
AskTimeout() - Method in class akka.remote.transport.ActorTransportAdapter$
 
AskTimeout() - Static method in class akka.remote.transport.ActorTransportAdapter
 
AskTimeoutException - Exception in akka.pattern
This is what is used to complete a Future that is returned from an ask/? call, when it times out.
AskTimeoutException(String, Throwable) - Constructor for exception akka.pattern.AskTimeoutException
 
AskTimeoutException(String) - Constructor for exception akka.pattern.AskTimeoutException
 
asOutputStream() - Method in class akka.util.ByteStringBuilder
Directly wraps this ByteStringBuilder in an OutputStream.
asScala() - Method in class akka.japi.Option
 
asScala() - Method in class akka.japi.Option.Some
 
associate(ActorRef, ActorRef) - Method in interface akka.event.ActorClassification
 
associate(Address) - Method in class akka.remote.transport.AbstractTransportAdapter
 
associate(Address, Option<Object>) - Method in class akka.remote.transport.AkkaProtocolTransport
 
associate(Address) - Method in class akka.remote.transport.netty.NettyTransport
 
associate(Address) - Method in class akka.remote.transport.TestTransport
 
associate(Address) - Method in interface akka.remote.transport.Transport
Asynchronously opens a logical duplex link between two Transport Entities over a network.
ASSOCIATE_VALUE - Static variable in enum akka.remote.WireFormats.CommandType
ASSOCIATE = 1;
associateBehavior() - Method in class akka.remote.transport.TestTransport
The TestTransport.SwitchableLoggedBehavior for the associate() method.
AssociatedEvent - Class in akka.remote
 
AssociatedEvent(Address, Address, boolean) - Constructor for class akka.remote.AssociatedEvent
 
AssociatedEvent$ - Class in akka.remote
 
AssociatedEvent$() - Constructor for class akka.remote.AssociatedEvent$
 
association() - Method in class akka.remote.transport.Transport.InboundAssociation
 
AssociationErrorEvent - Class in akka.remote
 
AssociationErrorEvent(Throwable, Address, Address, boolean, Logging.LogLevel) - Constructor for class akka.remote.AssociationErrorEvent
 
AssociationErrorEvent$ - Class in akka.remote
 
AssociationErrorEvent$() - Constructor for class akka.remote.AssociationErrorEvent$
 
AssociationEvent - Interface in akka.remote
 
AssociationHandle - Interface in akka.remote.transport
An SPI layer for abstracting over logical links (associations) created by a Transport.
AssociationHandle$ - Class in akka.remote.transport
 
AssociationHandle$() - Constructor for class akka.remote.transport.AssociationHandle$
 
AssociationHandle.ActorHandleEventListener - Class in akka.remote.transport
Class to convert ordinary ActorRef instances to a HandleEventListener.
AssociationHandle.ActorHandleEventListener(ActorRef) - Constructor for class akka.remote.transport.AssociationHandle.ActorHandleEventListener
 
AssociationHandle.ActorHandleEventListener$ - Class in akka.remote.transport
 
AssociationHandle.ActorHandleEventListener$() - Constructor for class akka.remote.transport.AssociationHandle.ActorHandleEventListener$
 
AssociationHandle.Disassociated - Class in akka.remote.transport
Message sent to the listener registered to an association
AssociationHandle.Disassociated(AssociationHandle.DisassociateInfo) - Constructor for class akka.remote.transport.AssociationHandle.Disassociated
 
AssociationHandle.Disassociated$ - Class in akka.remote.transport
 
AssociationHandle.Disassociated$() - Constructor for class akka.remote.transport.AssociationHandle.Disassociated$
 
AssociationHandle.DisassociateInfo - Interface in akka.remote.transport
Supertype of possible disassociation reasons
AssociationHandle.HandleEvent - Interface in akka.remote.transport
Trait for events that the registered listener for an AssociationHandle might receive.
AssociationHandle.HandleEventListener - Interface in akka.remote.transport
An interface that needs to be implemented by the user of an AssociationHandle to listen to association events.
AssociationHandle.InboundPayload - Class in akka.remote.transport
Message sent to the listener registered to an association (via the Promise returned by akka.remote.transport.AssociationHandle.readHandlerPromise) when an inbound payload arrives.
AssociationHandle.InboundPayload(ByteString) - Constructor for class akka.remote.transport.AssociationHandle.InboundPayload
 
AssociationHandle.InboundPayload$ - Class in akka.remote.transport
 
AssociationHandle.InboundPayload$() - Constructor for class akka.remote.transport.AssociationHandle.InboundPayload$
 
AssociationHandle.Quarantined$ - Class in akka.remote.transport
 
AssociationHandle.Quarantined$() - Constructor for class akka.remote.transport.AssociationHandle.Quarantined$
 
AssociationHandle.Shutdown$ - Class in akka.remote.transport
 
AssociationHandle.Shutdown$() - Constructor for class akka.remote.transport.AssociationHandle.Shutdown$
 
AssociationHandle.Unknown$ - Class in akka.remote.transport
 
AssociationHandle.Unknown$() - Constructor for class akka.remote.transport.AssociationHandle.Unknown$
 
associationHandler() - Method in class akka.remote.transport.ThrottledAssociation
 
associationListener() - Method in class akka.remote.transport.ActorTransportAdapterManager
 
associationListener() - Method in class akka.remote.transport.ProtocolStateActor.InboundUnassociated
 
AssociationProblem - Interface in akka.remote
INTERNAL API
AssociationRegistry - Class in akka.remote.transport
 
AssociationRegistry() - Constructor for class akka.remote.transport.AssociationRegistry
 
AssociationRegistry$ - Class in akka.remote.transport
 
AssociationRegistry$() - Constructor for class akka.remote.transport.AssociationRegistry$
 
async() - Method in class akka.dispatch.sysmsg.Supervise
 
asyncDeleteMessages(Seq<PersistentId>, boolean) - Method in interface akka.persistence.journal.AsyncWriteJournal
Plugin API: asynchronously deletes messages identified by messageIds from the journal.
asyncDeleteMessages(Seq<PersistentId>, boolean) - Method in interface akka.persistence.journal.AsyncWriteProxy
 
asyncDeleteMessages(Seq<PersistentId>, boolean) - Method in class akka.persistence.journal.japi.AsyncWriteJournal
 
asyncDeleteMessagesTo(String, long, boolean) - Method in interface akka.persistence.journal.AsyncWriteJournal
Plugin API: asynchronously deletes all persistent messages up to toSequenceNr (inclusive).
asyncDeleteMessagesTo(String, long, boolean) - Method in interface akka.persistence.journal.AsyncWriteProxy
 
asyncDeleteMessagesTo(String, long, boolean) - Method in class akka.persistence.journal.japi.AsyncWriteJournal
 
asyncMode() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory
 
asyncReadHighestSequenceNr(String, long) - Method in interface akka.persistence.journal.AsyncRecovery
Plugin API: asynchronously reads the highest stored sequence number for the given persistenceId.
asyncReadHighestSequenceNr(String, long) - Method in interface akka.persistence.journal.AsyncWriteProxy
 
asyncReadHighestSequenceNr(String, long) - Method in class akka.persistence.journal.japi.AsyncRecovery
 
asyncReadHighestSequenceNr(String, long) - Method in interface akka.persistence.journal.leveldb.LeveldbRecovery
 
AsyncRecovery - Interface in akka.persistence.journal
Asynchronous message replay and sequence number recovery interface.
AsyncRecovery - Class in akka.persistence.journal.japi
Java API: asynchronous message replay and sequence number recovery interface.
AsyncRecovery() - Constructor for class akka.persistence.journal.japi.AsyncRecovery
 
asyncReplayMessages(String, long, long, long, Function1<PersistentRepr, BoxedUnit>) - Method in interface akka.persistence.journal.AsyncRecovery
Plugin API: asynchronously replays persistent messages.
asyncReplayMessages(String, long, long, long, Function1<PersistentRepr, BoxedUnit>) - Method in interface akka.persistence.journal.AsyncWriteProxy
 
asyncReplayMessages(String, long, long, long, Function1<PersistentRepr, BoxedUnit>) - Method in class akka.persistence.journal.japi.AsyncRecovery
 
asyncReplayMessages(String, long, long, long, Function1<PersistentRepr, BoxedUnit>) - Method in interface akka.persistence.journal.leveldb.LeveldbRecovery
 
AsyncReplayTimeoutException - Exception in akka.persistence.journal
Thrown if replay inactivity exceeds a specified timeout.
AsyncReplayTimeoutException(String) - Constructor for exception akka.persistence.journal.AsyncReplayTimeoutException
 
asyncWriteConfirmations(Seq<PersistentConfirmation>) - Method in interface akka.persistence.journal.AsyncWriteJournal
Plugin API: asynchronously writes a batch of delivery confirmations to the journal.
asyncWriteConfirmations(Seq<PersistentConfirmation>) - Method in interface akka.persistence.journal.AsyncWriteProxy
 
asyncWriteConfirmations(Seq<PersistentConfirmation>) - Method in class akka.persistence.journal.japi.AsyncWriteJournal
 
AsyncWriteJournal - Interface in akka.persistence.journal
Abstract journal, optimized for asynchronous, non-blocking writes.
AsyncWriteJournal - Class in akka.persistence.journal.japi
Java API: abstract journal, optimized for asynchronous, non-blocking writes.
AsyncWriteJournal() - Constructor for class akka.persistence.journal.japi.AsyncWriteJournal
 
AsyncWriteJournal$ - Class in akka.persistence.journal
INTERNAL API.
AsyncWriteJournal$() - Constructor for class akka.persistence.journal.AsyncWriteJournal$
 
AsyncWriteJournal.Desequenced - Class in akka.persistence.journal
 
AsyncWriteJournal.Desequenced(Object, long, ActorRef, ActorRef) - Constructor for class akka.persistence.journal.AsyncWriteJournal.Desequenced
 
AsyncWriteJournal.Desequenced$ - Class in akka.persistence.journal
 
AsyncWriteJournal.Desequenced$() - Constructor for class akka.persistence.journal.AsyncWriteJournal.Desequenced$
 
AsyncWriteJournal.Resequencer - Class in akka.persistence.journal
 
AsyncWriteJournal.Resequencer() - Constructor for class akka.persistence.journal.AsyncWriteJournal.Resequencer
 
asyncWriteMessages(Seq<PersistentRepr>) - Method in interface akka.persistence.journal.AsyncWriteJournal
Plugin API: asynchronously writes a batch of persistent messages to the journal.
asyncWriteMessages(Seq<PersistentRepr>) - Method in interface akka.persistence.journal.AsyncWriteProxy
 
asyncWriteMessages(Seq<PersistentRepr>) - Method in class akka.persistence.journal.japi.AsyncWriteJournal
 
AsyncWriteProxy - Interface in akka.persistence.journal
INTERNAL API.
AsyncWriteProxy$ - Class in akka.persistence.journal
INTERNAL API.
AsyncWriteProxy$() - Constructor for class akka.persistence.journal.AsyncWriteProxy$
 
AsyncWriteProxy.SetStore - Class in akka.persistence.journal
 
AsyncWriteProxy.SetStore(ActorRef) - Constructor for class akka.persistence.journal.AsyncWriteProxy.SetStore
 
AsyncWriteProxy.SetStore$ - Class in akka.persistence.journal
 
AsyncWriteProxy.SetStore$() - Constructor for class akka.persistence.journal.AsyncWriteProxy.SetStore$
 
AsyncWriteTarget - Class in akka.persistence.journal
INTERNAL API.
AsyncWriteTarget() - Constructor for class akka.persistence.journal.AsyncWriteTarget
 
AsyncWriteTarget$ - Class in akka.persistence.journal
INTERNAL API.
AsyncWriteTarget$() - Constructor for class akka.persistence.journal.AsyncWriteTarget$
 
AsyncWriteTarget.DeleteMessages - Class in akka.persistence.journal
 
AsyncWriteTarget.DeleteMessages(Seq<PersistentId>, boolean) - Constructor for class akka.persistence.journal.AsyncWriteTarget.DeleteMessages
 
AsyncWriteTarget.DeleteMessages$ - Class in akka.persistence.journal
 
AsyncWriteTarget.DeleteMessages$() - Constructor for class akka.persistence.journal.AsyncWriteTarget.DeleteMessages$
 
AsyncWriteTarget.DeleteMessagesTo - Class in akka.persistence.journal
 
AsyncWriteTarget.DeleteMessagesTo(String, long, boolean) - Constructor for class akka.persistence.journal.AsyncWriteTarget.DeleteMessagesTo
 
AsyncWriteTarget.DeleteMessagesTo$ - Class in akka.persistence.journal
 
AsyncWriteTarget.DeleteMessagesTo$() - Constructor for class akka.persistence.journal.AsyncWriteTarget.DeleteMessagesTo$
 
AsyncWriteTarget.ReadHighestSequenceNr - Class in akka.persistence.journal
 
AsyncWriteTarget.ReadHighestSequenceNr(String, long) - Constructor for class akka.persistence.journal.AsyncWriteTarget.ReadHighestSequenceNr
 
AsyncWriteTarget.ReadHighestSequenceNr$ - Class in akka.persistence.journal
 
AsyncWriteTarget.ReadHighestSequenceNr$() - Constructor for class akka.persistence.journal.AsyncWriteTarget.ReadHighestSequenceNr$
 
AsyncWriteTarget.ReplayFailure - Class in akka.persistence.journal
 
AsyncWriteTarget.ReplayFailure(Throwable) - Constructor for class akka.persistence.journal.AsyncWriteTarget.ReplayFailure
 
AsyncWriteTarget.ReplayFailure$ - Class in akka.persistence.journal
 
AsyncWriteTarget.ReplayFailure$() - Constructor for class akka.persistence.journal.AsyncWriteTarget.ReplayFailure$
 
AsyncWriteTarget.ReplayMessages - Class in akka.persistence.journal
 
AsyncWriteTarget.ReplayMessages(String, long, long, long) - Constructor for class akka.persistence.journal.AsyncWriteTarget.ReplayMessages
 
AsyncWriteTarget.ReplayMessages$ - Class in akka.persistence.journal
 
AsyncWriteTarget.ReplayMessages$() - Constructor for class akka.persistence.journal.AsyncWriteTarget.ReplayMessages$
 
AsyncWriteTarget.ReplaySuccess$ - Class in akka.persistence.journal
 
AsyncWriteTarget.ReplaySuccess$() - Constructor for class akka.persistence.journal.AsyncWriteTarget.ReplaySuccess$
 
AsyncWriteTarget.WriteConfirmations - Class in akka.persistence.journal
 
AsyncWriteTarget.WriteConfirmations(Seq<PersistentConfirmation>) - Constructor for class akka.persistence.journal.AsyncWriteTarget.WriteConfirmations
 
AsyncWriteTarget.WriteConfirmations$ - Class in akka.persistence.journal
 
AsyncWriteTarget.WriteConfirmations$() - Constructor for class akka.persistence.journal.AsyncWriteTarget.WriteConfirmations$
 
AsyncWriteTarget.WriteMessages - Class in akka.persistence.journal
 
AsyncWriteTarget.WriteMessages(Seq<PersistentRepr>) - Constructor for class akka.persistence.journal.AsyncWriteTarget.WriteMessages
 
AsyncWriteTarget.WriteMessages$ - Class in akka.persistence.journal
 
AsyncWriteTarget.WriteMessages$() - Constructor for class akka.persistence.journal.AsyncWriteTarget.WriteMessages$
 
atFullThrottle() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinPool
 
atFullThrottle() - Method in interface akka.dispatch.LoadMetrics
 
atKey(String) - Method in class akka.dispatch.CachingConfig
 
AtLeastOnceDelivery - Interface in akka.persistence
Mix-in this trait with your PersistentActor to send messages with at-least-once delivery semantics to destinations.
atLeastOnceDelivery() - Method in class akka.persistence.PersistenceSettings
 
AtLeastOnceDelivery$ - Class in akka.persistence
 
AtLeastOnceDelivery$() - Constructor for class akka.persistence.AtLeastOnceDelivery$
 
AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot - Class in akka.persistence
Snapshot of current AtLeastOnceDelivery state.
AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot(long, Seq<AtLeastOnceDelivery.UnconfirmedDelivery>) - Constructor for class akka.persistence.AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot
 
AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot$ - Class in akka.persistence
 
AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot$() - Constructor for class akka.persistence.AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot$
 
AtLeastOnceDelivery.Internal$ - Class in akka.persistence
 
AtLeastOnceDelivery.Internal$() - Constructor for class akka.persistence.AtLeastOnceDelivery.Internal$
 
AtLeastOnceDelivery.Internal$.Delivery - Class in akka.persistence
 
AtLeastOnceDelivery.Internal$.Delivery(ActorPath, Object, long, int) - Constructor for class akka.persistence.AtLeastOnceDelivery.Internal$.Delivery
 
AtLeastOnceDelivery.Internal$.RedeliveryTick - Class in akka.persistence
 
AtLeastOnceDelivery.Internal$.RedeliveryTick() - Constructor for class akka.persistence.AtLeastOnceDelivery.Internal$.RedeliveryTick
 
AtLeastOnceDelivery.MaxUnconfirmedMessagesExceededException - Exception in akka.persistence
 
AtLeastOnceDelivery.MaxUnconfirmedMessagesExceededException(String) - Constructor for exception akka.persistence.AtLeastOnceDelivery.MaxUnconfirmedMessagesExceededException
 
AtLeastOnceDelivery.UnconfirmedDelivery - Class in akka.persistence
Information about a message that has not been confirmed.
AtLeastOnceDelivery.UnconfirmedDelivery(long, ActorPath, Object) - Constructor for class akka.persistence.AtLeastOnceDelivery.UnconfirmedDelivery
 
AtLeastOnceDelivery.UnconfirmedDelivery$ - Class in akka.persistence
 
AtLeastOnceDelivery.UnconfirmedDelivery$() - Constructor for class akka.persistence.AtLeastOnceDelivery.UnconfirmedDelivery$
 
AtLeastOnceDelivery.UnconfirmedWarning - Class in akka.persistence
 
AtLeastOnceDelivery.UnconfirmedWarning(Seq<AtLeastOnceDelivery.UnconfirmedDelivery>) - Constructor for class akka.persistence.AtLeastOnceDelivery.UnconfirmedWarning
 
AtLeastOnceDelivery.UnconfirmedWarning$ - Class in akka.persistence
 
AtLeastOnceDelivery.UnconfirmedWarning$() - Constructor for class akka.persistence.AtLeastOnceDelivery.UnconfirmedWarning$
 
atLeastOnceDeliverySnapshot(MessageFormats.AtLeastOnceDeliverySnapshot) - Method in class akka.persistence.serialization.MessageSerializer
 
atLeastOnceDeliverySnapshotBuilder(AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot) - Method in class akka.persistence.serialization.MessageSerializer
 
AtLeastOnceDeliverySnapshotClass() - Method in class akka.persistence.serialization.MessageSerializer
 
atomic(Function1<scala.concurrent.stm.InTxn, A>) - Method in class akka.transactor.Coordinated
Delimits the coordinated transaction.
atomic(Runnable) - Method in class akka.transactor.Coordinated
Java API: coordinated atomic method that accepts a java.lang.Runnable.
atomic(Callable<A>) - Method in class akka.transactor.Coordinated
Java API: coordinated atomic method that accepts a java.util.concurrent.Callable.
atomically() - Method in interface akka.transactor.Transactor
The Receive block to run inside the coordinated transaction.
atomically(Object) - Method in class akka.transactor.UntypedTransactor
The Receive block to run inside the coordinated transaction.
atPath(String) - Method in class akka.dispatch.CachingConfig
 
atStartup() - Method in class akka.actor.mailbox.DurableMailboxSpec
May be implemented in concrete subclass to do additional things once before test cases are run.
atStartup() - Method in class akka.remote.testkit.MultiNodeSpec
Override this method to do something when the whole test is starting up.
atStartup() - Method in class akka.testkit.AkkaSpec
 
attach(ActorCell) - Method in class akka.dispatch.MessageDispatcher
Attaches the specified actor instance to this dispatcher, which includes scheduling it to run for the first time (Create() is expected to have been enqueued by the ActorCell upon mailbox creation).
attach() - Method in class akka.util.SerializedSuspendableExecutionContext
 
attachChild(Props, boolean) - Method in interface akka.actor.dungeon.Children
 
attachChild(Props, String, boolean) - Method in interface akka.actor.dungeon.Children
 
attachConductor(TestConductorExt) - Method in class akka.remote.testkit.MultiNodeSpec
 
attempt() - Method in class akka.persistence.AtLeastOnceDelivery.Internal$.Delivery
 
attemptedReconnects() - Method in class akka.contrib.pattern.ReliableProxy
 
attempts() - Method in class akka.persistence.ReliableDelivery.Redeliver
 
augmentScheme(String) - Method in interface akka.remote.transport.SchemeAugmenter
 
augmentScheme(Address) - Method in interface akka.remote.transport.SchemeAugmenter
 
AutoAck() - Method in class akka.camel.CamelSettings
Configured setting which determines whether one-way communications between an endpoint and this consumer actor should be auto-acknowledged or application-acknowledged.
autoAck() - Method in interface akka.camel.Consumer
Determines whether one-way communications between an endpoint and this consumer actor should be auto-acknowledged or application-acknowledged.
autoAck() - Method in class akka.camel.ConsumerConfig
 
autoAck() - Method in interface akka.camel.internal.component.ActorEndpointConfig
 
AutoDown - Class in akka.cluster
INTERNAL API
AutoDown(FiniteDuration) - Constructor for class akka.cluster.AutoDown
 
AutoDown() - Method in class akka.cluster.ClusterSettings
 
AutoDown$ - Class in akka.cluster
INTERNAL API
AutoDown$() - Constructor for class akka.cluster.AutoDown$
 
AutoDown.UnreachableTimeout - Class in akka.cluster
 
AutoDown.UnreachableTimeout(UniqueAddress) - Constructor for class akka.cluster.AutoDown.UnreachableTimeout
 
AutoDown.UnreachableTimeout$ - Class in akka.cluster
 
AutoDown.UnreachableTimeout$() - Constructor for class akka.cluster.AutoDown.UnreachableTimeout$
 
AutoDownBase - Class in akka.cluster
INTERNAL API
AutoDownBase(FiniteDuration) - Constructor for class akka.cluster.AutoDownBase
 
AutoDownUnreachableAfter() - Method in class akka.cluster.ClusterSettings
 
autopilot() - Method in class akka.testkit.TestActor
 
AutoReceivedMessage - Interface in akka.actor
INTERNAL API
autoReceiveMessage(Envelope) - Method in class akka.actor.ActorCell
 
autoResendTimer() - Method in class akka.remote.ReliableDeliverySupervisor
 
autoUpdate() - Method in class akka.persistence.PersistenceSettings.view
 
autoUpdate() - Method in interface akka.persistence.PersistentView
If true, this view automatically updates itself with an interval specified by autoUpdateInterval.
autoUpdate() - Method in interface akka.persistence.View
If true, this view automatically updates itself with an interval specified by autoUpdateInterval.
autoUpdateInterval() - Method in class akka.persistence.PersistenceSettings.view
 
autoUpdateInterval() - Method in interface akka.persistence.PersistentView
The interval for automated updates.
autoUpdateInterval() - Method in interface akka.persistence.View
The interval for automated updates.
autoUpdateReplayMax() - Method in class akka.persistence.PersistenceSettings.view
 
autoUpdateReplayMax() - Method in interface akka.persistence.PersistentView
The maximum number of messages to replay per update.
autoUpdateReplayMax() - Method in interface akka.persistence.View
The maximum number of messages to replay per update.
availableNodes() - Method in interface akka.cluster.routing.ClusterRouterActor
 
availableTokens() - Method in class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket
 
average() - Method in class akka.cluster.Metric
 
await() - Method in class akka.persistence.Update
 
await() - Method in class akka.remote.testkit.MultiNodeSpec.AwaitHelper
 
await(ActorSystem) - Method in class akka.testkit.TestBarrier
 
await(FiniteDuration, ActorSystem) - Method in class akka.testkit.TestBarrier
 
await() - Method in class akka.transactor.Coordinated
An empty coordinated atomic block.
AwaitActivation - Class in akka.camel.internal
INTERNAL API A request message to the ActivationTracker for the status of activation.
AwaitActivation(ActorRef) - Constructor for class akka.camel.internal.AwaitActivation
 
AwaitActivation$ - Class in akka.camel.internal
 
AwaitActivation$() - Constructor for class akka.camel.internal.AwaitActivation$
 
awaitAssert(Function0<Object>, Duration, Duration) - Method in interface akka.testkit.TestKitBase
Await until the given assert does not throw an exception or the timeout expires, whichever comes first.
awaitCond(Function0<Object>, Duration, Duration, boolean) - Method in class akka.testkit.TestKit$
Await until the given condition evaluates to true or the timeout expires, whichever comes first.
awaitCond(Function0<Object>, Duration, Duration, boolean) - Static method in class akka.testkit.TestKit
Await until the given condition evaluates to true or the timeout expires, whichever comes first.
awaitCond(Function0<Object>, Duration, Duration, String) - Method in interface akka.testkit.TestKitBase
Await until the given condition evaluates to true or the timeout expires, whichever comes first.
AwaitDeActivation - Class in akka.camel.internal
INTERNAL API A request message to the ActivationTracker for the status of de-activation.
AwaitDeActivation(ActorRef) - Constructor for class akka.camel.internal.AwaitDeActivation
 
AwaitDeActivation$ - Class in akka.camel.internal
 
AwaitDeActivation$() - Constructor for class akka.camel.internal.AwaitDeActivation$
 
awaitDone(Duration) - Method in class akka.testkit.EventFilter
 
awaitDuration() - Method in interface akka.persistence.journal.JournalPerfSpec
Override in order to customize timeouts used for expectMsg, in order to tune the awaits to your journal's perf
awaitDurationMillis() - Method in interface akka.persistence.journal.JournalPerfSpec
Override in order to customize timeouts used for expectMsg, in order to tune the awaits to your journal's perf
awaitHelper(Awaitable<T>) - Method in class akka.remote.testkit.MultiNodeSpec
Enrich .await() onto all Awaitables, using remaining duration from the innermost enclosing within block or QueryTimeout.
awaitTermination(Duration) - Method in class akka.actor.ActorSystem
Block current thread until the system has been shutdown, or the specified timeout has elapsed.
awaitTermination() - Method in class akka.actor.ActorSystem
Block current thread until the system has been shutdown.
awaitTermination(Duration) - Method in class akka.actor.ActorSystemImpl
 
awaitTermination() - Method in class akka.actor.ActorSystemImpl
 
awaitTermination(long, TimeUnit) - Method in interface akka.dispatch.ExecutorServiceDelegate
 

B

backendName() - Method in class akka.actor.mailbox.DurableMailboxSpec
 
backlog() - Method in class akka.io.Tcp.Bind
 
Backlog() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
Backlog - Class in akka.zeromq
The Backlog option shall set the maximum length of the queue of outstanding peer connections for the specified socket; this only applies to connection-oriented transports.
Backlog(long) - Constructor for class akka.zeromq.Backlog
 
backlog() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its backlog configuration.
backlog() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its backlog configuration.
Backlog$ - Class in akka.zeromq
Gets the backlog
Backlog$() - Constructor for class akka.zeromq.Backlog$
 
backoff(int, int) - Method in class akka.routing.DefaultResizer
Computes a proposed negative (or zero) capacity delta using the configured backoffThreshold and backoffRate
backoffDispatcher() - Method in class akka.remote.EndpointWriter
 
BackoffPeriod() - Method in class akka.remote.RemoteSettings
 
backoffRate() - Method in class akka.routing.DefaultResizer
 
backoffThreshold() - Method in class akka.routing.DefaultResizer
 
bailoutAt() - Method in class akka.remote.ReliableDeliverySupervisor
 
BalancingDispatcher - Class in akka.dispatch
An executor based event driven dispatcher which will try to redistribute work from busy actors to idle actors.
BalancingDispatcher(MessageDispatcherConfigurator, String, int, Duration, MailboxType, ExecutorServiceFactoryProvider, FiniteDuration, boolean) - Constructor for class akka.dispatch.BalancingDispatcher
 
BalancingDispatcherConfigurator - Class in akka.dispatch
Configurator for creating BalancingDispatcher.
BalancingDispatcherConfigurator(com.typesafe.config.Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.BalancingDispatcherConfigurator
 
BalancingDispatcherConfigurator$ - Class in akka.dispatch
INTERNAL API
BalancingDispatcherConfigurator$() - Constructor for class akka.dispatch.BalancingDispatcherConfigurator$
 
BalancingPool - Class in akka.routing
A router pool that will try to redistribute work from busy routees to idle routees.
BalancingPool(int, SupervisorStrategy, String) - Constructor for class akka.routing.BalancingPool
 
BalancingPool(com.typesafe.config.Config) - Constructor for class akka.routing.BalancingPool
 
BalancingPool$ - Class in akka.routing
 
BalancingPool$() - Constructor for class akka.routing.BalancingPool$
 
BalancingRoutingLogic - Class in akka.routing
INTERNAL API Selects the first routee, balancing will be done by the dispatcher.
BalancingRoutingLogic() - Constructor for class akka.routing.BalancingRoutingLogic
 
BalancingRoutingLogic$ - Class in akka.routing
INTERNAL API
BalancingRoutingLogic$() - Constructor for class akka.routing.BalancingRoutingLogic$
 
barrier() - Method in class akka.remote.testconductor.BarrierCoordinator.Data
 
barrier() - Method in exception akka.remote.testconductor.BarrierCoordinator.WrongBarrier
 
barrier() - Method in class akka.remote.testconductor.Controller
 
BARRIER_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
BarrierCoordinator - Class in akka.remote.testconductor
This barrier coordinator gets informed of players connecting (NodeInfo), players being deliberately removed (RemoveClient) or failing (ClientDisconnected) by the controller.
BarrierCoordinator() - Constructor for class akka.remote.testconductor.BarrierCoordinator
 
BarrierCoordinator$ - Class in akka.remote.testconductor
INTERNAL API.
BarrierCoordinator$() - Constructor for class akka.remote.testconductor.BarrierCoordinator$
 
BarrierCoordinator.BarrierEmpty - Exception in akka.remote.testconductor
 
BarrierCoordinator.BarrierEmpty(BarrierCoordinator.Data, String) - Constructor for exception akka.remote.testconductor.BarrierCoordinator.BarrierEmpty
 
BarrierCoordinator.BarrierEmpty$ - Class in akka.remote.testconductor
 
BarrierCoordinator.BarrierEmpty$() - Constructor for class akka.remote.testconductor.BarrierCoordinator.BarrierEmpty$
 
BarrierCoordinator.BarrierTimeout - Exception in akka.remote.testconductor
 
BarrierCoordinator.BarrierTimeout(BarrierCoordinator.Data) - Constructor for exception akka.remote.testconductor.BarrierCoordinator.BarrierTimeout
 
BarrierCoordinator.BarrierTimeout$ - Class in akka.remote.testconductor
 
BarrierCoordinator.BarrierTimeout$() - Constructor for class akka.remote.testconductor.BarrierCoordinator.BarrierTimeout$
 
BarrierCoordinator.ClientLost - Exception in akka.remote.testconductor
 
BarrierCoordinator.ClientLost(BarrierCoordinator.Data, RoleName) - Constructor for exception akka.remote.testconductor.BarrierCoordinator.ClientLost
 
BarrierCoordinator.ClientLost$ - Class in akka.remote.testconductor
 
BarrierCoordinator.ClientLost$() - Constructor for class akka.remote.testconductor.BarrierCoordinator.ClientLost$
 
BarrierCoordinator.Data - Class in akka.remote.testconductor
 
BarrierCoordinator.Data(Set<Controller.NodeInfo>, String, List<ActorRef>, Deadline) - Constructor for class akka.remote.testconductor.BarrierCoordinator.Data
 
BarrierCoordinator.Data$ - Class in akka.remote.testconductor
 
BarrierCoordinator.Data$() - Constructor for class akka.remote.testconductor.BarrierCoordinator.Data$
 
BarrierCoordinator.DuplicateNode - Exception in akka.remote.testconductor
 
BarrierCoordinator.DuplicateNode(BarrierCoordinator.Data, Controller.NodeInfo) - Constructor for exception akka.remote.testconductor.BarrierCoordinator.DuplicateNode
 
BarrierCoordinator.DuplicateNode$ - Class in akka.remote.testconductor
 
BarrierCoordinator.DuplicateNode$() - Constructor for class akka.remote.testconductor.BarrierCoordinator.DuplicateNode$
 
BarrierCoordinator.FailedBarrier - Exception in akka.remote.testconductor
 
BarrierCoordinator.FailedBarrier(BarrierCoordinator.Data) - Constructor for exception akka.remote.testconductor.BarrierCoordinator.FailedBarrier
 
BarrierCoordinator.FailedBarrier$ - Class in akka.remote.testconductor
 
BarrierCoordinator.FailedBarrier$() - Constructor for class akka.remote.testconductor.BarrierCoordinator.FailedBarrier$
 
BarrierCoordinator.Idle$ - Class in akka.remote.testconductor
 
BarrierCoordinator.Idle$() - Constructor for class akka.remote.testconductor.BarrierCoordinator.Idle$
 
BarrierCoordinator.Printer - Interface in akka.remote.testconductor
 
BarrierCoordinator.RemoveClient - Class in akka.remote.testconductor
 
BarrierCoordinator.RemoveClient(RoleName) - Constructor for class akka.remote.testconductor.BarrierCoordinator.RemoveClient
 
BarrierCoordinator.RemoveClient$ - Class in akka.remote.testconductor
 
BarrierCoordinator.RemoveClient$() - Constructor for class akka.remote.testconductor.BarrierCoordinator.RemoveClient$
 
BarrierCoordinator.State - Interface in akka.remote.testconductor
 
BarrierCoordinator.Waiting$ - Class in akka.remote.testconductor
 
BarrierCoordinator.Waiting$() - Constructor for class akka.remote.testconductor.BarrierCoordinator.Waiting$
 
BarrierCoordinator.WrongBarrier - Exception in akka.remote.testconductor
 
BarrierCoordinator.WrongBarrier(String, ActorRef, BarrierCoordinator.Data) - Constructor for exception akka.remote.testconductor.BarrierCoordinator.WrongBarrier
 
BarrierCoordinator.WrongBarrier$ - Class in akka.remote.testconductor
 
BarrierCoordinator.WrongBarrier$() - Constructor for class akka.remote.testconductor.BarrierCoordinator.WrongBarrier$
 
BarrierResult - Class in akka.remote.testconductor
 
BarrierResult(String, boolean) - Constructor for class akka.remote.testconductor.BarrierResult
 
BarrierResult$ - Class in akka.remote.testconductor
 
BarrierResult$() - Constructor for class akka.remote.testconductor.BarrierResult$
 
BarrierTimeout() - Method in class akka.remote.testconductor.TestConductorExt.Settings
 
base64(long, StringBuilder) - Method in class akka.util.Helpers$
 
base64(long, StringBuilder) - Static method in class akka.util.Helpers
 
base64chars() - Method in class akka.util.Helpers$
 
base64chars() - Static method in class akka.util.Helpers
 
baseConfig() - Method in class akka.remote.testkit.MultiNodeSpec$
 
baseConfig() - Static method in class akka.remote.testkit.MultiNodeSpec
 
batch() - Method in class akka.persistence.PersistentBatch
 
BATCH_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
 
Batchable - Interface in akka.dispatch
All Batchables are automatically batched when submitted to a BatchingExecutor
batchable(Runnable) - Method in interface akka.dispatch.BatchingExecutor
Override this to define which runnables will be batched.
BatchAcceptLimit() - Method in class akka.io.TcpExt.Settings
 
BatchingExecutor - Interface in akka.dispatch
Mixin trait for an Executor which groups multiple nested Runnable.run() calls into a single Runnable passed to the original Executor.
BatchingExecutor.AbstractBatch - Class in akka.dispatch
 
BatchingExecutor.AbstractBatch() - Constructor for class akka.dispatch.BatchingExecutor.AbstractBatch
 
BatchingExecutor.Batch - Class in akka.dispatch
 
BatchingExecutor.Batch() - Constructor for class akka.dispatch.BatchingExecutor.Batch
 
BatchingExecutor.BlockableBatch - Class in akka.dispatch
 
BatchingExecutor.BlockableBatch() - Constructor for class akka.dispatch.BatchingExecutor.BlockableBatch
 
BatchReceiveLimit() - Method in class akka.io.Udp.UdpSettings
 
batchSize() - Method in class akka.io.Tcp.ResumeAccepting
 
become(PartialFunction<Object, BoxedUnit>, boolean) - Method in class akka.actor.ActorCell
 
become(Procedure<Object>) - Method in class akka.actor.ActorCell
 
become(Procedure<Object>, boolean) - Method in class akka.actor.ActorCell
 
become(PartialFunction<Object, BoxedUnit>) - Method in interface akka.actor.ActorContext
Changes the Actor's behavior to become the new 'Receive' (PartialFunction[Any, Unit]) handler.
become(PartialFunction<Object, BoxedUnit>, boolean) - Method in interface akka.actor.ActorContext
Changes the Actor's behavior to become the new 'Receive' (PartialFunction[Any, Unit]) handler.
become(PartialFunction<Object, BoxedUnit>) - Method in interface akka.actor.dsl.Creators.Act
Replace the behavior at the top of the behavior stack for this actor.
become(Procedure<Object>) - Method in interface akka.actor.UntypedActorContext
Changes the Actor's behavior to become the new 'Procedure' handler.
become(Procedure<Object>, boolean) - Method in interface akka.actor.UntypedActorContext
Changes the Actor's behavior to become the new 'Procedure' handler.
becomeClosed() - Method in class akka.dispatch.Mailbox
set new primary status Closed.
becomeInitialized() - Method in class akka.cluster.ClusterCoreDaemon
 
becomeStacked(PartialFunction<Object, BoxedUnit>) - Method in interface akka.actor.dsl.Creators.Act
Add the given behavior on top of the behavior stack for this actor.
becomeUninitialized() - Method in class akka.cluster.ClusterCoreDaemon
 
becomeWritingOrSendBufferedMessages() - Method in class akka.remote.EndpointWriter
 
before() - Method in interface akka.transactor.Transactor
A Receive block that runs before the coordinated transaction is entered.
before(Object) - Method in class akka.transactor.UntypedTransactor
A Receive block that runs before the coordinated transaction is entered.
beforeAll() - Method in class akka.actor.mailbox.DurableMailboxSpec
 
beforeAll() - Method in interface akka.persistence.PluginSpec
 
beforeAll() - Method in class akka.testkit.AkkaSpec
 
beforeConnect(Socket) - Method in class akka.io.Inet.SO$.ReceiveBufferSize
 
beforeConnect(Socket) - Method in class akka.io.Inet.SO$.ReuseAddress
 
beforeConnect(Socket) - Method in interface akka.io.Inet.SocketOption
Action to be taken for this option before calling connect()
beforeDatagramBind(DatagramSocket) - Method in class akka.io.Inet.SO$.ReceiveBufferSize
 
beforeDatagramBind(DatagramSocket) - Method in class akka.io.Inet.SO$.ReuseAddress
 
beforeDatagramBind(DatagramSocket) - Method in interface akka.io.Inet.SocketOption
 
beforeDatagramBind(DatagramSocket) - Method in class akka.io.Udp.SO$.Broadcast
 
beforeEach() - Method in interface akka.persistence.journal.JournalSpec
 
beforeEach() - Method in interface akka.persistence.PluginSpec
 
beforeEach() - Method in interface akka.persistence.snapshot.SnapshotStoreSpec
 
beforeEach() - Method in class akka.testkit.TestActorRefSpec
 
beforeServerSocketBind(ServerSocket) - Method in class akka.io.Inet.SO$.ReceiveBufferSize
 
beforeServerSocketBind(ServerSocket) - Method in class akka.io.Inet.SO$.ReuseAddress
 
beforeServerSocketBind(ServerSocket) - Method in interface akka.io.Inet.SocketOption
 
beforeTermination() - Method in class akka.testkit.AkkaSpec
 
benchActor(int) - Method in interface akka.persistence.journal.JournalPerfSpec
 
bind(ActorRef, InetSocketAddress, int, Iterable<Inet.SocketOption>, boolean) - Method in class akka.io.TcpMessage$
The Bind message is send to the TCP manager actor, which is obtained via TcpExt.getManager() in order to bind to a listening socket.
bind(ActorRef, InetSocketAddress, int) - Method in class akka.io.TcpMessage$
Open a listening socket without specifying options.
bind(ActorRef, InetSocketAddress, int, Iterable<Inet.SocketOption>, boolean) - Static method in class akka.io.TcpMessage
The Bind message is send to the TCP manager actor, which is obtained via TcpExt.getManager() in order to bind to a listening socket.
bind(ActorRef, InetSocketAddress, int) - Static method in class akka.io.TcpMessage
Open a listening socket without specifying options.
bind(ActorRef, InetSocketAddress, Iterable<Inet.SocketOption>) - Method in class akka.io.UdpMessage$
Send this message to the UdpExt.manager() in order to bind to the given local port (or an automatically assigned one if the port number is zero).
bind(ActorRef, InetSocketAddress) - Method in class akka.io.UdpMessage$
Bind without specifying options.
bind(ActorRef, InetSocketAddress, Iterable<Inet.SocketOption>) - Static method in class akka.io.UdpMessage
Send this message to the UdpExt.manager() in order to bind to the given local port (or an automatically assigned one if the port number is zero).
bind(ActorRef, InetSocketAddress) - Static method in class akka.io.UdpMessage
Bind without specifying options.
Bind - Class in akka.zeromq
Start listening with this server socket on the specified address
Bind(String) - Constructor for class akka.zeromq.Bind
 
Bind$ - Class in akka.zeromq
 
Bind$() - Constructor for class akka.zeromq.Bind$
 
bindings() - Method in class akka.serialization.Serialization
bindings is a Seq of tuple representing the mapping from Class to Serializer.
blackhole(RoleName, RoleName, ThrottlerTransportAdapter.Direction) - Method in interface akka.remote.testconductor.Conductor
Switch the Netty pipeline of the remote support into blackhole mode for sending and/or receiving: it will just drop all messages right before submitting them to the Socket or right after receiving them from the Socket.
blockOn(Function0<T>, CanAwait) - Method in class akka.dispatch.BatchingExecutor.BlockableBatch
 
blockOn(Function0<T>, CanAwait) - Method in class akka.dispatch.MonitorableThreadFactory.AkkaForkJoinWorkerThread
 
body() - Method in class akka.camel.CamelMessage
 
bodyAs(ClassTag<T>, org.apache.camel.CamelContext) - Method in class akka.camel.CamelMessage
Returns the body of the message converted to the type T.
Bootable - Interface in akka.kernel
To use the microkernel at least one 'boot class' needs to be specified.
boss() - Method in class akka.actor.ActorDSL.Extension
 
Both_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.Direction
Both = 3;
bound(ChannelRegistration) - Method in class akka.io.TcpListener
 
boundAddress() - Method in class akka.remote.transport.TestTransport.ListenAttempt
 
boundAddress() - Method in class akka.remote.transport.TestTransport.ShutdownAttempt
 
BoundedBlockingQueue<E> - Class in akka.util
BoundedBlockingQueue wraps any Queue and turns the result into a BlockingQueue with a limited capacity.
BoundedBlockingQueue(int, Queue<E>) - Constructor for class akka.util.BoundedBlockingQueue
 
BoundedDequeBasedMailbox - Class in akka.dispatch
BoundedDequeBasedMailbox is an bounded MailboxType, backed by a Deque.
BoundedDequeBasedMailbox(int, FiniteDuration) - Constructor for class akka.dispatch.BoundedDequeBasedMailbox
 
BoundedDequeBasedMailbox(ActorSystem.Settings, com.typesafe.config.Config) - Constructor for class akka.dispatch.BoundedDequeBasedMailbox
 
BoundedDequeBasedMailbox$ - Class in akka.dispatch
 
BoundedDequeBasedMailbox$() - Constructor for class akka.dispatch.BoundedDequeBasedMailbox$
 
BoundedDequeBasedMailbox.MessageQueue - Class in akka.dispatch
 
BoundedDequeBasedMailbox.MessageQueue(int, FiniteDuration) - Constructor for class akka.dispatch.BoundedDequeBasedMailbox.MessageQueue
 
BoundedDequeBasedMessageQueue - Interface in akka.dispatch
BoundedMessageQueueSemantics adds bounded semantics to a DequeBasedMessageQueue, i.e.
BoundedDequeBasedMessageQueueSemantics - Interface in akka.dispatch
 
BoundedMailbox - Class in akka.dispatch
BoundedMailbox is the default bounded MailboxType used by Akka Actors.
BoundedMailbox(int, FiniteDuration) - Constructor for class akka.dispatch.BoundedMailbox
 
BoundedMailbox(ActorSystem.Settings, com.typesafe.config.Config) - Constructor for class akka.dispatch.BoundedMailbox
 
BoundedMailbox$ - Class in akka.dispatch
 
BoundedMailbox$() - Constructor for class akka.dispatch.BoundedMailbox$
 
BoundedMailbox.MessageQueue - Class in akka.dispatch
 
BoundedMailbox.MessageQueue(int, FiniteDuration) - Constructor for class akka.dispatch.BoundedMailbox.MessageQueue
 
BoundedMessageQueueSemantics - Interface in akka.dispatch
BoundedMessageQueueSemantics adds bounded semantics to a QueueBasedMessageQueue, i.e.
BoundedPriorityMailbox - Class in akka.dispatch
BoundedPriorityMailbox is a bounded mailbox that allows for prioritization of its contents.
BoundedPriorityMailbox(Comparator<Envelope>, int, Duration) - Constructor for class akka.dispatch.BoundedPriorityMailbox
 
BoundedPriorityMailbox$ - Class in akka.dispatch
 
BoundedPriorityMailbox$() - Constructor for class akka.dispatch.BoundedPriorityMailbox$
 
BoundedPriorityMailbox.MessageQueue - Class in akka.dispatch
 
BoundedPriorityMailbox.MessageQueue(int, Comparator<Envelope>, Duration) - Constructor for class akka.dispatch.BoundedPriorityMailbox.MessageQueue
 
BoundedQueueBasedMessageQueue - Interface in akka.dispatch
 
BoxedType - Class in akka.util
 
BoxedType() - Constructor for class akka.util.BoxedType
 
BoxedType$ - Class in akka.util
 
BoxedType$() - Constructor for class akka.util.BoxedType$
 
breaker() - Method in class akka.actor.mailbox.filebased.FileBasedMessageQueue
 
broadcast(boolean) - Method in class akka.io.UdpSO$
Inet.SocketOption to set the SO_BROADCAST option
broadcast(boolean) - Static method in class akka.io.UdpSO
Inet.SocketOption to set the SO_BROADCAST option
Broadcast - Class in akka.routing
Used to broadcast a message to all routees in a router; only the contained message will be forwarded, i.e.
Broadcast(Object) - Constructor for class akka.routing.Broadcast
 
Broadcast$ - Class in akka.routing
 
Broadcast$() - Constructor for class akka.routing.Broadcast$
 
BroadcastGroup - Class in akka.routing
A router group that broadcasts a message to all its routees.
BroadcastGroup(Iterable<String>, String) - Constructor for class akka.routing.BroadcastGroup
 
BroadcastGroup(com.typesafe.config.Config) - Constructor for class akka.routing.BroadcastGroup
 
BroadcastGroup$ - Class in akka.routing
 
BroadcastGroup$() - Constructor for class akka.routing.BroadcastGroup$
 
BroadcastPool - Class in akka.routing
A router pool that broadcasts a message to all its routees.
BroadcastPool(int, Option<Resizer>, SupervisorStrategy, String, boolean) - Constructor for class akka.routing.BroadcastPool
 
BroadcastPool(com.typesafe.config.Config) - Constructor for class akka.routing.BroadcastPool
 
BroadcastPool$ - Class in akka.routing
 
BroadcastPool$() - Constructor for class akka.routing.BroadcastPool$
 
BroadcastRouter - Class in akka.routing
 
BroadcastRouter(int, Iterable<String>, Option<Resizer>, String, SupervisorStrategy) - Constructor for class akka.routing.BroadcastRouter
 
BroadcastRouter(int) - Constructor for class akka.routing.BroadcastRouter
Java API: Constructor that sets nrOfInstances to be created.
BroadcastRouter(Iterable<String>) - Constructor for class akka.routing.BroadcastRouter
Java API: Constructor that sets the routees to be used.
BroadcastRouter(Resizer) - Constructor for class akka.routing.BroadcastRouter
Java API: Constructor that sets the resizer to be used.
BroadcastRouter$ - Class in akka.routing
 
BroadcastRouter$() - Constructor for class akka.routing.BroadcastRouter$
 
BroadcastRoutingLogic - Class in akka.routing
Broadcasts a message to all its routees.
BroadcastRoutingLogic() - Constructor for class akka.routing.BroadcastRoutingLogic
 
BroadcastRoutingLogic$ - Class in akka.routing
 
BroadcastRoutingLogic$() - Constructor for class akka.routing.BroadcastRoutingLogic$
 
BrokenItemException - Exception in akka.actor.mailbox.filebased.filequeue
 
BrokenItemException(long, Throwable) - Constructor for exception akka.actor.mailbox.filebased.filequeue.BrokenItemException
 
BrokenItemException$ - Class in akka.actor.mailbox.filebased.filequeue
 
BrokenItemException$() - Constructor for class akka.actor.mailbox.filebased.filequeue.BrokenItemException$
 
buckets() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Internal$.Delta
 
BUCKETS_FIELD_NUMBER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
 
buf() - Method in class akka.remote.AckedReceiveBuffer
 
buffer(T) - Method in class akka.remote.AckedSendBuffer
Puts a new message in the buffer.
buffer() - Method in class akka.remote.EndpointManager.ResendState
 
buffer() - Method in class akka.remote.EndpointWriter
 
buffering() - Method in class akka.remote.EndpointWriter
 
BufferPool - Interface in akka.io
 
bufferPool() - Method in class akka.io.TcpExt
 
bufferPool() - Method in class akka.io.UdpConnectedExt
 
bufferPool() - Method in class akka.io.UdpExt
INTERNAL API
BufferSize() - Method in class akka.contrib.pattern.ClusterSharding.Settings$
 
build() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
 
build() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty.Builder
 
build() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
 
build() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
 
build() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
 
build() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
 
build() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
 
build() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
 
build() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
 
build() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
 
build() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
 
build() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
 
build() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
 
build() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
 
build() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
 
build() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
 
build() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
 
build() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
 
build() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
 
build() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
 
build() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
 
build() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
 
build() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
 
build() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
 
build() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload.Builder
 
build() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish.Builder
 
build() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
 
build() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
 
build() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
 
build() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
 
build() - Method in class akka.japi.pf.FSMStateFunctionBuilder
Build a PartialFunction from this builder.
build() - Method in class akka.japi.pf.FSMStopBuilder
Build a PartialFunction from this builder.
build() - Method in class akka.japi.pf.FSMTransitionHandlerBuilder
Build a PartialFunction from this builder.
build() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
 
build() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
 
build() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
 
build() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage.Builder
 
build() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
 
build() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
 
build() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
 
build() - Method in class akka.remote.ContainerFormats.Selection.Builder
 
build() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
build() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
build() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
build() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
build() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
build() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
build() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
build() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
build() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
build() - Method in class akka.remote.WireFormats.ActorRefData.Builder
 
build() - Method in class akka.remote.WireFormats.AddressData.Builder
 
build() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
build() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
build() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
build() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
build() - Method in class akka.remote.WireFormats.DeployData.Builder
 
build() - Method in class akka.remote.WireFormats.PropsData.Builder
 
build() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
build() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
buildPartial() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
 
buildPartial() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty.Builder
 
buildPartial() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
 
buildPartial() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
 
buildPartial() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
 
buildPartial() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
 
buildPartial() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
 
buildPartial() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
 
buildPartial() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
 
buildPartial() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
 
buildPartial() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
 
buildPartial() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
 
buildPartial() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
 
buildPartial() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
 
buildPartial() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
 
buildPartial() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
 
buildPartial() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
 
buildPartial() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
 
buildPartial() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
 
buildPartial() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
 
buildPartial() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
 
buildPartial() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
 
buildPartial() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
 
buildPartial() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
 
buildPartial() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload.Builder
 
buildPartial() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish.Builder
 
buildPartial() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
 
buildPartial() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
 
buildPartial() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
 
buildPartial() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
 
buildPartial() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
 
buildPartial() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
 
buildPartial() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
 
buildPartial() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage.Builder
 
buildPartial() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
 
buildPartial() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
 
buildPartial() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
 
buildPartial() - Method in class akka.remote.ContainerFormats.Selection.Builder
 
buildPartial() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
buildPartial() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
buildPartial() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
buildPartial() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
buildPartial() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
buildPartial() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
buildPartial() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
buildPartial() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
buildPartial() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
buildPartial() - Method in class akka.remote.WireFormats.ActorRefData.Builder
 
buildPartial() - Method in class akka.remote.WireFormats.AddressData.Builder
 
buildPartial() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
buildPartial() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
buildPartial() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
buildPartial() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
buildPartial() - Method in class akka.remote.WireFormats.DeployData.Builder
 
buildPartial() - Method in class akka.remote.WireFormats.PropsData.Builder
 
buildPartial() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
buildPartial() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
BundleDelegatingClassLoader - Class in akka.osgi
A bundle delegating ClassLoader implementation - this will try to load classes and resources from the bundle and the bundles transitive dependencies.
BundleDelegatingClassLoader(org.osgi.framework.Bundle, ClassLoader) - Constructor for class akka.osgi.BundleDelegatingClassLoader
 
BundleDelegatingClassLoader$ - Class in akka.osgi
Companion object to create bundle delegating ClassLoader instances
BundleDelegatingClassLoader$() - Constructor for class akka.osgi.BundleDelegatingClassLoader$
 
bus() - Method in class akka.event.BusLogging
 
bus() - Method in class akka.event.Logging.InitializeLogger
 
business() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Internal$.Group
 
business() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Internal$.Topic
 
business() - Method in interface akka.contrib.pattern.DistributedPubSubMediator.Internal$.TopicLike
 
BusLogging - Class in akka.event
LoggingAdapter that publishes Logging.LogEvent to event stream.
BusLogging(LoggingBus, String, Class<?>) - Constructor for class akka.event.BusLogging
 
ByteArraySerializer - Class in akka.serialization
This is a special Serializer that Serializes and deserializes byte arrays only, (just returns the byte array unchanged/uncopied)
ByteArraySerializer() - Constructor for class akka.serialization.ByteArraySerializer
 
ByteIterator - Class in akka.util
An iterator over a ByteString.
ByteIterator() - Constructor for class akka.util.ByteIterator
 
ByteIterator$ - Class in akka.util
 
ByteIterator$() - Constructor for class akka.util.ByteIterator$
 
ByteIterator.ByteArrayIterator - Class in akka.util
 
ByteIterator.ByteArrayIterator$ - Class in akka.util
 
ByteIterator.ByteArrayIterator$() - Constructor for class akka.util.ByteIterator.ByteArrayIterator$
 
ByteIterator.MultiByteArrayIterator - Class in akka.util
 
ByteIterator.MultiByteArrayIterator$ - Class in akka.util
 
ByteIterator.MultiByteArrayIterator$() - Constructor for class akka.util.ByteIterator.MultiByteArrayIterator$
 
bytes() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
bytes() - Method in class akka.remote.transport.AkkaPduCodec.Payload
 
bytesToHuman(long, long) - Method in class akka.actor.mailbox.filebased.filequeue.tools.Util$
 
bytesToHuman(long, long) - Static method in class akka.actor.mailbox.filebased.filequeue.tools.Util
 
ByteString - Class in akka.util
A rope-like immutable data structure containing bytes.
ByteString() - Constructor for class akka.util.ByteString
 
ByteString$ - Class in akka.util
 
ByteString$() - Constructor for class akka.util.ByteString$
 
ByteString.ByteString1 - Class in akka.util
An unfragmented ByteString.
ByteString.ByteString1$ - Class in akka.util
 
ByteString.ByteString1$() - Constructor for class akka.util.ByteString.ByteString1$
 
ByteString.ByteString1C - Class in akka.util
A compact (unsliced) and unfragmented ByteString, implementation of ByteString1C.
ByteString.ByteString1C$ - Class in akka.util
 
ByteString.ByteString1C$() - Constructor for class akka.util.ByteString.ByteString1C$
 
ByteString.ByteStrings - Class in akka.util
A ByteString with 2 or more fragments.
ByteString.ByteStrings$ - Class in akka.util
 
ByteString.ByteStrings$() - Constructor for class akka.util.ByteString.ByteStrings$
 
ByteStringBuilder - Class in akka.util
A mutable builder for efficiently creating a ByteString.
ByteStringBuilder() - Constructor for class akka.util.ByteStringBuilder
 
bytestrings() - Method in class akka.util.ByteString.ByteStrings
 

C

c() - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
 
c() - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
 
cache() - Method in interface akka.event.SubchannelClassification
 
cache() - Method in class akka.testkit.CachingPartialFunction
 
CachingConfig - Class in akka.dispatch
INTERNAL API
CachingConfig(com.typesafe.config.Config) - Constructor for class akka.dispatch.CachingConfig
 
cachingConfig() - Method in class akka.dispatch.Dispatchers
 
CachingConfig$ - Class in akka.dispatch
INTERNAL API
CachingConfig$() - Constructor for class akka.dispatch.CachingConfig$
 
CachingConfig.PathEntry - Interface in akka.dispatch
 
CachingConfig.StringPathEntry - Class in akka.dispatch
 
CachingConfig.StringPathEntry(boolean, boolean, com.typesafe.config.Config, String) - Constructor for class akka.dispatch.CachingConfig.StringPathEntry
 
CachingConfig.StringPathEntry$ - Class in akka.dispatch
 
CachingConfig.StringPathEntry$() - Constructor for class akka.dispatch.CachingConfig.StringPathEntry$
 
CachingConfig.ValuePathEntry - Class in akka.dispatch
 
CachingConfig.ValuePathEntry(boolean, boolean, com.typesafe.config.Config) - Constructor for class akka.dispatch.CachingConfig.ValuePathEntry
 
CachingConfig.ValuePathEntry$ - Class in akka.dispatch
 
CachingConfig.ValuePathEntry$() - Constructor for class akka.dispatch.CachingConfig.ValuePathEntry$
 
CachingPartialFunction<A,B> - Class in akka.testkit
INTERNAL API
CachingPartialFunction() - Constructor for class akka.testkit.CachingPartialFunction
 
callback() - Method in class akka.cluster.InternalClusterAction.AddOnMemberUpListener
 
CallingThreadDispatcher - Class in akka.testkit
Dispatcher which runs invocations on the current thread only.
CallingThreadDispatcher(MessageDispatcherConfigurator) - Constructor for class akka.testkit.CallingThreadDispatcher
 
CallingThreadDispatcher$ - Class in akka.testkit
 
CallingThreadDispatcher$() - Constructor for class akka.testkit.CallingThreadDispatcher$
 
CallingThreadDispatcherConfigurator - Class in akka.testkit
 
CallingThreadDispatcherConfigurator(com.typesafe.config.Config, DispatcherPrerequisites) - Constructor for class akka.testkit.CallingThreadDispatcherConfigurator
 
CallingThreadDispatcherQueues - Class in akka.testkit
 
CallingThreadDispatcherQueues() - Constructor for class akka.testkit.CallingThreadDispatcherQueues
 
CallingThreadDispatcherQueues$ - Class in akka.testkit
 
CallingThreadDispatcherQueues$() - Constructor for class akka.testkit.CallingThreadDispatcherQueues$
 
CallingThreadMailbox - Class in akka.testkit
 
CallingThreadMailbox(Cell, MailboxType) - Constructor for class akka.testkit.CallingThreadMailbox
 
callsLeftInThisPeriod() - Method in class akka.contrib.throttle.TimerBasedThrottler.Data
 
callWithCircuitBreaker(Callable<Future<T>>) - Method in class akka.pattern.CircuitBreaker
Java API for CircuitBreaker.withCircuitBreaker(scala.Function0>)
callWithSyncCircuitBreaker(Callable<T>) - Method in class akka.pattern.CircuitBreaker
Java API for CircuitBreaker.withSyncCircuitBreaker(scala.Function0)
Camel - Interface in akka.camel
Camel trait encapsulates the underlying camel machinery.
camel() - Method in interface akka.camel.CamelSupport
INTERNAL API Returns a Camel trait which provides access to the CamelExtension.
camel() - Method in class akka.camel.internal.component.ActorEndpoint
 
camel() - Method in interface akka.camel.internal.component.ActorEndpointConfig
 
camelContext() - Method in interface akka.camel.CamelSupport
Returns the CamelContext.
CamelExchangeAdapter - Class in akka.camel.internal
INTERNAL API Adapter for converting an org.apache.camel.Exchange to and from CamelMessage and akka.camel.Failure objects.
CamelExchangeAdapter(org.apache.camel.Exchange) - Constructor for class akka.camel.internal.CamelExchangeAdapter
 
CamelExtension - Class in akka.camel
This class can be used to get hold of an instance of the Camel class bound to the actor system.
CamelExtension() - Constructor for class akka.camel.CamelExtension
 
CamelExtension$ - Class in akka.camel
This class can be used to get hold of an instance of the Camel class bound to the actor system.
CamelExtension$() - Constructor for class akka.camel.CamelExtension$
 
CamelMessage - Class in akka.camel
An immutable representation of a Camel message.
CamelMessage(Object, Map<String, Object>) - Constructor for class akka.camel.CamelMessage
 
CamelMessage(Object, Map<String, Object>) - Constructor for class akka.camel.CamelMessage
 
CamelMessage$ - Class in akka.camel
Companion object of CamelMessage class.
CamelMessage$() - Constructor for class akka.camel.CamelMessage$
 
CamelPath - Class in akka.camel.internal.component
Converts ActorRefs and actorPaths to URI's that point to the actor through the Camel Actor Component.
CamelPath() - Constructor for class akka.camel.internal.component.CamelPath
 
CamelPath$ - Class in akka.camel.internal.component
Converts ActorRefs and actorPaths to URI's that point to the actor through the Camel Actor Component.
CamelPath$() - Constructor for class akka.camel.internal.component.CamelPath$
 
CamelSettings - Class in akka.camel
Settings for the Camel Extension param: config the config
CamelSettings(com.typesafe.config.Config, DynamicAccess) - Constructor for class akka.camel.CamelSettings
 
CamelSupervisor - Class in akka.camel.internal
INTERNAL API Top level supervisor for internal Camel actors
CamelSupervisor() - Constructor for class akka.camel.internal.CamelSupervisor
 
CamelSupervisor$ - Class in akka.camel.internal
INTERNAL API Messages for the camel supervisor, registrations and de-registrations.
CamelSupervisor$() - Constructor for class akka.camel.internal.CamelSupervisor$
 
CamelSupervisor.AddWatch - Class in akka.camel.internal
INTERNAL API Adds a watch for the actor
CamelSupervisor.AddWatch(ActorRef) - Constructor for class akka.camel.internal.CamelSupervisor.AddWatch
 
CamelSupervisor.AddWatch$ - Class in akka.camel.internal
 
CamelSupervisor.AddWatch$() - Constructor for class akka.camel.internal.CamelSupervisor.AddWatch$
 
CamelSupervisor.CamelProducerObjects - Class in akka.camel.internal
INTERNAL API Provides a Producer with the required camel objects to function.
CamelSupervisor.CamelProducerObjects(org.apache.camel.Endpoint, org.apache.camel.processor.SendProcessor) - Constructor for class akka.camel.internal.CamelSupervisor.CamelProducerObjects
 
CamelSupervisor.CamelProducerObjects$ - Class in akka.camel.internal
 
CamelSupervisor.CamelProducerObjects$() - Constructor for class akka.camel.internal.CamelSupervisor.CamelProducerObjects$
 
CamelSupervisor.CamelSupervisorMessage - Interface in akka.camel.internal
 
CamelSupervisor.DeRegister - Class in akka.camel.internal
INTERNAL API De-registers a producer or a consumer.
CamelSupervisor.DeRegister(ActorRef) - Constructor for class akka.camel.internal.CamelSupervisor.DeRegister
 
CamelSupervisor.DeRegister$ - Class in akka.camel.internal
 
CamelSupervisor.DeRegister$() - Constructor for class akka.camel.internal.CamelSupervisor.DeRegister$
 
CamelSupervisor.Register - Class in akka.camel.internal
INTERNAL API Registers a consumer or a producer.
CamelSupervisor.Register(ActorRef, String, Option<ConsumerConfig>) - Constructor for class akka.camel.internal.CamelSupervisor.Register
 
CamelSupervisor.Register$ - Class in akka.camel.internal
 
CamelSupervisor.Register$() - Constructor for class akka.camel.internal.CamelSupervisor.Register$
 
CamelSupport - Interface in akka.camel
 
canBeScheduledForExecution(boolean, boolean) - Method in class akka.dispatch.Mailbox
 
canBuildFrom() - Method in class akka.util.ByteString$
 
canBuildFrom() - Static method in class akka.util.ByteString
 
cancel() - Method in interface akka.actor.Cancellable
Cancels this Cancellable and returns true if that was successful.
cancel() - Method in class akka.actor.FSM.Timer
 
cancel() - Method in class akka.actor.LightArrayRevolverScheduler.TaskHolder
 
cancel() - Method in interface akka.testkit.Coroner.WatchHandle
Will try to ensure that the Coroner has finished reporting.
cancel(Object) - Method in class akka.transactor.Coordinated
Cancel this Coordinated transaction.
Cancellable - Interface in akka.actor
Signifies something that can be cancelled There is no strict guarantee that the implementation is thread-safe, but it should be good practice to make it so.
cancelReceiveTimeout() - Method in interface akka.actor.dungeon.ReceiveTimeout
 
cancelTimer(String) - Method in interface akka.actor.FSM
 
cancelTimer() - Method in class akka.contrib.pattern.ClusterSingletonProxy
 
cancelTimer(String) - Method in class akka.testkit.TestFSMRef
Proxy for FSM.cancelTimer(java.lang.String).
canonicalize(Object) - Method in class akka.camel.CamelMessage$
Creates a canonical form of the given message msg.
canonicalize(Object) - Static method in class akka.camel.CamelMessage
Creates a canonical form of the given message msg.
capacity() - Method in interface akka.actor.StashSupport
 
capacity(Set<NodeMetrics>) - Method in class akka.cluster.routing.CapacityMetricsSelector
Remaining capacity for each node.
capacity(Set<NodeMetrics>) - Method in class akka.cluster.routing.CpuMetricsSelector$
 
capacity(Set<NodeMetrics>) - Static method in class akka.cluster.routing.CpuMetricsSelector
 
capacity(Set<NodeMetrics>) - Method in class akka.cluster.routing.HeapMetricsSelector$
 
capacity(Set<NodeMetrics>) - Static method in class akka.cluster.routing.HeapMetricsSelector
 
capacity(Set<NodeMetrics>) - Method in class akka.cluster.routing.MixMetricsSelectorBase
 
capacity(Set<NodeMetrics>) - Method in class akka.cluster.routing.SystemLoadAverageMetricsSelector$
 
capacity(Set<NodeMetrics>) - Static method in class akka.cluster.routing.SystemLoadAverageMetricsSelector
 
capacity() - Method in class akka.dispatch.BoundedDequeBasedMailbox
 
capacity() - Method in class akka.dispatch.BoundedMailbox
 
capacity() - Method in class akka.dispatch.BoundedPriorityMailbox
 
capacity() - Method in class akka.remote.AckedSendBuffer
 
capacity() - Method in class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket
 
capacity(IndexedSeq<Routee>) - Method in class akka.routing.DefaultResizer
Returns the overall desired change in resizer capacity.
CapacityMetricsSelector - Class in akka.cluster.routing
A MetricsSelector producing weights from remaining capacity.
CapacityMetricsSelector() - Constructor for class akka.cluster.routing.CapacityMetricsSelector
 
CaseStatement<F,P,T> - Class in akka.japi.pf
 
CaseStatement(FI.Predicate, FI.Apply<P, T>) - Constructor for class akka.japi.pf.CaseStatement
 
CaseStatement$ - Class in akka.japi.pf
 
CaseStatement$() - Constructor for class akka.japi.pf.CaseStatement$
 
cause() - Method in class akka.actor.dungeon.ChildrenContainer.Recreation
 
cause() - Method in class akka.actor.FSM.Failure
 
cause() - Method in exception akka.actor.mailbox.filebased.filequeue.BrokenItemException
 
cause() - Method in exception akka.actor.PostRestartException
 
cause() - Method in exception akka.actor.PreRestartException
 
cause() - Method in class akka.actor.Status.Failure
 
cause() - Method in class akka.camel.FailureResult
 
cause() - Method in class akka.camel.internal.ActivationProtocol.EndpointFailedToActivate
 
cause() - Method in class akka.camel.internal.ActivationProtocol.EndpointFailedToDeActivate
 
cause() - Method in class akka.dispatch.sysmsg.Failed
 
cause() - Method in class akka.dispatch.sysmsg.Recreate
 
cause() - Method in class akka.event.Logging.Error
 
cause() - Method in class akka.io.Tcp.ErrorClosed
 
cause() - Method in class akka.persistence.journal.AsyncWriteTarget.ReplayFailure
 
cause() - Method in class akka.persistence.JournalProtocol.DeleteMessagesFailure
 
cause() - Method in class akka.persistence.JournalProtocol.ReadHighestSequenceNrFailure
 
cause() - Method in class akka.persistence.JournalProtocol.ReplayMessagesFailure
 
cause() - Method in class akka.persistence.JournalProtocol.WriteConfirmationsFailure
 
cause() - Method in class akka.persistence.JournalProtocol.WriteMessageFailure
 
cause() - Method in class akka.persistence.JournalProtocol.WriteMessagesFailed
 
cause() - Method in class akka.persistence.PersistenceFailure
 
cause() - Method in class akka.persistence.RecoveryFailure
 
cause() - Method in class akka.persistence.SaveSnapshotFailure
 
cause() - Method in class akka.remote.AssociationErrorEvent
 
cause() - Method in class akka.remote.EndpointManager.ListensFailure
 
cause() - Method in exception akka.remote.HopelessAssociation
 
cause() - Method in exception akka.remote.InvalidAssociation
 
cause() - Method in class akka.remote.RemotingErrorEvent
 
cause() - Method in exception akka.remote.ShutDownAssociation
 
cause() - Method in exception akka.remote.transport.Transport.InvalidAssociationException
 
causedByFailure() - Method in class akka.dispatch.sysmsg.Resume
 
Cell - Interface in akka.actor
INTERNAL API
cell() - Method in class akka.routing.RouterActor
 
change() - Method in class akka.routing.AdjustPoolSize
 
changeMembers(SortedSet<Member>) - Method in class akka.contrib.pattern.ShardRegion
 
channel() - Method in class akka.io.TcpConnection
 
channel() - Method in class akka.io.TcpListener
 
channel() - Method in class akka.io.TcpListener.FailedRegisterIncoming
 
channel() - Method in class akka.io.TcpListener.RegisterIncoming
 
channel() - Method in class akka.io.UdpConnection
 
channel() - Method in class akka.io.UdpListener
 
channel() - Method in class akka.io.UdpSender
 
channel() - Method in interface akka.io.WithUdpSend
 
Channel - Class in akka.persistence
A channel is used by Processors (and Views) for sending Persistent messages to destinations.
Channel(Option<String>, ChannelSettings) - Constructor for class akka.persistence.Channel
 
channel() - Method in interface akka.persistence.Delivered
 
channel() - Method in class akka.persistence.DeliveredByChannel
 
channel() - Method in class akka.persistence.DeliveredByPersistentChannel
 
channel() - Method in class akka.remote.testconductor.ClientFSM.Connected
 
channel() - Method in class akka.remote.testconductor.ClientFSM.Data
 
channel() - Method in class akka.remote.testconductor.Controller.CreateServerFSM
 
channel() - Method in class akka.remote.testconductor.ServerFSM
 
Channel$ - Class in akka.persistence
 
Channel$() - Constructor for class akka.persistence.Channel$
 
CHANNEL_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
channelBound(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ChannelStateEvent) - Method in class akka.remote.testconductor.PlayerHandler
 
channelClosed(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ChannelStateEvent) - Method in class akka.remote.testconductor.PlayerHandler
 
channelConnected(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ChannelStateEvent) - Method in class akka.remote.testconductor.ConductorHandler
 
channelConnected(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ChannelStateEvent) - Method in class akka.remote.testconductor.PlayerHandler
 
channelConnected(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ChannelStateEvent) - Method in interface akka.remote.transport.netty.NettyClientHelpers
 
channelConnected(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ChannelStateEvent) - Method in interface akka.remote.transport.netty.NettyServerHelpers
 
channelDisconnected(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ChannelStateEvent) - Method in class akka.remote.testconductor.ConductorHandler
 
channelDisconnected(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ChannelStateEvent) - Method in class akka.remote.testconductor.PlayerHandler
 
channelDisconnected(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ChannelStateEvent) - Method in interface akka.remote.transport.netty.NettyClientHelpers
 
channelDisconnected(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ChannelStateEvent) - Method in interface akka.remote.transport.netty.NettyServerHelpers
 
channelGroup() - Method in class akka.remote.transport.netty.NettyTransport
 
channelId() - Method in interface akka.persistence.Delivered
 
channelId() - Method in class akka.persistence.DeliveredByChannel
 
channelId() - Method in class akka.persistence.DeliveredByPersistentChannel
 
channelId() - Method in class akka.persistence.journal.JournalSpec.Confirmation
 
channelId() - Method in class akka.persistence.journal.leveldb.Key
 
channelId(ActorRef) - Method in class akka.persistence.Persistence
Creates a canonical channel id from a channel actor ref.
channelId() - Method in interface akka.persistence.PersistentConfirmation
 
CHANNELID_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
ChannelLocalActor - Class in akka.remote.transport.netty
INTERNAL API
ChannelLocalActor() - Constructor for class akka.remote.transport.netty.ChannelLocalActor
 
ChannelLocalActor$ - Class in akka.remote.transport.netty
INTERNAL API
ChannelLocalActor$() - Constructor for class akka.remote.transport.netty.ChannelLocalActor$
 
channelOpen(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ChannelStateEvent) - Method in class akka.remote.testconductor.PlayerHandler
 
channelOpen(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ChannelStateEvent) - Method in interface akka.remote.transport.netty.NettyClientHelpers
 
channelOpen(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ChannelStateEvent) - Method in interface akka.remote.transport.netty.NettyServerHelpers
 
ChannelRegistration - Interface in akka.io
Implementations of this interface are sent as actor messages back to a channel actor as a result of it having called register on the ChannelRegistry.
ChannelRegistry - Interface in akka.io
Interface behind which we hide our selector management logic from the connection actors
ChannelSettings - Class in akka.persistence
A Channel configuration object.
ChannelSettings(int, FiniteDuration, Option<ActorRef>) - Constructor for class akka.persistence.ChannelSettings
 
ChannelSettings$ - Class in akka.persistence
 
ChannelSettings$() - Constructor for class akka.persistence.ChannelSettings$
 
channelUnbound(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ChannelStateEvent) - Method in class akka.remote.testconductor.PlayerHandler
 
chaosMode(Address) - Method in class akka.remote.transport.FailureInjectorTransportAdapter
 
check() - Method in class akka.testkit.JavaTestKit.AwaitAssert
 
checkedApply(T) - Method in class akka.dispatch.Mapper
Override this method if you need to throw checked exceptions
checkLastUnwatchOfNode(Address) - Method in class akka.remote.RemoteWatcher
 
checkMissingAndUnexpected(Seq<Object>, Seq<Object>, String, String) - Method in interface akka.testkit.TestKitBase
 
checkName(String) - Method in interface akka.actor.dungeon.Children
 
checkReceiveTimeout() - Method in interface akka.actor.dungeon.ReceiveTimeout
 
checkValid(com.typesafe.config.Config, Seq<String>) - Method in class akka.dispatch.CachingConfig
 
checkValid(com.typesafe.config.Config, String[]) - Method in class akka.dispatch.CachingConfig
 
child(String) - Method in interface akka.actor.ActorContext
Get the child with the given name if it exists.
child(String) - Method in interface akka.actor.ActorPath
Java API: Create a new child actor path.
child(String) - Method in class akka.actor.ActorSystem
Java API: Create a new child actor path.
child() - Method in class akka.actor.ChildRestartStats
 
child(String) - Method in interface akka.actor.dungeon.Children
 
child() - Method in class akka.actor.StopChild
 
child() - Method in class akka.dispatch.sysmsg.Failed
 
child() - Method in class akka.dispatch.sysmsg.Supervise
 
CHILD_NAME_VALUE - Static variable in enum akka.remote.ContainerFormats.PatternType
CHILD_NAME = 1;
CHILD_PATTERN_VALUE - Static variable in enum akka.remote.ContainerFormats.PatternType
CHILD_PATTERN = 2;
ChildActorPath - Class in akka.actor
 
ChildActorPath(ActorPath, String, int) - Constructor for class akka.actor.ChildActorPath
 
ChildActorPath(ActorPath, String) - Constructor for class akka.actor.ChildActorPath
 
ChildNameReserved - Class in akka.actor
INTERNAL API
ChildNameReserved() - Constructor for class akka.actor.ChildNameReserved
 
ChildNameReserved$ - Class in akka.actor
INTERNAL API
ChildNameReserved$() - Constructor for class akka.actor.ChildNameReserved$
 
childProps() - Method in class akka.io.SelectionHandler.WorkerForCommand
 
children() - Method in interface akka.actor.ActorContext
Returns all supervised children; this method returns a view (i.e.
children() - Method in class akka.actor.ActorRefWithCell
 
Children - Interface in akka.actor.dungeon
 
children() - Method in interface akka.actor.dungeon.Children
 
children() - Method in interface akka.actor.dungeon.ChildrenContainer
 
children() - Method in interface akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer
 
children() - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
 
children() - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
 
children() - Method in class akka.actor.LocalActorRef
 
children() - Method in class akka.actor.RepointableActorRef
 
children() - Method in class akka.util.WildcardTree
 
ChildrenContainer - Interface in akka.actor.dungeon
INTERNAL API
ChildrenContainer$ - Class in akka.actor.dungeon
INTERNAL API
ChildrenContainer$() - Constructor for class akka.actor.dungeon.ChildrenContainer$
 
ChildrenContainer.ChildrenIterable - Class in akka.actor.dungeon
 
ChildrenContainer.ChildrenIterable(MapLike<?, ChildStats, ?>) - Constructor for class akka.actor.dungeon.ChildrenContainer.ChildrenIterable
 
ChildrenContainer.ChildRestartsIterable - Class in akka.actor.dungeon
 
ChildrenContainer.ChildRestartsIterable(MapLike<?, ChildStats, ?>) - Constructor for class akka.actor.dungeon.ChildrenContainer.ChildRestartsIterable
 
ChildrenContainer.Creation - Class in akka.actor.dungeon
 
ChildrenContainer.Creation() - Constructor for class akka.actor.dungeon.ChildrenContainer.Creation
 
ChildrenContainer.Creation$ - Class in akka.actor.dungeon
 
ChildrenContainer.Creation$() - Constructor for class akka.actor.dungeon.ChildrenContainer.Creation$
 
ChildrenContainer.EmptyChildrenContainer - Interface in akka.actor.dungeon
 
ChildrenContainer.EmptyChildrenContainer$ - Class in akka.actor.dungeon
This is the empty container, shared among all leaf actors.
ChildrenContainer.EmptyChildrenContainer$() - Constructor for class akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer$
 
ChildrenContainer.NormalChildrenContainer - Class in akka.actor.dungeon
Normal children container: we do have at least one child, but none of our children are currently terminating (which is the time period between calling context.stop(child) and processing the ChildTerminated() system message).
ChildrenContainer.NormalChildrenContainer(TreeMap<String, ChildStats>) - Constructor for class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
 
ChildrenContainer.NormalChildrenContainer$ - Class in akka.actor.dungeon
 
ChildrenContainer.NormalChildrenContainer$() - Constructor for class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer$
 
ChildrenContainer.Recreation - Class in akka.actor.dungeon
 
ChildrenContainer.Recreation(Throwable) - Constructor for class akka.actor.dungeon.ChildrenContainer.Recreation
 
ChildrenContainer.Recreation$ - Class in akka.actor.dungeon
 
ChildrenContainer.Recreation$() - Constructor for class akka.actor.dungeon.ChildrenContainer.Recreation$
 
ChildrenContainer.SuspendReason - Interface in akka.actor.dungeon
 
ChildrenContainer.TerminatedChildrenContainer$ - Class in akka.actor.dungeon
This is the empty container which is installed after the last child has terminated while stopping; it is necessary to distinguish from the normal empty state while calling handleChildTerminated() for the last time.
ChildrenContainer.TerminatedChildrenContainer$() - Constructor for class akka.actor.dungeon.ChildrenContainer.TerminatedChildrenContainer$
 
ChildrenContainer.TerminatingChildrenContainer - Class in akka.actor.dungeon
Waiting state: there are outstanding termination requests (i.e.
ChildrenContainer.TerminatingChildrenContainer(TreeMap<String, ChildStats>, Set<ActorRef>, ChildrenContainer.SuspendReason) - Constructor for class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
 
ChildrenContainer.TerminatingChildrenContainer$ - Class in akka.actor.dungeon
 
ChildrenContainer.TerminatingChildrenContainer$() - Constructor for class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer$
 
ChildrenContainer.Termination$ - Class in akka.actor.dungeon
 
ChildrenContainer.Termination$() - Constructor for class akka.actor.dungeon.ChildrenContainer.Termination$
 
ChildrenContainer.UserRequest$ - Class in akka.actor.dungeon
 
ChildrenContainer.UserRequest$() - Constructor for class akka.actor.dungeon.ChildrenContainer.UserRequest$
 
ChildrenContainer.WaitingForChildren - Interface in akka.actor.dungeon
 
childrenRefs() - Method in interface akka.actor.Cell
All children of this actor, including only reserved-names.
childrenRefs() - Method in interface akka.actor.dungeon.Children
 
childrenRefs() - Method in class akka.actor.UnstartedCell
 
ChildRestartStats - Class in akka.actor
ChildRestartStats is the statistics kept by every parent Actor for every child Actor and is used for SupervisorStrategies to know how to deal with problems that occur for the children.
ChildRestartStats(ActorRef, int, long) - Constructor for class akka.actor.ChildRestartStats
 
ChildRestartStats$ - Class in akka.actor
 
ChildRestartStats$() - Constructor for class akka.actor.ChildRestartStats$
 
ChildStats - Interface in akka.actor
INTERNAL API
CircuitBreaker - Class in akka.pattern
Provides circuit breaker functionality to provide stability when working with "dangerous" operations, e.g.
CircuitBreaker(Scheduler, int, FiniteDuration, FiniteDuration, ExecutionContext) - Constructor for class akka.pattern.CircuitBreaker
 
CircuitBreaker(ExecutionContext, Scheduler, int, FiniteDuration, FiniteDuration) - Constructor for class akka.pattern.CircuitBreaker
 
CircuitBreaker$ - Class in akka.pattern
Companion object providing factory methods for Circuit Breaker which runs callbacks in caller's thread
CircuitBreaker$() - Constructor for class akka.pattern.CircuitBreaker$
 
CircuitBreakerCallTimeout() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
CircuitBreakerMaxFailures() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
CircuitBreakerOpenException - Exception in akka.pattern
Exception thrown when Circuit Breaker is open.
CircuitBreakerOpenException(FiniteDuration, String) - Constructor for exception akka.pattern.CircuitBreakerOpenException
 
CircuitBreakerOpenException$ - Class in akka.pattern
 
CircuitBreakerOpenException$() - Constructor for class akka.pattern.CircuitBreakerOpenException$
 
CircuitBreakerResetTimeout() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
CLASSES_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.PropsData
 
classFor(Logging.LogLevel) - Method in class akka.event.Logging$
Returns the event class associated with the given LogLevel
classFor(Logging.LogLevel) - Static method in class akka.event.Logging
Returns the event class associated with the given LogLevel
classify(ActorClassification) - Method in interface akka.event.ActorClassification
Returns the Classifier associated with the specified Event
classify(Object) - Method in class akka.event.EventStream
 
classify(E) - Method in class akka.event.japi.ActorEventBus
Returns the Classifier associated with the given Event
classify(E) - Method in class akka.event.japi.LookupEventBus
Returns the Classifier associated with the given Event
classify(E) - Method in class akka.event.japi.SubchannelEventBus
Returns the Classifier associated with the given Event
classify(LookupClassification) - Method in interface akka.event.LookupClassification
Returns the Classifier associated with the given Event
classify(SubchannelClassification) - Method in interface akka.event.SubchannelClassification
Returns the Classifier associated with the given Event
classLoader() - Method in class akka.actor.DynamicAccess
This is the class loader to be used in those special cases where the other factory method are not applicable (e.g.
classLoader() - Method in class akka.actor.ReflectiveDynamicAccess
 
ClassLoaderObjectInputStream - Class in akka.util
ClassLoaderObjectInputStream tries to utilize the provided ClassLoader to load Classes and falls back to ObjectInputStreams resolver.
ClassLoaderObjectInputStream(ClassLoader, InputStream) - Constructor for class akka.util.ClassLoaderObjectInputStream
 
classTag(Class<T>) - Method in class akka.japi.Util$
Returns a ClassTag describing the provided Class.
classTag(Class<T>) - Static method in class akka.japi.Util
Returns a ClassTag describing the provided Class.
clazz(Object) - Method in class akka.actor.ActorCell
 
clazz() - Method in class akka.actor.Props
 
CLAZZ_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.PropsData
 
cleanUp(ActorRef, MessageQueue) - Method in class akka.actor.mailbox.filebased.FileBasedMessageQueue
 
cleanUp(ActorRef, MessageQueue) - Method in class akka.contrib.mailbox.PeekMailbox
 
cleanUp() - Method in class akka.dispatch.Mailbox
Overridable callback to clean up the mailbox, called when an actor is unregistered.
cleanUp(ActorRef, MessageQueue) - Method in interface akka.dispatch.MessageQueue
Called when the mailbox this queue belongs to is disposed of.
cleanUp(ActorRef, MessageQueue) - Method in class akka.dispatch.NodeMessageQueue
 
cleanUp(ActorRef, MessageQueue) - Method in interface akka.dispatch.QueueBasedMessageQueue
 
cleanup() - Method in class akka.dispatch.TaskInvocation
 
cleanUp() - Method in class akka.testkit.CallingThreadMailbox
 
cleanupOverdueNotMemberAnyMore() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
 
clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty.Builder
 
clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
 
clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
 
clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
 
clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
 
clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
 
clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
 
clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
 
clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
 
clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
 
clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
 
clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
 
clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
 
clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
 
clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
 
clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
 
clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
 
clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
 
clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
 
clear() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
 
clear() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
 
clear() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
 
clear() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
 
clear() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload.Builder
 
clear() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish.Builder
 
clear() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
 
clear() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
 
clear() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
 
clear() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
 
clear() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
 
clear() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
 
clear() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
 
clear() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage.Builder
 
clear() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
 
clear() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
 
clear() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
 
clear() - Method in class akka.remote.ContainerFormats.Selection.Builder
 
clear() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
clear() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
clear() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
clear() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
clear() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
clear() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
clear() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
clear() - Method in class akka.remote.transport.AssociationRegistry$
 
clear() - Static method in class akka.remote.transport.AssociationRegistry
 
clear() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
clear() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
clear() - Method in class akka.remote.WireFormats.ActorRefData.Builder
 
clear() - Method in class akka.remote.WireFormats.AddressData.Builder
 
clear() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
clear() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
clear() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
clear() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
clear() - Method in class akka.remote.WireFormats.DeployData.Builder
 
clear() - Method in class akka.remote.WireFormats.PropsData.Builder
 
clear() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
clear() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
clear() - Method in class akka.util.BoundedBlockingQueue
 
clear() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
clear() - Method in class akka.util.ByteIterator
 
clear() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
clear() - Method in class akka.util.ByteStringBuilder
 
clear() - Method in class akka.util.Index
Removes all keys and all values
clearAck() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .AcknowledgementInfo ack = 1;
clearActorCellFields(ActorCell) - Method in class akka.actor.ActorCell
 
clearActorFields(Actor, boolean) - Method in class akka.actor.ActorCell
 
clearAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
optional .Address addr = 2;
clearAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .AddressRequest addr = 5;
clearAddress() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
required .Address address = 1;
clearAddress() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
required .Address address = 1;
clearAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
required .Address address = 2;
clearAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
optional .Address address = 3;
clearAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
required int32 addressIndex = 1;
clearAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
required int32 addressIndex = 1;
clearAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
required int32 addressIndex = 1;
clearAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
required int32 addressIndex = 1;
clearAllAddresses() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .UniqueAddress allAddresses = 1;
clearAllAddresses() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .Address allAddresses = 1;
clearAllButSelf() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
required bool allButSelf = 2;
clearAllHashes() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated string allHashes = 3;
clearAllHashes() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
repeated string allHashes = 2;
clearAllMetricNames() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated string allMetricNames = 2;
clearAllRoles() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated string allRoles = 2;
clearAlpha() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
required double alpha = 2;
clearArgs() - Method in class akka.remote.WireFormats.PropsData.Builder
repeated bytes args = 4;
clearBarrier() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .EnterBarrier barrier = 2;
clearBatch() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
repeated .PersistentMessage batch = 1;
clearBuckets() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
repeated .Delta.Bucket buckets = 1;
clearChannel() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
optional string channel = 5;
clearChannelId() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
optional string channelId = 2;
clearClasses() - Method in class akka.remote.WireFormats.PropsData.Builder
repeated string classes = 5;
clearClazz() - Method in class akka.remote.WireFormats.PropsData.Builder
required string clazz = 3;
clearCommandType() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
required .CommandType commandType = 1;
clearConfig() - Method in class akka.remote.WireFormats.DeployData.Builder
optional bytes config = 2;
clearConfirmable() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional bool confirmable = 8;
clearConfirmMessage() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional .DeliveredMessage confirmMessage = 9;
clearConfirms() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
repeated string confirms = 7;
clearConfirmTarget() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string confirmTarget = 10;
clearContent() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
repeated .Delta.Entry content = 3;
clearCookie() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
optional string cookie = 3;
clearCumulativeAck() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
required fixed64 cumulativeAck = 1;
clearCurrentDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
required int64 currentDeliveryId = 1;
clearDeleted() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional bool deleted = 4;
clearDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required int64 deliveryId = 1;
clearDeliverySequenceNr() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
optional int64 deliverySequenceNr = 4;
clearDeploy() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .DeployData deploy = 2;
clearDeploy() - Method in class akka.remote.WireFormats.PropsData.Builder
required .DeployData deploy = 2;
clearDestination() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required string destination = 2;
clearDestination() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage.Builder
optional string destination = 2;
clearDirection() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
optional .Direction direction = 2;
clearDispatcher() - Method in class akka.remote.WireFormats.DeployData.Builder
optional string dispatcher = 5;
clearDone() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional string done = 4;
clearedList() - Method in class akka.util.ByteIterator.MultiByteArrayIterator$
 
clearEnclosedMessage() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload.Builder
required bytes enclosedMessage = 1;
clearEnclosedMessage() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
required bytes enclosedMessage = 1;
clearEnvelope() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .RemoteEnvelope envelope = 2;
clearEwma() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
optional .NodeMetrics.EWMA ewma = 3;
clearExitValue() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
optional int32 exitValue = 7;
clearFailed() - Method in interface akka.actor.dungeon.FaultHandling
 
clearFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
required .FailType failure = 1;
clearFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .InjectFailure failure = 3;
clearFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
required .UniqueAddress from = 1;
clearFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
required .UniqueAddress from = 1;
clearFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
required .Address from = 1;
clearFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
required .UniqueAddress from = 1;
clearGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
required .MetricsGossip gossip = 2;
clearGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
required .Gossip gossip = 2;
clearHandshakeInfo() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
optional .AkkaHandshakeInfo handshakeInfo = 2;
clearHashIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
required int32 hashIndex = 1;
clearHello() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .Hello hello = 1;
clearHost() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
required string host = 3;
clearHostname() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
required string hostname = 2;
clearHostname() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
required string hostname = 2;
clearHostname() - Method in class akka.remote.WireFormats.AddressData.Builder
required string hostname = 2;
clearInstruction() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
optional .AkkaControlMessage instruction = 2;
clearKey() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
required string key = 1;
clearLocalAffinity() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
required bool localAffinity = 2;
clearLog() - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Clears the activity log.
clearMatcher() - Method in class akka.remote.ContainerFormats.Selection.Builder
optional string matcher = 2;
clearMDC() - Method in interface akka.event.DiagnosticLoggingAdapter
Clear all entries in the MDC
clearMembers() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .Member members = 4;
clearMessage() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
required .SerializedMessage message = 2;
clearMessage() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
required bytes message = 1;
clearMessageManifest() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload.Builder
optional bytes messageManifest = 4;
clearMessageManifest() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
optional bytes messageManifest = 4;
clearMessageManifest() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
optional bytes messageManifest = 3;
clearMetrics() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
repeated .NodeMetrics.Metric metrics = 3;
clearNacks() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
repeated fixed64 nacks = 2;
clearName() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
required string name = 1;
clearName() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
required string name = 1;
clearNameIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
required int32 nameIndex = 1;
clearNode() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
required .UniqueAddress node = 1;
clearNode() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
required string node = 1;
clearNodeMetrics() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .NodeMetrics nodeMetrics = 3;
clearNumber() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
required .NodeMetrics.Number number = 2;
clearObserverReachability() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
repeated .ObserverReachability observerReachability = 2;
clearOp() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
required .BarrierOp op = 2;
clearOrigin() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
required .AddressData origin = 1;
clearOverview() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
required .GossipOverview overview = 5;
clearOwner() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
required .Address owner = 1;
clearPath() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
required string path = 1;
clearPath() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
required string path = 1;
clearPath() - Method in class akka.remote.WireFormats.ActorRefData.Builder
required string path = 1;
clearPath() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required string path = 3;
clearPath() - Method in class akka.remote.WireFormats.DeployData.Builder
required string path = 1;
clearPattern() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
repeated .Selection pattern = 3;
clearPayload() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish.Builder
required .Payload payload = 3;
clearPayload() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
required .Payload payload = 3;
clearPayload() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
required .Payload payload = 3;
clearPayload() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required .PersistentPayload payload = 3;
clearPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional .PersistentPayload payload = 1;
clearPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
required bytes payload = 2;
clearPayload() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
optional bytes payload = 1;
clearPayloadManifest() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
optional bytes payloadManifest = 3;
clearPersistenceId() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
optional string persistenceId = 1;
clearPersistenceId() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string persistenceId = 3;
clearPersistent() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage.Builder
optional .PersistentMessage persistent = 1;
clearPersistentSequenceNr() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
optional int64 persistentSequenceNr = 3;
clearPort() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
required uint32 port = 3;
clearPort() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
required uint32 port = 3;
clearPort() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
required int32 port = 4;
clearPort() - Method in class akka.remote.WireFormats.AddressData.Builder
required uint32 port = 3;
clearProps() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .PropsData props = 1;
clearProtocol() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
optional string protocol = 4;
clearProtocol() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
optional string protocol = 4;
clearProtocol() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
required string protocol = 1;
clearProtocol() - Method in class akka.remote.WireFormats.AddressData.Builder
optional string protocol = 4;
clearRateMBit() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
optional float rateMBit = 6;
clearRecipient() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
required .ActorRefData recipient = 1;
clearRedeliveries() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional int32 redeliveries = 6;
clearRef() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
optional string ref = 3;
clearReply() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
required bool reply = 3;
clearRoles() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
repeated string roles = 2;
clearRolesIndexes() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
repeated int32 rolesIndexes = 4 [packed = true];
clearRouterConfig() - Method in class akka.remote.WireFormats.DeployData.Builder
optional bytes routerConfig = 3;
clearScope() - Method in class akka.remote.WireFormats.DeployData.Builder
optional bytes scope = 4;
clearSeen() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
repeated int32 seen = 1;
clearSender() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string sender = 11;
clearSender() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
optional .ActorRefData sender = 4;
clearSeq() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
optional fixed64 seq = 5;
clearSequenceNr() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional int64 sequenceNr = 2;
clearSerialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
optional bytes serialized = 4;
clearSerializedGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
required bytes serializedGossip = 3;
clearSerializerId() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload.Builder
required int32 serializerId = 2;
clearSerializerId() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
required int32 serializerId = 1;
clearSerializerId() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
required int32 serializerId = 2;
clearSerializerId() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
required int32 serializerId = 2;
clearStash() - Method in interface akka.actor.StashSupport
INTERNAL API.
clearState() - Method in class akka.cluster.ClusterDomainEventPublisher
 
clearStatus() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
required .MemberStatus status = 3;
clearStatus() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
required .ReachabilityStatus status = 3;
clearSubjectReachability() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
repeated .SubjectReachability subjectReachability = 2;
clearSupervisor() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .ActorRefData supervisor = 4;
clearSystem() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
required string system = 1;
clearSystem() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
required string system = 1;
clearSystem() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
required string system = 2;
clearSystem() - Method in class akka.remote.WireFormats.AddressData.Builder
required string system = 1;
clearTimeout() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
optional int64 timeout = 3;
clearTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
required int64 timestamp = 2;
clearTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
optional int64 timestamp = 1;
clearTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
required int64 timestamp = 2;
clearTimestamp() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
required int64 timestamp = 2;
clearTo() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
required .UniqueAddress to = 2;
clearTopic() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish.Builder
required string topic = 1;
clearType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
required .NodeMetrics.NumberType type = 1;
clearType() - Method in class akka.remote.ContainerFormats.Selection.Builder
required .PatternType type = 1;
clearUid() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
required uint32 uid = 2;
clearUid() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
required fixed64 uid = 2;
clearUnconfirmedDeliveries() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
clearUpNumber() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
required int32 upNumber = 2;
clearValue() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
required double value = 1;
clearValue32() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
optional uint32 value32 = 2;
clearValue64() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
optional uint64 value64 = 3;
clearVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
required .VectorClock version = 6;
clearVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
required .VectorClock version = 3;
clearVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
required int64 version = 4;
clearVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
required int64 version = 4;
clearVersion() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
required int64 version = 2;
clearVersion() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
required int64 version = 2;
clearVersions() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
repeated .VectorClock.Version versions = 2;
clearVersions() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
repeated .Status.Version versions = 1;
clearWildcardFanOut() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
optional bool wildcardFanOut = 5;
client() - Method in class akka.actor.dsl.Inbox.Get
 
client() - Method in interface akka.actor.dsl.Inbox.Query
 
client() - Method in class akka.actor.dsl.Inbox.Select
 
client() - Method in exception akka.remote.testconductor.BarrierCoordinator.ClientLost
 
client() - Method in exception akka.remote.testconductor.BarrierCoordinator.WrongBarrier
 
Client - Class in akka.remote.testconductor
INTERNAL API.
Client() - Constructor for class akka.remote.testconductor.Client
 
client() - Method in interface akka.remote.testconductor.Player
 
Client$ - Class in akka.remote.testconductor
INTERNAL API.
Client$() - Constructor for class akka.remote.testconductor.Client$
 
ClientFSM - Class in akka.remote.testconductor
This is the controlling entity on the Player side: in a first step it registers itself with a symbolic name and its remote address at the Controller, then waits for the Done message which signals that all other expected test participants have done the same.
ClientFSM(RoleName, InetSocketAddress) - Constructor for class akka.remote.testconductor.ClientFSM
 
ClientFSM$ - Class in akka.remote.testconductor
INTERNAL API.
ClientFSM$() - Constructor for class akka.remote.testconductor.ClientFSM$
 
ClientFSM.AwaitDone$ - Class in akka.remote.testconductor
 
ClientFSM.AwaitDone$() - Constructor for class akka.remote.testconductor.ClientFSM.AwaitDone$
 
ClientFSM.Connected - Class in akka.remote.testconductor
 
ClientFSM.Connected(org.jboss.netty.channel.Channel) - Constructor for class akka.remote.testconductor.ClientFSM.Connected
 
ClientFSM.Connected$ - Class in akka.remote.testconductor
 
ClientFSM.Connected$() - Constructor for class akka.remote.testconductor.ClientFSM.Connected$
 
ClientFSM.Connecting$ - Class in akka.remote.testconductor
 
ClientFSM.Connecting$() - Constructor for class akka.remote.testconductor.ClientFSM.Connecting$
 
ClientFSM.ConnectionFailure - Exception in akka.remote.testconductor
 
ClientFSM.ConnectionFailure(String) - Constructor for exception akka.remote.testconductor.ClientFSM.ConnectionFailure
 
ClientFSM.ConnectionFailure$ - Class in akka.remote.testconductor
 
ClientFSM.ConnectionFailure$() - Constructor for class akka.remote.testconductor.ClientFSM.ConnectionFailure$
 
ClientFSM.Data - Class in akka.remote.testconductor
 
ClientFSM.Data(Option<org.jboss.netty.channel.Channel>, Option<Tuple2<String, ActorRef>>) - Constructor for class akka.remote.testconductor.ClientFSM.Data
 
ClientFSM.Data$ - Class in akka.remote.testconductor
 
ClientFSM.Data$() - Constructor for class akka.remote.testconductor.ClientFSM.Data$
 
ClientFSM.Disconnected$ - Class in akka.remote.testconductor
 
ClientFSM.Disconnected$() - Constructor for class akka.remote.testconductor.ClientFSM.Disconnected$
 
ClientFSM.Failed$ - Class in akka.remote.testconductor
 
ClientFSM.Failed$() - Constructor for class akka.remote.testconductor.ClientFSM.Failed$
 
ClientFSM.State - Interface in akka.remote.testconductor
 
ClientHandler - Class in akka.remote.transport.netty
INTERNAL API
ClientHandler(NettyTransport, Address) - Constructor for class akka.remote.transport.netty.ClientHandler
 
ClientOp - Interface in akka.remote.testconductor
 
clientPredicate() - Method in class akka.actor.dsl.Inbox.InboxActor
 
ClientReconnects() - Method in class akka.remote.testconductor.TestConductorExt.Settings
 
clients() - Method in class akka.actor.dsl.Inbox.InboxActor
 
clients() - Method in class akka.remote.testconductor.BarrierCoordinator.Data
 
clients() - Method in class akka.remote.testconductor.ConductorHandler
 
clientsByTimeout() - Method in class akka.actor.dsl.Inbox.InboxActor
 
ClientSocketWorkerPoolSize() - Method in class akka.remote.testconductor.TestConductorExt.Settings
 
ClientSocketWorkerPoolSize() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
clock() - Method in class akka.actor.LightArrayRevolverScheduler
Clock implementation is replaceable (for testing); the implementation must return a monotonically increasing series of Long nanoseconds.
clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
 
clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty.Builder
 
clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
 
clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
 
clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
 
clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
 
clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
 
clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
 
clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
 
clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
 
clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
 
clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
 
clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
 
clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
 
clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
 
clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
 
clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
 
clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
 
clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
 
clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
 
clone() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
 
clone() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
 
clone() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
 
clone() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
 
clone() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload.Builder
 
clone() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish.Builder
 
clone() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
 
clone() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
 
clone() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
 
clone() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
 
clone() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
 
clone() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
 
clone() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
 
clone() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage.Builder
 
clone() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
 
clone() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
 
clone() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
 
clone() - Method in class akka.remote.ContainerFormats.Selection.Builder
 
clone() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
clone() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
clone() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
clone() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
clone() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
clone() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
clone() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
clone() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
clone() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
clone() - Method in class akka.remote.WireFormats.ActorRefData.Builder
 
clone() - Method in class akka.remote.WireFormats.AddressData.Builder
 
clone() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
clone() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
clone() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
clone() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
clone() - Method in class akka.remote.WireFormats.DeployData.Builder
 
clone() - Method in class akka.remote.WireFormats.PropsData.Builder
 
clone() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
clone() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
clone() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
clone() - Method in class akka.util.ByteIterator
 
clone() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
close() - Method in class akka.actor.LightArrayRevolverScheduler
 
close() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
close() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
Close the queue's journal file.
close() - Method in class akka.cluster.ClusterReadView
Unsubscribe to cluster events.
close() - Method in class akka.cluster.JmxMetricsCollector
 
close() - Method in class akka.cluster.SigarMetricsCollector
Releases any native resources associated with this instance.
close() - Method in class akka.io.TcpMessage$
A normal close operation will first flush pending writes and then close the socket.
close() - Static method in class akka.io.TcpMessage
A normal close operation will first flush pending writes and then close the socket.
Closed() - Method in class akka.dispatch.Mailbox$
 
Closed() - Static method in class akka.dispatch.Mailbox
 
Closed - Class in akka.zeromq
When the ZeroMQ socket disconnects it sends this message to a listener
Closed() - Constructor for class akka.zeromq.Closed
 
closed() - Method in class akka.zeromq.ZeroMQ$
The message that is sent when an ZeroMQ socket disconnects.
closed() - Static method in class akka.zeromq.ZeroMQ
The message that is sent when an ZeroMQ socket disconnects.
Closed$ - Class in akka.zeromq
When the ZeroMQ socket disconnects it sends this message to a listener
Closed$() - Constructor for class akka.zeromq.Closed$
 
closedEvent() - Method in class akka.io.TcpConnection.CloseInformation
 
closedMessage() - Method in class akka.io.TcpConnection
 
closeReason() - Method in class akka.io.TcpConnection
 
closing(TcpConnection.ConnectionInfo, Option<ActorRef>) - Method in class akka.io.TcpConnection
connection is closed on our side and we're waiting from confirmation from the other side
closingWithPendingWrite(TcpConnection.ConnectionInfo, Option<ActorRef>, Tcp.ConnectionClosed) - Method in class akka.io.TcpConnection
connection is closing but a write has to be finished first
cluster() - Method in class akka.cluster.AutoDown
 
Cluster - Class in akka.cluster
This module is responsible cluster membership information.
Cluster(ExtendedActorSystem) - Constructor for class akka.cluster.Cluster
 
cluster() - Method in class akka.cluster.ClusterCoreDaemon
 
cluster() - Method in class akka.cluster.ClusterHeartbeatSender
 
cluster() - Method in class akka.cluster.ClusterMetricsCollector
 
cluster() - Method in class akka.cluster.ClusterRemoteWatcher
 
cluster() - Method in class akka.cluster.FirstSeedNodeProcess
 
cluster() - Method in class akka.cluster.OnMemberUpListener
 
cluster() - Method in class akka.cluster.routing.AdaptiveLoadBalancingMetricsListener
 
cluster() - Method in interface akka.cluster.routing.ClusterRouterActor
 
cluster() - Method in class akka.contrib.pattern.ClusterReceptionist
 
cluster() - Method in class akka.contrib.pattern.ClusterShardingGuardian
 
cluster() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
cluster() - Method in class akka.contrib.pattern.ClusterSingletonProxy
 
cluster() - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
cluster() - Method in class akka.contrib.pattern.ShardRegion
 
Cluster$ - Class in akka.cluster
Cluster Extension Id and factory for creating Cluster extension.
Cluster$() - Constructor for class akka.cluster.Cluster$
 
Cluster.InfoLogger$ - Class in akka.cluster
INTERNAL API
Cluster.InfoLogger$() - Constructor for class akka.cluster.Cluster.InfoLogger$
 
ClusterActorRefProvider - Class in akka.cluster
INTERNAL API
ClusterActorRefProvider(String, ActorSystem.Settings, EventStream, DynamicAccess) - Constructor for class akka.cluster.ClusterActorRefProvider
 
ClusterClient - Class in akka.contrib.pattern
This actor is intended to be used on an external node that is not member of the cluster.
ClusterClient(Set<ActorSelection>, FiniteDuration, FiniteDuration) - Constructor for class akka.contrib.pattern.ClusterClient
 
ClusterClient$ - Class in akka.contrib.pattern
 
ClusterClient$() - Constructor for class akka.contrib.pattern.ClusterClient$
 
ClusterClient.Internal$ - Class in akka.contrib.pattern
INTERNAL API
ClusterClient.Internal$() - Constructor for class akka.contrib.pattern.ClusterClient.Internal$
 
ClusterClient.Internal$.HeartbeatTick - Class in akka.contrib.pattern
 
ClusterClient.Internal$.HeartbeatTick() - Constructor for class akka.contrib.pattern.ClusterClient.Internal$.HeartbeatTick
 
ClusterClient.Internal$.RefreshContactsTick - Class in akka.contrib.pattern
 
ClusterClient.Internal$.RefreshContactsTick() - Constructor for class akka.contrib.pattern.ClusterClient.Internal$.RefreshContactsTick
 
ClusterClient.Publish - Class in akka.contrib.pattern
 
ClusterClient.Publish(String, Object) - Constructor for class akka.contrib.pattern.ClusterClient.Publish
 
ClusterClient.Publish$ - Class in akka.contrib.pattern
 
ClusterClient.Publish$() - Constructor for class akka.contrib.pattern.ClusterClient.Publish$
 
ClusterClient.Send - Class in akka.contrib.pattern
 
ClusterClient.Send(String, Object, boolean) - Constructor for class akka.contrib.pattern.ClusterClient.Send
 
ClusterClient.Send(String, Object) - Constructor for class akka.contrib.pattern.ClusterClient.Send
Convenience constructor with localAffinity false
ClusterClient.Send$ - Class in akka.contrib.pattern
 
ClusterClient.Send$() - Constructor for class akka.contrib.pattern.ClusterClient.Send$
 
ClusterClient.SendToAll - Class in akka.contrib.pattern
 
ClusterClient.SendToAll(String, Object) - Constructor for class akka.contrib.pattern.ClusterClient.SendToAll
 
ClusterClient.SendToAll$ - Class in akka.contrib.pattern
 
ClusterClient.SendToAll$() - Constructor for class akka.contrib.pattern.ClusterClient.SendToAll$
 
clusterCore() - Method in class akka.cluster.Cluster
INTERNAL API
ClusterCoreDaemon - Class in akka.cluster
INTERNAL API.
ClusterCoreDaemon(ActorRef) - Constructor for class akka.cluster.ClusterCoreDaemon
 
ClusterCoreDaemon.Ignored - Class in akka.cluster
 
ClusterCoreDaemon.Ignored() - Constructor for class akka.cluster.ClusterCoreDaemon.Ignored
 
ClusterCoreDaemon.Merge - Class in akka.cluster
 
ClusterCoreDaemon.Merge() - Constructor for class akka.cluster.ClusterCoreDaemon.Merge
 
ClusterCoreDaemon.Newer - Class in akka.cluster
 
ClusterCoreDaemon.Newer() - Constructor for class akka.cluster.ClusterCoreDaemon.Newer
 
ClusterCoreDaemon.Older - Class in akka.cluster
 
ClusterCoreDaemon.Older() - Constructor for class akka.cluster.ClusterCoreDaemon.Older
 
ClusterCoreDaemon.ReceiveGossipType - Interface in akka.cluster
The types of gossip actions that receive gossip has performed.
ClusterCoreDaemon.Same - Class in akka.cluster
 
ClusterCoreDaemon.Same() - Constructor for class akka.cluster.ClusterCoreDaemon.Same
 
ClusterCoreSupervisor - Class in akka.cluster
INTERNAL API.
ClusterCoreSupervisor() - Constructor for class akka.cluster.ClusterCoreSupervisor
 
ClusterDaemon - Class in akka.cluster
INTERNAL API.
ClusterDaemon(ClusterSettings) - Constructor for class akka.cluster.ClusterDaemon
 
ClusterDeployer - Class in akka.cluster
INTERNAL API
ClusterDeployer(ActorSystem.Settings, DynamicAccess) - Constructor for class akka.cluster.ClusterDeployer
 
ClusterDomainEventPublisher - Class in akka.cluster
INTERNAL API.
ClusterDomainEventPublisher() - Constructor for class akka.cluster.ClusterDomainEventPublisher
 
ClusterEvent - Class in akka.cluster
Domain events published to the event bus.
ClusterEvent() - Constructor for class akka.cluster.ClusterEvent
 
ClusterEvent$ - Class in akka.cluster
Domain events published to the event bus.
ClusterEvent$() - Constructor for class akka.cluster.ClusterEvent$
 
ClusterEvent.ClusterDomainEvent - Interface in akka.cluster
Marker interface for cluster domain events.
ClusterEvent.ClusterMetricsChanged - Class in akka.cluster
Current snapshot of cluster node metrics.
ClusterEvent.ClusterMetricsChanged(Set<NodeMetrics>) - Constructor for class akka.cluster.ClusterEvent.ClusterMetricsChanged
 
ClusterEvent.ClusterMetricsChanged$ - Class in akka.cluster
 
ClusterEvent.ClusterMetricsChanged$() - Constructor for class akka.cluster.ClusterEvent.ClusterMetricsChanged$
 
ClusterEvent.ClusterShuttingDown$ - Class in akka.cluster
This event is published when the cluster node is shutting down, before the final ClusterEvent.MemberRemoved events are published.
ClusterEvent.ClusterShuttingDown$() - Constructor for class akka.cluster.ClusterEvent.ClusterShuttingDown$
 
ClusterEvent.CurrentClusterState - Class in akka.cluster
Current snapshot state of the cluster.
ClusterEvent.CurrentClusterState(SortedSet<Member>, Set<Member>, Set<Address>, Option<Address>, Map<String, Option<Address>>) - Constructor for class akka.cluster.ClusterEvent.CurrentClusterState
 
ClusterEvent.CurrentClusterState$ - Class in akka.cluster
 
ClusterEvent.CurrentClusterState$() - Constructor for class akka.cluster.ClusterEvent.CurrentClusterState$
 
ClusterEvent.CurrentInternalStats - Class in akka.cluster
INTERNAL API
ClusterEvent.CurrentInternalStats(GossipStats, VectorClockStats) - Constructor for class akka.cluster.ClusterEvent.CurrentInternalStats
 
ClusterEvent.CurrentInternalStats$ - Class in akka.cluster
 
ClusterEvent.CurrentInternalStats$() - Constructor for class akka.cluster.ClusterEvent.CurrentInternalStats$
 
ClusterEvent.InitialStateAsEvents$ - Class in akka.cluster
When using this subscription mode the events corresponding to the current state will be sent to the subscriber to mimic what you would have seen if you were listening to the events when they occurred in the past.
ClusterEvent.InitialStateAsEvents$() - Constructor for class akka.cluster.ClusterEvent.InitialStateAsEvents$
 
ClusterEvent.InitialStateAsSnapshot$ - Class in akka.cluster
When using this subscription mode a snapshot of ClusterEvent.CurrentClusterState will be sent to the subscriber as the first message.
ClusterEvent.InitialStateAsSnapshot$() - Constructor for class akka.cluster.ClusterEvent.InitialStateAsSnapshot$
 
ClusterEvent.LeaderChanged - Class in akka.cluster
Leader of the cluster members changed.
ClusterEvent.LeaderChanged(Option<Address>) - Constructor for class akka.cluster.ClusterEvent.LeaderChanged
 
ClusterEvent.LeaderChanged$ - Class in akka.cluster
 
ClusterEvent.LeaderChanged$() - Constructor for class akka.cluster.ClusterEvent.LeaderChanged$
 
ClusterEvent.MemberEvent - Interface in akka.cluster
Marker interface for membership events.
ClusterEvent.MemberExited - Class in akka.cluster
Member status changed to MemberStatus.Exiting and will be removed when all members have seen the Exiting status.
ClusterEvent.MemberExited(Member) - Constructor for class akka.cluster.ClusterEvent.MemberExited
 
ClusterEvent.MemberExited$ - Class in akka.cluster
 
ClusterEvent.MemberExited$() - Constructor for class akka.cluster.ClusterEvent.MemberExited$
 
ClusterEvent.MemberRemoved - Class in akka.cluster
Member completely removed from the cluster.
ClusterEvent.MemberRemoved(Member, MemberStatus) - Constructor for class akka.cluster.ClusterEvent.MemberRemoved
 
ClusterEvent.MemberRemoved$ - Class in akka.cluster
 
ClusterEvent.MemberRemoved$() - Constructor for class akka.cluster.ClusterEvent.MemberRemoved$
 
ClusterEvent.MemberUp - Class in akka.cluster
Member status changed to Up.
ClusterEvent.MemberUp(Member) - Constructor for class akka.cluster.ClusterEvent.MemberUp
 
ClusterEvent.MemberUp$ - Class in akka.cluster
 
ClusterEvent.MemberUp$() - Constructor for class akka.cluster.ClusterEvent.MemberUp$
 
ClusterEvent.ReachabilityChanged - Class in akka.cluster
INTERNAL API
ClusterEvent.ReachabilityChanged(Reachability) - Constructor for class akka.cluster.ClusterEvent.ReachabilityChanged
 
ClusterEvent.ReachabilityChanged$ - Class in akka.cluster
 
ClusterEvent.ReachabilityChanged$() - Constructor for class akka.cluster.ClusterEvent.ReachabilityChanged$
 
ClusterEvent.ReachabilityEvent - Interface in akka.cluster
Marker interface to facilitate subscription of both ClusterEvent.UnreachableMember and ClusterEvent.ReachableMember.
ClusterEvent.ReachableMember - Class in akka.cluster
A member is considered as reachable by the failure detector after having been unreachable.
ClusterEvent.ReachableMember(Member) - Constructor for class akka.cluster.ClusterEvent.ReachableMember
 
ClusterEvent.ReachableMember$ - Class in akka.cluster
 
ClusterEvent.ReachableMember$() - Constructor for class akka.cluster.ClusterEvent.ReachableMember$
 
ClusterEvent.RoleLeaderChanged - Class in akka.cluster
First member (leader) of the members within a role set changed.
ClusterEvent.RoleLeaderChanged(String, Option<Address>) - Constructor for class akka.cluster.ClusterEvent.RoleLeaderChanged
 
ClusterEvent.RoleLeaderChanged$ - Class in akka.cluster
 
ClusterEvent.RoleLeaderChanged$() - Constructor for class akka.cluster.ClusterEvent.RoleLeaderChanged$
 
ClusterEvent.SeenChanged - Class in akka.cluster
INTERNAL API The nodes that have seen current version of the Gossip.
ClusterEvent.SeenChanged(boolean, Set<Address>) - Constructor for class akka.cluster.ClusterEvent.SeenChanged
 
ClusterEvent.SeenChanged$ - Class in akka.cluster
 
ClusterEvent.SeenChanged$() - Constructor for class akka.cluster.ClusterEvent.SeenChanged$
 
ClusterEvent.SubscriptionInitialStateMode - Class in akka.cluster
 
ClusterEvent.SubscriptionInitialStateMode() - Constructor for class akka.cluster.ClusterEvent.SubscriptionInitialStateMode
 
ClusterEvent.UnreachableMember - Class in akka.cluster
A member is considered as unreachable by the failure detector.
ClusterEvent.UnreachableMember(Member) - Constructor for class akka.cluster.ClusterEvent.UnreachableMember
 
ClusterEvent.UnreachableMember$ - Class in akka.cluster
 
ClusterEvent.UnreachableMember$() - Constructor for class akka.cluster.ClusterEvent.UnreachableMember$
 
ClusterHeartbeatReceiver - Class in akka.cluster
INTERNAL API.
ClusterHeartbeatReceiver() - Constructor for class akka.cluster.ClusterHeartbeatReceiver
 
ClusterHeartbeatSender - Class in akka.cluster
 
ClusterHeartbeatSender() - Constructor for class akka.cluster.ClusterHeartbeatSender
 
ClusterHeartbeatSender$ - Class in akka.cluster
INTERNAL API
ClusterHeartbeatSender$() - Constructor for class akka.cluster.ClusterHeartbeatSender$
 
ClusterHeartbeatSender.ExpectedFirstHeartbeat - Class in akka.cluster
 
ClusterHeartbeatSender.ExpectedFirstHeartbeat(UniqueAddress) - Constructor for class akka.cluster.ClusterHeartbeatSender.ExpectedFirstHeartbeat
 
ClusterHeartbeatSender.ExpectedFirstHeartbeat$ - Class in akka.cluster
 
ClusterHeartbeatSender.ExpectedFirstHeartbeat$() - Constructor for class akka.cluster.ClusterHeartbeatSender.ExpectedFirstHeartbeat$
 
ClusterHeartbeatSender.Heartbeat - Class in akka.cluster
Sent at regular intervals for failure detection.
ClusterHeartbeatSender.Heartbeat(Address) - Constructor for class akka.cluster.ClusterHeartbeatSender.Heartbeat
 
ClusterHeartbeatSender.Heartbeat$ - Class in akka.cluster
 
ClusterHeartbeatSender.Heartbeat$() - Constructor for class akka.cluster.ClusterHeartbeatSender.Heartbeat$
 
ClusterHeartbeatSender.HeartbeatRsp - Class in akka.cluster
Sent as reply to ClusterHeartbeatSender.Heartbeat messages.
ClusterHeartbeatSender.HeartbeatRsp(UniqueAddress) - Constructor for class akka.cluster.ClusterHeartbeatSender.HeartbeatRsp
 
ClusterHeartbeatSender.HeartbeatRsp$ - Class in akka.cluster
 
ClusterHeartbeatSender.HeartbeatRsp$() - Constructor for class akka.cluster.ClusterHeartbeatSender.HeartbeatRsp$
 
ClusterHeartbeatSender.HeartbeatTick$ - Class in akka.cluster
 
ClusterHeartbeatSender.HeartbeatTick$() - Constructor for class akka.cluster.ClusterHeartbeatSender.HeartbeatTick$
 
ClusterHeartbeatSenderState - Class in akka.cluster
INTERNAL API State of ClusterHeartbeatSender.
ClusterHeartbeatSenderState(HeartbeatNodeRing, Set<UniqueAddress>, FailureDetectorRegistry<Address>) - Constructor for class akka.cluster.ClusterHeartbeatSenderState
 
ClusterHeartbeatSenderState$ - Class in akka.cluster
 
ClusterHeartbeatSenderState$() - Constructor for class akka.cluster.ClusterHeartbeatSenderState$
 
ClusterJmx - Class in akka.cluster
INTERNAL API
ClusterJmx(Cluster, LoggingAdapter) - Constructor for class akka.cluster.ClusterJmx
 
ClusterMessage - Interface in akka.cluster
Base trait for all cluster messages.
ClusterMessages - Class in akka.cluster.protobuf.msg
 
ClusterMessages.Address - Class in akka.cluster.protobuf.msg
Protobuf type Address
ClusterMessages.Address.Builder - Class in akka.cluster.protobuf.msg
Protobuf type Address
ClusterMessages.AddressOrBuilder - Interface in akka.cluster.protobuf.msg
 
ClusterMessages.Empty - Class in akka.cluster.protobuf.msg
Protobuf type Empty
ClusterMessages.Empty.Builder - Class in akka.cluster.protobuf.msg
Protobuf type Empty
ClusterMessages.EmptyOrBuilder - Interface in akka.cluster.protobuf.msg
 
ClusterMessages.Gossip - Class in akka.cluster.protobuf.msg
Protobuf type Gossip
ClusterMessages.Gossip.Builder - Class in akka.cluster.protobuf.msg
Protobuf type Gossip
ClusterMessages.GossipEnvelope - Class in akka.cluster.protobuf.msg
Protobuf type GossipEnvelope
ClusterMessages.GossipEnvelope.Builder - Class in akka.cluster.protobuf.msg
Protobuf type GossipEnvelope
ClusterMessages.GossipEnvelopeOrBuilder - Interface in akka.cluster.protobuf.msg
 
ClusterMessages.GossipOrBuilder - Interface in akka.cluster.protobuf.msg
 
ClusterMessages.GossipOverview - Class in akka.cluster.protobuf.msg
Protobuf type GossipOverview
ClusterMessages.GossipOverview.Builder - Class in akka.cluster.protobuf.msg
Protobuf type GossipOverview
ClusterMessages.GossipOverviewOrBuilder - Interface in akka.cluster.protobuf.msg
 
ClusterMessages.GossipStatus - Class in akka.cluster.protobuf.msg
Protobuf type GossipStatus
ClusterMessages.GossipStatus.Builder - Class in akka.cluster.protobuf.msg
Protobuf type GossipStatus
ClusterMessages.GossipStatusOrBuilder - Interface in akka.cluster.protobuf.msg
 
ClusterMessages.Join - Class in akka.cluster.protobuf.msg
Protobuf type Join
ClusterMessages.Join.Builder - Class in akka.cluster.protobuf.msg
Protobuf type Join
ClusterMessages.JoinOrBuilder - Interface in akka.cluster.protobuf.msg
 
ClusterMessages.Member - Class in akka.cluster.protobuf.msg
Protobuf type Member
ClusterMessages.Member.Builder - Class in akka.cluster.protobuf.msg
Protobuf type Member
ClusterMessages.MemberOrBuilder - Interface in akka.cluster.protobuf.msg
 
ClusterMessages.MemberStatus - Enum in akka.cluster.protobuf.msg
Protobuf enum MemberStatus
ClusterMessages.MetricsGossip - Class in akka.cluster.protobuf.msg
Protobuf type MetricsGossip
ClusterMessages.MetricsGossip.Builder - Class in akka.cluster.protobuf.msg
Protobuf type MetricsGossip
ClusterMessages.MetricsGossipEnvelope - Class in akka.cluster.protobuf.msg
Protobuf type MetricsGossipEnvelope
ClusterMessages.MetricsGossipEnvelope.Builder - Class in akka.cluster.protobuf.msg
Protobuf type MetricsGossipEnvelope
ClusterMessages.MetricsGossipEnvelopeOrBuilder - Interface in akka.cluster.protobuf.msg
 
ClusterMessages.MetricsGossipOrBuilder - Interface in akka.cluster.protobuf.msg
 
ClusterMessages.NodeMetrics - Class in akka.cluster.protobuf.msg
Protobuf type NodeMetrics
ClusterMessages.NodeMetrics.Builder - Class in akka.cluster.protobuf.msg
Protobuf type NodeMetrics
ClusterMessages.NodeMetrics.EWMA - Class in akka.cluster.protobuf.msg
Protobuf type NodeMetrics.EWMA
ClusterMessages.NodeMetrics.EWMA.Builder - Class in akka.cluster.protobuf.msg
Protobuf type NodeMetrics.EWMA
ClusterMessages.NodeMetrics.EWMAOrBuilder - Interface in akka.cluster.protobuf.msg
 
ClusterMessages.NodeMetrics.Metric - Class in akka.cluster.protobuf.msg
Protobuf type NodeMetrics.Metric
ClusterMessages.NodeMetrics.Metric.Builder - Class in akka.cluster.protobuf.msg
Protobuf type NodeMetrics.Metric
ClusterMessages.NodeMetrics.MetricOrBuilder - Interface in akka.cluster.protobuf.msg
 
ClusterMessages.NodeMetrics.Number - Class in akka.cluster.protobuf.msg
Protobuf type NodeMetrics.Number
ClusterMessages.NodeMetrics.Number.Builder - Class in akka.cluster.protobuf.msg
Protobuf type NodeMetrics.Number
ClusterMessages.NodeMetrics.NumberOrBuilder - Interface in akka.cluster.protobuf.msg
 
ClusterMessages.NodeMetrics.NumberType - Enum in akka.cluster.protobuf.msg
Protobuf enum NodeMetrics.NumberType
ClusterMessages.NodeMetricsOrBuilder - Interface in akka.cluster.protobuf.msg
 
ClusterMessages.ObserverReachability - Class in akka.cluster.protobuf.msg
Protobuf type ObserverReachability
ClusterMessages.ObserverReachability.Builder - Class in akka.cluster.protobuf.msg
Protobuf type ObserverReachability
ClusterMessages.ObserverReachabilityOrBuilder - Interface in akka.cluster.protobuf.msg
 
ClusterMessages.ReachabilityStatus - Enum in akka.cluster.protobuf.msg
Protobuf enum ReachabilityStatus
ClusterMessages.SubjectReachability - Class in akka.cluster.protobuf.msg
Protobuf type SubjectReachability
ClusterMessages.SubjectReachability.Builder - Class in akka.cluster.protobuf.msg
Protobuf type SubjectReachability
ClusterMessages.SubjectReachabilityOrBuilder - Interface in akka.cluster.protobuf.msg
 
ClusterMessages.UniqueAddress - Class in akka.cluster.protobuf.msg
Protobuf type UniqueAddress
ClusterMessages.UniqueAddress.Builder - Class in akka.cluster.protobuf.msg
Protobuf type UniqueAddress
ClusterMessages.UniqueAddressOrBuilder - Interface in akka.cluster.protobuf.msg
 
ClusterMessages.VectorClock - Class in akka.cluster.protobuf.msg
Protobuf type VectorClock
ClusterMessages.VectorClock.Builder - Class in akka.cluster.protobuf.msg
Protobuf type VectorClock
ClusterMessages.VectorClock.Version - Class in akka.cluster.protobuf.msg
Protobuf type VectorClock.Version
ClusterMessages.VectorClock.Version.Builder - Class in akka.cluster.protobuf.msg
Protobuf type VectorClock.Version
ClusterMessages.VectorClock.VersionOrBuilder - Interface in akka.cluster.protobuf.msg
 
ClusterMessages.VectorClockOrBuilder - Interface in akka.cluster.protobuf.msg
 
ClusterMessages.Welcome - Class in akka.cluster.protobuf.msg
Protobuf type Welcome
ClusterMessages.Welcome.Builder - Class in akka.cluster.protobuf.msg
Protobuf type Welcome
ClusterMessages.WelcomeOrBuilder - Interface in akka.cluster.protobuf.msg
 
ClusterMessageSerializer - Class in akka.cluster.protobuf
Protobuf serializer of cluster messages.
ClusterMessageSerializer(ExtendedActorSystem) - Constructor for class akka.cluster.protobuf.ClusterMessageSerializer
 
clusterMetrics() - Method in class akka.cluster.ClusterReadView
Current cluster metrics.
ClusterMetricsCollector - Class in akka.cluster
INTERNAL API.
ClusterMetricsCollector(ActorRef) - Constructor for class akka.cluster.ClusterMetricsCollector
 
ClusterNodeMBean - Interface in akka.cluster
Interface for the cluster JMX MBean.
clusterNodes() - Method in class akka.cluster.ClusterRemoteWatcher
 
ClusterReadView - Class in akka.cluster
INTERNAL API
ClusterReadView(Cluster) - Constructor for class akka.cluster.ClusterReadView
 
clusterReceive() - Method in interface akka.cluster.routing.ClusterRouterActor
 
ClusterReceptionist - Class in akka.contrib.pattern
ClusterClient connects to this actor to retrieve.
ClusterReceptionist(ActorRef, Option<String>, int, FiniteDuration) - Constructor for class akka.contrib.pattern.ClusterReceptionist
 
ClusterReceptionist$ - Class in akka.contrib.pattern
 
ClusterReceptionist$() - Constructor for class akka.contrib.pattern.ClusterReceptionist$
 
ClusterReceptionist.Internal$ - Class in akka.contrib.pattern
INTERNAL API
ClusterReceptionist.Internal$() - Constructor for class akka.contrib.pattern.ClusterReceptionist.Internal$
 
ClusterReceptionist.Internal$.ClientResponseTunnel - Class in akka.contrib.pattern
Replies are tunneled via this actor, child of the receptionist, to avoid inbound connections from other cluster nodes to the client.
ClusterReceptionist.Internal$.ClientResponseTunnel(ActorRef, FiniteDuration) - Constructor for class akka.contrib.pattern.ClusterReceptionist.Internal$.ClientResponseTunnel
 
ClusterReceptionist.Internal$.Contacts - Class in akka.contrib.pattern
 
ClusterReceptionist.Internal$.Contacts(IndexedSeq<ActorSelection>) - Constructor for class akka.contrib.pattern.ClusterReceptionist.Internal$.Contacts
 
ClusterReceptionist.Internal$.GetContacts - Class in akka.contrib.pattern
 
ClusterReceptionist.Internal$.GetContacts() - Constructor for class akka.contrib.pattern.ClusterReceptionist.Internal$.GetContacts
 
ClusterReceptionist.Internal$.Ping - Class in akka.contrib.pattern
 
ClusterReceptionist.Internal$.Ping() - Constructor for class akka.contrib.pattern.ClusterReceptionist.Internal$.Ping
 
ClusterReceptionistExtension - Class in akka.contrib.pattern
 
ClusterReceptionistExtension(ExtendedActorSystem) - Constructor for class akka.contrib.pattern.ClusterReceptionistExtension
 
ClusterReceptionistExtension$ - Class in akka.contrib.pattern
Extension that starts ClusterReceptionist and accompanying DistributedPubSubMediator with settings defined in config section akka.contrib.cluster.receptionist.
ClusterReceptionistExtension$() - Constructor for class akka.contrib.pattern.ClusterReceptionistExtension$
 
ClusterRemoteWatcher - Class in akka.cluster
INTERNAL API
ClusterRemoteWatcher(FailureDetectorRegistry<Address>, FiniteDuration, FiniteDuration, FiniteDuration) - Constructor for class akka.cluster.ClusterRemoteWatcher
 
ClusterRemoteWatcher$ - Class in akka.cluster
INTERNAL API
ClusterRemoteWatcher$() - Constructor for class akka.cluster.ClusterRemoteWatcher$
 
ClusterRouterActor - Interface in akka.cluster.routing
INTERNAL API The router actor, subscribes to cluster events and adjusts the routees.
ClusterRouterConfig - Class in akka.cluster.routing
 
ClusterRouterConfig(DeprecatedRouterConfig, ClusterRouterSettings) - Constructor for class akka.cluster.routing.ClusterRouterConfig
 
ClusterRouterConfig$ - Class in akka.cluster.routing
 
ClusterRouterConfig$() - Constructor for class akka.cluster.routing.ClusterRouterConfig$
 
ClusterRouterConfigBase - Interface in akka.cluster.routing
INTERNAL API
ClusterRouterGroup - Class in akka.cluster.routing
RouterConfig implementation for deployment on cluster nodes.
ClusterRouterGroup(Group, ClusterRouterGroupSettings) - Constructor for class akka.cluster.routing.ClusterRouterGroup
 
ClusterRouterGroup$ - Class in akka.cluster.routing
 
ClusterRouterGroup$() - Constructor for class akka.cluster.routing.ClusterRouterGroup$
 
ClusterRouterGroupActor - Class in akka.cluster.routing
INTERNAL API
ClusterRouterGroupActor(ClusterRouterGroupSettings) - Constructor for class akka.cluster.routing.ClusterRouterGroupActor
 
ClusterRouterGroupSettings - Class in akka.cluster.routing
 
ClusterRouterGroupSettings(int, Seq<String>, boolean, Option<String>) - Constructor for class akka.cluster.routing.ClusterRouterGroupSettings
 
ClusterRouterGroupSettings(int, String, boolean, Option<String>) - Constructor for class akka.cluster.routing.ClusterRouterGroupSettings
 
ClusterRouterGroupSettings(int, Iterable<String>, boolean, String) - Constructor for class akka.cluster.routing.ClusterRouterGroupSettings
Java API
ClusterRouterGroupSettings(int, String, boolean, String) - Constructor for class akka.cluster.routing.ClusterRouterGroupSettings
Java API
ClusterRouterGroupSettings$ - Class in akka.cluster.routing
 
ClusterRouterGroupSettings$() - Constructor for class akka.cluster.routing.ClusterRouterGroupSettings$
 
ClusterRouterPool - Class in akka.cluster.routing
RouterConfig implementation for deployment on cluster nodes.
ClusterRouterPool(Pool, ClusterRouterPoolSettings) - Constructor for class akka.cluster.routing.ClusterRouterPool
 
ClusterRouterPool$ - Class in akka.cluster.routing
 
ClusterRouterPool$() - Constructor for class akka.cluster.routing.ClusterRouterPool$
 
ClusterRouterPoolActor - Class in akka.cluster.routing
INTERNAL API
ClusterRouterPoolActor(SupervisorStrategy, ClusterRouterPoolSettings) - Constructor for class akka.cluster.routing.ClusterRouterPoolActor
 
ClusterRouterPoolSettings - Class in akka.cluster.routing
 
ClusterRouterPoolSettings(int, int, boolean, Option<String>) - Constructor for class akka.cluster.routing.ClusterRouterPoolSettings
 
ClusterRouterPoolSettings(int, int, boolean, String) - Constructor for class akka.cluster.routing.ClusterRouterPoolSettings
Java API
ClusterRouterPoolSettings$ - Class in akka.cluster.routing
 
ClusterRouterPoolSettings$() - Constructor for class akka.cluster.routing.ClusterRouterPoolSettings$
 
ClusterRouterSettings - Class in akka.cluster.routing
 
ClusterRouterSettings(int, int, String, boolean, Option<String>) - Constructor for class akka.cluster.routing.ClusterRouterSettings
 
ClusterRouterSettings(int, int, boolean, String) - Constructor for class akka.cluster.routing.ClusterRouterSettings
Java API: Settings for create and deploy of the routees
ClusterRouterSettings(int, String, boolean, String) - Constructor for class akka.cluster.routing.ClusterRouterSettings
Java API: Settings for lookup of the routees
ClusterRouterSettings$ - Class in akka.cluster.routing
 
ClusterRouterSettings$() - Constructor for class akka.cluster.routing.ClusterRouterSettings$
 
ClusterRouterSettingsBase - Interface in akka.cluster.routing
INTERNAL API
ClusterRouterSettingsBase$ - Class in akka.cluster.routing
INTERNAL API
ClusterRouterSettingsBase$() - Constructor for class akka.cluster.routing.ClusterRouterSettingsBase$
 
ClusterScope - Class in akka.cluster
 
ClusterScope() - Constructor for class akka.cluster.ClusterScope
 
ClusterScope$ - Class in akka.cluster
Cluster aware scope of a Deploy
ClusterScope$() - Constructor for class akka.cluster.ClusterScope$
 
ClusterSettings - Class in akka.cluster
 
ClusterSettings(com.typesafe.config.Config, String) - Constructor for class akka.cluster.ClusterSettings
 
ClusterSharding - Class in akka.contrib.pattern
 
ClusterSharding(ExtendedActorSystem) - Constructor for class akka.contrib.pattern.ClusterSharding
 
ClusterSharding$ - Class in akka.contrib.pattern
This extension provides sharding functionality of actors in a cluster.
ClusterSharding$() - Constructor for class akka.contrib.pattern.ClusterSharding$
 
ClusterSharding.Settings$ - Class in akka.contrib.pattern
INTERNAL API
ClusterSharding.Settings$() - Constructor for class akka.contrib.pattern.ClusterSharding.Settings$
 
ClusterShardingGuardian - Class in akka.contrib.pattern
INTERNAL API.
ClusterShardingGuardian() - Constructor for class akka.contrib.pattern.ClusterShardingGuardian
 
ClusterShardingGuardian$ - Class in akka.contrib.pattern
INTERNAL API.
ClusterShardingGuardian$() - Constructor for class akka.contrib.pattern.ClusterShardingGuardian$
 
ClusterShardingGuardian.Start - Class in akka.contrib.pattern
 
ClusterShardingGuardian.Start(String, Option<Props>, PartialFunction<Object, Tuple2<String, Object>>, Function1<Object, String>, ShardCoordinator.ShardAllocationStrategy) - Constructor for class akka.contrib.pattern.ClusterShardingGuardian.Start
 
ClusterShardingGuardian.Start$ - Class in akka.contrib.pattern
 
ClusterShardingGuardian.Start$() - Constructor for class akka.contrib.pattern.ClusterShardingGuardian.Start$
 
ClusterShardingGuardian.Started - Class in akka.contrib.pattern
 
ClusterShardingGuardian.Started(ActorRef) - Constructor for class akka.contrib.pattern.ClusterShardingGuardian.Started
 
ClusterShardingGuardian.Started$ - Class in akka.contrib.pattern
 
ClusterShardingGuardian.Started$() - Constructor for class akka.contrib.pattern.ClusterShardingGuardian.Started$
 
ClusterSingletonManager - Class in akka.contrib.pattern
Manages singleton actor instance among all cluster nodes or a group of nodes tagged with a specific role.
ClusterSingletonManager(Props, String, Object, Option<String>, int, int, FiniteDuration) - Constructor for class akka.contrib.pattern.ClusterSingletonManager
 
ClusterSingletonManager$ - Class in akka.contrib.pattern
 
ClusterSingletonManager$() - Constructor for class akka.contrib.pattern.ClusterSingletonManager$
 
ClusterSingletonManager.Data - Interface in akka.contrib.pattern
INTERNAL API public due to the with FSM type parameters
ClusterSingletonManager.State - Interface in akka.contrib.pattern
INTERNAL API public due to the with FSM type parameters
ClusterSingletonManagerIsStuck - Exception in akka.contrib.pattern
Thrown when a consistent state can't be determined within the defined retry limits.
ClusterSingletonManagerIsStuck(String) - Constructor for exception akka.contrib.pattern.ClusterSingletonManagerIsStuck
 
ClusterSingletonProxy - Class in akka.contrib.pattern
The ClusterSingletonProxy works together with the ClusterSingletonManager to provide a distributed proxy to the singleton actor.
ClusterSingletonProxy(String, Option<String>, FiniteDuration) - Constructor for class akka.contrib.pattern.ClusterSingletonProxy
 
ClusterSingletonProxy$ - Class in akka.contrib.pattern
 
ClusterSingletonProxy$() - Constructor for class akka.contrib.pattern.ClusterSingletonProxy$
 
ClusterUserAction - Class in akka.cluster
INTERNAL API Cluster commands sent by the USER via Cluster extension or JMX.
ClusterUserAction() - Constructor for class akka.cluster.ClusterUserAction
 
ClusterUserAction$ - Class in akka.cluster
INTERNAL API Cluster commands sent by the USER via Cluster extension or JMX.
ClusterUserAction$() - Constructor for class akka.cluster.ClusterUserAction$
 
ClusterUserAction.Down - Class in akka.cluster
Command to mark node as temporary down.
ClusterUserAction.Down(Address) - Constructor for class akka.cluster.ClusterUserAction.Down
 
ClusterUserAction.Down$ - Class in akka.cluster
 
ClusterUserAction.Down$() - Constructor for class akka.cluster.ClusterUserAction.Down$
 
ClusterUserAction.JoinTo - Class in akka.cluster
Command to initiate join another node (represented by address).
ClusterUserAction.JoinTo(Address) - Constructor for class akka.cluster.ClusterUserAction.JoinTo
 
ClusterUserAction.JoinTo$ - Class in akka.cluster
 
ClusterUserAction.JoinTo$() - Constructor for class akka.cluster.ClusterUserAction.JoinTo$
 
ClusterUserAction.Leave - Class in akka.cluster
Command to leave the cluster.
ClusterUserAction.Leave(Address) - Constructor for class akka.cluster.ClusterUserAction.Leave
 
ClusterUserAction.Leave$ - Class in akka.cluster
 
ClusterUserAction.Leave$() - Constructor for class akka.cluster.ClusterUserAction.Leave$
 
cmd() - Method in class akka.io.Tcp.CommandFailed
 
cmd() - Method in class akka.io.Udp.CommandFailed
 
cmd() - Method in class akka.io.UdpConnected.CommandFailed
 
cmd() - Method in class akka.remote.EndpointManager.ManagementCommand
 
cmp() - Method in class akka.dispatch.BoundedPriorityMailbox
 
cmp() - Method in class akka.dispatch.UnboundedPriorityMailbox
 
codec() - Method in class akka.remote.EndpointActor
 
codec() - Method in class akka.remote.ReliableDeliverySupervisor
 
collect() - Method in class akka.cluster.ClusterMetricsCollector
Samples the latest metrics for the node, updates metrics statistics in MetricsGossip, and publishes the change to the event bus.
collectDelta(Map<Address, Object>) - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
collected() - Method in class akka.routing.CollectRouteeRefs
 
Collections - Class in akka.util
INTERNAL API
Collections() - Constructor for class akka.util.Collections
 
Collections$ - Class in akka.util
INTERNAL API
Collections$() - Constructor for class akka.util.Collections$
 
Collections.EmptyImmutableSeq$ - Class in akka.util
 
Collections.EmptyImmutableSeq$() - Constructor for class akka.util.Collections.EmptyImmutableSeq$
 
Collections.PartialImmutableValuesIterable<From,To> - Class in akka.util
 
Collections.PartialImmutableValuesIterable() - Constructor for class akka.util.Collections.PartialImmutableValuesIterable
 
collector() - Method in class akka.cluster.ClusterMetricsCollector
The metrics collector that samples data on the node.
CollectRouteeRefs - Class in akka.routing
INTERNAL API Backwards compatibility glue to support CurrentRoutees/RouterRoutees containing refs of the routees.
CollectRouteeRefs(IndexedSeq<Routee>, ActorRef) - Constructor for class akka.routing.CollectRouteeRefs
 
command() - Method in class akka.io.SelectionHandler.Retry
 
CommandAckTimeout() - Method in class akka.remote.RemoteSettings
 
commander() - Method in class akka.io.SelectionHandler.WorkerForCommand
 
commander() - Method in class akka.io.TcpConnection.EmptyPendingWrite$
 
commander() - Method in class akka.io.TcpConnection.PendingBufferWrite
 
commander() - Method in class akka.io.TcpConnection.PendingWrite
 
commander() - Method in class akka.io.TcpConnection.PendingWriteFile
 
CommandOp - Interface in akka.remote.testconductor
 
commands() - Method in interface akka.persistence.journal.JournalPerfSpec
 
COMMANDTYPE_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AkkaControlMessage
 
committed() - Method in class akka.cluster.StandardMetrics.HeapMemory
 
commonConfig(com.typesafe.config.Config) - Method in class akka.remote.testkit.MultiNodeConfig
Register a common base config for all test participants, if so desired.
CommonHandlers - Interface in akka.remote.transport.netty
INTERNAL API
compact() - Method in class akka.util.ByteString.ByteString1
 
compact() - Method in class akka.util.ByteString.ByteStrings
 
compact() - Method in class akka.util.ByteString
Create a new ByteString with all contents compacted into a single, full byte array.
compact() - Method in class akka.util.CompactByteString
 
CompactByteString - Class in akka.util
A compact ByteString.
CompactByteString() - Constructor for class akka.util.CompactByteString
 
CompactByteString$ - Class in akka.util
 
CompactByteString$() - Constructor for class akka.util.CompactByteString$
 
compare(UniqueAddress) - Method in class akka.cluster.UniqueAddress
 
compare(int, int) - Method in class akka.contrib.pattern.ReliableProxy$
Wrap-around aware comparison of integers: differences limited to 2**31-1 in magnitude will work correctly.
compare(int, int) - Static method in class akka.contrib.pattern.ReliableProxy
Wrap-around aware comparison of integers: differences limited to 2**31-1 in magnitude will work correctly.
compare(Envelope, Envelope) - Method in class akka.dispatch.PriorityGenerator
 
compare(SeqNo) - Method in class akka.remote.SeqNo
 
compare(ByteString, ByteString) - Method in class akka.util.ByteString.ByteStrings$
 
compareClassifiers(C, C) - Method in class akka.event.japi.ScanningEventBus
Provides a total ordering of Classifiers (think java.util.Comparator.compare)
compareClassifiers(ScanningClassification, ScanningClassification) - Method in interface akka.event.ScanningClassification
Provides a total ordering of Classifiers (think java.util.Comparator.compare)
compareIdentityHash(Object, Object) - Method in class akka.util.Helpers$
 
compareIdentityHash(Object, Object) - Static method in class akka.util.Helpers
 
compareSubscribers(ActorRef, ActorRef) - Method in interface akka.event.ActorEventBus
 
compareSubscribers(S, S) - Method in class akka.event.japi.LookupEventBus
Provides a total ordering of Subscribers (think java.util.Comparator.compare)
compareSubscribers(S, S) - Method in class akka.event.japi.ScanningEventBus
Provides a total ordering of Subscribers (think java.util.Comparator.compare)
compareSubscribers(LookupClassification, LookupClassification) - Method in interface akka.event.LookupClassification
Provides a total ordering of Subscribers (think java.util.Comparator.compare)
compareSubscribers(ScanningClassification, ScanningClassification) - Method in interface akka.event.ScanningClassification
Provides a total ordering of Subscribers (think java.util.Comparator.compare)
compareTo(ActorRef) - Method in class akka.actor.ActorRef
Comparison takes path and the unique id of the actor cell into account.
compareTo(ActorPath) - Method in class akka.actor.ChildActorPath
 
compareTo(ActorPath) - Method in class akka.actor.RootActorPath
 
compareTo(VectorClock) - Method in class akka.cluster.VectorClock
Compare two vector clocks.
complete() - Method in class akka.testkit.DebugFilter
 
complete() - Method in class akka.testkit.ErrorFilter
 
complete() - Method in class akka.testkit.EventFilter
 
complete() - Method in class akka.testkit.InfoFilter
 
complete() - Method in class akka.testkit.WarningFilter
 
completeConnect(ChannelRegistration, ActorRef, Traversable<Inet.SocketOption>) - Method in class akka.io.TcpConnection
used in subclasses to start the common machinery above once a channel is connected
compress(com.google.protobuf.MessageLite) - Method in class akka.cluster.protobuf.ClusterMessageSerializer
 
compress(com.google.protobuf.MessageLite) - Method in class akka.contrib.pattern.protobuf.DistributedPubSubMessageSerializer
 
concat(ByteString) - Method in class akka.util.ByteString
Java API: efficiently concatenate another ByteString.
ConcurrentMultiMap<K,V> - Class in akka.util
An implementation of a ConcurrentMultiMap Adds/remove is serialized over the specified key Reads are fully concurrent <-- el-cheapo
ConcurrentMultiMap(int, Comparator<V>) - Constructor for class akka.util.ConcurrentMultiMap
 
ConcurrentSocketActor - Class in akka.zeromq
 
ConcurrentSocketActor(Seq<SocketOption>) - Constructor for class akka.zeromq.ConcurrentSocketActor
 
ConcurrentSocketActor$ - Class in akka.zeromq
 
ConcurrentSocketActor$() - Constructor for class akka.zeromq.ConcurrentSocketActor$
 
cond() - Method in class akka.testkit.JavaTestKit.AwaitCond
 
Conductor - Interface in akka.remote.testconductor
The conductor is the one orchestrating the test: it governs the Controller&rsquo;s port to which all Players connect, it issues commands to their akka.remote.testconductor.NetworkFailureInjector and provides support for barriers using the BarrierCoordinator.
ConductorHandler - Class in akka.remote.testconductor
This handler is installed at the end of the controller&rsquo;s netty pipeline.
ConductorHandler(Timeout, ActorRef, LoggingAdapter) - Constructor for class akka.remote.testconductor.ConductorHandler
 
config() - Method in class akka.actor.ActorDSL.Extension
 
config() - Method in class akka.actor.ActorSystem.Settings
The backing Config of this ActorSystem's Settings
config() - Method in class akka.actor.Deploy
 
config() - Method in interface akka.actor.mailbox.DurableMailboxSettings
The extracted config section for this mailbox, which is the &ldquo;name&rdquo; section (if that exists), falling back to system defaults.
config() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
config() - Method in class akka.camel.internal.CamelSupervisor.Register
 
config() - Method in class akka.cluster.ClusterSettings
 
config() - Method in class akka.contrib.pattern.ClusterClient
 
config() - Method in class akka.contrib.pattern.ClusterSharding.Settings$
 
config() - Method in interface akka.dispatch.CachingConfig.PathEntry
 
config() - Method in class akka.dispatch.CachingConfig.StringPathEntry
 
config() - Method in class akka.dispatch.CachingConfig.ValuePathEntry
 
config(String) - Method in class akka.dispatch.Dispatchers
INTERNAL API
config(String, com.typesafe.config.Config) - Method in class akka.dispatch.Dispatchers
INTERNAL API
config() - Method in class akka.dispatch.MessageDispatcherConfigurator
 
config() - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
config() - Method in class akka.persistence.japi.journal.JavaJournalPerfSpec
 
config() - Method in class akka.persistence.japi.journal.JavaJournalSpec
 
config() - Method in class akka.persistence.japi.snapshot.JavaSnapshotStoreSpec
 
config() - Method in class akka.persistence.journal.JournalSpec$
 
config() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
config() - Method in interface akka.persistence.PluginSpec
 
config() - Method in class akka.persistence.snapshot.SnapshotStoreSpec$
 
config() - Method in class akka.remote.RemoteSettings
 
config() - Method in class akka.remote.testconductor.TestConductorExt.Settings
 
config() - Method in class akka.remote.testkit.MultiNodeConfig
 
config() - Method in class akka.serialization.Serialization.Settings
 
config() - Method in class akka.testkit.TestKitSettings
 
config() - Method in class akka.transactor.TransactorSettings
 
config() - Method in class akka.util.Helpers.ConfigOps
 
CONFIG_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DeployData
 
configPath() - Method in class akka.persistence.journal.leveldb.LeveldbJournal
 
configPath() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
configPath() - Method in class akka.persistence.journal.leveldb.SharedLeveldbStore
 
ConfigurationException - Exception in akka
This exception is thrown when Akka detects a problem with the provided configuration
ConfigurationException(String, Throwable) - Constructor for exception akka.ConfigurationException
 
ConfigurationException(String) - Constructor for exception akka.ConfigurationException
 
configurator() - Method in class akka.dispatch.MessageDispatcher
 
configure(FileBasedMailboxSettings) - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
configure() - Method in class akka.camel.internal.ConsumerActorRouteBuilder
 
configure(Seq<Option<Function1<ThreadPoolConfigBuilder, ThreadPoolConfigBuilder>>>) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
configure(org.osgi.framework.BundleContext, ActorSystem) - Method in class akka.osgi.ActorSystemActivator
Implement this method to add your own actors to the ActorSystem.
configureDispatcher(Props) - Method in class akka.remote.RARP
 
configureDispatcher(Props) - Method in class akka.remote.RemoteSettings
 
configureExecutor() - Method in class akka.dispatch.MessageDispatcherConfigurator
 
ConfigVersion() - Method in class akka.actor.ActorSystem.Settings
 
confirm() - Method in class akka.persistence.ConfirmablePersistent
Called by Channel and PersistentChannel destinations to confirm the receipt of a persistent message.
confirm() - Method in class akka.persistence.ConfirmablePersistentImpl
 
confirmable() - Method in class akka.persistence.ConfirmablePersistentImpl
 
confirmable() - Method in class akka.persistence.PersistentImpl
 
confirmable() - Method in interface akka.persistence.PersistentRepr
true only if this message has been delivered by a channel.
CONFIRMABLE_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
ConfirmablePersistent - Class in akka.persistence
Persistent message that has been delivered by a Channel or PersistentChannel.
ConfirmablePersistent() - Constructor for class akka.persistence.ConfirmablePersistent
 
ConfirmablePersistent$ - Class in akka.persistence
 
ConfirmablePersistent$() - Constructor for class akka.persistence.ConfirmablePersistent$
 
ConfirmablePersistentImpl - Class in akka.persistence
INTERNAL API.
ConfirmablePersistentImpl(Object, long, String, boolean, int, Seq<String>, Delivered, ActorRef, ActorRef) - Constructor for class akka.persistence.ConfirmablePersistentImpl
 
ConfirmablePersistentImpl$ - Class in akka.persistence
INTERNAL API.
ConfirmablePersistentImpl$() - Constructor for class akka.persistence.ConfirmablePersistentImpl$
 
ConfirmablePersistentImplClass() - Method in class akka.persistence.serialization.MessageSerializer
 
confirmationBatchingJournalForChannel(String) - Method in class akka.persistence.Persistence
INTERNAL API.
confirmations() - Method in class akka.persistence.journal.AsyncWriteTarget.WriteConfirmations
 
confirmations() - Method in class akka.persistence.JournalProtocol.WriteConfirmations
 
confirmations() - Method in class akka.persistence.JournalProtocol.WriteConfirmationsSuccess
 
confirmDelivery(long) - Method in interface akka.persistence.AtLeastOnceDelivery
Call this method when a message has been confirmed by the destination, or to abort re-sending.
ConfirmedClientOp - Interface in akka.remote.testconductor
 
confirmedClose() - Method in class akka.io.TcpMessage$
A confirmed close operation will flush pending writes and half-close the connection, waiting for the peer to close the other half.
confirmedClose() - Static method in class akka.io.TcpMessage
A confirmed close operation will flush pending writes and half-close the connection, waiting for the peer to close the other half.
confirmMessage() - Method in class akka.persistence.ConfirmablePersistentImpl
 
confirmMessage() - Method in class akka.persistence.PersistentImpl
 
confirmMessage() - Method in interface akka.persistence.PersistentRepr
Delivery confirmation message.
CONFIRMMESSAGE_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
confirmRemove(int) - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
confirmRemove(int) - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
confirmRemove(String, int) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
confirms() - Method in class akka.persistence.ConfirmablePersistentImpl
 
confirms() - Method in class akka.persistence.PersistentImpl
 
confirms() - Method in interface akka.persistence.PersistentRepr
Channel ids of delivery confirmations that are available for this message.
CONFIRMS_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
confirmTarget() - Method in class akka.persistence.ConfirmablePersistentImpl
 
confirmTarget() - Method in class akka.persistence.PersistentImpl
 
confirmTarget() - Method in interface akka.persistence.PersistentRepr
Delivery confirmation message.
CONFIRMTARGET_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
connect(InetSocketAddress, InetSocketAddress, Iterable<Inet.SocketOption>, FiniteDuration, boolean) - Method in class akka.io.TcpMessage$
The Connect message is sent to the TCP manager actor, which is obtained via TcpExt.getManager().
connect(InetSocketAddress) - Method in class akka.io.TcpMessage$
Connect to the given remoteAddress without binding to a local address and without specifying options.
connect(InetSocketAddress, InetSocketAddress, Iterable<Inet.SocketOption>, FiniteDuration, boolean) - Static method in class akka.io.TcpMessage
The Connect message is sent to the TCP manager actor, which is obtained via TcpExt.getManager().
connect(InetSocketAddress) - Static method in class akka.io.TcpMessage
Connect to the given remoteAddress without binding to a local address and without specifying options.
connect(ActorRef, InetSocketAddress, InetSocketAddress, Iterable<Inet.SocketOption>) - Method in class akka.io.UdpConnectedMessage$
Send this message to the UdpExt.manager() in order to bind to a local port (optionally with the chosen localAddress) and create a UDP socket which is restricted to sending to and receiving from the given remoteAddress.
connect(ActorRef, InetSocketAddress, Iterable<Inet.SocketOption>) - Method in class akka.io.UdpConnectedMessage$
Connect without specifying the localAddress.
connect(ActorRef, InetSocketAddress) - Method in class akka.io.UdpConnectedMessage$
Connect without specifying the localAddress or options.
connect(ActorRef, InetSocketAddress, InetSocketAddress, Iterable<Inet.SocketOption>) - Static method in class akka.io.UdpConnectedMessage
Send this message to the UdpExt.manager() in order to bind to a local port (optionally with the chosen localAddress) and create a UDP socket which is restricted to sending to and receiving from the given remoteAddress.
connect(ActorRef, InetSocketAddress, Iterable<Inet.SocketOption>) - Static method in class akka.io.UdpConnectedMessage
Connect without specifying the localAddress.
connect(ActorRef, InetSocketAddress) - Static method in class akka.io.UdpConnectedMessage
Connect without specifying the localAddress or options.
Connect - Class in akka.zeromq
This socket should be a client socket and connect to the specified endpoint
Connect(String) - Constructor for class akka.zeromq.Connect
 
Connect$ - Class in akka.zeromq
 
Connect$() - Constructor for class akka.zeromq.Connect$
 
connected(TcpConnection.ConnectionInfo) - Method in class akka.io.TcpConnection
normal connected state
connected(ChannelRegistration) - Method in class akka.io.UdpConnection
 
connecting(ChannelRegistration, int) - Method in class akka.io.TcpOutgoingConnection
 
Connecting - Class in akka.zeromq
When the ZeroMQ socket connects it sends this message to a listener
Connecting() - Constructor for class akka.zeromq.Connecting
 
connecting() - Method in class akka.zeromq.ZeroMQ$
The message that is sent when an ZeroMQ socket connects.
connecting() - Static method in class akka.zeromq.ZeroMQ
The message that is sent when an ZeroMQ socket connects.
Connecting$ - Class in akka.zeromq
When the ZeroMQ socket connects it sends this message to a listener
Connecting$() - Constructor for class akka.zeromq.Connecting$
 
connection() - Method in class akka.remote.testconductor.Controller
 
connectionSupervisorStrategy() - Method in class akka.io.SelectionHandler$
Special supervisor strategy for parents of TCP connection and listener actors.
connectionSupervisorStrategy() - Static method in class akka.io.SelectionHandler
Special supervisor strategy for parents of TCP connection and listener actors.
ConnectionTimeout() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
ConnectTimeout() - Method in class akka.remote.testconductor.TestConductorExt.Settings
 
ConsistentActorRef - Class in akka.routing
INTERNAL API Important to use ActorRef with full address, with host and port, in the hash ring, so that same ring is produced on different nodes.
ConsistentActorRef(ActorRef, Address) - Constructor for class akka.routing.ConsistentActorRef
 
ConsistentActorRef$ - Class in akka.routing
 
ConsistentActorRef$() - Constructor for class akka.routing.ConsistentActorRef$
 
consistentHash() - Method in class akka.contrib.pattern.ClusterReceptionist
 
ConsistentHash<T> - Class in akka.routing
Consistent Hashing node ring implementation.
ConsistentHash$ - Class in akka.routing
 
ConsistentHash$() - Constructor for class akka.routing.ConsistentHash$
 
ConsistentHashingGroup - Class in akka.routing
 
ConsistentHashingGroup(Iterable<String>, int, PartialFunction<Object, Object>, String) - Constructor for class akka.routing.ConsistentHashingGroup
 
ConsistentHashingGroup(com.typesafe.config.Config) - Constructor for class akka.routing.ConsistentHashingGroup
 
ConsistentHashingGroup$ - Class in akka.routing
 
ConsistentHashingGroup$() - Constructor for class akka.routing.ConsistentHashingGroup$
 
ConsistentHashingPool - Class in akka.routing
 
ConsistentHashingPool(int, Option<Resizer>, int, PartialFunction<Object, Object>, SupervisorStrategy, String, boolean) - Constructor for class akka.routing.ConsistentHashingPool
 
ConsistentHashingPool(com.typesafe.config.Config) - Constructor for class akka.routing.ConsistentHashingPool
 
ConsistentHashingPool$ - Class in akka.routing
 
ConsistentHashingPool$() - Constructor for class akka.routing.ConsistentHashingPool$
 
ConsistentHashingRouter - Class in akka.routing
 
ConsistentHashingRouter(int, Iterable<String>, Option<Resizer>, String, SupervisorStrategy, int, PartialFunction<Object, Object>) - Constructor for class akka.routing.ConsistentHashingRouter
 
ConsistentHashingRouter(int) - Constructor for class akka.routing.ConsistentHashingRouter
Java API: Constructor that sets nrOfInstances to be created.
ConsistentHashingRouter(Iterable<String>) - Constructor for class akka.routing.ConsistentHashingRouter
Java API: Constructor that sets the routees to be used.
ConsistentHashingRouter(Resizer) - Constructor for class akka.routing.ConsistentHashingRouter
Java API: Constructor that sets the resizer to be used.
ConsistentHashingRouter$ - Class in akka.routing
 
ConsistentHashingRouter$() - Constructor for class akka.routing.ConsistentHashingRouter$
 
ConsistentHashingRouter.ConsistentHashable - Interface in akka.routing
If you don't define the hashMapping when constructing the ConsistentHashingRouter the messages need to implement this interface to define what data to use for the consistent hash key.
ConsistentHashingRouter.ConsistentHashableEnvelope - Class in akka.routing
If you don't define the hashMapping when constructing the ConsistentHashingRouter and messages can't implement ConsistentHashingRouter.ConsistentHashable themselves they can we wrapped by this envelope instead.
ConsistentHashingRouter.ConsistentHashableEnvelope(Object, Object) - Constructor for class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope
 
ConsistentHashingRouter.ConsistentHashableEnvelope$ - Class in akka.routing
 
ConsistentHashingRouter.ConsistentHashableEnvelope$() - Constructor for class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope$
 
ConsistentHashingRouter.ConsistentHashMapper - Interface in akka.routing
JAVA API Mapping from message to the data to use for the consistent hash key.
ConsistentHashingRouter.emptyConsistentHashMapping$ - Class in akka.routing
 
ConsistentHashingRouter.emptyConsistentHashMapping$() - Constructor for class akka.routing.ConsistentHashingRouter.emptyConsistentHashMapping$
 
ConsistentHashingRoutingLogic - Class in akka.routing
 
ConsistentHashingRoutingLogic(ActorSystem, int, PartialFunction<Object, Object>) - Constructor for class akka.routing.ConsistentHashingRoutingLogic
 
ConsistentHashingRoutingLogic(ActorSystem) - Constructor for class akka.routing.ConsistentHashingRoutingLogic
 
ConsistentHashingRoutingLogic$ - Class in akka.routing
 
ConsistentHashingRoutingLogic$() - Constructor for class akka.routing.ConsistentHashingRoutingLogic$
 
consistentHashKey() - Method in interface akka.routing.ConsistentHashingRouter.ConsistentHashable
 
consistentHashKey() - Method in class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope
 
ConsistentRoutee - Class in akka.routing
 
ConsistentRoutee(Routee, Address) - Constructor for class akka.routing.ConsistentRoutee
 
ConsistentRoutee$ - Class in akka.routing
 
ConsistentRoutee$() - Constructor for class akka.routing.ConsistentRoutee$
 
constructAssociate(HandshakeInfo) - Method in interface akka.remote.transport.AkkaPduCodec
 
constructAssociate(HandshakeInfo) - Method in class akka.remote.transport.AkkaPduProtobufCodec$
 
constructAssociate(HandshakeInfo) - Static method in class akka.remote.transport.AkkaPduProtobufCodec
 
constructDisassociate(AssociationHandle.DisassociateInfo) - Method in interface akka.remote.transport.AkkaPduCodec
 
constructDisassociate(AssociationHandle.DisassociateInfo) - Method in class akka.remote.transport.AkkaPduProtobufCodec$
 
constructDisassociate(AssociationHandle.DisassociateInfo) - Static method in class akka.remote.transport.AkkaPduProtobufCodec
 
constructHeartbeat() - Method in interface akka.remote.transport.AkkaPduCodec
 
constructHeartbeat() - Method in class akka.remote.transport.AkkaPduProtobufCodec$
 
constructHeartbeat() - Static method in class akka.remote.transport.AkkaPduProtobufCodec
 
constructMessage(Address, ActorRef, WireFormats.SerializedMessage, Option<ActorRef>, Option<SeqNo>, Option<Ack>) - Method in interface akka.remote.transport.AkkaPduCodec
 
constructMessage(Address, ActorRef, WireFormats.SerializedMessage, Option<ActorRef>, Option<SeqNo>, Option<Ack>) - Method in class akka.remote.transport.AkkaPduProtobufCodec$
 
constructMessage(Address, ActorRef, WireFormats.SerializedMessage, Option<ActorRef>, Option<SeqNo>, Option<Ack>) - Static method in class akka.remote.transport.AkkaPduProtobufCodec
 
constructPayload(ByteString) - Method in interface akka.remote.transport.AkkaPduCodec
 
constructPayload(ByteString) - Method in class akka.remote.transport.AkkaPduProtobufCodec$
 
constructPayload(ByteString) - Static method in class akka.remote.transport.AkkaPduProtobufCodec
 
constructPureAck(Ack) - Method in interface akka.remote.transport.AkkaPduCodec
 
constructPureAck(Ack) - Method in class akka.remote.transport.AkkaPduProtobufCodec$
 
constructPureAck(Ack) - Static method in class akka.remote.transport.AkkaPduProtobufCodec
 
Consumer - Interface in akka.camel
Mixed in by Actor implementations that consume message from Camel endpoints.
Consumer$ - Class in akka.camel
Internal use only.
Consumer$() - Constructor for class akka.camel.Consumer$
 
ConsumerActorRouteBuilder - Class in akka.camel.internal
INTERNAL API Builder of a route to a target which can be an actor.
ConsumerActorRouteBuilder(String, ActorRef, ConsumerConfig, CamelSettings) - Constructor for class akka.camel.internal.ConsumerActorRouteBuilder
 
ConsumerConfig - Class in akka.camel
INTERNAL API Captures the configuration of the Consumer.
ConsumerConfig(FiniteDuration, FiniteDuration, boolean, Function1<org.apache.camel.model.RouteDefinition, <any>>) - Constructor for class akka.camel.ConsumerConfig
 
ConsumerConfig$ - Class in akka.camel
 
ConsumerConfig$() - Constructor for class akka.camel.ConsumerConfig$
 
ConsumerRegistrar - Class in akka.camel.internal
INTERNAL API Registers Consumers.
ConsumerRegistrar(ActorRef) - Constructor for class akka.camel.internal.ConsumerRegistrar
 
contactPoints() - Method in class akka.contrib.pattern.ClusterReceptionist.Internal$.Contacts
 
contacts() - Method in class akka.contrib.pattern.ClusterClient
 
ContainerFormats - Class in akka.remote
 
ContainerFormats.PatternType - Enum in akka.remote
Protobuf enum PatternType
ContainerFormats.Selection - Class in akka.remote
Protobuf type Selection
ContainerFormats.Selection.Builder - Class in akka.remote
Protobuf type Selection
ContainerFormats.SelectionEnvelope - Class in akka.remote
Protobuf type SelectionEnvelope
ContainerFormats.SelectionEnvelope.Builder - Class in akka.remote
Protobuf type SelectionEnvelope
ContainerFormats.SelectionEnvelopeOrBuilder - Interface in akka.remote
 
ContainerFormats.SelectionOrBuilder - Interface in akka.remote
 
contains(UniqueAddress) - Method in class akka.cluster.ClusterHeartbeatSenderState
 
contains(Object) - Method in class akka.util.BoundedBlockingQueue
 
containsAll(Collection<?>) - Method in class akka.util.BoundedBlockingQueue
 
content() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Internal$.Bucket
 
CONTENT_FIELD_NUMBER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
context() - Method in interface akka.actor.Actor
Stores the context for this actor, including self, and sender.
context() - Method in interface akka.actor.StashSupport
INTERNAL API.
context() - Method in class akka.actor.TypedActor$
Returns the ActorContext (for a TypedActor) when inside a method call in a TypedActor.
context() - Static method in class akka.actor.TypedActor
Returns the ActorContext (for a TypedActor) when inside a method call in a TypedActor.
context() - Method in interface akka.camel.Camel
Underlying camel context.
context() - Method in class akka.camel.internal.DefaultCamel
 
context() - Method in class akka.osgi.OsgiActorSystemFactory
 
context() - Method in class akka.routing.TailChoppingRoutingLogic
 
context() - Method in class akka.util.SerializedSuspendableExecutionContext
 
Context - Class in akka.zeromq
Represents an I/O thread pool for ZeroMQ sockets.
Context(int) - Constructor for class akka.zeromq.Context
 
Context$ - Class in akka.zeromq
Companion object for a ZeroMQ I/O thread pool
Context$() - Constructor for class akka.zeromq.Context$
 
contextClassLoader() - Method in class akka.dispatch.MonitorableThreadFactory
 
ContextProvider() - Method in class akka.camel.CamelSettings
Configured setting, determine the class used to load/retrive the instance of the Camel Context
ContextProvider - Interface in akka.camel
Implement this interface in order to inject a specific CamelContext in a system An instance of this class must be instantiable using a no-arg constructor.
contextStack() - Method in class akka.actor.ActorCell$
 
contextStack() - Static method in class akka.actor.ActorCell
 
ContextualTypedActorFactory - Class in akka.actor
ContextualTypedActorFactory allows TypedActors to create children, effectively forming the same Actor Supervision Hierarchies as normal Actors can.
ContextualTypedActorFactory(TypedActorExtension, ActorContext) - Constructor for class akka.actor.ContextualTypedActorFactory
 
ContextualTypedActorFactory$ - Class in akka.actor
 
ContextualTypedActorFactory$() - Constructor for class akka.actor.ContextualTypedActorFactory$
 
controller() - Method in interface akka.remote.testconductor.Conductor
 
Controller - Class in akka.remote.testconductor
This controls test execution by managing barriers (delegated to BarrierCoordinator, its child) and allowing network and other failures to be injected at the test nodes.
Controller(int, InetSocketAddress) - Constructor for class akka.remote.testconductor.Controller
 
controller() - Method in class akka.remote.testconductor.ServerFSM
 
Controller$ - Class in akka.remote.testconductor
INTERNAL API.
Controller$() - Constructor for class akka.remote.testconductor.Controller$
 
Controller.ClientDisconnected - Class in akka.remote.testconductor
 
Controller.ClientDisconnected(RoleName) - Constructor for class akka.remote.testconductor.Controller.ClientDisconnected
 
Controller.ClientDisconnected$ - Class in akka.remote.testconductor
 
Controller.ClientDisconnected$() - Constructor for class akka.remote.testconductor.Controller.ClientDisconnected$
 
Controller.ClientDisconnectedException - Exception in akka.remote.testconductor
 
Controller.ClientDisconnectedException(String) - Constructor for exception akka.remote.testconductor.Controller.ClientDisconnectedException
 
Controller.CreateServerFSM - Class in akka.remote.testconductor
 
Controller.CreateServerFSM(org.jboss.netty.channel.Channel) - Constructor for class akka.remote.testconductor.Controller.CreateServerFSM
 
Controller.CreateServerFSM$ - Class in akka.remote.testconductor
 
Controller.CreateServerFSM$() - Constructor for class akka.remote.testconductor.Controller.CreateServerFSM$
 
Controller.GetNodes$ - Class in akka.remote.testconductor
 
Controller.GetNodes$() - Constructor for class akka.remote.testconductor.Controller.GetNodes$
 
Controller.GetSockAddr$ - Class in akka.remote.testconductor
 
Controller.GetSockAddr$() - Constructor for class akka.remote.testconductor.Controller.GetSockAddr$
 
Controller.NodeInfo - Class in akka.remote.testconductor
 
Controller.NodeInfo(RoleName, Address, ActorRef) - Constructor for class akka.remote.testconductor.Controller.NodeInfo
 
Controller.NodeInfo$ - Class in akka.remote.testconductor
 
Controller.NodeInfo$() - Constructor for class akka.remote.testconductor.Controller.NodeInfo$
 
convergence() - Method in class akka.cluster.ClusterEvent.SeenChanged
 
convergence(UniqueAddress) - Method in class akka.cluster.Gossip
Checks if we have a cluster convergence.
convergenceSkipUnreachableWithMemberStatus() - Method in class akka.cluster.Gossip$
 
convergenceSkipUnreachableWithMemberStatus() - Static method in class akka.cluster.Gossip
 
Conversions() - Method in class akka.camel.CamelSettings
 
convertNumber(Object) - Method in interface akka.cluster.MetricNumericConverter
May involve rounding or truncation.
convertTo(Class<T>, org.apache.camel.Exchange, Object) - Method in class akka.camel.internal.component.DurationTypeConverter$
 
convertTo(Class<T>, org.apache.camel.Exchange, Object) - Static method in class akka.camel.internal.component.DurationTypeConverter
 
cookie() - Method in class akka.remote.transport.HandshakeInfo
 
COOKIE_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AkkaHandshakeInfo
 
coordinate(Object) - Method in class akka.transactor.Coordinated
Java API: create a new Coordinated object and increment the number of members by one.
coordinate() - Method in interface akka.transactor.Transactor
Override this method to coordinate with other transactors.
coordinate(Object) - Method in class akka.transactor.UntypedTransactor
Override this method to coordinate with other transactors.
Coordinated - Class in akka.transactor
Coordinated is a message wrapper that adds a CommitBarrier for explicitly coordinating transactions across actors or threads.
Coordinated(Object, scala.concurrent.stm.CommitBarrier.Member) - Constructor for class akka.transactor.Coordinated
 
Coordinated(Timeout) - Constructor for class akka.transactor.Coordinated
 
Coordinated$ - Class in akka.transactor
Coordinated transactions across actors.
Coordinated$() - Constructor for class akka.transactor.Coordinated$
 
CoordinatedTimeout() - Method in class akka.transactor.TransactorSettings
 
CoordinatedTransactionException - Exception in akka.transactor
Akka-specific exception for coordinated transactions.
CoordinatedTransactionException(String, Throwable) - Constructor for exception akka.transactor.CoordinatedTransactionException
 
CoordinatedTransactionException(String) - Constructor for exception akka.transactor.CoordinatedTransactionException
 
coordinator() - Method in class akka.contrib.pattern.ShardCoordinator.Internal$.RegisterAck
 
coordinator() - Method in class akka.contrib.pattern.ShardRegion
 
CoordinatorFailureBackoff() - Method in class akka.contrib.pattern.ClusterSharding.Settings$
 
coordinatorSelection() - Method in class akka.contrib.pattern.ShardRegion
 
copy(MemberStatus) - Method in class akka.cluster.Member
 
copyContent(CamelMessage, org.apache.camel.Message) - Method in class akka.camel.CamelMessage$
INTERNAL API copies the content of this CamelMessage to an Apache Camel Message.
copyContent(CamelMessage, org.apache.camel.Message) - Static method in class akka.camel.CamelMessage
INTERNAL API copies the content of this CamelMessage to an Apache Camel Message.
copyToArray(Object, int, int) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
copyToArray(Object, int, int) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
copyToArray(Object, int, int) - Method in class akka.util.ByteString
 
copyToBuffer(ByteBuffer) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
copyToBuffer(ByteBuffer) - Method in class akka.util.ByteIterator
Copy as many bytes as possible to a ByteBuffer, starting from it's current position.
copyToBuffer(ByteBuffer) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
copyToBuffer(ByteBuffer) - Method in class akka.util.ByteString
Copy as many bytes as possible to a ByteBuffer, starting from it's current position.
copyUp(int) - Method in class akka.cluster.Member
 
coreDaemon() - Method in class akka.cluster.ClusterCoreSupervisor
 
corePoolSize() - Method in class akka.dispatch.ThreadPoolConfig
 
coreSupervisor() - Method in class akka.cluster.ClusterDaemon
 
Coroner - Class in akka.testkit
The Coroner can be used to print a diagnostic report of the JVM state, including stack traces and deadlocks.
Coroner() - Constructor for class akka.testkit.Coroner
 
Coroner$ - Class in akka.testkit
The Coroner can be used to print a diagnostic report of the JVM state, including stack traces and deadlocks.
Coroner$() - Constructor for class akka.testkit.Coroner$
 
Coroner.WatchHandle - Interface in akka.testkit
Used to cancel the Coroner after calling watch.
CoronerSpec - Class in akka.testkit
 
CoronerSpec() - Constructor for class akka.testkit.CoronerSpec
 
coronerWatch() - Method in interface akka.testkit.WatchedByCoroner
 
correlationId() - Method in class akka.actor.ActorIdentity
 
count() - Method in class akka.dispatch.AbstractNodeQueue
This method returns an upper bound on the queue size at the time it starts executing.
count() - Method in class akka.event.DeadLetterListener
 
count() - Method in class akka.io.Tcp.WriteFile
 
count() - Method in class akka.routing.CollectRouteeRefs
 
count() - Method in class akka.testkit.TestActorRefSpec.Logger
 
countDown() - Method in class akka.testkit.TestLatch
 
Counter - Class in akka.actor.mailbox.filebased.filequeue
 
Counter() - Constructor for class akka.actor.mailbox.filebased.filequeue.Counter
 
counter() - Method in class akka.dispatch.MonitorableThreadFactory
 
counter() - Method in class akka.persistence.journal.JournalPerfSpec.BenchActor
 
counter() - Method in interface akka.persistence.PluginSpec
 
counter() - Method in class akka.testkit.TestActorRefSpec$
 
counter() - Static method in class akka.testkit.TestActorRefSpec
 
counterFromBytes(byte[]) - Method in class akka.persistence.journal.leveldb.Key$
 
counterFromBytes(byte[]) - Static method in class akka.persistence.journal.leveldb.Key
 
counterKey(int) - Method in class akka.persistence.journal.leveldb.Key$
 
counterKey(int) - Static method in class akka.persistence.journal.leveldb.Key
 
counterToBytes(long) - Method in class akka.persistence.journal.leveldb.Key$
 
counterToBytes(long) - Static method in class akka.persistence.journal.leveldb.Key
 
counts(int, int) - Method in class akka.remote.RemoteWatcher.Stats$
 
cpuCombined() - Method in class akka.cluster.SigarMetricsCollector
(SIGAR) Returns the combined CPU sum of User + Sys + Nice + Wait, in percentage.
CpuCombined() - Method in class akka.cluster.StandardMetrics$
 
cpuCombined() - Method in class akka.cluster.StandardMetrics.Cpu
 
CpuCombined() - Static method in class akka.cluster.StandardMetrics
 
CpuMetricsSelector - Class in akka.cluster.routing
MetricsSelector that uses the combined CPU metrics.
CpuMetricsSelector() - Constructor for class akka.cluster.routing.CpuMetricsSelector
 
CpuMetricsSelector$ - Class in akka.cluster.routing
MetricsSelector that uses the combined CPU metrics.
CpuMetricsSelector$() - Constructor for class akka.cluster.routing.CpuMetricsSelector$
 
create(Option<ActorInitializationException>) - Method in class akka.actor.ActorCell
 
create() - Method in class akka.actor.ActorSystem$
Creates a new ActorSystem with the name "default", obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
create(String) - Method in class akka.actor.ActorSystem$
Creates a new ActorSystem with the specified name, obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
create(String, com.typesafe.config.Config) - Method in class akka.actor.ActorSystem$
Creates a new ActorSystem with the specified name, and the specified Config, then obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
create(String, com.typesafe.config.Config, ClassLoader) - Method in class akka.actor.ActorSystem$
Creates a new ActorSystem with the specified name, the specified Config, and specified ClassLoader
create(String, com.typesafe.config.Config, ClassLoader, ExecutionContext) - Method in class akka.actor.ActorSystem$
Creates a new ActorSystem with the specified name, the specified Config, the specified ClassLoader, and the specified ExecutionContext.
create() - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the name "default", obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
create(String) - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the specified name, obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
create(String, com.typesafe.config.Config) - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the specified name, and the specified Config, then obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
create(String, com.typesafe.config.Config, ClassLoader) - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the specified name, the specified Config, and specified ClassLoader
create(String, com.typesafe.config.Config, ClassLoader, ExecutionContext) - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the specified name, the specified Config, the specified ClassLoader, and the specified ExecutionContext.
create() - Method in class akka.actor.DefaultSupervisorStrategy
 
create(ActorSystem) - Method in class akka.actor.Inbox$
Create a new Inbox within the given system.
create(ActorSystem) - Static method in class akka.actor.Inbox
Create a new Inbox within the given system.
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.actor.mailbox.filebased.FileBasedMailboxType
 
create(Class<?>, Object...) - Method in class akka.actor.Props$
Java API: create a Props given a class and its constructor arguments.
create(Class<?>, Seq<Object>) - Method in class akka.actor.Props$
 
create(Creator<T>) - Method in class akka.actor.Props$
Create new Props from the given Creator.
create(Class<T>, Creator<T>) - Method in class akka.actor.Props$
Create new Props from the given Creator with the type set to the given actorClass.
create(Class<?>, Object...) - Static method in class akka.actor.Props
Java API: create a Props given a class and its constructor arguments.
create(Class<?>, Seq<Object>) - Static method in class akka.actor.Props
 
create(Creator<T>) - Static method in class akka.actor.Props
Create new Props from the given Creator.
create(Class<T>, Creator<T>) - Static method in class akka.actor.Props
Create new Props from the given Creator with the type set to the given actorClass.
create() - Method in class akka.actor.StoppingSupervisorStrategy
 
create() - Method in interface akka.actor.SupervisorStrategyConfigurator
 
create(T, ExecutionContext) - Method in class akka.agent.Agent$
Java API: Factory method for creating an Agent.
create(T, ExecutionContext) - Static method in class akka.agent.Agent
Java API: Factory method for creating an Agent.
create(String, Number, Option<Object>) - Method in class akka.cluster.Metric$
Creates a new Metric instance if the value is valid, otherwise None is returned.
create(String, Try<Number>, Option<Object>) - Method in class akka.cluster.Metric$
Creates a new Metric instance if the Try is successful and the value is valid, otherwise None is returned.
create(String, Number, Option<Object>) - Static method in class akka.cluster.Metric
Creates a new Metric instance if the value is valid, otherwise None is returned.
create(String, Try<Number>, Option<Object>) - Static method in class akka.cluster.Metric
Creates a new Metric instance if the Try is successful and the value is valid, otherwise None is returned.
create(Seq<Reachability.Record>, Map<UniqueAddress, Object>) - Method in class akka.cluster.Reachability$
 
create(Seq<Reachability.Record>, Map<UniqueAddress, Object>) - Static method in class akka.cluster.Reachability
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.contrib.mailbox.PeekMailboxType
 
create(MailboxType) - Method in class akka.dispatch.BalancingDispatcherConfigurator
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.BoundedDequeBasedMailbox
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.BoundedMailbox
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.BoundedPriorityMailbox
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in interface akka.dispatch.MailboxType
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.SingleConsumerOnlyUnboundedMailbox
 
Create - Class in akka.dispatch.sysmsg
INTERNAL API
Create(Option<ActorInitializationException>) - Constructor for class akka.dispatch.sysmsg.Create
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.UnboundedDequeBasedMailbox
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.UnboundedMailbox
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.UnboundedPriorityMailbox
 
create(PartialFunction<Object, BoxedUnit>, ActorContext) - Method in class akka.event.LoggingReceive$
Java API: compatible with lambda expressions This is an EXPERIMENTAL feature and is subject to change until it has received more real world testing.
create(PartialFunction<Object, BoxedUnit>, ActorContext) - Static method in class akka.event.LoggingReceive
Java API: compatible with lambda expressions This is an EXPERIMENTAL feature and is subject to change until it has received more real world testing.
create(Iterable<Tcp.WriteCommand>) - Method in class akka.io.Tcp.WriteCommand$
Java API: combines the given number of write commands into one atomic WriteCommand.
create() - Method in interface akka.japi.Creator
This method must return a different instance upon every call.
create() - Method in interface akka.japi.function.Creator
This method must return a different instance upon every call.
create(A, B) - Method in class akka.japi.Pair$
 
create(A, B) - Static method in class akka.japi.Pair
 
create(PFBuilder<F, T>) - Static method in class akka.japi.pf.Match
Create a Match from the builder.
create(UnitPFBuilder<F>) - Static method in class akka.japi.pf.UnitMatch
Create a UnitMatch from the builder.
create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Method in class akka.japi.tuple.Tuple10$
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Static method in class akka.japi.tuple.Tuple10
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Method in class akka.japi.tuple.Tuple11$
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Static method in class akka.japi.tuple.Tuple11
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Method in class akka.japi.tuple.Tuple12$
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Static method in class akka.japi.tuple.Tuple12
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Method in class akka.japi.tuple.Tuple13$
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Static method in class akka.japi.tuple.Tuple13
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Method in class akka.japi.tuple.Tuple14$
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Static method in class akka.japi.tuple.Tuple14
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Method in class akka.japi.tuple.Tuple15$
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Static method in class akka.japi.tuple.Tuple15
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Method in class akka.japi.tuple.Tuple16$
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Static method in class akka.japi.tuple.Tuple16
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Method in class akka.japi.tuple.Tuple17$
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Static method in class akka.japi.tuple.Tuple17
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Method in class akka.japi.tuple.Tuple18$
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Static method in class akka.japi.tuple.Tuple18
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Method in class akka.japi.tuple.Tuple19$
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Static method in class akka.japi.tuple.Tuple19
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Method in class akka.japi.tuple.Tuple20$
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Static method in class akka.japi.tuple.Tuple20
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Method in class akka.japi.tuple.Tuple21$
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Static method in class akka.japi.tuple.Tuple21
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Method in class akka.japi.tuple.Tuple22$
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Static method in class akka.japi.tuple.Tuple22
 
create(T1, T2, T3) - Method in class akka.japi.tuple.Tuple3$
 
create(T1, T2, T3) - Static method in class akka.japi.tuple.Tuple3
 
create(T1, T2, T3, T4) - Method in class akka.japi.tuple.Tuple4$
 
create(T1, T2, T3, T4) - Static method in class akka.japi.tuple.Tuple4
 
create(T1, T2, T3, T4, T5) - Method in class akka.japi.tuple.Tuple5$
 
create(T1, T2, T3, T4, T5) - Static method in class akka.japi.tuple.Tuple5
 
create(T1, T2, T3, T4, T5, T6) - Method in class akka.japi.tuple.Tuple6$
 
create(T1, T2, T3, T4, T5, T6) - Static method in class akka.japi.tuple.Tuple6
 
create(T1, T2, T3, T4, T5, T6, T7) - Method in class akka.japi.tuple.Tuple7$
 
create(T1, T2, T3, T4, T5, T6, T7) - Static method in class akka.japi.tuple.Tuple7
 
create(T1, T2, T3, T4, T5, T6, T7, T8) - Method in class akka.japi.tuple.Tuple8$
 
create(T1, T2, T3, T4, T5, T6, T7, T8) - Static method in class akka.japi.tuple.Tuple8
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in class akka.japi.tuple.Tuple9$
 
create(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Static method in class akka.japi.tuple.Tuple9
 
create(Scheduler, int, FiniteDuration, FiniteDuration) - Method in class akka.pattern.CircuitBreaker$
Java API: Create a new CircuitBreaker.
create(Scheduler, int, FiniteDuration, FiniteDuration) - Static method in class akka.pattern.CircuitBreaker
Java API: Create a new CircuitBreaker.
create() - Method in class akka.persistence.ChannelSettings$
Java API.
create() - Static method in class akka.persistence.ChannelSettings
Java API.
create(Persistent, ActorPath) - Method in class akka.persistence.Deliver$
Java API.
create(Persistent, ActorPath) - Static method in class akka.persistence.Deliver
Java API.
create(Object) - Method in class akka.persistence.Persistent$
Java API: creates a new persistent message.
create(Object, Persistent) - Method in class akka.persistence.Persistent$
Java API: creates a new persistent message, derived from the specified current message.
create(Object) - Static method in class akka.persistence.Persistent
Java API: creates a new persistent message.
create(Object, Persistent) - Static method in class akka.persistence.Persistent
Java API: creates a new persistent message, derived from the specified current message.
create(Iterable<Persistent>) - Method in class akka.persistence.PersistentBatch$
Java API.
create(Iterable<Persistent>) - Static method in class akka.persistence.PersistentBatch
Java API.
create() - Method in class akka.persistence.PersistentChannelSettings$
Java API.
create() - Static method in class akka.persistence.PersistentChannelSettings
Java API.
create() - Method in class akka.persistence.PersistentRepr$
Java API, Plugin API.
create() - Method in class akka.persistence.Recover$
Java API.
create(long) - Method in class akka.persistence.Recover$
Java API.
create(SnapshotSelectionCriteria) - Method in class akka.persistence.Recover$
Java API.
create(SnapshotSelectionCriteria, long) - Method in class akka.persistence.Recover$
Java API.
create(SnapshotSelectionCriteria, long, long) - Method in class akka.persistence.Recover$
Java API.
create() - Static method in class akka.persistence.Recover
Java API.
create(long) - Static method in class akka.persistence.Recover
Java API.
create(SnapshotSelectionCriteria) - Static method in class akka.persistence.Recover
Java API.
create(SnapshotSelectionCriteria, long) - Static method in class akka.persistence.Recover
Java API.
create(SnapshotSelectionCriteria, long, long) - Static method in class akka.persistence.Recover
Java API.
create(SnapshotMetadata, Object) - Method in class akka.persistence.SelectedSnapshot$
Java API, Plugin API.
create(SnapshotMetadata, Object) - Static method in class akka.persistence.SelectedSnapshot
Java API, Plugin API.
create(long, long) - Method in class akka.persistence.SnapshotSelectionCriteria$
Java API.
create(long, long) - Static method in class akka.persistence.SnapshotSelectionCriteria
Java API.
create() - Method in class akka.persistence.Update$
Java API.
create(boolean) - Method in class akka.persistence.Update$
Java API.
create(boolean, long) - Method in class akka.persistence.Update$
Java API.
create() - Static method in class akka.persistence.Update
Java API.
create(boolean) - Static method in class akka.persistence.Update
Java API.
create(boolean, long) - Static method in class akka.persistence.Update
Java API.
create(Transport, ExtendedActorSystem) - Method in class akka.remote.transport.FailureInjectorProvider
 
create(Transport, ExtendedActorSystem) - Method in class akka.remote.transport.ThrottlerProvider
 
create(Transport, ExtendedActorSystem) - Method in interface akka.remote.transport.TransportAdapterProvider
Create the transport adapter that wraps an underlying transport.
create(Iterable<ActorRef>) - Method in class akka.routing.BroadcastRouter$
 
create(Iterable<ActorRef>) - Static method in class akka.routing.BroadcastRouter
 
create(Iterable<T>, int) - Method in class akka.routing.ConsistentHash$
Java API: Factory method to create a ConsistentHash
create(Iterable<T>, int) - Static method in class akka.routing.ConsistentHash
Java API: Factory method to create a ConsistentHash
create(Iterable<ActorRef>) - Method in class akka.routing.ConsistentHashingRouter$
 
create(Iterable<ActorRef>) - Static method in class akka.routing.ConsistentHashingRouter
 
create(Iterable<ActorRef>) - Method in class akka.routing.RandomRouter$
 
create(Iterable<ActorRef>) - Static method in class akka.routing.RandomRouter
 
create(Iterable<ActorRef>) - Method in class akka.routing.RoundRobinRouter$
 
create(Iterable<ActorRef>) - Static method in class akka.routing.RoundRobinRouter
 
create(Iterable<ActorRef>, FiniteDuration) - Method in class akka.routing.ScatterGatherFirstCompletedRouter$
 
create(Iterable<ActorRef>, FiniteDuration) - Static method in class akka.routing.ScatterGatherFirstCompletedRouter
 
create(Iterable<ActorRef>) - Method in class akka.routing.SmallestMailboxRouter$
 
create(Iterable<ActorRef>) - Static method in class akka.routing.SmallestMailboxRouter
 
create(ActorSystem, Props, String) - Method in class akka.testkit.TestActorRef$
Java API: create a TestActorRef in the given system for the given props, with the given name.
create(ActorSystem, Props) - Method in class akka.testkit.TestActorRef$
Java API: create a TestActorRef in the given system for the given props, with a random name.
create(ActorSystem, Props, String) - Static method in class akka.testkit.TestActorRef
Java API: create a TestActorRef in the given system for the given props, with the given name.
create(ActorSystem, Props) - Static method in class akka.testkit.TestActorRef
Java API: create a TestActorRef in the given system for the given props, with a random name.
Create$ - Class in akka.dispatch.sysmsg
 
Create$() - Constructor for class akka.dispatch.sysmsg.Create$
 
createActorRefProxy(TypedProps<T>, AtomicReference<R>, Function0<ActorRef>) - Method in class akka.actor.TypedActorExtension
INTERNAL API
createActorSystem(String) - Method in class akka.osgi.OsgiActorSystemFactory
Creates the ActorSystem, using the name specified
createActorSystem(Option<String>) - Method in class akka.osgi.OsgiActorSystemFactory
Creates the ActorSystem, using the name specified.
createConsumer(org.apache.camel.Processor) - Method in class akka.camel.internal.component.ActorEndpoint
The ActorEndpoint only supports receiving messages from Camel.
createDeployer() - Method in class akka.cluster.ClusterActorRefProvider
Factory method to make it possible to override deployer in subclass Creates a new instance every time
createDeployer() - Method in class akka.remote.RemoteActorRefProvider
Factory method to make it possible to override deployer in subclass Creates a new instance every time
createDynamicAccess() - Method in class akka.actor.ActorSystemImpl
This is an extension point: by overriding this method, subclasses can control all reflection activities of an actor system.
createEndpoint(String, String, Map<String, Object>) - Method in class akka.camel.internal.component.ActorComponent
 
createExecutorService() - Method in interface akka.dispatch.ExecutorServiceFactory
 
createExecutorService() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory
 
createExecutorService() - Method in class akka.dispatch.ThreadPoolConfig.ThreadPoolExecutorServiceFactory
 
createExecutorServiceFactory(String, ThreadFactory) - Method in class akka.dispatch.DefaultExecutorServiceConfigurator
 
createExecutorServiceFactory(String, ThreadFactory) - Method in interface akka.dispatch.ExecutorServiceFactoryProvider
 
createExecutorServiceFactory(String, ThreadFactory) - Method in class akka.dispatch.ForkJoinExecutorConfigurator
 
createExecutorServiceFactory(String, ThreadFactory) - Method in class akka.dispatch.ThreadPoolConfig
 
createExecutorServiceFactory(String, ThreadFactory) - Method in class akka.dispatch.ThreadPoolExecutorConfigurator
 
createExtension(ExtendedActorSystem) - Method in class akka.actor.ActorDSL.Extension$
 
createExtension(ExtendedActorSystem) - Method in interface akka.actor.ExtensionId
Is used by Akka to instantiate the Extension identified by this ExtensionId, internal use only.
createExtension(ExtendedActorSystem) - Method in class akka.actor.ExtensionKey
 
createExtension(ExtendedActorSystem) - Method in class akka.actor.TypedActor$
 
createExtension(ExtendedActorSystem) - Static method in class akka.actor.TypedActor
 
createExtension(ExtendedActorSystem) - Method in class akka.camel.CamelExtension$
Creates a new instance of Camel and makes sure it gets stopped when the actor system is shutdown.
createExtension(ExtendedActorSystem) - Static method in class akka.camel.CamelExtension
Creates a new instance of Camel and makes sure it gets stopped when the actor system is shutdown.
createExtension(ExtendedActorSystem) - Method in class akka.cluster.Cluster$
 
createExtension(ExtendedActorSystem) - Static method in class akka.cluster.Cluster
 
createExtension(ExtendedActorSystem) - Method in class akka.contrib.mailbox.PeekMailboxExtension$
 
createExtension(ExtendedActorSystem) - Static method in class akka.contrib.mailbox.PeekMailboxExtension
 
createExtension(ExtendedActorSystem) - Method in class akka.contrib.pattern.ClusterReceptionistExtension$
 
createExtension(ExtendedActorSystem) - Static method in class akka.contrib.pattern.ClusterReceptionistExtension
 
createExtension(ExtendedActorSystem) - Method in class akka.contrib.pattern.ClusterSharding$
 
createExtension(ExtendedActorSystem) - Static method in class akka.contrib.pattern.ClusterSharding
 
createExtension(ExtendedActorSystem) - Method in class akka.contrib.pattern.DistributedPubSubExtension$
 
createExtension(ExtendedActorSystem) - Static method in class akka.contrib.pattern.DistributedPubSubExtension
 
createExtension(ExtendedActorSystem) - Method in class akka.event.AddressTerminatedTopic$
 
createExtension(ExtendedActorSystem) - Static method in class akka.event.AddressTerminatedTopic
 
createExtension(ExtendedActorSystem) - Method in class akka.io.Tcp$
 
createExtension(ExtendedActorSystem) - Static method in class akka.io.Tcp
 
createExtension(ExtendedActorSystem) - Method in class akka.io.Udp$
 
createExtension(ExtendedActorSystem) - Static method in class akka.io.Udp
 
createExtension(ExtendedActorSystem) - Method in class akka.io.UdpConnected$
 
createExtension(ExtendedActorSystem) - Static method in class akka.io.UdpConnected
 
createExtension(ExtendedActorSystem) - Method in class akka.persistence.Persistence$
 
createExtension(ExtendedActorSystem) - Static method in class akka.persistence.Persistence
 
createExtension(ExtendedActorSystem) - Method in class akka.remote.AddressUidExtension$
 
createExtension(ExtendedActorSystem) - Static method in class akka.remote.AddressUidExtension
 
createExtension(ExtendedActorSystem) - Method in class akka.remote.RARP$
 
createExtension(ExtendedActorSystem) - Static method in class akka.remote.RARP
 
createExtension(ExtendedActorSystem) - Method in class akka.remote.RemoteMetricsExtension$
 
createExtension(ExtendedActorSystem) - Static method in class akka.remote.RemoteMetricsExtension
 
createExtension(ExtendedActorSystem) - Method in class akka.remote.testconductor.TestConductor$
 
createExtension(ExtendedActorSystem) - Static method in class akka.remote.testconductor.TestConductor
 
createExtension(ExtendedActorSystem) - Method in class akka.remote.transport.TransportAdaptersExtension$
 
createExtension(ExtendedActorSystem) - Static method in class akka.remote.transport.TransportAdaptersExtension
 
createExtension(ExtendedActorSystem) - Method in class akka.serialization.SerializationExtension$
 
createExtension(ExtendedActorSystem) - Static method in class akka.serialization.SerializationExtension
 
createExtension(ExtendedActorSystem) - Method in class akka.testkit.CallingThreadDispatcherQueues$
 
createExtension(ExtendedActorSystem) - Static method in class akka.testkit.CallingThreadDispatcherQueues
 
createExtension(ExtendedActorSystem) - Method in class akka.testkit.TestKitExtension$
 
createExtension(ExtendedActorSystem) - Static method in class akka.testkit.TestKitExtension
 
createExtension(ExtendedActorSystem) - Method in class akka.transactor.TransactorExtension$
 
createExtension(ExtendedActorSystem) - Static method in class akka.transactor.TransactorExtension
 
createExtension(ExtendedActorSystem) - Method in class akka.zeromq.ZeroMQExtension$
 
createExtension(ExtendedActorSystem) - Static method in class akka.zeromq.ZeroMQExtension
 
createHandle(org.jboss.netty.channel.Channel, Address, Address) - Method in interface akka.remote.transport.netty.CommonHandlers
 
createHandle(org.jboss.netty.channel.Channel, Address, Address) - Method in interface akka.remote.transport.netty.TcpHandlers
 
createHandle(org.jboss.netty.channel.Channel, Address, Address) - Method in interface akka.remote.transport.netty.UdpHandlers
 
createIdentifyId(int) - Method in class akka.contrib.pattern.ClusterSingletonProxy
 
createInstanceFor(Class<?>, Seq<Tuple2<Class<?>, Object>>, ClassTag<T>) - Method in class akka.actor.DynamicAccess
Convenience method which given a Class[_] object and a constructor description will create a new instance of that class.
createInstanceFor(String, Seq<Tuple2<Class<?>, Object>>, ClassTag<T>) - Method in class akka.actor.DynamicAccess
Obtain an object conforming to the type T, which is expected to be instantiated from a class designated by the fully-qualified class name given, where the constructor is selected and invoked according to the args argument.
createInstanceFor(Class<?>, Seq<Tuple2<Class<?>, Object>>, ClassTag<T>) - Method in class akka.actor.ReflectiveDynamicAccess
 
createInstanceFor(String, Seq<Tuple2<Class<?>, Object>>, ClassTag<T>) - Method in class akka.actor.ReflectiveDynamicAccess
 
createMailbox(Cell, MailboxType) - Method in class akka.dispatch.BalancingDispatcher
 
createMailbox(Cell, MailboxType) - Method in class akka.dispatch.Dispatcher
INTERNAL API
createMailbox(Cell, MailboxType) - Method in class akka.dispatch.MessageDispatcher
Creates and returns a mailbox for the given actor.
createMailbox(Cell, MailboxType) - Method in class akka.testkit.CallingThreadDispatcher
 
createMailboxTestActor(Props, String) - Method in class akka.actor.mailbox.DurableMailboxSpec
 
createMBean() - Method in class akka.cluster.ClusterJmx
Creates the cluster JMX MBean and registers it in the MBean server.
createProducer() - Method in class akka.camel.internal.component.ActorEndpoint
Creates a new producer which is used send messages into the endpoint.
createRemoteDeploymentWatcher(ActorSystemImpl) - Method in class akka.remote.RemoteActorRefProvider
 
createRemoteWatcher(ActorSystemImpl) - Method in class akka.cluster.ClusterActorRefProvider
 
createRemoteWatcher(ActorSystemImpl) - Method in class akka.remote.RemoteActorRefProvider
 
createRemoteWatcherFailureDetector(ExtendedActorSystem) - Method in class akka.remote.RemoteActorRefProvider
 
createRouter(ActorSystem) - Method in class akka.cluster.routing.AdaptiveLoadBalancingGroup
 
createRouter(ActorSystem) - Method in class akka.cluster.routing.AdaptiveLoadBalancingPool
 
createRouter(ActorSystem) - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
 
createRouter(ActorSystem) - Method in interface akka.cluster.routing.ClusterRouterConfigBase
 
createRouter(ActorSystem) - Method in class akka.remote.routing.RemoteRouterConfig
 
createRouter(ActorSystem) - Method in class akka.routing.BalancingPool
 
createRouter(ActorSystem) - Method in class akka.routing.BroadcastGroup
 
createRouter(ActorSystem) - Method in class akka.routing.BroadcastPool
 
createRouter(ActorSystem) - Method in class akka.routing.BroadcastRouter
 
createRouter(ActorSystem) - Method in class akka.routing.ConsistentHashingGroup
 
createRouter(ActorSystem) - Method in class akka.routing.ConsistentHashingPool
 
createRouter(ActorSystem) - Method in class akka.routing.ConsistentHashingRouter
 
createRouter(ActorSystem) - Method in class akka.routing.FromConfig
 
createRouter(ActorSystem) - Method in class akka.routing.NoRouter$
 
createRouter(ActorSystem) - Static method in class akka.routing.NoRouter
 
createRouter(ActorSystem) - Method in class akka.routing.RandomGroup
 
createRouter(ActorSystem) - Method in class akka.routing.RandomPool
 
createRouter(ActorSystem) - Method in class akka.routing.RandomRouter
 
createRouter(ActorSystem) - Method in class akka.routing.RoundRobinGroup
 
createRouter(ActorSystem) - Method in class akka.routing.RoundRobinPool
 
createRouter(ActorSystem) - Method in class akka.routing.RoundRobinRouter
 
createRouter(ActorSystem) - Method in interface akka.routing.RouterConfig
Create the actual router, responsible for routing messages to routees.
createRouter(ActorSystem) - Method in class akka.routing.ScatterGatherFirstCompletedGroup
 
createRouter(ActorSystem) - Method in class akka.routing.ScatterGatherFirstCompletedPool
 
createRouter(ActorSystem) - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
createRouter(ActorSystem) - Method in class akka.routing.SmallestMailboxPool
 
createRouter(ActorSystem) - Method in class akka.routing.SmallestMailboxRouter
 
createRouter(ActorSystem) - Method in class akka.routing.TailChoppingGroup
 
createRouter(ActorSystem) - Method in class akka.routing.TailChoppingPool
 
createRouterActor() - Method in class akka.cluster.routing.ClusterRouterConfig
INTERNAL API
createRouterActor() - Method in class akka.cluster.routing.ClusterRouterGroup
INTERNAL API
createRouterActor() - Method in class akka.cluster.routing.ClusterRouterPool
INTERNAL API
createRouterActor() - Method in class akka.remote.routing.RemoteRouterConfig
 
createRouterActor() - Method in class akka.routing.CustomRouterConfig
INTERNAL API
createRouterActor() - Method in class akka.routing.FromConfig
INTERNAL API
createRouterActor() - Method in interface akka.routing.Group
INTERNAL API
createRouterActor() - Method in class akka.routing.NoRouter$
INTERNAL API
createRouterActor() - Static method in class akka.routing.NoRouter
INTERNAL API
createRouterActor() - Method in interface akka.routing.Pool
INTERNAL API
createRouterActor() - Method in interface akka.routing.RouterConfig
INTERNAL API The router "head" actor.
createRouterConfig(String, String, com.typesafe.config.Config, com.typesafe.config.Config) - Method in class akka.actor.Deployer
Factory method for creating RouterConfig
createScheduler() - Method in class akka.actor.ActorSystemImpl
Create the scheduler service.
createStash(ActorContext, ActorRef) - Method in interface akka.actor.StashFactory
 
createThreadPoolConfigBuilder(com.typesafe.config.Config, DispatcherPrerequisites) - Method in class akka.dispatch.ThreadPoolExecutorConfigurator
 
createTimeout() - Method in class akka.remote.testconductor.ConductorHandler
 
createTunnel(ActorRef) - Method in class akka.contrib.pattern.ReliableProxy
 
CreationTimeout() - Method in class akka.actor.ActorSystem.Settings
 
creator() - Method in class akka.actor.TypedProps
 
Creator<T> - Interface in akka.japi
A constructor/factory, takes no parameters but creates a new value of type T every call.
Creator<T> - Interface in akka.japi.function
A constructor/factory, takes no parameters but creates a new value of type T every call.
CreatorConsumer - Class in akka.actor
INTERNAL API
CreatorConsumer(Class<? extends Actor>, Creator<Actor>) - Constructor for class akka.actor.CreatorConsumer
 
CreatorConsumerClass() - Method in class akka.actor.IndirectActorProducer$
 
CreatorFunctionConsumer - Class in akka.actor
INTERNAL API
CreatorFunctionConsumer(Function0<Actor>) - Constructor for class akka.actor.CreatorFunctionConsumer
 
CreatorFunctionConsumerClass() - Method in class akka.actor.IndirectActorProducer$
 
Creators - Interface in akka.actor.dsl
 
Creators.Act - Interface in akka.actor.dsl
This trait provides a DSL for writing the inner workings of an actor, e.g.
Creators.ActWithStash - Interface in akka.actor.dsl
Use this trait when defining an Actor with Stash, since just using actor()(new Act with Stash{}) will not be able to see the Stash component due to type erasure.
criteria() - Method in class akka.persistence.SnapshotProtocol.DeleteSnapshots
 
criteria() - Method in class akka.persistence.SnapshotProtocol.LoadSnapshot
 
Crypt - Class in akka.util
 
Crypt() - Constructor for class akka.util.Crypt
 
Crypt$ - Class in akka.util
 
Crypt$() - Constructor for class akka.util.Crypt$
 
ctdLock() - Method in class akka.testkit.CallingThreadMailbox
 
cumulativeAck() - Method in class akka.remote.Ack
 
cumulativeAck() - Method in class akka.remote.AckedReceiveBuffer
 
CUMULATIVEACK_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AcknowledgementInfo
 
currentAge() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
currentBytes() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
currentDeadline() - Method in class akka.actor.dsl.Inbox.InboxActor
 
currentDeliveryId() - Method in class akka.persistence.AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot
 
CURRENTDELIVERYID_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
currentFailureCount() - Method in class akka.pattern.CircuitBreaker
Retrieves current failure count.
currentHandle() - Method in class akka.remote.ReliableDeliverySupervisor
 
currentItems() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
currentMessage() - Method in class akka.actor.ActorCell
 
currentMsg() - Method in class akka.actor.dsl.Inbox.InboxActor
 
currentPersistentMessage() - Method in interface akka.persistence.Recovery
Returns the current persistent message if there is any.
CurrentRoutees - Class in akka.routing
Sending this message to a router will make it send back its currently used routees.
CurrentRoutees() - Constructor for class akka.routing.CurrentRoutees
 
CurrentRoutees$ - Class in akka.routing
 
CurrentRoutees$() - Constructor for class akka.routing.CurrentRoutees$
 
currentSelect() - Method in class akka.actor.dsl.Inbox.InboxActor
 
currentSerial() - Method in class akka.contrib.pattern.ReliableProxy
 
currentState() - Method in interface akka.actor.FSM
 
currentState() - Method in class akka.actor.FSM.StopEvent
 
currentState() - Method in interface akka.persistence.Eventsourced
 
currentStatus() - Method in class akka.dispatch.Mailbox
 
currentSystem() - Method in class akka.serialization.JavaSerializer$
This holds a reference to the current ActorSystem (the surrounding context) during serialization and deserialization.
currentSystem() - Static method in class akka.serialization.JavaSerializer
This holds a reference to the current ActorSystem (the surrounding context) during serialization and deserialization.
currentTarget() - Method in class akka.contrib.pattern.ReliableProxy
 
currentTimeMillisToUTCString(long) - Method in class akka.util.Helpers$
Converts a "currentTimeMillis"-obtained timestamp accordingly:
currentTimeMillisToUTCString(long) - Static method in class akka.util.Helpers
Converts a "currentTimeMillis"-obtained timestamp accordingly:
currentTransportInformation() - Method in class akka.serialization.Serialization$
This holds a reference to the current transport serialization information used for serializing local actor refs.
currentTransportInformation() - Static method in class akka.serialization.Serialization
This holds a reference to the current transport serialization information used for serializing local actor refs.
currentXid() - Method in class akka.actor.mailbox.filebased.filequeue.tools.QueueDumper
 
custom(PartialFunction<Logging.LogEvent, Object>, int) - Method in class akka.testkit.EventFilter$
Create a custom event filter.
custom(PartialFunction<Logging.LogEvent, Object>, int) - Static method in class akka.testkit.EventFilter
Create a custom event filter.
CustomEventFilter - Class in akka.testkit
Custom event filter when the others do not fit the bill.
CustomEventFilter(PartialFunction<Logging.LogEvent, Object>, int) - Constructor for class akka.testkit.CustomEventFilter
 
CustomEventFilter$ - Class in akka.testkit
 
CustomEventFilter$() - Constructor for class akka.testkit.CustomEventFilter$
 
CustomRouterConfig - Class in akka.routing
If a custom router implementation is not a Group nor a Pool it may extend this base class.
CustomRouterConfig() - Constructor for class akka.routing.CustomRouterConfig
 

D

daemonic() - Method in class akka.dispatch.MonitorableThreadFactory
 
Daemonicity() - Method in class akka.actor.ActorSystem.Settings
 
DaemonMsg - Interface in akka.remote
INTERNAL API
DaemonMsgCreate - Class in akka.remote
INTERNAL API
DaemonMsgCreate(Props, Deploy, String, ActorRef) - Constructor for class akka.remote.DaemonMsgCreate
 
DaemonMsgCreate$ - Class in akka.remote
 
DaemonMsgCreate$() - Constructor for class akka.remote.DaemonMsgCreate$
 
DaemonMsgCreateSerializer - Class in akka.remote.serialization
Serializes akka's internal DaemonMsgCreate using protobuf for the core structure of DaemonMsgCreate, Props and Deploy.
DaemonMsgCreateSerializer(ExtendedActorSystem) - Constructor for class akka.remote.serialization.DaemonMsgCreateSerializer
 
data() - Method in class akka.actor.mailbox.filebased.filequeue.QItem
 
data() - Method in class akka.io.Tcp.Received
 
data() - Method in class akka.io.Tcp.Write
 
data() - Method in class akka.io.Udp.Received
 
data() - Method in class akka.io.UdpConnected.Received
 
data() - Method in class akka.persistence.serialization.Snapshot
 
data() - Method in exception akka.remote.testconductor.BarrierCoordinator.BarrierEmpty
 
data() - Method in exception akka.remote.testconductor.BarrierCoordinator.BarrierTimeout
 
data() - Method in exception akka.remote.testconductor.BarrierCoordinator.ClientLost
 
data() - Method in exception akka.remote.testconductor.BarrierCoordinator.DuplicateNode
 
data() - Method in exception akka.remote.testconductor.BarrierCoordinator.FailedBarrier
 
data() - Method in exception akka.remote.testconductor.BarrierCoordinator.WrongBarrier
 
data() - Method in class akka.util.WildcardTree
 
date() - Method in interface akka.event.Logging.StdOutLogger
 
dateFormat() - Method in interface akka.event.Logging.StdOutLogger
 
deactivated() - Method in class akka.camel.internal.ActivationTracker.ActivationStateMachine
De-activated state
deactivationFutureFor(ActorRef, Timeout, ExecutionContext) - Method in interface akka.camel.Activation
Produces a Future which will be completed when the given endpoint has been deactivated or or if it times out, which will happen after the specified Timeout.
deactivationFutureFor(ActorRef, Timeout, ExecutionContext) - Method in class akka.camel.internal.DefaultCamel
Produces a Future which will be completed when the given endpoint has been deactivated or or if it times out, which will happen after the specified Timeout.
dead() - Method in exception akka.actor.DeathPactException
 
DeadLetter - Class in akka.actor
When a message is sent to an Actor that is terminated before receiving the message, it will be sent as a DeadLetter to the ActorSystem's EventStream
DeadLetter(Object, ActorRef, ActorRef) - Constructor for class akka.actor.DeadLetter
 
DeadLetter$ - Class in akka.actor
 
DeadLetter$() - Constructor for class akka.actor.DeadLetter$
 
DeadLetterActorRef - Class in akka.actor
Internal implementation of the dead letter destination: will publish any received message to the eventStream, wrapped as DeadLetter.
DeadLetterActorRef(ActorRefProvider, ActorPath, EventStream) - Constructor for class akka.actor.DeadLetterActorRef
 
DeadLetterActorRef$ - Class in akka.actor
 
DeadLetterActorRef$() - Constructor for class akka.actor.DeadLetterActorRef$
 
DeadLetterActorRef.SerializedDeadLetterActorRef - Class in akka.actor
 
DeadLetterActorRef.SerializedDeadLetterActorRef() - Constructor for class akka.actor.DeadLetterActorRef.SerializedDeadLetterActorRef
 
DeadLetterListener - Class in akka.event
 
DeadLetterListener() - Constructor for class akka.event.DeadLetterListener
 
deadLetterMailbox() - Method in class akka.dispatch.Mailboxes
 
deadLetters() - Method in interface akka.actor.ActorRefProvider
Dead letter destination for this provider.
deadLetters() - Method in class akka.actor.ActorSystem
Actor reference where messages are re-routed to which were addressed to stopped or non-existing actors.
deadLetters() - Method in class akka.actor.ActorSystemImpl
 
deadLetters() - Method in class akka.actor.LocalActorRefProvider
 
deadLetters() - Method in class akka.remote.RemoteActorRefProvider
 
DeadLettersFilter - Class in akka.testkit
 
DeadLettersFilter(Class<?>, int) - Constructor for class akka.testkit.DeadLettersFilter
 
DeadLettersFilter$ - Class in akka.testkit
 
DeadLettersFilter$() - Constructor for class akka.testkit.DeadLettersFilter$
 
DeadLetterSuppression - Interface in akka.actor
Use with caution: Messages extending this trait will not be sent to dead-letters.
deadline() - Method in class akka.actor.dsl.Inbox.Get
 
deadline() - Method in interface akka.actor.dsl.Inbox.Query
 
deadline() - Method in class akka.actor.dsl.Inbox.Select
 
deadline() - Method in class akka.remote.testconductor.BarrierCoordinator.Data
 
DeadlineFailureDetector - Class in akka.remote
Implementation of failure detector using an absolute timeout of missing heartbeats to trigger unavailability.
DeadlineFailureDetector(FiniteDuration, FailureDetector.Clock) - Constructor for class akka.remote.DeadlineFailureDetector
 
DeadlineFailureDetector(com.typesafe.config.Config, EventStream) - Constructor for class akka.remote.DeadlineFailureDetector
Constructor that reads parameters from config.
deadlineOrder() - Method in interface akka.actor.dsl.Inbox
 
Deafen - Class in akka.routing
 
Deafen(ActorRef) - Constructor for class akka.routing.Deafen
 
Deafen$ - Class in akka.routing
 
Deafen$() - Constructor for class akka.routing.Deafen$
 
DeathPactException - Exception in akka.actor
A DeathPactException is thrown by an Actor that receives a Terminated(someActor) message that it doesn't handle itself, effectively crashing the Actor and escalating to the supervisor.
DeathPactException(ActorRef) - Constructor for exception akka.actor.DeathPactException
 
DeathPactException$ - Class in akka.actor
 
DeathPactException$() - Constructor for class akka.actor.DeathPactException$
 
DeathWatch - Interface in akka.actor.dungeon
 
DeathWatchNotification - Class in akka.dispatch.sysmsg
 
DeathWatchNotification(ActorRef, boolean, boolean) - Constructor for class akka.dispatch.sysmsg.DeathWatchNotification
 
DeathWatchNotification$ - Class in akka.dispatch.sysmsg
 
DeathWatchNotification$() - Constructor for class akka.dispatch.sysmsg.DeathWatchNotification$
 
debug() - Method in interface akka.contrib.pattern.ReliableProxyDebugLogging
 
debug() - Method in class akka.dispatch.Mailbox$
 
debug() - Static method in class akka.dispatch.Mailbox
 
debug() - Method in class akka.dispatch.MessageDispatcher$
 
debug() - Static method in class akka.dispatch.MessageDispatcher
 
debug(Logging.Debug) - Method in interface akka.event.Logging.StdOutLogger
 
debug(String) - Method in interface akka.event.LoggingAdapter
Log message at debug level.
debug(String, Object) - Method in interface akka.event.LoggingAdapter
Message template with 1 replacement argument.
debug(String, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 2 replacement arguments.
debug(String, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 3 replacement arguments.
debug(String, Object, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 4 replacement arguments.
debug(String, String, String, String, int) - Method in class akka.testkit.EventFilter$
Create a filter for Debug events.
debug(String, String, String, String, int) - Static method in class akka.testkit.EventFilter
Create a filter for Debug events.
DebugAutoReceive() - Method in class akka.actor.ActorSystem.Settings
 
debugConfig(boolean) - Method in class akka.remote.testkit.MultiNodeConfig
Include for verbose debug logging
debugEvent() - Method in interface akka.actor.FSM
 
debugEvent() - Method in interface akka.actor.LoggingFSM
 
DebugEventStream() - Method in class akka.actor.ActorSystem.Settings
 
DebugFilter - Class in akka.testkit
Filter which matches Debug events, if they satisfy the given criteria: source, if given, applies a filter on the event&rsquo;s origin message applies a filter on the event&rsquo;s message (either with String.startsWith or Regex.findFirstIn().isDefined) If you want to match all Debug events, the most efficient is to use Left("").
DebugFilter(Option<String>, Either<String, Regex>, boolean, int) - Constructor for class akka.testkit.DebugFilter
 
DebugFilter(String, String, boolean, boolean, int) - Constructor for class akka.testkit.DebugFilter
Java API: create a DebugFilter
DebugFilter$ - Class in akka.testkit
 
DebugFilter$() - Constructor for class akka.testkit.DebugFilter$
 
debugFormat() - Method in interface akka.event.Logging.StdOutLogger
 
DebugLevel() - Method in class akka.event.Logging$
 
DebugLevel() - Static method in class akka.event.Logging
 
DebugLifecycle() - Method in class akka.actor.ActorSystem.Settings
 
DebugRouterMisconfiguration() - Method in class akka.actor.ActorSystem.Settings
 
DebugUnhandledMessage() - Method in class akka.actor.ActorSystem.Settings
 
decider() - Method in class akka.actor.AllForOneStrategy
 
decider() - Method in class akka.actor.OneForOneStrategy
 
decider() - Method in class akka.actor.SupervisorStrategy
Returns the Decider that is associated with this SupervisorStrategy.
DeciderBuilder - Class in akka.japi.pf
Used for building a partial function for Actor.supervisorStrategy().
decode(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.Channel, Object) - Method in class akka.remote.testconductor.MsgDecoder
 
decodeMessage(ByteString, RemoteActorRefProvider, Address) - Method in interface akka.remote.transport.AkkaPduCodec
 
decodeMessage(ByteString, RemoteActorRefProvider, Address) - Method in class akka.remote.transport.AkkaPduProtobufCodec$
 
decodeMessage(ByteString, RemoteActorRefProvider, Address) - Static method in class akka.remote.transport.AkkaPduProtobufCodec
 
decodePdu(ByteString) - Method in interface akka.remote.transport.AkkaPduCodec
Returns an AkkaPduCodec.AkkaPdu instance that represents the PDU contained in the raw ByteString.
decodePdu(ByteString) - Method in class akka.remote.transport.AkkaPduProtobufCodec$
 
decodePdu(ByteString) - Static method in class akka.remote.transport.AkkaPduProtobufCodec
 
decodeString(String) - Method in class akka.util.ByteString.ByteString1
 
decodeString(String) - Method in class akka.util.ByteString.ByteString1C
 
decodeString(String) - Method in class akka.util.ByteString.ByteStrings
 
decodeString(String) - Method in class akka.util.ByteString
Decodes this ByteString using a charset to produce a String.
decompress(byte[]) - Method in class akka.cluster.protobuf.ClusterMessageSerializer
 
decompress(byte[]) - Method in class akka.contrib.pattern.protobuf.DistributedPubSubMessageSerializer
 
decr() - Method in class akka.actor.mailbox.filebased.filequeue.Counter
 
decr(long) - Method in class akka.actor.mailbox.filebased.filequeue.Counter
 
defaultAddress() - Method in class akka.remote.RemoteTransport
The default transport address of the actorsystem
defaultAddress() - Method in class akka.remote.Remoting
 
defaultAddress(ActorSystem) - Method in class akka.routing.ConsistentHashingRoutingLogic$
 
defaultAddress(ActorSystem) - Static method in class akka.routing.ConsistentHashingRoutingLogic
 
defaultAllowCoreThreadTimeout() - Method in class akka.dispatch.ThreadPoolConfig$
 
defaultAllowCoreThreadTimeout() - Static method in class akka.dispatch.ThreadPoolConfig
 
DefaultCamel - Class in akka.camel.internal
INTERNAL API Creates an instance of the Camel subsystem.
DefaultCamel(ExtendedActorSystem) - Constructor for class akka.camel.internal.DefaultCamel
 
defaultClock() - Method in class akka.remote.FailureDetector$
 
defaultConnectInterval() - Method in class akka.contrib.pattern.ReliableProxy
 
DefaultContextProvider - Class in akka.camel
Default implementation of ContextProvider Provides a new DefaultCamelContext per actor system
DefaultContextProvider() - Constructor for class akka.camel.DefaultContextProvider
 
defaultCorePoolSize() - Method in class akka.dispatch.ThreadPoolConfig$
 
defaultCorePoolSize() - Static method in class akka.dispatch.ThreadPoolConfig
 
defaultCreator() - Method in class akka.actor.Props$
The defaultCreator, simply throws an UnsupportedOperationException when applied, which is used when creating a Props
defaultCreator() - Static method in class akka.actor.Props
The defaultCreator, simply throws an UnsupportedOperationException when applied, which is used when creating a Props
defaultDecider() - Method in class akka.actor.SupervisorStrategy$
When supervisorStrategy is not specified for an actor this Decider is used by default in the supervisor strategy.
defaultDecider() - Static method in class akka.actor.SupervisorStrategy
When supervisorStrategy is not specified for an actor this Decider is used by default in the supervisor strategy.
defaultDeploy() - Method in class akka.actor.Props$
The default Deploy instance which is used when creating a Props
defaultDeploy() - Static method in class akka.actor.Props
The default Deploy instance which is used when creating a Props
defaultDispatcherConfig() - Method in class akka.dispatch.Dispatchers
 
defaultDispatcherId() - Method in class akka.actor.TypedProps$
 
defaultDispatcherId() - Static method in class akka.actor.TypedProps
 
DefaultDispatcherId() - Method in class akka.dispatch.Dispatchers$
The id of the default dispatcher, also the full key of the configuration of the default dispatcher.
DefaultDispatcherId() - Static method in class akka.dispatch.Dispatchers
The id of the default dispatcher, also the full key of the configuration of the default dispatcher.
DefaultDispatcherPrerequisites - Class in akka.dispatch
INTERNAL API
DefaultDispatcherPrerequisites(ThreadFactory, EventStream, Scheduler, DynamicAccess, ActorSystem.Settings, Mailboxes, Option<ExecutionContext>) - Constructor for class akka.dispatch.DefaultDispatcherPrerequisites
 
DefaultDispatcherPrerequisites$ - Class in akka.dispatch
 
DefaultDispatcherPrerequisites$() - Constructor for class akka.dispatch.DefaultDispatcherPrerequisites$
 
defaultExecutionContext() - Method in class akka.dispatch.DefaultDispatcherPrerequisites
 
defaultExecutionContext() - Method in interface akka.dispatch.DispatcherPrerequisites
 
DefaultExecutorServiceConfigurator - Class in akka.dispatch
 
DefaultExecutorServiceConfigurator(com.typesafe.config.Config, DispatcherPrerequisites, ExecutorServiceConfigurator) - Constructor for class akka.dispatch.DefaultExecutorServiceConfigurator
 
DefaultFailureDetectorRegistry<A> - Class in akka.remote
A lock-less thread-safe implementation of FailureDetectorRegistry.
DefaultFailureDetectorRegistry(Function0<FailureDetector>) - Constructor for class akka.remote.DefaultFailureDetectorRegistry
 
defaultGlobalDispatcher() - Method in class akka.dispatch.Dispatchers
The one and only default dispatcher.
defaultLoader() - Method in class akka.actor.TypedProps$
 
defaultLoader() - Static method in class akka.actor.TypedProps
 
DefaultMailboxId() - Method in class akka.dispatch.Mailboxes$
 
DefaultMailboxId() - Static method in class akka.dispatch.Mailboxes
 
defaultMaxPoolSize() - Method in class akka.dispatch.ThreadPoolConfig$
 
defaultMaxPoolSize() - Static method in class akka.dispatch.ThreadPoolConfig
 
defaultMaxUnconfirmedMessages() - Method in interface akka.persistence.AtLeastOnceDelivery
 
DefaultMessageDispatcher - Class in akka.remote
INTERNAL API
DefaultMessageDispatcher(ExtendedActorSystem, RemoteActorRefProvider, LoggingAdapter) - Constructor for class akka.remote.DefaultMessageDispatcher
 
DefaultOSGiLogger - Class in akka.osgi
Logger for OSGi environment.
DefaultOSGiLogger() - Constructor for class akka.osgi.DefaultOSGiLogger
 
DefaultPollTimeout() - Method in class akka.zeromq.ZeroMQExtension
 
defaultProps(Set<ActorSelection>) - Method in class akka.contrib.pattern.ClusterClient$
Java API: Factory method for ClusterClient Props with default values.
defaultProps(Set<ActorSelection>) - Static method in class akka.contrib.pattern.ClusterClient
Java API: Factory method for ClusterClient Props with default values.
defaultProps(Props, String, Object, String) - Method in class akka.contrib.pattern.ClusterSingletonManager$
Java API: Factory method for ClusterSingletonManager Props with default values.
defaultProps(Props, String, Object, String) - Static method in class akka.contrib.pattern.ClusterSingletonManager
Java API: Factory method for ClusterSingletonManager Props with default values.
defaultProps(String, String) - Method in class akka.contrib.pattern.ClusterSingletonProxy$
Java API: Factory method for ClusterSingletonProxy Props.
defaultProps(String, String) - Static method in class akka.contrib.pattern.ClusterSingletonProxy
Java API: Factory method for ClusterSingletonProxy Props.
defaultProps(String) - Method in class akka.contrib.pattern.DistributedPubSubMediator$
Java API: Factory method for DistributedPubSubMediator Props with default values.
defaultProps(String) - Static method in class akka.contrib.pattern.DistributedPubSubMediator
Java API: Factory method for DistributedPubSubMediator Props with default values.
defaultReceive() - Method in interface akka.contrib.pattern.DistributedPubSubMediator.Internal$.TopicLike
 
defaultRedeliverInterval() - Method in interface akka.persistence.AtLeastOnceDelivery
 
defaultRejectionPolicy() - Method in class akka.dispatch.ThreadPoolConfig$
 
defaultRejectionPolicy() - Static method in class akka.dispatch.ThreadPoolConfig
 
DefaultResizer - Class in akka.routing
 
DefaultResizer(int, int, int, double, double, double, int) - Constructor for class akka.routing.DefaultResizer
 
DefaultResizer(int, int) - Constructor for class akka.routing.DefaultResizer
Java API constructor for default values except bounds.
DefaultResizer$ - Class in akka.routing
 
DefaultResizer$() - Constructor for class akka.routing.DefaultResizer$
 
DefaultReturnTimeout() - Method in class akka.actor.TypedActorExtension
Default timeout for typed actor methods with non-void return type
defaultRoutedProps() - Method in class akka.actor.Props$
The defaultRoutedProps is NoRouter which is used when creating a Props
defaultRoutedProps() - Static method in class akka.actor.Props
The defaultRoutedProps is NoRouter which is used when creating a Props
defaultStartAndStopDuration() - Method in class akka.testkit.Coroner$
 
defaultStartAndStopDuration() - Static method in class akka.testkit.Coroner
 
DefaultState() - Method in class akka.actor.ActorCell$
 
DefaultState() - Static method in class akka.actor.ActorCell
 
defaultStrategy() - Method in class akka.actor.SupervisorStrategy$
When supervisorStrategy is not specified for an actor this is used by default.
defaultStrategy() - Static method in class akka.actor.SupervisorStrategy
When supervisorStrategy is not specified for an actor this is used by default.
DefaultSupervisorStrategy - Class in akka.actor
 
DefaultSupervisorStrategy() - Constructor for class akka.actor.DefaultSupervisorStrategy
 
defaultSupervisorStrategy() - Method in class akka.routing.Pool$
 
DefaultSystemMessageQueue - Interface in akka.dispatch
INTERNAL API
defaultTimeout() - Method in class akka.actor.TypedProps$
 
defaultTimeout() - Static method in class akka.actor.TypedProps
 
defaultTimeout() - Method in class akka.dispatch.ThreadPoolConfig$
 
defaultTimeout() - Static method in class akka.dispatch.ThreadPoolConfig
 
DefaultTimeout - Interface in akka.testkit
 
DefaultTimeout() - Method in class akka.testkit.TestBarrier$
 
DefaultTimeout() - Static method in class akka.testkit.TestBarrier
 
DefaultTimeout() - Method in class akka.testkit.TestKitSettings
 
DefaultTimeout() - Method in class akka.testkit.TestLatch$
 
DefaultTimeout() - Static method in class akka.testkit.TestLatch
 
DefaultTimeoutSpec - Class in akka.testkit
 
DefaultTimeoutSpec() - Constructor for class akka.testkit.DefaultTimeoutSpec
 
DefaultVirtualNodesFactor() - Method in class akka.actor.ActorSystem.Settings
 
defaultWarnAfterNumberOfUnconfirmedAttempts() - Method in interface akka.persistence.AtLeastOnceDelivery
 
defer(A, Procedure<A>) - Method in class akka.persistence.AbstractPersistentActor
Defer the handler execution until all pending handlers have been executed.
defer(Iterable<A>, Procedure<A>) - Method in class akka.persistence.AbstractPersistentActor
Defer the handler execution until all pending handlers have been executed.
defer(A, Function1<A, BoxedUnit>) - Method in interface akka.persistence.Eventsourced
 
defer(Seq<A>, Function1<A, BoxedUnit>) - Method in interface akka.persistence.Eventsourced
 
defer(A, Procedure<A>) - Method in class akka.persistence.UntypedPersistentActor
Defer the handler execution until all pending handlers have been executed.
defer(Iterable<A>, Procedure<A>) - Method in class akka.persistence.UntypedPersistentActor
Defer the handler execution until all pending handlers have been executed.
defined(Number) - Method in interface akka.cluster.MetricNumericConverter
An defined value is neither negative nor NaN/Infinite: JMX system load average and max heap can be 'undefined' for certain OS, in which case a -1 is returned SIGAR combined CPU can occasionally return a NaN or Infinite (known bug)
defined(T) - Method in interface akka.japi.pf.FI.TypedPredicate
The predicate to evaluate.
defined(T, U) - Method in interface akka.japi.pf.FI.TypedPredicate2
The predicate to evaluate.
delete(String) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
delete(String, long) - Method in interface akka.persistence.journal.inmem.InmemMessages
 
delete(SnapshotMetadata) - Method in class akka.persistence.snapshot.japi.SnapshotStore
 
delete(String, SnapshotSelectionCriteria) - Method in class akka.persistence.snapshot.japi.SnapshotStore
 
delete(SnapshotMetadata) - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
 
delete(String, SnapshotSelectionCriteria) - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
 
delete(SnapshotMetadata) - Method in interface akka.persistence.snapshot.SnapshotStore
Plugin API: deletes the snapshot identified by metadata.
delete(String, SnapshotSelectionCriteria) - Method in interface akka.persistence.snapshot.SnapshotStore
Plugin API: deletes all snapshots matching criteria.
deleted() - Method in class akka.persistence.ConfirmablePersistentImpl
 
deleted() - Method in class akka.persistence.PersistentImpl
 
deleted() - Method in interface akka.persistence.PersistentRepr
true if this message is marked as deleted.
DELETED_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
deleteMessage(long) - Method in interface akka.persistence.ProcessorImpl
Marks a persistent message, identified by sequenceNr, as deleted.
deleteMessage(long, boolean) - Method in interface akka.persistence.ProcessorImpl
Deletes a persistent message identified by sequenceNr.
deleteMessages(Seq<PersistentId>, boolean) - Method in class akka.persistence.journal.japi.SyncWriteJournal
 
deleteMessages(Seq<PersistentId>, boolean) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
deleteMessages(Seq<PersistentId>, boolean) - Method in interface akka.persistence.journal.SyncWriteJournal
Plugin API: synchronously deletes messages identified by messageIds from the journal.
deleteMessages(long) - Method in interface akka.persistence.ProcessorImpl
Permanently deletes all persistent messages with sequence numbers less than or equal toSequenceNr.
deleteMessages(long, boolean) - Method in interface akka.persistence.ProcessorImpl
Deletes all persistent messages with sequence numbers less than or equal toSequenceNr.
deleteMessagesTo(String, long, boolean) - Method in class akka.persistence.journal.japi.SyncWriteJournal
 
deleteMessagesTo(String, long, boolean) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
deleteMessagesTo(String, long, boolean) - Method in interface akka.persistence.journal.SyncWriteJournal
Plugin API: synchronously deletes all persistent messages up to toSequenceNr (inclusive).
deleteSnapshot(long, long) - Method in interface akka.persistence.Snapshotter
Deletes a snapshot identified by sequenceNr and timestamp.
deleteSnapshots(SnapshotSelectionCriteria) - Method in interface akka.persistence.Snapshotter
Deletes all snapshots matching criteria.
deletionBatchingJournalForChannel(String) - Method in class akka.persistence.Persistence
INTERNAL API.
deletionKey(int, long) - Method in class akka.persistence.journal.leveldb.Key$
 
deletionKey(int, long) - Static method in class akka.persistence.journal.leveldb.Key
 
deliver(ActorPath, Function<Long, Object>) - Method in class akka.persistence.AbstractPersistentActorWithAtLeastOnceDelivery
Java API: Send the message created by the deliveryIdToMessage function to the destination actor.
deliver(ActorPath, Function1<Object, Object>) - Method in interface akka.persistence.AtLeastOnceDelivery
Scala API: Send the message created by the deliveryIdToMessage function to the destination actor.
Deliver - Class in akka.persistence
Instructs a Channel or PersistentChannel to deliver a persistent message to a destination.
Deliver(Persistent, ActorPath) - Constructor for class akka.persistence.Deliver
 
deliver(ActorPath, Function<Long, Object>) - Method in class akka.persistence.UntypedPersistentActorWithAtLeastOnceDelivery
Java API: Send the message created by the deliveryIdToMessage function to the destination actor.
Deliver$ - Class in akka.persistence
 
Deliver$() - Constructor for class akka.persistence.Deliver$
 
DeliverClass() - Method in class akka.persistence.serialization.MessageSerializer
 
Delivered - Interface in akka.persistence
Plugin API: confirmation message generated by receivers of ConfirmablePersistent messages by calling ConfirmablePersistent.confirm().
DeliveredByChannel - Class in akka.persistence
Plugin API.
DeliveredByChannel(String, String, long, long, ActorRef) - Constructor for class akka.persistence.DeliveredByChannel
 
DeliveredByChannel$ - Class in akka.persistence
 
DeliveredByChannel$() - Constructor for class akka.persistence.DeliveredByChannel$
 
DeliveredByChannelBatching - Class in akka.persistence
INTERNAL API.
DeliveredByChannelBatching(ActorRef, PersistenceSettings) - Constructor for class akka.persistence.DeliveredByChannelBatching
 
DeliveredByPersistentChannel - Class in akka.persistence
Plugin API.
DeliveredByPersistentChannel(String, long, long, ActorRef) - Constructor for class akka.persistence.DeliveredByPersistentChannel
 
DeliveredByPersistentChannel$ - Class in akka.persistence
 
DeliveredByPersistentChannel$() - Constructor for class akka.persistence.DeliveredByPersistentChannel$
 
DeliveredByPersistentChannelBatching - Class in akka.persistence
INTERNAL API.
DeliveredByPersistentChannelBatching(ActorRef, PersistenceSettings) - Constructor for class akka.persistence.DeliveredByPersistentChannelBatching
 
DeliveredByPersistentChannelClass() - Method in class akka.persistence.serialization.MessageSerializer
 
DeliveredByTransientChannelClass() - Method in class akka.persistence.serialization.MessageSerializer
 
deliverMessage(Object, ActorRef) - Method in class akka.contrib.pattern.ShardRegion
 
deliverSelection(InternalActorRef, ActorRef, ActorSelectionMessage) - Method in class akka.actor.ActorSelection$
INTERNAL API The receive logic for ActorSelectionMessage.
deliverSelection(InternalActorRef, ActorRef, ActorSelectionMessage) - Static method in class akka.actor.ActorSelection
INTERNAL API The receive logic for ActorSelectionMessage.
deliveryId() - Method in class akka.persistence.AtLeastOnceDelivery.UnconfirmedDelivery
 
DELIVERYID_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
deliverySequenceNr() - Method in interface akka.persistence.AtLeastOnceDelivery
 
deliverySequenceNr() - Method in interface akka.persistence.Delivered
 
deliverySequenceNr() - Method in class akka.persistence.DeliveredByChannel
 
deliverySequenceNr() - Method in class akka.persistence.DeliveredByPersistentChannel
 
DELIVERYSEQUENCENR_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
Deploy - Class in akka.actor
 
Deploy(String, com.typesafe.config.Config, RouterConfig, Scope, String, String) - Constructor for class akka.actor.Deploy
 
Deploy(RouterConfig) - Constructor for class akka.actor.Deploy
Java API to create a Deploy with the given RouterConfig
Deploy(RouterConfig, Scope) - Constructor for class akka.actor.Deploy
Java API to create a Deploy with the given RouterConfig with Scope
Deploy(Scope) - Constructor for class akka.actor.Deploy
Java API to create a Deploy with the given Scope
deploy(Deploy) - Method in class akka.actor.Deployer
 
deploy() - Method in class akka.actor.Props
 
deploy() - Method in class akka.actor.TypedProps
 
deploy() - Method in class akka.remote.DaemonMsgCreate
 
Deploy$ - Class in akka.actor
 
Deploy$() - Constructor for class akka.actor.Deploy$
 
DEPLOY_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DaemonMsgCreateData
 
DEPLOY_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.PropsData
 
deployer() - Method in interface akka.actor.ActorRefProvider
The Deployer associated with this ActorRefProvider
Deployer - Class in akka.actor
Deployer maps actor paths to actor deployments.
Deployer(ActorSystem.Settings, DynamicAccess) - Constructor for class akka.actor.Deployer
 
deployer() - Method in class akka.actor.LocalActorRefProvider
 
deployer() - Method in class akka.remote.RemoteActorRefProvider
 
deployments(RoleName) - Method in class akka.remote.testkit.MultiNodeConfig
 
deployOn(RoleName, String) - Method in class akka.remote.testkit.MultiNodeConfig
 
deployOnAll(String) - Method in class akka.remote.testkit.MultiNodeConfig
 
DeprecatedRouterConfig - Interface in akka.routing
 
DequeBasedMessageQueue - Interface in akka.dispatch
 
DequeBasedMessageQueueSemantics - Interface in akka.dispatch
DequeBasedMessageQueue refines QueueBasedMessageQueue to be backed by a java.util.Deque.
dequeue() - Method in class akka.actor.mailbox.filebased.FileBasedMessageQueue
 
dequeue() - Method in class akka.contrib.mailbox.PeekMailbox
 
dequeue() - Method in interface akka.dispatch.BoundedDequeBasedMessageQueue
 
dequeue() - Method in interface akka.dispatch.BoundedQueueBasedMessageQueue
 
dequeue() - Method in class akka.dispatch.Mailbox
Try to dequeue the next message from this queue, return null failing that.
dequeue() - Method in interface akka.dispatch.MessageQueue
Try to dequeue the next message from this queue, return null failing that.
dequeue() - Method in class akka.dispatch.NodeMessageQueue
 
dequeue() - Method in interface akka.dispatch.UnboundedDequeBasedMessageQueue
 
dequeue() - Method in interface akka.dispatch.UnboundedQueueBasedMessageQueue
 
dequeue() - Method in class akka.testkit.CallingThreadMailbox
 
deregisterAssociation(Tuple2<Address, Address>) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Removes an association.
descendant(Iterable<String>) - Method in interface akka.actor.ActorPath
Java API: Recursively create a descendant&rsquo;s path by appending all child names.
descendant(Iterable<String>) - Method in class akka.actor.ActorSystem
Java API: Recursively create a descendant&rsquo;s path by appending all child names.
deserialize(byte[]) - Method in interface akka.actor.mailbox.DurableMessageSerialization
Deserializes an array of Bytes that were serialized using the DurableMessageSerialization.serialize method, into an Envelope.
deserialize(InputStream) - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
 
deserialize(ExtendedActorSystem, WireFormats.SerializedMessage) - Method in class akka.remote.MessageSerializer$
Uses Akka Serialization for the specified ActorSystem to transform the given MessageProtocol to a message
deserialize(ExtendedActorSystem, WireFormats.SerializedMessage) - Static method in class akka.remote.MessageSerializer
Uses Akka Serialization for the specified ActorSystem to transform the given MessageProtocol to a message
deserialize(com.google.protobuf.ByteString, Class<T>, ClassTag<T>) - Method in class akka.remote.serialization.DaemonMsgCreateSerializer
 
deserialize(byte[], int, Option<Class<? extends T>>) - Method in class akka.serialization.Serialization
Deserializes the given array of bytes using the specified serializer id, using the optional type hint to the Serializer and the optional ClassLoader ot load it into.
deserialize(byte[], Class<T>) - Method in class akka.serialization.Serialization
Deserializes the given array of bytes using the specified type to look up what Serializer should be used.
deserializeActorRef(ExtendedActorSystem, WireFormats.ActorRefData) - Method in class akka.remote.serialization.ProtobufSerializer$
Helper to materialize (lookup) an ActorRef from Akka's protobuf representation in the supplied ActorSystem.
deserializeActorRef(ExtendedActorSystem, WireFormats.ActorRefData) - Static method in class akka.remote.serialization.ProtobufSerializer
Helper to materialize (lookup) an ActorRef from Akka's protobuf representation in the supplied ActorSystem.
Deserializer - Interface in akka.zeromq
A base trait for message deserializers
destination() - Method in class akka.persistence.AtLeastOnceDelivery.Internal$.Delivery
 
destination() - Method in class akka.persistence.AtLeastOnceDelivery.UnconfirmedDelivery
 
destination() - Method in class akka.persistence.Deliver
 
destination() - Method in class akka.persistence.ReliableDelivery.DeliveryAttempt
 
DESTINATION_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
DESTINATION_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.DeliverMessage
 
destroyJournal() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
detach(ActorCell) - Method in class akka.dispatch.MessageDispatcher
Detaches the specified actor instance from this dispatcher
DiagnosticActorLogging - Interface in akka.actor
Scala API: Mix in DiagnosticActorLogging into your Actor to easily obtain a reference to a logger with MDC support, which is available under the name "log".
DiagnosticLoggingAdapter - Interface in akka.event
LoggingAdapter extension which adds MDC support.
diffLeader(Gossip, Gossip, UniqueAddress) - Method in class akka.cluster.ClusterEvent$
INTERNAL API
diffLeader(Gossip, Gossip, UniqueAddress) - Static method in class akka.cluster.ClusterEvent
INTERNAL API
diffMemberEvents(Gossip, Gossip) - Method in class akka.cluster.ClusterEvent$
INTERNAL API.
diffMemberEvents(Gossip, Gossip) - Static method in class akka.cluster.ClusterEvent
INTERNAL API.
diffReachability(Gossip, Gossip) - Method in class akka.cluster.ClusterEvent$
INTERNAL API
diffReachability(Gossip, Gossip) - Static method in class akka.cluster.ClusterEvent
INTERNAL API
diffReachable(Gossip, Gossip, UniqueAddress) - Method in class akka.cluster.ClusterEvent$
INTERNAL API
diffReachable(Gossip, Gossip, UniqueAddress) - Static method in class akka.cluster.ClusterEvent
INTERNAL API
diffRolesLeader(Gossip, Gossip, UniqueAddress) - Method in class akka.cluster.ClusterEvent$
INTERNAL API
diffRolesLeader(Gossip, Gossip, UniqueAddress) - Static method in class akka.cluster.ClusterEvent
INTERNAL API
diffSeen(Gossip, Gossip, UniqueAddress) - Method in class akka.cluster.ClusterEvent$
INTERNAL API
diffSeen(Gossip, Gossip, UniqueAddress) - Static method in class akka.cluster.ClusterEvent
INTERNAL API
diffUnreachable(Gossip, Gossip, UniqueAddress) - Method in class akka.cluster.ClusterEvent$
INTERNAL API
diffUnreachable(Gossip, Gossip, UniqueAddress) - Static method in class akka.cluster.ClusterEvent
INTERNAL API
digest(byte[], MessageDigest) - Method in class akka.util.Crypt$
 
digest(byte[], MessageDigest) - Static method in class akka.util.Crypt
 
dilated(Duration) - Method in class akka.testkit.JavaTestKit
 
dilated(Duration, ActorSystem) - Method in class akka.testkit.TestKit$
Java API: Scale timeouts (durations) during tests with the configured 'akka.test.timefactor'.
dilated(Duration, ActorSystem) - Static method in class akka.testkit.TestKit
Java API: Scale timeouts (durations) during tests with the configured 'akka.test.timefactor'.
DirectBufferSize() - Method in class akka.io.TcpExt.Settings
 
DirectBufferSize() - Method in class akka.io.Udp.UdpSettings
 
DirectByteBufferPool - Class in akka.io
INTERNAL API
DirectByteBufferPool(int, int) - Constructor for class akka.io.DirectByteBufferPool
 
direction() - Method in class akka.remote.testconductor.Throttle
 
direction() - Method in class akka.remote.testconductor.ThrottleMsg
 
direction() - Method in class akka.remote.transport.ThrottlerTransportAdapter.SetThrottle
 
direction2proto(ThrottlerTransportAdapter.Direction) - Method in class akka.remote.testconductor.MsgEncoder
 
direction2scala(TestConductorProtocol.Direction) - Method in class akka.remote.testconductor.MsgDecoder
 
DIRECTION_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
disableInterest(int) - Method in interface akka.io.ChannelRegistration
 
disassociate() - Method in class akka.remote.transport.AkkaProtocolHandle
 
disassociate(AssociationHandle.DisassociateInfo) - Method in class akka.remote.transport.AkkaProtocolHandle
 
disassociate() - Method in interface akka.remote.transport.AssociationHandle
Closes the underlying transport link, if needed.
disassociate() - Method in class akka.remote.transport.FailureInjectorHandle
 
disassociate() - Method in class akka.remote.transport.netty.TcpAssociationHandle
 
disassociate() - Method in class akka.remote.transport.netty.UdpAssociationHandle
 
disassociate() - Method in class akka.remote.transport.TestAssociationHandle
 
disassociate(TestAssociationHandle) - Method in class akka.remote.transport.TestTransport
 
disassociate() - Method in class akka.remote.transport.ThrottlerHandle
 
DISASSOCIATE_QUARANTINED_VALUE - Static variable in enum akka.remote.WireFormats.CommandType
DISASSOCIATE_QUARANTINED = 5;
DISASSOCIATE_SHUTTING_DOWN_VALUE - Static variable in enum akka.remote.WireFormats.CommandType
DISASSOCIATE_SHUTTING_DOWN = 4;
DISASSOCIATE_VALUE - Static variable in enum akka.remote.WireFormats.CommandType
DISASSOCIATE = 2;
disassociateBehavior() - Method in class akka.remote.transport.TestTransport
The TestTransport.SwitchableLoggedBehavior for the disassociate() method on handles.
DisassociatedEvent - Class in akka.remote
 
DisassociatedEvent(Address, Address, boolean) - Constructor for class akka.remote.DisassociatedEvent
 
DisassociatedEvent$ - Class in akka.remote
 
DisassociatedEvent$() - Constructor for class akka.remote.DisassociatedEvent$
 
disassociateWithFailure(AssociationHandle.DisassociateInfo) - Method in class akka.remote.transport.ThrottlerHandle
 
discardExpired() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
DiscardOldWhenFull() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
discardOldWhenFull() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
discardOldWhenFull() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
disconnect() - Method in class akka.io.UdpConnectedMessage$
Send this message to a connection actor (which had previously sent the UdpConnected.Connected message) in order to close the socket.
disconnect() - Static method in class akka.io.UdpConnectedMessage
Send this message to a connection actor (which had previously sent the UdpConnected.Connected message) in order to close the socket.
disconnect(RoleName, RoleName) - Method in interface akka.remote.testconductor.Conductor
Tell the remote support to shutdown the connection to the given remote peer.
Disconnect - Class in akka.remote.testconductor
 
Disconnect(RoleName, RoleName, boolean) - Constructor for class akka.remote.testconductor.Disconnect
 
Disconnect$ - Class in akka.remote.testconductor
 
Disconnect$() - Constructor for class akka.remote.testconductor.Disconnect$
 
Disconnect_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.FailType
Disconnect = 2;
DisconnectMsg - Class in akka.remote.testconductor
 
DisconnectMsg(Address, boolean) - Constructor for class akka.remote.testconductor.DisconnectMsg
 
DisconnectMsg$ - Class in akka.remote.testconductor
 
DisconnectMsg$() - Constructor for class akka.remote.testconductor.DisconnectMsg$
 
Dispatch - Interface in akka.actor.dungeon
 
dispatch(ActorCell, Envelope) - Method in class akka.dispatch.BalancingDispatcher
 
dispatch(ActorCell, Envelope) - Method in class akka.dispatch.Dispatcher
INTERNAL API
dispatch(ActorCell, Envelope) - Method in class akka.dispatch.MessageDispatcher
Will be called when the dispatcher is to queue an invocation for execution
dispatch(InternalActorRef, Address, WireFormats.SerializedMessage, Option<ActorRef>) - Method in class akka.remote.DefaultMessageDispatcher
 
dispatch(InternalActorRef, Address, WireFormats.SerializedMessage, Option<ActorRef>) - Method in interface akka.remote.InboundMessageDispatcher
 
dispatch(ActorCell, Envelope) - Method in class akka.testkit.CallingThreadDispatcher
 
dispatcher() - Method in class akka.actor.ActorCell
 
dispatcher() - Method in interface akka.actor.ActorContext
Returns the dispatcher (MessageDispatcher) that is used for this Actor.
dispatcher() - Method in interface akka.actor.ActorRefFactory
Returns the default MessageDispatcher associated with this ActorRefFactory
dispatcher() - Method in class akka.actor.ActorSystem
Default dispatcher as configured.
dispatcher() - Method in class akka.actor.ActorSystemImpl
 
dispatcher() - Method in class akka.actor.Deploy
 
dispatcher() - Method in class akka.actor.Props
Convenience method for extracting the dispatcher information from the contained Deploy instance.
dispatcher() - Method in class akka.actor.RepointableActorRef
 
dispatcher() - Method in class akka.actor.TypedActor$
Returns the default dispatcher (for a TypedActor) when inside a method call in a TypedActor.
dispatcher() - Static method in class akka.actor.TypedActor
Returns the default dispatcher (for a TypedActor) when inside a method call in a TypedActor.
dispatcher() - Method in class akka.actor.TypedProps
 
dispatcher() - Method in class akka.dispatch.BalancingDispatcherConfigurator
Returns the same dispatcher instance for each invocation
Dispatcher - Class in akka.dispatch
The event-based Dispatcher binds a set of Actors to a thread pool backed up by a BlockingQueue.
Dispatcher(MessageDispatcherConfigurator, String, int, Duration, ExecutorServiceFactoryProvider, FiniteDuration) - Constructor for class akka.dispatch.Dispatcher
 
dispatcher() - Method in class akka.dispatch.DispatcherConfigurator
Returns the same dispatcher instance for each invocation
dispatcher() - Method in class akka.dispatch.Mailbox
 
dispatcher() - Method in class akka.dispatch.MessageDispatcherConfigurator
Returns an instance of MessageDispatcher given the configuration.
dispatcher() - Method in class akka.dispatch.PinnedDispatcherConfigurator
Creates new dispatcher for each invocation.
Dispatcher() - Method in class akka.remote.RemoteSettings
 
dispatcher() - Method in class akka.testkit.CallingThreadDispatcherConfigurator
 
dispatcher() - Method in class akka.testkit.TestActorRef
 
DISPATCHER_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DeployData
 
DispatcherConfigurator - Class in akka.dispatch
Configurator for creating Dispatcher.
DispatcherConfigurator(com.typesafe.config.Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.DispatcherConfigurator
 
DispatcherPrerequisites - Interface in akka.dispatch
DispatcherPrerequisites represents useful contextual pieces when constructing a MessageDispatcher
dispatchers() - Method in class akka.actor.ActorSystem
Helper object for looking up configured dispatchers.
dispatchers() - Method in class akka.actor.ActorSystemImpl
 
Dispatchers - Class in akka.dispatch
Dispatchers are to be defined in configuration to allow for tuning for different environments.
Dispatchers(ActorSystem.Settings, DispatcherPrerequisites) - Constructor for class akka.dispatch.Dispatchers
 
Dispatchers$ - Class in akka.dispatch
 
Dispatchers$() - Constructor for class akka.dispatch.Dispatchers$
 
displayThreadCounts() - Method in interface akka.testkit.WatchedByCoroner
 
dissociate(ActorRef) - Method in interface akka.event.ActorClassification
 
dissociate(ActorRef, ActorRef) - Method in interface akka.event.ActorClassification
 
DistributedPubSubExtension - Class in akka.contrib.pattern
 
DistributedPubSubExtension(ExtendedActorSystem) - Constructor for class akka.contrib.pattern.DistributedPubSubExtension
 
DistributedPubSubExtension$ - Class in akka.contrib.pattern
Extension that starts a DistributedPubSubMediator actor with settings defined in config section akka.contrib.cluster.pub-sub.
DistributedPubSubExtension$() - Constructor for class akka.contrib.pattern.DistributedPubSubExtension$
 
DistributedPubSubMediator - Class in akka.contrib.pattern
This actor manages a registry of actor references and replicates the entries to peer actors among all cluster nodes or a group of nodes tagged with a specific role.
DistributedPubSubMediator(Option<String>, RoutingLogic, FiniteDuration, FiniteDuration, int) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator
 
DistributedPubSubMediator$ - Class in akka.contrib.pattern
 
DistributedPubSubMediator$() - Constructor for class akka.contrib.pattern.DistributedPubSubMediator$
 
DistributedPubSubMediator.Count$ - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Count$() - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Count$
 
DistributedPubSubMediator.Internal$ - Class in akka.contrib.pattern
INTERNAL API
DistributedPubSubMediator.Internal$() - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Internal$
 
DistributedPubSubMediator.Internal$.Bucket - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Internal$.Bucket(Address, long, TreeMap<String, akka.contrib.pattern.DistributedPubSubMediator.Internal.ValueHolder>) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Internal$.Bucket
 
DistributedPubSubMediator.Internal$.Delta - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Internal$.Delta(Iterable<akka.contrib.pattern.DistributedPubSubMediator.Internal.Bucket>) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Internal$.Delta
 
DistributedPubSubMediator.Internal$.GossipTick - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Internal$.GossipTick() - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Internal$.GossipTick
 
DistributedPubSubMediator.Internal$.Group - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Internal$.Group(FiniteDuration, RoutingLogic) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Internal$.Group
 
DistributedPubSubMediator.Internal$.MediatorRouterEnvelope - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Internal$.MediatorRouterEnvelope(Object) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Internal$.MediatorRouterEnvelope
 
DistributedPubSubMediator.Internal$.Prune - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Internal$.Prune() - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Internal$.Prune
 
DistributedPubSubMediator.Internal$.RegisterTopic - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Internal$.RegisterTopic(ActorRef) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Internal$.RegisterTopic
 
DistributedPubSubMediator.Internal$.SendToOneSubscriber - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Internal$.SendToOneSubscriber(Object) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Internal$.SendToOneSubscriber
 
DistributedPubSubMediator.Internal$.Status - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Internal$.Status(Map<Address, Object>) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Internal$.Status
 
DistributedPubSubMediator.Internal$.Subscribed - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Internal$.Subscribed(DistributedPubSubMediator.SubscribeAck, ActorRef) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Internal$.Subscribed
 
DistributedPubSubMediator.Internal$.Topic - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Internal$.Topic(FiniteDuration, RoutingLogic) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Internal$.Topic
 
DistributedPubSubMediator.Internal$.TopicLike - Interface in akka.contrib.pattern
 
DistributedPubSubMediator.Internal$.Unsubscribed - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Internal$.Unsubscribed(DistributedPubSubMediator.UnsubscribeAck, ActorRef) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Internal$.Unsubscribed
 
DistributedPubSubMediator.Internal$.ValueHolder - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Internal$.ValueHolder(long, Option<ActorRef>) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Internal$.ValueHolder
 
DistributedPubSubMediator.Publish - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Publish(String, Object, boolean) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Publish
 
DistributedPubSubMediator.Publish(String, Object) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Publish
 
DistributedPubSubMediator.Publish$ - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Publish$() - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Publish$
 
DistributedPubSubMediator.Put - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Put(ActorRef) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Put
 
DistributedPubSubMediator.Put$ - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Put$() - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Put$
 
DistributedPubSubMediator.Remove - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Remove(String) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Remove
 
DistributedPubSubMediator.Remove$ - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Remove$() - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Remove$
 
DistributedPubSubMediator.Send - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Send(String, Object, boolean) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Send
 
DistributedPubSubMediator.Send(String, Object) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Send
Convenience constructor with localAffinity false
DistributedPubSubMediator.Send$ - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Send$() - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Send$
 
DistributedPubSubMediator.SendToAll - Class in akka.contrib.pattern
 
DistributedPubSubMediator.SendToAll(String, Object, boolean) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.SendToAll
 
DistributedPubSubMediator.SendToAll(String, Object) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.SendToAll
 
DistributedPubSubMediator.SendToAll$ - Class in akka.contrib.pattern
 
DistributedPubSubMediator.SendToAll$() - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.SendToAll$
 
DistributedPubSubMediator.Subscribe - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Subscribe(String, Option<String>, ActorRef) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Subscribe
 
DistributedPubSubMediator.Subscribe(String, ActorRef) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Subscribe
Convenience constructor with group None
DistributedPubSubMediator.Subscribe(String, String, ActorRef) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Subscribe
Java API: constructor with group: String
DistributedPubSubMediator.Subscribe$ - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Subscribe$() - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Subscribe$
 
DistributedPubSubMediator.SubscribeAck - Class in akka.contrib.pattern
 
DistributedPubSubMediator.SubscribeAck(DistributedPubSubMediator.Subscribe) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.SubscribeAck
 
DistributedPubSubMediator.SubscribeAck$ - Class in akka.contrib.pattern
 
DistributedPubSubMediator.SubscribeAck$() - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.SubscribeAck$
 
DistributedPubSubMediator.Unsubscribe - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Unsubscribe(String, Option<String>, ActorRef) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Unsubscribe
 
DistributedPubSubMediator.Unsubscribe(String, ActorRef) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Unsubscribe
 
DistributedPubSubMediator.Unsubscribe(String, String, ActorRef) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Unsubscribe
 
DistributedPubSubMediator.Unsubscribe$ - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Unsubscribe$() - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Unsubscribe$
 
DistributedPubSubMediator.UnsubscribeAck - Class in akka.contrib.pattern
 
DistributedPubSubMediator.UnsubscribeAck(DistributedPubSubMediator.Unsubscribe) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.UnsubscribeAck
 
DistributedPubSubMediator.UnsubscribeAck$ - Class in akka.contrib.pattern
 
DistributedPubSubMediator.UnsubscribeAck$() - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.UnsubscribeAck$
 
DistributedPubSubMessage - Interface in akka.contrib.pattern
Marker trait for remote messages with special serializer.
DistributedPubSubMessages - Class in akka.contrib.pattern.protobuf.msg
 
DistributedPubSubMessages.Address - Class in akka.contrib.pattern.protobuf.msg
Protobuf type Address
DistributedPubSubMessages.Address.Builder - Class in akka.contrib.pattern.protobuf.msg
Protobuf type Address
DistributedPubSubMessages.AddressOrBuilder - Interface in akka.contrib.pattern.protobuf.msg
 
DistributedPubSubMessages.Delta - Class in akka.contrib.pattern.protobuf.msg
Protobuf type Delta
DistributedPubSubMessages.Delta.Bucket - Class in akka.contrib.pattern.protobuf.msg
Protobuf type Delta.Bucket
DistributedPubSubMessages.Delta.Bucket.Builder - Class in akka.contrib.pattern.protobuf.msg
Protobuf type Delta.Bucket
DistributedPubSubMessages.Delta.BucketOrBuilder - Interface in akka.contrib.pattern.protobuf.msg
 
DistributedPubSubMessages.Delta.Builder - Class in akka.contrib.pattern.protobuf.msg
Protobuf type Delta
DistributedPubSubMessages.Delta.Entry - Class in akka.contrib.pattern.protobuf.msg
Protobuf type Delta.Entry
DistributedPubSubMessages.Delta.Entry.Builder - Class in akka.contrib.pattern.protobuf.msg
Protobuf type Delta.Entry
DistributedPubSubMessages.Delta.EntryOrBuilder - Interface in akka.contrib.pattern.protobuf.msg
 
DistributedPubSubMessages.DeltaOrBuilder - Interface in akka.contrib.pattern.protobuf.msg
 
DistributedPubSubMessages.Payload - Class in akka.contrib.pattern.protobuf.msg
Protobuf type Payload
DistributedPubSubMessages.Payload.Builder - Class in akka.contrib.pattern.protobuf.msg
Protobuf type Payload
DistributedPubSubMessages.PayloadOrBuilder - Interface in akka.contrib.pattern.protobuf.msg
 
DistributedPubSubMessages.Publish - Class in akka.contrib.pattern.protobuf.msg
Protobuf type Publish
DistributedPubSubMessages.Publish.Builder - Class in akka.contrib.pattern.protobuf.msg
Protobuf type Publish
DistributedPubSubMessages.PublishOrBuilder - Interface in akka.contrib.pattern.protobuf.msg
 
DistributedPubSubMessages.Send - Class in akka.contrib.pattern.protobuf.msg
Protobuf type Send
DistributedPubSubMessages.Send.Builder - Class in akka.contrib.pattern.protobuf.msg
Protobuf type Send
DistributedPubSubMessages.SendOrBuilder - Interface in akka.contrib.pattern.protobuf.msg
 
DistributedPubSubMessages.SendToAll - Class in akka.contrib.pattern.protobuf.msg
Protobuf type SendToAll
DistributedPubSubMessages.SendToAll.Builder - Class in akka.contrib.pattern.protobuf.msg
Protobuf type SendToAll
DistributedPubSubMessages.SendToAllOrBuilder - Interface in akka.contrib.pattern.protobuf.msg
 
DistributedPubSubMessages.Status - Class in akka.contrib.pattern.protobuf.msg
Protobuf type Status
DistributedPubSubMessages.Status.Builder - Class in akka.contrib.pattern.protobuf.msg
Protobuf type Status
DistributedPubSubMessages.Status.Version - Class in akka.contrib.pattern.protobuf.msg
Protobuf type Status.Version
DistributedPubSubMessages.Status.Version.Builder - Class in akka.contrib.pattern.protobuf.msg
Protobuf type Status.Version
DistributedPubSubMessages.Status.VersionOrBuilder - Interface in akka.contrib.pattern.protobuf.msg
 
DistributedPubSubMessages.StatusOrBuilder - Interface in akka.contrib.pattern.protobuf.msg
 
DistributedPubSubMessageSerializer - Class in akka.contrib.pattern.protobuf
Protobuf serializer of DistributedPubSubMediator messages.
DistributedPubSubMessageSerializer(ExtendedActorSystem) - Constructor for class akka.contrib.pattern.protobuf.DistributedPubSubMessageSerializer
 
doCloseConnection(ActorRef, Option<ActorRef>, Tcp.ConnectionClosed) - Method in class akka.io.TcpConnection
 
doMatch(String, Object) - Method in class akka.testkit.EventFilter
internal implementation helper, no guaranteed API
done() - Method in class akka.cluster.JoinSeedNodeProcess
 
done() - Method in class akka.cluster.OnMemberUpListener
 
done(boolean) - Method in class akka.contrib.pattern.ShardCoordinator.RebalanceWorker
 
Done - Class in akka.remote.testconductor
 
Done() - Constructor for class akka.remote.testconductor.Done
 
done() - Method in class akka.routing.CollectRouteeRefs
 
Done$ - Class in akka.remote.testconductor
 
Done$() - Constructor for class akka.remote.testconductor.Done$
 
DONE_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
doNothing() - Method in class akka.dispatch.MonitorableThreadFactory$
 
doNothing() - Static method in class akka.dispatch.MonitorableThreadFactory
 
doNothing() - Method in class akka.io.TcpConnection$
 
doNothing() - Static method in class akka.io.TcpConnection
 
doNothing() - Method in interface akka.transactor.Transactor
Default catch-all for the different Receive methods.
doPatch() - Method in class akka.persistence.serialization.SnapshotSerializer$
 
doPatch() - Static method in class akka.persistence.serialization.SnapshotSerializer
 
doRead(TcpConnection.ConnectionInfo, Option<ActorRef>) - Method in class akka.io.TcpConnection
 
doRead(ChannelRegistration, ActorRef) - Method in class akka.io.UdpConnection
 
doReceive(ChannelRegistration, ActorRef) - Method in class akka.io.UdpListener
 
doSend(ChannelRegistration) - Method in interface akka.io.WithUdpSend
 
Double_VALUE - Static variable in enum akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberType
Double = 1;
down(Address) - Method in class akka.cluster.AutoDown
 
down(Address) - Method in class akka.cluster.AutoDownBase
 
down(Address) - Method in class akka.cluster.Cluster
Send command to DOWN the node specified by 'address'.
down(String) - Method in interface akka.cluster.ClusterNodeMBean
Send command to DOWN the node specified by 'address'.
down() - Method in class akka.cluster.MemberStatus$
Java API: retrieve the &ldquo;down&rdquo; status singleton
down() - Static method in class akka.cluster.MemberStatus
Java API: retrieve the &ldquo;down&rdquo; status singleton
Down_VALUE - Static variable in enum akka.cluster.protobuf.msg.ClusterMessages.MemberStatus
Down = 4;
downing(Address) - Method in class akka.cluster.ClusterCoreDaemon
State transition to DOWN.
downOrAddPending(UniqueAddress) - Method in class akka.cluster.AutoDownBase
 
doWrite(TcpConnection.ConnectionInfo) - Method in class akka.io.TcpConnection
 
doWrite(TcpConnection.ConnectionInfo) - Method in class akka.io.TcpConnection.EmptyPendingWrite$
 
doWrite(TcpConnection.ConnectionInfo) - Method in class akka.io.TcpConnection.PendingBufferWrite
 
doWrite(TcpConnection.ConnectionInfo) - Method in class akka.io.TcpConnection.PendingWrite
 
doWrite(TcpConnection.ConnectionInfo) - Method in class akka.io.TcpConnection.PendingWriteFile
 
doWrite() - Method in class akka.io.UdpConnection
 
drainTo(Collection<? super E>) - Method in class akka.util.BoundedBlockingQueue
 
drainTo(Collection<? super E>, int) - Method in class akka.util.BoundedBlockingQueue
 
drop(int) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
drop(int) - Method in class akka.util.ByteIterator
 
drop(int) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
drop(int) - Method in class akka.util.ByteString
 
dropRight(int) - Method in class akka.util.ByteString
 
dropWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
dropWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator
 
dropWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
dropWhile(Function1<Object, Object>) - Method in class akka.util.ByteString
 
DSLDefaultTimeout() - Method in class akka.actor.ActorDSL.Extension
 
DSLInboxQueueSize() - Method in interface akka.actor.dsl.Inbox.InboxExtension
 
DummyClassForStringSources - Class in akka.event
This is a &ldquo;marker&rdquo; class which is inserted as originator class into Logging.LogEvent when the string representation was supplied directly.
DummyClassForStringSources() - Constructor for class akka.event.DummyClassForStringSources
 
dumpConfig() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
dumpConfig(String) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
dumpItem(JournalItem) - Method in class akka.actor.mailbox.filebased.filequeue.tools.QueueDumper
 
dumpStats() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
duplicate() - Method in class akka.util.ByteIterator
 
DurableExecutableMailboxConfig - Class in akka.actor.mailbox
 
DurableExecutableMailboxConfig() - Constructor for class akka.actor.mailbox.DurableExecutableMailboxConfig
 
DurableExecutableMailboxConfig$ - Class in akka.actor.mailbox
 
DurableExecutableMailboxConfig$() - Constructor for class akka.actor.mailbox.DurableExecutableMailboxConfig$
 
DurableMailboxSettings - Interface in akka.actor.mailbox
Conventional organization of durable mailbox settings:
DurableMailboxSpec - Class in akka.actor.mailbox
Reusable test fixture for durable mailboxes.
DurableMailboxSpec(ActorSystem, String) - Constructor for class akka.actor.mailbox.DurableMailboxSpec
 
DurableMailboxSpec(String, String) - Constructor for class akka.actor.mailbox.DurableMailboxSpec
Subclass must define dispatcher in the supplied config for the specific backend.
DurableMailboxSpec$ - Class in akka.actor.mailbox
 
DurableMailboxSpec$() - Constructor for class akka.actor.mailbox.DurableMailboxSpec$
 
DurableMailboxSpecActorFactory - Class in akka.actor.mailbox
 
DurableMailboxSpecActorFactory() - Constructor for class akka.actor.mailbox.DurableMailboxSpecActorFactory
 
DurableMailboxSpecActorFactory$ - Class in akka.actor.mailbox
 
DurableMailboxSpecActorFactory$() - Constructor for class akka.actor.mailbox.DurableMailboxSpecActorFactory$
 
DurableMailboxSpecActorFactory.AccumulatorActor - Class in akka.actor.mailbox
 
DurableMailboxSpecActorFactory.AccumulatorActor() - Constructor for class akka.actor.mailbox.DurableMailboxSpecActorFactory.AccumulatorActor
 
DurableMailboxSpecActorFactory.MailboxTestActor - Class in akka.actor.mailbox
 
DurableMailboxSpecActorFactory.MailboxTestActor() - Constructor for class akka.actor.mailbox.DurableMailboxSpecActorFactory.MailboxTestActor
 
DurableMessageQueue - Class in akka.actor.mailbox
 
DurableMessageQueue(ActorRef, ExtendedActorSystem) - Constructor for class akka.actor.mailbox.DurableMessageQueue
 
DurableMessageQueueWithSerialization - Class in akka.actor.mailbox
Java API DurableMessageQueue with functionality to serialize and deserialize Envelopes (messages)
DurableMessageQueueWithSerialization(ActorRef, ExtendedActorSystem) - Constructor for class akka.actor.mailbox.DurableMessageQueueWithSerialization
 
DurableMessageSerialization - Interface in akka.actor.mailbox
DurableMessageSerialization can be mixed into a DurableMessageQueue and adds functionality to serialize and deserialize Envelopes (messages)
duration() - Method in class akka.contrib.throttle.Throttler.Rate
 
duration(String) - Static method in class akka.testkit.JavaTestKit
 
duration() - Method in class akka.util.Timeout
 
duration() - Method in class akka.zeromq.PollTimeoutDuration
 
durationInMillis() - Method in class akka.contrib.throttle.Throttler.Rate
The duration in milliseconds.
durationToTimeout(FiniteDuration) - Method in class akka.util.Timeout$
 
durationToTimeout(FiniteDuration) - Static method in class akka.util.Timeout
 
DurationTypeConverter - Class in akka.camel.internal.component
INTERNAL API Converts Strings to Duration
DurationTypeConverter() - Constructor for class akka.camel.internal.component.DurationTypeConverter
 
DurationTypeConverter$ - Class in akka.camel.internal.component
INTERNAL API Converts Strings to Duration
DurationTypeConverter$() - Constructor for class akka.camel.internal.component.DurationTypeConverter$
 
dynamicAccess() - Method in class akka.actor.ActorSystemImpl
 
dynamicAccess() - Method in class akka.actor.Deployer
 
DynamicAccess - Class in akka.actor
The DynamicAccess implementation is the class which is used for loading all configurable parts of an actor system (the ReflectiveDynamicAccess is the default implementation).
DynamicAccess() - Constructor for class akka.actor.DynamicAccess
 
dynamicAccess() - Method in class akka.actor.ExtendedActorSystem
ClassLoader wrapper which is used for reflective accesses internally.
dynamicAccess() - Method in class akka.actor.LocalActorRefProvider
 
dynamicAccess() - Method in class akka.dispatch.DefaultDispatcherPrerequisites
 
dynamicAccess() - Method in interface akka.dispatch.DispatcherPrerequisites
 
dynamicAccess() - Method in class akka.remote.RemoteActorRefProvider
 

E

e() - Method in class akka.io.TcpConnection.WriteFileFailed
 
each(T) - Method in class akka.dispatch.Foreach
This method will be invoked once when/if a Future that this callback is registered on becomes successfully completed
EarliestFirstSystemMessageList - Class in akka.dispatch.sysmsg
INTERNAL API
EarliestFirstSystemMessageList(SystemMessage) - Constructor for class akka.dispatch.sysmsg.EarliestFirstSystemMessageList
 
EarliestFirstSystemMessageList$ - Class in akka.dispatch.sysmsg
 
EarliestFirstSystemMessageList$() - Constructor for class akka.dispatch.sysmsg.EarliestFirstSystemMessageList$
 
ec() - Method in class akka.remote.transport.AbstractTransportAdapter
 
echoActorProps() - Method in class akka.testkit.TestActors$
 
echoActorProps() - Static method in class akka.testkit.TestActors
 
Effect - Interface in akka.japi
An executable piece of code that takes no parameters and doesn't return any value.
Effect - Interface in akka.japi.function
An executable piece of code that takes no parameters and doesn't return any value.
ElementRegex() - Method in class akka.actor.ActorPath$
 
elements() - Method in interface akka.actor.ActorPath
Sequence of names for this path from root to this.
elements() - Method in class akka.actor.ActorSelectionMessage
 
elements() - Method in class akka.actor.ChildActorPath
 
elements() - Method in class akka.actor.RootActorPath
 
empty() - Method in class akka.actor.Props$
A Props instance whose creator will create an actor that doesn't respond to any message
empty() - Static method in class akka.actor.Props
A Props instance whose creator will create an actor that doesn't respond to any message
empty() - Method in class akka.cluster.Gossip$
 
empty() - Static method in class akka.cluster.Gossip
 
empty() - Method in class akka.cluster.MetricsGossip$
 
empty() - Static method in class akka.cluster.MetricsGossip
 
empty() - Method in class akka.cluster.Reachability$
 
empty() - Static method in class akka.cluster.Reachability
 
empty() - Method in class akka.contrib.pattern.ShardCoordinator.Internal$.State
 
empty() - Method in class akka.contrib.pattern.WorkList$
 
empty() - Static method in class akka.contrib.pattern.WorkList
 
empty() - Method in interface akka.event.ActorClassification
 
empty() - Method in class akka.io.Tcp.Write$
The empty Write doesn't write anything and isn't acknowledged.
empty() - Method in class akka.japi.pf.CaseStatement$
 
empty() - Static method in class akka.japi.pf.CaseStatement
 
empty() - Method in class akka.remote.RemoteWatcher.Stats$
 
empty() - Method in class akka.util.ByteIterator.ByteArrayIterator$
 
empty() - Method in class akka.util.ByteIterator.MultiByteArrayIterator$
 
empty() - Method in class akka.util.ByteString$
 
empty() - Method in class akka.util.ByteString.ByteString1$
 
empty() - Static method in class akka.util.ByteString
 
empty() - Method in class akka.util.CompactByteString$
 
empty() - Static method in class akka.util.CompactByteString
 
empty() - Method in class akka.zeromq.ZMQMessage$
 
empty() - Static method in class akka.zeromq.ZMQMessage
 
emptyActorPath() - Method in class akka.actor.ActorPath$
 
emptyActorRefSet() - Method in class akka.actor.ActorCell$
 
emptyActorRefSet() - Static method in class akka.actor.ActorCell
 
emptyBehavior() - Method in class akka.actor.AbstractActor$
emptyBehavior is a Receive-expression that matches no messages at all, ever.
emptyBehavior() - Static method in class akka.actor.AbstractActor
emptyBehavior is a Receive-expression that matches no messages at all, ever.
emptyBehaviorStack() - Method in class akka.actor.ActorCell$
 
emptyBehaviorStack() - Static method in class akka.actor.ActorCell
 
emptyCancellable() - Method in class akka.actor.ActorCell$
 
emptyCancellable() - Static method in class akka.actor.ActorCell
 
emptyConfig() - Method in class akka.dispatch.CachingConfig$
 
emptyConfig() - Static method in class akka.dispatch.CachingConfig
 
EmptyLocalActorRef - Class in akka.actor
This special dead letter reference has a name: it is that which is returned by a local look-up which is unsuccessful.
EmptyLocalActorRef(ActorRefProvider, ActorPath, EventStream) - Constructor for class akka.actor.EmptyLocalActorRef
 
emptyMDC() - Method in class akka.event.Logging$
 
emptyMDC() - Static method in class akka.event.Logging
 
emptyMembers() - Method in class akka.cluster.Gossip$
 
emptyMembers() - Static method in class akka.cluster.Gossip
 
emptyMergeMap() - Method in class akka.util.SubclassifiedIndex$
 
emptyMergeMap() - Static method in class akka.util.SubclassifiedIndex
 
emptyPathEntry() - Method in class akka.dispatch.CachingConfig$
 
emptyPathEntry() - Static method in class akka.dispatch.CachingConfig
 
EmptyReceive - Class in akka.transactor
INTERNAL API
EmptyReceive() - Constructor for class akka.transactor.EmptyReceive
 
EmptyReceive$ - Class in akka.transactor
INTERNAL API
EmptyReceive$() - Constructor for class akka.transactor.EmptyReceive$
 
emptyReceiveTimeoutData() - Method in class akka.actor.dungeon.ReceiveTimeout$
 
emptyStats() - Method in interface akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer
 
emptyTimeToLive() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Internal$.Group
 
emptyTimeToLive() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Internal$.Topic
 
emptyTimeToLive() - Method in interface akka.contrib.pattern.DistributedPubSubMediator.Internal$.TopicLike
 
enabled() - Method in interface akka.contrib.pattern.ReliableProxyDebugLogging
 
enableInterest(int) - Method in interface akka.io.ChannelRegistration
 
EnableSsl() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
ENCLOSEDMESSAGE_FIELD_NUMBER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
ENCLOSEDMESSAGE_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.SelectionEnvelope
 
encName(String) - Method in class akka.contrib.pattern.DistributedPubSubMediator.Internal$
 
encode(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.Channel, Object) - Method in class akka.remote.testconductor.MsgEncoder
 
encodePdu(AkkaPduCodec.AkkaPdu) - Method in interface akka.remote.transport.AkkaPduCodec
Takes an AkkaPduCodec.AkkaPdu representation of an Akka PDU and returns its encoded form as a ByteString.
end() - Method in interface akka.testkit.TestKitBase
 
EndMarker() - Method in class akka.cluster.VectorClock.Timestamp$
 
endpoint() - Method in class akka.camel.internal.CamelSupervisor.CamelProducerObjects
 
endpoint() - Method in class akka.camel.internal.component.ActorProducer
 
endpoint() - Method in class akka.remote.EndpointManager.Pass
 
endpoint() - Method in class akka.zeromq.Bind
 
endpoint() - Method in class akka.zeromq.Connect
 
endpoint() - Method in interface akka.zeromq.SocketConnectOption
 
EndpointActor - Class in akka.remote
INTERNAL API
EndpointActor(Address, Address, Transport, RemoteSettings, AkkaPduCodec) - Constructor for class akka.remote.EndpointActor
 
EndpointAssociationException - Exception in akka.remote
INTERNAL API
EndpointAssociationException(String, Throwable) - Constructor for exception akka.remote.EndpointAssociationException
 
EndpointDisassociatedException - Exception in akka.remote
INTERNAL API
EndpointDisassociatedException(String) - Constructor for exception akka.remote.EndpointDisassociatedException
 
EndpointException - Exception in akka.remote
INTERNAL API
EndpointException(String, Throwable) - Constructor for exception akka.remote.EndpointException
 
EndpointException(String) - Constructor for exception akka.remote.EndpointException
 
endpointId() - Method in class akka.remote.EndpointManager
 
EndpointManager - Class in akka.remote
INTERNAL API
EndpointManager(com.typesafe.config.Config, LoggingAdapter) - Constructor for class akka.remote.EndpointManager
 
EndpointManager$ - Class in akka.remote
INTERNAL API
EndpointManager$() - Constructor for class akka.remote.EndpointManager$
 
EndpointManager.EndpointPolicy - Interface in akka.remote
 
EndpointManager.EndpointRegistry - Class in akka.remote
 
EndpointManager.EndpointRegistry() - Constructor for class akka.remote.EndpointManager.EndpointRegistry
 
EndpointManager.Gated - Class in akka.remote
 
EndpointManager.Gated(Deadline) - Constructor for class akka.remote.EndpointManager.Gated
 
EndpointManager.Gated$ - Class in akka.remote
 
EndpointManager.Gated$() - Constructor for class akka.remote.EndpointManager.Gated$
 
EndpointManager.Link - Class in akka.remote
 
EndpointManager.Link(Address, Address) - Constructor for class akka.remote.EndpointManager.Link
 
EndpointManager.Link$ - Class in akka.remote
 
EndpointManager.Link$() - Constructor for class akka.remote.EndpointManager.Link$
 
EndpointManager.Listen - Class in akka.remote
 
EndpointManager.Listen(Promise<Seq<Tuple2<AkkaProtocolTransport, Address>>>) - Constructor for class akka.remote.EndpointManager.Listen
 
EndpointManager.Listen$ - Class in akka.remote
 
EndpointManager.Listen$() - Constructor for class akka.remote.EndpointManager.Listen$
 
EndpointManager.ListensFailure - Class in akka.remote
 
EndpointManager.ListensFailure(Promise<Seq<Tuple2<AkkaProtocolTransport, Address>>>, Throwable) - Constructor for class akka.remote.EndpointManager.ListensFailure
 
EndpointManager.ListensFailure$ - Class in akka.remote
 
EndpointManager.ListensFailure$() - Constructor for class akka.remote.EndpointManager.ListensFailure$
 
EndpointManager.ListensResult - Class in akka.remote
 
EndpointManager.ListensResult(Promise<Seq<Tuple2<AkkaProtocolTransport, Address>>>, Seq<Tuple3<AkkaProtocolTransport, Address, Promise<Transport.AssociationEventListener>>>) - Constructor for class akka.remote.EndpointManager.ListensResult
 
EndpointManager.ListensResult$ - Class in akka.remote
 
EndpointManager.ListensResult$() - Constructor for class akka.remote.EndpointManager.ListensResult$
 
EndpointManager.ManagementCommand - Class in akka.remote
 
EndpointManager.ManagementCommand(Object) - Constructor for class akka.remote.EndpointManager.ManagementCommand
 
EndpointManager.ManagementCommand$ - Class in akka.remote
 
EndpointManager.ManagementCommand$() - Constructor for class akka.remote.EndpointManager.ManagementCommand$
 
EndpointManager.ManagementCommandAck - Class in akka.remote
 
EndpointManager.ManagementCommandAck(boolean) - Constructor for class akka.remote.EndpointManager.ManagementCommandAck
 
EndpointManager.ManagementCommandAck$ - Class in akka.remote
 
EndpointManager.ManagementCommandAck$() - Constructor for class akka.remote.EndpointManager.ManagementCommandAck$
 
EndpointManager.Pass - Class in akka.remote
 
EndpointManager.Pass(ActorRef, Option<Object>, Option<Object>) - Constructor for class akka.remote.EndpointManager.Pass
 
EndpointManager.Pass$ - Class in akka.remote
 
EndpointManager.Pass$() - Constructor for class akka.remote.EndpointManager.Pass$
 
EndpointManager.Prune$ - Class in akka.remote
 
EndpointManager.Prune$() - Constructor for class akka.remote.EndpointManager.Prune$
 
EndpointManager.Quarantine - Class in akka.remote
 
EndpointManager.Quarantine(Address, Option<Object>) - Constructor for class akka.remote.EndpointManager.Quarantine
 
EndpointManager.Quarantine$ - Class in akka.remote
 
EndpointManager.Quarantine$() - Constructor for class akka.remote.EndpointManager.Quarantine$
 
EndpointManager.Quarantined - Class in akka.remote
 
EndpointManager.Quarantined(int, Deadline) - Constructor for class akka.remote.EndpointManager.Quarantined
 
EndpointManager.Quarantined$ - Class in akka.remote
 
EndpointManager.Quarantined$() - Constructor for class akka.remote.EndpointManager.Quarantined$
 
EndpointManager.RemotingCommand - Interface in akka.remote
 
EndpointManager.ResendState - Class in akka.remote
 
EndpointManager.ResendState(int, AckedReceiveBuffer<AkkaPduCodec.Message>) - Constructor for class akka.remote.EndpointManager.ResendState
 
EndpointManager.ResendState$ - Class in akka.remote
 
EndpointManager.ResendState$() - Constructor for class akka.remote.EndpointManager.ResendState$
 
EndpointManager.Send - Class in akka.remote
 
EndpointManager.Send(Object, Option<ActorRef>, RemoteActorRef, Option<SeqNo>) - Constructor for class akka.remote.EndpointManager.Send
 
EndpointManager.Send$ - Class in akka.remote
 
EndpointManager.Send$() - Constructor for class akka.remote.EndpointManager.Send$
 
EndpointManager.ShutdownAndFlush$ - Class in akka.remote
 
EndpointManager.ShutdownAndFlush$() - Constructor for class akka.remote.EndpointManager.ShutdownAndFlush$
 
EndpointManager.StartupFinished$ - Class in akka.remote
 
EndpointManager.StartupFinished$() - Constructor for class akka.remote.EndpointManager.StartupFinished$
 
EndpointManagerName() - Method in class akka.remote.Remoting$
 
EndpointManagerName() - Static method in class akka.remote.Remoting
 
EndpointReader - Class in akka.remote
INTERNAL API
EndpointReader(Address, Address, Transport, RemoteSettings, AkkaPduCodec, InboundMessageDispatcher, boolean, int, Option<ActorRef>, ConcurrentHashMap<EndpointManager.Link, EndpointManager.ResendState>) - Constructor for class akka.remote.EndpointReader
 
EndpointReader$ - Class in akka.remote
INTERNAL API
EndpointReader$() - Constructor for class akka.remote.EndpointReader$
 
endpoints() - Method in class akka.remote.EndpointManager
 
endpointUri() - Method in interface akka.camel.Consumer
Must return the Camel endpoint URI that the consumer wants to consume messages from.
endpointUri() - Method in class akka.camel.internal.CamelSupervisor.Register
 
endpointUri() - Method in class akka.camel.javaapi.UntypedConsumerActor
 
endpointUri() - Method in class akka.camel.javaapi.UntypedProducerActor
 
endpointUri() - Method in interface akka.camel.ProducerSupport
Returns the Camel endpoint URI to produce messages to.
EndpointWriter - Class in akka.remote
INTERNAL API
EndpointWriter(Option<AkkaProtocolHandle>, Address, Address, Option<Object>, AkkaProtocolTransport, RemoteSettings, AkkaPduCodec, ConcurrentHashMap<EndpointManager.Link, EndpointManager.ResendState>, Option<ActorRef>) - Constructor for class akka.remote.EndpointWriter
 
EndpointWriter$ - Class in akka.remote
INTERNAL API
EndpointWriter$() - Constructor for class akka.remote.EndpointWriter$
 
EndpointWriter.AckIdleCheckTimer$ - Class in akka.remote
 
EndpointWriter.AckIdleCheckTimer$() - Constructor for class akka.remote.EndpointWriter.AckIdleCheckTimer$
 
EndpointWriter.BackoffTimer$ - Class in akka.remote
 
EndpointWriter.BackoffTimer$() - Constructor for class akka.remote.EndpointWriter.BackoffTimer$
 
EndpointWriter.FlushAndStop$ - Class in akka.remote
 
EndpointWriter.FlushAndStop$() - Constructor for class akka.remote.EndpointWriter.FlushAndStop$
 
EndpointWriter.Handle - Class in akka.remote
 
EndpointWriter.Handle(AkkaProtocolHandle) - Constructor for class akka.remote.EndpointWriter.Handle
 
EndpointWriter.Handle$ - Class in akka.remote
 
EndpointWriter.Handle$() - Constructor for class akka.remote.EndpointWriter.Handle$
 
EndpointWriter.OutboundAck - Class in akka.remote
 
EndpointWriter.OutboundAck(Ack) - Constructor for class akka.remote.EndpointWriter.OutboundAck
 
EndpointWriter.OutboundAck$ - Class in akka.remote
 
EndpointWriter.OutboundAck$() - Constructor for class akka.remote.EndpointWriter.OutboundAck$
 
EndpointWriter.StoppedReading - Class in akka.remote
 
EndpointWriter.StoppedReading(ActorRef) - Constructor for class akka.remote.EndpointWriter.StoppedReading
 
EndpointWriter.StoppedReading$ - Class in akka.remote
 
EndpointWriter.StoppedReading$() - Constructor for class akka.remote.EndpointWriter.StoppedReading$
 
EndpointWriter.StopReading - Class in akka.remote
 
EndpointWriter.StopReading(ActorRef, ActorRef) - Constructor for class akka.remote.EndpointWriter.StopReading
 
EndpointWriter.StopReading$ - Class in akka.remote
 
EndpointWriter.StopReading$() - Constructor for class akka.remote.EndpointWriter.StopReading$
 
EndpointWriter.TakeOver - Class in akka.remote
This message signals that the current association maintained by the local EndpointWriter and EndpointReader is to be overridden by a new inbound association.
EndpointWriter.TakeOver(AkkaProtocolHandle, ActorRef) - Constructor for class akka.remote.EndpointWriter.TakeOver
 
EndpointWriter.TakeOver$ - Class in akka.remote
 
EndpointWriter.TakeOver$() - Constructor for class akka.remote.EndpointWriter.TakeOver$
 
EndpointWriter.TookOver - Class in akka.remote
 
EndpointWriter.TookOver(ActorRef, AkkaProtocolHandle) - Constructor for class akka.remote.EndpointWriter.TookOver
 
EndpointWriter.TookOver$ - Class in akka.remote
 
EndpointWriter.TookOver$() - Constructor for class akka.remote.EndpointWriter.TookOver$
 
engineGenerateSeed(int) - Method in class akka.remote.security.provider.AES128CounterInetRNG
Unused method Returns the given number of seed bytes.
engineGenerateSeed(int) - Method in class akka.remote.security.provider.AES128CounterSecureRNG
Unused method Returns the given number of seed bytes.
engineGenerateSeed(int) - Method in class akka.remote.security.provider.AES256CounterInetRNG
Unused method Returns the given number of seed bytes.
engineGenerateSeed(int) - Method in class akka.remote.security.provider.AES256CounterSecureRNG
Unused method Returns the given number of seed bytes.
engineNextBytes(byte[]) - Method in class akka.remote.security.provider.AES128CounterInetRNG
Generates a user-specified number of random bytes.
engineNextBytes(byte[]) - Method in class akka.remote.security.provider.AES128CounterSecureRNG
Generates a user-specified number of random bytes.
engineNextBytes(byte[]) - Method in class akka.remote.security.provider.AES256CounterInetRNG
Generates a user-specified number of random bytes.
engineNextBytes(byte[]) - Method in class akka.remote.security.provider.AES256CounterSecureRNG
Generates a user-specified number of random bytes.
engineSetSeed(byte[]) - Method in class akka.remote.security.provider.AES128CounterInetRNG
This is managed internally by AESCounterRNG
engineSetSeed(byte[]) - Method in class akka.remote.security.provider.AES128CounterSecureRNG
This is managed internally by AESCounterRNG
engineSetSeed(byte[]) - Method in class akka.remote.security.provider.AES256CounterInetRNG
This is managed internally by AESCounterRNG
engineSetSeed(byte[]) - Method in class akka.remote.security.provider.AES256CounterSecureRNG
This is managed internally by AESCounterRNG
ENil() - Method in class akka.dispatch.sysmsg.SystemMessageList$
 
ENil() - Static method in class akka.dispatch.sysmsg.SystemMessageList
 
enqueue(ActorRef, Envelope) - Method in class akka.actor.mailbox.filebased.FileBasedMessageQueue
 
enqueue(ActorRef, Envelope) - Method in interface akka.dispatch.BoundedDequeBasedMessageQueue
 
enqueue(ActorRef, Envelope) - Method in interface akka.dispatch.BoundedQueueBasedMessageQueue
 
enqueue(ActorRef, Envelope) - Method in class akka.dispatch.Mailbox
Try to enqueue the message to this queue, or throw an exception.
enqueue(ActorRef, Envelope) - Method in interface akka.dispatch.MessageQueue
Try to enqueue the message to this queue, or throw an exception.
enqueue(ActorRef, Envelope) - Method in class akka.dispatch.NodeMessageQueue
 
enqueue(ActorRef, Envelope) - Method in interface akka.dispatch.UnboundedDequeBasedMessageQueue
 
enqueue(ActorRef, Envelope) - Method in interface akka.dispatch.UnboundedQueueBasedMessageQueue
 
enqueue(ActorRef, Envelope) - Method in class akka.testkit.CallingThreadMailbox
 
enqueueFirst(Envelope) - Method in interface akka.actor.StashSupport
Enqueues envelope at the first position in the mailbox.
enqueueFirst(ActorRef, Envelope) - Method in interface akka.dispatch.BoundedDequeBasedMessageQueue
 
enqueueFirst(ActorRef, Envelope) - Method in interface akka.dispatch.DequeBasedMessageQueueSemantics
 
enqueueFirst(ActorRef, Envelope) - Method in interface akka.dispatch.UnboundedDequeBasedMessageQueue
 
enqueueInBuffer(Object) - Method in class akka.remote.EndpointWriter
 
enqueueMessage(Object) - Method in class akka.actor.dsl.Inbox.InboxActor
 
enqueueQuery(Inbox.Query) - Method in class akka.actor.dsl.Inbox.InboxActor
 
enrichWithPoolDispatcher(Props, ActorContext) - Method in interface akka.routing.Pool
INTERNAL API
enter(Seq<String>) - Method in interface akka.remote.testconductor.Player
Enter the named barriers, one after the other, in the order given.
enter(Timeout, Seq<String>) - Method in interface akka.remote.testconductor.Player
Enter the named barriers, one after the other, in the order given.
Enter_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
Enter = 1;
EnterBarrier - Class in akka.remote.testconductor
 
EnterBarrier(String, Option<FiniteDuration>) - Constructor for class akka.remote.testconductor.EnterBarrier
 
enterBarrier(Seq<String>) - Method in class akka.remote.testkit.MultiNodeSpec
Enter the named barriers in the order given.
EnterBarrier$ - Class in akka.remote.testconductor
 
EnterBarrier$() - Constructor for class akka.remote.testconductor.EnterBarrier$
 
entries() - Method in class akka.contrib.pattern.ShardRegion
 
entriesByShard() - Method in class akka.contrib.pattern.ShardRegion
 
entryId(Object) - Method in interface akka.contrib.pattern.ShardRegion.MessageExtractor
Extract the entry id from an incoming message.
entryMessage(Object) - Method in interface akka.contrib.pattern.ShardRegion.MessageExtractor
Extract the message to send to the entry from an incoming message.
entryProps() - Method in class akka.contrib.pattern.ClusterShardingGuardian.Start
 
entrySet() - Method in class akka.dispatch.CachingConfig
 
Envelope - Class in akka.dispatch
 
Envelope$ - Class in akka.dispatch
 
Envelope$() - Constructor for class akka.dispatch.Envelope$
 
ENVELOPE_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
EnvHome() - Method in class akka.actor.ActorSystem$
 
EnvHome() - Static method in class akka.actor.ActorSystem
 
equals(Object) - Method in class akka.actor.ActorRef
Equals takes path and the unique id of the actor cell into account.
equals(Object) - Method in class akka.actor.ActorSelection
 
equals(Object) - Method in class akka.actor.ChildActorPath
 
equals(Object) - Method in interface akka.actor.ExtensionId
 
equals(Object) - Method in class akka.cluster.Member
 
equals(Object) - Method in class akka.cluster.Metric
 
equals(Object) - Method in class akka.cluster.NodeMetrics
 
equals(Object) - Method in class akka.cluster.Reachability
 
erase() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
error(Logging.Error) - Method in interface akka.event.Logging.StdOutLogger
 
error(Throwable, String) - Method in interface akka.event.LoggingAdapter
Log message at error level, including the exception that caused the error.
error(Throwable, String, Object) - Method in interface akka.event.LoggingAdapter
Message template with 1 replacement argument.
error(Throwable, String, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 2 replacement arguments.
error(Throwable, String, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 3 replacement arguments.
error(Throwable, String, Object, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 4 replacement arguments.
error(String) - Method in interface akka.event.LoggingAdapter
Log message at error level, without providing the exception that caused the error.
error(String, Object) - Method in interface akka.event.LoggingAdapter
Message template with 1 replacement argument.
error(String, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 2 replacement arguments.
error(String, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 3 replacement arguments.
error(String, Object, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 4 replacement arguments.
error(String, String, String, String, int) - Method in class akka.testkit.EventFilter$
Create a filter for Error events which do not have a cause set (i.e.
error(String, String, String, String, int) - Static method in class akka.testkit.EventFilter
Create a filter for Error events which do not have a cause set (i.e.
ErrorFilter - Class in akka.testkit
Filter which matches Error events, if they satisfy the given criteria: throwable applies an upper bound on the type of exception contained in the Error event source, if given, applies a filter on the event&rsquo;s origin message applies a filter on the event&rsquo;s message (either with String.startsWith or Regex.findFirstIn().isDefined); if the message itself does not match, the match is retried with the contained Exception&rsquo;s message; if both are null, the filter always matches if at the same time the Exception&rsquo;s stack trace is empty (this catches JVM-omitted &ldquo;fast-throw&rdquo; exceptions) If you want to match all Error events, the most efficient is to use Left("").
ErrorFilter(Class<?>, Option<String>, Either<String, Regex>, boolean, int) - Constructor for class akka.testkit.ErrorFilter
 
ErrorFilter(Class<?>, String, String, boolean, boolean, int) - Constructor for class akka.testkit.ErrorFilter
Java API: create an ErrorFilter
ErrorFilter(Class<?>) - Constructor for class akka.testkit.ErrorFilter
Java API: filter only on the given type of exception
ErrorFilter$ - Class in akka.testkit
 
ErrorFilter$() - Constructor for class akka.testkit.ErrorFilter$
 
errorFormat() - Method in interface akka.event.Logging.StdOutLogger
 
errorFormatWithoutCause() - Method in interface akka.event.Logging.StdOutLogger
 
ErrorLevel() - Method in class akka.event.Logging$
Log level in numeric form, used when deciding whether a certain log statement should generate a log event.
ErrorLevel() - Static method in class akka.event.Logging
Log level in numeric form, used when deciding whether a certain log statement should generate a log event.
errorMessage() - Method in class akka.remote.transport.ProtocolStateActor.TimeoutReason
 
Escalate() - Method in interface akka.actor.dsl.Creators.Act
 
escalate() - Method in class akka.actor.SupervisorStrategy$
Java API: Returning this directive escalates the failure to the supervisor of the supervisor, by rethrowing the cause of the failure, i.e.
escalate() - Static method in class akka.actor.SupervisorStrategy
Java API: Returning this directive escalates the failure to the supervisor of the supervisor, by rethrowing the cause of the failure, i.e.
escalateDefault() - Method in class akka.actor.SupervisorStrategy$
 
escalateDefault() - Static method in class akka.actor.SupervisorStrategy
 
establishing() - Method in class akka.contrib.pattern.ClusterClient
 
Event() - Method in interface akka.actor.FSM
 
event() - Method in class akka.actor.FSM.Event
 
event() - Method in class akka.actor.FSM.LogEntry
 
event() - Method in class akka.cluster.InternalClusterAction.PublishEvent
 
event() - Method in class akka.event.Logging.LogEventException
 
event() - Method in class akka.io.Tcp.Abort$
The corresponding event which is sent as an acknowledgment once the close operation is finished.
event() - Method in class akka.io.Tcp.Close$
The corresponding event which is sent as an acknowledgment once the close operation is finished.
event() - Method in interface akka.io.Tcp.CloseCommand
The corresponding event which is sent as an acknowledgment once the close operation is finished.
event() - Method in class akka.io.Tcp.ConfirmedClose$
The corresponding event which is sent as an acknowledgment once the close operation is finished.
event(Class<P>, Class<Q>, FI.TypedPredicate2<P, Q>, FI.Apply2<P, Q, FSM.State<S, D>>) - Method in class akka.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches on an event and data type and a predicate.
event(Class<P>, Class<Q>, FI.Apply2<P, Q, FSM.State<S, D>>) - Method in class akka.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches on an event and data type.
event(Class<P>, FI.TypedPredicate2<P, D>, FI.Apply2<P, D, FSM.State<S, D>>) - Method in class akka.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches if the event type and predicate matches.
event(Class<P>, FI.Apply2<P, D, FSM.State<S, D>>) - Method in class akka.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches if the event type and predicate matches.
event(FI.TypedPredicate2<Object, D>, FI.Apply2<Object, D, FSM.State<S, D>>) - Method in class akka.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches if the predicate matches.
event(List<Object>, Class<Q>, FI.Apply2<Object, Q, FSM.State<S, D>>) - Method in class akka.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches on the data type and if any of the event types in the list match or any of the event instances in the list compares equal.
event(List<Object>, FI.Apply2<Object, D, FSM.State<S, D>>) - Method in class akka.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches if any of the event types in the list match or any of the event instances in the list compares equal.
EventBus - Interface in akka.event
Represents the base type for EventBuses Internally has an Event type, a Classifier type and a Subscriber type
EventBus<E,S,C> - Interface in akka.event.japi
Java API: See documentation for EventBus E is the Event type S is the Subscriber type C is the Classifier type
eventEquals(P, Class<Q>, FI.Apply2<P, Q, FSM.State<S, D>>) - Method in class akka.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches on the data type and if the event compares equal.
eventEquals(P, FI.Apply2<P, D, FSM.State<S, D>>) - Method in class akka.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches if event compares equal.
EventFilter - Class in akka.testkit
Facilities for selectively filtering out expected events from logging so that you can keep your test run&rsquo;s console output clean and do not miss real error messages.
EventFilter(int) - Constructor for class akka.testkit.EventFilter
 
EventFilter$ - Class in akka.testkit
Facilities for selectively filtering out expected events from logging so that you can keep your test run&rsquo;s console output clean and do not miss real error messages.
EventFilter$() - Constructor for class akka.testkit.EventFilter$
 
eventName() - Method in class akka.remote.AssociatedEvent
 
eventName() - Method in class akka.remote.AssociationErrorEvent
 
eventName() - Method in interface akka.remote.AssociationEvent
 
eventName() - Method in class akka.remote.DisassociatedEvent
 
eventPublisher() - Method in class akka.remote.EndpointActor
 
eventPublisher() - Method in class akka.remote.EndpointManager
 
EventPublisher - Class in akka.remote
INTERNAL API
EventPublisher(ActorSystem, LoggingAdapter, Logging.LogLevel) - Constructor for class akka.remote.EventPublisher
 
eventPublisher() - Method in class akka.remote.Remoting
 
events() - Method in interface akka.actor.LoggingFSM
 
eventsCount() - Method in interface akka.persistence.journal.JournalPerfSpec
Numbe of messages sent to the PersistentActor under test for each test iteration
Eventsourced - Interface in akka.persistence
INTERNAL API.
Eventsourced.AsyncHandlerInvocation - Class in akka.persistence
 
Eventsourced.AsyncHandlerInvocation(Object, Function1<Object, BoxedUnit>) - Constructor for class akka.persistence.Eventsourced.AsyncHandlerInvocation
 
Eventsourced.PendingHandlerInvocation - Interface in akka.persistence
 
Eventsourced.StashingHandlerInvocation - Class in akka.persistence
 
Eventsourced.StashingHandlerInvocation(Object, Function1<Object, BoxedUnit>) - Constructor for class akka.persistence.Eventsourced.StashingHandlerInvocation
 
EventsourcedProcessor - Interface in akka.persistence
An event sourced processor.
eventStream() - Method in class akka.actor.ActorSystem
Main event bus of this actor system, used for example for logging.
eventStream() - Method in class akka.actor.ActorSystemImpl
 
eventStream() - Method in class akka.actor.EmptyLocalActorRef
 
eventStream() - Method in class akka.actor.LocalActorRefProvider
 
eventStream() - Method in class akka.cluster.ClusterDomainEventPublisher
 
eventStream() - Method in class akka.dispatch.DefaultDispatcherPrerequisites
 
eventStream() - Method in interface akka.dispatch.DispatcherPrerequisites
 
eventStream() - Method in class akka.dispatch.Mailboxes
 
eventStream() - Method in class akka.dispatch.MessageDispatcher
 
eventStream() - Method in class akka.dispatch.TaskInvocation
 
eventStream() - Method in class akka.event.DeadLetterListener
 
EventStream - Class in akka.event
 
EventStream(boolean) - Constructor for class akka.event.EventStream
 
eventStream() - Method in class akka.remote.RemoteActorRefProvider
 
EventStream$ - Class in akka.event
 
EventStream$() - Constructor for class akka.event.EventStream$
 
evt() - Method in class akka.persistence.Eventsourced.AsyncHandlerInvocation
 
evt() - Method in interface akka.persistence.Eventsourced.PendingHandlerInvocation
 
evt() - Method in class akka.persistence.Eventsourced.StashingHandlerInvocation
 
EWMA - Class in akka.cluster
 
EWMA(double, double) - Constructor for class akka.cluster.EWMA
 
EWMA$ - Class in akka.cluster
 
EWMA$() - Constructor for class akka.cluster.EWMA$
 
EWMA_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
exceptionCaught(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ExceptionEvent) - Method in class akka.remote.testconductor.PlayerHandler
 
exceptionCaught(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ExceptionEvent) - Method in interface akka.remote.transport.netty.NettyClientHelpers
 
exceptionCaught(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ExceptionEvent) - Method in interface akka.remote.transport.netty.NettyServerHelpers
 
exceptionHandler() - Method in class akka.dispatch.MonitorableThreadFactory
 
exchange() - Method in class akka.camel.internal.CamelExchangeAdapter
 
exec() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinTask
 
exec() - Method in class akka.testkit.JavaTestKit.EventFilter
 
execute(Runnable) - Method in interface akka.dispatch.BatchingExecutor
 
execute(Runnable) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
execute(Runnable) - Method in class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinPool
 
execute(Runnable) - Method in class akka.util.SerializedSuspendableExecutionContext
 
executeTask() - Method in class akka.actor.LightArrayRevolverScheduler.TaskHolder
 
executeTask(TaskInvocation) - Method in class akka.dispatch.Dispatcher
INTERNAL API
executeTask(TaskInvocation) - Method in class akka.dispatch.MessageDispatcher
INTERNAL API
executeTask(TaskInvocation) - Method in class akka.testkit.CallingThreadDispatcher
 
executionContext() - Method in class akka.remote.transport.netty.NettyTransport
 
ExecutionContexts - Class in akka.dispatch
ExecutionContexts is the Java API for ExecutionContexts
ExecutionContexts() - Constructor for class akka.dispatch.ExecutionContexts
 
ExecutionContexts$ - Class in akka.dispatch
ExecutionContexts is the Java API for ExecutionContexts
ExecutionContexts$() - Constructor for class akka.dispatch.ExecutionContexts$
 
ExecutionContexts.sameThreadExecutionContext$ - Class in akka.dispatch
WARNING: Not A General Purpose ExecutionContext!
ExecutionContexts.sameThreadExecutionContext$() - Constructor for class akka.dispatch.ExecutionContexts.sameThreadExecutionContext$
 
executor() - Method in interface akka.dispatch.ExecutorServiceDelegate
 
executorService() - Method in class akka.dispatch.Dispatcher
 
ExecutorServiceConfigurator - Class in akka.dispatch
An ExecutorServiceConfigurator is a class that given some prerequisites and a configuration can create instances of ExecutorService
ExecutorServiceConfigurator(com.typesafe.config.Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.ExecutorServiceConfigurator
 
ExecutorServiceDelegate - Interface in akka.dispatch
As the name says
ExecutorServiceFactory - Interface in akka.dispatch
 
ExecutorServiceFactoryProvider - Interface in akka.dispatch
 
existenceConfirmed() - Method in class akka.actor.Terminated
 
existenceConfirmed() - Method in class akka.dispatch.sysmsg.DeathWatchNotification
 
exists() - Method in interface akka.dispatch.CachingConfig.PathEntry
 
exists() - Method in class akka.dispatch.CachingConfig.StringPathEntry
 
exists() - Method in class akka.dispatch.CachingConfig.ValuePathEntry
 
existsAssociation(Address, Address) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Tests if an association was registered.
exit(RoleName, int) - Method in interface akka.remote.testconductor.Conductor
Tell the remote node to shut itself down using System.exit with the given exitValue.
Exit_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.FailType
Exit = 4;
exiting() - Method in class akka.cluster.MemberStatus$
Java API: retrieve the &ldquo;exiting&rdquo; status singleton
exiting() - Static method in class akka.cluster.MemberStatus
Java API: retrieve the &ldquo;exiting&rdquo; status singleton
Exiting_VALUE - Static variable in enum akka.cluster.protobuf.msg.ClusterMessages.MemberStatus
Exiting = 3;
EXITVALUE_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
expect(PartialFunction<Object, BoxedUnit>) - Method in interface akka.contrib.pattern.Aggregator
Adds the partial function to the receive set and keeping it in the receive set till removed.
expectedTestDuration() - Method in class akka.testkit.AkkaSpec
 
expectedTestDuration() - Method in interface akka.testkit.WatchedByCoroner
 
expectList() - Method in interface akka.contrib.pattern.Aggregator
 
expectMsg(T) - Method in interface akka.testkit.TestKitBase
Same as expectMsg(remaining, obj), but correctly treating the timeFactor.
expectMsg(FiniteDuration, T) - Method in interface akka.testkit.TestKitBase
Receive one message from the test actor and assert that it equals the given object.
expectMsg(FiniteDuration, String, T) - Method in interface akka.testkit.TestKitBase
Receive one message from the test actor and assert that it equals the given object.
expectMsg_internal(Duration, T, Option<String>) - Method in interface akka.testkit.TestKitBase
 
expectMsgAllClassOf(Seq<Class<? extends T>>) - Method in interface akka.testkit.TestKitBase
Same as expectMsgAllClassOf(remaining, obj...), but correctly treating the timeFactor.
expectMsgAllClassOf(FiniteDuration, Seq<Class<? extends T>>) - Method in interface akka.testkit.TestKitBase
Receive a number of messages from the test actor matching the given number of classes and assert that for each given class one is received which is of that class (equality, not conformance).
expectMsgAllConformingOf(Seq<Class<? extends T>>) - Method in interface akka.testkit.TestKitBase
Same as expectMsgAllConformingOf(remaining, obj...), but correctly treating the timeFactor.
expectMsgAllConformingOf(FiniteDuration, Seq<Class<? extends T>>) - Method in interface akka.testkit.TestKitBase
Receive a number of messages from the test actor matching the given number of classes and assert that for each given class one is received which conforms to that class (and vice versa).
expectMsgAllOf(Object...) - Method in class akka.testkit.JavaTestKit
Same as expectMsgAllOf(remaining(), obj...), but correctly treating the timeFactor.
expectMsgAllOf(FiniteDuration, Object...) - Method in class akka.testkit.JavaTestKit
Receive a number of messages from the test actor matching the given number of objects and assert that for each given object one is received which equals it and vice versa.
expectMsgAllOf(Seq<T>) - Method in interface akka.testkit.TestKitBase
Same as expectMsgAllOf(remaining, obj...), but correctly treating the timeFactor.
expectMsgAllOf(FiniteDuration, Seq<T>) - Method in interface akka.testkit.TestKitBase
Receive a number of messages from the test actor matching the given number of objects and assert that for each given object one is received which equals it and vice versa.
expectMsgAllOf_internal(FiniteDuration, Seq<T>) - Method in interface akka.testkit.TestKitBase
 
expectMsgAnyClassOf(Class<? extends T>...) - Method in class akka.testkit.JavaTestKit
Same as expectMsgAnyClassOf(remaining(), obj...), but correctly treating the timeFactor.
expectMsgAnyClassOf(FiniteDuration, Class<?>...) - Method in class akka.testkit.JavaTestKit
Receive one message from the test actor and assert that it conforms to one of the given classes.
expectMsgAnyClassOf(Seq<Class<? extends C>>) - Method in interface akka.testkit.TestKitBase
Same as expectMsgAnyClassOf(remaining, obj...), but correctly treating the timeFactor.
expectMsgAnyClassOf(FiniteDuration, Seq<Class<? extends C>>) - Method in interface akka.testkit.TestKitBase
Receive one message from the test actor and assert that it conforms to one of the given classes.
expectMsgAnyClassOf_internal(FiniteDuration, Seq<Class<? extends C>>) - Method in interface akka.testkit.TestKitBase
 
expectMsgAnyOf(Object...) - Method in class akka.testkit.JavaTestKit
Same as expectMsgAnyOf(remaining(), obj...), but correctly treating the timeFactor.
expectMsgAnyOf(FiniteDuration, Object...) - Method in class akka.testkit.JavaTestKit
Receive one message from the test actor and assert that it equals one of the given objects.
expectMsgAnyOf(Seq<T>) - Method in interface akka.testkit.TestKitBase
Same as expectMsgAnyOf(remaining, obj...), but correctly treating the timeFactor.
expectMsgAnyOf(FiniteDuration, Seq<T>) - Method in interface akka.testkit.TestKitBase
Receive one message from the test actor and assert that it equals one of the given objects.
expectMsgAnyOf_internal(FiniteDuration, Seq<T>) - Method in interface akka.testkit.TestKitBase
 
expectMsgClass(Class<T>) - Method in class akka.testkit.JavaTestKit
Same as expectMsgClass(remaining(), clazz), but correctly treating the timeFactor.
expectMsgClass(FiniteDuration, Class<T>) - Method in class akka.testkit.JavaTestKit
Receive one message from the test actor and assert that it conforms to the given class.
expectMsgClass(Class<C>) - Method in interface akka.testkit.TestKitBase
Same as expectMsgClass(remaining, c), but correctly treating the timeFactor.
expectMsgClass(FiniteDuration, Class<C>) - Method in interface akka.testkit.TestKitBase
Receive one message from the test actor and assert that it conforms to the given class.
expectMsgClass_internal(FiniteDuration, Class<C>) - Method in interface akka.testkit.TestKitBase
 
expectMsgEquals(T) - Method in class akka.testkit.JavaTestKit
Same as expectMsgEquals(remaining(), obj), but correctly treating the timeFactor.
expectMsgEquals(FiniteDuration, T) - Method in class akka.testkit.JavaTestKit
Receive one message from the test actor and assert that it equals the given object.
expectMsgPF(Duration, String, PartialFunction<Object, T>) - Method in interface akka.testkit.TestKitBase
Receive one message from the test actor and assert that the given partial function accepts it.
expectMsgType(ClassTag<T>) - Method in interface akka.testkit.TestKitBase
Same as expectMsgType[T](remaining), but correctly treating the timeFactor.
expectMsgType(FiniteDuration, ClassTag<T>) - Method in interface akka.testkit.TestKitBase
Receive one message from the test actor and assert that it conforms to the given type (after erasure).
expectNoMsg() - Method in class akka.testkit.JavaTestKit
Same as expectNoMsg(remaining()), but correctly treating the timeFactor.
expectNoMsg(FiniteDuration) - Method in class akka.testkit.JavaTestKit
Assert that no message is received for the specified time.
expectNoMsg() - Method in interface akka.testkit.TestKitBase
Same as expectNoMsg(remaining), but correctly treating the timeFactor.
expectNoMsg(FiniteDuration) - Method in interface akka.testkit.TestKitBase
Assert that no message is received for the specified time.
expectNoMsg_internal(FiniteDuration) - Method in interface akka.testkit.TestKitBase
 
expectOnce(PartialFunction<Object, BoxedUnit>) - Method in interface akka.contrib.pattern.Aggregator
Adds the partial function to the receive set, to be removed on first match.
expectTerminated(Duration, ActorRef) - Method in class akka.testkit.JavaTestKit
Assert that the given ActorRef is Terminated within the specified time.
expectTerminated(ActorRef) - Method in class akka.testkit.JavaTestKit
Same as expectTerminated(remaining(), target), but correctly treating the timeFactor.
expectTerminated(ActorRef, Duration) - Method in interface akka.testkit.TestKitBase
Receive one message from the test actor and assert that it is the Terminated message of the given ActorRef.
expiredQueue() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
expiredQueue() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
expiry() - Method in class akka.actor.mailbox.filebased.filequeue.QItem
 
ExtendedActorSystem - Class in akka.actor
More powerful interface to the actor system&rsquo;s implementation which is presented to extensions (see Extension).
ExtendedActorSystem() - Constructor for class akka.actor.ExtendedActorSystem
 
extendedSystem() - Method in class akka.remote.EndpointManager
 
extendedSystem() - Method in class akka.remote.EndpointWriter
 
extendedSystem() - Method in class akka.remote.transport.FailureInjectorTransportAdapter
 
extendHash(int, int, int, int) - Method in class akka.routing.MurmurHash$
Incorporates a new value into an existing hash.
extendHash(int, int, int, int) - Static method in class akka.routing.MurmurHash
Incorporates a new value into an existing hash.
extension(ExtensionId<T>) - Method in class akka.actor.ActorSystem
Returns the payload that is associated with the provided extension throws an IllegalStateException if it is not registered.
extension(ExtensionId<T>) - Method in class akka.actor.ActorSystemImpl
 
Extension - Interface in akka.actor
The basic ActorSystem covers all that is needed for locally running actors, using futures and so on.
extension() - Method in class akka.actor.TypedActor.TypedActorInvocationHandler
 
extension() - Method in interface akka.persistence.journal.AsyncWriteJournal
 
extension() - Method in interface akka.persistence.journal.SyncWriteJournal
 
extension() - Method in interface akka.persistence.PluginSpec
 
extension() - Method in interface akka.persistence.Recovery
INTERNAL API.
extension() - Method in interface akka.persistence.snapshot.SnapshotStore
 
ExtensionId<T extends Extension> - Interface in akka.actor
Identifies an Extension Lookup of Extensions is done by object identity, so the Id must be the same wherever it's used, otherwise you'll get the same extension loaded multiple times.
ExtensionIdProvider - Interface in akka.actor
To be able to load an ExtensionId from the configuration, a class that implements ExtensionIdProvider must be specified.
ExtensionKey<T extends Extension> - Class in akka.actor
This is a one-stop-shop if all you want is an extension which is constructed with the ExtendedActorSystem as its only constructor argument:
ExtensionKey(ClassTag<T>) - Constructor for class akka.actor.ExtensionKey
 
ExtensionKey(Class<T>) - Constructor for class akka.actor.ExtensionKey
 
extractCpu(NodeMetrics) - Method in class akka.cluster.StandardMetrics$
 
extractCpu(NodeMetrics) - Static method in class akka.cluster.StandardMetrics
 
extractDeliverable() - Method in class akka.remote.AckedReceiveBuffer
Extract all messages that could be safely delivered, an updated ack to be sent to the sender(), and an updated buffer that has the messages removed that can be delivered.
extractHeapMemory(NodeMetrics) - Method in class akka.cluster.StandardMetrics$
 
extractHeapMemory(NodeMetrics) - Static method in class akka.cluster.StandardMetrics
 
extractInterfaces(Class<?>) - Method in class akka.actor.TypedProps$
 
extractInterfaces(Class<?>) - Static method in class akka.actor.TypedProps
 
extraTime() - Method in interface akka.actor.dsl.Inbox
 

F

f() - Method in class akka.routing.WithListeners
 
Fail_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
Fail = 2;
failBarrier(BarrierCoordinator.Data) - Method in class akka.remote.testconductor.Controller
 
FailBarrier - Class in akka.remote.testconductor
 
FailBarrier(String) - Constructor for class akka.remote.testconductor.FailBarrier
 
FailBarrier$ - Class in akka.remote.testconductor
 
FailBarrier$() - Constructor for class akka.remote.testconductor.FailBarrier$
 
failed(Throwable) - Method in class akka.dispatch.Futures$
creates an already completed Promise with the specified exception
failed(Throwable) - Static method in class akka.dispatch.Futures
creates an already completed Promise with the specified exception
Failed - Class in akka.dispatch.sysmsg
INTERNAL API
Failed(ActorRef, Throwable, int) - Constructor for class akka.dispatch.sysmsg.Failed
 
failed() - Method in class akka.remote.testconductor.BarrierCoordinator
 
Failed$ - Class in akka.dispatch.sysmsg
 
Failed$() - Constructor for class akka.dispatch.sysmsg.Failed$
 
Failed_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
Failed = 4;
failedToActivate(Throwable) - Method in class akka.camel.internal.ActivationTracker.ActivationStateMachine
Failed to activate state
failedToDeActivate(Throwable) - Method in class akka.camel.internal.ActivationTracker.ActivationStateMachine
Failed to de-activate state
failure() - Method in class akka.dispatch.sysmsg.Create
 
FAILURE_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
FAILURE_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
failureDetector() - Method in class akka.cluster.Cluster
 
failureDetector() - Method in class akka.cluster.ClusterHeartbeatSender
 
failureDetector() - Method in class akka.cluster.ClusterHeartbeatSenderState
 
failureDetector() - Method in class akka.contrib.pattern.ClusterClient
 
failureDetector(A) - Method in class akka.remote.DefaultFailureDetectorRegistry
INTERNAL API Get the underlying FailureDetector for a resource.
FailureDetector - Interface in akka.remote
A failure detector must be a thread-safe mutable construct that registers heartbeat events of a resource and is able to decide the availability of that monitored resource.
FailureDetector$ - Class in akka.remote
 
FailureDetector$() - Constructor for class akka.remote.FailureDetector$
 
FailureDetector.Clock - Class in akka.remote
Abstraction of a clock that returns time in milliseconds.
FailureDetector.Clock() - Constructor for class akka.remote.FailureDetector.Clock
 
FailureDetectorConfig() - Method in class akka.cluster.ClusterSettings
 
FailureDetectorImplementationClass() - Method in class akka.cluster.ClusterSettings
 
FailureDetectorLoader - Class in akka.remote
INTERNAL API
FailureDetectorLoader() - Constructor for class akka.remote.FailureDetectorLoader
 
FailureDetectorLoader$ - Class in akka.remote
INTERNAL API
FailureDetectorLoader$() - Constructor for class akka.remote.FailureDetectorLoader$
 
failureDetectorReaperTask() - Method in class akka.cluster.ClusterCoreDaemon
 
failureDetectorReaperTask() - Method in class akka.remote.RemoteWatcher
 
FailureDetectorRegistry<A> - Interface in akka.remote
Interface for a registry of Akka failure detectors.
FailureInjectorException - Exception in akka.remote.transport
 
FailureInjectorException(String) - Constructor for exception akka.remote.transport.FailureInjectorException
 
FailureInjectorException$ - Class in akka.remote.transport
 
FailureInjectorException$() - Constructor for class akka.remote.transport.FailureInjectorException$
 
FailureInjectorHandle - Class in akka.remote.transport
INTERNAL API
FailureInjectorHandle(AssociationHandle, FailureInjectorTransportAdapter) - Constructor for class akka.remote.transport.FailureInjectorHandle
 
FailureInjectorHandle$ - Class in akka.remote.transport
 
FailureInjectorHandle$() - Constructor for class akka.remote.transport.FailureInjectorHandle$
 
FailureInjectorProvider - Class in akka.remote.transport
 
FailureInjectorProvider() - Constructor for class akka.remote.transport.FailureInjectorProvider
 
FailureInjectorSchemeIdentifier() - Method in class akka.remote.transport.FailureInjectorTransportAdapter$
 
FailureInjectorSchemeIdentifier() - Static method in class akka.remote.transport.FailureInjectorTransportAdapter
 
FailureInjectorTransportAdapter - Class in akka.remote.transport
INTERNAL API
FailureInjectorTransportAdapter(Transport, ExtendedActorSystem) - Constructor for class akka.remote.transport.FailureInjectorTransportAdapter
 
FailureInjectorTransportAdapter$ - Class in akka.remote.transport
INTERNAL API
FailureInjectorTransportAdapter$() - Constructor for class akka.remote.transport.FailureInjectorTransportAdapter$
 
FailureInjectorTransportAdapter.All - Class in akka.remote.transport
 
FailureInjectorTransportAdapter.All(FailureInjectorTransportAdapter.GremlinMode) - Constructor for class akka.remote.transport.FailureInjectorTransportAdapter.All
 
FailureInjectorTransportAdapter.All$ - Class in akka.remote.transport
 
FailureInjectorTransportAdapter.All$() - Constructor for class akka.remote.transport.FailureInjectorTransportAdapter.All$
 
FailureInjectorTransportAdapter.Drop - Class in akka.remote.transport
 
FailureInjectorTransportAdapter.Drop(double, double) - Constructor for class akka.remote.transport.FailureInjectorTransportAdapter.Drop
 
FailureInjectorTransportAdapter.Drop$ - Class in akka.remote.transport
 
FailureInjectorTransportAdapter.Drop$() - Constructor for class akka.remote.transport.FailureInjectorTransportAdapter.Drop$
 
FailureInjectorTransportAdapter.FailureInjectorCommand - Interface in akka.remote.transport
 
FailureInjectorTransportAdapter.GremlinMode - Interface in akka.remote.transport
 
FailureInjectorTransportAdapter.One - Class in akka.remote.transport
 
FailureInjectorTransportAdapter.One(Address, FailureInjectorTransportAdapter.GremlinMode) - Constructor for class akka.remote.transport.FailureInjectorTransportAdapter.One
 
FailureInjectorTransportAdapter.One$ - Class in akka.remote.transport
 
FailureInjectorTransportAdapter.One$() - Constructor for class akka.remote.transport.FailureInjectorTransportAdapter.One$
 
FailureInjectorTransportAdapter.PassThru$ - Class in akka.remote.transport
 
FailureInjectorTransportAdapter.PassThru$() - Constructor for class akka.remote.transport.FailureInjectorTransportAdapter.PassThru$
 
failureMessage() - Method in interface akka.io.SelectionHandler.HasFailureMessage
 
failureMessage() - Method in interface akka.io.Tcp.Command
 
failureMessage() - Method in class akka.io.TcpListener.RegisterIncoming
 
failureMessage() - Method in interface akka.io.Udp.Command
 
failureMessage() - Method in interface akka.io.UdpConnected.Command
 
FailureResult - Class in akka.camel
INTERNAL API
FailureResult(Throwable, Map<String, Object>) - Constructor for class akka.camel.FailureResult
 
FailureResult$ - Class in akka.camel
 
FailureResult$() - Constructor for class akka.camel.FailureResult$
 
fallbackClassLoader() - Method in class akka.osgi.OsgiActorSystemFactory
 
fallbackConfig() - Method in class akka.actor.mailbox.DurableMailboxSpec$
 
fallbackConfig() - Static method in class akka.actor.mailbox.DurableMailboxSpec
 
FALSE() - Method in class akka.testkit.TestActor$
 
FALSE() - Static method in class akka.testkit.TestActor
 
faultCreate() - Method in interface akka.actor.dungeon.FaultHandling
Do create the actor in response to a failure.
FaultHandling - Interface in akka.actor.dungeon
 
faultRecreate(Throwable) - Method in interface akka.actor.dungeon.FaultHandling
Do re-create the actor in response to a failure.
faultResume(Throwable) - Method in interface akka.actor.dungeon.FaultHandling
Do resume the actor in response to a failure.
faultSuspend() - Method in interface akka.actor.dungeon.FaultHandling
Do suspend the actor in response to a failure of a parent (i.e.
feedAndExpectLast(ActorRef, String, Seq<Object>) - Method in interface akka.persistence.journal.JournalPerfSpec
 
FI - Class in akka.japi.pf
Class that encapsulates all the Functional Interfaces used for creating partial functions.
FI.Apply<I,R> - Interface in akka.japi.pf
Functional interface for an application.
FI.Apply2<I1,I2,R> - Interface in akka.japi.pf
Functional interface for an application.
FI.TypedPredicate<T> - Interface in akka.japi.pf
Functional interface for a predicate.
FI.TypedPredicate2<T,U> - Interface in akka.japi.pf
Functional interface for a predicate.
FI.UnitApply<I> - Interface in akka.japi.pf
Functional interface for an application.
FI.UnitApply2<I1,I2> - Interface in akka.japi.pf
Functional interface for an application.
FI.UnitApply3<I1,I2,I3> - Interface in akka.japi.pf
Functional interface for an application.
FI.UnitApplyVoid - Interface in akka.japi.pf
Functional interface for an application.
FileBasedMailboxSettings - Class in akka.actor.mailbox.filebased
 
FileBasedMailboxSettings(ActorSystem.Settings, com.typesafe.config.Config) - Constructor for class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
FileBasedMailboxType - Class in akka.actor.mailbox.filebased
 
FileBasedMailboxType(ActorSystem.Settings, com.typesafe.config.Config) - Constructor for class akka.actor.mailbox.filebased.FileBasedMailboxType
 
FileBasedMessageQueue - Class in akka.actor.mailbox.filebased
 
FileBasedMessageQueue(ActorRef, ExtendedActorSystem, FileBasedMailboxSettings) - Constructor for class akka.actor.mailbox.filebased.FileBasedMessageQueue
 
FileDescriptor - Class in akka.zeromq
Gets the file descriptor associated with the ZeroMQ socket
FileDescriptor() - Constructor for class akka.zeromq.FileDescriptor
 
fileDescriptor() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its file descriptor configuration.
fileDescriptor() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its file descriptor configuration.
FileDescriptor$ - Class in akka.zeromq
Gets the file descriptor associated with the ZeroMQ socket
FileDescriptor$() - Constructor for class akka.zeromq.FileDescriptor$
 
fileIoDispatcher() - Method in class akka.io.TcpExt
 
FileIODispatcher() - Method in class akka.io.TcpExt.Settings
 
filenames() - Method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper$
 
filenames() - Static method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper
 
filePath() - Method in class akka.io.Tcp.WriteFile
 
fillArray(int, Function2<byte[], Object, BoxedUnit>) - Method in class akka.util.ByteStringBuilder
 
fillByteBuffer(int, ByteOrder, Function1<ByteBuffer, BoxedUnit>) - Method in class akka.util.ByteStringBuilder
 
fillInStackTrace() - Method in interface akka.OnlyCauseStackTrace
 
fillReadBehind(Function1<QItem, BoxedUnit>) - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
filter(Set<Address>) - Method in class akka.cluster.MetricsGossip
Only the nodes that are in the includeNodes Set.
Filter - Class in akka.dispatch
Java API (not recommended): Callback for the Future.filter operation that creates a new Future which will conditionally contain the success of another Future.
Filter() - Constructor for class akka.dispatch.Filter
 
filter(int, int) - Method in class akka.routing.DefaultResizer
This method can be used to smooth the capacity delta by considering the current pressure and current capacity.
filter(Logging.LogEvent) - Method in class akka.testkit.TestEventListener
 
Filter$ - Class in akka.dispatch
Java API (not recommended): Callback for the Future.filter operation that creates a new Future which will conditionally contain the success of another Future.
Filter$() - Constructor for class akka.dispatch.Filter$
 
filterOf(Function<T, Boolean>) - Method in class akka.dispatch.Filter$
 
filterOf(Function<T, Boolean>) - Static method in class akka.dispatch.Filter
 
filters() - Method in class akka.testkit.TestEvent.Mute
 
filters() - Method in class akka.testkit.TestEvent.UnMute
 
filters() - Method in class akka.testkit.TestEventListener
 
finalize() - Method in class akka.actor.dsl.Inbox.Inbox
Overridden finalizer which will try to stop the actor once this Inbox is no longer referenced.
finalizeHash(int) - Method in class akka.routing.MurmurHash$
Once all hashes have been incorporated, this performs a final mixing
finalizeHash(int) - Static method in class akka.routing.MurmurHash
Once all hashes have been incorporated, this performs a final mixing
find(Iterable<Future<T>>, Function<T, Boolean>, ExecutionContext) - Method in class akka.dispatch.Futures$
Returns a Future that will hold the optional result of the first Future with a result that matches the predicate
find(Iterable<Future<T>>, Function<T, Boolean>, ExecutionContext) - Static method in class akka.dispatch.Futures
Returns a Future that will hold the optional result of the first Future with a result that matches the predicate
find(Iterator<String>) - Method in class akka.util.WildcardTree
 
findActorIn(ActorSystem) - Method in class akka.camel.internal.component.ActorEndpointPath
 
findClass(String) - Method in class akka.osgi.BundleDelegatingClassLoader
 
findClassLoader() - Method in class akka.actor.ActorSystem$
INTERNAL API
findClassLoader() - Static method in class akka.actor.ActorSystem
INTERNAL API
findConstructor(Class<T>, Seq<Object>) - Method in class akka.util.Reflect$
INTERNAL API Implements a primitive form of overload resolution a.k.a.
findConstructor(Class<T>, Seq<Object>) - Static method in class akka.util.Reflect
INTERNAL API Implements a primitive form of overload resolution a.k.a.
findMarker(Class<?>, Class<?>) - Method in class akka.util.Reflect$
 
findMarker(Class<?>, Class<?>) - Static method in class akka.util.Reflect
 
findResource(String) - Method in class akka.osgi.BundleDelegatingClassLoader
 
findResources(String) - Method in class akka.osgi.BundleDelegatingClassLoader
 
findSerializerFor(Object) - Method in class akka.serialization.Serialization
Returns the Serializer configured for the given object, returns the NullSerializer if it's null.
findSubKeysExcept(K, Vector<SubclassifiedIndex.Nonroot<K, V>>) - Method in class akka.util.SubclassifiedIndex
Find all subkeys of a given key in the index excluding some subkeys.
findValue(K, Function1<V, Object>) - Method in class akka.util.Index
 
findValues(K) - Method in class akka.util.SubclassifiedIndex
Find all values for a given key in the index.
FinishConnectRetries() - Method in class akka.io.TcpExt.Settings
 
finishCreate() - Method in interface akka.actor.dungeon.FaultHandling
 
finishRecreate(Throwable, Actor) - Method in interface akka.actor.dungeon.FaultHandling
 
finishTerminate() - Method in interface akka.actor.dungeon.FaultHandling
 
first() - Method in class akka.japi.Pair
 
firstCompletedOf(Iterable<Future<T>>, ExecutionContext) - Method in class akka.dispatch.Futures$
Returns a Future to the result of the first future in the list that is completed
firstCompletedOf(Iterable<Future<T>>, ExecutionContext) - Static method in class akka.dispatch.Futures
Returns a Future to the result of the first future in the list that is completed
firstHeartbeatEstimate() - Method in class akka.remote.PhiAccrualFailureDetector
 
FirstSeedNodeProcess - Class in akka.cluster
INTERNAL API.
FirstSeedNodeProcess(IndexedSeq<Address>) - Constructor for class akka.cluster.FirstSeedNodeProcess
 
fishForMessage(Duration, String, PartialFunction<Object, Object>) - Method in interface akka.testkit.TestKitBase
Hybrid of expectMsgPF and receiveWhile: receive messages while the partial function matches and returns false.
flatMap(Function1<T, Agent<B>>) - Method in class akka.agent.Agent
Flatmap this agent to a new agent, applying the function to the internal state.
Float_VALUE - Static variable in enum akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberType
Float = 2;
flush() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
flush(String) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
flushAllExpired() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
flushAndStop() - Method in class akka.remote.EndpointWriter
 
flushBatch() - Method in interface akka.persistence.Eventsourced
 
flushExpired(String) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
flushing() - Method in class akka.remote.EndpointManager
 
flushJournalBatch() - Method in interface akka.persistence.ProcessorImpl
INTERNAL API
flushWait() - Method in class akka.remote.ReliableDeliverySupervisor
 
FlushWait() - Method in class akka.remote.RemoteSettings
 
fold(R, Iterable<Future<T>>, Function2<R, T, R>, ExecutionContext) - Method in class akka.dispatch.Futures$
A non-blocking fold over the specified futures, with the start value of the given zero.
fold(R, Iterable<Future<T>>, Function2<R, T, R>, ExecutionContext) - Static method in class akka.dispatch.Futures
A non-blocking fold over the specified futures, with the start value of the given zero.
fold(Function0<T>, Function0<T>) - Method in class akka.util.Switch
Executes the provided callbacks depending on if the switch is either on or off waiting for any pending changes to happen before (locking) Be careful of longrunning or blocking within the provided action as it can lead to deadlocks or bad performance
foldLeft(B, Function2<B, Object, B>) - Method in class akka.util.ByteIterator
 
foreach(Function1<T, U>) - Method in class akka.agent.Agent
Applies the function to the internal state.
Foreach<T> - Class in akka.dispatch
Callback for the Future.foreach operation that will be invoked if the Future that this callback is registered on becomes completed with a success.
Foreach() - Constructor for class akka.dispatch.Foreach
 
foreach(Function1<Object, U>) - Method in class akka.util.ByteIterator
 
foreach(Function1<Object, U>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
foreach(Function1<Object, U>) - Method in class akka.util.ByteString
 
foreach(Function1<To, C>) - Method in class akka.util.Collections.PartialImmutableValuesIterable
 
foreach(Function2<K, V, BoxedUnit>) - Method in class akka.util.Index
Applies the supplied function to all keys and their values
foreachChild(Function1<ActorRef, BoxedUnit>) - Method in class akka.actor.VirtualPathContainer
 
ForkJoinExecutorConfigurator - Class in akka.dispatch
 
ForkJoinExecutorConfigurator(com.typesafe.config.Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator
 
ForkJoinExecutorConfigurator$ - Class in akka.dispatch
 
ForkJoinExecutorConfigurator$() - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator$
 
ForkJoinExecutorConfigurator.AkkaForkJoinPool - Class in akka.dispatch
INTERNAL AKKA USAGE ONLY
ForkJoinExecutorConfigurator.AkkaForkJoinPool(int, ForkJoinPool.ForkJoinWorkerThreadFactory, Thread.UncaughtExceptionHandler, boolean) - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinPool
 
ForkJoinExecutorConfigurator.AkkaForkJoinPool(int, ForkJoinPool.ForkJoinWorkerThreadFactory, Thread.UncaughtExceptionHandler) - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinPool
 
ForkJoinExecutorConfigurator.AkkaForkJoinTask - Class in akka.dispatch
INTERNAL AKKA USAGE ONLY
ForkJoinExecutorConfigurator.AkkaForkJoinTask(Runnable) - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinTask
 
ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory - Class in akka.dispatch
 
ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory(ForkJoinPool.ForkJoinWorkerThreadFactory, int, boolean) - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory
 
ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory(ForkJoinPool.ForkJoinWorkerThreadFactory, int) - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory
 
format(String, Seq<Object>) - Method in interface akka.event.LoggingAdapter
 
format(TimeUnit, Duration) - Method in interface akka.testkit.TestKitBase
 
format1(String, Object) - Method in interface akka.event.LoggingAdapter
 
formatTimestamp(long) - Method in class akka.event.slf4j.Slf4jLogger
Override this method to provide a differently formatted timestamp
forMax(Duration) - Method in class akka.actor.FSM.State
Modify state transition descriptor to include a state timeout for the next state.
forward(Object, ActorContext) - Method in class akka.actor.ActorRef
Forwards the message and passes the original sender actor as the sender.
forward(Object, ActorContext) - Method in class akka.actor.ActorSelection
Forwards the message and passes the original sender actor as the sender.
forward(ActorRef) - Method in class akka.testkit.JavaTestKit
 
forward(ActorRef, Object) - Method in class akka.testkit.TestProbe
Forward this message as if in the TestActor's receive method with self.forward.
forwardOrDelay(ByteString) - Method in class akka.remote.transport.ThrottledAssociation
 
frame(int) - Method in class akka.zeromq.ZMQMessage
 
FrameLengthFieldLength() - Method in class akka.remote.transport.netty.NettyTransport$
 
FrameLengthFieldLength() - Static method in class akka.remote.transport.netty.NettyTransport
 
frames() - Method in class akka.zeromq.Send
 
frames() - Method in class akka.zeromq.ZMQMessage
 
from() - Method in class akka.actor.FSM.Transition
 
from(org.apache.camel.Message, Map<String, Object>) - Method in class akka.camel.CamelMessage$
Creates a new CamelMessage object from the Camel message.
from(org.apache.camel.Message, Map<String, Object>) - Static method in class akka.camel.CamelMessage
Creates a new CamelMessage object from the Camel message.
from() - Method in class akka.cluster.ClusterHeartbeatSender.ExpectedFirstHeartbeat
 
from() - Method in class akka.cluster.ClusterHeartbeatSender.Heartbeat
 
from() - Method in class akka.cluster.ClusterHeartbeatSender.HeartbeatRsp
 
from() - Method in class akka.cluster.GossipEnvelope
 
from() - Method in class akka.cluster.GossipStatus
 
from() - Method in class akka.cluster.InternalClusterAction.Welcome
 
from() - Method in class akka.cluster.MetricsGossipEnvelope
 
from(com.typesafe.config.Config) - Method in class akka.dispatch.Dispatchers
INTERNAL API
from() - Method in class akka.remote.RemoteWatcher.ExpectedFirstHeartbeat
 
from(String) - Method in class akka.testkit.JavaTestKit.EventFilter
 
FROM_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
FROM_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
FROM_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
FROM_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
 
fromActor() - Method in class akka.event.LogSource$
 
fromActorRef() - Method in class akka.event.LogSource$
 
fromActorSystem(ActorSystem) - Method in class akka.event.EventStream$
 
fromActorSystem(ActorSystem) - Static method in class akka.event.EventStream
 
fromAnyClass() - Method in class akka.event.LogSource$
 
fromAnyRef(Object) - Method in class akka.event.LogSource$
construct string representation for any object according to rules above with fallback to its Class&rsquo;s simple name.
fromAnyRef(Object, ActorSystem) - Method in class akka.event.LogSource$
construct string representation for any object according to rules above (including the actor system&rsquo;s address) with fallback to its Class&rsquo;s simple name.
fromArray(byte[]) - Method in class akka.util.ByteString$
Creates a new ByteString by copying a byte array.
fromArray(byte[], int, int) - Method in class akka.util.ByteString$
Creates a new ByteString by copying length bytes starting at offset from an Array.
fromArray(byte[]) - Static method in class akka.util.ByteString
Creates a new ByteString by copying a byte array.
fromArray(byte[], int, int) - Static method in class akka.util.ByteString
Creates a new ByteString by copying length bytes starting at offset from an Array.
fromArray(byte[], int, int) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by copying length bytes starting at offset from an Array.
fromArray(byte[], int, int) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by copying length bytes starting at offset from an Array.
fromBinary(byte[], Option<Class<?>>) - Method in class akka.cluster.protobuf.ClusterMessageSerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in class akka.contrib.pattern.protobuf.DistributedPubSubMessageSerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in class akka.persistence.serialization.MessageSerializer
Deserializes PersistentBatch, PersistentRepr and Deliver messages.
fromBinary(byte[], Option<Class<?>>) - Method in class akka.persistence.serialization.SnapshotSerializer
Deserializes a Snapshot.
fromBinary(byte[], Option<Class<?>>) - Method in class akka.remote.serialization.DaemonMsgCreateSerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in class akka.remote.serialization.MessageContainerSerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in class akka.remote.serialization.ProtobufSerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in class akka.serialization.ByteArraySerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in class akka.serialization.JavaSerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in class akka.serialization.JSerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in class akka.serialization.NullSerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in interface akka.serialization.Serializer
Produces an object from an array of bytes, with an optional type-hint; the class should be loaded using ActorSystem.dynamicAccess.
fromBinary(byte[]) - Method in interface akka.serialization.Serializer
Java API: deserialize without type hint
fromBinary(byte[], Class<?>) - Method in interface akka.serialization.Serializer
Java API: deserialize with type hint
fromBinaryJava(byte[], Class<?>) - Method in class akka.serialization.JSerializer
This method must be implemented, manifest may be null.
fromByteBuffer(ByteBuffer) - Method in class akka.util.ByteString$
Creates a new ByteString by copying bytes out of a ByteBuffer.
fromByteBuffer(ByteBuffer) - Static method in class akka.util.ByteString
Creates a new ByteString by copying bytes out of a ByteBuffer.
fromCamelPath(String) - Method in class akka.camel.internal.component.ActorEndpointPath$
Creates an ActorEndpointPath from the uri Expects the uri in the akka ActorPath format, i.e 'akka://system/user/someactor'.
fromCamelPath(String) - Static method in class akka.camel.internal.component.ActorEndpointPath
Creates an ActorEndpointPath from the uri Expects the uri in the akka ActorPath format, i.e 'akka://system/user/someactor'.
fromClass() - Method in class akka.event.LogSource$
 
fromConfig(com.typesafe.config.Config) - Method in class akka.cluster.routing.ClusterRouterGroupSettings$
 
fromConfig(com.typesafe.config.Config) - Static method in class akka.cluster.routing.ClusterRouterGroupSettings
 
fromConfig(com.typesafe.config.Config) - Method in class akka.cluster.routing.ClusterRouterPoolSettings$
 
fromConfig(com.typesafe.config.Config) - Static method in class akka.cluster.routing.ClusterRouterPoolSettings
 
fromConfig(com.typesafe.config.Config, DynamicAccess) - Method in class akka.cluster.routing.MetricsSelector$
 
fromConfig(com.typesafe.config.Config) - Method in class akka.routing.DefaultResizer$
 
fromConfig(com.typesafe.config.Config) - Static method in class akka.routing.DefaultResizer
 
FromConfig - Class in akka.routing
Java API: Router configuration which has no default, i.e.
FromConfig(Option<Resizer>, SupervisorStrategy, String) - Constructor for class akka.routing.FromConfig
 
FromConfig() - Constructor for class akka.routing.FromConfig
 
FromConfig$ - Class in akka.routing
Router configuration which has no default, i.e.
FromConfig$() - Constructor for class akka.routing.FromConfig$
 
fromExecutor(Executor) - Method in class akka.dispatch.ExecutionContexts$
Returns a new ExecutionContextExecutor which will delegate execution to the underlying Executor, and which will use the default error reporter.
fromExecutor(Executor, Procedure<Throwable>) - Method in class akka.dispatch.ExecutionContexts$
Returns a new ExecutionContextExecutor which will delegate execution to the underlying Executor, and which will use the provided error reporter.
fromExecutor(Executor) - Static method in class akka.dispatch.ExecutionContexts
Returns a new ExecutionContextExecutor which will delegate execution to the underlying Executor, and which will use the default error reporter.
fromExecutor(Executor, Procedure<Throwable>) - Static method in class akka.dispatch.ExecutionContexts
Returns a new ExecutionContextExecutor which will delegate execution to the underlying Executor, and which will use the provided error reporter.
fromExecutorService(ExecutorService) - Method in class akka.dispatch.ExecutionContexts$
Returns a new ExecutionContextExecutorService which will delegate execution to the underlying ExecutorService, and which will use the default error reporter.
fromExecutorService(ExecutorService, Procedure<Throwable>) - Method in class akka.dispatch.ExecutionContexts$
Returns a new ExecutionContextExecutorService which will delegate execution to the underlying ExecutorService, and which will use the provided error reporter.
fromExecutorService(ExecutorService) - Static method in class akka.dispatch.ExecutionContexts
Returns a new ExecutionContextExecutorService which will delegate execution to the underlying ExecutorService, and which will use the default error reporter.
fromExecutorService(ExecutorService, Procedure<Throwable>) - Static method in class akka.dispatch.ExecutionContexts
Returns a new ExecutionContextExecutorService which will delegate execution to the underlying ExecutorService, and which will use the provided error reporter.
fromHash(String) - Method in class akka.cluster.VectorClock.Node$
 
fromInts(int...) - Method in class akka.util.ByteString$
JAVA API Creates a new ByteString by copying an int array by converting from integral numbers to bytes.
fromInts(Seq<Object>) - Method in class akka.util.ByteString$
JAVA API Creates a new ByteString by copying an int array by converting from integral numbers to bytes.
fromInts(int...) - Static method in class akka.util.ByteString
JAVA API Creates a new ByteString by copying an int array by converting from integral numbers to bytes.
fromInts(Seq<Object>) - Static method in class akka.util.ByteString
JAVA API Creates a new ByteString by copying an int array by converting from integral numbers to bytes.
fromScalaOption(Option<T>) - Method in class akka.japi.Option$
Converts a Scala Option to a Java Option
fromScalaOption(Option<T>) - Static method in class akka.japi.Option
Converts a Scala Option to a Java Option
fromSequenceNr() - Method in class akka.persistence.journal.AsyncWriteTarget.ReadHighestSequenceNr
 
fromSequenceNr() - Method in class akka.persistence.journal.AsyncWriteTarget.ReplayMessages
 
fromSequenceNr() - Method in class akka.persistence.JournalProtocol.ReadHighestSequenceNr
 
fromSequenceNr() - Method in class akka.persistence.JournalProtocol.ReplayMessages
 
fromSnapshot() - Method in class akka.persistence.Recover
 
fromString(String) - Method in class akka.actor.ActorPath$
Parse string as actor path; throws java.net.MalformedURLException if unable to do so.
fromString() - Method in class akka.event.LogSource$
 
fromString(String) - Method in class akka.util.ByteString$
Creates a new ByteString which will contain the UTF-8 representation of the given String
fromString(String, String) - Method in class akka.util.ByteString$
Creates a new ByteString which will contain the representation of the given String in the given charset
fromString(String) - Static method in class akka.util.ByteString
Creates a new ByteString which will contain the UTF-8 representation of the given String
fromString(String, String) - Static method in class akka.util.ByteString
Creates a new ByteString which will contain the representation of the given String in the given charset
FSM<S,D> - Interface in akka.actor
Finite State Machine actor trait.
fsm() - Method in class akka.remote.testconductor.Controller.NodeInfo
 
FSM$ - Class in akka.actor
 
FSM$() - Constructor for class akka.actor.FSM$
 
FSM.$minus$greater$ - Class in akka.actor
This extractor is just convenience for matching a (S, S) pair, including a reminder what the new state is.
FSM.$minus$greater$() - Constructor for class akka.actor.FSM.$minus$greater$
 
FSM.CurrentState<S> - Class in akka.actor
Message type which is sent directly to the subscribed actor in FSM.SubscribeTransitionCallBack before sending any FSM.Transition messages.
FSM.CurrentState(ActorRef, S) - Constructor for class akka.actor.FSM.CurrentState
 
FSM.CurrentState$ - Class in akka.actor
 
FSM.CurrentState$() - Constructor for class akka.actor.FSM.CurrentState$
 
FSM.Event<D> - Class in akka.actor
All messages sent to the FSM will be wrapped inside an Event, which allows pattern matching to extract both state and data.
FSM.Event(Object, D) - Constructor for class akka.actor.FSM.Event
 
FSM.Event$ - Class in akka.actor
 
FSM.Event$() - Constructor for class akka.actor.FSM.Event$
 
FSM.Failure - Class in akka.actor
Signifies that the FSM is shutting itself down because of an error, e.g.
FSM.Failure(Object) - Constructor for class akka.actor.FSM.Failure
 
FSM.Failure$ - Class in akka.actor
 
FSM.Failure$() - Constructor for class akka.actor.FSM.Failure$
 
FSM.LogEntry<S,D> - Class in akka.actor
Log Entry of the LoggingFSM, can be obtained by calling getLog.
FSM.LogEntry(S, D, Object) - Constructor for class akka.actor.FSM.LogEntry
 
FSM.LogEntry$ - Class in akka.actor
 
FSM.LogEntry$() - Constructor for class akka.actor.FSM.LogEntry$
 
FSM.Normal$ - Class in akka.actor
Default reason if calling stop().
FSM.Normal$() - Constructor for class akka.actor.FSM.Normal$
 
FSM.NullFunction$ - Class in akka.actor
A partial function value which does not match anything and can be used to &ldquo;reset&rdquo; whenUnhandled and onTermination handlers.
FSM.NullFunction$() - Constructor for class akka.actor.FSM.NullFunction$
 
FSM.Reason - Interface in akka.actor
Reason why this FSM is shutting down.
FSM.Shutdown$ - Class in akka.actor
Reason given when someone was calling system.stop(fsm) from outside; also applies to Stop supervision directive.
FSM.Shutdown$() - Constructor for class akka.actor.FSM.Shutdown$
 
FSM.State<S,D> - Class in akka.actor
This captures all of the managed state of the FSM: the state name, the state data, possibly custom timeout, stop reason and replies accumulated while processing the last message.
FSM.State(S, D, Option<FiniteDuration>, Option<FSM.Reason>, List<Object>) - Constructor for class akka.actor.FSM.State
 
FSM.State$ - Class in akka.actor
 
FSM.State$() - Constructor for class akka.actor.FSM.State$
 
FSM.StateTimeout$ - Class in akka.actor
This case object is received in case of a state timeout.
FSM.StateTimeout$() - Constructor for class akka.actor.FSM.StateTimeout$
 
FSM.StopEvent<S,D> - Class in akka.actor
Case class representing the state of the FSM whithin the onTermination block.
FSM.StopEvent(FSM.Reason, S, D) - Constructor for class akka.actor.FSM.StopEvent
 
FSM.StopEvent$ - Class in akka.actor
 
FSM.StopEvent$() - Constructor for class akka.actor.FSM.StopEvent$
 
FSM.SubscribeTransitionCallBack - Class in akka.actor
Send this to an FSM to request first the FSM.CurrentState and then a series of FSM.Transition updates.
FSM.SubscribeTransitionCallBack(ActorRef) - Constructor for class akka.actor.FSM.SubscribeTransitionCallBack
 
FSM.SubscribeTransitionCallBack$ - Class in akka.actor
 
FSM.SubscribeTransitionCallBack$() - Constructor for class akka.actor.FSM.SubscribeTransitionCallBack$
 
FSM.TimeoutMarker - Class in akka.actor
INTERNAL API
FSM.TimeoutMarker(long) - Constructor for class akka.actor.FSM.TimeoutMarker
 
FSM.TimeoutMarker$ - Class in akka.actor
 
FSM.TimeoutMarker$() - Constructor for class akka.actor.FSM.TimeoutMarker$
 
FSM.Timer - Class in akka.actor
INTERNAL API
FSM.Timer(String, Object, boolean, int, ActorContext) - Constructor for class akka.actor.FSM.Timer
 
FSM.Timer$ - Class in akka.actor
 
FSM.Timer$() - Constructor for class akka.actor.FSM.Timer$
 
FSM.TransformHelper - Class in akka.actor
 
FSM.TransformHelper(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Constructor for class akka.actor.FSM.TransformHelper
 
FSM.Transition<S> - Class in akka.actor
Message type which is used to communicate transitions between states to all subscribed listeners (use FSM.SubscribeTransitionCallBack).
FSM.Transition(ActorRef, S, S) - Constructor for class akka.actor.FSM.Transition
 
FSM.Transition$ - Class in akka.actor
 
FSM.Transition$() - Constructor for class akka.actor.FSM.Transition$
 
FSM.UnsubscribeTransitionCallBack - Class in akka.actor
Unsubscribe from FSM.Transition notifications which was effected by sending the corresponding FSM.SubscribeTransitionCallBack.
FSM.UnsubscribeTransitionCallBack(ActorRef) - Constructor for class akka.actor.FSM.UnsubscribeTransitionCallBack
 
FSM.UnsubscribeTransitionCallBack$ - Class in akka.actor
 
FSM.UnsubscribeTransitionCallBack$() - Constructor for class akka.actor.FSM.UnsubscribeTransitionCallBack$
 
FsmDebugEvent() - Method in class akka.actor.ActorSystem.Settings
 
fsmRef() - Method in class akka.actor.FSM.CurrentState
 
fsmRef() - Method in class akka.actor.FSM.Transition
 
FSMStateFunctionBuilder<S,D> - Class in akka.japi.pf
Builder used to create a partial function for FSM.whenUnhandled(scala.PartialFunction, akka.actor.FSM.State>).
FSMStateFunctionBuilder() - Constructor for class akka.japi.pf.FSMStateFunctionBuilder
 
FSMStopBuilder<S,D> - Class in akka.japi.pf
Builder used to create a partial function for FSM.onTermination(scala.PartialFunction, scala.runtime.BoxedUnit>).
FSMStopBuilder() - Constructor for class akka.japi.pf.FSMStopBuilder
 
FSMTransitionHandlerBuilder<S> - Class in akka.japi.pf
Builder used to create a partial function for FSM.onTransition(scala.PartialFunction, scala.runtime.BoxedUnit>).
FSMTransitionHandlerBuilder() - Constructor for class akka.japi.pf.FSMTransitionHandlerBuilder
 
full() - Method in interface akka.actor.LoggingFSM
 
fullAddress(Routee) - Method in interface akka.cluster.routing.ClusterRouterActor
Fills in self address for local ActorRef
fullBackoff() - Method in class akka.remote.EndpointWriter
 
fullBackoffCount() - Method in class akka.remote.EndpointWriter
 
Function<T,R> - Interface in akka.japi
A Function interface.
Function<T,R> - Interface in akka.japi.function
A Function interface.
Function10<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,R> - Interface in akka.japi.function
A Function interface.
Function11<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,R> - Interface in akka.japi.function
A Function interface.
Function12<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,R> - Interface in akka.japi.function
A Function interface.
Function13<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,R> - Interface in akka.japi.function
A Function interface.
Function14<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,R> - Interface in akka.japi.function
A Function interface.
Function15<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,R> - Interface in akka.japi.function
A Function interface.
Function16<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,R> - Interface in akka.japi.function
A Function interface.
Function17<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,R> - Interface in akka.japi.function
A Function interface.
Function18<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,R> - Interface in akka.japi.function
A Function interface.
Function19<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,R> - Interface in akka.japi.function
A Function interface.
Function2<T1,T2,R> - Interface in akka.japi.function
A Function interface.
Function2<T1,T2,R> - Interface in akka.japi
A Function interface.
Function20<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,R> - Interface in akka.japi.function
A Function interface.
Function21<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,R> - Interface in akka.japi.function
A Function interface.
Function22<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,R> - Interface in akka.japi.function
A Function interface.
Function3<T1,T2,T3,R> - Interface in akka.japi.function
A Function interface.
Function4<T1,T2,T3,T4,R> - Interface in akka.japi.function
A Function interface.
Function5<T1,T2,T3,T4,T5,R> - Interface in akka.japi.function
A Function interface.
Function6<T1,T2,T3,T4,T5,T6,R> - Interface in akka.japi.function
A Function interface.
Function7<T1,T2,T3,T4,T5,T6,T7,R> - Interface in akka.japi.function
A Function interface.
Function8<T1,T2,T3,T4,T5,T6,T7,T8,R> - Interface in akka.japi.function
A Function interface.
Function9<T1,T2,T3,T4,T5,T6,T7,T8,T9,R> - Interface in akka.japi.function
A Function interface.
future() - Method in class akka.agent.Agent
A future to the current value that will be completed after any currently queued updates.
future(Callable<T>, ExecutionContext) - Method in class akka.dispatch.Futures$
Starts an asynchronous computation and returns a Future object with the result of that computation.
future(Callable<T>, ExecutionContext) - Static method in class akka.dispatch.Futures
Starts an asynchronous computation and returns a Future object with the result of that computation.
future() - Method in class akka.pattern.PipeToSupport.PipeableFuture
 
Futures - Class in akka.dispatch
Futures is the Java API for Futures and Promises
Futures() - Constructor for class akka.dispatch.Futures
 
Futures$ - Class in akka.dispatch
Futures is the Java API for Futures and Promises
Futures$() - Constructor for class akka.dispatch.Futures$
 
FutureTimeoutSupport - Interface in akka.pattern
Copyright (C) 2009-2014 Typesafe Inc.

G

g() - Method in class akka.cluster.GossipEnvelope
 
gated(boolean, boolean) - Method in class akka.remote.ReliableDeliverySupervisor
 
gatherFromAllOtherQueues(CallingThreadMailbox, MessageQueue) - Method in class akka.testkit.CallingThreadDispatcherQueues
 
gen(Object) - Method in class akka.dispatch.PriorityGenerator
 
generateSecureCookie() - Method in class akka.util.Crypt$
 
generateSecureCookie() - Static method in class akka.util.Crypt
 
generateSeed(int) - Method in class akka.remote.security.provider.InternetSeedGenerator
Generates a seed by trying each of the available strategies in turn until one succeeds.
generation() - Method in interface akka.actor.FSM
 
generation() - Method in class akka.actor.FSM.TimeoutMarker
 
generation() - Method in class akka.actor.FSM.Timer
 
generation() - Method in class akka.remote.testconductor.Controller
 
genString(T) - Method in interface akka.event.LogSource
 
genString(T, ActorSystem) - Method in interface akka.event.LogSource
 
get(ActorSystem) - Method in class akka.actor.ActorDSL.Extension$
Java API: retrieve the ActorDSL extension for the given system.
get(ActorSystem) - Method in interface akka.actor.ExtensionId
Returns an instance of the extension identified by this ExtensionId instance.
get(ActorSystem) - Method in class akka.actor.TypedActor$
 
get(ActorContext) - Method in class akka.actor.TypedActor$
Returns a contextual TypedActorFactory of this extension, this means that any TypedActors created by this TypedActorExtension will be children to the specified context, this allows for creating hierarchies of TypedActors.
get(ActorSystem) - Static method in class akka.actor.TypedActor
 
get(ActorContext) - Static method in class akka.actor.TypedActor
Returns a contextual TypedActorFactory of this extension, this means that any TypedActors created by this TypedActorExtension will be children to the specified context, this allows for creating hierarchies of TypedActors.
get() - Method in class akka.agent.Agent
Java API: Read the internal state of the agent.
get(ActorSystem) - Method in class akka.camel.CamelExtension$
 
get(ActorSystem) - Static method in class akka.camel.CamelExtension
 
get(ActorSystem) - Method in class akka.cluster.Cluster$
 
get(ActorSystem) - Static method in class akka.cluster.Cluster
 
get(ActorSystem) - Method in class akka.contrib.pattern.ClusterReceptionistExtension$
 
get(ActorSystem) - Static method in class akka.contrib.pattern.ClusterReceptionistExtension
 
get(ActorSystem) - Method in class akka.contrib.pattern.ClusterSharding$
 
get(ActorSystem) - Static method in class akka.contrib.pattern.ClusterSharding
 
get(ActorSystem) - Method in class akka.contrib.pattern.DistributedPubSubExtension$
 
get(ActorSystem) - Static method in class akka.contrib.pattern.DistributedPubSubExtension
 
get(ActorSystem) - Method in class akka.event.AddressTerminatedTopic$
 
get(ActorSystem) - Static method in class akka.event.AddressTerminatedTopic
 
get(ActorSystem) - Method in class akka.io.Tcp$
Java API: retrieve the Tcp extension for the given system.
get(ActorSystem) - Static method in class akka.io.Tcp
Java API: retrieve the Tcp extension for the given system.
get(ActorSystem) - Method in class akka.io.Udp$
Java API: retrieve the Udp extension for the given system.
get(ActorSystem) - Static method in class akka.io.Udp
Java API: retrieve the Udp extension for the given system.
get(ActorSystem) - Method in class akka.io.UdpConnected$
Java API: retrieve the UdpConnected extension for the given system.
get(ActorSystem) - Static method in class akka.io.UdpConnected
Java API: retrieve the UdpConnected extension for the given system.
get() - Method in class akka.japi.Option
 
get() - Method in class akka.japi.Option.Some
 
get(ActorSystem) - Method in class akka.persistence.Persistence$
Java API.
get(ActorSystem) - Static method in class akka.persistence.Persistence
Java API.
get(ActorSystem) - Method in class akka.remote.AddressUidExtension$
 
get(ActorSystem) - Static method in class akka.remote.AddressUidExtension
 
get(ActorSystem) - Method in class akka.remote.RemoteMetricsExtension$
 
get(ActorSystem) - Static method in class akka.remote.RemoteMetricsExtension
 
get(ActorSystem) - Method in class akka.remote.testconductor.TestConductor$
Java API: retrieve the TestConductor extension for the given system.
get(ActorSystem) - Static method in class akka.remote.testconductor.TestConductor
Java API: retrieve the TestConductor extension for the given system.
get(String) - Method in class akka.remote.transport.AssociationRegistry$
 
get(String) - Static method in class akka.remote.transport.AssociationRegistry
 
get(ActorSystem) - Method in class akka.remote.transport.TransportAdaptersExtension$
 
get(ActorSystem) - Static method in class akka.remote.transport.TransportAdaptersExtension
 
get(ActorSystem) - Method in class akka.serialization.SerializationExtension$
 
get(ActorSystem) - Static method in class akka.serialization.SerializationExtension
 
get() - Method in class akka.testkit.JavaTestKit.ExpectMsg
 
get() - Method in class akka.testkit.JavaTestKit.ReceiveWhile
 
get(ActorSystem) - Method in class akka.testkit.TestKitExtension$
 
get(ActorSystem) - Static method in class akka.testkit.TestKitExtension
 
get(ActorSystem) - Method in class akka.transactor.TransactorExtension$
 
get(ActorSystem) - Static method in class akka.transactor.TransactorExtension
 
get(ActorSystem) - Method in class akka.zeromq.ZeroMQExtension$
 
get(ActorSystem) - Static method in class akka.zeromq.ZeroMQExtension
 
getAck() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .AcknowledgementInfo ack = 1;
getAck() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
optional .AcknowledgementInfo ack = 1;
getAck() - Method in interface akka.remote.WireFormats.AckAndEnvelopeContainerOrBuilder
optional .AcknowledgementInfo ack = 1;
getAckBuilder() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .AcknowledgementInfo ack = 1;
getAckOrBuilder() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .AcknowledgementInfo ack = 1;
getAckOrBuilder() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
optional .AcknowledgementInfo ack = 1;
getAckOrBuilder() - Method in interface akka.remote.WireFormats.AckAndEnvelopeContainerOrBuilder
optional .AcknowledgementInfo ack = 1;
getActivation() - Method in class akka.camel.javaapi.UntypedConsumerActor
Java API: Returns the Activation interface that can be used to wait on activation or de-activation of Camel endpoints.
getActivation() - Method in class akka.camel.javaapi.UntypedProducerActor
''Java API'': Returns the Activation interface that can be used to wait on activation or de-activation of Camel endpoints.
getActor() - Method in exception akka.actor.ActorInitializationException
 
getActor() - Method in class akka.actor.Terminated
 
getActorRefFor(Object) - Method in class akka.actor.ContextualTypedActorFactory
 
getActorRefFor(Object) - Method in class akka.actor.TypedActorExtension
Retrieves the underlying ActorRef for the supplied TypedActor proxy, or null if none found
getActorRefFor(Object) - Method in interface akka.actor.TypedActorFactory
Retrieves the underlying ActorRef for the supplied TypedActor proxy, or null if none found
getActorSystemConfiguration(org.osgi.framework.BundleContext) - Method in class akka.osgi.ActorSystemActivator
Override this method to define a configuration for your ActorSystem instance.
getActorSystemName(org.osgi.framework.BundleContext) - Method in class akka.osgi.ActorSystemActivator
By default, the ActorSystem name will be set to bundle--ActorSystem.
getAdapterProvider(String) - Method in class akka.remote.transport.TransportAdapters
 
getAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
optional .Address addr = 2;
getAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
optional .Address addr = 2;
getAddr() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressRequestOrBuilder
optional .Address addr = 2;
getAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .AddressRequest addr = 5;
getAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
optional .AddressRequest addr = 5;
getAddr() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
optional .AddressRequest addr = 5;
getAddrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
optional .Address addr = 2;
getAddrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .AddressRequest addr = 5;
getAddress() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
required .Address address = 1;
getAddress() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
required .Address address = 1;
getAddress() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.UniqueAddressOrBuilder
required .Address address = 1;
getAddress() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
required .Address address = 1;
getAddress() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
required .Address address = 1;
getAddress() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.VersionOrBuilder
required .Address address = 1;
GetAddress - Class in akka.remote.testconductor
 
GetAddress(RoleName) - Constructor for class akka.remote.testconductor.GetAddress
 
getAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
required .Address address = 2;
getAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
required .Address address = 2;
getAddress() - Method in interface akka.remote.testconductor.TestConductorProtocol.HelloOrBuilder
required .Address address = 2;
getAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
optional .Address address = 3;
getAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
optional .Address address = 3;
getAddress() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
optional .Address address = 3;
GetAddress$ - Class in akka.remote.testconductor
 
GetAddress$() - Constructor for class akka.remote.testconductor.GetAddress$
 
getAddressBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
required .Address address = 1;
getAddressBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
required .Address address = 1;
getAddressBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
required .Address address = 2;
getAddressBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
optional .Address address = 3;
getAddressFor(RoleName) - Method in interface akka.remote.testconductor.Player
Query remote transport address of named node.
getAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
required int32 addressIndex = 1;
getAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
required int32 addressIndex = 1;
getAddressIndex() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MemberOrBuilder
required int32 addressIndex = 1;
getAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
required int32 addressIndex = 1;
getAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
required int32 addressIndex = 1;
getAddressIndex() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetricsOrBuilder
required int32 addressIndex = 1;
getAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
required int32 addressIndex = 1;
getAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
required int32 addressIndex = 1;
getAddressIndex() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.ObserverReachabilityOrBuilder
required int32 addressIndex = 1;
getAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
required int32 addressIndex = 1;
getAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
required int32 addressIndex = 1;
getAddressIndex() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.SubjectReachabilityOrBuilder
required int32 addressIndex = 1;
getAddressOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
required .Address address = 1;
getAddressOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
required .Address address = 1;
getAddressOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.UniqueAddressOrBuilder
required .Address address = 1;
getAddressOrBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
required .Address address = 1;
getAddressOrBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
required .Address address = 1;
getAddressOrBuilder() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.VersionOrBuilder
required .Address address = 1;
getAddressOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
required .Address address = 2;
getAddressOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
required .Address address = 2;
getAddressOrBuilder() - Method in interface akka.remote.testconductor.TestConductorProtocol.HelloOrBuilder
required .Address address = 2;
getAddressOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
optional .Address address = 3;
getAddressOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
optional .Address address = 3;
getAddressOrBuilder() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
optional .Address address = 3;
getAddressTerminated() - Method in class akka.actor.Terminated
 
getAddrOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
optional .Address addr = 2;
getAddrOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
optional .Address addr = 2;
getAddrOrBuilder() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressRequestOrBuilder
optional .Address addr = 2;
getAddrOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .AddressRequest addr = 5;
getAddrOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
optional .AddressRequest addr = 5;
getAddrOrBuilder() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
optional .AddressRequest addr = 5;
getAddrString(org.jboss.netty.channel.Channel) - Method in class akka.remote.testconductor.RemoteConnection$
 
getAddrString(org.jboss.netty.channel.Channel) - Static method in class akka.remote.testconductor.RemoteConnection
 
getAllAddresses(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .UniqueAddress allAddresses = 1;
getAllAddresses(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
repeated .UniqueAddress allAddresses = 1;
getAllAddresses(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
repeated .UniqueAddress allAddresses = 1;
getAllAddresses(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .Address allAddresses = 1;
getAllAddresses(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
repeated .Address allAddresses = 1;
getAllAddresses(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
repeated .Address allAddresses = 1;
getAllAddressesBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .UniqueAddress allAddresses = 1;
getAllAddressesBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .Address allAddresses = 1;
getAllAddressesBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .UniqueAddress allAddresses = 1;
getAllAddressesBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .Address allAddresses = 1;
getAllAddressesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .UniqueAddress allAddresses = 1;
getAllAddressesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
repeated .UniqueAddress allAddresses = 1;
getAllAddressesCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
repeated .UniqueAddress allAddresses = 1;
getAllAddressesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .Address allAddresses = 1;
getAllAddressesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
repeated .Address allAddresses = 1;
getAllAddressesCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
repeated .Address allAddresses = 1;
getAllAddressesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .UniqueAddress allAddresses = 1;
getAllAddressesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
repeated .UniqueAddress allAddresses = 1;
getAllAddressesList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
repeated .UniqueAddress allAddresses = 1;
getAllAddressesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .Address allAddresses = 1;
getAllAddressesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
repeated .Address allAddresses = 1;
getAllAddressesList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
repeated .Address allAddresses = 1;
getAllAddressesOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .UniqueAddress allAddresses = 1;
getAllAddressesOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
repeated .UniqueAddress allAddresses = 1;
getAllAddressesOrBuilder(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
repeated .UniqueAddress allAddresses = 1;
getAllAddressesOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .Address allAddresses = 1;
getAllAddressesOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
repeated .Address allAddresses = 1;
getAllAddressesOrBuilder(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
repeated .Address allAddresses = 1;
getAllAddressesOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .UniqueAddress allAddresses = 1;
getAllAddressesOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
repeated .UniqueAddress allAddresses = 1;
getAllAddressesOrBuilderList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
repeated .UniqueAddress allAddresses = 1;
getAllAddressesOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .Address allAddresses = 1;
getAllAddressesOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
repeated .Address allAddresses = 1;
getAllAddressesOrBuilderList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
repeated .Address allAddresses = 1;
getAllButSelf() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
required bool allButSelf = 2;
getAllButSelf() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
required bool allButSelf = 2;
getAllButSelf() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAllOrBuilder
required bool allButSelf = 2;
getAllChildStats() - Method in interface akka.actor.dungeon.Children
 
getAllHashes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated string allHashes = 3;
getAllHashes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
repeated string allHashes = 3;
getAllHashes(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
repeated string allHashes = 3;
getAllHashes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
repeated string allHashes = 2;
getAllHashes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
repeated string allHashes = 2;
getAllHashes(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipStatusOrBuilder
repeated string allHashes = 2;
getAllHashesBytes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated string allHashes = 3;
getAllHashesBytes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
repeated string allHashes = 3;
getAllHashesBytes(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
repeated string allHashes = 3;
getAllHashesBytes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
repeated string allHashes = 2;
getAllHashesBytes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
repeated string allHashes = 2;
getAllHashesBytes(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipStatusOrBuilder
repeated string allHashes = 2;
getAllHashesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated string allHashes = 3;
getAllHashesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
repeated string allHashes = 3;
getAllHashesCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
repeated string allHashes = 3;
getAllHashesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
repeated string allHashes = 2;
getAllHashesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
repeated string allHashes = 2;
getAllHashesCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipStatusOrBuilder
repeated string allHashes = 2;
getAllHashesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated string allHashes = 3;
getAllHashesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
repeated string allHashes = 3;
getAllHashesList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
repeated string allHashes = 3;
getAllHashesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
repeated string allHashes = 2;
getAllHashesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
repeated string allHashes = 2;
getAllHashesList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipStatusOrBuilder
repeated string allHashes = 2;
getAllMetricNames(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated string allMetricNames = 2;
getAllMetricNames(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
repeated string allMetricNames = 2;
getAllMetricNames(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
repeated string allMetricNames = 2;
getAllMetricNamesBytes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated string allMetricNames = 2;
getAllMetricNamesBytes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
repeated string allMetricNames = 2;
getAllMetricNamesBytes(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
repeated string allMetricNames = 2;
getAllMetricNamesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated string allMetricNames = 2;
getAllMetricNamesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
repeated string allMetricNames = 2;
getAllMetricNamesCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
repeated string allMetricNames = 2;
getAllMetricNamesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated string allMetricNames = 2;
getAllMetricNamesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
repeated string allMetricNames = 2;
getAllMetricNamesList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
repeated string allMetricNames = 2;
getAllRoles() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
Java API: All node roles in the cluster
getAllRoles(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated string allRoles = 2;
getAllRoles(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
repeated string allRoles = 2;
getAllRoles(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
repeated string allRoles = 2;
getAllRolesBytes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated string allRoles = 2;
getAllRolesBytes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
repeated string allRoles = 2;
getAllRolesBytes(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
repeated string allRoles = 2;
getAllRolesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated string allRoles = 2;
getAllRolesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
repeated string allRoles = 2;
getAllRolesCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
repeated string allRoles = 2;
getAllRolesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated string allRoles = 2;
getAllRolesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
repeated string allRoles = 2;
getAllRolesList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
repeated string allRoles = 2;
getAlpha() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
required double alpha = 2;
getAlpha() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
required double alpha = 2;
getAlpha() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMAOrBuilder
required double alpha = 2;
getAnyRef(String) - Method in class akka.dispatch.CachingConfig
 
getAnyRefList(String) - Method in class akka.dispatch.CachingConfig
 
getArgs(int) - Method in class akka.remote.WireFormats.PropsData.Builder
repeated bytes args = 4;
getArgs(int) - Method in class akka.remote.WireFormats.PropsData
repeated bytes args = 4;
getArgs(int) - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
repeated bytes args = 4;
getArgsCount() - Method in class akka.remote.WireFormats.PropsData.Builder
repeated bytes args = 4;
getArgsCount() - Method in class akka.remote.WireFormats.PropsData
repeated bytes args = 4;
getArgsCount() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
repeated bytes args = 4;
getArgsList() - Method in class akka.remote.WireFormats.PropsData.Builder
repeated bytes args = 4;
getArgsList() - Method in class akka.remote.WireFormats.PropsData
repeated bytes args = 4;
getArgsList() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
repeated bytes args = 4;
getAutoAck() - Method in interface akka.camel.internal.component.ActorEndpointConfig
 
getBarrier() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .EnterBarrier barrier = 2;
getBarrier() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
optional .EnterBarrier barrier = 2;
getBarrier() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
optional .EnterBarrier barrier = 2;
getBarrierBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .EnterBarrier barrier = 2;
getBarrierOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .EnterBarrier barrier = 2;
getBarrierOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
optional .EnterBarrier barrier = 2;
getBarrierOrBuilder() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
optional .EnterBarrier barrier = 2;
getBatch(int) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
repeated .PersistentMessage batch = 1;
getBatch(int) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
repeated .PersistentMessage batch = 1;
getBatch(int) - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageBatchOrBuilder
repeated .PersistentMessage batch = 1;
getBatchBuilder(int) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
repeated .PersistentMessage batch = 1;
getBatchBuilderList() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
repeated .PersistentMessage batch = 1;
getBatchCount() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
repeated .PersistentMessage batch = 1;
getBatchCount() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
repeated .PersistentMessage batch = 1;
getBatchCount() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageBatchOrBuilder
repeated .PersistentMessage batch = 1;
getBatchList() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
repeated .PersistentMessage batch = 1;
getBatchList() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
repeated .PersistentMessage batch = 1;
getBatchList() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageBatchOrBuilder
repeated .PersistentMessage batch = 1;
getBatchOrBuilder(int) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
repeated .PersistentMessage batch = 1;
getBatchOrBuilder(int) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
repeated .PersistentMessage batch = 1;
getBatchOrBuilder(int) - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageBatchOrBuilder
repeated .PersistentMessage batch = 1;
getBatchOrBuilderList() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
repeated .PersistentMessage batch = 1;
getBatchOrBuilderList() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
repeated .PersistentMessage batch = 1;
getBatchOrBuilderList() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageBatchOrBuilder
repeated .PersistentMessage batch = 1;
getBodyAs(Class<T>, org.apache.camel.CamelContext) - Method in class akka.camel.CamelMessage
Java API: Returns the body of the message converted to the type as given by the clazz parameter.
getBoolean(String) - Method in class akka.dispatch.CachingConfig
 
getBooleanList(String) - Method in class akka.dispatch.CachingConfig
 
getBuckets(int) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
repeated .Delta.Bucket buckets = 1;
getBuckets(int) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
repeated .Delta.Bucket buckets = 1;
getBuckets(int) - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.DeltaOrBuilder
repeated .Delta.Bucket buckets = 1;
getBucketsBuilder(int) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
repeated .Delta.Bucket buckets = 1;
getBucketsBuilderList() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
repeated .Delta.Bucket buckets = 1;
getBucketsCount() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
repeated .Delta.Bucket buckets = 1;
getBucketsCount() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
repeated .Delta.Bucket buckets = 1;
getBucketsCount() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.DeltaOrBuilder
repeated .Delta.Bucket buckets = 1;
getBucketsList() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
repeated .Delta.Bucket buckets = 1;
getBucketsList() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
repeated .Delta.Bucket buckets = 1;
getBucketsList() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.DeltaOrBuilder
repeated .Delta.Bucket buckets = 1;
getBucketsOrBuilder(int) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
repeated .Delta.Bucket buckets = 1;
getBucketsOrBuilder(int) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
repeated .Delta.Bucket buckets = 1;
getBucketsOrBuilder(int) - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.DeltaOrBuilder
repeated .Delta.Bucket buckets = 1;
getBucketsOrBuilderList() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
repeated .Delta.Bucket buckets = 1;
getBucketsOrBuilderList() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
repeated .Delta.Bucket buckets = 1;
getBucketsOrBuilderList() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.DeltaOrBuilder
repeated .Delta.Bucket buckets = 1;
getByName(String) - Method in interface akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer
 
getByName(String) - Method in interface akka.actor.dungeon.ChildrenContainer
 
getByName(String) - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
 
getByName(String) - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
 
getByRef(ActorRef) - Method in interface akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer
 
getByRef(ActorRef) - Method in interface akka.actor.dungeon.ChildrenContainer
 
getByRef(ActorRef) - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
 
getByRef(ActorRef) - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
 
getByte() - Method in class akka.util.ByteIterator
Get a single Byte from this iterator.
getByteBuffers() - Method in class akka.util.ByteString
Java API: Returns an Iterable of read-only ByteBuffers that directly wraps this ByteStrings all fragments.
getBytes(String) - Method in class akka.dispatch.CachingConfig
 
getBytes(byte[], int, int) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
getBytes(byte[]) - Method in class akka.util.ByteIterator
Get a specific number of Bytes from this iterator.
getBytes(byte[], int, int) - Method in class akka.util.ByteIterator
Get a specific number of Bytes from this iterator.
getBytes(byte[], int, int) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
getBytesList(String) - Method in class akka.dispatch.CachingConfig
 
getCallerClass() - Method in class akka.util.Reflect$
This optionally holds a function which looks N levels above itself on the call stack and returns the Class[_] object for the code executing in that stack frame.
getCallerClass() - Static method in class akka.util.Reflect
This optionally holds a function which looks N levels above itself on the call stack and returns the Class[_] object for the code executing in that stack frame.
getCallerName(Class<?>) - Method in class akka.testkit.AkkaSpec$
 
getCallerName(Class<?>) - Static method in class akka.testkit.AkkaSpec
 
getCamelContext() - Method in class akka.camel.javaapi.UntypedConsumerActor
Java API: Returns the org.apache.camel.impl.DefaultCamelContext
getCamelContext() - Method in class akka.camel.javaapi.UntypedProducerActor
Returns the CamelContext.
getCause() - Method in class akka.event.Logging.LogEventException
 
getCause() - Method in exception akka.pattern.AskTimeoutException
 
getCause() - Method in class akka.remote.AssociationErrorEvent
 
getCause() - Method in class akka.remote.RemotingErrorEvent
 
getChannel() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
optional string channel = 5;
getChannel() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
optional string channel = 5;
getChannel() - Method in interface akka.persistence.serialization.MessageFormats.DeliveredMessageOrBuilder
optional string channel = 5;
getChannelBytes() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
optional string channel = 5;
getChannelBytes() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
optional string channel = 5;
getChannelBytes() - Method in interface akka.persistence.serialization.MessageFormats.DeliveredMessageOrBuilder
optional string channel = 5;
getChannelId() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
optional string channelId = 2;
getChannelId() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
optional string channelId = 2;
getChannelId() - Method in interface akka.persistence.serialization.MessageFormats.DeliveredMessageOrBuilder
optional string channelId = 2;
getChannelIdBytes() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
optional string channelId = 2;
getChannelIdBytes() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
optional string channelId = 2;
getChannelIdBytes() - Method in interface akka.persistence.serialization.MessageFormats.DeliveredMessageOrBuilder
optional string channelId = 2;
getChild(String) - Method in interface akka.actor.AbstractActorContext
Returns a reference to the named child or null if no child with that name exists.
getChild(String) - Method in interface akka.actor.dungeon.Children
 
getChild(Iterator<String>) - Method in class akka.actor.InternalActorRef
Obtain ActorRef by possibly traversing the actor tree or looking it up at some provider-specific location.
getChild(Iterator<String>) - Method in class akka.actor.LocalActorRef
 
getChild(Iterator<String>) - Method in interface akka.actor.MinimalActorRef
 
getChild(Iterator<String>) - Method in class akka.actor.RepointableActorRef
 
getChild(String) - Method in interface akka.actor.UntypedActorContext
Returns a reference to the named child or null if no child with that name exists.
getChild(String) - Method in class akka.actor.VirtualPathContainer
 
getChild(Iterator<String>) - Method in class akka.actor.VirtualPathContainer
 
getChild(Iterator<String>) - Method in class akka.remote.RemoteActorRef
 
getChild(Iterator<String>) - Method in class akka.remote.RemoteSystemDaemon
Find the longest matching path which we know about and return that ref (or ask that ref to continue searching if elements are left).
getChildByName(String) - Method in interface akka.actor.Cell
Get the stats for the named child, if that exists.
getChildByName(String) - Method in interface akka.actor.dungeon.Children
 
getChildByName(String) - Method in class akka.actor.UnstartedCell
 
getChildByRef(ActorRef) - Method in interface akka.actor.dungeon.Children
 
getChildren() - Method in interface akka.actor.AbstractActorContext
Returns an unmodifiable Java Collection containing the linked actors, please note that the backing map is thread-safe but not immutable
getChildren() - Method in interface akka.actor.dungeon.Children
 
getChildren() - Method in interface akka.actor.UntypedActorContext
Returns an unmodifiable Java Collection containing the linked actors, please note that the backing map is thread-safe but not immutable
getClasses(int) - Method in class akka.remote.WireFormats.PropsData.Builder
repeated string classes = 5;
getClasses(int) - Method in class akka.remote.WireFormats.PropsData
repeated string classes = 5;
getClasses(int) - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
repeated string classes = 5;
getClassesBytes(int) - Method in class akka.remote.WireFormats.PropsData.Builder
repeated string classes = 5;
getClassesBytes(int) - Method in class akka.remote.WireFormats.PropsData
repeated string classes = 5;
getClassesBytes(int) - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
repeated string classes = 5;
getClassesCount() - Method in class akka.remote.WireFormats.PropsData.Builder
repeated string classes = 5;
getClassesCount() - Method in class akka.remote.WireFormats.PropsData
repeated string classes = 5;
getClassesCount() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
repeated string classes = 5;
getClassesList() - Method in class akka.remote.WireFormats.PropsData.Builder
repeated string classes = 5;
getClassesList() - Method in class akka.remote.WireFormats.PropsData
repeated string classes = 5;
getClassesList() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
repeated string classes = 5;
getClassFor(String, ClassTag<T>) - Method in class akka.actor.DynamicAccess
Obtain a Class[_] object loaded with the right class loader (i.e.
getClassFor(String, ClassTag<T>) - Method in class akka.actor.ReflectiveDynamicAccess
 
getClazz(T) - Method in interface akka.event.LogSource
 
getClazz() - Method in class akka.remote.WireFormats.PropsData.Builder
required string clazz = 3;
getClazz() - Method in class akka.remote.WireFormats.PropsData
required string clazz = 3;
getClazz() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
required string clazz = 3;
getClazzBytes() - Method in class akka.remote.WireFormats.PropsData.Builder
required string clazz = 3;
getClazzBytes() - Method in class akka.remote.WireFormats.PropsData
required string clazz = 3;
getClazzBytes() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
required string clazz = 3;
getClusterShuttingDownInstance() - Method in class akka.cluster.ClusterEvent$
Java API: get the singleton instance of ClusterShuttingDown event
getClusterShuttingDownInstance() - Static method in class akka.cluster.ClusterEvent
Java API: get the singleton instance of ClusterShuttingDown event
getClusterStatus() - Method in interface akka.cluster.ClusterNodeMBean
 
getCommandType() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
required .CommandType commandType = 1;
getCommandType() - Method in class akka.remote.WireFormats.AkkaControlMessage
required .CommandType commandType = 1;
getCommandType() - Method in interface akka.remote.WireFormats.AkkaControlMessageOrBuilder
required .CommandType commandType = 1;
getConfig(String) - Method in class akka.dispatch.CachingConfig
 
getConfig() - Method in class akka.remote.WireFormats.DeployData.Builder
optional bytes config = 2;
getConfig() - Method in class akka.remote.WireFormats.DeployData
optional bytes config = 2;
getConfig() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
optional bytes config = 2;
getConfigList(String) - Method in class akka.dispatch.CachingConfig
 
getConfirmable() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional bool confirmable = 8;
getConfirmable() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional bool confirmable = 8;
getConfirmable() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional bool confirmable = 8;
getConfirmMessage() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional .DeliveredMessage confirmMessage = 9;
getConfirmMessage() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional .DeliveredMessage confirmMessage = 9;
getConfirmMessage() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional .DeliveredMessage confirmMessage = 9;
getConfirmMessageBuilder() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional .DeliveredMessage confirmMessage = 9;
getConfirmMessageOrBuilder() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional .DeliveredMessage confirmMessage = 9;
getConfirmMessageOrBuilder() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional .DeliveredMessage confirmMessage = 9;
getConfirmMessageOrBuilder() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional .DeliveredMessage confirmMessage = 9;
getConfirms() - Method in interface akka.persistence.PersistentRepr
Java API, Plugin API: channel ids of delivery confirmations that are available for this message.
getConfirms(int) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
repeated string confirms = 7;
getConfirms(int) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
repeated string confirms = 7;
getConfirms(int) - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
repeated string confirms = 7;
getConfirmsBytes(int) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
repeated string confirms = 7;
getConfirmsBytes(int) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
repeated string confirms = 7;
getConfirmsBytes(int) - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
repeated string confirms = 7;
getConfirmsCount() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
repeated string confirms = 7;
getConfirmsCount() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
repeated string confirms = 7;
getConfirmsCount() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
repeated string confirms = 7;
getConfirmsList() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
repeated string confirms = 7;
getConfirmsList() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
repeated string confirms = 7;
getConfirmsList() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
repeated string confirms = 7;
getConfirmTarget() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string confirmTarget = 10;
getConfirmTarget() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional string confirmTarget = 10;
getConfirmTarget() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional string confirmTarget = 10;
getConfirmTargetBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string confirmTarget = 10;
getConfirmTargetBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional string confirmTarget = 10;
getConfirmTargetBytes() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional string confirmTarget = 10;
getContent(int) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
repeated .Delta.Entry content = 3;
getContent(int) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
repeated .Delta.Entry content = 3;
getContent(int) - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.BucketOrBuilder
repeated .Delta.Entry content = 3;
getContentBuilder(int) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
repeated .Delta.Entry content = 3;
getContentBuilderList() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
repeated .Delta.Entry content = 3;
getContentCount() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
repeated .Delta.Entry content = 3;
getContentCount() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
repeated .Delta.Entry content = 3;
getContentCount() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.BucketOrBuilder
repeated .Delta.Entry content = 3;
getContentList() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
repeated .Delta.Entry content = 3;
getContentList() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
repeated .Delta.Entry content = 3;
getContentList() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.BucketOrBuilder
repeated .Delta.Entry content = 3;
getContentOrBuilder(int) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
repeated .Delta.Entry content = 3;
getContentOrBuilder(int) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
repeated .Delta.Entry content = 3;
getContentOrBuilder(int) - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.BucketOrBuilder
repeated .Delta.Entry content = 3;
getContentOrBuilderList() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
repeated .Delta.Entry content = 3;
getContentOrBuilderList() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
repeated .Delta.Entry content = 3;
getContentOrBuilderList() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.BucketOrBuilder
repeated .Delta.Entry content = 3;
getContext() - Method in class akka.actor.AbstractActor
Returns this AbstractActor's AbstractActorContext The AbstractActorContext is not thread safe so do not expose it outside of the AbstractActor.
getContext() - Method in class akka.actor.UntypedActor
Returns this UntypedActor's UntypedActorContext The UntypedActorContext is not thread safe so do not expose it outside of the UntypedActor.
getContext(ExtendedActorSystem) - Method in interface akka.camel.ContextProvider
Retrieve or create a Camel Context for the given actor system Called once per actor system
getContext(ExtendedActorSystem) - Method in class akka.camel.DefaultContextProvider
 
getCookie() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
optional string cookie = 3;
getCookie() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
optional string cookie = 3;
getCookie() - Method in interface akka.remote.WireFormats.AkkaHandshakeInfoOrBuilder
optional string cookie = 3;
getCookieBytes() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
optional string cookie = 3;
getCookieBytes() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
optional string cookie = 3;
getCookieBytes() - Method in interface akka.remote.WireFormats.AkkaHandshakeInfoOrBuilder
optional string cookie = 3;
getCumulativeAck() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
required fixed64 cumulativeAck = 1;
getCumulativeAck() - Method in class akka.remote.WireFormats.AcknowledgementInfo
required fixed64 cumulativeAck = 1;
getCumulativeAck() - Method in interface akka.remote.WireFormats.AcknowledgementInfoOrBuilder
required fixed64 cumulativeAck = 1;
getCurrentDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
required int64 currentDeliveryId = 1;
getCurrentDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
required int64 currentDeliveryId = 1;
getCurrentDeliveryId() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshotOrBuilder
required int64 currentDeliveryId = 1;
getCurrentPersistentMessage() - Method in interface akka.persistence.Recovery
Java API: returns the current persistent message or null if there is none.
getDeadline(Option<FiniteDuration>) - Method in class akka.remote.testconductor.BarrierCoordinator
 
getDefaultAddress() - Method in interface akka.actor.ActorRefProvider
Obtain the external address of the default transport.
getDefaultAddress() - Method in class akka.actor.LocalActorRefProvider
 
getDefaultAddress() - Method in class akka.remote.RemoteActorRefProvider
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Join
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
 
getDefaultInstance() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
getDefaultInstance() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
getDefaultInstance() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
getDefaultInstance() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
 
getDefaultInstance() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
getDefaultInstance() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
 
getDefaultInstance() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
getDefaultInstance() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
getDefaultInstance() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
 
getDefaultInstance() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
 
getDefaultInstance() - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
getDefaultInstance() - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
getDefaultInstance() - Static method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
getDefaultInstance() - Static method in class akka.persistence.serialization.MessageFormats.DeliverMessage
 
getDefaultInstance() - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
getDefaultInstance() - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
 
getDefaultInstance() - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
getDefaultInstance() - Static method in class akka.remote.ContainerFormats.Selection
 
getDefaultInstance() - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
getDefaultInstance() - Static method in class akka.remote.testconductor.TestConductorProtocol.Address
 
getDefaultInstance() - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
getDefaultInstance() - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
getDefaultInstance() - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
getDefaultInstance() - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
getDefaultInstance() - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.ActorRefData
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.AddressData
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.DeployData
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.PropsData
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.SerializedMessage
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty.Builder
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
 
getDefaultInstanceForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
 
getDefaultInstanceForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
getDefaultInstanceForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
 
getDefaultInstanceForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
getDefaultInstanceForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
 
getDefaultInstanceForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
 
getDefaultInstanceForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
getDefaultInstanceForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
 
getDefaultInstanceForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload.Builder
 
getDefaultInstanceForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
getDefaultInstanceForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish.Builder
 
getDefaultInstanceForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
 
getDefaultInstanceForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
 
getDefaultInstanceForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
getDefaultInstanceForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
 
getDefaultInstanceForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
getDefaultInstanceForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
 
getDefaultInstanceForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
 
getDefaultInstanceForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
 
getDefaultInstanceForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
 
getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
 
getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
 
getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
 
getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage.Builder
 
getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage
 
getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
 
getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
 
getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
 
getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
 
getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.Selection.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.Selection
 
getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.ActorRefData.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.ActorRefData
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AddressData.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AddressData
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.DeployData.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.DeployData
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.PropsData.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.PropsData
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.SerializedMessage
 
getDeleted() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional bool deleted = 4;
getDeleted() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional bool deleted = 4;
getDeleted() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional bool deleted = 4;
getDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required int64 deliveryId = 1;
getDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
required int64 deliveryId = 1;
getDeliveryId() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder
required int64 deliveryId = 1;
getDeliverySequenceNr() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
optional int64 deliverySequenceNr = 4;
getDeliverySequenceNr() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
optional int64 deliverySequenceNr = 4;
getDeliverySequenceNr() - Method in interface akka.persistence.serialization.MessageFormats.DeliveredMessageOrBuilder
optional int64 deliverySequenceNr = 4;
getDeliverySnapshot() - Method in interface akka.persistence.AtLeastOnceDelivery
Full state of the AtLeastOnceDelivery.
getDeploy() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .DeployData deploy = 2;
getDeploy() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
required .DeployData deploy = 2;
getDeploy() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
required .DeployData deploy = 2;
getDeploy() - Method in class akka.remote.WireFormats.PropsData.Builder
required .DeployData deploy = 2;
getDeploy() - Method in class akka.remote.WireFormats.PropsData
required .DeployData deploy = 2;
getDeploy() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
required .DeployData deploy = 2;
getDeployBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .DeployData deploy = 2;
getDeployBuilder() - Method in class akka.remote.WireFormats.PropsData.Builder
required .DeployData deploy = 2;
getDeployOrBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .DeployData deploy = 2;
getDeployOrBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
required .DeployData deploy = 2;
getDeployOrBuilder() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
required .DeployData deploy = 2;
getDeployOrBuilder() - Method in class akka.remote.WireFormats.PropsData.Builder
required .DeployData deploy = 2;
getDeployOrBuilder() - Method in class akka.remote.WireFormats.PropsData
required .DeployData deploy = 2;
getDeployOrBuilder() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
required .DeployData deploy = 2;
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Empty.Builder
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Join
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
getDescriptor() - Static method in enum akka.cluster.protobuf.msg.ClusterMessages.MemberStatus
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
getDescriptor() - Static method in enum akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberType
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
getDescriptor() - Static method in enum akka.cluster.protobuf.msg.ClusterMessages.ReachabilityStatus
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
 
getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
 
getDescriptor() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
 
getDescriptor() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
getDescriptor() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
 
getDescriptor() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
getDescriptor() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
 
getDescriptor() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
 
getDescriptor() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
getDescriptor() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
 
getDescriptor() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages
 
getDescriptor() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload.Builder
 
getDescriptor() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
getDescriptor() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish.Builder
 
getDescriptor() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
 
getDescriptor() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
 
getDescriptor() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
getDescriptor() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
 
getDescriptor() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
getDescriptor() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
 
getDescriptor() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
 
getDescriptor() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
 
getDescriptor() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.DeliverMessage.Builder
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.DeliverMessage
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
getDescriptor() - Static method in class akka.remote.ContainerFormats
 
getDescriptor() - Static method in enum akka.remote.ContainerFormats.PatternType
 
getDescriptor() - Static method in class akka.remote.ContainerFormats.Selection.Builder
 
getDescriptor() - Static method in class akka.remote.ContainerFormats.Selection
 
getDescriptor() - Static method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
getDescriptor() - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.Address
 
getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
getDescriptor() - Static method in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
 
getDescriptor() - Static method in enum akka.remote.testconductor.TestConductorProtocol.Direction
 
getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
getDescriptor() - Static method in enum akka.remote.testconductor.TestConductorProtocol.FailType
 
getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol
 
getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
getDescriptor() - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
getDescriptor() - Static method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
getDescriptor() - Static method in class akka.remote.WireFormats.ActorRefData.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.ActorRefData
 
getDescriptor() - Static method in class akka.remote.WireFormats.AddressData.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.AddressData
 
getDescriptor() - Static method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
getDescriptor() - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
getDescriptor() - Static method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
getDescriptor() - Static method in enum akka.remote.WireFormats.CommandType
 
getDescriptor() - Static method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
getDescriptor() - Static method in class akka.remote.WireFormats.DeployData.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.DeployData
 
getDescriptor() - Static method in class akka.remote.WireFormats
 
getDescriptor() - Static method in class akka.remote.WireFormats.PropsData.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.PropsData
 
getDescriptor() - Static method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
getDescriptor() - Static method in class akka.remote.WireFormats.SerializedMessage.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.SerializedMessage
 
getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
 
getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty.Builder
 
getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
 
getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
 
getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
 
getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
 
getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
 
getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
 
getDescriptorForType() - Method in enum akka.cluster.protobuf.msg.ClusterMessages.MemberStatus
 
getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
 
getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
 
getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
 
getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
 
getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
 
getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
 
getDescriptorForType() - Method in enum akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberType
 
getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
 
getDescriptorForType() - Method in enum akka.cluster.protobuf.msg.ClusterMessages.ReachabilityStatus
 
getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
 
getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
 
getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
 
getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
 
getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
 
getDescriptorForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
 
getDescriptorForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
 
getDescriptorForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
 
getDescriptorForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
 
getDescriptorForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload.Builder
 
getDescriptorForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish.Builder
 
getDescriptorForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
 
getDescriptorForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
 
getDescriptorForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
 
getDescriptorForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
 
getDescriptorForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
 
getDescriptorForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
 
getDescriptorForType() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
 
getDescriptorForType() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage.Builder
 
getDescriptorForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
 
getDescriptorForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
 
getDescriptorForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
 
getDescriptorForType() - Method in enum akka.remote.ContainerFormats.PatternType
 
getDescriptorForType() - Method in class akka.remote.ContainerFormats.Selection.Builder
 
getDescriptorForType() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
getDescriptorForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
getDescriptorForType() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
getDescriptorForType() - Method in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
 
getDescriptorForType() - Method in enum akka.remote.testconductor.TestConductorProtocol.Direction
 
getDescriptorForType() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
getDescriptorForType() - Method in enum akka.remote.testconductor.TestConductorProtocol.FailType
 
getDescriptorForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
getDescriptorForType() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
getDescriptorForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
getDescriptorForType() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
getDescriptorForType() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
getDescriptorForType() - Method in class akka.remote.WireFormats.ActorRefData.Builder
 
getDescriptorForType() - Method in class akka.remote.WireFormats.AddressData.Builder
 
getDescriptorForType() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
getDescriptorForType() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
getDescriptorForType() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
getDescriptorForType() - Method in enum akka.remote.WireFormats.CommandType
 
getDescriptorForType() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
getDescriptorForType() - Method in class akka.remote.WireFormats.DeployData.Builder
 
getDescriptorForType() - Method in class akka.remote.WireFormats.PropsData.Builder
 
getDescriptorForType() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
getDescriptorForType() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
getDestination() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required string destination = 2;
getDestination() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
required string destination = 2;
getDestination() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder
required string destination = 2;
getDestination() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage.Builder
optional string destination = 2;
getDestination() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage
optional string destination = 2;
getDestination() - Method in interface akka.persistence.serialization.MessageFormats.DeliverMessageOrBuilder
optional string destination = 2;
getDestinationBytes() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required string destination = 2;
getDestinationBytes() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
required string destination = 2;
getDestinationBytes() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder
required string destination = 2;
getDestinationBytes() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage.Builder
optional string destination = 2;
getDestinationBytes() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage
optional string destination = 2;
getDestinationBytes() - Method in interface akka.persistence.serialization.MessageFormats.DeliverMessageOrBuilder
optional string destination = 2;
getDirection() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
optional .Direction direction = 2;
getDirection() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
optional .Direction direction = 2;
getDirection() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
optional .Direction direction = 2;
getDispatcher() - Method in class akka.remote.WireFormats.DeployData.Builder
optional string dispatcher = 5;
getDispatcher() - Method in class akka.remote.WireFormats.DeployData
optional string dispatcher = 5;
getDispatcher() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
optional string dispatcher = 5;
getDispatcherBytes() - Method in class akka.remote.WireFormats.DeployData.Builder
optional string dispatcher = 5;
getDispatcherBytes() - Method in class akka.remote.WireFormats.DeployData
optional string dispatcher = 5;
getDispatcherBytes() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
optional string dispatcher = 5;
getDone() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional string done = 4;
getDone() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
optional string done = 4;
getDone() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
optional string done = 4;
getDoneBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional string done = 4;
getDoneBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
optional string done = 4;
getDoneBytes() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
optional string done = 4;
getDouble(String) - Method in class akka.dispatch.CachingConfig
 
getDouble(ByteOrder) - Method in class akka.util.ByteIterator
 
getDoubleList(String) - Method in class akka.dispatch.CachingConfig
 
getDoubles(double[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
getDoubles(double[], ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Doubles from this iterator.
getDoubles(double[], int, int, ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Doubles from this iterator.
getDoubles(double[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
getDuration(String, TimeUnit) - Method in class akka.dispatch.CachingConfig
 
getDurationList(String, TimeUnit) - Method in class akka.dispatch.CachingConfig
 
getElements() - Method in interface akka.actor.ActorPath
Java API: Sequence of names for this path from root to this.
getEnclosedMessage() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload.Builder
required bytes enclosedMessage = 1;
getEnclosedMessage() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
required bytes enclosedMessage = 1;
getEnclosedMessage() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.PayloadOrBuilder
required bytes enclosedMessage = 1;
getEnclosedMessage() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
required bytes enclosedMessage = 1;
getEnclosedMessage() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
required bytes enclosedMessage = 1;
getEnclosedMessage() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
required bytes enclosedMessage = 1;
getEndpointUri() - Method in class akka.camel.javaapi.UntypedConsumerActor
Java API: Returns the Camel endpoint URI to consume messages from.
getEndpointUri() - Method in class akka.camel.javaapi.UntypedProducerActor
Returns the Camel endpoint URI to produce messages to.
getEnvelope() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .RemoteEnvelope envelope = 2;
getEnvelope() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
optional .RemoteEnvelope envelope = 2;
getEnvelope() - Method in interface akka.remote.WireFormats.AckAndEnvelopeContainerOrBuilder
optional .RemoteEnvelope envelope = 2;
getEnvelopeBuilder() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .RemoteEnvelope envelope = 2;
getEnvelopeOrBuilder() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .RemoteEnvelope envelope = 2;
getEnvelopeOrBuilder() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
optional .RemoteEnvelope envelope = 2;
getEnvelopeOrBuilder() - Method in interface akka.remote.WireFormats.AckAndEnvelopeContainerOrBuilder
optional .RemoteEnvelope envelope = 2;
getErrorCause() - Method in interface akka.io.Tcp.ConnectionClosed
If isErrorClosed returns true, then the error condition can be retrieved by this method.
getErrorCause() - Method in class akka.io.Tcp.ErrorClosed
 
getEwma() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
optional .NodeMetrics.EWMA ewma = 3;
getEwma() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
optional .NodeMetrics.EWMA ewma = 3;
getEwma() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.MetricOrBuilder
optional .NodeMetrics.EWMA ewma = 3;
getEwmaBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
optional .NodeMetrics.EWMA ewma = 3;
getEwmaOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
optional .NodeMetrics.EWMA ewma = 3;
getEwmaOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
optional .NodeMetrics.EWMA ewma = 3;
getEwmaOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.MetricOrBuilder
optional .NodeMetrics.EWMA ewma = 3;
getExchangeId() - Method in class akka.camel.internal.CamelExchangeAdapter
Returns the exchange id
getExistenceConfirmed() - Method in class akka.actor.Terminated
 
getExitValue() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
optional int32 exitValue = 7;
getExitValue() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
optional int32 exitValue = 7;
getExitValue() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
optional int32 exitValue = 7;
getExternalAddressFor(Address) - Method in interface akka.actor.ActorRefProvider
Obtain the address which is to be used within sender references when sending to the given other address or none if the other address cannot be reached from this system (i.e.
getExternalAddressFor(Address) - Method in class akka.actor.LocalActorRefProvider
 
getExternalAddressFor(Address) - Method in class akka.remote.RemoteActorRefProvider
 
getFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
required .FailType failure = 1;
getFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
required .FailType failure = 1;
getFailure() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
required .FailType failure = 1;
getFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .InjectFailure failure = 3;
getFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
optional .InjectFailure failure = 3;
getFailure() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
optional .InjectFailure failure = 3;
getFailureBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .InjectFailure failure = 3;
getFailureOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .InjectFailure failure = 3;
getFailureOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
optional .InjectFailure failure = 3;
getFailureOrBuilder() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
optional .InjectFailure failure = 3;
getFloat(ByteOrder) - Method in class akka.util.ByteIterator
 
getFloats(float[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
getFloats(float[], ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Floats from this iterator.
getFloats(float[], int, int, ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Floats from this iterator.
getFloats(float[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
getFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
required .UniqueAddress from = 1;
getFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
required .UniqueAddress from = 1;
getFrom() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelopeOrBuilder
required .UniqueAddress from = 1;
getFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
required .UniqueAddress from = 1;
getFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
required .UniqueAddress from = 1;
getFrom() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipStatusOrBuilder
required .UniqueAddress from = 1;
getFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
required .Address from = 1;
getFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
required .Address from = 1;
getFrom() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelopeOrBuilder
required .Address from = 1;
getFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
required .UniqueAddress from = 1;
getFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
required .UniqueAddress from = 1;
getFrom() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.WelcomeOrBuilder
required .UniqueAddress from = 1;
getFromBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
required .UniqueAddress from = 1;
getFromBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
required .UniqueAddress from = 1;
getFromBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
required .Address from = 1;
getFromBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
required .UniqueAddress from = 1;
getFromOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
required .UniqueAddress from = 1;
getFromOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
required .UniqueAddress from = 1;
getFromOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelopeOrBuilder
required .UniqueAddress from = 1;
getFromOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
required .UniqueAddress from = 1;
getFromOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
required .UniqueAddress from = 1;
getFromOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipStatusOrBuilder
required .UniqueAddress from = 1;
getFromOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
required .Address from = 1;
getFromOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
required .Address from = 1;
getFromOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelopeOrBuilder
required .Address from = 1;
getFromOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
required .UniqueAddress from = 1;
getFromOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
required .UniqueAddress from = 1;
getFromOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.WelcomeOrBuilder
required .UniqueAddress from = 1;
getGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
required .MetricsGossip gossip = 2;
getGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
required .MetricsGossip gossip = 2;
getGossip() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelopeOrBuilder
required .MetricsGossip gossip = 2;
getGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
required .Gossip gossip = 2;
getGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
required .Gossip gossip = 2;
getGossip() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.WelcomeOrBuilder
required .Gossip gossip = 2;
getGossipBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
required .MetricsGossip gossip = 2;
getGossipBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
required .Gossip gossip = 2;
getGossipOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
required .MetricsGossip gossip = 2;
getGossipOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
required .MetricsGossip gossip = 2;
getGossipOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelopeOrBuilder
required .MetricsGossip gossip = 2;
getGossipOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
required .Gossip gossip = 2;
getGossipOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
required .Gossip gossip = 2;
getGossipOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.WelcomeOrBuilder
required .Gossip gossip = 2;
getHandshakeInfo() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
optional .AkkaHandshakeInfo handshakeInfo = 2;
getHandshakeInfo() - Method in class akka.remote.WireFormats.AkkaControlMessage
optional .AkkaHandshakeInfo handshakeInfo = 2;
getHandshakeInfo() - Method in interface akka.remote.WireFormats.AkkaControlMessageOrBuilder
optional .AkkaHandshakeInfo handshakeInfo = 2;
getHandshakeInfoBuilder() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
optional .AkkaHandshakeInfo handshakeInfo = 2;
getHandshakeInfoOrBuilder() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
optional .AkkaHandshakeInfo handshakeInfo = 2;
getHandshakeInfoOrBuilder() - Method in class akka.remote.WireFormats.AkkaControlMessage
optional .AkkaHandshakeInfo handshakeInfo = 2;
getHandshakeInfoOrBuilder() - Method in interface akka.remote.WireFormats.AkkaControlMessageOrBuilder
optional .AkkaHandshakeInfo handshakeInfo = 2;
getHashIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
required int32 hashIndex = 1;
getHashIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
required int32 hashIndex = 1;
getHashIndex() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.VectorClock.VersionOrBuilder
required int32 hashIndex = 1;
getHeaderAs(String, Class<T>, org.apache.camel.CamelContext) - Method in class akka.camel.CamelMessage
Java API: Returns the header by given name parameter.
getHeaders(Set<String>) - Method in class akka.camel.CamelMessage
Java API: Returns those headers from this message whose name is contained in names.
getHeaders() - Method in class akka.camel.CamelMessage
Java API: Returns all headers from this message.
getHello() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .Hello hello = 1;
getHello() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
optional .Hello hello = 1;
getHello() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
optional .Hello hello = 1;
getHelloBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .Hello hello = 1;
getHelloOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .Hello hello = 1;
getHelloOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
optional .Hello hello = 1;
getHelloOrBuilder() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
optional .Hello hello = 1;
getHost() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
required string host = 3;
getHost() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
required string host = 3;
getHost() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
required string host = 3;
getHostBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
required string host = 3;
getHostBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
required string host = 3;
getHostBytes() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
required string host = 3;
getHostname() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
required string hostname = 2;
getHostname() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
required string hostname = 2;
getHostname() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.AddressOrBuilder
required string hostname = 2;
getHostname() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
required string hostname = 2;
getHostname() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
required string hostname = 2;
getHostname() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.AddressOrBuilder
required string hostname = 2;
getHostname() - Method in class akka.remote.WireFormats.AddressData.Builder
required string hostname = 2;
getHostname() - Method in class akka.remote.WireFormats.AddressData
required string hostname = 2;
getHostname() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
required string hostname = 2;
getHostnameBytes() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
required string hostname = 2;
getHostnameBytes() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
required string hostname = 2;
getHostnameBytes() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.AddressOrBuilder
required string hostname = 2;
getHostnameBytes() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
required string hostname = 2;
getHostnameBytes() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
required string hostname = 2;
getHostnameBytes() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.AddressOrBuilder
required string hostname = 2;
getHostnameBytes() - Method in class akka.remote.WireFormats.AddressData.Builder
required string hostname = 2;
getHostnameBytes() - Method in class akka.remote.WireFormats.AddressData
required string hostname = 2;
getHostnameBytes() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
required string hostname = 2;
getInstance() - Method in class akka.actor.Kill$
Java API: get the singleton instance
getInstance() - Static method in class akka.actor.Kill
Java API: get the singleton instance
getInstance() - Method in class akka.actor.LocalScope$
Java API: get the singleton instance
getInstance() - Static method in class akka.actor.LocalScope
Java API: get the singleton instance
getInstance() - Method in class akka.actor.NoScopeGiven$
Java API: get the singleton instance
getInstance() - Static method in class akka.actor.NoScopeGiven
Java API: get the singleton instance
getInstance() - Method in class akka.actor.PoisonPill$
Java API: get the singleton instance
getInstance() - Static method in class akka.actor.PoisonPill
Java API: get the singleton instance
getInstance() - Method in class akka.actor.ReceiveTimeout$
Java API: get the singleton instance
getInstance() - Static method in class akka.actor.ReceiveTimeout
Java API: get the singleton instance
getInstance() - Method in class akka.camel.Ack$
Java API to get the Ack singleton
getInstance() - Static method in class akka.camel.Ack
Java API to get the Ack singleton
getInstance() - Method in class akka.cluster.ClusterScope$
Java API: get the singleton instance
getInstance() - Static method in class akka.cluster.ClusterScope
Java API: get the singleton instance
getInstance() - Method in class akka.cluster.routing.CpuMetricsSelector$
Java API: get the singleton instance
getInstance() - Static method in class akka.cluster.routing.CpuMetricsSelector
Java API: get the singleton instance
getInstance() - Method in class akka.cluster.routing.HeapMetricsSelector$
Java API: get the singleton instance
getInstance() - Static method in class akka.cluster.routing.HeapMetricsSelector
Java API: get the singleton instance
getInstance() - Method in class akka.cluster.routing.MixMetricsSelector$
Java API: get the default singleton instance
getInstance() - Static method in class akka.cluster.routing.MixMetricsSelector
Java API: get the default singleton instance
getInstance() - Method in class akka.cluster.routing.SystemLoadAverageMetricsSelector$
Java API: get the singleton instance
getInstance() - Static method in class akka.cluster.routing.SystemLoadAverageMetricsSelector
Java API: get the singleton instance
getInstance() - Method in class akka.event.Logging.LoggerInitialized$
Java API: get the singleton instance
getInstance() - Method in class akka.event.NoLogging$
Java API to return the reference to NoLogging
getInstance() - Static method in class akka.event.NoLogging
Java API to return the reference to NoLogging
getInstance() - Method in class akka.persistence.RecoveryCompleted$
Java API: get the singleton instance
getInstance() - Static method in class akka.persistence.RecoveryCompleted
Java API: get the singleton instance
getInstance() - Method in class akka.persistence.Reset$
Java API.
getInstance() - Static method in class akka.persistence.Reset
Java API.
getInstance() - Method in class akka.remote.security.provider.InternetSeedGenerator$
 
getInstance() - Static method in class akka.remote.security.provider.InternetSeedGenerator
 
getInstance() - Method in class akka.remote.testconductor.Done$
 
getInstance() - Static method in class akka.remote.testconductor.Done
 
getInstance() - Method in class akka.remote.transport.FailureInjectorTransportAdapter.PassThru$
Java API: get the singleton instance
getInstance() - Method in class akka.remote.transport.ThrottlerTransportAdapter.Blackhole$
Java API: get the singleton instance
getInstance() - Method in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Both$
Java API: get the singleton instance
getInstance() - Method in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Receive$
Java API: get the singleton instance
getInstance() - Method in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Send$
Java API: get the singleton instance
getInstance() - Method in class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociateAck$
Java API: get the singleton instance
getInstance() - Method in class akka.remote.transport.ThrottlerTransportAdapter.SetThrottleAck$
Java API: get the singleton instance
getInstance() - Method in class akka.remote.transport.ThrottlerTransportAdapter.Unthrottled$
Java API: get the singleton instance
getInstance() - Method in class akka.routing.CurrentRoutees$
Java API: get the singleton instance
getInstance() - Static method in class akka.routing.CurrentRoutees
Java API: get the singleton instance
getInstance() - Method in class akka.routing.FromConfig$
Java API: get the singleton instance
getInstance() - Static method in class akka.routing.FromConfig
Java API: get the singleton instance
getInstance() - Method in class akka.routing.GetRoutees$
Java API: get the singleton instance
getInstance() - Static method in class akka.routing.GetRoutees
Java API: get the singleton instance
getInstance() - Method in class akka.routing.NoRouter$
Java API: get the singleton instance
getInstance() - Static method in class akka.routing.NoRouter
Java API: get the singleton instance
getInstance() - Method in class akka.zeromq.Closed$
Java API: get the singleton instance
getInstance() - Static method in class akka.zeromq.Closed
Java API: get the singleton instance
getInstance() - Method in class akka.zeromq.Connecting$
Java API: get the singleton instance
getInstance() - Static method in class akka.zeromq.Connecting
Java API: get the singleton instance
getInstruction() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
optional .AkkaControlMessage instruction = 2;
getInstruction() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
optional .AkkaControlMessage instruction = 2;
getInstruction() - Method in interface akka.remote.WireFormats.AkkaProtocolMessageOrBuilder
optional .AkkaControlMessage instruction = 2;
getInstructionBuilder() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
optional .AkkaControlMessage instruction = 2;
getInstructionOrBuilder() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
optional .AkkaControlMessage instruction = 2;
getInstructionOrBuilder() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
optional .AkkaControlMessage instruction = 2;
getInstructionOrBuilder() - Method in interface akka.remote.WireFormats.AkkaProtocolMessageOrBuilder
optional .AkkaControlMessage instruction = 2;
getInt(String) - Method in class akka.dispatch.CachingConfig
 
getInt(ByteOrder) - Method in class akka.util.ByteIterator
Get a single Int from this iterator.
getIntList(String) - Method in class akka.dispatch.CachingConfig
 
getInts(int[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
getInts(int[], ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Ints from this iterator.
getInts(int[], int, int, ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Ints from this iterator.
getInts(int[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
getKey() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
required string key = 1;
getKey() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
required string key = 1;
getKey() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.EntryOrBuilder
required string key = 1;
getKeyBytes() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
required string key = 1;
getKeyBytes() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
required string key = 1;
getKeyBytes() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.EntryOrBuilder
required string key = 1;
getLastSender() - Method in class akka.testkit.JavaTestKit
 
getLeader() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
Java API: get address of current leader, or null if none
getLeader() - Method in class akka.cluster.ClusterEvent.LeaderChanged
Java API
getLeader() - Method in class akka.cluster.ClusterEvent.RoleLeaderChanged
Java API
getLeader() - Method in interface akka.cluster.ClusterNodeMBean
Get the address of the current leader.
getList(String) - Method in class akka.dispatch.CachingConfig
 
getListenAddresses() - Method in class akka.remote.RemotingListenEvent
 
getLocalAddress() - Method in interface akka.remote.AssociationEvent
 
getLocalAffinity() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
required bool localAffinity = 2;
getLocalAffinity() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
required bool localAffinity = 2;
getLocalAffinity() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendOrBuilder
required bool localAffinity = 2;
getLog() - Method in interface akka.actor.LoggingFSM
Retrieve current rolling log in oldest-first order.
getLogger(ActorSystem, Object) - Method in class akka.event.Logging$
Obtain LoggingAdapter for the given actor system and source object.
getLogger(LoggingBus, Object) - Method in class akka.event.Logging$
Obtain LoggingAdapter for the given logging bus and source object.
getLogger(UntypedActor) - Method in class akka.event.Logging$
Obtain LoggingAdapter with MDC support for the given actor.
getLogger(ActorSystem, Object) - Static method in class akka.event.Logging
Obtain LoggingAdapter for the given actor system and source object.
getLogger(LoggingBus, Object) - Static method in class akka.event.Logging
Obtain LoggingAdapter for the given logging bus and source object.
getLogger(UntypedActor) - Static method in class akka.event.Logging
Obtain LoggingAdapter with MDC support for the given actor.
getLong(String) - Method in class akka.dispatch.CachingConfig
 
getLong(ByteOrder) - Method in class akka.util.ByteIterator
Get a single Long from this iterator.
getLongList(String) - Method in class akka.dispatch.CachingConfig
 
getLongPart(int, ByteOrder) - Method in class akka.util.ByteIterator
Get a Long from this iterator where only the least significant n bytes were encoded.
getLongs(long[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
getLongs(long[], ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Longs from this iterator.
getLongs(long[], int, int, ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Longs from this iterator.
getLongs(long[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
getMailboxRequirement(com.typesafe.config.Config) - Method in class akka.dispatch.Mailboxes
 
getMailboxType(Props, com.typesafe.config.Config) - Method in class akka.dispatch.Mailboxes
Finds out the mailbox type for an actor based on configuration, props and requirements.
getManager() - Method in class akka.io.TcpExt
Java API: retrieve a reference to the manager actor.
getManager() - Method in class akka.io.UdpConnectedExt
Java API: retrieve the UDP manager actor&rsquo;s reference.
getManager() - Method in class akka.io.UdpExt
Java API: retrieve the UDP manager actor&rsquo;s reference.
getMatcher() - Method in class akka.remote.ContainerFormats.Selection.Builder
optional string matcher = 2;
getMatcher() - Method in class akka.remote.ContainerFormats.Selection
optional string matcher = 2;
getMatcher() - Method in interface akka.remote.ContainerFormats.SelectionOrBuilder
optional string matcher = 2;
getMatcherBytes() - Method in class akka.remote.ContainerFormats.Selection.Builder
optional string matcher = 2;
getMatcherBytes() - Method in class akka.remote.ContainerFormats.Selection
optional string matcher = 2;
getMatcherBytes() - Method in interface akka.remote.ContainerFormats.SelectionOrBuilder
optional string matcher = 2;
getMDC() - Method in interface akka.event.DiagnosticLoggingAdapter
Java API: Mapped Diagnostic Context for application defined values which can be used in PatternLayout when Slf4jLogger is configured.
getMembers() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
Java API: get current member list.
getMembers() - Method in interface akka.cluster.ClusterNodeMBean
Comma separated addresses of member nodes, sorted in the cluster ring order.
getMembers(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .Member members = 4;
getMembers(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
repeated .Member members = 4;
getMembers(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
repeated .Member members = 4;
getMembersBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .Member members = 4;
getMembersBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .Member members = 4;
getMembersCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .Member members = 4;
getMembersCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
repeated .Member members = 4;
getMembersCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
repeated .Member members = 4;
getMembersList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .Member members = 4;
getMembersList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
repeated .Member members = 4;
getMembersList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
repeated .Member members = 4;
getMembersOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .Member members = 4;
getMembersOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
repeated .Member members = 4;
getMembersOrBuilder(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
repeated .Member members = 4;
getMembersOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .Member members = 4;
getMembersOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
repeated .Member members = 4;
getMembersOrBuilderList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
repeated .Member members = 4;
getMemberStatus() - Method in interface akka.cluster.ClusterNodeMBean
Member status for this node.
getMessage() - Method in class akka.actor.UnhandledMessage
 
getMessage() - Method in exception akka.camel.ActorNotRegisteredException
 
getMessage() - Method in class akka.event.Logging.LogEventException
 
getMessage() - Method in class akka.persistence.AtLeastOnceDelivery.UnconfirmedDelivery
Java API
getMessage() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
required .SerializedMessage message = 2;
getMessage() - Method in class akka.remote.WireFormats.RemoteEnvelope
required .SerializedMessage message = 2;
getMessage() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
required .SerializedMessage message = 2;
getMessage() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
required bytes message = 1;
getMessage() - Method in class akka.remote.WireFormats.SerializedMessage
required bytes message = 1;
getMessage() - Method in interface akka.remote.WireFormats.SerializedMessageOrBuilder
required bytes message = 1;
getMessage() - Method in class akka.transactor.Coordinated
Java API: get the message for this Coordinated.
getMessageBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
required .SerializedMessage message = 2;
getMessageManifest() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload.Builder
optional bytes messageManifest = 4;
getMessageManifest() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
optional bytes messageManifest = 4;
getMessageManifest() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.PayloadOrBuilder
optional bytes messageManifest = 4;
getMessageManifest() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
optional bytes messageManifest = 4;
getMessageManifest() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
optional bytes messageManifest = 4;
getMessageManifest() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
optional bytes messageManifest = 4;
getMessageManifest() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
optional bytes messageManifest = 3;
getMessageManifest() - Method in class akka.remote.WireFormats.SerializedMessage
optional bytes messageManifest = 3;
getMessageManifest() - Method in interface akka.remote.WireFormats.SerializedMessageOrBuilder
optional bytes messageManifest = 3;
getMessageOrBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
required .SerializedMessage message = 2;
getMessageOrBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope
required .SerializedMessage message = 2;
getMessageOrBuilder() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
required .SerializedMessage message = 2;
getMessages() - Method in class akka.persistence.RedeliverFailure
Java API.
getMetrics() - Method in class akka.cluster.NodeMetrics
Java API
getMetrics(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
repeated .NodeMetrics.Metric metrics = 3;
getMetrics(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
repeated .NodeMetrics.Metric metrics = 3;
getMetrics(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetricsOrBuilder
repeated .NodeMetrics.Metric metrics = 3;
getMetricsBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
repeated .NodeMetrics.Metric metrics = 3;
getMetricsBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
repeated .NodeMetrics.Metric metrics = 3;
getMetricsCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
repeated .NodeMetrics.Metric metrics = 3;
getMetricsCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
repeated .NodeMetrics.Metric metrics = 3;
getMetricsCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetricsOrBuilder
repeated .NodeMetrics.Metric metrics = 3;
getMetricsList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
repeated .NodeMetrics.Metric metrics = 3;
getMetricsList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
repeated .NodeMetrics.Metric metrics = 3;
getMetricsList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetricsOrBuilder
repeated .NodeMetrics.Metric metrics = 3;
getMetricsOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
repeated .NodeMetrics.Metric metrics = 3;
getMetricsOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
repeated .NodeMetrics.Metric metrics = 3;
getMetricsOrBuilder(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetricsOrBuilder
repeated .NodeMetrics.Metric metrics = 3;
getMetricsOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
repeated .NodeMetrics.Metric metrics = 3;
getMetricsOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
repeated .NodeMetrics.Metric metrics = 3;
getMetricsOrBuilderList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetricsOrBuilder
repeated .NodeMetrics.Metric metrics = 3;
getMillisDuration(String) - Method in class akka.util.Helpers.ConfigOps
 
getMilliseconds(String) - Method in class akka.dispatch.CachingConfig
 
getMillisecondsList(String) - Method in class akka.dispatch.CachingConfig
 
getNacks(int) - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
repeated fixed64 nacks = 2;
getNacks(int) - Method in class akka.remote.WireFormats.AcknowledgementInfo
repeated fixed64 nacks = 2;
getNacks(int) - Method in interface akka.remote.WireFormats.AcknowledgementInfoOrBuilder
repeated fixed64 nacks = 2;
getNacksCount() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
repeated fixed64 nacks = 2;
getNacksCount() - Method in class akka.remote.WireFormats.AcknowledgementInfo
repeated fixed64 nacks = 2;
getNacksCount() - Method in interface akka.remote.WireFormats.AcknowledgementInfoOrBuilder
repeated fixed64 nacks = 2;
getNacksList() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
repeated fixed64 nacks = 2;
getNacksList() - Method in class akka.remote.WireFormats.AcknowledgementInfo
repeated fixed64 nacks = 2;
getNacksList() - Method in interface akka.remote.WireFormats.AcknowledgementInfoOrBuilder
repeated fixed64 nacks = 2;
getName() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
required string name = 1;
getName() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
required string name = 1;
getName() - Method in interface akka.remote.testconductor.TestConductorProtocol.EnterBarrierOrBuilder
required string name = 1;
getName() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
required string name = 1;
getName() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
required string name = 1;
getName() - Method in interface akka.remote.testconductor.TestConductorProtocol.HelloOrBuilder
required string name = 1;
getNameBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
required string name = 1;
getNameBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
required string name = 1;
getNameBytes() - Method in interface akka.remote.testconductor.TestConductorProtocol.EnterBarrierOrBuilder
required string name = 1;
getNameBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
required string name = 1;
getNameBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
required string name = 1;
getNameBytes() - Method in interface akka.remote.testconductor.TestConductorProtocol.HelloOrBuilder
required string name = 1;
getNameIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
required int32 nameIndex = 1;
getNameIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
required int32 nameIndex = 1;
getNameIndex() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.MetricOrBuilder
required int32 nameIndex = 1;
getNanosDuration(String) - Method in class akka.util.Helpers.ConfigOps
 
getNanoseconds(String) - Method in class akka.dispatch.CachingConfig
 
getNanosecondsList(String) - Method in class akka.dispatch.CachingConfig
 
getNextOldestChanged() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
getNode() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
required .UniqueAddress node = 1;
getNode() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
required .UniqueAddress node = 1;
getNode() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.JoinOrBuilder
required .UniqueAddress node = 1;
getNode() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
required string node = 1;
getNode() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
required string node = 1;
getNode() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressRequestOrBuilder
required string node = 1;
getNodeBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
required .UniqueAddress node = 1;
getNodeBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
required string node = 1;
getNodeBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
required string node = 1;
getNodeBytes() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressRequestOrBuilder
required string node = 1;
getNodeMetrics() - Method in class akka.cluster.ClusterEvent.ClusterMetricsChanged
Java API
getNodeMetrics(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .NodeMetrics nodeMetrics = 3;
getNodeMetrics(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
repeated .NodeMetrics nodeMetrics = 3;
getNodeMetrics(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
repeated .NodeMetrics nodeMetrics = 3;
getNodeMetricsBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .NodeMetrics nodeMetrics = 3;
getNodeMetricsBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .NodeMetrics nodeMetrics = 3;
getNodeMetricsCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .NodeMetrics nodeMetrics = 3;
getNodeMetricsCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
repeated .NodeMetrics nodeMetrics = 3;
getNodeMetricsCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
repeated .NodeMetrics nodeMetrics = 3;
getNodeMetricsList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .NodeMetrics nodeMetrics = 3;
getNodeMetricsList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
repeated .NodeMetrics nodeMetrics = 3;
getNodeMetricsList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
repeated .NodeMetrics nodeMetrics = 3;
getNodeMetricsOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .NodeMetrics nodeMetrics = 3;
getNodeMetricsOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
repeated .NodeMetrics nodeMetrics = 3;
getNodeMetricsOrBuilder(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
repeated .NodeMetrics nodeMetrics = 3;
getNodeMetricsOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .NodeMetrics nodeMetrics = 3;
getNodeMetricsOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
repeated .NodeMetrics nodeMetrics = 3;
getNodeMetricsOrBuilderList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
repeated .NodeMetrics nodeMetrics = 3;
getNodeOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
required .UniqueAddress node = 1;
getNodeOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
required .UniqueAddress node = 1;
getNodeOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.JoinOrBuilder
required .UniqueAddress node = 1;
getNodes() - Method in interface akka.remote.testconductor.Conductor
Obtain the list of remote host names currently registered.
getNumber() - Method in enum akka.cluster.protobuf.msg.ClusterMessages.MemberStatus
 
getNumber() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
required .NodeMetrics.Number number = 2;
getNumber() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
required .NodeMetrics.Number number = 2;
getNumber() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.MetricOrBuilder
required .NodeMetrics.Number number = 2;
getNumber() - Method in enum akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberType
 
getNumber() - Method in enum akka.cluster.protobuf.msg.ClusterMessages.ReachabilityStatus
 
getNumber(String) - Method in class akka.dispatch.CachingConfig
 
getNumber() - Method in enum akka.remote.ContainerFormats.PatternType
 
getNumber() - Method in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
 
getNumber() - Method in enum akka.remote.testconductor.TestConductorProtocol.Direction
 
getNumber() - Method in enum akka.remote.testconductor.TestConductorProtocol.FailType
 
getNumber() - Method in enum akka.remote.WireFormats.CommandType
 
getNumberBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
required .NodeMetrics.Number number = 2;
getNumberList(String) - Method in class akka.dispatch.CachingConfig
 
getNumberOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
required .NodeMetrics.Number number = 2;
getNumberOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
required .NodeMetrics.Number number = 2;
getNumberOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.MetricOrBuilder
required .NodeMetrics.Number number = 2;
getObject(String) - Method in class akka.dispatch.CachingConfig
 
getObjectFor(String, ClassTag<T>) - Method in class akka.actor.DynamicAccess
Obtain the Scala &ldquo;object&rdquo; instance for the given fully-qualified class name, if there is one.
getObjectFor(String, ClassTag<T>) - Method in class akka.actor.ReflectiveDynamicAccess
 
getObjectList(String) - Method in class akka.dispatch.CachingConfig
 
getObserverReachability(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
repeated .ObserverReachability observerReachability = 2;
getObserverReachability(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
repeated .ObserverReachability observerReachability = 2;
getObserverReachability(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOverviewOrBuilder
repeated .ObserverReachability observerReachability = 2;
getObserverReachabilityBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
repeated .ObserverReachability observerReachability = 2;
getObserverReachabilityBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
repeated .ObserverReachability observerReachability = 2;
getObserverReachabilityCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
repeated .ObserverReachability observerReachability = 2;
getObserverReachabilityCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
repeated .ObserverReachability observerReachability = 2;
getObserverReachabilityCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOverviewOrBuilder
repeated .ObserverReachability observerReachability = 2;
getObserverReachabilityList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
repeated .ObserverReachability observerReachability = 2;
getObserverReachabilityList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
repeated .ObserverReachability observerReachability = 2;
getObserverReachabilityList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOverviewOrBuilder
repeated .ObserverReachability observerReachability = 2;
getObserverReachabilityOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
repeated .ObserverReachability observerReachability = 2;
getObserverReachabilityOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
repeated .ObserverReachability observerReachability = 2;
getObserverReachabilityOrBuilder(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOverviewOrBuilder
repeated .ObserverReachability observerReachability = 2;
getObserverReachabilityOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
repeated .ObserverReachability observerReachability = 2;
getObserverReachabilityOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
repeated .ObserverReachability observerReachability = 2;
getObserverReachabilityOrBuilderList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOverviewOrBuilder
repeated .ObserverReachability observerReachability = 2;
getOp() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
required .BarrierOp op = 2;
getOp() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
required .BarrierOp op = 2;
getOp() - Method in interface akka.remote.testconductor.TestConductorProtocol.EnterBarrierOrBuilder
required .BarrierOp op = 2;
getOrElse(B) - Method in class akka.japi.Option
Returns a if this is some(a) or defaultValue if this is none.
getOrElse(B) - Method in class akka.japi.Option.Some
 
getOrigin() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
required .AddressData origin = 1;
getOrigin() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
required .AddressData origin = 1;
getOrigin() - Method in interface akka.remote.WireFormats.AkkaHandshakeInfoOrBuilder
required .AddressData origin = 1;
getOriginBuilder() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
required .AddressData origin = 1;
getOriginOrBuilder() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
required .AddressData origin = 1;
getOriginOrBuilder() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
required .AddressData origin = 1;
getOriginOrBuilder() - Method in interface akka.remote.WireFormats.AkkaHandshakeInfoOrBuilder
required .AddressData origin = 1;
getOverview() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
required .GossipOverview overview = 5;
getOverview() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
required .GossipOverview overview = 5;
getOverview() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
required .GossipOverview overview = 5;
getOverviewBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
required .GossipOverview overview = 5;
getOverviewOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
required .GossipOverview overview = 5;
getOverviewOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
required .GossipOverview overview = 5;
getOverviewOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
required .GossipOverview overview = 5;
getOwner() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
required .Address owner = 1;
getOwner() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
required .Address owner = 1;
getOwner() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.BucketOrBuilder
required .Address owner = 1;
getOwnerBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
required .Address owner = 1;
getOwnerOrBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
required .Address owner = 1;
getOwnerOrBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
required .Address owner = 1;
getOwnerOrBuilder() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.BucketOrBuilder
required .Address owner = 1;
getParent() - Method in class akka.actor.InternalActorRef
Obtain parent of this ref; used by getChild for ".." paths.
getParent() - Method in class akka.actor.LocalActorRef
 
getParent() - Method in interface akka.actor.MinimalActorRef
 
getParent() - Method in class akka.actor.RepointableActorRef
 
getParent() - Method in class akka.actor.VirtualPathContainer
 
getParent() - Method in class akka.pattern.PromiseActorRef
 
getParent() - Method in class akka.remote.RemoteActorRef
 
getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
 
getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
 
getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
 
getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
 
getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
 
getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
 
getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
 
getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
 
getParserForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
getParserForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
getParserForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
getParserForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
 
getParserForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
getParserForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
 
getParserForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
getParserForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
getParserForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
 
getParserForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
 
getParserForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
getParserForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
getParserForType() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
getParserForType() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage
 
getParserForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
getParserForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
 
getParserForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
getParserForType() - Method in class akka.remote.ContainerFormats.Selection
 
getParserForType() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
getParserForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
getParserForType() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
getParserForType() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
getParserForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
getParserForType() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
getParserForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
getParserForType() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
getParserForType() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
getParserForType() - Method in class akka.remote.WireFormats.ActorRefData
 
getParserForType() - Method in class akka.remote.WireFormats.AddressData
 
getParserForType() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
getParserForType() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
getParserForType() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
getParserForType() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
getParserForType() - Method in class akka.remote.WireFormats.DeployData
 
getParserForType() - Method in class akka.remote.WireFormats.PropsData
 
getParserForType() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
getParserForType() - Method in class akka.remote.WireFormats.SerializedMessage
 
getPath() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
required string path = 1;
getPath() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
required string path = 1;
getPath() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendOrBuilder
required string path = 1;
getPath() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
required string path = 1;
getPath() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
required string path = 1;
getPath() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAllOrBuilder
required string path = 1;
getPath() - Method in class akka.remote.WireFormats.ActorRefData.Builder
required string path = 1;
getPath() - Method in class akka.remote.WireFormats.ActorRefData
required string path = 1;
getPath() - Method in interface akka.remote.WireFormats.ActorRefDataOrBuilder
required string path = 1;
getPath() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required string path = 3;
getPath() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
required string path = 3;
getPath() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
required string path = 3;
getPath() - Method in class akka.remote.WireFormats.DeployData.Builder
required string path = 1;
getPath() - Method in class akka.remote.WireFormats.DeployData
required string path = 1;
getPath() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
required string path = 1;
getPathBytes() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
required string path = 1;
getPathBytes() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
required string path = 1;
getPathBytes() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendOrBuilder
required string path = 1;
getPathBytes() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
required string path = 1;
getPathBytes() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
required string path = 1;
getPathBytes() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAllOrBuilder
required string path = 1;
getPathBytes() - Method in class akka.remote.WireFormats.ActorRefData.Builder
required string path = 1;
getPathBytes() - Method in class akka.remote.WireFormats.ActorRefData
required string path = 1;
getPathBytes() - Method in interface akka.remote.WireFormats.ActorRefDataOrBuilder
required string path = 1;
getPathBytes() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required string path = 3;
getPathBytes() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
required string path = 3;
getPathBytes() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
required string path = 3;
getPathBytes() - Method in class akka.remote.WireFormats.DeployData.Builder
required string path = 1;
getPathBytes() - Method in class akka.remote.WireFormats.DeployData
required string path = 1;
getPathBytes() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
required string path = 1;
getPaths() - Method in class akka.routing.GroupBase
 
getPattern(int) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
repeated .Selection pattern = 3;
getPattern(int) - Method in class akka.remote.ContainerFormats.SelectionEnvelope
repeated .Selection pattern = 3;
getPattern(int) - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
repeated .Selection pattern = 3;
getPatternBuilder(int) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
repeated .Selection pattern = 3;
getPatternBuilderList() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
repeated .Selection pattern = 3;
getPatternCount() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
repeated .Selection pattern = 3;
getPatternCount() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
repeated .Selection pattern = 3;
getPatternCount() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
repeated .Selection pattern = 3;
getPatternList() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
repeated .Selection pattern = 3;
getPatternList() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
repeated .Selection pattern = 3;
getPatternList() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
repeated .Selection pattern = 3;
getPatternOrBuilder(int) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
repeated .Selection pattern = 3;
getPatternOrBuilder(int) - Method in class akka.remote.ContainerFormats.SelectionEnvelope
repeated .Selection pattern = 3;
getPatternOrBuilder(int) - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
repeated .Selection pattern = 3;
getPatternOrBuilderList() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
repeated .Selection pattern = 3;
getPatternOrBuilderList() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
repeated .Selection pattern = 3;
getPatternOrBuilderList() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
repeated .Selection pattern = 3;
getPayload() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish.Builder
required .Payload payload = 3;
getPayload() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
required .Payload payload = 3;
getPayload() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.PublishOrBuilder
required .Payload payload = 3;
getPayload() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
required .Payload payload = 3;
getPayload() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
required .Payload payload = 3;
getPayload() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendOrBuilder
required .Payload payload = 3;
getPayload() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
required .Payload payload = 3;
getPayload() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
required .Payload payload = 3;
getPayload() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAllOrBuilder
required .Payload payload = 3;
getPayload() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required .PersistentPayload payload = 3;
getPayload() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
required .PersistentPayload payload = 3;
getPayload() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder
required .PersistentPayload payload = 3;
getPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional .PersistentPayload payload = 1;
getPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional .PersistentPayload payload = 1;
getPayload() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional .PersistentPayload payload = 1;
getPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
required bytes payload = 2;
getPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
required bytes payload = 2;
getPayload() - Method in interface akka.persistence.serialization.MessageFormats.PersistentPayloadOrBuilder
required bytes payload = 2;
getPayload() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
optional bytes payload = 1;
getPayload() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
optional bytes payload = 1;
getPayload() - Method in interface akka.remote.WireFormats.AkkaProtocolMessageOrBuilder
optional bytes payload = 1;
getPayloadBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish.Builder
required .Payload payload = 3;
getPayloadBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
required .Payload payload = 3;
getPayloadBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
required .Payload payload = 3;
getPayloadBuilder() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required .PersistentPayload payload = 3;
getPayloadBuilder() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional .PersistentPayload payload = 1;
getPayloadManifest() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
optional bytes payloadManifest = 3;
getPayloadManifest() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
optional bytes payloadManifest = 3;
getPayloadManifest() - Method in interface akka.persistence.serialization.MessageFormats.PersistentPayloadOrBuilder
optional bytes payloadManifest = 3;
getPayloadOrBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish.Builder
required .Payload payload = 3;
getPayloadOrBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
required .Payload payload = 3;
getPayloadOrBuilder() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.PublishOrBuilder
required .Payload payload = 3;
getPayloadOrBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
required .Payload payload = 3;
getPayloadOrBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
required .Payload payload = 3;
getPayloadOrBuilder() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendOrBuilder
required .Payload payload = 3;
getPayloadOrBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
required .Payload payload = 3;
getPayloadOrBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
required .Payload payload = 3;
getPayloadOrBuilder() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAllOrBuilder
required .Payload payload = 3;
getPayloadOrBuilder() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required .PersistentPayload payload = 3;
getPayloadOrBuilder() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
required .PersistentPayload payload = 3;
getPayloadOrBuilder() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder
required .PersistentPayload payload = 3;
getPayloadOrBuilder() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional .PersistentPayload payload = 1;
getPayloadOrBuilder() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional .PersistentPayload payload = 1;
getPayloadOrBuilder() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional .PersistentPayload payload = 1;
getPersistenceId() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
optional string persistenceId = 1;
getPersistenceId() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
optional string persistenceId = 1;
getPersistenceId() - Method in interface akka.persistence.serialization.MessageFormats.DeliveredMessageOrBuilder
optional string persistenceId = 1;
getPersistenceId() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string persistenceId = 3;
getPersistenceId() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional string persistenceId = 3;
getPersistenceId() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional string persistenceId = 3;
getPersistenceIdBytes() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
optional string persistenceId = 1;
getPersistenceIdBytes() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
optional string persistenceId = 1;
getPersistenceIdBytes() - Method in interface akka.persistence.serialization.MessageFormats.DeliveredMessageOrBuilder
optional string persistenceId = 1;
getPersistenceIdBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string persistenceId = 3;
getPersistenceIdBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional string persistenceId = 3;
getPersistenceIdBytes() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional string persistenceId = 3;
getPersistent() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage.Builder
optional .PersistentMessage persistent = 1;
getPersistent() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage
optional .PersistentMessage persistent = 1;
getPersistent() - Method in interface akka.persistence.serialization.MessageFormats.DeliverMessageOrBuilder
optional .PersistentMessage persistent = 1;
getPersistentBuilder() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage.Builder
optional .PersistentMessage persistent = 1;
getPersistentOrBuilder() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage.Builder
optional .PersistentMessage persistent = 1;
getPersistentOrBuilder() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage
optional .PersistentMessage persistent = 1;
getPersistentOrBuilder() - Method in interface akka.persistence.serialization.MessageFormats.DeliverMessageOrBuilder
optional .PersistentMessage persistent = 1;
getPersistentSequenceNr() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
optional int64 persistentSequenceNr = 3;
getPersistentSequenceNr() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
optional int64 persistentSequenceNr = 3;
getPersistentSequenceNr() - Method in interface akka.persistence.serialization.MessageFormats.DeliveredMessageOrBuilder
optional int64 persistentSequenceNr = 3;
getPipeline() - Method in class akka.remote.testconductor.TestConductorPipelineFactory
 
getPort() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
required uint32 port = 3;
getPort() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
required uint32 port = 3;
getPort() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.AddressOrBuilder
required uint32 port = 3;
getPort() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
required uint32 port = 3;
getPort() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
required uint32 port = 3;
getPort() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.AddressOrBuilder
required uint32 port = 3;
getPort() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
required int32 port = 4;
getPort() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
required int32 port = 4;
getPort() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
required int32 port = 4;
getPort() - Method in class akka.remote.WireFormats.AddressData.Builder
required uint32 port = 3;
getPort() - Method in class akka.remote.WireFormats.AddressData
required uint32 port = 3;
getPort() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
required uint32 port = 3;
getProducedMessageQueueType(MailboxType) - Method in class akka.dispatch.Mailboxes
 
getProducerTemplate() - Method in class akka.camel.javaapi.UntypedConsumerActor
Java API: Returns the org.apache.camel.ProducerTemplate
getProducerTemplate() - Method in class akka.camel.javaapi.UntypedProducerActor
Returns the ProducerTemplate.
getProps() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .PropsData props = 1;
getProps() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
required .PropsData props = 1;
getProps() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
required .PropsData props = 1;
getPropsBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .PropsData props = 1;
getPropsOrBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .PropsData props = 1;
getPropsOrBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
required .PropsData props = 1;
getPropsOrBuilder() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
required .PropsData props = 1;
getProtocol() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
optional string protocol = 4;
getProtocol() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
optional string protocol = 4;
getProtocol() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.AddressOrBuilder
optional string protocol = 4;
getProtocol() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
optional string protocol = 4;
getProtocol() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
optional string protocol = 4;
getProtocol() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.AddressOrBuilder
optional string protocol = 4;
getProtocol() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
required string protocol = 1;
getProtocol() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
required string protocol = 1;
getProtocol() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
required string protocol = 1;
getProtocol() - Method in class akka.remote.WireFormats.AddressData.Builder
optional string protocol = 4;
getProtocol() - Method in class akka.remote.WireFormats.AddressData
optional string protocol = 4;
getProtocol() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
optional string protocol = 4;
getProtocolBytes() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
optional string protocol = 4;
getProtocolBytes() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
optional string protocol = 4;
getProtocolBytes() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.AddressOrBuilder
optional string protocol = 4;
getProtocolBytes() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
optional string protocol = 4;
getProtocolBytes() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
optional string protocol = 4;
getProtocolBytes() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.AddressOrBuilder
optional string protocol = 4;
getProtocolBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
required string protocol = 1;
getProtocolBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
required string protocol = 1;
getProtocolBytes() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
required string protocol = 1;
getProtocolBytes() - Method in class akka.remote.WireFormats.AddressData.Builder
optional string protocol = 4;
getProtocolBytes() - Method in class akka.remote.WireFormats.AddressData
optional string protocol = 4;
getProtocolBytes() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
optional string protocol = 4;
getRateMBit() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
optional float rateMBit = 6;
getRateMBit() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
optional float rateMBit = 6;
getRateMBit() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
optional float rateMBit = 6;
getRawResult() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinTask
 
getRecipient() - Method in class akka.actor.UnhandledMessage
 
getRecipient() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
required .ActorRefData recipient = 1;
getRecipient() - Method in class akka.remote.WireFormats.RemoteEnvelope
required .ActorRefData recipient = 1;
getRecipient() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
required .ActorRefData recipient = 1;
getRecipientBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
required .ActorRefData recipient = 1;
getRecipientOrBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
required .ActorRefData recipient = 1;
getRecipientOrBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope
required .ActorRefData recipient = 1;
getRecipientOrBuilder() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
required .ActorRefData recipient = 1;
getRedeliveries() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional int32 redeliveries = 6;
getRedeliveries() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional int32 redeliveries = 6;
getRedeliveries() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional int32 redeliveries = 6;
getRef() - Method in class akka.actor.ActorIdentity
Java API: ActorRef of the actor replying to the request or null if no actor matched the request.
getRef() - Method in class akka.actor.dsl.Inbox.Inbox
 
getRef() - Method in class akka.actor.Inbox
Obtain a reference to the internal actor, which can then for example be registered with the event stream or whatever else you may want to do with an ActorRef.
getRef() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
optional string ref = 3;
getRef() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
optional string ref = 3;
getRef() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.EntryOrBuilder
optional string ref = 3;
getRef() - Method in class akka.testkit.JavaTestKit
Shorthand to get the testActor.
getRefBytes() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
optional string ref = 3;
getRefBytes() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
optional string ref = 3;
getRefBytes() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.EntryOrBuilder
optional string ref = 3;
getRemainingTime() - Method in class akka.testkit.JavaTestKit
 
getRemainingTimeOr(FiniteDuration) - Method in class akka.testkit.JavaTestKit
 
getRemoteAddress() - Method in interface akka.remote.AssociationEvent
 
getRemoteReadHandlerFor(TestAssociationHandle) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Returns the event handler corresponding to the remote endpoint of the given local handle.
getReply() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
required bool reply = 3;
getReply() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
required bool reply = 3;
getReply() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelopeOrBuilder
required bool reply = 3;
getReplyTimeout() - Method in interface akka.camel.internal.component.ActorEndpointConfig
 
getRequiredType(Class<? extends Actor>) - Method in class akka.dispatch.Mailboxes
Return the required message queue type for this class if any.
getRoleLeader(String) - Method in class akka.cluster.ClusterEvent.CurrentClusterState
Java API: get address of current leader within the role set, or null if no node with that role
getRoles() - Method in class akka.cluster.Member
Java API
getRoles(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
repeated string roles = 2;
getRoles(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
repeated string roles = 2;
getRoles(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.JoinOrBuilder
repeated string roles = 2;
getRolesBytes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
repeated string roles = 2;
getRolesBytes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
repeated string roles = 2;
getRolesBytes(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.JoinOrBuilder
repeated string roles = 2;
getRolesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
repeated string roles = 2;
getRolesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
repeated string roles = 2;
getRolesCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.JoinOrBuilder
repeated string roles = 2;
getRolesIndexes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
repeated int32 rolesIndexes = 4 [packed = true];
getRolesIndexes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
repeated int32 rolesIndexes = 4 [packed = true];
getRolesIndexes(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MemberOrBuilder
repeated int32 rolesIndexes = 4 [packed = true];
getRolesIndexesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
repeated int32 rolesIndexes = 4 [packed = true];
getRolesIndexesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
repeated int32 rolesIndexes = 4 [packed = true];
getRolesIndexesCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MemberOrBuilder
repeated int32 rolesIndexes = 4 [packed = true];
getRolesIndexesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
repeated int32 rolesIndexes = 4 [packed = true];
getRolesIndexesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
repeated int32 rolesIndexes = 4 [packed = true];
getRolesIndexesList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MemberOrBuilder
repeated int32 rolesIndexes = 4 [packed = true];
getRolesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
repeated string roles = 2;
getRolesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
repeated string roles = 2;
getRolesList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.JoinOrBuilder
repeated string roles = 2;
getRouteDefinitionHandler() - Method in interface akka.camel.Consumer
Java API: Returns the Mapper function that will be used as a route definition handler for creating custom route to this consumer.
GetRoutees - Class in akka.routing
Sending this message to a router will make it send back its currently used routees.
GetRoutees() - Constructor for class akka.routing.GetRoutees
 
getRoutees() - Method in class akka.routing.Routees
Java API
getRoutees() - Method in class akka.routing.RouterRoutees
Java API
getRoutees() - Method in class akka.routing.SeveralRoutees
Java API
GetRoutees$ - Class in akka.routing
 
GetRoutees$() - Constructor for class akka.routing.GetRoutees$
 
getRouterConfig() - Method in class akka.remote.WireFormats.DeployData.Builder
optional bytes routerConfig = 3;
getRouterConfig() - Method in class akka.remote.WireFormats.DeployData
optional bytes routerConfig = 3;
getRouterConfig() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
optional bytes routerConfig = 3;
getScope() - Method in class akka.remote.WireFormats.DeployData.Builder
optional bytes scope = 4;
getScope() - Method in class akka.remote.WireFormats.DeployData
optional bytes scope = 4;
getScope() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
optional bytes scope = 4;
getSeen(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
repeated int32 seen = 1;
getSeen(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
repeated int32 seen = 1;
getSeen(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOverviewOrBuilder
repeated int32 seen = 1;
getSeenBy() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
Java API: get current &ldquo;seen-by&rdquo; set.
getSeenCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
repeated int32 seen = 1;
getSeenCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
repeated int32 seen = 1;
getSeenCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOverviewOrBuilder
repeated int32 seen = 1;
getSeenList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
repeated int32 seen = 1;
getSeenList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
repeated int32 seen = 1;
getSeenList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOverviewOrBuilder
repeated int32 seen = 1;
getSelf() - Method in class akka.actor.UntypedActor
Returns the ActorRef for this actor.
getSelfRoles() - Method in class akka.cluster.Cluster
Java API: roles that this member has
getSender() - Method in class akka.actor.UnhandledMessage
 
getSender() - Method in class akka.actor.UntypedActor
The reference sender Actor of the currently processed message.
getSender() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string sender = 11;
getSender() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional string sender = 11;
getSender() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional string sender = 11;
getSender() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
optional .ActorRefData sender = 4;
getSender() - Method in class akka.remote.WireFormats.RemoteEnvelope
optional .ActorRefData sender = 4;
getSender() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
optional .ActorRefData sender = 4;
getSenderBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
optional .ActorRefData sender = 4;
getSenderBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string sender = 11;
getSenderBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional string sender = 11;
getSenderBytes() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional string sender = 11;
getSenderOrBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
optional .ActorRefData sender = 4;
getSenderOrBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope
optional .ActorRefData sender = 4;
getSenderOrBuilder() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
optional .ActorRefData sender = 4;
getSeq() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
optional fixed64 seq = 5;
getSeq() - Method in class akka.remote.WireFormats.RemoteEnvelope
optional fixed64 seq = 5;
getSeq() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
optional fixed64 seq = 5;
getSequenceNr() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional int64 sequenceNr = 2;
getSequenceNr() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional int64 sequenceNr = 2;
getSequenceNr() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional int64 sequenceNr = 2;
getSerialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
optional bytes serialized = 4;
getSerialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
optional bytes serialized = 4;
getSerialized() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberOrBuilder
optional bytes serialized = 4;
getSerializedGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
required bytes serializedGossip = 3;
getSerializedGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
required bytes serializedGossip = 3;
getSerializedGossip() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelopeOrBuilder
required bytes serializedGossip = 3;
getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
 
getSerializedSize() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
getSerializedSize() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
getSerializedSize() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
getSerializedSize() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
 
getSerializedSize() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
getSerializedSize() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
 
getSerializedSize() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
getSerializedSize() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
getSerializedSize() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
 
getSerializedSize() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
 
getSerializedSize() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
getSerializedSize() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
getSerializedSize() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
getSerializedSize() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage
 
getSerializedSize() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
getSerializedSize() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
 
getSerializedSize() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
getSerializedSize() - Method in class akka.remote.ContainerFormats.Selection
 
getSerializedSize() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
getSerializedSize() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
getSerializedSize() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
getSerializedSize() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
getSerializedSize() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
getSerializedSize() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
getSerializedSize() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
getSerializedSize() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
getSerializedSize() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
getSerializedSize() - Method in class akka.remote.WireFormats.ActorRefData
 
getSerializedSize() - Method in class akka.remote.WireFormats.AddressData
 
getSerializedSize() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
getSerializedSize() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
getSerializedSize() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
getSerializedSize() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
getSerializedSize() - Method in class akka.remote.WireFormats.DeployData
 
getSerializedSize() - Method in class akka.remote.WireFormats.PropsData
 
getSerializedSize() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
getSerializedSize() - Method in class akka.remote.WireFormats.SerializedMessage
 
getSerializerId() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload.Builder
required int32 serializerId = 2;
getSerializerId() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
required int32 serializerId = 2;
getSerializerId() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.PayloadOrBuilder
required int32 serializerId = 2;
getSerializerId() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
required int32 serializerId = 1;
getSerializerId() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
required int32 serializerId = 1;
getSerializerId() - Method in interface akka.persistence.serialization.MessageFormats.PersistentPayloadOrBuilder
required int32 serializerId = 1;
getSerializerId() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
required int32 serializerId = 2;
getSerializerId() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
required int32 serializerId = 2;
getSerializerId() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
required int32 serializerId = 2;
getSerializerId() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
required int32 serializerId = 2;
getSerializerId() - Method in class akka.remote.WireFormats.SerializedMessage
required int32 serializerId = 2;
getSerializerId() - Method in interface akka.remote.WireFormats.SerializedMessageOrBuilder
required int32 serializerId = 2;
getShort(ByteOrder) - Method in class akka.util.ByteIterator
Get a single Short from this iterator.
getShorts(short[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
getShorts(short[], ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Shorts from this iterator.
getShorts(short[], int, int, ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Shorts from this iterator.
getShorts(short[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
getShutdownTimeout() - Method in class akka.actor.LightArrayRevolverScheduler
Overridable for tests
getSingleChild(String) - Method in class akka.actor.ActorRefWithCell
 
getSingleChild(String) - Method in interface akka.actor.Cell
Method for looking up a single child beneath this actor.
getSingleChild(String) - Method in interface akka.actor.dungeon.Children
 
getSingleChild(String) - Method in class akka.actor.LocalActorRef
Method for looking up a single child beneath this actor.
getSingleChild(String) - Method in class akka.actor.RepointableActorRef
Method for looking up a single child beneath this actor.
getSingleChild(String) - Method in class akka.actor.UnstartedCell
 
getStatus() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
required .MemberStatus status = 3;
getStatus() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
required .MemberStatus status = 3;
getStatus() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MemberOrBuilder
required .MemberStatus status = 3;
getStatus() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
required .ReachabilityStatus status = 3;
getStatus() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
required .ReachabilityStatus status = 3;
getStatus() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.SubjectReachabilityOrBuilder
required .ReachabilityStatus status = 3;
getString(String) - Method in class akka.dispatch.CachingConfig
 
getStringList(String) - Method in class akka.dispatch.CachingConfig
 
getSubjectReachability(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
repeated .SubjectReachability subjectReachability = 2;
getSubjectReachability(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
repeated .SubjectReachability subjectReachability = 2;
getSubjectReachability(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.ObserverReachabilityOrBuilder
repeated .SubjectReachability subjectReachability = 2;
getSubjectReachabilityBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
repeated .SubjectReachability subjectReachability = 2;
getSubjectReachabilityBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
repeated .SubjectReachability subjectReachability = 2;
getSubjectReachabilityCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
repeated .SubjectReachability subjectReachability = 2;
getSubjectReachabilityCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
repeated .SubjectReachability subjectReachability = 2;
getSubjectReachabilityCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.ObserverReachabilityOrBuilder
repeated .SubjectReachability subjectReachability = 2;
getSubjectReachabilityList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
repeated .SubjectReachability subjectReachability = 2;
getSubjectReachabilityList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
repeated .SubjectReachability subjectReachability = 2;
getSubjectReachabilityList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.ObserverReachabilityOrBuilder
repeated .SubjectReachability subjectReachability = 2;
getSubjectReachabilityOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
repeated .SubjectReachability subjectReachability = 2;
getSubjectReachabilityOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
repeated .SubjectReachability subjectReachability = 2;
getSubjectReachabilityOrBuilder(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.ObserverReachabilityOrBuilder
repeated .SubjectReachability subjectReachability = 2;
getSubjectReachabilityOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
repeated .SubjectReachability subjectReachability = 2;
getSubjectReachabilityOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
repeated .SubjectReachability subjectReachability = 2;
getSubjectReachabilityOrBuilderList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.ObserverReachabilityOrBuilder
repeated .SubjectReachability subjectReachability = 2;
getSupervisor() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .ActorRefData supervisor = 4;
getSupervisor() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
required .ActorRefData supervisor = 4;
getSupervisor() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
required .ActorRefData supervisor = 4;
getSupervisorBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .ActorRefData supervisor = 4;
getSupervisorOrBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .ActorRefData supervisor = 4;
getSupervisorOrBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
required .ActorRefData supervisor = 4;
getSupervisorOrBuilder() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
required .ActorRefData supervisor = 4;
getSystem() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
required string system = 1;
getSystem() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
required string system = 1;
getSystem() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.AddressOrBuilder
required string system = 1;
getSystem() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
required string system = 1;
getSystem() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
required string system = 1;
getSystem() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.AddressOrBuilder
required string system = 1;
getSystem() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
required string system = 2;
getSystem() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
required string system = 2;
getSystem() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
required string system = 2;
getSystem() - Method in class akka.remote.WireFormats.AddressData.Builder
required string system = 1;
getSystem() - Method in class akka.remote.WireFormats.AddressData
required string system = 1;
getSystem() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
required string system = 1;
getSystem() - Method in class akka.testkit.JavaTestKit
 
getSystemBytes() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
required string system = 1;
getSystemBytes() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
required string system = 1;
getSystemBytes() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.AddressOrBuilder
required string system = 1;
getSystemBytes() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
required string system = 1;
getSystemBytes() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
required string system = 1;
getSystemBytes() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.AddressOrBuilder
required string system = 1;
getSystemBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
required string system = 2;
getSystemBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
required string system = 2;
getSystemBytes() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
required string system = 2;
getSystemBytes() - Method in class akka.remote.WireFormats.AddressData.Builder
required string system = 1;
getSystemBytes() - Method in class akka.remote.WireFormats.AddressData
required string system = 1;
getSystemBytes() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
required string system = 1;
getTestActor() - Method in class akka.testkit.JavaTestKit
ActorRef of the test actor.
getTimeout() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
optional int64 timeout = 3;
getTimeout() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
optional int64 timeout = 3;
getTimeout() - Method in interface akka.remote.testconductor.TestConductorProtocol.EnterBarrierOrBuilder
optional int64 timeout = 3;
getTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
required int64 timestamp = 2;
getTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
required int64 timestamp = 2;
getTimestamp() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetricsOrBuilder
required int64 timestamp = 2;
getTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
optional int64 timestamp = 1;
getTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
optional int64 timestamp = 1;
getTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
required int64 timestamp = 2;
getTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
required int64 timestamp = 2;
getTimestamp() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.VectorClock.VersionOrBuilder
required int64 timestamp = 2;
getTimestamp() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.VectorClockOrBuilder
optional int64 timestamp = 1;
getTimestamp() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
required int64 timestamp = 2;
getTimestamp() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
required int64 timestamp = 2;
getTimestamp() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.VersionOrBuilder
required int64 timestamp = 2;
getTo() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
required .UniqueAddress to = 2;
getTo() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
required .UniqueAddress to = 2;
getTo() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelopeOrBuilder
required .UniqueAddress to = 2;
getToArray(Object, int, int, int, Function0<A>, Function3<Object, Object, Object, BoxedUnit>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
getToBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
required .UniqueAddress to = 2;
getToOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
required .UniqueAddress to = 2;
getToOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
required .UniqueAddress to = 2;
getToOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelopeOrBuilder
required .UniqueAddress to = 2;
getTopic() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish.Builder
required string topic = 1;
getTopic() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
required string topic = 1;
getTopic() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.PublishOrBuilder
required string topic = 1;
getTopicBytes() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish.Builder
required string topic = 1;
getTopicBytes() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
required string topic = 1;
getTopicBytes() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.PublishOrBuilder
required string topic = 1;
getType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
required .NodeMetrics.NumberType type = 1;
getType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
required .NodeMetrics.NumberType type = 1;
getType() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberOrBuilder
required .NodeMetrics.NumberType type = 1;
getType() - Method in class akka.remote.ContainerFormats.Selection.Builder
required .PatternType type = 1;
getType() - Method in class akka.remote.ContainerFormats.Selection
required .PatternType type = 1;
getType() - Method in interface akka.remote.ContainerFormats.SelectionOrBuilder
required .PatternType type = 1;
getUid() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
required uint32 uid = 2;
getUid() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
required uint32 uid = 2;
getUid() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.UniqueAddressOrBuilder
required uint32 uid = 2;
getUid() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
required fixed64 uid = 2;
getUid() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
required fixed64 uid = 2;
getUid() - Method in interface akka.remote.WireFormats.AkkaHandshakeInfoOrBuilder
required fixed64 uid = 2;
getUnconfirmedDeliveries() - Method in class akka.persistence.AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot
Java API
getUnconfirmedDeliveries() - Method in class akka.persistence.AtLeastOnceDelivery.UnconfirmedWarning
Java API
getUnconfirmedDeliveries(int) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveries(int) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveries(int) - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshotOrBuilder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesBuilder(int) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesBuilderList() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesCount() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesCount() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesCount() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshotOrBuilder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesList() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesList() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesList() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshotOrBuilder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesOrBuilder(int) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesOrBuilder(int) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesOrBuilder(int) - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshotOrBuilder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesOrBuilderList() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesOrBuilderList() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesOrBuilderList() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshotOrBuilder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
 
getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
 
getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
 
getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
 
getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
 
getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
 
getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
 
getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
 
getUnknownFields() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
getUnknownFields() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
getUnknownFields() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
getUnknownFields() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
 
getUnknownFields() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
getUnknownFields() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
 
getUnknownFields() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
getUnknownFields() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
getUnknownFields() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
 
getUnknownFields() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
 
getUnknownFields() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
getUnknownFields() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
getUnknownFields() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
getUnknownFields() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage
 
getUnknownFields() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
getUnknownFields() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
 
getUnknownFields() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
getUnknownFields() - Method in class akka.remote.ContainerFormats.Selection
 
getUnknownFields() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
getUnknownFields() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
getUnknownFields() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
getUnknownFields() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
getUnknownFields() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
getUnknownFields() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
getUnknownFields() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
getUnknownFields() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
getUnknownFields() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
getUnknownFields() - Method in class akka.remote.WireFormats.ActorRefData
 
getUnknownFields() - Method in class akka.remote.WireFormats.AddressData
 
getUnknownFields() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
getUnknownFields() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
getUnknownFields() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
getUnknownFields() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
getUnknownFields() - Method in class akka.remote.WireFormats.DeployData
 
getUnknownFields() - Method in class akka.remote.WireFormats.PropsData
 
getUnknownFields() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
getUnknownFields() - Method in class akka.remote.WireFormats.SerializedMessage
 
getUnreachable() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
Java API: get current unreachable set.
getUnreachable() - Method in interface akka.cluster.ClusterNodeMBean
Comma separated addresses of unreachable member nodes.
getUpNumber() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
required int32 upNumber = 2;
getUpNumber() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
required int32 upNumber = 2;
getUpNumber() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MemberOrBuilder
required int32 upNumber = 2;
getValue() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
required double value = 1;
getValue() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
required double value = 1;
getValue() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMAOrBuilder
required double value = 1;
getValue(String) - Method in class akka.dispatch.CachingConfig
 
getValue32() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
optional uint32 value32 = 2;
getValue32() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
optional uint32 value32 = 2;
getValue32() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberOrBuilder
optional uint32 value32 = 2;
getValue64() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
optional uint64 value64 = 3;
getValue64() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
optional uint64 value64 = 3;
getValue64() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberOrBuilder
optional uint64 value64 = 3;
getValueDescriptor() - Method in enum akka.cluster.protobuf.msg.ClusterMessages.MemberStatus
 
getValueDescriptor() - Method in enum akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberType
 
getValueDescriptor() - Method in enum akka.cluster.protobuf.msg.ClusterMessages.ReachabilityStatus
 
getValueDescriptor() - Method in enum akka.remote.ContainerFormats.PatternType
 
getValueDescriptor() - Method in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
 
getValueDescriptor() - Method in enum akka.remote.testconductor.TestConductorProtocol.Direction
 
getValueDescriptor() - Method in enum akka.remote.testconductor.TestConductorProtocol.FailType
 
getValueDescriptor() - Method in enum akka.remote.WireFormats.CommandType
 
getVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
required .VectorClock version = 6;
getVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
required .VectorClock version = 6;
getVersion() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
required .VectorClock version = 6;
getVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
required .VectorClock version = 3;
getVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
required .VectorClock version = 3;
getVersion() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipStatusOrBuilder
required .VectorClock version = 3;
getVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
required int64 version = 4;
getVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
required int64 version = 4;
getVersion() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.ObserverReachabilityOrBuilder
required int64 version = 4;
getVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
required int64 version = 4;
getVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
required int64 version = 4;
getVersion() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.SubjectReachabilityOrBuilder
required int64 version = 4;
getVersion() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
required int64 version = 2;
getVersion() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
required int64 version = 2;
getVersion() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.BucketOrBuilder
required int64 version = 2;
getVersion() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
required int64 version = 2;
getVersion() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
required int64 version = 2;
getVersion() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.EntryOrBuilder
required int64 version = 2;
getVersionBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
required .VectorClock version = 6;
getVersionBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
required .VectorClock version = 3;
getVersionOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
required .VectorClock version = 6;
getVersionOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
required .VectorClock version = 6;
getVersionOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
required .VectorClock version = 6;
getVersionOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
required .VectorClock version = 3;
getVersionOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
required .VectorClock version = 3;
getVersionOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipStatusOrBuilder
required .VectorClock version = 3;
getVersions(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
repeated .VectorClock.Version versions = 2;
getVersions(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
repeated .VectorClock.Version versions = 2;
getVersions(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.VectorClockOrBuilder
repeated .VectorClock.Version versions = 2;
getVersions(int) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
repeated .Status.Version versions = 1;
getVersions(int) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
repeated .Status.Version versions = 1;
getVersions(int) - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.StatusOrBuilder
repeated .Status.Version versions = 1;
getVersionsBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
repeated .VectorClock.Version versions = 2;
getVersionsBuilder(int) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
repeated .Status.Version versions = 1;
getVersionsBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
repeated .VectorClock.Version versions = 2;
getVersionsBuilderList() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
repeated .Status.Version versions = 1;
getVersionsCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
repeated .VectorClock.Version versions = 2;
getVersionsCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
repeated .VectorClock.Version versions = 2;
getVersionsCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.VectorClockOrBuilder
repeated .VectorClock.Version versions = 2;
getVersionsCount() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
repeated .Status.Version versions = 1;
getVersionsCount() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
repeated .Status.Version versions = 1;
getVersionsCount() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.StatusOrBuilder
repeated .Status.Version versions = 1;
getVersionsList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
repeated .VectorClock.Version versions = 2;
getVersionsList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
repeated .VectorClock.Version versions = 2;
getVersionsList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.VectorClockOrBuilder
repeated .VectorClock.Version versions = 2;
getVersionsList() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
repeated .Status.Version versions = 1;
getVersionsList() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
repeated .Status.Version versions = 1;
getVersionsList() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.StatusOrBuilder
repeated .Status.Version versions = 1;
getVersionsOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
repeated .VectorClock.Version versions = 2;
getVersionsOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
repeated .VectorClock.Version versions = 2;
getVersionsOrBuilder(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.VectorClockOrBuilder
repeated .VectorClock.Version versions = 2;
getVersionsOrBuilder(int) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
repeated .Status.Version versions = 1;
getVersionsOrBuilder(int) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
repeated .Status.Version versions = 1;
getVersionsOrBuilder(int) - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.StatusOrBuilder
repeated .Status.Version versions = 1;
getVersionsOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
repeated .VectorClock.Version versions = 2;
getVersionsOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
repeated .VectorClock.Version versions = 2;
getVersionsOrBuilderList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.VectorClockOrBuilder
repeated .VectorClock.Version versions = 2;
getVersionsOrBuilderList() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
repeated .Status.Version versions = 1;
getVersionsOrBuilderList() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
repeated .Status.Version versions = 1;
getVersionsOrBuilderList() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.StatusOrBuilder
repeated .Status.Version versions = 1;
getWildcardFanOut() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
optional bool wildcardFanOut = 5;
getWildcardFanOut() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
optional bool wildcardFanOut = 5;
getWildcardFanOut() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
optional bool wildcardFanOut = 5;
GIGABYTE() - Method in class akka.actor.mailbox.filebased.filequeue.tools.Util$
 
GIGABYTE() - Static method in class akka.actor.mailbox.filebased.filequeue.tools.Util
 
global() - Method in class akka.dispatch.ExecutionContexts$
 
global() - Static method in class akka.dispatch.ExecutionContexts
 
GlobalHome() - Method in class akka.actor.ActorSystem$
 
GlobalHome() - Static method in class akka.actor.ActorSystem
 
gossip() - Method in class akka.cluster.ClusterCoreDaemon
Initiates a new round of gossip.
gossip() - Method in class akka.cluster.ClusterMetricsCollector
Gossip to peer nodes.
Gossip - Class in akka.cluster
 
Gossip(SortedSet<Member>, GossipOverview, VectorClock) - Constructor for class akka.cluster.Gossip
 
gossip() - Method in class akka.cluster.GossipEnvelope
 
gossip() - Method in class akka.cluster.InternalClusterAction.Welcome
 
gossip() - Method in class akka.cluster.MetricsGossipEnvelope
 
gossip() - Method in class akka.contrib.pattern.DistributedPubSubMediator
Gossip to peer nodes.
gossip(Object, ActorRef) - Method in interface akka.routing.Listeners
Sends the supplied message to all current listeners using the provided sender() as sender.
Gossip$ - Class in akka.cluster
INTERNAL API
Gossip$() - Constructor for class akka.cluster.Gossip$
 
GOSSIP_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
GOSSIP_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
 
GossipDifferentViewProbability() - Method in class akka.cluster.ClusterSettings
 
GossipEnvelope - Class in akka.cluster
INTERNAL API Envelope adding a sender and receiver address to the gossip.
GossipEnvelope$ - Class in akka.cluster
 
GossipEnvelope$() - Constructor for class akka.cluster.GossipEnvelope$
 
GossipInterval() - Method in class akka.cluster.ClusterSettings
 
GossipOverview - Class in akka.cluster
INTERNAL API Represents the overview of the cluster, holds the cluster convergence table and set with unreachable nodes.
GossipOverview(Set<UniqueAddress>, Reachability) - Constructor for class akka.cluster.GossipOverview
 
GossipOverview$ - Class in akka.cluster
 
GossipOverview$() - Constructor for class akka.cluster.GossipOverview$
 
gossipSpeedupTick() - Method in class akka.cluster.ClusterCoreDaemon
 
gossipStats() - Method in class akka.cluster.ClusterCoreDaemon
 
gossipStats() - Method in class akka.cluster.ClusterEvent.CurrentInternalStats
 
GossipStats - Class in akka.cluster
INTERNAL API
GossipStats(long, long, long, long, long) - Constructor for class akka.cluster.GossipStats
 
GossipStats$ - Class in akka.cluster
 
GossipStats$() - Constructor for class akka.cluster.GossipStats$
 
GossipStatus - Class in akka.cluster
INTERNAL API When there are no known changes to the node ring a GossipStatus initiates a gossip chat between two members.
GossipStatus(UniqueAddress, VectorClock) - Constructor for class akka.cluster.GossipStatus
 
GossipStatus$ - Class in akka.cluster
 
GossipStatus$() - Constructor for class akka.cluster.GossipStatus$
 
gossipStatusTo(UniqueAddress, ActorRef) - Method in class akka.cluster.ClusterCoreDaemon
 
gossipStatusTo(UniqueAddress) - Method in class akka.cluster.ClusterCoreDaemon
 
gossipTask() - Method in class akka.cluster.ClusterCoreDaemon
 
gossipTask() - Method in class akka.cluster.ClusterMetricsCollector
Start periodic gossip to random nodes in cluster
gossipTask() - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
gossipTick() - Method in class akka.cluster.ClusterCoreDaemon
 
GossipTimeToLive() - Method in class akka.cluster.ClusterSettings
 
gossipTo(UniqueAddress) - Method in class akka.cluster.ClusterCoreDaemon
Gossips latest gossip to a node.
gossipTo(UniqueAddress, ActorRef) - Method in class akka.cluster.ClusterCoreDaemon
 
gossipTo(Address) - Method in class akka.cluster.ClusterMetricsCollector
 
gossipTo(Address) - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
goTo(S) - Method in class akka.actor.AbstractFSM
Produce transition to other state.
gotoHandingOver(ActorRef, boolean, Option<ActorRef>) - Method in class akka.contrib.pattern.ClusterSingletonManager
 
gotoOldest() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
gracefulClose(org.jboss.netty.channel.Channel, ExecutionContext) - Method in class akka.remote.transport.netty.NettyTransport$
 
gracefulClose(org.jboss.netty.channel.Channel, ExecutionContext) - Static method in class akka.remote.transport.netty.NettyTransport
 
gracefulStop(ActorRef, FiniteDuration, Object) - Method in interface akka.pattern.GracefulStopSupport
Returns a Future that will be completed with success (value true) when existing messages of the target actor has been processed and the actor has been terminated.
gracefulStop(ActorRef, FiniteDuration) - Method in class akka.pattern.Patterns$
Returns a Future that will be completed with success (value true) when existing messages of the target actor has been processed and the actor has been terminated.
gracefulStop(ActorRef, FiniteDuration, Object) - Method in class akka.pattern.Patterns$
Returns a Future that will be completed with success (value true) when existing messages of the target actor has been processed and the actor has been terminated.
gracefulStop(ActorRef, FiniteDuration) - Static method in class akka.pattern.Patterns
Returns a Future that will be completed with success (value true) when existing messages of the target actor has been processed and the actor has been terminated.
gracefulStop(ActorRef, FiniteDuration, Object) - Static method in class akka.pattern.Patterns
Returns a Future that will be completed with success (value true) when existing messages of the target actor has been processed and the actor has been terminated.
GracefulStopSupport - Interface in akka.pattern
 
group() - Method in class akka.cluster.routing.ClusterRouterGroupActor
 
group() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Subscribe
 
group() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Unsubscribe
 
Group - Interface in akka.routing
RouterConfig for router actor with routee actors that are created external to the router and the router sends messages to the specified path using actor selection, without watching for termination.
GroupBase - Class in akka.routing
Java API: Base class for custom router Group
GroupBase() - Constructor for class akka.routing.GroupBase
 
guard() - Method in interface akka.event.LoggingBus
 
guardian() - Method in class akka.actor.ActorCell
 
guardian() - Method in interface akka.actor.ActorRefFactory
Father of all children created by this interface.
guardian() - Method in interface akka.actor.ActorRefProvider
Reference to the supervisor used for all top-level user actors.
guardian() - Method in class akka.actor.ActorSystemImpl
 
guardian() - Method in class akka.actor.ExtendedActorSystem
The top-level supervisor of all actors created using system.actorOf(...).
guardian() - Method in class akka.actor.LocalActorRefProvider
 
guardian() - Method in class akka.remote.RemoteActorRefProvider
 
GuardianName() - Method in class akka.contrib.pattern.ClusterSharding.Settings$
 
guardianStrategy() - Method in class akka.actor.LocalActorRefProvider
Overridable supervision strategy to be used by the &ldquo;/user&rdquo; guardian.

H

handle() - Method in class akka.remote.EndpointWriter
 
handle() - Method in class akka.remote.EndpointWriter.Handle
 
handle() - Method in class akka.remote.EndpointWriter.TakeOver
 
handle() - Method in class akka.remote.EndpointWriter.TookOver
 
handle() - Method in class akka.remote.transport.ProtocolStateActor.Handle
 
handle() - Method in class akka.remote.transport.ThrottledAssociation.ExposedHandle
 
handle() - Method in class akka.remote.transport.ThrottlerManager.AssociateResult
 
handle() - Method in class akka.remote.transport.ThrottlerManager.Checkin
 
handle() - Method in class akka.remote.transport.ThrottlerManager.Handle
 
handleBarrier(BarrierCoordinator.Data) - Method in class akka.remote.testconductor.BarrierCoordinator
 
handleChildTerminated(ActorContext, ActorRef, Iterable<ActorRef>) - Method in class akka.actor.AllForOneStrategy
 
handleChildTerminated(ActorRef) - Method in interface akka.actor.dungeon.FaultHandling
 
handleChildTerminated(ActorContext, ActorRef, Iterable<ActorRef>) - Method in class akka.actor.OneForOneStrategy
 
handleChildTerminated(ActorContext, ActorRef, Iterable<ActorRef>) - Method in class akka.actor.SupervisorStrategy
This method is called after the child has been removed from the set of children.
handleClose(TcpConnection.ConnectionInfo, Option<ActorRef>, Tcp.ConnectionClosed) - Method in class akka.io.TcpConnection
 
handleError(ActorRef, IOException) - Method in class akka.io.TcpConnection
 
handleEvent() - Method in interface akka.actor.FSM
 
handleEventDefault() - Method in interface akka.actor.FSM
 
handleException() - Method in interface akka.actor.dungeon.Dispatch
 
handleFailure(Failed) - Method in interface akka.actor.dungeon.FaultHandling
 
handleFailure(ActorContext, ActorRef, Throwable, ChildRestartStats, Iterable<ChildRestartStats>) - Method in class akka.actor.SupervisorStrategy
This is the main entry point: in case of a child&rsquo;s failure, this method must try to handle the failure by resuming, restarting or stopping the child (and returning true), or it returns false to escalate the failure, which will lead to this actor re-throwing the exception which caused the failure.
handleInboundAssociation(Transport.InboundAssociation, boolean) - Method in class akka.remote.EndpointManager
 
handleInitial(ClusterEvent.CurrentClusterState) - Method in class akka.contrib.pattern.ClusterSingletonProxy
 
handleInvokeFailure(Iterable<ActorRef>, Throwable) - Method in interface akka.actor.dungeon.FaultHandling
 
handleListener() - Method in class akka.remote.transport.ProtocolStateActor.AssociatedWaitHandler
 
handleMessage(Object) - Method in interface akka.contrib.pattern.Aggregator
Handles messages and matches against the expect list.
handleNonFatalOrInterruptedException(Function1<Throwable, BoxedUnit>) - Method in interface akka.actor.dungeon.FaultHandling
 
handler() - Method in class akka.io.Tcp.Bind
 
handler() - Method in class akka.io.Tcp.Register
 
handler() - Method in class akka.io.TcpConnection.ConnectionInfo
 
handler() - Method in class akka.io.Udp.Bind
 
handler() - Method in class akka.io.UdpConnected.Connect
 
handler() - Method in class akka.persistence.Eventsourced.AsyncHandlerInvocation
 
handler() - Method in interface akka.persistence.Eventsourced.PendingHandlerInvocation
 
handler() - Method in class akka.persistence.Eventsourced.StashingHandlerInvocation
 
handler() - Method in class akka.remote.testconductor.ClientFSM
 
handleStashedInbound(ActorRef, boolean) - Method in class akka.remote.EndpointManager
 
handleSupervise(ActorRef, boolean) - Method in class akka.actor.ActorCell
 
handleTransition(S, S) - Method in interface akka.actor.FSM
 
handleWriteMessages(TcpConnection.ConnectionInfo) - Method in class akka.io.TcpConnection
 
handoff() - Method in class akka.remote.EndpointWriter
 
HandOffTimeout() - Method in class akka.contrib.pattern.ClusterSharding.Settings$
 
handOverDone(Option<ActorRef>) - Method in class akka.contrib.pattern.ClusterSingletonManager
 
handshakeInfo() - Method in class akka.remote.transport.AkkaProtocolHandle
 
HandshakeInfo - Class in akka.remote.transport
 
HandshakeInfo(Address, int, Option<String>) - Constructor for class akka.remote.transport.HandshakeInfo
 
HandshakeInfo$ - Class in akka.remote.transport
 
HandshakeInfo$() - Constructor for class akka.remote.transport.HandshakeInfo$
 
HANDSHAKEINFO_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AkkaControlMessage
 
HandshakeTimeout() - Method in class akka.remote.transport.AkkaProtocolSettings
 
handshakeTimerKey() - Method in class akka.remote.transport.ProtocolStateActor
 
hasAck() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .AcknowledgementInfo ack = 1;
hasAck() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
optional .AcknowledgementInfo ack = 1;
hasAck() - Method in interface akka.remote.WireFormats.AckAndEnvelopeContainerOrBuilder
optional .AcknowledgementInfo ack = 1;
hasAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
optional .Address addr = 2;
hasAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
optional .Address addr = 2;
hasAddr() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressRequestOrBuilder
optional .Address addr = 2;
hasAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .AddressRequest addr = 5;
hasAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
optional .AddressRequest addr = 5;
hasAddr() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
optional .AddressRequest addr = 5;
hasAddress() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
required .Address address = 1;
hasAddress() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
required .Address address = 1;
hasAddress() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.UniqueAddressOrBuilder
required .Address address = 1;
hasAddress() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
required .Address address = 1;
hasAddress() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
required .Address address = 1;
hasAddress() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.VersionOrBuilder
required .Address address = 1;
hasAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
required .Address address = 2;
hasAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
required .Address address = 2;
hasAddress() - Method in interface akka.remote.testconductor.TestConductorProtocol.HelloOrBuilder
required .Address address = 2;
hasAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
optional .Address address = 3;
hasAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
optional .Address address = 3;
hasAddress() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
optional .Address address = 3;
hasAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
required int32 addressIndex = 1;
hasAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
required int32 addressIndex = 1;
hasAddressIndex() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MemberOrBuilder
required int32 addressIndex = 1;
hasAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
required int32 addressIndex = 1;
hasAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
required int32 addressIndex = 1;
hasAddressIndex() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetricsOrBuilder
required int32 addressIndex = 1;
hasAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
required int32 addressIndex = 1;
hasAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
required int32 addressIndex = 1;
hasAddressIndex() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.ObserverReachabilityOrBuilder
required int32 addressIndex = 1;
hasAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
required int32 addressIndex = 1;
hasAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
required int32 addressIndex = 1;
hasAddressIndex() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.SubjectReachabilityOrBuilder
required int32 addressIndex = 1;
hasAllButSelf() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
required bool allButSelf = 2;
hasAllButSelf() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
required bool allButSelf = 2;
hasAllButSelf() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAllOrBuilder
required bool allButSelf = 2;
hasAlpha() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
required double alpha = 2;
hasAlpha() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
required double alpha = 2;
hasAlpha() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMAOrBuilder
required double alpha = 2;
hasBarrier() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .EnterBarrier barrier = 2;
hasBarrier() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
optional .EnterBarrier barrier = 2;
hasBarrier() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
optional .EnterBarrier barrier = 2;
hasChannel() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
optional string channel = 5;
hasChannel() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
optional string channel = 5;
hasChannel() - Method in interface akka.persistence.serialization.MessageFormats.DeliveredMessageOrBuilder
optional string channel = 5;
hasChannelId() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
optional string channelId = 2;
hasChannelId() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
optional string channelId = 2;
hasChannelId() - Method in interface akka.persistence.serialization.MessageFormats.DeliveredMessageOrBuilder
optional string channelId = 2;
hasChildren() - Method in class akka.actor.VirtualPathContainer
 
hasClazz() - Method in class akka.remote.WireFormats.PropsData.Builder
required string clazz = 3;
hasClazz() - Method in class akka.remote.WireFormats.PropsData
required string clazz = 3;
hasClazz() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
required string clazz = 3;
hasCommandType() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
required .CommandType commandType = 1;
hasCommandType() - Method in class akka.remote.WireFormats.AkkaControlMessage
required .CommandType commandType = 1;
hasCommandType() - Method in interface akka.remote.WireFormats.AkkaControlMessageOrBuilder
required .CommandType commandType = 1;
hasConfig() - Method in class akka.remote.WireFormats.DeployData.Builder
optional bytes config = 2;
hasConfig() - Method in class akka.remote.WireFormats.DeployData
optional bytes config = 2;
hasConfig() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
optional bytes config = 2;
hasConfirmable() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional bool confirmable = 8;
hasConfirmable() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional bool confirmable = 8;
hasConfirmable() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional bool confirmable = 8;
hasConfirmMessage() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional .DeliveredMessage confirmMessage = 9;
hasConfirmMessage() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional .DeliveredMessage confirmMessage = 9;
hasConfirmMessage() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional .DeliveredMessage confirmMessage = 9;
hasConfirmTarget() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string confirmTarget = 10;
hasConfirmTarget() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional string confirmTarget = 10;
hasConfirmTarget() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional string confirmTarget = 10;
hasCookie() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
optional string cookie = 3;
hasCookie() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
optional string cookie = 3;
hasCookie() - Method in interface akka.remote.WireFormats.AkkaHandshakeInfoOrBuilder
optional string cookie = 3;
hasCumulativeAck() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
required fixed64 cumulativeAck = 1;
hasCumulativeAck() - Method in class akka.remote.WireFormats.AcknowledgementInfo
required fixed64 cumulativeAck = 1;
hasCumulativeAck() - Method in interface akka.remote.WireFormats.AcknowledgementInfoOrBuilder
required fixed64 cumulativeAck = 1;
hasCurrentDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
required int64 currentDeliveryId = 1;
hasCurrentDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
required int64 currentDeliveryId = 1;
hasCurrentDeliveryId() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshotOrBuilder
required int64 currentDeliveryId = 1;
hasDeleted() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional bool deleted = 4;
hasDeleted() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional bool deleted = 4;
hasDeleted() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional bool deleted = 4;
hasDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required int64 deliveryId = 1;
hasDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
required int64 deliveryId = 1;
hasDeliveryId() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder
required int64 deliveryId = 1;
hasDeliverySequenceNr() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
optional int64 deliverySequenceNr = 4;
hasDeliverySequenceNr() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
optional int64 deliverySequenceNr = 4;
hasDeliverySequenceNr() - Method in interface akka.persistence.serialization.MessageFormats.DeliveredMessageOrBuilder
optional int64 deliverySequenceNr = 4;
hasDeploy() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .DeployData deploy = 2;
hasDeploy() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
required .DeployData deploy = 2;
hasDeploy() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
required .DeployData deploy = 2;
hasDeploy() - Method in class akka.remote.WireFormats.PropsData.Builder
required .DeployData deploy = 2;
hasDeploy() - Method in class akka.remote.WireFormats.PropsData
required .DeployData deploy = 2;
hasDeploy() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
required .DeployData deploy = 2;
hasDestination() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required string destination = 2;
hasDestination() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
required string destination = 2;
hasDestination() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder
required string destination = 2;
hasDestination() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage.Builder
optional string destination = 2;
hasDestination() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage
optional string destination = 2;
hasDestination() - Method in interface akka.persistence.serialization.MessageFormats.DeliverMessageOrBuilder
optional string destination = 2;
hasDirection() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
optional .Direction direction = 2;
hasDirection() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
optional .Direction direction = 2;
hasDirection() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
optional .Direction direction = 2;
hasDispatcher(String) - Method in class akka.dispatch.Dispatchers
Checks that the configuration provides a section for the given dispatcher.
hasDispatcher() - Method in class akka.remote.WireFormats.DeployData.Builder
optional string dispatcher = 5;
hasDispatcher() - Method in class akka.remote.WireFormats.DeployData
optional string dispatcher = 5;
hasDispatcher() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
optional string dispatcher = 5;
hasDone() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional string done = 4;
hasDone() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
optional string done = 4;
hasDone() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
optional string done = 4;
hasEnclosedMessage() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload.Builder
required bytes enclosedMessage = 1;
hasEnclosedMessage() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
required bytes enclosedMessage = 1;
hasEnclosedMessage() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.PayloadOrBuilder
required bytes enclosedMessage = 1;
hasEnclosedMessage() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
required bytes enclosedMessage = 1;
hasEnclosedMessage() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
required bytes enclosedMessage = 1;
hasEnclosedMessage() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
required bytes enclosedMessage = 1;
hasEnvelope() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .RemoteEnvelope envelope = 2;
hasEnvelope() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
optional .RemoteEnvelope envelope = 2;
hasEnvelope() - Method in interface akka.remote.WireFormats.AckAndEnvelopeContainerOrBuilder
optional .RemoteEnvelope envelope = 2;
hasEwma() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
optional .NodeMetrics.EWMA ewma = 3;
hasEwma() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
optional .NodeMetrics.EWMA ewma = 3;
hasEwma() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.MetricOrBuilder
optional .NodeMetrics.EWMA ewma = 3;
hasExitValue() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
optional int32 exitValue = 7;
hasExitValue() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
optional int32 exitValue = 7;
hasExitValue() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
optional int32 exitValue = 7;
hasExtension(ExtensionId<? extends Extension>) - Method in class akka.actor.ActorSystem
Returns whether the specified extension is already registered, this method can potentially block, waiting for the initialization of the payload, if is in the process of registration from another Thread of execution
hasExtension(ExtensionId<? extends Extension>) - Method in class akka.actor.ActorSystemImpl
 
hasFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
required .FailType failure = 1;
hasFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
required .FailType failure = 1;
hasFailure() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
required .FailType failure = 1;
hasFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .InjectFailure failure = 3;
hasFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
optional .InjectFailure failure = 3;
hasFailure() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
optional .InjectFailure failure = 3;
hasFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
required .UniqueAddress from = 1;
hasFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
required .UniqueAddress from = 1;
hasFrom() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelopeOrBuilder
required .UniqueAddress from = 1;
hasFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
required .UniqueAddress from = 1;
hasFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
required .UniqueAddress from = 1;
hasFrom() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipStatusOrBuilder
required .UniqueAddress from = 1;
hasFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
required .Address from = 1;
hasFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
required .Address from = 1;
hasFrom() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelopeOrBuilder
required .Address from = 1;
hasFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
required .UniqueAddress from = 1;
hasFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
required .UniqueAddress from = 1;
hasFrom() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.WelcomeOrBuilder
required .UniqueAddress from = 1;
hasGlobalScope() - Method in class akka.actor.Address
Returns true if this Address is usable globally.
hasGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
required .MetricsGossip gossip = 2;
hasGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
required .MetricsGossip gossip = 2;
hasGossip() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelopeOrBuilder
required .MetricsGossip gossip = 2;
hasGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
required .Gossip gossip = 2;
hasGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
required .Gossip gossip = 2;
hasGossip() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.WelcomeOrBuilder
required .Gossip gossip = 2;
hash(int, Object) - Method in class akka.util.HashCode$
 
hash(int, boolean) - Method in class akka.util.HashCode$
 
hash(int, char) - Method in class akka.util.HashCode$
 
hash(int, int) - Method in class akka.util.HashCode$
 
hash(int, long) - Method in class akka.util.HashCode$
 
hash(int, float) - Method in class akka.util.HashCode$
 
hash(int, double) - Method in class akka.util.HashCode$
 
hash(int, Object) - Static method in class akka.util.HashCode
 
hash(int, boolean) - Static method in class akka.util.HashCode
 
hash(int, char) - Static method in class akka.util.HashCode
 
hash(int, int) - Static method in class akka.util.HashCode
 
hash(int, long) - Static method in class akka.util.HashCode
 
hash(int, float) - Static method in class akka.util.HashCode
 
hash(int, double) - Static method in class akka.util.HashCode
 
hasHandshakeInfo() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
optional .AkkaHandshakeInfo handshakeInfo = 2;
hasHandshakeInfo() - Method in class akka.remote.WireFormats.AkkaControlMessage
optional .AkkaHandshakeInfo handshakeInfo = 2;
hasHandshakeInfo() - Method in interface akka.remote.WireFormats.AkkaControlMessageOrBuilder
optional .AkkaHandshakeInfo handshakeInfo = 2;
hasHashIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
required int32 hashIndex = 1;
hasHashIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
required int32 hashIndex = 1;
hasHashIndex() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.VectorClock.VersionOrBuilder
required int32 hashIndex = 1;
hashCode() - Method in class akka.actor.ActorRef
 
hashCode() - Method in class akka.actor.ActorSelection
 
hashCode() - Method in class akka.actor.Address
 
hashCode() - Method in class akka.actor.ChildActorPath
 
hashCode() - Method in interface akka.actor.ExtensionId
 
hashCode() - Method in class akka.cluster.Member
 
hashCode() - Method in class akka.cluster.Metric
 
hashCode() - Method in class akka.cluster.NodeMetrics
 
hashCode() - Method in class akka.cluster.Reachability
 
hashCode() - Method in class akka.cluster.UniqueAddress
 
HashCode - Class in akka.util
Set of methods which allow easy implementation of hashCode.
HashCode() - Constructor for class akka.util.HashCode
 
HashCode$ - Class in akka.util
Set of methods which allow easy implementation of hashCode.
HashCode$() - Constructor for class akka.util.HashCode$
 
hasHello() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .Hello hello = 1;
hasHello() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
optional .Hello hello = 1;
hasHello() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
optional .Hello hello = 1;
HASHINDEX_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
 
hashKey() - Method in class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope
 
hashKey(Object) - Method in interface akka.routing.ConsistentHashingRouter.ConsistentHashMapper
 
hashMapping() - Method in class akka.routing.ConsistentHashingGroup
 
hashMapping() - Method in class akka.routing.ConsistentHashingPool
 
hashMapping() - Method in class akka.routing.ConsistentHashingRouter
 
hashMapping() - Method in class akka.routing.ConsistentHashingRoutingLogic
 
hashMappingAdapter(ConsistentHashingRouter.ConsistentHashMapper) - Method in class akka.routing.ConsistentHashingRouter$
INTERNAL API
hashMappingAdapter(ConsistentHashingRouter.ConsistentHashMapper) - Static method in class akka.routing.ConsistentHashingRouter
INTERNAL API
hasHost() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
required string host = 3;
hasHost() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
required string host = 3;
hasHost() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
required string host = 3;
hasHostname() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
required string hostname = 2;
hasHostname() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
required string hostname = 2;
hasHostname() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.AddressOrBuilder
required string hostname = 2;
hasHostname() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
required string hostname = 2;
hasHostname() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
required string hostname = 2;
hasHostname() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.AddressOrBuilder
required string hostname = 2;
hasHostname() - Method in class akka.remote.WireFormats.AddressData.Builder
required string hostname = 2;
hasHostname() - Method in class akka.remote.WireFormats.AddressData
required string hostname = 2;
hasHostname() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
required string hostname = 2;
hasInstruction() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
optional .AkkaControlMessage instruction = 2;
hasInstruction() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
optional .AkkaControlMessage instruction = 2;
hasInstruction() - Method in interface akka.remote.WireFormats.AkkaProtocolMessageOrBuilder
optional .AkkaControlMessage instruction = 2;
hasKey() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
required string key = 1;
hasKey() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
required string key = 1;
hasKey() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.EntryOrBuilder
required string key = 1;
hasLocalAffinity() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
required bool localAffinity = 2;
hasLocalAffinity() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
required bool localAffinity = 2;
hasLocalAffinity() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendOrBuilder
required bool localAffinity = 2;
hasLocalScope() - Method in class akka.actor.Address
Returns true if this Address is only defined locally.
hasMatcher() - Method in class akka.remote.ContainerFormats.Selection.Builder
optional string matcher = 2;
hasMatcher() - Method in class akka.remote.ContainerFormats.Selection
optional string matcher = 2;
hasMatcher() - Method in interface akka.remote.ContainerFormats.SelectionOrBuilder
optional string matcher = 2;
hasMember(UniqueAddress) - Method in class akka.cluster.Gossip
 
hasMessage() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
required .SerializedMessage message = 2;
hasMessage() - Method in class akka.remote.WireFormats.RemoteEnvelope
required .SerializedMessage message = 2;
hasMessage() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
required .SerializedMessage message = 2;
hasMessage() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
required bytes message = 1;
hasMessage() - Method in class akka.remote.WireFormats.SerializedMessage
required bytes message = 1;
hasMessage() - Method in interface akka.remote.WireFormats.SerializedMessageOrBuilder
required bytes message = 1;
hasMessageManifest() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload.Builder
optional bytes messageManifest = 4;
hasMessageManifest() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
optional bytes messageManifest = 4;
hasMessageManifest() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.PayloadOrBuilder
optional bytes messageManifest = 4;
hasMessageManifest() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
optional bytes messageManifest = 4;
hasMessageManifest() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
optional bytes messageManifest = 4;
hasMessageManifest() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
optional bytes messageManifest = 4;
hasMessageManifest() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
optional bytes messageManifest = 3;
hasMessageManifest() - Method in class akka.remote.WireFormats.SerializedMessage
optional bytes messageManifest = 3;
hasMessageManifest() - Method in interface akka.remote.WireFormats.SerializedMessageOrBuilder
optional bytes messageManifest = 3;
hasMessages() - Method in interface akka.actor.Cell
If the actor isLocal, returns whether "user messages" are currently queued, &ldquo;false&rdquo; otherwise.
hasMessages() - Method in interface akka.actor.dungeon.Dispatch
 
hasMessages() - Method in class akka.actor.mailbox.filebased.FileBasedMessageQueue
 
hasMessages() - Method in class akka.actor.UnstartedCell
 
hasMessages() - Method in class akka.dispatch.Mailbox
Indicates whether this queue is non-empty.
hasMessages() - Method in interface akka.dispatch.MessageQueue
Indicates whether this queue is non-empty.
hasMessages() - Method in class akka.dispatch.NodeMessageQueue
 
hasMessages() - Method in interface akka.dispatch.QueueBasedMessageQueue
 
hasMessages(Routee) - Method in class akka.routing.SmallestMailboxRoutingLogic
Returns true if the actor currently has any pending messages in the mailbox, i.e.
hasMessages() - Method in class akka.testkit.CallingThreadMailbox
 
hasName() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
required string name = 1;
hasName() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
required string name = 1;
hasName() - Method in interface akka.remote.testconductor.TestConductorProtocol.EnterBarrierOrBuilder
required string name = 1;
hasName() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
required string name = 1;
hasName() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
required string name = 1;
hasName() - Method in interface akka.remote.testconductor.TestConductorProtocol.HelloOrBuilder
required string name = 1;
hasNameIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
required int32 nameIndex = 1;
hasNameIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
required int32 nameIndex = 1;
hasNameIndex() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.MetricOrBuilder
required int32 nameIndex = 1;
HasNecessaryClusterRole() - Method in class akka.contrib.pattern.ClusterSharding.Settings$
 
hasNext() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
hasNext() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
hasNode() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
required .UniqueAddress node = 1;
hasNode() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
required .UniqueAddress node = 1;
hasNode() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.JoinOrBuilder
required .UniqueAddress node = 1;
hasNode() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
required string node = 1;
hasNode() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
required string node = 1;
hasNode() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressRequestOrBuilder
required string node = 1;
hasNumber() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
required .NodeMetrics.Number number = 2;
hasNumber() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
required .NodeMetrics.Number number = 2;
hasNumber() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.MetricOrBuilder
required .NodeMetrics.Number number = 2;
hasOp() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
required .BarrierOp op = 2;
hasOp() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
required .BarrierOp op = 2;
hasOp() - Method in interface akka.remote.testconductor.TestConductorProtocol.EnterBarrierOrBuilder
required .BarrierOp op = 2;
hasOrigin() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
required .AddressData origin = 1;
hasOrigin() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
required .AddressData origin = 1;
hasOrigin() - Method in interface akka.remote.WireFormats.AkkaHandshakeInfoOrBuilder
required .AddressData origin = 1;
hasOverview() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
required .GossipOverview overview = 5;
hasOverview() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
required .GossipOverview overview = 5;
hasOverview() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
required .GossipOverview overview = 5;
hasOwner() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
required .Address owner = 1;
hasOwner() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
required .Address owner = 1;
hasOwner() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.BucketOrBuilder
required .Address owner = 1;
hasPath() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
required string path = 1;
hasPath() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
required string path = 1;
hasPath() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendOrBuilder
required string path = 1;
hasPath() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
required string path = 1;
hasPath() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
required string path = 1;
hasPath() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAllOrBuilder
required string path = 1;
hasPath(String) - Method in class akka.dispatch.CachingConfig
 
hasPath() - Method in class akka.remote.WireFormats.ActorRefData.Builder
required string path = 1;
hasPath() - Method in class akka.remote.WireFormats.ActorRefData
required string path = 1;
hasPath() - Method in interface akka.remote.WireFormats.ActorRefDataOrBuilder
required string path = 1;
hasPath() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required string path = 3;
hasPath() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
required string path = 3;
hasPath() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
required string path = 3;
hasPath() - Method in class akka.remote.WireFormats.DeployData.Builder
required string path = 1;
hasPath() - Method in class akka.remote.WireFormats.DeployData
required string path = 1;
hasPath() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
required string path = 1;
hasPayload() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish.Builder
required .Payload payload = 3;
hasPayload() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
required .Payload payload = 3;
hasPayload() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.PublishOrBuilder
required .Payload payload = 3;
hasPayload() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
required .Payload payload = 3;
hasPayload() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
required .Payload payload = 3;
hasPayload() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendOrBuilder
required .Payload payload = 3;
hasPayload() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
required .Payload payload = 3;
hasPayload() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
required .Payload payload = 3;
hasPayload() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAllOrBuilder
required .Payload payload = 3;
hasPayload() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required .PersistentPayload payload = 3;
hasPayload() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
required .PersistentPayload payload = 3;
hasPayload() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder
required .PersistentPayload payload = 3;
hasPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional .PersistentPayload payload = 1;
hasPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional .PersistentPayload payload = 1;
hasPayload() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional .PersistentPayload payload = 1;
hasPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
required bytes payload = 2;
hasPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
required bytes payload = 2;
hasPayload() - Method in interface akka.persistence.serialization.MessageFormats.PersistentPayloadOrBuilder
required bytes payload = 2;
hasPayload() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
optional bytes payload = 1;
hasPayload() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
optional bytes payload = 1;
hasPayload() - Method in interface akka.remote.WireFormats.AkkaProtocolMessageOrBuilder
optional bytes payload = 1;
hasPayloadManifest() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
optional bytes payloadManifest = 3;
hasPayloadManifest() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
optional bytes payloadManifest = 3;
hasPayloadManifest() - Method in interface akka.persistence.serialization.MessageFormats.PersistentPayloadOrBuilder
optional bytes payloadManifest = 3;
hasPersistenceId() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
optional string persistenceId = 1;
hasPersistenceId() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
optional string persistenceId = 1;
hasPersistenceId() - Method in interface akka.persistence.serialization.MessageFormats.DeliveredMessageOrBuilder
optional string persistenceId = 1;
hasPersistenceId() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string persistenceId = 3;
hasPersistenceId() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional string persistenceId = 3;
hasPersistenceId() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional string persistenceId = 3;
hasPersistent() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage.Builder
optional .PersistentMessage persistent = 1;
hasPersistent() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage
optional .PersistentMessage persistent = 1;
hasPersistent() - Method in interface akka.persistence.serialization.MessageFormats.DeliverMessageOrBuilder
optional .PersistentMessage persistent = 1;
hasPersistentSequenceNr() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
optional int64 persistentSequenceNr = 3;
hasPersistentSequenceNr() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
optional int64 persistentSequenceNr = 3;
hasPersistentSequenceNr() - Method in interface akka.persistence.serialization.MessageFormats.DeliveredMessageOrBuilder
optional int64 persistentSequenceNr = 3;
hasPort() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
required uint32 port = 3;
hasPort() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
required uint32 port = 3;
hasPort() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.AddressOrBuilder
required uint32 port = 3;
hasPort() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
required uint32 port = 3;
hasPort() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
required uint32 port = 3;
hasPort() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.AddressOrBuilder
required uint32 port = 3;
hasPort() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
required int32 port = 4;
hasPort() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
required int32 port = 4;
hasPort() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
required int32 port = 4;
hasPort() - Method in class akka.remote.WireFormats.AddressData.Builder
required uint32 port = 3;
hasPort() - Method in class akka.remote.WireFormats.AddressData
required uint32 port = 3;
hasPort() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
required uint32 port = 3;
hasProps() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .PropsData props = 1;
hasProps() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
required .PropsData props = 1;
hasProps() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
required .PropsData props = 1;
hasProtocol() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
optional string protocol = 4;
hasProtocol() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
optional string protocol = 4;
hasProtocol() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.AddressOrBuilder
optional string protocol = 4;
hasProtocol() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
optional string protocol = 4;
hasProtocol() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
optional string protocol = 4;
hasProtocol() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.AddressOrBuilder
optional string protocol = 4;
hasProtocol() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
required string protocol = 1;
hasProtocol() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
required string protocol = 1;
hasProtocol() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
required string protocol = 1;
hasProtocol() - Method in class akka.remote.WireFormats.AddressData.Builder
optional string protocol = 4;
hasProtocol() - Method in class akka.remote.WireFormats.AddressData
optional string protocol = 4;
hasProtocol() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
optional string protocol = 4;
hasRateMBit() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
optional float rateMBit = 6;
hasRateMBit() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
optional float rateMBit = 6;
hasRateMBit() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
optional float rateMBit = 6;
hasRecipient() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
required .ActorRefData recipient = 1;
hasRecipient() - Method in class akka.remote.WireFormats.RemoteEnvelope
required .ActorRefData recipient = 1;
hasRecipient() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
required .ActorRefData recipient = 1;
hasRedeliveries() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional int32 redeliveries = 6;
hasRedeliveries() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional int32 redeliveries = 6;
hasRedeliveries() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional int32 redeliveries = 6;
hasRef() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
optional string ref = 3;
hasRef() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
optional string ref = 3;
hasRef() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.EntryOrBuilder
optional string ref = 3;
hasReply() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
required bool reply = 3;
hasReply() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
required bool reply = 3;
hasReply() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelopeOrBuilder
required bool reply = 3;
hasRequiredType(Class<? extends Actor>) - Method in class akka.dispatch.Mailboxes
Check if this class can have a required message queue type.
hasRole(String) - Method in class akka.cluster.Member
 
hasRouterConfig() - Method in class akka.remote.WireFormats.DeployData.Builder
optional bytes routerConfig = 3;
hasRouterConfig() - Method in class akka.remote.WireFormats.DeployData
optional bytes routerConfig = 3;
hasRouterConfig() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
optional bytes routerConfig = 3;
hasScope() - Method in class akka.remote.WireFormats.DeployData.Builder
optional bytes scope = 4;
hasScope() - Method in class akka.remote.WireFormats.DeployData
optional bytes scope = 4;
hasScope() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
optional bytes scope = 4;
hasSender() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string sender = 11;
hasSender() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional string sender = 11;
hasSender() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional string sender = 11;
hasSender() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
optional .ActorRefData sender = 4;
hasSender() - Method in class akka.remote.WireFormats.RemoteEnvelope
optional .ActorRefData sender = 4;
hasSender() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
optional .ActorRefData sender = 4;
hasSeq() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
optional fixed64 seq = 5;
hasSeq() - Method in class akka.remote.WireFormats.RemoteEnvelope
optional fixed64 seq = 5;
hasSeq() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
optional fixed64 seq = 5;
hasSequenceNr() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional int64 sequenceNr = 2;
hasSequenceNr() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional int64 sequenceNr = 2;
hasSequenceNr() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional int64 sequenceNr = 2;
HasSequenceNumber - Interface in akka.remote
Messages that are to be buffered in AckedSendBuffer or AckedReceiveBuffer has to implement this interface to provide the sequence needed by the buffers.
HasSequenceNumber$ - Class in akka.remote
 
HasSequenceNumber$() - Constructor for class akka.remote.HasSequenceNumber$
 
hasSerialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
optional bytes serialized = 4;
hasSerialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
optional bytes serialized = 4;
hasSerialized() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberOrBuilder
optional bytes serialized = 4;
hasSerializedGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
required bytes serializedGossip = 3;
hasSerializedGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
required bytes serializedGossip = 3;
hasSerializedGossip() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelopeOrBuilder
required bytes serializedGossip = 3;
hasSerializerId() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload.Builder
required int32 serializerId = 2;
hasSerializerId() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
required int32 serializerId = 2;
hasSerializerId() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.PayloadOrBuilder
required int32 serializerId = 2;
hasSerializerId() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
required int32 serializerId = 1;
hasSerializerId() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
required int32 serializerId = 1;
hasSerializerId() - Method in interface akka.persistence.serialization.MessageFormats.PersistentPayloadOrBuilder
required int32 serializerId = 1;
hasSerializerId() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
required int32 serializerId = 2;
hasSerializerId() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
required int32 serializerId = 2;
hasSerializerId() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
required int32 serializerId = 2;
hasSerializerId() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
required int32 serializerId = 2;
hasSerializerId() - Method in class akka.remote.WireFormats.SerializedMessage
required int32 serializerId = 2;
hasSerializerId() - Method in interface akka.remote.WireFormats.SerializedMessageOrBuilder
required int32 serializerId = 2;
hasStatus() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
required .MemberStatus status = 3;
hasStatus() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
required .MemberStatus status = 3;
hasStatus() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MemberOrBuilder
required .MemberStatus status = 3;
hasStatus() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
required .ReachabilityStatus status = 3;
hasStatus() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
required .ReachabilityStatus status = 3;
hasStatus() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.SubjectReachabilityOrBuilder
required .ReachabilityStatus status = 3;
hasSupervisor() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .ActorRefData supervisor = 4;
hasSupervisor() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
required .ActorRefData supervisor = 4;
hasSupervisor() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
required .ActorRefData supervisor = 4;
hasSystem() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
required string system = 1;
hasSystem() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
required string system = 1;
hasSystem() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.AddressOrBuilder
required string system = 1;
hasSystem() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
required string system = 1;
hasSystem() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
required string system = 1;
hasSystem() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.AddressOrBuilder
required string system = 1;
hasSystem() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
required string system = 2;
hasSystem() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
required string system = 2;
hasSystem() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
required string system = 2;
hasSystem() - Method in class akka.remote.WireFormats.AddressData.Builder
required string system = 1;
hasSystem() - Method in class akka.remote.WireFormats.AddressData
required string system = 1;
hasSystem() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
required string system = 1;
hasSystemMessages() - Method in interface akka.dispatch.DefaultSystemMessageQueue
 
hasSystemMessages() - Method in interface akka.dispatch.SystemMessageQueue
 
hasTimeout() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
optional int64 timeout = 3;
hasTimeout() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
optional int64 timeout = 3;
hasTimeout() - Method in interface akka.remote.testconductor.TestConductorProtocol.EnterBarrierOrBuilder
optional int64 timeout = 3;
hasTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
required int64 timestamp = 2;
hasTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
required int64 timestamp = 2;
hasTimestamp() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetricsOrBuilder
required int64 timestamp = 2;
hasTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
optional int64 timestamp = 1;
hasTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
optional int64 timestamp = 1;
hasTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
required int64 timestamp = 2;
hasTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
required int64 timestamp = 2;
hasTimestamp() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.VectorClock.VersionOrBuilder
required int64 timestamp = 2;
hasTimestamp() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.VectorClockOrBuilder
optional int64 timestamp = 1;
hasTimestamp() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
required int64 timestamp = 2;
hasTimestamp() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
required int64 timestamp = 2;
hasTimestamp() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.VersionOrBuilder
required int64 timestamp = 2;
hasTo() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
required .UniqueAddress to = 2;
hasTo() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
required .UniqueAddress to = 2;
hasTo() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelopeOrBuilder
required .UniqueAddress to = 2;
hasTopic() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish.Builder
required string topic = 1;
hasTopic() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
required string topic = 1;
hasTopic() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.PublishOrBuilder
required string topic = 1;
hasType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
required .NodeMetrics.NumberType type = 1;
hasType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
required .NodeMetrics.NumberType type = 1;
hasType() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberOrBuilder
required .NodeMetrics.NumberType type = 1;
hasType() - Method in class akka.remote.ContainerFormats.Selection.Builder
required .PatternType type = 1;
hasType() - Method in class akka.remote.ContainerFormats.Selection
required .PatternType type = 1;
hasType() - Method in interface akka.remote.ContainerFormats.SelectionOrBuilder
required .PatternType type = 1;
hasUid() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
required uint32 uid = 2;
hasUid() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
required uint32 uid = 2;
hasUid() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.UniqueAddressOrBuilder
required uint32 uid = 2;
hasUid() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
required fixed64 uid = 2;
hasUid() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
required fixed64 uid = 2;
hasUid() - Method in interface akka.remote.WireFormats.AkkaHandshakeInfoOrBuilder
required fixed64 uid = 2;
hasUpNumber() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
required int32 upNumber = 2;
hasUpNumber() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
required int32 upNumber = 2;
hasUpNumber() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MemberOrBuilder
required int32 upNumber = 2;
hasValue() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
required double value = 1;
hasValue() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
required double value = 1;
hasValue() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMAOrBuilder
required double value = 1;
hasValue32() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
optional uint32 value32 = 2;
hasValue32() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
optional uint32 value32 = 2;
hasValue32() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberOrBuilder
optional uint32 value32 = 2;
hasValue64() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
optional uint64 value64 = 3;
hasValue64() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
optional uint64 value64 = 3;
hasValue64() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberOrBuilder
optional uint64 value64 = 3;
hasVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
required .VectorClock version = 6;
hasVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
required .VectorClock version = 6;
hasVersion() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
required .VectorClock version = 6;
hasVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
required .VectorClock version = 3;
hasVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
required .VectorClock version = 3;
hasVersion() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipStatusOrBuilder
required .VectorClock version = 3;
hasVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
required int64 version = 4;
hasVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
required int64 version = 4;
hasVersion() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.ObserverReachabilityOrBuilder
required int64 version = 4;
hasVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
required int64 version = 4;
hasVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
required int64 version = 4;
hasVersion() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.SubjectReachabilityOrBuilder
required int64 version = 4;
hasVersion() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
required int64 version = 2;
hasVersion() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
required int64 version = 2;
hasVersion() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.BucketOrBuilder
required int64 version = 2;
hasVersion() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
required int64 version = 2;
hasVersion() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
required int64 version = 2;
hasVersion() - Method in interface akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.EntryOrBuilder
required int64 version = 2;
hasWildcardFanOut() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
optional bool wildcardFanOut = 5;
hasWildcardFanOut() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
optional bool wildcardFanOut = 5;
hasWildcardFanOut() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
optional bool wildcardFanOut = 5;
hasWritableEndpointFor(Address) - Method in class akka.remote.EndpointManager.EndpointRegistry
 
hasWritePending() - Method in interface akka.io.WithUdpSend
 
head() - Method in class akka.contrib.pattern.WorkList
 
head() - Method in class akka.dispatch.sysmsg.EarliestFirstSystemMessageList
 
head() - Method in class akka.dispatch.sysmsg.LatestFirstSystemMessageList
 
head() - Method in class akka.io.Tcp.CompoundWrite
 
head() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
head() - Method in class akka.util.ByteIterator
 
head() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
head() - Method in class akka.util.ByteString
 
headerAs(String, ClassTag<T>, org.apache.camel.CamelContext) - Method in class akka.camel.CamelMessage
Returns the header by given name parameter in a Try.
headers() - Method in exception akka.camel.AkkaCamelException
 
headers() - Method in class akka.camel.CamelMessage
 
headers(Set<String>) - Method in class akka.camel.CamelMessage
Returns those headers from this message whose name is contained in names.
headers() - Method in class akka.camel.FailureResult
 
headersToCopy() - Method in interface akka.camel.ProducerSupport
Returns the names of message headers to copy from a request message to a response message.
headersToCopyDefault() - Method in interface akka.camel.ProducerSupport
CamelMessage headers to copy by default from request message to response-message.
heapCommitted(MemoryUsage) - Method in class akka.cluster.JmxMetricsCollector
(JMX) Returns the current sum of heap memory guaranteed to be available to the JVM from all heap memory pools (in bytes).
heapMax(MemoryUsage) - Method in class akka.cluster.JmxMetricsCollector
(JMX) Returns the maximum amount of memory (in bytes) that can be used for JVM memory management.
HeapMemoryCommitted() - Method in class akka.cluster.StandardMetrics$
 
HeapMemoryCommitted() - Static method in class akka.cluster.StandardMetrics
 
HeapMemoryMax() - Method in class akka.cluster.StandardMetrics$
 
HeapMemoryMax() - Static method in class akka.cluster.StandardMetrics
 
heapMemoryUsage() - Method in class akka.cluster.JmxMetricsCollector
Current heap to be passed in to heapUsed, heapCommitted and heapMax
HeapMemoryUsed() - Method in class akka.cluster.StandardMetrics$
 
HeapMemoryUsed() - Static method in class akka.cluster.StandardMetrics
 
HeapMetricsSelector - Class in akka.cluster.routing
MetricsSelector that uses the heap metrics.
HeapMetricsSelector() - Constructor for class akka.cluster.routing.HeapMetricsSelector
 
HeapMetricsSelector$ - Class in akka.cluster.routing
MetricsSelector that uses the heap metrics.
HeapMetricsSelector$() - Constructor for class akka.cluster.routing.HeapMetricsSelector$
 
heapUsed(MemoryUsage) - Method in class akka.cluster.JmxMetricsCollector
(JMX) Returns the current sum of heap memory used from all heap memory pools (in bytes).
heartbeat() - Method in class akka.cluster.ClusterHeartbeatSender
 
Heartbeat() - Method in class akka.contrib.pattern.ClusterClient.Internal$
 
heartbeat() - Method in class akka.remote.DeadlineFailureDetector
 
heartbeat(A) - Method in class akka.remote.DefaultFailureDetectorRegistry
 
heartbeat() - Method in interface akka.remote.FailureDetector
Notifies the FailureDetector that a heartbeat arrived from the monitored resource.
heartbeat(A) - Method in interface akka.remote.FailureDetectorRegistry
Records a heartbeat for a resource.
heartbeat() - Method in class akka.remote.PhiAccrualFailureDetector
 
HEARTBEAT_VALUE - Static variable in enum akka.remote.WireFormats.CommandType
HEARTBEAT = 3;
HeartbeatExpectedResponseAfter() - Method in class akka.cluster.ClusterSettings
 
HeartbeatHistory - Class in akka.remote
 
HeartbeatHistory$ - Class in akka.remote
 
HeartbeatHistory$() - Constructor for class akka.remote.HeartbeatHistory$
 
HeartbeatInterval() - Method in class akka.cluster.ClusterSettings
 
heartbeatInterval() - Method in class akka.contrib.pattern.ClusterClient
 
HeartbeatNodeRing - Class in akka.cluster
INTERNAL API
HeartbeatNodeRing(UniqueAddress, Set<UniqueAddress>, Set<UniqueAddress>, int) - Constructor for class akka.cluster.HeartbeatNodeRing
 
HeartbeatNodeRing$ - Class in akka.cluster
 
HeartbeatNodeRing$() - Constructor for class akka.cluster.HeartbeatNodeRing$
 
heartbeatReceiver(Address) - Method in class akka.cluster.ClusterHeartbeatSender
Looks up and returns the remote cluster heartbeat connection for the specific address.
heartbeatRsp(UniqueAddress) - Method in class akka.cluster.ClusterHeartbeatSender
 
heartbeatRsp(UniqueAddress) - Method in class akka.cluster.ClusterHeartbeatSenderState
 
heartbeatTask() - Method in class akka.cluster.ClusterHeartbeatSender
 
heartbeatTask() - Method in class akka.contrib.pattern.ClusterClient
 
heartbeatTask() - Method in class akka.remote.RemoteWatcher
 
Hello - Class in akka.remote.testconductor
First message of connection sets names straight.
Hello(String, Address) - Constructor for class akka.remote.testconductor.Hello
 
Hello$ - Class in akka.remote.testconductor
 
Hello$() - Constructor for class akka.remote.testconductor.Hello$
 
HELLO_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
Helpers - Class in akka.util
 
Helpers() - Constructor for class akka.util.Helpers
 
Helpers$ - Class in akka.util
 
Helpers$() - Constructor for class akka.util.Helpers$
 
Helpers.ConfigOps - Class in akka.util
INTERNAL API
Helpers.ConfigOps(com.typesafe.config.Config) - Constructor for class akka.util.Helpers.ConfigOps
 
Helpers.ConfigOps$ - Class in akka.util
 
Helpers.ConfigOps$() - Constructor for class akka.util.Helpers.ConfigOps$
 
Helpers.Requiring<A> - Class in akka.util
Implicit class providing requiring methods.
Helpers.Requiring(A) - Constructor for class akka.util.Helpers.Requiring
 
Helpers.Requiring$ - Class in akka.util
 
Helpers.Requiring$() - Constructor for class akka.util.Helpers.Requiring$
 
hex() - Method in class akka.util.Crypt$
 
hex() - Static method in class akka.util.Crypt
 
hexify(byte[]) - Method in class akka.util.Crypt$
 
hexify(byte[]) - Static method in class akka.util.Crypt
 
highestPriorityOf(Member, Member) - Method in class akka.cluster.Member$
Picks the Member with the highest "priority" MemberStatus.
highestPriorityOf(Member, Member) - Static method in class akka.cluster.Member
Picks the Member with the highest "priority" MemberStatus.
highestSequenceNr(String) - Method in interface akka.persistence.journal.inmem.InmemMessages
 
highestSequenceNr() - Method in class akka.persistence.JournalProtocol.ReadHighestSequenceNrSuccess
 
HighWatermark - Class in akka.zeromq
The HighWatermark option shall set the high water mark for the specified socket.
HighWatermark(long) - Constructor for class akka.zeromq.HighWatermark
 
HighWatermark$ - Class in akka.zeromq
 
HighWatermark$() - Constructor for class akka.zeromq.HighWatermark$
 
Home() - Method in class akka.actor.ActorSystem.Settings
 
HopelessAssociation - Exception in akka.remote
INTERNAL API
HopelessAssociation(Address, Address, Option<Object>, Throwable) - Constructor for exception akka.remote.HopelessAssociation
 
HopelessAssociation$ - Class in akka.remote
 
HopelessAssociation$() - Constructor for class akka.remote.HopelessAssociation$
 
host() - Method in class akka.actor.Address
 
HOST_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Address
 
Hostname() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
HOSTNAME_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
HOSTNAME_FIELD_NUMBER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
HOSTNAME_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AddressData
 
hostPort() - Method in class akka.actor.Address
Returns a String representation formatted as:

I

i() - Method in class akka.testkit.TestActor.SetIgnore
 
id() - Method in class akka.dispatch.Dispatcher
 
id() - Method in class akka.dispatch.MessageDispatcher
Identifier of this dispatcher, corresponds to the full key of the dispatcher configuration.
id() - Method in class akka.event.Logging.LogExt
 
id(Key) - Method in class akka.persistence.journal.leveldb.Key$
 
id(Key) - Static method in class akka.persistence.journal.leveldb.Key
 
Id() - Method in class akka.testkit.CallingThreadDispatcher$
 
Id() - Static method in class akka.testkit.CallingThreadDispatcher
 
id() - Method in class akka.testkit.CallingThreadDispatcher
 
id() - Method in class akka.zeromq.SocketType.ZMQSocketType
 
identifier() - Method in class akka.cluster.protobuf.ClusterMessageSerializer
 
identifier() - Method in class akka.contrib.pattern.protobuf.DistributedPubSubMessageSerializer
 
identifier() - Method in class akka.persistence.serialization.MessageSerializer
 
identifier() - Method in class akka.persistence.serialization.SnapshotSerializer
 
identifier() - Method in class akka.remote.serialization.DaemonMsgCreateSerializer
 
identifier() - Method in class akka.remote.serialization.MessageContainerSerializer
 
identifier() - Method in class akka.remote.serialization.ProtobufSerializer
 
identifier() - Method in class akka.serialization.ByteArraySerializer
 
identifier() - Method in class akka.serialization.JavaSerializer
 
identifier() - Method in class akka.serialization.NullSerializer
 
identifier() - Method in interface akka.serialization.Serializer
Completely unique value to identify this implementation of Serializer, used to optimize network traffic Values from 0 to 16 is reserved for Akka internal usage
Identify - Class in akka.actor
A message all Actors will understand, that when processed will reply with ActorIdentity containing the ActorRef.
Identify(Object) - Constructor for class akka.actor.Identify
 
Identify$ - Class in akka.actor
 
Identify$() - Constructor for class akka.actor.Identify$
 
identifyCounter() - Method in class akka.contrib.pattern.ClusterSingletonProxy
 
identifyId() - Method in class akka.contrib.pattern.ClusterSingletonProxy
 
identifyRequest() - Method in class akka.actor.ActorSelectionMessage
 
identifySingleton() - Method in class akka.contrib.pattern.ClusterSingletonProxy
Discard old singleton ActorRef and send a periodic message to self to identify the singleton.
identifyTimer() - Method in class akka.contrib.pattern.ClusterSingletonProxy
 
Identity - Class in akka.zeromq
Sets the identity of the specified socket.
Identity(byte[]) - Constructor for class akka.zeromq.Identity
 
identity() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its identity configuration.
identity() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its identity configuration.
Identity$ - Class in akka.zeromq
Gets the Identity value
Identity$() - Constructor for class akka.zeromq.Identity$
 
identityHashComparator(Comparator<T>) - Method in class akka.util.Helpers$
Create a comparator which will efficiently use System.identityHashCode, unless that happens to be the same for two non-equals objects, in which case the supplied &ldquo;real&rdquo; comparator is used; the comparator must be consistent with equals, otherwise it would not be an enhancement over the identityHashCode.
identityHashComparator(Comparator<T>) - Static method in class akka.util.Helpers
Create a comparator which will efficiently use System.identityHashCode, unless that happens to be the same for two non-equals objects, in which case the supplied &ldquo;real&rdquo; comparator is used; the comparator must be consistent with equals, otherwise it would not be an enhancement over the identityHashCode.
identityRouteMapper() - Method in class akka.camel.Consumer$
 
idExtractor() - Method in class akka.contrib.pattern.ClusterShardingGuardian.Start
 
idKey(int) - Method in class akka.persistence.journal.leveldb.Key$
 
idKey(int) - Static method in class akka.persistence.journal.leveldb.Key
 
idle() - Method in class akka.contrib.pattern.ReliableProxy$
 
idle() - Static method in class akka.contrib.pattern.ReliableProxy
 
idle() - Method in interface akka.persistence.PersistentView
When receiving an Update request, switches to replayStarted state and triggers an incremental message replay.
idle() - Method in interface akka.persistence.View
When receiving an Update request, switches to replayStarted state and triggers an incremental message replay.
idle() - Method in class akka.remote.ReliableDeliverySupervisor
 
idleTimeout() - Method in class akka.persistence.PersistentChannelSettings
 
idMap() - Method in interface akka.persistence.journal.leveldb.LeveldbIdMapping
 
idOffset() - Method in interface akka.persistence.journal.leveldb.LeveldbIdMapping
 
ifOff(Function0<BoxedUnit>) - Method in class akka.util.Switch
Executes the provided action and returns if the action was executed or not, if the switch is IMMEDIATELY off (i.e.
ifOffYield(Function0<T>) - Method in class akka.util.Switch
Executes the provided action and returns its value if the switch is IMMEDIATELY off (i.e.
ifOn(Function0<BoxedUnit>) - Method in class akka.util.Switch
Executes the provided action and returns if the action was executed or not, if the switch is IMMEDIATELY on (i.e.
ifOnYield(Function0<T>) - Method in class akka.util.Switch
Executes the provided action and returns its value if the switch is IMMEDIATELY on (i.e.
ignore(Object) - Method in class akka.testkit.JavaTestKit.IgnoreMsg
 
ignore() - Method in class akka.testkit.TestActor
 
Ignored() - Method in class akka.cluster.ClusterCoreDaemon
 
ignoreMsg(PartialFunction<Object, Object>) - Method in interface akka.testkit.TestKitBase
Ignore all messages in the test actor for which the given partial function returns true.
ignoreNoMsg() - Method in class akka.testkit.JavaTestKit
Stop ignoring messages in the test actor.
ignoreNoMsg() - Method in interface akka.testkit.TestKitBase
Stop ignoring messages in the test actor.
IllegalActorStateException - Exception in akka.actor
IllegalActorStateException is thrown when a core invariant in the Actor implementation has been violated.
IllegalActorStateException(String) - Constructor for exception akka.actor.IllegalActorStateException
 
IllegalActorStateException$ - Class in akka.actor
 
IllegalActorStateException$() - Constructor for class akka.actor.IllegalActorStateException$
 
immutableIndexedSeq(Iterable<T>) - Method in class akka.japi.Util$
Turns an Iterable into an immutable Scala IndexedSeq (by copying it).
immutableIndexedSeq(Iterable<T>) - Static method in class akka.japi.Util
Turns an Iterable into an immutable Scala IndexedSeq (by copying it).
immutableSeq(Class<?>[]) - Method in class akka.japi.Util$
Returns an immutable.Seq representing the provided array of Classes, an overloading of the generic immutableSeq in Util, to accommodate for erasure.
immutableSeq(Object) - Method in class akka.japi.Util$
Turns an array into an immutable Scala sequence (by copying it).
immutableSeq(Iterable<T>) - Method in class akka.japi.Util$
Turns an Iterable into an immutable Scala sequence (by copying it).
immutableSeq(Class<?>[]) - Static method in class akka.japi.Util
Returns an immutable.Seq representing the provided array of Classes, an overloading of the generic immutableSeq in Util, to accommodate for erasure.
immutableSeq(Object) - Static method in class akka.japi.Util
Turns an array into an immutable Scala sequence (by copying it).
immutableSeq(Iterable<T>) - Static method in class akka.japi.Util
Turns an Iterable into an immutable Scala sequence (by copying it).
immutableSingletonSeq(T) - Method in class akka.japi.Util$
 
immutableSingletonSeq(T) - Static method in class akka.japi.Util
 
ImplicitSender - Interface in akka.testkit
 
ImplicitSenderSpec - Class in akka.testkit
 
ImplicitSenderSpec() - Constructor for class akka.testkit.ImplicitSenderSpec
 
InaccessibleQueuePath - Exception in akka.actor.mailbox.filebased.filequeue
 
InaccessibleQueuePath() - Constructor for exception akka.actor.mailbox.filebased.filequeue.InaccessibleQueuePath
 
inbound() - Method in class akka.remote.AssociatedEvent
 
inbound() - Method in class akka.remote.AssociationErrorEvent
 
inbound() - Method in interface akka.remote.AssociationEvent
 
inbound() - Method in class akka.remote.DisassociatedEvent
 
inbound() - Method in class akka.remote.EndpointActor
 
inbound() - Method in class akka.remote.EndpointReader
 
inbound() - Method in class akka.remote.EndpointWriter
 
inbound() - Method in class akka.remote.transport.TestAssociationHandle
 
inbound() - Method in class akka.remote.transport.ThrottledAssociation
 
inboundDropP() - Method in class akka.remote.transport.FailureInjectorTransportAdapter.Drop
 
InboundMessageDispatcher - Interface in akka.remote
INTERNAL API
inboundProps(HandshakeInfo, AssociationHandle, Transport.AssociationEventListener, AkkaProtocolSettings, AkkaPduCodec, FailureDetector) - Method in class akka.remote.transport.ProtocolStateActor$
 
inboundProps(HandshakeInfo, AssociationHandle, Transport.AssociationEventListener, AkkaProtocolSettings, AkkaPduCodec, FailureDetector) - Static method in class akka.remote.transport.ProtocolStateActor
 
inboundThrottleMode() - Method in class akka.remote.transport.ThrottledAssociation
 
Inbox - Interface in akka.actor.dsl
 
inbox(ActorSystem) - Method in interface akka.actor.dsl.Inbox
Create a new actor which will internally queue up messages it gets so that they can be interrogated with the akka.actor.dsl.Inbox!.Inbox!.receive and akka.actor.dsl.Inbox!.Inbox!.select methods.
Inbox - Class in akka.actor
An Inbox is an actor-like object which is interrogated from the outside.
Inbox() - Constructor for class akka.actor.Inbox
 
Inbox$ - Class in akka.actor.dsl
INTERNAL API
Inbox$() - Constructor for class akka.actor.dsl.Inbox$
 
Inbox$ - Class in akka.actor
 
Inbox$() - Constructor for class akka.actor.Inbox$
 
Inbox.Get - Class in akka.actor.dsl
 
Inbox.Get(Deadline, ActorRef) - Constructor for class akka.actor.dsl.Inbox.Get
 
Inbox.Get$ - Class in akka.actor.dsl
 
Inbox.Get$() - Constructor for class akka.actor.dsl.Inbox.Get$
 
Inbox.Inbox - Class in akka.actor.dsl
 
Inbox.Inbox(ActorSystem) - Constructor for class akka.actor.dsl.Inbox.Inbox
 
Inbox.InboxActor - Class in akka.actor.dsl
 
Inbox.InboxActor(int) - Constructor for class akka.actor.dsl.Inbox.InboxActor
 
Inbox.InboxExtension - Interface in akka.actor.dsl
 
Inbox.Kick$ - Class in akka.actor.dsl
 
Inbox.Kick$() - Constructor for class akka.actor.dsl.Inbox.Kick$
 
Inbox.Query - Interface in akka.actor.dsl
 
Inbox.Select - Class in akka.actor.dsl
 
Inbox.Select(Deadline, PartialFunction<Object, Object>, ActorRef) - Constructor for class akka.actor.dsl.Inbox.Select
 
Inbox.Select$ - Class in akka.actor.dsl
 
Inbox.Select$() - Constructor for class akka.actor.dsl.Inbox.Select$
 
Inbox.StartWatch - Class in akka.actor.dsl
 
Inbox.StartWatch(ActorRef) - Constructor for class akka.actor.dsl.Inbox.StartWatch
 
Inbox.StartWatch$ - Class in akka.actor.dsl
 
Inbox.StartWatch$() - Constructor for class akka.actor.dsl.Inbox.StartWatch$
 
inboxNr() - Method in interface akka.actor.dsl.Inbox.InboxExtension
 
inboxProps() - Method in interface akka.actor.dsl.Inbox.InboxExtension
 
inc() - Method in class akka.remote.SeqNo
Increments the sequence number.
include(Seq<ActorRef>) - Method in interface akka.transactor.Transactor
Include other actors in this coordinated transaction and send them the same message as received.
include(ActorRef) - Method in class akka.transactor.UntypedTransactor
For including one other actor in this coordinated transaction and sending them the same message as received.
include(ActorRef, Object) - Method in class akka.transactor.UntypedTransactor
For including one other actor in this coordinated transaction and specifying the message to send.
includeManifest() - Method in class akka.cluster.protobuf.ClusterMessageSerializer
 
includeManifest() - Method in class akka.contrib.pattern.protobuf.DistributedPubSubMessageSerializer
 
includeManifest() - Method in class akka.persistence.serialization.MessageSerializer
 
includeManifest() - Method in class akka.persistence.serialization.SnapshotSerializer
 
includeManifest() - Method in class akka.remote.serialization.DaemonMsgCreateSerializer
 
includeManifest() - Method in class akka.remote.serialization.MessageContainerSerializer
 
includeManifest() - Method in class akka.remote.serialization.ProtobufSerializer
 
includeManifest() - Method in class akka.serialization.ByteArraySerializer
 
includeManifest() - Method in class akka.serialization.JavaSerializer
 
includeManifest() - Method in class akka.serialization.NullSerializer
 
includeManifest() - Method in interface akka.serialization.Serializer
Returns whether this serializer needs a manifest in the fromBinary method
includes(ThrottlerTransportAdapter.Direction) - Method in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Both$
 
includes(ThrottlerTransportAdapter.Direction) - Method in interface akka.remote.transport.ThrottlerTransportAdapter.Direction
 
includes(ThrottlerTransportAdapter.Direction) - Method in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Receive$
 
includes(ThrottlerTransportAdapter.Direction) - Method in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Send$
 
incr() - Method in class akka.actor.mailbox.filebased.filequeue.Counter
 
incr(long) - Method in class akka.actor.mailbox.filebased.filequeue.Counter
 
incrementMergeCount() - Method in class akka.cluster.GossipStats
 
incrementNewerCount() - Method in class akka.cluster.GossipStats
 
incrementOlderCount() - Method in class akka.cluster.GossipStats
 
incrementRedeliveryCount() - Method in class akka.persistence.ReliableDelivery.DeliveryAttempt
 
incrementSameCount() - Method in class akka.cluster.GossipStats
 
Index<K,V> - Class in akka.util
An implementation of a ConcurrentMultiMap Adds/remove is serialized over the specified key Reads are fully concurrent <-- el-cheapo
Index(int, Comparator<V>) - Constructor for class akka.util.Index
 
Index(int, Function2<V, V, Object>) - Constructor for class akka.util.Index
 
indexOf(byte) - Method in class akka.util.ByteIterator
 
indexOf(B) - Method in class akka.util.ByteIterator
 
indexOf(B) - Method in class akka.util.ByteString
 
indexWhere(Function1<Object, Object>) - Method in class akka.util.ByteIterator
 
indexWhere(Function1<Object, Object>) - Method in class akka.util.ByteString
 
IndirectActorProducer - Interface in akka.actor
This interface defines a class of actor creation strategies deviating from the usual default of just reflectively instantiating the Actor subclass.
IndirectActorProducer$ - Class in akka.actor
 
IndirectActorProducer$() - Constructor for class akka.actor.IndirectActorProducer$
 
Inet - Class in akka.io
 
Inet() - Constructor for class akka.io.Inet
 
Inet$ - Class in akka.io
 
Inet$() - Constructor for class akka.io.Inet$
 
Inet.SO$ - Class in akka.io
 
Inet.SO$() - Constructor for class akka.io.Inet.SO$
 
Inet.SO$.ReceiveBufferSize - Class in akka.io
Inet.SocketOption to set the SO_RCVBUF option
Inet.SO$.ReceiveBufferSize(int) - Constructor for class akka.io.Inet.SO$.ReceiveBufferSize
 
Inet.SO$.ReuseAddress - Class in akka.io
Inet.SocketOption to enable or disable SO_REUSEADDR
Inet.SO$.ReuseAddress(boolean) - Constructor for class akka.io.Inet.SO$.ReuseAddress
 
Inet.SO$.SendBufferSize - Class in akka.io
Inet.SocketOption to set the SO_SNDBUF option.
Inet.SO$.SendBufferSize(int) - Constructor for class akka.io.Inet.SO$.SendBufferSize
 
Inet.SO$.TrafficClass - Class in akka.io
Inet.SocketOption to set the traffic class or type-of-service octet in the IP header for packets sent from this socket.
Inet.SO$.TrafficClass(int) - Constructor for class akka.io.Inet.SO$.TrafficClass
 
Inet.SocketOption - Interface in akka.io
SocketOption is a package of data (from the user) and associated behavior (how to apply that to a socket).
Inet.SoForwarders - Interface in akka.io
 
Inet.SoJavaFactories - Interface in akka.io
 
info(Logging.Info) - Method in interface akka.event.Logging.StdOutLogger
 
info(String) - Method in interface akka.event.LoggingAdapter
Log message at info level.
info(String, Object) - Method in interface akka.event.LoggingAdapter
Message template with 1 replacement argument.
info(String, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 2 replacement arguments.
info(String, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 3 replacement arguments.
info(String, Object, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 4 replacement arguments.
info() - Method in class akka.persistence.japi.journal.JavaJournalPerfSpec
 
info() - Method in class akka.remote.transport.ActorTransportAdapter.DisassociateUnderlying
 
info() - Method in class akka.remote.transport.AkkaPduCodec.Associate
 
info() - Method in class akka.remote.transport.AssociationHandle.Disassociated
 
info(String, String, String, String, int) - Method in class akka.testkit.EventFilter$
Create a filter for Info events.
info(String, String, String, String, int) - Static method in class akka.testkit.EventFilter
Create a filter for Info events.
InfoFilter - Class in akka.testkit
Filter which matches Info events, if they satisfy the given criteria: source, if given, applies a filter on the event&rsquo;s origin message applies a filter on the event&rsquo;s message (either with String.startsWith or Regex.findFirstIn().isDefined) If you want to match all Info events, the most efficient is to use Left("").
InfoFilter(Option<String>, Either<String, Regex>, boolean, int) - Constructor for class akka.testkit.InfoFilter
 
InfoFilter(String, String, boolean, boolean, int) - Constructor for class akka.testkit.InfoFilter
Java API: create an InfoFilter
InfoFilter$ - Class in akka.testkit
 
InfoFilter$() - Constructor for class akka.testkit.InfoFilter$
 
infoFormat() - Method in interface akka.event.Logging.StdOutLogger
 
InfoLevel() - Method in class akka.event.Logging$
 
InfoLevel() - Static method in class akka.event.Logging
 
InfoLogger() - Method in class akka.cluster.Cluster
Accessor for nested Scala object
inhabitants() - Method in class akka.dispatch.MessageDispatcher
 
init(ActorSystemImpl) - Method in interface akka.actor.ActorRefProvider
Initialization of an ActorRefProvider happens in two steps: first construction of the object with settings, eventStream, etc.
init(boolean, MailboxType) - Method in interface akka.actor.dungeon.Dispatch
Initialize this cell, i.e.
init(ActorSystemImpl) - Method in class akka.actor.LocalActorRefProvider
 
init(ActorSystemImpl) - Method in class akka.cluster.ClusterActorRefProvider
 
init(ClusterEvent.CurrentClusterState) - Method in class akka.cluster.ClusterHeartbeatSender
 
init(Set<UniqueAddress>, Set<UniqueAddress>) - Method in class akka.cluster.ClusterHeartbeatSenderState
 
init(ActorSystemImpl) - Method in class akka.remote.RemoteActorRefProvider
 
init(org.jboss.netty.channel.Channel, SocketAddress, Address, org.jboss.netty.buffer.ChannelBuffer, Function1<AssociationHandle, Object>) - Method in interface akka.remote.transport.netty.CommonHandlers
 
init() - Method in class akka.util.ByteString
 
initChild(ActorRef) - Method in interface akka.actor.dungeon.Children
 
initialBehavior() - Method in interface akka.persistence.Eventsourced
INTERNAL API.
initialCapacity() - Method in class akka.dispatch.UnboundedPriorityMailbox
 
initialisedReceive(org.osgi.service.log.LogService) - Method in class akka.osgi.DefaultOSGiLogger
Behaviour of the Eventhanlder that is setup (has received a LogService)
initialize() - Method in interface akka.actor.FSM
 
initialize() - Method in interface akka.actor.mailbox.DurableMailboxSettings
Obtain default extracted mailbox config section from userConfig and system.
initialize(boolean) - Method in class akka.actor.RepointableActorRef
Initialize: make a dummy cell which holds just a mailbox, then tell our supervisor that we exist so that he can create the real Cell in handleSupervise().
initializeClientSSL(SSLSettings, LoggingAdapter) - Method in class akka.remote.transport.netty.NettySSLSupport$
 
initializeClientSSL(SSLSettings, LoggingAdapter) - Static method in class akka.remote.transport.netty.NettySSLSupport
 
initializeCustomSecureRandom(Option<String>, LoggingAdapter) - Method in class akka.remote.transport.netty.NettySSLSupport$
 
initializeCustomSecureRandom(Option<String>, LoggingAdapter) - Static method in class akka.remote.transport.netty.NettySSLSupport
 
initialized() - Method in class akka.cluster.ClusterCoreDaemon
 
initialized() - Method in interface akka.persistence.journal.AsyncWriteProxy
 
initializeServerSSL(SSLSettings, LoggingAdapter) - Method in class akka.remote.transport.netty.NettySSLSupport$
 
initializeServerSSL(SSLSettings, LoggingAdapter) - Static method in class akka.remote.transport.netty.NettySSLSupport
 
initializing() - Method in class akka.cluster.ClusterHeartbeatSender
 
initializing() - Method in interface akka.persistence.ProcessorImpl
Processes the highest stored sequence number response from the journal and then switches to processing state.
initializing() - Method in class akka.remote.EndpointWriter
 
initialParticipants() - Method in class akka.remote.testkit.MultiNodeSpec
TO BE DEFINED BY USER: Defines the number of participants required for starting the test.
initialState() - Method in class akka.contrib.pattern.ReliableProxy
 
initialStateAsEvents() - Method in class akka.cluster.ClusterEvent$
Java API
initialStateAsEvents() - Static method in class akka.cluster.ClusterEvent
Java API
initialStateAsSnapshot() - Method in class akka.cluster.ClusterEvent$
Java API
initialStateAsSnapshot() - Static method in class akka.cluster.ClusterEvent
Java API
initialStateMode() - Method in class akka.cluster.InternalClusterAction.Subscribe
 
InitialSysMsgDeliveryTimeout() - Method in class akka.remote.RemoteSettings
 
initialValue(org.jboss.netty.channel.Channel) - Method in class akka.remote.transport.netty.ChannelLocalActor$
 
initialValue(org.jboss.netty.channel.Channel) - Static method in class akka.remote.transport.netty.ChannelLocalActor
 
initInbound(org.jboss.netty.channel.Channel, SocketAddress, org.jboss.netty.buffer.ChannelBuffer) - Method in class akka.remote.transport.netty.ServerHandler
 
initJoin() - Method in class akka.cluster.ClusterCoreDaemon
 
initOutbound(org.jboss.netty.channel.Channel, SocketAddress, org.jboss.netty.buffer.ChannelBuffer) - Method in class akka.remote.transport.netty.ClientHandler
 
initUdp(org.jboss.netty.channel.Channel, SocketAddress, org.jboss.netty.buffer.ChannelBuffer) - Method in class akka.remote.transport.netty.UdpClientHandler
 
initUdp(org.jboss.netty.channel.Channel, SocketAddress, org.jboss.netty.buffer.ChannelBuffer) - Method in interface akka.remote.transport.netty.UdpHandlers
 
initUdp(org.jboss.netty.channel.Channel, SocketAddress, org.jboss.netty.buffer.ChannelBuffer) - Method in class akka.remote.transport.netty.UdpServerHandler
 
injectDeployments(ActorSystem, RoleName) - Method in class akka.remote.testkit.MultiNodeSpec
 
InmemJournal - Class in akka.persistence.journal.inmem
INTERNAL API.
InmemJournal() - Constructor for class akka.persistence.journal.inmem.InmemJournal
 
InmemMessages - Interface in akka.persistence.journal.inmem
INTERNAL API.
InmemStore - Class in akka.persistence.journal.inmem
INTERNAL API.
InmemStore() - Constructor for class akka.persistence.journal.inmem.InmemStore
 
innerAddKey(K) - Method in class akka.util.SubclassifiedIndex
 
innerAddValue(K, V) - Method in class akka.util.SubclassifiedIndex
 
innerAddValue(K, V) - Method in class akka.util.SubclassifiedIndex.Nonroot
 
innerFindSubKeys(K, Vector<SubclassifiedIndex.Nonroot<K, V>>) - Method in class akka.util.SubclassifiedIndex
 
innerFindValues(K) - Method in class akka.util.SubclassifiedIndex
 
innerFindValues(K) - Method in class akka.util.SubclassifiedIndex.Nonroot
 
innerRemoveValue(K, V) - Method in class akka.util.SubclassifiedIndex
 
innerRemoveValue(K, V) - Method in class akka.util.SubclassifiedIndex.Nonroot
 
inReadBehind() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
inReadBehind() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
insert(Iterator<String>, T) - Method in class akka.util.WildcardTree
 
instance - Static variable in class akka.util.Unsafe
 
instanceId() - Method in interface akka.persistence.ProcessorImpl
 
instantiate(Class<T>) - Method in class akka.util.Reflect$
INTERNAL API
instantiate(Class<T>, Seq<Object>) - Method in class akka.util.Reflect$
INTERNAL API Calls findConstructor and invokes it with the given arguments.
instantiate(Constructor<T>, Seq<Object>) - Method in class akka.util.Reflect$
INTERNAL API Invokes the constructor with the the given arguments.
instantiate(Class<T>) - Static method in class akka.util.Reflect
INTERNAL API
instantiate(Class<T>, Seq<Object>) - Static method in class akka.util.Reflect
INTERNAL API Calls findConstructor and invokes it with the given arguments.
instantiate(Constructor<T>, Seq<Object>) - Static method in class akka.util.Reflect
INTERNAL API Invokes the constructor with the the given arguments.
instantiator(Class<T>) - Method in class akka.util.Reflect$
INTERNAL API
instantiator(Class<T>) - Static method in class akka.util.Reflect
INTERNAL API
INSTRUCTION_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AkkaProtocolMessage
 
Integer_VALUE - Static variable in enum akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberType
Integer = 3;
intercept(Function0<T>, ActorSystem) - Method in class akka.testkit.EventFilter
Apply this filter while executing the given code block.
interceptAssociate(Address, Promise<AssociationHandle>) - Method in class akka.remote.transport.AbstractTransportAdapter
 
interceptAssociate(Address, Promise<AssociationHandle>) - Method in class akka.remote.transport.ActorTransportAdapter
 
interceptAssociate(Address, Promise<AssociationHandle>) - Method in class akka.remote.transport.FailureInjectorTransportAdapter
 
interceptInboundAssociation(Transport.AssociationEvent) - Method in class akka.remote.transport.FailureInjectorTransportAdapter
 
interceptListen(Address, Future<Transport.AssociationEventListener>) - Method in class akka.remote.transport.AbstractTransportAdapter
 
interceptListen(Address, Future<Transport.AssociationEventListener>) - Method in class akka.remote.transport.ActorTransportAdapter
 
interceptListen(Address, Future<Transport.AssociationEventListener>) - Method in class akka.remote.transport.FailureInjectorTransportAdapter
 
interfaces() - Method in class akka.actor.TypedProps
 
internal(T) - Method in class akka.dispatch.Foreach
 
internal(T) - Method in class akka.dispatch.japi.BooleanFunctionBridge
 
internal(T) - Method in class akka.dispatch.japi.CallbackBridge
 
internal(Throwable) - Method in class akka.dispatch.japi.RecoverBridge
 
internal(T) - Method in class akka.dispatch.japi.UnitFunctionBridge
 
internal(Try<T>) - Method in class akka.dispatch.OnComplete
 
internal(Throwable) - Method in class akka.dispatch.OnFailure
 
internal(T) - Method in class akka.dispatch.OnSuccess
 
internal(Throwable) - Method in class akka.dispatch.Recover
 
internal() - Method in class akka.persistence.PersistenceSettings
 
InternalActorRef - Class in akka.actor
Internal trait for assembling all the functionality needed internally on ActorRefs.
InternalActorRef() - Constructor for class akka.actor.InternalActorRef
 
internalCallingThreadExecutionContext() - Method in class akka.actor.ActorSystemImpl
 
internalCallingThreadExecutionContext() - Method in class akka.pattern.PromiseActorRef
 
InternalClusterAction - Class in akka.cluster
INTERNAL API
InternalClusterAction() - Constructor for class akka.cluster.InternalClusterAction
 
InternalClusterAction$ - Class in akka.cluster
INTERNAL API
InternalClusterAction$() - Constructor for class akka.cluster.InternalClusterAction$
 
InternalClusterAction.AddOnMemberUpListener - Class in akka.cluster
Comand to ClusterDaemon to create a OnMemberUpListener.
InternalClusterAction.AddOnMemberUpListener(Runnable) - Constructor for class akka.cluster.InternalClusterAction.AddOnMemberUpListener
 
InternalClusterAction.AddOnMemberUpListener$ - Class in akka.cluster
 
InternalClusterAction.AddOnMemberUpListener$() - Constructor for class akka.cluster.InternalClusterAction.AddOnMemberUpListener$
 
InternalClusterAction.GetClusterCoreRef$ - Class in akka.cluster
 
InternalClusterAction.GetClusterCoreRef$() - Constructor for class akka.cluster.InternalClusterAction.GetClusterCoreRef$
 
InternalClusterAction.GossipSpeedupTick$ - Class in akka.cluster
 
InternalClusterAction.GossipSpeedupTick$() - Constructor for class akka.cluster.InternalClusterAction.GossipSpeedupTick$
 
InternalClusterAction.GossipTick$ - Class in akka.cluster
 
InternalClusterAction.GossipTick$() - Constructor for class akka.cluster.InternalClusterAction.GossipTick$
 
InternalClusterAction.InitJoin$ - Class in akka.cluster
 
InternalClusterAction.InitJoin$() - Constructor for class akka.cluster.InternalClusterAction.InitJoin$
 
InternalClusterAction.InitJoinAck - Class in akka.cluster
 
InternalClusterAction.InitJoinAck(Address) - Constructor for class akka.cluster.InternalClusterAction.InitJoinAck
 
InternalClusterAction.InitJoinAck$ - Class in akka.cluster
 
InternalClusterAction.InitJoinAck$() - Constructor for class akka.cluster.InternalClusterAction.InitJoinAck$
 
InternalClusterAction.InitJoinNack - Class in akka.cluster
 
InternalClusterAction.InitJoinNack(Address) - Constructor for class akka.cluster.InternalClusterAction.InitJoinNack
 
InternalClusterAction.InitJoinNack$ - Class in akka.cluster
 
InternalClusterAction.InitJoinNack$() - Constructor for class akka.cluster.InternalClusterAction.InitJoinNack$
 
InternalClusterAction.Join - Class in akka.cluster
Command to join the cluster.
InternalClusterAction.Join(UniqueAddress, Set<String>) - Constructor for class akka.cluster.InternalClusterAction.Join
 
InternalClusterAction.Join$ - Class in akka.cluster
 
InternalClusterAction.Join$() - Constructor for class akka.cluster.InternalClusterAction.Join$
 
InternalClusterAction.JoinSeedNode$ - Class in akka.cluster
Start message of the process to join one of the seed nodes.
InternalClusterAction.JoinSeedNode$() - Constructor for class akka.cluster.InternalClusterAction.JoinSeedNode$
 
InternalClusterAction.JoinSeedNodes - Class in akka.cluster
Command to initiate the process to join the specified seed nodes.
InternalClusterAction.JoinSeedNodes(IndexedSeq<Address>) - Constructor for class akka.cluster.InternalClusterAction.JoinSeedNodes
 
InternalClusterAction.JoinSeedNodes$ - Class in akka.cluster
 
InternalClusterAction.JoinSeedNodes$() - Constructor for class akka.cluster.InternalClusterAction.JoinSeedNodes$
 
InternalClusterAction.LeaderActionsTick$ - Class in akka.cluster
 
InternalClusterAction.LeaderActionsTick$() - Constructor for class akka.cluster.InternalClusterAction.LeaderActionsTick$
 
InternalClusterAction.MetricsTick$ - Class in akka.cluster
 
InternalClusterAction.MetricsTick$() - Constructor for class akka.cluster.InternalClusterAction.MetricsTick$
 
InternalClusterAction.PublishChanges - Class in akka.cluster
 
InternalClusterAction.PublishChanges(Gossip) - Constructor for class akka.cluster.InternalClusterAction.PublishChanges
 
InternalClusterAction.PublishChanges$ - Class in akka.cluster
 
InternalClusterAction.PublishChanges$() - Constructor for class akka.cluster.InternalClusterAction.PublishChanges$
 
InternalClusterAction.PublishCurrentClusterState - Class in akka.cluster
param: receiver if receiver is defined the event will only be sent to that actor, otherwise it will be sent to all subscribers via the eventStream.
InternalClusterAction.PublishCurrentClusterState(Option<ActorRef>) - Constructor for class akka.cluster.InternalClusterAction.PublishCurrentClusterState
 
InternalClusterAction.PublishCurrentClusterState$ - Class in akka.cluster
 
InternalClusterAction.PublishCurrentClusterState$() - Constructor for class akka.cluster.InternalClusterAction.PublishCurrentClusterState$
 
InternalClusterAction.PublisherCreated - Class in akka.cluster
 
InternalClusterAction.PublisherCreated(ActorRef) - Constructor for class akka.cluster.InternalClusterAction.PublisherCreated
 
InternalClusterAction.PublisherCreated$ - Class in akka.cluster
 
InternalClusterAction.PublisherCreated$() - Constructor for class akka.cluster.InternalClusterAction.PublisherCreated$
 
InternalClusterAction.PublishEvent - Class in akka.cluster
 
InternalClusterAction.PublishEvent(ClusterEvent.ClusterDomainEvent) - Constructor for class akka.cluster.InternalClusterAction.PublishEvent
 
InternalClusterAction.PublishEvent$ - Class in akka.cluster
 
InternalClusterAction.PublishEvent$() - Constructor for class akka.cluster.InternalClusterAction.PublishEvent$
 
InternalClusterAction.PublishMessage - Interface in akka.cluster
 
InternalClusterAction.PublishStatsTick$ - Class in akka.cluster
 
InternalClusterAction.PublishStatsTick$() - Constructor for class akka.cluster.InternalClusterAction.PublishStatsTick$
 
InternalClusterAction.ReapUnreachableTick$ - Class in akka.cluster
 
InternalClusterAction.ReapUnreachableTick$() - Constructor for class akka.cluster.InternalClusterAction.ReapUnreachableTick$
 
InternalClusterAction.SendGossipTo - Class in akka.cluster
 
InternalClusterAction.SendGossipTo(Address) - Constructor for class akka.cluster.InternalClusterAction.SendGossipTo
 
InternalClusterAction.SendGossipTo$ - Class in akka.cluster
 
InternalClusterAction.SendGossipTo$() - Constructor for class akka.cluster.InternalClusterAction.SendGossipTo$
 
InternalClusterAction.Subscribe - Class in akka.cluster
 
InternalClusterAction.Subscribe(ActorRef, ClusterEvent.SubscriptionInitialStateMode, Set<Class<?>>) - Constructor for class akka.cluster.InternalClusterAction.Subscribe
 
InternalClusterAction.Subscribe$ - Class in akka.cluster
 
InternalClusterAction.Subscribe$() - Constructor for class akka.cluster.InternalClusterAction.Subscribe$
 
InternalClusterAction.SubscriptionMessage - Interface in akka.cluster
 
InternalClusterAction.Tick - Interface in akka.cluster
Marker interface for periodic tick messages
InternalClusterAction.Unsubscribe - Class in akka.cluster
 
InternalClusterAction.Unsubscribe(ActorRef, Option<Class<?>>) - Constructor for class akka.cluster.InternalClusterAction.Unsubscribe
 
InternalClusterAction.Unsubscribe$ - Class in akka.cluster
 
InternalClusterAction.Unsubscribe$() - Constructor for class akka.cluster.InternalClusterAction.Unsubscribe$
 
InternalClusterAction.Welcome - Class in akka.cluster
Reply to Join param: from the sender node in the cluster, i.e.
InternalClusterAction.Welcome(UniqueAddress, Gossip) - Constructor for class akka.cluster.InternalClusterAction.Welcome
 
InternalClusterAction.Welcome$ - Class in akka.cluster
 
InternalClusterAction.Welcome$() - Constructor for class akka.cluster.InternalClusterAction.Welcome$
 
internalExpectMsgAllClassOf(FiniteDuration, Seq<Class<? extends T>>) - Method in interface akka.testkit.TestKitBase
 
internalExpectMsgAllConformingOf(FiniteDuration, Seq<Class<? extends T>>) - Method in interface akka.testkit.TestKitBase
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty.Builder
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
 
internalGetFieldAccessorTable() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
 
internalGetFieldAccessorTable() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
 
internalGetFieldAccessorTable() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
internalGetFieldAccessorTable() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
 
internalGetFieldAccessorTable() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
internalGetFieldAccessorTable() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
 
internalGetFieldAccessorTable() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
 
internalGetFieldAccessorTable() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
internalGetFieldAccessorTable() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
 
internalGetFieldAccessorTable() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload.Builder
 
internalGetFieldAccessorTable() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
internalGetFieldAccessorTable() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish.Builder
 
internalGetFieldAccessorTable() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
 
internalGetFieldAccessorTable() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
 
internalGetFieldAccessorTable() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
internalGetFieldAccessorTable() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
 
internalGetFieldAccessorTable() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
internalGetFieldAccessorTable() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
 
internalGetFieldAccessorTable() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
 
internalGetFieldAccessorTable() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
 
internalGetFieldAccessorTable() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
 
internalGetFieldAccessorTable() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
 
internalGetFieldAccessorTable() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
internalGetFieldAccessorTable() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
 
internalGetFieldAccessorTable() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
internalGetFieldAccessorTable() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
 
internalGetFieldAccessorTable() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
internalGetFieldAccessorTable() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage.Builder
 
internalGetFieldAccessorTable() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage
 
internalGetFieldAccessorTable() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
 
internalGetFieldAccessorTable() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
internalGetFieldAccessorTable() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
 
internalGetFieldAccessorTable() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
 
internalGetFieldAccessorTable() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
 
internalGetFieldAccessorTable() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
internalGetFieldAccessorTable() - Method in class akka.remote.ContainerFormats.Selection.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.ContainerFormats.Selection
 
internalGetFieldAccessorTable() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
internalGetFieldAccessorTable() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
internalGetFieldAccessorTable() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
internalGetFieldAccessorTable() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
internalGetFieldAccessorTable() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
internalGetFieldAccessorTable() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
internalGetFieldAccessorTable() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.ActorRefData.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.ActorRefData
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AddressData.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AddressData
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.DeployData.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.DeployData
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.PropsData.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.PropsData
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.SerializedMessage
 
internalGetValueMap() - Static method in enum akka.cluster.protobuf.msg.ClusterMessages.MemberStatus
 
internalGetValueMap() - Static method in enum akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberType
 
internalGetValueMap() - Static method in enum akka.cluster.protobuf.msg.ClusterMessages.ReachabilityStatus
 
internalGetValueMap() - Static method in enum akka.remote.ContainerFormats.PatternType
 
internalGetValueMap() - Static method in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
 
internalGetValueMap() - Static method in enum akka.remote.testconductor.TestConductorProtocol.Direction
 
internalGetValueMap() - Static method in enum akka.remote.testconductor.TestConductorProtocol.FailType
 
internalGetValueMap() - Static method in enum akka.remote.WireFormats.CommandType
 
InternetSeedGenerator - Class in akka.remote.security.provider
 
InternetSeedGenerator() - Constructor for class akka.remote.security.provider.InternetSeedGenerator
 
InternetSeedGenerator$ - Class in akka.remote.security.provider
INTERNAL API Seed generator that maintains multiple strategies for seed generation and will delegate to the best one available for the current operating environment.
InternetSeedGenerator$() - Constructor for class akka.remote.security.provider.InternetSeedGenerator$
 
interval() - Method in class akka.routing.TailChoppingGroup
 
interval() - Method in class akka.routing.TailChoppingPool
 
interval() - Method in class akka.routing.TailChoppingRoutees
 
interval() - Method in class akka.routing.TailChoppingRoutingLogic
 
intervals() - Method in class akka.remote.HeartbeatHistory
 
intervalSum() - Method in class akka.remote.HeartbeatHistory
 
intToTimeout(int) - Method in class akka.util.Timeout$
 
intToTimeout(int) - Static method in class akka.util.Timeout
 
InvalidActorNameException - Exception in akka.actor
An InvalidActorNameException is thrown when you try to convert something, usually a String, to an Actor name which doesn't validate.
InvalidActorNameException(String) - Constructor for exception akka.actor.InvalidActorNameException
 
InvalidActorNameException$ - Class in akka.actor
 
InvalidActorNameException$() - Constructor for class akka.actor.InvalidActorNameException$
 
InvalidAssociation - Exception in akka.remote
INTERNAL API
InvalidAssociation(Address, Address, Throwable) - Constructor for exception akka.remote.InvalidAssociation
 
InvalidAssociation$ - Class in akka.remote
 
InvalidAssociation$() - Constructor for class akka.remote.InvalidAssociation$
 
InvalidMessageException - Exception in akka.actor
InvalidMessageException is thrown when an invalid message is sent to an Actor; Currently only null is an invalid message.
InvalidMessageException(String) - Constructor for exception akka.actor.InvalidMessageException
 
InvalidMessageException$ - Class in akka.actor
 
InvalidMessageException$() - Constructor for class akka.actor.InvalidMessageException$
 
invalidPathEntry() - Method in class akka.dispatch.CachingConfig$
 
invalidPathEntry() - Static method in class akka.dispatch.CachingConfig
 
invocationHandlerFor(Object) - Method in class akka.actor.TypedActorExtension
INTERNAL API
invoke(Envelope) - Method in class akka.actor.ActorCell
 
invoke(Object, Method, Object[]) - Method in class akka.actor.TypedActor.TypedActorInvocationHandler
 
invokeAll(Collection<? extends Callable<T>>) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
invokeAny(Collection<? extends Callable<T>>) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
invokeBeforeAllAndAfterAllEvenIfNoTestsAreExpected() - Method in class akka.testkit.AkkaSpec
 
IO - Class in akka.io
Entry point to Akka&rsquo;s IO layer.
IO() - Constructor for class akka.io.IO
 
IO$ - Class in akka.io
Entry point to Akka&rsquo;s IO layer.
IO$() - Constructor for class akka.io.IO$
 
IO.Extension - Interface in akka.io
 
isAborted() - Method in class akka.io.Tcp.Aborted$
 
isAborted() - Method in interface akka.io.Tcp.ConnectionClosed
true iff the connection has been closed in response to an Abort command.
isAllReachable() - Method in class akka.cluster.Reachability
 
isAssertInvariantsEnabled() - Method in class akka.cluster.Cluster$
INTERNAL API
isAssertInvariantsEnabled() - Static method in class akka.cluster.Cluster
INTERNAL API
isAvailable() - Method in interface akka.cluster.ClusterNodeMBean
Returns true if the node is not unreachable and not Down and not Removed.
isAvailable() - Method in class akka.cluster.ClusterReadView
Returns true if the node is not unreachable and not Down and not Removed.
isAvailable(Member) - Method in interface akka.cluster.routing.ClusterRouterActor
 
isAvailable() - Method in class akka.remote.DeadlineFailureDetector
 
isAvailable(A) - Method in class akka.remote.DefaultFailureDetectorRegistry
 
isAvailable() - Method in interface akka.remote.FailureDetector
Returns true if the resource is considered to be up and healthy and returns false otherwise.
isAvailable(A) - Method in interface akka.remote.FailureDetectorRegistry
Returns true if the resource is considered to be up and healthy and returns false otherwise.
isAvailable() - Method in class akka.remote.PhiAccrualFailureDetector
 
isBatchable() - Method in interface akka.dispatch.Batchable
 
isBatchable() - Method in class akka.dispatch.TaskInvocation
 
isCancelled() - Method in interface akka.actor.Cancellable
Returns true if and only if this Cancellable has been successfully cancelled
isCancelled() - Method in class akka.actor.LightArrayRevolverScheduler.TaskHolder
 
isClosed() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
isClosed() - Method in class akka.dispatch.Mailbox
 
isCompact() - Method in class akka.util.ByteString.ByteString1
 
isCompact() - Method in class akka.util.ByteString.ByteStrings
 
isCompact() - Method in class akka.util.ByteString
Check whether this ByteString is compact in memory.
isCompact() - Method in class akka.util.CompactByteString
 
isConfirmed() - Method in class akka.io.Tcp.ConfirmedClosed$
 
isConfirmed() - Method in interface akka.io.Tcp.ConnectionClosed
true iff the connection has been fully closed in response to a ConfirmedClose command.
isDebugEnabled() - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
isDebugEnabled() - Method in class akka.event.BusLogging
 
isDebugEnabled() - Method in interface akka.event.LoggingAdapter
 
isDebugEnabled() - Method in class akka.event.NoLogging$
 
isDebugEnabled() - Static method in class akka.event.NoLogging
 
isDefined() - Method in class akka.japi.Option
 
isDefinedAt(Object) - Method in class akka.actor.Actor.emptyBehavior$
 
isDefinedAt(ChildStats) - Method in class akka.actor.dungeon.ChildrenContainer.ChildrenIterable
 
isDefinedAt(ChildStats) - Method in class akka.actor.dungeon.ChildrenContainer.ChildRestartsIterable
 
isDefinedAt(Object) - Method in class akka.actor.FSM.NullFunction$
 
isDefinedAt(T) - Method in class akka.dispatch.japi.CallbackBridge
 
isDefinedAt(Throwable) - Method in class akka.dispatch.japi.RecoverBridge
 
isDefinedAt(Object) - Method in class akka.event.LoggingReceive
 
isDefinedAt(A) - Method in class akka.japi.JavaPartialFunction
 
isDefinedAt(F) - Method in class akka.japi.pf.CaseStatement
 
isDefinedAt(F) - Method in class akka.japi.pf.UnitCaseStatement
 
isDefinedAt(Object) - Method in class akka.routing.ConsistentHashingRouter.emptyConsistentHashMapping$
 
isDefinedAt(A) - Method in class akka.testkit.CachingPartialFunction
 
isDefinedAt(Object) - Method in class akka.transactor.EmptyReceive$
 
isDefinedAt(Object) - Static method in class akka.transactor.EmptyReceive
 
isDefinedAt(From) - Method in class akka.util.Collections.PartialImmutableValuesIterable
 
isDeleted() - Method in class akka.contrib.pattern.WorkList.Entry
 
isDeletionKey(Key) - Method in class akka.persistence.journal.leveldb.Key$
 
isDeletionKey(Key) - Static method in class akka.persistence.journal.leveldb.Key
 
isEmpty() - Method in class akka.cluster.routing.WeightedRoutees
 
isEmpty() - Method in class akka.dispatch.AbstractNodeQueue
Query the queue whether it is empty right now.
isEmpty() - Method in class akka.dispatch.CachingConfig
 
isEmpty() - Method in class akka.dispatch.sysmsg.EarliestFirstSystemMessageList
Indicates if the list is empty or not.
isEmpty() - Method in class akka.dispatch.sysmsg.LatestFirstSystemMessageList
Indicates if the list is empty or not.
isEmpty() - Method in class akka.japi.Option
 
isEmpty() - Method in class akka.japi.Option.Some
 
isEmpty() - Method in class akka.routing.ConsistentHash
Is the node ring empty, i.e.
isEmpty() - Method in class akka.util.BoundedBlockingQueue
 
isEmpty() - Method in class akka.util.Index
 
isEnabled(Logging.LogLevel) - Method in interface akka.event.LoggingAdapter
 
isEqual(K, K) - Method in interface akka.util.Subclassification
True if and only if x and y are of the same class.
isErrorClosed() - Method in interface akka.io.Tcp.ConnectionClosed
true iff the connection has been closed due to an IO error.
isErrorClosed() - Method in class akka.io.Tcp.ErrorClosed
 
isErrorEnabled() - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
isErrorEnabled() - Method in class akka.event.BusLogging
 
isErrorEnabled() - Method in interface akka.event.LoggingAdapter
 
isErrorEnabled() - Method in class akka.event.NoLogging$
 
isErrorEnabled() - Static method in class akka.event.NoLogging
 
isFailed() - Method in interface akka.actor.dungeon.FaultHandling
 
isGossipSpeedupNeeded() - Method in class akka.cluster.ClusterCoreDaemon
 
isIdKey(Key) - Method in class akka.persistence.journal.leveldb.Key$
 
isIdKey(Key) - Static method in class akka.persistence.journal.leveldb.Key
 
isInbound() - Method in interface akka.remote.AssociationEvent
 
isInfoEnabled() - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
isInfoEnabled() - Method in class akka.event.BusLogging
 
isInfoEnabled() - Method in interface akka.event.LoggingAdapter
 
isInfoEnabled() - Method in class akka.event.NoLogging$
 
isInfoEnabled() - Static method in class akka.event.NoLogging
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty.Builder
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
 
isInitialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
 
isInitialized() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
 
isInitialized() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
isInitialized() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
 
isInitialized() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
isInitialized() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
 
isInitialized() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
 
isInitialized() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
isInitialized() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
 
isInitialized() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload.Builder
 
isInitialized() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
isInitialized() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish.Builder
 
isInitialized() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
 
isInitialized() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
 
isInitialized() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
isInitialized() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
 
isInitialized() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
isInitialized() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
 
isInitialized() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
 
isInitialized() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
 
isInitialized() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
 
isInitialized() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
 
isInitialized() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
isInitialized() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
 
isInitialized() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
isInitialized() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
 
isInitialized() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
isInitialized() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage.Builder
 
isInitialized() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage
 
isInitialized() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
 
isInitialized() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
isInitialized() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
 
isInitialized() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
 
isInitialized() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
 
isInitialized() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
isInitialized() - Method in class akka.remote.ContainerFormats.Selection.Builder
 
isInitialized() - Method in class akka.remote.ContainerFormats.Selection
 
isInitialized() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
isInitialized() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
isInitialized() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
isInitialized() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
isInitialized() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
isInitialized() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
isInitialized() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
isInitialized() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
isInitialized() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
isInitialized() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
isInitialized() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
isInitialized() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
isInitialized() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
isInitialized() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
isInitialized() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
isInitialized() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
isInitialized() - Method in class akka.remote.WireFormats.ActorRefData.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.ActorRefData
 
isInitialized() - Method in class akka.remote.WireFormats.AddressData.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.AddressData
 
isInitialized() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
isInitialized() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
isInitialized() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
isInitialized() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
isInitialized() - Method in class akka.remote.WireFormats.DeployData.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.DeployData
 
isInitialized() - Method in class akka.remote.WireFormats.PropsData.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.PropsData
 
isInitialized() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
isInitialized() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.SerializedMessage
 
isLeader() - Method in class akka.cluster.ClusterReadView
Is this node the leader?
isLeader(UniqueAddress, UniqueAddress) - Method in class akka.cluster.Gossip
 
isLocal() - Method in class akka.actor.ActorCell
 
isLocal() - Method in interface akka.actor.ActorRefScope
 
isLocal() - Method in interface akka.actor.Cell
Returns true if the actor is local, i.e.
isLocal() - Method in class akka.actor.InternalActorRef
Scope: if this ref points to an actor which resides within the same JVM, i.e.
isLocal() - Method in interface akka.actor.LocalRef
 
isLocal() - Method in class akka.actor.RepointableActorRef
 
isLocal() - Method in class akka.actor.UnstartedCell
 
isLocal() - Method in interface akka.remote.RemoteRef
 
isManagementMessage(Object) - Method in interface akka.cluster.routing.ClusterRouterConfigBase
 
isManagementMessage(Object) - Method in interface akka.routing.RouterConfig
Is the message handled by the router head actor or the RouterConfig.routingLogicController(akka.routing.RoutingLogic) actor.
isMonitoring() - Method in class akka.remote.DeadlineFailureDetector
 
isMonitoring(A) - Method in class akka.remote.DefaultFailureDetectorRegistry
 
isMonitoring() - Method in interface akka.remote.FailureDetector
Returns true if the failure detector has received any heartbeats and started monitoring of the resource.
isMonitoring(A) - Method in interface akka.remote.FailureDetectorRegistry
Returns true if the failure detector has received any heartbeats and started monitoring of the resource.
isMonitoring() - Method in class akka.remote.PhiAccrualFailureDetector
 
isNode(Seq<RoleName>) - Method in class akka.remote.testkit.MultiNodeSpec
Verify that the running node matches one of the given nodes
isNormal() - Method in interface akka.actor.dungeon.Children
 
isNormal() - Method in interface akka.actor.dungeon.ChildrenContainer
 
isNormal() - Method in class akka.actor.dungeon.ChildrenContainer.TerminatedChildrenContainer$
 
isNormal() - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
 
isOff() - Method in class akka.util.Switch
Returns whether the switch is IMMEDDIATELY off (no locking)
isOlderThan(Member) - Method in class akka.cluster.Member
Is this member older, has been part of cluster longer, than another member.
isOn() - Method in class akka.util.Switch
Returns whether the switch is IMMEDIATELY on (no locking)
isOneWay() - Method in class akka.actor.TypedActor.MethodCall
 
isOneway() - Method in class akka.camel.javaapi.UntypedProducerActor
If set to false (default), this producer expects a response message from the Camel endpoint.
isOpen() - Method in class akka.testkit.TestLatch
 
isOutCapable() - Method in class akka.camel.internal.CamelExchangeAdapter
Returns if the exchange is out capable.
isPeerClosed() - Method in interface akka.io.Tcp.ConnectionClosed
true iff the connection has been closed by the peer; in case keepOpenOnPeerClosed is in effect as per the Tcp.Register command, this connection&rsquo;s reading half is now closed.
isPeerClosed() - Method in class akka.io.Tcp.PeerClosed$
 
isPersistent() - Method in interface akka.persistence.PersistentView
If true, the currently processed message was persisted (is sent from the Journal).
isProcessingMessage(Routee) - Method in class akka.routing.SmallestMailboxRoutingLogic
Returns true if the actor is currently processing a message.
isQuarantined(Address, int) - Method in class akka.remote.EndpointManager.EndpointRegistry
 
isReachable(UniqueAddress) - Method in class akka.cluster.Reachability
 
isReachable(UniqueAddress, UniqueAddress) - Method in class akka.cluster.Reachability
 
isReadOnly(ActorRef) - Method in class akka.remote.EndpointManager.EndpointRegistry
 
isReplaying() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
isResolved() - Method in class akka.dispatch.CachingConfig
 
isResponsibleFor(Address) - Method in class akka.remote.transport.AbstractTransportAdapter
 
isResponsibleFor(Address) - Method in class akka.remote.transport.netty.NettyTransport
 
isResponsibleFor(Address) - Method in class akka.remote.transport.TestTransport
 
isResponsibleFor(Address) - Method in interface akka.remote.transport.Transport
A function that decides whether the specific transport instance is responsible for delivering to a given address.
isRouteesPathDefined() - Method in class akka.cluster.routing.ClusterRouterSettings
 
isScheduled() - Method in class akka.dispatch.Mailbox
 
isSelfUp(Member) - Method in class akka.cluster.OnMemberUpListener
 
isShutdown() - Method in interface akka.dispatch.ExecutorServiceDelegate
 
isSingleton() - Method in class akka.camel.internal.component.ActorEndpoint
Returns true.
isSingleton() - Method in interface akka.cluster.ClusterNodeMBean
Does the cluster consist of only one member?
isSingletonCluster() - Method in class akka.cluster.ClusterCoreDaemon
 
isSingletonCluster() - Method in class akka.cluster.ClusterReadView
Does the cluster consist of only one member?
isSingletonCluster() - Method in class akka.cluster.Gossip
 
isSmooth() - Method in class akka.cluster.Metric
 
isStarted() - Method in class akka.actor.RepointableActorRef
 
isStarted() - Method in interface akka.actor.RepointableRef
 
isStateTimerActive() - Method in interface akka.actor.FSM
 
isStateTimerActive() - Method in class akka.testkit.TestFSMRef
Proxy for FSM.isStateTimerActive().
isSubclass(K, K) - Method in interface akka.util.Subclassification
True if and only if x is a subclass of y; equal classes must be considered sub-classes!
isSuccessor(SeqNo) - Method in class akka.remote.SeqNo
Checks if this sequence number is an immediate successor of the provided one.
isSuspended() - Method in class akka.dispatch.Mailbox
 
isSuspended(Routee) - Method in class akka.routing.SmallestMailboxRoutingLogic
Returns true if the actor is currently suspended.
isTerminated() - Method in class akka.actor.ActorRef
Is the actor shut down? The contract is that if this method returns true, then it will never be false again.
isTerminated() - Method in class akka.actor.ActorSystem
Query the termination status: if it returns true, all callbacks have run and the ActorSystem has been fully stopped, i.e.
isTerminated() - Method in class akka.actor.ActorSystemImpl
 
isTerminated() - Method in class akka.actor.ActorSystemImpl.TerminationCallbacks
 
isTerminated() - Method in interface akka.actor.Cell
Returns &ldquo;true&rdquo; if the actor is locally known to be terminated, &ldquo;false&rdquo; if alive or uncertain.
isTerminated() - Method in interface akka.actor.dungeon.Dispatch
 
isTerminated() - Method in class akka.actor.EmptyLocalActorRef
 
isTerminated() - Method in class akka.actor.InternalActorRef
Returns &ldquo;true&rdquo; if the actor is locally known to be terminated, &ldquo;false&rdquo; if alive or uncertain.
isTerminated() - Method in class akka.actor.LocalActorRef
Is the actor terminated? If this method returns true, it will never return false again, but if it returns false, you cannot be sure if it's alive still (race condition)
isTerminated() - Method in interface akka.actor.MinimalActorRef
 
isTerminated() - Method in class akka.actor.RepointableActorRef
 
isTerminated() - Method in class akka.actor.UnstartedCell
 
isTerminated() - Method in class akka.cluster.Cluster
Returns true if this cluster instance has be shutdown.
isTerminated() - Method in class akka.cluster.ClusterReadView
Returns true if this cluster instance has be shutdown.
isTerminated() - Method in class akka.contrib.pattern.ClusterReceptionistExtension
Returns true if this member is not tagged with the role configured for the receptionist.
isTerminated() - Method in class akka.contrib.pattern.DistributedPubSubExtension
Returns true if this member is not tagged with the role configured for the mediator.
isTerminated() - Method in interface akka.dispatch.ExecutorServiceDelegate
 
isTerminated() - Method in class akka.pattern.PromiseActorRef
 
isTerminated() - Method in class akka.remote.RemoteActorRef
 
isTerminated(Routee) - Method in class akka.routing.SmallestMailboxRoutingLogic
 
isTerminating() - Method in interface akka.actor.dungeon.Children
 
isTerminating() - Method in interface akka.actor.dungeon.ChildrenContainer
 
isTerminating() - Method in class akka.actor.dungeon.ChildrenContainer.TerminatedChildrenContainer$
 
isTerminating() - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
 
isThroughputDeadlineTimeDefined() - Method in class akka.dispatch.MessageDispatcher
INTERNAL API
isTimeForResize(long) - Method in class akka.routing.DefaultResizer
 
isTimeForResize(long) - Method in interface akka.routing.Resizer
Is it time for resizing.
isTimerActive(String) - Method in interface akka.actor.FSM
 
isTimerActive(String) - Method in class akka.testkit.TestFSMRef
Proxy for FSM.isStateTimerActive().
isTombstone() - Method in interface akka.remote.EndpointManager.EndpointPolicy
Indicates that the policy does not contain an active endpoint, but it is a tombstone of a previous failure
isTombstone() - Method in class akka.remote.EndpointManager.Gated
 
isTombstone() - Method in class akka.remote.EndpointManager.Pass
 
isTombstone() - Method in class akka.remote.EndpointManager.Quarantined
 
isTypedActor(Object) - Method in class akka.actor.ContextualTypedActorFactory
 
isTypedActor(Object) - Method in class akka.actor.TypedActorExtension
Returns wether the supplied AnyRef is a TypedActor proxy or not
isTypedActor(Object) - Method in interface akka.actor.TypedActorFactory
Returns wether the supplied AnyRef is a TypedActor proxy or not
isValidPathElement(String) - Method in class akka.actor.ActorPath$
This method is used to validate a path element (Actor Name).
isWarningEnabled() - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
isWarningEnabled() - Method in class akka.event.BusLogging
 
isWarningEnabled() - Method in interface akka.event.LoggingAdapter
 
isWarningEnabled() - Method in class akka.event.NoLogging$
 
isWarningEnabled() - Static method in class akka.event.NoLogging
 
isWindows() - Method in class akka.util.Helpers$
 
isWindows() - Static method in class akka.util.Helpers
 
isWritable(ActorRef) - Method in class akka.remote.EndpointManager.EndpointRegistry
 
item() - Method in class akka.actor.mailbox.filebased.filequeue.JournalItem.Add
 
iterator() - Method in class akka.io.Tcp.CompoundWrite
 
iterator() - Method in class akka.japi.Option
 
iterator() - Method in class akka.util.BoundedBlockingQueue
 
iterator() - Method in class akka.util.ByteString.ByteString1
 
iterator() - Method in class akka.util.ByteString.ByteString1C
 
iterator() - Method in class akka.util.ByteString.ByteStrings
 
iterator() - Method in class akka.util.ByteString
 
iterator() - Method in class akka.util.Collections.EmptyImmutableSeq$
 
iterator() - Method in class akka.util.Collections.PartialImmutableValuesIterable
 

J

japi - Class in akka.dispatch
This class contains bridge classes between Scala and Java.
japi() - Constructor for class akka.dispatch.japi
 
JAPI - Class in akka.japi
 
JAPI() - Constructor for class akka.japi.JAPI
 
japi$ - Class in akka.dispatch
This class contains bridge classes between Scala and Java.
japi$() - Constructor for class akka.dispatch.japi$
 
japi.BooleanFunctionBridge<T> - Class in akka.dispatch
 
japi.BooleanFunctionBridge() - Constructor for class akka.dispatch.japi.BooleanFunctionBridge
 
japi.CallbackBridge<T> - Class in akka.dispatch
 
japi.CallbackBridge() - Constructor for class akka.dispatch.japi.CallbackBridge
 
japi.RecoverBridge<T> - Class in akka.dispatch
 
japi.RecoverBridge() - Constructor for class akka.dispatch.japi.RecoverBridge
 
japi.UnitFunctionBridge<T> - Class in akka.dispatch
 
japi.UnitFunctionBridge() - Constructor for class akka.dispatch.japi.UnitFunctionBridge
 
java2ScalaOption(Option<A>) - Method in class akka.japi.Option$
 
java2ScalaOption(Option<A>) - Static method in class akka.japi.Option
 
JavaJournalPerfSpec - Class in akka.persistence.japi.journal
JAVA API
JavaJournalPerfSpec(com.typesafe.config.Config) - Constructor for class akka.persistence.japi.journal.JavaJournalPerfSpec
 
JavaJournalSpec - Class in akka.persistence.japi.journal
JAVA API
JavaJournalSpec(com.typesafe.config.Config) - Constructor for class akka.persistence.japi.journal.JavaJournalSpec
 
JavaLogger - Class in akka.contrib.jul
java.util.logging logger.
JavaLogger() - Constructor for class akka.contrib.jul.JavaLogger
 
JavaLogging - Interface in akka.contrib.jul
Makes the Akka Logging API available as the log field, using java.util.logging as the backend.
JavaLoggingAdapter - Interface in akka.contrib.jul
 
JavaLoggingEventHandler - Class in akka.contrib.jul
 
JavaLoggingEventHandler() - Constructor for class akka.contrib.jul.JavaLoggingEventHandler
 
JavaPartialFunction<A,B> - Class in akka.japi
Helper for implementing a *pure* partial function: it will possibly be invoked multiple times for a single &ldquo;application&rdquo;, because its only abstract method is used for both isDefinedAt() and apply(); the former is mapped to isCheck == true and the latter to isCheck == false for those cases where this is important to know.
JavaPartialFunction() - Constructor for class akka.japi.JavaPartialFunction
 
JavaPartialFunction$ - Class in akka.japi
 
JavaPartialFunction$() - Constructor for class akka.japi.JavaPartialFunction$
 
JavaPartialFunction.NoMatch$ - Exception in akka.japi
 
JavaPartialFunction.NoMatch$() - Constructor for exception akka.japi.JavaPartialFunction.NoMatch$
 
JavaPartialFunction.NoMatchException - Exception in akka.japi
 
JavaPartialFunction.NoMatchException() - Constructor for exception akka.japi.JavaPartialFunction.NoMatchException
 
JavaSerializer - Class in akka.serialization
This Serializer uses standard Java Serialization
JavaSerializer(ExtendedActorSystem) - Constructor for class akka.serialization.JavaSerializer
 
JavaSerializer$ - Class in akka.serialization
 
JavaSerializer$() - Constructor for class akka.serialization.JavaSerializer$
 
JavaSerializer.CurrentSystem - Class in akka.serialization
 
JavaSerializer.CurrentSystem() - Constructor for class akka.serialization.JavaSerializer.CurrentSystem
 
JavaSnapshotStoreSpec - Class in akka.persistence.japi.snapshot
JAVA API
JavaSnapshotStoreSpec(com.typesafe.config.Config) - Constructor for class akka.persistence.japi.snapshot.JavaSnapshotStoreSpec
 
JavaTestKit - Class in akka.testkit
Java API: Test kit for testing actors.
JavaTestKit(ActorSystem) - Constructor for class akka.testkit.JavaTestKit
 
JavaTestKit.AwaitAssert - Class in akka.testkit
Await until the given assert does not throw an exception or the timeout expires, whichever comes first.
JavaTestKit.AwaitAssert() - Constructor for class akka.testkit.JavaTestKit.AwaitAssert
 
JavaTestKit.AwaitAssert(Duration) - Constructor for class akka.testkit.JavaTestKit.AwaitAssert
 
JavaTestKit.AwaitAssert(Duration, Duration) - Constructor for class akka.testkit.JavaTestKit.AwaitAssert
 
JavaTestKit.AwaitCond - Class in akka.testkit
Await until the given condition evaluates to true or the timeout expires, whichever comes first.
JavaTestKit.AwaitCond() - Constructor for class akka.testkit.JavaTestKit.AwaitCond
 
JavaTestKit.AwaitCond(Duration) - Constructor for class akka.testkit.JavaTestKit.AwaitCond
 
JavaTestKit.AwaitCond(Duration, Duration) - Constructor for class akka.testkit.JavaTestKit.AwaitCond
 
JavaTestKit.AwaitCond(Duration, Duration, String) - Constructor for class akka.testkit.JavaTestKit.AwaitCond
 
JavaTestKit.EventFilter<T> - Class in akka.testkit
Facilities for selectively filtering out expected events from logging so that you can keep your test run’s console output clean and do not miss real error messages.
JavaTestKit.EventFilter(Class<?>) - Constructor for class akka.testkit.JavaTestKit.EventFilter
 
JavaTestKit.ExpectMsg<T> - Class in akka.testkit
Receive one message from the test actor and assert that the given matching function accepts it.
JavaTestKit.ExpectMsg(String) - Constructor for class akka.testkit.JavaTestKit.ExpectMsg
 
JavaTestKit.ExpectMsg(Duration, String) - Constructor for class akka.testkit.JavaTestKit.ExpectMsg
 
JavaTestKit.IgnoreMsg - Class in akka.testkit
Ignore all messages in the test actor for which the given function returns true.
JavaTestKit.IgnoreMsg() - Constructor for class akka.testkit.JavaTestKit.IgnoreMsg
 
JavaTestKit.ReceiveWhile<T> - Class in akka.testkit
Receive a series of messages until one does not match the given match function or the idle timeout is met (disabled by default) or the overall maximum duration is elapsed.
JavaTestKit.ReceiveWhile(Class<T>) - Constructor for class akka.testkit.JavaTestKit.ReceiveWhile
 
JavaTestKit.ReceiveWhile(Class<T>, Duration) - Constructor for class akka.testkit.JavaTestKit.ReceiveWhile
 
JavaTestKit.ReceiveWhile(Class<T>, Duration, int) - Constructor for class akka.testkit.JavaTestKit.ReceiveWhile
 
JavaTestKit.ReceiveWhile(Class<T>, Duration, Duration, int) - Constructor for class akka.testkit.JavaTestKit.ReceiveWhile
 
JavaTestKit.Within - Class in akka.testkit
Execute code block while bounding its execution time between min and max.
JavaTestKit.Within(FiniteDuration) - Constructor for class akka.testkit.JavaTestKit.Within
 
JavaTestKit.Within(FiniteDuration, FiniteDuration) - Constructor for class akka.testkit.JavaTestKit.Within
 
JavaTestKitSpec - Class in akka.testkit
 
JavaTestKitSpec() - Constructor for class akka.testkit.JavaTestKitSpec
 
JmxEnabled() - Method in class akka.cluster.ClusterSettings
 
JmxMetricsCollector - Class in akka.cluster
Loads JVM and system metrics through JMX monitoring beans.
JmxMetricsCollector(Address, double) - Constructor for class akka.cluster.JmxMetricsCollector
 
JmxMetricsCollector(ActorSystem) - Constructor for class akka.cluster.JmxMetricsCollector
This constructor is used when creating an instance from configured FQCN
JmxStatistics() - Method in class akka.camel.CamelSettings
 
join(Address) - Method in class akka.cluster.Cluster
Try to join this cluster node with the node specified by 'address'.
join(Address) - Method in class akka.cluster.ClusterCoreDaemon
Try to join this cluster node with the node specified by address.
join(String) - Method in interface akka.cluster.ClusterNodeMBean
Try to join this cluster node with the node specified by 'address'.
joining(UniqueAddress, Set<String>) - Method in class akka.cluster.ClusterCoreDaemon
State transition to JOINING - new node joining.
joining() - Method in class akka.cluster.MemberStatus$
Java API: retrieve the &ldquo;joining&rdquo; status singleton
joining() - Static method in class akka.cluster.MemberStatus
Java API: retrieve the &ldquo;joining&rdquo; status singleton
Joining_VALUE - Static variable in enum akka.cluster.protobuf.msg.ClusterMessages.MemberStatus
Joining = 0;
JoinSeedNodeProcess - Class in akka.cluster
INTERNAL API.
JoinSeedNodeProcess(IndexedSeq<Address>) - Constructor for class akka.cluster.JoinSeedNodeProcess
 
joinSeedNodes(Seq<Address>) - Method in class akka.cluster.Cluster
Join the specified seed nodes without defining them in config.
joinSeedNodes(IndexedSeq<Address>) - Method in class akka.cluster.ClusterCoreDaemon
 
Journal - Class in akka.actor.mailbox.filebased.filequeue
Codes for working with the journal file for a PersistentQueue.
Journal(String, Function0<Object>, LoggingAdapter) - Constructor for class akka.actor.mailbox.filebased.filequeue.Journal
 
journal() - Method in interface akka.persistence.journal.JournalSpec
 
journal() - Method in class akka.persistence.PersistenceSettings
 
journal() - Method in interface akka.persistence.Recovery
INTERNAL API.
journalBatch() - Method in class akka.persistence.DeliveredByChannelBatching
 
journalBatch() - Method in class akka.persistence.DeliveredByPersistentChannelBatching
 
journalFor(String) - Method in class akka.persistence.Persistence
Returns a journal for a processor identified by persistenceId.
JournalItem - Interface in akka.actor.mailbox.filebased.filequeue
 
JournalItem$ - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem$() - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem$
 
JournalItem.Add - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.Add(QItem) - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.Add
 
JournalItem.Add$ - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.Add$() - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.Add$
 
JournalItem.ConfirmRemove - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.ConfirmRemove(int) - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.ConfirmRemove
 
JournalItem.ConfirmRemove$ - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.ConfirmRemove$() - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.ConfirmRemove$
 
JournalItem.EndOfFile$ - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.EndOfFile$() - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.EndOfFile$
 
JournalItem.Remove$ - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.Remove$() - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.Remove$
 
JournalItem.RemoveTentative$ - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.RemoveTentative$() - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.RemoveTentative$
 
JournalItem.SavedXid - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.SavedXid(int) - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.SavedXid
 
JournalItem.SavedXid$ - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.SavedXid$() - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.SavedXid$
 
JournalItem.Unremove - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.Unremove(int) - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.Unremove
 
JournalItem.Unremove$ - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.Unremove$() - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.Unremove$
 
JournalPerfSpec - Interface in akka.persistence.journal
This spec measures execution times of the basic operations that an PersistentActor provides, using the provided Journal (plugin).
JournalPerfSpec$ - Class in akka.persistence.journal
 
JournalPerfSpec$() - Constructor for class akka.persistence.journal.JournalPerfSpec$
 
JournalPerfSpec.BenchActor - Class in akka.persistence.journal
 
JournalPerfSpec.BenchActor(String, ActorRef, int) - Constructor for class akka.persistence.journal.JournalPerfSpec.BenchActor
 
JournalPerfSpec.Cmd - Class in akka.persistence.journal
 
JournalPerfSpec.Cmd(String, int) - Constructor for class akka.persistence.journal.JournalPerfSpec.Cmd
 
JournalPerfSpec.Cmd$ - Class in akka.persistence.journal
 
JournalPerfSpec.Cmd$() - Constructor for class akka.persistence.journal.JournalPerfSpec.Cmd$
 
JournalPerfSpec.ResetCounter$ - Class in akka.persistence.journal
 
JournalPerfSpec.ResetCounter$() - Constructor for class akka.persistence.journal.JournalPerfSpec.ResetCounter$
 
JournalProtocol - Class in akka.persistence
INTERNAL API.
JournalProtocol() - Constructor for class akka.persistence.JournalProtocol
 
JournalProtocol$ - Class in akka.persistence
INTERNAL API.
JournalProtocol$() - Constructor for class akka.persistence.JournalProtocol$
 
JournalProtocol.DeleteMessages - Class in akka.persistence
Request to delete messages identified by messageIds.
JournalProtocol.DeleteMessages(Seq<PersistentId>, boolean, Option<ActorRef>) - Constructor for class akka.persistence.JournalProtocol.DeleteMessages
 
JournalProtocol.DeleteMessages$ - Class in akka.persistence
 
JournalProtocol.DeleteMessages$() - Constructor for class akka.persistence.JournalProtocol.DeleteMessages$
 
JournalProtocol.DeleteMessagesFailure - Class in akka.persistence
Reply message to a failed JournalProtocol.DeleteMessages request.
JournalProtocol.DeleteMessagesFailure(Throwable) - Constructor for class akka.persistence.JournalProtocol.DeleteMessagesFailure
 
JournalProtocol.DeleteMessagesFailure$ - Class in akka.persistence
 
JournalProtocol.DeleteMessagesFailure$() - Constructor for class akka.persistence.JournalProtocol.DeleteMessagesFailure$
 
JournalProtocol.DeleteMessagesSuccess - Class in akka.persistence
Reply message to a successful JournalProtocol.DeleteMessages request.
JournalProtocol.DeleteMessagesSuccess(Seq<PersistentId>) - Constructor for class akka.persistence.JournalProtocol.DeleteMessagesSuccess
 
JournalProtocol.DeleteMessagesSuccess$ - Class in akka.persistence
 
JournalProtocol.DeleteMessagesSuccess$() - Constructor for class akka.persistence.JournalProtocol.DeleteMessagesSuccess$
 
JournalProtocol.DeleteMessagesTo - Class in akka.persistence
Request to delete all persistent messages with sequence numbers up to toSequenceNr (inclusive).
JournalProtocol.DeleteMessagesTo(String, long, boolean) - Constructor for class akka.persistence.JournalProtocol.DeleteMessagesTo
 
JournalProtocol.DeleteMessagesTo$ - Class in akka.persistence
 
JournalProtocol.DeleteMessagesTo$() - Constructor for class akka.persistence.JournalProtocol.DeleteMessagesTo$
 
JournalProtocol.LoopMessage - Class in akka.persistence
Request to loop a message back to persistent actor, without persisting the message.
JournalProtocol.LoopMessage(Object, ActorRef, int) - Constructor for class akka.persistence.JournalProtocol.LoopMessage
 
JournalProtocol.LoopMessage$ - Class in akka.persistence
 
JournalProtocol.LoopMessage$() - Constructor for class akka.persistence.JournalProtocol.LoopMessage$
 
JournalProtocol.LoopMessageSuccess - Class in akka.persistence
Reply message to a JournalProtocol.LoopMessage request.
JournalProtocol.LoopMessageSuccess(Object, int) - Constructor for class akka.persistence.JournalProtocol.LoopMessageSuccess
 
JournalProtocol.LoopMessageSuccess$ - Class in akka.persistence
 
JournalProtocol.LoopMessageSuccess$() - Constructor for class akka.persistence.JournalProtocol.LoopMessageSuccess$
 
JournalProtocol.ReadHighestSequenceNr - Class in akka.persistence
Request to read the highest stored sequence number of a given persistent actor.
JournalProtocol.ReadHighestSequenceNr(long, String, ActorRef) - Constructor for class akka.persistence.JournalProtocol.ReadHighestSequenceNr
 
JournalProtocol.ReadHighestSequenceNr$ - Class in akka.persistence
 
JournalProtocol.ReadHighestSequenceNr$() - Constructor for class akka.persistence.JournalProtocol.ReadHighestSequenceNr$
 
JournalProtocol.ReadHighestSequenceNrFailure - Class in akka.persistence
Reply message to a failed JournalProtocol.ReadHighestSequenceNr request.
JournalProtocol.ReadHighestSequenceNrFailure(Throwable) - Constructor for class akka.persistence.JournalProtocol.ReadHighestSequenceNrFailure
 
JournalProtocol.ReadHighestSequenceNrFailure$ - Class in akka.persistence
 
JournalProtocol.ReadHighestSequenceNrFailure$() - Constructor for class akka.persistence.JournalProtocol.ReadHighestSequenceNrFailure$
 
JournalProtocol.ReadHighestSequenceNrSuccess - Class in akka.persistence
Reply message to a successful JournalProtocol.ReadHighestSequenceNr request.
JournalProtocol.ReadHighestSequenceNrSuccess(long) - Constructor for class akka.persistence.JournalProtocol.ReadHighestSequenceNrSuccess
 
JournalProtocol.ReadHighestSequenceNrSuccess$ - Class in akka.persistence
 
JournalProtocol.ReadHighestSequenceNrSuccess$() - Constructor for class akka.persistence.JournalProtocol.ReadHighestSequenceNrSuccess$
 
JournalProtocol.ReplayedMessage - Class in akka.persistence
Reply message to a JournalProtocol.ReplayMessages request.
JournalProtocol.ReplayedMessage(PersistentRepr) - Constructor for class akka.persistence.JournalProtocol.ReplayedMessage
 
JournalProtocol.ReplayedMessage$ - Class in akka.persistence
 
JournalProtocol.ReplayedMessage$() - Constructor for class akka.persistence.JournalProtocol.ReplayedMessage$
 
JournalProtocol.ReplayMessages - Class in akka.persistence
Request to replay messages to persistentActor.
JournalProtocol.ReplayMessages(long, long, long, String, ActorRef, boolean) - Constructor for class akka.persistence.JournalProtocol.ReplayMessages
 
JournalProtocol.ReplayMessages$ - Class in akka.persistence
 
JournalProtocol.ReplayMessages$() - Constructor for class akka.persistence.JournalProtocol.ReplayMessages$
 
JournalProtocol.ReplayMessagesFailure - Class in akka.persistence
Reply message to a failed JournalProtocol.ReplayMessages request.
JournalProtocol.ReplayMessagesFailure(Throwable) - Constructor for class akka.persistence.JournalProtocol.ReplayMessagesFailure
 
JournalProtocol.ReplayMessagesFailure$ - Class in akka.persistence
 
JournalProtocol.ReplayMessagesFailure$() - Constructor for class akka.persistence.JournalProtocol.ReplayMessagesFailure$
 
JournalProtocol.ReplayMessagesSuccess$ - Class in akka.persistence
Reply message to a successful JournalProtocol.ReplayMessages request.
JournalProtocol.ReplayMessagesSuccess$() - Constructor for class akka.persistence.JournalProtocol.ReplayMessagesSuccess$
 
JournalProtocol.WriteConfirmations - Class in akka.persistence
Request to write delivery confirmations.
JournalProtocol.WriteConfirmations(Seq<PersistentConfirmation>, ActorRef) - Constructor for class akka.persistence.JournalProtocol.WriteConfirmations
 
JournalProtocol.WriteConfirmations$ - Class in akka.persistence
 
JournalProtocol.WriteConfirmations$() - Constructor for class akka.persistence.JournalProtocol.WriteConfirmations$
 
JournalProtocol.WriteConfirmationsFailure - Class in akka.persistence
Reply message to a failed JournalProtocol.WriteConfirmations request.
JournalProtocol.WriteConfirmationsFailure(Throwable) - Constructor for class akka.persistence.JournalProtocol.WriteConfirmationsFailure
 
JournalProtocol.WriteConfirmationsFailure$ - Class in akka.persistence
 
JournalProtocol.WriteConfirmationsFailure$() - Constructor for class akka.persistence.JournalProtocol.WriteConfirmationsFailure$
 
JournalProtocol.WriteConfirmationsSuccess - Class in akka.persistence
Reply message to a successful JournalProtocol.WriteConfirmations request.
JournalProtocol.WriteConfirmationsSuccess(Seq<PersistentConfirmation>) - Constructor for class akka.persistence.JournalProtocol.WriteConfirmationsSuccess
 
JournalProtocol.WriteConfirmationsSuccess$ - Class in akka.persistence
 
JournalProtocol.WriteConfirmationsSuccess$() - Constructor for class akka.persistence.JournalProtocol.WriteConfirmationsSuccess$
 
JournalProtocol.WriteMessageFailure - Class in akka.persistence
Reply message to a failed JournalProtocol.WriteMessages request.
JournalProtocol.WriteMessageFailure(PersistentRepr, Throwable, int) - Constructor for class akka.persistence.JournalProtocol.WriteMessageFailure
 
JournalProtocol.WriteMessageFailure$ - Class in akka.persistence
 
JournalProtocol.WriteMessageFailure$() - Constructor for class akka.persistence.JournalProtocol.WriteMessageFailure$
 
JournalProtocol.WriteMessages - Class in akka.persistence
Request to write messages.
JournalProtocol.WriteMessages(Seq<Resequenceable>, ActorRef, int) - Constructor for class akka.persistence.JournalProtocol.WriteMessages
 
JournalProtocol.WriteMessages$ - Class in akka.persistence
 
JournalProtocol.WriteMessages$() - Constructor for class akka.persistence.JournalProtocol.WriteMessages$
 
JournalProtocol.WriteMessagesFailed - Class in akka.persistence
Reply message to a failed JournalProtocol.WriteMessages request.
JournalProtocol.WriteMessagesFailed(Throwable) - Constructor for class akka.persistence.JournalProtocol.WriteMessagesFailed
 
JournalProtocol.WriteMessagesFailed$ - Class in akka.persistence
 
JournalProtocol.WriteMessagesFailed$() - Constructor for class akka.persistence.JournalProtocol.WriteMessagesFailed$
 
JournalProtocol.WriteMessagesSuccessful$ - Class in akka.persistence
Reply message to a successful JournalProtocol.WriteMessages request.
JournalProtocol.WriteMessagesSuccessful$() - Constructor for class akka.persistence.JournalProtocol.WriteMessagesSuccessful$
 
JournalProtocol.WriteMessageSuccess - Class in akka.persistence
Reply message to a successful JournalProtocol.WriteMessages request.
JournalProtocol.WriteMessageSuccess(PersistentRepr, int) - Constructor for class akka.persistence.JournalProtocol.WriteMessageSuccess
 
JournalProtocol.WriteMessageSuccess$ - Class in akka.persistence
 
JournalProtocol.WriteMessageSuccess$() - Constructor for class akka.persistence.JournalProtocol.WriteMessageSuccess$
 
journalSize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
JournalSpec - Interface in akka.persistence.journal
This spec aims to verify custom akka-persistence Journal implementations.
JournalSpec$ - Class in akka.persistence.journal
 
JournalSpec$() - Constructor for class akka.persistence.journal.JournalSpec$
 
JournalSpec.Confirmation - Class in akka.persistence.journal
 
JournalSpec.Confirmation(String, String, long) - Constructor for class akka.persistence.journal.JournalSpec.Confirmation
 
JournalSpec.Confirmation$ - Class in akka.persistence.journal
 
JournalSpec.Confirmation$() - Constructor for class akka.persistence.journal.JournalSpec.Confirmation$
 
JSerializer - Class in akka.serialization
Java API for creating a Serializer: make sure to include a constructor which takes exactly one argument of type ExtendedActorSystem, because that is the preferred constructor which will be invoked when reflectively instantiating the JSerializer (also possible with empty constructor).
JSerializer() - Constructor for class akka.serialization.JSerializer
 
JvmExitOnFatalError() - Method in class akka.actor.ActorSystem.Settings
 

K

keepAlive(boolean) - Method in class akka.io.TcpSO$
Inet.SocketOption to enable or disable SO_KEEPALIVE
keepAlive(boolean) - Static method in class akka.io.TcpSO
Inet.SocketOption to enable or disable SO_KEEPALIVE
KeepJournal() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
keepJournal() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
keepJournal() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
keepOpenOnPeerClosed() - Method in class akka.io.Tcp.Register
 
keepOpenOnPeerClosed() - Method in class akka.io.TcpConnection.ConnectionInfo
 
keepQuarantinedOr(Address, Function0<BoxedUnit>) - Method in class akka.remote.EndpointManager
 
keepRunning() - Method in class akka.testkit.TestActor.AutoPilot
 
Key - Class in akka.persistence.journal.leveldb
LevelDB key.
Key(int, long, int) - Constructor for class akka.persistence.journal.leveldb.Key
 
key() - Method in class akka.persistence.serialization.SnapshotSerializer$
 
key() - Static method in class akka.persistence.serialization.SnapshotSerializer
 
key() - Method in class akka.remote.transport.TestAssociationHandle
Key used in TestTransport.AssociationRegistry to identify associations.
key() - Method in class akka.util.SubclassifiedIndex.Nonroot
 
Key$ - Class in akka.persistence.journal.leveldb
 
Key$() - Constructor for class akka.persistence.journal.leveldb.Key$
 
KEY_FIELD_NUMBER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
keyFromBytes(byte[]) - Method in class akka.persistence.journal.leveldb.Key$
 
keyFromBytes(byte[]) - Static method in class akka.persistence.journal.leveldb.Key
 
keys() - Method in class akka.util.Index
Returns the key set.
keyToBytes(Key) - Method in class akka.persistence.journal.leveldb.Key$
 
keyToBytes(Key) - Static method in class akka.persistence.journal.leveldb.Key
 
Kill - Class in akka.actor
 
Kill() - Constructor for class akka.actor.Kill
 
Kill$ - Class in akka.actor
A message all Actors will understand, that when processed will make the Actor throw an ActorKilledException, which will trigger supervision.
Kill$() - Constructor for class akka.actor.Kill$
 
KILOBYTE() - Method in class akka.actor.mailbox.filebased.filequeue.tools.Util$
 
KILOBYTE() - Static method in class akka.actor.mailbox.filebased.filequeue.tools.Util
 

L

largeBufferLogTimestamp() - Method in class akka.remote.EndpointWriter
 
last() - Method in class akka.util.ByteString
 
lastAck() - Method in class akka.remote.EndpointWriter
 
lastAckSerial() - Method in class akka.contrib.pattern.ReliableProxy
 
lastDelivered() - Method in class akka.remote.AckedReceiveBuffer
 
lastMessage() - Method in interface akka.testkit.TestKitBase
 
lastSender() - Method in interface akka.testkit.TestKitBase
 
lastSequenceNr() - Method in interface akka.persistence.Recovery
Highest received sequence number so far or 0L if this actor hasn't received a persistent message yet.
lastSerial() - Method in class akka.contrib.pattern.ReliableProxy.Receiver
 
lastValidPosition() - Method in exception akka.actor.mailbox.filebased.filequeue.BrokenItemException
 
lastWasNoMsg() - Method in interface akka.testkit.TestKitBase
if last assertion was expectNoMsg, disable timing failure upon within() block end.
Latest() - Method in class akka.persistence.SnapshotSelectionCriteria$
The latest saved snapshot.
latest() - Method in class akka.persistence.SnapshotSelectionCriteria$
Java API.
Latest() - Static method in class akka.persistence.SnapshotSelectionCriteria
The latest saved snapshot.
latest() - Static method in class akka.persistence.SnapshotSelectionCriteria
Java API.
LatestFirstSystemMessageList - Class in akka.dispatch.sysmsg
INTERNAL API
LatestFirstSystemMessageList(SystemMessage) - Constructor for class akka.dispatch.sysmsg.LatestFirstSystemMessageList
 
LatestFirstSystemMessageList$ - Class in akka.dispatch.sysmsg
 
LatestFirstSystemMessageList$() - Constructor for class akka.dispatch.sysmsg.LatestFirstSystemMessageList$
 
latestGossip() - Method in class akka.cluster.ClusterCoreDaemon
 
latestGossip() - Method in class akka.cluster.ClusterDomainEventPublisher
 
latestGossip() - Method in class akka.cluster.ClusterMetricsCollector
The latest metric values with their statistical data.
latestStats() - Method in class akka.cluster.ClusterReadView
INTERNAL API
leader() - Method in class akka.cluster.AutoDownBase
 
leader() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
 
leader() - Method in class akka.cluster.ClusterEvent.LeaderChanged
 
leader() - Method in class akka.cluster.ClusterEvent.RoleLeaderChanged
 
leader() - Method in class akka.cluster.ClusterReadView
Get the address of the current leader.
leader(UniqueAddress) - Method in class akka.cluster.Gossip
 
leaderActionCounter() - Method in class akka.cluster.ClusterCoreDaemon
 
leaderActions() - Method in class akka.cluster.ClusterCoreDaemon
Runs periodic leader actions, such as member status transitions, assigning partitions etc.
LeaderActionsInterval() - Method in class akka.cluster.ClusterSettings
 
leaderActionsOnConvergence() - Method in class akka.cluster.ClusterCoreDaemon
Leader actions are as follows: 1.
leaderActionsTask() - Method in class akka.cluster.ClusterCoreDaemon
 
leaderStatusOrdering() - Method in class akka.cluster.Member$
INTERNAL API Orders the members by their address except that members with status Joining, Exiting and Down are ordered last (in that order).
leaderStatusOrdering() - Static method in class akka.cluster.Member
INTERNAL API Orders the members by their address except that members with status Joining, Exiting and Down are ordered last (in that order).
LeastShardAllocationMaxSimultaneousRebalance() - Method in class akka.contrib.pattern.ClusterSharding.Settings$
 
LeastShardAllocationRebalanceThreshold() - Method in class akka.contrib.pattern.ClusterSharding.Settings$
 
leave(Address) - Method in class akka.cluster.Cluster
Send command to issue state transition to LEAVING for the node specified by 'address'.
leave(String) - Method in interface akka.cluster.ClusterNodeMBean
Send command to issue state transition to LEAVING for the node specified by 'address'.
leaving(Address) - Method in class akka.cluster.ClusterCoreDaemon
State transition to LEAVING.
leaving() - Method in class akka.cluster.MemberStatus$
Java API: retrieve the &ldquo;leaving&rdquo; status singleton
leaving() - Static method in class akka.cluster.MemberStatus
Java API: retrieve the &ldquo;leaving&rdquo; status singleton
Leaving_VALUE - Static variable in enum akka.cluster.protobuf.msg.ClusterMessages.MemberStatus
Leaving = 2;
len() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
len() - Method in class akka.util.ByteIterator
 
len() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
length() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
length() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
length() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
length() - Method in class akka.util.ByteString.ByteString1
 
length() - Method in class akka.util.ByteString.ByteString1C
 
length() - Method in class akka.util.ByteString.ByteStrings
 
length() - Method in class akka.util.ByteStringBuilder
 
length() - Method in class akka.util.Collections.EmptyImmutableSeq$
 
level() - Method in class akka.event.Logging.Debug
 
level() - Method in class akka.event.Logging.Error
 
level() - Method in class akka.event.Logging.Info
 
level() - Method in interface akka.event.Logging.LogEvent
The LogLevel of this LogEvent
level() - Method in class akka.event.Logging.Warning
 
leveldb() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
leveldbDir() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
leveldbFactory() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
LeveldbIdMapping - Interface in akka.persistence.journal.leveldb
INTERNAL API.
LeveldbJournal - Class in akka.persistence.journal.leveldb
INTERNAL API.
LeveldbJournal() - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal
 
leveldbOptions() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
leveldbReadOptions() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
LeveldbRecovery - Interface in akka.persistence.journal.leveldb
INTERNAL API.
leveldbSnapshot() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
LeveldbStore - Interface in akka.persistence.journal.leveldb
INTERNAL API.
leveldbWriteOptions() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
levelFor(String) - Method in class akka.event.Logging$
Returns the LogLevel associated with the given string, valid inputs are upper or lowercase (not mixed) versions of: "error", "warning", "info" and "debug"
levelFor(Class<? extends Logging.LogEvent>) - Method in class akka.event.Logging$
Returns the LogLevel associated with the given event class.
levelFor(String) - Static method in class akka.event.Logging
Returns the LogLevel associated with the given string, valid inputs are upper or lowercase (not mixed) versions of: "error", "warning", "info" and "debug"
levelFor(Class<? extends Logging.LogEvent>) - Static method in class akka.event.Logging
Returns the LogLevel associated with the given event class.
LightArrayRevolverScheduler - Class in akka.actor
This scheduler implementation is based on a revolving wheel of buckets, like Netty&rsquo;s HashedWheelTimer, which it advances at a fixed tick rate and dispatches tasks it finds in the current bucket to their respective ExecutionContexts.
LightArrayRevolverScheduler(com.typesafe.config.Config, LoggingAdapter, ThreadFactory) - Constructor for class akka.actor.LightArrayRevolverScheduler
 
LightArrayRevolverScheduler$ - Class in akka.actor
 
LightArrayRevolverScheduler$() - Constructor for class akka.actor.LightArrayRevolverScheduler$
 
LightArrayRevolverScheduler.TaskHolder - Class in akka.actor
INTERNAL API
LightArrayRevolverScheduler.TaskHolder(Runnable, int, ExecutionContext) - Constructor for class akka.actor.LightArrayRevolverScheduler.TaskHolder
 
LightArrayRevolverScheduler.TimerTask - Interface in akka.actor
INTERNAL API
limit(long) - Method in class akka.persistence.SnapshotSelectionCriteria
INTERNAL API.
lineSeparator() - Method in class akka.util.Crypt$
 
lineSeparator() - Static method in class akka.util.Crypt
 
Linger - Class in akka.zeromq
Configure this socket to have a linger of the specified value
Linger(long) - Constructor for class akka.zeromq.Linger
 
linger() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its linger configuration.
linger() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its linger configuration.
Linger$ - Class in akka.zeromq
Gets the linger option @see akka.zeromq.Linger
Linger$() - Constructor for class akka.zeromq.Linger$
 
linkedBlockingQueue() - Method in class akka.dispatch.ThreadPoolConfig$
 
linkedBlockingQueue(int) - Method in class akka.dispatch.ThreadPoolConfig$
 
linkedBlockingQueue() - Static method in class akka.dispatch.ThreadPoolConfig
 
linkedBlockingQueue(int) - Static method in class akka.dispatch.ThreadPoolConfig
 
listen() - Method in class akka.remote.transport.AbstractTransportAdapter
 
listen() - Method in class akka.remote.transport.netty.NettyTransport
 
listen() - Method in class akka.remote.transport.TestTransport
 
listen() - Method in interface akka.remote.transport.Transport
Asynchronously attempts to setup the transport layer to listen and accept incoming associations.
Listen - Class in akka.routing
 
Listen(ActorRef) - Constructor for class akka.routing.Listen
 
Listen$ - Class in akka.routing
 
Listen$() - Constructor for class akka.routing.Listen$
 
listenAddress() - Method in class akka.remote.transport.ActorTransportAdapter.ListenUnderlying
 
listenAddresses() - Method in class akka.remote.RemotingListenEvent
 
listenBehavior() - Method in class akka.remote.transport.TestTransport
The TestTransport.SwitchableLoggedBehavior for the listen() method.
listener() - Method in class akka.remote.transport.ActorTransportAdapter.ListenerRegistered
 
listener() - Method in class akka.remote.transport.ProtocolStateActor.HandleListenerRegistered
 
listener() - Method in class akka.remote.transport.ProtocolStateActor.ListenerReady
 
listener() - Method in class akka.remote.transport.ThrottlerManager.Listener
 
listener() - Method in class akka.remote.transport.ThrottlerManager.ListenerAndMode
 
listener() - Method in class akka.routing.Deafen
 
listener() - Method in class akka.routing.Listen
 
Listener - Class in akka.zeromq
An option containing the listener for the socket param: listener
Listener(ActorRef) - Constructor for class akka.zeromq.Listener
 
listener() - Method in class akka.zeromq.Listener
 
Listener$ - Class in akka.zeromq
 
Listener$() - Constructor for class akka.zeromq.Listener$
 
listenerManagement() - Method in interface akka.routing.Listeners
Chain this into the receive function.
ListenerMessage - Interface in akka.routing
 
Listeners - Interface in akka.routing
Listeners is a generic trait to implement listening capability on an Actor.
listeners() - Method in interface akka.routing.Listeners
 
LNil() - Method in class akka.dispatch.sysmsg.SystemMessageList$
 
LNil() - Static method in class akka.dispatch.sysmsg.SystemMessageList
 
load(String, com.typesafe.config.Config, ActorSystem) - Method in class akka.remote.FailureDetectorLoader$
Loads and instantiates a given FailureDetector implementation.
load(String, com.typesafe.config.Config, ActorSystem) - Static method in class akka.remote.FailureDetectorLoader
Loads and instantiates a given FailureDetector implementation.
loadAsync(String, SnapshotSelectionCriteria) - Method in class akka.persistence.snapshot.japi.SnapshotStore
 
loadAsync(String, SnapshotSelectionCriteria) - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
 
loadAsync(String, SnapshotSelectionCriteria) - Method in interface akka.persistence.snapshot.SnapshotStore
Plugin API: asynchronously loads a snapshot.
loader() - Method in class akka.actor.TypedProps
 
LoadMetrics - Interface in akka.dispatch
INTERNAL API
loadQueues() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
loadSnapshot(String, SnapshotSelectionCriteria, long) - Method in interface akka.persistence.Snapshotter
 
local() - Method in class akka.actor.Deploy$
 
local() - Static method in class akka.actor.Deploy
 
local() - Method in class akka.cluster.routing.ClusterRouterConfig
 
local() - Method in interface akka.cluster.routing.ClusterRouterConfigBase
 
local() - Method in class akka.cluster.routing.ClusterRouterGroup
 
local() - Method in class akka.cluster.routing.ClusterRouterPool
 
local() - Method in class akka.remote.routing.RemoteRouterConfig
 
LocalActorRef - Class in akka.actor
Local (serializable) ActorRef that is used when referencing the Actor on its "home" node.
LocalActorRef(ActorSystemImpl, Props, MessageDispatcher, MailboxType, InternalActorRef, ActorPath) - Constructor for class akka.actor.LocalActorRef
 
LocalActorRefProvider - Class in akka.actor
Local ActorRef provider.
LocalActorRefProvider(String, ActorSystem.Settings, EventStream, DynamicAccess, Deployer, Option<Function1<ActorPath, InternalActorRef>>) - Constructor for class akka.actor.LocalActorRefProvider
 
LocalActorRefProvider(String, ActorSystem.Settings, EventStream, DynamicAccess) - Constructor for class akka.actor.LocalActorRefProvider
 
LocalActorRefProvider$ - Class in akka.actor
 
LocalActorRefProvider$() - Constructor for class akka.actor.LocalActorRefProvider$
 
localAddress() - Method in class akka.io.Tcp.Bind
 
localAddress() - Method in class akka.io.Tcp.Bound
 
localAddress() - Method in class akka.io.Tcp.Connect
 
localAddress() - Method in class akka.io.Tcp.Connected
 
localAddress() - Method in class akka.io.TcpListener
 
localAddress() - Method in class akka.io.Udp.Bind
 
localAddress() - Method in class akka.io.Udp.Bound
 
localAddress() - Method in class akka.io.UdpConnected.Connect
 
localAddress() - Method in class akka.io.UdpListener
 
localAddress() - Method in class akka.remote.AssociatedEvent
 
localAddress() - Method in class akka.remote.AssociationErrorEvent
 
localAddress() - Method in interface akka.remote.AssociationEvent
 
localAddress() - Method in class akka.remote.DisassociatedEvent
 
localAddress() - Method in class akka.remote.EndpointActor
 
localAddress() - Method in class akka.remote.EndpointManager.Link
 
localAddress() - Method in exception akka.remote.HopelessAssociation
 
localAddress() - Method in exception akka.remote.InvalidAssociation
 
localAddress() - Method in class akka.remote.ReliableDeliverySupervisor
 
localAddress() - Method in exception akka.remote.ShutDownAssociation
 
localAddress() - Method in class akka.remote.transport.AbstractTransportAdapterHandle
 
localAddress() - Method in class akka.remote.transport.ActorTransportAdapterManager
 
localAddress() - Method in interface akka.remote.transport.AssociationHandle
Address of the local endpoint.
localAddress() - Method in class akka.remote.transport.netty.TcpAssociationHandle
 
localAddress() - Method in class akka.remote.transport.netty.UdpAssociationHandle
 
localAddress() - Method in class akka.remote.transport.ProtocolStateActor
 
localAddress() - Method in class akka.remote.transport.TestAssociationHandle
 
localAddress() - Method in class akka.remote.transport.TestTransport.AssociateAttempt
 
localAddress() - Method in class akka.remote.transport.TestTransport
 
localAddressForRemote(Address) - Method in class akka.remote.RemoteTransport
Resolves the correct local address to be used for contacting the given remote address
localAddressForRemote(Map<String, Set<Tuple2<AkkaProtocolTransport, Address>>>, Address) - Method in class akka.remote.Remoting$
 
localAddressForRemote(Address) - Method in class akka.remote.Remoting
 
localAddressToUse() - Method in class akka.remote.RemoteActorRef
 
localAffinity() - Method in class akka.contrib.pattern.ClusterClient.Send
 
localAffinity() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Send
 
LOCALAFFINITY_FIELD_NUMBER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
LocalRef - Interface in akka.actor
Refs which are statically known to be local inherit from this Scope
LocalScope - Class in akka.actor
 
LocalScope() - Constructor for class akka.actor.LocalScope
 
LocalScope$ - Class in akka.actor
The Local Scope is the default one, which is assumed on all deployments which do not set a different scope.
LocalScope$() - Constructor for class akka.actor.LocalScope$
 
LocalSnapshotStore - Class in akka.persistence.snapshot.local
INTERNAL API.
LocalSnapshotStore() - Constructor for class akka.persistence.snapshot.local.LocalSnapshotStore
 
lock() - Method in class akka.util.BoundedBlockingQueue
 
locked(Function0<T>) - Method in class akka.util.Switch
Executes the given code while holding this switch&rsquo;s lock, i.e.
log() - Method in interface akka.actor.ActorLogging
 
log() - Method in class akka.actor.ActorSystem
Convenient logging adapter for logging to the ActorSystem.eventStream.
log() - Method in class akka.actor.ActorSystemImpl
 
log() - Method in interface akka.actor.DiagnosticActorLogging
 
log() - Method in class akka.actor.LocalActorRefProvider
 
log() - Method in class akka.actor.VirtualPathContainer
 
log() - Method in class akka.camel.internal.DefaultCamel
 
log(Level, Throwable, Logging.LogEvent) - Method in class akka.contrib.jul.JavaLogger
 
log() - Method in interface akka.contrib.jul.JavaLogging
 
log(Level, Throwable, String) - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
log(Logging.LogLevel, String) - Method in interface akka.event.LoggingAdapter
Log message at the specified log level.
log(Logging.LogLevel, String, Object) - Method in interface akka.event.LoggingAdapter
Message template with 1 replacement argument.
log(Logging.LogLevel, String, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 2 replacement arguments.
log(Logging.LogLevel, String, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 3 replacement arguments.
log(Logging.LogLevel, String, Object, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 4 replacement arguments.
log() - Method in interface akka.event.slf4j.SLF4JLogging
 
log() - Method in class akka.remote.RemoteActorRefProvider
 
log() - Method in class akka.remote.RemoteTransport
A Logger that can be used to log issues that may occur
log() - Method in class akka.remote.Remoting
 
log() - Method in class akka.remote.testkit.MultiNodeSpec
 
log() - Method in class akka.serialization.Serialization
 
log() - Method in class akka.testkit.AkkaSpec
 
log() - Method in class akka.testkit.CallingThreadDispatcher
 
logActivity(TestTransport.Activity) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Logs a transport activity.
logActorForDeprecationWarning(ActorRef) - Method in class akka.remote.RemoteWatcher
 
LogBufferSizeExceeding() - Method in class akka.remote.RemoteSettings
 
logClass() - Method in class akka.event.BusLogging
 
logClass() - Method in class akka.event.Logging.Debug
 
logClass() - Method in class akka.event.Logging.Error
 
logClass() - Method in class akka.event.Logging.Info
 
logClass() - Method in interface akka.event.Logging.LogEvent
The class of the source of this event
logClass() - Method in class akka.event.Logging.Warning
 
LogConfigOnStart() - Method in class akka.actor.ActorSystem.Settings
 
logConfiguration() - Method in class akka.actor.ActorSystem
Log the configuration.
logConfiguration() - Method in class akka.actor.ActorSystemImpl
 
LogDeadLetters() - Method in class akka.actor.ActorSystem.Settings
 
LogDeadLettersDuringShutdown() - Method in class akka.actor.ActorSystem.Settings
 
logDebug(String, Object, Object) - Method in interface akka.contrib.pattern.ReliableProxyDebugLogging
 
logDebug(String, Object) - Method in interface akka.contrib.pattern.ReliableProxyDebugLogging
 
logDepth() - Method in interface akka.actor.LoggingFSM
 
logFailure(ActorContext, ActorRef, Throwable, SupervisorStrategy.Directive) - Method in class akka.actor.SupervisorStrategy
Default logging of actor failures when SupervisorStrategy.loggingEnabled() is true.
logFailure(ActorContext, ActorRef, Throwable, SupervisorStrategy.Directive) - Method in class akka.camel.internal.Registry.RegistryLogStrategy
 
logger() - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
Logger - Class in akka.event.slf4j
Logger is a factory for obtaining SLF4J-Loggers
Logger() - Constructor for class akka.event.slf4j.Logger
 
Logger$ - Class in akka.event.slf4j
Logger is a factory for obtaining SLF4J-Loggers
Logger$() - Constructor for class akka.event.slf4j.Logger$
 
loggerInitialized() - Method in class akka.event.Logging$
Java API to create a LoggerInitialized message.
loggerInitialized() - Static method in class akka.event.Logging
Java API to create a LoggerInitialized message.
Loggers() - Method in class akka.actor.ActorSystem.Settings
 
loggers() - Method in interface akka.event.LoggingBus
 
LoggerStartTimeout() - Method in class akka.actor.ActorSystem.Settings
 
Logging - Class in akka.event
Main entry point for Akka logging: log levels and message types (aka channels) defined for the main transport medium, the main event bus.
Logging() - Constructor for class akka.event.Logging
 
Logging$ - Class in akka.event
Main entry point for Akka logging: log levels and message types (aka channels) defined for the main transport medium, the main event bus.
Logging$() - Constructor for class akka.event.Logging$
 
Logging.Debug - Class in akka.event
For DEBUG Logging
Logging.Debug(String, Class<?>, Object) - Constructor for class akka.event.Logging.Debug
 
Logging.Debug$ - Class in akka.event
 
Logging.Debug$() - Constructor for class akka.event.Logging.Debug$
 
Logging.Debug2 - Class in akka.event
 
Logging.Debug2(String, Class<?>, Object, Map<String, Object>) - Constructor for class akka.event.Logging.Debug2
 
Logging.DefaultLogger - Class in akka.event
Actor wrapper around the standard output logger.
Logging.DefaultLogger() - Constructor for class akka.event.Logging.DefaultLogger
 
Logging.Error - Class in akka.event
For ERROR Logging
Logging.Error(Throwable, String, Class<?>, Object) - Constructor for class akka.event.Logging.Error
 
Logging.Error(String, Class<?>, Object) - Constructor for class akka.event.Logging.Error
 
Logging.Error$ - Class in akka.event
 
Logging.Error$() - Constructor for class akka.event.Logging.Error$
 
Logging.Error.NoCause$ - Class in akka.event
Null Object used for errors without cause Throwable
Logging.Error.NoCause$() - Constructor for class akka.event.Logging.Error.NoCause$
 
Logging.Error2 - Class in akka.event
 
Logging.Error2(Throwable, String, Class<?>, Object, Map<String, Object>) - Constructor for class akka.event.Logging.Error2
 
Logging.Error2(String, Class<?>, Object, Map<String, Object>) - Constructor for class akka.event.Logging.Error2
 
Logging.Error2$ - Class in akka.event
 
Logging.Error2$() - Constructor for class akka.event.Logging.Error2$
 
Logging.Extension$ - Class in akka.event
INTERNAL API
Logging.Extension$() - Constructor for class akka.event.Logging.Extension$
 
Logging.Info - Class in akka.event
For INFO Logging
Logging.Info(String, Class<?>, Object) - Constructor for class akka.event.Logging.Info
 
Logging.Info$ - Class in akka.event
 
Logging.Info$() - Constructor for class akka.event.Logging.Info$
 
Logging.Info2 - Class in akka.event
 
Logging.Info2(String, Class<?>, Object, Map<String, Object>) - Constructor for class akka.event.Logging.Info2
 
Logging.InitializeLogger - Class in akka.event
Message which is sent to each default logger (i.e.
Logging.InitializeLogger(LoggingBus) - Constructor for class akka.event.Logging.InitializeLogger
 
Logging.InitializeLogger$ - Class in akka.event
 
Logging.InitializeLogger$() - Constructor for class akka.event.Logging.InitializeLogger$
 
Logging.LogEvent - Interface in akka.event
Base type of LogEvents
Logging.LogEventException - Class in akka.event
Exception that wraps a LogEvent.
Logging.LogEventException(Logging.LogEvent, Throwable) - Constructor for class akka.event.Logging.LogEventException
 
Logging.LogExt - Class in akka.event
INTERNAL API
Logging.LogExt(ExtendedActorSystem) - Constructor for class akka.event.Logging.LogExt
 
Logging.LoggerException - Exception in akka.event
Artificial exception injected into Error events if no Throwable is supplied; used for getting a stack dump of error locations.
Logging.LoggerException() - Constructor for exception akka.event.Logging.LoggerException
 
Logging.LoggerInitializationException - Exception in akka.event
LoggerInitializationException is thrown to indicate that there was a problem initializing a logger param: msg
Logging.LoggerInitializationException(String) - Constructor for exception akka.event.Logging.LoggerInitializationException
 
Logging.LoggerInitialized - Class in akka.event
Response message each logger must send within 1 second after receiving the InitializeLogger request.
Logging.LoggerInitialized() - Constructor for class akka.event.Logging.LoggerInitialized
 
Logging.LoggerInitialized$ - Class in akka.event
 
Logging.LoggerInitialized$() - Constructor for class akka.event.Logging.LoggerInitialized$
 
Logging.LogLevel - Class in akka.event
Marker trait for annotating LogLevel, which must be Int after erasure.
Logging.LogLevel(int) - Constructor for class akka.event.Logging.LogLevel
 
Logging.LogLevel$ - Class in akka.event
 
Logging.LogLevel$() - Constructor for class akka.event.Logging.LogLevel$
 
Logging.StandardOutLogger - Class in akka.event
Actor-less logging implementation for synchronous logging to standard output.
Logging.StandardOutLogger() - Constructor for class akka.event.Logging.StandardOutLogger
 
Logging.StdOutLogger - Interface in akka.event
 
Logging.Warning - Class in akka.event
For WARNING Logging
Logging.Warning(String, Class<?>, Object) - Constructor for class akka.event.Logging.Warning
 
Logging.Warning$ - Class in akka.event
 
Logging.Warning$() - Constructor for class akka.event.Logging.Warning$
 
Logging.Warning2 - Class in akka.event
 
Logging.Warning2(String, Class<?>, Object, Map<String, Object>) - Constructor for class akka.event.Logging.Warning2
 
LoggingAdapter - Interface in akka.event
Logging wrapper to make nicer and optimize: provide template versions which evaluate .toString only if the log level is actually enabled.
LoggingBus - Interface in akka.event
This trait brings log level handling to the EventStream: it reads the log levels for the initial logging (StandardOutLogger) and the loggers & level for after-init logging, possibly keeping the StandardOutLogger enabled if it is part of the configured loggers.
loggingEnabled() - Method in class akka.actor.AllForOneStrategy
 
loggingEnabled() - Method in class akka.actor.OneForOneStrategy
 
loggingEnabled() - Method in class akka.actor.SupervisorStrategy
Logging of actor failures is done when this is true.
loggingExecutionContext() - Method in interface akka.contrib.jul.JavaLoggingAdapter
Override-able option for asynchronous logging
LoggingFSM<S,D> - Interface in akka.actor
Stackable trait for FSM which adds a rolling event log and debug logging capabilities (analogous to LoggingReceive).
LoggingReceive - Class in akka.event
This decorator adds invocation logging to a Receive function.
LoggingReceive(Option<Object>, PartialFunction<Object, BoxedUnit>, Option<String>, ActorContext) - Constructor for class akka.event.LoggingReceive
 
LoggingReceive(Option<Object>, PartialFunction<Object, BoxedUnit>, ActorContext) - Constructor for class akka.event.LoggingReceive
 
LoggingReceive$ - Class in akka.event
 
LoggingReceive$() - Constructor for class akka.event.LoggingReceive$
 
logic() - Method in class akka.routing.Router
 
logInfo(String) - Method in class akka.cluster.Cluster.InfoLogger$
 
logInfo(String, Object) - Method in class akka.cluster.Cluster.InfoLogger$
 
logInfo(String, Object, Object) - Method in class akka.cluster.Cluster.InfoLogger$
 
LogInfo() - Method in class akka.cluster.ClusterSettings
 
logInfo(String) - Method in class akka.contrib.pattern.ClusterSingletonManager
 
logInfo(String, Object) - Method in class akka.contrib.pattern.ClusterSingletonManager
 
logInfo(String, Object, Object) - Method in class akka.contrib.pattern.ClusterSingletonManager
 
LogLevel() - Method in class akka.actor.ActorSystem.Settings
 
logLevel() - Method in interface akka.event.LoggingBus
Query currently set log level.
logLevel() - Method in class akka.remote.AssociatedEvent
 
logLevel() - Method in class akka.remote.AssociationErrorEvent
 
logLevel() - Method in class akka.remote.DisassociatedEvent
 
logLevel() - Method in class akka.remote.QuarantinedEvent
 
logLevel() - Method in class akka.remote.RemotingErrorEvent
 
logLevel() - Method in interface akka.remote.RemotingLifecycleEvent
 
logLevel() - Method in class akka.remote.RemotingListenEvent
 
logLevel() - Method in class akka.remote.RemotingShutdownEvent$
 
logLevel() - Static method in class akka.remote.RemotingShutdownEvent
 
logMessage(org.osgi.service.log.LogService, Logging.LogEvent) - Method in class akka.osgi.DefaultOSGiLogger
Logs a message in an OSGi LogService
logPayloadBytes(Object, int) - Method in interface akka.remote.RemoteMetrics
Logging of the size of different message types.
logPayloadBytes(Object, int) - Method in class akka.remote.RemoteMetricsOff
 
logPayloadBytes(Object, int) - Method in class akka.remote.RemoteMetricsOn
 
LogReceive() - Method in class akka.remote.RemoteSettings
 
LogRemoteLifecycleEvents() - Method in class akka.remote.RemoteSettings
 
logRemoteLifeCycleEvents() - Method in class akka.remote.RemoteTransport
When this method returns true, RemoteLifeCycleEvents will be logged as well as be put onto the eventStream.
logRemoteLifeCycleEvents() - Method in class akka.remote.Remoting
 
logResend(int) - Method in class akka.contrib.pattern.ReliableProxy
 
LogSend() - Method in class akka.remote.RemoteSettings
 
logSnapshot() - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Takes a thread-safe snapshot of the current state of the activity log.
logSource() - Method in class akka.event.BusLogging
 
logSource() - Method in class akka.event.Logging.Debug
 
logSource() - Method in class akka.event.Logging.Error
 
logSource() - Method in class akka.event.Logging.Info
 
logSource() - Method in interface akka.event.Logging.LogEvent
The source of this event
logSource() - Method in class akka.event.Logging.Warning
 
LogSource<T> - Interface in akka.event
This trait defines the interface to be provided by a &ldquo;log source formatting rule&rdquo; as used by Logging&rsquo;s apply/create method.
LogSource$ - Class in akka.event
This object holds predefined formatting rules for log sources.
LogSource$() - Constructor for class akka.event.LogSource$
 
logTermination(FSM.Reason) - Method in interface akka.actor.FSM
By default FSM.Failure is logged at error level and other reason types are not logged.
logTermination(FSM.Reason) - Method in class akka.remote.transport.ProtocolStateActor
 
Long_VALUE - Static variable in enum akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberType
Long = 4;
LongRunningTest - Class in akka.testkit
 
LongRunningTest() - Constructor for class akka.testkit.LongRunningTest
 
LongRunningTest$ - Class in akka.testkit
 
LongRunningTest$() - Constructor for class akka.testkit.LongRunningTest$
 
longToTimeout(long) - Method in class akka.util.Timeout$
 
longToTimeout(long) - Static method in class akka.util.Timeout
 
lookup() - Method in class akka.actor.ActorDSL.Extension$
 
lookup(ActorPath) - Method in class akka.actor.Deployer
 
lookup(Iterable<String>) - Method in class akka.actor.Deployer
 
lookup(Iterator<String>) - Method in class akka.actor.Deployer
 
lookup() - Method in interface akka.actor.ExtensionIdProvider
Returns the canonical ExtensionId for this Extension
lookup() - Method in class akka.actor.ExtensionKey
 
lookup() - Method in class akka.actor.RepointableActorRef
 
lookup() - Method in class akka.actor.TypedActor$
 
lookup() - Static method in class akka.actor.TypedActor
 
lookup() - Method in class akka.camel.CamelExtension$
 
lookup() - Static method in class akka.camel.CamelExtension
 
lookup() - Method in class akka.cluster.Cluster$
 
lookup() - Static method in class akka.cluster.Cluster
 
lookup() - Method in class akka.contrib.mailbox.PeekMailboxExtension$
 
lookup() - Static method in class akka.contrib.mailbox.PeekMailboxExtension
 
lookup() - Method in class akka.contrib.pattern.ClusterReceptionistExtension$
 
lookup() - Static method in class akka.contrib.pattern.ClusterReceptionistExtension
 
lookup() - Method in class akka.contrib.pattern.ClusterSharding$
 
lookup() - Static method in class akka.contrib.pattern.ClusterSharding
 
lookup() - Method in class akka.contrib.pattern.DistributedPubSubExtension$
 
lookup() - Static method in class akka.contrib.pattern.DistributedPubSubExtension
 
lookup(String) - Method in class akka.dispatch.Dispatchers
Returns a dispatcher as specified in configuration.
lookup(String) - Method in class akka.dispatch.Mailboxes
Returns a mailbox type as specified in configuration, based on the id, or if not defined None.
lookup() - Method in class akka.event.AddressTerminatedTopic$
 
lookup() - Static method in class akka.event.AddressTerminatedTopic
 
lookup() - Method in class akka.io.Tcp$
 
lookup() - Static method in class akka.io.Tcp
 
lookup() - Method in class akka.io.Udp$
 
lookup() - Static method in class akka.io.Udp
 
lookup() - Method in class akka.io.UdpConnected$
 
lookup() - Static method in class akka.io.UdpConnected
 
lookup() - Method in class akka.persistence.Persistence$
 
lookup() - Static method in class akka.persistence.Persistence
 
lookup() - Method in class akka.remote.AddressUidExtension$
 
lookup() - Static method in class akka.remote.AddressUidExtension
 
lookup() - Method in class akka.remote.RARP$
 
lookup() - Static method in class akka.remote.RARP
 
lookup() - Method in class akka.remote.RemoteMetricsExtension$
 
lookup() - Static method in class akka.remote.RemoteMetricsExtension
 
lookup() - Method in class akka.remote.testconductor.TestConductor$
 
lookup() - Static method in class akka.remote.testconductor.TestConductor
 
lookup() - Method in class akka.remote.transport.TransportAdaptersExtension$
 
lookup() - Static method in class akka.remote.transport.TransportAdaptersExtension
 
lookup() - Method in class akka.serialization.SerializationExtension$
 
lookup() - Static method in class akka.serialization.SerializationExtension
 
lookup() - Method in class akka.testkit.CallingThreadDispatcherQueues$
 
lookup() - Static method in class akka.testkit.CallingThreadDispatcherQueues
 
lookup() - Method in class akka.transactor.TransactorExtension$
 
lookup() - Static method in class akka.transactor.TransactorExtension
 
lookup() - Method in class akka.zeromq.ZeroMQExtension$
 
lookup() - Static method in class akka.zeromq.ZeroMQExtension
 
lookupByQueueType(Class<?>) - Method in class akka.dispatch.Mailboxes
Returns a mailbox type as specified in configuration, based on the type, or if not defined None.
LookupClassification - Interface in akka.event
Maps Subscribers to Classifiers using equality on Classifier to store a Set of Subscribers (hence the need for compareSubscribers) Maps Events to Classifiers through the classify-method (so it knows who to publish to)
LookupEventBus<E,S,C> - Class in akka.event.japi
Java API: See documentation for LookupClassification E is the Event type S is the Subscriber type C is the Classifier type
LookupEventBus() - Constructor for class akka.event.japi.LookupEventBus
 
lookupRoot() - Method in class akka.actor.ActorCell
 
lookupRoot() - Method in interface akka.actor.ActorRefFactory
INTERNAL API
lookupRoot() - Method in class akka.actor.ActorSystemImpl
 
lowerBound() - Method in class akka.routing.DefaultResizer
 

M

mailbox() - Method in class akka.actor.Deploy
 
mailbox() - Method in interface akka.actor.dungeon.Dispatch
 
mailbox() - Method in class akka.actor.Props
Convenience method for extracting the mailbox information from the contained Deploy instance.
mailbox() - Method in interface akka.actor.StashSupport
INTERNAL API.
Mailbox - Class in akka.dispatch
Mailbox and InternalMailbox is separated in two classes because ActorCell is needed for implementation, but can't be exposed to user defined mailbox subclasses.
Mailbox(MessageQueue) - Constructor for class akka.dispatch.Mailbox
 
Mailbox$ - Class in akka.dispatch
INTERNAL API
Mailbox$() - Constructor for class akka.dispatch.Mailbox$
 
mailboxes() - Method in class akka.actor.ActorSystem
Helper object for looking up configured mailbox types.
mailboxes() - Method in class akka.actor.ActorSystemImpl
 
mailboxes() - Method in class akka.dispatch.DefaultDispatcherPrerequisites
 
mailboxes() - Method in interface akka.dispatch.DispatcherPrerequisites
 
Mailboxes - Class in akka.dispatch
 
Mailboxes(ActorSystem.Settings, EventStream, DynamicAccess, ActorRef) - Constructor for class akka.dispatch.Mailboxes
 
mailboxes() - Method in class akka.dispatch.MessageDispatcher
 
Mailboxes$ - Class in akka.dispatch
 
Mailboxes$() - Constructor for class akka.dispatch.Mailboxes$
 
mailboxType() - Method in class akka.actor.RepointableActorRef
 
MailboxType - Interface in akka.dispatch
MailboxType is a factory to create MessageQueues for an optionally provided ActorContext.
mailboxType() - Method in class akka.testkit.CallingThreadMailbox
 
main(String[]) - Method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper$
 
main(String[]) - Static method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper
 
Main - Class in akka.kernel
Main class for running the microkernel.
Main() - Constructor for class akka.kernel.Main
 
main(String[]) - Method in class akka.kernel.Main$
 
main(String[]) - Static method in class akka.kernel.Main
 
Main - Class in akka
Main class to start an ActorSystem with one top level application supervisor actor.
Main() - Constructor for class akka.Main
 
main(String[]) - Method in class akka.Main$
 
main(String[]) - Static method in class akka.Main
 
Main$ - Class in akka.kernel
Main class for running the microkernel.
Main$() - Constructor for class akka.kernel.Main$
 
Main$ - Class in akka
Main class to start an ActorSystem with one top level application supervisor actor.
Main$() - Constructor for class akka.Main$
 
Main.Terminator - Class in akka
 
Main.Terminator(ActorRef) - Constructor for class akka.Main.Terminator
 
maintainAddressTerminatedSubscription(ActorRef, Function0<T>) - Method in interface akka.actor.dungeon.DeathWatch
Starts subscription to AddressTerminated if not already subscribing and the block adds a non-local ref to watching or watchedBy.
major() - Method in class akka.zeromq.ZeroMQVersion
 
makeChild(ActorCell, Props, String, boolean, boolean) - Method in interface akka.actor.dungeon.Children
 
makeDecider(Seq<Class<? extends Throwable>>) - Method in class akka.actor.SupervisorStrategy$
Decider builder which just checks whether one of the given Throwables matches the cause and restarts, otherwise escalates.
makeDecider(Iterable<Class<? extends Throwable>>) - Method in class akka.actor.SupervisorStrategy$
Decider builder which just checks whether one of the given Throwables matches the cause and restarts, otherwise escalates.
makeDecider(Iterable<Tuple2<Class<? extends Throwable>, SupervisorStrategy.Directive>>) - Method in class akka.actor.SupervisorStrategy$
Decider builder for Iterables of cause-directive pairs, e.g.
makeDecider(Function<Throwable, SupervisorStrategy.Directive>) - Method in class akka.actor.SupervisorStrategy$
Converts a Java Decider into a Scala Decider
makeDecider(Seq<Class<? extends Throwable>>) - Static method in class akka.actor.SupervisorStrategy
Decider builder which just checks whether one of the given Throwables matches the cause and restarts, otherwise escalates.
makeDecider(Iterable<Class<? extends Throwable>>) - Static method in class akka.actor.SupervisorStrategy
Decider builder which just checks whether one of the given Throwables matches the cause and restarts, otherwise escalates.
makeDecider(Iterable<Tuple2<Class<? extends Throwable>, SupervisorStrategy.Directive>>) - Static method in class akka.actor.SupervisorStrategy
Decider builder for Iterables of cause-directive pairs, e.g.
makeDecider(Function<Throwable, SupervisorStrategy.Directive>) - Static method in class akka.actor.SupervisorStrategy
Converts a Java Decider into a Scala Decider
makePattern(String) - Method in class akka.util.Helpers$
 
makePattern(String) - Static method in class akka.util.Helpers
 
makeTransition(FSM.State<S, D>) - Method in interface akka.actor.FSM
 
managementCommand(Object) - Method in class akka.remote.RemoteTransport
Sends a management command to the underlying transport stack.
managementCommand(Object) - Method in class akka.remote.Remoting
 
managementCommand(Object) - Method in class akka.remote.transport.AkkaProtocolTransport
 
managementCommand(Object) - Method in class akka.remote.transport.FailureInjectorTransportAdapter
 
managementCommand(Object) - Method in class akka.remote.transport.ThrottlerTransportAdapter
 
managementCommand(Object) - Method in interface akka.remote.transport.Transport
This method allows upper layers to send management commands to the transport.
ManagementDispatcher() - Method in class akka.io.TcpExt.Settings
 
ManagementDispatcher() - Method in class akka.io.Udp.UdpSettings
 
manager() - Method in interface akka.io.IO.Extension
 
manager() - Method in class akka.io.TcpExt
 
manager() - Method in class akka.io.UdpConnectedExt
 
manager() - Method in class akka.io.UdpExt
 
manager() - Method in class akka.remote.transport.ActorTransportAdapter
 
manager() - Method in class akka.remote.transport.ThrottledAssociation
 
managerName() - Method in class akka.remote.transport.ActorTransportAdapter
 
managerName() - Method in class akka.remote.transport.AkkaProtocolTransport
 
managerName() - Method in class akka.remote.transport.ThrottlerTransportAdapter
 
managerProps() - Method in class akka.remote.transport.ActorTransportAdapter
 
managerProps() - Method in class akka.remote.transport.AkkaProtocolTransport
 
managerProps() - Method in class akka.remote.transport.ThrottlerTransportAdapter
 
manifest() - Method in class akka.persistence.serialization.SnapshotHeader
 
map(Function1<T, B>) - Method in class akka.agent.Agent
Map this agent to a new agent, applying the function to the internal state.
mapBody(Function1<A, B>) - Method in class akka.camel.CamelMessage
Returns a new CamelMessage with a transformed body using a transformer function.
mapBody(Mapper<A, B>) - Method in class akka.camel.CamelMessage
Java API: Returns a new CamelMessage with a transformed body using a transformer function.
mapI(Function1<Object, Object>) - Method in class akka.util.ByteString
map method that will automatically cast Int back into Byte.
Mapper<T,R> - Class in akka.dispatch
Callback for the Future.map and Future.flatMap operations that will be invoked if the Future that this callback is registered on becomes completed with a success.
Mapper() - Constructor for class akka.dispatch.Mapper
 
mappings() - Method in interface akka.event.ActorClassification
 
mapSize() - Method in interface akka.event.ActorClassification
This is a size hint for the number of Classifiers you expect to have (use powers of 2)
mapSize() - Method in class akka.event.japi.ActorEventBus
This is a size hint for the number of Classifiers you expect to have (use powers of 2)
mapSize() - Method in class akka.event.japi.LookupEventBus
This is a size hint for the number of Classifiers you expect to have (use powers of 2)
mapSize() - Method in interface akka.event.LookupClassification
This is a size hint for the number of Classifiers you expect to have (use powers of 2)
mapSize() - Method in class akka.util.Index
 
mapToConfig(Map<String, Object>) - Method in class akka.testkit.AkkaSpec$
 
mapToConfig(Map<String, Object>) - Static method in class akka.testkit.AkkaSpec
 
markAsFailed(ActorRef, Deadline) - Method in class akka.remote.EndpointManager.EndpointRegistry
Marking an endpoint as failed means that we will not try to connect to the remote system within the gated period but it is ok for the remote system to try to connect to us.
markAsQuarantined(Address, int, Deadline) - Method in class akka.remote.EndpointManager.EndpointRegistry
 
Marker() - Method in class akka.contrib.mailbox.PeekMailbox
 
match(Class<P>, FI.Apply<P, SupervisorStrategy.Directive>) - Static method in class akka.japi.pf.DeciderBuilder
Return a new PFBuilder with a case statement added.
match(Class<P>, FI.TypedPredicate<P>, FI.Apply<P, SupervisorStrategy.Directive>) - Static method in class akka.japi.pf.DeciderBuilder
Return a new PFBuilder with a case statement added.
Match<I,R> - Class in akka.japi.pf
Version of PartialFunction that can be built during runtime from Java.
match(Class<P>, FI.Apply<P, T>) - Static method in class akka.japi.pf.Match
Convenience function to create a PFBuilder with the first case statement added.
match(Class<P>, FI.TypedPredicate<P>, FI.Apply<P, T>) - Static method in class akka.japi.pf.Match
Convenience function to create a PFBuilder with the first case statement added.
match(I) - Method in class akka.japi.pf.Match
Convenience function to make the Java code more readable.
match(Class<P>, FI.Apply<P, R>) - Method in class akka.japi.pf.PFBuilder
Add a new case statement to this builder.
match(Class<P>, FI.TypedPredicate<P>, FI.Apply<P, R>) - Method in class akka.japi.pf.PFBuilder
Add a new case statement to this builder.
match(Class<P>, FI.UnitApply<P>) - Static method in class akka.japi.pf.ReceiveBuilder
Return a new UnitPFBuilder with a case statement added.
match(Class<P>, FI.TypedPredicate<P>, FI.UnitApply<P>) - Static method in class akka.japi.pf.ReceiveBuilder
Return a new UnitPFBuilder with a case statement added.
match(Class<P>, FI.UnitApply<P>) - Static method in class akka.japi.pf.UnitMatch
Convenience function to create a UnitPFBuilder with the first case statement added.
match(Class<P>, FI.TypedPredicate<P>, FI.UnitApply<P>) - Static method in class akka.japi.pf.UnitMatch
Convenience function to create a UnitPFBuilder with the first case statement added.
match(I) - Method in class akka.japi.pf.UnitMatch
Convenience function to make the Java code more readable.
match(Class<P>, FI.UnitApply<P>) - Method in class akka.japi.pf.UnitPFBuilder
Add a new case statement to this builder.
match(Class<P>, FI.TypedPredicate<P>, FI.UnitApply<P>) - Method in class akka.japi.pf.UnitPFBuilder
Add a new case statement to this builder.
match(A) - Method in class akka.testkit.CachingPartialFunction
 
match(Object) - Method in class akka.testkit.JavaTestKit.ExpectMsg
 
match(Object) - Method in class akka.testkit.JavaTestKit.ReceiveWhile
 
matchAny(FI.Apply<Object, SupervisorStrategy.Directive>) - Static method in class akka.japi.pf.DeciderBuilder
Return a new PFBuilder with a case statement added.
matchAny(FI.Apply<Object, T>) - Static method in class akka.japi.pf.Match
Convenience function to create a PFBuilder with the first case statement added.
matchAny(FI.Apply<Object, R>) - Method in class akka.japi.pf.PFBuilder
Add a new case statement to this builder, that matches any argument.
matchAny(FI.UnitApply<Object>) - Static method in class akka.japi.pf.ReceiveBuilder
Return a new UnitPFBuilder with a case statement added.
matchAny(FI.UnitApply<Object>) - Static method in class akka.japi.pf.UnitMatch
Convenience function to create a UnitPFBuilder with the first case statement added.
matchAny(FI.UnitApply<Object>) - Method in class akka.japi.pf.UnitPFBuilder
Add a new case statement to this builder, that matches any argument.
matchAnyEvent(FI.Apply2<Object, D, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
Create an FSMStateFunctionBuilder with the first case statement set.
matchData(Class<DT>, FI.UnitApply<DT>) - Method in class akka.actor.AbstractFSM
Create a UnitPFBuilder with the first case statement set.
matchData(Class<DT>, FI.TypedPredicate<DT>, FI.UnitApply<DT>) - Method in class akka.actor.AbstractFSM
Create a UnitPFBuilder with the first case statement set.
matchEquals(P, FI.Apply<P, T>) - Static method in class akka.japi.pf.Match
Convenience function to create a PFBuilder with the first case statement added.
matchEquals(P, FI.Apply<P, R>) - Method in class akka.japi.pf.PFBuilder
Add a new case statement to this builder.
matchEquals(P, FI.UnitApply<P>) - Static method in class akka.japi.pf.ReceiveBuilder
Return a new UnitPFBuilder with a case statement added.
matchEquals(P, FI.TypedPredicate<P>, FI.UnitApply<P>) - Static method in class akka.japi.pf.ReceiveBuilder
Return a new UnitPFBuilder with a case statement added.
matchEquals(P, FI.UnitApply<P>) - Static method in class akka.japi.pf.UnitMatch
Convenience function to create a UnitPFBuilder with the first case statement added.
matchEquals(P, FI.TypedPredicate<P>, FI.UnitApply<P>) - Static method in class akka.japi.pf.UnitMatch
Convenience function to create a UnitPFBuilder with the first case statement added.
matchEquals(P, FI.UnitApply<P>) - Method in class akka.japi.pf.UnitPFBuilder
Add a new case statement to this builder.
matchEquals(P, FI.TypedPredicate<P>, FI.UnitApply<P>) - Method in class akka.japi.pf.UnitPFBuilder
Add a new case statement to this builder.
MATCHER_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.Selection
 
matches(C, E) - Method in class akka.event.japi.ScanningEventBus
Returns whether the specified Classifier matches the specified Event
matches(ScanningClassification, ScanningClassification) - Method in interface akka.event.ScanningClassification
Returns whether the specified Classifier matches the specified Event
matches(SnapshotMetadata) - Method in class akka.persistence.SnapshotSelectionCriteria
INTERNAL API.
matches(Logging.LogEvent) - Method in class akka.testkit.CustomEventFilter
 
matches(Logging.LogEvent) - Method in class akka.testkit.DeadLettersFilter
 
matches(Logging.LogEvent) - Method in class akka.testkit.DebugFilter
 
matches(Logging.LogEvent) - Method in class akka.testkit.ErrorFilter
 
matches(Logging.LogEvent) - Method in class akka.testkit.EventFilter
This method decides whether to filter the event (true) or not (false).
matches(Logging.LogEvent) - Method in class akka.testkit.InfoFilter
 
matches(String) - Method in class akka.testkit.JavaTestKit.EventFilter
 
matches(Logging.LogEvent) - Method in class akka.testkit.WarningFilter
 
matchEvent(Class<ET>, Class<DT>, FI.TypedPredicate2<ET, DT>, FI.Apply2<ET, DT, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
Create an FSMStateFunctionBuilder with the first case statement set.
matchEvent(Class<ET>, Class<DT>, FI.Apply2<ET, DT, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
Create an FSMStateFunctionBuilder with the first case statement set.
matchEvent(Class<ET>, FI.TypedPredicate2<ET, D>, FI.Apply2<ET, D, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
Create an FSMStateFunctionBuilder with the first case statement set.
matchEvent(Class<ET>, FI.Apply2<ET, D, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
Create an FSMStateFunctionBuilder with the first case statement set.
matchEvent(FI.TypedPredicate2<Object, D>, FI.Apply2<Object, D, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
Create an FSMStateFunctionBuilder with the first case statement set.
matchEvent(List<Object>, Class<DT>, FI.Apply2<Object, DT, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
Create an FSMStateFunctionBuilder with the first case statement set.
matchEvent(List<Object>, FI.Apply2<Object, D, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
Create an FSMStateFunctionBuilder with the first case statement set.
matchEventEquals(E, Class<DT>, FI.Apply2<E, DT, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
Create an FSMStateFunctionBuilder with the first case statement set.
matchEventEquals(E, FI.Apply2<E, D, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
Create an FSMStateFunctionBuilder with the first case statement set.
matchingRole(Member) - Method in class akka.contrib.pattern.ClusterReceptionist
 
matchingRole(Member) - Method in class akka.contrib.pattern.ClusterSingletonProxy
 
matchingRole(Member) - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
matchingRole(Member) - Method in class akka.contrib.pattern.ShardRegion
 
matchState(S, S, FI.UnitApplyVoid) - Method in class akka.actor.AbstractFSM
Create an FSMTransitionHandlerBuilder with the first case statement set.
matchState(S, S, FI.UnitApply2<S, S>) - Method in class akka.actor.AbstractFSM
Create an FSMTransitionHandlerBuilder with the first case statement set.
matchStop(FSM.Reason, FI.UnitApply2<S, D>) - Method in class akka.actor.AbstractFSM
Create an FSMStopBuilder with the first case statement set.
matchStop(Class<RT>, FI.UnitApply3<RT, S, D>) - Method in class akka.actor.AbstractFSM
Create an FSMStopBuilder with the first case statement set.
matchStop(Class<RT>, FI.TypedPredicate<RT>, FI.UnitApply3<RT, S, D>) - Method in class akka.actor.AbstractFSM
Create an FSMStopBuilder with the first case statement set.
max() - Method in class akka.cluster.StandardMetrics.HeapMemory
 
max() - Method in class akka.persistence.journal.AsyncWriteTarget.ReplayMessages
 
max() - Method in class akka.persistence.JournalProtocol.ReplayMessages
 
MaxAge() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
maxAge() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
maxAge() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
maxBatchSizeReached() - Method in class akka.persistence.DeliveredByChannelBatching
 
maxBatchSizeReached() - Method in class akka.persistence.DeliveredByPersistentChannelBatching
 
maxCapacity() - Method in class akka.util.BoundedBlockingQueue
 
MaxChannels() - Method in class akka.io.SelectionHandlerSettings
 
MaxChannelsPerSelector() - Method in class akka.io.SelectionHandlerSettings
 
MaxChannelsPerSelector() - Method in class akka.io.TcpExt.Settings
 
MaxChannelsPerSelector() - Method in class akka.io.Udp.UdpSettings
 
maxConfirmationBatchSize() - Method in class akka.persistence.PersistenceSettings.journal
 
maxCount() - Method in class akka.event.DeadLetterListener
 
maxDeletionBatchSize() - Method in class akka.persistence.PersistenceSettings.journal
 
MaxDirectBufferPoolSize() - Method in class akka.io.TcpExt.Settings
 
MaxDirectBufferPoolSize() - Method in class akka.io.Udp.UdpSettings
 
MaxFrameSize() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
maxFrequency() - Method in class akka.actor.AbstractScheduler
The maximum supported task frequency of this scheduler, i.e.
maxFrequency() - Method in class akka.actor.LightArrayRevolverScheduler
 
maxFrequency() - Method in interface akka.actor.Scheduler
The maximum supported task frequency of this scheduler, i.e.
maximumOverhead() - Method in class akka.remote.transport.AbstractTransportAdapter
 
maximumOverhead() - Method in class akka.remote.transport.AkkaProtocolTransport
 
maximumOverhead() - Method in class akka.remote.transport.FailureInjectorTransportAdapter
 
maximumOverhead() - Method in class akka.remote.transport.ThrottlerTransportAdapter
 
maximumPayloadBytes() - Method in class akka.remote.transport.AbstractTransportAdapter
 
maximumPayloadBytes() - Method in class akka.remote.transport.netty.NettyTransport
 
maximumPayloadBytes() - Method in class akka.remote.transport.TestTransport
 
maximumPayloadBytes() - Method in interface akka.remote.transport.Transport
Defines the maximum size of payload this transport is able to deliver.
maxInstancesPerNode() - Method in class akka.cluster.routing.ClusterRouterPoolSettings
 
maxInstancesPerNode() - Method in class akka.cluster.routing.ClusterRouterSettings
 
MaxItems() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
maxItems() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
maxItems() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
MaxItemSize() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
maxItemSize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
maxItemSize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
MaxJournalOverflow() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
maxJournalOverflow() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
maxJournalOverflow() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
MaxJournalSize() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
maxJournalSize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
maxJournalSize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
MaxJournalSizeAbsolute() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
maxJournalSizeAbsolute() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
maxJournalSizeAbsolute() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
MaxMemorySize() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
maxMemorySize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
maxMemorySize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
maxMessageBatchSize() - Method in class akka.persistence.PersistenceSettings.journal
 
maxMessageSize() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its max message size configuration.
maxMessageSize() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its max message size configuration.
MaxMsgSize - Class in akka.zeromq
Limits the size of the inbound message.
MaxMsgSize(long) - Constructor for class akka.zeromq.MaxMsgSize
 
MaxMsgSize$ - Class in akka.zeromq
 
MaxMsgSize$() - Constructor for class akka.zeromq.MaxMsgSize$
 
maxNodes() - Method in class akka.remote.testkit.MultiNodeSpec$
Number of nodes node taking part in this test.
maxNodes() - Static method in class akka.remote.testkit.MultiNodeSpec
Number of nodes node taking part in this test.
maxNrOfRetries() - Method in class akka.actor.AllForOneStrategy
 
maxNrOfRetries() - Method in class akka.actor.OneForOneStrategy
 
maxNrOfRetriesCount() - Method in class akka.actor.ChildRestartStats
 
maxNrOfRetriesOption(int) - Method in class akka.actor.SupervisorStrategy$
 
maxNrOfRetriesOption(int) - Static method in class akka.actor.SupervisorStrategy
 
maxPoolSize() - Method in class akka.dispatch.ThreadPoolConfig
 
maxSampleSize() - Method in class akka.remote.HeartbeatHistory
 
maxSampleSize() - Method in class akka.remote.PhiAccrualFailureDetector
 
maxSeq() - Method in class akka.remote.AckedSendBuffer
 
maxSequenceNr() - Method in class akka.persistence.SnapshotSelectionCriteria
 
maxSilenceTimer() - Method in class akka.remote.ReliableDeliverySupervisor
 
MaxSize() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
maxSize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
maxSize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
maxTimestamp() - Method in class akka.persistence.SnapshotSelectionCriteria
 
maxUnconfirmedMessages() - Method in interface akka.persistence.AtLeastOnceDelivery
Maximum number of unconfirmed messages that this actor is allowed to hold in memory.
maxUnconfirmedMessages() - Method in class akka.persistence.PersistenceSettings.atLeastOnceDelivery
 
maxWriteCount() - Method in class akka.remote.EndpointWriter
 
md5(String) - Method in class akka.util.Crypt$
 
md5(byte[]) - Method in class akka.util.Crypt$
 
md5(String) - Static method in class akka.util.Crypt
 
md5(byte[]) - Static method in class akka.util.Crypt
 
mdc(Object) - Method in interface akka.actor.DiagnosticActorLogging
 
mdc() - Method in interface akka.event.DiagnosticLoggingAdapter
Scala API: Mapped Diagnostic Context for application defined values which can be used in PatternLayout when Slf4jLogger is configured.
mdc(Map<String, Object>) - Method in interface akka.event.DiagnosticLoggingAdapter
Scala API: Sets the values to be added to the MDC (Mapped Diagnostic Context) before the log is appended.
mdc() - Method in class akka.event.Logging.Debug2
 
mdc() - Method in class akka.event.Logging.Error2
 
mdc() - Method in class akka.event.Logging.Info2
 
mdc() - Method in interface akka.event.Logging.LogEvent
Extra values for adding to MDC
mdc() - Method in class akka.event.Logging.Warning2
 
mdc() - Method in interface akka.event.LoggingAdapter
 
mdcAkkaSourceAttributeName() - Method in class akka.event.slf4j.Slf4jLogger
 
mdcAkkaTimestamp() - Method in class akka.event.slf4j.Slf4jLogger
 
mdcThreadAttributeName() - Method in class akka.event.slf4j.Slf4jLogger
 
mean() - Method in class akka.remote.HeartbeatHistory
 
measure(Function1<Duration, String>, Function0<BoxedUnit>) - Method in interface akka.persistence.journal.JournalPerfSpec
Executes a block of code multiple times (no warmup)
measurementIterations() - Method in interface akka.persistence.journal.JournalPerfSpec
Number of measurement iterations each test will be run.
mediator() - Method in class akka.contrib.pattern.DistributedPubSubExtension
The DistributedPubSubMediator
MEGABYTE() - Method in class akka.actor.mailbox.filebased.filequeue.tools.Util$
 
MEGABYTE() - Static method in class akka.actor.mailbox.filebased.filequeue.tools.Util
 
member() - Method in interface akka.cluster.ClusterEvent.MemberEvent
 
member() - Method in class akka.cluster.ClusterEvent.MemberExited
 
member() - Method in class akka.cluster.ClusterEvent.MemberRemoved
 
member() - Method in class akka.cluster.ClusterEvent.MemberUp
 
member() - Method in class akka.cluster.ClusterEvent.ReachableMember
 
member() - Method in class akka.cluster.ClusterEvent.UnreachableMember
 
member(UniqueAddress) - Method in class akka.cluster.Gossip
 
Member - Class in akka.cluster
Represents the address, current status, and roles of a cluster member node.
Member(UniqueAddress, int, MemberStatus, Set<String>) - Constructor for class akka.cluster.Member
 
Member$ - Class in akka.cluster
Module with factory and ordering methods for Member instances.
Member$() - Constructor for class akka.cluster.Member$
 
members() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
 
members() - Method in class akka.cluster.ClusterReadView
Current cluster members, sorted by address.
members() - Method in class akka.cluster.Gossip
 
MEMBERS_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
membersByAge() - Method in class akka.contrib.pattern.ClusterSingletonProxy
 
membersByAge() - Method in class akka.contrib.pattern.ShardRegion
 
MemberStatus - Class in akka.cluster
Defines the current status of a cluster member node
MemberStatus() - Constructor for class akka.cluster.MemberStatus
 
MemberStatus$ - Class in akka.cluster
 
MemberStatus$() - Constructor for class akka.cluster.MemberStatus$
 
MemberStatus.Down$ - Class in akka.cluster
 
MemberStatus.Down$() - Constructor for class akka.cluster.MemberStatus.Down$
 
MemberStatus.Exiting$ - Class in akka.cluster
 
MemberStatus.Exiting$() - Constructor for class akka.cluster.MemberStatus.Exiting$
 
MemberStatus.Joining$ - Class in akka.cluster
 
MemberStatus.Joining$() - Constructor for class akka.cluster.MemberStatus.Joining$
 
MemberStatus.Leaving$ - Class in akka.cluster
 
MemberStatus.Leaving$() - Constructor for class akka.cluster.MemberStatus.Leaving$
 
MemberStatus.Removed$ - Class in akka.cluster
 
MemberStatus.Removed$() - Constructor for class akka.cluster.MemberStatus.Removed$
 
MemberStatus.Up$ - Class in akka.cluster
 
MemberStatus.Up$() - Constructor for class akka.cluster.MemberStatus.Up$
 
memoryBytes() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
memoryLength() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
Merge() - Method in class akka.cluster.ClusterCoreDaemon
 
merge(Gossip) - Method in class akka.cluster.Gossip
Merges two Gossip instances including membership tables, and the VectorClock histories.
merge(MetricsGossip) - Method in class akka.cluster.MetricsGossip
Adds new remote NodeMetrics and merges existing from a remote gossip.
merge(NodeMetrics) - Method in class akka.cluster.NodeMetrics
Returns the most recent data.
merge(Set<UniqueAddress>, Reachability) - Method in class akka.cluster.Reachability
 
merge(VectorClock) - Method in class akka.cluster.VectorClock
Merges this VectorClock with another VectorClock.
mergeAck(WireFormats.AcknowledgementInfo) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .AcknowledgementInfo ack = 1;
mergeAddr(TestConductorProtocol.Address) - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
optional .Address addr = 2;
mergeAddr(TestConductorProtocol.AddressRequest) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .AddressRequest addr = 5;
mergeAddress(ClusterMessages.Address) - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
required .Address address = 1;
mergeAddress(DistributedPubSubMessages.Address) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
required .Address address = 1;
mergeAddress(TestConductorProtocol.Address) - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
required .Address address = 2;
mergeAddress(TestConductorProtocol.Address) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
optional .Address address = 3;
mergeBarrier(TestConductorProtocol.EnterBarrier) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .EnterBarrier barrier = 2;
mergeConfirmMessage(MessageFormats.DeliveredMessage) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional .DeliveredMessage confirmMessage = 9;
mergeCount() - Method in class akka.cluster.GossipStats
 
mergeDeploy(WireFormats.DeployData) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .DeployData deploy = 2;
mergeDeploy(WireFormats.DeployData) - Method in class akka.remote.WireFormats.PropsData.Builder
required .DeployData deploy = 2;
mergeEnvelope(WireFormats.RemoteEnvelope) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .RemoteEnvelope envelope = 2;
mergeEwma(ClusterMessages.NodeMetrics.EWMA) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
optional .NodeMetrics.EWMA ewma = 3;
mergeFailure(TestConductorProtocol.InjectFailure) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .InjectFailure failure = 3;
mergeFrom(com.google.protobuf.Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
 
mergeFrom(AckedReceiveBuffer<T>) - Method in class akka.remote.AckedReceiveBuffer
Merges two receive buffers.
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.ContainerFormats.Selection.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.ContainerFormats.Selection.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.WireFormats.ActorRefData.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.WireFormats.ActorRefData.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.WireFormats.AddressData.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.WireFormats.AddressData.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.WireFormats.DeployData.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.WireFormats.DeployData.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.WireFormats.PropsData.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.WireFormats.PropsData.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
mergeGossip(ClusterMessages.MetricsGossip) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
required .MetricsGossip gossip = 2;
mergeGossip(ClusterMessages.Gossip) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
required .Gossip gossip = 2;
mergeHandshakeInfo(WireFormats.AkkaHandshakeInfo) - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
optional .AkkaHandshakeInfo handshakeInfo = 2;
mergeHello(TestConductorProtocol.Hello) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .Hello hello = 1;
mergeInstruction(WireFormats.AkkaControlMessage) - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
optional .AkkaControlMessage instruction = 2;
mergeMessage(WireFormats.SerializedMessage) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
required .SerializedMessage message = 2;
mergeNode(ClusterMessages.UniqueAddress) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
required .UniqueAddress node = 1;
mergeNumber(ClusterMessages.NodeMetrics.Number) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
required .NodeMetrics.Number number = 2;
mergeOrigin(WireFormats.AddressData) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
required .AddressData origin = 1;
mergeOverview(ClusterMessages.GossipOverview) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
required .GossipOverview overview = 5;
mergeOwner(DistributedPubSubMessages.Address) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
required .Address owner = 1;
mergePayload(DistributedPubSubMessages.Payload) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish.Builder
required .Payload payload = 3;
mergePayload(DistributedPubSubMessages.Payload) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
required .Payload payload = 3;
mergePayload(DistributedPubSubMessages.Payload) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
required .Payload payload = 3;
mergePayload(MessageFormats.PersistentPayload) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required .PersistentPayload payload = 3;
mergePayload(MessageFormats.PersistentPayload) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional .PersistentPayload payload = 1;
mergePersistent(MessageFormats.PersistentMessage) - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage.Builder
optional .PersistentMessage persistent = 1;
mergeProps(WireFormats.PropsData) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .PropsData props = 1;
mergeRecipient(WireFormats.ActorRefData) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
required .ActorRefData recipient = 1;
mergeSeen(Gossip) - Method in class akka.cluster.Gossip
Merges the seen table of two Gossip instances.
mergeSender(WireFormats.ActorRefData) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
optional .ActorRefData sender = 4;
mergeSupervisor(WireFormats.ActorRefData) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .ActorRefData supervisor = 4;
mergeTo(ClusterMessages.UniqueAddress) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
required .UniqueAddress to = 2;
mergeVersion(ClusterMessages.VectorClock) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
required .VectorClock version = 6;
mergeVersion(ClusterMessages.VectorClock) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
required .VectorClock version = 3;
message() - Method in exception akka.actor.ActorKilledException
 
message() - Method in interface akka.actor.AllDeadLetters
 
message() - Method in class akka.actor.DeadLetter
 
message() - Method in exception akka.actor.IllegalActorStateException
 
message() - Method in exception akka.actor.InvalidActorNameException
 
message() - Method in exception akka.actor.InvalidMessageException
 
message() - Method in class akka.actor.SuppressedDeadLetter
 
message() - Method in class akka.actor.UnhandledMessage
 
message() - Method in class akka.camel.MessageResult
 
message() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Internal$.MediatorRouterEnvelope
 
message() - Method in class akka.contrib.throttle.TimerBasedThrottler.Message
 
message() - Method in class akka.dispatch.Envelope
 
message() - Method in class akka.event.Logging.Debug
 
message() - Method in class akka.event.Logging.Error
 
message() - Method in class akka.event.Logging.Info
 
message() - Method in interface akka.event.Logging.LogEvent
The message, may be any object or null.
message() - Method in class akka.event.Logging.Warning
 
message() - Method in class akka.persistence.AtLeastOnceDelivery.Internal$.Delivery
 
message() - Method in class akka.persistence.AtLeastOnceDelivery.UnconfirmedDelivery
 
message() - Method in class akka.persistence.JournalProtocol.LoopMessage
 
message() - Method in class akka.persistence.JournalProtocol.LoopMessageSuccess
 
message() - Method in class akka.persistence.JournalProtocol.WriteMessageFailure
 
Message - Interface in akka.persistence.serialization
Marker trait for all protobuf-serializable messages in akka.persistence.
message() - Method in class akka.remote.EndpointManager.Send
 
message() - Method in class akka.routing.Broadcast
 
message() - Method in class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope
 
message() - Method in interface akka.routing.RouterEnvelope
 
message() - Method in class akka.testkit.DebugFilter
 
message() - Method in class akka.testkit.ErrorFilter
 
message() - Method in class akka.testkit.EventFilter
 
message() - Method in class akka.testkit.InfoFilter
 
message(String) - Method in class akka.testkit.JavaTestKit.EventFilter
 
message() - Method in class akka.testkit.WarningFilter
 
message() - Method in class akka.transactor.Coordinated
 
message() - Method in class akka.transactor.SendTo
 
MESSAGE_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.RemoteEnvelope
 
MESSAGE_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.SerializedMessage
 
messageClass() - Method in class akka.testkit.DeadLettersFilter
 
MessageContainerSerializer - Class in akka.remote.serialization
 
MessageContainerSerializer(ExtendedActorSystem) - Constructor for class akka.remote.serialization.MessageContainerSerializer
 
MessageDispatcher - Class in akka.dispatch
 
MessageDispatcher(MessageDispatcherConfigurator) - Constructor for class akka.dispatch.MessageDispatcher
 
MessageDispatcher$ - Class in akka.dispatch
INTERNAL API
MessageDispatcher$() - Constructor for class akka.dispatch.MessageDispatcher$
 
MessageDispatcherConfigurator - Class in akka.dispatch
Base class to be used for hooking in new dispatchers into Dispatchers.
MessageDispatcherConfigurator(com.typesafe.config.Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.MessageDispatcherConfigurator
 
MessageExchangeId() - Method in class akka.camel.CamelMessage$
CamelMessage header to correlate request with response messages.
MessageExchangeId() - Static method in class akka.camel.CamelMessage
CamelMessage header to correlate request with response messages.
messageFormat() - Method in class akka.osgi.DefaultOSGiLogger
 
MessageFormats - Class in akka.persistence.serialization
 
MessageFormats.AtLeastOnceDeliverySnapshot - Class in akka.persistence.serialization
Protobuf type AtLeastOnceDeliverySnapshot
MessageFormats.AtLeastOnceDeliverySnapshot.Builder - Class in akka.persistence.serialization
Protobuf type AtLeastOnceDeliverySnapshot
MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery - Class in akka.persistence.serialization
Protobuf type AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder - Class in akka.persistence.serialization
Protobuf type AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder - Interface in akka.persistence.serialization
 
MessageFormats.AtLeastOnceDeliverySnapshotOrBuilder - Interface in akka.persistence.serialization
 
MessageFormats.DeliveredMessage - Class in akka.persistence.serialization
Protobuf type DeliveredMessage
MessageFormats.DeliveredMessage.Builder - Class in akka.persistence.serialization
Protobuf type DeliveredMessage
MessageFormats.DeliveredMessageOrBuilder - Interface in akka.persistence.serialization
 
MessageFormats.DeliverMessage - Class in akka.persistence.serialization
Protobuf type DeliverMessage
MessageFormats.DeliverMessage.Builder - Class in akka.persistence.serialization
Protobuf type DeliverMessage
MessageFormats.DeliverMessageOrBuilder - Interface in akka.persistence.serialization
 
MessageFormats.PersistentMessage - Class in akka.persistence.serialization
Protobuf type PersistentMessage
MessageFormats.PersistentMessage.Builder - Class in akka.persistence.serialization
Protobuf type PersistentMessage
MessageFormats.PersistentMessageBatch - Class in akka.persistence.serialization
Protobuf type PersistentMessageBatch
MessageFormats.PersistentMessageBatch.Builder - Class in akka.persistence.serialization
Protobuf type PersistentMessageBatch
MessageFormats.PersistentMessageBatchOrBuilder - Interface in akka.persistence.serialization
 
MessageFormats.PersistentMessageOrBuilder - Interface in akka.persistence.serialization
 
MessageFormats.PersistentPayload - Class in akka.persistence.serialization
Protobuf type PersistentPayload
MessageFormats.PersistentPayload.Builder - Class in akka.persistence.serialization
Protobuf type PersistentPayload
MessageFormats.PersistentPayloadOrBuilder - Interface in akka.persistence.serialization
 
messageId() - Method in class akka.actor.Identify
 
messageIds() - Method in class akka.persistence.journal.AsyncWriteTarget.DeleteMessages
 
messageIds() - Method in class akka.persistence.JournalProtocol.DeleteMessages
 
messageIds() - Method in class akka.persistence.JournalProtocol.DeleteMessagesSuccess
 
MESSAGEMANIFEST_FIELD_NUMBER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
MESSAGEMANIFEST_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.SelectionEnvelope
 
MESSAGEMANIFEST_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.SerializedMessage
 
messageOption() - Method in exception akka.actor.PreRestartException
 
messagePredicate() - Method in class akka.actor.dsl.Inbox.InboxActor
 
messageQueue() - Method in class akka.dispatch.BalancingDispatcher
INTERNAL API
messageQueue() - Method in class akka.dispatch.Mailbox
 
MessageQueue - Interface in akka.dispatch
A MessageQueue is one of the core components in forming an Akka Mailbox.
messageQueue() - Method in class akka.testkit.CallingThreadMailbox
This is only a marker to be put in the messageQueue&rsquo;s stead to make error messages pertaining to violated mailbox type requirements less cryptic.
messageReceived(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.MessageEvent) - Method in class akka.remote.testconductor.ConductorHandler
 
messageReceived(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.MessageEvent) - Method in class akka.remote.testconductor.PlayerHandler
 
messageReceived(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.MessageEvent) - Method in interface akka.remote.transport.netty.NettyClientHelpers
 
messageReceived(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.MessageEvent) - Method in interface akka.remote.transport.netty.NettyServerHelpers
 
MessageResult - Class in akka.camel
INTERNAL API
MessageResult(CamelMessage) - Constructor for class akka.camel.MessageResult
 
MessageResult$ - Class in akka.camel
 
MessageResult$() - Constructor for class akka.camel.MessageResult$
 
messages() - Method in class akka.actor.dsl.Inbox.InboxActor
 
messages() - Method in class akka.persistence.journal.AsyncWriteTarget.WriteMessages
 
messages() - Method in interface akka.persistence.journal.inmem.InmemMessages
 
messages() - Method in class akka.persistence.JournalProtocol.WriteMessages
 
messages() - Method in class akka.persistence.RedeliverFailure
 
MessageSerializer - Class in akka.persistence.serialization
Protobuf serializer for PersistentBatch, PersistentRepr and Deliver messages.
MessageSerializer(ExtendedActorSystem) - Constructor for class akka.persistence.serialization.MessageSerializer
 
MessageSerializer - Class in akka.remote
INTERNAL API
MessageSerializer() - Constructor for class akka.remote.MessageSerializer
 
MessageSerializer$ - Class in akka.remote
INTERNAL API
MessageSerializer$() - Constructor for class akka.remote.MessageSerializer$
 
messagesPerResize() - Method in class akka.routing.DefaultResizer
 
metadata() - Method in class akka.persistence.SaveSnapshotFailure
 
metadata() - Method in class akka.persistence.SaveSnapshotSuccess
 
metadata() - Method in class akka.persistence.SelectedSnapshot
 
metadata() - Method in interface akka.persistence.snapshot.SnapshotStoreSpec
 
metadata() - Method in class akka.persistence.SnapshotOffer
 
metadata() - Method in class akka.persistence.SnapshotProtocol.DeleteSnapshot
 
metadata() - Method in class akka.persistence.SnapshotProtocol.SaveSnapshot
 
method() - Method in class akka.actor.TypedActor.MethodCall
 
methodName() - Method in class akka.actor.TypedActor.SerializedMethodCall
 
Metric - Class in akka.cluster
Metrics key/value.
Metric(String, Number, Option<EWMA>) - Constructor for class akka.cluster.Metric
 
metric(String) - Method in class akka.cluster.NodeMetrics
 
Metric$ - Class in akka.cluster
Factory for creating valid Metric instances.
Metric$() - Constructor for class akka.cluster.Metric$
 
MetricNumericConverter - Interface in akka.cluster
INTERNAL API
metrics() - Method in class akka.cluster.JmxMetricsCollector
 
metrics() - Method in class akka.cluster.NodeMetrics
 
metrics() - Method in class akka.cluster.SigarMetricsCollector
 
METRICS_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
metricsChanged(ClusterEvent.ClusterMetricsChanged) - Method in class akka.cluster.routing.AdaptiveLoadBalancingRoutingLogic
 
MetricsCollector - Interface in akka.cluster
Implementations of cluster system metrics extends this trait.
MetricsCollector$ - Class in akka.cluster
INTERNAL API Factory to create configured MetricsCollector.
MetricsCollector$() - Constructor for class akka.cluster.MetricsCollector$
 
MetricsCollectorClass() - Method in class akka.cluster.ClusterSettings
 
MetricsEnabled() - Method in class akka.cluster.ClusterSettings
 
MetricsGossip - Class in akka.cluster
 
MetricsGossip(Set<NodeMetrics>) - Constructor for class akka.cluster.MetricsGossip
 
MetricsGossip$ - Class in akka.cluster
INTERNAL API
MetricsGossip$() - Constructor for class akka.cluster.MetricsGossip$
 
MetricsGossipEnvelope - Class in akka.cluster
INTERNAL API Envelope adding a sender address to the gossip.
MetricsGossipEnvelope(Address, MetricsGossip, boolean) - Constructor for class akka.cluster.MetricsGossipEnvelope
 
MetricsGossipEnvelope$ - Class in akka.cluster
 
MetricsGossipEnvelope$() - Constructor for class akka.cluster.MetricsGossipEnvelope$
 
MetricsGossipInterval() - Method in class akka.cluster.ClusterSettings
 
MetricsInterval() - Method in class akka.cluster.ClusterSettings
 
MetricsMovingAverageHalfLife() - Method in class akka.cluster.ClusterSettings
 
metricsSelector() - Method in class akka.cluster.routing.AdaptiveLoadBalancingGroup
 
metricsSelector() - Method in class akka.cluster.routing.AdaptiveLoadBalancingPool
 
metricsSelector() - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
 
metricsSelector() - Method in class akka.cluster.routing.AdaptiveLoadBalancingRoutingLogic
 
MetricsSelector - Interface in akka.cluster.routing
A MetricsSelector is responsible for producing weights from the node metrics.
MetricsSelector$ - Class in akka.cluster.routing
 
MetricsSelector$() - Constructor for class akka.cluster.routing.MetricsSelector$
 
metricsTask() - Method in class akka.cluster.ClusterMetricsCollector
Start periodic metrics collection
MinimalActorRef - Interface in akka.actor
Trait for ActorRef implementations where all methods contain default stubs.
MinNrOfMembers() - Method in class akka.cluster.ClusterSettings
 
MinNrOfMembersOfRole() - Method in class akka.cluster.ClusterSettings
 
minor() - Method in class akka.zeromq.ZeroMQVersion
 
minStdDeviation() - Method in class akka.remote.PhiAccrualFailureDetector
 
MixMetricsSelector - Class in akka.cluster.routing
 
MixMetricsSelector(IndexedSeq<CapacityMetricsSelector>) - Constructor for class akka.cluster.routing.MixMetricsSelector
 
MixMetricsSelector$ - Class in akka.cluster.routing
Singleton instance of the default MixMetricsSelector, which uses [akka.cluster.routing.HeapMetricsSelector], [akka.cluster.routing.CpuMetricsSelector], and [akka.cluster.routing.SystemLoadAverageMetricsSelector]
MixMetricsSelector$() - Constructor for class akka.cluster.routing.MixMetricsSelector$
 
MixMetricsSelectorBase - Class in akka.cluster.routing
Base class for MetricsSelector that combines other selectors and aggregates their capacity.
MixMetricsSelectorBase(IndexedSeq<CapacityMetricsSelector>) - Constructor for class akka.cluster.routing.MixMetricsSelectorBase
 
MixMetricsSelectorBase(Iterable<CapacityMetricsSelector>) - Constructor for class akka.cluster.routing.MixMetricsSelectorBase
Java API: construct a mix-selector from a sequence of selectors
mkChild(Props, String) - Method in class akka.actor.ActorDSL.Extension
 
mkKey(ActorRef) - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
mkKey(ActorPath) - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
mkProps(Class<?>, Function0<Actor>) - Method in interface akka.actor.dsl.Creators
 
mode() - Method in class akka.persistence.journal.JournalPerfSpec.Cmd
 
mode() - Method in class akka.remote.transport.FailureInjectorTransportAdapter.All
 
mode() - Method in class akka.remote.transport.FailureInjectorTransportAdapter.One
 
mode() - Method in class akka.remote.transport.ThrottlerManager.ListenerAndMode
 
mode() - Method in class akka.remote.transport.ThrottlerTransportAdapter.SetThrottle
 
MODULE$ - Static variable in class akka.actor.AbstractActor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.AbstractFSM$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Actor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Actor.emptyBehavior$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorCell$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorDSL$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorDSL.Extension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorIdentity$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorInitializationException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorKilledException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorNotFound$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorPath$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorPathExtractor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorRef$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorSelection$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorSelectionMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorSystem$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Address$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.AddressFromURIString$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.AddressTerminated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.AllForOneStrategy$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ChildNameReserved$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ChildRestartStats$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ContextualTypedActorFactory$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.DeadLetter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.DeadLetterActorRef$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.DeathPactException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Deploy$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.dsl.Inbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.dsl.Inbox.Get$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.dsl.Inbox.Kick$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.dsl.Inbox.Select$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.dsl.Inbox.StartWatch$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer.Creation$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer.Recreation$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer.TerminatedChildrenContainer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer.Termination$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer.UserRequest$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.dungeon.ReceiveTimeout$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.FSM$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.FSM.$minus$greater$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.FSM.CurrentState$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.FSM.Event$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.FSM.Failure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.FSM.LogEntry$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.FSM.Normal$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.FSM.NullFunction$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.FSM.Shutdown$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.FSM.State$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.FSM.StateTimeout$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.FSM.StopEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.FSM.SubscribeTransitionCallBack$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.FSM.TimeoutMarker$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.FSM.Timer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.FSM.Transition$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.FSM.UnsubscribeTransitionCallBack$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Identify$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.IllegalActorStateException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Inbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.IndirectActorProducer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.InvalidActorNameException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.InvalidMessageException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Kill$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.LightArrayRevolverScheduler$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.LocalActorRefProvider$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.LocalScope$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.DurableExecutableMailboxConfig$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.DurableMailboxSpec$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.DurableMailboxSpecActorFactory$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.filebased.filequeue.BrokenItemException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.filebased.filequeue.JournalItem$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.filebased.filequeue.JournalItem.Add$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.filebased.filequeue.JournalItem.ConfirmRemove$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.filebased.filequeue.JournalItem.EndOfFile$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.filebased.filequeue.JournalItem.Remove$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.filebased.filequeue.JournalItem.RemoveTentative$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.filebased.filequeue.JournalItem.SavedXid$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.filebased.filequeue.JournalItem.Unremove$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.filebased.filequeue.QItem$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.filebased.filequeue.tools.QDumper$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.filebased.filequeue.tools.Util$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Nobody$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.NoScopeGiven$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.OneForOneStrategy$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.OriginalRestartException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.PoisonPill$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.PostRestartException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.PreRestartException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Props$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ReceiveTimeout$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.RelativeActorPath$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.RootActorPath$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.SchedulerException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.SelectChildName$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.SelectChildPattern$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.SelectParent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.SerializedActorRef$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.StashOverflowException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Status$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Status.Failure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Status.Success$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.StopChild$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.SupervisorStrategy$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.SupervisorStrategy.Escalate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.SupervisorStrategy.Restart$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.SupervisorStrategy.Resume$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.SupervisorStrategy.Stop$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.SuppressedDeadLetter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.SystemGuardian$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.SystemGuardian.RegisterTerminationHook$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.SystemGuardian.TerminationHook$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.SystemGuardian.TerminationHookDone$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Terminated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.TypedActor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.TypedActor.MethodCall$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.TypedActor.SerializedMethodCall$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.TypedActor.SerializedTypedActorInvocationHandler$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.TypedProps$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.UnhandledMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.agent.Agent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.Ack$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.CamelExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.CamelMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.Consumer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.ConsumerConfig$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.FailureResult$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.internal.ActivationProtocol$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.internal.ActivationProtocol.ActivationMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.internal.ActivationProtocol.EndpointActivated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.internal.ActivationProtocol.EndpointDeActivated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.internal.ActivationProtocol.EndpointFailedToActivate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.internal.ActivationProtocol.EndpointFailedToDeActivate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.internal.AwaitActivation$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.internal.AwaitDeActivation$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.internal.CamelSupervisor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.internal.CamelSupervisor.AddWatch$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.internal.CamelSupervisor.CamelProducerObjects$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.internal.CamelSupervisor.DeRegister$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.internal.CamelSupervisor.Register$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.internal.component.ActorEndpointPath$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.internal.component.CamelPath$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.internal.component.DurationTypeConverter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.MessageResult$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.AutoDown$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.AutoDown.UnreachableTimeout$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.Cluster$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterEvent.ClusterMetricsChanged$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterEvent.ClusterShuttingDown$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterEvent.CurrentClusterState$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterEvent.CurrentInternalStats$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterEvent.InitialStateAsEvents$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterEvent.InitialStateAsSnapshot$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterEvent.LeaderChanged$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterEvent.MemberExited$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterEvent.MemberRemoved$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterEvent.MemberUp$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterEvent.ReachabilityChanged$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterEvent.ReachableMember$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterEvent.RoleLeaderChanged$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterEvent.SeenChanged$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterEvent.UnreachableMember$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterHeartbeatSender$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterHeartbeatSender.ExpectedFirstHeartbeat$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterHeartbeatSender.Heartbeat$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterHeartbeatSender.HeartbeatRsp$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterHeartbeatSender.HeartbeatTick$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterHeartbeatSenderState$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterRemoteWatcher$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterScope$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterUserAction$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterUserAction.Down$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterUserAction.JoinTo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterUserAction.Leave$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.EWMA$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.Gossip$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.GossipEnvelope$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.GossipOverview$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.GossipStats$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.GossipStatus$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.HeartbeatNodeRing$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.InternalClusterAction$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.InternalClusterAction.AddOnMemberUpListener$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.InternalClusterAction.GetClusterCoreRef$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.InternalClusterAction.GossipSpeedupTick$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.InternalClusterAction.GossipTick$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.InternalClusterAction.InitJoin$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.InternalClusterAction.InitJoinAck$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.InternalClusterAction.InitJoinNack$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.InternalClusterAction.Join$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.InternalClusterAction.JoinSeedNode$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.InternalClusterAction.JoinSeedNodes$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.InternalClusterAction.LeaderActionsTick$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.InternalClusterAction.MetricsTick$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.InternalClusterAction.PublishChanges$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.InternalClusterAction.PublishCurrentClusterState$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.InternalClusterAction.PublisherCreated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.InternalClusterAction.PublishEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.InternalClusterAction.PublishStatsTick$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.InternalClusterAction.ReapUnreachableTick$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.InternalClusterAction.SendGossipTo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.InternalClusterAction.Subscribe$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.InternalClusterAction.Unsubscribe$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.InternalClusterAction.Welcome$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.Member$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.MemberStatus$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.MemberStatus.Down$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.MemberStatus.Exiting$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.MemberStatus.Joining$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.MemberStatus.Leaving$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.MemberStatus.Removed$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.MemberStatus.Up$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.Metric$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.MetricsCollector$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.MetricsGossip$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.MetricsGossipEnvelope$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.NodeMetrics$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.Reachability$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.Reachability.Reachable$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.Reachability.Record$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.Reachability.Terminated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.Reachability.Unreachable$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.AdaptiveLoadBalancingGroup$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.AdaptiveLoadBalancingPool$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.AdaptiveLoadBalancingRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.AdaptiveLoadBalancingRoutingLogic$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.ClusterRouterConfig$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.ClusterRouterGroup$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.ClusterRouterGroupSettings$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.ClusterRouterPool$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.ClusterRouterPoolSettings$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.ClusterRouterSettings$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.ClusterRouterSettingsBase$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.CpuMetricsSelector$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.HeapMetricsSelector$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.MetricsSelector$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.MixMetricsSelector$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.SystemLoadAverageMetricsSelector$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.StandardMetrics$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.StandardMetrics.Cpu$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.StandardMetrics.HeapMemory$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.UniqueAddress$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.VectorClock$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.VectorClock.After$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.VectorClock.Before$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.VectorClock.Concurrent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.VectorClock.Node$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.VectorClock.Same$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.VectorClock.Timestamp$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.VectorClockStats$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.mailbox.PeekMailboxExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ClusterClient$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ClusterClient.Internal$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ClusterClient.Publish$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ClusterClient.Send$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ClusterClient.SendToAll$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ClusterReceptionist$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ClusterReceptionist.Internal$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ClusterReceptionistExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ClusterSharding$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ClusterShardingGuardian$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ClusterShardingGuardian.Start$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ClusterShardingGuardian.Started$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ClusterSingletonManager$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ClusterSingletonProxy$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.DistributedPubSubExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.DistributedPubSubMediator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.DistributedPubSubMediator.Count$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.DistributedPubSubMediator.Internal$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.DistributedPubSubMediator.Publish$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.DistributedPubSubMediator.Put$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.DistributedPubSubMediator.Remove$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.DistributedPubSubMediator.Send$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.DistributedPubSubMediator.SendToAll$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.DistributedPubSubMediator.Subscribe$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.DistributedPubSubMediator.SubscribeAck$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.DistributedPubSubMediator.Unsubscribe$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.DistributedPubSubMediator.UnsubscribeAck$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ReliableProxy$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ReliableProxy.Active$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ReliableProxy.Connecting$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ReliableProxy.Idle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ReliableProxy.Message$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ReliableProxy.ProxyTerminated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ReliableProxy.TargetChanged$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ReliableProxy.Unsent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ShardCoordinator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ShardCoordinator.Internal$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ShardCoordinatorSupervisor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ShardRegion$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ShardRegion.Passivate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.WorkList$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.throttle.Throttler$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.throttle.Throttler.Rate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.throttle.Throttler.RateInt$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.throttle.Throttler.SetRate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.throttle.Throttler.SetTarget$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.throttle.TimerBasedThrottler$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.throttle.TimerBasedThrottler.Active$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.throttle.TimerBasedThrottler.Data$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.throttle.TimerBasedThrottler.Idle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.throttle.TimerBasedThrottler.Message$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.throttle.TimerBasedThrottler.Tick$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.BalancingDispatcherConfigurator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.BoundedDequeBasedMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.BoundedMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.BoundedPriorityMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.CachingConfig$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.CachingConfig.StringPathEntry$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.CachingConfig.ValuePathEntry$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.DefaultDispatcherPrerequisites$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.Dispatchers$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.Envelope$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.ExecutionContexts$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.ExecutionContexts.sameThreadExecutionContext$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.Filter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.ForkJoinExecutorConfigurator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.Futures$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.japi$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.Mailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.Mailboxes$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.MessageDispatcher$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.MonitorableThreadFactory$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.PriorityGenerator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.SingleConsumerOnlyUnboundedMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.Create$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.DeathWatchNotification$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.EarliestFirstSystemMessageList$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.Failed$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.LatestFirstSystemMessageList$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.NoMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.Recreate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.Resume$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.Supervise$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.Suspend$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.SystemMessageList$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.Terminate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.Unwatch$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.Watch$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.TaskInvocation$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.ThreadPoolConfig$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.ThreadPoolConfigBuilder$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.UnboundedDequeBasedMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.UnboundedMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.UnboundedPriorityMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.AddressTerminatedTopic$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.EventStream$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.Logging$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.Logging.Debug$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.Logging.Error$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.Logging.Error.NoCause$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.Logging.Error2$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.Logging.Extension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.Logging.Info$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.Logging.InitializeLogger$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.Logging.LoggerInitialized$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.Logging.LogLevel$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.Logging.Warning$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.LoggingReceive$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.LogSource$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.NoLogging$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.slf4j.Logger$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Inet$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Inet.SO$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.IO$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.SelectionHandler$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.SelectionHandler.ChannelAcceptable$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.SelectionHandler.ChannelConnectable$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.SelectionHandler.ChannelReadable$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.SelectionHandler.ChannelWritable$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.SelectionHandler.Retry$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.SelectionHandler.WorkerForCommand$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.Abort$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.Aborted$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.Bind$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.Bound$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.Close$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.Closed$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.CommandFailed$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.CompoundWrite$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.ConfirmedClose$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.ConfirmedClosed$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.Connect$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.Connected$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.ErrorClosed$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.NoAck$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.PeerClosed$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.Received$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.Register$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.ResumeAccepting$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.ResumeReading$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.ResumeWriting$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.SO$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.SuspendReading$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.Unbind$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.Unbound$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.Write$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.WriteCommand$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.WriteFile$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp.WritingResumed$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.TcpConnection$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.TcpConnection.AllRead$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.TcpConnection.CloseInformation$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.TcpConnection.ConnectionInfo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.TcpConnection.EmptyPendingWrite$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.TcpConnection.EndOfStream$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.TcpConnection.MoreDataWaiting$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.TcpConnection.UpdatePendingWriteAndThen$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.TcpConnection.WriteFileFailed$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.TcpListener$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.TcpListener.FailedRegisterIncoming$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.TcpListener.RegisterIncoming$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.TcpMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.TcpSO$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Udp$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Udp.Bind$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Udp.Bound$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Udp.CommandFailed$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Udp.NoAck$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Udp.Received$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Udp.ResumeReading$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Udp.Send$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Udp.SimpleSender$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Udp.SimpleSenderReady$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Udp.SO$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Udp.SuspendReading$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Udp.Unbind$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Udp.Unbound$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.UdpConnected$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.UdpConnected.CommandFailed$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.UdpConnected.Connect$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.UdpConnected.Connected$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.UdpConnected.Disconnect$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.UdpConnected.Disconnected$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.UdpConnected.NoAck$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.UdpConnected.Received$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.UdpConnected.ResumeReading$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.UdpConnected.Send$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.UdpConnected.SuspendReading$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.UdpConnectedMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.UdpMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.UdpSO$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.JavaPartialFunction$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in exception akka.japi.JavaPartialFunction.NoMatch$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.Option$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.Option.Some$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.Pair$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.pf.CaseStatement$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.tuple.Tuple10$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.tuple.Tuple11$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.tuple.Tuple12$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.tuple.Tuple13$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.tuple.Tuple14$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.tuple.Tuple15$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.tuple.Tuple16$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.tuple.Tuple17$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.tuple.Tuple18$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.tuple.Tuple19$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.tuple.Tuple20$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.tuple.Tuple21$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.tuple.Tuple22$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.tuple.Tuple3$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.tuple.Tuple4$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.tuple.Tuple5$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.tuple.Tuple6$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.tuple.Tuple7$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.tuple.Tuple8$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.tuple.Tuple9$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.Util$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.kernel.Main$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.Main$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.osgi.BundleDelegatingClassLoader$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.osgi.OsgiActorSystemFactory$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.osgi.UnregisteringLogService$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.pattern.AskableActorRef$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.pattern.AskableActorSelection$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.pattern.CircuitBreaker$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.pattern.CircuitBreakerOpenException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.pattern.Patterns$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.pattern.PromiseActorRef$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.AtLeastOnceDelivery$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.AtLeastOnceDelivery.Internal$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.AtLeastOnceDelivery.UnconfirmedDelivery$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.AtLeastOnceDelivery.UnconfirmedWarning$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.Channel$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.ChannelSettings$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.ConfirmablePersistent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.ConfirmablePersistentImpl$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.Deliver$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.DeliveredByChannel$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.DeliveredByPersistentChannel$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteJournal$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteJournal.Desequenced$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteProxy$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteProxy.SetStore$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteTarget$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteTarget.DeleteMessages$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteTarget.DeleteMessagesTo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteTarget.ReadHighestSequenceNr$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteTarget.ReplayFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteTarget.ReplayMessages$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteTarget.ReplaySuccess$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteTarget.WriteConfirmations$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteTarget.WriteMessages$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.JournalPerfSpec$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.JournalPerfSpec.Cmd$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.JournalPerfSpec.ResetCounter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.JournalSpec$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.JournalSpec.Confirmation$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.leveldb.Key$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.leveldb.SharedLeveldbJournal$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.DeleteMessages$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.DeleteMessagesFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.DeleteMessagesSuccess$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.DeleteMessagesTo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.LoopMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.LoopMessageSuccess$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.ReadHighestSequenceNr$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.ReadHighestSequenceNrFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.ReadHighestSequenceNrSuccess$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.ReplayedMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.ReplayMessages$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.ReplayMessagesFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.ReplayMessagesSuccess$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.WriteConfirmations$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.WriteConfirmationsFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.WriteConfirmationsSuccess$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.WriteMessageFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.WriteMessages$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.WriteMessagesFailed$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.WriteMessagesSuccessful$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.WriteMessageSuccess$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.NonPersistentRepr$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.Persistence$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.PersistenceFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.Persistent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.PersistentBatch$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.PersistentChannel$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.PersistentChannelSettings$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.PersistentIdImpl$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.PersistentImpl$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.PersistentRepr$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.ProcessorImpl$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.Recover$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.RecoveryCompleted$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.RecoveryFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.RedeliverFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.ReliableDelivery$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.ReliableDelivery.DeliveryAttempt$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.ReliableDelivery.Redeliver$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.RequestWriter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.RequestWriter.RequestsWritten$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.Reset$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.SaveSnapshotFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.SaveSnapshotSuccess$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.SelectedSnapshot$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.serialization.Snapshot$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.serialization.SnapshotHeader$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.serialization.SnapshotSerializer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.snapshot.SnapshotStoreSpec$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.SnapshotMetadata$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.SnapshotOffer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.SnapshotProtocol$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.SnapshotProtocol.DeleteSnapshot$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.SnapshotProtocol.DeleteSnapshots$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.SnapshotProtocol.LoadSnapshot$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.SnapshotProtocol.LoadSnapshotResult$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.SnapshotProtocol.SaveSnapshot$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.SnapshotSelectionCriteria$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.Update$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.Ack$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.AckedReceiveBuffer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.AckedSendBuffer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.AddressUidExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.AddressUrlEncoder$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.AssociatedEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.AssociationErrorEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.DaemonMsgCreate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.DisassociatedEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.Gated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.Link$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.Listen$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.ListensFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.ListensResult$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.ManagementCommand$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.ManagementCommandAck$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.Pass$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.Prune$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.Quarantine$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.Quarantined$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.ResendState$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.Send$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.ShutdownAndFlush$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.StartupFinished$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointReader$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointWriter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointWriter.AckIdleCheckTimer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointWriter.BackoffTimer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointWriter.FlushAndStop$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointWriter.Handle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointWriter.OutboundAck$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointWriter.StoppedReading$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointWriter.StopReading$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointWriter.TakeOver$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointWriter.TookOver$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.FailureDetector$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.FailureDetectorLoader$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.HasSequenceNumber$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.HeartbeatHistory$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.HopelessAssociation$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.InvalidAssociation$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.MessageSerializer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.QuarantinedEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RARP$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.ReliableDeliverySupervisor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.ReliableDeliverySupervisor.AttemptSysMsgRedelivery$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.ReliableDeliverySupervisor.GotUid$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.ReliableDeliverySupervisor.Idle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.ReliableDeliverySupervisor.IsIdle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.ReliableDeliverySupervisor.TooLongIdle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.ReliableDeliverySupervisor.Ungate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteActorRefProvider$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteActorRefProvider.Finished$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteActorRefProvider.Idle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteActorRefProvider.Uninitialized$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteActorRefProvider.WaitDaemonShutdown$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteActorRefProvider.WaitTransportShutdown$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteDeploymentWatcher$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteDeploymentWatcher.WatchRemote$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteMetricsExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteScope$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteWatcher$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteWatcher.ExpectedFirstHeartbeat$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteWatcher.Heartbeat$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteWatcher.HeartbeatRsp$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteWatcher.HeartbeatTick$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteWatcher.ReapUnreachableTick$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteWatcher.RewatchRemote$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteWatcher.Stats$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteWatcher.UnwatchRemote$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteWatcher.WatchRemote$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.Remoting$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.Remoting.RegisterTransportActor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemotingErrorEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemotingListenEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemotingShutdownEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.routing.RemoteRouterConfig$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.security.provider.AkkaProvider$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.security.provider.InternetSeedGenerator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.security.provider.SeedSize$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.SeqNo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.serialization.ProtobufSerializer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.ShutDownAssociation$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.AddressReply$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.BarrierCoordinator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.BarrierCoordinator.BarrierEmpty$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.BarrierCoordinator.BarrierTimeout$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.BarrierCoordinator.ClientLost$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.BarrierCoordinator.Data$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.BarrierCoordinator.DuplicateNode$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.BarrierCoordinator.FailedBarrier$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.BarrierCoordinator.Idle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.BarrierCoordinator.RemoveClient$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.BarrierCoordinator.Waiting$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.BarrierCoordinator.WrongBarrier$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.BarrierResult$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.Client$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.ClientFSM$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.ClientFSM.AwaitDone$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.ClientFSM.Connected$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.ClientFSM.Connecting$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.ClientFSM.ConnectionFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.ClientFSM.Data$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.ClientFSM.Disconnected$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.ClientFSM.Failed$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.Controller$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.Controller.ClientDisconnected$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.Controller.CreateServerFSM$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.Controller.GetNodes$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.Controller.GetSockAddr$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.Controller.NodeInfo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.Disconnect$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.DisconnectMsg$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.Done$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.EnterBarrier$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.FailBarrier$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.GetAddress$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.Hello$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.RemoteConnection$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.Remove$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.RoleName$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.Server$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.ServerFSM$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.ServerFSM.Initial$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.ServerFSM.Ready$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.Terminate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.TerminateMsg$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.TestConductor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.Throttle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.ThrottleMsg$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.ToClient$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.ToServer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testkit.MultiNodeSpec$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ActorTransportAdapter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ActorTransportAdapter.AssociateUnderlying$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ActorTransportAdapter.DisassociateUnderlying$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ActorTransportAdapter.ListenerRegistered$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ActorTransportAdapter.ListenUnderlying$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AkkaPduCodec$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AkkaPduCodec.Associate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AkkaPduCodec.Disassociate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AkkaPduCodec.Heartbeat$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AkkaPduCodec.Message$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AkkaPduCodec.Payload$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AkkaPduProtobufCodec$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AkkaProtocolTransport$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AkkaProtocolTransport.AssociateUnderlyingRefuseUid$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AssociationHandle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AssociationHandle.ActorHandleEventListener$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AssociationHandle.Disassociated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AssociationHandle.InboundPayload$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AssociationHandle.Quarantined$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AssociationHandle.Shutdown$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AssociationHandle.Unknown$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AssociationRegistry$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.FailureInjectorException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.FailureInjectorHandle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.FailureInjectorTransportAdapter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.FailureInjectorTransportAdapter.All$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.FailureInjectorTransportAdapter.Drop$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.FailureInjectorTransportAdapter.One$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.FailureInjectorTransportAdapter.PassThru$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.HandshakeInfo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.netty.ChannelLocalActor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.netty.NettyFutureBridge$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.netty.NettySSLSupport$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.netty.NettyTransport$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.netty.NettyTransportSettings$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.netty.NettyTransportSettings.Tcp$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.netty.NettyTransportSettings.Udp$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.AssociatedWaitHandler$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.Closed$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.ForbiddenUidReason$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.Handle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.HandleListenerRegistered$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.HandshakeTimer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.HeartbeatTimer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.InboundUnassociated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.ListenerReady$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.Open$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.OutboundUnassociated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.OutboundUnderlyingAssociated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.TimeoutReason$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.WaitHandshake$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.TestAssociationHandle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.TestTransport$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.TestTransport.AssociateAttempt$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.TestTransport.DisassociateAttempt$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.TestTransport.ListenAttempt$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.TestTransport.ShutdownAttempt$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.TestTransport.WriteAttempt$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.Dequeue$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.ExposedHandle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.FailWith$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.Throttling$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.Uninitialized$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.WaitExposedHandle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.WaitMode$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.WaitModeAndUpstreamListener$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.WaitOrigin$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.WaitUpstreamListener$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerHandle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerManager$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerManager.AssociateResult$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerManager.Checkin$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerManager.Handle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerManager.Listener$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerManager.ListenerAndMode$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.Blackhole$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.Direction$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Both$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Receive$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Send$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociateAck$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociateExplicitly$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.SetThrottle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.SetThrottleAck$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.Unthrottled$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.Transport$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.Transport.ActorAssociationEventListener$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.Transport.InboundAssociation$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.Transport.InvalidAssociationException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.TransportAdaptersExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ActorRefRoutee$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ActorSelectionRoutee$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.AddRoutee$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.AdjustPoolSize$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.BalancingPool$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.BalancingRoutingLogic$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.Broadcast$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.BroadcastGroup$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.BroadcastPool$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.BroadcastRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.BroadcastRoutingLogic$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ConsistentActorRef$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ConsistentHash$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ConsistentHashingGroup$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ConsistentHashingPool$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ConsistentHashingRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ConsistentHashingRouter.emptyConsistentHashMapping$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ConsistentHashingRoutingLogic$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ConsistentRoutee$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.CurrentRoutees$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.Deafen$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.DefaultResizer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.FromConfig$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.GetRoutees$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.Listen$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.MurmurHash$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.NoRoutee$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.NoRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.Pool$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RandomGroup$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RandomPool$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RandomRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RandomRoutingLogic$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RemoveRoutee$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ResizablePoolActor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ResizablePoolActor.Resize$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RoundRobinGroup$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RoundRobinPool$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RoundRobinRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RoundRobinRoutingLogic$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RoutedActorCell$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.Routees$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.Router$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RouterRoutees$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ScatterGatherFirstCompletedGroup$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ScatterGatherFirstCompletedPool$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ScatterGatherFirstCompletedRoutees$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ScatterGatherFirstCompletedRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ScatterGatherFirstCompletedRoutingLogic$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.SeveralRoutees$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.SmallestMailboxPool$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.SmallestMailboxRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.SmallestMailboxRoutingLogic$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.TailChoppingGroup$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.TailChoppingPool$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.TailChoppingRoutees$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.TailChoppingRoutingLogic$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.WithListeners$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.serialization.JavaSerializer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.serialization.NullSerializer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.serialization.Serialization$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.serialization.Serialization.Information$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.serialization.SerializationExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.AkkaSpec$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.CallingThreadDispatcher$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.CallingThreadDispatcherQueues$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.Coroner$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.CustomEventFilter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.DeadLettersFilter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.DebugFilter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.ErrorFilter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.EventFilter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.InfoFilter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.LongRunningTest$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.PerformanceTest$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.SocketUtil$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestActor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestActor.KeepRunning$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestActor.NoAutoPilot$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestActor.NullMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestActor.RealMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestActor.SetAutoPilot$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestActor.SetIgnore$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestActor.UnWatch$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestActor.Watch$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestActorRef$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestActorRefSpec$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestActorRefSpec.WrappedTerminated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestActors$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestBarrier$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestEvent.Mute$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestEvent.UnMute$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestFSMRef$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestKit$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestKitExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestLatch$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestProbe$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TimingTest$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.WarningFilter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.transactor.Coordinated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.transactor.EmptyReceive$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.transactor.SendTo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.transactor.TransactorExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.BoxedType$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.ByteIterator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.ByteIterator.ByteArrayIterator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.ByteIterator.MultiByteArrayIterator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.ByteString$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.ByteString.ByteString1$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.ByteString.ByteString1C$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.ByteString.ByteStrings$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.Collections$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.Collections.EmptyImmutableSeq$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.CompactByteString$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.Crypt$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.HashCode$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.Helpers$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.Helpers.ConfigOps$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.Helpers.Requiring$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.Reflect$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.SerializedSuspendableExecutionContext$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.SubclassifiedIndex$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.Switch$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.Timeout$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.WildcardTree$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Affinity$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Backlog$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Bind$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Closed$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.ConcurrentSocketActor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Connect$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Connecting$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Context$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.FileDescriptor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.HighWatermark$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Identity$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Linger$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Listener$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.MaxMsgSize$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.MulticastHops$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.MulticastLoop$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.PollDispatcher$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.PollTimeoutDuration$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Rate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.ReceiveBufferSize$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.ReceiveHighWatermark$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.ReconnectIVL$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.ReconnectIVLMax$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.RecoveryInterval$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Send$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.SendBufferSize$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.SendHighWatermark$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.SocketType$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.SocketType.Dealer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.SocketType.Pair$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.SocketType.Pub$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.SocketType.Pull$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.SocketType.Push$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.SocketType.Rep$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.SocketType.Req$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.SocketType.Router$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.SocketType.Sub$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Subscribe$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Swap$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Unsubscribe$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.ZeroMQ$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.ZeroMQExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.ZeroMQVersion$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.ZMQMessage$
Static reference to the singleton instance of this Scala object.
MonitorableThreadFactory - Class in akka.dispatch
 
MonitorableThreadFactory(String, boolean, Option<ClassLoader>, Thread.UncaughtExceptionHandler, AtomicLong) - Constructor for class akka.dispatch.MonitorableThreadFactory
 
MonitorableThreadFactory$ - Class in akka.dispatch
 
MonitorableThreadFactory$() - Constructor for class akka.dispatch.MonitorableThreadFactory$
 
MonitorableThreadFactory.AkkaForkJoinWorkerThread - Class in akka.dispatch
 
MonitorableThreadFactory.AkkaForkJoinWorkerThread(ForkJoinPool) - Constructor for class akka.dispatch.MonitorableThreadFactory.AkkaForkJoinWorkerThread
 
MonitoredByNrOfMembers() - Method in class akka.cluster.ClusterSettings
 
monitoredByNrOfMembers() - Method in class akka.cluster.HeartbeatNodeRing
 
msg() - Method in class akka.actor.ActorSelectionMessage
 
msg() - Method in class akka.actor.FSM.Timer
 
msg() - Method in exception akka.actor.SchedulerException
 
msg() - Method in class akka.contrib.pattern.ClusterClient.Publish
 
msg() - Method in class akka.contrib.pattern.ClusterClient.Send
 
msg() - Method in class akka.contrib.pattern.ClusterClient.SendToAll
 
msg() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Internal$.MediatorRouterEnvelope
 
msg() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Internal$.SendToOneSubscriber
 
msg() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Publish
 
msg() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Send
 
msg() - Method in class akka.contrib.pattern.DistributedPubSubMediator.SendToAll
 
msg() - Method in class akka.contrib.pattern.ReliableProxy.Message
 
msg() - Method in class akka.persistence.journal.AsyncWriteJournal.Desequenced
 
msg() - Method in exception akka.remote.testconductor.BarrierCoordinator.BarrierEmpty
 
msg() - Method in exception akka.remote.testconductor.ClientFSM.ConnectionFailure
 
msg() - Method in class akka.remote.testconductor.ToClient
 
msg() - Method in class akka.remote.testconductor.ToServer
 
msg() - Method in exception akka.remote.transport.FailureInjectorException
 
msg() - Method in exception akka.remote.transport.Transport.InvalidAssociationException
 
msg() - Method in interface akka.testkit.TestActor.Message
 
msg() - Method in class akka.testkit.TestActor.NullMessage$
 
msg() - Method in class akka.testkit.TestActor.RealMessage
 
msg() - Method in class akka.testkit.TestActorRefSpec.Logger
 
msgAvailable() - Method in class akka.testkit.JavaTestKit
Query queue status.
msgAvailable() - Method in interface akka.testkit.TestKitBase
Query queue status.
MsgDecoder - Class in akka.remote.testconductor
 
MsgDecoder() - Constructor for class akka.remote.testconductor.MsgDecoder
 
msgDispatch() - Method in class akka.remote.EndpointWriter
 
MsgEncoder - Class in akka.remote.testconductor
 
MsgEncoder() - Constructor for class akka.remote.testconductor.MsgEncoder
 
msgsPer(int, TimeUnit) - Method in class akka.contrib.throttle.Throttler.RateInt
 
msgsPer(FiniteDuration) - Method in class akka.contrib.throttle.Throttler.RateInt
 
msgsPerHour() - Method in class akka.contrib.throttle.Throttler.RateInt
 
msgsPerMinute() - Method in class akka.contrib.throttle.Throttler.RateInt
 
msgsPerSecond() - Method in class akka.contrib.throttle.Throttler.RateInt
 
MulticastHops - Class in akka.zeromq
Sets the time-to-live field in every multicast packet sent from this socket.
MulticastHops(long) - Constructor for class akka.zeromq.MulticastHops
 
multicastHops() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its multicast hops configuration.
multicastHops() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its multicast hops configuration.
MulticastHops$ - Class in akka.zeromq
Gets the MulticastHops
MulticastHops$() - Constructor for class akka.zeromq.MulticastHops$
 
MulticastLoop - Class in akka.zeromq
Controls whether data sent via multicast transports using the specified socket can also be received by the sending host via loop-back.
MulticastLoop(boolean) - Constructor for class akka.zeromq.MulticastLoop
 
multicastLoop() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its multicast loop configuration.
multicastLoop() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its multicast loop configuration.
MulticastLoop$ - Class in akka.zeromq
Gets the MulticastLoop
MulticastLoop$() - Constructor for class akka.zeromq.MulticastLoop$
 
MultiNodeConfig - Class in akka.remote.testkit
Configure the role names and participants of the test, including configuration settings.
MultiNodeConfig() - Constructor for class akka.remote.testkit.MultiNodeConfig
 
MultiNodeSpec - Class in akka.remote.testkit
Note: To be able to run tests with everything ignored or excluded by tags you must not use testconductor, or helper methods that use testconductor, from the constructor of your test class.
MultiNodeSpec(RoleName, ActorSystem, Seq<RoleName>, Function1<RoleName, Seq<String>>) - Constructor for class akka.remote.testkit.MultiNodeSpec
 
MultiNodeSpec(MultiNodeConfig) - Constructor for class akka.remote.testkit.MultiNodeSpec
 
MultiNodeSpec$ - Class in akka.remote.testkit
 
MultiNodeSpec$() - Constructor for class akka.remote.testkit.MultiNodeSpec$
 
MultiNodeSpec.AwaitHelper<T> - Class in akka.remote.testkit
 
MultiNodeSpec.AwaitHelper(Awaitable<T>) - Constructor for class akka.remote.testkit.MultiNodeSpec.AwaitHelper
 
multiNodeSpecAfterAll() - Method in class akka.remote.testkit.MultiNodeSpec
 
multiNodeSpecAfterAll() - Method in interface akka.remote.testkit.MultiNodeSpecCallbacks
Call this after the all test cases have run.
multiNodeSpecBeforeAll() - Method in class akka.remote.testkit.MultiNodeSpec
 
multiNodeSpecBeforeAll() - Method in interface akka.remote.testkit.MultiNodeSpecCallbacks
Call this before the start of the test run.
MultiNodeSpecCallbacks - Interface in akka.remote.testkit
Use this to hook MultiNodeSpec into your test framework lifecycle, either by having your test extend MultiNodeSpec and call these methods or by creating a trait that calls them and then mixing that trait with your test together with MultiNodeSpec.
MultipleConsumerSemantics - Interface in akka.dispatch
This is a marker trait for message queues which support multiple consumers, as is required by the BalancingDispatcher.
MurmurHash - Class in akka.routing
An object designed to generate well-distributed non-cryptographic hashes.
MurmurHash() - Constructor for class akka.routing.MurmurHash
 
MurmurHash$ - Class in akka.routing
An object designed to generate well-distributed non-cryptographic hashes.
MurmurHash$() - Constructor for class akka.routing.MurmurHash$
 
muteDeadLetters(Seq<Class<?>>, ActorSystem) - Method in class akka.remote.testkit.MultiNodeSpec
 
muteDeadLetters(Seq<Class<?>>, ActorSystem) - Method in class akka.testkit.AkkaSpec
 
myAddress() - Method in class akka.remote.testkit.MultiNodeSpec
 
myReceivers() - Method in class akka.cluster.HeartbeatNodeRing
Receivers for selfAddress.
myself() - Method in class akka.remote.testkit.MultiNodeConfig
 
myself() - Method in class akka.remote.testkit.MultiNodeSpec
 
myVersions() - Method in class akka.contrib.pattern.DistributedPubSubMediator
 

N

nacked() - Method in class akka.remote.AckedSendBuffer
 
nacks() - Method in class akka.remote.Ack
 
NACKS_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AcknowledgementInfo
 
name() - Method in interface akka.actor.ActorPath
The name of the actor that this path refers to.
name() - Method in class akka.actor.ActorSystem
The name of this actor system, used to distinguish multiple ones within the same JVM & class loader.
name() - Method in class akka.actor.ActorSystem.Settings
 
name() - Method in class akka.actor.ActorSystemImpl
 
name() - Method in class akka.actor.ChildActorPath
 
name() - Method in class akka.actor.FSM.Timer
 
Name() - Method in class akka.actor.mailbox.DurableExecutableMailboxConfig$
 
Name() - Static method in class akka.actor.mailbox.DurableExecutableMailboxConfig
 
name() - Method in interface akka.actor.mailbox.DurableMailboxSettings
Name of this mailbox type for purposes of configuration scoping.
name() - Method in class akka.actor.mailbox.DurableMessageQueue
 
name() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
name() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
name() - Method in class akka.actor.RootActorPath
 
name() - Method in class akka.actor.SelectChildName
 
name() - Method in class akka.cluster.Metric
 
name() - Method in class akka.dispatch.MonitorableThreadFactory
 
name() - Method in class akka.remote.Remoting.RegisterTransportActor
 
name() - Method in class akka.remote.testconductor.BarrierCoordinator.RemoveClient
 
name() - Method in class akka.remote.testconductor.BarrierResult
 
name() - Method in class akka.remote.testconductor.Controller.ClientDisconnected
 
name() - Method in class akka.remote.testconductor.Controller.NodeInfo
 
name() - Method in class akka.remote.testconductor.EnterBarrier
 
name() - Method in class akka.remote.testconductor.FailBarrier
 
name() - Method in class akka.remote.testconductor.Hello
 
name() - Method in class akka.remote.testconductor.RoleName
 
name() - Method in class akka.zeromq.PollDispatcher
 
NAME_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
NAME_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Hello
 
NAMEINDEX_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
nanoTimeOfLastSend() - Method in class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket
 
nativeLeveldb() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
NettyClientHelpers - Interface in akka.remote.transport.netty
INTERNAL API
NettyFutureBridge - Class in akka.remote.transport.netty
 
NettyFutureBridge() - Constructor for class akka.remote.transport.netty.NettyFutureBridge
 
NettyFutureBridge$ - Class in akka.remote.transport.netty
 
NettyFutureBridge$() - Constructor for class akka.remote.transport.netty.NettyFutureBridge$
 
NettyHelpers - Interface in akka.remote.transport.netty
INTERNAL API
NettyServerHelpers - Interface in akka.remote.transport.netty
INTERNAL API
NettySSLSupport - Class in akka.remote.transport.netty
INTERNAL API
NettySSLSupport() - Constructor for class akka.remote.transport.netty.NettySSLSupport
 
NettySSLSupport$ - Class in akka.remote.transport.netty
INTERNAL API
NettySSLSupport$() - Constructor for class akka.remote.transport.netty.NettySSLSupport$
 
NettyTransport - Class in akka.remote.transport.netty
 
NettyTransport(NettyTransportSettings, ExtendedActorSystem) - Constructor for class akka.remote.transport.netty.NettyTransport
 
NettyTransport(ExtendedActorSystem, com.typesafe.config.Config) - Constructor for class akka.remote.transport.netty.NettyTransport
 
NettyTransport$ - Class in akka.remote.transport.netty
INTERNAL API
NettyTransport$() - Constructor for class akka.remote.transport.netty.NettyTransport$
 
NettyTransportException - Exception in akka.remote.transport.netty
 
NettyTransportException(String, Throwable) - Constructor for exception akka.remote.transport.netty.NettyTransportException
 
NettyTransportException(String) - Constructor for exception akka.remote.transport.netty.NettyTransportException
 
NettyTransportSettings - Class in akka.remote.transport.netty
 
NettyTransportSettings(com.typesafe.config.Config) - Constructor for class akka.remote.transport.netty.NettyTransportSettings
 
NettyTransportSettings$ - Class in akka.remote.transport.netty
 
NettyTransportSettings$() - Constructor for class akka.remote.transport.netty.NettyTransportSettings$
 
NettyTransportSettings.Mode - Interface in akka.remote.transport.netty
 
NettyTransportSettings.Tcp$ - Class in akka.remote.transport.netty
 
NettyTransportSettings.Tcp$() - Constructor for class akka.remote.transport.netty.NettyTransportSettings.Tcp$
 
NettyTransportSettings.Udp$ - Class in akka.remote.transport.netty
 
NettyTransportSettings.Udp$() - Constructor for class akka.remote.transport.netty.NettyTransportSettings.Udp$
 
NetworkOp - Interface in akka.remote.testconductor
 
newAckDeadline() - Method in class akka.remote.EndpointWriter
 
newActor() - Method in class akka.actor.ActorCell
 
newActor() - Method in class akka.actor.Props
INTERNAL API
newActorCell(ActorSystemImpl, InternalActorRef, Props, MessageDispatcher, InternalActorRef) - Method in class akka.actor.LocalActorRef
 
newActorCell(ActorSystemImpl, InternalActorRef, Props, MessageDispatcher, InternalActorRef) - Method in class akka.testkit.TestActorRef
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
newBuilder(ClusterMessages.Address) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
 
newBuilder(ClusterMessages.Empty) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
newBuilder(ClusterMessages.Gossip) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
newBuilder(ClusterMessages.GossipEnvelope) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
 
newBuilder(ClusterMessages.GossipOverview) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
newBuilder(ClusterMessages.GossipStatus) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Join
 
newBuilder(ClusterMessages.Join) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Join
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
newBuilder(ClusterMessages.Member) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
newBuilder(ClusterMessages.MetricsGossip) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
newBuilder(ClusterMessages.MetricsGossipEnvelope) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
 
newBuilder(ClusterMessages.NodeMetrics.EWMA) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
newBuilder(ClusterMessages.NodeMetrics.Metric) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
newBuilder(ClusterMessages.NodeMetrics) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
newBuilder(ClusterMessages.NodeMetrics.Number) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
newBuilder(ClusterMessages.ObserverReachability) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
newBuilder(ClusterMessages.SubjectReachability) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
 
newBuilder(ClusterMessages.UniqueAddress) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
 
newBuilder(ClusterMessages.VectorClock) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
 
newBuilder(ClusterMessages.VectorClock.Version) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
 
newBuilder(ClusterMessages.Welcome) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
 
newBuilder() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
newBuilder(DistributedPubSubMessages.Address) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
newBuilder() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
newBuilder(DistributedPubSubMessages.Delta.Bucket) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
newBuilder() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
newBuilder(DistributedPubSubMessages.Delta.Entry) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
newBuilder() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
 
newBuilder(DistributedPubSubMessages.Delta) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
 
newBuilder() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
newBuilder(DistributedPubSubMessages.Payload) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
newBuilder() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
 
newBuilder(DistributedPubSubMessages.Publish) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
 
newBuilder() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
newBuilder(DistributedPubSubMessages.Send) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
newBuilder() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
newBuilder(DistributedPubSubMessages.SendToAll) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
newBuilder() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
 
newBuilder(DistributedPubSubMessages.Status) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
 
newBuilder() - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
 
newBuilder(DistributedPubSubMessages.Status.Version) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
 
newBuilder() - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
newBuilder(MessageFormats.AtLeastOnceDeliverySnapshot) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
newBuilder() - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
newBuilder(MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
newBuilder() - Static method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
newBuilder(MessageFormats.DeliveredMessage) - Static method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
newBuilder() - Static method in class akka.persistence.serialization.MessageFormats.DeliverMessage
 
newBuilder(MessageFormats.DeliverMessage) - Static method in class akka.persistence.serialization.MessageFormats.DeliverMessage
 
newBuilder() - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
newBuilder(MessageFormats.PersistentMessage) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
newBuilder() - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
 
newBuilder(MessageFormats.PersistentMessageBatch) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
 
newBuilder() - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
newBuilder(MessageFormats.PersistentPayload) - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
newBuilder() - Static method in class akka.remote.ContainerFormats.Selection
 
newBuilder(ContainerFormats.Selection) - Static method in class akka.remote.ContainerFormats.Selection
 
newBuilder() - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
newBuilder(ContainerFormats.SelectionEnvelope) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
newBuilder() - Static method in class akka.remote.testconductor.TestConductorProtocol.Address
 
newBuilder(TestConductorProtocol.Address) - Static method in class akka.remote.testconductor.TestConductorProtocol.Address
 
newBuilder() - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
newBuilder(TestConductorProtocol.AddressRequest) - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
newBuilder() - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
newBuilder(TestConductorProtocol.EnterBarrier) - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
newBuilder() - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
newBuilder(TestConductorProtocol.Hello) - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
newBuilder() - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
newBuilder(TestConductorProtocol.InjectFailure) - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
newBuilder() - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
newBuilder(TestConductorProtocol.Wrapper) - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
newBuilder() - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
newBuilder(WireFormats.AckAndEnvelopeContainer) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
newBuilder() - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
newBuilder(WireFormats.AcknowledgementInfo) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
newBuilder() - Static method in class akka.remote.WireFormats.ActorRefData
 
newBuilder(WireFormats.ActorRefData) - Static method in class akka.remote.WireFormats.ActorRefData
 
newBuilder() - Static method in class akka.remote.WireFormats.AddressData
 
newBuilder(WireFormats.AddressData) - Static method in class akka.remote.WireFormats.AddressData
 
newBuilder() - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
newBuilder(WireFormats.AkkaControlMessage) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
newBuilder() - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
newBuilder(WireFormats.AkkaHandshakeInfo) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
newBuilder() - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
newBuilder(WireFormats.AkkaProtocolMessage) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
newBuilder() - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
newBuilder(WireFormats.DaemonMsgCreateData) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
newBuilder() - Static method in class akka.remote.WireFormats.DeployData
 
newBuilder(WireFormats.DeployData) - Static method in class akka.remote.WireFormats.DeployData
 
newBuilder() - Static method in class akka.remote.WireFormats.PropsData
 
newBuilder(WireFormats.PropsData) - Static method in class akka.remote.WireFormats.PropsData
 
newBuilder() - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
newBuilder(WireFormats.RemoteEnvelope) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
newBuilder() - Static method in class akka.remote.WireFormats.SerializedMessage
 
newBuilder(WireFormats.SerializedMessage) - Static method in class akka.remote.WireFormats.SerializedMessage
 
newBuilder() - Method in class akka.util.ByteString$
 
newBuilder() - Method in class akka.util.ByteString
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
 
newBuilderForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
newBuilderForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
newBuilderForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
newBuilderForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
 
newBuilderForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
newBuilderForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
 
newBuilderForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
newBuilderForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
newBuilderForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
 
newBuilderForType() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
 
newBuilderForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
newBuilderForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
newBuilderForType() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
newBuilderForType() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage
 
newBuilderForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
newBuilderForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
 
newBuilderForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
newBuilderForType() - Method in class akka.remote.ContainerFormats.Selection
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.ContainerFormats.Selection
 
newBuilderForType() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
newBuilderForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
newBuilderForType() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
newBuilderForType() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
newBuilderForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
newBuilderForType() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
newBuilderForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
newBuilderForType() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
newBuilderForType() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
newBuilderForType() - Method in class akka.remote.WireFormats.ActorRefData
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.ActorRefData
 
newBuilderForType() - Method in class akka.remote.WireFormats.AddressData
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.AddressData
 
newBuilderForType() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.AkkaControlMessage
 
newBuilderForType() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
newBuilderForType() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
newBuilderForType() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
newBuilderForType() - Method in class akka.remote.WireFormats.DeployData
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.DeployData
 
newBuilderForType() - Method in class akka.remote.WireFormats.PropsData
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.PropsData
 
newBuilderForType() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.RemoteEnvelope
 
newBuilderForType() - Method in class akka.remote.WireFormats.SerializedMessage
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.SerializedMessage
 
newCell(UnstartedCell) - Method in class akka.actor.RepointableActorRef
This is called by activate() to obtain the cell which is to replace the unstarted cell.
newCell(UnstartedCell) - Method in class akka.routing.RoutedActorRef
 
newDealerSocket(SocketOption[]) - Method in class akka.zeromq.ZeroMQExtension
Java API factory method to create the actor representing the ZeroMQ Dealer socket.
newDealerSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Java API: Factory method to create the Props to build a ZeroMQ Dealer socket actor.
Newer() - Method in class akka.cluster.ClusterCoreDaemon
 
newerCount() - Method in class akka.cluster.GossipStats
 
newGossip() - Method in class akka.cluster.InternalClusterAction.PublishChanges
 
newPubSocket(SocketOption[]) - Method in class akka.zeromq.ZeroMQExtension
Java API factory method to create the actor representing the ZeroMQ Publisher socket.
newPubSocket(Bind) - Method in class akka.zeromq.ZeroMQExtension
Convenience for creating a publisher socket.
newPubSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Java API: Factory method to create the Props to build a ZeroMQ Publisher socket actor.
newPullSocket(SocketOption[]) - Method in class akka.zeromq.ZeroMQExtension
Java API factory method to create the actor representing the ZeroMQ Pull socket.
newPullSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Java API: Factory method to create the Props to build a ZeroMQ Pull socket actor.
newPushSocket(SocketOption[]) - Method in class akka.zeromq.ZeroMQExtension
Java API factory method to create the actor representing the ZeroMQ Push socket.
newPushSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Java API: Factory method to create the Props to build a ZeroMQ Push socket actor.
newReceiver() - Method in interface akka.actor.dsl.Inbox.InboxExtension
 
newRepSocket(SocketOption[]) - Method in class akka.zeromq.ZeroMQExtension
Java API factory method to create the actor representing the ZeroMQ Rep socket.
newRepSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Java API: Factory method to create the Props to build a ZeroMQ Rep socket actor.
newReqSocket(SocketOption[]) - Method in class akka.zeromq.ZeroMQExtension
Java API factory method to create the actor representing the ZeroMQ Req socket.
newReqSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Java API: Factory method to create the Props to build a ZeroMQ Req socket actor.
newRoutee(Props, ActorContext) - Method in class akka.cluster.routing.ClusterRouterConfig
INTERNAL API
newRoutee(Props, ActorContext) - Method in class akka.cluster.routing.ClusterRouterPool
INTERNAL API
newRoutee(Props, ActorContext) - Method in class akka.remote.routing.RemoteRouterConfig
 
newRoutee(Props, ActorContext) - Method in class akka.routing.BalancingPool
INTERNAL API
newRoutee(Props, ActorContext) - Method in interface akka.routing.Pool
INTERNAL API
newRouterSocket(SocketOption[]) - Method in class akka.zeromq.ZeroMQExtension
Java API factory method to create the actor representing the ZeroMQ Router socket.
newRouterSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Java API: Factory method to create the Props to build a ZeroMQ Router socket actor.
newSocket(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Factory method to create the actor representing the ZeroMQ socket.
newSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Factory method to create the Props to build the ZeroMQ socket actor.
NewSocketTimeout() - Method in class akka.zeromq.ZeroMQExtension
 
newSubSocket(SocketOption[]) - Method in class akka.zeromq.ZeroMQExtension
Java API factory method to create the actor representing the ZeroMQ Subscriber socket.
newSubSocket(Connect, Listener, Subscribe) - Method in class akka.zeromq.ZeroMQExtension
Convenience for creating a subscriber socket.
newSubSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Java API: Factory method to create the Props to build a ZeroMQ Subscriber socket actor.
newThread(ForkJoinPool) - Method in class akka.dispatch.MonitorableThreadFactory
 
newThread(Runnable) - Method in class akka.dispatch.MonitorableThreadFactory
 
newUid() - Method in class akka.actor.ActorCell$
 
newUid() - Static method in class akka.actor.ActorCell
 
next() - Method in class akka.contrib.pattern.WorkList.Entry
 
next() - Method in class akka.dispatch.AbstractNodeQueue.Node
 
next() - Method in interface akka.dispatch.sysmsg.SystemMessage
 
next() - Method in class akka.routing.RoundRobinRoutingLogic
 
next() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
next() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
next() - Method in class akka.util.ByteIterator
 
nextAttempt() - Method in class akka.remote.testconductor.PlayerHandler
 
nextBackoff() - Method in class akka.contrib.pattern.ReliableProxy
Returns the next retry interval duration.
nextDeliverySequenceNr() - Method in interface akka.persistence.AtLeastOnceDelivery
 
nextId() - Method in class akka.remote.transport.ActorTransportAdapterManager
 
nextMagicA(int) - Method in class akka.routing.MurmurHash$
Given a magic integer from the first stream, compute the next
nextMagicA(int) - Static method in class akka.routing.MurmurHash
Given a magic integer from the first stream, compute the next
nextMagicB(int) - Method in class akka.routing.MurmurHash$
Given a magic integer from the second stream, compute the next
nextMagicB(int) - Static method in class akka.routing.MurmurHash
Given a magic integer from the second stream, compute the next
nextSeq() - Method in class akka.remote.ReliableDeliverySupervisor
 
nextSequenceNr() - Method in interface akka.persistence.ProcessorImpl
 
nextSerial() - Method in class akka.contrib.pattern.ReliableProxy
 
nextState() - Method in interface akka.actor.FSM
 
nextStateData() - Method in interface akka.actor.FSM
 
nextVersion() - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
no() - Method in class akka.zeromq.Linger$
 
no() - Static method in class akka.zeromq.Linger
 
noAck(Object) - Method in class akka.io.TcpMessage$
Each Tcp.WriteCommand can optionally request a positive acknowledgment to be sent to the commanding actor.
noAck() - Method in class akka.io.TcpMessage$
Default Tcp.NoAck instance which is used when no acknowledgment information is explicitly provided.
noAck(Object) - Static method in class akka.io.TcpMessage
Each Tcp.WriteCommand can optionally request a positive acknowledgment to be sent to the commanding actor.
noAck() - Static method in class akka.io.TcpMessage
Default Tcp.NoAck instance which is used when no acknowledgment information is explicitly provided.
noAck(Object) - Method in class akka.io.UdpConnectedMessage$
Each UdpConnected.Send can optionally request a positive acknowledgment to be sent to the commanding actor.
noAck() - Method in class akka.io.UdpConnectedMessage$
Default UdpConnected.NoAck instance which is used when no acknowledgment information is explicitly provided.
noAck(Object) - Static method in class akka.io.UdpConnectedMessage
Each UdpConnected.Send can optionally request a positive acknowledgment to be sent to the commanding actor.
noAck() - Static method in class akka.io.UdpConnectedMessage
Default UdpConnected.NoAck instance which is used when no acknowledgment information is explicitly provided.
noAck(Object) - Method in class akka.io.UdpMessage$
Each Udp.Send can optionally request a positive acknowledgment to be sent to the commanding actor.
noAck() - Method in class akka.io.UdpMessage$
Default Udp.NoAck instance which is used when no acknowledgment information is explicitly provided.
noAck(Object) - Static method in class akka.io.UdpMessage
Each Udp.Send can optionally request a positive acknowledgment to be sent to the commanding actor.
noAck() - Static method in class akka.io.UdpMessage
Default Udp.NoAck instance which is used when no acknowledgment information is explicitly provided.
NoArgsReflectConstructor - Class in akka.actor
INTERNAL API
NoArgsReflectConstructor(Class<? extends Actor>) - Constructor for class akka.actor.NoArgsReflectConstructor
 
noAutoPilot() - Method in class akka.testkit.TestActor.AutoPilot
 
noBackoffCount() - Method in class akka.remote.EndpointWriter
 
Nobody - Class in akka.actor
This is an internal look-up failure token, not useful for anything else.
Nobody() - Constructor for class akka.actor.Nobody
 
nobody() - Method in interface akka.transactor.Transactor
Empty set of transactors to send to.
nobody() - Method in class akka.transactor.UntypedTransactor
Empty set of transactors to send to.
Nobody$ - Class in akka.actor
This is an internal look-up failure token, not useful for anything else.
Nobody$() - Constructor for class akka.actor.Nobody$
 
noCause() - Method in class akka.event.Logging$
 
noCause() - Static method in class akka.event.Logging
 
node() - Method in class akka.cluster.AutoDown.UnreachableTimeout
 
node() - Method in class akka.cluster.InternalClusterAction.Join
 
node() - Method in class akka.remote.RemoteScope
 
node() - Method in class akka.remote.testconductor.AddressReply
 
node() - Method in exception akka.remote.testconductor.BarrierCoordinator.DuplicateNode
 
node() - Method in class akka.remote.testconductor.Disconnect
 
node() - Method in class akka.remote.testconductor.GetAddress
 
node() - Method in class akka.remote.testconductor.Remove
 
node() - Method in class akka.remote.testconductor.Terminate
 
node() - Method in class akka.remote.testconductor.Throttle
 
node(RoleName) - Method in class akka.remote.testkit.MultiNodeSpec
Query the controller for the transport address of the given node (by role name) and return that as an ActorPath for easy composition:
NODE_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Join
 
NODE_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
nodeConfig(Seq<RoleName>, Seq<com.typesafe.config.Config>) - Method in class akka.remote.testkit.MultiNodeConfig
Register a config override for a specific participant.
nodeConfig() - Method in class akka.remote.testkit.MultiNodeSpec$
 
nodeConfig() - Static method in class akka.remote.testkit.MultiNodeSpec
 
nodeFor(byte[]) - Method in class akka.routing.ConsistentHash
Get the node responsible for the data key.
nodeFor(String) - Method in class akka.routing.ConsistentHash
Get the node responsible for the data key.
NodeMessageQueue - Class in akka.dispatch
 
NodeMessageQueue() - Constructor for class akka.dispatch.NodeMessageQueue
 
nodeMetrics() - Method in class akka.cluster.ClusterEvent.ClusterMetricsChanged
 
NodeMetrics - Class in akka.cluster
The snapshot of current sampled health metrics for any monitored process.
NodeMetrics(Address, long, Set<Metric>) - Constructor for class akka.cluster.NodeMetrics
 
NodeMetrics$ - Class in akka.cluster
 
NodeMetrics$() - Constructor for class akka.cluster.NodeMetrics$
 
NODEMETRICS_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
nodeMetricsFor(Address) - Method in class akka.cluster.MetricsGossip
Returns NodeMetrics for a node if exists.
nodes() - Method in class akka.cluster.ClusterMetricsCollector
The node ring gossipped that contains only members that are Up.
nodes() - Method in class akka.cluster.HeartbeatNodeRing
 
nodes() - Method in class akka.cluster.MetricsGossip
 
nodes() - Method in interface akka.cluster.routing.ClusterRouterActor
 
nodes() - Method in class akka.contrib.pattern.ClusterReceptionist
 
nodes() - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
nodes() - Method in class akka.remote.routing.RemoteRouterConfig
 
nodes() - Method in class akka.remote.testconductor.Controller
 
NoDispatcherGiven() - Method in class akka.actor.Deploy$
 
NoDispatcherGiven() - Static method in class akka.actor.Deploy
 
noIncrement(Object) - Method in class akka.transactor.Coordinated
Create a new Coordinated object but *do not* increment the number of members by one.
NoLogging - Class in akka.event
NoLogging is a LoggingAdapter that does absolutely nothing – no logging at all.
NoLogging() - Constructor for class akka.event.NoLogging
 
NoLogging$ - Class in akka.event
NoLogging is a LoggingAdapter that does absolutely nothing – no logging at all.
NoLogging$() - Constructor for class akka.event.NoLogging$
 
NoMailboxGiven() - Method in class akka.actor.Deploy$
 
NoMailboxGiven() - Static method in class akka.actor.Deploy
 
NoMailboxRequirement() - Method in class akka.dispatch.Mailboxes$
 
NoMailboxRequirement() - Static method in class akka.dispatch.Mailboxes
 
noMatch() - Method in class akka.japi.JavaPartialFunction$
 
noMatch() - Static method in class akka.japi.JavaPartialFunction
 
noMatch() - Method in class akka.testkit.JavaTestKit.ExpectMsg
 
noMatch() - Method in class akka.testkit.JavaTestKit.ReceiveWhile
 
NoMessage - Class in akka.dispatch.sysmsg
INTERNAL API
NoMessage() - Constructor for class akka.dispatch.sysmsg.NoMessage
 
NoMessage$ - Class in akka.dispatch.sysmsg
INTERNAL API
NoMessage$() - Constructor for class akka.dispatch.sysmsg.NoMessage$
 
nonAcked() - Method in class akka.remote.AckedSendBuffer
 
none() - Method in class akka.cluster.Member$
 
none() - Static method in class akka.cluster.Member
 
none() - Method in class akka.japi.Option$
Option factory that creates None
none() - Static method in class akka.japi.Option
Option factory that creates None
None() - Method in class akka.persistence.SnapshotSelectionCriteria$
No saved snapshot matches.
none() - Method in class akka.persistence.SnapshotSelectionCriteria$
Java API.
None() - Static method in class akka.persistence.SnapshotSelectionCriteria
No saved snapshot matches.
none() - Static method in class akka.persistence.SnapshotSelectionCriteria
Java API.
nonEmpty() - Method in class akka.dispatch.sysmsg.EarliestFirstSystemMessageList
Indicates if the list has at least one element or not.
nonEmpty() - Method in class akka.dispatch.sysmsg.LatestFirstSystemMessageList
Indicates if the list has at least one element or not.
nonExistingPathEntry() - Method in class akka.dispatch.CachingConfig$
 
nonExistingPathEntry() - Static method in class akka.dispatch.CachingConfig
 
NonPersistentRepr - Class in akka.persistence
INTERNAL API Message which can be resequenced by the Journal, but will not be persisted.
NonPersistentRepr(Object, ActorRef) - Constructor for class akka.persistence.NonPersistentRepr
 
NonPersistentRepr$ - Class in akka.persistence
 
NonPersistentRepr$() - Constructor for class akka.persistence.NonPersistentRepr$
 
Normal() - Method in class akka.actor.AbstractFSM
Default reason if calling stop().
normally() - Method in interface akka.transactor.Transactor
Bypass transactionality and behave like a normal actor.
normally(Object) - Method in class akka.transactor.UntypedTransactor
Bypass transactionality and behave like a normal actor.
NoRoutee - Class in akka.routing
Routee that doesn't send the message to any routee.
NoRoutee() - Constructor for class akka.routing.NoRoutee
 
NoRoutee$ - Class in akka.routing
Routee that doesn't send the message to any routee.
NoRoutee$() - Constructor for class akka.routing.NoRoutee$
 
NoRouter - Class in akka.routing
Routing configuration that indicates no routing; this is also the default value which hence overrides the merge strategy in order to accept values from lower-precedence sources.
NoRouter() - Constructor for class akka.routing.NoRouter
 
NoRouter$ - Class in akka.routing
 
NoRouter$() - Constructor for class akka.routing.NoRouter$
 
NoScopeGiven - Class in akka.actor
This is the default value and as such allows overrides.
NoScopeGiven() - Constructor for class akka.actor.NoScopeGiven
 
NoScopeGiven$ - Class in akka.actor
 
NoScopeGiven$() - Constructor for class akka.actor.NoScopeGiven$
 
noSender() - Method in class akka.actor.Actor$
Default placeholder (null) used for "!" to indicate that there is no sender of the message, that will be translated to the receiving system's deadLetters.
noSender() - Method in class akka.actor.ActorRef$
Use this value as an argument to ActorRef.tell(java.lang.Object, akka.actor.ActorRef) if there is not actor to reply to (e.g.
noSender() - Static method in class akka.actor.ActorRef
Use this value as an argument to ActorRef.tell(java.lang.Object, akka.actor.ActorRef) if there is not actor to reply to (e.g.
NoSerializationVerificationNeeded - Interface in akka.actor
Marker trait to signal that this class should not be verified for serializability.
notActivated() - Method in class akka.camel.internal.ActivationTracker.ActivationStateMachine
Not activated state
notificationsTo() - Method in class akka.io.TcpConnection.CloseInformation
 
notify(AssociationHandle.HandleEvent) - Method in class akka.remote.transport.AssociationHandle.ActorHandleEventListener
 
notify(AssociationHandle.HandleEvent) - Method in interface akka.remote.transport.AssociationHandle.HandleEventListener
Called by the transport to notify the listener about a HandleEvent
notify(AssociationHandle.HandleEvent) - Method in class akka.remote.transport.FailureInjectorHandle
 
notify(Transport.AssociationEvent) - Method in class akka.remote.transport.FailureInjectorTransportAdapter
 
notify(Transport.AssociationEvent) - Method in class akka.remote.transport.Transport.ActorAssociationEventListener
 
notify(Transport.AssociationEvent) - Method in interface akka.remote.transport.Transport.AssociationEventListener
Called by the transport to notify the listener about an AssociationEvent
notifyDebug(String) - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
notifyDebug(String) - Method in class akka.event.BusLogging
 
notifyDebug(String) - Method in interface akka.event.LoggingAdapter
 
notifyDebug(String) - Method in class akka.event.NoLogging$
 
notifyDebug(String) - Static method in class akka.event.NoLogging
 
notifyError(String) - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
notifyError(Throwable, String) - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
notifyError(String) - Method in class akka.event.BusLogging
 
notifyError(Throwable, String) - Method in class akka.event.BusLogging
 
notifyError(String) - Method in interface akka.event.LoggingAdapter
 
notifyError(Throwable, String) - Method in interface akka.event.LoggingAdapter
 
notifyError(String) - Method in class akka.event.NoLogging$
 
notifyError(Throwable, String) - Method in class akka.event.NoLogging$
 
notifyError(String) - Static method in class akka.event.NoLogging
 
notifyError(Throwable, String) - Static method in class akka.event.NoLogging
 
notifyInfo(String) - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
notifyInfo(String) - Method in class akka.event.BusLogging
 
notifyInfo(String) - Method in interface akka.event.LoggingAdapter
 
notifyInfo(String) - Method in class akka.event.NoLogging$
 
notifyInfo(String) - Static method in class akka.event.NoLogging
 
notifyListener(org.jboss.netty.channel.Channel, AssociationHandle.HandleEvent) - Method in class akka.remote.transport.netty.ChannelLocalActor$
 
notifyListener(org.jboss.netty.channel.Channel, AssociationHandle.HandleEvent) - Static method in class akka.remote.transport.netty.ChannelLocalActor
 
notifyListeners(RemotingLifecycleEvent) - Method in class akka.remote.EventPublisher
 
notifyLog(Logging.LogLevel, String) - Method in interface akka.event.LoggingAdapter
 
notifyWarning(String) - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
notifyWarning(String) - Method in class akka.event.BusLogging
 
notifyWarning(String) - Method in interface akka.event.LoggingAdapter
 
notifyWarning(String) - Method in class akka.event.NoLogging$
 
notifyWarning(String) - Static method in class akka.event.NoLogging
 
notReading() - Method in class akka.remote.EndpointReader
 
now() - Method in class akka.testkit.TestKit$
Obtain current timestamp as Duration for relative measurements (using System.nanoTime).
now() - Static method in class akka.testkit.TestKit
Obtain current timestamp as Duration for relative measurements (using System.nanoTime).
now() - Method in interface akka.testkit.TestKitBase
Obtain current time (System.nanoTime) as Duration.
nrOfInstances() - Method in class akka.cluster.routing.AdaptiveLoadBalancingPool
 
nrOfInstances() - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
 
nrOfInstances() - Method in class akka.cluster.routing.ClusterRouterConfig
 
nrOfInstances() - Method in class akka.cluster.routing.ClusterRouterPool
Initial number of routee instances
nrOfInstances() - Method in class akka.remote.routing.RemoteRouterConfig
 
nrOfInstances() - Method in class akka.routing.BalancingPool
 
nrOfInstances() - Method in class akka.routing.BroadcastPool
 
nrOfInstances() - Method in class akka.routing.BroadcastRouter
 
nrOfInstances() - Method in class akka.routing.ConsistentHashingPool
 
nrOfInstances() - Method in class akka.routing.ConsistentHashingRouter
 
nrOfInstances() - Method in class akka.routing.FromConfig
 
nrOfInstances() - Method in interface akka.routing.Pool
Initial number of routee instances
nrOfInstances() - Method in class akka.routing.RandomPool
 
nrOfInstances() - Method in class akka.routing.RandomRouter
 
nrOfInstances() - Method in class akka.routing.RoundRobinPool
 
nrOfInstances() - Method in class akka.routing.RoundRobinRouter
 
nrOfInstances() - Method in class akka.routing.ScatterGatherFirstCompletedPool
 
nrOfInstances() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
nrOfInstances() - Method in class akka.routing.SmallestMailboxPool
 
nrOfInstances() - Method in class akka.routing.SmallestMailboxRouter
 
nrOfInstances() - Method in class akka.routing.TailChoppingPool
 
NrOfSelectors() - Method in class akka.io.TcpExt.Settings
 
NrOfSelectors() - Method in class akka.io.Udp.UdpSettings
 
nullAsBytes() - Method in class akka.serialization.NullSerializer
 
NullFunction() - Method in class akka.actor.AbstractFSM$
A partial function value which does not match anything and can be used to &ldquo;reset&rdquo; whenUnhandled and onTermination handlers.
NullFunction() - Static method in class akka.actor.AbstractFSM
A partial function value which does not match anything and can be used to &ldquo;reset&rdquo; whenUnhandled and onTermination handlers.
NullSerializer - Class in akka.serialization
This is a special Serializer that Serializes and deserializes nulls only
NullSerializer() - Constructor for class akka.serialization.NullSerializer
 
NullSerializer$ - Class in akka.serialization
 
NullSerializer$() - Constructor for class akka.serialization.NullSerializer$
 
num() - Method in class akka.actor.mailbox.DurableMailboxSpecActorFactory.AccumulatorActor
 
NUMBER_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
numberOfCalls() - Method in class akka.contrib.throttle.Throttler.Rate
 
numberOfCalls() - Method in class akka.contrib.throttle.Throttler.RateInt
 
NumberOfGossipsBeforeShutdownWhenLeaderExits() - Method in class akka.cluster.ClusterCoreDaemon
 
numberOfMessages() - Method in interface akka.actor.Cell
If the actor isLocal, returns the number of "user messages" currently queued, which may be a costly operation, 0 otherwise.
numberOfMessages() - Method in interface akka.actor.dungeon.Dispatch
 
numberOfMessages() - Method in class akka.actor.mailbox.filebased.FileBasedMessageQueue
 
numberOfMessages() - Method in class akka.actor.UnstartedCell
 
numberOfMessages() - Method in class akka.dispatch.Mailbox
Should return the current number of messages held in this queue; may always return 0 if no other value is available efficiently.
numberOfMessages() - Method in interface akka.dispatch.MessageQueue
Should return the current number of messages held in this queue; may always return 0 if no other value is available efficiently.
numberOfMessages() - Method in class akka.dispatch.NodeMessageQueue
 
numberOfMessages() - Method in interface akka.dispatch.QueueBasedMessageQueue
 
numberOfMessages(Routee) - Method in class akka.routing.SmallestMailboxRoutingLogic
Returns the number of pending messages in the mailbox of the actor.
numberOfMessages() - Method in class akka.testkit.CallingThreadMailbox
 
numberOfUnconfirmed() - Method in interface akka.persistence.AtLeastOnceDelivery
Number of messages that have not been confirmed yet.
numericId(String) - Method in interface akka.persistence.journal.leveldb.LeveldbIdMapping
Get the mapped numeric id for the specified persistent actor or channel id.

O

observer() - Method in class akka.cluster.Reachability.Record
 
OBSERVERREACHABILITY_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
 
observersGroupedByUnreachable() - Method in class akka.cluster.Reachability
 
occurrences(int) - Method in class akka.testkit.JavaTestKit.EventFilter
 
Off() - Method in class akka.util.SerializedSuspendableExecutionContext$
 
Off() - Static method in class akka.util.SerializedSuspendableExecutionContext
 
offer(E) - Method in class akka.util.BoundedBlockingQueue
 
offer(E, long, TimeUnit) - Method in class akka.util.BoundedBlockingQueue
 
offset() - Method in class akka.actor.mailbox.filebased.filequeue.tools.QueueDumper
 
offset() - Method in class akka.persistence.serialization.SnapshotSerializer$
 
offset() - Static method in class akka.persistence.serialization.SnapshotSerializer
 
Older() - Method in class akka.cluster.ClusterCoreDaemon
 
olderCount() - Method in class akka.cluster.GossipStats
 
oldestChangedBuffer() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
oldestChangedReceived() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
oldReceiversNowUnreachable() - Method in class akka.cluster.ClusterHeartbeatSenderState
 
on() - Method in class akka.io.Inet.SO$.ReuseAddress
 
on() - Method in class akka.io.Tcp.SO$.KeepAlive
 
on() - Method in class akka.io.Tcp.SO$.OOBInline
 
on() - Method in class akka.io.Tcp.SO$.TcpNoDelay
 
on() - Method in class akka.io.Udp.SO$.Broadcast
 
On() - Method in class akka.util.SerializedSuspendableExecutionContext$
 
On() - Static method in class akka.util.SerializedSuspendableExecutionContext
 
onClose(Function0<BoxedUnit>) - Method in class akka.pattern.CircuitBreaker
Adds a callback to execute when circuit breaker state closes
onClose(Runnable) - Method in class akka.pattern.CircuitBreaker
JavaAPI for onClose
OnComplete<T> - Class in akka.dispatch
Callback for when a Future is completed with either failure or a success SAM (Single Abstract Method) class
OnComplete() - Constructor for class akka.dispatch.OnComplete
 
onComplete(Throwable, T) - Method in class akka.dispatch.OnComplete
This method will be invoked once when/if a Future that this callback is registered on becomes completed with a failure or a success.
onConnect(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ChannelStateEvent) - Method in interface akka.remote.transport.netty.NettyHelpers
 
onConnect(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ChannelStateEvent) - Method in class akka.remote.transport.netty.TcpClientHandler
 
onConnect(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ChannelStateEvent) - Method in class akka.remote.transport.netty.TcpServerHandler
 
onDisconnect(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ChannelStateEvent) - Method in interface akka.remote.transport.netty.NettyHelpers
 
onDisconnect(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ChannelStateEvent) - Method in interface akka.remote.transport.netty.TcpHandlers
 
OneForOneStrategy() - Method in interface akka.actor.dsl.Creators.Act
 
OneForOneStrategy - Class in akka.actor
Applies the fault handling Directive (Resume, Restart, Stop) specified in the Decider to the child actor that failed, as opposed to AllForOneStrategy that applies it to all children.
OneForOneStrategy(int, Duration, boolean, PartialFunction<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.OneForOneStrategy
 
OneForOneStrategy(int, Duration, Function<Throwable, SupervisorStrategy.Directive>, boolean) - Constructor for class akka.actor.OneForOneStrategy
Java API
OneForOneStrategy(int, Duration, Function<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.OneForOneStrategy
Java API
OneForOneStrategy(int, Duration, Iterable<Class<? extends Throwable>>) - Constructor for class akka.actor.OneForOneStrategy
Java API
OneForOneStrategy(int, Duration, PartialFunction<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.OneForOneStrategy
Java API: compatible with lambda expressions This is an EXPERIMENTAL feature and is subject to change until it has received more real world testing.
OneForOneStrategy(boolean, PartialFunction<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.OneForOneStrategy
Java API: compatible with lambda expressions This is an EXPERIMENTAL feature and is subject to change until it has received more real world testing.
OneForOneStrategy(PartialFunction<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.OneForOneStrategy
Java API: compatible with lambda expressions This is an EXPERIMENTAL feature and is subject to change until it has received more real world testing.
OneForOneStrategy$ - Class in akka.actor
 
OneForOneStrategy$() - Constructor for class akka.actor.OneForOneStrategy$
 
oneway() - Method in class akka.camel.javaapi.UntypedProducerActor
 
Oneway - Interface in akka.camel
A one-way producer.
oneway() - Method in interface akka.camel.Oneway
 
oneway() - Method in interface akka.camel.ProducerSupport
If set to false (default), this producer expects a response message from the Camel endpoint.
onException(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ExceptionEvent) - Method in interface akka.remote.transport.netty.NettyHelpers
 
onException(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ExceptionEvent) - Method in interface akka.remote.transport.netty.TcpHandlers
 
OnFailure - Class in akka.dispatch
Callback for when a Future is completed with a failure SAM (Single Abstract Method) class
OnFailure() - Constructor for class akka.dispatch.OnFailure
 
onFailure(Throwable) - Method in class akka.dispatch.OnFailure
This method will be invoked once when/if a Future that this callback is registered on becomes completed with a failure
onHalfOpen(Function0<BoxedUnit>) - Method in class akka.pattern.CircuitBreaker
Adds a callback to execute when circuit breaker transitions to half-open
onHalfOpen(Runnable) - Method in class akka.pattern.CircuitBreaker
JavaAPI for onHalfOpen
OnlyCauseStackTrace - Interface in akka
Mix in this trait to suppress the StackTrace for the instance of the exception but not the cause, scala.util.control.NoStackTrace suppresses all the StackTraces.
onlySeen(UniqueAddress) - Method in class akka.cluster.Gossip
Marks the gossip as seen by only this node (address) by replacing the 'gossip.overview.seen'
OnMemberUpListener - Class in akka.cluster
INTERNAL API
OnMemberUpListener(Runnable) - Constructor for class akka.cluster.OnMemberUpListener
 
onMessage(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.MessageEvent) - Method in interface akka.remote.transport.netty.NettyHelpers
 
onMessage(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.MessageEvent) - Method in interface akka.remote.transport.netty.TcpHandlers
 
onMessage(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.MessageEvent) - Method in interface akka.remote.transport.netty.UdpHandlers
 
onOpen(Function0<BoxedUnit>) - Method in class akka.pattern.CircuitBreaker
Adds a callback to execute when circuit breaker opens
onOpen(Runnable) - Method in class akka.pattern.CircuitBreaker
Java API for onOpen
onOpen(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ChannelStateEvent) - Method in interface akka.remote.transport.netty.CommonHandlers
 
onOpen(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ChannelStateEvent) - Method in interface akka.remote.transport.netty.NettyHelpers
 
onReceive(Object, ActorRef) - Method in interface akka.actor.TypedActor.Receiver
 
onReceive(Object) - Method in class akka.actor.UntypedActor
To be implemented by concrete UntypedActor, this defines the behavior of the UntypedActor.
onReceive(Object) - Method in class akka.camel.javaapi.UntypedProducerActor
Default implementation of UntypedActor.onReceive
onReceive(Object) - Method in class akka.persistence.UntypedPersistentActor
 
onReceive(Object) - Method in class akka.transactor.UntypedTransactor
Implement a general pattern for using coordinated transactions.
onReceiveCommand(Object) - Method in class akka.persistence.UntypedPersistentActor
Java API: command handler.
onReceiveRecover(Object) - Method in class akka.persistence.UntypedPersistentActor
Java API: recovery handler that receives persisted events during recovery.
onRecoveryCompleted(PartialFunction<Object, BoxedUnit>) - Method in interface akka.persistence.ProcessorImpl
Invokes this processor's behavior with a RecoveryFinished message.
onRecoveryFailure(PartialFunction<Object, BoxedUnit>, Throwable) - Method in interface akka.persistence.ProcessorImpl
Invokes this processor's behavior with a RecoveryFailure message.
onReplayComplete(boolean) - Method in interface akka.persistence.PersistentView
Switches to idle state and schedules the next update if autoUpdate returns true.
onReplayComplete(boolean) - Method in interface akka.persistence.View
Switches to idle state and schedules the next update if autoUpdate returns true.
onReplayFailure(PartialFunction<Object, BoxedUnit>, boolean, Throwable) - Method in interface akka.persistence.PersistentView
INTERNAL API.
onReplayFailure(PartialFunction<Object, BoxedUnit>, boolean, Throwable) - Method in interface akka.persistence.ProcessorImpl
INTERNAL API.
onReplayFailure(PartialFunction<Object, BoxedUnit>, boolean, Throwable) - Method in interface akka.persistence.Recovery
INTERNAL API.
onReplayFailure(PartialFunction<Object, BoxedUnit>, boolean, Throwable) - Method in class akka.persistence.RequestReader
 
onReplayFailure(PartialFunction<Object, BoxedUnit>, boolean, Throwable) - Method in interface akka.persistence.View
INTERNAL API.
onReplaySuccess(PartialFunction<Object, BoxedUnit>, boolean) - Method in interface akka.persistence.PersistentView
INTERNAL API.
onReplaySuccess(PartialFunction<Object, BoxedUnit>, boolean) - Method in interface akka.persistence.ProcessorImpl
INTERNAL API.
onReplaySuccess(PartialFunction<Object, BoxedUnit>, boolean) - Method in interface akka.persistence.Recovery
INTERNAL API.
onReplaySuccess(PartialFunction<Object, BoxedUnit>, boolean) - Method in class akka.persistence.RequestReader
 
onReplaySuccess(PartialFunction<Object, BoxedUnit>, boolean) - Method in interface akka.persistence.View
INTERNAL API.
onRouteDefinition() - Method in interface akka.camel.Consumer
Returns the route definition handler for creating a custom route to this consumer.
onRouteDefinition() - Method in class akka.camel.ConsumerConfig
 
onRouteResponse(Object) - Method in class akka.camel.javaapi.UntypedProducerActor
Called after a response was received from the endpoint specified by endpointUri.
OnSuccess<T> - Class in akka.dispatch
Callback for when a Future is completed successfully SAM (Single Abstract Method) class
OnSuccess() - Constructor for class akka.dispatch.OnSuccess
 
onSuccess(T) - Method in class akka.dispatch.OnSuccess
This method will be invoked once when/if a Future that this callback is registered on becomes successfully completed
onTermination(FSMStopBuilder<S, D>) - Method in class akka.actor.AbstractFSM
Set handler which is called upon termination of this FSM actor.
onTermination(PartialFunction<FSM.StopEvent<S, D>, BoxedUnit>) - Method in interface akka.actor.FSM
 
onTransformOutgoingMessage(Object) - Method in class akka.camel.javaapi.UntypedProducerActor
Called before the message is sent to the endpoint specified by getEndpointUri.
onTransformResponse(Object) - Method in class akka.camel.javaapi.UntypedProducerActor
Called before the response message is sent to original sender.
onTransition(FSMTransitionHandlerBuilder<S>) - Method in class akka.actor.AbstractFSM
Add a handler which is called upon each state transition, i.e.
onTransition(FI.UnitApply2<S, S>) - Method in class akka.actor.AbstractFSM
Add a handler which is called upon each state transition, i.e.
onTransition(PartialFunction<Tuple2<S, S>, BoxedUnit>) - Method in interface akka.actor.FSM
 
oobInline(boolean) - Method in class akka.io.TcpSO$
Inet.SocketOption to enable or disable OOBINLINE (receipt of TCP urgent data) By default, this option is disabled and TCP urgent data is silently discarded.
oobInline(boolean) - Static method in class akka.io.TcpSO
Inet.SocketOption to enable or disable OOBINLINE (receipt of TCP urgent data) By default, this option is disabled and TCP urgent data is silently discarded.
OP_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
open() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
Open() - Method in class akka.dispatch.Mailbox$
 
Open() - Static method in class akka.dispatch.Mailbox
 
open() - Method in class akka.testkit.TestLatch
 
openTransactionCount() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
openTransactionIds() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
openTransactions() - Method in class akka.actor.mailbox.filebased.filequeue.tools.QueueDumper
 
operations() - Method in class akka.actor.mailbox.filebased.filequeue.tools.QueueDumper
 
Option<A> - Class in akka.japi
This class represents optional values.
Option() - Constructor for class akka.japi.Option
 
option(A) - Method in class akka.japi.Option$
Option factory that creates None if v is null, Some(v) otherwise.
option(A) - Static method in class akka.japi.Option
Option factory that creates None if v is null, Some(v) otherwise.
Option$ - Class in akka.japi
 
Option$() - Constructor for class akka.japi.Option$
 
Option.Some<A> - Class in akka.japi
Class Some[A] represents existing values of type A.
Option.Some(A) - Constructor for class akka.japi.Option.Some
 
Option.Some$ - Class in akka.japi
 
Option.Some$() - Constructor for class akka.japi.Option.Some$
 
options() - Method in class akka.io.Tcp.Bind
 
options() - Method in class akka.io.Tcp.Connect
 
options() - Method in class akka.io.Udp.Bind
 
options() - Method in class akka.io.Udp.SimpleSender
 
options() - Method in class akka.io.UdpConnected.Connect
 
ord() - Method in class akka.remote.SeqNo$
 
ord() - Static method in class akka.remote.SeqNo
 
ordering() - Method in class akka.cluster.Member$
Member ordering type class, sorts members by host and port.
ordering() - Static method in class akka.cluster.Member
Member ordering type class, sorts members by host and port.
origin() - Method in class akka.dispatch.CachingConfig
 
origin() - Method in class akka.remote.transport.HandshakeInfo
 
origin() - Method in class akka.remote.transport.ThrottlerManager.Checkin
 
ORIGIN_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AkkaHandshakeInfo
 
originalCause() - Method in exception akka.actor.PostRestartException
 
originalCause() - Method in exception akka.actor.PreRestartException
 
originalHandle() - Method in class akka.remote.transport.ThrottledAssociation
 
originalLocalAddress() - Method in class akka.remote.transport.AbstractTransportAdapterHandle
 
originalRemoteAddress() - Method in class akka.remote.transport.AbstractTransportAdapterHandle
 
OriginalRestartException - Class in akka.actor
This is an extractor for retrieving the original cause (i.e.
OriginalRestartException() - Constructor for class akka.actor.OriginalRestartException
 
OriginalRestartException$ - Class in akka.actor
This is an extractor for retrieving the original cause (i.e.
OriginalRestartException$() - Constructor for class akka.actor.OriginalRestartException$
 
OsgiActorSystemFactory - Class in akka.osgi
Factory class to create ActorSystem implementations in an OSGi environment.
OsgiActorSystemFactory(org.osgi.framework.BundleContext, Option<ClassLoader>, com.typesafe.config.Config) - Constructor for class akka.osgi.OsgiActorSystemFactory
 
OsgiActorSystemFactory$ - Class in akka.osgi
 
OsgiActorSystemFactory$() - Constructor for class akka.osgi.OsgiActorSystemFactory$
 
otherHasNewerVersions(Map<Address, Object>) - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
otherthread() - Method in class akka.testkit.TestActorRefSpec$
 
otherthread() - Static method in class akka.testkit.TestActorRefSpec
 
outboundDropP() - Method in class akka.remote.transport.FailureInjectorTransportAdapter.Drop
 
outboundProps(HandshakeInfo, Address, Promise<AssociationHandle>, Transport, AkkaProtocolSettings, AkkaPduCodec, FailureDetector, Option<Object>) - Method in class akka.remote.transport.ProtocolStateActor$
 
outboundProps(HandshakeInfo, Address, Promise<AssociationHandle>, Transport, AkkaProtocolSettings, AkkaPduCodec, FailureDetector, Option<Object>) - Static method in class akka.remote.transport.ProtocolStateActor
 
outboundThrottleMode() - Method in class akka.remote.transport.ThrottlerHandle
 
outstanding() - Method in class akka.contrib.pattern.ReliableProxy.ProxyTerminated
 
overlay(Function0<T>) - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
OverlaySetting<T> - Class in akka.actor.mailbox.filebased.filequeue
 
OverlaySetting(Function0<T>) - Constructor for class akka.actor.mailbox.filebased.filequeue.OverlaySetting
 
overrideUnsetConfig(RouterConfig) - Method in interface akka.routing.PoolOverrideUnsetConfig
 
OversizedPayloadException - Exception in akka.remote
INTERNAL API
OversizedPayloadException(String) - Constructor for exception akka.remote.OversizedPayloadException
 
overview() - Method in class akka.cluster.Gossip
 
OVERVIEW_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
owner() - Method in class akka.actor.mailbox.DurableMessageQueue
 
owner() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Internal$.Bucket
 
OWNER_FIELD_NUMBER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
ownerPath() - Method in class akka.actor.mailbox.DurableMessageQueue
 
ownerPathString() - Method in class akka.actor.mailbox.DurableMessageQueue
 
ownerType() - Method in class akka.actor.TypedActor.SerializedMethodCall
 

P

pack() - Method in class akka.actor.mailbox.filebased.filequeue.QItem
 
PacketSplitThreshold() - Method in class akka.remote.testconductor.TestConductorExt.Settings
 
Pair<A,B> - Class in akka.japi
Java API Represents a pair (tuple) of two elements.
Pair(A, B) - Constructor for class akka.japi.Pair
 
Pair$ - Class in akka.japi
 
Pair$() - Constructor for class akka.japi.Pair$
 
parallelism() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory
 
parameters() - Method in class akka.actor.TypedActor.MethodCall
 
parameterTypes() - Method in class akka.actor.TypedActor.SerializedMethodCall
 
parent() - Method in class akka.actor.ActorCell
 
parent() - Method in interface akka.actor.ActorContext
Returns the supervising parent ActorRef.
parent() - Method in interface akka.actor.ActorPath
The path for the parent actor.
parent() - Method in interface akka.actor.Cell
The supervisor of this actor.
parent() - Method in class akka.actor.ChildActorPath
 
parent() - Method in class akka.actor.RootActorPath
 
parent() - Method in class akka.actor.UnstartedCell
 
PARENT_VALUE - Static variable in enum akka.remote.ContainerFormats.PatternType
PARENT = 0;
parse(String) - Method in class akka.actor.AddressFromURIString$
Java API: Try to construct an Address from the given String or throw a java.net.MalformedURLException.
parse(String) - Static method in class akka.actor.AddressFromURIString
Java API: Try to construct an Address from the given String or throw a java.net.MalformedURLException.
parseArgs(List<String>) - Method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper$
 
parseArgs(List<String>) - Static method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper
 
parseConfig(String, com.typesafe.config.Config) - Method in class akka.actor.Deployer
 
parseConfig(String, com.typesafe.config.Config) - Method in class akka.cluster.ClusterDeployer
 
parseConfig(String, com.typesafe.config.Config) - Method in class akka.remote.RemoteDeployer
 
parseDelimitedFrom(InputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
parseDelimitedFrom(InputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
 
parseDelimitedFrom(InputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
parseDelimitedFrom(InputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
parseDelimitedFrom(InputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
 
parseDelimitedFrom(InputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
parseDelimitedFrom(InputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Join
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Join
 
parseDelimitedFrom(InputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
parseDelimitedFrom(InputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
parseDelimitedFrom(InputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
parseDelimitedFrom(InputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
 
parseDelimitedFrom(InputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
parseDelimitedFrom(InputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
parseDelimitedFrom(InputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
parseDelimitedFrom(InputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
parseDelimitedFrom(InputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
parseDelimitedFrom(InputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
 
parseDelimitedFrom(InputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
 
parseDelimitedFrom(InputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
 
parseDelimitedFrom(InputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
 
parseDelimitedFrom(InputStream) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
parseDelimitedFrom(InputStream) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
parseDelimitedFrom(InputStream) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
parseDelimitedFrom(InputStream) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
 
parseDelimitedFrom(InputStream) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
parseDelimitedFrom(InputStream) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
 
parseDelimitedFrom(InputStream) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
parseDelimitedFrom(InputStream) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
parseDelimitedFrom(InputStream) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
 
parseDelimitedFrom(InputStream) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
 
parseDelimitedFrom(InputStream) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
parseDelimitedFrom(InputStream) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
parseDelimitedFrom(InputStream) - Static method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
parseDelimitedFrom(InputStream) - Static method in class akka.persistence.serialization.MessageFormats.DeliverMessage
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.DeliverMessage
 
parseDelimitedFrom(InputStream) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
parseDelimitedFrom(InputStream) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
 
parseDelimitedFrom(InputStream) - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.ContainerFormats.Selection
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.Selection
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.testconductor.TestConductorProtocol.Address
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Address
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.ActorRefData
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.ActorRefData
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.AddressData
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AddressData
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.DeployData
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DeployData
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.PropsData
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.PropsData
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.SerializedMessage
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.SerializedMessage
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Join
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Join
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Join
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Join
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Join
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Join
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.persistence.serialization.MessageFormats.DeliverMessage
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.DeliverMessage
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.DeliverMessage
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.DeliverMessage
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.persistence.serialization.MessageFormats.DeliverMessage
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.DeliverMessage
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.ContainerFormats.Selection
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.Selection
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.Selection
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.Selection
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.ContainerFormats.Selection
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.Selection
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.testconductor.TestConductorProtocol.Address
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Address
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Address
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Address
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.testconductor.TestConductorProtocol.Address
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Address
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.WireFormats.ActorRefData
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.ActorRefData
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.ActorRefData
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.ActorRefData
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.WireFormats.ActorRefData
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.ActorRefData
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.WireFormats.AddressData
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AddressData
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AddressData
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AddressData
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.WireFormats.AddressData
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AddressData
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.WireFormats.DeployData
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DeployData
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DeployData
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DeployData
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.WireFormats.DeployData
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DeployData
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.WireFormats.PropsData
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.PropsData
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.PropsData
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.PropsData
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.WireFormats.PropsData
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.PropsData
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.WireFormats.SerializedMessage
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.SerializedMessage
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.SerializedMessage
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.SerializedMessage
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.WireFormats.SerializedMessage
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.SerializedMessage
 
PARSER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
PARSER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Empty
 
PARSER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
PARSER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
PARSER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
 
PARSER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
PARSER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Join
 
PARSER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
PARSER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
PARSER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
PARSER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
 
PARSER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
PARSER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
PARSER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
PARSER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
PARSER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
PARSER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
 
PARSER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
 
PARSER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
 
PARSER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
 
PARSER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
PARSER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
PARSER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
PARSER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
 
PARSER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
PARSER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
 
PARSER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
PARSER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
PARSER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
 
PARSER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
 
PARSER - Static variable in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
PARSER - Static variable in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
PARSER - Static variable in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
PARSER - Static variable in class akka.persistence.serialization.MessageFormats.DeliverMessage
 
PARSER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
PARSER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
 
PARSER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
PARSER - Static variable in class akka.remote.ContainerFormats.Selection
 
PARSER - Static variable in class akka.remote.ContainerFormats.SelectionEnvelope
 
PARSER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Address
 
PARSER - Static variable in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
PARSER - Static variable in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
PARSER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Hello
 
PARSER - Static variable in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
PARSER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
PARSER - Static variable in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
PARSER - Static variable in class akka.remote.WireFormats.AcknowledgementInfo
 
PARSER - Static variable in class akka.remote.WireFormats.ActorRefData
 
PARSER - Static variable in class akka.remote.WireFormats.AddressData
 
PARSER - Static variable in class akka.remote.WireFormats.AkkaControlMessage
 
PARSER - Static variable in class akka.remote.WireFormats.AkkaHandshakeInfo
 
PARSER - Static variable in class akka.remote.WireFormats.AkkaProtocolMessage
 
PARSER - Static variable in class akka.remote.WireFormats.DaemonMsgCreateData
 
PARSER - Static variable in class akka.remote.WireFormats.DeployData
 
PARSER - Static variable in class akka.remote.WireFormats.PropsData
 
PARSER - Static variable in class akka.remote.WireFormats.RemoteEnvelope
 
PARSER - Static variable in class akka.remote.WireFormats.SerializedMessage
 
passivate(ActorRef, Object) - Method in class akka.contrib.pattern.ShardRegion
 
passivatingBuffers() - Method in class akka.contrib.pattern.ShardRegion
 
passThrough(RoleName, RoleName, ThrottlerTransportAdapter.Direction) - Method in interface akka.remote.testconductor.Conductor
Switch the Netty pipeline of the remote support into pass through mode for sending and/or receiving.
patch() - Method in class akka.zeromq.ZeroMQVersion
 
path() - Method in class akka.actor.ActorRef
Returns the path for this actor (from this actor up to the root actor).
path() - Method in class akka.actor.ActorSelection
 
path() - Method in class akka.actor.Deploy
 
path() - Method in class akka.actor.dungeon.UndefinedUidActorRef
 
path() - Method in class akka.actor.EmptyLocalActorRef
 
path() - Method in class akka.actor.LocalActorRef
 
path() - Method in class akka.actor.Nobody$
 
path() - Static method in class akka.actor.Nobody
 
path() - Method in class akka.actor.RepointableActorRef
 
path() - Method in class akka.actor.SerializedActorRef
 
path() - Method in class akka.actor.VirtualPathContainer
 
path() - Method in class akka.camel.internal.component.ActorEndpoint
 
path() - Method in interface akka.camel.internal.component.ActorEndpointConfig
 
path() - Method in class akka.contrib.pattern.ClusterClient.Send
 
path() - Method in class akka.contrib.pattern.ClusterClient.SendToAll
 
path() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Remove
 
path() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Send
 
path() - Method in class akka.contrib.pattern.DistributedPubSubMediator.SendToAll
 
path() - Method in class akka.event.Logging.StandardOutLogger
 
path() - Method in class akka.pattern.PromiseActorRef
Contract of this method: Must always return the same ActorPath, which must have been registered if we haven't been stopped yet.
path() - Method in class akka.remote.DaemonMsgCreate
 
path() - Method in class akka.remote.RemoteActorRef
 
PATH_FIELD_NUMBER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
PATH_FIELD_NUMBER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
PATH_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.ActorRefData
 
PATH_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DaemonMsgCreateData
 
PATH_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DeployData
 
paths() - Method in class akka.cluster.routing.AdaptiveLoadBalancingGroup
 
paths() - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
 
paths() - Method in class akka.cluster.routing.ClusterRouterConfig
 
paths() - Method in class akka.cluster.routing.ClusterRouterGroup
 
paths() - Method in class akka.routing.BroadcastGroup
 
paths() - Method in class akka.routing.BroadcastRouter
 
paths() - Method in class akka.routing.ConsistentHashingGroup
 
paths() - Method in class akka.routing.ConsistentHashingRouter
 
paths() - Method in interface akka.routing.Group
 
paths() - Method in class akka.routing.GroupBase
 
paths() - Method in class akka.routing.RandomGroup
 
paths() - Method in class akka.routing.RandomRouter
 
paths() - Method in class akka.routing.RoundRobinGroup
 
paths() - Method in class akka.routing.RoundRobinRouter
 
paths() - Method in class akka.routing.ScatterGatherFirstCompletedGroup
 
paths() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
paths() - Method in class akka.routing.SmallestMailboxRouter
 
paths() - Method in class akka.routing.TailChoppingGroup
 
pathString() - Method in class akka.actor.ActorSelection
String representation of the path elements, starting with "/" and separated with "/".
PathUtils - Interface in akka.actor
 
pattern() - Method in class akka.actor.SelectChildPattern
 
PATTERN_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.SelectionEnvelope
 
Patterns - Class in akka.pattern
 
Patterns() - Constructor for class akka.pattern.Patterns
 
Patterns$ - Class in akka.pattern
 
Patterns$() - Constructor for class akka.pattern.Patterns$
 
patternStr() - Method in class akka.actor.SelectChildPattern
 
pauseReads() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
payload() - Method in class akka.io.Udp.Send
 
payload() - Method in class akka.io.UdpConnected.Send
 
payload() - Method in class akka.persistence.ConfirmablePersistentImpl
 
payload() - Method in class akka.persistence.journal.JournalPerfSpec.Cmd
 
payload() - Method in class akka.persistence.NonPersistentRepr
 
payload() - Method in class akka.persistence.PersistenceFailure
 
payload() - Method in class akka.persistence.Persistent
This persistent message's payload.
payload() - Method in class akka.persistence.PersistentImpl
 
payload() - Method in interface akka.persistence.PersistentRepr
This persistent message's payload.
payload() - Method in interface akka.persistence.Resequenceable
 
payload() - Method in class akka.remote.transport.AssociationHandle.InboundPayload
 
payload() - Method in class akka.remote.transport.TestTransport.WriteAttempt
 
payload() - Method in interface akka.zeromq.PubSubOption
 
payload() - Method in class akka.zeromq.Subscribe
 
payload() - Method in class akka.zeromq.Unsubscribe
 
PAYLOAD_FIELD_NUMBER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
 
PAYLOAD_FIELD_NUMBER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
PAYLOAD_FIELD_NUMBER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
PAYLOAD_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
PAYLOAD_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
PAYLOAD_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
PAYLOAD_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AkkaProtocolMessage
 
PAYLOADMANIFEST_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
PduCodecException - Exception in akka.remote.transport
INTERNAL API
PduCodecException(String, Throwable) - Constructor for exception akka.remote.transport.PduCodecException
 
peek() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
Peek at the head item in the queue, if there is one.
peek() - Method in class akka.dispatch.AbstractNodeQueue
Query the queue tail for the next element without dequeuing it.
peek() - Method in class akka.util.BoundedBlockingQueue
 
PeekMailbox - Class in akka.contrib.mailbox
 
PeekMailbox(ActorRef, ActorSystem, int) - Constructor for class akka.contrib.mailbox.PeekMailbox
 
PeekMailboxExtension - Class in akka.contrib.mailbox
 
PeekMailboxExtension(ExtendedActorSystem) - Constructor for class akka.contrib.mailbox.PeekMailboxExtension
 
PeekMailboxExtension$ - Class in akka.contrib.mailbox
 
PeekMailboxExtension$() - Constructor for class akka.contrib.mailbox.PeekMailboxExtension$
 
PeekMailboxType - Class in akka.contrib.mailbox
configure the mailbox via dispatcher configuration:
PeekMailboxType(ActorSystem.Settings, com.typesafe.config.Config) - Constructor for class akka.contrib.mailbox.PeekMailboxType
 
peekNode() - Method in class akka.dispatch.AbstractNodeQueue
Query the queue tail for the next element without dequeuing it.
peer(Address) - Method in class akka.contrib.pattern.ClusterSingletonManager
 
peerSentEOF(TcpConnection.ConnectionInfo) - Method in class akka.io.TcpConnection
the peer sent EOF first, but we may still want to send
PendingBufferWrite(ActorRef, ByteString, Tcp.Event, Tcp.WriteCommand) - Method in class akka.io.TcpConnection
 
pendingCommander() - Method in interface akka.io.WithUdpSend
 
pendingConfirmationsMax() - Method in class akka.persistence.PersistentChannelSettings
 
pendingConfirmationsMin() - Method in class akka.persistence.PersistentChannelSettings
 
pendingInvocations() - Method in interface akka.persistence.Eventsourced
 
pendingReadHandoffs() - Method in class akka.remote.EndpointManager
 
pendingSend() - Method in class akka.io.UdpConnection
 
pendingSend() - Method in interface akka.io.WithUdpSend
 
pendingStashingPersistInvocations() - Method in interface akka.persistence.Eventsourced
 
pendingUnreachable() - Method in class akka.cluster.AutoDownBase
 
PendingWrite(ActorRef, Tcp.WriteCommand) - Method in class akka.io.TcpConnection
 
PendingWriteFile(ActorRef, String, long, long, Tcp.Event, Tcp.WriteCommand) - Method in class akka.io.TcpConnection
 
PerformanceTest - Class in akka.testkit
 
PerformanceTest() - Constructor for class akka.testkit.PerformanceTest
 
PerformanceTest$ - Class in akka.testkit
 
PerformanceTest$() - Constructor for class akka.testkit.PerformanceTest$
 
PeriodicTasksInitialDelay() - Method in class akka.cluster.ClusterSettings
 
permanent() - Method in class akka.contrib.pattern.WorkList.Entry
 
permanent() - Method in class akka.persistence.journal.AsyncWriteTarget.DeleteMessages
 
permanent() - Method in class akka.persistence.journal.AsyncWriteTarget.DeleteMessagesTo
 
permanent() - Method in class akka.persistence.JournalProtocol.DeleteMessages
 
permanent() - Method in class akka.persistence.JournalProtocol.DeleteMessagesTo
 
perpetrator() - Method in interface akka.actor.dungeon.FaultHandling
 
persist(A, Procedure<A>) - Method in class akka.persistence.AbstractPersistentActor
Java API: asynchronously persists event.
persist(Iterable<A>, Procedure<A>) - Method in class akka.persistence.AbstractPersistentActor
Java API: asynchronously persists events in specified order.
persist(A, Function1<A, BoxedUnit>) - Method in interface akka.persistence.Eventsourced
 
persist(Seq<A>, Function1<A, BoxedUnit>) - Method in interface akka.persistence.Eventsourced
 
persist(A, Procedure<A>) - Method in class akka.persistence.UntypedPersistentActor
Java API: asynchronously persists event.
persist(Iterable<A>, Procedure<A>) - Method in class akka.persistence.UntypedPersistentActor
Java API: asynchronously persists events in specified order.
persistAsync(A, Procedure<A>) - Method in class akka.persistence.AbstractPersistentActor
Java API: asynchronously persists event.
persistAsync(Iterable<A>, Procedure<A>) - Method in class akka.persistence.AbstractPersistentActor
Java API: asynchronously persists events in specified order.
persistAsync(A, Function1<A, BoxedUnit>) - Method in interface akka.persistence.Eventsourced
 
persistAsync(Seq<A>, Function1<A, BoxedUnit>) - Method in interface akka.persistence.Eventsourced
 
persistAsync(A, Procedure<A>) - Method in class akka.persistence.UntypedPersistentActor
JAVA API: asynchronously persists event.
persistAsync(Iterable<A>, Function1<A, BoxedUnit>) - Method in class akka.persistence.UntypedPersistentActor
JAVA API: asynchronously persists events in specified order.
Persistence - Class in akka.persistence
Persistence extension.
Persistence(ExtendedActorSystem) - Constructor for class akka.persistence.Persistence
 
Persistence$ - Class in akka.persistence
Persistence extension.
Persistence$() - Constructor for class akka.persistence.Persistence$
 
PersistenceFailure - Class in akka.persistence
Sent to a Processor if a journal fails to write a Persistent message.
PersistenceFailure(Object, long, Throwable) - Constructor for class akka.persistence.PersistenceFailure
 
PersistenceFailure$ - Class in akka.persistence
 
PersistenceFailure$() - Constructor for class akka.persistence.PersistenceFailure$
 
persistenceId() - Method in class akka.contrib.pattern.ShardCoordinator
 
persistenceId() - Method in class akka.persistence.AbstractEventsourcedProcessor
 
persistenceId() - Method in class akka.persistence.ConfirmablePersistentImpl
 
persistenceId() - Method in class akka.persistence.DeliveredByChannel
 
persistenceId() - Method in class akka.persistence.DeliveredByPersistentChannel
 
persistenceId() - Method in class akka.persistence.journal.AsyncWriteTarget.DeleteMessagesTo
 
persistenceId() - Method in class akka.persistence.journal.AsyncWriteTarget.ReadHighestSequenceNr
 
persistenceId() - Method in class akka.persistence.journal.AsyncWriteTarget.ReplayMessages
 
persistenceId() - Method in class akka.persistence.journal.JournalPerfSpec.BenchActor
 
persistenceId() - Method in class akka.persistence.journal.JournalSpec.Confirmation
 
persistenceId() - Method in class akka.persistence.journal.leveldb.Key
 
persistenceId() - Method in class akka.persistence.JournalProtocol.DeleteMessagesTo
 
persistenceId() - Method in class akka.persistence.JournalProtocol.ReadHighestSequenceNr
 
persistenceId() - Method in class akka.persistence.JournalProtocol.ReplayMessages
 
persistenceId(ActorRef) - Method in class akka.persistence.Persistence
Creates a canonical persistent actor id from a processor actor ref.
persistenceId() - Method in interface akka.persistence.PersistentConfirmation
 
persistenceId() - Method in interface akka.persistence.PersistentId
Persistent id that journals a persistent message
persistenceId() - Method in class akka.persistence.PersistentImpl
 
persistenceId() - Method in interface akka.persistence.Processor
Persistence id.
persistenceId() - Method in interface akka.persistence.Recovery
Id of the persistent entity for which messages should be replayed.
persistenceId() - Method in class akka.persistence.RequestReader
 
persistenceId() - Method in class akka.persistence.RequestWriter
 
persistenceId() - Method in class akka.persistence.SnapshotMetadata
 
persistenceId() - Method in class akka.persistence.SnapshotProtocol.DeleteSnapshots
 
persistenceId() - Method in class akka.persistence.SnapshotProtocol.LoadSnapshot
 
persistenceId() - Method in class akka.persistence.UntypedEventsourcedProcessor
 
persistenceId() - Method in interface akka.persistence.View
Persistence id.
PersistenceId_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
PersistenceId_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
PersistenceSettings - Class in akka.persistence
Persistence configuration.
PersistenceSettings(com.typesafe.config.Config) - Constructor for class akka.persistence.PersistenceSettings
 
PersistenceSettings.atLeastOnceDelivery - Class in akka.persistence
 
PersistenceSettings.atLeastOnceDelivery() - Constructor for class akka.persistence.PersistenceSettings.atLeastOnceDelivery
 
PersistenceSettings.internal - Class in akka.persistence
INTERNAL API.
PersistenceSettings.internal() - Constructor for class akka.persistence.PersistenceSettings.internal
 
PersistenceSettings.journal - Class in akka.persistence
 
PersistenceSettings.journal() - Constructor for class akka.persistence.PersistenceSettings.journal
 
PersistenceSettings.view - Class in akka.persistence
 
PersistenceSettings.view() - Constructor for class akka.persistence.PersistenceSettings.view
 
persistent() - Method in class akka.persistence.Deliver
 
persistent() - Method in class akka.persistence.JournalProtocol.ReplayedMessage
 
persistent() - Method in class akka.persistence.JournalProtocol.WriteMessageSuccess
 
Persistent - Class in akka.persistence
Persistent message.
Persistent() - Constructor for class akka.persistence.Persistent
 
persistent() - Method in class akka.persistence.ReliableDelivery.DeliveryAttempt
 
Persistent$ - Class in akka.persistence
 
Persistent$() - Constructor for class akka.persistence.Persistent$
 
PERSISTENT_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.DeliverMessage
 
persistentActor() - Method in class akka.persistence.JournalProtocol.LoopMessage
 
persistentActor() - Method in class akka.persistence.JournalProtocol.ReadHighestSequenceNr
 
persistentActor() - Method in class akka.persistence.JournalProtocol.ReplayMessages
 
persistentActor() - Method in class akka.persistence.JournalProtocol.WriteMessages
 
PersistentActor - Interface in akka.persistence
An persistent Actor - can be used to implement command or event sourcing.
PersistentBatch - Class in akka.persistence
Instructs a Processor to atomically write the contained Persistent messages to the journal.
PersistentBatch(Seq<Resequenceable>) - Constructor for class akka.persistence.PersistentBatch
 
PersistentBatch$ - Class in akka.persistence
 
PersistentBatch$() - Constructor for class akka.persistence.PersistentBatch$
 
PersistentBatchClass() - Method in class akka.persistence.serialization.MessageSerializer
 
PersistentChannel - Class in akka.persistence
A PersistentChannel implements the same functionality as a Channel but additionally persists Deliver requests before they are served.
PersistentChannel(Option<String>, PersistentChannelSettings) - Constructor for class akka.persistence.PersistentChannel
 
PersistentChannel$ - Class in akka.persistence
 
PersistentChannel$() - Constructor for class akka.persistence.PersistentChannel$
 
PersistentChannelSettings - Class in akka.persistence
A PersistentChannel configuration object.
PersistentChannelSettings(int, FiniteDuration, Option<ActorRef>, boolean, long, long, FiniteDuration) - Constructor for class akka.persistence.PersistentChannelSettings
 
PersistentChannelSettings$ - Class in akka.persistence
 
PersistentChannelSettings$() - Constructor for class akka.persistence.PersistentChannelSettings$
 
PersistentConfirmation - Interface in akka.persistence
Plugin API: confirmation entry written by journal plugins.
persistentFromBytes(byte[]) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
PersistentId - Interface in akka.persistence
Plugin API: persistent message identifier.
PersistentIdImpl - Class in akka.persistence
INTERNAL API.
PersistentIdImpl(String, long) - Constructor for class akka.persistence.PersistentIdImpl
 
PersistentIdImpl$ - Class in akka.persistence
 
PersistentIdImpl$() - Constructor for class akka.persistence.PersistentIdImpl$
 
PersistentImpl - Class in akka.persistence
INTERNAL API.
PersistentImpl(Object, long, String, boolean, Seq<String>, ActorRef) - Constructor for class akka.persistence.PersistentImpl
 
PersistentImpl$ - Class in akka.persistence
 
PersistentImpl$() - Constructor for class akka.persistence.PersistentImpl$
 
PersistentImplClass() - Method in class akka.persistence.serialization.MessageSerializer
 
persistentPrepareWrite(Resequenceable) - Method in interface akka.persistence.journal.WriteJournalBase
 
PersistentQueue - Class in akka.actor.mailbox.filebased.filequeue
 
PersistentQueue(String, String, FileBasedMailboxSettings, LoggingAdapter) - Constructor for class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
PersistentQueue$ - Class in akka.actor.mailbox.filebased.filequeue
 
PersistentQueue$() - Constructor for class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
PersistentRepr - Interface in akka.persistence
Plugin API: representation of a persistent message in the journal plugin API.
PersistentRepr$ - Class in akka.persistence
 
PersistentRepr$() - Constructor for class akka.persistence.PersistentRepr$
 
PersistentReprClass() - Method in class akka.persistence.serialization.MessageSerializer
 
persistentSequenceNr() - Method in interface akka.persistence.Delivered
 
persistentSequenceNr() - Method in class akka.persistence.DeliveredByChannel
 
persistentSequenceNr() - Method in class akka.persistence.DeliveredByPersistentChannel
 
PERSISTENTSEQUENCENR_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
persistentState() - Method in class akka.contrib.pattern.ShardCoordinator
 
persistentToBytes(PersistentRepr) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
PersistentView - Interface in akka.persistence
A view replicates the persistent message stream of a PersistentActor.
persistingEvents() - Method in interface akka.persistence.Eventsourced
Event persisting state.
PFBuilder<I,R> - Class in akka.japi.pf
A builder for PartialFunction.
PFBuilder() - Constructor for class akka.japi.pf.PFBuilder
Create a PFBuilder.
phi() - Method in class akka.remote.PhiAccrualFailureDetector
The suspicion level of the accrual failure detector.
phi(long, double, double) - Method in class akka.remote.PhiAccrualFailureDetector
Calculation of phi, derived from the Cumulative distribution function for N(mean, stdDeviation) normal distribution, given by 1.0 / (1.0 + math.exp(-y * (1.5976 + 0.070566 * y * y))) where y = (x - mean) / standard_deviation This is an approximation defined in β Mathematics Handbook (Logistic approximation).
PhiAccrualFailureDetector - Class in akka.remote
Implementation of 'The Phi Accrual Failure Detector' by Hayashibara et al.
PhiAccrualFailureDetector(double, int, FiniteDuration, FiniteDuration, FiniteDuration, FailureDetector.Clock) - Constructor for class akka.remote.PhiAccrualFailureDetector
 
PhiAccrualFailureDetector(com.typesafe.config.Config, EventStream) - Constructor for class akka.remote.PhiAccrualFailureDetector
Constructor that reads parameters from config.
pickHighestPriority(Set<Member>, Set<Member>) - Method in class akka.cluster.Member$
 
pickHighestPriority(Set<Member>, Set<Member>) - Static method in class akka.cluster.Member
 
pid() - Method in class akka.cluster.SigarMetricsCollector
 
pid() - Method in interface akka.persistence.PluginSpec
 
PinnedDispatcher - Class in akka.dispatch
Dedicates a unique thread for each actor passed in as reference.
PinnedDispatcher(MessageDispatcherConfigurator, ActorCell, String, FiniteDuration, ThreadPoolConfig) - Constructor for class akka.dispatch.PinnedDispatcher
 
PinnedDispatcherConfigurator - Class in akka.dispatch
Configurator for creating PinnedDispatcher.
PinnedDispatcherConfigurator(com.typesafe.config.Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.PinnedDispatcherConfigurator
 
pipe(Future<T>, ExecutionContext) - Method in class akka.pattern.Patterns$
Register an onComplete callback on this Future to send the result to the given ActorRef or ActorSelection.
pipe(Future<T>, ExecutionContext) - Static method in class akka.pattern.Patterns
Register an onComplete callback on this Future to send the result to the given ActorRef or ActorSelection.
pipe(Future<T>, ExecutionContext) - Method in interface akka.pattern.PipeToSupport
Import this implicit conversion to gain the pipeTo method on Future:
pipeTo(ActorRef, ActorRef) - Method in class akka.pattern.PipeToSupport.PipeableFuture
 
pipeToSelection(ActorSelection, ActorRef) - Method in class akka.pattern.PipeToSupport.PipeableFuture
 
PipeToSupport - Interface in akka.pattern
 
PipeToSupport.PipeableFuture<T> - Class in akka.pattern
 
PipeToSupport.PipeableFuture(Future<T>, ExecutionContext) - Constructor for class akka.pattern.PipeToSupport.PipeableFuture
 
Player - Interface in akka.remote.testconductor
The Player is the client component of the TestConductorExt extension.
PlayerHandler - Class in akka.remote.testconductor
This handler only forwards messages received from the conductor to the ClientFSM.
PlayerHandler(InetSocketAddress, int, FiniteDuration, int, ActorRef, LoggingAdapter, Scheduler, ExecutionContext) - Constructor for class akka.remote.testconductor.PlayerHandler
 
PluginSpec - Interface in akka.persistence
 
point() - Method in class akka.actor.RepointableActorRef
This method is supposed to be called by the supervisor in handleSupervise() to replace the UnstartedCell with the real one.
PoisonPill - Class in akka.actor
 
PoisonPill() - Constructor for class akka.actor.PoisonPill
 
poisonPill(Object) - Method in interface akka.actor.TypedActorFactory
Sends a PoisonPill the underlying ActorRef for the supplied TypedActor proxy, if any, returns whether it could find the find the ActorRef or not
PoisonPill$ - Class in akka.actor
A message all Actors will understand, that when processed will terminate the Actor permanently.
PoisonPill$() - Constructor for class akka.actor.PoisonPill$
 
poll() - Method in class akka.dispatch.AbstractNodeQueue
Pull one item from the queue’s tail if there is one.
poll(long, TimeUnit) - Method in class akka.util.BoundedBlockingQueue
 
poll() - Method in class akka.util.BoundedBlockingQueue
 
PollDispatcher - Class in akka.zeromq
An option containing the configuration key for the poller loop dispatcher param: name
PollDispatcher(String) - Constructor for class akka.zeromq.PollDispatcher
 
PollDispatcher$ - Class in akka.zeromq
 
PollDispatcher$() - Constructor for class akka.zeromq.PollDispatcher$
 
poller() - Method in class akka.zeromq.Context
 
pollNode() - Method in class akka.dispatch.AbstractNodeQueue
Pull one item from the queue, returning it within a queue node.
PollTimeoutDuration - Class in akka.zeromq
An option containing the duration a poll cycle should wait for a message before it loops param: duration
PollTimeoutDuration(FiniteDuration) - Constructor for class akka.zeromq.PollTimeoutDuration
 
PollTimeoutDuration$ - Class in akka.zeromq
 
PollTimeoutDuration$() - Constructor for class akka.zeromq.PollTimeoutDuration$
 
pollTimeUnit() - Method in class akka.zeromq.ZeroMQExtension
 
Pool - Interface in akka.routing
RouterConfig for router actor that creates routees as child actors and removes them from the router if they terminate.
pool() - Method in class akka.routing.ResizablePoolCell
 
pool() - Method in class akka.routing.RouterPoolActor
 
Pool$ - Class in akka.routing
 
Pool$() - Constructor for class akka.routing.Pool$
 
PoolBase - Class in akka.routing
Java API: Base class for custom router Pool
PoolBase() - Constructor for class akka.routing.PoolBase
 
PoolOverrideUnsetConfig<T extends Pool> - Interface in akka.routing
INTERNAL API
pop() - Method in class akka.remote.transport.TestTransport.SwitchableLoggedBehavior
Restores the previous behavior.
port() - Method in class akka.actor.Address
 
PORT_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
PORT_FIELD_NUMBER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
PORT_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Address
 
PORT_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AddressData
 
PortSelector() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
pos() - Method in interface akka.actor.LoggingFSM
 
position() - Method in class akka.io.Tcp.WriteFile
 
PossiblyHarmful - Interface in akka.actor
Marker trait to indicate that a message might be potentially harmful, this is used to block messages coming in over remoting.
postRestart(Throwable) - Method in interface akka.actor.Actor
User overridable callback: By default it calls preStart().
postRestart(Throwable) - Method in interface akka.actor.dsl.Creators.Act
 
postRestart(Throwable) - Method in interface akka.actor.TypedActor.PostRestart
User overridable callback: By default it calls preStart().
postRestart(Throwable) - Method in class akka.actor.TypedActor.TypedActor
 
postRestart(Throwable) - Method in class akka.actor.UntypedActor
User overridable callback: By default it calls preStart().
postRestart(Throwable) - Method in class akka.event.DeadLetterListener
 
postRestart(Throwable) - Method in class akka.io.TcpConnection
 
postRestart(Throwable) - Method in class akka.remote.EndpointWriter
 
postRestart(Throwable) - Method in class akka.remote.ReliableDeliverySupervisor
 
postRestart(Throwable) - Method in class akka.remote.testconductor.BarrierCoordinator
 
postRestart(Throwable) - Method in class akka.zeromq.ConcurrentSocketActor
 
PostRestartException - Exception in akka.actor
A PostRestartException is thrown when constructor or postRestart() method fails during a restart attempt.
PostRestartException(ActorRef, Throwable, Throwable) - Constructor for exception akka.actor.PostRestartException
 
PostRestartException$ - Class in akka.actor
 
PostRestartException$() - Constructor for class akka.actor.PostRestartException$
 
postStop() - Method in interface akka.actor.Actor
User overridable callback.
postStop() - Method in interface akka.actor.dsl.Creators.Act
 
postStop() - Method in interface akka.actor.FSM
 
postStop() - Method in interface akka.actor.TypedActor.PostStop
User overridable callback.
postStop() - Method in class akka.actor.TypedActor.TypedActor
 
postStop() - Method in interface akka.actor.UnrestrictedStash
Overridden callback.
postStop() - Method in class akka.actor.UntypedActor
User overridable callback.
postStop() - Method in class akka.cluster.AutoDown
 
postStop() - Method in class akka.cluster.AutoDownBase
 
postStop() - Method in class akka.cluster.ClusterCoreDaemon
 
postStop() - Method in class akka.cluster.ClusterCoreSupervisor
 
postStop() - Method in class akka.cluster.ClusterDomainEventPublisher
 
postStop() - Method in class akka.cluster.ClusterHeartbeatSender
 
postStop() - Method in class akka.cluster.ClusterMetricsCollector
 
postStop() - Method in class akka.cluster.ClusterRemoteWatcher
 
postStop() - Method in class akka.cluster.FirstSeedNodeProcess
 
postStop() - Method in class akka.cluster.OnMemberUpListener
 
postStop() - Method in class akka.cluster.routing.AdaptiveLoadBalancingMetricsListener
 
postStop() - Method in interface akka.cluster.routing.ClusterRouterActor
 
postStop() - Method in class akka.contrib.pattern.ClusterClient
 
postStop() - Method in class akka.contrib.pattern.ClusterReceptionist
 
postStop() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
postStop() - Method in class akka.contrib.pattern.ClusterSingletonProxy
 
postStop() - Method in interface akka.contrib.pattern.DistributedPubSubMediator.Internal$.TopicLike
 
postStop() - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
postStop() - Method in class akka.contrib.pattern.ReliableProxy
 
postStop() - Method in class akka.contrib.pattern.ShardCoordinator
 
postStop() - Method in class akka.contrib.pattern.ShardRegion
 
postStop() - Method in class akka.event.DeadLetterListener
 
postStop() - Method in class akka.io.SelectionHandler
 
postStop() - Method in class akka.io.TcpConnection
 
postStop() - Method in class akka.io.TcpListener
 
postStop() - Method in class akka.io.UdpConnection
 
postStop() - Method in class akka.io.UdpListener
 
postStop() - Method in class akka.io.UdpSender
 
postStop() - Method in interface akka.persistence.Eventsourced
 
postStop() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
postStop() - Method in interface akka.persistence.PersistentView
 
postStop() - Method in class akka.persistence.Redelivery
 
postStop() - Method in interface akka.persistence.View
 
postStop() - Method in class akka.remote.EndpointManager
 
postStop() - Method in class akka.remote.EndpointReader
 
postStop() - Method in class akka.remote.EndpointWriter
 
postStop() - Method in class akka.remote.ReliableDeliverySupervisor
 
postStop() - Method in class akka.remote.RemoteWatcher
 
postStop() - Method in class akka.remote.testconductor.Controller
 
postStop() - Method in class akka.remote.transport.ProtocolStateActor
 
postStop() - Method in class akka.remote.transport.ThrottledAssociation
 
postStop() - Method in class akka.testkit.TestActor
 
postStop() - Method in class akka.zeromq.ConcurrentSocketActor
 
predicate() - Method in class akka.actor.dsl.Inbox.Select
 
Predicate<T> - Interface in akka.japi.function
Java API: Defines a criteria and determines whether the parameter meets this criteria.
Predicate<T> - Interface in akka.japi
Java API: Defines a criteria and determines whether the parameter meets this criteria.
PredicateClassifier - Interface in akka.event
Can be mixed into an EventBus to specify that the Classifier type is a Function from Event to Boolean (predicate)
preparePersistentBatch(Seq<Resequenceable>) - Method in interface akka.persistence.journal.WriteJournalBase
 
prepareRestart() - Method in interface akka.persistence.Recovery
INTERNAL API.
prepareWrite(ActorRef) - Method in class akka.persistence.ConfirmablePersistentImpl
 
prepareWrite(ActorRef) - Method in class akka.persistence.PersistentImpl
 
prepareWrite(ActorRef) - Method in interface akka.persistence.PersistentRepr
INTERNAL API.
prepareWrite(ActorContext) - Method in interface akka.persistence.PersistentRepr
INTERNAL API.
prepend(T) - Method in interface akka.actor.mailbox.filebased.filequeue.Prependable
 
prepend(Seq<Envelope>) - Method in interface akka.actor.StashSupport
Prepends others to this stash.
prepend(Tcp.SimpleWriteCommand) - Method in class akka.io.Tcp.WriteCommand
Java API: prepends this command with another Write or WriteFile to form a CompoundWrite.
prepend(Iterable<Tcp.WriteCommand>) - Method in class akka.io.Tcp.WriteCommand
Java API: prepends this command with a number of other writes.
Prependable<T> - Interface in akka.actor.mailbox.filebased.filequeue
 
prerequisites() - Method in class akka.dispatch.Dispatchers
 
prerequisites() - Method in class akka.dispatch.MessageDispatcherConfigurator
 
preRestart(Throwable, Option<Object>) - Method in interface akka.actor.Actor
User overridable callback: '''By default it disposes of all children and then calls postStop().'''
preRestart(Throwable, Option<Object>) - Method in interface akka.actor.dsl.Creators.Act
 
preRestart(Throwable, Option<Object>) - Method in interface akka.actor.TypedActor.PreRestart
User overridable callback: '''By default it disposes of all children and then calls postStop().'''
preRestart(Throwable, Option<Object>) - Method in class akka.actor.TypedActor.TypedActor
 
preRestart(Throwable, Option<Object>) - Method in interface akka.actor.UnrestrictedStash
Overridden callback.
preRestart(Throwable, Option<Object>) - Method in class akka.actor.UntypedActor
User overridable callback: '''By default it disposes of all children and then calls postStop().'''
preRestart(Throwable, Option<Object>) - Method in class akka.cluster.ClusterDomainEventPublisher
 
preRestart(Throwable, Option<Object>) - Method in class akka.event.DeadLetterListener
 
preRestart(Throwable, Option<Object>) - Method in interface akka.persistence.Eventsourced
 
preRestart(Throwable, Option<Object>) - Method in interface akka.persistence.PersistentView
 
preRestart(Throwable, Option<Object>) - Method in interface akka.persistence.ProcessorImpl
User-overridable callback.
preRestart(Throwable, Option<Object>) - Method in class akka.persistence.RequestReader
 
preRestart(Throwable, Option<Object>) - Method in class akka.persistence.RequestWriter
 
preRestart(Throwable, Option<Object>) - Method in interface akka.persistence.View
 
preRestart(Throwable, Option<Object>) - Method in class akka.remote.testconductor.BarrierCoordinator
 
preRestart(Throwable, Option<Object>) - Method in class akka.routing.RouterActor
 
preRestart(Throwable, Option<Object>) - Method in class akka.zeromq.ConcurrentSocketActor
 
preRestartDefault(Throwable, Option<Object>) - Method in interface akka.persistence.ProcessorImpl
Calls preRestart and then super.preRestart().
PreRestartException - Exception in akka.actor
A PreRestartException is thrown when the preRestart() method failed; this exception is not propagated to the supervisor, as it originates from the already failed instance, hence it is only visible as log entry on the event stream.
PreRestartException(ActorRef, Throwable, Throwable, Option<Object>) - Constructor for exception akka.actor.PreRestartException
 
PreRestartException$ - Class in akka.actor
 
PreRestartException$() - Constructor for class akka.actor.PreRestartException$
 
pressure(IndexedSeq<Routee>) - Method in class akka.routing.DefaultResizer
Number of routees considered busy, or above 'pressure level'.
pressureThreshold() - Method in class akka.routing.DefaultResizer
 
preStart() - Method in interface akka.actor.Actor
User overridable callback.
preStart() - Method in interface akka.actor.dsl.Creators.Act
 
preStart() - Method in interface akka.actor.TypedActor.PreStart
User overridable callback.
preStart() - Method in class akka.actor.TypedActor.TypedActor
 
preStart() - Method in class akka.actor.UntypedActor
User overridable callback.
preStart() - Method in interface akka.camel.Consumer
Registers the consumer endpoint.
preStart() - Method in interface akka.camel.ProducerSupport
 
preStart() - Method in class akka.cluster.AutoDown
 
preStart() - Method in class akka.cluster.ClusterCoreDaemon
 
preStart() - Method in class akka.cluster.ClusterHeartbeatSender
 
preStart() - Method in class akka.cluster.ClusterMetricsCollector
 
preStart() - Method in class akka.cluster.ClusterRemoteWatcher
 
preStart() - Method in class akka.cluster.JoinSeedNodeProcess
 
preStart() - Method in class akka.cluster.OnMemberUpListener
 
preStart() - Method in class akka.cluster.routing.AdaptiveLoadBalancingMetricsListener
 
preStart() - Method in interface akka.cluster.routing.ClusterRouterActor
 
preStart() - Method in class akka.contrib.pattern.ClusterReceptionist
 
preStart() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
preStart() - Method in class akka.contrib.pattern.ClusterSingletonProxy
 
preStart() - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
preStart() - Method in class akka.contrib.pattern.ShardCoordinatorSupervisor
 
preStart() - Method in class akka.contrib.pattern.ShardRegion
 
preStart() - Method in class akka.event.DeadLetterListener
 
preStart() - Method in class akka.persistence.journal.inmem.InmemJournal
 
preStart() - Method in interface akka.persistence.journal.leveldb.LeveldbIdMapping
 
preStart() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
preStart() - Method in interface akka.persistence.PersistentView
Triggers an initial recovery, starting form a snapshot, if any, and replaying at most autoUpdateReplayMax messages (following that snapshot).
preStart() - Method in interface akka.persistence.ProcessorImpl
User-overridable callback.
preStart() - Method in class akka.persistence.Redelivery
 
preStart() - Method in class akka.persistence.RequestReader
 
preStart() - Method in class akka.persistence.RequestWriter
 
preStart() - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
 
preStart() - Method in interface akka.persistence.View
Triggers an initial recovery, starting form a snapshot, if any, and replaying at most autoUpdateReplayMax messages (following that snapshot).
preStart() - Method in class akka.remote.EndpointReader
 
preStart() - Method in class akka.remote.EndpointWriter
 
preStart() - Method in class akka.zeromq.ConcurrentSocketActor
 
preSuperStart() - Method in class akka.routing.ResizablePoolCell
 
preSuperStart() - Method in class akka.routing.RoutedActorCell
Called when router is initalized but before super.start() to be able to do extra initialization in subclass.
previousStatus() - Method in class akka.cluster.ClusterEvent.MemberRemoved
 
print(Object) - Method in interface akka.event.Logging.StdOutLogger
 
printActors() - Method in class akka.dispatch.MessageDispatcher$
 
printActors() - Static method in class akka.dispatch.MessageDispatcher
 
printedWarning() - Method in class akka.actor.dsl.Inbox.InboxActor
 
printReport(String, PrintStream) - Method in class akka.testkit.Coroner$
Print a report containing diagnostic information.
printReport(String, PrintStream) - Static method in class akka.testkit.Coroner
Print a report containing diagnostic information.
printTree() - Method in class akka.actor.ActorSystemImpl
 
printTree() - Method in class akka.actor.ExtendedActorSystem
For debugging: traverse actor hierarchy and make string representation.
prioBuffer() - Method in class akka.remote.EndpointWriter
 
PriorityGenerator - Class in akka.dispatch
A PriorityGenerator is a convenience API to create a Comparator that orders the messages of a PriorityDispatcher
PriorityGenerator() - Constructor for class akka.dispatch.PriorityGenerator
 
PriorityGenerator$ - Class in akka.dispatch
 
PriorityGenerator$() - Constructor for class akka.dispatch.PriorityGenerator$
 
PriorityMessage - Interface in akka.remote
INTERNAL API Messages marked with this trait will be sent before other messages when buffering is active.
Procedure<T> - Interface in akka.japi.function
A Procedure is like a Function, but it doesn't produce a return value.
Procedure<T> - Interface in akka.japi
A Procedure is like a Function, but it doesn't produce a return value.
Procedure10<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10> - Interface in akka.japi.function
A Consumer interface.
Procedure11<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11> - Interface in akka.japi.function
A Consumer interface.
Procedure12<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12> - Interface in akka.japi.function
A Consumer interface.
Procedure13<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13> - Interface in akka.japi.function
A Consumer interface.
Procedure14<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14> - Interface in akka.japi.function
A Consumer interface.
Procedure15<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15> - Interface in akka.japi.function
A Consumer interface.
Procedure16<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16> - Interface in akka.japi.function
A Consumer interface.
Procedure17<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17> - Interface in akka.japi.function
A Consumer interface.
Procedure18<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18> - Interface in akka.japi.function
A Consumer interface.
Procedure19<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19> - Interface in akka.japi.function
A Consumer interface.
Procedure2<T1,T2> - Interface in akka.japi.function
A Consumer interface.
Procedure20<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20> - Interface in akka.japi.function
A Consumer interface.
Procedure21<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21> - Interface in akka.japi.function
A Consumer interface.
Procedure22<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22> - Interface in akka.japi.function
A Consumer interface.
Procedure3<T1,T2,T3> - Interface in akka.japi.function
A Consumer interface.
Procedure4<T1,T2,T3,T4> - Interface in akka.japi.function
A Consumer interface.
Procedure5<T1,T2,T3,T4,T5> - Interface in akka.japi.function
A Consumer interface.
Procedure6<T1,T2,T3,T4,T5,T6> - Interface in akka.japi.function
A Consumer interface.
Procedure7<T1,T2,T3,T4,T5,T6,T7> - Interface in akka.japi.function
A Consumer interface.
Procedure8<T1,T2,T3,T4,T5,T6,T7,T8> - Interface in akka.japi.function
A Consumer interface.
Procedure9<T1,T2,T3,T4,T5,T6,T7,T8,T9> - Interface in akka.japi.function
A Consumer interface.
process(org.apache.camel.Exchange) - Method in class akka.camel.internal.component.ActorProducer
Processes the exchange.
process(org.apache.camel.Exchange, org.apache.camel.AsyncCallback) - Method in class akka.camel.internal.component.ActorProducer
Processes the message exchange.
process(Function1<T, Object>) - Method in class akka.contrib.pattern.WorkList
Tries to process each entry using the processing function.
process(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.persistence.Recovery.State
 
processAllSystemMessages() - Method in class akka.dispatch.Mailbox
Will at least try to process all queued system messages: in case of failure simply drop and go on to the next, because there is nothing to restart here (failure is in ActorCell somewhere …).
processBatch(BatchingExecutor.AbstractBatch) - Method in class akka.dispatch.BatchingExecutor.AbstractBatch
 
processEvent(FSM.Event<D>, Object) - Method in interface akka.actor.FSM
 
processEvent(FSM.Event<D>, Object) - Method in interface akka.actor.LoggingFSM
 
processExchangeAdapter(CamelExchangeAdapter) - Method in class akka.camel.internal.component.ActorProducer
INTERNAL API Processes the CamelExchangeAdapter
processExchangeAdapter(CamelExchangeAdapter, org.apache.camel.AsyncCallback) - Method in class akka.camel.internal.component.ActorProducer
INTERNAL API Processes the CamelExchangeAdapter.
processFailure(ActorContext, boolean, ActorRef, Throwable, ChildRestartStats, Iterable<ChildRestartStats>) - Method in class akka.actor.AllForOneStrategy
 
processFailure(ActorContext, boolean, ActorRef, Throwable, ChildRestartStats, Iterable<ChildRestartStats>) - Method in class akka.actor.OneForOneStrategy
 
processFailure(ActorContext, boolean, ActorRef, Throwable, ChildRestartStats, Iterable<ChildRestartStats>) - Method in class akka.actor.SupervisorStrategy
This method is called to act on the failure of a child: restart if the flag is true, stop otherwise.
processing() - Method in interface akka.contrib.pattern.Aggregator
 
processing() - Method in interface akka.persistence.ProcessorImpl
Journals and processes new messages, both persistent and transient.
processingCommands() - Method in interface akka.persistence.Eventsourced
Command processing state.
processMsg(Object, Object) - Method in interface akka.actor.FSM
 
processor() - Method in class akka.camel.internal.CamelSupervisor.CamelProducerObjects
 
Processor - Interface in akka.persistence
An actor that persists (journals) messages of type Persistent.
processorBatch() - Method in interface akka.persistence.ProcessorImpl
 
processorId() - Method in class akka.persistence.ConfirmablePersistentImpl
 
processorId() - Method in class akka.persistence.DeliveredByPersistentChannel
 
processorId(ActorRef) - Method in class akka.persistence.Persistence
Creates a canonical processor id from a processor actor ref.
processorId() - Method in interface akka.persistence.PersistentConfirmation
 
processorId() - Method in interface akka.persistence.PersistentId
Persistent id that journals a persistent message
processorId() - Method in class akka.persistence.PersistentIdImpl
 
processorId() - Method in class akka.persistence.PersistentImpl
 
processorId() - Method in interface akka.persistence.ProcessorImpl
Processor id.
processorId() - Method in interface akka.persistence.Recovery
Id of the processor for which messages should be replayed.
processorId() - Method in class akka.persistence.SnapshotMetadata
 
processorId() - Method in class akka.persistence.SnapshotProtocol.DeleteSnapshots
 
processorId() - Method in class akka.persistence.SnapshotProtocol.LoadSnapshot
 
ProcessorImpl - Interface in akka.persistence
INTERNAL API
ProcessorImpl$ - Class in akka.persistence
INTERNAL API
ProcessorImpl$() - Constructor for class akka.persistence.ProcessorImpl$
 
processors() - Method in class akka.cluster.JmxMetricsCollector
(JMX) Returns the number of available processors Creates a new instance each time.
Processors() - Method in class akka.cluster.StandardMetrics$
 
processors() - Method in class akka.cluster.StandardMetrics.Cpu
 
Processors() - Static method in class akka.cluster.StandardMetrics
 
processorStash() - Method in interface akka.persistence.Eventsourced
 
processPersistent(PartialFunction<Object, BoxedUnit>, Persistent) - Method in interface akka.persistence.Recovery.State
 
produce() - Method in class akka.actor.ArgsReflectConstructor
 
produce() - Method in class akka.actor.CreatorConsumer
 
produce() - Method in class akka.actor.CreatorFunctionConsumer
 
produce() - Method in interface akka.actor.IndirectActorProducer
This factory method must produce a fresh actor instance upon each invocation.
produce() - Method in class akka.actor.NoArgsReflectConstructor
 
produce() - Method in class akka.actor.TypedCreatorFunctionConsumer
 
produce() - Method in class akka.actor.UntypedActorFactoryConsumer
 
produce() - Method in interface akka.camel.ProducerSupport
Produces msg to the endpoint specified by endpointUri.
produce(org.apache.camel.Endpoint, org.apache.camel.processor.SendProcessor, Object, org.apache.camel.ExchangePattern) - Method in class akka.camel.ProducerSupport.ProducerChild
Initiates a message exchange of given pattern with the endpoint specified by endpointUri.
produce() - Method in class akka.routing.RoutedActorCell.RouterActorCreator
 
producer() - Method in class akka.actor.Props
INTERNAL API
Producer - Interface in akka.camel
Mixed in by Actor implementations to produce messages to Camel endpoints.
ProducerRegistrar - Class in akka.camel.internal
INTERNAL API Registers Producers.
ProducerRegistrar(ActorRef) - Constructor for class akka.camel.internal.ProducerRegistrar
 
ProducerSupport - Interface in akka.camel
Support trait for producing messages to Camel endpoints.
ProducerSupport.ProducerChild - Class in akka.camel
 
ProducerSupport.ProducerChild(org.apache.camel.Endpoint, org.apache.camel.processor.SendProcessor) - Constructor for class akka.camel.ProducerSupport.ProducerChild
 
ProducesMessageQueue<T extends MessageQueue> - Interface in akka.dispatch
 
promise() - Method in class akka.dispatch.Futures$
Creates a promise object which can be completed with a value.
promise() - Static method in class akka.dispatch.Futures
Creates a promise object which can be completed with a value.
PromiseActorRef - Class in akka.pattern
Akka private optimized representation of the temporary actor spawned to receive the reply to an "ask" operation.
PromiseActorRef$ - Class in akka.pattern
INTERNAL API
PromiseActorRef$() - Constructor for class akka.pattern.PromiseActorRef$
 
props() - Method in class akka.actor.ActorCell
 
props() - Method in interface akka.actor.ActorContext
Retrieve the Props which were used to create this actor.
props() - Method in interface akka.actor.Cell
The props for this actor cell.
Props - Class in akka.actor
 
Props(Deploy, Class<?>, Seq<Object>) - Constructor for class akka.actor.Props
 
props() - Method in class akka.actor.RepointableActorRef
 
props() - Method in class akka.actor.UnstartedCell
 
props(FiniteDuration) - Method in class akka.cluster.AutoDown$
 
props(FiniteDuration) - Static method in class akka.cluster.AutoDown
 
props(FailureDetectorRegistry<Address>, FiniteDuration, FiniteDuration, FiniteDuration) - Method in class akka.cluster.ClusterRemoteWatcher$
Factory method for ClusterRemoteWatcher Props.
props(FailureDetectorRegistry<Address>, FiniteDuration, FiniteDuration, FiniteDuration) - Static method in class akka.cluster.ClusterRemoteWatcher
Factory method for ClusterRemoteWatcher Props.
props(Set<ActorSelection>, FiniteDuration, FiniteDuration) - Method in class akka.contrib.pattern.ClusterClient$
Scala API: Factory method for ClusterClient Props.
props(Set<ActorSelection>, FiniteDuration, FiniteDuration) - Method in class akka.contrib.pattern.ClusterClient$
Java API: Factory method for ClusterClient Props.
props(Set<ActorSelection>, FiniteDuration, FiniteDuration) - Static method in class akka.contrib.pattern.ClusterClient
Scala API: Factory method for ClusterClient Props.
props(Set<ActorSelection>, FiniteDuration, FiniteDuration) - Static method in class akka.contrib.pattern.ClusterClient
Java API: Factory method for ClusterClient Props.
props(ActorRef, Option<String>, int, FiniteDuration) - Method in class akka.contrib.pattern.ClusterReceptionist$
Scala API: Factory method for ClusterReceptionist Props.
props(ActorRef, String, int, FiniteDuration) - Method in class akka.contrib.pattern.ClusterReceptionist$
Java API: Factory method for ClusterReceptionist Props.
props(ActorRef, String) - Method in class akka.contrib.pattern.ClusterReceptionist$
Java API: Factory method for ClusterReceptionist Props with default values.
props(ActorRef, Option<String>, int, FiniteDuration) - Static method in class akka.contrib.pattern.ClusterReceptionist
Scala API: Factory method for ClusterReceptionist Props.
props(ActorRef, String, int, FiniteDuration) - Static method in class akka.contrib.pattern.ClusterReceptionist
Java API: Factory method for ClusterReceptionist Props.
props(ActorRef, String) - Static method in class akka.contrib.pattern.ClusterReceptionist
Java API: Factory method for ClusterReceptionist Props with default values.
props(Props, String, Object, Option<String>, int, int, FiniteDuration) - Method in class akka.contrib.pattern.ClusterSingletonManager$
Scala API: Factory method for ClusterSingletonManager Props.
props(Props, String, Object, String, int, int, FiniteDuration) - Method in class akka.contrib.pattern.ClusterSingletonManager$
Java API: Factory method for ClusterSingletonManager Props.
props(Props, String, Object, Option<String>, int, int, FiniteDuration) - Static method in class akka.contrib.pattern.ClusterSingletonManager
Scala API: Factory method for ClusterSingletonManager Props.
props(Props, String, Object, String, int, int, FiniteDuration) - Static method in class akka.contrib.pattern.ClusterSingletonManager
Java API: Factory method for ClusterSingletonManager Props.
props(String, Option<String>, FiniteDuration) - Method in class akka.contrib.pattern.ClusterSingletonProxy$
Scala API: Factory method for ClusterSingletonProxy Props.
props(String, String, FiniteDuration) - Method in class akka.contrib.pattern.ClusterSingletonProxy$
Java API: Factory method for ClusterSingletonProxy Props.
props(String, Option<String>, FiniteDuration) - Static method in class akka.contrib.pattern.ClusterSingletonProxy
Scala API: Factory method for ClusterSingletonProxy Props.
props(String, String, FiniteDuration) - Static method in class akka.contrib.pattern.ClusterSingletonProxy
Java API: Factory method for ClusterSingletonProxy Props.
props(Option<String>, RoutingLogic, FiniteDuration, FiniteDuration, int) - Method in class akka.contrib.pattern.DistributedPubSubMediator$
Scala API: Factory method for DistributedPubSubMediator Props.
props(String, RoutingLogic, FiniteDuration, FiniteDuration, int) - Method in class akka.contrib.pattern.DistributedPubSubMediator$
Java API: Factory method for DistributedPubSubMediator Props.
props(Option<String>, RoutingLogic, FiniteDuration, FiniteDuration, int) - Static method in class akka.contrib.pattern.DistributedPubSubMediator
Scala API: Factory method for DistributedPubSubMediator Props.
props(String, RoutingLogic, FiniteDuration, FiniteDuration, int) - Static method in class akka.contrib.pattern.DistributedPubSubMediator
Java API: Factory method for DistributedPubSubMediator Props.
props(ActorPath, FiniteDuration, Option<FiniteDuration>, Option<Object>) - Method in class akka.contrib.pattern.ReliableProxy$
Scala API Props.
props(ActorPath, FiniteDuration, FiniteDuration, int) - Method in class akka.contrib.pattern.ReliableProxy$
Java API Props.
props(ActorPath, FiniteDuration, FiniteDuration) - Method in class akka.contrib.pattern.ReliableProxy$
Props with no limit on reconnections.
props(ActorPath, FiniteDuration) - Method in class akka.contrib.pattern.ReliableProxy$
Props with no reconnections.
props(ActorPath, FiniteDuration, Option<FiniteDuration>, Option<Object>) - Static method in class akka.contrib.pattern.ReliableProxy
Scala API Props.
props(ActorPath, FiniteDuration, FiniteDuration, int) - Static method in class akka.contrib.pattern.ReliableProxy
Java API Props.
props(ActorPath, FiniteDuration, FiniteDuration) - Static method in class akka.contrib.pattern.ReliableProxy
Props with no limit on reconnections.
props(ActorPath, FiniteDuration) - Static method in class akka.contrib.pattern.ReliableProxy
Props with no reconnections.
props(FiniteDuration, FiniteDuration, FiniteDuration, ShardCoordinator.ShardAllocationStrategy) - Method in class akka.contrib.pattern.ShardCoordinator$
Factory method for the Props of the ShardCoordinator actor.
props(FiniteDuration, FiniteDuration, FiniteDuration, ShardCoordinator.ShardAllocationStrategy) - Static method in class akka.contrib.pattern.ShardCoordinator
Factory method for the Props of the ShardCoordinator actor.
props(FiniteDuration, Props) - Method in class akka.contrib.pattern.ShardCoordinatorSupervisor$
Factory method for the Props of the ShardCoordinator actor.
props(FiniteDuration, Props) - Static method in class akka.contrib.pattern.ShardCoordinatorSupervisor
Factory method for the Props of the ShardCoordinator actor.
props(Option<Props>, Option<String>, String, FiniteDuration, int, PartialFunction<Object, Tuple2<String, Object>>, Function1<Object, String>) - Method in class akka.contrib.pattern.ShardRegion$
Scala API: Factory method for the Props of the ShardRegion actor.
props(Props, Option<String>, String, FiniteDuration, int, PartialFunction<Object, Tuple2<String, Object>>, Function1<Object, String>) - Method in class akka.contrib.pattern.ShardRegion$
Scala API: Factory method for the Props of the ShardRegion actor.
props(Props, String, String, FiniteDuration, int, ShardRegion.MessageExtractor) - Method in class akka.contrib.pattern.ShardRegion$
Java API: Factory method for the Props of the ShardRegion actor.
props(Option<Props>, Option<String>, String, FiniteDuration, int, PartialFunction<Object, Tuple2<String, Object>>, Function1<Object, String>) - Static method in class akka.contrib.pattern.ShardRegion
Scala API: Factory method for the Props of the ShardRegion actor.
props(Props, Option<String>, String, FiniteDuration, int, PartialFunction<Object, Tuple2<String, Object>>, Function1<Object, String>) - Static method in class akka.contrib.pattern.ShardRegion
Scala API: Factory method for the Props of the ShardRegion actor.
props(Props, String, String, FiniteDuration, int, ShardRegion.MessageExtractor) - Static method in class akka.contrib.pattern.ShardRegion
Java API: Factory method for the Props of the ShardRegion actor.
props() - Method in class akka.persistence.Channel$
Returns a channel actor configuration object for creating a Channel with a generated id and default ChannelSettings.
props(ChannelSettings) - Method in class akka.persistence.Channel$
Returns a channel actor configuration object for creating a Channel with a generated id and specified channelSettings.
props(String) - Method in class akka.persistence.Channel$
Returns a channel actor configuration object for creating a Channel with the specified id and default ChannelSettings.
props(String, ChannelSettings) - Method in class akka.persistence.Channel$
Returns a channel actor configuration object for creating a Channel with the specified id and specified channelSettings.
props() - Static method in class akka.persistence.Channel
Returns a channel actor configuration object for creating a Channel with a generated id and default ChannelSettings.
props(ChannelSettings) - Static method in class akka.persistence.Channel
Returns a channel actor configuration object for creating a Channel with a generated id and specified channelSettings.
props(String) - Static method in class akka.persistence.Channel
Returns a channel actor configuration object for creating a Channel with the specified id and default ChannelSettings.
props(String, ChannelSettings) - Static method in class akka.persistence.Channel
Returns a channel actor configuration object for creating a Channel with the specified id and specified channelSettings.
props() - Method in class akka.persistence.PersistentChannel$
Returns a channel actor configuration object for creating a PersistentChannel with a generated id and default PersistentChannelSettings.
props(PersistentChannelSettings) - Method in class akka.persistence.PersistentChannel$
Returns a channel actor configuration object for creating a PersistentChannel with a generated id and specified channelSettings.
props(String) - Method in class akka.persistence.PersistentChannel$
Returns a channel actor configuration object for creating a PersistentChannel with the specified id and default PersistentChannelSettings.
props(String, PersistentChannelSettings) - Method in class akka.persistence.PersistentChannel$
Returns a channel actor configuration object for creating a PersistentChannel with the specified id and specified channelSettings.
props() - Static method in class akka.persistence.PersistentChannel
Returns a channel actor configuration object for creating a PersistentChannel with a generated id and default PersistentChannelSettings.
props(PersistentChannelSettings) - Static method in class akka.persistence.PersistentChannel
Returns a channel actor configuration object for creating a PersistentChannel with a generated id and specified channelSettings.
props(String) - Static method in class akka.persistence.PersistentChannel
Returns a channel actor configuration object for creating a PersistentChannel with the specified id and default PersistentChannelSettings.
props(String, PersistentChannelSettings) - Static method in class akka.persistence.PersistentChannel
Returns a channel actor configuration object for creating a PersistentChannel with the specified id and specified channelSettings.
props() - Method in class akka.remote.DaemonMsgCreate
 
props(Address, Address, Transport, RemoteSettings, AkkaPduCodec, InboundMessageDispatcher, boolean, int, Option<ActorRef>, ConcurrentHashMap<EndpointManager.Link, EndpointManager.ResendState>) - Method in class akka.remote.EndpointReader$
 
props(Address, Address, Transport, RemoteSettings, AkkaPduCodec, InboundMessageDispatcher, boolean, int, Option<ActorRef>, ConcurrentHashMap<EndpointManager.Link, EndpointManager.ResendState>) - Static method in class akka.remote.EndpointReader
 
props(Option<AkkaProtocolHandle>, Address, Address, Option<Object>, AkkaProtocolTransport, RemoteSettings, AkkaPduCodec, ConcurrentHashMap<EndpointManager.Link, EndpointManager.ResendState>, Option<ActorRef>) - Method in class akka.remote.EndpointWriter$
 
props(Option<AkkaProtocolHandle>, Address, Address, Option<Object>, AkkaProtocolTransport, RemoteSettings, AkkaPduCodec, ConcurrentHashMap<EndpointManager.Link, EndpointManager.ResendState>, Option<ActorRef>) - Static method in class akka.remote.EndpointWriter
 
props(Option<AkkaProtocolHandle>, Address, Address, Option<Object>, AkkaProtocolTransport, RemoteSettings, AkkaPduCodec, ConcurrentHashMap<EndpointManager.Link, EndpointManager.ResendState>) - Method in class akka.remote.ReliableDeliverySupervisor$
 
props(Option<AkkaProtocolHandle>, Address, Address, Option<Object>, AkkaProtocolTransport, RemoteSettings, AkkaPduCodec, ConcurrentHashMap<EndpointManager.Link, EndpointManager.ResendState>) - Static method in class akka.remote.ReliableDeliverySupervisor
 
props(FailureDetectorRegistry<Address>, FiniteDuration, FiniteDuration, FiniteDuration) - Method in class akka.remote.RemoteWatcher$
Factory method for RemoteWatcher Props.
props(FailureDetectorRegistry<Address>, FiniteDuration, FiniteDuration, FiniteDuration) - Static method in class akka.remote.RemoteWatcher
Factory method for RemoteWatcher Props.
props() - Method in class akka.remote.Remoting.RegisterTransportActor
 
props() - Method in class akka.routing.FromConfig
Props for a group router based on the settings defined by this instance.
props() - Method in interface akka.routing.Group
Props for a group router based on the settings defined by this instance.
props(Props) - Method in class akka.routing.NoRouter$
 
props(Props) - Static method in class akka.routing.NoRouter
 
props(Props) - Method in interface akka.routing.Pool
Props for a pool router based on the settings defined by this instance and the supplied Props for the routees created by the router.
props(BlockingDeque<TestActor.Message>) - Method in class akka.testkit.TestActor$
 
props(BlockingDeque<TestActor.Message>) - Static method in class akka.testkit.TestActor
 
props() - Method in class akka.testkit.TestActorRef
 
Props$ - Class in akka.actor
Factory for Props instances.
Props$() - Constructor for class akka.actor.Props$
 
Props.EmptyActor - Class in akka.actor
INTERNAL API
Props.EmptyActor() - Constructor for class akka.actor.Props.EmptyActor
 
PROPS_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DaemonMsgCreateData
 
ProtobufSerializer - Class in akka.remote.serialization
This Serializer serializes com.google.protobuf.Messages
ProtobufSerializer() - Constructor for class akka.remote.serialization.ProtobufSerializer
 
ProtobufSerializer$ - Class in akka.remote.serialization
 
ProtobufSerializer$() - Constructor for class akka.remote.serialization.ProtobufSerializer$
 
protocol() - Method in class akka.actor.Address
 
PROTOCOL_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
PROTOCOL_FIELD_NUMBER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
PROTOCOL_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Address
 
PROTOCOL_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AddressData
 
ProtocolStateActor - Class in akka.remote.transport
 
ProtocolStateActor(ProtocolStateActor.InitialProtocolStateData, HandshakeInfo, Option<Object>, AkkaProtocolSettings, AkkaPduCodec, FailureDetector) - Constructor for class akka.remote.transport.ProtocolStateActor
 
ProtocolStateActor(HandshakeInfo, Address, Promise<AssociationHandle>, Transport, AkkaProtocolSettings, AkkaPduCodec, FailureDetector, Option<Object>) - Constructor for class akka.remote.transport.ProtocolStateActor
 
ProtocolStateActor(HandshakeInfo, AssociationHandle, Transport.AssociationEventListener, AkkaProtocolSettings, AkkaPduCodec, FailureDetector) - Constructor for class akka.remote.transport.ProtocolStateActor
 
ProtocolStateActor$ - Class in akka.remote.transport
 
ProtocolStateActor$() - Constructor for class akka.remote.transport.ProtocolStateActor$
 
ProtocolStateActor.AssociatedWaitHandler - Class in akka.remote.transport
 
ProtocolStateActor.AssociatedWaitHandler(Future<AssociationHandle.HandleEventListener>, AssociationHandle, Queue<ByteString>) - Constructor for class akka.remote.transport.ProtocolStateActor.AssociatedWaitHandler
 
ProtocolStateActor.AssociatedWaitHandler$ - Class in akka.remote.transport
 
ProtocolStateActor.AssociatedWaitHandler$() - Constructor for class akka.remote.transport.ProtocolStateActor.AssociatedWaitHandler$
 
ProtocolStateActor.AssociationState - Interface in akka.remote.transport
 
ProtocolStateActor.Closed$ - Class in akka.remote.transport
 
ProtocolStateActor.Closed$() - Constructor for class akka.remote.transport.ProtocolStateActor.Closed$
 
ProtocolStateActor.ForbiddenUidReason$ - Class in akka.remote.transport
 
ProtocolStateActor.ForbiddenUidReason$() - Constructor for class akka.remote.transport.ProtocolStateActor.ForbiddenUidReason$
 
ProtocolStateActor.Handle - Class in akka.remote.transport
 
ProtocolStateActor.Handle(AssociationHandle) - Constructor for class akka.remote.transport.ProtocolStateActor.Handle
 
ProtocolStateActor.Handle$ - Class in akka.remote.transport
 
ProtocolStateActor.Handle$() - Constructor for class akka.remote.transport.ProtocolStateActor.Handle$
 
ProtocolStateActor.HandleListenerRegistered - Class in akka.remote.transport
 
ProtocolStateActor.HandleListenerRegistered(AssociationHandle.HandleEventListener) - Constructor for class akka.remote.transport.ProtocolStateActor.HandleListenerRegistered
 
ProtocolStateActor.HandleListenerRegistered$ - Class in akka.remote.transport
 
ProtocolStateActor.HandleListenerRegistered$() - Constructor for class akka.remote.transport.ProtocolStateActor.HandleListenerRegistered$
 
ProtocolStateActor.HandshakeTimer$ - Class in akka.remote.transport
 
ProtocolStateActor.HandshakeTimer$() - Constructor for class akka.remote.transport.ProtocolStateActor.HandshakeTimer$
 
ProtocolStateActor.HeartbeatTimer$ - Class in akka.remote.transport
 
ProtocolStateActor.HeartbeatTimer$() - Constructor for class akka.remote.transport.ProtocolStateActor.HeartbeatTimer$
 
ProtocolStateActor.InboundUnassociated - Class in akka.remote.transport
 
ProtocolStateActor.InboundUnassociated(Transport.AssociationEventListener, AssociationHandle) - Constructor for class akka.remote.transport.ProtocolStateActor.InboundUnassociated
 
ProtocolStateActor.InboundUnassociated$ - Class in akka.remote.transport
 
ProtocolStateActor.InboundUnassociated$() - Constructor for class akka.remote.transport.ProtocolStateActor.InboundUnassociated$
 
ProtocolStateActor.InitialProtocolStateData - Interface in akka.remote.transport
 
ProtocolStateActor.ListenerReady - Class in akka.remote.transport
 
ProtocolStateActor.ListenerReady(AssociationHandle.HandleEventListener, AssociationHandle) - Constructor for class akka.remote.transport.ProtocolStateActor.ListenerReady
 
ProtocolStateActor.ListenerReady$ - Class in akka.remote.transport
 
ProtocolStateActor.ListenerReady$() - Constructor for class akka.remote.transport.ProtocolStateActor.ListenerReady$
 
ProtocolStateActor.Open$ - Class in akka.remote.transport
 
ProtocolStateActor.Open$() - Constructor for class akka.remote.transport.ProtocolStateActor.Open$
 
ProtocolStateActor.OutboundUnassociated - Class in akka.remote.transport
 
ProtocolStateActor.OutboundUnassociated(Address, Promise<AssociationHandle>, Transport) - Constructor for class akka.remote.transport.ProtocolStateActor.OutboundUnassociated
 
ProtocolStateActor.OutboundUnassociated$ - Class in akka.remote.transport
 
ProtocolStateActor.OutboundUnassociated$() - Constructor for class akka.remote.transport.ProtocolStateActor.OutboundUnassociated$
 
ProtocolStateActor.OutboundUnderlyingAssociated - Class in akka.remote.transport
 
ProtocolStateActor.OutboundUnderlyingAssociated(Promise<AssociationHandle>, AssociationHandle) - Constructor for class akka.remote.transport.ProtocolStateActor.OutboundUnderlyingAssociated
 
ProtocolStateActor.OutboundUnderlyingAssociated$ - Class in akka.remote.transport
 
ProtocolStateActor.OutboundUnderlyingAssociated$() - Constructor for class akka.remote.transport.ProtocolStateActor.OutboundUnderlyingAssociated$
 
ProtocolStateActor.ProtocolStateData - Interface in akka.remote.transport
 
ProtocolStateActor.TimeoutReason - Class in akka.remote.transport
 
ProtocolStateActor.TimeoutReason(String) - Constructor for class akka.remote.transport.ProtocolStateActor.TimeoutReason
 
ProtocolStateActor.TimeoutReason$ - Class in akka.remote.transport
 
ProtocolStateActor.TimeoutReason$() - Constructor for class akka.remote.transport.ProtocolStateActor.TimeoutReason$
 
ProtocolStateActor.WaitHandshake$ - Class in akka.remote.transport
 
ProtocolStateActor.WaitHandshake$() - Constructor for class akka.remote.transport.ProtocolStateActor.WaitHandshake$
 
provider() - Method in class akka.actor.ActorCell
 
provider() - Method in interface akka.actor.ActorRefFactory
INTERNAL API
provider() - Method in class akka.actor.ActorSystemImpl
 
provider() - Method in class akka.actor.dungeon.UndefinedUidActorRef
 
provider() - Method in class akka.actor.EmptyLocalActorRef
 
provider() - Method in class akka.actor.ExtendedActorSystem
The ActorRefProvider is the only entity which creates all actor references within this actor system.
provider() - Method in class akka.actor.InternalActorRef
Get a reference to the actor ref provider which created this ref.
provider() - Method in class akka.actor.LocalActorRef
 
provider() - Method in class akka.actor.Nobody$
 
provider() - Static method in class akka.actor.Nobody
 
provider() - Method in class akka.actor.RepointableActorRef
 
provider() - Method in class akka.actor.VirtualPathContainer
 
provider() - Method in class akka.dispatch.DefaultExecutorServiceConfigurator
 
provider() - Method in class akka.event.Logging.StandardOutLogger
 
provider() - Method in class akka.pattern.PromiseActorRef
 
provider() - Method in class akka.remote.EndpointReader
 
provider() - Method in class akka.remote.EndpointWriter
 
provider() - Method in class akka.remote.RARP
 
provider() - Method in class akka.remote.RemoteActorRef
 
provider() - Method in class akka.remote.RemoteTransport
 
ProviderClass() - Method in class akka.actor.ActorSystem.Settings
 
proxyProps(Option<String>, String, FiniteDuration, int, PartialFunction<Object, Tuple2<String, Object>>, Function1<Object, String>) - Method in class akka.contrib.pattern.ShardRegion$
Scala API: Factory method for the Props of the ShardRegion actor when using it in proxy only mode.
proxyProps(String, String, FiniteDuration, int, ShardRegion.MessageExtractor) - Method in class akka.contrib.pattern.ShardRegion$
Java API: : Factory method for the Props of the ShardRegion actor when using it in proxy only mode.
proxyProps(Option<String>, String, FiniteDuration, int, PartialFunction<Object, Tuple2<String, Object>>, Function1<Object, String>) - Static method in class akka.contrib.pattern.ShardRegion
Scala API: Factory method for the Props of the ShardRegion actor when using it in proxy only mode.
proxyProps(String, String, FiniteDuration, int, ShardRegion.MessageExtractor) - Static method in class akka.contrib.pattern.ShardRegion
Java API: : Factory method for the Props of the ShardRegion actor when using it in proxy only mode.
proxyVar() - Method in class akka.actor.TypedActor.TypedActor
 
prune() - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
prune() - Method in class akka.remote.EndpointManager.EndpointRegistry
 
pruneDeadline() - Method in interface akka.contrib.pattern.DistributedPubSubMediator.Internal$.TopicLike
 
pruneInterval() - Method in interface akka.contrib.pattern.DistributedPubSubMediator.Internal$.TopicLike
 
pruneInterval() - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
pruneInterval() - Method in class akka.remote.EndpointManager
 
pruneTask() - Method in interface akka.contrib.pattern.DistributedPubSubMediator.Internal$.TopicLike
 
pruneTask() - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
pruneTimerCancellable() - Method in class akka.remote.EndpointManager
 
publish(Logging.LogEvent) - Method in class akka.actor.ActorCell
 
publish(Gossip) - Method in class akka.cluster.ClusterCoreDaemon
 
publish(Object) - Method in class akka.cluster.ClusterDomainEventPublisher
 
publish() - Method in class akka.cluster.ClusterMetricsCollector
Publishes to the event stream.
publish(String, Object, boolean) - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
publish(ActorClassification) - Method in interface akka.event.ActorClassification
 
publish(AddressTerminated) - Method in class akka.event.AddressTerminatedTopic
 
publish(EventBus) - Method in interface akka.event.EventBus
Publishes the specified Event to this bus
publish(Object, ActorRef) - Method in class akka.event.EventStream
 
publish(E) - Method in class akka.event.japi.ActorEventBus
 
publish(E) - Method in interface akka.event.japi.EventBus
Publishes the specified Event to this bus
publish(E, S) - Method in class akka.event.japi.LookupEventBus
Publishes the given Event to the given Subscriber
publish(E) - Method in class akka.event.japi.LookupEventBus
 
publish(E, S) - Method in class akka.event.japi.ScanningEventBus
Publishes the specified Event to the specified Subscriber
publish(E) - Method in class akka.event.japi.ScanningEventBus
 
publish(E, S) - Method in class akka.event.japi.SubchannelEventBus
Publishes the given Event to the given Subscriber
publish(E) - Method in class akka.event.japi.SubchannelEventBus
 
publish(LookupClassification, LookupClassification) - Method in interface akka.event.LookupClassification
Publishes the given Event to the given Subscriber
publish(LookupClassification) - Method in interface akka.event.LookupClassification
 
publish(ScanningClassification, ScanningClassification) - Method in interface akka.event.ScanningClassification
Publishes the specified Event to the specified Subscriber
publish(ScanningClassification) - Method in interface akka.event.ScanningClassification
 
publish(SubchannelClassification, SubchannelClassification) - Method in interface akka.event.SubchannelClassification
Publishes the given Event to the given Subscriber
publish(SubchannelClassification) - Method in interface akka.event.SubchannelClassification
 
publish() - Method in interface akka.persistence.journal.AsyncWriteJournal
 
publish() - Method in interface akka.persistence.journal.SyncWriteJournal
 
publish() - Method in interface akka.persistence.snapshot.SnapshotStore
 
publishAddressTerminated(Address) - Method in class akka.remote.RemoteWatcher
 
publishChanges(Gossip) - Method in class akka.cluster.ClusterDomainEventPublisher
 
publishConfirmations() - Method in class akka.persistence.PersistenceSettings.internal
 
publishCurrentClusterState() - Method in class akka.cluster.Cluster
Publish current (full) state of the cluster to subscribers, that are subscribing to ClusterEvent.ClusterDomainEvent or ClusterEvent.CurrentClusterState.
publishCurrentClusterState(Option<ActorRef>) - Method in class akka.cluster.ClusterDomainEventPublisher
The current snapshot state corresponding to latest gossip to mimic what you would have seen if you were listening to the events.
publishDiff(Gossip, Gossip, Function1<Object, BoxedUnit>) - Method in class akka.cluster.ClusterDomainEventPublisher
 
publishDisassociated() - Method in class akka.remote.EndpointActor
 
publisher() - Method in class akka.cluster.ClusterCoreSupervisor
 
publisher() - Method in class akka.cluster.InternalClusterAction.PublisherCreated
 
publishError(Throwable, Logging.LogLevel) - Method in class akka.remote.EndpointActor
 
publishInternalStats() - Method in class akka.cluster.ClusterCoreDaemon
 
publishInternalStats(ClusterEvent.CurrentInternalStats) - Method in class akka.cluster.ClusterDomainEventPublisher
 
publishPluginCommands() - Method in class akka.persistence.PersistenceSettings.internal
 
publishStart() - Method in class akka.cluster.ClusterDomainEventPublisher
 
PublishStatsInterval() - Method in class akka.cluster.ClusterSettings
 
publishStatsTask() - Method in class akka.cluster.ClusterCoreDaemon
 
publishToEachGroup(String, Object) - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
PubSubOption - Interface in akka.zeromq
A base trait for pubsub options for the ZeroMQ socket
pullMode() - Method in class akka.io.Tcp.Bind
 
pullMode() - Method in class akka.io.Tcp.Connect
 
pullMode() - Method in class akka.io.TcpConnection
 
push(Function1<A, Future<B>>) - Method in class akka.remote.transport.TestTransport.SwitchableLoggedBehavior
Changes the current behavior to the provided one.
pushConstant(B) - Method in class akka.remote.transport.TestTransport.SwitchableLoggedBehavior
Changes the behavior to return a completed future with the given constant value.
pushDelayed() - Method in class akka.remote.transport.TestTransport.SwitchableLoggedBehavior
Enables control of the completion of the previously active behavior.
pushError(Throwable) - Method in class akka.remote.transport.TestTransport.SwitchableLoggedBehavior
Changes the current behavior to return a failed future containing the given Throwable.
pushTimeOut() - Method in class akka.dispatch.BoundedDequeBasedMailbox.MessageQueue
 
pushTimeOut() - Method in class akka.dispatch.BoundedDequeBasedMailbox
 
pushTimeOut() - Method in interface akka.dispatch.BoundedDequeBasedMessageQueue
 
pushTimeOut() - Method in class akka.dispatch.BoundedMailbox.MessageQueue
 
pushTimeOut() - Method in class akka.dispatch.BoundedMailbox
 
pushTimeOut() - Method in interface akka.dispatch.BoundedMessageQueueSemantics
 
pushTimeOut() - Method in class akka.dispatch.BoundedPriorityMailbox.MessageQueue
 
pushTimeOut() - Method in class akka.dispatch.BoundedPriorityMailbox
 
put(String, Option<ActorRef>) - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
put(E) - Method in class akka.util.BoundedBlockingQueue
 
put(K, V) - Method in class akka.util.Index
Associates the value of type V with the key of type K
putByte(byte) - Method in class akka.util.ByteStringBuilder
Add a single Byte to this builder.
putByteArrayUnsafe(byte[]) - Method in class akka.util.ByteStringBuilder
 
putBytes(byte[]) - Method in class akka.util.ByteStringBuilder
Add a number of Bytes from an array to this builder.
putBytes(byte[], int, int) - Method in class akka.util.ByteStringBuilder
Add a number of Bytes from an array to this builder.
putDouble(double, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a single Double to this builder.
putDoubles(double[], ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Doubles from an array to this builder.
putDoubles(double[], int, int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Doubles from an array to this builder.
putFloat(float, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a single Float to this builder.
putFloats(float[], ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Floats from an array to this builder.
putFloats(float[], int, int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Floats from an array to this builder.
putInt(int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a single Int to this builder.
putInts(int[], ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Ints from an array to this builder.
putInts(int[], int, int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Ints from an array to this builder.
putLong(long, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a single Long to this builder.
putLongPart(long, int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add the n least significant bytes of the given Long to this builder.
putLongs(long[], ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Longs from an array to this builder.
putLongs(long[], int, int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Longs from an array to this builder.
putShort(int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a single Short to this builder.
putShorts(short[], ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Shorts from an array to this builder.
putShorts(short[], int, int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Shorts from an array to this builder.

Q

QDumper - Class in akka.actor.mailbox.filebased.filequeue.tools
 
QDumper() - Constructor for class akka.actor.mailbox.filebased.filequeue.tools.QDumper
 
QDumper$ - Class in akka.actor.mailbox.filebased.filequeue.tools
 
QDumper$() - Constructor for class akka.actor.mailbox.filebased.filequeue.tools.QDumper$
 
QItem - Class in akka.actor.mailbox.filebased.filequeue
 
QItem(long, long, byte[], int) - Constructor for class akka.actor.mailbox.filebased.filequeue.QItem
 
QItem$ - Class in akka.actor.mailbox.filebased.filequeue
 
QItem$() - Constructor for class akka.actor.mailbox.filebased.filequeue.QItem$
 
quarantine(Address, Option<Object>) - Method in class akka.remote.RemoteActorRefProvider
Marks a remote system as out of sync and prevents reconnects until the quarantine timeout elapses.
quarantine(Address, Option<Object>) - Method in class akka.remote.RemoteTransport
Marks a remote system as out of sync and prevents reconnects until the quarantine timeout elapses.
quarantine(Address, Option<Object>) - Method in class akka.remote.RemoteWatcher
 
quarantine(Address, Option<Object>) - Method in class akka.remote.Remoting
 
quarantined(UniqueAddress) - Method in class akka.cluster.ClusterCoreDaemon
 
QuarantinedEvent - Class in akka.remote
 
QuarantinedEvent(Address, int) - Constructor for class akka.remote.QuarantinedEvent
 
QuarantinedEvent$ - Class in akka.remote
 
QuarantinedEvent$() - Constructor for class akka.remote.QuarantinedEvent$
 
QuarantineDuration() - Method in class akka.remote.RemoteSettings
 
QuarantineSilentSystemTimeout() - Method in class akka.remote.RemoteSettings
 
QueryTimeout() - Method in class akka.remote.testconductor.TestConductorExt.Settings
 
queue(String) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
Get a named queue, creating it if necessary.
queue() - Method in class akka.actor.mailbox.filebased.filequeue.tools.QueueDumper
 
queue() - Method in class akka.contrib.mailbox.PeekMailbox
 
queue() - Method in class akka.contrib.pattern.ReliableProxy.Unsent
 
queue() - Method in class akka.contrib.throttle.TimerBasedThrottler.Data
 
queue() - Method in class akka.dispatch.BoundedDequeBasedMailbox.MessageQueue
 
queue() - Method in interface akka.dispatch.BoundedDequeBasedMessageQueue
 
queue() - Method in class akka.dispatch.BoundedMailbox.MessageQueue
 
queue() - Method in class akka.dispatch.BoundedPriorityMailbox.MessageQueue
 
queue() - Method in interface akka.dispatch.BoundedQueueBasedMessageQueue
 
queue() - Method in interface akka.dispatch.DequeBasedMessageQueue
 
queue() - Method in interface akka.dispatch.QueueBasedMessageQueue
 
queue() - Method in class akka.dispatch.UnboundedDequeBasedMailbox.MessageQueue
 
queue() - Method in class akka.dispatch.UnboundedMailbox.MessageQueue
 
queue() - Method in class akka.dispatch.UnboundedPriorityMailbox.MessageQueue
 
queue() - Method in class akka.remote.transport.ProtocolStateActor.AssociatedWaitHandler
 
queue() - Method in class akka.testkit.CallingThreadMailbox
 
queue() - Method in interface akka.testkit.TestKitBase
 
QueueBasedMessageQueue - Interface in akka.dispatch
A QueueBasedMessageQueue is a MessageQueue backed by a java.util.Queue.
QueueCollection - Class in akka.actor.mailbox.filebased.filequeue
 
QueueCollection(String, FileBasedMailboxSettings, LoggingAdapter) - Constructor for class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
QueueDumper - Class in akka.actor.mailbox.filebased.filequeue.tools
 
QueueDumper(String, LoggingAdapter) - Constructor for class akka.actor.mailbox.filebased.filequeue.tools.QueueDumper
 
queueFactory() - Method in class akka.dispatch.ThreadPoolConfig
 
queueHits() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
queueMisses() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
queueNames() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
QueuePath() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
quiet() - Method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper$
 
quiet() - Static method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper
 

R

rampup(int, int) - Method in class akka.routing.DefaultResizer
Computes a proposed positive (or zero) capacity delta using the configured rampupRate.
rampupRate() - Method in class akka.routing.DefaultResizer
 
random() - Method in class akka.util.Crypt$
 
random() - Static method in class akka.util.Crypt
 
RandomGroup - Class in akka.routing
A router group that randomly selects one of the target routees to send a message to.
RandomGroup(Iterable<String>, String) - Constructor for class akka.routing.RandomGroup
 
RandomGroup(com.typesafe.config.Config) - Constructor for class akka.routing.RandomGroup
 
RandomGroup$ - Class in akka.routing
 
RandomGroup$() - Constructor for class akka.routing.RandomGroup$
 
randomName() - Method in interface akka.actor.dungeon.Children
 
randomName() - Method in class akka.testkit.TestActorRef$
 
randomName() - Static method in class akka.testkit.TestActorRef
 
RandomPool - Class in akka.routing
A router pool that randomly selects one of the target routees to send a message to.
RandomPool(int, Option<Resizer>, SupervisorStrategy, String, boolean) - Constructor for class akka.routing.RandomPool
 
RandomPool(com.typesafe.config.Config) - Constructor for class akka.routing.RandomPool
 
RandomPool$ - Class in akka.routing
 
RandomPool$() - Constructor for class akka.routing.RandomPool$
 
RandomRouter - Class in akka.routing
 
RandomRouter(int, Iterable<String>, Option<Resizer>, String, SupervisorStrategy) - Constructor for class akka.routing.RandomRouter
 
RandomRouter(int) - Constructor for class akka.routing.RandomRouter
Java API: Constructor that sets nrOfInstances to be created.
RandomRouter(Iterable<String>) - Constructor for class akka.routing.RandomRouter
Java API: Constructor that sets the routees to be used.
RandomRouter(Resizer) - Constructor for class akka.routing.RandomRouter
Java API: Constructor that sets the resizer to be used.
RandomRouter$ - Class in akka.routing
 
RandomRouter$() - Constructor for class akka.routing.RandomRouter$
 
RandomRoutingLogic - Class in akka.routing
Randomly selects one of the target routees to send a message to
RandomRoutingLogic() - Constructor for class akka.routing.RandomRoutingLogic
 
RandomRoutingLogic$ - Class in akka.routing
 
RandomRoutingLogic$() - Constructor for class akka.routing.RandomRoutingLogic$
 
RARP - Class in akka.remote
INTERNAL API
RARP(RemoteActorRefProvider) - Constructor for class akka.remote.RARP
 
RARP$ - Class in akka.remote
INTERNAL API
RARP$() - Constructor for class akka.remote.RARP$
 
rate() - Method in class akka.contrib.throttle.Throttler.SetRate
 
rate() - Method in class akka.contrib.throttle.TimerBasedThrottler
 
Rate - Class in akka.zeromq
Sets the maximum send or receive data rate for multicast transports such as pgm using the specified socket.
Rate(long) - Constructor for class akka.zeromq.Rate
 
rate() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its rate configuration.
rate() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its rate configuration.
Rate$ - Class in akka.zeromq
Gets the send or receive rate for the socket
Rate$() - Constructor for class akka.zeromq.Rate$
 
rateMBit() - Method in class akka.remote.testconductor.Throttle
 
rateMBit() - Method in class akka.remote.testconductor.ThrottleMsg
 
RATEMBIT_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
rawValue() - Method in class akka.remote.SeqNo
 
reachability() - Method in class akka.cluster.ClusterEvent.ReachabilityChanged
 
reachability() - Method in class akka.cluster.ClusterReadView
 
reachability() - Method in class akka.cluster.GossipOverview
 
Reachability - Class in akka.cluster
INTERNAL API
Reachability$ - Class in akka.cluster
INTERNAL API
Reachability$() - Constructor for class akka.cluster.Reachability$
 
Reachability.ReachabilityStatus - Interface in akka.cluster
 
Reachability.Reachable$ - Class in akka.cluster
 
Reachability.Reachable$() - Constructor for class akka.cluster.Reachability.Reachable$
 
Reachability.Record - Class in akka.cluster
 
Reachability.Record(UniqueAddress, UniqueAddress, Reachability.ReachabilityStatus, long) - Constructor for class akka.cluster.Reachability.Record
 
Reachability.Record$ - Class in akka.cluster
 
Reachability.Record$() - Constructor for class akka.cluster.Reachability.Record$
 
Reachability.Terminated$ - Class in akka.cluster
 
Reachability.Terminated$() - Constructor for class akka.cluster.Reachability.Terminated$
 
Reachability.Unreachable$ - Class in akka.cluster
 
Reachability.Unreachable$() - Constructor for class akka.cluster.Reachability.Unreachable$
 
reachabilityExcludingDownedObservers() - Method in class akka.cluster.Gossip
 
reachable(UniqueAddress, UniqueAddress) - Method in class akka.cluster.Reachability
 
Reachable_VALUE - Static variable in enum akka.cluster.protobuf.msg.ClusterMessages.ReachabilityStatus
Reachable = 0;
reachableMember(Member) - Method in class akka.cluster.ClusterHeartbeatSender
 
reachableMember(UniqueAddress) - Method in class akka.cluster.ClusterHeartbeatSenderState
 
read(String, long, long, long) - Method in interface akka.persistence.journal.inmem.InmemMessages
 
reader() - Method in class akka.remote.EndpointWriter
 
readerId() - Method in class akka.remote.EndpointWriter
 
readHandlerPromise() - Method in class akka.remote.transport.AkkaProtocolHandle
 
readHandlerPromise() - Method in interface akka.remote.transport.AssociationHandle
The Promise returned by this call must be completed with an AssociationHandle.HandleEventListener to register a listener responsible for handling incoming payload.
readHandlerPromise() - Method in class akka.remote.transport.FailureInjectorHandle
 
readHandlerPromise() - Method in class akka.remote.transport.netty.TcpAssociationHandle
 
readHandlerPromise() - Method in class akka.remote.transport.netty.UdpAssociationHandle
 
readHandlerPromise() - Method in class akka.remote.transport.TestAssociationHandle
 
readHandlerPromise() - Method in class akka.remote.transport.ThrottlerHandle
 
readHandlers(ChannelRegistration) - Method in class akka.io.UdpListener
 
readHighestSequenceNr(int) - Method in interface akka.persistence.journal.leveldb.LeveldbRecovery
 
readIdMap() - Method in interface akka.persistence.journal.leveldb.LeveldbIdMapping
 
readIdMap(Map<String, Object>, org.iq80.leveldb.DBIterator) - Method in interface akka.persistence.journal.leveldb.LeveldbIdMapping
 
readJournalEntry(FileChannel) - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
readOnlyEndpointFor(Address) - Method in class akka.remote.EndpointManager.EndpointRegistry
 
readResolve() - Method in class akka.actor.SerializedActorRef
 
readView() - Method in class akka.cluster.Cluster
 
ready(Duration, CanAwait) - Method in class akka.actor.ActorSystemImpl.TerminationCallbacks
 
ready() - Method in class akka.remote.transport.ActorTransportAdapterManager
 
ready() - Method in class akka.remote.transport.AkkaProtocolManager
 
ready() - Method in class akka.remote.transport.ThrottlerManager
 
ready(Duration, CanAwait) - Method in class akka.testkit.TestLatch
 
reapUnreachable() - Method in class akka.remote.RemoteWatcher
 
reapUnreachableMembers() - Method in class akka.cluster.ClusterCoreDaemon
Reaps the unreachable members according to the failure detector's verdict.
reason() - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
 
reason() - Method in class akka.actor.FSM.StopEvent
 
reason() - Method in class akka.remote.transport.AkkaPduCodec.Disassociate
 
reason() - Method in class akka.remote.transport.ThrottledAssociation.FailWith
 
reason() - Method in class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociateExplicitly
 
rebalance(Map<ActorRef, IndexedSeq<String>>, Set<String>) - Method in class akka.contrib.pattern.ShardCoordinator.AbstractShardAllocationStrategy
 
rebalance(Map<ActorRef, IndexedSeq<String>>, Set<String>) - Method in class akka.contrib.pattern.ShardCoordinator.AbstractShardAllocationStrategy
Invoked periodically to decide which shards to rebalance to another location.
rebalance(Map<ActorRef, IndexedSeq<String>>, Set<String>) - Method in class akka.contrib.pattern.ShardCoordinator.LeastShardAllocationStrategy
 
rebalance(Map<ActorRef, IndexedSeq<String>>, Set<String>) - Method in interface akka.contrib.pattern.ShardCoordinator.ShardAllocationStrategy
Invoked periodically to decide which shards to rebalance to another location.
rebalanceInProgress() - Method in class akka.contrib.pattern.ShardCoordinator
 
RebalanceInterval() - Method in class akka.contrib.pattern.ClusterSharding.Settings$
 
rebalanceTask() - Method in class akka.contrib.pattern.ShardCoordinator
 
receive(PartialFunction<Object, BoxedUnit>) - Method in class akka.actor.AbstractActor
Set up the initial receive behavior of the Actor.
receive() - Method in class akka.actor.AbstractActor
 
receive() - Method in interface akka.actor.Actor
This defines the initial actor behavior, it must return a partial function with the actor logic.
receive() - Method in interface akka.actor.dsl.Creators.Act
Default behavior of the actor is empty, use become to change this.
receive(FiniteDuration) - Method in class akka.actor.dsl.Inbox.Inbox
Receive a single message from the internal receiver actor.
receive() - Method in class akka.actor.dsl.Inbox.InboxActor
 
receive() - Method in interface akka.actor.FSM
 
receive(FiniteDuration) - Method in class akka.actor.Inbox
Receive the next message from this Inbox.
receive() - Method in class akka.actor.mailbox.DurableMailboxSpecActorFactory.AccumulatorActor
 
receive() - Method in class akka.actor.mailbox.DurableMailboxSpecActorFactory.MailboxTestActor
 
receive(String) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
receive() - Method in class akka.actor.Props.EmptyActor
 
receive() - Method in class akka.actor.TypedActor.TypedActor
 
receive() - Method in class akka.actor.UntypedActor
 
receive() - Method in class akka.camel.internal.ActivationTracker.ActivationStateMachine
 
receive() - Method in class akka.camel.internal.ActivationTracker
 
receive() - Method in class akka.camel.internal.CamelSupervisor
 
receive() - Method in class akka.camel.internal.ConsumerRegistrar
 
receive() - Method in class akka.camel.internal.ProducerRegistrar
 
receive() - Method in class akka.camel.internal.Registry
 
receive() - Method in interface akka.camel.Producer
Implementation of Actor.receive.
receive() - Method in class akka.camel.ProducerSupport.ProducerChild
 
receive() - Method in class akka.cluster.AutoDownBase
 
receive() - Method in class akka.cluster.ClusterCoreDaemon
 
receive() - Method in class akka.cluster.ClusterCoreSupervisor
 
receive() - Method in class akka.cluster.ClusterDaemon
 
receive() - Method in class akka.cluster.ClusterDomainEventPublisher
 
receive() - Method in class akka.cluster.ClusterHeartbeatReceiver
 
receive() - Method in class akka.cluster.ClusterHeartbeatSender
 
receive() - Method in class akka.cluster.ClusterMetricsCollector
 
receive() - Method in class akka.cluster.ClusterRemoteWatcher
 
receive() - Method in class akka.cluster.FirstSeedNodeProcess
 
receive() - Method in class akka.cluster.JoinSeedNodeProcess
 
receive() - Method in class akka.cluster.OnMemberUpListener
 
receive() - Method in class akka.cluster.routing.AdaptiveLoadBalancingMetricsListener
 
receive() - Method in class akka.cluster.routing.ClusterRouterGroupActor
 
receive() - Method in class akka.cluster.routing.ClusterRouterPoolActor
 
receive() - Method in class akka.contrib.jul.JavaLogger
 
receive() - Method in interface akka.contrib.pattern.Aggregator
Receive function for handling the aggregations.
receive() - Method in class akka.contrib.pattern.ClusterClient
 
receive() - Method in class akka.contrib.pattern.ClusterReceptionist.Internal$.ClientResponseTunnel
 
receive() - Method in class akka.contrib.pattern.ClusterReceptionist
 
receive() - Method in class akka.contrib.pattern.ClusterShardingGuardian
 
receive() - Method in class akka.contrib.pattern.ClusterSingletonProxy
 
receive() - Method in interface akka.contrib.pattern.DistributedPubSubMediator.Internal$.TopicLike
 
receive() - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
receive() - Method in class akka.contrib.pattern.ReliableProxy.Receiver
 
receive() - Method in class akka.contrib.pattern.ShardCoordinator.RebalanceWorker
 
receive() - Method in class akka.contrib.pattern.ShardCoordinatorSupervisor
 
receive() - Method in class akka.contrib.pattern.ShardRegion.HandOffStopper
 
receive() - Method in class akka.contrib.pattern.ShardRegion
 
receive() - Method in class akka.event.DeadLetterListener
 
receive() - Method in class akka.event.Logging.DefaultLogger
 
receive() - Method in class akka.event.slf4j.Slf4jLogger
 
receive() - Method in class akka.io.SelectionHandler
 
receive() - Method in class akka.io.TcpIncomingConnection
 
receive() - Method in class akka.io.TcpListener
 
receive() - Method in class akka.io.TcpManager
 
receive() - Method in class akka.io.TcpOutgoingConnection
 
receive() - Method in class akka.io.UdpConnectedManager
 
receive() - Method in class akka.io.UdpConnection
 
receive() - Method in class akka.io.UdpListener
 
receive() - Method in class akka.io.UdpManager
 
receive() - Method in class akka.io.UdpSender
 
receive() - Method in class akka.Main.Terminator
 
receive() - Method in class akka.osgi.DefaultOSGiLogger
 
receive() - Method in class akka.persistence.AbstractPersistentActor
 
receive() - Method in class akka.persistence.Channel
 
receive() - Method in class akka.persistence.DeliveredByChannelBatching
 
receive() - Method in class akka.persistence.DeliveredByPersistentChannelBatching
 
receive() - Method in interface akka.persistence.EventsourcedProcessor
 
receive() - Method in interface akka.persistence.journal.AsyncWriteJournal
 
receive() - Method in class akka.persistence.journal.AsyncWriteJournal.Resequencer
 
receive() - Method in interface akka.persistence.journal.AsyncWriteProxy
 
receive() - Method in class akka.persistence.journal.inmem.InmemStore
 
receive() - Method in class akka.persistence.journal.leveldb.SharedLeveldbStore
 
receive() - Method in class akka.persistence.journal.ReplayMediator
 
receive() - Method in interface akka.persistence.journal.SyncWriteJournal
 
receive() - Method in interface akka.persistence.PersistentActor
 
receive() - Method in class akka.persistence.PersistentChannel
 
receive() - Method in class akka.persistence.Redelivery
 
receive() - Method in class akka.persistence.ReliableDelivery
 
receive() - Method in class akka.persistence.RequestReader
 
receive() - Method in class akka.persistence.RequestWriter
 
receive() - Method in interface akka.persistence.snapshot.SnapshotStore
 
receive(T) - Method in class akka.remote.AckedReceiveBuffer
Puts a sequenced message in the receive buffer returning a new buffer.
receive() - Method in class akka.remote.EndpointManager
 
receive() - Method in class akka.remote.EndpointReader
 
receive() - Method in class akka.remote.EndpointWriter
 
receive() - Method in class akka.remote.ReliableDeliverySupervisor
 
receive() - Method in class akka.remote.RemoteDeploymentWatcher
 
receive() - Method in class akka.remote.RemoteWatcher
 
receive() - Method in class akka.remote.Remoting.TransportSupervisor
 
receive() - Method in class akka.remote.testconductor.Controller
 
receive() - Method in class akka.remote.transport.ActorTransportAdapterManager
 
receive() - Method in class akka.routing.CollectRouteeRefs
 
receive() - Method in class akka.routing.ResizablePoolActor
 
receive() - Method in class akka.routing.RouterActor
 
receive() - Method in class akka.routing.RouterPoolActor
 
receive() - Method in class akka.testkit.TestActor
 
receive(Object) - Method in class akka.testkit.TestActorRef
Directly inject messages into actor receive behavior.
receive(Object, ActorRef) - Method in class akka.testkit.TestActorRef
Directly inject messages into actor receive behavior.
receive() - Method in class akka.testkit.TestActorRefSpec.Logger
 
receive() - Method in class akka.testkit.TestActorRefSpec.ReceiveTimeoutActor
 
receive() - Method in interface akka.testkit.TestActorRefSpec.TActor
 
receive() - Method in class akka.testkit.TestActors.EchoActor
 
receive() - Method in class akka.testkit.TestEventListener
 
receive() - Method in interface akka.transactor.Transactor
Implement a general pattern for using coordinated transactions.
receive() - Method in class akka.zeromq.ConcurrentSocketActor
 
Receive_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.Direction
Receive = 2;
receiveBuffers() - Method in class akka.remote.EndpointManager
 
receiveBuffers() - Method in class akka.remote.EndpointReader
 
receiveBuffers() - Method in class akka.remote.EndpointWriter
 
receiveBuffers() - Method in class akka.remote.ReliableDeliverySupervisor
 
ReceiveBufferSize() - Method in interface akka.io.Inet.SoForwarders
Inet.SocketOption to set the SO_RCVBUF option
receiveBufferSize(int) - Method in interface akka.io.Inet.SoJavaFactories
Inet.SocketOption to set the SO_RCVBUF option
ReceiveBufferSize() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
ReceiveBufferSize - Class in akka.zeromq
The ReceiveBufferSize option shall set the underlying kernel receive buffer size for the socket to the specified size in bytes.
ReceiveBufferSize(long) - Constructor for class akka.zeromq.ReceiveBufferSize
 
receiveBufferSize() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its receive bufferSize configuration.
receiveBufferSize() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its receive bufferSize configuration.
ReceiveBufferSize$ - Class in akka.zeromq
Gets the ReceiveBufferSize
ReceiveBufferSize$() - Constructor for class akka.zeromq.ReceiveBufferSize$
 
ReceiveBuilder - Class in akka.japi.pf
Used for building a partial function for Actor.receive().
receiveClusterEvent() - Method in class akka.cluster.ClusterRemoteWatcher
 
receiveClusterEvent(ClusterEvent.ClusterDomainEvent) - Method in class akka.contrib.pattern.ShardRegion
 
receiveClusterState(ClusterEvent.CurrentClusterState) - Method in class akka.contrib.pattern.ShardRegion
 
receiveCommand() - Method in class akka.contrib.pattern.ShardCoordinator
 
receiveCommand(ShardRegion.ShardRegionCommand) - Method in class akka.contrib.pattern.ShardRegion
 
receiveCommand() - Method in interface akka.persistence.Eventsourced
 
receiveCommand() - Method in class akka.persistence.journal.JournalPerfSpec.BenchActor
 
receiveCommand() - Method in class akka.persistence.UntypedPersistentActor
 
receiveCoordinatorMessage(akka.contrib.pattern.ShardCoordinator.Internal.CoordinatorMessage) - Method in class akka.contrib.pattern.ShardRegion
 
receivedGossipCount() - Method in class akka.cluster.GossipStats
 
ReceivedMessageSizeLimit() - Method in class akka.io.TcpExt.Settings
 
receivedTerminated(Terminated) - Method in interface akka.actor.dungeon.DeathWatch
 
receiveGossip(GossipEnvelope) - Method in class akka.cluster.ClusterCoreDaemon
Receive new gossip.
receiveGossip(MetricsGossipEnvelope) - Method in class akka.cluster.ClusterMetricsCollector
Receives changes from peer nodes, merges remote with local gossip nodes, then publishes changes to the event stream for load balancing router consumption, and gossip back.
receiveGossipStatus(GossipStatus) - Method in class akka.cluster.ClusterCoreDaemon
 
receiveHeartbeat() - Method in class akka.remote.RemoteWatcher
 
receiveHeartbeatRsp(int) - Method in class akka.remote.RemoteWatcher
 
ReceiveHighWatermark - Class in akka.zeromq
The ReceiveHighWatermark option shall set the high water mark for inbound messages on the specified socket.
ReceiveHighWatermark(long) - Constructor for class akka.zeromq.ReceiveHighWatermark
 
receiveHighWatermark() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its receive high watermark configuration.
receiveHighWatermark() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its receive high watermark configuration.
ReceiveHighWatermark$ - Class in akka.zeromq
Gets the ReceiveHighWatermark
ReceiveHighWatermark$() - Constructor for class akka.zeromq.ReceiveHighWatermark$
 
receiveMessage(Object) - Method in class akka.actor.ActorCell
 
receiveN(int) - Method in class akka.testkit.JavaTestKit
Same as receiveN(n, remaining()), but correctly treating the timeFactor.
receiveN(int, FiniteDuration) - Method in class akka.testkit.JavaTestKit
Receive N messages in a row before the given deadline.
receiveN(int) - Method in interface akka.testkit.TestKitBase
Same as receiveN(n, remaining) but correctly taking into account Duration.timeFactor.
receiveN(int, FiniteDuration) - Method in interface akka.testkit.TestKitBase
Receive N messages in a row before the given deadline.
receiveN_internal(int, Duration) - Method in interface akka.testkit.TestKitBase
 
receiveOne(Duration) - Method in class akka.testkit.JavaTestKit
Receive one message from the internal queue of the TestActor.
receiveOne(Duration) - Method in interface akka.testkit.TestKitBase
Receive one message from the internal queue of the TestActor.
receiver() - Method in class akka.actor.dsl.Inbox.Inbox
 
receiver() - Method in class akka.cluster.InternalClusterAction.PublishCurrentClusterState
 
receiver(ActorRef, int) - Method in class akka.contrib.pattern.ReliableProxy$
 
receiver(ActorRef, int) - Static method in class akka.contrib.pattern.ReliableProxy
 
receiveRecover() - Method in class akka.contrib.pattern.ShardCoordinator
 
receiveRecover() - Method in interface akka.persistence.Eventsourced
 
receiveRecover() - Method in class akka.persistence.journal.JournalPerfSpec.BenchActor
 
receiveRecover() - Method in class akka.persistence.UntypedPersistentActor
 
receiverProbe() - Method in interface akka.persistence.journal.JournalSpec
 
receivers(UniqueAddress) - Method in class akka.cluster.HeartbeatNodeRing
The receivers to use from a specified sender.
receiverStash() - Method in interface akka.persistence.Recovery
INTERNAL API.
receiveState(ClusterEvent.CurrentClusterState) - Method in class akka.cluster.ClusterMetricsCollector
Updates the initial node ring for those nodes that are akka.cluster.MemberStatus.Up.
receiveT() - Method in class akka.testkit.TestActorRefSpec.ReplyActor
 
receiveT() - Method in class akka.testkit.TestActorRefSpec.SenderActor
 
receiveT() - Method in interface akka.testkit.TestActorRefSpec.TActor
 
receiveT() - Method in class akka.testkit.TestActorRefSpec.WorkerActor
 
receiveTerminated(ActorRef) - Method in class akka.contrib.pattern.ShardRegion
 
receiveTimeout() - Method in interface akka.actor.ActorContext
Gets the current receive timeout.
ReceiveTimeout - Interface in akka.actor.dungeon
 
receiveTimeout() - Method in interface akka.actor.dungeon.ReceiveTimeout
 
ReceiveTimeout - Class in akka.actor
 
ReceiveTimeout() - Constructor for class akka.actor.ReceiveTimeout
 
ReceiveTimeout$ - Class in akka.actor.dungeon
 
ReceiveTimeout$() - Constructor for class akka.actor.dungeon.ReceiveTimeout$
 
ReceiveTimeout$ - Class in akka.actor
When using ActorContext.setReceiveTimeout, the singleton instance of ReceiveTimeout will be sent to the Actor when there hasn't been any message for that long.
ReceiveTimeout$() - Constructor for class akka.actor.ReceiveTimeout$
 
receiveTimeoutData() - Method in interface akka.actor.dungeon.ReceiveTimeout
 
receiveWhile(Duration, Duration, int, PartialFunction<Object, T>) - Method in interface akka.testkit.TestKitBase
Receive a series of messages until one does not match the given partial function or the idle timeout is met (disabled by default) or the overall maximum duration is elapsed.
recipient() - Method in interface akka.actor.AllDeadLetters
 
recipient() - Method in class akka.actor.DeadLetter
 
recipient() - Method in class akka.actor.SuppressedDeadLetter
 
recipient() - Method in class akka.actor.UnhandledMessage
 
recipient() - Method in class akka.remote.EndpointManager.Send
 
recipient() - Method in class akka.remote.transport.AkkaPduCodec.Message
 
recipient() - Method in class akka.remote.transport.TestTransport.WriteAttempt
 
RECIPIENT_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.RemoteEnvelope
 
recipientAddress() - Method in class akka.remote.transport.AkkaPduCodec.Message
 
ReconnectBackoff() - Method in class akka.remote.testconductor.TestConductorExt.Settings
 
reconnecting() - Method in class akka.contrib.pattern.ReliableProxy$
 
reconnecting() - Static method in class akka.contrib.pattern.ReliableProxy
 
ReconnectIVL - Class in akka.zeromq
Sets the recovery interval for multicast transports using the specified socket.
ReconnectIVL(long) - Constructor for class akka.zeromq.ReconnectIVL
 
reconnectIVL() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its reconnect interval configuration.
reconnectIVL() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its reconnect interval configuration.
ReconnectIVL$ - Class in akka.zeromq
Gets the recover interval @see akka.zeromq.ReconnectIVL
ReconnectIVL$() - Constructor for class akka.zeromq.ReconnectIVL$
 
ReconnectIVLMax - Class in akka.zeromq
The ReconnectIVLMax option shall set the maximum reconnection interval for the specified socket.
ReconnectIVLMax(long) - Constructor for class akka.zeromq.ReconnectIVLMax
 
reconnectIVLMax() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its max reconnect interval configuration.
reconnectIVLMax() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its max reconnect interval configuration.
ReconnectIVLMax$ - Class in akka.zeromq
Gets the max reconnect IVL
ReconnectIVLMax$() - Constructor for class akka.zeromq.ReconnectIVLMax$
 
reconnectTimer() - Method in class akka.contrib.pattern.ReliableProxy
 
recordFailure(Throwable) - Method in interface akka.persistence.Recovery.State
 
records() - Method in class akka.cluster.Reachability
 
recordsFrom(UniqueAddress) - Method in class akka.cluster.Reachability
 
Recover<T> - Class in akka.dispatch
Callback for the Future.recover operation that conditionally turns failures into successes.
Recover() - Constructor for class akka.dispatch.Recover
 
recover(Throwable) - Method in class akka.dispatch.Recover
This method will be invoked once when/if the Future this recover callback is registered on becomes completed with a failure.
Recover - Class in akka.persistence
Instructs a persistent actor to recover itself.
Recover(SnapshotSelectionCriteria, long, long) - Constructor for class akka.persistence.Recover
 
Recover$ - Class in akka.persistence
 
Recover$() - Constructor for class akka.persistence.Recover$
 
recovering() - Method in interface akka.persistence.Eventsourced
Processor recovery state.
Recovery - Interface in akka.persistence
Recovery state machine that loads snapshots and replays messages.
Recovery.State - Interface in akka.persistence
INTERNAL API.
recoveryBehavior() - Method in interface akka.persistence.Eventsourced
INTERNAL API.
RecoveryCompleted - Class in akka.persistence
 
RecoveryCompleted() - Constructor for class akka.persistence.RecoveryCompleted
 
RecoveryCompleted$ - Class in akka.persistence
Sent to a Processor when the journal replay has been finished.
RecoveryCompleted$() - Constructor for class akka.persistence.RecoveryCompleted$
 
RecoveryFailure - Class in akka.persistence
Sent to a Processor if a journal fails to replay messages or fetch that processor's highest sequence number.
RecoveryFailure(Throwable) - Constructor for class akka.persistence.RecoveryFailure
 
RecoveryFailure$ - Class in akka.persistence
 
RecoveryFailure$() - Constructor for class akka.persistence.RecoveryFailure$
 
recoveryFinished() - Method in interface akka.persistence.ProcessorImpl
Returns true if this processor has successfully finished recovery.
RecoveryInterval - Class in akka.zeromq
Sets the recovery interval for multicast transports using the specified socket.
RecoveryInterval(long) - Constructor for class akka.zeromq.RecoveryInterval
 
recoveryInterval() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its recovery interval configuration.
recoveryInterval() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its recovery interval configuration.
RecoveryInterval$ - Class in akka.zeromq
Gets the RecoveryInterval
RecoveryInterval$() - Constructor for class akka.zeromq.RecoveryInterval$
 
recoveryPending() - Method in interface akka.persistence.Recovery
INTERNAL API.
recoveryRunning() - Method in interface akka.persistence.ProcessorImpl
Returns true if this processor is currently recovering.
recoveryStarted(long) - Method in interface akka.persistence.Recovery
INTERNAL API.
Recreate - Class in akka.dispatch.sysmsg
INTERNAL API
Recreate(Throwable) - Constructor for class akka.dispatch.sysmsg.Recreate
 
Recreate$ - Class in akka.dispatch.sysmsg
 
Recreate$() - Constructor for class akka.dispatch.sysmsg.Recreate$
 
RedeliverFailure - Class in akka.persistence
Notification message to inform channel listeners about messages that have reached the maximum number of redeliveries.
RedeliverFailure(Seq<ConfirmablePersistent>) - Constructor for class akka.persistence.RedeliverFailure
 
RedeliverFailure$ - Class in akka.persistence
 
RedeliverFailure$() - Constructor for class akka.persistence.RedeliverFailure$
 
redeliverFailureListener() - Method in class akka.persistence.ChannelSettings
 
redeliverFailureListener() - Method in class akka.persistence.PersistentChannelSettings
 
redeliveries() - Method in class akka.persistence.ConfirmablePersistent
Number of redeliveries.
redeliveries() - Method in class akka.persistence.ConfirmablePersistentImpl
 
redeliveries() - Method in class akka.persistence.PersistentImpl
 
redeliveries() - Method in interface akka.persistence.PersistentRepr
Number of redeliveries.
REDELIVERIES_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
redeliverInterval() - Method in interface akka.persistence.AtLeastOnceDelivery
Interval between redelivery attempts.
redeliverInterval() - Method in class akka.persistence.ChannelSettings
 
redeliverInterval() - Method in class akka.persistence.PersistenceSettings.atLeastOnceDelivery
 
redeliverInterval() - Method in class akka.persistence.PersistentChannelSettings
 
redeliverMax() - Method in class akka.persistence.ChannelSettings
 
redeliverMax() - Method in class akka.persistence.PersistentChannelSettings
 
redeliverOverdue() - Method in interface akka.persistence.AtLeastOnceDelivery
 
redeliverTask() - Method in interface akka.persistence.AtLeastOnceDelivery
 
Redelivery - Class in akka.persistence
Redelivery process used by ReliableDelivery.
Redelivery(ChannelSettings) - Constructor for class akka.persistence.Redelivery
 
redeliveryMax() - Method in class akka.persistence.ReliableDelivery.Redeliver
 
reduce(Iterable<Future<T>>, Function2<R, T, R>, ExecutionContext) - Method in class akka.dispatch.Futures$
Reduces the results of the supplied futures and binary function.
reduce(Iterable<Future<T>>, Function2<R, T, R>, ExecutionContext) - Static method in class akka.dispatch.Futures
Reduces the results of the supplied futures and binary function.
ReduceGossipDifferentViewProbability() - Method in class akka.cluster.ClusterSettings
 
ReentrantGuard - Class in akka.util
 
ReentrantGuard() - Constructor for class akka.util.ReentrantGuard
 
ref() - Method in class akka.actor.ActorIdentity
 
ref() - Method in class akka.camel.internal.AwaitActivation
 
ref() - Method in class akka.camel.internal.AwaitDeActivation
 
ref() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Internal$.ValueHolder
 
ref() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Put
 
ref() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Subscribe
 
ref() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Unsubscribe
 
ref() - Method in class akka.contrib.pattern.ReliableProxy.TargetChanged
 
ref() - Method in class akka.contrib.pattern.ShardCoordinator.Internal$.ShardHome
 
ref() - Method in class akka.contrib.pattern.WorkList.Entry
 
ref() - Method in class akka.persistence.journal.AsyncWriteProxy.SetStore
 
ref() - Method in class akka.routing.ActorRefRoutee
 
ref() - Method in class akka.testkit.TestActor.UnWatch
 
ref() - Method in class akka.testkit.TestActor.Watch
 
ref() - Method in class akka.testkit.TestProbe
Shorthand to get the testActor.
REF_FIELD_NUMBER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
Reflect - Class in akka.util
Collection of internal reflection utilities which may or may not be available (most services specific to HotSpot, but fails gracefully).
Reflect() - Constructor for class akka.util.Reflect
 
Reflect$ - Class in akka.util
Collection of internal reflection utilities which may or may not be available (most services specific to HotSpot, but fails gracefully).
Reflect$() - Constructor for class akka.util.Reflect$
 
ReflectiveDynamicAccess - Class in akka.actor
This is the default DynamicAccess implementation used by ExtendedActorSystem unless overridden.
ReflectiveDynamicAccess(ClassLoader) - Constructor for class akka.actor.ReflectiveDynamicAccess
 
refreshContactsTask() - Method in class akka.contrib.pattern.ClusterClient
 
refreshCurrentState() - Method in class akka.cluster.ClusterReadView
INTERNAL API
refuseUid(Address) - Method in class akka.remote.EndpointManager.EndpointRegistry
 
refuseUid() - Method in class akka.remote.EndpointManager.Pass
 
refuseUid() - Method in class akka.remote.ReliableDeliverySupervisor
 
refuseUid() - Method in class akka.remote.transport.AkkaProtocolTransport.AssociateUnderlyingRefuseUid
 
region() - Method in class akka.contrib.pattern.ShardCoordinator.Internal$.ShardHomeAllocated
 
region() - Method in class akka.contrib.pattern.ShardCoordinator.Internal$.ShardRegionRegistered
 
region() - Method in class akka.contrib.pattern.ShardCoordinator.Internal$.ShardRegionTerminated
 
regionByShard() - Method in class akka.contrib.pattern.ShardRegion
 
regionProxy() - Method in class akka.contrib.pattern.ShardCoordinator.Internal$.ShardRegionProxyRegistered
 
regionProxy() - Method in class akka.contrib.pattern.ShardCoordinator.Internal$.ShardRegionProxyTerminated
 
regions() - Method in class akka.contrib.pattern.ShardRegion
 
register(S, PartialFunction<FSM.Event<D>, FSM.State<S, D>>, Option<FiniteDuration>) - Method in interface akka.actor.FSM
 
register() - Method in interface akka.camel.Consumer
 
register() - Method in interface akka.camel.ProducerSupport
 
register(ActorRef, PeekMailbox) - Method in class akka.contrib.mailbox.PeekMailboxExtension
 
register() - Method in class akka.contrib.pattern.ShardRegion
 
register(ActorCell) - Method in class akka.dispatch.BalancingDispatcher
 
register(ActorCell) - Method in class akka.dispatch.MessageDispatcher
If you override it, you must call it.
register(ActorCell) - Method in class akka.dispatch.PinnedDispatcher
 
register(SelectableChannel, int, ActorRef) - Method in interface akka.io.ChannelRegistry
Registers the given channel with the selector, creates a ChannelRegistration instance for it and dispatches it back to the channelActor calling this register
register(ActorRef, boolean, boolean) - Method in class akka.io.TcpMessage$
This message must be sent to a TCP connection actor after receiving the Tcp.Connected message.
register(ActorRef) - Method in class akka.io.TcpMessage$
The same as register(handler, false, false).
register(ActorRef, boolean, boolean) - Static method in class akka.io.TcpMessage
This message must be sent to a TCP connection actor after receiving the Tcp.Connected message.
register(ActorRef) - Static method in class akka.io.TcpMessage
The same as register(handler, false, false).
register(ActorCell) - Method in class akka.testkit.CallingThreadDispatcher
 
registerAllExtensions(com.google.protobuf.ExtensionRegistry) - Static method in class akka.cluster.protobuf.msg.ClusterMessages
 
registerAllExtensions(com.google.protobuf.ExtensionRegistry) - Static method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages
 
registerAllExtensions(com.google.protobuf.ExtensionRegistry) - Static method in class akka.persistence.serialization.MessageFormats
 
registerAllExtensions(com.google.protobuf.ExtensionRegistry) - Static method in class akka.remote.ContainerFormats
 
registerAllExtensions(com.google.protobuf.ExtensionRegistry) - Static method in class akka.remote.testconductor.TestConductorProtocol
 
registerAllExtensions(com.google.protobuf.ExtensionRegistry) - Static method in class akka.remote.WireFormats
 
registerConfigurator(String, MessageDispatcherConfigurator) - Method in class akka.dispatch.Dispatchers
Register a MessageDispatcherConfigurator that will be used by Dispatchers.lookup(java.lang.String) and Dispatchers.hasDispatcher(java.lang.String) instead of looking up the configurator from the system configuration.
registerExtension(ExtensionId<T>) - Method in class akka.actor.ActorSystem
Registers the provided extension and creates its payload, if this extension isn't already registered This method has putIfAbsent-semantics, this method can potentially block, waiting for the initialization of the payload, if is in the process of registration from another Thread of execution
registerExtension(ExtensionId<T>) - Method in class akka.actor.ActorSystemImpl
 
registerExtraNames(Map<String, InternalActorRef>) - Method in class akka.actor.LocalActorRefProvider
Higher-level providers (or extensions) might want to register new synthetic top-level paths for doing special stuff.
registerForExecution(Mailbox, boolean, boolean) - Method in class akka.dispatch.Dispatcher
Returns if it was registered
registerForExecution(Mailbox, boolean, boolean) - Method in class akka.dispatch.MessageDispatcher
Suggest to register the provided mailbox for execution
registerForExecution(Mailbox, boolean, boolean) - Method in class akka.testkit.CallingThreadDispatcher
 
registerListener(org.jboss.netty.channel.Channel, AssociationHandle.HandleEventListener, org.jboss.netty.buffer.ChannelBuffer, InetSocketAddress) - Method in interface akka.remote.transport.netty.CommonHandlers
 
registerListener(org.jboss.netty.channel.Channel, AssociationHandle.HandleEventListener, org.jboss.netty.buffer.ChannelBuffer, InetSocketAddress) - Method in interface akka.remote.transport.netty.TcpHandlers
 
registerListener(org.jboss.netty.channel.Channel, AssociationHandle.HandleEventListener, org.jboss.netty.buffer.ChannelBuffer, InetSocketAddress) - Method in interface akka.remote.transport.netty.UdpHandlers
 
registerListenerPair(Tuple2<Address, Address>, Tuple2<AssociationHandle.HandleEventListener, AssociationHandle.HandleEventListener>) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Registers a Future of two handle event listeners corresponding to the two endpoints of an association.
registerOnMemberUp(Function0<T>) - Method in class akka.cluster.Cluster
The supplied thunk will be run, once, when current cluster member is Up.
registerOnMemberUp(Runnable) - Method in class akka.cluster.Cluster
Java API: The supplied callback will be run, once, when current cluster member is Up.
registerOnTermination(Function0<T>) - Method in class akka.actor.ActorSystem
Register a block of code (callback) to run after ActorSystem.shutdown has been issued and all actors in this actor system have been stopped.
registerOnTermination(Runnable) - Method in class akka.actor.ActorSystem
Java API: Register a block of code (callback) to run after ActorSystem.shutdown has been issued and all actors in this actor system have been stopped.
registerOnTermination(Function0<T>) - Method in class akka.actor.ActorSystemImpl
 
registerOnTermination(Runnable) - Method in class akka.actor.ActorSystemImpl
 
registerQueue(CallingThreadMailbox, MessageQueue) - Method in class akka.testkit.CallingThreadDispatcherQueues
 
registerReadOnlyEndpoint(Address, ActorRef, int) - Method in class akka.remote.EndpointManager.EndpointRegistry
 
registerService(ActorRef) - Method in class akka.contrib.pattern.ClusterReceptionistExtension
Register an actor that should be reachable for the clients.
registerService(org.osgi.framework.BundleContext, ActorSystem) - Method in class akka.osgi.ActorSystemActivator
Register the actor system in the OSGi service registry.
registerSubscriber(String, ActorRef) - Method in class akka.contrib.pattern.ClusterReceptionistExtension
Register an actor that should be reachable for the clients to a named topic.
registerTempActor(InternalActorRef, ActorPath) - Method in interface akka.actor.ActorRefProvider
Registers an actorRef at a path returned by tempPath(); do NOT pass in any other path.
registerTempActor(InternalActorRef, ActorPath) - Method in class akka.actor.LocalActorRefProvider
 
registerTempActor(InternalActorRef, ActorPath) - Method in class akka.remote.RemoteActorRefProvider
 
RegisterTimeout() - Method in class akka.io.TcpExt.Settings
 
registerTopic(ActorRef) - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
registerTransport(TestTransport, Future<Transport.AssociationEventListener>) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Records a mapping between an address and the corresponding (transport, associationEventListener) pair.
registerWritableEndpoint(Address, Option<Object>, Option<Object>, ActorRef) - Method in class akka.remote.EndpointManager.EndpointRegistry
 
registerWritableEndpointUid(Address, int) - Method in class akka.remote.EndpointManager.EndpointRegistry
 
registration() - Method in class akka.io.TcpConnection.ConnectionInfo
 
registrationMessage() - Method in class akka.contrib.pattern.ShardRegion
 
Registry - Class in akka.camel.internal
INTERNAL API Registry for Camel Consumers and Producers.
Registry(ActorRef) - Constructor for class akka.camel.internal.Registry
 
registry() - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
registry() - Method in class akka.remote.transport.TestTransport
 
Registry.RegistryLogStrategy - Class in akka.camel.internal
 
Registry.RegistryLogStrategy(PartialFunction<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.camel.internal.Registry.RegistryLogStrategy
 
rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class akka.dispatch.SaneRejectedExecutionHandler
 
rejectionPolicy() - Method in class akka.dispatch.ThreadPoolConfig
 
RelativeActorPath - Class in akka.actor
Extractor for so-called &ldquo;relative actor paths&rdquo; as in &ldquo;relative URI&rdquo;, not in &ldquo;relative to some actor&rdquo;.
RelativeActorPath() - Constructor for class akka.actor.RelativeActorPath
 
RelativeActorPath$ - Class in akka.actor
Extractor for so-called &ldquo;relative actor paths&rdquo; as in &ldquo;relative URI&rdquo;, not in &ldquo;relative to some actor&rdquo;.
RelativeActorPath$() - Constructor for class akka.actor.RelativeActorPath$
 
release(ByteBuffer) - Method in interface akka.io.BufferPool
 
release(ByteBuffer) - Method in class akka.io.DirectByteBufferPool
 
release() - Method in class akka.io.TcpConnection.EmptyPendingWrite$
 
release() - Method in class akka.io.TcpConnection.PendingBufferWrite
 
release() - Method in class akka.io.TcpConnection.PendingWrite
 
release() - Method in class akka.io.TcpConnection.PendingWriteFile
 
ReliableDelivery - Class in akka.persistence
Reliably deliver messages contained in Deliver requests to their destinations.
ReliableDelivery(ChannelSettings) - Constructor for class akka.persistence.ReliableDelivery
 
ReliableDelivery$ - Class in akka.persistence
 
ReliableDelivery$() - Constructor for class akka.persistence.ReliableDelivery$
 
ReliableDelivery.DeliveryAttempt - Class in akka.persistence
 
ReliableDelivery.DeliveryAttempt(ConfirmablePersistentImpl, ActorPath, ActorRef, long) - Constructor for class akka.persistence.ReliableDelivery.DeliveryAttempt
 
ReliableDelivery.DeliveryAttempt$ - Class in akka.persistence
 
ReliableDelivery.DeliveryAttempt$() - Constructor for class akka.persistence.ReliableDelivery.DeliveryAttempt$
 
ReliableDelivery.Redeliver - Class in akka.persistence
 
ReliableDelivery.Redeliver(SortedMap<Object, ReliableDelivery.DeliveryAttempt>, int) - Constructor for class akka.persistence.ReliableDelivery.Redeliver
 
ReliableDelivery.Redeliver$ - Class in akka.persistence
 
ReliableDelivery.Redeliver$() - Constructor for class akka.persistence.ReliableDelivery.Redeliver$
 
reliableDeliveryEnabled() - Method in class akka.remote.transport.AkkaPduCodec.Message
 
reliableDeliverySupervisor() - Method in class akka.remote.EndpointReader
 
reliableDeliverySupervisor() - Method in class akka.remote.EndpointWriter
 
ReliableDeliverySupervisor - Class in akka.remote
INTERNAL API
ReliableDeliverySupervisor(Option<AkkaProtocolHandle>, Address, Address, Option<Object>, AkkaProtocolTransport, RemoteSettings, AkkaPduCodec, ConcurrentHashMap<EndpointManager.Link, EndpointManager.ResendState>) - Constructor for class akka.remote.ReliableDeliverySupervisor
 
ReliableDeliverySupervisor$ - Class in akka.remote
INTERNAL API
ReliableDeliverySupervisor$() - Constructor for class akka.remote.ReliableDeliverySupervisor$
 
ReliableDeliverySupervisor.AttemptSysMsgRedelivery$ - Class in akka.remote
 
ReliableDeliverySupervisor.AttemptSysMsgRedelivery$() - Constructor for class akka.remote.ReliableDeliverySupervisor.AttemptSysMsgRedelivery$
 
ReliableDeliverySupervisor.GotUid - Class in akka.remote
 
ReliableDeliverySupervisor.GotUid(int, Address) - Constructor for class akka.remote.ReliableDeliverySupervisor.GotUid
 
ReliableDeliverySupervisor.GotUid$ - Class in akka.remote
 
ReliableDeliverySupervisor.GotUid$() - Constructor for class akka.remote.ReliableDeliverySupervisor.GotUid$
 
ReliableDeliverySupervisor.Idle$ - Class in akka.remote
 
ReliableDeliverySupervisor.Idle$() - Constructor for class akka.remote.ReliableDeliverySupervisor.Idle$
 
ReliableDeliverySupervisor.IsIdle$ - Class in akka.remote
 
ReliableDeliverySupervisor.IsIdle$() - Constructor for class akka.remote.ReliableDeliverySupervisor.IsIdle$
 
ReliableDeliverySupervisor.TooLongIdle$ - Class in akka.remote
 
ReliableDeliverySupervisor.TooLongIdle$() - Constructor for class akka.remote.ReliableDeliverySupervisor.TooLongIdle$
 
ReliableDeliverySupervisor.Ungate$ - Class in akka.remote
 
ReliableDeliverySupervisor.Ungate$() - Constructor for class akka.remote.ReliableDeliverySupervisor.Ungate$
 
ReliableProxy - Class in akka.contrib.pattern
A ReliableProxy is a means to wrap a remote actor reference in order to obtain certain improved delivery guarantees:
ReliableProxy(ActorPath, FiniteDuration, Option<FiniteDuration>, Option<Object>) - Constructor for class akka.contrib.pattern.ReliableProxy
 
ReliableProxy$ - Class in akka.contrib.pattern
 
ReliableProxy$() - Constructor for class akka.contrib.pattern.ReliableProxy$
 
ReliableProxy.Active$ - Class in akka.contrib.pattern
 
ReliableProxy.Active$() - Constructor for class akka.contrib.pattern.ReliableProxy.Active$
 
ReliableProxy.Connecting$ - Class in akka.contrib.pattern
 
ReliableProxy.Connecting$() - Constructor for class akka.contrib.pattern.ReliableProxy.Connecting$
 
ReliableProxy.Idle$ - Class in akka.contrib.pattern
 
ReliableProxy.Idle$() - Constructor for class akka.contrib.pattern.ReliableProxy.Idle$
 
ReliableProxy.Message - Class in akka.contrib.pattern
 
ReliableProxy.Message(Object, ActorRef, int) - Constructor for class akka.contrib.pattern.ReliableProxy.Message
 
ReliableProxy.Message$ - Class in akka.contrib.pattern
 
ReliableProxy.Message$() - Constructor for class akka.contrib.pattern.ReliableProxy.Message$
 
ReliableProxy.ProxyTerminated - Class in akka.contrib.pattern
ProxyTerminated is sent to transition subscribers during postStop.
ReliableProxy.ProxyTerminated(ActorRef, ReliableProxy.Unsent) - Constructor for class akka.contrib.pattern.ReliableProxy.ProxyTerminated
 
ReliableProxy.ProxyTerminated$ - Class in akka.contrib.pattern
 
ReliableProxy.ProxyTerminated$() - Constructor for class akka.contrib.pattern.ReliableProxy.ProxyTerminated$
 
ReliableProxy.Receiver - Class in akka.contrib.pattern
 
ReliableProxy.Receiver(ActorRef, int) - Constructor for class akka.contrib.pattern.ReliableProxy.Receiver
 
ReliableProxy.State - Interface in akka.contrib.pattern
 
ReliableProxy.TargetChanged - Class in akka.contrib.pattern
TargetChanged is sent to transition subscribers when the initial connection is made the target and when the target ActorRef has changed (for example, the target system crashed and has been restarted).
ReliableProxy.TargetChanged(ActorRef) - Constructor for class akka.contrib.pattern.ReliableProxy.TargetChanged
 
ReliableProxy.TargetChanged$ - Class in akka.contrib.pattern
 
ReliableProxy.TargetChanged$() - Constructor for class akka.contrib.pattern.ReliableProxy.TargetChanged$
 
ReliableProxy.Unsent - Class in akka.contrib.pattern
 
ReliableProxy.Unsent(Vector<ReliableProxy.Message>) - Constructor for class akka.contrib.pattern.ReliableProxy.Unsent
 
ReliableProxy.Unsent$ - Class in akka.contrib.pattern
 
ReliableProxy.Unsent$() - Constructor for class akka.contrib.pattern.ReliableProxy.Unsent$
 
ReliableProxyDebugLogging - Interface in akka.contrib.pattern
INTERNAL API
remaining() - Method in class akka.contrib.pattern.ShardCoordinator.RebalanceWorker
 
remaining() - Method in class akka.contrib.pattern.ShardRegion.HandOffStopper
 
remaining() - Method in class akka.testkit.JavaTestKit
Obtain time remaining for execution of the innermost enclosing Within block or missing that it returns the properly dilated default for this case from settings (key "akka.test.single-expect-default").
remaining() - Method in interface akka.testkit.TestKitBase
Obtain time remaining for execution of the innermost enclosing within block or missing that it returns the properly dilated default for this case from settings (key "akka.test.single-expect-default").
remainingCapacity() - Method in class akka.util.BoundedBlockingQueue
 
remainingDuration() - Method in exception akka.pattern.CircuitBreakerOpenException
 
remainingOr(FiniteDuration) - Method in class akka.testkit.JavaTestKit
Obtain time remaining for execution of the innermost enclosing Within block or missing that it returns the given duration.
remainingOr(FiniteDuration) - Method in interface akka.testkit.TestKitBase
Obtain time remaining for execution of the innermost enclosing within block or missing that it returns the given duration.
remainingOrDilated(Duration) - Method in interface akka.testkit.TestKitBase
 
remainingSeedNodes() - Method in class akka.cluster.FirstSeedNodeProcess
 
remainingWrite() - Method in class akka.io.TcpConnection.UpdatePendingWriteAndThen
 
remote() - Method in class akka.remote.transport.TestTransport.DisassociateAttempt
 
RemoteActorRef - Class in akka.remote
INTERNAL API Remote ActorRef that is used when referencing the Actor on a different node than its "home" node.
RemoteActorRef(RemoteTransport, Address, ActorPath, InternalActorRef, Option<Props>, Option<Deploy>) - Constructor for class akka.remote.RemoteActorRef
 
RemoteActorRefProvider - Class in akka.remote
INTERNAL API Depending on this class is not supported, only the ActorRefProvider interface is supported.
RemoteActorRefProvider(String, ActorSystem.Settings, EventStream, DynamicAccess) - Constructor for class akka.remote.RemoteActorRefProvider
 
RemoteActorRefProvider$ - Class in akka.remote
INTERNAL API
RemoteActorRefProvider$() - Constructor for class akka.remote.RemoteActorRefProvider$
 
RemoteActorRefProvider.Finished$ - Class in akka.remote
 
RemoteActorRefProvider.Finished$() - Constructor for class akka.remote.RemoteActorRefProvider.Finished$
 
RemoteActorRefProvider.Idle$ - Class in akka.remote
 
RemoteActorRefProvider.Idle$() - Constructor for class akka.remote.RemoteActorRefProvider.Idle$
 
RemoteActorRefProvider.TerminatorState - Interface in akka.remote
 
RemoteActorRefProvider.Uninitialized$ - Class in akka.remote
 
RemoteActorRefProvider.Uninitialized$() - Constructor for class akka.remote.RemoteActorRefProvider.Uninitialized$
 
RemoteActorRefProvider.WaitDaemonShutdown$ - Class in akka.remote
 
RemoteActorRefProvider.WaitDaemonShutdown$() - Constructor for class akka.remote.RemoteActorRefProvider.WaitDaemonShutdown$
 
RemoteActorRefProvider.WaitTransportShutdown$ - Class in akka.remote
 
RemoteActorRefProvider.WaitTransportShutdown$() - Constructor for class akka.remote.RemoteActorRefProvider.WaitTransportShutdown$
 
remoteAddres() - Method in class akka.remote.ReliableDeliverySupervisor.GotUid
 
remoteAddress() - Method in class akka.io.Tcp.Connect
 
remoteAddress() - Method in class akka.io.Tcp.Connected
 
remoteAddress() - Method in class akka.io.UdpConnected.Connect
 
remoteAddress() - Method in class akka.remote.AssociatedEvent
 
remoteAddress() - Method in class akka.remote.AssociationErrorEvent
 
remoteAddress() - Method in interface akka.remote.AssociationEvent
 
remoteAddress() - Method in class akka.remote.DisassociatedEvent
 
remoteAddress() - Method in class akka.remote.EndpointActor
 
remoteAddress() - Method in class akka.remote.EndpointManager.Link
 
remoteAddress() - Method in class akka.remote.EndpointManager.Quarantine
 
remoteAddress() - Method in exception akka.remote.HopelessAssociation
 
remoteAddress() - Method in exception akka.remote.InvalidAssociation
 
remoteAddress() - Method in class akka.remote.ReliableDeliverySupervisor
 
remoteAddress() - Method in exception akka.remote.ShutDownAssociation
 
remoteAddress() - Method in class akka.remote.transport.AbstractTransportAdapterHandle
 
remoteAddress() - Method in class akka.remote.transport.ActorTransportAdapter.AssociateUnderlying
 
remoteAddress() - Method in class akka.remote.transport.AkkaProtocolTransport.AssociateUnderlyingRefuseUid
 
remoteAddress() - Method in interface akka.remote.transport.AssociationHandle
Address of the remote endpoint.
remoteAddress() - Method in class akka.remote.transport.FailureInjectorTransportAdapter.One
 
remoteAddress() - Method in class akka.remote.transport.netty.TcpAssociationHandle
 
remoteAddress() - Method in class akka.remote.transport.netty.UdpAssociationHandle
 
remoteAddress() - Method in class akka.remote.transport.ProtocolStateActor.OutboundUnassociated
 
remoteAddress() - Method in class akka.remote.transport.TestAssociationHandle
 
remoteAddress() - Method in class akka.remote.transport.TestTransport.AssociateAttempt
 
RemoteConnection - Class in akka.remote.testconductor
INTERNAL API.
RemoteConnection() - Constructor for class akka.remote.testconductor.RemoteConnection
 
RemoteConnection$ - Class in akka.remote.testconductor
INTERNAL API.
RemoteConnection$() - Constructor for class akka.remote.testconductor.RemoteConnection$
 
remoteDaemon() - Method in class akka.remote.RemoteActorRefProvider
 
RemoteDeployer - Class in akka.remote
INTERNAL API
RemoteDeployer(ActorSystem.Settings, DynamicAccess) - Constructor for class akka.remote.RemoteDeployer
 
RemoteDeploymentWatcher - Class in akka.remote
INTERNAL API
RemoteDeploymentWatcher() - Constructor for class akka.remote.RemoteDeploymentWatcher
 
RemoteDeploymentWatcher$ - Class in akka.remote
INTERNAL API
RemoteDeploymentWatcher$() - Constructor for class akka.remote.RemoteDeploymentWatcher$
 
RemoteDeploymentWatcher.WatchRemote - Class in akka.remote
 
RemoteDeploymentWatcher.WatchRemote(ActorRef, ActorRef) - Constructor for class akka.remote.RemoteDeploymentWatcher.WatchRemote
 
RemoteDeploymentWatcher.WatchRemote$ - Class in akka.remote
 
RemoteDeploymentWatcher.WatchRemote$() - Constructor for class akka.remote.RemoteDeploymentWatcher.WatchRemote$
 
RemoteLifecycleEventsLogLevel() - Method in class akka.remote.RemoteSettings
 
remoteListenerRelativeTo(TestAssociationHandle, Tuple2<AssociationHandle.HandleEventListener, AssociationHandle.HandleEventListener>) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Returns the remote endpoint for a pair of endpoints relative to the owner of the supplied handle.
remoteMetrics() - Method in class akka.remote.EndpointWriter
 
RemoteMetrics - Interface in akka.remote
INTERNAL API
RemoteMetricsExtension - Class in akka.remote
INTERNAL API Extension that keeps track of remote metrics, such as max size of different message types.
RemoteMetricsExtension() - Constructor for class akka.remote.RemoteMetricsExtension
 
RemoteMetricsExtension$ - Class in akka.remote
INTERNAL API Extension that keeps track of remote metrics, such as max size of different message types.
RemoteMetricsExtension$() - Constructor for class akka.remote.RemoteMetricsExtension$
 
RemoteMetricsOff - Class in akka.remote
INTERNAL API
RemoteMetricsOff() - Constructor for class akka.remote.RemoteMetricsOff
 
RemoteMetricsOn - Class in akka.remote
INTERNAL API
RemoteMetricsOn(ExtendedActorSystem) - Constructor for class akka.remote.RemoteMetricsOn
 
remoteProvider() - Method in class akka.remote.RemoteWatcher
 
RemoteRef - Interface in akka.remote
 
RemoteRouterConfig - Class in akka.remote.routing
RouterConfig implementation for remote deployment on defined target nodes.
RemoteRouterConfig(Pool, Iterable<Address>) - Constructor for class akka.remote.routing.RemoteRouterConfig
 
RemoteRouterConfig(Pool, Iterable<Address>) - Constructor for class akka.remote.routing.RemoteRouterConfig
 
RemoteRouterConfig(Pool, Address[]) - Constructor for class akka.remote.routing.RemoteRouterConfig
 
RemoteRouterConfig$ - Class in akka.remote.routing
 
RemoteRouterConfig$() - Constructor for class akka.remote.routing.RemoteRouterConfig$
 
RemoteScope - Class in akka.remote
 
RemoteScope(Address) - Constructor for class akka.remote.RemoteScope
 
RemoteScope$ - Class in akka.remote
 
RemoteScope$() - Constructor for class akka.remote.RemoteScope$
 
remoteSettings() - Method in class akka.remote.RemoteActorRefProvider
 
RemoteSettings - Class in akka.remote
 
RemoteSettings(com.typesafe.config.Config) - Constructor for class akka.remote.RemoteSettings
 
RemoteSystemDaemon - Class in akka.remote
INTERNAL API
RemoteSystemDaemon(ActorSystemImpl, ActorPath, InternalActorRef, ActorRef, LoggingAdapter, boolean) - Constructor for class akka.remote.RemoteSystemDaemon
 
RemoteTransport - Class in akka.remote
INTERNAL API
RemoteTransport(ExtendedActorSystem, RemoteActorRefProvider) - Constructor for class akka.remote.RemoteTransport
 
RemoteTransportException - Exception in akka.remote
RemoteTransportException represents a general failure within a RemoteTransport, such as inability to start, wrong configuration etc.
RemoteTransportException(String, Throwable) - Constructor for exception akka.remote.RemoteTransportException
 
RemoteTransportExceptionNoStackTrace - Exception in akka.remote
RemoteTransportException without stack trace.
RemoteTransportExceptionNoStackTrace(String, Throwable) - Constructor for exception akka.remote.RemoteTransportExceptionNoStackTrace
 
RemoteWatcher - Class in akka.remote
INTERNAL API
RemoteWatcher(FailureDetectorRegistry<Address>, FiniteDuration, FiniteDuration, FiniteDuration) - Constructor for class akka.remote.RemoteWatcher
 
RemoteWatcher$ - Class in akka.remote
INTERNAL API
RemoteWatcher$() - Constructor for class akka.remote.RemoteWatcher$
 
RemoteWatcher.ExpectedFirstHeartbeat - Class in akka.remote
 
RemoteWatcher.ExpectedFirstHeartbeat(Address) - Constructor for class akka.remote.RemoteWatcher.ExpectedFirstHeartbeat
 
RemoteWatcher.ExpectedFirstHeartbeat$ - Class in akka.remote
 
RemoteWatcher.ExpectedFirstHeartbeat$() - Constructor for class akka.remote.RemoteWatcher.ExpectedFirstHeartbeat$
 
RemoteWatcher.Heartbeat$ - Class in akka.remote
 
RemoteWatcher.Heartbeat$() - Constructor for class akka.remote.RemoteWatcher.Heartbeat$
 
RemoteWatcher.HeartbeatRsp - Class in akka.remote
 
RemoteWatcher.HeartbeatRsp(int) - Constructor for class akka.remote.RemoteWatcher.HeartbeatRsp
 
RemoteWatcher.HeartbeatRsp$ - Class in akka.remote
 
RemoteWatcher.HeartbeatRsp$() - Constructor for class akka.remote.RemoteWatcher.HeartbeatRsp$
 
RemoteWatcher.HeartbeatTick$ - Class in akka.remote
 
RemoteWatcher.HeartbeatTick$() - Constructor for class akka.remote.RemoteWatcher.HeartbeatTick$
 
RemoteWatcher.ReapUnreachableTick$ - Class in akka.remote
 
RemoteWatcher.ReapUnreachableTick$() - Constructor for class akka.remote.RemoteWatcher.ReapUnreachableTick$
 
RemoteWatcher.Rewatch - Class in akka.remote
 
RemoteWatcher.Rewatch(InternalActorRef, InternalActorRef) - Constructor for class akka.remote.RemoteWatcher.Rewatch
 
RemoteWatcher.RewatchRemote - Class in akka.remote
 
RemoteWatcher.RewatchRemote(ActorRef, ActorRef) - Constructor for class akka.remote.RemoteWatcher.RewatchRemote
 
RemoteWatcher.RewatchRemote$ - Class in akka.remote
 
RemoteWatcher.RewatchRemote$() - Constructor for class akka.remote.RemoteWatcher.RewatchRemote$
 
RemoteWatcher.Stats - Class in akka.remote
 
RemoteWatcher.Stats(int, int, Set<Tuple2<ActorRef, ActorRef>>) - Constructor for class akka.remote.RemoteWatcher.Stats
 
RemoteWatcher.Stats$ - Class in akka.remote
 
RemoteWatcher.Stats$() - Constructor for class akka.remote.RemoteWatcher.Stats$
 
RemoteWatcher.UnwatchRemote - Class in akka.remote
 
RemoteWatcher.UnwatchRemote(ActorRef, ActorRef) - Constructor for class akka.remote.RemoteWatcher.UnwatchRemote
 
RemoteWatcher.UnwatchRemote$ - Class in akka.remote
 
RemoteWatcher.UnwatchRemote$() - Constructor for class akka.remote.RemoteWatcher.UnwatchRemote$
 
RemoteWatcher.WatchRemote - Class in akka.remote
 
RemoteWatcher.WatchRemote(ActorRef, ActorRef) - Constructor for class akka.remote.RemoteWatcher.WatchRemote
 
RemoteWatcher.WatchRemote$ - Class in akka.remote
 
RemoteWatcher.WatchRemote$() - Constructor for class akka.remote.RemoteWatcher.WatchRemote$
 
Remoting - Class in akka.remote
INTERNAL API
Remoting(ExtendedActorSystem, RemoteActorRefProvider) - Constructor for class akka.remote.Remoting
 
Remoting$ - Class in akka.remote
INTERNAL API
Remoting$() - Constructor for class akka.remote.Remoting$
 
Remoting.RegisterTransportActor - Class in akka.remote
 
Remoting.RegisterTransportActor(Props, String) - Constructor for class akka.remote.Remoting.RegisterTransportActor
 
Remoting.RegisterTransportActor$ - Class in akka.remote
 
Remoting.RegisterTransportActor$() - Constructor for class akka.remote.Remoting.RegisterTransportActor$
 
Remoting.TransportSupervisor - Class in akka.remote
 
Remoting.TransportSupervisor() - Constructor for class akka.remote.Remoting.TransportSupervisor
 
RemotingErrorEvent - Class in akka.remote
 
RemotingErrorEvent(Throwable) - Constructor for class akka.remote.RemotingErrorEvent
 
RemotingErrorEvent$ - Class in akka.remote
 
RemotingErrorEvent$() - Constructor for class akka.remote.RemotingErrorEvent$
 
RemotingLifecycleEvent - Interface in akka.remote
 
RemotingListenEvent - Class in akka.remote
 
RemotingListenEvent(Set<Address>) - Constructor for class akka.remote.RemotingListenEvent
 
RemotingListenEvent$ - Class in akka.remote
 
RemotingListenEvent$() - Constructor for class akka.remote.RemotingListenEvent$
 
RemotingShutdownEvent - Class in akka.remote
 
RemotingShutdownEvent() - Constructor for class akka.remote.RemotingShutdownEvent
 
RemotingShutdownEvent$ - Class in akka.remote
 
RemotingShutdownEvent$() - Constructor for class akka.remote.RemotingShutdownEvent$
 
remove(ActorRef) - Method in interface akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer
 
remove(ActorRef) - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
 
remove(ActorRef) - Method in interface akka.actor.dungeon.ChildrenContainer
 
remove(ActorRef) - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
 
remove() - Method in class akka.actor.mailbox.filebased.FileBasedMessageQueue
Completely delete the queue.
remove() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
remove(boolean) - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
Remove and return an item from the queue, if there is one.
remove() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
Remove and return an item from the queue, if there is one.
remove(String, int, boolean, boolean, Function1<Option<QItem>, BoxedUnit>) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
Retrieve an item from a queue and pass it to a continuation.
remove(UniqueAddress) - Method in class akka.cluster.AutoDownBase
 
remove(Address) - Method in class akka.cluster.MetricsGossip
Removes nodes if their correlating node ring members are not akka.cluster.MemberStatus.Up
remove(Iterable<UniqueAddress>) - Method in class akka.cluster.Reachability
 
remove(Member) - Method in class akka.contrib.pattern.ClusterSingletonProxy
Removes a member.
remove(ActorRef) - Method in interface akka.contrib.pattern.DistributedPubSubMediator.Internal$.TopicLike
 
remove(T) - Method in class akka.contrib.pattern.WorkList
Removes an entry from the work list
remove(A) - Method in class akka.remote.DefaultFailureDetectorRegistry
 
remove(A) - Method in interface akka.remote.FailureDetectorRegistry
Removes the heartbeat management for a resource.
Remove - Class in akka.remote.testconductor
 
Remove(RoleName) - Constructor for class akka.remote.testconductor.Remove
 
remove(T) - Method in class akka.routing.ConsistentHash
Java API: Removes a node from the node ring.
remove(Object) - Method in class akka.util.BoundedBlockingQueue
 
remove(K, V) - Method in class akka.util.Index
Disassociates the value of type V from the key of type K
remove(K) - Method in class akka.util.Index
Disassociates all the values for the specified key
Remove$ - Class in akka.remote.testconductor
 
Remove$() - Constructor for class akka.remote.testconductor.Remove$
 
removeAll() - Method in class akka.contrib.pattern.WorkList
Removes all entries from this WorkList
removeAll(Collection<?>) - Method in class akka.util.BoundedBlockingQueue
 
removeAllAddresses(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .UniqueAddress allAddresses = 1;
removeAllAddresses(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .Address allAddresses = 1;
removeBatch(int) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
repeated .PersistentMessage batch = 1;
removeBuckets(int) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
repeated .Delta.Bucket buckets = 1;
removeChild(String) - Method in class akka.actor.VirtualPathContainer
 
removeChild(String, ActorRef) - Method in class akka.actor.VirtualPathContainer
Remove a named child if it matches the ref.
removeChildAndGetStateChange(ActorRef) - Method in interface akka.actor.dungeon.Children
 
removeContent(int) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
repeated .Delta.Entry content = 3;
removed() - Method in class akka.cluster.ClusterCoreDaemon
 
removed(UniqueAddress) - Method in class akka.cluster.Member$
INTERNAL API
removed(UniqueAddress) - Static method in class akka.cluster.Member
INTERNAL API
removed() - Method in class akka.cluster.MemberStatus$
Java API: retrieve the &ldquo;removed&rdquo; status singleton
removed() - Static method in class akka.cluster.MemberStatus
Java API: retrieve the &ldquo;removed&rdquo; status singleton
removed() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
Removed_VALUE - Static variable in enum akka.cluster.protobuf.msg.ClusterMessages.MemberStatus
Removed = 5;
removedTimeToLiveMillis() - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
removeFilter(EventFilter) - Method in class akka.testkit.TestEventListener
 
removeFromCache(Seq<Tuple2<Object, Set<Object>>>) - Method in interface akka.event.SubchannelClassification
 
removeFromSet(ActorRef, Set<ActorRef>) - Method in interface akka.actor.dungeon.DeathWatch
 
removeMember(Member) - Method in class akka.cluster.ClusterHeartbeatSender
 
removeMember(UniqueAddress) - Method in class akka.cluster.ClusterHeartbeatSenderState
 
removeMember(Member) - Method in class akka.cluster.ClusterMetricsCollector
Removes a member from the member node ring.
removeMember(Member) - Method in interface akka.cluster.routing.ClusterRouterActor
 
removeMember(Member) - Method in class akka.cluster.routing.ClusterRouterGroupActor
 
removeMembers(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .Member members = 4;
removeMetrics(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
repeated .NodeMetrics.Metric metrics = 3;
removeNode(RoleName) - Method in interface akka.remote.testconductor.Conductor
Remove a remote host from the list, so that the remaining nodes may still pass subsequent barriers.
removeNodeMetrics(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .NodeMetrics nodeMetrics = 3;
removeObserverReachability(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
repeated .ObserverReachability observerReachability = 2;
removeObservers(Set<UniqueAddress>) - Method in class akka.cluster.Reachability
 
removePattern(int) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
repeated .Selection pattern = 3;
removePolicy(Address) - Method in class akka.remote.EndpointManager.EndpointRegistry
 
RemoveRoutee - Class in akka.routing
Remove a specific routee by sending this message to the router.
RemoveRoutee(Routee) - Constructor for class akka.routing.RemoveRoutee
 
removeRoutee(Routee, boolean) - Method in class akka.routing.RoutedActorCell
 
removeRoutee(Routee) - Method in class akka.routing.Router
Create a new instance without the specified routee.
removeRoutee(ActorRef) - Method in class akka.routing.Router
Create a new instance without the ActorRefRoutee for the specified ActorRef.
removeRoutee(ActorSelection) - Method in class akka.routing.Router
Create a new instance without the ActorSelectionRoutee for the specified ActorSelection.
RemoveRoutee$ - Class in akka.routing
 
RemoveRoutee$() - Constructor for class akka.routing.RemoveRoutee$
 
removeRoutees(Iterable<Routee>, boolean) - Method in class akka.routing.RoutedActorCell
Remove routees from the Router.
removeScheme(String) - Method in interface akka.remote.transport.SchemeAugmenter
 
removeScheme(Address) - Method in interface akka.remote.transport.SchemeAugmenter
 
removeSubjectReachability(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
repeated .SubjectReachability subjectReachability = 2;
removeTentative() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
removeUnconfirmedDeliveries(int) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
removeUnreachableWithMemberStatus() - Method in class akka.cluster.Gossip$
 
removeUnreachableWithMemberStatus() - Static method in class akka.cluster.Gossip
 
removeValue(V) - Method in class akka.util.Index
Removes the specified value from all keys
removeValue(V) - Method in class akka.util.SubclassifiedIndex.Nonroot
 
removeValue(K, V) - Method in class akka.util.SubclassifiedIndex
Remove value from all keys which are subclasses of the given key.
removeValue(V) - Method in class akka.util.SubclassifiedIndex
Remove value from all keys in the index.
removeVersions(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
repeated .VectorClock.Version versions = 2;
removeVersions(int) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
repeated .Status.Version versions = 1;
remWatcher(ActorRef, ActorRef) - Method in interface akka.actor.dungeon.DeathWatch
 
repeat() - Method in class akka.actor.FSM.Timer
 
replacement() - Method in class akka.persistence.serialization.SnapshotSerializer$
 
replacement() - Static method in class akka.persistence.serialization.SnapshotSerializer
 
replaceWith(Cell) - Method in class akka.actor.UnstartedCell
 
replay(String, Function1<JournalItem, BoxedUnit>) - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
replayDeleted() - Method in class akka.persistence.JournalProtocol.ReplayMessages
 
replayDispatcher() - Method in interface akka.persistence.journal.leveldb.LeveldbRecovery
 
replayDispatcherId() - Method in interface akka.persistence.journal.leveldb.LeveldbRecovery
 
replayedMessage(long, boolean, Seq<String>) - Method in interface akka.persistence.journal.JournalSpec
 
replayFailed() - Method in interface akka.persistence.Recovery
INTERNAL API.
replayJournal() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
replayMax() - Method in class akka.persistence.Recover
 
replayMax() - Method in class akka.persistence.Update
 
ReplayMediator - Class in akka.persistence.journal
 
ReplayMediator(Function1<PersistentRepr, BoxedUnit>, Promise<BoxedUnit>, Duration) - Constructor for class akka.persistence.journal.ReplayMediator
 
replayMessages(int, long, long, long, Function1<PersistentRepr, BoxedUnit>) - Method in interface akka.persistence.journal.leveldb.LeveldbRecovery
 
replayStarted(boolean) - Method in interface akka.persistence.PersistentView
INTERNAL API.
replayStarted(boolean) - Method in interface akka.persistence.Recovery
INTERNAL API.
replayStarted(boolean) - Method in interface akka.persistence.View
INTERNAL API.
replies() - Method in class akka.actor.FSM.State
 
reply() - Method in class akka.cluster.MetricsGossipEnvelope
 
reply(Object) - Method in class akka.testkit.JavaTestKit
 
reply(Object) - Method in class akka.testkit.TestProbe
Send message to the sender of the last dequeued message.
REPLY_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
replyGossipTo(Address) - Method in class akka.cluster.ClusterMetricsCollector
 
replying(Object) - Method in class akka.actor.FSM.State
Send reply to sender of the current message, if available.
replyPersistent() - Method in class akka.persistence.PersistentChannelSettings
 
ReplyTimeout() - Method in class akka.camel.CamelSettings
Configured setting, when endpoint is out-capable (can produce responses) replyTimeout is the maximum time the endpoint can take to send the response before the message exchange fails.
replyTimeout() - Method in interface akka.camel.Consumer
When endpoint is out-capable (can produce responses) replyTimeout is the maximum time the endpoint can take to send the response before the message exchange fails.
replyTimeout() - Method in class akka.camel.ConsumerConfig
 
replyTimeout() - Method in interface akka.camel.internal.component.ActorEndpointConfig
 
replyTo() - Method in class akka.remote.EndpointWriter.StopReading
 
replyTo() - Method in class akka.remote.EndpointWriter.TakeOver
 
replyTo() - Method in class akka.testkit.TestActorRefSpec.ReplyActor
 
RepointableActorRef - Class in akka.actor
This actor ref starts out with some dummy cell (by default just enqueuing messages into vectors protected by ReentrantLock), it must be initialize()&rsquo;d before it can be sent to, and it will be activate()&rsquo;d by its supervisor in response to the Supervise() message, which will replace the contained Cell with a fully functional one, transfer all messages from dummy to real queue and swap out the cell ref.
RepointableActorRef(ActorSystemImpl, Props, MessageDispatcher, MailboxType, InternalActorRef, ActorPath) - Constructor for class akka.actor.RepointableActorRef
 
RepointableRef - Interface in akka.actor
RepointableActorRef (and potentially others) may change their locality at runtime, meaning that isLocal might not be stable.
reportFailure(Throwable) - Method in class akka.dispatch.ExecutionContexts.sameThreadExecutionContext$
 
reportFailure(Throwable) - Method in class akka.dispatch.MessageDispatcher
 
reportFailure(Throwable) - Method in class akka.util.SerializedSuspendableExecutionContext
 
Request - Interface in akka.zeromq
Marker trait representing request messages for zeromq
requester() - Method in class akka.remote.transport.TestTransport.DisassociateAttempt
 
requestor() - Method in class akka.persistence.JournalProtocol.DeleteMessages
 
requestor() - Method in class akka.persistence.JournalProtocol.WriteConfirmations
 
RequestReader - Class in akka.persistence
Reads Deliver requests from the journal and processes them.
RequestReader(String, PersistentChannelSettings) - Constructor for class akka.persistence.RequestReader
 
requestRestartPermission(Tuple2<Option<Object>, Option<Object>>) - Method in class akka.actor.ChildRestartStats
 
requestShardBufferHomes() - Method in class akka.contrib.pattern.ShardRegion
 
RequestWriter - Class in akka.persistence
Writes Deliver requests to the journal.
RequestWriter(String, PersistentChannelSettings, ActorRef) - Constructor for class akka.persistence.RequestWriter
 
RequestWriter$ - Class in akka.persistence
 
RequestWriter$() - Constructor for class akka.persistence.RequestWriter$
 
RequestWriter.RequestsWritten$ - Class in akka.persistence
 
RequestWriter.RequestsWritten$() - Constructor for class akka.persistence.RequestWriter.RequestsWritten$
 
RequireCookie() - Method in class akka.remote.transport.AkkaProtocolSettings
 
RequiresMessageQueue<T> - Interface in akka.dispatch
Trait to signal that an Actor requires a certain type of message queue semantics.
requireTestConductorTranport() - Method in interface akka.remote.testconductor.Conductor
 
requiring(boolean, Function0<Object>) - Method in class akka.util.Helpers.Requiring
Check that a condition is true.
requiring(Function1<A, Object>, Function0<Object>) - Method in class akka.util.Helpers.Requiring
Check that a condition is true for the value.
RESCHEDULED() - Method in class akka.dispatch.MessageDispatcher$
 
RESCHEDULED() - Static method in class akka.dispatch.MessageDispatcher
 
resend(Vector<ReliableProxy.Message>) - Method in class akka.contrib.pattern.ReliableProxy
 
resendBuffer() - Method in class akka.remote.ReliableDeliverySupervisor
 
ResendBufferCapacityReachedException - Exception in akka.remote
 
ResendBufferCapacityReachedException(int) - Constructor for exception akka.remote.ResendBufferCapacityReachedException
 
resendTimer() - Method in class akka.contrib.pattern.ReliableProxy
 
ResendUnfulfillableException - Exception in akka.remote
 
ResendUnfulfillableException() - Constructor for exception akka.remote.ResendUnfulfillableException
 
Resequenceable - Interface in akka.persistence
INTERNAL API
resequenceableEventBatch() - Method in interface akka.persistence.Eventsourced
 
resequencer() - Method in interface akka.persistence.journal.AsyncWriteJournal
 
resequencerCounter() - Method in interface akka.persistence.journal.AsyncWriteJournal
 
reserve(String) - Method in interface akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer
 
reserve(String) - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
 
reserve(String) - Method in interface akka.actor.dungeon.ChildrenContainer
 
reserve(String) - Method in class akka.actor.dungeon.ChildrenContainer.TerminatedChildrenContainer$
 
reserve(String) - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
 
reserveChild(String) - Method in interface akka.actor.dungeon.Children
 
Reset - Class in akka.persistence
Resets a PersistentChannel, forcing it to redeliver all unconfirmed persistent messages.
Reset() - Constructor for class akka.persistence.Reset
 
reset() - Method in class akka.remote.DefaultFailureDetectorRegistry
 
reset() - Method in interface akka.remote.FailureDetectorRegistry
Removes all resources and any associated failure detector state.
reset() - Method in class akka.remote.ReliableDeliverySupervisor
 
reset() - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Resets the state of the registry.
reset() - Method in class akka.testkit.TestBarrier
 
reset() - Method in class akka.testkit.TestLatch
 
Reset$ - Class in akka.persistence
Resets a PersistentChannel, forcing it to redeliver all unconfirmed persistent messages.
Reset$() - Constructor for class akka.persistence.Reset$
 
resetBackoff() - Method in class akka.contrib.pattern.ReliableProxy
Reset backoff interval.
ResetException - Exception in akka.persistence
Exception thrown by a PersistentChannel child actor to re-initiate delivery.
ResetException() - Constructor for exception akka.persistence.ResetException
 
resetStreamCache() - Method in class akka.camel.CamelMessage
Reset StreamCache body.
ResizablePoolActor - Class in akka.routing
INTERNAL API
ResizablePoolActor(SupervisorStrategy) - Constructor for class akka.routing.ResizablePoolActor
 
ResizablePoolActor$ - Class in akka.routing
INTERNAL API
ResizablePoolActor$() - Constructor for class akka.routing.ResizablePoolActor$
 
ResizablePoolActor.Resize$ - Class in akka.routing
 
ResizablePoolActor.Resize$() - Constructor for class akka.routing.ResizablePoolActor.Resize$
 
ResizablePoolCell - Class in akka.routing
INTERNAL API
ResizablePoolCell(ActorSystemImpl, InternalActorRef, Props, MessageDispatcher, Props, InternalActorRef, Pool) - Constructor for class akka.routing.ResizablePoolCell
 
resize(IndexedSeq<Routee>) - Method in class akka.routing.DefaultResizer
 
resize(boolean) - Method in class akka.routing.ResizablePoolCell
 
resize(IndexedSeq<Routee>) - Method in interface akka.routing.Resizer
Decide if the capacity of the router need to be changed.
resizer() - Method in class akka.cluster.routing.AdaptiveLoadBalancingPool
 
resizer() - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
 
resizer() - Method in class akka.cluster.routing.ClusterRouterConfig
 
resizer() - Method in class akka.cluster.routing.ClusterRouterPool
 
resizer() - Method in class akka.remote.routing.RemoteRouterConfig
 
resizer() - Method in class akka.routing.BalancingPool
Resizer cannot be used together with BalancingPool
resizer() - Method in class akka.routing.BroadcastPool
 
resizer() - Method in class akka.routing.BroadcastRouter
 
resizer() - Method in class akka.routing.ConsistentHashingPool
 
resizer() - Method in class akka.routing.ConsistentHashingRouter
 
resizer() - Method in class akka.routing.FromConfig
 
resizer() - Method in interface akka.routing.Pool
Pool with dynamically resizable number of routees return the Resizer to use.
resizer() - Method in class akka.routing.RandomPool
 
resizer() - Method in class akka.routing.RandomRouter
 
resizer() - Method in class akka.routing.ResizablePoolCell
 
Resizer - Interface in akka.routing
Pool routers with dynamically resizable number of routees are implemented by providing a Resizer implementation in the Pool configuration.
resizer() - Method in class akka.routing.RoundRobinPool
 
resizer() - Method in class akka.routing.RoundRobinRouter
 
resizer() - Method in class akka.routing.ScatterGatherFirstCompletedPool
 
resizer() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
resizer() - Method in class akka.routing.SmallestMailboxPool
 
resizer() - Method in class akka.routing.SmallestMailboxRouter
 
resizer() - Method in class akka.routing.TailChoppingPool
 
resizerCell() - Method in class akka.routing.ResizablePoolActor
 
resolve() - Method in class akka.dispatch.CachingConfig
 
resolve(com.typesafe.config.ConfigResolveOptions) - Method in class akka.dispatch.CachingConfig
 
resolveActorRef(String) - Method in interface akka.actor.ActorRefProvider
Create actor reference for a specified path.
resolveActorRef(ActorPath) - Method in interface akka.actor.ActorRefProvider
Create actor reference for a specified path.
resolveActorRef(String) - Method in class akka.actor.LocalActorRefProvider
 
resolveActorRef(ActorPath) - Method in class akka.actor.LocalActorRefProvider
 
resolveActorRef(InternalActorRef, Iterable<String>) - Method in class akka.actor.LocalActorRefProvider
INTERNAL API
resolveActorRef(String) - Method in class akka.remote.RemoteActorRefProvider
 
resolveActorRef(ActorPath) - Method in class akka.remote.RemoteActorRefProvider
 
resolveActorRefWithLocalAddress(String, Address) - Method in class akka.remote.RemoteActorRefProvider
INTERNAL API Called in deserialization of incoming remote messages where the correct local address is known.
resolveClass(ObjectStreamClass) - Method in class akka.util.ClassLoaderObjectInputStream
 
resolveOne(Timeout) - Method in class akka.actor.ActorSelection
Resolve the ActorRef matching this selection.
resolveOne(FiniteDuration) - Method in class akka.actor.ActorSelection
Resolve the ActorRef matching this selection.
resolveWith(com.typesafe.config.Config, com.typesafe.config.ConfigResolveOptions) - Method in class akka.dispatch.CachingConfig
 
resolveWith(com.typesafe.config.Config) - Method in class akka.dispatch.CachingConfig
 
Response - Interface in akka.zeromq
Base trait for the events raised by a ZeroMQ socket actor
responseTunnel(ActorRef) - Method in class akka.contrib.pattern.ClusterReceptionist
 
restart(Throwable) - Method in interface akka.actor.Cell
Restart this actor (will recursively restart or stop all children).
Restart() - Method in interface akka.actor.dsl.Creators.Act
 
restart(Throwable) - Method in interface akka.actor.dungeon.Dispatch
 
restart(Throwable) - Method in class akka.actor.InternalActorRef
 
restart(Throwable) - Method in class akka.actor.LocalActorRef
 
restart(Throwable) - Method in interface akka.actor.MinimalActorRef
 
restart(Throwable) - Method in class akka.actor.RepointableActorRef
 
restart() - Method in class akka.actor.SupervisorStrategy$
Java API: Returning this directive discards the old Actor instance and replaces it with a new, then resumes message processing.
restart() - Static method in class akka.actor.SupervisorStrategy
Java API: Returning this directive discards the old Actor instance and replaces it with a new, then resumes message processing.
restart(Throwable) - Method in class akka.actor.UnstartedCell
 
restart(Throwable) - Method in class akka.remote.RemoteActorRef
 
restartChild(ActorRef, Throwable, boolean) - Method in class akka.actor.SupervisorStrategy
Restart the given child, possibly suspending it first.
restartTimeWindowStartNanos() - Method in class akka.actor.ChildRestartStats
 
resubmitOnBlock() - Method in interface akka.dispatch.BatchingExecutor
 
resubmitOnBlock() - Method in class akka.dispatch.ExecutionContexts.sameThreadExecutionContext$
 
resubmitOnBlock() - Method in class akka.dispatch.MessageDispatcher
 
resubmitUnbatched() - Method in class akka.dispatch.BatchingExecutor.AbstractBatch
 
result(Duration, CanAwait) - Method in class akka.actor.ActorSystemImpl.TerminationCallbacks
 
result() - Method in class akka.pattern.PromiseActorRef
 
result(Duration, CanAwait) - Method in class akka.testkit.TestLatch
 
result() - Method in class akka.util.ByteStringBuilder
 
results() - Method in class akka.remote.EndpointManager.ListensResult
 
resume(Throwable) - Method in interface akka.actor.Cell
Recursively resume this actor and all its children.
Resume() - Method in interface akka.actor.dsl.Creators.Act
 
resume(Throwable) - Method in interface akka.actor.dungeon.Dispatch
 
resume(Throwable) - Method in class akka.actor.InternalActorRef
 
resume(Throwable) - Method in class akka.actor.LocalActorRef
Resumes a suspended actor.
resume(Throwable) - Method in interface akka.actor.MinimalActorRef
 
resume(Throwable) - Method in class akka.actor.RepointableActorRef
 
resume() - Method in class akka.actor.SupervisorStrategy$
Java API: Returning this directive resumes message processing for the failed Actor
resume() - Static method in class akka.actor.SupervisorStrategy
Java API: Returning this directive resumes message processing for the failed Actor
resume(Throwable) - Method in class akka.actor.UnstartedCell
 
resume() - Method in class akka.dispatch.Mailbox
Reduce the suspend count by one.
resume(ActorCell) - Method in class akka.dispatch.MessageDispatcher
 
Resume - Class in akka.dispatch.sysmsg
INTERNAL API
Resume(Throwable) - Constructor for class akka.dispatch.sysmsg.Resume
 
resume(Throwable) - Method in class akka.remote.RemoteActorRef
 
resume(ActorCell) - Method in class akka.testkit.CallingThreadDispatcher
 
resume() - Method in class akka.util.SerializedSuspendableExecutionContext
Resumes execution of tasks until suspend is called, if it isn't currently suspended, it is a no-op.
Resume$ - Class in akka.dispatch.sysmsg
 
Resume$() - Constructor for class akka.dispatch.sysmsg.Resume$
 
resumeAccepting(int) - Method in class akka.io.TcpMessage$
This message enables the accepting of the next connection if pull reading is enabled for connection actors.
resumeAccepting(int) - Static method in class akka.io.TcpMessage
This message enables the accepting of the next connection if pull reading is enabled for connection actors.
resumeChild(ActorRef, Throwable) - Method in class akka.actor.SupervisorStrategy
Resume the previously failed child: do never apply this to a child which is not the currently failing child.
resumeChildren(Throwable, ActorRef) - Method in interface akka.actor.dungeon.Children
 
resumeNonRecursive() - Method in interface akka.actor.dungeon.FaultHandling
 
resumeReading(TcpConnection.ConnectionInfo) - Method in class akka.io.TcpConnection
 
resumeReading() - Method in class akka.io.TcpMessage$
This command needs to be sent to the connection actor after a Tcp.SuspendReading command in order to resume reading from the socket.
resumeReading() - Static method in class akka.io.TcpMessage
This command needs to be sent to the connection actor after a Tcp.SuspendReading command in order to resume reading from the socket.
resumeReading() - Method in class akka.io.UdpConnectedMessage$
This message must be sent to the listener actor to re-enable reading from the socket after a UdpConnected.SuspendReading command.
resumeReading() - Static method in class akka.io.UdpConnectedMessage
This message must be sent to the listener actor to re-enable reading from the socket after a UdpConnected.SuspendReading command.
resumeReading() - Method in class akka.io.UdpMessage$
This message must be sent to the listener actor to re-enable reading from the socket after a Udp.SuspendReading command.
resumeReading() - Static method in class akka.io.UdpMessage
This message must be sent to the listener actor to re-enable reading from the socket after a Udp.SuspendReading command.
resumeReads() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
resumeWriting() - Method in class akka.io.TcpMessage$
When useResumeWriting is in effect as was indicated in the Tcp.Register message then this command needs to be sent to the connection actor in order to re-enable writing after a Tcp.CommandFailed event.
resumeWriting() - Static method in class akka.io.TcpMessage
When useResumeWriting is in effect as was indicated in the Tcp.Register message then this command needs to be sent to the connection actor in order to re-enable writing after a Tcp.CommandFailed event.
retainAll(Collection<?>) - Method in class akka.util.BoundedBlockingQueue
 
retriedSend() - Method in interface akka.io.WithUdpSend
 
retriesLeft() - Method in class akka.io.SelectionHandler.Retry
 
retryGateClosedFor() - Method in class akka.contrib.pattern.ReliableProxy
 
RetryGateClosedFor() - Method in class akka.remote.RemoteSettings
 
RetryInterval() - Method in class akka.contrib.pattern.ClusterSharding.Settings$
 
retryTask() - Method in class akka.cluster.FirstSeedNodeProcess
 
retryTask() - Method in class akka.contrib.pattern.ShardRegion
 
RetryUnsuccessfulJoinAfter() - Method in class akka.cluster.ClusterSettings
 
returnsFuture() - Method in class akka.actor.TypedActor.MethodCall
 
returnsJOption() - Method in class akka.actor.TypedActor.MethodCall
 
returnsOption() - Method in class akka.actor.TypedActor.MethodCall
 
reusableQueue(BlockingQueue<Runnable>) - Method in class akka.dispatch.ThreadPoolConfig$
 
reusableQueue(Function0<BlockingQueue<Runnable>>) - Method in class akka.dispatch.ThreadPoolConfig$
 
reusableQueue(BlockingQueue<Runnable>) - Static method in class akka.dispatch.ThreadPoolConfig
 
reusableQueue(Function0<BlockingQueue<Runnable>>) - Static method in class akka.dispatch.ThreadPoolConfig
 
ReuseAddress() - Method in interface akka.io.Inet.SoForwarders
Inet.SocketOption to enable or disable SO_REUSEADDR
reuseAddress(boolean) - Method in interface akka.io.Inet.SoJavaFactories
Inet.SocketOption to enable or disable SO_REUSEADDR
reverse() - Method in class akka.dispatch.sysmsg.EarliestFirstSystemMessageList
Reverses the list.
reverse() - Method in class akka.dispatch.sysmsg.LatestFirstSystemMessageList
Reverses the list.
reverseInner(SystemMessage, SystemMessage) - Method in class akka.dispatch.sysmsg.SystemMessageList$
 
reverseInner(SystemMessage, SystemMessage) - Static method in class akka.dispatch.sysmsg.SystemMessageList
 
reWatch(Address) - Method in class akka.remote.RemoteWatcher
To ensure that we receive heartbeat messages from the right actor system incarnation we send Watch again for the first HeartbeatRsp (containing the system UID) and if HeartbeatRsp contains a new system UID.
rewatchRemote(ActorRef, ActorRef) - Method in class akka.remote.RemoteWatcher
 
ring() - Method in class akka.cluster.ClusterHeartbeatSenderState
 
role() - Method in class akka.cluster.ClusterEvent.RoleLeaderChanged
 
Role() - Method in class akka.contrib.pattern.ClusterSharding.Settings$
 
Role - Interface in akka.remote.testconductor
INTERNAL API.
role(String) - Method in class akka.remote.testkit.MultiNodeConfig
Construct a RoleName and return it, to be used as an identifier in the test.
roleLeader(String) - Method in class akka.cluster.ClusterEvent.CurrentClusterState
get address of current leader, if any, within the role set
roleLeader(String, UniqueAddress) - Method in class akka.cluster.Gossip
 
roleLeaderMap() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
 
RoleName - Class in akka.remote.testconductor
 
RoleName(String) - Constructor for class akka.remote.testconductor.RoleName
 
roleName() - Method in class akka.remote.testconductor.ServerFSM
 
RoleName$ - Class in akka.remote.testconductor
 
RoleName$() - Constructor for class akka.remote.testconductor.RoleName$
 
roleOption(String) - Method in class akka.contrib.pattern.ClusterReceptionist.Internal$
 
roleOption(String) - Method in class akka.contrib.pattern.DistributedPubSubMediator.Internal$
 
Roles() - Method in class akka.cluster.ClusterSettings
 
roles() - Method in class akka.cluster.InternalClusterAction.Join
 
roles() - Method in class akka.cluster.Member
 
roles() - Method in class akka.remote.testkit.MultiNodeConfig
 
roles() - Method in class akka.remote.testkit.MultiNodeSpec
All registered roles
ROLES_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Join
 
ROLESINDEXES_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
roll(int, List<QItem>, Iterable<QItem>) - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
root() - Method in interface akka.actor.ActorPath
Walk up the tree to obtain and return the RootActorPath.
root() - Method in class akka.actor.ChildActorPath
 
root() - Method in class akka.actor.RootActorPath
 
root() - Method in class akka.dispatch.CachingConfig
 
root() - Method in class akka.event.slf4j.Logger$
Returns the SLF4J Root Logger
root() - Static method in class akka.event.slf4j.Logger
Returns the SLF4J Root Logger
root() - Method in class akka.util.SubclassifiedIndex.Nonroot
 
root() - Method in class akka.util.SubclassifiedIndex
 
RootActorPath - Class in akka.actor
Root of the hierarchy of ActorPaths.
RootActorPath(Address, String) - Constructor for class akka.actor.RootActorPath
 
RootActorPath$ - Class in akka.actor
 
RootActorPath$() - Constructor for class akka.actor.RootActorPath$
 
rootGuardian() - Method in interface akka.actor.ActorRefProvider
Reference to the supervisor of guardian and systemGuardian; this is exposed so that the ActorSystemImpl can use it as lookupRoot, i.e.
rootGuardian() - Method in class akka.actor.LocalActorRefProvider
 
rootGuardian() - Method in class akka.remote.RemoteActorRefProvider
 
rootGuardianAt(Address) - Method in interface akka.actor.ActorRefProvider
Reference to the supervisor of guardian and systemGuardian at the specified address; this is exposed so that the ActorRefFactory can use it as lookupRoot, i.e.
rootGuardianAt(Address) - Method in class akka.actor.LocalActorRefProvider
 
rootGuardianAt(Address) - Method in class akka.remote.RemoteActorRefProvider
 
rootGuardianStrategy() - Method in class akka.actor.LocalActorRefProvider
Overridable supervision strategy to be used by the &ldquo;/user&rdquo; guardian.
rootPath() - Method in interface akka.actor.ActorRefProvider
The root path for all actors within this actor system, not including any remote address information.
rootPath() - Method in class akka.actor.LocalActorRefProvider
 
rootPath() - Method in class akka.remote.RemoteActorRefProvider
 
RoundRobinGroup - Class in akka.routing
A router group that uses round-robin to select a routee.
RoundRobinGroup(Iterable<String>, String) - Constructor for class akka.routing.RoundRobinGroup
 
RoundRobinGroup(com.typesafe.config.Config) - Constructor for class akka.routing.RoundRobinGroup
 
RoundRobinGroup$ - Class in akka.routing
 
RoundRobinGroup$() - Constructor for class akka.routing.RoundRobinGroup$
 
RoundRobinPool - Class in akka.routing
A router pool that uses round-robin to select a routee.
RoundRobinPool(int, Option<Resizer>, SupervisorStrategy, String, boolean) - Constructor for class akka.routing.RoundRobinPool
 
RoundRobinPool(com.typesafe.config.Config) - Constructor for class akka.routing.RoundRobinPool
 
RoundRobinPool$ - Class in akka.routing
 
RoundRobinPool$() - Constructor for class akka.routing.RoundRobinPool$
 
RoundRobinRouter - Class in akka.routing
 
RoundRobinRouter(int, Iterable<String>, Option<Resizer>, String, SupervisorStrategy) - Constructor for class akka.routing.RoundRobinRouter
 
RoundRobinRouter(int) - Constructor for class akka.routing.RoundRobinRouter
Java API: Constructor that sets nrOfInstances to be created.
RoundRobinRouter(Iterable<String>) - Constructor for class akka.routing.RoundRobinRouter
Java API: Constructor that sets the routees to be used.
RoundRobinRouter(Resizer) - Constructor for class akka.routing.RoundRobinRouter
Java API: Constructor that sets the resizer to be used.
RoundRobinRouter$ - Class in akka.routing
 
RoundRobinRouter$() - Constructor for class akka.routing.RoundRobinRouter$
 
RoundRobinRoutingLogic - Class in akka.routing
Uses round-robin to select a routee.
RoundRobinRoutingLogic() - Constructor for class akka.routing.RoundRobinRoutingLogic
 
RoundRobinRoutingLogic$ - Class in akka.routing
 
RoundRobinRoutingLogic$() - Constructor for class akka.routing.RoundRobinRoutingLogic$
 
route(Object, ActorRef) - Method in class akka.routing.Router
Send the message to the destination Routee selected by the RoutingLogic.
RoutedActorCell - Class in akka.routing
INTERNAL API
RoutedActorCell(ActorSystemImpl, InternalActorRef, Props, MessageDispatcher, Props, InternalActorRef) - Constructor for class akka.routing.RoutedActorCell
 
RoutedActorCell$ - Class in akka.routing
INTERNAL API
RoutedActorCell$() - Constructor for class akka.routing.RoutedActorCell$
 
RoutedActorCell.RouterActorCreator - Class in akka.routing
 
RoutedActorCell.RouterActorCreator(RouterConfig) - Constructor for class akka.routing.RoutedActorCell.RouterActorCreator
 
RoutedActorRef - Class in akka.routing
INTERNAL API
RoutedActorRef(ActorSystemImpl, Props, MessageDispatcher, MailboxType, Props, InternalActorRef, ActorPath) - Constructor for class akka.routing.RoutedActorRef
 
routee() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Internal$.ValueHolder
 
routee() - Method in class akka.routing.AddRoutee
 
routee() - Method in class akka.routing.ConsistentRoutee
 
routee() - Method in class akka.routing.RemoveRoutee
 
Routee - Interface in akka.routing
Abstraction of a destination for messages routed via a Router.
routeeFor(String, ActorContext) - Method in interface akka.routing.Group
INTERNAL API
routeeProps() - Method in class akka.routing.RoutedActorCell
 
routees() - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
 
routees() - Method in class akka.routing.BroadcastRouter
 
routees() - Method in class akka.routing.ConsistentHashingRouter
 
routees() - Method in class akka.routing.RandomRouter
 
routees() - Method in class akka.routing.RoundRobinRouter
 
Routees - Class in akka.routing
Message used to carry information about what routees the router is currently using.
Routees(IndexedSeq<Routee>) - Constructor for class akka.routing.Routees
 
routees() - Method in class akka.routing.Routees
 
routees() - Method in class akka.routing.Router
 
routees() - Method in class akka.routing.RouterRoutees
 
routees() - Method in class akka.routing.ScatterGatherFirstCompletedRoutees
 
routees() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
routees() - Method in class akka.routing.SeveralRoutees
 
routees() - Method in class akka.routing.SmallestMailboxRouter
 
routees() - Method in class akka.routing.TailChoppingRoutees
 
Routees$ - Class in akka.routing
 
Routees$() - Constructor for class akka.routing.Routees$
 
routeesPath() - Method in class akka.cluster.routing.ClusterRouterSettings
 
routeesPaths() - Method in class akka.cluster.routing.ClusterRouterGroupSettings
 
router() - Method in class akka.routing.RoutedActorCell
 
Router - Class in akka.routing
For each message that is sent through the router via the Router.route(java.lang.Object, akka.actor.ActorRef) method the RoutingLogic decides to which Routee to send the message.
Router(RoutingLogic, IndexedSeq<Routee>) - Constructor for class akka.routing.Router
 
Router(RoutingLogic) - Constructor for class akka.routing.Router
Java API
Router(RoutingLogic, Iterable<Routee>) - Constructor for class akka.routing.Router
Java API
Router$ - Class in akka.routing
 
Router$() - Constructor for class akka.routing.Router$
 
RouterActor - Class in akka.routing
INTERNAL API
RouterActor() - Constructor for class akka.routing.RouterActor
 
routerConfig() - Method in class akka.actor.Deploy
 
routerConfig() - Method in class akka.actor.Props
Convenience method for extracting the router configuration from the contained Deploy instance.
routerConfig() - Method in class akka.routing.RoutedActorCell
 
RouterConfig - Interface in akka.routing
This trait represents a router factory: it produces the actual router actor and creates the routing table (a function which determines the recipients for each message which is to be dispatched).
ROUTERCONFIG_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DeployData
 
routerDispatcher() - Method in class akka.cluster.routing.AdaptiveLoadBalancingGroup
 
routerDispatcher() - Method in class akka.cluster.routing.AdaptiveLoadBalancingPool
 
routerDispatcher() - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
 
routerDispatcher() - Method in interface akka.cluster.routing.ClusterRouterConfigBase
 
routerDispatcher() - Method in class akka.remote.routing.RemoteRouterConfig
 
routerDispatcher() - Method in class akka.routing.BalancingPool
 
routerDispatcher() - Method in class akka.routing.BroadcastGroup
 
routerDispatcher() - Method in class akka.routing.BroadcastPool
 
routerDispatcher() - Method in class akka.routing.BroadcastRouter
 
routerDispatcher() - Method in class akka.routing.ConsistentHashingGroup
 
routerDispatcher() - Method in class akka.routing.ConsistentHashingPool
 
routerDispatcher() - Method in class akka.routing.ConsistentHashingRouter
 
routerDispatcher() - Method in class akka.routing.CustomRouterConfig
 
routerDispatcher() - Method in class akka.routing.FromConfig
 
routerDispatcher() - Method in class akka.routing.NoRouter$
 
routerDispatcher() - Static method in class akka.routing.NoRouter
 
routerDispatcher() - Method in class akka.routing.RandomGroup
 
routerDispatcher() - Method in class akka.routing.RandomPool
 
routerDispatcher() - Method in class akka.routing.RandomRouter
 
routerDispatcher() - Method in class akka.routing.RoundRobinGroup
 
routerDispatcher() - Method in class akka.routing.RoundRobinPool
 
routerDispatcher() - Method in class akka.routing.RoundRobinRouter
 
routerDispatcher() - Method in interface akka.routing.RouterConfig
Dispatcher ID to use for running the &ldquo;head&rdquo; actor, which handles supervision, death watch and router management messages
routerDispatcher() - Method in class akka.routing.ScatterGatherFirstCompletedGroup
 
routerDispatcher() - Method in class akka.routing.ScatterGatherFirstCompletedPool
 
routerDispatcher() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
routerDispatcher() - Method in class akka.routing.SmallestMailboxPool
 
routerDispatcher() - Method in class akka.routing.SmallestMailboxRouter
 
routerDispatcher() - Method in class akka.routing.TailChoppingGroup
 
routerDispatcher() - Method in class akka.routing.TailChoppingPool
 
RouterEnvelope - Interface in akka.routing
Only the contained message will be forwarded to the destination, i.e.
routeResponse(Object) - Method in class akka.camel.javaapi.UntypedProducerActor
 
routeResponse(Object) - Method in interface akka.camel.ProducerSupport
Called after a response was received from the endpoint specified by endpointUri.
RouterManagementMesssage - Interface in akka.routing
INTERNAL API
RouterPoolActor - Class in akka.routing
INTERNAL API
RouterPoolActor(SupervisorStrategy) - Constructor for class akka.routing.RouterPoolActor
 
RouterRoutees - Class in akka.routing
Message used to carry information about what routees the router is currently using.
RouterRoutees(IndexedSeq<ActorRef>) - Constructor for class akka.routing.RouterRoutees
 
RouterRoutees$ - Class in akka.routing
 
RouterRoutees$() - Constructor for class akka.routing.RouterRoutees$
 
routerTypeMapping() - Method in class akka.actor.Deployer
 
RoutingLogic - Interface in akka.routing
The interface of the routing logic that is used in a Router to select destination routed messages.
routingLogicController(RoutingLogic) - Method in class akka.cluster.routing.AdaptiveLoadBalancingGroup
 
routingLogicController(RoutingLogic) - Method in class akka.cluster.routing.AdaptiveLoadBalancingPool
 
routingLogicController(RoutingLogic) - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
 
routingLogicController(RoutingLogic) - Method in interface akka.cluster.routing.ClusterRouterConfigBase
 
routingLogicController() - Method in class akka.routing.RouterActor
 
routingLogicController(RoutingLogic) - Method in interface akka.routing.RouterConfig
Possibility to define an actor for controlling the routing logic from external stimuli (e.g.
run() - Method in class akka.actor.ActorSystemImpl.TerminationCallbacks
 
run() - Method in class akka.actor.LightArrayRevolverScheduler.TaskHolder
 
run() - Method in class akka.dispatch.BatchingExecutor.Batch
 
run() - Method in class akka.dispatch.BatchingExecutor.BlockableBatch
 
run() - Method in class akka.dispatch.Mailbox
 
run() - Method in class akka.dispatch.TaskInvocation
 
run() - Method in class akka.io.TcpConnection.PendingWriteFile
 
run() - Method in class akka.testkit.JavaTestKit.EventFilter
 
run() - Method in class akka.testkit.JavaTestKit.Within
 
run(ActorRef, Object) - Method in class akka.testkit.TestActor.AutoPilot
 
run(ActorRef, Object) - Method in class akka.testkit.TestActor.KeepRunning$
 
run(ActorRef, Object) - Method in class akka.testkit.TestActor.NoAutoPilot$
 
run() - Method in class akka.util.SerializedSuspendableExecutionContext
 
runnable() - Method in class akka.dispatch.TaskInvocation
 
runningOp() - Method in class akka.remote.testconductor.ClientFSM.Data
 
runOn(Seq<RoleName>, Function0<BoxedUnit>) - Method in class akka.remote.testkit.MultiNodeSpec
Execute the given block of code only on the given nodes (names according to the roleMap).
runReceive(PartialFunction<Object, BoxedUnit>, Persistent) - Method in interface akka.persistence.PersistentView
INTERNAL API WARNING: This implementation UNWRAPS PERSISTENT() before delivering to the receive block.
runReceive(PartialFunction<Object, BoxedUnit>, Persistent) - Method in interface akka.persistence.Recovery
INTERNAL API.

S

safeLongToInt(long) - Method in interface akka.persistence.journal.inmem.InmemMessages
 
safeShutdownOutput() - Method in class akka.io.TcpConnection
 
Same() - Method in class akka.cluster.ClusterCoreDaemon
 
sameAs(Metric) - Method in class akka.cluster.Metric
Returns true if that is tracking the same metric as this.
sameAs(NodeMetrics) - Method in class akka.cluster.NodeMetrics
Returns true if that address is the same as this
sameCount() - Method in class akka.cluster.GossipStats
 
sample() - Method in class akka.cluster.JmxMetricsCollector
Samples and collects new data points.
sample() - Method in interface akka.cluster.MetricsCollector
Samples and collects new data points.
SaneRejectedExecutionHandler - Class in akka.dispatch
The RejectedExecutionHandler used by Akka, it improves on CallerRunsPolicy by throwing a RejectedExecutionException if the executor isShutdown.
SaneRejectedExecutionHandler() - Constructor for class akka.dispatch.SaneRejectedExecutionHandler
 
satisfiesRole(Set<String>) - Method in interface akka.cluster.routing.ClusterRouterActor
 
save(SnapshotMetadata, Object) - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
 
saveAsync(SnapshotMetadata, Object) - Method in class akka.persistence.snapshot.japi.SnapshotStore
 
saveAsync(SnapshotMetadata, Object) - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
 
saveAsync(SnapshotMetadata, Object) - Method in interface akka.persistence.snapshot.SnapshotStore
Plugin API: asynchronously saves a snapshot.
saved(SnapshotMetadata) - Method in class akka.persistence.snapshot.japi.SnapshotStore
 
saved(SnapshotMetadata) - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
 
saved(SnapshotMetadata) - Method in interface akka.persistence.snapshot.SnapshotStore
Plugin API: called after successful saving of a snapshot.
saveSnapshot(Object) - Method in interface akka.persistence.Snapshotter
Saves a snapshot of this snapshotter's state.
SaveSnapshotFailure - Class in akka.persistence
Sent to a PersistentActor after failed saving of a snapshot.
SaveSnapshotFailure(SnapshotMetadata, Throwable) - Constructor for class akka.persistence.SaveSnapshotFailure
 
SaveSnapshotFailure$ - Class in akka.persistence
 
SaveSnapshotFailure$() - Constructor for class akka.persistence.SaveSnapshotFailure$
 
SaveSnapshotSuccess - Class in akka.persistence
Sent to a PersistentActor after successful saving of a snapshot.
SaveSnapshotSuccess(SnapshotMetadata) - Constructor for class akka.persistence.SaveSnapshotSuccess
 
SaveSnapshotSuccess$ - Class in akka.persistence
 
SaveSnapshotSuccess$() - Constructor for class akka.persistence.SaveSnapshotSuccess$
 
saveState() - Method in class akka.remote.EndpointReader
 
scala2JavaOption(Option<A>) - Method in class akka.japi.Option$
 
scala2JavaOption(Option<A>) - Static method in class akka.japi.Option
 
ScalaActorRef - Interface in akka.actor
This trait represents the Scala Actor API There are implicit conversions in ../actor/Implicits.scala from ActorRef -> ScalaActorRef and back
ScalaActorSelection - Interface in akka.actor
Contains the Scala API (!-method) for ActorSelections) which provides automatic tracking of the sender, as per the usual implicit ActorRef pattern.
scaledPoolSize(int, double, int) - Method in class akka.dispatch.ThreadPoolConfig$
 
scaledPoolSize(int, double, int) - Static method in class akka.dispatch.ThreadPoolConfig
 
ScanningClassification - Interface in akka.event
Maps Classifiers to Subscribers and selects which Subscriber should receive which publication through scanning through all Subscribers through the matches(classifier, event) method
ScanningEventBus<E,S,C> - Class in akka.event.japi
See documentation for ScanningClassification E is the Event type S is the Subscriber type C is the Classifier type
ScanningEventBus() - Constructor for class akka.event.japi.ScanningEventBus
 
ScatterGatherFirstCompletedGroup - Class in akka.routing
A router group that broadcasts the message to all routees, and replies with the first response.
ScatterGatherFirstCompletedGroup(Iterable<String>, FiniteDuration, String) - Constructor for class akka.routing.ScatterGatherFirstCompletedGroup
 
ScatterGatherFirstCompletedGroup(com.typesafe.config.Config) - Constructor for class akka.routing.ScatterGatherFirstCompletedGroup
 
ScatterGatherFirstCompletedGroup(Iterable<String>, FiniteDuration) - Constructor for class akka.routing.ScatterGatherFirstCompletedGroup
Java API
ScatterGatherFirstCompletedGroup$ - Class in akka.routing
 
ScatterGatherFirstCompletedGroup$() - Constructor for class akka.routing.ScatterGatherFirstCompletedGroup$
 
ScatterGatherFirstCompletedPool - Class in akka.routing
A router pool that broadcasts the message to all routees, and replies with the first response.
ScatterGatherFirstCompletedPool(int, Option<Resizer>, FiniteDuration, SupervisorStrategy, String, boolean) - Constructor for class akka.routing.ScatterGatherFirstCompletedPool
 
ScatterGatherFirstCompletedPool(com.typesafe.config.Config) - Constructor for class akka.routing.ScatterGatherFirstCompletedPool
 
ScatterGatherFirstCompletedPool(int, FiniteDuration) - Constructor for class akka.routing.ScatterGatherFirstCompletedPool
Java API
ScatterGatherFirstCompletedPool$ - Class in akka.routing
 
ScatterGatherFirstCompletedPool$() - Constructor for class akka.routing.ScatterGatherFirstCompletedPool$
 
ScatterGatherFirstCompletedRoutees - Class in akka.routing
INTERNAL API
ScatterGatherFirstCompletedRoutees(IndexedSeq<Routee>, FiniteDuration) - Constructor for class akka.routing.ScatterGatherFirstCompletedRoutees
 
ScatterGatherFirstCompletedRoutees$ - Class in akka.routing
 
ScatterGatherFirstCompletedRoutees$() - Constructor for class akka.routing.ScatterGatherFirstCompletedRoutees$
 
ScatterGatherFirstCompletedRouter - Class in akka.routing
 
ScatterGatherFirstCompletedRouter(int, Iterable<String>, FiniteDuration, Option<Resizer>, String, SupervisorStrategy) - Constructor for class akka.routing.ScatterGatherFirstCompletedRouter
 
ScatterGatherFirstCompletedRouter(int, FiniteDuration) - Constructor for class akka.routing.ScatterGatherFirstCompletedRouter
Java API: Constructor that sets nrOfInstances to be created.
ScatterGatherFirstCompletedRouter(Iterable<String>, FiniteDuration) - Constructor for class akka.routing.ScatterGatherFirstCompletedRouter
Java API: Constructor that sets the routees to be used.
ScatterGatherFirstCompletedRouter(Resizer, FiniteDuration) - Constructor for class akka.routing.ScatterGatherFirstCompletedRouter
Java API: Constructor that sets the resizer to be used.
ScatterGatherFirstCompletedRouter$ - Class in akka.routing
 
ScatterGatherFirstCompletedRouter$() - Constructor for class akka.routing.ScatterGatherFirstCompletedRouter$
 
ScatterGatherFirstCompletedRoutingLogic - Class in akka.routing
Broadcasts the message to all routees, and replies with the first response.
ScatterGatherFirstCompletedRoutingLogic(FiniteDuration) - Constructor for class akka.routing.ScatterGatherFirstCompletedRoutingLogic
 
ScatterGatherFirstCompletedRoutingLogic$ - Class in akka.routing
 
ScatterGatherFirstCompletedRoutingLogic$() - Constructor for class akka.routing.ScatterGatherFirstCompletedRoutingLogic$
 
schedule(FiniteDuration, FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.AbstractScheduler
Schedules a function to be run repeatedly with an initial delay and a frequency.
schedule(ActorRef, FiniteDuration) - Method in class akka.actor.FSM.Timer
 
schedule(FiniteDuration, FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.LightArrayRevolverScheduler
 
schedule(FiniteDuration, FiniteDuration, ActorRef, Object, ExecutionContext, ActorRef) - Method in interface akka.actor.Scheduler
Schedules a message to be sent repeatedly with an initial delay and frequency.
schedule(FiniteDuration, FiniteDuration, Function0<BoxedUnit>, ExecutionContext) - Method in interface akka.actor.Scheduler
Schedules a function to be run repeatedly with an initial delay and a frequency.
schedule(FiniteDuration, FiniteDuration, Runnable, ExecutionContext) - Method in interface akka.actor.Scheduler
Schedules a function to be run repeatedly with an initial delay and a frequency.
schedule() - Method in interface akka.persistence.PersistentView
 
schedule() - Method in interface akka.persistence.View
 
scheduleBackoffTimer() - Method in class akka.remote.EndpointWriter
 
Scheduled() - Method in class akka.dispatch.Mailbox$
 
Scheduled() - Static method in class akka.dispatch.Mailbox
 
SCHEDULED() - Method in class akka.dispatch.MessageDispatcher$
 
SCHEDULED() - Static method in class akka.dispatch.MessageDispatcher
 
scheduleDequeue(FiniteDuration) - Method in class akka.remote.transport.ThrottledAssociation
 
scheduledUnreachable() - Method in class akka.cluster.AutoDownBase
 
scheduleOnce(FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.AbstractScheduler
Schedules a Runnable to be run once with a delay, i.e.
scheduleOnce(FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.LightArrayRevolverScheduler
 
scheduleOnce(FiniteDuration, ActorRef, Object, ExecutionContext, ActorRef) - Method in interface akka.actor.Scheduler
Schedules a message to be sent once with a delay, i.e.
scheduleOnce(FiniteDuration, Function0<BoxedUnit>, ExecutionContext) - Method in interface akka.actor.Scheduler
Schedules a function to be run once with a delay, i.e.
scheduleOnce(FiniteDuration, Runnable, ExecutionContext) - Method in interface akka.actor.Scheduler
Schedules a Runnable to be run once with a delay, i.e.
scheduler() - Method in class akka.actor.ActorSystem
Light-weight scheduler for running asynchronous tasks after some deadline in the future.
scheduler() - Method in class akka.actor.ActorSystemImpl
 
Scheduler - Interface in akka.actor
An Akka scheduler service.
scheduler() - Method in class akka.cluster.AutoDown
 
scheduler() - Method in class akka.cluster.AutoDownBase
 
scheduler() - Method in class akka.cluster.Cluster
INTERNAL API
scheduler() - Method in class akka.dispatch.DefaultDispatcherPrerequisites
 
scheduler() - Method in interface akka.dispatch.DispatcherPrerequisites
 
scheduler() - Method in class akka.remote.RemoteWatcher
 
scheduler() - Method in class akka.routing.TailChoppingRoutees
 
scheduler() - Method in class akka.routing.TailChoppingRoutingLogic
 
SchedulerClass() - Method in class akka.actor.ActorSystem.Settings
 
scheduleReconnectTick() - Method in class akka.contrib.pattern.ReliableProxy
 
scheduleRefreshContactsTick(FiniteDuration) - Method in class akka.contrib.pattern.ClusterClient
 
SchedulerException - Exception in akka.actor
This exception is thrown by Scheduler.schedule* when scheduling is not possible, e.g.
SchedulerException(String) - Constructor for exception akka.actor.SchedulerException
 
SchedulerException$ - Class in akka.actor
 
SchedulerException$() - Constructor for class akka.actor.SchedulerException$
 
SchedulerTickDuration() - Method in class akka.cluster.ClusterSettings
 
SchedulerTicksPerWheel() - Method in class akka.cluster.ClusterSettings
 
scheduleTick() - Method in class akka.contrib.pattern.ReliableProxy
 
scheduleUnreachable(UniqueAddress) - Method in class akka.cluster.AutoDownBase
 
SchemeAugmenter - Interface in akka.remote.transport
 
schemeIdentifier() - Method in class akka.remote.transport.AbstractTransportAdapter
 
schemeIdentifier() - Method in class akka.remote.transport.netty.NettyTransport
 
schemeIdentifier() - Method in class akka.remote.transport.TestTransport
 
SchemeIdentifier() - Method in class akka.remote.transport.ThrottlerTransportAdapter$
 
SchemeIdentifier() - Static method in class akka.remote.transport.ThrottlerTransportAdapter
 
schemeIdentifier() - Method in interface akka.remote.transport.Transport
Returns a string that will be used as the scheme part of the URLs corresponding to this transport
scope() - Method in class akka.actor.Deploy
 
Scope - Interface in akka.actor
The scope of a Deploy serves two purposes: as a marker for pattern matching the &ldquo;scope&rdquo; (i.e.
SCOPE_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DeployData
 
second() - Method in class akka.japi.Pair
 
SecureCookie() - Method in class akka.remote.transport.AkkaProtocolSettings
 
SEED() - Method in class akka.util.HashCode$
 
SEED() - Static method in class akka.util.HashCode
 
Seed128() - Method in class akka.remote.security.provider.SeedSize$
 
Seed128() - Static method in class akka.remote.security.provider.SeedSize
 
Seed192() - Method in class akka.remote.security.provider.SeedSize$
 
Seed192() - Static method in class akka.remote.security.provider.SeedSize
 
Seed256() - Method in class akka.remote.security.provider.SeedSize$
 
Seed256() - Static method in class akka.remote.security.provider.SeedSize
 
seedNodeProcess() - Method in class akka.cluster.ClusterCoreDaemon
 
seedNodeProcessCounter() - Method in class akka.cluster.ClusterCoreDaemon
 
SeedNodes() - Method in class akka.cluster.ClusterSettings
 
seedNodes() - Method in class akka.cluster.InternalClusterAction.JoinSeedNodes
 
SeedNodeTimeout() - Method in class akka.cluster.ClusterSettings
 
SeedSize - Class in akka.remote.security.provider
INTERNAL API From AESCounterRNG API docs: Valid values are 16 (128 bits), 24 (192 bits) and 32 (256 bits).
SeedSize() - Constructor for class akka.remote.security.provider.SeedSize
 
SeedSize$ - Class in akka.remote.security.provider
INTERNAL API From AESCounterRNG API docs: Valid values are 16 (128 bits), 24 (192 bits) and 32 (256 bits).
SeedSize$() - Constructor for class akka.remote.security.provider.SeedSize$
 
seen(UniqueAddress) - Method in class akka.cluster.Gossip
Marks the gossip as seen by this node (address) by updating the address entry in the 'gossip.overview.seen'
seen() - Method in class akka.cluster.GossipOverview
 
SEEN_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
 
seenBy() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
 
seenBy() - Method in class akka.cluster.ClusterEvent.SeenChanged
 
seenBy() - Method in class akka.cluster.ClusterReadView
INTERNAL API The nodes that has seen current version of the Gossip.
seenBy() - Method in class akka.cluster.Gossip
The nodes that have seen the current version of the Gossip.
seenByNode(UniqueAddress) - Method in class akka.cluster.Gossip
Has this Gossip been seen by this node.
seenLatest() - Method in class akka.cluster.VectorClockStats
 
select(FiniteDuration, PartialFunction<Object, T>) - Method in class akka.actor.dsl.Inbox.Inbox
Receive a single message for which the given partial function is defined and return the transformed result, using the internal receiver actor.
select(Object, IndexedSeq<Routee>) - Method in class akka.cluster.routing.AdaptiveLoadBalancingRoutingLogic
 
select(Object, IndexedSeq<Routee>) - Method in class akka.routing.BalancingRoutingLogic
 
select(Object, IndexedSeq<Routee>) - Method in class akka.routing.BroadcastRoutingLogic
 
select(Object, IndexedSeq<Routee>) - Method in class akka.routing.ConsistentHashingRoutingLogic
 
select(Object, IndexedSeq<Routee>) - Method in class akka.routing.RandomRoutingLogic
 
select(Object, IndexedSeq<Routee>) - Method in class akka.routing.RoundRobinRoutingLogic
 
select(Object, IndexedSeq<Routee>) - Method in interface akka.routing.RoutingLogic
Pick the destination for a given message.
select(Object, IndexedSeq<Routee>) - Method in class akka.routing.ScatterGatherFirstCompletedRoutingLogic
 
select(Object, IndexedSeq<Routee>) - Method in class akka.routing.SmallestMailboxRoutingLogic
 
select(Object, IndexedSeq<Routee>) - Method in class akka.routing.TailChoppingRoutingLogic
 
SelectChildName - Class in akka.actor
INTERNAL API
SelectChildName(String) - Constructor for class akka.actor.SelectChildName
 
SelectChildName$ - Class in akka.actor
 
SelectChildName$() - Constructor for class akka.actor.SelectChildName$
 
SelectChildPattern - Class in akka.actor
INTERNAL API
SelectChildPattern(String) - Constructor for class akka.actor.SelectChildPattern
 
SelectChildPattern$ - Class in akka.actor
 
SelectChildPattern$() - Constructor for class akka.actor.SelectChildPattern$
 
selectDeploymentTarget() - Method in class akka.cluster.routing.ClusterRouterGroupActor
 
selectDeploymentTarget() - Method in class akka.cluster.routing.ClusterRouterPoolActor
 
SelectedSnapshot - Class in akka.persistence
Plugin API: a selected snapshot matching SnapshotSelectionCriteria.
SelectedSnapshot(SnapshotMetadata, Object) - Constructor for class akka.persistence.SelectedSnapshot
 
SelectedSnapshot$ - Class in akka.persistence
 
SelectedSnapshot$() - Constructor for class akka.persistence.SelectedSnapshot$
 
selection() - Method in exception akka.actor.ActorNotFound
 
selection() - Method in class akka.routing.ActorSelectionRoutee
 
SelectionHandler - Class in akka.io
 
SelectionHandler(SelectionHandlerSettings) - Constructor for class akka.io.SelectionHandler
 
SelectionHandler$ - Class in akka.io
 
SelectionHandler$() - Constructor for class akka.io.SelectionHandler$
 
SelectionHandler.ChannelAcceptable$ - Class in akka.io
 
SelectionHandler.ChannelAcceptable$() - Constructor for class akka.io.SelectionHandler.ChannelAcceptable$
 
SelectionHandler.ChannelConnectable$ - Class in akka.io
 
SelectionHandler.ChannelConnectable$() - Constructor for class akka.io.SelectionHandler.ChannelConnectable$
 
SelectionHandler.ChannelReadable$ - Class in akka.io
 
SelectionHandler.ChannelReadable$() - Constructor for class akka.io.SelectionHandler.ChannelReadable$
 
SelectionHandler.ChannelWritable$ - Class in akka.io
 
SelectionHandler.ChannelWritable$() - Constructor for class akka.io.SelectionHandler.ChannelWritable$
 
SelectionHandler.HasFailureMessage - Interface in akka.io
 
SelectionHandler.Retry - Class in akka.io
 
SelectionHandler.Retry(SelectionHandler.WorkerForCommand, int) - Constructor for class akka.io.SelectionHandler.Retry
 
SelectionHandler.Retry$ - Class in akka.io
 
SelectionHandler.Retry$() - Constructor for class akka.io.SelectionHandler.Retry$
 
SelectionHandler.SelectorBasedManager - Class in akka.io
 
SelectionHandler.SelectorBasedManager(SelectionHandlerSettings, int) - Constructor for class akka.io.SelectionHandler.SelectorBasedManager
 
SelectionHandler.WorkerForCommand - Class in akka.io
 
SelectionHandler.WorkerForCommand(SelectionHandler.HasFailureMessage, ActorRef, Function1<ChannelRegistry, Props>) - Constructor for class akka.io.SelectionHandler.WorkerForCommand
 
SelectionHandler.WorkerForCommand$ - Class in akka.io
 
SelectionHandler.WorkerForCommand$() - Constructor for class akka.io.SelectionHandler.WorkerForCommand$
 
SelectionHandlerSettings - Class in akka.io
 
SelectionHandlerSettings(com.typesafe.config.Config) - Constructor for class akka.io.SelectionHandlerSettings
 
SelectionPathElement - Interface in akka.actor
INTERNAL API
selector() - Method in class akka.io.UdpListener
 
SelectorAssociationRetries() - Method in class akka.io.SelectionHandlerSettings
 
SelectorDispatcher() - Method in class akka.io.SelectionHandlerSettings
 
selectorPool() - Method in class akka.io.SelectionHandler.SelectorBasedManager
 
selectors() - Method in class akka.cluster.routing.MixMetricsSelector
 
SelectParent - Class in akka.actor
INTERNAL API
SelectParent() - Constructor for class akka.actor.SelectParent
 
SelectParent$ - Class in akka.actor
INTERNAL API
SelectParent$() - Constructor for class akka.actor.SelectParent$
 
selectRandomNode(IndexedSeq<UniqueAddress>) - Method in class akka.cluster.ClusterCoreDaemon
 
selectRandomNode(IndexedSeq<Address>) - Method in class akka.cluster.ClusterMetricsCollector
 
selectRandomNode(IndexedSeq<Address>) - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
self() - Method in interface akka.actor.Actor
The 'self' field holds the ActorRef for this actor.
self() - Method in class akka.actor.ActorCell
 
self() - Method in interface akka.actor.ActorContext
 
self() - Method in interface akka.actor.Cell
The &ldquo;self&rdquo; reference which this Cell is attached to.
self() - Method in interface akka.actor.StashSupport
INTERNAL API.
self() - Method in class akka.actor.TypedActor$
Returns the reference to the proxy when called inside a method call in a TypedActor
self() - Static method in class akka.actor.TypedActor
Returns the reference to the proxy when called inside a method call in a TypedActor
self() - Method in class akka.actor.UnstartedCell
 
self() - Method in class akka.cluster.ClusterReadView
 
self() - Method in class akka.testkit.CallingThreadMailbox
 
self() - Method in interface akka.testkit.ImplicitSender
 
selfAddress() - Method in class akka.cluster.AutoDown
 
selfAddress() - Method in class akka.cluster.AutoDownBase
 
selfAddress() - Method in class akka.cluster.Cluster
The address of this cluster member.
selfAddress() - Method in class akka.cluster.ClusterHeartbeatSenderState
 
selfAddress() - Method in class akka.cluster.ClusterReadView
 
selfAddress() - Method in class akka.cluster.FirstSeedNodeProcess
 
selfAddress() - Method in class akka.cluster.HeartbeatNodeRing
 
selfAddress() - Method in class akka.cluster.JoinSeedNodeProcess
 
selfAddress() - Method in class akka.routing.ConsistentActorRef
 
selfAddress() - Method in class akka.routing.ConsistentRoutee
 
selfAddressOption() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
selfExited() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
selfHeartbeat() - Method in class akka.cluster.ClusterHeartbeatSender
 
selfHeartbeatRsp() - Method in class akka.cluster.ClusterHeartbeatReceiver
 
selfHeartbeatRspMsg() - Method in class akka.remote.RemoteWatcher
 
selfIndex() - Method in class akka.remote.testkit.MultiNodeSpec$
Index of this node in the roles sequence.
selfIndex() - Static method in class akka.remote.testkit.MultiNodeSpec
Index of this node in the roles sequence.
selfName() - Method in class akka.remote.testkit.MultiNodeSpec$
Name (or IP address; must be resolvable using InetAddress.getByName) of the host this node is running on.
selfName() - Static method in class akka.remote.testkit.MultiNodeSpec
Name (or IP address; must be resolvable using InetAddress.getByName) of the host this node is running on.
selfPort() - Method in class akka.remote.testkit.MultiNodeSpec$
Port number of this node.
selfPort() - Static method in class akka.remote.testkit.MultiNodeSpec
Port number of this node.
selfRoles() - Method in class akka.cluster.Cluster
roles that this member has
selfUniqueAddress() - Method in class akka.cluster.Cluster
The address including a uid of this cluster member.
selfUniqueAddress() - Method in class akka.cluster.ClusterCoreDaemon
 
selfUniqueAddress() - Method in class akka.cluster.ClusterDomainEventPublisher
 
send(ActorRef, Object) - Method in class akka.actor.dsl.Inbox.Inbox
 
send(ActorRef, Object) - Method in class akka.actor.Inbox
Have the internal actor act as the sender of the given message which will be sent to the given target.
send(T) - Method in class akka.agent.Agent
Dispatch a new value for the internal state.
send(Function1<T, T>) - Method in class akka.agent.Agent
Dispatch a function to update the internal state.
send(Object, ActorRef) - Method in class akka.contrib.pattern.ReliableProxy
 
send(ByteString, Object) - Method in class akka.io.UdpConnectedMessage$
This message is understood by the connection actors to send data to their designated destination.
send(ByteString) - Method in class akka.io.UdpConnectedMessage$
Send without requesting acknowledgment.
send(ByteString, Object) - Static method in class akka.io.UdpConnectedMessage
This message is understood by the connection actors to send data to their designated destination.
send(ByteString) - Static method in class akka.io.UdpConnectedMessage
Send without requesting acknowledgment.
send(ByteString, InetSocketAddress, Udp.Event) - Method in class akka.io.UdpMessage$
This message is understood by the &ldquo;simple sender&rdquo; which can be obtained by sending the Udp.SimpleSender query to the UdpExt.manager() as well as by the listener actors which are created in response to Udp.Bind.
send(ByteString, InetSocketAddress) - Method in class akka.io.UdpMessage$
The same as send(payload, target, noAck()).
send(ByteString, InetSocketAddress, Udp.Event) - Static method in class akka.io.UdpMessage
This message is understood by the &ldquo;simple sender&rdquo; which can be obtained by sending the Udp.SimpleSender query to the UdpExt.manager() as well as by the listener actors which are created in response to Udp.Bind.
send(ByteString, InetSocketAddress) - Static method in class akka.io.UdpMessage
The same as send(payload, target, noAck()).
send(long, akka.persistence.AtLeastOnceDelivery.Internal.Delivery, long) - Method in interface akka.persistence.AtLeastOnceDelivery
 
send(Object, Option<ActorRef>, RemoteActorRef) - Method in class akka.remote.RemoteTransport
Sends the given message to the recipient supplying the sender() if any
send(Object, Option<ActorRef>, RemoteActorRef) - Method in class akka.remote.Remoting
 
send(Object, ActorRef) - Method in class akka.routing.ActorRefRoutee
 
send(Object, ActorRef) - Method in class akka.routing.ActorSelectionRoutee
 
send(Object, ActorRef) - Method in class akka.routing.NoRoutee$
 
send(Object, ActorRef) - Static method in class akka.routing.NoRoutee
 
send(Object, ActorRef) - Method in interface akka.routing.Routee
 
send(Object, ActorRef) - Method in class akka.routing.ScatterGatherFirstCompletedRoutees
 
send(Object, ActorRef) - Method in class akka.routing.SeveralRoutees
 
send(Object, ActorRef) - Method in class akka.routing.TailChoppingRoutees
 
send(ActorRef, Object) - Method in class akka.testkit.JavaTestKit
 
send(ActorRef, Object) - Method in class akka.testkit.TestProbe
Send message to an actor while using the probe's TestActor as the sender.
Send - Class in akka.zeromq
Send a message over the zeromq socket param: frames
Send(Seq<ByteString>) - Constructor for class akka.zeromq.Send
 
Send$ - Class in akka.zeromq
 
Send$() - Constructor for class akka.zeromq.Send$
 
Send_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.Direction
Send = 1;
sendBufferedMessages() - Method in class akka.remote.EndpointWriter
 
SendBufferSize() - Method in interface akka.io.Inet.SoForwarders
Inet.SocketOption to set the SO_SNDBUF option.
sendBufferSize(int) - Method in interface akka.io.Inet.SoJavaFactories
Inet.SocketOption to set the SO_SNDBUF option.
SendBufferSize() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
SendBufferSize - Class in akka.zeromq
The SendBufferSize option shall set the underlying kernel transmit buffer size for the socket to the specified size in bytes.
SendBufferSize(long) - Constructor for class akka.zeromq.SendBufferSize
 
sendBufferSize() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its send buffer size configuration.
sendBufferSize() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its send buffer size configuration.
SendBufferSize$ - Class in akka.zeromq
Gets the SendBufferSize
SendBufferSize$() - Constructor for class akka.zeromq.SendBufferSize$
 
sendCurrentClusterState(ActorRef) - Method in class akka.cluster.Cluster
Publish current (full) state of the cluster to the specified receiver.
sender() - Method in interface akka.actor.Actor
The reference sender Actor of the last received message.
sender() - Method in class akka.actor.ActorCell
 
sender() - Method in interface akka.actor.ActorContext
Returns the sender 'ActorRef' of the current message.
sender() - Method in interface akka.actor.AllDeadLetters
 
sender() - Method in class akka.actor.DeadLetter
 
sender() - Method in class akka.actor.SuppressedDeadLetter
 
sender() - Method in class akka.actor.UnhandledMessage
 
sender() - Method in class akka.contrib.pattern.ReliableProxy.Message
 
sender() - Method in class akka.contrib.throttle.TimerBasedThrottler.Message
 
sender() - Method in class akka.dispatch.Envelope
 
sender() - Method in class akka.io.Udp.Received
 
sender() - Method in class akka.persistence.ConfirmablePersistentImpl
 
sender() - Method in class akka.persistence.journal.AsyncWriteJournal.Desequenced
 
sender() - Method in class akka.persistence.NonPersistentRepr
 
sender() - Method in class akka.persistence.PersistentImpl
 
sender() - Method in interface akka.persistence.PersistentRepr
Sender of this message.
sender() - Method in class akka.persistence.ReliableDelivery.DeliveryAttempt
 
sender() - Method in interface akka.persistence.Resequenceable
 
sender() - Method in class akka.remote.transport.TestTransport.WriteAttempt
 
sender() - Method in interface akka.testkit.TestActor.Message
 
sender() - Method in class akka.testkit.TestActor.NullMessage$
 
sender() - Method in class akka.testkit.TestActor.RealMessage
 
sender() - Method in class akka.testkit.TestProbe
Get sender of last received message.
SENDER_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
SENDER_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.RemoteEnvelope
 
senderFromInbox(Inbox.Inbox) - Method in interface akka.actor.dsl.Inbox
 
senderOption() - Method in class akka.remote.EndpointManager.Send
 
senderOption() - Method in class akka.remote.transport.AkkaPduCodec.Message
 
senderProbe() - Method in interface akka.persistence.journal.JournalSpec
 
senderProbe() - Method in interface akka.persistence.snapshot.SnapshotStoreSpec
 
sendGetContacts() - Method in class akka.contrib.pattern.ClusterClient
 
sendGossip(Address, MetricsGossipEnvelope) - Method in class akka.cluster.ClusterMetricsCollector
 
sendGossipTo(Address) - Method in class akka.cluster.ClusterCoreDaemon
 
sendHandlers(ChannelRegistration) - Method in interface akka.io.WithUdpSend
 
sendHeartbeat() - Method in class akka.remote.RemoteWatcher
 
SendHighWatermark - Class in akka.zeromq
The SendHighWatermark option shall set the high water mark for outbound messages on the specified socket.
SendHighWatermark(long) - Constructor for class akka.zeromq.SendHighWatermark
 
sendHighWatermark() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its send high watermark configuration.
sendHighWatermark() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its send high watermark configuration.
SendHighWatermark$ - Class in akka.zeromq
Gets the SendHWM
SendHighWatermark$() - Constructor for class akka.zeromq.SendHighWatermark$
 
sendMessage(Envelope) - Method in interface akka.actor.Cell
Enqueue a message to be sent to the actor; may or may not actually schedule the actor to run, depending on which type of cell it is.
sendMessage(Object, ActorRef) - Method in interface akka.actor.Cell
Enqueue a message to be sent to the actor; may or may not actually schedule the actor to run, depending on which type of cell it is.
sendMessage(Envelope) - Method in interface akka.actor.dungeon.Dispatch
 
sendMessage(Envelope) - Method in class akka.actor.UnstartedCell
 
sendMessage(Envelope) - Method in class akka.routing.ResizablePoolCell
 
sendMessage(Envelope) - Method in class akka.routing.RoutedActorCell
Route the message via the router to the selected destination.
sendOff(Function1<T, T>, ExecutionContext) - Method in class akka.agent.Agent
Dispatch a function to update the internal state but on its own thread.
sendOneMessageToEachGroup() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Publish
 
sendSystemMessage(SystemMessage) - Method in interface akka.actor.Cell
Enqueue a message to be sent to the actor; may or may not actually schedule the actor to run, depending on which type of cell it is.
sendSystemMessage(SystemMessage) - Method in interface akka.actor.dungeon.Dispatch
 
sendSystemMessage(SystemMessage) - Method in class akka.actor.EmptyLocalActorRef
 
sendSystemMessage(SystemMessage) - Method in class akka.actor.InternalActorRef
 
sendSystemMessage(SystemMessage) - Method in class akka.actor.LocalActorRef
 
sendSystemMessage(SystemMessage) - Method in interface akka.actor.MinimalActorRef
 
sendSystemMessage(SystemMessage) - Method in class akka.actor.RepointableActorRef
 
sendSystemMessage(SystemMessage) - Method in class akka.actor.UnstartedCell
 
sendSystemMessage(SystemMessage) - Method in class akka.pattern.PromiseActorRef
 
sendSystemMessage(SystemMessage) - Method in class akka.remote.RemoteActorRef
 
sendSystemMessage(SystemMessage) - Method in class akka.remote.RemoteSystemDaemon
 
SendTo - Class in akka.transactor
Used for specifying actor refs and messages to send to during coordination.
SendTo(ActorRef, Option<Object>) - Constructor for class akka.transactor.SendTo
 
sendTo(Seq<Tuple2<ActorRef, Object>>) - Method in interface akka.transactor.Transactor
Include other actors in this coordinated transaction and specify the message to send by providing ActorRef -> Message pairs.
sendTo(ActorRef) - Method in class akka.transactor.UntypedTransactor
For including another actor in this coordinated transaction and sending them the same message as received.
sendTo(ActorRef, Object) - Method in class akka.transactor.UntypedTransactor
For including another actor in this coordinated transaction and specifying the message to send.
SendTo$ - Class in akka.transactor
 
SendTo$() - Constructor for class akka.transactor.SendTo$
 
seq(T...) - Static method in class akka.japi.JAPI
 
seq() - Method in class akka.remote.EndpointManager.Send
 
seq() - Method in interface akka.remote.HasSequenceNumber
Sequence number of the message
seq() - Method in class akka.remote.transport.AkkaPduCodec.Message
 
SEQ_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.RemoteEnvelope
 
seqCauseDirective2Decider(Iterable<Tuple2<Class<? extends Throwable>, SupervisorStrategy.Directive>>) - Method in interface akka.actor.SupervisorStrategyLowPriorityImplicits
Implicit conversion from Seq of Cause-Directive pairs to a Decider.
seqCounter() - Method in class akka.remote.ReliableDeliverySupervisor
 
SeqNo - Class in akka.remote
 
SeqNo(long) - Constructor for class akka.remote.SeqNo
 
SeqNo$ - Class in akka.remote
 
SeqNo$() - Constructor for class akka.remote.SeqNo$
 
seqOpt() - Method in class akka.remote.EndpointManager.Send
 
seqOption() - Method in class akka.remote.transport.AkkaPduCodec.Message
 
seqOrdering() - Method in class akka.remote.AckedReceiveBuffer
 
seqOrdering() - Method in class akka.remote.HasSequenceNumber$
 
seqThrowable2Decider(Seq<Class<? extends Throwable>>) - Method in class akka.actor.SupervisorStrategy$
Implicit conversion from Seq of Throwables to a Decider.
seqThrowable2Decider(Seq<Class<? extends Throwable>>) - Static method in class akka.actor.SupervisorStrategy
Implicit conversion from Seq of Throwables to a Decider.
sequence(Iterable<Future<A>>, ExecutionContext) - Method in class akka.dispatch.Futures$
Simple version of Futures$.traverse(java.lang.Iterable, akka.japi.Function>, scala.concurrent.ExecutionContext).
sequence(Iterable<Future<A>>, ExecutionContext) - Static method in class akka.dispatch.Futures
Simple version of Futures.traverse(java.lang.Iterable, akka.japi.Function>, scala.concurrent.ExecutionContext).
sequenceNr() - Method in class akka.persistence.ConfirmablePersistentImpl
 
sequenceNr() - Method in class akka.persistence.DeliveredByChannel
 
sequenceNr() - Method in class akka.persistence.DeliveredByPersistentChannel
 
sequenceNr() - Method in class akka.persistence.journal.JournalSpec.Confirmation
 
sequenceNr() - Method in class akka.persistence.journal.leveldb.Key
 
sequenceNr() - Method in class akka.persistence.PersistenceFailure
 
sequenceNr() - Method in class akka.persistence.Persistent
This persistent message's sequence number.
sequenceNr() - Method in interface akka.persistence.PersistentConfirmation
 
sequenceNr() - Method in interface akka.persistence.PersistentId
A persistent message's sequence number.
sequenceNr() - Method in class akka.persistence.PersistentIdImpl
 
sequenceNr() - Method in class akka.persistence.PersistentImpl
 
sequenceNr() - Method in interface akka.persistence.ProcessorImpl
 
sequenceNr() - Method in class akka.persistence.SnapshotMetadata
 
SEQUENCENR_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
ser() - Method in class akka.cluster.GossipEnvelope
 
serial() - Method in class akka.contrib.pattern.ReliableProxy.Message
 
serialization() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
serialization() - Method in class akka.remote.RemoteActorRefProvider
 
serialization() - Method in class akka.remote.serialization.DaemonMsgCreateSerializer
 
Serialization - Class in akka.serialization
Serialization module.
Serialization(ExtendedActorSystem) - Constructor for class akka.serialization.Serialization
 
Serialization$ - Class in akka.serialization
 
Serialization$() - Constructor for class akka.serialization.Serialization$
 
Serialization.Information - Class in akka.serialization
Serialization information needed for serializing local actor refs.
Serialization.Information(Address, ActorSystem) - Constructor for class akka.serialization.Serialization.Information
 
Serialization.Information$ - Class in akka.serialization
 
Serialization.Information$() - Constructor for class akka.serialization.Serialization.Information$
 
Serialization.Settings - Class in akka.serialization
 
Serialization.Settings(com.typesafe.config.Config) - Constructor for class akka.serialization.Serialization.Settings
 
SerializationBindings() - Method in class akka.serialization.Serialization.Settings
 
SerializationExtension - Class in akka.serialization
SerializationExtension is an Akka Extension to interact with the Serialization that is built into Akka
SerializationExtension() - Constructor for class akka.serialization.SerializationExtension
 
SerializationExtension$ - Class in akka.serialization
SerializationExtension is an Akka Extension to interact with the Serialization that is built into Akka
SerializationExtension$() - Constructor for class akka.serialization.SerializationExtension$
 
serialize(Envelope) - Method in interface akka.actor.mailbox.DurableMessageSerialization
Serializes the given Envelope into an Array of Bytes using an efficient serialization/deserialization strategy
serialize(OutputStream, Snapshot) - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
 
serialize(ExtendedActorSystem, Object) - Method in class akka.remote.MessageSerializer$
Uses Akka Serialization for the specified ActorSystem to transform the given message to a MessageProtocol
serialize(ExtendedActorSystem, Object) - Static method in class akka.remote.MessageSerializer
Uses Akka Serialization for the specified ActorSystem to transform the given message to a MessageProtocol
serialize(Object) - Method in class akka.remote.serialization.DaemonMsgCreateSerializer
 
serialize(Object) - Method in class akka.serialization.Serialization
Serializes the given AnyRef/java.lang.Object according to the Serialization configuration to either an Array of Bytes or an Exception if one was thrown.
serializeActorRef(ActorRef) - Method in class akka.remote.serialization.ProtobufSerializer$
Helper to serialize an ActorRef to Akka's protobuf representation.
serializeActorRef(ActorRef) - Static method in class akka.remote.serialization.ProtobufSerializer
Helper to serialize an ActorRef to Akka's protobuf representation.
SerializeAllCreators() - Method in class akka.actor.ActorSystem.Settings
 
SerializeAllMessages() - Method in class akka.actor.ActorSystem.Settings
 
serialized() - Method in class akka.actor.DeadLetterActorRef$
 
serialized() - Static method in class akka.actor.DeadLetterActorRef
 
SERIALIZED_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
Serialized_VALUE - Static variable in enum akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberType
Serialized = 0;
serializedActorPath(ActorRef) - Method in class akka.serialization.Serialization$
The serialized path of an actorRef, based on the current transport serialization information.
serializedActorPath(ActorRef) - Static method in class akka.serialization.Serialization
The serialized path of an actorRef, based on the current transport serialization information.
SerializedActorRef - Class in akka.actor
Memento pattern for serializing ActorRefs transparently INTERNAL API
SerializedActorRef(ActorRef) - Constructor for class akka.actor.SerializedActorRef
 
SerializedActorRef$ - Class in akka.actor
INTERNAL API
SerializedActorRef$() - Constructor for class akka.actor.SerializedActorRef$
 
SERIALIZEDGOSSIP_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
serializedMessage() - Method in class akka.remote.transport.AkkaPduCodec.Message
 
serializedParameters() - Method in class akka.actor.TypedActor.SerializedMethodCall
 
SerializedSuspendableExecutionContext - Class in akka.util
This ExecutionContext allows to wrap an underlying ExecutionContext and provide guaranteed serial execution of tasks submitted to it.
SerializedSuspendableExecutionContext(int, ExecutionContext) - Constructor for class akka.util.SerializedSuspendableExecutionContext
 
SerializedSuspendableExecutionContext$ - Class in akka.util
 
SerializedSuspendableExecutionContext$() - Constructor for class akka.util.SerializedSuspendableExecutionContext$
 
Serializer - Interface in akka.serialization
A Serializer represents a bimap between an object and an array of bytes representing that object.
serializerByIdentity() - Method in class akka.serialization.Serialization
Maps from a Serializer Identity (Int) to a Serializer instance (optimization)
serializerFor(Class<?>) - Method in class akka.serialization.Serialization
Returns the configured Serializer for the given Class.
serializerId() - Method in class akka.persistence.serialization.SnapshotHeader
 
SERIALIZERID_FIELD_NUMBER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
SERIALIZERID_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
SERIALIZERID_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.SelectionEnvelope
 
SERIALIZERID_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.SerializedMessage
 
serializerOf(String) - Method in class akka.serialization.Serialization
Tries to load the specified Serializer by the fully-qualified name; the actual loading is performed by the system&rsquo;s DynamicAccess.
Serializers() - Method in class akka.serialization.Serialization.Settings
 
Server - Class in akka.remote.testconductor
INTERNAL API.
Server() - Constructor for class akka.remote.testconductor.Server
 
Server$ - Class in akka.remote.testconductor
INTERNAL API.
Server$() - Constructor for class akka.remote.testconductor.Server$
 
ServerFSM - Class in akka.remote.testconductor
The server part of each client connection is represented by a ServerFSM.
ServerFSM(ActorRef, org.jboss.netty.channel.Channel) - Constructor for class akka.remote.testconductor.ServerFSM
 
ServerFSM$ - Class in akka.remote.testconductor
INTERNAL API.
ServerFSM$() - Constructor for class akka.remote.testconductor.ServerFSM$
 
ServerFSM.Initial$ - Class in akka.remote.testconductor
 
ServerFSM.Initial$() - Constructor for class akka.remote.testconductor.ServerFSM.Initial$
 
ServerFSM.Ready$ - Class in akka.remote.testconductor
 
ServerFSM.Ready$() - Constructor for class akka.remote.testconductor.ServerFSM.Ready$
 
ServerFSM.State - Interface in akka.remote.testconductor
 
ServerHandler - Class in akka.remote.transport.netty
INTERNAL API
ServerHandler(NettyTransport, Future<Transport.AssociationEventListener>) - Constructor for class akka.remote.transport.netty.ServerHandler
 
serverName() - Method in class akka.remote.testkit.MultiNodeSpec$
Name (or IP address; must be resolvable using InetAddress.getByName) of the host that the server node is running on.
serverName() - Static method in class akka.remote.testkit.MultiNodeSpec
Name (or IP address; must be resolvable using InetAddress.getByName) of the host that the server node is running on.
ServerOp - Interface in akka.remote.testconductor
 
serverPort() - Method in class akka.remote.testkit.MultiNodeSpec$
Port number of the node that's running the server system.
serverPort() - Static method in class akka.remote.testkit.MultiNodeSpec
Port number of the node that's running the server system.
ServerSocketWorkerPoolSize() - Method in class akka.remote.testconductor.TestConductorExt.Settings
 
ServerSocketWorkerPoolSize() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
serviceForReference(org.osgi.framework.BundleContext, <any>) - Method in class akka.osgi.ActorSystemActivator
Convenience method to find a service by its reference.
set(long) - Method in class akka.actor.mailbox.filebased.filequeue.Counter
 
set(Option<T>) - Method in class akka.actor.mailbox.filebased.filequeue.OverlaySetting
 
setAck(WireFormats.AcknowledgementInfo) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .AcknowledgementInfo ack = 1;
setAck(WireFormats.AcknowledgementInfo.Builder) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .AcknowledgementInfo ack = 1;
setActor(ActorCell) - Method in class akka.dispatch.Mailbox
 
setActorFields(Actor, ActorContext, ActorRef) - Method in class akka.actor.ActorCell
 
setAddr(TestConductorProtocol.Address) - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
optional .Address addr = 2;
setAddr(TestConductorProtocol.Address.Builder) - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
optional .Address addr = 2;
setAddr(TestConductorProtocol.AddressRequest) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .AddressRequest addr = 5;
setAddr(TestConductorProtocol.AddressRequest.Builder) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .AddressRequest addr = 5;
setAddress(ClusterMessages.Address) - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
required .Address address = 1;
setAddress(ClusterMessages.Address.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
required .Address address = 1;
setAddress(DistributedPubSubMessages.Address) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
required .Address address = 1;
setAddress(DistributedPubSubMessages.Address.Builder) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
required .Address address = 1;
setAddress(TestConductorProtocol.Address) - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
required .Address address = 2;
setAddress(TestConductorProtocol.Address.Builder) - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
required .Address address = 2;
setAddress(TestConductorProtocol.Address) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
optional .Address address = 3;
setAddress(TestConductorProtocol.Address.Builder) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
optional .Address address = 3;
setAddressIndex(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
required int32 addressIndex = 1;
setAddressIndex(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
required int32 addressIndex = 1;
setAddressIndex(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
required int32 addressIndex = 1;
setAddressIndex(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
required int32 addressIndex = 1;
setAllAddresses(int, ClusterMessages.UniqueAddress) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .UniqueAddress allAddresses = 1;
setAllAddresses(int, ClusterMessages.UniqueAddress.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .UniqueAddress allAddresses = 1;
setAllAddresses(int, ClusterMessages.Address) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .Address allAddresses = 1;
setAllAddresses(int, ClusterMessages.Address.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .Address allAddresses = 1;
setAllButSelf(boolean) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
required bool allButSelf = 2;
setAllHashes(int, String) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated string allHashes = 3;
setAllHashes(int, String) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
repeated string allHashes = 2;
setAllMetricNames(int, String) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated string allMetricNames = 2;
setAllowCoreThreadTimeout(boolean) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
setAllRoles(int, String) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated string allRoles = 2;
setAlpha(double) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
required double alpha = 2;
setArgs(int, com.google.protobuf.ByteString) - Method in class akka.remote.WireFormats.PropsData.Builder
repeated bytes args = 4;
setAsIdle() - Method in class akka.dispatch.Mailbox
Reset Scheduled status, keeping primary status as is.
setAsScheduled() - Method in class akka.dispatch.Mailbox
Set Scheduled status, keeping primary status as is.
setAutoAck(boolean) - Method in interface akka.camel.internal.component.ActorEndpointConfig
 
setAutoPilot(TestActor.AutoPilot) - Method in class akka.testkit.JavaTestKit
Install an AutoPilot to drive the testActor: the AutoPilot will be run for each received message and can be used to send or forward messages, etc.
setAutoPilot(TestActor.AutoPilot) - Method in interface akka.testkit.TestKitBase
Install an AutoPilot to drive the testActor: the AutoPilot will be run for each received message and can be used to send or forward messages, etc.
setBarrier(TestConductorProtocol.EnterBarrier) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .EnterBarrier barrier = 2;
setBarrier(TestConductorProtocol.EnterBarrier.Builder) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .EnterBarrier barrier = 2;
setBatch(int, MessageFormats.PersistentMessage) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
repeated .PersistentMessage batch = 1;
setBatch(int, MessageFormats.PersistentMessage.Builder) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch.Builder
repeated .PersistentMessage batch = 1;
setBuckets(int, DistributedPubSubMessages.Delta.Bucket) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
repeated .Delta.Bucket buckets = 1;
setBuckets(int, DistributedPubSubMessages.Delta.Bucket.Builder) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Builder
repeated .Delta.Bucket buckets = 1;
setChannel(String) - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
optional string channel = 5;
setChannelBytes(com.google.protobuf.ByteString) - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
optional string channel = 5;
setChannelId(String) - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
optional string channelId = 2;
setChannelIdBytes(com.google.protobuf.ByteString) - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
optional string channelId = 2;
setChildrenTerminationReason(ChildrenContainer.SuspendReason) - Method in interface akka.actor.dungeon.Children
 
setClasses(int, String) - Method in class akka.remote.WireFormats.PropsData.Builder
repeated string classes = 5;
setClazz(String) - Method in class akka.remote.WireFormats.PropsData.Builder
required string clazz = 3;
setClazzBytes(com.google.protobuf.ByteString) - Method in class akka.remote.WireFormats.PropsData.Builder
required string clazz = 3;
setCommandType(WireFormats.CommandType) - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
required .CommandType commandType = 1;
setConfig(com.google.protobuf.ByteString) - Method in class akka.remote.WireFormats.DeployData.Builder
optional bytes config = 2;
setConfirmable(boolean) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional bool confirmable = 8;
setConfirmMessage(MessageFormats.DeliveredMessage) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional .DeliveredMessage confirmMessage = 9;
setConfirmMessage(MessageFormats.DeliveredMessage.Builder) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional .DeliveredMessage confirmMessage = 9;
setConfirms(int, String) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
repeated string confirms = 7;
setConfirmTarget(String) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string confirmTarget = 10;
setConfirmTargetBytes(com.google.protobuf.ByteString) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string confirmTarget = 10;
setContent(int, DistributedPubSubMessages.Delta.Entry) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
repeated .Delta.Entry content = 3;
setContent(int, DistributedPubSubMessages.Delta.Entry.Builder) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
repeated .Delta.Entry content = 3;
setCookie(String) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
optional string cookie = 3;
setCookieBytes(com.google.protobuf.ByteString) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
optional string cookie = 3;
setCorePoolSize(int) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
setCorePoolSizeFromFactor(int, double, int) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
setCumulativeAck(long) - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
required fixed64 cumulativeAck = 1;
setCurrentDeliveryId(long) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
required int64 currentDeliveryId = 1;
setDeleted(boolean) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional bool deleted = 4;
setDeliveryId(long) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required int64 deliveryId = 1;
setDeliverySequenceNr(long) - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
optional int64 deliverySequenceNr = 4;
setDeliverySnapshot(AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot) - Method in interface akka.persistence.AtLeastOnceDelivery
If snapshot from AtLeastOnceDelivery.getDeliverySnapshot() was saved it will be received during recovery in a SnapshotOffer message and should be set with this method.
setDeploy(WireFormats.DeployData) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .DeployData deploy = 2;
setDeploy(WireFormats.DeployData.Builder) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .DeployData deploy = 2;
setDeploy(WireFormats.DeployData) - Method in class akka.remote.WireFormats.PropsData.Builder
required .DeployData deploy = 2;
setDeploy(WireFormats.DeployData.Builder) - Method in class akka.remote.WireFormats.PropsData.Builder
required .DeployData deploy = 2;
setDestination(String) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required string destination = 2;
setDestination(String) - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage.Builder
optional string destination = 2;
setDestinationBytes(com.google.protobuf.ByteString) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required string destination = 2;
setDestinationBytes(com.google.protobuf.ByteString) - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage.Builder
optional string destination = 2;
setDirection(TestConductorProtocol.Direction) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
optional .Direction direction = 2;
setDispatcher(String) - Method in class akka.remote.WireFormats.DeployData.Builder
optional string dispatcher = 5;
setDispatcherBytes(com.google.protobuf.ByteString) - Method in class akka.remote.WireFormats.DeployData.Builder
optional string dispatcher = 5;
setDone(String) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional string done = 4;
setDoneBytes(com.google.protobuf.ByteString) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional string done = 4;
setEnclosedMessage(com.google.protobuf.ByteString) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload.Builder
required bytes enclosedMessage = 1;
setEnclosedMessage(com.google.protobuf.ByteString) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
required bytes enclosedMessage = 1;
setEnvelope(WireFormats.RemoteEnvelope) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .RemoteEnvelope envelope = 2;
setEnvelope(WireFormats.RemoteEnvelope.Builder) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .RemoteEnvelope envelope = 2;
setEwma(ClusterMessages.NodeMetrics.EWMA) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
optional .NodeMetrics.EWMA ewma = 3;
setEwma(ClusterMessages.NodeMetrics.EWMA.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
optional .NodeMetrics.EWMA ewma = 3;
setExitValue(int) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
optional int32 exitValue = 7;
setFailed(ActorRef) - Method in interface akka.actor.dungeon.FaultHandling
 
setFailure(FailureResult) - Method in class akka.camel.internal.CamelExchangeAdapter
Sets Exchange.getException from the given FailureResult message.
setFailure(TestConductorProtocol.FailType) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
required .FailType failure = 1;
setFailure(TestConductorProtocol.InjectFailure) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .InjectFailure failure = 3;
setFailure(TestConductorProtocol.InjectFailure.Builder) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .InjectFailure failure = 3;
setFrom(ClusterMessages.UniqueAddress) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
required .UniqueAddress from = 1;
setFrom(ClusterMessages.UniqueAddress.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
required .UniqueAddress from = 1;
setFrom(ClusterMessages.UniqueAddress) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
required .UniqueAddress from = 1;
setFrom(ClusterMessages.UniqueAddress.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
required .UniqueAddress from = 1;
setFrom(ClusterMessages.Address) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
required .Address from = 1;
setFrom(ClusterMessages.Address.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
required .Address from = 1;
setFrom(ClusterMessages.UniqueAddress) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
required .UniqueAddress from = 1;
setFrom(ClusterMessages.UniqueAddress.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
required .UniqueAddress from = 1;
setGossip(ClusterMessages.MetricsGossip) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
required .MetricsGossip gossip = 2;
setGossip(ClusterMessages.MetricsGossip.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
required .MetricsGossip gossip = 2;
setGossip(ClusterMessages.Gossip) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
required .Gossip gossip = 2;
setGossip(ClusterMessages.Gossip.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
required .Gossip gossip = 2;
setHandshakeInfo(WireFormats.AkkaHandshakeInfo) - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
optional .AkkaHandshakeInfo handshakeInfo = 2;
setHandshakeInfo(WireFormats.AkkaHandshakeInfo.Builder) - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
optional .AkkaHandshakeInfo handshakeInfo = 2;
setHashIndex(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
required int32 hashIndex = 1;
setHello(TestConductorProtocol.Hello) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .Hello hello = 1;
setHello(TestConductorProtocol.Hello.Builder) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
optional .Hello hello = 1;
setHost(String) - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
required string host = 3;
setHostBytes(com.google.protobuf.ByteString) - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
required string host = 3;
setHostname(String) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
required string hostname = 2;
setHostname(String) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
required string hostname = 2;
setHostname(String) - Method in class akka.remote.WireFormats.AddressData.Builder
required string hostname = 2;
setHostnameBytes(com.google.protobuf.ByteString) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
required string hostname = 2;
setHostnameBytes(com.google.protobuf.ByteString) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
required string hostname = 2;
setHostnameBytes(com.google.protobuf.ByteString) - Method in class akka.remote.WireFormats.AddressData.Builder
required string hostname = 2;
setInstruction(WireFormats.AkkaControlMessage) - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
optional .AkkaControlMessage instruction = 2;
setInstruction(WireFormats.AkkaControlMessage.Builder) - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
optional .AkkaControlMessage instruction = 2;
setKeepAliveTime(Duration) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
setKeepAliveTimeInMillis(long) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
setKey(String) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
required string key = 1;
setKeyBytes(com.google.protobuf.ByteString) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
required string key = 1;
setLocalAffinity(boolean) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
required bool localAffinity = 2;
setLogLevel(Logging.LogLevel) - Method in interface akka.event.LoggingBus
Change log level: default loggers (i.e.
setMatcher(String) - Method in class akka.remote.ContainerFormats.Selection.Builder
optional string matcher = 2;
setMatcherBytes(com.google.protobuf.ByteString) - Method in class akka.remote.ContainerFormats.Selection.Builder
optional string matcher = 2;
setMaxPoolSize(int) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
setMaxPoolSizeFromFactor(int, double, int) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
setMDC(Map<String, Object>) - Method in interface akka.event.DiagnosticLoggingAdapter
Java API: Sets the values to be added to the MDC (Mapped Diagnostic Context) before the log is appended.
setMembers(int, ClusterMessages.Member) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .Member members = 4;
setMembers(int, ClusterMessages.Member.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
repeated .Member members = 4;
setMessage(WireFormats.SerializedMessage) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
required .SerializedMessage message = 2;
setMessage(WireFormats.SerializedMessage.Builder) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
required .SerializedMessage message = 2;
setMessage(com.google.protobuf.ByteString) - Method in class akka.remote.WireFormats.SerializedMessage.Builder
required bytes message = 1;
setMessageManifest(com.google.protobuf.ByteString) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload.Builder
optional bytes messageManifest = 4;
setMessageManifest(com.google.protobuf.ByteString) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
optional bytes messageManifest = 4;
setMessageManifest(com.google.protobuf.ByteString) - Method in class akka.remote.WireFormats.SerializedMessage.Builder
optional bytes messageManifest = 3;
setMetrics(int, ClusterMessages.NodeMetrics.Metric) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
repeated .NodeMetrics.Metric metrics = 3;
setMetrics(int, ClusterMessages.NodeMetrics.Metric.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
repeated .NodeMetrics.Metric metrics = 3;
setNacks(int, long) - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
repeated fixed64 nacks = 2;
setName(String) - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
required string name = 1;
setName(String) - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
required string name = 1;
setNameBytes(com.google.protobuf.ByteString) - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
required string name = 1;
setNameBytes(com.google.protobuf.ByteString) - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
required string name = 1;
setNameIndex(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
required int32 nameIndex = 1;
setNext(AbstractNodeQueue.Node<T>) - Method in class akka.dispatch.AbstractNodeQueue.Node
 
setNode(ClusterMessages.UniqueAddress) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
required .UniqueAddress node = 1;
setNode(ClusterMessages.UniqueAddress.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
required .UniqueAddress node = 1;
setNode(String) - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
required string node = 1;
setNodeBytes(com.google.protobuf.ByteString) - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
required string node = 1;
setNodeMetrics(int, ClusterMessages.NodeMetrics) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .NodeMetrics nodeMetrics = 3;
setNodeMetrics(int, ClusterMessages.NodeMetrics.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
repeated .NodeMetrics nodeMetrics = 3;
setNumber(ClusterMessages.NodeMetrics.Number) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
required .NodeMetrics.Number number = 2;
setNumber(ClusterMessages.NodeMetrics.Number.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
required .NodeMetrics.Number number = 2;
setObserverReachability(int, ClusterMessages.ObserverReachability) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
repeated .ObserverReachability observerReachability = 2;
setObserverReachability(int, ClusterMessages.ObserverReachability.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
repeated .ObserverReachability observerReachability = 2;
setOp(TestConductorProtocol.BarrierOp) - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
required .BarrierOp op = 2;
setOrigin(WireFormats.AddressData) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
required .AddressData origin = 1;
setOrigin(WireFormats.AddressData.Builder) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
required .AddressData origin = 1;
setOverview(ClusterMessages.GossipOverview) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
required .GossipOverview overview = 5;
setOverview(ClusterMessages.GossipOverview.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
required .GossipOverview overview = 5;
setOwner(DistributedPubSubMessages.Address) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
required .Address owner = 1;
setOwner(DistributedPubSubMessages.Address.Builder) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
required .Address owner = 1;
setPath(String) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
required string path = 1;
setPath(String) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
required string path = 1;
setPath(String) - Method in class akka.remote.WireFormats.ActorRefData.Builder
required string path = 1;
setPath(String) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required string path = 3;
setPath(String) - Method in class akka.remote.WireFormats.DeployData.Builder
required string path = 1;
setPathBytes(com.google.protobuf.ByteString) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
required string path = 1;
setPathBytes(com.google.protobuf.ByteString) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
required string path = 1;
setPathBytes(com.google.protobuf.ByteString) - Method in class akka.remote.WireFormats.ActorRefData.Builder
required string path = 1;
setPathBytes(com.google.protobuf.ByteString) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required string path = 3;
setPathBytes(com.google.protobuf.ByteString) - Method in class akka.remote.WireFormats.DeployData.Builder
required string path = 1;
setPattern(int, ContainerFormats.Selection) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
repeated .Selection pattern = 3;
setPattern(int, ContainerFormats.Selection.Builder) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
repeated .Selection pattern = 3;
setPayload(DistributedPubSubMessages.Payload) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish.Builder
required .Payload payload = 3;
setPayload(DistributedPubSubMessages.Payload.Builder) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish.Builder
required .Payload payload = 3;
setPayload(DistributedPubSubMessages.Payload) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
required .Payload payload = 3;
setPayload(DistributedPubSubMessages.Payload.Builder) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send.Builder
required .Payload payload = 3;
setPayload(DistributedPubSubMessages.Payload) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
required .Payload payload = 3;
setPayload(DistributedPubSubMessages.Payload.Builder) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
required .Payload payload = 3;
setPayload(MessageFormats.PersistentPayload) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required .PersistentPayload payload = 3;
setPayload(MessageFormats.PersistentPayload.Builder) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required .PersistentPayload payload = 3;
setPayload(MessageFormats.PersistentPayload) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional .PersistentPayload payload = 1;
setPayload(MessageFormats.PersistentPayload.Builder) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional .PersistentPayload payload = 1;
setPayload(com.google.protobuf.ByteString) - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
required bytes payload = 2;
setPayload(com.google.protobuf.ByteString) - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
optional bytes payload = 1;
setPayloadManifest(com.google.protobuf.ByteString) - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
optional bytes payloadManifest = 3;
setPersistenceId(String) - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
optional string persistenceId = 1;
setPersistenceId(String) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string persistenceId = 3;
setPersistenceIdBytes(com.google.protobuf.ByteString) - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
optional string persistenceId = 1;
setPersistenceIdBytes(com.google.protobuf.ByteString) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string persistenceId = 3;
setPersistent(MessageFormats.PersistentMessage) - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage.Builder
optional .PersistentMessage persistent = 1;
setPersistent(MessageFormats.PersistentMessage.Builder) - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage.Builder
optional .PersistentMessage persistent = 1;
setPersistentSequenceNr(long) - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage.Builder
optional int64 persistentSequenceNr = 3;
setPort(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
required uint32 port = 3;
setPort(int) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
required uint32 port = 3;
setPort(int) - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
required int32 port = 4;
setPort(int) - Method in class akka.remote.WireFormats.AddressData.Builder
required uint32 port = 3;
setProps(WireFormats.PropsData) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .PropsData props = 1;
setProps(WireFormats.PropsData.Builder) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .PropsData props = 1;
setProtocol(String) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
optional string protocol = 4;
setProtocol(String) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
optional string protocol = 4;
setProtocol(String) - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
required string protocol = 1;
setProtocol(String) - Method in class akka.remote.WireFormats.AddressData.Builder
optional string protocol = 4;
setProtocolBytes(com.google.protobuf.ByteString) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
optional string protocol = 4;
setProtocolBytes(com.google.protobuf.ByteString) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
optional string protocol = 4;
setProtocolBytes(com.google.protobuf.ByteString) - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
required string protocol = 1;
setProtocolBytes(com.google.protobuf.ByteString) - Method in class akka.remote.WireFormats.AddressData.Builder
optional string protocol = 4;
setQueueFactory(Function0<BlockingQueue<Runnable>>) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
setRateMBit(float) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
optional float rateMBit = 6;
setRawResult(BoxedUnit) - Method in class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinTask
 
setReceiveTimeout(Duration) - Method in interface akka.actor.ActorContext
Defines the inactivity timeout after which the sending of a ReceiveTimeout message is triggered.
setReceiveTimeout(Duration) - Method in interface akka.actor.dungeon.ReceiveTimeout
 
setRecipient(WireFormats.ActorRefData) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
required .ActorRefData recipient = 1;
setRecipient(WireFormats.ActorRefData.Builder) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
required .ActorRefData recipient = 1;
setRedeliveries(int) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional int32 redeliveries = 6;
setRef(String) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
optional string ref = 3;
setRefBytes(com.google.protobuf.ByteString) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
optional string ref = 3;
setReply(boolean) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
required bool reply = 3;
setReplyTimeout(FiniteDuration) - Method in interface akka.camel.internal.component.ActorEndpointConfig
 
setRequest(CamelMessage) - Method in class akka.camel.internal.CamelExchangeAdapter
Sets Exchange.getIn from the given CamelMessage object.
setResponse(CamelMessage) - Method in class akka.camel.internal.CamelExchangeAdapter
Depending on the exchange pattern, sets Exchange.getIn or Exchange.getOut from the given CamelMessage object.
setRoles(int, String) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
repeated string roles = 2;
setRolesIndexes(int, int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
repeated int32 rolesIndexes = 4 [packed = true];
setRouterConfig(com.google.protobuf.ByteString) - Method in class akka.remote.WireFormats.DeployData.Builder
optional bytes routerConfig = 3;
setScope(com.google.protobuf.ByteString) - Method in class akka.remote.WireFormats.DeployData.Builder
optional bytes scope = 4;
setSeen(int, int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
repeated int32 seen = 1;
setSender(String) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string sender = 11;
setSender(WireFormats.ActorRefData) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
optional .ActorRefData sender = 4;
setSender(WireFormats.ActorRefData.Builder) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
optional .ActorRefData sender = 4;
setSenderBytes(com.google.protobuf.ByteString) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string sender = 11;
setSeq(long) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
optional fixed64 seq = 5;
setSequenceNr(long) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional int64 sequenceNr = 2;
setSerialized(com.google.protobuf.ByteString) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
optional bytes serialized = 4;
setSerializedGossip(com.google.protobuf.ByteString) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
required bytes serializedGossip = 3;
setSerializerId(int) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload.Builder
required int32 serializerId = 2;
setSerializerId(int) - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
required int32 serializerId = 1;
setSerializerId(int) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
required int32 serializerId = 2;
setSerializerId(int) - Method in class akka.remote.WireFormats.SerializedMessage.Builder
required int32 serializerId = 2;
setState(S, D, FiniteDuration, Option<FSM.Reason>) - Method in class akka.testkit.TestFSMRef
Change FSM state; any value left out defaults to the current FSM state (timeout defaults to None).
setStateTimeout(S, Option<FiniteDuration>) - Method in interface akka.actor.FSM
 
setStatus(ClusterMessages.MemberStatus) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
required .MemberStatus status = 3;
setStatus(ClusterMessages.ReachabilityStatus) - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
required .ReachabilityStatus status = 3;
setStatus(int) - Method in class akka.dispatch.Mailbox
 
setStore(ActorRef, ActorSystem) - Method in class akka.persistence.journal.leveldb.SharedLeveldbJournal$
Sets the shared LevelDB store for the given actor system.
setStore(ActorRef, ActorSystem) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
Sets the shared LevelDB store for the given actor system.
setSubjectReachability(int, ClusterMessages.SubjectReachability) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
repeated .SubjectReachability subjectReachability = 2;
setSubjectReachability(int, ClusterMessages.SubjectReachability.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
repeated .SubjectReachability subjectReachability = 2;
setSupervisor(WireFormats.ActorRefData) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .ActorRefData supervisor = 4;
setSupervisor(WireFormats.ActorRefData.Builder) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .ActorRefData supervisor = 4;
setSystem(String) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
required string system = 1;
setSystem(String) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
required string system = 1;
setSystem(String) - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
required string system = 2;
setSystem(String) - Method in class akka.remote.WireFormats.AddressData.Builder
required string system = 1;
setSystemBytes(com.google.protobuf.ByteString) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
required string system = 1;
setSystemBytes(com.google.protobuf.ByteString) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address.Builder
required string system = 1;
setSystemBytes(com.google.protobuf.ByteString) - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
required string system = 2;
setSystemBytes(com.google.protobuf.ByteString) - Method in class akka.remote.WireFormats.AddressData.Builder
required string system = 1;
setTerminated() - Method in interface akka.actor.dungeon.Children
 
setTimeout(long) - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
optional int64 timeout = 3;
setTimer(String, Object, FiniteDuration) - Method in class akka.actor.AbstractFSM
Schedule named timer to deliver message after given delay, possibly repeating.
setTimer(String, Object, FiniteDuration, boolean) - Method in interface akka.actor.FSM
 
setTimer(String, Object, FiniteDuration, boolean) - Method in class akka.testkit.TestFSMRef
Proxy for FSM.setTimer(java.lang.String, java.lang.Object, scala.concurrent.duration.FiniteDuration, boolean).
setTimestamp(long) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
required int64 timestamp = 2;
setTimestamp(long) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
optional int64 timestamp = 1;
setTimestamp(long) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
required int64 timestamp = 2;
setTimestamp(long) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
required int64 timestamp = 2;
settings() - Method in interface akka.actor.ActorRefProvider
The Settings associated with this ActorRefProvider
settings() - Method in class akka.actor.ActorSystem
The core settings extracted from the supplied configuration.
settings() - Method in class akka.actor.ActorSystemImpl
 
settings() - Method in class akka.actor.Deployer
 
settings() - Method in class akka.actor.LocalActorRefProvider
 
settings() - Method in class akka.actor.mailbox.filebased.FileBasedMessageQueue
 
settings() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
settings() - Method in interface akka.camel.Camel
The settings for the CamelExtension
settings() - Method in class akka.camel.internal.DefaultCamel
 
settings() - Method in class akka.cluster.Cluster
 
settings() - Method in interface akka.cluster.routing.ClusterRouterActor
 
settings() - Method in class akka.cluster.routing.ClusterRouterConfig
 
settings() - Method in interface akka.cluster.routing.ClusterRouterConfigBase
 
settings() - Method in class akka.cluster.routing.ClusterRouterGroup
 
settings() - Method in class akka.cluster.routing.ClusterRouterGroupActor
 
settings() - Method in class akka.cluster.routing.ClusterRouterPool
 
settings() - Method in class akka.cluster.routing.ClusterRouterPoolActor
 
Settings() - Method in class akka.contrib.pattern.ClusterSharding
Accessor for nested Scala object
settings() - Method in class akka.dispatch.DefaultDispatcherPrerequisites
 
settings() - Method in interface akka.dispatch.DispatcherPrerequisites
 
settings() - Method in class akka.dispatch.Dispatchers
 
settings() - Method in class akka.dispatch.Mailboxes
 
Settings() - Method in class akka.io.TcpExt
 
settings() - Method in class akka.io.UdpConnectedExt
 
settings() - Method in class akka.io.UdpExt
 
settings() - Method in interface akka.io.WithUdpSend
 
settings() - Method in class akka.persistence.Persistence
 
settings() - Method in class akka.remote.EndpointActor
 
settings() - Method in class akka.remote.EndpointManager
 
settings() - Method in class akka.remote.ReliableDeliverySupervisor
 
settings() - Method in class akka.remote.RemoteActorRefProvider
 
settings() - Method in class akka.remote.testconductor.ClientFSM
 
settings() - Method in class akka.remote.testconductor.Controller
 
Settings() - Method in class akka.remote.testconductor.TestConductorExt
 
settings() - Method in class akka.remote.transport.netty.NettyTransport
 
settings() - Method in class akka.remote.transport.TransportAdapters
 
settings() - Method in class akka.serialization.Serialization
 
settings() - Method in interface akka.transactor.Transactor
 
setTo(ClusterMessages.UniqueAddress) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
required .UniqueAddress to = 2;
setTo(ClusterMessages.UniqueAddress.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
required .UniqueAddress to = 2;
setTopic(String) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish.Builder
required string topic = 1;
setTopicBytes(com.google.protobuf.ByteString) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish.Builder
required string topic = 1;
setType(ClusterMessages.NodeMetrics.NumberType) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
required .NodeMetrics.NumberType type = 1;
setType(ContainerFormats.PatternType) - Method in class akka.remote.ContainerFormats.Selection.Builder
required .PatternType type = 1;
setUid(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
required uint32 uid = 2;
setUid(long) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
required fixed64 uid = 2;
setUnconfirmedDeliveries(int, MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
setUnconfirmedDeliveries(int, MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
setup() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
setUpNumber(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
required int32 upNumber = 2;
setUpStdoutLogger(ActorSystem.Settings) - Method in interface akka.event.LoggingBus
 
setValue(double) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
required double value = 1;
setValue32(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
optional uint32 value32 = 2;
setValue64(long) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
optional uint64 value64 = 3;
setVersion(ClusterMessages.VectorClock) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
required .VectorClock version = 6;
setVersion(ClusterMessages.VectorClock.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
required .VectorClock version = 6;
setVersion(ClusterMessages.VectorClock) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
required .VectorClock version = 3;
setVersion(ClusterMessages.VectorClock.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
required .VectorClock version = 3;
setVersion(long) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
required int64 version = 4;
setVersion(long) - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
required int64 version = 4;
setVersion(long) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
required int64 version = 2;
setVersion(long) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
required int64 version = 2;
setVersions(int, ClusterMessages.VectorClock.Version) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
repeated .VectorClock.Version versions = 2;
setVersions(int, ClusterMessages.VectorClock.Version.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
repeated .VectorClock.Version versions = 2;
setVersions(int, DistributedPubSubMessages.Status.Version) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
repeated .Status.Version versions = 1;
setVersions(int, DistributedPubSubMessages.Status.Version.Builder) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Builder
repeated .Status.Version versions = 1;
setWildcardFanOut(boolean) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
optional bool wildcardFanOut = 5;
SeveralRoutees - Class in akka.routing
Routee that sends each message to all routees.
SeveralRoutees(IndexedSeq<Routee>) - Constructor for class akka.routing.SeveralRoutees
 
SeveralRoutees(Iterable<Routee>) - Constructor for class akka.routing.SeveralRoutees
Java API
SeveralRoutees$ - Class in akka.routing
 
SeveralRoutees$() - Constructor for class akka.routing.SeveralRoutees$
 
sha1(String) - Method in class akka.util.Crypt$
 
sha1(byte[]) - Method in class akka.util.Crypt$
 
sha1(String) - Static method in class akka.util.Crypt
 
sha1(byte[]) - Static method in class akka.util.Crypt
 
shallDie(ActorRef) - Method in interface akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer
 
shallDie(ActorRef) - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
 
shallDie(ActorRef) - Method in interface akka.actor.dungeon.ChildrenContainer
 
shallDie(ActorRef) - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
 
shard() - Method in class akka.contrib.pattern.ShardCoordinator.Internal$.BeginHandOff
 
shard() - Method in class akka.contrib.pattern.ShardCoordinator.Internal$.BeginHandOffAck
 
shard() - Method in class akka.contrib.pattern.ShardCoordinator.Internal$.GetShardHome
 
shard() - Method in class akka.contrib.pattern.ShardCoordinator.Internal$.HandOff
 
shard() - Method in class akka.contrib.pattern.ShardCoordinator.Internal$.ShardHome
 
shard() - Method in class akka.contrib.pattern.ShardCoordinator.Internal$.ShardHomeAllocated
 
shard() - Method in class akka.contrib.pattern.ShardCoordinator.Internal$.ShardHomeDeallocated
 
shard() - Method in class akka.contrib.pattern.ShardCoordinator.Internal$.ShardStopped
 
shardBuffers() - Method in class akka.contrib.pattern.ShardRegion
 
ShardCoordinator - Class in akka.contrib.pattern
Singleton coordinator that decides where to allocate shards.
ShardCoordinator(FiniteDuration, FiniteDuration, FiniteDuration, ShardCoordinator.ShardAllocationStrategy) - Constructor for class akka.contrib.pattern.ShardCoordinator
 
ShardCoordinator$ - Class in akka.contrib.pattern
 
ShardCoordinator$() - Constructor for class akka.contrib.pattern.ShardCoordinator$
 
ShardCoordinator.AbstractShardAllocationStrategy - Class in akka.contrib.pattern
Java API: Java implementations of custom shard allocation and rebalancing logic used by the ShardCoordinator should extend this abstract class and implement the two methods.
ShardCoordinator.AbstractShardAllocationStrategy() - Constructor for class akka.contrib.pattern.ShardCoordinator.AbstractShardAllocationStrategy
 
ShardCoordinator.Internal$ - Class in akka.contrib.pattern
INTERNAL API
ShardCoordinator.Internal$() - Constructor for class akka.contrib.pattern.ShardCoordinator.Internal$
 
ShardCoordinator.Internal$.BeginHandOff - Class in akka.contrib.pattern
ShardCoordinator initiates rebalancing process by sending this message to all registered ShardRegion actors (including proxy only).
ShardCoordinator.Internal$.BeginHandOff(String) - Constructor for class akka.contrib.pattern.ShardCoordinator.Internal$.BeginHandOff
 
ShardCoordinator.Internal$.BeginHandOffAck - Class in akka.contrib.pattern
Acknowledgement of ShardCoordinator.Internal$.BeginHandOff
ShardCoordinator.Internal$.BeginHandOffAck(String) - Constructor for class akka.contrib.pattern.ShardCoordinator.Internal$.BeginHandOffAck
 
ShardCoordinator.Internal$.CoordinatorCommand - Interface in akka.contrib.pattern
Messages sent to the coordinator
ShardCoordinator.Internal$.CoordinatorMessage - Interface in akka.contrib.pattern
Messages sent from the coordinator
ShardCoordinator.Internal$.DomainEvent - Interface in akka.contrib.pattern
 
ShardCoordinator.Internal$.GetShardHome - Class in akka.contrib.pattern
ShardRegion requests the location of a shard by sending this message to the ShardCoordinator.
ShardCoordinator.Internal$.GetShardHome(String) - Constructor for class akka.contrib.pattern.ShardCoordinator.Internal$.GetShardHome
 
ShardCoordinator.Internal$.HandOff - Class in akka.contrib.pattern
When all ShardRegion actors have acknoledged the ShardCoordinator.Internal$.BeginHandOff the ShardCoordinator sends this message to the ShardRegion responsible for the shard.
ShardCoordinator.Internal$.HandOff(String) - Constructor for class akka.contrib.pattern.ShardCoordinator.Internal$.HandOff
 
ShardCoordinator.Internal$.Register - Class in akka.contrib.pattern
ShardRegion registers to ShardCoordinator, until it receives ShardCoordinator.Internal$.RegisterAck
ShardCoordinator.Internal$.Register(ActorRef) - Constructor for class akka.contrib.pattern.ShardCoordinator.Internal$.Register
 
ShardCoordinator.Internal$.RegisterAck - Class in akka.contrib.pattern
Acknowledgement from ShardCoordinator that ShardCoordinator.Internal$.Register or ShardCoordinator.Internal$.RegisterProxy was sucessful.
ShardCoordinator.Internal$.RegisterAck(ActorRef) - Constructor for class akka.contrib.pattern.ShardCoordinator.Internal$.RegisterAck
 
ShardCoordinator.Internal$.RegisterProxy - Class in akka.contrib.pattern
ShardRegion in proxy only mode registers to ShardCoordinator, until it receives ShardCoordinator.Internal$.RegisterAck
ShardCoordinator.Internal$.RegisterProxy(ActorRef) - Constructor for class akka.contrib.pattern.ShardCoordinator.Internal$.RegisterProxy
 
ShardCoordinator.Internal$.ShardHome - Class in akka.contrib.pattern
ShardCoordinator replies with this message for ShardCoordinator.Internal$.GetShardHome requests.
ShardCoordinator.Internal$.ShardHome(String, ActorRef) - Constructor for class akka.contrib.pattern.ShardCoordinator.Internal$.ShardHome
 
ShardCoordinator.Internal$.ShardHomeAllocated - Class in akka.contrib.pattern
 
ShardCoordinator.Internal$.ShardHomeAllocated(String, ActorRef) - Constructor for class akka.contrib.pattern.ShardCoordinator.Internal$.ShardHomeAllocated
 
ShardCoordinator.Internal$.ShardHomeDeallocated - Class in akka.contrib.pattern
 
ShardCoordinator.Internal$.ShardHomeDeallocated(String) - Constructor for class akka.contrib.pattern.ShardCoordinator.Internal$.ShardHomeDeallocated
 
ShardCoordinator.Internal$.ShardRegionProxyRegistered - Class in akka.contrib.pattern
 
ShardCoordinator.Internal$.ShardRegionProxyRegistered(ActorRef) - Constructor for class akka.contrib.pattern.ShardCoordinator.Internal$.ShardRegionProxyRegistered
 
ShardCoordinator.Internal$.ShardRegionProxyTerminated - Class in akka.contrib.pattern
 
ShardCoordinator.Internal$.ShardRegionProxyTerminated(ActorRef) - Constructor for class akka.contrib.pattern.ShardCoordinator.Internal$.ShardRegionProxyTerminated
 
ShardCoordinator.Internal$.ShardRegionRegistered - Class in akka.contrib.pattern
 
ShardCoordinator.Internal$.ShardRegionRegistered(ActorRef) - Constructor for class akka.contrib.pattern.ShardCoordinator.Internal$.ShardRegionRegistered
 
ShardCoordinator.Internal$.ShardRegionTerminated - Class in akka.contrib.pattern
 
ShardCoordinator.Internal$.ShardRegionTerminated(ActorRef) - Constructor for class akka.contrib.pattern.ShardCoordinator.Internal$.ShardRegionTerminated
 
ShardCoordinator.Internal$.ShardStopped - Class in akka.contrib.pattern
Reply to ShardCoordinator.Internal$.BeginHandOff when all entries in the shard have been terminated.
ShardCoordinator.Internal$.ShardStopped(String) - Constructor for class akka.contrib.pattern.ShardCoordinator.Internal$.ShardStopped
 
ShardCoordinator.Internal$.State - Class in akka.contrib.pattern
 
ShardCoordinator.Internal$.State() - Constructor for class akka.contrib.pattern.ShardCoordinator.Internal$.State
 
ShardCoordinator.LeastShardAllocationStrategy - Class in akka.contrib.pattern
The default implementation of ShardCoordinator.LeastShardAllocationStrategy allocates new shards to the ShardRegion with least number of previously allocated shards.
ShardCoordinator.LeastShardAllocationStrategy(int, int) - Constructor for class akka.contrib.pattern.ShardCoordinator.LeastShardAllocationStrategy
 
ShardCoordinator.RebalanceWorker - Class in akka.contrib.pattern
INTERNAL API.
ShardCoordinator.RebalanceWorker(String, ActorRef, FiniteDuration, Set<ActorRef>) - Constructor for class akka.contrib.pattern.ShardCoordinator.RebalanceWorker
 
ShardCoordinator.ShardAllocationStrategy - Interface in akka.contrib.pattern
Interface of the pluggable shard allocation and rebalancing logic used by the ShardCoordinator.
ShardCoordinatorSupervisor - Class in akka.contrib.pattern
 
ShardCoordinatorSupervisor(FiniteDuration, Props) - Constructor for class akka.contrib.pattern.ShardCoordinatorSupervisor
 
ShardCoordinatorSupervisor$ - Class in akka.contrib.pattern
 
ShardCoordinatorSupervisor$() - Constructor for class akka.contrib.pattern.ShardCoordinatorSupervisor$
 
shardId(Object) - Method in interface akka.contrib.pattern.ShardRegion.MessageExtractor
Extract the entry id from an incoming message.
sharding() - Method in class akka.contrib.pattern.ClusterShardingGuardian
 
shardRegion(String) - Method in class akka.contrib.pattern.ClusterSharding
Retrieve the actor reference of the ShardRegion actor responsible for the named entry type.
shardRegion() - Method in class akka.contrib.pattern.ClusterShardingGuardian.Started
 
shardRegion() - Method in class akka.contrib.pattern.ShardCoordinator.Internal$.Register
 
ShardRegion - Class in akka.contrib.pattern
This actor creates children entry actors on demand for the shards that it is told to be responsible for.
ShardRegion(Option<Props>, Option<String>, String, FiniteDuration, int, PartialFunction<Object, Tuple2<String, Object>>, Function1<Object, String>) - Constructor for class akka.contrib.pattern.ShardRegion
 
ShardRegion$ - Class in akka.contrib.pattern
 
ShardRegion$() - Constructor for class akka.contrib.pattern.ShardRegion$
 
ShardRegion.HandOffStopper - Class in akka.contrib.pattern
INTERNAL API.
ShardRegion.HandOffStopper(String, ActorRef, Set<ActorRef>) - Constructor for class akka.contrib.pattern.ShardRegion.HandOffStopper
 
ShardRegion.MessageExtractor - Interface in akka.contrib.pattern
Java API: Interface of functions to extract entry id, shard id, and the message to send to the entry from an incoming message.
ShardRegion.Passivate - Class in akka.contrib.pattern
If the state of the entries are persistent you may stop entries that are not used to reduce memory consumption.
ShardRegion.Passivate(Object) - Constructor for class akka.contrib.pattern.ShardRegion.Passivate
 
ShardRegion.Passivate$ - Class in akka.contrib.pattern
 
ShardRegion.Passivate$() - Constructor for class akka.contrib.pattern.ShardRegion.Passivate$
 
ShardRegion.ShardRegionCommand - Interface in akka.contrib.pattern
 
shardRegionProxy() - Method in class akka.contrib.pattern.ShardCoordinator.Internal$.RegisterProxy
 
shardResolver() - Method in class akka.contrib.pattern.ClusterShardingGuardian.Start
 
SharedLeveldbJournal - Class in akka.persistence.journal.leveldb
INTERNAL API.
SharedLeveldbJournal() - Constructor for class akka.persistence.journal.leveldb.SharedLeveldbJournal
 
SharedLeveldbJournal$ - Class in akka.persistence.journal.leveldb
 
SharedLeveldbJournal$() - Constructor for class akka.persistence.journal.leveldb.SharedLeveldbJournal$
 
SharedLeveldbStore - Class in akka.persistence.journal.leveldb
A LevelDB store that can be shared by multiple actor systems.
SharedLeveldbStore() - Constructor for class akka.persistence.journal.leveldb.SharedLeveldbStore
 
shouldDropInbound(Address, Object, String) - Method in class akka.remote.transport.FailureInjectorTransportAdapter
 
shouldDropOutbound(Address, Object, String) - Method in class akka.remote.transport.FailureInjectorTransportAdapter
 
shouldNotProcessMask() - Method in class akka.dispatch.Mailbox$
 
shouldNotProcessMask() - Static method in class akka.dispatch.Mailbox
 
shouldProcessMessage() - Method in class akka.dispatch.Mailbox
 
shouldScheduleMask() - Method in class akka.dispatch.Mailbox$
 
shouldScheduleMask() - Static method in class akka.dispatch.Mailbox
 
Shutdown() - Method in class akka.actor.AbstractFSM
Reason given when someone was calling system.stop(fsm) from outside; also applies to Stop supervision directive.
shutdown() - Method in class akka.actor.ActorSystem
Stop this actor system.
shutdown() - Method in class akka.actor.ActorSystemImpl
 
shutdown() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
Shutdown this queue collection.
shutdown() - Method in class akka.camel.internal.DefaultCamel
Stops camel and underlying camel context and template.
shutdown() - Method in class akka.cluster.Cluster
INTERNAL API.
shutdown() - Method in class akka.cluster.ClusterCoreDaemon
This method is called when a member sees itself as Exiting or Down.
shutdown() - Method in class akka.dispatch.Dispatcher
INTERNAL API
shutdown() - Method in interface akka.dispatch.ExecutorServiceDelegate
 
shutdown() - Method in class akka.dispatch.MessageDispatcher
Called one time every time an actor is detached from this dispatcher and this dispatcher has no actors left attached Must be idempotent
shutdown() - Method in interface akka.kernel.Bootable
Callback run on microkernel shutdown.
shutdown() - Method in class akka.remote.RemoteTransport
Shuts down the remoting
shutdown() - Method in class akka.remote.Remoting
 
shutdown(RoleName) - Method in interface akka.remote.testconductor.Conductor
Tell the actor system at the remote node to shut itself down.
shutdown(RoleName, boolean) - Method in interface akka.remote.testconductor.Conductor
Tell the actor system at the remote node to shut itself down without awaiting termination of remote-deployed children.
shutdown(org.jboss.netty.channel.Channel) - Method in class akka.remote.testconductor.RemoteConnection$
 
shutdown(org.jboss.netty.channel.Channel) - Static method in class akka.remote.testconductor.RemoteConnection
 
shutdown() - Method in class akka.remote.transport.AbstractTransportAdapter
 
shutdown() - Method in class akka.remote.transport.ActorTransportAdapter
 
shutdown() - Method in class akka.remote.transport.netty.NettyTransport
 
shutdown() - Method in class akka.remote.transport.TestTransport
 
shutdown() - Method in interface akka.remote.transport.Transport
Shuts down the transport layer and releases all the corresponding resources.
shutdown() - Method in class akka.testkit.CallingThreadDispatcher
 
shutdown(ActorSystem, Duration, Boolean) - Method in class akka.testkit.JavaTestKit
Shut down an actor system and wait for termination.
shutdown(ActorSystem) - Method in class akka.testkit.JavaTestKit
 
shutdown(ActorSystem, Duration) - Method in class akka.testkit.JavaTestKit
 
shutdown(ActorSystem, Boolean) - Method in class akka.testkit.JavaTestKit
 
shutdown(ActorSystem, Duration, boolean) - Method in interface akka.testkit.TestKitBase
Shut down an actor system and wait for termination.
Shutdown_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.FailType
Shutdown = 5;
ShutdownAbrupt_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.FailType
ShutdownAbrupt = 6;
shutdownActorSystem(ActorSystem, Duration, Boolean) - Static method in class akka.testkit.JavaTestKit
Shut down an actor system and wait for termination.
shutdownActorSystem(ActorSystem) - Static method in class akka.testkit.JavaTestKit
 
shutdownActorSystem(ActorSystem, Duration) - Method in class akka.testkit.JavaTestKit
 
shutdownActorSystem(ActorSystem, Boolean) - Method in class akka.testkit.JavaTestKit
 
shutdownActorSystem(ActorSystem, Duration, boolean) - Method in class akka.testkit.TestKit$
Shut down an actor system and wait for termination.
shutdownActorSystem(ActorSystem, Duration, boolean) - Static method in class akka.testkit.TestKit
Shut down an actor system and wait for termination.
ShutDownAssociation - Exception in akka.remote
INTERNAL API
ShutDownAssociation(Address, Address, Throwable) - Constructor for exception akka.remote.ShutDownAssociation
 
ShutDownAssociation$ - Class in akka.remote
 
ShutDownAssociation$() - Constructor for class akka.remote.ShutDownAssociation$
 
shutdownBehavior() - Method in class akka.remote.transport.TestTransport
The TestTransport.SwitchableLoggedBehavior for the shutdown() method.
shutdownNow() - Method in interface akka.dispatch.ExecutorServiceDelegate
 
shutdownOrExit() - Method in class akka.remote.testconductor.Terminate
 
shutdownOrExit() - Method in class akka.remote.testconductor.TerminateMsg
 
ShutdownTimeout() - Method in class akka.actor.LightArrayRevolverScheduler
 
shutdownTimeout() - Method in class akka.dispatch.Dispatcher
 
shutdownTimeout() - Method in class akka.dispatch.MessageDispatcher
When the dispatcher no longer has any actors registered, how long will it wait until it shuts itself down, defaulting to your akka configs "akka.actor.default-dispatcher.shutdown-timeout" or default specified in reference.conf
ShutdownTimeout() - Method in class akka.remote.RemoteSettings
 
shutdownTimeout() - Method in class akka.remote.testkit.MultiNodeSpec
 
shutdownTimeout() - Method in class akka.testkit.CallingThreadDispatcher
 
shuttingDown() - Method in class akka.contrib.pattern.ShardCoordinator
 
SigarMetricsCollector - Class in akka.cluster
Loads metrics through Hyperic SIGAR and JMX monitoring beans.
SigarMetricsCollector(Address, double, Object) - Constructor for class akka.cluster.SigarMetricsCollector
 
SigarMetricsCollector(ActorSystem) - Constructor for class akka.cluster.SigarMetricsCollector
This constructor is used when creating an instance from configured FQCN
signDeathPact(ActorRef) - Method in class akka.io.TcpConnection
 
simpleName(Object) - Method in class akka.event.Logging$
Returns a 'safe' getSimpleName for the provided object's Class
simpleName(Class<?>) - Method in class akka.event.Logging$
Returns a 'safe' getSimpleName for the provided Class
simpleName(Object) - Static method in class akka.event.Logging
Returns a 'safe' getSimpleName for the provided object's Class
simpleName(Class<?>) - Static method in class akka.event.Logging
Returns a 'safe' getSimpleName for the provided Class
simpleSender(Iterable<Inet.SocketOption>) - Method in class akka.io.UdpMessage$
Retrieve a reference to a &ldquo;simple sender&rdquo; actor of the UDP extension.
simpleSender() - Method in class akka.io.UdpMessage$
Retrieve a simple sender without specifying options.
simpleSender(Iterable<Inet.SocketOption>) - Static method in class akka.io.UdpMessage
Retrieve a reference to a &ldquo;simple sender&rdquo; actor of the UDP extension.
simpleSender() - Static method in class akka.io.UdpMessage
Retrieve a simple sender without specifying options.
SingleConsumerOnlyUnboundedMailbox - Class in akka.dispatch
SingleConsumerOnlyUnboundedMailbox is a high-performance, multiple producer—single consumer, unbounded MailboxType, with the drawback that you can't have multiple consumers, which rules out using it with BalancingPool (BalancingDispatcher) for instance.
SingleConsumerOnlyUnboundedMailbox() - Constructor for class akka.dispatch.SingleConsumerOnlyUnboundedMailbox
 
SingleConsumerOnlyUnboundedMailbox(ActorSystem.Settings, com.typesafe.config.Config) - Constructor for class akka.dispatch.SingleConsumerOnlyUnboundedMailbox
 
SingleConsumerOnlyUnboundedMailbox$ - Class in akka.dispatch
 
SingleConsumerOnlyUnboundedMailbox$() - Constructor for class akka.dispatch.SingleConsumerOnlyUnboundedMailbox$
 
SingleExpectDefaultTimeout() - Method in class akka.testkit.TestKitSettings
 
singleton() - Method in class akka.contrib.pattern.ClusterSingletonProxy
 
singletonPath() - Method in class akka.contrib.pattern.ClusterSingletonProxy
 
size() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
size() - Method in class akka.dispatch.sysmsg.EarliestFirstSystemMessageList
Indicates if the list is empty or not.
size() - Method in class akka.dispatch.sysmsg.LatestFirstSystemMessageList
Indicates if the list is empty or not.
size() - Method in class akka.io.Inet.SO$.ReceiveBufferSize
 
size() - Method in class akka.io.Inet.SO$.SendBufferSize
 
size() - Method in class akka.util.BoundedBlockingQueue
 
size() - Method in class akka.util.Collections.PartialImmutableValuesIterable
 
size() - Method in class akka.util.SerializedSuspendableExecutionContext
O(N)
sizeHint(int) - Method in class akka.util.ByteStringBuilder
 
sizeInner(SystemMessage, int) - Method in class akka.dispatch.sysmsg.SystemMessageList$
 
sizeInner(SystemMessage, int) - Static method in class akka.dispatch.sysmsg.SystemMessageList
 
skipMemberStatus() - Method in class akka.cluster.AutoDownBase
 
Slf4jLogger - Class in akka.event.slf4j
SLF4J logger.
Slf4jLogger() - Constructor for class akka.event.slf4j.Slf4jLogger
 
SLF4JLogging - Interface in akka.event.slf4j
Base trait for all classes that wants to be able use the SLF4J logging infrastructure.
slice(int, int) - Method in class akka.util.ByteIterator
 
slice(int, int) - Method in class akka.util.ByteString.ByteString1C
 
slice(int, int) - Method in class akka.util.ByteString
 
smallBackoffCount() - Method in class akka.remote.EndpointWriter
 
SmallestMailboxPool - Class in akka.routing
A router pool that tries to send to the non-suspended routee with fewest messages in mailbox.
SmallestMailboxPool(int, Option<Resizer>, SupervisorStrategy, String, boolean) - Constructor for class akka.routing.SmallestMailboxPool
 
SmallestMailboxPool(com.typesafe.config.Config) - Constructor for class akka.routing.SmallestMailboxPool
 
SmallestMailboxPool$ - Class in akka.routing
 
SmallestMailboxPool$() - Constructor for class akka.routing.SmallestMailboxPool$
 
SmallestMailboxRouter - Class in akka.routing
 
SmallestMailboxRouter(int, Iterable<String>, Option<Resizer>, String, SupervisorStrategy) - Constructor for class akka.routing.SmallestMailboxRouter
 
SmallestMailboxRouter(int) - Constructor for class akka.routing.SmallestMailboxRouter
Java API: Constructor that sets nrOfInstances to be created.
SmallestMailboxRouter(Iterable<String>) - Constructor for class akka.routing.SmallestMailboxRouter
Java API: Constructor that sets the routees to be used.
SmallestMailboxRouter(Resizer) - Constructor for class akka.routing.SmallestMailboxRouter
Java API: Constructor that sets the resizer to be used.
SmallestMailboxRouter$ - Class in akka.routing
 
SmallestMailboxRouter$() - Constructor for class akka.routing.SmallestMailboxRouter$
 
SmallestMailboxRoutingLogic - Class in akka.routing
Tries to send to the non-suspended routee with fewest messages in mailbox.
SmallestMailboxRoutingLogic() - Constructor for class akka.routing.SmallestMailboxRoutingLogic
 
SmallestMailboxRoutingLogic$ - Class in akka.routing
 
SmallestMailboxRoutingLogic$() - Constructor for class akka.routing.SmallestMailboxRoutingLogic$
 
smoothValue() - Method in class akka.cluster.Metric
The numerical value of the average, if defined, otherwise the latest value
snapshot() - Method in class akka.persistence.SelectedSnapshot
 
Snapshot - Class in akka.persistence.serialization
Wrapper for snapshot data.
Snapshot(Object) - Constructor for class akka.persistence.serialization.Snapshot
 
snapshot() - Method in class akka.persistence.SnapshotOffer
 
snapshot() - Method in class akka.persistence.SnapshotProtocol.LoadSnapshotResult
 
snapshot() - Method in class akka.persistence.SnapshotProtocol.SaveSnapshot
 
Snapshot$ - Class in akka.persistence.serialization
 
Snapshot$() - Constructor for class akka.persistence.serialization.Snapshot$
 
SnapshotHeader - Class in akka.persistence.serialization
INTERNAL API.
SnapshotHeader(int, Option<String>) - Constructor for class akka.persistence.serialization.SnapshotHeader
 
SnapshotHeader$ - Class in akka.persistence.serialization
 
SnapshotHeader$() - Constructor for class akka.persistence.serialization.SnapshotHeader$
 
SnapshotInterval() - Method in class akka.contrib.pattern.ClusterSharding.Settings$
 
SnapshotMetadata - Class in akka.persistence
Snapshot metadata.
SnapshotMetadata(String, long, long) - Constructor for class akka.persistence.SnapshotMetadata
 
SnapshotMetadata$ - Class in akka.persistence
 
SnapshotMetadata$() - Constructor for class akka.persistence.SnapshotMetadata$
 
SnapshotOffer - Class in akka.persistence
Offers a PersistentActor a previously saved snapshot during recovery.
SnapshotOffer(SnapshotMetadata, Object) - Constructor for class akka.persistence.SnapshotOffer
 
SnapshotOffer$ - Class in akka.persistence
 
SnapshotOffer$() - Constructor for class akka.persistence.SnapshotOffer$
 
SnapshotProtocol - Class in akka.persistence
INTERNAL API.
SnapshotProtocol() - Constructor for class akka.persistence.SnapshotProtocol
 
SnapshotProtocol$ - Class in akka.persistence
INTERNAL API.
SnapshotProtocol$() - Constructor for class akka.persistence.SnapshotProtocol$
 
SnapshotProtocol.DeleteSnapshot - Class in akka.persistence
Instructs snapshot store to delete a snapshot.
SnapshotProtocol.DeleteSnapshot(SnapshotMetadata) - Constructor for class akka.persistence.SnapshotProtocol.DeleteSnapshot
 
SnapshotProtocol.DeleteSnapshot$ - Class in akka.persistence
 
SnapshotProtocol.DeleteSnapshot$() - Constructor for class akka.persistence.SnapshotProtocol.DeleteSnapshot$
 
SnapshotProtocol.DeleteSnapshots - Class in akka.persistence
Instructs snapshot store to delete all snapshots that match criteria.
SnapshotProtocol.DeleteSnapshots(String, SnapshotSelectionCriteria) - Constructor for class akka.persistence.SnapshotProtocol.DeleteSnapshots
 
SnapshotProtocol.DeleteSnapshots$ - Class in akka.persistence
 
SnapshotProtocol.DeleteSnapshots$() - Constructor for class akka.persistence.SnapshotProtocol.DeleteSnapshots$
 
SnapshotProtocol.LoadSnapshot - Class in akka.persistence
Instructs a snapshot store to load a snapshot.
SnapshotProtocol.LoadSnapshot(String, SnapshotSelectionCriteria, long) - Constructor for class akka.persistence.SnapshotProtocol.LoadSnapshot
 
SnapshotProtocol.LoadSnapshot$ - Class in akka.persistence
 
SnapshotProtocol.LoadSnapshot$() - Constructor for class akka.persistence.SnapshotProtocol.LoadSnapshot$
 
SnapshotProtocol.LoadSnapshotResult - Class in akka.persistence
Response message to a SnapshotProtocol.LoadSnapshot message.
SnapshotProtocol.LoadSnapshotResult(Option<SelectedSnapshot>, long) - Constructor for class akka.persistence.SnapshotProtocol.LoadSnapshotResult
 
SnapshotProtocol.LoadSnapshotResult$ - Class in akka.persistence
 
SnapshotProtocol.LoadSnapshotResult$() - Constructor for class akka.persistence.SnapshotProtocol.LoadSnapshotResult$
 
SnapshotProtocol.SaveSnapshot - Class in akka.persistence
Instructs snapshot store to save a snapshot.
SnapshotProtocol.SaveSnapshot(SnapshotMetadata, Object) - Constructor for class akka.persistence.SnapshotProtocol.SaveSnapshot
 
SnapshotProtocol.SaveSnapshot$ - Class in akka.persistence
 
SnapshotProtocol.SaveSnapshot$() - Constructor for class akka.persistence.SnapshotProtocol.SaveSnapshot$
 
SnapshotSelectionCriteria - Class in akka.persistence
Selection criteria for loading and deleting snapshots.
SnapshotSelectionCriteria(long, long) - Constructor for class akka.persistence.SnapshotSelectionCriteria
 
SnapshotSelectionCriteria$ - Class in akka.persistence
 
SnapshotSelectionCriteria$() - Constructor for class akka.persistence.SnapshotSelectionCriteria$
 
snapshotSequenceNr() - Method in interface akka.persistence.Recovery
Returns lastSequenceNr.
snapshotSequenceNr() - Method in interface akka.persistence.Snapshotter
Sequence number to use when taking a snapshot.
SnapshotSerializer - Class in akka.persistence.serialization
Snapshot serializer.
SnapshotSerializer(ExtendedActorSystem) - Constructor for class akka.persistence.serialization.SnapshotSerializer
 
SnapshotSerializer$ - Class in akka.persistence.serialization
 
SnapshotSerializer$() - Constructor for class akka.persistence.serialization.SnapshotSerializer$
 
SnapshotStore - Class in akka.persistence.snapshot.japi
Java API: abstract snapshot store.
SnapshotStore() - Constructor for class akka.persistence.snapshot.japi.SnapshotStore
 
SnapshotStore - Interface in akka.persistence.snapshot
Abstract snapshot store.
snapshotStore() - Method in interface akka.persistence.snapshot.SnapshotStoreSpec
 
snapshotStore() - Method in interface akka.persistence.Snapshotter
 
snapshotStoreFor(String) - Method in class akka.persistence.Persistence
Returns a snapshot store for a processor identified by persistenceId.
SnapshotStoreSpec - Interface in akka.persistence.snapshot
This spec aims to verify custom akka-persistence SnapshotStore implementations.
SnapshotStoreSpec$ - Class in akka.persistence.snapshot
 
SnapshotStoreSpec$() - Constructor for class akka.persistence.snapshot.SnapshotStoreSpec$
 
snapshotTask() - Method in class akka.contrib.pattern.ShardCoordinator
 
Snapshotter - Interface in akka.persistence
Snapshot API on top of the internal snapshot protocol.
snapshotterId() - Method in interface akka.persistence.PersistentView
Returns viewId.
snapshotterId() - Method in interface akka.persistence.ProcessorImpl
Returns persistenceId.
snapshotterId() - Method in class akka.persistence.RequestReader
 
snapshotterId() - Method in interface akka.persistence.Snapshotter
Snapshotter id.
snapshotterId() - Method in interface akka.persistence.View
Returns viewId.
snr() - Method in class akka.persistence.journal.AsyncWriteJournal.Desequenced
 
sockAddr() - Method in interface akka.remote.testconductor.Conductor
Obtain the port to which the controller&rsquo;s socket is actually bound.
socket(SocketType.ZMQSocketType) - Method in class akka.zeromq.Context
 
SocketConnectOption - Interface in akka.zeromq
A base trait for connection options for a ZeroMQ socket
SocketMeta - Interface in akka.zeromq
Marker trait representing the base for all meta operations for a socket such as the context, listener, socket type and poller dispatcher
SocketOption - Interface in akka.zeromq
Marker trait representing the base for all socket options
SocketOptionQuery - Interface in akka.zeromq
A marker trait to group option queries together
SocketType - Class in akka.zeromq
The different socket types you can create with zeromq
SocketType() - Constructor for class akka.zeromq.SocketType
 
SocketType$ - Class in akka.zeromq
The different socket types you can create with zeromq
SocketType$() - Constructor for class akka.zeromq.SocketType$
 
SocketType.Dealer$ - Class in akka.zeromq
A dealer socket
SocketType.Dealer$() - Constructor for class akka.zeromq.SocketType.Dealer$
 
SocketType.Pair$ - Class in akka.zeromq
A Pair socket
SocketType.Pair$() - Constructor for class akka.zeromq.SocketType.Pair$
 
SocketType.Pub$ - Class in akka.zeromq
A Publisher socket
SocketType.Pub$() - Constructor for class akka.zeromq.SocketType.Pub$
 
SocketType.Pull$ - Class in akka.zeromq
A pull socket
SocketType.Pull$() - Constructor for class akka.zeromq.SocketType.Pull$
 
SocketType.Push$ - Class in akka.zeromq
A push socket
SocketType.Push$() - Constructor for class akka.zeromq.SocketType.Push$
 
SocketType.Rep$ - Class in akka.zeromq
A reply socket
SocketType.Rep$() - Constructor for class akka.zeromq.SocketType.Rep$
 
SocketType.Req$ - Class in akka.zeromq
A request socket
SocketType.Req$() - Constructor for class akka.zeromq.SocketType.Req$
 
SocketType.Router$ - Class in akka.zeromq
A router socket
SocketType.Router$() - Constructor for class akka.zeromq.SocketType.Router$
 
SocketType.Sub$ - Class in akka.zeromq
A subscriber socket
SocketType.Sub$() - Constructor for class akka.zeromq.SocketType.Sub$
 
SocketType.ZMQSocketType - Class in akka.zeromq
 
SocketType.ZMQSocketType(int) - Constructor for class akka.zeromq.SocketType.ZMQSocketType
 
SocketUtil - Class in akka.testkit
Utilities to get free socket address.
SocketUtil() - Constructor for class akka.testkit.SocketUtil
 
SocketUtil$ - Class in akka.testkit
Utilities to get free socket address.
SocketUtil$() - Constructor for class akka.testkit.SocketUtil$
 
some(A) - Method in class akka.japi.Option$
Option factory that creates Some
some(A) - Static method in class akka.japi.Option
Option factory that creates Some
sort(Iterable<Tuple2<Class<? extends Throwable>, SupervisorStrategy.Directive>>) - Method in class akka.actor.SupervisorStrategy$
Sort so that subtypes always precede their supertypes, but without obeying any order between unrelated subtypes (insert sort).
sort(Iterable<Tuple2<Class<? extends Throwable>, SupervisorStrategy.Directive>>) - Static method in class akka.actor.SupervisorStrategy
Sort so that subtypes always precede their supertypes, but without obeying any order between unrelated subtypes (insert sort).
source() - Method in class akka.testkit.DebugFilter
 
source() - Method in class akka.testkit.ErrorFilter
 
source() - Method in class akka.testkit.EventFilter
 
source() - Method in class akka.testkit.InfoFilter
 
source() - Method in class akka.testkit.WarningFilter
 
span(Function1<Object, Object>) - Method in class akka.util.ByteIterator
 
span(Function1<Object, Object>) - Method in class akka.util.ByteString
 
spawn(String, Function0<BoxedUnit>) - Method in class akka.testkit.AkkaSpec
 
spawnChildWithCapacityProtection(SelectionHandler.WorkerForCommand, int) - Method in class akka.io.SelectionHandler
 
specialHandle(Object, ActorRef) - Method in class akka.actor.DeadLetterActorRef
 
specialHandle(Object, ActorRef) - Method in class akka.actor.EmptyLocalActorRef
 
split(String, String) - Method in interface akka.actor.PathUtils
 
splitAt(int) - Method in class akka.util.ByteString
 
splitNameAndUid(String) - Method in class akka.actor.ActorCell$
 
splitNameAndUid(String) - Static method in class akka.actor.ActorCell
 
squaredIntervalSum() - Method in class akka.remote.HeartbeatHistory
 
SSLEnabledAlgorithms() - Method in class akka.remote.transport.netty.SSLSettings
 
SSLKeyPassword() - Method in class akka.remote.transport.netty.SSLSettings
 
SSLKeyStore() - Method in class akka.remote.transport.netty.SSLSettings
 
SSLKeyStorePassword() - Method in class akka.remote.transport.netty.SSLSettings
 
SSLProtocol() - Method in class akka.remote.transport.netty.SSLSettings
 
SSLRandomNumberGenerator() - Method in class akka.remote.transport.netty.SSLSettings
 
SslSettings() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
SSLSettings - Class in akka.remote.transport.netty
INTERNAL API
SSLSettings(com.typesafe.config.Config) - Constructor for class akka.remote.transport.netty.SSLSettings
 
SSLTrustStore() - Method in class akka.remote.transport.netty.SSLSettings
 
SSLTrustStorePassword() - Method in class akka.remote.transport.netty.SSLSettings
 
stackTraceFor(Throwable) - Method in class akka.event.Logging$
Returns the StackTrace for the given Throwable as a String
stackTraceFor(Throwable) - Static method in class akka.event.Logging
Returns the StackTrace for the given Throwable as a String
StandardMetrics - Class in akka.cluster
Definitions of the built-in standard metrics.
StandardMetrics() - Constructor for class akka.cluster.StandardMetrics
 
StandardMetrics$ - Class in akka.cluster
Definitions of the built-in standard metrics.
StandardMetrics$() - Constructor for class akka.cluster.StandardMetrics$
 
StandardMetrics.Cpu - Class in akka.cluster
 
StandardMetrics.Cpu(Address, long, Option<Object>, Option<Object>, int) - Constructor for class akka.cluster.StandardMetrics.Cpu
 
StandardMetrics.Cpu$ - Class in akka.cluster
 
StandardMetrics.Cpu$() - Constructor for class akka.cluster.StandardMetrics.Cpu$
 
StandardMetrics.HeapMemory - Class in akka.cluster
 
StandardMetrics.HeapMemory(Address, long, long, long, Option<Object>) - Constructor for class akka.cluster.StandardMetrics.HeapMemory
 
StandardMetrics.HeapMemory$ - Class in akka.cluster
 
StandardMetrics.HeapMemory$() - Constructor for class akka.cluster.StandardMetrics.HeapMemory$
 
StandardOutLogger() - Method in class akka.event.Logging$
 
StandardOutLogger() - Static method in class akka.event.Logging
 
start() - Method in class akka.actor.ActorSystemImpl
 
start() - Method in interface akka.actor.Cell
Start the cell: enqueued message must not be processed before this has been called.
start() - Method in interface akka.actor.dungeon.Dispatch
Start this cell, i.e.
start() - Method in class akka.actor.InternalActorRef
 
start() - Method in class akka.actor.LocalActorRef
Starts the actor after initialization.
start() - Method in interface akka.actor.MinimalActorRef
 
start() - Method in class akka.actor.RepointableActorRef
 
start() - Method in class akka.actor.UnstartedCell
 
start() - Method in class akka.camel.internal.DefaultCamel
Starts camel and underlying camel context and template.
start(String, Option<Props>, PartialFunction<Object, Tuple2<String, Object>>, Function1<Object, String>, ShardCoordinator.ShardAllocationStrategy) - Method in class akka.contrib.pattern.ClusterSharding
Scala API: Register a named entry type by defining the Props of the entry actor and functions to extract entry and shard identifier from messages.
start(String, Option<Props>, PartialFunction<Object, Tuple2<String, Object>>, Function1<Object, String>) - Method in class akka.contrib.pattern.ClusterSharding
Register a named entry type by defining the Props of the entry actor and functions to extract entry and shard identifier from messages.
start(String, Props, ShardRegion.MessageExtractor, ShardCoordinator.ShardAllocationStrategy) - Method in class akka.contrib.pattern.ClusterSharding
Java API: Register a named entry type by defining the Props of the entry actor and functions to extract entry and shard identifier from messages.
start(String, Props, ShardRegion.MessageExtractor) - Method in class akka.contrib.pattern.ClusterSharding
Java API: Register a named entry type by defining the Props of the entry actor and functions to extract entry and shard identifier from messages.
start(org.osgi.framework.BundleContext) - Method in class akka.osgi.ActorSystemActivator
Sets up a new ActorSystem
start() - Method in class akka.remote.RemoteActorRef
 
start() - Method in class akka.remote.RemoteTransport
Start up the transport, i.e.
start() - Method in class akka.remote.Remoting
 
start() - Method in class akka.routing.RoutedActorCell
 
startAndStopDuration() - Method in interface akka.testkit.WatchedByCoroner
 
startClient(RoleName, InetSocketAddress) - Method in interface akka.remote.testconductor.Player
Connect to the conductor on the given port (the host is taken from setting akka.testconductor.host).
startController(int, RoleName, InetSocketAddress) - Method in interface akka.remote.testconductor.Conductor
Start the Controller, which in turn will bind to a TCP port as specified in the akka.testconductor.port config property, where 0 denotes automatic allocation.
startCoordinator() - Method in class akka.contrib.pattern.ShardCoordinatorSupervisor
 
startCoroner() - Method in interface akka.testkit.WatchedByCoroner
 
startDefaultLoggers(ActorSystemImpl) - Method in interface akka.event.LoggingBus
Internal Akka use only
startHash(int) - Method in class akka.routing.MurmurHash$
Begin a new hash with a seed value.
startHash(int) - Static method in class akka.routing.MurmurHash
Begin a new hash with a seed value.
startMagicA() - Method in class akka.routing.MurmurHash$
The initial magic integers in the first stream.
startMagicA() - Static method in class akka.routing.MurmurHash
The initial magic integers in the first stream.
startMagicB() - Method in class akka.routing.MurmurHash$
The initial magic integer in the second stream.
startMagicB() - Static method in class akka.routing.MurmurHash
The initial magic integer in the second stream.
startNewSystem() - Method in class akka.remote.testkit.MultiNodeSpec
This method starts a new ActorSystem with the same configuration as the previous one on the current node, including deployments.
startReadBehind() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
startStdoutLogger(ActorSystem.Settings) - Method in interface akka.event.LoggingBus
Internal Akka use only
startsWith(String) - Method in class akka.testkit.JavaTestKit.EventFilter
 
startTick() - Method in class akka.actor.LightArrayRevolverScheduler
Replaceable for testing.
startTime() - Method in class akka.actor.ActorSystem
Start-up time in milliseconds since the epoch.
startup() - Method in interface akka.kernel.Bootable
Callback run on microkernel startup.
StartupTimeout() - Method in class akka.remote.RemoteSettings
 
startWith(S, D) - Method in class akka.actor.AbstractFSM
Set initial state.
startWith(S, D, FiniteDuration) - Method in class akka.actor.AbstractFSM
Set initial state.
startWith(S, D, Option<FiniteDuration>) - Method in interface akka.actor.FSM
Set initial state.
stash(SystemMessage) - Method in class akka.actor.ActorCell
 
Stash - Interface in akka.actor
The Stash trait enables an actor to temporarily stash away messages that can not or should not be handled using the actor's current behavior.
stash() - Method in interface akka.actor.StashSupport
Adds the current message (the message that the actor received last) to the actor's stash.
stashedInbound() - Method in class akka.remote.EndpointManager
 
StashFactory - Interface in akka.actor
INTERNAL API.
StashOverflowException - Exception in akka.actor
Is thrown when the size of the Stash exceeds the capacity of the Stash
StashOverflowException(String, Throwable) - Constructor for exception akka.actor.StashOverflowException
 
StashOverflowException$ - Class in akka.actor
 
StashOverflowException$() - Constructor for class akka.actor.StashOverflowException$
 
StashSupport - Interface in akka.actor
INTERNAL API.
StashWhenFailed - Interface in akka.dispatch.sysmsg
INTERNAL API
StashWhenWaitingForChildren - Interface in akka.dispatch.sysmsg
INTERNAL API
state() - Method in class akka.actor.FSM.CurrentState
 
state() - Method in class akka.cluster.Cluster
Current snapshot state of the cluster.
state() - Method in class akka.cluster.ClusterHeartbeatSender
 
state() - Method in class akka.cluster.ClusterReadView
 
state(S, S, FI.UnitApplyVoid) - Method in class akka.japi.pf.FSMTransitionHandlerBuilder
Add a case statement that matches on a from state and a to state.
state(S, S, FI.UnitApply2<S, S>) - Method in class akka.japi.pf.FSMTransitionHandlerBuilder
Add a case statement that matches on a from state and a to state.
stateData() - Method in class akka.actor.FSM.Event
 
stateData() - Method in class akka.actor.FSM.LogEntry
 
stateData() - Method in class akka.actor.FSM.State
 
stateData() - Method in interface akka.actor.FSM
 
stateData() - Method in class akka.actor.FSM.StopEvent
 
stateData() - Method in class akka.testkit.TestFSMRef
Get current state data of this FSM.
stateFunctions() - Method in interface akka.actor.FSM
 
stateName() - Method in class akka.actor.FSM.LogEntry
 
stateName() - Method in class akka.actor.FSM.State
 
stateName() - Method in interface akka.actor.FSM
 
stateName() - Method in class akka.testkit.TestFSMRef
Get current state name of this FSM.
states() - Method in interface akka.actor.LoggingFSM
 
StateTimeout() - Method in interface akka.actor.FSM
This case object is received in case of a state timeout.
stateTimeouts() - Method in interface akka.actor.FSM
 
stats() - Method in interface akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer
 
stats() - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
 
stats() - Method in interface akka.actor.dungeon.ChildrenContainer
 
stats() - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
 
stats(String) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
statsEnabled() - Method in class akka.cluster.ClusterCoreDaemon
 
Status - Class in akka.actor
Classes for passing status back to the sender.
Status() - Constructor for class akka.actor.Status
 
status() - Method in class akka.actor.Status.Success
 
status() - Method in class akka.cluster.ClusterReadView
Member status for this node (MemberStatus).
status() - Method in class akka.cluster.Member
 
status() - Method in class akka.cluster.Reachability.Record
 
status(UniqueAddress, UniqueAddress) - Method in class akka.cluster.Reachability
 
status(UniqueAddress) - Method in class akka.cluster.Reachability
 
status() - Method in class akka.remote.EndpointManager.ManagementCommandAck
 
Status$ - Class in akka.actor
Classes for passing status back to the sender.
Status$() - Constructor for class akka.actor.Status$
 
Status.Failure - Class in akka.actor
This class/message type is preferably used to indicate failure of some operation performed.
Status.Failure(Throwable) - Constructor for class akka.actor.Status.Failure
 
Status.Failure$ - Class in akka.actor
 
Status.Failure$() - Constructor for class akka.actor.Status.Failure$
 
Status.Status - Interface in akka.actor
 
Status.Success - Class in akka.actor
This class/message type is preferably used to indicate success of some operation performed.
Status.Success(Object) - Constructor for class akka.actor.Status.Success
 
Status.Success$ - Class in akka.actor
 
Status.Success$() - Constructor for class akka.actor.Status.Success$
 
STATUS_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
STATUS_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
statusFuture() - Method in class akka.remote.transport.netty.ClientHandler
 
statusPromise() - Method in class akka.remote.transport.ActorTransportAdapter.AssociateUnderlying
 
statusPromise() - Method in class akka.remote.transport.AkkaProtocolTransport.AssociateUnderlyingRefuseUid
 
statusPromise() - Method in class akka.remote.transport.netty.ClientHandler
 
statusPromise() - Method in class akka.remote.transport.ProtocolStateActor.OutboundUnassociated
 
statusPromise() - Method in class akka.remote.transport.ProtocolStateActor.OutboundUnderlyingAssociated
 
statusPromise() - Method in class akka.remote.transport.ThrottlerManager.AssociateResult
 
stay() - Method in interface akka.actor.FSM
Produce "empty" transition descriptor.
stdDeviation() - Method in class akka.remote.HeartbeatHistory
 
StdoutLogLevel() - Method in class akka.actor.ActorSystem.Settings
 
stop(ActorRef) - Method in interface akka.actor.ActorRefFactory
Stop the actor pointed to by the given ActorRef; this is an asynchronous operation, i.e.
stop(ActorRef) - Method in class akka.actor.ActorSystemImpl
 
stop() - Method in interface akka.actor.Cell
Recursively terminate this actor and all its children.
Stop() - Method in interface akka.actor.dsl.Creators.Act
 
stop(ActorRef) - Method in interface akka.actor.dungeon.Children
 
stop() - Method in interface akka.actor.dungeon.Dispatch
 
stop() - Method in interface akka.actor.FSM
Produce change descriptor to stop this FSM actor with reason "Normal".
stop(FSM.Reason) - Method in interface akka.actor.FSM
Produce change descriptor to stop this FSM actor including specified reason.
stop(FSM.Reason, D) - Method in interface akka.actor.FSM
Produce change descriptor to stop this FSM actor including specified reason.
stop() - Method in class akka.actor.InternalActorRef
 
stop() - Method in class akka.actor.LocalActorRef
Shuts down the actor and its message queue
stop() - Method in interface akka.actor.MinimalActorRef
 
stop() - Method in class akka.actor.RepointableActorRef
 
stop() - Method in class akka.actor.SupervisorStrategy$
Java API: Returning this directive stops the Actor
stop() - Static method in class akka.actor.SupervisorStrategy
Java API: Returning this directive stops the Actor
stop(Object) - Method in interface akka.actor.TypedActorFactory
Stops the underlying ActorRef for the supplied TypedActor proxy, if any, returns whether it could find the find the ActorRef or not
stop() - Method in class akka.actor.UnstartedCell
 
stop(FSM.Reason, FI.UnitApply2<S, D>) - Method in class akka.japi.pf.FSMStopBuilder
Add a case statement that matches on an FSM.Reason.
stop(Class<P>, FI.UnitApply3<P, S, D>) - Method in class akka.japi.pf.FSMStopBuilder
Add a case statement that matches on a reason type.
stop(Class<P>, FI.TypedPredicate<P>, FI.UnitApply3<P, S, D>) - Method in class akka.japi.pf.FSMStopBuilder
Add a case statement that matches on a reason type and a predicate.
stop(org.osgi.framework.BundleContext) - Method in class akka.osgi.ActorSystemActivator
Shuts down the ActorSystem when the bundle is stopped and, if necessary, unregisters a service registration.
stop() - Method in class akka.pattern.PromiseActorRef
 
stop() - Method in class akka.remote.RemoteActorRef
 
StopChild - Class in akka.actor
Internal Akka use only, used in implementation of system.stop(child).
StopChild(ActorRef) - Constructor for class akka.actor.StopChild
 
StopChild$ - Class in akka.actor
 
StopChild$() - Constructor for class akka.actor.StopChild$
 
stopCoroner() - Method in interface akka.testkit.WatchedByCoroner
 
stopDefaultLoggers(ActorSystem) - Method in interface akka.event.LoggingBus
Internal Akka use only
StopEvent() - Method in interface akka.actor.FSM
 
stopIfAllRouteesRemoved() - Method in class akka.routing.RouterActor
 
stopMessage() - Method in class akka.contrib.pattern.ShardRegion.Passivate
 
stoppingShard() - Method in class akka.contrib.pattern.ShardCoordinator.RebalanceWorker
 
stoppingStrategy() - Method in class akka.actor.SupervisorStrategy$
This strategy resembles Erlang in that failing children are always terminated (one-for-one).
stoppingStrategy() - Static method in class akka.actor.SupervisorStrategy
This strategy resembles Erlang in that failing children are always terminated (one-for-one).
StoppingSupervisorStrategy - Class in akka.actor
 
StoppingSupervisorStrategy() - Constructor for class akka.actor.StoppingSupervisorStrategy
 
stopReason() - Method in class akka.actor.FSM.State
 
stopReason() - Method in class akka.remote.EndpointWriter
 
stopRouterWhenAllRouteesRemoved() - Method in interface akka.cluster.routing.ClusterRouterConfigBase
 
stopRouterWhenAllRouteesRemoved() - Method in interface akka.routing.Pool
 
stopRouterWhenAllRouteesRemoved() - Method in interface akka.routing.RouterConfig
 
stopScheduler() - Method in class akka.actor.ActorSystemImpl
 
stopSeedNodeProcess() - Method in class akka.cluster.ClusterCoreDaemon
 
stopWith(TcpConnection.CloseInformation) - Method in class akka.io.TcpConnection
 
store() - Method in interface akka.persistence.journal.AsyncWriteProxy
 
StreamingCache() - Method in class akka.camel.CamelSettings
enables or disables streamingCache on the Camel Context
streamMustContain(InputStream, String) - Method in class akka.actor.mailbox.DurableMailboxSpec
 
stringHash(String) - Method in class akka.routing.MurmurHash$
Compute a high-quality hash of a string
stringHash(String) - Static method in class akka.routing.MurmurHash
Compute a high-quality hash of a string
SubchannelClassification - Interface in akka.event
Classification which respects relationships between channels: subscribing to one channel automatically and idempotently subscribes to all sub-channels.
SubchannelEventBus<E,S,C> - Class in akka.event.japi
See documentation for SubchannelClassification E is the Event type S is the Subscriber type C is the Classifier type
SubchannelEventBus() - Constructor for class akka.event.japi.SubchannelEventBus
 
subclassification() - Method in class akka.event.EventStream
 
subclassification() - Method in class akka.event.japi.SubchannelEventBus
The logic to form sub-class hierarchy
subclassification() - Method in interface akka.event.SubchannelClassification
The logic to form sub-class hierarchy
Subclassification<K> - Interface in akka.util
Typeclass which describes a classification hierarchy.
SubclassifiedIndex<K,V> - Class in akka.util
Mutable index which respects sub-class relationships between keys:
SubclassifiedIndex(Subclassification<K>) - Constructor for class akka.util.SubclassifiedIndex
 
SubclassifiedIndex$ - Class in akka.util
 
SubclassifiedIndex$() - Constructor for class akka.util.SubclassifiedIndex$
 
SubclassifiedIndex.Nonroot<K,V> - Class in akka.util
 
SubclassifiedIndex.Nonroot(SubclassifiedIndex<K, V>, K, Set<V>, Subclassification<K>) - Constructor for class akka.util.SubclassifiedIndex.Nonroot
 
subject() - Method in class akka.cluster.Reachability.Record
 
SUBJECTREACHABILITY_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
subkeys() - Method in class akka.util.SubclassifiedIndex
 
submit(Callable<T>) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
submit(Runnable, T) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
submit(Runnable) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
subscribe(ActorRef, Class<?>...) - Method in class akka.cluster.Cluster
Subscribe to one or more cluster domain events.
subscribe(ActorRef, ClusterEvent.SubscriptionInitialStateMode, Class<?>...) - Method in class akka.cluster.Cluster
Subscribe to one or more cluster domain events.
subscribe(ActorRef, Seq<Class<?>>) - Method in class akka.cluster.Cluster
Subscribe to one or more cluster domain events.
subscribe(ActorRef, ClusterEvent.SubscriptionInitialStateMode, Seq<Class<?>>) - Method in class akka.cluster.Cluster
Subscribe to one or more cluster domain events.
subscribe(ActorRef, ClusterEvent.SubscriptionInitialStateMode, Set<Class<?>>) - Method in class akka.cluster.ClusterDomainEventPublisher
 
subscribe() - Method in class akka.contrib.pattern.DistributedPubSubMediator.SubscribeAck
 
subscribe(ActorRef, ActorRef) - Method in interface akka.event.ActorClassification
 
subscribe(ActorRef) - Method in class akka.event.AddressTerminatedTopic
 
subscribe(EventBus, EventBus) - Method in interface akka.event.EventBus
 
subscribe(ActorRef, Class<?>) - Method in class akka.event.EventStream
 
subscribe(ActorRef, ActorRef) - Method in class akka.event.japi.ActorEventBus
 
subscribe(S, C) - Method in interface akka.event.japi.EventBus
Attempts to register the subscriber to the specified Classifier
subscribe(S, C) - Method in class akka.event.japi.LookupEventBus
 
subscribe(S, C) - Method in class akka.event.japi.ScanningEventBus
 
subscribe(S, C) - Method in class akka.event.japi.SubchannelEventBus
 
subscribe(LookupClassification, LookupClassification) - Method in interface akka.event.LookupClassification
 
subscribe(ScanningClassification, ScanningClassification) - Method in interface akka.event.ScanningClassification
 
subscribe(SubchannelClassification, SubchannelClassification) - Method in interface akka.event.SubchannelClassification
 
subscribe(ActorRef, ClassTag<T>) - Method in interface akka.persistence.PluginSpec
 
Subscribe - Class in akka.zeromq
The Subscribe option establishes a new message filter on a akka.zeromq.SocketType.Pub socket.
Subscribe(ByteString) - Constructor for class akka.zeromq.Subscribe
 
Subscribe(String) - Constructor for class akka.zeromq.Subscribe
 
Subscribe$ - Class in akka.zeromq
 
Subscribe$() - Constructor for class akka.zeromq.Subscribe$
 
subscribeAddressTerminated() - Method in interface akka.actor.dungeon.DeathWatch
 
subscriber() - Method in class akka.cluster.InternalClusterAction.Subscribe
 
subscriber() - Method in class akka.cluster.InternalClusterAction.Unsubscribe
 
subscriber() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Internal$.Subscribed
 
subscriber() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Internal$.Unsubscribed
 
subscribers() - Method in interface akka.contrib.pattern.DistributedPubSubMediator.Internal$.TopicLike
 
subscribers() - Method in interface akka.event.LookupClassification
 
subscribers() - Method in interface akka.event.ScanningClassification
 
subscriptions() - Method in interface akka.event.SubchannelClassification
 
Succeeded_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
Succeeded = 3;
success() - Method in class akka.remote.testconductor.BarrierResult
 
successful(T) - Method in class akka.dispatch.Futures$
Creates an already completed Promise with the specified result
successful(T) - Static method in class akka.dispatch.Futures
Creates an already completed Promise with the specified result
Supervise - Class in akka.dispatch.sysmsg
INTERNAL API
Supervise(ActorRef, boolean) - Constructor for class akka.dispatch.sysmsg.Supervise
 
Supervise$ - Class in akka.dispatch.sysmsg
 
Supervise$() - Constructor for class akka.dispatch.sysmsg.Supervise$
 
superviseWith(SupervisorStrategy) - Method in interface akka.actor.dsl.Creators.Act
Set the supervisor strategy of this actor, i.e.
supervisor() - Method in class akka.actor.RepointableActorRef
 
supervisor() - Method in class akka.actor.UnstartedCell
 
supervisor() - Method in interface akka.camel.Camel
INTERNAL API Returns the camel supervisor actor.
supervisor() - Method in class akka.camel.internal.DefaultCamel
 
supervisor() - Method in class akka.remote.DaemonMsgCreate
 
supervisor() - Method in class akka.remote.RemoteDeploymentWatcher.WatchRemote
 
SUPERVISOR_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DaemonMsgCreateData
 
supervisors() - Method in class akka.remote.RemoteDeploymentWatcher
 
supervisorStrategy() - Method in interface akka.actor.Actor
User overridable definition the strategy to use for supervising child actors.
supervisorStrategy() - Method in interface akka.actor.dsl.Creators.Act
 
SupervisorStrategy - Class in akka.actor
An Akka SupervisorStrategy is the policy to apply for crashing children.
SupervisorStrategy() - Constructor for class akka.actor.SupervisorStrategy
 
supervisorStrategy() - Method in interface akka.actor.TypedActor.Supervisor
User overridable definition the strategy to use for supervising child actors.
supervisorStrategy() - Method in class akka.actor.TypedActor.TypedActor
 
supervisorStrategy() - Method in class akka.actor.UntypedActor
User overridable definition the strategy to use for supervising child actors.
supervisorStrategy() - Method in class akka.camel.internal.CamelSupervisor
 
supervisorStrategy() - Method in class akka.camel.internal.Registry
 
supervisorStrategy() - Method in class akka.cluster.ClusterCoreSupervisor
 
supervisorStrategy() - Method in class akka.cluster.routing.AdaptiveLoadBalancingPool
 
supervisorStrategy() - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
 
supervisorStrategy() - Method in class akka.cluster.routing.ClusterRouterConfig
 
supervisorStrategy() - Method in class akka.cluster.routing.ClusterRouterPool
 
supervisorStrategy() - Method in class akka.contrib.pattern.ReliableProxy
 
supervisorStrategy() - Method in class akka.io.SelectionHandler.SelectorBasedManager
 
supervisorStrategy() - Method in class akka.io.SelectionHandler
 
supervisorStrategy() - Method in class akka.io.TcpListener
 
supervisorStrategy() - Method in class akka.remote.EndpointManager
 
supervisorStrategy() - Method in class akka.remote.EndpointWriter
 
supervisorStrategy() - Method in class akka.remote.ReliableDeliverySupervisor
 
supervisorStrategy() - Method in class akka.remote.Remoting.TransportSupervisor
 
supervisorStrategy() - Method in class akka.remote.routing.RemoteRouterConfig
 
supervisorStrategy() - Method in class akka.remote.testconductor.Controller
 
supervisorStrategy() - Method in class akka.remote.transport.AkkaProtocolManager
 
supervisorStrategy() - Method in class akka.routing.BalancingPool
 
supervisorStrategy() - Method in class akka.routing.BroadcastPool
 
supervisorStrategy() - Method in class akka.routing.BroadcastRouter
 
supervisorStrategy() - Method in class akka.routing.ConsistentHashingPool
 
supervisorStrategy() - Method in class akka.routing.ConsistentHashingRouter
 
supervisorStrategy() - Method in class akka.routing.FromConfig
 
supervisorStrategy() - Method in interface akka.routing.Pool
SupervisorStrategy for the head actor, i.e.
supervisorStrategy() - Method in class akka.routing.RandomPool
 
supervisorStrategy() - Method in class akka.routing.RandomRouter
 
supervisorStrategy() - Method in class akka.routing.RoundRobinPool
 
supervisorStrategy() - Method in class akka.routing.RoundRobinRouter
 
supervisorStrategy() - Method in class akka.routing.RouterPoolActor
 
supervisorStrategy() - Method in class akka.routing.ScatterGatherFirstCompletedPool
 
supervisorStrategy() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
supervisorStrategy() - Method in class akka.routing.SmallestMailboxPool
 
supervisorStrategy() - Method in class akka.routing.SmallestMailboxRouter
 
supervisorStrategy() - Method in class akka.routing.TailChoppingPool
 
SupervisorStrategy$ - Class in akka.actor
 
SupervisorStrategy$() - Constructor for class akka.actor.SupervisorStrategy$
 
SupervisorStrategy.Directive - Interface in akka.actor
 
SupervisorStrategy.Escalate$ - Class in akka.actor
Escalates the failure to the supervisor of the supervisor, by rethrowing the cause of the failure, i.e.
SupervisorStrategy.Escalate$() - Constructor for class akka.actor.SupervisorStrategy.Escalate$
 
SupervisorStrategy.Restart$ - Class in akka.actor
Discards the old Actor instance and replaces it with a new, then resumes message processing.
SupervisorStrategy.Restart$() - Constructor for class akka.actor.SupervisorStrategy.Restart$
 
SupervisorStrategy.Resume$ - Class in akka.actor
Resumes message processing for the failed Actor
SupervisorStrategy.Resume$() - Constructor for class akka.actor.SupervisorStrategy.Resume$
 
SupervisorStrategy.Stop$ - Class in akka.actor
Stops the Actor
SupervisorStrategy.Stop$() - Constructor for class akka.actor.SupervisorStrategy.Stop$
 
SupervisorStrategyClass() - Method in class akka.actor.ActorSystem.Settings
 
SupervisorStrategyConfigurator - Interface in akka.actor
Implement this interface in order to configure the supervisorStrategy for the top-level guardian actor (/user).
SupervisorStrategyLowPriorityImplicits - Interface in akka.actor
 
SuppressedDeadLetter - Class in akka.actor
Similar to DeadLetter with the slight twist of NOT being logged by the default dead letters listener.
SuppressedDeadLetter(DeadLetterSuppression, ActorRef, ActorRef) - Constructor for class akka.actor.SuppressedDeadLetter
 
SuppressedDeadLetter$ - Class in akka.actor
 
SuppressedDeadLetter$() - Constructor for class akka.actor.SuppressedDeadLetter$
 
suspend() - Method in interface akka.actor.Cell
Recursively suspend this actor and all its children.
suspend() - Method in interface akka.actor.dungeon.Dispatch
 
suspend() - Method in class akka.actor.InternalActorRef
 
suspend() - Method in class akka.actor.LocalActorRef
Suspends the actor so that it will not process messages until resumed.
suspend() - Method in interface akka.actor.MinimalActorRef
 
suspend() - Method in class akka.actor.RepointableActorRef
 
suspend() - Method in class akka.actor.UnstartedCell
 
suspend() - Method in class akka.dispatch.Mailbox
Increment the suspend count by one.
suspend(ActorCell) - Method in class akka.dispatch.MessageDispatcher
After the call to this method, the dispatcher mustn't begin any new message processing for the specified reference
Suspend - Class in akka.dispatch.sysmsg
INTERNAL API
Suspend() - Constructor for class akka.dispatch.sysmsg.Suspend
 
suspend() - Method in class akka.remote.RemoteActorRef
 
suspend(ActorCell) - Method in class akka.testkit.CallingThreadDispatcher
 
suspend() - Method in class akka.util.SerializedSuspendableExecutionContext
Suspends execution of tasks until resume is called, this operation is idempotent.
Suspend$ - Class in akka.dispatch.sysmsg
 
Suspend$() - Constructor for class akka.dispatch.sysmsg.Suspend$
 
suspendChildren(Set<ActorRef>) - Method in interface akka.actor.dungeon.Children
 
suspendCount() - Method in class akka.dispatch.Mailbox
 
Suspended() - Method in class akka.util.SerializedSuspendableExecutionContext$
 
Suspended() - Static method in class akka.util.SerializedSuspendableExecutionContext
 
SuspendedState() - Method in class akka.actor.ActorCell$
 
SuspendedState() - Static method in class akka.actor.ActorCell
 
SuspendedWaitForChildrenState() - Method in class akka.actor.ActorCell$
 
SuspendedWaitForChildrenState() - Static method in class akka.actor.ActorCell
 
suspendMask() - Method in class akka.dispatch.Mailbox$
 
suspendMask() - Static method in class akka.dispatch.Mailbox
 
suspendNonRecursive() - Method in interface akka.actor.dungeon.FaultHandling
 
suspendReading(TcpConnection.ConnectionInfo) - Method in class akka.io.TcpConnection
 
suspendReading() - Method in class akka.io.TcpMessage$
Sending this command to the connection actor will disable reading from the TCP socket.
suspendReading() - Static method in class akka.io.TcpMessage
Sending this command to the connection actor will disable reading from the TCP socket.
suspendReading() - Method in class akka.io.UdpConnectedMessage$
Send this message to a listener actor (which sent a Udp.Bound message) to have it stop reading datagrams from the network.
suspendReading() - Static method in class akka.io.UdpConnectedMessage
Send this message to a listener actor (which sent a Udp.Bound message) to have it stop reading datagrams from the network.
suspendReading() - Method in class akka.io.UdpMessage$
Send this message to a listener actor (which sent a Udp.Bound message) to have it stop reading datagrams from the network.
suspendReading() - Static method in class akka.io.UdpMessage
Send this message to a listener actor (which sent a Udp.Bound message) to have it stop reading datagrams from the network.
suspendSwitch() - Method in class akka.testkit.CallingThreadMailbox
 
suspendUnit() - Method in class akka.dispatch.Mailbox$
 
suspendUnit() - Static method in class akka.dispatch.Mailbox
 
Swap - Class in akka.zeromq
The Swap option shall set the disk offload (swap) size for the specified socket.
Swap(long) - Constructor for class akka.zeromq.Swap
 
swap() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its swap configuration.
swap() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its swap configuration.
Swap$ - Class in akka.zeromq
Gets the Swap
Swap$() - Constructor for class akka.zeromq.Swap$
 
swapCell(Cell) - Method in class akka.actor.RepointableActorRef
 
swapChildrenRefs(ChildrenContainer, ChildrenContainer) - Method in interface akka.actor.dungeon.Children
 
swapLookup(Cell) - Method in class akka.actor.RepointableActorRef
 
swapMailbox(Mailbox) - Method in interface akka.actor.dungeon.Dispatch
 
Switch - Class in akka.util
An atomic switch that can be either on or off
Switch(boolean) - Constructor for class akka.util.Switch
 
Switch$ - Class in akka.util
 
Switch$() - Constructor for class akka.util.Switch$
 
switchOff(Function0<BoxedUnit>) - Method in class akka.util.Switch
Executes the provided action if the lock is on under a lock, so be _very_ careful with longrunning/blocking operations in it Only executes the action if the switch is on, and switches it off immediately after obtaining the lock Will switch it back on if the provided action throws an exception
switchOff() - Method in class akka.util.Switch
Switches the switch off (if on), uses locking
switchOn(Function0<BoxedUnit>) - Method in class akka.util.Switch
Executes the provided action if the lock is off under a lock, so be _very_ careful with longrunning/blocking operations in it Only executes the action if the switch is off, and switches it on immediately after obtaining the lock Will switch it back off if the provided action throws an exception
switchOn() - Method in class akka.util.Switch
Switches the switch on (if off), uses locking
symmetricHash(TraversableOnce<T>, int) - Method in class akka.routing.MurmurHash$
Compute a hash that is symmetric in its arguments--that is, where the order of appearance of elements does not matter.
symmetricHash(TraversableOnce<T>, int) - Static method in class akka.routing.MurmurHash
Compute a hash that is symmetric in its arguments--that is, where the order of appearance of elements does not matter.
synchronousQueue(boolean) - Method in class akka.dispatch.ThreadPoolConfig$
 
synchronousQueue(boolean) - Static method in class akka.dispatch.ThreadPoolConfig
 
SyncJournal() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
syncJournal() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
syncJournal() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
SyncWriteJournal - Class in akka.persistence.journal.japi
Java API: abstract journal, optimized for synchronous writes.
SyncWriteJournal() - Constructor for class akka.persistence.journal.japi.SyncWriteJournal
 
SyncWriteJournal - Interface in akka.persistence.journal
Abstract journal, optimized for synchronous writes.
SysMsgAckTimeout() - Method in class akka.remote.RemoteSettings
 
SysMsgBufferSize() - Method in class akka.remote.RemoteSettings
 
SysResendLimit() - Method in class akka.remote.RemoteSettings
 
SysResendTimeout() - Method in class akka.remote.RemoteSettings
 
system() - Method in class akka.actor.ActorCell
 
system() - Method in interface akka.actor.ActorContext
The system that the actor belongs to.
system() - Method in class akka.actor.ActorDSL.Extension
 
system() - Method in class akka.actor.Address
 
system() - Method in interface akka.actor.Cell
The system within which this Cell lives.
system() - Method in class akka.actor.mailbox.DurableMessageQueue
 
system() - Method in class akka.actor.RepointableActorRef
 
system() - Method in class akka.actor.TypedActorExtension
 
system() - Method in class akka.actor.UnstartedCell
 
system() - Method in interface akka.camel.Camel
INTERNAL API Returns the associated ActorSystem.
system() - Method in class akka.camel.internal.DefaultCamel
 
system() - Method in class akka.cluster.Cluster
 
system() - Method in class akka.cluster.protobuf.ClusterMessageSerializer
 
system() - Method in class akka.cluster.routing.AdaptiveLoadBalancingRoutingLogic
 
system() - Method in class akka.contrib.mailbox.PeekMailboxExtension
 
system() - Method in class akka.contrib.pattern.protobuf.DistributedPubSubMessageSerializer
 
system() - Method in interface akka.persistence.journal.JournalSpec
 
system() - Method in class akka.persistence.Persistence
 
system() - Method in class akka.persistence.serialization.MessageSerializer
 
system() - Method in interface akka.persistence.snapshot.SnapshotStoreSpec
 
system() - Method in class akka.remote.AddressUidExtension
 
system() - Method in class akka.remote.RemoteTransport
 
system() - Method in class akka.remote.serialization.DaemonMsgCreateSerializer
 
system() - Method in class akka.remote.serialization.MessageContainerSerializer
 
system() - Method in class akka.remote.testconductor.TestConductorExt
 
system() - Method in class akka.remote.transport.netty.NettyTransport
 
system() - Method in class akka.routing.ConsistentHashingRoutingLogic
 
system() - Method in class akka.serialization.JavaSerializer
 
system() - Method in class akka.serialization.Serialization.Information
 
system() - Method in class akka.serialization.Serialization
 
system() - Method in class akka.testkit.CallingThreadMailbox
 
system() - Method in class akka.testkit.DefaultTimeoutSpec
 
system() - Method in class akka.testkit.ImplicitSenderSpec
 
system() - Method in class akka.testkit.TestKit
 
system() - Method in interface akka.testkit.TestKitBase
 
SYSTEM_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
SYSTEM_FIELD_NUMBER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
SYSTEM_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Address
 
SYSTEM_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AddressData
 
systemActorOf(Props, String) - Method in class akka.actor.ActorSystemImpl
 
systemActorOf(Props, String) - Method in class akka.actor.ExtendedActorSystem
Create an actor in the "/system" namespace.
systemDispatch(ActorCell, SystemMessage) - Method in class akka.dispatch.Dispatcher
INTERNAL API
systemDispatch(ActorCell, SystemMessage) - Method in class akka.dispatch.MessageDispatcher
Will be called when the dispatcher is to queue an invocation for execution
systemDispatch(ActorCell, SystemMessage) - Method in class akka.testkit.CallingThreadDispatcher
 
systemDrain(LatestFirstSystemMessageList) - Method in interface akka.dispatch.DefaultSystemMessageQueue
 
systemDrain(LatestFirstSystemMessageList) - Method in interface akka.dispatch.SystemMessageQueue
Dequeue all messages from system queue and return them as single-linked list.
systemEnqueue(ActorRef, SystemMessage) - Method in interface akka.dispatch.DefaultSystemMessageQueue
 
systemEnqueue(ActorRef, SystemMessage) - Method in interface akka.dispatch.SystemMessageQueue
Enqueue a new system message, e.g.
systemGuardian() - Method in interface akka.actor.ActorRefProvider
Reference to the supervisor used for all top-level system actors.
systemGuardian() - Method in class akka.actor.ActorSystemImpl
 
systemGuardian() - Method in class akka.actor.ExtendedActorSystem
The top-level supervisor of all system-internal services like logging.
systemGuardian() - Method in class akka.actor.LocalActorRefProvider
 
SystemGuardian - Class in akka.actor
INTERNAL API
SystemGuardian() - Constructor for class akka.actor.SystemGuardian
 
systemGuardian() - Method in class akka.remote.RemoteActorRefProvider
 
SystemGuardian$ - Class in akka.actor
INTERNAL API
SystemGuardian$() - Constructor for class akka.actor.SystemGuardian$
 
SystemGuardian.RegisterTerminationHook$ - Class in akka.actor
For the purpose of orderly shutdown it's possible to register interest in the termination of systemGuardian and receive a notification akka.actor.Guardian.TerminationHook before systemGuardian is stopped.
SystemGuardian.RegisterTerminationHook$() - Constructor for class akka.actor.SystemGuardian.RegisterTerminationHook$
 
SystemGuardian.TerminationHook$ - Class in akka.actor
 
SystemGuardian.TerminationHook$() - Constructor for class akka.actor.SystemGuardian.TerminationHook$
 
SystemGuardian.TerminationHookDone$ - Class in akka.actor
 
SystemGuardian.TerminationHookDone$() - Constructor for class akka.actor.SystemGuardian.TerminationHookDone$
 
systemGuardianStrategy() - Method in class akka.actor.LocalActorRefProvider
Overridable supervision strategy to be used by the &ldquo;/user&rdquo; guardian.
SystemHome() - Method in class akka.actor.ActorSystem$
 
SystemHome() - Static method in class akka.actor.ActorSystem
 
systemImpl() - Method in class akka.actor.ActorCell
 
systemImpl() - Method in interface akka.actor.ActorRefFactory
INTERNAL API
systemImpl() - Method in class akka.actor.ActorSystemImpl
 
systemImpl() - Method in interface akka.actor.Cell
The system internals where this Cell lives.
systemImpl() - Method in class akka.actor.UnstartedCell
 
systemInvoke(SystemMessage) - Method in class akka.actor.ActorCell
 
systemLoadAverage() - Method in class akka.cluster.JmxMetricsCollector
JMX Returns the OS-specific average load on the CPUs in the system, for the past 1 minute.
systemLoadAverage() - Method in class akka.cluster.SigarMetricsCollector
(SIGAR / JMX) Returns the OS-specific average load on the CPUs in the system, for the past 1 minute.
SystemLoadAverage() - Method in class akka.cluster.StandardMetrics$
 
systemLoadAverage() - Method in class akka.cluster.StandardMetrics.Cpu
 
SystemLoadAverage() - Static method in class akka.cluster.StandardMetrics
 
SystemLoadAverageMetricsSelector - Class in akka.cluster.routing
MetricsSelector that uses the system load average metrics.
SystemLoadAverageMetricsSelector() - Constructor for class akka.cluster.routing.SystemLoadAverageMetricsSelector
 
SystemLoadAverageMetricsSelector$ - Class in akka.cluster.routing
MetricsSelector that uses the system load average metrics.
SystemLoadAverageMetricsSelector$() - Constructor for class akka.cluster.routing.SystemLoadAverageMetricsSelector$
 
SystemMessage - Interface in akka.dispatch.sysmsg
System messages are handled specially: they form their own queue within each actor&rsquo;s mailbox.
SystemMessageList - Class in akka.dispatch.sysmsg
INTERNAL API
SystemMessageList() - Constructor for class akka.dispatch.sysmsg.SystemMessageList
 
SystemMessageList$ - Class in akka.dispatch.sysmsg
INTERNAL API
SystemMessageList$() - Constructor for class akka.dispatch.sysmsg.SystemMessageList$
 
SystemMessageQueue - Interface in akka.dispatch
INTERNAL API
systemName() - Method in class akka.cluster.ClusterSettings
 
systemName() - Method in class akka.remote.RemoteActorRefProvider
 
systemQueueGet() - Method in class akka.dispatch.Mailbox
 
systemQueuePut(LatestFirstSystemMessageList, LatestFirstSystemMessageList) - Method in class akka.dispatch.Mailbox
 
systemSettings() - Method in interface akka.actor.mailbox.DurableMailboxSettings
A reference to the enclosing actor system.
systemSettings() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 

T

t() - Method in class akka.testkit.TestActorRefSpec.WrappedTerminated
 
t1() - Method in class akka.japi.tuple.Tuple10
 
t1() - Method in class akka.japi.tuple.Tuple11
 
t1() - Method in class akka.japi.tuple.Tuple12
 
t1() - Method in class akka.japi.tuple.Tuple13
 
t1() - Method in class akka.japi.tuple.Tuple14
 
t1() - Method in class akka.japi.tuple.Tuple15
 
t1() - Method in class akka.japi.tuple.Tuple16
 
t1() - Method in class akka.japi.tuple.Tuple17
 
t1() - Method in class akka.japi.tuple.Tuple18
 
t1() - Method in class akka.japi.tuple.Tuple19
 
t1() - Method in class akka.japi.tuple.Tuple20
 
t1() - Method in class akka.japi.tuple.Tuple21
 
t1() - Method in class akka.japi.tuple.Tuple22
 
t1() - Method in class akka.japi.tuple.Tuple3
 
t1() - Method in class akka.japi.tuple.Tuple4
 
t1() - Method in class akka.japi.tuple.Tuple5
 
t1() - Method in class akka.japi.tuple.Tuple6
 
t1() - Method in class akka.japi.tuple.Tuple7
 
t1() - Method in class akka.japi.tuple.Tuple8
 
t1() - Method in class akka.japi.tuple.Tuple9
 
t10() - Method in class akka.japi.tuple.Tuple10
 
t10() - Method in class akka.japi.tuple.Tuple11
 
t10() - Method in class akka.japi.tuple.Tuple12
 
t10() - Method in class akka.japi.tuple.Tuple13
 
t10() - Method in class akka.japi.tuple.Tuple14
 
t10() - Method in class akka.japi.tuple.Tuple15
 
t10() - Method in class akka.japi.tuple.Tuple16
 
t10() - Method in class akka.japi.tuple.Tuple17
 
t10() - Method in class akka.japi.tuple.Tuple18
 
t10() - Method in class akka.japi.tuple.Tuple19
 
t10() - Method in class akka.japi.tuple.Tuple20
 
t10() - Method in class akka.japi.tuple.Tuple21
 
t10() - Method in class akka.japi.tuple.Tuple22
 
t11() - Method in class akka.japi.tuple.Tuple11
 
t11() - Method in class akka.japi.tuple.Tuple12
 
t11() - Method in class akka.japi.tuple.Tuple13
 
t11() - Method in class akka.japi.tuple.Tuple14
 
t11() - Method in class akka.japi.tuple.Tuple15
 
t11() - Method in class akka.japi.tuple.Tuple16
 
t11() - Method in class akka.japi.tuple.Tuple17
 
t11() - Method in class akka.japi.tuple.Tuple18
 
t11() - Method in class akka.japi.tuple.Tuple19
 
t11() - Method in class akka.japi.tuple.Tuple20
 
t11() - Method in class akka.japi.tuple.Tuple21
 
t11() - Method in class akka.japi.tuple.Tuple22
 
t12() - Method in class akka.japi.tuple.Tuple12
 
t12() - Method in class akka.japi.tuple.Tuple13
 
t12() - Method in class akka.japi.tuple.Tuple14
 
t12() - Method in class akka.japi.tuple.Tuple15
 
t12() - Method in class akka.japi.tuple.Tuple16
 
t12() - Method in class akka.japi.tuple.Tuple17
 
t12() - Method in class akka.japi.tuple.Tuple18
 
t12() - Method in class akka.japi.tuple.Tuple19
 
t12() - Method in class akka.japi.tuple.Tuple20
 
t12() - Method in class akka.japi.tuple.Tuple21
 
t12() - Method in class akka.japi.tuple.Tuple22
 
t13() - Method in class akka.japi.tuple.Tuple13
 
t13() - Method in class akka.japi.tuple.Tuple14
 
t13() - Method in class akka.japi.tuple.Tuple15
 
t13() - Method in class akka.japi.tuple.Tuple16
 
t13() - Method in class akka.japi.tuple.Tuple17
 
t13() - Method in class akka.japi.tuple.Tuple18
 
t13() - Method in class akka.japi.tuple.Tuple19
 
t13() - Method in class akka.japi.tuple.Tuple20
 
t13() - Method in class akka.japi.tuple.Tuple21
 
t13() - Method in class akka.japi.tuple.Tuple22
 
t14() - Method in class akka.japi.tuple.Tuple14
 
t14() - Method in class akka.japi.tuple.Tuple15
 
t14() - Method in class akka.japi.tuple.Tuple16
 
t14() - Method in class akka.japi.tuple.Tuple17
 
t14() - Method in class akka.japi.tuple.Tuple18
 
t14() - Method in class akka.japi.tuple.Tuple19
 
t14() - Method in class akka.japi.tuple.Tuple20
 
t14() - Method in class akka.japi.tuple.Tuple21
 
t14() - Method in class akka.japi.tuple.Tuple22
 
t15() - Method in class akka.japi.tuple.Tuple15
 
t15() - Method in class akka.japi.tuple.Tuple16
 
t15() - Method in class akka.japi.tuple.Tuple17
 
t15() - Method in class akka.japi.tuple.Tuple18
 
t15() - Method in class akka.japi.tuple.Tuple19
 
t15() - Method in class akka.japi.tuple.Tuple20
 
t15() - Method in class akka.japi.tuple.Tuple21
 
t15() - Method in class akka.japi.tuple.Tuple22
 
t16() - Method in class akka.japi.tuple.Tuple16
 
t16() - Method in class akka.japi.tuple.Tuple17
 
t16() - Method in class akka.japi.tuple.Tuple18
 
t16() - Method in class akka.japi.tuple.Tuple19
 
t16() - Method in class akka.japi.tuple.Tuple20
 
t16() - Method in class akka.japi.tuple.Tuple21
 
t16() - Method in class akka.japi.tuple.Tuple22
 
t17() - Method in class akka.japi.tuple.Tuple17
 
t17() - Method in class akka.japi.tuple.Tuple18
 
t17() - Method in class akka.japi.tuple.Tuple19
 
t17() - Method in class akka.japi.tuple.Tuple20
 
t17() - Method in class akka.japi.tuple.Tuple21
 
t17() - Method in class akka.japi.tuple.Tuple22
 
t18() - Method in class akka.japi.tuple.Tuple18
 
t18() - Method in class akka.japi.tuple.Tuple19
 
t18() - Method in class akka.japi.tuple.Tuple20
 
t18() - Method in class akka.japi.tuple.Tuple21
 
t18() - Method in class akka.japi.tuple.Tuple22
 
t19() - Method in class akka.japi.tuple.Tuple19
 
t19() - Method in class akka.japi.tuple.Tuple20
 
t19() - Method in class akka.japi.tuple.Tuple21
 
t19() - Method in class akka.japi.tuple.Tuple22
 
t2() - Method in class akka.japi.tuple.Tuple10
 
t2() - Method in class akka.japi.tuple.Tuple11
 
t2() - Method in class akka.japi.tuple.Tuple12
 
t2() - Method in class akka.japi.tuple.Tuple13
 
t2() - Method in class akka.japi.tuple.Tuple14
 
t2() - Method in class akka.japi.tuple.Tuple15
 
t2() - Method in class akka.japi.tuple.Tuple16
 
t2() - Method in class akka.japi.tuple.Tuple17
 
t2() - Method in class akka.japi.tuple.Tuple18
 
t2() - Method in class akka.japi.tuple.Tuple19
 
t2() - Method in class akka.japi.tuple.Tuple20
 
t2() - Method in class akka.japi.tuple.Tuple21
 
t2() - Method in class akka.japi.tuple.Tuple22
 
t2() - Method in class akka.japi.tuple.Tuple3
 
t2() - Method in class akka.japi.tuple.Tuple4
 
t2() - Method in class akka.japi.tuple.Tuple5
 
t2() - Method in class akka.japi.tuple.Tuple6
 
t2() - Method in class akka.japi.tuple.Tuple7
 
t2() - Method in class akka.japi.tuple.Tuple8
 
t2() - Method in class akka.japi.tuple.Tuple9
 
t20() - Method in class akka.japi.tuple.Tuple20
 
t20() - Method in class akka.japi.tuple.Tuple21
 
t20() - Method in class akka.japi.tuple.Tuple22
 
t21() - Method in class akka.japi.tuple.Tuple21
 
t21() - Method in class akka.japi.tuple.Tuple22
 
t22() - Method in class akka.japi.tuple.Tuple22
 
t3() - Method in class akka.japi.tuple.Tuple10
 
t3() - Method in class akka.japi.tuple.Tuple11
 
t3() - Method in class akka.japi.tuple.Tuple12
 
t3() - Method in class akka.japi.tuple.Tuple13
 
t3() - Method in class akka.japi.tuple.Tuple14
 
t3() - Method in class akka.japi.tuple.Tuple15
 
t3() - Method in class akka.japi.tuple.Tuple16
 
t3() - Method in class akka.japi.tuple.Tuple17
 
t3() - Method in class akka.japi.tuple.Tuple18
 
t3() - Method in class akka.japi.tuple.Tuple19
 
t3() - Method in class akka.japi.tuple.Tuple20
 
t3() - Method in class akka.japi.tuple.Tuple21
 
t3() - Method in class akka.japi.tuple.Tuple22
 
t3() - Method in class akka.japi.tuple.Tuple3
 
t3() - Method in class akka.japi.tuple.Tuple4
 
t3() - Method in class akka.japi.tuple.Tuple5
 
t3() - Method in class akka.japi.tuple.Tuple6
 
t3() - Method in class akka.japi.tuple.Tuple7
 
t3() - Method in class akka.japi.tuple.Tuple8
 
t3() - Method in class akka.japi.tuple.Tuple9
 
t4() - Method in class akka.japi.tuple.Tuple10
 
t4() - Method in class akka.japi.tuple.Tuple11
 
t4() - Method in class akka.japi.tuple.Tuple12
 
t4() - Method in class akka.japi.tuple.Tuple13
 
t4() - Method in class akka.japi.tuple.Tuple14
 
t4() - Method in class akka.japi.tuple.Tuple15
 
t4() - Method in class akka.japi.tuple.Tuple16
 
t4() - Method in class akka.japi.tuple.Tuple17
 
t4() - Method in class akka.japi.tuple.Tuple18
 
t4() - Method in class akka.japi.tuple.Tuple19
 
t4() - Method in class akka.japi.tuple.Tuple20
 
t4() - Method in class akka.japi.tuple.Tuple21
 
t4() - Method in class akka.japi.tuple.Tuple22
 
t4() - Method in class akka.japi.tuple.Tuple4
 
t4() - Method in class akka.japi.tuple.Tuple5
 
t4() - Method in class akka.japi.tuple.Tuple6
 
t4() - Method in class akka.japi.tuple.Tuple7
 
t4() - Method in class akka.japi.tuple.Tuple8
 
t4() - Method in class akka.japi.tuple.Tuple9
 
t5() - Method in class akka.japi.tuple.Tuple10
 
t5() - Method in class akka.japi.tuple.Tuple11
 
t5() - Method in class akka.japi.tuple.Tuple12
 
t5() - Method in class akka.japi.tuple.Tuple13
 
t5() - Method in class akka.japi.tuple.Tuple14
 
t5() - Method in class akka.japi.tuple.Tuple15
 
t5() - Method in class akka.japi.tuple.Tuple16
 
t5() - Method in class akka.japi.tuple.Tuple17
 
t5() - Method in class akka.japi.tuple.Tuple18
 
t5() - Method in class akka.japi.tuple.Tuple19
 
t5() - Method in class akka.japi.tuple.Tuple20
 
t5() - Method in class akka.japi.tuple.Tuple21
 
t5() - Method in class akka.japi.tuple.Tuple22
 
t5() - Method in class akka.japi.tuple.Tuple5
 
t5() - Method in class akka.japi.tuple.Tuple6
 
t5() - Method in class akka.japi.tuple.Tuple7
 
t5() - Method in class akka.japi.tuple.Tuple8
 
t5() - Method in class akka.japi.tuple.Tuple9
 
t6() - Method in class akka.japi.tuple.Tuple10
 
t6() - Method in class akka.japi.tuple.Tuple11
 
t6() - Method in class akka.japi.tuple.Tuple12
 
t6() - Method in class akka.japi.tuple.Tuple13
 
t6() - Method in class akka.japi.tuple.Tuple14
 
t6() - Method in class akka.japi.tuple.Tuple15
 
t6() - Method in class akka.japi.tuple.Tuple16
 
t6() - Method in class akka.japi.tuple.Tuple17
 
t6() - Method in class akka.japi.tuple.Tuple18
 
t6() - Method in class akka.japi.tuple.Tuple19
 
t6() - Method in class akka.japi.tuple.Tuple20
 
t6() - Method in class akka.japi.tuple.Tuple21
 
t6() - Method in class akka.japi.tuple.Tuple22
 
t6() - Method in class akka.japi.tuple.Tuple6
 
t6() - Method in class akka.japi.tuple.Tuple7
 
t6() - Method in class akka.japi.tuple.Tuple8
 
t6() - Method in class akka.japi.tuple.Tuple9
 
t7() - Method in class akka.japi.tuple.Tuple10
 
t7() - Method in class akka.japi.tuple.Tuple11
 
t7() - Method in class akka.japi.tuple.Tuple12
 
t7() - Method in class akka.japi.tuple.Tuple13
 
t7() - Method in class akka.japi.tuple.Tuple14
 
t7() - Method in class akka.japi.tuple.Tuple15
 
t7() - Method in class akka.japi.tuple.Tuple16
 
t7() - Method in class akka.japi.tuple.Tuple17
 
t7() - Method in class akka.japi.tuple.Tuple18
 
t7() - Method in class akka.japi.tuple.Tuple19
 
t7() - Method in class akka.japi.tuple.Tuple20
 
t7() - Method in class akka.japi.tuple.Tuple21
 
t7() - Method in class akka.japi.tuple.Tuple22
 
t7() - Method in class akka.japi.tuple.Tuple7
 
t7() - Method in class akka.japi.tuple.Tuple8
 
t7() - Method in class akka.japi.tuple.Tuple9
 
t8() - Method in class akka.japi.tuple.Tuple10
 
t8() - Method in class akka.japi.tuple.Tuple11
 
t8() - Method in class akka.japi.tuple.Tuple12
 
t8() - Method in class akka.japi.tuple.Tuple13
 
t8() - Method in class akka.japi.tuple.Tuple14
 
t8() - Method in class akka.japi.tuple.Tuple15
 
t8() - Method in class akka.japi.tuple.Tuple16
 
t8() - Method in class akka.japi.tuple.Tuple17
 
t8() - Method in class akka.japi.tuple.Tuple18
 
t8() - Method in class akka.japi.tuple.Tuple19
 
t8() - Method in class akka.japi.tuple.Tuple20
 
t8() - Method in class akka.japi.tuple.Tuple21
 
t8() - Method in class akka.japi.tuple.Tuple22
 
t8() - Method in class akka.japi.tuple.Tuple8
 
t8() - Method in class akka.japi.tuple.Tuple9
 
t9() - Method in class akka.japi.tuple.Tuple10
 
t9() - Method in class akka.japi.tuple.Tuple11
 
t9() - Method in class akka.japi.tuple.Tuple12
 
t9() - Method in class akka.japi.tuple.Tuple13
 
t9() - Method in class akka.japi.tuple.Tuple14
 
t9() - Method in class akka.japi.tuple.Tuple15
 
t9() - Method in class akka.japi.tuple.Tuple16
 
t9() - Method in class akka.japi.tuple.Tuple17
 
t9() - Method in class akka.japi.tuple.Tuple18
 
t9() - Method in class akka.japi.tuple.Tuple19
 
t9() - Method in class akka.japi.tuple.Tuple20
 
t9() - Method in class akka.japi.tuple.Tuple21
 
t9() - Method in class akka.japi.tuple.Tuple22
 
t9() - Method in class akka.japi.tuple.Tuple9
 
tail() - Method in class akka.contrib.pattern.WorkList
 
tail() - Method in class akka.dispatch.sysmsg.EarliestFirstSystemMessageList
Gives back the list containing all the elements except the first.
tail() - Method in class akka.dispatch.sysmsg.LatestFirstSystemMessageList
Gives back the list containing all the elements except the first.
tail() - Method in class akka.util.ByteString
 
TailChoppingGroup - Class in akka.routing
A router group that sends the message to a first, random picked, routee, then wait a specified interval and then send to a second, random picked, and so on till one full cycle..
TailChoppingGroup(Iterable<String>, FiniteDuration, FiniteDuration, String) - Constructor for class akka.routing.TailChoppingGroup
 
TailChoppingGroup(com.typesafe.config.Config) - Constructor for class akka.routing.TailChoppingGroup
 
TailChoppingGroup(Iterable<String>, FiniteDuration, FiniteDuration) - Constructor for class akka.routing.TailChoppingGroup
Java API
TailChoppingGroup$ - Class in akka.routing
 
TailChoppingGroup$() - Constructor for class akka.routing.TailChoppingGroup$
 
TailChoppingPool - Class in akka.routing
A router poll thats sends the message to a first, random picked, routee, then wait a specified interval and then send to a second, random picked, and so on till one full cycle..
TailChoppingPool(int, Option<Resizer>, FiniteDuration, FiniteDuration, SupervisorStrategy, String, boolean) - Constructor for class akka.routing.TailChoppingPool
 
TailChoppingPool(com.typesafe.config.Config) - Constructor for class akka.routing.TailChoppingPool
 
TailChoppingPool(int, FiniteDuration, FiniteDuration) - Constructor for class akka.routing.TailChoppingPool
Java API
TailChoppingPool$ - Class in akka.routing
 
TailChoppingPool$() - Constructor for class akka.routing.TailChoppingPool$
 
TailChoppingRoutees - Class in akka.routing
INTERNAL API
TailChoppingRoutees(Scheduler, IndexedSeq<Routee>, FiniteDuration, FiniteDuration, ExecutionContext) - Constructor for class akka.routing.TailChoppingRoutees
 
TailChoppingRoutees$ - Class in akka.routing
 
TailChoppingRoutees$() - Constructor for class akka.routing.TailChoppingRoutees$
 
TailChoppingRoutingLogic - Class in akka.routing
Sends the message to a first, random picked, routee, then wait a specified interval and then send to a second, random picked, and so on till one full cycle.
TailChoppingRoutingLogic(Scheduler, FiniteDuration, FiniteDuration, ExecutionContext) - Constructor for class akka.routing.TailChoppingRoutingLogic
 
TailChoppingRoutingLogic$ - Class in akka.routing
 
TailChoppingRoutingLogic$() - Constructor for class akka.routing.TailChoppingRoutingLogic$
 
tailCommand() - Method in class akka.io.Tcp.CompoundWrite
 
take() - Method in class akka.util.BoundedBlockingQueue
 
take(int) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
take(int) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
take(int) - Method in class akka.util.ByteIterator
 
take(int) - Method in class akka.util.ByteString
 
takeOverResponsibility(Address) - Method in class akka.cluster.ClusterRemoteWatcher
When a cluster node is added this class takes over the responsibility for watchees on that node already handled by super RemoteWatcher.
takeRight(int) - Method in class akka.util.ByteString
 
takeWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
takeWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
takeWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator
 
takeWhile(Function1<Object, Object>) - Method in class akka.util.ByteString
 
target() - Method in class akka.actor.dsl.Inbox.StartWatch
 
target() - Method in class akka.contrib.throttle.Throttler.SetTarget
 
target() - Method in class akka.contrib.throttle.TimerBasedThrottler.Data
 
target() - Method in class akka.io.Udp.Send
 
target() - Method in class akka.persistence.journal.AsyncWriteJournal.Desequenced
 
target() - Method in class akka.remote.testconductor.Disconnect
 
target() - Method in class akka.remote.testconductor.DisconnectMsg
 
target() - Method in class akka.remote.testconductor.Throttle
 
target() - Method in class akka.remote.testconductor.ThrottleMsg
 
targetActorUri() - Method in class akka.camel.internal.ConsumerActorRouteBuilder
 
task() - Method in class akka.actor.LightArrayRevolverScheduler.TaskHolder
 
TaskInvocation - Class in akka.dispatch
 
TaskInvocation(EventStream, Runnable, Function0<BoxedUnit>) - Constructor for class akka.dispatch.TaskInvocation
 
TaskInvocation$ - Class in akka.dispatch
 
TaskInvocation$() - Constructor for class akka.dispatch.TaskInvocation$
 
tc() - Method in class akka.io.Inet.SO$.TrafficClass
 
Tcp - Class in akka.io
TCP Extension for Akka&rsquo;s IO layer.
Tcp() - Constructor for class akka.io.Tcp
 
tcp() - Method in class akka.io.TcpConnection
 
Tcp$ - Class in akka.io
TCP Extension for Akka&rsquo;s IO layer.
Tcp$() - Constructor for class akka.io.Tcp$
 
Tcp.Abort$ - Class in akka.io
An abort operation will not flush pending writes and will issue a TCP ABORT command to the O/S kernel which should result in a TCP_RST packet being sent to the peer.
Tcp.Abort$() - Constructor for class akka.io.Tcp.Abort$
 
Tcp.Aborted$ - Class in akka.io
The connection has been aborted in response to an Abort command.
Tcp.Aborted$() - Constructor for class akka.io.Tcp.Aborted$
 
Tcp.Bind - Class in akka.io
The Bind message is send to the TCP manager actor, which is obtained via TcpExt.manager() in order to bind to a listening socket.
Tcp.Bind(ActorRef, InetSocketAddress, int, Traversable<Inet.SocketOption>, boolean) - Constructor for class akka.io.Tcp.Bind
 
Tcp.Bind$ - Class in akka.io
 
Tcp.Bind$() - Constructor for class akka.io.Tcp.Bind$
 
Tcp.Bound - Class in akka.io
The sender of a Tcp.Bind command will—in case of success—receive confirmation in this form.
Tcp.Bound(InetSocketAddress) - Constructor for class akka.io.Tcp.Bound
 
Tcp.Bound$ - Class in akka.io
 
Tcp.Bound$() - Constructor for class akka.io.Tcp.Bound$
 
Tcp.Close$ - Class in akka.io
A normal close operation will first flush pending writes and then close the socket.
Tcp.Close$() - Constructor for class akka.io.Tcp.Close$
 
Tcp.CloseCommand - Interface in akka.io
Common interface for all commands which aim to close down an open connection.
Tcp.Closed$ - Class in akka.io
The connection has been closed normally in response to a Close command.
Tcp.Closed$() - Constructor for class akka.io.Tcp.Closed$
 
Tcp.Command - Interface in akka.io
This is the common trait for all commands understood by TCP actors.
Tcp.CommandFailed - Class in akka.io
Whenever a command cannot be completed, the queried actor will reply with this message, wrapping the original command which failed.
Tcp.CommandFailed(Tcp.Command) - Constructor for class akka.io.Tcp.CommandFailed
 
Tcp.CommandFailed$ - Class in akka.io
 
Tcp.CommandFailed$() - Constructor for class akka.io.Tcp.CommandFailed$
 
Tcp.CompoundWrite - Class in akka.io
A write command which aggregates two other write commands.
Tcp.CompoundWrite(Tcp.SimpleWriteCommand, Tcp.WriteCommand) - Constructor for class akka.io.Tcp.CompoundWrite
 
Tcp.CompoundWrite$ - Class in akka.io
 
Tcp.CompoundWrite$() - Constructor for class akka.io.Tcp.CompoundWrite$
 
Tcp.ConfirmedClose$ - Class in akka.io
A confirmed close operation will flush pending writes and half-close the connection, waiting for the peer to close the other half.
Tcp.ConfirmedClose$() - Constructor for class akka.io.Tcp.ConfirmedClose$
 
Tcp.ConfirmedClosed$ - Class in akka.io
The connection has been half-closed by us and then half-close by the peer in response to a ConfirmedClose command.
Tcp.ConfirmedClosed$() - Constructor for class akka.io.Tcp.ConfirmedClosed$
 
Tcp.Connect - Class in akka.io
The Connect message is sent to the TCP manager actor, which is obtained via TcpExt.manager().
Tcp.Connect(InetSocketAddress, Option<InetSocketAddress>, Traversable<Inet.SocketOption>, Option<FiniteDuration>, boolean) - Constructor for class akka.io.Tcp.Connect
 
Tcp.Connect$ - Class in akka.io
 
Tcp.Connect$() - Constructor for class akka.io.Tcp.Connect$
 
Tcp.Connected - Class in akka.io
The connection actor sends this message either to the sender of a Tcp.Connect command (for outbound) or to the handler for incoming connections designated in the Tcp.Bind message.
Tcp.Connected(InetSocketAddress, InetSocketAddress) - Constructor for class akka.io.Tcp.Connected
 
Tcp.Connected$ - Class in akka.io
 
Tcp.Connected$() - Constructor for class akka.io.Tcp.Connected$
 
Tcp.ConnectionClosed - Interface in akka.io
This is the common interface for all events which indicate that a connection has been closed or half-closed.
Tcp.ErrorClosed - Class in akka.io
The connection has been closed due to an IO error.
Tcp.ErrorClosed(String) - Constructor for class akka.io.Tcp.ErrorClosed
 
Tcp.ErrorClosed$ - Class in akka.io
 
Tcp.ErrorClosed$() - Constructor for class akka.io.Tcp.ErrorClosed$
 
Tcp.Event - Interface in akka.io
Common interface for all events generated by the TCP layer actors.
Tcp.Message - Interface in akka.io
The common interface for Tcp.WriteCommand and Tcp.Event.
Tcp.NoAck - Class in akka.io
Each Tcp.WriteCommand can optionally request a positive acknowledgment to be sent to the commanding actor.
Tcp.NoAck(Object) - Constructor for class akka.io.Tcp.NoAck
 
Tcp.NoAck$ - Class in akka.io
Default Tcp.NoAck instance which is used when no acknowledgment information is explicitly provided.
Tcp.NoAck$() - Constructor for class akka.io.Tcp.NoAck$
 
Tcp.PeerClosed$ - Class in akka.io
The peer has closed its writing half of the connection.
Tcp.PeerClosed$() - Constructor for class akka.io.Tcp.PeerClosed$
 
Tcp.Received - Class in akka.io
Whenever data are read from a socket they will be transferred within this class to the handler actor which was designated in the Tcp.Register message.
Tcp.Received(ByteString) - Constructor for class akka.io.Tcp.Received
 
Tcp.Received$ - Class in akka.io
 
Tcp.Received$() - Constructor for class akka.io.Tcp.Received$
 
Tcp.Register - Class in akka.io
This message must be sent to a TCP connection actor after receiving the Tcp.Connected message.
Tcp.Register(ActorRef, boolean, boolean) - Constructor for class akka.io.Tcp.Register
 
Tcp.Register$ - Class in akka.io
 
Tcp.Register$() - Constructor for class akka.io.Tcp.Register$
 
Tcp.ResumeAccepting - Class in akka.io
This message enables the accepting of the next connection if read throttling is enabled for connection actors.
Tcp.ResumeAccepting(int) - Constructor for class akka.io.Tcp.ResumeAccepting
 
Tcp.ResumeAccepting$ - Class in akka.io
 
Tcp.ResumeAccepting$() - Constructor for class akka.io.Tcp.ResumeAccepting$
 
Tcp.ResumeReading$ - Class in akka.io
This command needs to be sent to the connection actor after a SuspendReading command in order to resume reading from the socket.
Tcp.ResumeReading$() - Constructor for class akka.io.Tcp.ResumeReading$
 
Tcp.ResumeWriting$ - Class in akka.io
When useResumeWriting is in effect as was indicated in the Tcp.Register message then this command needs to be sent to the connection actor in order to re-enable writing after a Tcp.CommandFailed event.
Tcp.ResumeWriting$() - Constructor for class akka.io.Tcp.ResumeWriting$
 
Tcp.SimpleWriteCommand - Class in akka.io
Common supertype of Tcp.Write and Tcp.WriteFile.
Tcp.SimpleWriteCommand() - Constructor for class akka.io.Tcp.SimpleWriteCommand
 
Tcp.SO$ - Class in akka.io
Scala API: this object contains all applicable socket options for TCP.
Tcp.SO$() - Constructor for class akka.io.Tcp.SO$
 
Tcp.SO$.KeepAlive - Class in akka.io
Inet.SocketOption to enable or disable SO_KEEPALIVE
Tcp.SO$.KeepAlive(boolean) - Constructor for class akka.io.Tcp.SO$.KeepAlive
 
Tcp.SO$.OOBInline - Class in akka.io
Inet.SocketOption to enable or disable OOBINLINE (receipt of TCP urgent data) By default, this option is disabled and TCP urgent data is silently discarded.
Tcp.SO$.OOBInline(boolean) - Constructor for class akka.io.Tcp.SO$.OOBInline
 
Tcp.SO$.TcpNoDelay - Class in akka.io
Inet.SocketOption to enable or disable TCP_NODELAY (disable or enable Nagle's algorithm)
Tcp.SO$.TcpNoDelay(boolean) - Constructor for class akka.io.Tcp.SO$.TcpNoDelay
 
Tcp.SuspendReading$ - Class in akka.io
Sending this command to the connection actor will disable reading from the TCP socket.
Tcp.SuspendReading$() - Constructor for class akka.io.Tcp.SuspendReading$
 
Tcp.Unbind$ - Class in akka.io
In order to close down a listening socket, send this message to that socket&rsquo;s actor (that is the actor which previously had sent the Tcp.Bound message).
Tcp.Unbind$() - Constructor for class akka.io.Tcp.Unbind$
 
Tcp.Unbound - Interface in akka.io
The sender of an Unbind command will receive confirmation through this message once the listening socket has been closed.
Tcp.Unbound$ - Class in akka.io
 
Tcp.Unbound$() - Constructor for class akka.io.Tcp.Unbound$
 
Tcp.Write - Class in akka.io
Write data to the TCP connection.
Tcp.Write(ByteString, Tcp.Event) - Constructor for class akka.io.Tcp.Write
 
Tcp.Write$ - Class in akka.io
 
Tcp.Write$() - Constructor for class akka.io.Tcp.Write$
 
Tcp.WriteCommand - Class in akka.io
Common interface for all write commands, currently Tcp.Write, Tcp.WriteFile and Tcp.CompoundWrite.
Tcp.WriteCommand() - Constructor for class akka.io.Tcp.WriteCommand
 
Tcp.WriteCommand$ - Class in akka.io
 
Tcp.WriteCommand$() - Constructor for class akka.io.Tcp.WriteCommand$
 
Tcp.WriteFile - Class in akka.io
Write count bytes starting at position from file at filePath to the connection.
Tcp.WriteFile(String, long, long, Tcp.Event) - Constructor for class akka.io.Tcp.WriteFile
 
Tcp.WriteFile$ - Class in akka.io
 
Tcp.WriteFile$() - Constructor for class akka.io.Tcp.WriteFile$
 
Tcp.WritingResumed - Interface in akka.io
When useResumeWriting is in effect as indicated in the Tcp.Register message, the ResumeWriting command will be acknowledged by this message type, upon which it is safe to send at least one write.
Tcp.WritingResumed$ - Class in akka.io
 
Tcp.WritingResumed$() - Constructor for class akka.io.Tcp.WritingResumed$
 
TcpAssociationHandle - Class in akka.remote.transport.netty
INTERNAL API
TcpAssociationHandle(Address, Address, NettyTransport, org.jboss.netty.channel.Channel) - Constructor for class akka.remote.transport.netty.TcpAssociationHandle
 
TcpClientHandler - Class in akka.remote.transport.netty
INTERNAL API
TcpClientHandler(NettyTransport, Address) - Constructor for class akka.remote.transport.netty.TcpClientHandler
 
TcpConnection - Class in akka.io
Base class for TcpIncomingConnection and TcpOutgoingConnection.
TcpConnection(TcpExt, SocketChannel, boolean) - Constructor for class akka.io.TcpConnection
 
TcpConnection$ - Class in akka.io
INTERNAL API
TcpConnection$() - Constructor for class akka.io.TcpConnection$
 
TcpConnection.AllRead$ - Class in akka.io
 
TcpConnection.AllRead$() - Constructor for class akka.io.TcpConnection.AllRead$
 
TcpConnection.CloseInformation - Class in akka.io
Used to transport information to the postStop method to notify interested party about a connection close.
TcpConnection.CloseInformation(Set<ActorRef>, Tcp.Event) - Constructor for class akka.io.TcpConnection.CloseInformation
 
TcpConnection.CloseInformation$ - Class in akka.io
 
TcpConnection.CloseInformation$() - Constructor for class akka.io.TcpConnection.CloseInformation$
 
TcpConnection.ConnectionInfo - Class in akka.io
Groups required connection-related data that are only available once the connection has been fully established.
TcpConnection.ConnectionInfo(ChannelRegistration, ActorRef, boolean, boolean) - Constructor for class akka.io.TcpConnection.ConnectionInfo
 
TcpConnection.ConnectionInfo$ - Class in akka.io
 
TcpConnection.ConnectionInfo$() - Constructor for class akka.io.TcpConnection.ConnectionInfo$
 
TcpConnection.EmptyPendingWrite$ - Class in akka.io
 
TcpConnection.EmptyPendingWrite$() - Constructor for class akka.io.TcpConnection.EmptyPendingWrite$
 
TcpConnection.EndOfStream$ - Class in akka.io
 
TcpConnection.EndOfStream$() - Constructor for class akka.io.TcpConnection.EndOfStream$
 
TcpConnection.MoreDataWaiting$ - Class in akka.io
 
TcpConnection.MoreDataWaiting$() - Constructor for class akka.io.TcpConnection.MoreDataWaiting$
 
TcpConnection.PendingBufferWrite - Class in akka.io
 
TcpConnection.PendingBufferWrite(ActorRef, ByteString, Object, ByteBuffer, Tcp.WriteCommand) - Constructor for class akka.io.TcpConnection.PendingBufferWrite
 
TcpConnection.PendingWrite - Class in akka.io
 
TcpConnection.PendingWrite() - Constructor for class akka.io.TcpConnection.PendingWrite
 
TcpConnection.PendingWriteFile - Class in akka.io
 
TcpConnection.PendingWriteFile(ActorRef, FileChannel, long, long, Tcp.Event, Tcp.WriteCommand) - Constructor for class akka.io.TcpConnection.PendingWriteFile
 
TcpConnection.ReadResult - Interface in akka.io
 
TcpConnection.UpdatePendingWriteAndThen - Class in akka.io
 
TcpConnection.UpdatePendingWriteAndThen(TcpConnection.PendingWrite, Function0<BoxedUnit>) - Constructor for class akka.io.TcpConnection.UpdatePendingWriteAndThen
 
TcpConnection.UpdatePendingWriteAndThen$ - Class in akka.io
 
TcpConnection.UpdatePendingWriteAndThen$() - Constructor for class akka.io.TcpConnection.UpdatePendingWriteAndThen$
 
TcpConnection.WriteFileFailed - Class in akka.io
 
TcpConnection.WriteFileFailed(IOException) - Constructor for class akka.io.TcpConnection.WriteFileFailed
 
TcpConnection.WriteFileFailed$ - Class in akka.io
 
TcpConnection.WriteFileFailed$() - Constructor for class akka.io.TcpConnection.WriteFileFailed$
 
TcpExt - Class in akka.io
 
TcpExt(ExtendedActorSystem) - Constructor for class akka.io.TcpExt
 
TcpExt.Settings - Class in akka.io
 
TcpExt.Settings(com.typesafe.config.Config) - Constructor for class akka.io.TcpExt.Settings
 
TcpHandlers - Interface in akka.remote.transport.netty
INTERNAL API
TcpIncomingConnection - Class in akka.io
An actor handling the connection state machine for an incoming, already connected SocketChannel.
TcpIncomingConnection(TcpExt, SocketChannel, ChannelRegistry, ActorRef, Traversable<Inet.SocketOption>, boolean) - Constructor for class akka.io.TcpIncomingConnection
 
TcpKeepalive() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
TcpListener - Class in akka.io
INTERNAL API
TcpListener(ActorRef, TcpExt, ChannelRegistry, ActorRef, Tcp.Bind) - Constructor for class akka.io.TcpListener
 
TcpListener$ - Class in akka.io
INTERNAL API
TcpListener$() - Constructor for class akka.io.TcpListener$
 
TcpListener.FailedRegisterIncoming - Class in akka.io
 
TcpListener.FailedRegisterIncoming(SocketChannel) - Constructor for class akka.io.TcpListener.FailedRegisterIncoming
 
TcpListener.FailedRegisterIncoming$ - Class in akka.io
 
TcpListener.FailedRegisterIncoming$() - Constructor for class akka.io.TcpListener.FailedRegisterIncoming$
 
TcpListener.RegisterIncoming - Class in akka.io
 
TcpListener.RegisterIncoming(SocketChannel) - Constructor for class akka.io.TcpListener.RegisterIncoming
 
TcpListener.RegisterIncoming$ - Class in akka.io
 
TcpListener.RegisterIncoming$() - Constructor for class akka.io.TcpListener.RegisterIncoming$
 
TcpManager - Class in akka.io
INTERNAL API
TcpManager(TcpExt) - Constructor for class akka.io.TcpManager
 
TcpMessage - Class in akka.io
 
TcpMessage() - Constructor for class akka.io.TcpMessage
 
TcpMessage$ - Class in akka.io
 
TcpMessage$() - Constructor for class akka.io.TcpMessage$
 
tcpNoDelay(boolean) - Method in class akka.io.TcpSO$
Inet.SocketOption to enable or disable TCP_NODELAY (disable or enable Nagle's algorithm)
tcpNoDelay(boolean) - Static method in class akka.io.TcpSO
Inet.SocketOption to enable or disable TCP_NODELAY (disable or enable Nagle's algorithm)
TcpNodelay() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
TcpOutgoingConnection - Class in akka.io
An actor handling the connection state machine for an outgoing connection to be established.
TcpOutgoingConnection(TcpExt, ChannelRegistry, ActorRef, Tcp.Connect) - Constructor for class akka.io.TcpOutgoingConnection
 
TcpReuseAddr() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
TcpServerHandler - Class in akka.remote.transport.netty
INTERNAL API
TcpServerHandler(NettyTransport, Future<Transport.AssociationEventListener>) - Constructor for class akka.remote.transport.netty.TcpServerHandler
 
TcpSO - Class in akka.io
Java API for accessing socket options.
TcpSO() - Constructor for class akka.io.TcpSO
 
TcpSO$ - Class in akka.io
Java API for accessing socket options.
TcpSO$() - Constructor for class akka.io.TcpSO$
 
team() - Method in class akka.dispatch.BalancingDispatcher
INTERNAL API
teamWork() - Method in class akka.dispatch.BalancingDispatcher
 
tell(Object, ActorRef) - Method in class akka.actor.ActorRef
Sends the specified message to the sender, i.e.
tell(Object, ActorRef) - Method in class akka.actor.ActorSelection
Sends the specified message to the sender, i.e.
tellWatchersWeDied() - Method in interface akka.actor.dungeon.DeathWatch
 
tempContainer() - Method in interface akka.actor.ActorRefProvider
Returns the actor reference representing the &ldquo;/temp&rdquo; path.
tempContainer() - Method in class akka.actor.LocalActorRefProvider
 
tempContainer() - Method in class akka.remote.RemoteActorRefProvider
 
template() - Method in interface akka.camel.Camel
The Camel ProducerTemplate.
template() - Method in class akka.camel.internal.DefaultCamel
 
temporaryServerAddress(String, boolean) - Method in class akka.testkit.SocketUtil$
 
temporaryServerAddress(String, boolean) - Static method in class akka.testkit.SocketUtil
 
temporaryServerAddresses(int, String, boolean) - Method in class akka.testkit.SocketUtil$
 
temporaryServerAddresses(int, String, boolean) - Static method in class akka.testkit.SocketUtil
 
tempPath() - Method in interface akka.actor.ActorRefProvider
Generates and returns a unique actor path below &ldquo;/temp&rdquo;.
tempPath() - Method in class akka.actor.LocalActorRefProvider
 
tempPath() - Method in class akka.remote.RemoteActorRefProvider
 
term() - Method in class akka.zeromq.Context
 
terminate() - Method in interface akka.actor.dungeon.FaultHandling
 
terminate(FSM.State<S, D>) - Method in interface akka.actor.FSM
 
Terminate - Class in akka.dispatch.sysmsg
INTERNAL API
Terminate() - Constructor for class akka.dispatch.sysmsg.Terminate
 
Terminate - Class in akka.remote.testconductor
 
Terminate(RoleName, Either<Object, Object>) - Constructor for class akka.remote.testconductor.Terminate
 
Terminate$ - Class in akka.dispatch.sysmsg
 
Terminate$() - Constructor for class akka.dispatch.sysmsg.Terminate$
 
Terminate$ - Class in akka.remote.testconductor
 
Terminate$() - Constructor for class akka.remote.testconductor.Terminate$
 
Terminated - Class in akka.actor
When Death Watch is used, the watcher will receive a Terminated(watched) message when watched is terminated.
Terminated(ActorRef, boolean, boolean) - Constructor for class akka.actor.Terminated
 
terminated(UniqueAddress, UniqueAddress) - Method in class akka.cluster.Reachability
 
terminated() - Method in class akka.contrib.pattern.ReliableProxy
 
terminated(ActorRef, boolean, boolean) - Method in class akka.remote.RemoteWatcher
 
Terminated$ - Class in akka.actor
 
Terminated$() - Constructor for class akka.actor.Terminated$
 
Terminated_VALUE - Static variable in enum akka.cluster.protobuf.msg.ClusterMessages.ReachabilityStatus
Terminated = 2;
terminatedProps() - Method in class akka.actor.ActorCell$
 
terminatedProps() - Static method in class akka.actor.ActorCell
 
terminatedQueued() - Method in interface akka.actor.dungeon.DeathWatch
 
terminatedQueuedFor(ActorRef) - Method in interface akka.actor.dungeon.DeathWatch
 
terminateEvent() - Method in interface akka.actor.FSM
 
TerminateMsg - Class in akka.remote.testconductor
 
TerminateMsg(Either<Object, Object>) - Constructor for class akka.remote.testconductor.TerminateMsg
 
TerminateMsg$ - Class in akka.remote.testconductor
 
TerminateMsg$() - Constructor for class akka.remote.testconductor.TerminateMsg$
 
terminationFuture() - Method in interface akka.actor.ActorRefProvider
This Future is completed upon termination of this ActorRefProvider, which is usually initiated by stopping the guardian via ActorSystem.stop().
terminationFuture() - Method in class akka.actor.ActorSystemImpl
 
terminationFuture() - Method in class akka.actor.LocalActorRefProvider
 
terminationFuture() - Method in class akka.remote.RemoteActorRefProvider
 
terminationHookDoneWhenNoChildren() - Method in class akka.remote.RemoteSystemDaemon
 
terminationPromise() - Method in class akka.actor.LocalActorRefProvider
 
test(T) - Method in interface akka.japi.function.Predicate
 
test(T) - Method in interface akka.japi.Predicate
 
test() - Method in class akka.testkit.CustomEventFilter
 
TestActor - Class in akka.testkit
 
TestActor(BlockingDeque<TestActor.Message>) - Constructor for class akka.testkit.TestActor
 
testActor() - Method in interface akka.testkit.TestKitBase
ActorRef of the test actor.
TestActor$ - Class in akka.testkit
 
TestActor$() - Constructor for class akka.testkit.TestActor$
 
TestActor.AutoPilot - Class in akka.testkit
 
TestActor.AutoPilot() - Constructor for class akka.testkit.TestActor.AutoPilot
 
TestActor.KeepRunning$ - Class in akka.testkit
 
TestActor.KeepRunning$() - Constructor for class akka.testkit.TestActor.KeepRunning$
 
TestActor.Message - Interface in akka.testkit
 
TestActor.NoAutoPilot$ - Class in akka.testkit
 
TestActor.NoAutoPilot$() - Constructor for class akka.testkit.TestActor.NoAutoPilot$
 
TestActor.NullMessage$ - Class in akka.testkit
 
TestActor.NullMessage$() - Constructor for class akka.testkit.TestActor.NullMessage$
 
TestActor.RealMessage - Class in akka.testkit
 
TestActor.RealMessage(Object, ActorRef) - Constructor for class akka.testkit.TestActor.RealMessage
 
TestActor.RealMessage$ - Class in akka.testkit
 
TestActor.RealMessage$() - Constructor for class akka.testkit.TestActor.RealMessage$
 
TestActor.SetAutoPilot - Class in akka.testkit
 
TestActor.SetAutoPilot(TestActor.AutoPilot) - Constructor for class akka.testkit.TestActor.SetAutoPilot
 
TestActor.SetAutoPilot$ - Class in akka.testkit
 
TestActor.SetAutoPilot$() - Constructor for class akka.testkit.TestActor.SetAutoPilot$
 
TestActor.SetIgnore - Class in akka.testkit
 
TestActor.SetIgnore(Option<PartialFunction<Object, Object>>) - Constructor for class akka.testkit.TestActor.SetIgnore
 
TestActor.SetIgnore$ - Class in akka.testkit
 
TestActor.SetIgnore$() - Constructor for class akka.testkit.TestActor.SetIgnore$
 
TestActor.UnWatch - Class in akka.testkit
 
TestActor.UnWatch(ActorRef) - Constructor for class akka.testkit.TestActor.UnWatch
 
TestActor.UnWatch$ - Class in akka.testkit
 
TestActor.UnWatch$() - Constructor for class akka.testkit.TestActor.UnWatch$
 
TestActor.Watch - Class in akka.testkit
 
TestActor.Watch(ActorRef) - Constructor for class akka.testkit.TestActor.Watch
 
TestActor.Watch$ - Class in akka.testkit
 
TestActor.Watch$() - Constructor for class akka.testkit.TestActor.Watch$
 
testActorId() - Method in class akka.testkit.TestKit$
 
testActorId() - Static method in class akka.testkit.TestKit
 
TestActorRef<T extends Actor> - Class in akka.testkit
This special ActorRef is exclusively for use during unit testing in a single-threaded environment.
TestActorRef(ActorSystem, Props, ActorRef, String) - Constructor for class akka.testkit.TestActorRef
 
TestActorRef$ - Class in akka.testkit
 
TestActorRef$() - Constructor for class akka.testkit.TestActorRef$
 
TestActorRefSpec - Class in akka.testkit
 
TestActorRefSpec() - Constructor for class akka.testkit.TestActorRefSpec
 
TestActorRefSpec$ - Class in akka.testkit
Test whether TestActorRef behaves as an ActorRef should, besides its own spec.
TestActorRefSpec$() - Constructor for class akka.testkit.TestActorRefSpec$
 
TestActorRefSpec.Logger - Class in akka.testkit
 
TestActorRefSpec.Logger() - Constructor for class akka.testkit.TestActorRefSpec.Logger
 
TestActorRefSpec.ReceiveTimeoutActor - Class in akka.testkit
 
TestActorRefSpec.ReceiveTimeoutActor(ActorRef) - Constructor for class akka.testkit.TestActorRefSpec.ReceiveTimeoutActor
 
TestActorRefSpec.ReplyActor - Class in akka.testkit
 
TestActorRefSpec.ReplyActor() - Constructor for class akka.testkit.TestActorRefSpec.ReplyActor
 
TestActorRefSpec.SenderActor - Class in akka.testkit
 
TestActorRefSpec.SenderActor(ActorRef) - Constructor for class akka.testkit.TestActorRefSpec.SenderActor
 
TestActorRefSpec.TActor - Interface in akka.testkit
 
TestActorRefSpec.WorkerActor - Class in akka.testkit
 
TestActorRefSpec.WorkerActor() - Constructor for class akka.testkit.TestActorRefSpec.WorkerActor
 
TestActorRefSpec.WrappedTerminated - Class in akka.testkit
Forwarding Terminated to non-watching testActor is not possible, and therefore the Terminated message is wrapped.
TestActorRefSpec.WrappedTerminated(Terminated) - Constructor for class akka.testkit.TestActorRefSpec.WrappedTerminated
 
TestActorRefSpec.WrappedTerminated$ - Class in akka.testkit
 
TestActorRefSpec.WrappedTerminated$() - Constructor for class akka.testkit.TestActorRefSpec.WrappedTerminated$
 
TestActors - Class in akka.testkit
A collection of common actor patterns used in tests.
TestActors() - Constructor for class akka.testkit.TestActors
 
TestActors$ - Class in akka.testkit
A collection of common actor patterns used in tests.
TestActors$() - Constructor for class akka.testkit.TestActors$
 
TestActors.EchoActor - Class in akka.testkit
EchoActor sends back received messages (unmodified).
TestActors.EchoActor() - Constructor for class akka.testkit.TestActors.EchoActor
 
TestActorsSpec - Class in akka.testkit
 
TestActorsSpec() - Constructor for class akka.testkit.TestActorsSpec
 
TestAssociationHandle - Class in akka.remote.transport
 
TestAssociationHandle(Address, Address, TestTransport, boolean) - Constructor for class akka.remote.transport.TestAssociationHandle
 
TestAssociationHandle$ - Class in akka.remote.transport
 
TestAssociationHandle$() - Constructor for class akka.remote.transport.TestAssociationHandle$
 
TestBarrier - Class in akka.testkit
 
TestBarrier(int) - Constructor for class akka.testkit.TestBarrier
 
TestBarrier$ - Class in akka.testkit
A cyclic barrier wrapper for use in testing.
TestBarrier$() - Constructor for class akka.testkit.TestBarrier$
 
TestBarrierTimeoutException - Exception in akka.testkit
 
TestBarrierTimeoutException(String) - Constructor for exception akka.testkit.TestBarrierTimeoutException
 
TestConductor - Class in akka.remote.testconductor
Access to the TestConductorExt extension:
TestConductor() - Constructor for class akka.remote.testconductor.TestConductor
 
testConductor() - Method in class akka.remote.testkit.MultiNodeSpec
Access to the barriers, failure injection, etc.
TestConductor$ - Class in akka.remote.testconductor
Access to the TestConductorExt extension:
TestConductor$() - Constructor for class akka.remote.testconductor.TestConductor$
 
TestConductorExt - Class in akka.remote.testconductor
This binds together the Conductor and Player roles inside an Akka Extension.
TestConductorExt(ExtendedActorSystem) - Constructor for class akka.remote.testconductor.TestConductorExt
 
TestConductorExt.Settings - Class in akka.remote.testconductor
 
TestConductorExt.Settings() - Constructor for class akka.remote.testconductor.TestConductorExt.Settings
 
TestConductorPipelineFactory - Class in akka.remote.testconductor
INTERNAL API.
TestConductorPipelineFactory(org.jboss.netty.channel.ChannelUpstreamHandler) - Constructor for class akka.remote.testconductor.TestConductorPipelineFactory
 
TestConductorProtocol - Class in akka.remote.testconductor
 
TestConductorProtocol.Address - Class in akka.remote.testconductor
Protobuf type Address
TestConductorProtocol.Address.Builder - Class in akka.remote.testconductor
Protobuf type Address
TestConductorProtocol.AddressOrBuilder - Interface in akka.remote.testconductor
 
TestConductorProtocol.AddressRequest - Class in akka.remote.testconductor
Protobuf type AddressRequest
TestConductorProtocol.AddressRequest.Builder - Class in akka.remote.testconductor
Protobuf type AddressRequest
TestConductorProtocol.AddressRequestOrBuilder - Interface in akka.remote.testconductor
 
TestConductorProtocol.BarrierOp - Enum in akka.remote.testconductor
Protobuf enum BarrierOp
TestConductorProtocol.Direction - Enum in akka.remote.testconductor
Protobuf enum Direction
TestConductorProtocol.EnterBarrier - Class in akka.remote.testconductor
Protobuf type EnterBarrier
TestConductorProtocol.EnterBarrier.Builder - Class in akka.remote.testconductor
Protobuf type EnterBarrier
TestConductorProtocol.EnterBarrierOrBuilder - Interface in akka.remote.testconductor
 
TestConductorProtocol.FailType - Enum in akka.remote.testconductor
Protobuf enum FailType
TestConductorProtocol.Hello - Class in akka.remote.testconductor
Protobuf type Hello
TestConductorProtocol.Hello.Builder - Class in akka.remote.testconductor
Protobuf type Hello
TestConductorProtocol.HelloOrBuilder - Interface in akka.remote.testconductor
 
TestConductorProtocol.InjectFailure - Class in akka.remote.testconductor
Protobuf type InjectFailure
TestConductorProtocol.InjectFailure.Builder - Class in akka.remote.testconductor
Protobuf type InjectFailure
TestConductorProtocol.InjectFailureOrBuilder - Interface in akka.remote.testconductor
 
TestConductorProtocol.Wrapper - Class in akka.remote.testconductor
Protobuf type Wrapper
TestConductorProtocol.Wrapper.Builder - Class in akka.remote.testconductor
Protobuf type Wrapper
TestConductorProtocol.WrapperOrBuilder - Interface in akka.remote.testconductor
 
testConf() - Method in class akka.testkit.AkkaSpec$
 
testConf() - Static method in class akka.testkit.AkkaSpec
 
TestEvent - Interface in akka.testkit
Implementation helpers of the EventFilter facilities: send Mute to the TestEventListener to install a filter, and UnMute to deinstall it.
TestEvent$ - Class in akka.testkit
Implementation helpers of the EventFilter facilities: send Mute to the TestEventFilter to install a filter, and UnMute to deinstall it.
TestEvent$() - Constructor for class akka.testkit.TestEvent$
 
TestEvent.Mute - Class in akka.testkit
 
TestEvent.Mute(Seq<EventFilter>) - Constructor for class akka.testkit.TestEvent.Mute
 
TestEvent.Mute(Iterable<EventFilter>) - Constructor for class akka.testkit.TestEvent.Mute
Java API: create a Mute command from a list of filters
TestEvent.Mute$ - Class in akka.testkit
 
TestEvent.Mute$() - Constructor for class akka.testkit.TestEvent.Mute$
 
TestEvent.UnMute - Class in akka.testkit
 
TestEvent.UnMute(Seq<EventFilter>) - Constructor for class akka.testkit.TestEvent.UnMute
 
TestEvent.UnMute(Iterable<EventFilter>) - Constructor for class akka.testkit.TestEvent.UnMute
Java API: create an UnMute command from a list of filters
TestEvent.UnMute$ - Class in akka.testkit
 
TestEvent.UnMute$() - Constructor for class akka.testkit.TestEvent.UnMute$
 
TestEventFilterLeeway() - Method in class akka.testkit.TestKitSettings
 
TestEventListener - Class in akka.testkit
EventListener for running tests, which allows selectively filtering out expected messages.
TestEventListener() - Constructor for class akka.testkit.TestEventListener
 
TestFSMRef<S,D,T extends Actor> - Class in akka.testkit
This is a specialised form of the TestActorRef with support for querying and setting the state of a FSM.
TestFSMRef(ActorSystem, Props, ActorRef, String, Predef.$less$colon$less<T, FSM<S, D>>) - Constructor for class akka.testkit.TestFSMRef
 
TestFSMRef$ - Class in akka.testkit
 
TestFSMRef$() - Constructor for class akka.testkit.TestFSMRef$
 
TestFSMRefSpec - Class in akka.testkit
 
TestFSMRefSpec() - Constructor for class akka.testkit.TestFSMRefSpec
 
TestKit - Class in akka.testkit
Test kit for testing actors.
TestKit(ActorSystem) - Constructor for class akka.testkit.TestKit
 
TestKit$ - Class in akka.testkit
 
TestKit$() - Constructor for class akka.testkit.TestKit$
 
TestKitBase - Interface in akka.testkit
Implementation trait behind the TestKit class: you may use this if inheriting from a concrete class is not possible.
TestKitExtension - Class in akka.testkit
 
TestKitExtension() - Constructor for class akka.testkit.TestKitExtension
 
TestKitExtension$ - Class in akka.testkit
 
TestKitExtension$() - Constructor for class akka.testkit.TestKitExtension$
 
testKitSettings() - Method in interface akka.testkit.TestKitBase
 
TestKitSettings - Class in akka.testkit
 
TestKitSettings(com.typesafe.config.Config) - Constructor for class akka.testkit.TestKitSettings
 
TestLatch - Class in akka.testkit
 
TestLatch(int, ActorSystem) - Constructor for class akka.testkit.TestLatch
 
TestLatch$ - Class in akka.testkit
A count down latch wrapper for use in testing.
TestLatch$() - Constructor for class akka.testkit.TestLatch$
 
testProbe() - Method in interface akka.persistence.journal.JournalPerfSpec
 
TestProbe - Class in akka.testkit
TestKit-based probe which allows sending, reception and reply.
TestProbe(ActorSystem) - Constructor for class akka.testkit.TestProbe
 
TestProbe$ - Class in akka.testkit
 
TestProbe$() - Constructor for class akka.testkit.TestProbe$
 
TestProbeSpec - Class in akka.testkit
 
TestProbeSpec() - Constructor for class akka.testkit.TestProbeSpec
 
TestTimeFactor() - Method in class akka.testkit.TestKitSettings
 
TestTimeSpec - Class in akka.testkit
 
TestTimeSpec() - Constructor for class akka.testkit.TestTimeSpec
 
testTransport(boolean) - Method in class akka.remote.testkit.MultiNodeConfig
To be able to use blackhole, passThrough, and throttle you must activate the failure injector and throttler transport adapters by specifying testTransport(on = true) in your MultiNodeConfig.
TestTransport - Class in akka.remote.transport
Transport implementation to be used for testing.
TestTransport(Address, TestTransport.AssociationRegistry, int, String) - Constructor for class akka.remote.transport.TestTransport
 
TestTransport(ExtendedActorSystem, com.typesafe.config.Config) - Constructor for class akka.remote.transport.TestTransport
 
TestTransport$ - Class in akka.remote.transport
 
TestTransport$() - Constructor for class akka.remote.transport.TestTransport$
 
TestTransport.Activity - Interface in akka.remote.transport
Base trait for activities that are logged by TestTransport.
TestTransport.AssociateAttempt - Class in akka.remote.transport
 
TestTransport.AssociateAttempt(Address, Address) - Constructor for class akka.remote.transport.TestTransport.AssociateAttempt
 
TestTransport.AssociateAttempt$ - Class in akka.remote.transport
 
TestTransport.AssociateAttempt$() - Constructor for class akka.remote.transport.TestTransport.AssociateAttempt$
 
TestTransport.AssociationRegistry - Class in akka.remote.transport
Shared state among TestTransport instances.
TestTransport.AssociationRegistry() - Constructor for class akka.remote.transport.TestTransport.AssociationRegistry
 
TestTransport.DisassociateAttempt - Class in akka.remote.transport
 
TestTransport.DisassociateAttempt(Address, Address) - Constructor for class akka.remote.transport.TestTransport.DisassociateAttempt
 
TestTransport.DisassociateAttempt$ - Class in akka.remote.transport
 
TestTransport.DisassociateAttempt$() - Constructor for class akka.remote.transport.TestTransport.DisassociateAttempt$
 
TestTransport.ListenAttempt - Class in akka.remote.transport
 
TestTransport.ListenAttempt(Address) - Constructor for class akka.remote.transport.TestTransport.ListenAttempt
 
TestTransport.ListenAttempt$ - Class in akka.remote.transport
 
TestTransport.ListenAttempt$() - Constructor for class akka.remote.transport.TestTransport.ListenAttempt$
 
TestTransport.ShutdownAttempt - Class in akka.remote.transport
 
TestTransport.ShutdownAttempt(Address) - Constructor for class akka.remote.transport.TestTransport.ShutdownAttempt
 
TestTransport.ShutdownAttempt$ - Class in akka.remote.transport
 
TestTransport.ShutdownAttempt$() - Constructor for class akka.remote.transport.TestTransport.ShutdownAttempt$
 
TestTransport.SwitchableLoggedBehavior<A,B> - Class in akka.remote.transport
Test utility to make behavior of functions that return some Future[B] controllable from tests.
TestTransport.SwitchableLoggedBehavior(Function1<A, Future<B>>, Function1<A, BoxedUnit>) - Constructor for class akka.remote.transport.TestTransport.SwitchableLoggedBehavior
 
TestTransport.WriteAttempt - Class in akka.remote.transport
 
TestTransport.WriteAttempt(Address, Address, ByteString) - Constructor for class akka.remote.transport.TestTransport.WriteAttempt
 
TestTransport.WriteAttempt$ - Class in akka.remote.transport
 
TestTransport.WriteAttempt$() - Constructor for class akka.remote.transport.TestTransport.WriteAttempt$
 
theOneWhoWalksTheBubblesOfSpaceTime() - Method in class akka.actor.LocalActorRefProvider
Top-level anchor for the supervision hierarchy of this actor system.
theStash() - Method in interface akka.actor.StashSupport
 
thread() - Method in interface akka.event.Logging.LogEvent
The thread that created this log event
thread() - Method in class akka.testkit.TestActorRefSpec$
 
thread() - Static method in class akka.testkit.TestActorRefSpec
 
threadFactory() - Method in class akka.actor.ActorSystemImpl
 
threadFactory() - Method in class akka.actor.ExtendedActorSystem
A ThreadFactory that can be used if the transport needs to create any Threads
threadFactory() - Method in class akka.dispatch.DefaultDispatcherPrerequisites
 
threadFactory() - Method in interface akka.dispatch.DispatcherPrerequisites
 
threadFactory() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory
 
threadFactory() - Method in class akka.dispatch.ThreadPoolConfig.ThreadPoolExecutorServiceFactory
 
ThreadPoolConfig - Class in akka.dispatch
 
ThreadPoolConfig(boolean, int, int, Duration, Function0<BlockingQueue<Runnable>>, RejectedExecutionHandler) - Constructor for class akka.dispatch.ThreadPoolConfig
 
threadPoolConfig() - Method in class akka.dispatch.ThreadPoolExecutorConfigurator
 
ThreadPoolConfig$ - Class in akka.dispatch
 
ThreadPoolConfig$() - Constructor for class akka.dispatch.ThreadPoolConfig$
 
ThreadPoolConfig.ThreadPoolExecutorServiceFactory - Class in akka.dispatch
 
ThreadPoolConfig.ThreadPoolExecutorServiceFactory(ThreadFactory) - Constructor for class akka.dispatch.ThreadPoolConfig.ThreadPoolExecutorServiceFactory
 
ThreadPoolConfigBuilder - Class in akka.dispatch
A DSL to configure and create a MessageDispatcher with a ThreadPoolExecutor
ThreadPoolConfigBuilder(ThreadPoolConfig) - Constructor for class akka.dispatch.ThreadPoolConfigBuilder
 
ThreadPoolConfigBuilder$ - Class in akka.dispatch
 
ThreadPoolConfigBuilder$() - Constructor for class akka.dispatch.ThreadPoolConfigBuilder$
 
ThreadPoolExecutorConfigurator - Class in akka.dispatch
 
ThreadPoolExecutorConfigurator(com.typesafe.config.Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.ThreadPoolExecutorConfigurator
 
threadTimeout() - Method in class akka.dispatch.ThreadPoolConfig
 
threshold() - Method in class akka.remote.PhiAccrualFailureDetector
 
throttle(RoleName, RoleName, ThrottlerTransportAdapter.Direction, double) - Method in interface akka.remote.testconductor.Conductor
Make the remoting pipeline on the node throttle data sent to or received from the given remote peer.
Throttle - Class in akka.remote.testconductor
 
Throttle(RoleName, RoleName, ThrottlerTransportAdapter.Direction, float) - Constructor for class akka.remote.testconductor.Throttle
 
Throttle$ - Class in akka.remote.testconductor
 
Throttle$() - Constructor for class akka.remote.testconductor.Throttle$
 
Throttle_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.FailType
Throttle = 1;
ThrottledAssociation - Class in akka.remote.transport
INTERNAL API
ThrottledAssociation(ActorRef, Transport.AssociationEventListener, AssociationHandle, boolean) - Constructor for class akka.remote.transport.ThrottledAssociation
 
ThrottledAssociation$ - Class in akka.remote.transport
INTERNAL API
ThrottledAssociation$() - Constructor for class akka.remote.transport.ThrottledAssociation$
 
ThrottledAssociation.Dequeue$ - Class in akka.remote.transport
 
ThrottledAssociation.Dequeue$() - Constructor for class akka.remote.transport.ThrottledAssociation.Dequeue$
 
ThrottledAssociation.ExposedHandle - Class in akka.remote.transport
 
ThrottledAssociation.ExposedHandle(ThrottlerHandle) - Constructor for class akka.remote.transport.ThrottledAssociation.ExposedHandle
 
ThrottledAssociation.ExposedHandle$ - Class in akka.remote.transport
 
ThrottledAssociation.ExposedHandle$() - Constructor for class akka.remote.transport.ThrottledAssociation.ExposedHandle$
 
ThrottledAssociation.FailWith - Class in akka.remote.transport
 
ThrottledAssociation.FailWith(AssociationHandle.DisassociateInfo) - Constructor for class akka.remote.transport.ThrottledAssociation.FailWith
 
ThrottledAssociation.FailWith$ - Class in akka.remote.transport
 
ThrottledAssociation.FailWith$() - Constructor for class akka.remote.transport.ThrottledAssociation.FailWith$
 
ThrottledAssociation.ThrottlerData - Interface in akka.remote.transport
 
ThrottledAssociation.ThrottlerState - Interface in akka.remote.transport
 
ThrottledAssociation.Throttling$ - Class in akka.remote.transport
 
ThrottledAssociation.Throttling$() - Constructor for class akka.remote.transport.ThrottledAssociation.Throttling$
 
ThrottledAssociation.Uninitialized$ - Class in akka.remote.transport
 
ThrottledAssociation.Uninitialized$() - Constructor for class akka.remote.transport.ThrottledAssociation.Uninitialized$
 
ThrottledAssociation.WaitExposedHandle$ - Class in akka.remote.transport
 
ThrottledAssociation.WaitExposedHandle$() - Constructor for class akka.remote.transport.ThrottledAssociation.WaitExposedHandle$
 
ThrottledAssociation.WaitMode$ - Class in akka.remote.transport
 
ThrottledAssociation.WaitMode$() - Constructor for class akka.remote.transport.ThrottledAssociation.WaitMode$
 
ThrottledAssociation.WaitModeAndUpstreamListener$ - Class in akka.remote.transport
 
ThrottledAssociation.WaitModeAndUpstreamListener$() - Constructor for class akka.remote.transport.ThrottledAssociation.WaitModeAndUpstreamListener$
 
ThrottledAssociation.WaitOrigin$ - Class in akka.remote.transport
 
ThrottledAssociation.WaitOrigin$() - Constructor for class akka.remote.transport.ThrottledAssociation.WaitOrigin$
 
ThrottledAssociation.WaitUpstreamListener$ - Class in akka.remote.transport
 
ThrottledAssociation.WaitUpstreamListener$() - Constructor for class akka.remote.transport.ThrottledAssociation.WaitUpstreamListener$
 
throttledMessages() - Method in class akka.remote.transport.ThrottledAssociation
 
ThrottleMsg - Class in akka.remote.testconductor
 
ThrottleMsg(Address, ThrottlerTransportAdapter.Direction, float) - Constructor for class akka.remote.testconductor.ThrottleMsg
 
ThrottleMsg$ - Class in akka.remote.testconductor
 
ThrottleMsg$() - Constructor for class akka.remote.testconductor.ThrottleMsg$
 
Throttler - Class in akka.contrib.throttle
 
Throttler() - Constructor for class akka.contrib.throttle.Throttler
 
Throttler$ - Class in akka.contrib.throttle
 
Throttler$() - Constructor for class akka.contrib.throttle.Throttler$
 
Throttler.Rate - Class in akka.contrib.throttle
A rate used for throttling.
Throttler.Rate(int, FiniteDuration) - Constructor for class akka.contrib.throttle.Throttler.Rate
 
Throttler.Rate$ - Class in akka.contrib.throttle
 
Throttler.Rate$() - Constructor for class akka.contrib.throttle.Throttler.Rate$
 
Throttler.RateInt - Class in akka.contrib.throttle
Helper for some syntactic sugar.
Throttler.RateInt(int) - Constructor for class akka.contrib.throttle.Throttler.RateInt
 
Throttler.RateInt$ - Class in akka.contrib.throttle
 
Throttler.RateInt$() - Constructor for class akka.contrib.throttle.Throttler.RateInt$
 
Throttler.SetRate - Class in akka.contrib.throttle
Set the rate of a throttler.
Throttler.SetRate(Throttler.Rate) - Constructor for class akka.contrib.throttle.Throttler.SetRate
 
Throttler.SetRate$ - Class in akka.contrib.throttle
 
Throttler.SetRate$() - Constructor for class akka.contrib.throttle.Throttler.SetRate$
 
Throttler.SetTarget - Class in akka.contrib.throttle
Set the target of a throttler.
Throttler.SetTarget(Option<ActorRef>) - Constructor for class akka.contrib.throttle.Throttler.SetTarget
 
Throttler.SetTarget(ActorRef) - Constructor for class akka.contrib.throttle.Throttler.SetTarget
Java API:
Throttler.SetTarget$ - Class in akka.contrib.throttle
 
Throttler.SetTarget$() - Constructor for class akka.contrib.throttle.Throttler.SetTarget$
 
throttlerActor() - Method in class akka.remote.transport.ThrottlerHandle
 
ThrottlerHandle - Class in akka.remote.transport
INTERNAL API
ThrottlerHandle(AssociationHandle, ActorRef) - Constructor for class akka.remote.transport.ThrottlerHandle
 
ThrottlerHandle$ - Class in akka.remote.transport
 
ThrottlerHandle$() - Constructor for class akka.remote.transport.ThrottlerHandle$
 
ThrottlerManager - Class in akka.remote.transport
INTERNAL API
ThrottlerManager(Transport) - Constructor for class akka.remote.transport.ThrottlerManager
 
ThrottlerManager$ - Class in akka.remote.transport
INTERNAL API
ThrottlerManager$() - Constructor for class akka.remote.transport.ThrottlerManager$
 
ThrottlerManager.AssociateResult - Class in akka.remote.transport
 
ThrottlerManager.AssociateResult(AssociationHandle, Promise<AssociationHandle>) - Constructor for class akka.remote.transport.ThrottlerManager.AssociateResult
 
ThrottlerManager.AssociateResult$ - Class in akka.remote.transport
 
ThrottlerManager.AssociateResult$() - Constructor for class akka.remote.transport.ThrottlerManager.AssociateResult$
 
ThrottlerManager.Checkin - Class in akka.remote.transport
 
ThrottlerManager.Checkin(Address, ThrottlerHandle) - Constructor for class akka.remote.transport.ThrottlerManager.Checkin
 
ThrottlerManager.Checkin$ - Class in akka.remote.transport
 
ThrottlerManager.Checkin$() - Constructor for class akka.remote.transport.ThrottlerManager.Checkin$
 
ThrottlerManager.Handle - Class in akka.remote.transport
 
ThrottlerManager.Handle(ThrottlerHandle) - Constructor for class akka.remote.transport.ThrottlerManager.Handle
 
ThrottlerManager.Handle$ - Class in akka.remote.transport
 
ThrottlerManager.Handle$() - Constructor for class akka.remote.transport.ThrottlerManager.Handle$
 
ThrottlerManager.Listener - Class in akka.remote.transport
 
ThrottlerManager.Listener(AssociationHandle.HandleEventListener) - Constructor for class akka.remote.transport.ThrottlerManager.Listener
 
ThrottlerManager.Listener$ - Class in akka.remote.transport
 
ThrottlerManager.Listener$() - Constructor for class akka.remote.transport.ThrottlerManager.Listener$
 
ThrottlerManager.ListenerAndMode - Class in akka.remote.transport
 
ThrottlerManager.ListenerAndMode(AssociationHandle.HandleEventListener, ThrottlerTransportAdapter.ThrottleMode) - Constructor for class akka.remote.transport.ThrottlerManager.ListenerAndMode
 
ThrottlerManager.ListenerAndMode$ - Class in akka.remote.transport
 
ThrottlerManager.ListenerAndMode$() - Constructor for class akka.remote.transport.ThrottlerManager.ListenerAndMode$
 
ThrottlerProvider - Class in akka.remote.transport
 
ThrottlerProvider() - Constructor for class akka.remote.transport.ThrottlerProvider
 
ThrottlerTransportAdapter - Class in akka.remote.transport
 
ThrottlerTransportAdapter(Transport, ExtendedActorSystem) - Constructor for class akka.remote.transport.ThrottlerTransportAdapter
 
ThrottlerTransportAdapter$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter$
 
ThrottlerTransportAdapter.Blackhole$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.Blackhole$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.Blackhole$
 
ThrottlerTransportAdapter.Direction - Interface in akka.remote.transport
 
ThrottlerTransportAdapter.Direction$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.Direction$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.Direction$
 
ThrottlerTransportAdapter.Direction.Both$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.Direction.Both$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.Direction.Both$
 
ThrottlerTransportAdapter.Direction.Receive$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.Direction.Receive$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.Direction.Receive$
 
ThrottlerTransportAdapter.Direction.Send$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.Direction.Send$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.Direction.Send$
 
ThrottlerTransportAdapter.ForceDisassociate - Class in akka.remote.transport
Management Command to force dissocation of an address.
ThrottlerTransportAdapter.ForceDisassociate(Address) - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociate
 
ThrottlerTransportAdapter.ForceDisassociate$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.ForceDisassociate$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociate$
 
ThrottlerTransportAdapter.ForceDisassociateAck$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.ForceDisassociateAck$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociateAck$
 
ThrottlerTransportAdapter.ForceDisassociateExplicitly - Class in akka.remote.transport
Management Command to force dissocation of an address with an explicit error.
ThrottlerTransportAdapter.ForceDisassociateExplicitly(Address, AssociationHandle.DisassociateInfo) - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociateExplicitly
 
ThrottlerTransportAdapter.ForceDisassociateExplicitly$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.ForceDisassociateExplicitly$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociateExplicitly$
 
ThrottlerTransportAdapter.SetThrottle - Class in akka.remote.transport
 
ThrottlerTransportAdapter.SetThrottle(Address, ThrottlerTransportAdapter.Direction, ThrottlerTransportAdapter.ThrottleMode) - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.SetThrottle
 
ThrottlerTransportAdapter.SetThrottle$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.SetThrottle$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.SetThrottle$
 
ThrottlerTransportAdapter.SetThrottleAck$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.SetThrottleAck$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.SetThrottleAck$
 
ThrottlerTransportAdapter.ThrottleMode - Interface in akka.remote.transport
 
ThrottlerTransportAdapter.TokenBucket - Class in akka.remote.transport
 
ThrottlerTransportAdapter.TokenBucket(int, double, long, int) - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket
 
ThrottlerTransportAdapter.TokenBucket$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.TokenBucket$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket$
 
ThrottlerTransportAdapter.Unthrottled$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.Unthrottled$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.Unthrottled$
 
throughput() - Method in class akka.dispatch.Dispatcher
 
throughput() - Method in class akka.dispatch.MessageDispatcher
INTERNAL API
throughput() - Method in class akka.testkit.CallingThreadDispatcher
 
throughputDeadlineTime() - Method in class akka.dispatch.Dispatcher
 
throughputDeadlineTime() - Method in class akka.dispatch.MessageDispatcher
INTERNAL API
throughputDeadlineTime() - Method in class akka.testkit.CallingThreadDispatcher
 
throwable() - Method in class akka.testkit.ErrorFilter
 
TickDuration() - Method in class akka.actor.LightArrayRevolverScheduler
 
ticks() - Method in class akka.actor.LightArrayRevolverScheduler.TaskHolder
 
timeOfRelease() - Method in class akka.remote.EndpointManager.Gated
 
timeOfRelease() - Method in class akka.remote.EndpointManager.Quarantined
 
timeout() - Method in class akka.actor.FSM.State
 
timeout() - Method in class akka.actor.TypedActor.SerializedTypedActorInvocationHandler
 
timeout() - Method in class akka.actor.TypedActor.TypedActorInvocationHandler
 
timeout() - Method in class akka.actor.TypedProps
 
timeout() - Method in class akka.cluster.FirstSeedNodeProcess
 
timeout() - Method in class akka.io.Tcp.Connect
 
timeout() - Method in interface akka.persistence.journal.AsyncWriteProxy
 
timeout() - Method in class akka.persistence.journal.inmem.InmemJournal
 
timeout() - Method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
 
timeout() - Method in class akka.remote.testconductor.EnterBarrier
 
timeout() - Method in interface akka.testkit.DefaultTimeout
 
Timeout - Class in akka.util
 
Timeout(FiniteDuration) - Constructor for class akka.util.Timeout
 
Timeout(long) - Constructor for class akka.util.Timeout
Construct a Timeout from the given number of milliseconds.
Timeout(long, TimeUnit) - Constructor for class akka.util.Timeout
Construct a Timeout from the given time unit and factor.
Timeout$ - Class in akka.util
A Timeout is a wrapper on top of Duration to be more specific about what the duration means.
Timeout$() - Constructor for class akka.util.Timeout$
 
TIMEOUT_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
timeoutFuture() - Method in interface akka.actor.FSM
 
TimerBasedThrottler - Class in akka.contrib.throttle
A throttler that uses a timer to control the message delivery rate.
TimerBasedThrottler(Throttler.Rate) - Constructor for class akka.contrib.throttle.TimerBasedThrottler
 
TimerBasedThrottler$ - Class in akka.contrib.throttle
INTERNAL API
TimerBasedThrottler$() - Constructor for class akka.contrib.throttle.TimerBasedThrottler$
 
TimerBasedThrottler.Active$ - Class in akka.contrib.throttle
 
TimerBasedThrottler.Active$() - Constructor for class akka.contrib.throttle.TimerBasedThrottler.Active$
 
TimerBasedThrottler.Data - Class in akka.contrib.throttle
 
TimerBasedThrottler.Data(Option<ActorRef>, int, Queue<TimerBasedThrottler.Message>) - Constructor for class akka.contrib.throttle.TimerBasedThrottler.Data
 
TimerBasedThrottler.Data$ - Class in akka.contrib.throttle
 
TimerBasedThrottler.Data$() - Constructor for class akka.contrib.throttle.TimerBasedThrottler.Data$
 
TimerBasedThrottler.Idle$ - Class in akka.contrib.throttle
 
TimerBasedThrottler.Idle$() - Constructor for class akka.contrib.throttle.TimerBasedThrottler.Idle$
 
TimerBasedThrottler.Message - Class in akka.contrib.throttle
 
TimerBasedThrottler.Message(Object, ActorRef) - Constructor for class akka.contrib.throttle.TimerBasedThrottler.Message
 
TimerBasedThrottler.Message$ - Class in akka.contrib.throttle
 
TimerBasedThrottler.Message$() - Constructor for class akka.contrib.throttle.TimerBasedThrottler.Message$
 
TimerBasedThrottler.State - Interface in akka.contrib.throttle
 
TimerBasedThrottler.Tick$ - Class in akka.contrib.throttle
 
TimerBasedThrottler.Tick$() - Constructor for class akka.contrib.throttle.TimerBasedThrottler.Tick$
 
timerGen() - Method in interface akka.actor.FSM
 
timers() - Method in interface akka.actor.FSM
 
timestamp() - Method in class akka.cluster.NodeMetrics
 
timestamp() - Method in class akka.cluster.StandardMetrics.Cpu
 
timestamp() - Method in class akka.cluster.StandardMetrics.HeapMemory
 
timestamp() - Method in interface akka.event.Logging.LogEvent
When this LogEvent was created according to System.currentTimeMillis
timestamp(Logging.LogEvent) - Method in interface akka.event.Logging.StdOutLogger
 
timestamp() - Method in class akka.persistence.AtLeastOnceDelivery.Internal$.Delivery
 
timestamp() - Method in class akka.persistence.ReliableDelivery.DeliveryAttempt
 
timestamp() - Method in class akka.persistence.SnapshotMetadata
 
TIMESTAMP_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
TIMESTAMP_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
 
TIMESTAMP_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
 
TIMESTAMP_FIELD_NUMBER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
 
timeToAvailable(long, int) - Method in class akka.remote.transport.ThrottlerTransportAdapter.Blackhole$
 
timeToAvailable(long, int) - Method in interface akka.remote.transport.ThrottlerTransportAdapter.ThrottleMode
 
timeToAvailable(long, int) - Method in class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket
 
timeToAvailable(long, int) - Method in class akka.remote.transport.ThrottlerTransportAdapter.Unthrottled$
 
TimingTest - Class in akka.testkit
 
TimingTest() - Constructor for class akka.testkit.TimingTest
 
TimingTest$ - Class in akka.testkit
 
TimingTest$() - Constructor for class akka.testkit.TimingTest$
 
to() - Method in class akka.actor.FSM.Transition
 
to(ActorRef) - Method in class akka.camel.ActorRouteDefinition
Sends the message to an ActorRef endpoint.
to(ActorRef, boolean, Duration) - Method in class akka.camel.ActorRouteDefinition
Sends the message to an ActorRef endpoint
to() - Method in class akka.cluster.GossipEnvelope
 
to() - Method in class akka.cluster.InternalClusterAction.Subscribe
 
to() - Method in class akka.cluster.InternalClusterAction.Unsubscribe
 
to(ActorRef) - Method in class akka.pattern.PipeToSupport.PipeableFuture
 
to(ActorRef, ActorRef) - Method in class akka.pattern.PipeToSupport.PipeableFuture
 
to(ActorSelection) - Method in class akka.pattern.PipeToSupport.PipeableFuture
 
to(ActorSelection, ActorRef) - Method in class akka.pattern.PipeToSupport.PipeableFuture
 
TO_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
toAkkaCamelException() - Method in class akka.camel.internal.CamelExchangeAdapter
Creates an AkkaCamelException object from the adapted Exchange.
toAkkaCamelException(Map<String, Object>) - Method in class akka.camel.internal.CamelExchangeAdapter
Creates an AkkaCamelException object from the adapted Exchange.
toArray() - Method in class akka.util.BoundedBlockingQueue
 
toArray(X[]) - Method in class akka.util.BoundedBlockingQueue
 
toArray(ClassTag<B>) - Method in class akka.util.ByteIterator
 
toArray() - Method in class akka.util.ByteString
Java API: copy this ByteString into a fresh byte array
toArray(ClassTag<B>) - Method in class akka.util.ByteString
 
toBinary(Object) - Method in class akka.cluster.protobuf.ClusterMessageSerializer
 
toBinary(Object) - Method in class akka.contrib.pattern.protobuf.DistributedPubSubMessageSerializer
 
toBinary(Object) - Method in class akka.persistence.serialization.MessageSerializer
Serializes PersistentBatch, PersistentRepr and Deliver messages.
toBinary(Object) - Method in class akka.persistence.serialization.SnapshotSerializer
Serializes a Snapshot.
toBinary(Object) - Method in class akka.remote.serialization.DaemonMsgCreateSerializer
 
toBinary(Object) - Method in class akka.remote.serialization.MessageContainerSerializer
 
toBinary(Object) - Method in class akka.remote.serialization.ProtobufSerializer
 
toBinary(Object) - Method in class akka.serialization.ByteArraySerializer
 
toBinary(Object) - Method in class akka.serialization.JavaSerializer
 
toBinary(Object) - Method in class akka.serialization.NullSerializer
 
toBinary(Object) - Method in interface akka.serialization.Serializer
Serializes the given object into an Array of Byte
toBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
toBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
 
toBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
toBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
toBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
 
toBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
toBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
 
toBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
toBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
toBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
toBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
 
toBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
toBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
toBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
toBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
toBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
toBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
 
toBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
 
toBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
 
toBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
 
toBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
toBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
toBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
toBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
 
toBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
toBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
 
toBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
toBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
toBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
 
toBuilder() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
 
toBuilder() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
toBuilder() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
toBuilder() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
toBuilder() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage
 
toBuilder() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
toBuilder() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
 
toBuilder() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
toBuilder() - Method in class akka.remote.ContainerFormats.Selection
 
toBuilder() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
toBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
toBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
toBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
toBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
toBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
toBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
toBuilder() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
toBuilder() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
toBuilder() - Method in class akka.remote.WireFormats.ActorRefData
 
toBuilder() - Method in class akka.remote.WireFormats.AddressData
 
toBuilder() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
toBuilder() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
toBuilder() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
toBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
toBuilder() - Method in class akka.remote.WireFormats.DeployData
 
toBuilder() - Method in class akka.remote.WireFormats.PropsData
 
toBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
toBuilder() - Method in class akka.remote.WireFormats.SerializedMessage
 
toByteBuffer() - Method in class akka.util.ByteString
Creates a new ByteBuffer with a copy of all bytes contained in this ByteString.
toByteString() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
toByteString() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
toByteString() - Method in class akka.util.ByteIterator
 
toByteString1() - Method in class akka.util.ByteString.ByteString1C
 
toChannelSettings() - Method in class akka.persistence.PersistentChannelSettings
Converts this configuration object to ChannelSettings.
ToClient - Class in akka.remote.testconductor
 
ToClient(ClientOp) - Constructor for class akka.remote.testconductor.ToClient
 
ToClient$ - Class in akka.remote.testconductor
 
ToClient$() - Constructor for class akka.remote.testconductor.ToClient$
 
toDie() - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
 
toFailureMessage() - Method in class akka.camel.internal.CamelExchangeAdapter
Creates an immutable Failure object from the adapted Exchange so it can be used internally between Actors.
toFailureResult(Map<String, Object>) - Method in class akka.camel.internal.CamelExchangeAdapter
Creates an immutable FailureResult object from the adapted Exchange so it can be used internally between Actors.
token() - Method in class akka.io.Tcp.NoAck
 
token() - Method in class akka.io.Udp.NoAck
 
token() - Method in class akka.io.UdpConnected.NoAck
 
tokensPerSecond() - Method in class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket
 
toList() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
topic() - Method in class akka.contrib.pattern.ClusterClient.Publish
 
topic() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Publish
 
topic() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Subscribe
 
topic() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Unsubscribe
 
TOPIC_FIELD_NUMBER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
 
topicRef() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Internal$.RegisterTopic
 
toRequestMessage() - Method in class akka.camel.internal.CamelExchangeAdapter
Creates an immutable CamelMessage object from Exchange.getIn so it can be used with Actors.
toRequestMessage(Map<String, Object>) - Method in class akka.camel.internal.CamelExchangeAdapter
Creates an immutable CamelMessage object from Exchange.getIn so it can be used with Actors.
toResponseMessage() - Method in class akka.camel.internal.CamelExchangeAdapter
Depending on the exchange pattern, creates an immutable CamelMessage object from Exchange.getIn or Exchange.getOut so it can be used with Actors.
toResponseMessage(Map<String, Object>) - Method in class akka.camel.internal.CamelExchangeAdapter
Depending on the exchange pattern, creates an immutable CamelMessage object from Exchange.getIn or Exchange.getOut so it can be used with Actors.
toScala(ActorSelection) - Method in class akka.actor.ActorSelection$
 
toScala(ActorSelection) - Static method in class akka.actor.ActorSelection
 
toScala() - Method in class akka.japi.Pair
 
toScala() - Method in class akka.japi.tuple.Tuple10
 
toScala() - Method in class akka.japi.tuple.Tuple11
 
toScala() - Method in class akka.japi.tuple.Tuple12
 
toScala() - Method in class akka.japi.tuple.Tuple13
 
toScala() - Method in class akka.japi.tuple.Tuple14
 
toScala() - Method in class akka.japi.tuple.Tuple15
 
toScala() - Method in class akka.japi.tuple.Tuple16
 
toScala() - Method in class akka.japi.tuple.Tuple17
 
toScala() - Method in class akka.japi.tuple.Tuple18
 
toScala() - Method in class akka.japi.tuple.Tuple19
 
toScala() - Method in class akka.japi.tuple.Tuple20
 
toScala() - Method in class akka.japi.tuple.Tuple21
 
toScala() - Method in class akka.japi.tuple.Tuple22
 
toScala() - Method in class akka.japi.tuple.Tuple3
 
toScala() - Method in class akka.japi.tuple.Tuple4
 
toScala() - Method in class akka.japi.tuple.Tuple5
 
toScala() - Method in class akka.japi.tuple.Tuple6
 
toScala() - Method in class akka.japi.tuple.Tuple7
 
toScala() - Method in class akka.japi.tuple.Tuple8
 
toScala() - Method in class akka.japi.tuple.Tuple9
 
toSeq() - Method in class akka.util.ByteIterator
 
toSequenceNr() - Method in class akka.persistence.journal.AsyncWriteTarget.DeleteMessagesTo
 
toSequenceNr() - Method in class akka.persistence.journal.AsyncWriteTarget.ReplayMessages
 
toSequenceNr() - Method in class akka.persistence.JournalProtocol.DeleteMessagesTo
 
toSequenceNr() - Method in class akka.persistence.JournalProtocol.ReplayMessages
 
toSequenceNr() - Method in class akka.persistence.Recover
 
toSequenceNr() - Method in class akka.persistence.SnapshotProtocol.LoadSnapshot
 
toSequenceNr() - Method in class akka.persistence.SnapshotProtocol.LoadSnapshotResult
 
toSerializationFormat() - Method in interface akka.actor.ActorPath
Generate full String representation including the uid for the actor cell instance as URI fragment.
toSerializationFormat() - Method in class akka.actor.ActorSelection
String representation of the actor selection suitable for storage and recreation.
toSerializationFormat() - Method in class akka.actor.ChildActorPath
 
toSerializationFormat() - Method in class akka.actor.RootActorPath
 
toSerializationFormatWithAddress(Address) - Method in interface akka.actor.ActorPath
Generate full String representation including the uid for the actor cell instance as URI fragment, replacing the Address in the RootActor Path with the given one unless this path&rsquo;s address includes host and port information.
toSerializationFormatWithAddress(Address) - Method in class akka.actor.ChildActorPath
 
toSerializationFormatWithAddress(Address) - Method in class akka.actor.RootActorPath
 
ToServer - Class in akka.remote.testconductor
 
ToServer(ServerOp) - Constructor for class akka.remote.testconductor.ToServer
 
ToServer$ - Class in akka.remote.testconductor
 
ToServer$() - Constructor for class akka.remote.testconductor.ToServer$
 
toString() - Method in class akka.actor.ActorRef
 
toString() - Method in class akka.actor.ActorSelection
 
toString() - Method in class akka.actor.ActorSystem.Settings
Returns the String representation of the Config that this Settings is backed by
toString() - Method in class akka.actor.ActorSystemImpl
 
toString() - Method in class akka.actor.Address
Returns the canonical String representation of this Address formatted as:
toString() - Method in class akka.actor.ChildActorPath
 
toString() - Method in class akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer$
 
toString() - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
 
toString() - Method in class akka.actor.dungeon.ChildrenContainer.TerminatedChildrenContainer$
 
toString() - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
 
toString() - Method in class akka.actor.mailbox.filebased.filequeue.Counter
 
toString() - Method in class akka.actor.RootActorPath
 
toString() - Method in class akka.actor.SelectChildName
 
toString() - Method in class akka.actor.SelectChildPattern
 
toString() - Method in class akka.actor.SelectParent$
 
toString() - Static method in class akka.actor.SelectParent
 
toString() - Method in class akka.camel.CamelMessage
 
toString() - Method in class akka.cluster.Gossip
 
toString() - Method in class akka.cluster.GossipOverview
 
toString() - Method in class akka.cluster.Member
 
toString() - Method in class akka.cluster.Reachability
 
toString() - Method in class akka.cluster.VectorClock
 
toString() - Method in class akka.dispatch.Dispatcher
 
toString() - Method in class akka.event.Logging.StandardOutLogger
 
toString() - Method in class akka.remote.Ack
 
toString() - Method in class akka.remote.AckedReceiveBuffer
 
toString() - Method in class akka.remote.AckedSendBuffer
 
toString() - Method in class akka.remote.AssociationErrorEvent
 
toString() - Method in interface akka.remote.AssociationEvent
 
toString() - Method in class akka.remote.EndpointManager.Send
 
toString() - Method in class akka.remote.QuarantinedEvent
 
toString() - Method in class akka.remote.RemoteWatcher.Stats
 
toString() - Method in class akka.remote.RemotingErrorEvent
 
toString() - Method in class akka.remote.RemotingListenEvent
 
toString() - Method in class akka.remote.RemotingShutdownEvent$
 
toString() - Static method in class akka.remote.RemotingShutdownEvent
 
toString() - Method in class akka.remote.SeqNo
 
toString() - Method in interface akka.remote.testconductor.BarrierCoordinator.Printer
 
toString() - Method in class akka.remote.transport.AssociationHandle.InboundPayload
 
toString() - Method in class akka.remote.transport.netty.NettyTransportSettings.Tcp$
 
toString() - Method in class akka.remote.transport.netty.NettyTransportSettings.Udp$
 
toString() - Method in class akka.remote.transport.TestTransport
 
toString() - Method in class akka.routing.ConsistentActorRef
 
toString() - Method in class akka.routing.ConsistentRoutee
 
toString() - Method in class akka.testkit.TestActorRef
 
toString() - Method in class akka.util.SerializedSuspendableExecutionContext
 
toString() - Method in class akka.util.SubclassifiedIndex.Nonroot
 
toString() - Method in class akka.util.SubclassifiedIndex
 
toString() - Method in class akka.zeromq.ZeroMQVersion
 
toStringWithAddress(Address) - Method in interface akka.actor.ActorPath
Generate String representation, replacing the Address in the RootActor Path with the given one unless this path&rsquo;s address includes host and port information.
toStringWithAddress(Address) - Method in class akka.actor.ChildActorPath
 
toStringWithAddress(Address) - Method in class akka.actor.RootActorPath
 
toStringWithoutAddress() - Method in interface akka.actor.ActorPath
String representation of the path elements, excluding the address information.
total() - Method in class akka.cluster.routing.WeightedRoutees
 
total2pf(Function2<S, S, BoxedUnit>) - Method in interface akka.actor.FSM
 
totalAdded() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
totalBufferSize() - Method in class akka.contrib.pattern.ShardRegion
 
totalDiscarded() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
totalExpired() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
totalInstances() - Method in class akka.cluster.routing.ClusterRouterGroupSettings
 
totalInstances() - Method in class akka.cluster.routing.ClusterRouterPoolSettings
 
totalInstances() - Method in class akka.cluster.routing.ClusterRouterSettings
 
totalInstances() - Method in interface akka.cluster.routing.ClusterRouterSettingsBase
 
totalItems() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
toTypedActorInvocationHandler(ActorSystem) - Method in class akka.actor.TypedActor.SerializedTypedActorInvocationHandler
 
toUri(ActorRef) - Method in class akka.camel.internal.component.CamelPath$
Converts the actorRef to a Camel URI (string) which can be used in custom routes.
toUri(ActorRef, boolean, Duration) - Method in class akka.camel.internal.component.CamelPath$
Converts the actorRef to a Camel URI (string) which can be used in custom routes.
toUri(ActorRef) - Static method in class akka.camel.internal.component.CamelPath
Converts the actorRef to a Camel URI (string) which can be used in custom routes.
toUri(ActorRef, boolean, Duration) - Static method in class akka.camel.internal.component.CamelPath
Converts the actorRef to a Camel URI (string) which can be used in custom routes.
TraceLogging() - Method in class akka.io.SelectionHandlerSettings
 
trackChange(Function0<BoxedUnit>) - Method in class akka.contrib.pattern.ClusterSingletonProxy
 
TrafficClass() - Method in interface akka.io.Inet.SoForwarders
Inet.SocketOption to set the traffic class or type-of-service octet in the IP header for packets sent from this socket.
trafficClass(int) - Method in interface akka.io.Inet.SoJavaFactories
Inet.SocketOption to set the traffic class or type-of-service octet in the IP header for packets sent from this socket.
Transactor - Interface in akka.transactor
An actor with built-in support for coordinated transactions.
TransactorExtension - Class in akka.transactor
TransactorExtension is an Akka Extension to hold settings for transactors.
TransactorExtension() - Constructor for class akka.transactor.TransactorExtension
 
TransactorExtension$ - Class in akka.transactor
TransactorExtension is an Akka Extension to hold settings for transactors.
TransactorExtension$() - Constructor for class akka.transactor.TransactorExtension$
 
TransactorSettings - Class in akka.transactor
 
TransactorSettings(com.typesafe.config.Config) - Constructor for class akka.transactor.TransactorSettings
 
transcend(boolean, Function0<BoxedUnit>) - Method in class akka.util.Switch
 
TransferToLimit() - Method in class akka.io.TcpExt.Settings
 
transform(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Method in interface akka.actor.FSM
 
transformException(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.ExceptionEvent) - Method in interface akka.remote.transport.netty.NettyHelpers
 
transformOutgoingMessage(Object) - Method in class akka.camel.javaapi.UntypedProducerActor
 
transformOutgoingMessage(Object) - Method in interface akka.camel.ProducerSupport
Called before the message is sent to the endpoint specified by endpointUri.
transformResponse(Object) - Method in class akka.camel.javaapi.UntypedProducerActor
 
transformResponse(Object) - Method in interface akka.camel.ProducerSupport
Called before the response message is sent to the original sender.
transitionEvent() - Method in interface akka.actor.FSM
 
transport() - Method in class akka.remote.EndpointActor
 
transport() - Method in class akka.remote.ReliableDeliverySupervisor
 
transport() - Method in class akka.remote.RemoteActorRefProvider
 
transport() - Method in class akka.remote.testconductor.TestConductorExt
Remote transport used by the actor ref provider.
transport() - Method in class akka.remote.transport.netty.ClientHandler
 
transport() - Method in interface akka.remote.transport.netty.CommonHandlers
 
transport() - Method in class akka.remote.transport.netty.ServerHandler
 
transport() - Method in class akka.remote.transport.netty.TcpAssociationHandle
 
transport() - Method in class akka.remote.transport.ProtocolStateActor.OutboundUnassociated
 
transport() - Method in class akka.remote.transport.TestAssociationHandle
 
Transport - Interface in akka.remote.transport
An SPI layer for implementing asynchronous transport mechanisms.
Transport$ - Class in akka.remote.transport
 
Transport$() - Constructor for class akka.remote.transport.Transport$
 
Transport.ActorAssociationEventListener - Class in akka.remote.transport
Class to convert ordinary ActorRef instances to an AssociationEventListener.
Transport.ActorAssociationEventListener(ActorRef) - Constructor for class akka.remote.transport.Transport.ActorAssociationEventListener
 
Transport.ActorAssociationEventListener$ - Class in akka.remote.transport
 
Transport.ActorAssociationEventListener$() - Constructor for class akka.remote.transport.Transport.ActorAssociationEventListener$
 
Transport.AssociationEvent - Interface in akka.remote.transport
 
Transport.AssociationEventListener - Interface in akka.remote.transport
An interface that needs to be implemented by the user of a transport to listen to association events
Transport.InboundAssociation - Class in akka.remote.transport
Message sent to a Transport.AssociationEventListener registered to a transport (via the Promise returned by akka.remote.transport.Transport.listen) when an inbound association request arrives.
Transport.InboundAssociation(AssociationHandle) - Constructor for class akka.remote.transport.Transport.InboundAssociation
 
Transport.InboundAssociation$ - Class in akka.remote.transport
 
Transport.InboundAssociation$() - Constructor for class akka.remote.transport.Transport.InboundAssociation$
 
Transport.InvalidAssociationException - Exception in akka.remote.transport
Indicates that the association setup request is invalid, and it is impossible to recover (malformed IP address, hostname, etc.).
Transport.InvalidAssociationException(String, Throwable) - Constructor for exception akka.remote.transport.Transport.InvalidAssociationException
 
Transport.InvalidAssociationException$ - Class in akka.remote.transport
 
Transport.InvalidAssociationException$() - Constructor for class akka.remote.transport.Transport.InvalidAssociationException$
 
TransportAdapterProvider - Interface in akka.remote.transport
 
TransportAdapters - Class in akka.remote.transport
 
TransportAdapters(ExtendedActorSystem) - Constructor for class akka.remote.transport.TransportAdapters
 
TransportAdaptersExtension - Class in akka.remote.transport
 
TransportAdaptersExtension() - Constructor for class akka.remote.transport.TransportAdaptersExtension
 
TransportAdaptersExtension$ - Class in akka.remote.transport
 
TransportAdaptersExtension$() - Constructor for class akka.remote.transport.TransportAdaptersExtension$
 
TransportFailureDetectorConfig() - Method in class akka.remote.transport.AkkaProtocolSettings
 
TransportFailureDetectorImplementationClass() - Method in class akka.remote.transport.AkkaProtocolSettings
 
transportFor(Address) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Returns the Transport bound to the given address.
TransportHeartBeatInterval() - Method in class akka.remote.transport.AkkaProtocolSettings
 
transportMapping() - Method in class akka.remote.EndpointManager
 
TransportMode() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
Transports() - Method in class akka.remote.RemoteSettings
 
transportsReady(Seq<Address>) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Indicates if all given transports were successfully registered.
transportSupervisor() - Method in class akka.remote.Remoting
 
traverse(Iterable<A>, Function<A, Future<B>>, ExecutionContext) - Method in class akka.dispatch.Futures$
Transforms a JIterable[A] into a Future[JIterable[B} using the provided Function A ⇒ Future[B].
traverse(Iterable<A>, Function<A, Future<B>>, ExecutionContext) - Static method in class akka.dispatch.Futures
Transforms a JIterable[A] into a Future[JIterable[B} using the provided Function A ⇒ Future[B].
tries() - Method in class akka.contrib.mailbox.PeekMailbox
 
triggerFirstHeartbeat(UniqueAddress) - Method in class akka.cluster.ClusterHeartbeatSender
 
triggerFirstHeartbeat(Address) - Method in class akka.remote.RemoteWatcher
 
TrustedSelectionPaths() - Method in class akka.remote.RemoteSettings
 
tryConsumeTokens(long, int) - Method in class akka.remote.transport.ThrottlerTransportAdapter.Blackhole$
 
tryConsumeTokens(long, int) - Method in interface akka.remote.transport.ThrottlerTransportAdapter.ThrottleMode
 
tryConsumeTokens(long, int) - Method in class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket
 
tryConsumeTokens(long, int) - Method in class akka.remote.transport.ThrottlerTransportAdapter.Unthrottled$
 
tryingToJoin(Address, Option<Deadline>) - Method in class akka.cluster.ClusterCoreDaemon
 
tunnel() - Method in class akka.contrib.pattern.ReliableProxy
 
Tuple10<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10> - Class in akka.japi.tuple
 
Tuple10(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Constructor for class akka.japi.tuple.Tuple10
 
Tuple10$ - Class in akka.japi.tuple
Used to create tuples with 10 elements in Java.
Tuple10$() - Constructor for class akka.japi.tuple.Tuple10$
 
Tuple11<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11> - Class in akka.japi.tuple
 
Tuple11(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Constructor for class akka.japi.tuple.Tuple11
 
Tuple11$ - Class in akka.japi.tuple
Used to create tuples with 11 elements in Java.
Tuple11$() - Constructor for class akka.japi.tuple.Tuple11$
 
Tuple12<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12> - Class in akka.japi.tuple
 
Tuple12(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Constructor for class akka.japi.tuple.Tuple12
 
Tuple12$ - Class in akka.japi.tuple
Used to create tuples with 12 elements in Java.
Tuple12$() - Constructor for class akka.japi.tuple.Tuple12$
 
Tuple13<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13> - Class in akka.japi.tuple
 
Tuple13(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Constructor for class akka.japi.tuple.Tuple13
 
Tuple13$ - Class in akka.japi.tuple
Used to create tuples with 13 elements in Java.
Tuple13$() - Constructor for class akka.japi.tuple.Tuple13$
 
Tuple14<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14> - Class in akka.japi.tuple
 
Tuple14(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Constructor for class akka.japi.tuple.Tuple14
 
Tuple14$ - Class in akka.japi.tuple
Used to create tuples with 14 elements in Java.
Tuple14$() - Constructor for class akka.japi.tuple.Tuple14$
 
Tuple15<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15> - Class in akka.japi.tuple
 
Tuple15(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Constructor for class akka.japi.tuple.Tuple15
 
Tuple15$ - Class in akka.japi.tuple
Used to create tuples with 15 elements in Java.
Tuple15$() - Constructor for class akka.japi.tuple.Tuple15$
 
Tuple16<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16> - Class in akka.japi.tuple
 
Tuple16(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Constructor for class akka.japi.tuple.Tuple16
 
Tuple16$ - Class in akka.japi.tuple
Used to create tuples with 16 elements in Java.
Tuple16$() - Constructor for class akka.japi.tuple.Tuple16$
 
Tuple17<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17> - Class in akka.japi.tuple
 
Tuple17(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Constructor for class akka.japi.tuple.Tuple17
 
Tuple17$ - Class in akka.japi.tuple
Used to create tuples with 17 elements in Java.
Tuple17$() - Constructor for class akka.japi.tuple.Tuple17$
 
Tuple18<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18> - Class in akka.japi.tuple
 
Tuple18(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Constructor for class akka.japi.tuple.Tuple18
 
Tuple18$ - Class in akka.japi.tuple
Used to create tuples with 18 elements in Java.
Tuple18$() - Constructor for class akka.japi.tuple.Tuple18$
 
Tuple19<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19> - Class in akka.japi.tuple
 
Tuple19(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Constructor for class akka.japi.tuple.Tuple19
 
Tuple19$ - Class in akka.japi.tuple
Used to create tuples with 19 elements in Java.
Tuple19$() - Constructor for class akka.japi.tuple.Tuple19$
 
Tuple20<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20> - Class in akka.japi.tuple
 
Tuple20(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Constructor for class akka.japi.tuple.Tuple20
 
Tuple20$ - Class in akka.japi.tuple
Used to create tuples with 20 elements in Java.
Tuple20$() - Constructor for class akka.japi.tuple.Tuple20$
 
Tuple21<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21> - Class in akka.japi.tuple
 
Tuple21(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Constructor for class akka.japi.tuple.Tuple21
 
Tuple21$ - Class in akka.japi.tuple
Used to create tuples with 21 elements in Java.
Tuple21$() - Constructor for class akka.japi.tuple.Tuple21$
 
Tuple22<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22> - Class in akka.japi.tuple
 
Tuple22(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Constructor for class akka.japi.tuple.Tuple22
 
Tuple22$ - Class in akka.japi.tuple
Used to create tuples with 22 elements in Java.
Tuple22$() - Constructor for class akka.japi.tuple.Tuple22$
 
Tuple3<T1,T2,T3> - Class in akka.japi.tuple
 
Tuple3(T1, T2, T3) - Constructor for class akka.japi.tuple.Tuple3
 
Tuple3$ - Class in akka.japi.tuple
Used to create tuples with 3 elements in Java.
Tuple3$() - Constructor for class akka.japi.tuple.Tuple3$
 
Tuple4<T1,T2,T3,T4> - Class in akka.japi.tuple
 
Tuple4(T1, T2, T3, T4) - Constructor for class akka.japi.tuple.Tuple4
 
Tuple4$ - Class in akka.japi.tuple
Used to create tuples with 4 elements in Java.
Tuple4$() - Constructor for class akka.japi.tuple.Tuple4$
 
Tuple5<T1,T2,T3,T4,T5> - Class in akka.japi.tuple
 
Tuple5(T1, T2, T3, T4, T5) - Constructor for class akka.japi.tuple.Tuple5
 
Tuple5$ - Class in akka.japi.tuple
Used to create tuples with 5 elements in Java.
Tuple5$() - Constructor for class akka.japi.tuple.Tuple5$
 
Tuple6<T1,T2,T3,T4,T5,T6> - Class in akka.japi.tuple
 
Tuple6(T1, T2, T3, T4, T5, T6) - Constructor for class akka.japi.tuple.Tuple6
 
Tuple6$ - Class in akka.japi.tuple
Used to create tuples with 6 elements in Java.
Tuple6$() - Constructor for class akka.japi.tuple.Tuple6$
 
Tuple7<T1,T2,T3,T4,T5,T6,T7> - Class in akka.japi.tuple
 
Tuple7(T1, T2, T3, T4, T5, T6, T7) - Constructor for class akka.japi.tuple.Tuple7
 
Tuple7$ - Class in akka.japi.tuple
Used to create tuples with 7 elements in Java.
Tuple7$() - Constructor for class akka.japi.tuple.Tuple7$
 
Tuple8<T1,T2,T3,T4,T5,T6,T7,T8> - Class in akka.japi.tuple
 
Tuple8(T1, T2, T3, T4, T5, T6, T7, T8) - Constructor for class akka.japi.tuple.Tuple8
 
Tuple8$ - Class in akka.japi.tuple
Used to create tuples with 8 elements in Java.
Tuple8$() - Constructor for class akka.japi.tuple.Tuple8$
 
Tuple9<T1,T2,T3,T4,T5,T6,T7,T8,T9> - Class in akka.japi.tuple
 
Tuple9(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Constructor for class akka.japi.tuple.Tuple9
 
Tuple9$ - Class in akka.japi.tuple
Used to create tuples with 9 elements in Java.
Tuple9$() - Constructor for class akka.japi.tuple.Tuple9$
 
TYPE_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
TYPE_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.Selection
 
typedActor() - Method in class akka.actor.ContextualTypedActorFactory
 
TypedActor - Class in akka.actor
This represents the TypedActor Akka Extension, access to the functionality is done through a given ActorSystem.
TypedActor() - Constructor for class akka.actor.TypedActor
 
typedActor() - Method in class akka.actor.TypedActorExtension
 
typedActor() - Method in interface akka.actor.TypedActorFactory
Underlying dependency to a TypedActorExtension, which can either be contextual or ActorSystem "global"
TypedActor$ - Class in akka.actor
This represents the TypedActor Akka Extension, access to the functionality is done through a given ActorSystem.
TypedActor$() - Constructor for class akka.actor.TypedActor$
 
TypedActor.MethodCall - Class in akka.actor
This class represents a Method call, and has a reference to the Method to be called and the parameters to supply It's sent to the ActorRef backing the TypedActor and can be serialized and deserialized
TypedActor.MethodCall(Method, Object[]) - Constructor for class akka.actor.TypedActor.MethodCall
 
TypedActor.MethodCall$ - Class in akka.actor
 
TypedActor.MethodCall$() - Constructor for class akka.actor.TypedActor.MethodCall$
 
TypedActor.PostRestart - Interface in akka.actor
 
TypedActor.PostStop - Interface in akka.actor
Mix this into your TypedActor to be able to hook into its lifecycle
TypedActor.PreRestart - Interface in akka.actor
Mix this into your TypedActor to be able to hook into its lifecycle
TypedActor.PreStart - Interface in akka.actor
Mix this into your TypedActor to be able to hook into its lifecycle
TypedActor.Receiver - Interface in akka.actor
Mix this into your TypedActor to be able to intercept Terminated messages
TypedActor.SerializedMethodCall - Class in akka.actor
INTERNAL API
TypedActor.SerializedMethodCall(Class<?>, String, Class<?>[], Tuple3<Object, Class<?>, byte[]>[]) - Constructor for class akka.actor.TypedActor.SerializedMethodCall
 
TypedActor.SerializedMethodCall$ - Class in akka.actor
 
TypedActor.SerializedMethodCall$() - Constructor for class akka.actor.TypedActor.SerializedMethodCall$
 
TypedActor.SerializedTypedActorInvocationHandler - Class in akka.actor
INTERNAL API
TypedActor.SerializedTypedActorInvocationHandler(ActorRef, FiniteDuration) - Constructor for class akka.actor.TypedActor.SerializedTypedActorInvocationHandler
 
TypedActor.SerializedTypedActorInvocationHandler$ - Class in akka.actor
 
TypedActor.SerializedTypedActorInvocationHandler$() - Constructor for class akka.actor.TypedActor.SerializedTypedActorInvocationHandler$
 
TypedActor.Supervisor - Interface in akka.actor
Mix this into your TypedActor to be able to define supervisor strategy
TypedActor.TypedActor<R,T extends R> - Class in akka.actor
INTERNAL API
TypedActor.TypedActor(AtomicReference<R>, Function0<T>, Seq<Class<?>>) - Constructor for class akka.actor.TypedActor.TypedActor
 
TypedActor.TypedActorInvocationHandler - Class in akka.actor
INTERNAL API
TypedActor.TypedActorInvocationHandler(TypedActorExtension, AtomicReference<ActorRef>, Timeout) - Constructor for class akka.actor.TypedActor.TypedActorInvocationHandler
 
TypedActorExtension - Class in akka.actor
 
TypedActorExtension(ExtendedActorSystem) - Constructor for class akka.actor.TypedActorExtension
 
TypedActorFactory - Interface in akka.actor
A TypedActorFactory is something that can created TypedActor instances.
typedActorOf(TypedProps<T>) - Method in interface akka.actor.TypedActorFactory
Creates a new TypedActor with the specified properties
typedActorOf(TypedProps<T>, String) - Method in interface akka.actor.TypedActorFactory
Creates a new TypedActor with the specified properties
typedActorOf(TypedProps<T>, ActorRef) - Method in interface akka.actor.TypedActorFactory
Creates a TypedActor that intercepts the calls and forwards them as TypedActor.MethodCall to the provided ActorRef.
TypedCreatorFunctionConsumer - Class in akka.actor
INTERNAL API
TypedCreatorFunctionConsumer(Class<? extends Actor>, Function0<Actor>) - Constructor for class akka.actor.TypedCreatorFunctionConsumer
 
TypedCreatorFunctionConsumerClass() - Method in class akka.actor.IndirectActorProducer$
 
TypedProps<T> - Class in akka.actor
 
TypedProps(Seq<Class<?>>, Function0<T>, String, Deploy, Option<Timeout>, Option<ClassLoader>) - Constructor for class akka.actor.TypedProps
 
TypedProps(Class<T>) - Constructor for class akka.actor.TypedProps
Uses the supplied class as the factory for the TypedActor implementation, and that has the specified interface, or if the interface class is not an interface, all the interfaces it implements, appended in the sequence of interfaces.
TypedProps(Class<? super T>, Creator<T>) - Constructor for class akka.actor.TypedProps
Java API: Uses the supplied Creator as the factory for the TypedActor implementation, and that has the specified interface, or if the interface class is not an interface, all the interfaces it implements, appended in the sequence of interfaces.
TypedProps(Class<? super T>, Class<T>) - Constructor for class akka.actor.TypedProps
Java API: Uses the supplied class as the factory for the TypedActor implementation, and that has the specified interface, or if the interface class is not an interface, all the interfaces it implements, appended in the sequence of interfaces.
TypedProps$ - Class in akka.actor
TypedProps is a TypedActor configuration object, that is thread safe and fully sharable.
TypedProps$() - Constructor for class akka.actor.TypedProps$
 
typeName() - Method in class akka.contrib.pattern.ClusterShardingGuardian.Start
 

U

Udp - Class in akka.io
UDP Extension for Akka&rsquo;s IO layer.
Udp() - Constructor for class akka.io.Udp
 
udp() - Method in class akka.io.UdpListener
 
udp() - Method in class akka.io.UdpSender
 
udp() - Method in interface akka.io.WithUdpSend
 
Udp$ - Class in akka.io
UDP Extension for Akka&rsquo;s IO layer.
Udp$() - Constructor for class akka.io.Udp$
 
Udp.Bind - Class in akka.io
Send this message to the UdpExt.manager() in order to bind to the given local port (or an automatically assigned one if the port number is zero).
Udp.Bind(ActorRef, InetSocketAddress, Traversable<Inet.SocketOption>) - Constructor for class akka.io.Udp.Bind
 
Udp.Bind$ - Class in akka.io
 
Udp.Bind$() - Constructor for class akka.io.Udp.Bind$
 
Udp.Bound - Class in akka.io
This message is sent by the listener actor in response to a Udp.Bind command.
Udp.Bound(InetSocketAddress) - Constructor for class akka.io.Udp.Bound
 
Udp.Bound$ - Class in akka.io
 
Udp.Bound$() - Constructor for class akka.io.Udp.Bound$
 
Udp.Command - Interface in akka.io
The common type of all commands supported by the UDP implementation.
Udp.CommandFailed - Class in akka.io
When a command fails it will be replied to with this message type, wrapping the failing command object.
Udp.CommandFailed(Udp.Command) - Constructor for class akka.io.Udp.CommandFailed
 
Udp.CommandFailed$ - Class in akka.io
 
Udp.CommandFailed$() - Constructor for class akka.io.Udp.CommandFailed$
 
Udp.Event - Interface in akka.io
The common type of all events emitted by the UDP implementation.
Udp.Message - Interface in akka.io
The common interface for Udp.Command and Udp.Event.
Udp.NoAck - Class in akka.io
Each Udp.Send can optionally request a positive acknowledgment to be sent to the commanding actor.
Udp.NoAck(Object) - Constructor for class akka.io.Udp.NoAck
 
Udp.NoAck$ - Class in akka.io
Default Udp.NoAck instance which is used when no acknowledgment information is explicitly provided.
Udp.NoAck$() - Constructor for class akka.io.Udp.NoAck$
 
Udp.Received - Class in akka.io
When a listener actor receives a datagram from its socket it will send it to the handler designated in the Udp.Bind message using this message type.
Udp.Received(ByteString, InetSocketAddress) - Constructor for class akka.io.Udp.Received
 
Udp.Received$ - Class in akka.io
 
Udp.Received$() - Constructor for class akka.io.Udp.Received$
 
Udp.ResumeReading$ - Class in akka.io
This message must be sent to the listener actor to re-enable reading from the socket after a SuspendReading command.
Udp.ResumeReading$() - Constructor for class akka.io.Udp.ResumeReading$
 
Udp.Send - Class in akka.io
This message is understood by the &ldquo;simple sender&rdquo; which can be obtained by sending the Udp.SimpleSender query to the UdpExt.manager() as well as by the listener actors which are created in response to Udp.Bind.
Udp.Send(ByteString, InetSocketAddress, Udp.Event) - Constructor for class akka.io.Udp.Send
 
Udp.Send$ - Class in akka.io
 
Udp.Send$() - Constructor for class akka.io.Udp.Send$
 
Udp.SimpleSender - Class in akka.io
Retrieve a reference to a &ldquo;simple sender&rdquo; actor of the UDP extension.
Udp.SimpleSender(Traversable<Inet.SocketOption>) - Constructor for class akka.io.Udp.SimpleSender
 
Udp.SimpleSender$ - Class in akka.io
 
Udp.SimpleSender$() - Constructor for class akka.io.Udp.SimpleSender$
 
Udp.SimpleSenderReady - Interface in akka.io
The &ldquo;simple sender&rdquo; sends this message type in response to a Udp.SimpleSender query.
Udp.SimpleSenderReady$ - Class in akka.io
 
Udp.SimpleSenderReady$() - Constructor for class akka.io.Udp.SimpleSenderReady$
 
Udp.SO$ - Class in akka.io
Scala API: This object provides access to all socket options applicable to UDP sockets.
Udp.SO$() - Constructor for class akka.io.Udp.SO$
 
Udp.SO$.Broadcast - Class in akka.io
Inet.SocketOption to set the SO_BROADCAST option
Udp.SO$.Broadcast(boolean) - Constructor for class akka.io.Udp.SO$.Broadcast
 
Udp.SuspendReading$ - Class in akka.io
Send this message to a listener actor (which sent a Udp.Bound message) to have it stop reading datagrams from the network.
Udp.SuspendReading$() - Constructor for class akka.io.Udp.SuspendReading$
 
Udp.UdpSettings - Class in akka.io
 
Udp.UdpSettings(com.typesafe.config.Config) - Constructor for class akka.io.Udp.UdpSettings
 
Udp.Unbind$ - Class in akka.io
Send this message to the listener actor that previously sent a Udp.Bound message in order to close the listening socket.
Udp.Unbind$() - Constructor for class akka.io.Udp.Unbind$
 
Udp.Unbound - Interface in akka.io
This message is sent by the listener actor in response to an Unbind command after the socket has been closed.
Udp.Unbound$ - Class in akka.io
 
Udp.Unbound$() - Constructor for class akka.io.Udp.Unbound$
 
UdpAssociationHandle - Class in akka.remote.transport.netty
INTERNAL API
UdpAssociationHandle(Address, Address, org.jboss.netty.channel.Channel, NettyTransport) - Constructor for class akka.remote.transport.netty.UdpAssociationHandle
 
UdpClientHandler - Class in akka.remote.transport.netty
INTERNAL API
UdpClientHandler(NettyTransport, Address) - Constructor for class akka.remote.transport.netty.UdpClientHandler
 
UdpConnected - Class in akka.io
UDP Extension for Akka&rsquo;s IO layer.
UdpConnected() - Constructor for class akka.io.UdpConnected
 
UdpConnected$ - Class in akka.io
UDP Extension for Akka&rsquo;s IO layer.
UdpConnected$() - Constructor for class akka.io.UdpConnected$
 
UdpConnected.Command - Interface in akka.io
The common type of all commands supported by the UDP implementation.
UdpConnected.CommandFailed - Class in akka.io
When a command fails it will be replied to with this message type, wrapping the failing command object.
UdpConnected.CommandFailed(UdpConnected.Command) - Constructor for class akka.io.UdpConnected.CommandFailed
 
UdpConnected.CommandFailed$ - Class in akka.io
 
UdpConnected.CommandFailed$() - Constructor for class akka.io.UdpConnected.CommandFailed$
 
UdpConnected.Connect - Class in akka.io
Send this message to the UdpExt.manager() in order to bind to a local port (optionally with the chosen localAddress) and create a UDP socket which is restricted to sending to and receiving from the given remoteAddress.
UdpConnected.Connect(ActorRef, InetSocketAddress, Option<InetSocketAddress>, Traversable<Inet.SocketOption>) - Constructor for class akka.io.UdpConnected.Connect
 
UdpConnected.Connect$ - Class in akka.io
 
UdpConnected.Connect$() - Constructor for class akka.io.UdpConnected.Connect$
 
UdpConnected.Connected - Interface in akka.io
This message is sent by the connection actor to the actor which sent the UdpConnected.Connect message when the UDP socket has been bound to the local and remote addresses given.
UdpConnected.Connected$ - Class in akka.io
 
UdpConnected.Connected$() - Constructor for class akka.io.UdpConnected.Connected$
 
UdpConnected.Disconnect$ - Class in akka.io
Send this message to a connection actor (which had previously sent the UdpConnected.Connected message) in order to close the socket.
UdpConnected.Disconnect$() - Constructor for class akka.io.UdpConnected.Disconnect$
 
UdpConnected.Disconnected - Interface in akka.io
This message is sent by the connection actor to the actor which sent the Disconnect message when the UDP socket has been closed.
UdpConnected.Disconnected$ - Class in akka.io
 
UdpConnected.Disconnected$() - Constructor for class akka.io.UdpConnected.Disconnected$
 
UdpConnected.Event - Interface in akka.io
The common type of all events emitted by the UDP implementation.
UdpConnected.Message - Interface in akka.io
The common interface for UdpConnected.Command and UdpConnected.Event.
UdpConnected.NoAck - Class in akka.io
Each UdpConnected.Send can optionally request a positive acknowledgment to be sent to the commanding actor.
UdpConnected.NoAck(Object) - Constructor for class akka.io.UdpConnected.NoAck
 
UdpConnected.NoAck$ - Class in akka.io
Default UdpConnected.NoAck instance which is used when no acknowledgment information is explicitly provided.
UdpConnected.NoAck$() - Constructor for class akka.io.UdpConnected.NoAck$
 
UdpConnected.Received - Class in akka.io
When a connection actor receives a datagram from its socket it will send it to the handler designated in the Udp.Bind message using this message type.
UdpConnected.Received(ByteString) - Constructor for class akka.io.UdpConnected.Received
 
UdpConnected.Received$ - Class in akka.io
 
UdpConnected.Received$() - Constructor for class akka.io.UdpConnected.Received$
 
UdpConnected.ResumeReading$ - Class in akka.io
This message must be sent to the listener actor to re-enable reading from the socket after a SuspendReading command.
UdpConnected.ResumeReading$() - Constructor for class akka.io.UdpConnected.ResumeReading$
 
UdpConnected.Send - Class in akka.io
This message is understood by the connection actors to send data to their designated destination.
UdpConnected.Send(ByteString, Object) - Constructor for class akka.io.UdpConnected.Send
 
UdpConnected.Send$ - Class in akka.io
 
UdpConnected.Send$() - Constructor for class akka.io.UdpConnected.Send$
 
UdpConnected.SuspendReading$ - Class in akka.io
Send this message to a listener actor (which sent a Udp.Bound message) to have it stop reading datagrams from the network.
UdpConnected.SuspendReading$() - Constructor for class akka.io.UdpConnected.SuspendReading$
 
UdpConnectedExt - Class in akka.io
 
UdpConnectedExt(ExtendedActorSystem) - Constructor for class akka.io.UdpConnectedExt
 
UdpConnectedManager - Class in akka.io
INTERNAL API
UdpConnectedManager(UdpConnectedExt) - Constructor for class akka.io.UdpConnectedManager
 
UdpConnectedMessage - Class in akka.io
Java API: factory methods for the message types used when communicating with the UdpConnected service.
UdpConnectedMessage() - Constructor for class akka.io.UdpConnectedMessage
 
UdpConnectedMessage$ - Class in akka.io
Java API: factory methods for the message types used when communicating with the UdpConnected service.
UdpConnectedMessage$() - Constructor for class akka.io.UdpConnectedMessage$
 
UdpConnection - Class in akka.io
INTERNAL API
UdpConnection(UdpConnectedExt, ChannelRegistry, ActorRef, UdpConnected.Connect) - Constructor for class akka.io.UdpConnection
 
udpConnectionTable() - Method in class akka.remote.transport.netty.NettyTransport
INTERNAL API
UdpExt - Class in akka.io
 
UdpExt(ExtendedActorSystem) - Constructor for class akka.io.UdpExt
 
UdpHandlers - Interface in akka.remote.transport.netty
INTERNAL API
UdpListener - Class in akka.io
INTERNAL API
UdpListener(UdpExt, ChannelRegistry, ActorRef, Udp.Bind) - Constructor for class akka.io.UdpListener
 
UdpManager - Class in akka.io
INTERNAL API
UdpManager(UdpExt) - Constructor for class akka.io.UdpManager
 
UdpMessage - Class in akka.io
Java API: factory methods for the message types used when communicating with the Udp service.
UdpMessage() - Constructor for class akka.io.UdpMessage
 
UdpMessage$ - Class in akka.io
Java API: factory methods for the message types used when communicating with the Udp service.
UdpMessage$() - Constructor for class akka.io.UdpMessage$
 
UdpSender - Class in akka.io
INTERNAL API
UdpSender(UdpExt, ChannelRegistry, ActorRef, Traversable<Inet.SocketOption>) - Constructor for class akka.io.UdpSender
 
UdpServerHandler - Class in akka.remote.transport.netty
INTERNAL API
UdpServerHandler(NettyTransport, Future<Transport.AssociationEventListener>) - Constructor for class akka.remote.transport.netty.UdpServerHandler
 
UdpSO - Class in akka.io
 
UdpSO() - Constructor for class akka.io.UdpSO
 
UdpSO$ - Class in akka.io
 
UdpSO$() - Constructor for class akka.io.UdpSO$
 
uid() - Method in class akka.actor.ActorCell
 
uid() - Method in interface akka.actor.ActorPath
INTERNAL API Unique identifier of the actor.
uid() - Method in class akka.actor.ChildActorPath
 
uid() - Method in class akka.actor.ChildRestartStats
 
uid() - Method in class akka.actor.RootActorPath
INTERNAL API
uid() - Method in class akka.cluster.UniqueAddress
 
uid() - Method in class akka.dispatch.sysmsg.Failed
 
uid() - Method in class akka.remote.EndpointManager.Pass
 
uid() - Method in class akka.remote.EndpointManager.Quarantine
 
uid() - Method in class akka.remote.EndpointManager.Quarantined
 
uid() - Method in class akka.remote.EndpointManager.ResendState
 
uid() - Method in class akka.remote.EndpointReader
 
uid() - Method in exception akka.remote.HopelessAssociation
 
uid() - Method in class akka.remote.QuarantinedEvent
 
uid() - Method in class akka.remote.ReliableDeliverySupervisor.GotUid
 
uid() - Method in class akka.remote.ReliableDeliverySupervisor
 
uid() - Method in class akka.remote.transport.HandshakeInfo
 
UID_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
 
UID_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AkkaHandshakeInfo
 
uidConfirmed() - Method in class akka.remote.ReliableDeliverySupervisor
 
unapply(ActorInitializationException) - Method in class akka.actor.ActorInitializationException$
 
unapply(ActorInitializationException) - Static method in exception akka.actor.ActorInitializationException
 
unapply(String) - Method in class akka.actor.ActorPathExtractor$
 
unapply(String) - Static method in class akka.actor.ActorPathExtractor
 
unapply(String) - Method in class akka.actor.AddressFromURIString$
 
unapply(URI) - Method in class akka.actor.AddressFromURIString$
 
unapply(String) - Static method in class akka.actor.AddressFromURIString
 
unapply(URI) - Static method in class akka.actor.AddressFromURIString
 
unapply(Tuple2<S, S>) - Method in class akka.actor.FSM.$minus$greater$
 
unapply(PostRestartException) - Method in class akka.actor.OriginalRestartException$
 
unapply(PostRestartException) - Static method in class akka.actor.OriginalRestartException
 
unapply(String) - Method in class akka.actor.RelativeActorPath$
 
unapply(String) - Static method in class akka.actor.RelativeActorPath
 
unapply(ActivationProtocol.ActivationMessage) - Method in class akka.camel.internal.ActivationProtocol.ActivationMessage$
 
unapply(NodeMetrics) - Method in class akka.cluster.StandardMetrics.Cpu$
Given a NodeMetrics it returns the Cpu data if the nodeMetrics contains necessary cpu metrics.
unapply(NodeMetrics) - Method in class akka.cluster.StandardMetrics.HeapMemory$
Given a NodeMetrics it returns the HeapMemory data if the nodeMetrics contains necessary heap metrics.
unapply(ConfirmablePersistent) - Method in class akka.persistence.ConfirmablePersistent$
ConfirmablePersistent extractor.
unapply(ConfirmablePersistent) - Static method in class akka.persistence.ConfirmablePersistent
ConfirmablePersistent extractor.
unapply(Persistent) - Method in class akka.persistence.Persistent$
Persistent extractor.
unapply(Persistent) - Static method in class akka.persistence.Persistent
Persistent extractor.
unapply(FromConfig) - Method in class akka.routing.FromConfig$
 
unapply(FromConfig) - Static method in class akka.routing.FromConfig
 
unapply(Coordinated) - Method in class akka.transactor.Coordinated$
 
unapply(Coordinated) - Static method in class akka.transactor.Coordinated
 
unbatchedExecute(Runnable) - Method in interface akka.dispatch.BatchingExecutor
 
unbatchedExecute(Runnable) - Method in class akka.dispatch.ExecutionContexts.sameThreadExecutionContext$
 
unbatchedExecute(Runnable) - Method in class akka.dispatch.MessageDispatcher
 
unbecome() - Method in class akka.actor.ActorCell
 
unbecome() - Method in interface akka.actor.ActorContext
Reverts the Actor behavior to the previous one on the behavior stack.
unbecome() - Method in interface akka.actor.dsl.Creators.Act
Pop the active behavior from the behavior stack of this actor.
unbind() - Method in class akka.io.TcpMessage$
In order to close down a listening socket, send this message to that socket&rsquo;s actor (that is the actor which previously had sent the Tcp.Bound message).
unbind() - Static method in class akka.io.TcpMessage
In order to close down a listening socket, send this message to that socket&rsquo;s actor (that is the actor which previously had sent the Tcp.Bound message).
unbind() - Method in class akka.io.UdpMessage$
Send this message to the listener actor that previously sent a Udp.Bound message in order to close the listening socket.
unbind() - Static method in class akka.io.UdpMessage
Send this message to the listener actor that previously sent a Udp.Bound message in order to close the listening socket.
UnboundedDequeBasedMailbox - Class in akka.dispatch
UnboundedDequeBasedMailbox is an unbounded MailboxType, backed by a Deque.
UnboundedDequeBasedMailbox() - Constructor for class akka.dispatch.UnboundedDequeBasedMailbox
 
UnboundedDequeBasedMailbox(ActorSystem.Settings, com.typesafe.config.Config) - Constructor for class akka.dispatch.UnboundedDequeBasedMailbox
 
UnboundedDequeBasedMailbox$ - Class in akka.dispatch
 
UnboundedDequeBasedMailbox$() - Constructor for class akka.dispatch.UnboundedDequeBasedMailbox$
 
UnboundedDequeBasedMailbox.MessageQueue - Class in akka.dispatch
 
UnboundedDequeBasedMailbox.MessageQueue() - Constructor for class akka.dispatch.UnboundedDequeBasedMailbox.MessageQueue
 
UnboundedDequeBasedMessageQueue - Interface in akka.dispatch
UnboundedDequeBasedMessageQueueSemantics adds unbounded semantics to a DequeBasedMessageQueue, i.e.
UnboundedDequeBasedMessageQueueSemantics - Interface in akka.dispatch
 
UnboundedMailbox - Class in akka.dispatch
UnboundedMailbox is the default unbounded MailboxType used by Akka Actors.
UnboundedMailbox() - Constructor for class akka.dispatch.UnboundedMailbox
 
UnboundedMailbox(ActorSystem.Settings, com.typesafe.config.Config) - Constructor for class akka.dispatch.UnboundedMailbox
 
UnboundedMailbox$ - Class in akka.dispatch
 
UnboundedMailbox$() - Constructor for class akka.dispatch.UnboundedMailbox$
 
UnboundedMailbox.MessageQueue - Class in akka.dispatch
 
UnboundedMailbox.MessageQueue() - Constructor for class akka.dispatch.UnboundedMailbox.MessageQueue
 
UnboundedMessageQueueSemantics - Interface in akka.dispatch
UnboundedMessageQueueSemantics adds unbounded semantics to a QueueBasedMessageQueue, i.e.
UnboundedPriorityMailbox - Class in akka.dispatch
UnboundedPriorityMailbox is an unbounded mailbox that allows for prioritization of its contents.
UnboundedPriorityMailbox(Comparator<Envelope>, int) - Constructor for class akka.dispatch.UnboundedPriorityMailbox
 
UnboundedPriorityMailbox(Comparator<Envelope>) - Constructor for class akka.dispatch.UnboundedPriorityMailbox
 
UnboundedPriorityMailbox$ - Class in akka.dispatch
 
UnboundedPriorityMailbox$() - Constructor for class akka.dispatch.UnboundedPriorityMailbox$
 
UnboundedPriorityMailbox.MessageQueue - Class in akka.dispatch
 
UnboundedPriorityMailbox.MessageQueue(int, Comparator<Envelope>) - Constructor for class akka.dispatch.UnboundedPriorityMailbox.MessageQueue
 
UnboundedQueueBasedMessageQueue - Interface in akka.dispatch
 
UnboundedStash - Interface in akka.actor
The UnboundedStash trait is a version of Stash that enforces an unbounded stash for you actor.
uncaughtExceptionHandler() - Method in class akka.actor.ActorSystemImpl
 
unconfirmed() - Method in interface akka.persistence.AtLeastOnceDelivery
 
UnconfirmedClientOp - Interface in akka.remote.testconductor
 
unconfirmedDeliveries() - Method in class akka.persistence.AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot
 
unconfirmedDeliveries() - Method in class akka.persistence.AtLeastOnceDelivery.UnconfirmedWarning
 
UNCONFIRMEDDELIVERIES_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
Undefined() - Method in class akka.persistence.PersistentRepr$
Plugin API: value of an undefined processor or channel id.
undefinedUid() - Method in class akka.actor.ActorCell$
 
undefinedUid() - Static method in class akka.actor.ActorCell
 
UndefinedUidActorRef - Class in akka.actor.dungeon
 
UndefinedUidActorRef(ActorRef) - Constructor for class akka.actor.dungeon.UndefinedUidActorRef
 
underlying() - Method in class akka.actor.ActorRefWithCell
 
underlying() - Method in class akka.actor.LocalActorRef
 
underlying() - Method in class akka.actor.RepointableActorRef
 
underlyingActor() - Method in class akka.testkit.TestActorRef
Retrieve reference to the underlying actor, where the static type matches the factory used inside the constructor.
unexpect(PartialFunction<Object, BoxedUnit>) - Method in interface akka.contrib.pattern.Aggregator
Removes the partial function from the receive set.
unhandled(Object) - Method in interface akka.actor.Actor
User overridable callback.
unhandled(Object) - Method in class akka.actor.UntypedActor
Recommended convention is to call this method if the message isn't handled in UntypedActor.onReceive(java.lang.Object) (e.g.
unhandled(Object) - Method in class akka.cluster.ClusterCoreDaemon
 
unhandled(Object) - Method in interface akka.persistence.ProcessorImpl
 
unhandled(Object) - Method in class akka.remote.EndpointWriter
 
UnhandledMessage - Class in akka.actor
This message is published to the EventStream whenever an Actor receives a message it doesn't understand
UnhandledMessage(Object, ActorRef, ActorRef) - Constructor for class akka.actor.UnhandledMessage
 
UnhandledMessage$ - Class in akka.actor
 
UnhandledMessage$() - Constructor for class akka.actor.UnhandledMessage$
 
uninitialisedReceive() - Method in class akka.osgi.DefaultOSGiLogger
Behaviour of the logger that waits for its LogService
uninitialized() - Method in class akka.cluster.ClusterCoreDaemon
 
uniqueAddress() - Method in class akka.cluster.Member
 
UniqueAddress - Class in akka.cluster
Member identifier consisting of address and random uid.
UniqueAddress(Address, int) - Constructor for class akka.cluster.UniqueAddress
 
UniqueAddress$ - Class in akka.cluster
 
UniqueAddress$() - Constructor for class akka.cluster.UniqueAddress$
 
UniqueId() - Method in class akka.remote.transport.AkkaProtocolTransport$
 
UniqueId() - Static method in class akka.remote.transport.AkkaProtocolTransport
 
UniqueId() - Method in class akka.remote.transport.ThrottlerTransportAdapter$
 
UniqueId() - Static method in class akka.remote.transport.ThrottlerTransportAdapter
 
uniqueIdCounter() - Method in class akka.remote.transport.netty.NettyTransport$
 
uniqueIdCounter() - Static method in class akka.remote.transport.netty.NettyTransport
 
UnitCaseStatement<F,P> - Class in akka.japi.pf
 
UnitCaseStatement(FI.Predicate, FI.UnitApply<P>) - Constructor for class akka.japi.pf.UnitCaseStatement
 
UnitMatch<I> - Class in akka.japi.pf
Version of PartialFunction that can be built during runtime from Java.
UnitPFBuilder<I> - Class in akka.japi.pf
A builder for PartialFunction.
UnitPFBuilder() - Constructor for class akka.japi.pf.UnitPFBuilder
Create a UnitPFBuilder.
unlink() - Method in interface akka.dispatch.sysmsg.SystemMessage
 
unlinked() - Method in interface akka.dispatch.sysmsg.SystemMessage
 
unpack(byte[]) - Method in class akka.actor.mailbox.filebased.filequeue.QItem$
 
unpack(byte[]) - Static method in class akka.actor.mailbox.filebased.filequeue.QItem
 
unpackOldAdd(byte[]) - Method in class akka.actor.mailbox.filebased.filequeue.QItem$
 
unpackOldAdd(byte[]) - Static method in class akka.actor.mailbox.filebased.filequeue.QItem
 
unreachable() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
 
unreachable() - Method in class akka.cluster.HeartbeatNodeRing
 
unreachable(UniqueAddress, UniqueAddress) - Method in class akka.cluster.Reachability
 
unreachable() - Method in class akka.remote.RemoteWatcher
 
Unreachable_VALUE - Static variable in enum akka.cluster.protobuf.msg.ClusterMessages.ReachabilityStatus
Unreachable = 1;
unreachableMember(Member) - Method in class akka.cluster.AutoDownBase
 
unreachableMember(Member) - Method in class akka.cluster.ClusterHeartbeatSender
 
unreachableMember(UniqueAddress) - Method in class akka.cluster.ClusterHeartbeatSenderState
 
unreachableMembers() - Method in class akka.cluster.ClusterReadView
Members that has been detected as unreachable.
UnreachableNodesReaperInterval() - Method in class akka.cluster.ClusterSettings
 
unregister(ActorRef) - Method in class akka.contrib.mailbox.PeekMailboxExtension
 
unregister(ActorCell) - Method in class akka.dispatch.BalancingDispatcher
 
unregister(ActorCell) - Method in class akka.dispatch.MessageDispatcher
If you override it, you must call it.
unregister(ActorCell) - Method in class akka.dispatch.PinnedDispatcher
 
unregister(ActorCell) - Method in class akka.testkit.CallingThreadDispatcher
 
unregisterEndpoint(ActorRef) - Method in class akka.remote.EndpointManager.EndpointRegistry
 
UnregisteringLogService - Class in akka.osgi
Message sent when LogService is unregistred.
UnregisteringLogService() - Constructor for class akka.osgi.UnregisteringLogService
 
UnregisteringLogService$ - Class in akka.osgi
Message sent when LogService is unregistred.
UnregisteringLogService$() - Constructor for class akka.osgi.UnregisteringLogService$
 
unregisterMBean() - Method in class akka.cluster.ClusterJmx
Unregisters the cluster JMX MBean from MBean server.
unregisterQueues(CallingThreadMailbox) - Method in class akka.testkit.CallingThreadDispatcherQueues
 
unregisterService(ActorRef) - Method in class akka.contrib.pattern.ClusterReceptionistExtension
A registered actor will be automatically unregistered when terminated, but it can also be explicitly unregistered before termination.
unregisterSubscriber(String, ActorRef) - Method in class akka.contrib.pattern.ClusterReceptionistExtension
A registered subscriber will be automatically unregistered when terminated, but it can also be explicitly unregistered before termination.
unregisterTempActor(ActorPath) - Method in interface akka.actor.ActorRefProvider
Unregister a temporary actor from the &ldquo;/temp&rdquo; path (i.e.
unregisterTempActor(ActorPath) - Method in class akka.actor.LocalActorRefProvider
 
unregisterTempActor(ActorPath) - Method in class akka.remote.RemoteActorRefProvider
 
unremove(int) - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
unremove(int) - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
Return a transactionally-removed item to the queue.
unremove(String, int) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
unreserve(String) - Method in interface akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer
 
unreserve(String) - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
 
unreserve(String) - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
 
unreserve(String) - Method in interface akka.actor.dungeon.ChildrenContainer
 
unreserveChild(String) - Method in interface akka.actor.dungeon.Children
 
UnrestrictedStash - Interface in akka.actor
A version of Stash that does not enforce any mailbox type.
Unsafe - Class in akka.util
INTERNAL API
Unsafe() - Constructor for class akka.util.Unsafe
 
UNSCHEDULED() - Method in class akka.dispatch.MessageDispatcher$
 
UNSCHEDULED() - Static method in class akka.dispatch.MessageDispatcher
 
unsignDeathPact() - Method in class akka.io.TcpConnection
 
UnstartedCell - Class in akka.actor
 
UnstartedCell(ActorSystemImpl, RepointableActorRef, Props, InternalActorRef) - Constructor for class akka.actor.UnstartedCell
 
UnstartedPushTimeout() - Method in class akka.actor.ActorSystem.Settings
 
unstash() - Method in interface akka.actor.StashSupport
Prepends the oldest message in the stash to the mailbox, and then removes that message from the stash.
unstashAll() - Method in interface akka.actor.StashSupport
Prepends all messages in the stash to the mailbox, and then clears the stash.
unstashAll(Function1<Object, Object>) - Method in interface akka.actor.StashSupport
INTERNAL API.
unstashAll() - Method in interface akka.persistence.Eventsourced
 
unstashFilterPredicate() - Method in interface akka.persistence.ProcessorImpl
 
unsubscribe(ActorRef) - Method in class akka.cluster.Cluster
Unsubscribe to all cluster domain events.
unsubscribe(ActorRef, Class<?>) - Method in class akka.cluster.Cluster
Unsubscribe to a specific type of cluster domain events, matching previous subscribe registration.
unsubscribe(ActorRef, Option<Class<?>>) - Method in class akka.cluster.ClusterDomainEventPublisher
 
unsubscribe() - Method in class akka.contrib.pattern.DistributedPubSubMediator.UnsubscribeAck
 
unsubscribe(ActorRef, ActorRef) - Method in interface akka.event.ActorClassification
 
unsubscribe(ActorRef) - Method in interface akka.event.ActorClassification
 
unsubscribe(ActorRef) - Method in class akka.event.AddressTerminatedTopic
 
unsubscribe(EventBus, EventBus) - Method in interface akka.event.EventBus
Attempts to deregister the subscriber from the specified Classifier
unsubscribe(EventBus) - Method in interface akka.event.EventBus
Attempts to deregister the subscriber from all Classifiers it may be subscribed to
unsubscribe(ActorRef, Class<?>) - Method in class akka.event.EventStream
 
unsubscribe(ActorRef) - Method in class akka.event.EventStream
 
unsubscribe(ActorRef, ActorRef) - Method in class akka.event.japi.ActorEventBus
 
unsubscribe(ActorRef) - Method in class akka.event.japi.ActorEventBus
 
unsubscribe(S, C) - Method in interface akka.event.japi.EventBus
Attempts to deregister the subscriber from the specified Classifier
unsubscribe(S) - Method in interface akka.event.japi.EventBus
Attempts to deregister the subscriber from all Classifiers it may be subscribed to
unsubscribe(S, C) - Method in class akka.event.japi.LookupEventBus
 
unsubscribe(S) - Method in class akka.event.japi.LookupEventBus
 
unsubscribe(S, C) - Method in class akka.event.japi.ScanningEventBus
 
unsubscribe(S) - Method in class akka.event.japi.ScanningEventBus
 
unsubscribe(S, C) - Method in class akka.event.japi.SubchannelEventBus
 
unsubscribe(S) - Method in class akka.event.japi.SubchannelEventBus
 
unsubscribe(LookupClassification, LookupClassification) - Method in interface akka.event.LookupClassification
 
unsubscribe(LookupClassification) - Method in interface akka.event.LookupClassification
 
unsubscribe(ScanningClassification, ScanningClassification) - Method in interface akka.event.ScanningClassification
 
unsubscribe(ScanningClassification) - Method in interface akka.event.ScanningClassification
 
unsubscribe(SubchannelClassification, SubchannelClassification) - Method in interface akka.event.SubchannelClassification
 
unsubscribe(SubchannelClassification) - Method in interface akka.event.SubchannelClassification
 
Unsubscribe - Class in akka.zeromq
The Unsubscribe option shall remove an existing message filter on a akka.zeromq.SocketType.Sub socket.
Unsubscribe(ByteString) - Constructor for class akka.zeromq.Unsubscribe
 
Unsubscribe(String) - Constructor for class akka.zeromq.Unsubscribe
 
Unsubscribe$ - Class in akka.zeromq
 
Unsubscribe$() - Constructor for class akka.zeromq.Unsubscribe$
 
unsubscribeAddressTerminated() - Method in interface akka.actor.dungeon.DeathWatch
 
UntrustedMode() - Method in class akka.remote.RemoteSettings
 
untrustedMode() - Method in class akka.remote.RemoteSystemDaemon
 
UntypedActor - Class in akka.actor
Actor base trait that should be extended by or mixed to create an Actor with the semantics of the 'Actor Model': http://en.wikipedia.org/wiki/Actor_model
UntypedActor() - Constructor for class akka.actor.UntypedActor
 
UntypedActorContext - Interface in akka.actor
UntypedActorContext is the UntypedActor equivalent of ActorContext, containing the Java API
UntypedActorFactory - Interface in akka.actor
Factory closure for an UntypedActor, to be used with 'Actors.actorOf(factory)'.
UntypedActorFactoryConsumer - Class in akka.actor
INTERNAL API
UntypedActorFactoryConsumer(UntypedActorFactory) - Constructor for class akka.actor.UntypedActorFactoryConsumer
 
UntypedActorFactoryConsumerClass() - Method in class akka.actor.IndirectActorProducer$
 
UntypedActorWithStash - Class in akka.actor
Actor base class that should be extended to create an actor with a stash.
UntypedActorWithStash() - Constructor for class akka.actor.UntypedActorWithStash
 
UntypedActorWithUnboundedStash - Class in akka.actor
Actor base class with Stash that enforces an unbounded deque for the actor.
UntypedActorWithUnboundedStash() - Constructor for class akka.actor.UntypedActorWithUnboundedStash
 
UntypedActorWithUnrestrictedStash - Class in akka.actor
Actor base class with Stash that does not enforce any mailbox type.
UntypedActorWithUnrestrictedStash() - Constructor for class akka.actor.UntypedActorWithUnrestrictedStash
 
UntypedConsumerActor - Class in akka.camel.javaapi
Subclass this abstract class to create an MDB-style untyped consumer actor.
UntypedConsumerActor() - Constructor for class akka.camel.javaapi.UntypedConsumerActor
 
UntypedEventsourcedProcessor - Class in akka.persistence
Java API: an event sourced processor.
UntypedEventsourcedProcessor() - Constructor for class akka.persistence.UntypedEventsourcedProcessor
 
UntypedPersistentActor - Class in akka.persistence
Java API: an persistent actor - can be used to implement command or event sourcing.
UntypedPersistentActor() - Constructor for class akka.persistence.UntypedPersistentActor
 
UntypedPersistentActorWithAtLeastOnceDelivery - Class in akka.persistence
Java API: Use this class instead of UntypedPersistentActor to send messages with at-least-once delivery semantics to destinations.
UntypedPersistentActorWithAtLeastOnceDelivery() - Constructor for class akka.persistence.UntypedPersistentActorWithAtLeastOnceDelivery
 
UntypedPersistentView - Class in akka.persistence
Java API.
UntypedPersistentView() - Constructor for class akka.persistence.UntypedPersistentView
 
UntypedProcessor - Class in akka.persistence
Java API: an actor that persists (journals) messages of type Persistent.
UntypedProcessor() - Constructor for class akka.persistence.UntypedProcessor
 
UntypedProducerActor - Class in akka.camel.javaapi
Subclass this abstract class to create an untyped producer actor.
UntypedProducerActor() - Constructor for class akka.camel.javaapi.UntypedProducerActor
 
UntypedTransactor - Class in akka.transactor
An UntypedActor version of transactor for using from Java.
UntypedTransactor() - Constructor for class akka.transactor.UntypedTransactor
 
UntypedView - Class in akka.persistence
Java API.
UntypedView() - Constructor for class akka.persistence.UntypedView
 
unwatch(ActorRef) - Method in interface akka.actor.ActorContext
Unregisters this actor as Monitor for the provided ActorRef.
unwatch(ActorRef) - Method in interface akka.actor.dungeon.DeathWatch
 
Unwatch - Class in akka.dispatch.sysmsg
INTERNAL API
Unwatch(ActorRef, ActorRef) - Constructor for class akka.dispatch.sysmsg.Unwatch
 
unwatch(ActorRef) - Method in class akka.testkit.JavaTestKit
Have the testActor stop watching someone (i.e.
unwatch(ActorRef) - Method in class akka.testkit.TestActorRef
Deregisters this actor from being a death monitor of the provided ActorRef This means that this actor will not get a Terminated()-message when the provided actor is permanently terminated.
unwatch(ActorRef) - Method in interface akka.testkit.TestKitBase
Have the testActor stop watching someone (i.e.
Unwatch$ - Class in akka.dispatch.sysmsg
 
Unwatch$() - Constructor for class akka.dispatch.sysmsg.Unwatch$
 
unwatchRemote(ActorRef, ActorRef) - Method in class akka.remote.RemoteWatcher
 
unwatchWatchedActors(Actor) - Method in interface akka.actor.dungeon.DeathWatch
 
up() - Method in class akka.cluster.MemberStatus$
Java API: retrieve the &ldquo;up&rdquo; status singleton
up() - Static method in class akka.cluster.MemberStatus
Java API: retrieve the &ldquo;up&rdquo; status singleton
Up_VALUE - Static variable in enum akka.cluster.protobuf.msg.ClusterMessages.MemberStatus
Up = 1;
update(long, String, boolean, int, Seq<String>, Delivered, ActorRef, ActorRef) - Method in class akka.persistence.ConfirmablePersistentImpl
 
update(long, ActorRef) - Method in interface akka.persistence.Delivered
INTERNAL API.
update(long, ActorRef) - Method in class akka.persistence.DeliveredByChannel
 
update(long, ActorRef) - Method in class akka.persistence.DeliveredByPersistentChannel
 
update(String, long, Function1<PersistentRepr, PersistentRepr>) - Method in interface akka.persistence.journal.inmem.InmemMessages
 
update(long, String, boolean, int, Seq<String>, Delivered, ActorRef, ActorRef) - Method in class akka.persistence.PersistentImpl
 
update(long, String, boolean, int, Seq<String>, Delivered, ActorRef, ActorRef) - Method in interface akka.persistence.PersistentRepr
Creates a new copy of this PersistentRepr.
Update - Class in akka.persistence
Instructs a PersistentView to update itself.
Update(boolean, long) - Constructor for class akka.persistence.Update
 
Update$ - Class in akka.persistence
 
Update$() - Constructor for class akka.persistence.Update$
 
updateLastSequenceNr(Persistent) - Method in interface akka.persistence.Recovery
INTERNAL API.
updateLastSequenceNr(long) - Method in interface akka.persistence.Recovery
INTERNAL API.
updateLatestGossip(Gossip) - Method in class akka.cluster.ClusterCoreDaemon
 
updateSerial(Vector<ReliableProxy.Message>) - Method in class akka.contrib.pattern.ReliableProxy
 
updateSource(LogRecord) - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
updateStatus(int, int) - Method in class akka.dispatch.Mailbox
 
upNumber() - Method in class akka.cluster.Member
INTERNAL API
UPNUMBER_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
upperBound() - Method in class akka.routing.DefaultResizer
 
upstreamListener() - Method in class akka.remote.transport.ActorTransportAdapter.ListenUnderlying
 
upstreamListener() - Method in class akka.remote.transport.ThrottledAssociation
 
uptime() - Method in class akka.actor.ActorSystem
Up-time of this actor system in seconds.
usage() - Method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper$
 
usage() - Static method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper
 
useActorOnNode(ActorRef, Props, Deploy, ActorRef) - Method in class akka.remote.RemoteActorRefProvider
Using (checking out) actor on a specific node.
used() - Method in class akka.cluster.StandardMetrics.HeapMemory
 
UseDispatcher() - Method in class akka.cluster.ClusterSettings
 
UseDispatcherForIo() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
usedRouteePaths() - Method in class akka.cluster.routing.ClusterRouterGroupActor
 
UsePassiveConnections() - Method in class akka.remote.RemoteSettings
 
usePoolDispatcher() - Method in class akka.cluster.routing.AdaptiveLoadBalancingPool
 
usePoolDispatcher() - Method in class akka.routing.BroadcastPool
 
usePoolDispatcher() - Method in class akka.routing.ConsistentHashingPool
 
usePoolDispatcher() - Method in interface akka.routing.Pool
Use a dedicated dispatcher for the routees of the pool.
usePoolDispatcher() - Method in class akka.routing.RandomPool
 
usePoolDispatcher() - Method in class akka.routing.RoundRobinPool
 
usePoolDispatcher() - Method in class akka.routing.ScatterGatherFirstCompletedPool
 
usePoolDispatcher() - Method in class akka.routing.SmallestMailboxPool
 
usePoolDispatcher() - Method in class akka.routing.TailChoppingPool
 
useProcessorBatching() - Method in interface akka.persistence.Eventsourced
 
userConfig() - Method in interface akka.actor.mailbox.DurableMailboxSettings
A reference to the config section which the user specified for this mailbox&rsquo;s dispatcher.
userConfig() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
useResumeWriting() - Method in class akka.io.Tcp.Register
 
useResumeWriting() - Method in class akka.io.TcpConnection.ConnectionInfo
 
useRole() - Method in class akka.cluster.routing.ClusterRouterGroupSettings
 
useRole() - Method in class akka.cluster.routing.ClusterRouterPoolSettings
 
useRole() - Method in class akka.cluster.routing.ClusterRouterSettings
 
useRole() - Method in interface akka.cluster.routing.ClusterRouterSettingsBase
 
useRoleOption(String) - Method in class akka.cluster.routing.ClusterRouterSettings$
 
useRoleOption(String) - Static method in class akka.cluster.routing.ClusterRouterSettings
 
useRoleOption(String) - Method in class akka.cluster.routing.ClusterRouterSettingsBase$
 
useUntrustedMode() - Method in class akka.remote.RemoteTransport
When this method returns true, some functionality will be turned off for security purposes.
useUntrustedMode() - Method in class akka.remote.Remoting
 
using(D) - Method in class akka.actor.FSM.State
Modify state transition descriptor with new state data.
using(PartialFunction<FSM.State<S, D>, FSM.State<S, D>>) - Method in class akka.actor.FSM.TransformHelper
 
utf8String() - Method in class akka.util.ByteString
Decodes this ByteString as a UTF-8 encoded String.
Util - Class in akka.actor.mailbox.filebased.filequeue.tools
 
Util() - Constructor for class akka.actor.mailbox.filebased.filequeue.tools.Util
 
Util - Class in akka.japi
This class hold common utilities for Java
Util() - Constructor for class akka.japi.Util
 
Util$ - Class in akka.actor.mailbox.filebased.filequeue.tools
 
Util$() - Constructor for class akka.actor.mailbox.filebased.filequeue.tools.Util$
 
Util$ - Class in akka.japi
This class hold common utilities for Java
Util$() - Constructor for class akka.japi.Util$
 

V

v() - Method in class akka.japi.Option.Some
 
valid() - Method in interface akka.dispatch.CachingConfig.PathEntry
 
valid() - Method in class akka.dispatch.CachingConfig.StringPathEntry
 
valid() - Method in class akka.dispatch.CachingConfig.ValuePathEntry
 
validate(ThreadFactory) - Method in class akka.dispatch.ForkJoinExecutorConfigurator
 
validNodeForGossip(UniqueAddress) - Method in class akka.cluster.ClusterCoreDaemon
 
ValidSymbols() - Method in class akka.actor.ActorPath$
INTERNAL API
value() - Method in class akka.cluster.EWMA
 
value() - Method in class akka.cluster.Metric
 
value - Variable in class akka.dispatch.AbstractNodeQueue.Node
 
value() - Method in class akka.dispatch.CachingConfig.StringPathEntry
 
value() - Method in class akka.util.Helpers.Requiring
 
value() - Method in class akka.zeromq.Affinity
 
value() - Method in class akka.zeromq.Backlog
 
value() - Method in class akka.zeromq.HighWatermark
 
value() - Method in class akka.zeromq.Identity
 
value() - Method in class akka.zeromq.Linger
 
value() - Method in class akka.zeromq.MaxMsgSize
 
value() - Method in class akka.zeromq.MulticastHops
 
value() - Method in class akka.zeromq.MulticastLoop
 
value() - Method in class akka.zeromq.Rate
 
value() - Method in class akka.zeromq.ReceiveBufferSize
 
value() - Method in class akka.zeromq.ReceiveHighWatermark
 
value() - Method in class akka.zeromq.ReconnectIVL
 
value() - Method in class akka.zeromq.ReconnectIVLMax
 
value() - Method in class akka.zeromq.RecoveryInterval
 
value() - Method in class akka.zeromq.SendBufferSize
 
value() - Method in class akka.zeromq.SendHighWatermark
 
value() - Method in class akka.zeromq.Swap
 
VALUE32_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
VALUE64_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
VALUE_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
 
valueComparator() - Method in class akka.util.Index
 
valueIterator(K) - Method in class akka.util.Index
Returns an Iterator of V containing the values for the supplied key, or an empty iterator if the key doesn't exist
valueOf(String) - Static method in enum akka.cluster.protobuf.msg.ClusterMessages.MemberStatus
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum akka.cluster.protobuf.msg.ClusterMessages.MemberStatus
 
valueOf(com.google.protobuf.Descriptors.EnumValueDescriptor) - Static method in enum akka.cluster.protobuf.msg.ClusterMessages.MemberStatus
 
valueOf(String) - Static method in enum akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberType
 
valueOf(com.google.protobuf.Descriptors.EnumValueDescriptor) - Static method in enum akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberType
 
valueOf(String) - Static method in enum akka.cluster.protobuf.msg.ClusterMessages.ReachabilityStatus
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum akka.cluster.protobuf.msg.ClusterMessages.ReachabilityStatus
 
valueOf(com.google.protobuf.Descriptors.EnumValueDescriptor) - Static method in enum akka.cluster.protobuf.msg.ClusterMessages.ReachabilityStatus
 
valueOf(String) - Static method in enum akka.remote.ContainerFormats.PatternType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum akka.remote.ContainerFormats.PatternType
 
valueOf(com.google.protobuf.Descriptors.EnumValueDescriptor) - Static method in enum akka.remote.ContainerFormats.PatternType
 
valueOf(String) - Static method in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
 
valueOf(com.google.protobuf.Descriptors.EnumValueDescriptor) - Static method in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
 
valueOf(String) - Static method in enum akka.remote.testconductor.TestConductorProtocol.Direction
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum akka.remote.testconductor.TestConductorProtocol.Direction
 
valueOf(com.google.protobuf.Descriptors.EnumValueDescriptor) - Static method in enum akka.remote.testconductor.TestConductorProtocol.Direction
 
valueOf(String) - Static method in enum akka.remote.testconductor.TestConductorProtocol.FailType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum akka.remote.testconductor.TestConductorProtocol.FailType
 
valueOf(com.google.protobuf.Descriptors.EnumValueDescriptor) - Static method in enum akka.remote.testconductor.TestConductorProtocol.FailType
 
valueOf(String) - Static method in enum akka.remote.WireFormats.CommandType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum akka.remote.WireFormats.CommandType
 
valueOf(com.google.protobuf.Descriptors.EnumValueDescriptor) - Static method in enum akka.remote.WireFormats.CommandType
 
values() - Static method in enum akka.cluster.protobuf.msg.ClusterMessages.MemberStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum akka.cluster.protobuf.msg.ClusterMessages.ReachabilityStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum akka.remote.ContainerFormats.PatternType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum akka.remote.testconductor.TestConductorProtocol.Direction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum akka.remote.testconductor.TestConductorProtocol.FailType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum akka.remote.WireFormats.CommandType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class akka.util.Index
Returns the union of all value sets.
values() - Method in class akka.util.SubclassifiedIndex
 
valuesIterator() - Method in class akka.actor.dungeon.ChildrenContainer.ChildrenIterable
 
valuesIterator() - Method in class akka.actor.dungeon.ChildrenContainer.ChildRestartsIterable
 
valuesIterator() - Method in class akka.util.Collections.PartialImmutableValuesIterable
 
variance() - Method in class akka.remote.HeartbeatHistory
 
vclockName(UniqueAddress) - Method in class akka.cluster.ClusterCoreDaemon
 
vclockNode() - Method in class akka.cluster.ClusterCoreDaemon
 
vclockStats() - Method in class akka.cluster.ClusterEvent.CurrentInternalStats
 
VectorClock - Class in akka.cluster
 
VectorClock(TreeMap<String, Object>) - Constructor for class akka.cluster.VectorClock
 
VectorClock$ - Class in akka.cluster
VectorClock module with helper classes and methods.
VectorClock$() - Constructor for class akka.cluster.VectorClock$
 
VectorClock.After$ - Class in akka.cluster
 
VectorClock.After$() - Constructor for class akka.cluster.VectorClock.After$
 
VectorClock.Before$ - Class in akka.cluster
 
VectorClock.Before$() - Constructor for class akka.cluster.VectorClock.Before$
 
VectorClock.Concurrent$ - Class in akka.cluster
 
VectorClock.Concurrent$() - Constructor for class akka.cluster.VectorClock.Concurrent$
 
VectorClock.Node$ - Class in akka.cluster
 
VectorClock.Node$() - Constructor for class akka.cluster.VectorClock.Node$
 
VectorClock.Ordering - Interface in akka.cluster
 
VectorClock.Same$ - Class in akka.cluster
 
VectorClock.Same$() - Constructor for class akka.cluster.VectorClock.Same$
 
VectorClock.Timestamp$ - Class in akka.cluster
 
VectorClock.Timestamp$() - Constructor for class akka.cluster.VectorClock.Timestamp$
 
VectorClockStats - Class in akka.cluster
INTERNAL API
VectorClockStats(int, int) - Constructor for class akka.cluster.VectorClockStats
 
VectorClockStats$ - Class in akka.cluster
 
VectorClockStats$() - Constructor for class akka.cluster.VectorClockStats$
 
verifyConfig(ActorPath) - Method in class akka.routing.FromConfig
 
verifyConfig(ActorPath) - Method in interface akka.routing.RouterConfig
Check that everything is there which is needed.
verifySystemShutdown() - Method in class akka.remote.testkit.MultiNodeSpec
Override this and return true to assert that the shutdown of the ActorSystem was done properly.
Version() - Method in class akka.actor.ActorSystem$
 
Version() - Static method in class akka.actor.ActorSystem
 
version() - Method in class akka.cluster.Gossip
 
version() - Method in class akka.cluster.GossipStatus
 
version() - Method in class akka.cluster.Reachability.Record
 
version() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Internal$.Bucket
 
version() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Internal$.ValueHolder
 
version() - Method in class akka.zeromq.ZeroMQExtension
The version of the ZeroMQ library
VERSION_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
VERSION_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
VERSION_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
VERSION_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
VERSION_FIELD_NUMBER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
VERSION_FIELD_NUMBER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
versions() - Method in class akka.cluster.Reachability
 
versions() - Method in class akka.cluster.VectorClock
 
versions() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Internal$.Status
 
VERSIONS_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
 
VERSIONS_FIELD_NUMBER - Static variable in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
 
versionSize() - Method in class akka.cluster.VectorClockStats
 
view() - Method in class akka.persistence.PersistenceSettings
 
View - Interface in akka.persistence
A view replicates the persistent message stream of a processor.
viewId() - Method in interface akka.persistence.PersistentView
View id is used as identifier for snapshots performed by this PersistentView.
viewId() - Method in interface akka.persistence.View
View id.
viewSettings() - Method in interface akka.persistence.PersistentView
 
viewSettings() - Method in interface akka.persistence.View
 
virtualNodesFactor() - Method in class akka.contrib.pattern.ClusterReceptionist
 
virtualNodesFactor() - Method in class akka.routing.ConsistentHash
 
virtualNodesFactor() - Method in class akka.routing.ConsistentHashingGroup
 
virtualNodesFactor() - Method in class akka.routing.ConsistentHashingPool
 
virtualNodesFactor() - Method in class akka.routing.ConsistentHashingRouter
 
virtualNodesFactor() - Method in class akka.routing.ConsistentHashingRoutingLogic
 
VirtualPathContainer - Class in akka.actor
Internal implementation detail used for paths like &ldquo;/temp&rdquo;
VirtualPathContainer(ActorRefProvider, ActorPath, InternalActorRef, LoggingAdapter) - Constructor for class akka.actor.VirtualPathContainer
 
vnodes() - Method in class akka.routing.ConsistentHashingRoutingLogic
 

W

waitingForChildrenOrNull() - Method in interface akka.actor.dungeon.Children
 
waitingForRegistration(ChannelRegistration, ActorRef) - Method in class akka.io.TcpConnection
connection established, waiting for registration from user handler
waitNanos(long) - Method in class akka.actor.LightArrayRevolverScheduler
Overridable for tests
walk() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
wantsAck() - Method in class akka.io.Tcp.SimpleWriteCommand
An acknowledgment is only sent if this write command &ldquo;wants an ack&rdquo;, which is equivalent to the Tcp.SimpleWriteCommand.ack() token not being a of type Tcp.NoAck.
wantsAck() - Method in class akka.io.Udp.Send
 
wantsAck() - Method in class akka.io.UdpConnected.Send
 
warnAfterNumberOfUnconfirmedAttempts() - Method in interface akka.persistence.AtLeastOnceDelivery
After this number of delivery attempts a AtLeastOnceDelivery.UnconfirmedWarning message will be sent to self.
warnAfterNumberOfUnconfirmedAttempts() - Method in class akka.persistence.PersistenceSettings.atLeastOnceDelivery
 
warning(Logging.Warning) - Method in interface akka.event.Logging.StdOutLogger
 
warning(String) - Method in interface akka.event.LoggingAdapter
Log message at warning level.
warning(String, Object) - Method in interface akka.event.LoggingAdapter
Message template with 1 replacement argument.
warning(String, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 2 replacement arguments.
warning(String, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 3 replacement arguments.
warning(String, Object, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 4 replacement arguments.
warning(String, String, String, String, int) - Method in class akka.testkit.EventFilter$
Create a filter for Warning events.
warning(String, String, String, String, int) - Static method in class akka.testkit.EventFilter
Create a filter for Warning events.
WarningFilter - Class in akka.testkit
Filter which matches Warning events, if they satisfy the given criteria: source, if given, applies a filter on the event&rsquo;s origin message applies a filter on the event&rsquo;s message (either with String.startsWith or Regex.findFirstIn().isDefined) If you want to match all Warning events, the most efficient is to use Left("").
WarningFilter(Option<String>, Either<String, Regex>, boolean, int) - Constructor for class akka.testkit.WarningFilter
 
WarningFilter(String, String, boolean, boolean, int) - Constructor for class akka.testkit.WarningFilter
Java API: create a WarningFilter
WarningFilter$ - Class in akka.testkit
 
WarningFilter$() - Constructor for class akka.testkit.WarningFilter$
 
warningFormat() - Method in interface akka.event.Logging.StdOutLogger
 
WarningLevel() - Method in class akka.event.Logging$
 
WarningLevel() - Static method in class akka.event.Logging
 
watch(ActorRef) - Method in interface akka.actor.ActorContext
Registers this actor as a Monitor for the provided ActorRef.
watch(ActorRef) - Method in class akka.actor.dsl.Inbox.Inbox
Make the inbox&rsquo;s actor watch the target actor such that reception of the Terminated message can then be awaited.
watch(ActorRef) - Method in interface akka.actor.dungeon.DeathWatch
 
watch(ActorRef) - Method in class akka.actor.Inbox
Have the internal actor watch the target actor.
Watch - Class in akka.dispatch.sysmsg
INTERNAL API
Watch(InternalActorRef, InternalActorRef) - Constructor for class akka.dispatch.sysmsg.Watch
 
watch(FiniteDuration, String, PrintStream, FiniteDuration, boolean) - Method in class akka.testkit.Coroner$
Ask the Coroner to print a report if it is not cancelled by the given deadline.
watch(FiniteDuration, String, PrintStream, FiniteDuration, boolean) - Static method in class akka.testkit.Coroner
Ask the Coroner to print a report if it is not cancelled by the given deadline.
watch(ActorRef) - Method in class akka.testkit.JavaTestKit
Have the testActor watch someone (i.e.
watch(ActorRef) - Method in class akka.testkit.TestActorRef
Registers this actor to be a death monitor of the provided ActorRef This means that this actor will get a Terminated()-message when the provided actor is permanently terminated.
watch(ActorRef) - Method in interface akka.testkit.TestKitBase
Have the testActor watch someone (i.e.
Watch$ - Class in akka.dispatch.sysmsg
 
Watch$() - Constructor for class akka.dispatch.sysmsg.Watch$
 
watchedActorTerminated(ActorRef, boolean, boolean) - Method in interface akka.actor.dungeon.DeathWatch
When this actor is watching the subject of Terminated message it will be propagated to user's receive.
watchedBy() - Method in interface akka.actor.dungeon.DeathWatch
 
WatchedByCoroner - Interface in akka.testkit
Mixin for tests that should be watched by the Coroner.
watchee() - Method in class akka.dispatch.sysmsg.Unwatch
 
watchee() - Method in class akka.dispatch.sysmsg.Watch
 
watchee() - Method in class akka.remote.RemoteWatcher.RewatchRemote
 
watchee() - Method in class akka.remote.RemoteWatcher.UnwatchRemote
 
watchee() - Method in class akka.remote.RemoteWatcher.WatchRemote
 
watcher() - Method in class akka.dispatch.sysmsg.Unwatch
 
watcher() - Method in class akka.dispatch.sysmsg.Watch
 
watcher() - Method in class akka.remote.RemoteWatcher.RewatchRemote
 
watcher() - Method in class akka.remote.RemoteWatcher.UnwatchRemote
 
watcher() - Method in class akka.remote.RemoteWatcher.WatchRemote
 
WatchFailureDetectorConfig() - Method in class akka.remote.RemoteSettings
 
WatchFailureDetectorImplementationClass() - Method in class akka.remote.RemoteSettings
 
WatchHeartbeatExpectedResponseAfter() - Method in class akka.remote.RemoteSettings
 
WatchHeartBeatInterval() - Method in class akka.remote.RemoteSettings
 
watching() - Method in interface akka.actor.dungeon.DeathWatch
 
watching() - Method in class akka.remote.RemoteWatcher.Stats
 
watching() - Method in class akka.remote.RemoteWatcher
 
watchingContains(ActorRef) - Method in interface akka.actor.dungeon.DeathWatch
 
watchingNodes() - Method in class akka.remote.RemoteWatcher.Stats
 
watchingNodes() - Method in class akka.remote.RemoteWatcher
 
watchingRefs() - Method in class akka.remote.RemoteWatcher.Stats
 
watchRemote(ActorRef, ActorRef) - Method in class akka.remote.RemoteWatcher
 
WatchUnreachableReaperInterval() - Method in class akka.remote.RemoteSettings
 
WeightedRoutees - Class in akka.cluster.routing
INTERNAL API
WeightedRoutees(IndexedSeq<Routee>, Address, Map<Address, Object>) - Constructor for class akka.cluster.routing.WeightedRoutees
 
weights(Map<Address, Object>) - Method in class akka.cluster.routing.CapacityMetricsSelector
Converts the capacity values to weights.
weights(Set<NodeMetrics>) - Method in class akka.cluster.routing.CapacityMetricsSelector
The weights per address, based on the capacity produced by the nodeMetrics.
weights(Set<NodeMetrics>) - Method in interface akka.cluster.routing.MetricsSelector
The weights per address, based on the the nodeMetrics.
welcome(Address, UniqueAddress, Gossip) - Method in class akka.cluster.ClusterCoreDaemon
Reply from Join request.
WheelSize() - Method in class akka.actor.LightArrayRevolverScheduler
 
when(S, PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
Insert a new StateFunction at the end of the processing chain for the given state.
when(S, FSMStateFunctionBuilder<S, D>) - Method in class akka.actor.AbstractFSM
Insert a new StateFunction at the end of the processing chain for the given state.
when(S, FiniteDuration, FSMStateFunctionBuilder<S, D>) - Method in class akka.actor.AbstractFSM
Insert a new StateFunction at the end of the processing chain for the given state.
when(S, FiniteDuration, PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Method in interface akka.actor.FSM
Insert a new StateFunction at the end of the processing chain for the given state.
whenFailing(Function2<Throwable, Option<Object>, BoxedUnit>) - Method in interface akka.actor.dsl.Creators.Act
Replace the preRestart action with the supplied function.
whenRestarted(Function1<Throwable, BoxedUnit>) - Method in interface akka.actor.dsl.Creators.Act
Replace the postRestart action with the supplied function.
whenStarting(Function0<BoxedUnit>) - Method in interface akka.actor.dsl.Creators.Act
Replace the preStart action with the supplied thunk.
whenStopping(Function0<BoxedUnit>) - Method in interface akka.actor.dsl.Creators.Act
Replace the postStop action with the supplied thunk.
whenUnhandled(FSMStateFunctionBuilder<S, D>) - Method in class akka.actor.AbstractFSM
Set handler which is called upon reception of unhandled messages.
whenUnhandled(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Method in interface akka.actor.FSM
 
whileOff(Function0<BoxedUnit>) - Method in class akka.util.Switch
Executes the provided action and returns if the action was executed or not, if the switch is off, waiting for any pending changes to happen before (locking) Be careful of longrunning or blocking within the provided action as it can lead to deadlocks or bad performance
whileOffYield(Function0<T>) - Method in class akka.util.Switch
Executes the provided action and returns its value if the switch is off, waiting for any pending changes to happen before (locking) Be careful of longrunning or blocking within the provided action as it can lead to deadlocks or bad performance
whileOn(Function0<BoxedUnit>) - Method in class akka.util.Switch
Executes the provided action and returns if the action was executed or not, if the switch is on, waiting for any pending changes to happen before (locking) Be careful of longrunning or blocking within the provided action as it can lead to deadlocks or bad performance
whileOnYield(Function0<T>) - Method in class akka.util.Switch
Executes the provided action and returns its value if the switch is on, waiting for any pending changes to happen before (locking) Be careful of longrunning or blocking within the provided action as it can lead to deadlocks or bad performance
wildcardFanOut() - Method in class akka.actor.ActorSelectionMessage
 
WILDCARDFANOUT_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.SelectionEnvelope
 
WildcardTree<T> - Class in akka.util
 
WildcardTree(Option<T>, Map<String, WildcardTree<T>>) - Constructor for class akka.util.WildcardTree
 
WildcardTree$ - Class in akka.util
 
WildcardTree$() - Constructor for class akka.util.WildcardTree$
 
WindowsConnectionAbortWorkaroundEnabled() - Method in class akka.io.TcpExt.Settings
 
wire(T) - Method in class akka.dispatch.MonitorableThreadFactory
 
WireFormats - Class in akka.remote
 
WireFormats.AckAndEnvelopeContainer - Class in akka.remote
Protobuf type AckAndEnvelopeContainer
WireFormats.AckAndEnvelopeContainer.Builder - Class in akka.remote
Protobuf type AckAndEnvelopeContainer
WireFormats.AckAndEnvelopeContainerOrBuilder - Interface in akka.remote
 
WireFormats.AcknowledgementInfo - Class in akka.remote
Protobuf type AcknowledgementInfo
WireFormats.AcknowledgementInfo.Builder - Class in akka.remote
Protobuf type AcknowledgementInfo
WireFormats.AcknowledgementInfoOrBuilder - Interface in akka.remote
 
WireFormats.ActorRefData - Class in akka.remote
Protobuf type ActorRefData
WireFormats.ActorRefData.Builder - Class in akka.remote
Protobuf type ActorRefData
WireFormats.ActorRefDataOrBuilder - Interface in akka.remote
 
WireFormats.AddressData - Class in akka.remote
Protobuf type AddressData
WireFormats.AddressData.Builder - Class in akka.remote
Protobuf type AddressData
WireFormats.AddressDataOrBuilder - Interface in akka.remote
 
WireFormats.AkkaControlMessage - Class in akka.remote
Protobuf type AkkaControlMessage
WireFormats.AkkaControlMessage.Builder - Class in akka.remote
Protobuf type AkkaControlMessage
WireFormats.AkkaControlMessageOrBuilder - Interface in akka.remote
 
WireFormats.AkkaHandshakeInfo - Class in akka.remote
Protobuf type AkkaHandshakeInfo
WireFormats.AkkaHandshakeInfo.Builder - Class in akka.remote
Protobuf type AkkaHandshakeInfo
WireFormats.AkkaHandshakeInfoOrBuilder - Interface in akka.remote
 
WireFormats.AkkaProtocolMessage - Class in akka.remote
Protobuf type AkkaProtocolMessage
WireFormats.AkkaProtocolMessage.Builder - Class in akka.remote
Protobuf type AkkaProtocolMessage
WireFormats.AkkaProtocolMessageOrBuilder - Interface in akka.remote
 
WireFormats.CommandType - Enum in akka.remote
Protobuf enum CommandType
WireFormats.DaemonMsgCreateData - Class in akka.remote
Protobuf type DaemonMsgCreateData
WireFormats.DaemonMsgCreateData.Builder - Class in akka.remote
Protobuf type DaemonMsgCreateData
WireFormats.DaemonMsgCreateDataOrBuilder - Interface in akka.remote
 
WireFormats.DeployData - Class in akka.remote
Protobuf type DeployData
WireFormats.DeployData.Builder - Class in akka.remote
Protobuf type DeployData
WireFormats.DeployDataOrBuilder - Interface in akka.remote
 
WireFormats.PropsData - Class in akka.remote
Protobuf type PropsData
WireFormats.PropsData.Builder - Class in akka.remote
Protobuf type PropsData
WireFormats.PropsDataOrBuilder - Interface in akka.remote
 
WireFormats.RemoteEnvelope - Class in akka.remote
Protobuf type RemoteEnvelope
WireFormats.RemoteEnvelope.Builder - Class in akka.remote
Protobuf type RemoteEnvelope
WireFormats.RemoteEnvelopeOrBuilder - Interface in akka.remote
 
WireFormats.SerializedMessage - Class in akka.remote
Protobuf type SerializedMessage
WireFormats.SerializedMessage.Builder - Class in akka.remote
Protobuf type SerializedMessage
WireFormats.SerializedMessageOrBuilder - Interface in akka.remote
 
withBatch(Function1<org.iq80.leveldb.WriteBatch, R>) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
withBody(T) - Method in class akka.camel.CamelMessage
Java API: Returns a new CamelMessage with a new body, while keeping the same headers.
withBodyAs(ClassTag<T>, org.apache.camel.CamelContext) - Method in class akka.camel.CamelMessage
Creates a CamelMessage with current body converted to type T.
withBodyAs(Class<T>, org.apache.camel.CamelContext) - Method in class akka.camel.CamelMessage
Java API: Creates a CamelMessage with current body converted to type clazz.
withCircuitBreaker(Function0<Future<T>>) - Method in class akka.pattern.CircuitBreaker
Wraps invocations of asynchronous calls that need to be protected
withClient(ActorRef) - Method in class akka.actor.dsl.Inbox.Get
 
withClient(ActorRef) - Method in interface akka.actor.dsl.Inbox.Query
 
withClient(ActorRef) - Method in class akka.actor.dsl.Inbox.Select
 
withContext(Function0<T>) - Method in class akka.actor.TypedActor.TypedActor
 
withCurrentPersistent(Persistent, Function1<Persistent, BoxedUnit>) - Method in interface akka.persistence.Recovery
INTERNAL API
withDeploy(Deploy) - Method in class akka.actor.Props
Returns a new Props with the specified deployment configuration.
withDeploy(Deploy) - Method in class akka.actor.TypedProps
Returns a new TypedProps with the specified deployment configuration.
withDispatcher(String) - Method in class akka.actor.Props
Returns a new Props with the specified dispatcher set.
withDispatcher(String) - Method in class akka.actor.TypedProps
Returns a new TypedProps with the specified dispatcher set.
withDispatcher(String) - Method in class akka.cluster.routing.AdaptiveLoadBalancingGroup
Setting the dispatcher to be used for the router head actor, which handles router management messages
withDispatcher(String) - Method in class akka.cluster.routing.AdaptiveLoadBalancingPool
Setting the dispatcher to be used for the router head actor, which handles supervision, death watch and router management messages.
withDispatcher(String) - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.BalancingPool
Setting the dispatcher to be used for the router head actor, which handles supervision, death watch and router management messages.
withDispatcher(String) - Method in class akka.routing.BroadcastGroup
Setting the dispatcher to be used for the router head actor, which handles router management messages
withDispatcher(String) - Method in class akka.routing.BroadcastPool
Setting the dispatcher to be used for the router head actor, which handles supervision, death watch and router management messages.
withDispatcher(String) - Method in class akka.routing.BroadcastRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.ConsistentHashingGroup
 
withDispatcher(String) - Method in class akka.routing.ConsistentHashingPool
 
withDispatcher(String) - Method in class akka.routing.ConsistentHashingRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.FromConfig
Setting the dispatcher to be used for the router head actor, which handles supervision, death watch and router management messages.
withDispatcher(String) - Method in class akka.routing.RandomGroup
Setting the dispatcher to be used for the router head actor, which handles router management messages
withDispatcher(String) - Method in class akka.routing.RandomPool
Setting the dispatcher to be used for the router head actor, which handles supervision, death watch and router management messages.
withDispatcher(String) - Method in class akka.routing.RandomRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.RoundRobinGroup
Setting the dispatcher to be used for the router head actor, which handles router management messages
withDispatcher(String) - Method in class akka.routing.RoundRobinPool
Setting the dispatcher to be used for the router head actor, which handles supervision, death watch and router management messages.
withDispatcher(String) - Method in class akka.routing.RoundRobinRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.ScatterGatherFirstCompletedGroup
Setting the dispatcher to be used for the router head actor, which handles router management messages
withDispatcher(String) - Method in class akka.routing.ScatterGatherFirstCompletedPool
Setting the dispatcher to be used for the router head actor, which handles supervision, death watch and router management messages.
withDispatcher(String) - Method in class akka.routing.ScatterGatherFirstCompletedRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.SmallestMailboxPool
Setting the dispatcher to be used for the router head actor, which handles supervision, death watch and router management messages.
withDispatcher(String) - Method in class akka.routing.SmallestMailboxRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.TailChoppingGroup
Setting the dispatcher to be used for the router head actor, which handles router management messages
withDispatcher(String) - Method in class akka.routing.TailChoppingPool
Setting the dispatcher to be used for the router head actor, which handles supervision, death watch and router management messages.
withFallback(Deploy) - Method in class akka.actor.Deploy
Do a merge between this and the other Deploy, where values from &ldquo;this&rdquo; take precedence.
withFallback(Scope) - Method in class akka.actor.LocalScope$
 
withFallback(Scope) - Static method in class akka.actor.LocalScope
 
withFallback(Scope) - Method in class akka.actor.NoScopeGiven$
 
withFallback(Scope) - Static method in class akka.actor.NoScopeGiven
 
withFallback(Scope) - Method in interface akka.actor.Scope
When merging Deploy instances using withFallback() on the left one, this is propagated to &ldquo;merging&rdquo; scopes in the same way.
withFallback(Scope) - Method in class akka.cluster.ClusterScope$
 
withFallback(Scope) - Static method in class akka.cluster.ClusterScope
 
withFallback(RouterConfig) - Method in class akka.cluster.routing.AdaptiveLoadBalancingPool
Uses the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one
withFallback(RouterConfig) - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in class akka.cluster.routing.ClusterRouterConfig
 
withFallback(RouterConfig) - Method in class akka.cluster.routing.ClusterRouterGroup
 
withFallback(RouterConfig) - Method in class akka.cluster.routing.ClusterRouterPool
 
withFallback(com.typesafe.config.ConfigMergeable) - Method in class akka.dispatch.CachingConfig
 
withFallback(Scope) - Method in class akka.remote.RemoteScope
 
withFallback(RouterConfig) - Method in class akka.remote.routing.RemoteRouterConfig
 
withFallback(RouterConfig) - Method in class akka.routing.BalancingPool
Uses the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one.
withFallback(RouterConfig) - Method in class akka.routing.BroadcastPool
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in class akka.routing.BroadcastRouter
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in class akka.routing.ConsistentHashingGroup
 
withFallback(RouterConfig) - Method in class akka.routing.ConsistentHashingPool
 
withFallback(RouterConfig) - Method in class akka.routing.ConsistentHashingRouter
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in class akka.routing.NoRouter$
 
withFallback(RouterConfig) - Static method in class akka.routing.NoRouter
 
withFallback(RouterConfig) - Method in class akka.routing.RandomPool
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in class akka.routing.RandomRouter
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in class akka.routing.RoundRobinPool
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in class akka.routing.RoundRobinRouter
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in interface akka.routing.RouterConfig
Overridable merge strategy, by default completely prefers this (i.e.
withFallback(RouterConfig) - Method in class akka.routing.ScatterGatherFirstCompletedPool
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in class akka.routing.ScatterGatherFirstCompletedRouter
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in class akka.routing.SmallestMailboxPool
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in class akka.routing.SmallestMailboxRouter
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in class akka.routing.TailChoppingPool
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFrames(ByteString...) - Method in class akka.zeromq.ZMQMessage$
Java API: create a message from the given frames
withFrames(Seq<ByteString>) - Method in class akka.zeromq.ZMQMessage$
Java API: create a message from the given frames
withFrames(ByteString...) - Static method in class akka.zeromq.ZMQMessage
Java API: create a message from the given frames
withFrames(Seq<ByteString>) - Static method in class akka.zeromq.ZMQMessage
Java API: create a message from the given frames
withGuard(Function0<T>) - Method in class akka.util.ReentrantGuard
 
withHashMapper(ConsistentHashingRouter.ConsistentHashMapper) - Method in class akka.routing.ConsistentHashingGroup
 
withHashMapper(ConsistentHashingRouter.ConsistentHashMapper) - Method in class akka.routing.ConsistentHashingPool
 
withHashMapper(ConsistentHashingRouter.ConsistentHashMapper) - Method in class akka.routing.ConsistentHashingRouter
Java API for setting the mapping from message to the data to use for the consistent hash key.
withHashMapper(ConsistentHashingRouter.ConsistentHashMapper) - Method in class akka.routing.ConsistentHashingRoutingLogic
 
withHeaders(Map<String, A>) - Method in class akka.camel.CamelMessage
Java API: Creates a new CamelMessage with given headers.
withIdleTimeout(FiniteDuration) - Method in class akka.persistence.PersistentChannelSettings
Java API.
within() - Method in class akka.routing.ScatterGatherFirstCompletedGroup
 
within() - Method in class akka.routing.ScatterGatherFirstCompletedPool
 
within() - Method in class akka.routing.ScatterGatherFirstCompletedRoutees
 
within() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
within() - Method in class akka.routing.ScatterGatherFirstCompletedRoutingLogic
 
within() - Method in class akka.routing.TailChoppingGroup
 
within() - Method in class akka.routing.TailChoppingPool
 
within() - Method in class akka.routing.TailChoppingRoutees
 
within() - Method in class akka.routing.TailChoppingRoutingLogic
 
within(FiniteDuration, FiniteDuration, Function0<T>) - Method in interface akka.testkit.TestKitBase
Execute code block while bounding its execution time between min and max.
within(FiniteDuration, Function0<T>) - Method in interface akka.testkit.TestKitBase
Same as calling within(0 seconds, max)(f).
withInterface(Class<? super T>) - Method in class akka.actor.TypedProps
Returns a new TypedProps that has the specified interface, or if the interface class is not an interface, all the interfaces it implements, appended in the sequence of interfaces.
withinTimeRange() - Method in class akka.actor.AllForOneStrategy
 
withinTimeRange() - Method in class akka.actor.OneForOneStrategy
 
withinTimeRangeOption(Duration) - Method in class akka.actor.SupervisorStrategy$
 
withinTimeRangeOption(Duration) - Static method in class akka.actor.SupervisorStrategy
 
withIterator(Function1<org.iq80.leveldb.DBIterator, R>) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
withLabel(String, PartialFunction<Object, BoxedUnit>, ActorContext) - Method in class akka.event.LoggingReceive$
Create a decorated logger which will append " in state " + label to each message it logs.
withLabel(String, PartialFunction<Object, BoxedUnit>, ActorContext) - Static method in class akka.event.LoggingReceive
Create a decorated logger which will append " in state " + label to each message it logs.
WithListeners - Class in akka.routing
 
WithListeners(Function1<ActorRef, BoxedUnit>) - Constructor for class akka.routing.WithListeners
 
WithListeners$ - Class in akka.routing
 
WithListeners$() - Constructor for class akka.routing.WithListeners$
 
withLoader(ClassLoader) - Method in class akka.actor.TypedProps
Java API: return a new TypedProps that will use the specified ClassLoader to create its proxy class in If loader is null, it will use the bootstrap classloader.
withLoader(Option<ClassLoader>) - Method in class akka.actor.TypedProps
Scala API: return a new TypedProps that will use the specified ClassLoader to create its proxy class in If loader is null, it will use the bootstrap classloader.
withMailbox(String) - Method in class akka.actor.Props
Returns a new Props with the specified mailbox set.
withMdc(String, Logging.LogEvent, Function0<BoxedUnit>) - Method in class akka.event.slf4j.Slf4jLogger
 
withName(String) - Method in class akka.dispatch.MonitorableThreadFactory
 
withNewThreadPoolWithArrayBlockingQueueWithCapacityAndFairness(int, boolean) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
withNewThreadPoolWithCustomBlockingQueue(Function0<BlockingQueue<Runnable>>) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
withNewThreadPoolWithCustomBlockingQueue(BlockingQueue<Runnable>) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
withNewThreadPoolWithLinkedBlockingQueueWithCapacity(int) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
withNewThreadPoolWithLinkedBlockingQueueWithUnboundedCapacity() - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
withNewThreadPoolWithSynchronousQueueWithFairness(boolean) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
withOnlyPath(String) - Method in class akka.dispatch.CachingConfig
 
withoutInterface(Class<? super T>) - Method in class akka.actor.TypedProps
Returns a new TypedProps without the specified interface, or if the interface class is not an interface, all the interfaces it implements.
withoutPath(String) - Method in class akka.dispatch.CachingConfig
 
withOutputStream(SnapshotMetadata, Function1<OutputStream, BoxedUnit>) - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
 
withPayload(Object) - Method in class akka.persistence.ConfirmablePersistentImpl
 
withPayload(Object) - Method in class akka.persistence.Persistent
Creates a new persistent message with the specified payload.
withPayload(Object) - Method in class akka.persistence.PersistentImpl
 
withPendingConfirmationsMax(long) - Method in class akka.persistence.PersistentChannelSettings
Java API.
withPendingConfirmationsMin(long) - Method in class akka.persistence.PersistentChannelSettings
Java API.
withRedeliverFailureListener(ActorRef) - Method in class akka.persistence.ChannelSettings
Java API.
withRedeliverFailureListener(ActorRef) - Method in class akka.persistence.PersistentChannelSettings
Java API.
withRedeliverInterval(FiniteDuration) - Method in class akka.persistence.ChannelSettings
Java API.
withRedeliverInterval(FiniteDuration) - Method in class akka.persistence.PersistentChannelSettings
Java API.
withRedeliverMax(int) - Method in class akka.persistence.ChannelSettings
Java API.
withRedeliverMax(int) - Method in class akka.persistence.PersistentChannelSettings
Java API.
withReplyPersistent(boolean) - Method in class akka.persistence.PersistentChannelSettings
Java API.
withResizer(Resizer) - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
Java API for setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.BroadcastPool
Setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.BroadcastRouter
Java API for setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.ConsistentHashingPool
 
withResizer(Resizer) - Method in class akka.routing.ConsistentHashingRouter
Java API for setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.FromConfig
Setting the resizer to be used.
withResizer(Resizer) - Method in interface akka.routing.PoolOverrideUnsetConfig
 
withResizer(Resizer) - Method in class akka.routing.RandomPool
Setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.RandomRouter
Java API for setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.RoundRobinPool
Setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.RoundRobinRouter
Java API for setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.ScatterGatherFirstCompletedPool
Setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.ScatterGatherFirstCompletedRouter
Java API for setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.SmallestMailboxPool
Setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.SmallestMailboxRouter
Java API for setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.TailChoppingPool
Setting the resizer to be used.
withRoutees(IndexedSeq<Routee>) - Method in class akka.routing.Router
Create a new instance with the specified routees and the same RoutingLogic.
withRouter(RouterConfig) - Method in class akka.actor.Props
Returns a new Props with the specified router config set.
withStopReason(FSM.Reason) - Method in class akka.actor.FSM.State
INTERNAL API.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.cluster.routing.AdaptiveLoadBalancingPool
Setting the supervisor strategy to be used for the &ldquo;head&rdquo; Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
Java API for setting the supervisor strategy to be used for the &ldquo;head&rdquo; Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.BalancingPool
Setting the supervisor strategy to be used for the &ldquo;head&rdquo; Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.BroadcastPool
Setting the supervisor strategy to be used for the &ldquo;head&rdquo; Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.BroadcastRouter
Java API for setting the supervisor strategy to be used for the &ldquo;head&rdquo; Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.ConsistentHashingPool
 
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.ConsistentHashingRouter
Java API for setting the supervisor strategy to be used for the &ldquo;head&rdquo; Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.FromConfig
Setting the supervisor strategy to be used for the &ldquo;head&rdquo; Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in interface akka.routing.PoolOverrideUnsetConfig
 
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.RandomPool
Setting the supervisor strategy to be used for the &ldquo;head&rdquo; Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.RandomRouter
Java API for setting the supervisor strategy to be used for the &ldquo;head&rdquo; Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.RoundRobinPool
Setting the supervisor strategy to be used for the &ldquo;head&rdquo; Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.RoundRobinRouter
Java API for setting the supervisor strategy to be used for the &ldquo;head&rdquo; Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.ScatterGatherFirstCompletedPool
Setting the supervisor strategy to be used for the &ldquo;head&rdquo; Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.ScatterGatherFirstCompletedRouter
Java API for setting the supervisor strategy to be used for the &ldquo;head&rdquo; Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.SmallestMailboxPool
Setting the supervisor strategy to be used for the &ldquo;head&rdquo; Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.SmallestMailboxRouter
Java API for setting the supervisor strategy to be used for the &ldquo;head&rdquo; Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.TailChoppingPool
Setting the supervisor strategy to be used for the &ldquo;head&rdquo; Router actor.
withSyncCircuitBreaker(Function0<T>) - Method in class akka.pattern.CircuitBreaker
Wraps invocations of synchronous calls that need to be protected
withTimeout(Timeout) - Method in class akka.actor.TypedProps
Java API: return a new TypedProps that will use the specified Timeout for its non-void-returning methods, if null is specified, it will use the default timeout as specified in the configuration.
withTimeout(Option<Timeout>) - Method in class akka.actor.TypedProps
Scala API: return a new TypedProps that will use the specified Timeout for its non-void-returning methods, if None is specified, it will use the default timeout as specified in the configuration.
WithUdpSend - Interface in akka.io
INTERNAL API
withUid(int) - Method in interface akka.actor.ActorPath
INTERNAL API Creates a new ActorPath with same elements but with the specified uid.
withUid(int) - Method in class akka.actor.ChildActorPath
INTERNAL API
withUid(int) - Method in class akka.actor.RootActorPath
INTERNAL API
withValue(String, com.typesafe.config.ConfigValue) - Method in class akka.dispatch.CachingConfig
 
withValue(ExtendedActorSystem, Callable<S>) - Method in class akka.serialization.JavaSerializer.CurrentSystem
Java API: invoke the callable with the current system being set to the given value for this thread.
withVirtualNodesFactor(int) - Method in class akka.routing.ConsistentHashingGroup
 
withVirtualNodesFactor(int) - Method in class akka.routing.ConsistentHashingPool
 
withVirtualNodesFactor(int) - Method in class akka.routing.ConsistentHashingRouter
Java API for setting the number of virtual nodes per node, used in ConsistentHash
withVirtualNodesFactor(int) - Method in class akka.routing.ConsistentHashingRoutingLogic
 
work() - Method in class akka.io.TcpConnection.UpdatePendingWriteAndThen
 
WorkerDispatcher() - Method in class akka.io.SelectionHandlerSettings
 
workerForCommandHandler(PartialFunction<SelectionHandler.HasFailureMessage, Function1<ChannelRegistry, Props>>) - Method in class akka.io.SelectionHandler.SelectorBasedManager
 
WorkList<T> - Class in akka.contrib.pattern
Fast, small, and dirty implementation of a linked list that removes transient work entries once they are processed.
WorkList() - Constructor for class akka.contrib.pattern.WorkList
 
WorkList$ - Class in akka.contrib.pattern
Provides the utility methods and constructors to the WorkList class.
WorkList$() - Constructor for class akka.contrib.pattern.WorkList$
 
WorkList.Entry<T> - Class in akka.contrib.pattern
Singly linked list entry implementation for WorkList.
WorkList.Entry(Option<T>, boolean) - Constructor for class akka.contrib.pattern.WorkList.Entry
 
wrapIfNeeded() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Internal$
Mediator uses Router to send messages to multiple destinations, Router in general unwraps messages from DistributedPubSubMediator.Internal$.MediatorRouterEnvelope and sends the contents to Routees.
wrappedHandle() - Method in class akka.remote.transport.AbstractTransportAdapterHandle
 
wrappedHandle() - Method in class akka.remote.transport.ProtocolStateActor.AssociatedWaitHandler
 
wrappedHandle() - Method in class akka.remote.transport.ProtocolStateActor.InboundUnassociated
 
wrappedHandle() - Method in class akka.remote.transport.ProtocolStateActor.ListenerReady
 
wrappedHandle() - Method in class akka.remote.transport.ProtocolStateActor.OutboundUnderlyingAssociated
 
wrappedTransport() - Method in class akka.remote.transport.AbstractTransportAdapter
 
writable() - Method in class akka.remote.transport.TestAssociationHandle
 
writableEndpointWithPolicyFor(Address) - Method in class akka.remote.EndpointManager.EndpointRegistry
 
write(ByteString, Tcp.Event) - Method in class akka.io.TcpMessage$
Write data to the TCP connection.
write(ByteString) - Method in class akka.io.TcpMessage$
The same as write(data, noAck()).
write(ByteString, Tcp.Event) - Static method in class akka.io.TcpMessage
Write data to the TCP connection.
write(ByteString) - Static method in class akka.io.TcpMessage
The same as write(data, noAck()).
write(ByteString) - Method in class akka.remote.transport.AkkaProtocolHandle
 
write(ByteString) - Method in interface akka.remote.transport.AssociationHandle
Asynchronously sends the specified payload to the remote endpoint.
write(ByteString) - Method in class akka.remote.transport.FailureInjectorHandle
 
write(ByteString) - Method in class akka.remote.transport.netty.TcpAssociationHandle
 
write(ByteString) - Method in class akka.remote.transport.netty.UdpAssociationHandle
 
write(ByteString) - Method in class akka.remote.transport.TestAssociationHandle
 
write(TestAssociationHandle, ByteString) - Method in class akka.remote.transport.TestTransport
 
write(ByteString) - Method in class akka.remote.transport.ThrottlerHandle
 
writeBehavior() - Method in class akka.remote.transport.TestTransport
The TestTransport.SwitchableLoggedBehavior for the write() method on handles.
WriteBufferHighWaterMark() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
WriteBufferLowWaterMark() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
writeComplete(org.jboss.netty.channel.ChannelHandlerContext, org.jboss.netty.channel.WriteCompletionEvent) - Method in class akka.remote.testconductor.PlayerHandler
 
writeConfirmations(Seq<PersistentConfirmation>) - Method in class akka.persistence.journal.japi.SyncWriteJournal
 
writeConfirmations(Seq<PersistentConfirmation>) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
writeConfirmations(Seq<PersistentConfirmation>) - Method in interface akka.persistence.journal.SyncWriteJournal
Plugin API: synchronously writes a batch of delivery confirmations to the journal.
writeCount() - Method in class akka.remote.EndpointWriter
 
writeFile(String, long, long, Tcp.Event) - Method in class akka.io.TcpMessage$
Write count bytes starting at position from file at filePath to the connection.
writeFile(String, long, long, Tcp.Event) - Static method in class akka.io.TcpMessage
Write count bytes starting at position from file at filePath to the connection.
writeIdMapping(String, int) - Method in interface akka.persistence.journal.leveldb.LeveldbIdMapping
 
WriteJournalBase - Interface in akka.persistence.journal
 
writeMessages(Seq<PersistentRepr>) - Method in class akka.persistence.journal.japi.SyncWriteJournal
 
writeMessages(int, int, String, ActorRef) - Method in interface akka.persistence.journal.JournalSpec
 
writeMessages(Seq<PersistentRepr>) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
writeMessages(Seq<PersistentRepr>) - Method in interface akka.persistence.journal.SyncWriteJournal
Plugin API: synchronously writes a batch of persistent messages to the journal.
writeObject(ObjectOutputStream) - Method in interface akka.actor.ActorContext
ActorContexts shouldn't be Serializable
writePending() - Method in class akka.io.TcpConnection
 
writePending() - Method in class akka.io.UdpConnection
 
writer() - Method in class akka.remote.EndpointWriter.StoppedReading
 
writer() - Method in class akka.remote.EndpointWriter.StopReading
 
writer() - Method in class akka.remote.EndpointWriter.TookOver
 
writer() - Method in class akka.remote.ReliableDeliverySupervisor
 
writeReplace() - Method in class akka.actor.DeadLetterActorRef
 
writeReplace() - Method in class akka.actor.LocalActorRef
 
writeReplace() - Method in interface akka.actor.MinimalActorRef
 
writeReplace() - Method in class akka.actor.RepointableActorRef
 
writeReplace() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
writeReplace() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
 
writeReplace() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
writeReplace() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
writeReplace() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
 
writeReplace() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
writeReplace() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
 
writeReplace() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
writeReplace() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
writeReplace() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
writeReplace() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
 
writeReplace() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
writeReplace() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
writeReplace() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
writeReplace() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
writeReplace() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
writeReplace() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
 
writeReplace() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
 
writeReplace() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
 
writeReplace() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
 
writeReplace() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
writeReplace() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
writeReplace() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
writeReplace() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
 
writeReplace() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
writeReplace() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
 
writeReplace() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
writeReplace() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
writeReplace() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
 
writeReplace() - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
 
writeReplace() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
writeReplace() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
writeReplace() - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
writeReplace() - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage
 
writeReplace() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
writeReplace() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
 
writeReplace() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
writeReplace() - Method in class akka.remote.ContainerFormats.Selection
 
writeReplace() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
writeReplace() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
writeReplace() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
writeReplace() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
writeReplace() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
writeReplace() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
writeReplace() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
writeReplace() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
writeReplace() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
writeReplace() - Method in class akka.remote.WireFormats.ActorRefData
 
writeReplace() - Method in class akka.remote.WireFormats.AddressData
 
writeReplace() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
writeReplace() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
writeReplace() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
writeReplace() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
writeReplace() - Method in class akka.remote.WireFormats.DeployData
 
writeReplace() - Method in class akka.remote.WireFormats.PropsData
 
writeReplace() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
writeReplace() - Method in class akka.remote.WireFormats.SerializedMessage
 
writeSend(EndpointManager.Send) - Method in class akka.remote.EndpointWriter
 
writeSnapshots() - Method in interface akka.persistence.snapshot.SnapshotStoreSpec
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Address
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta.Entry
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Delta
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Payload
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Publish
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Send
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.SendToAll
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status.Version
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.contrib.pattern.protobuf.msg.DistributedPubSubMessages.Status
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.persistence.serialization.MessageFormats.DeliveredMessage
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.persistence.serialization.MessageFormats.DeliverMessage
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessageBatch
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.ContainerFormats.Selection
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.WireFormats.ActorRefData
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.WireFormats.AddressData
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.WireFormats.AkkaControlMessage
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.WireFormats.DeployData
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.WireFormats.PropsData
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.WireFormats.RemoteEnvelope
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.WireFormats.SerializedMessage
 
writing() - Method in class akka.remote.EndpointWriter
 

X

xid() - Method in class akka.actor.mailbox.filebased.filequeue.JournalItem.ConfirmRemove
 
xid() - Method in class akka.actor.mailbox.filebased.filequeue.JournalItem.SavedXid
 
xid() - Method in class akka.actor.mailbox.filebased.filequeue.JournalItem.Unremove
 
xid() - Method in class akka.actor.mailbox.filebased.filequeue.QItem
 

Y

youngestMember() - Method in class akka.cluster.Gossip
 

Z

Zero() - Method in class akka.cluster.VectorClock.Timestamp$
 
zero() - Method in class akka.util.Timeout$
A timeout with zero duration, will cause most requests to always timeout.
zero() - Static method in class akka.util.Timeout
A timeout with zero duration, will cause most requests to always timeout.
ZeroMQ - Class in akka.zeromq
Java API for akka.zeromq
ZeroMQ() - Constructor for class akka.zeromq.ZeroMQ
 
ZeroMQ$ - Class in akka.zeromq
Java API for akka.zeromq
ZeroMQ$() - Constructor for class akka.zeromq.ZeroMQ$
 
ZeroMQExtension - Class in akka.zeromq
The extension for the ZeroMQ module
ZeroMQExtension(ActorSystem) - Constructor for class akka.zeromq.ZeroMQExtension
 
ZeroMQExtension$ - Class in akka.zeromq
The ExtensionId and ExtensionIdProvider for the ZeroMQ module
ZeroMQExtension$() - Constructor for class akka.zeromq.ZeroMQExtension$
 
ZeroMQVersion - Class in akka.zeromq
A Model to represent a version of the zeromq library param: major param: minor param: patch
ZeroMQVersion(int, int, int) - Constructor for class akka.zeromq.ZeroMQVersion
 
ZeroMQVersion$ - Class in akka.zeromq
 
ZeroMQVersion$() - Constructor for class akka.zeromq.ZeroMQVersion$
 
ZMQMessage - Class in akka.zeromq
A message received over the zeromq socket param: frames
ZMQMessage(Seq<ByteString>) - Constructor for class akka.zeromq.ZMQMessage
 
ZMQMessage$ - Class in akka.zeromq
 
ZMQMessage$() - Constructor for class akka.zeromq.ZMQMessage$
 
ZMQMessageDeserializer - Class in akka.zeromq
Deserializes ZeroMQ messages into an immutable sequence of frames
ZMQMessageDeserializer() - Constructor for class akka.zeromq.ZMQMessageDeserializer
 

_

_childrenRefsDoNotCallMeDirectly() - Method in interface akka.actor.dungeon.Children
 
_client() - Method in interface akka.remote.testconductor.Player
 
_controller() - Method in interface akka.remote.testconductor.Conductor
 
_currentPersistent() - Method in interface akka.persistence.Recovery
 
_currentState() - Method in interface akka.persistence.Recovery
INTERNAL API.
_extension() - Method in interface akka.persistence.PluginSpec
 
_failed() - Method in interface akka.actor.dungeon.FaultHandling
 
_lastSequenceNr() - Method in interface akka.persistence.Recovery
 
_log() - Method in interface akka.actor.ActorLogging
 
_logLevel() - Method in interface akka.event.LoggingBus
 
_mailboxDoNotCallMeDirectly() - Method in interface akka.actor.dungeon.Dispatch
 
_mdc() - Method in interface akka.event.DiagnosticLoggingAdapter
 
_nextNameDoNotCallMeDirectly() - Method in interface akka.actor.dungeon.Children
 
_persistenceId() - Method in interface akka.persistence.ProcessorImpl
 
_pid() - Method in interface akka.persistence.PluginSpec
 
_recoveryFailureCause() - Method in interface akka.persistence.Recovery
 
_recoveryFailureMessage() - Method in interface akka.persistence.Recovery
 
_statusDoNotCallMeDirectly() - Method in class akka.dispatch.Mailbox
 
_systemQueueDoNotCallMeDirectly() - Method in class akka.dispatch.Mailbox
 
_viewId() - Method in interface akka.persistence.View
 
_wrappedHandle() - Method in class akka.remote.transport.FailureInjectorHandle
 
_wrappedHandle() - Method in class akka.remote.transport.ThrottlerHandle
 

A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _