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.TestActorRefS