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

A

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_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.FailType
 
AbstractExtensionId<T extends Extension> - Class in akka.actor
Java API for ExtensionId
AbstractExtensionId() - Constructor for class akka.actor.AbstractExtensionId
 
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
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
 
AbstractPipelineContext - Class in akka.io
This base trait of each pipeline’s context provides optimized facilities for generating single commands or events (i.e.
AbstractPipelineContext() - Constructor for class akka.io.AbstractPipelineContext
 
AbstractPipePair<CmdAbove,CmdBelow,EvtAbove,EvtBelow> - Class in akka.io
Java API: A pair of pipes, one for commands and one for events.
AbstractPipePair() - Constructor for class akka.io.AbstractPipePair
 
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
 
AbstractSymmetricPipePair<Above,Below> - Class in akka.io
A convenience type for expressing a AbstractPipePair which has the same types for commands and events.
AbstractSymmetricPipePair() - Constructor for class akka.io.AbstractSymmetricPipePair
 
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
 
accept(Seq<IO.SocketOption>, ActorRef) - Method in class akka.actor.IO.ServerHandle
Sends a request to the IOManager to accept an incoming connection to the ServerSocketChannel associated with this IO.Handle.
acceptableHeartbeatPause() - Method in class akka.remote.PhiAccrualFailureDetector
 
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.io.BackpressureBuffer.Ack
 
ack() - Method in class akka.io.Tcp.CompoundWrite
 
ack() - Method in class akka.io.Tcp.Write
 
ack() - Method in interface akka.io.Tcp.WriteCommand
The acknowledgment token associated with this write command.
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$ - 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
 
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$ - 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$
 
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
 
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.
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.
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
 
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(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 class akka.actor.IOManager
A reference to the IOManagerActor that performs the actual IO.
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.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$
 
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.Props
Obtain an upper-bound approximation of the actor class which is going to be created by these Props.
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
ActorContext - Interface in akka.actor
The actor context - the view of the actor cell from the actor.
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$
 
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.
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$
 
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.
ActorKilledException - Exception in akka.actor
ActorKilledException is thrown when an Actor receives the Kill message
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 “$” 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 “$”.
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).
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$ - 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$
 
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.pattern.AskableActorRef
 
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.
ActorRouteDefinition<T extends > - Class in akka.camel
Wraps a org.apache.camel.model.ProcessorDefinition.
ActorRouteDefinition(<any>) - Constructor for class akka.camel.ActorRouteDefinition
 
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$
 
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.aries.blueprint.BlueprintActorSystemFactory
Strategy method to create the Config for the ActorSystem, ensuring that the default/reference configuration is loaded from the akka-actor bundle.
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.
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
 
Adapters() - Method in class akka.remote.RemoteSettings
 
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$
 
AdaptiveLoadBalancingRouterLike - Interface in akka.cluster.routing
INTERNAL API.
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(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(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(UniqueAddress) - Method in class akka.cluster.protobuf.msg.Gossip
 
addAllAddresses(Address) - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
addAllAllAddresses(Seq<UniqueAddress>) - Method in class akka.cluster.protobuf.msg.Gossip
 
addAllAllAddresses(TraversableOnce<UniqueAddress>) - Method in class akka.cluster.protobuf.msg.Gossip
 
addAllAllAddresses(Seq<Address>) - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
addAllAllAddresses(TraversableOnce<Address>) - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
addAllAllHashes(Seq<String>) - Method in class akka.cluster.protobuf.msg.Gossip
 
addAllAllHashes(TraversableOnce<String>) - Method in class akka.cluster.protobuf.msg.Gossip
 
addAllAllHashes(Seq<String>) - Method in class akka.cluster.protobuf.msg.GossipStatus
 
addAllAllHashes(TraversableOnce<String>) - Method in class akka.cluster.protobuf.msg.GossipStatus
 
addAllAllMetricNames(Seq<String>) - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
addAllAllMetricNames(TraversableOnce<String>) - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
addAllAllRoles(Seq<String>) - Method in class akka.cluster.protobuf.msg.Gossip
 
addAllAllRoles(TraversableOnce<String>) - Method in class akka.cluster.protobuf.msg.Gossip
 
addAllArgs(Iterable<? extends com.google.protobuf.ByteString>) - Method in class akka.remote.WireFormats.PropsData.Builder
 
addAllClasses(Iterable<String>) - Method in class akka.remote.WireFormats.PropsData.Builder
 
addAllHashes(String) - Method in class akka.cluster.protobuf.msg.Gossip
 
addAllHashes(String) - Method in class akka.cluster.protobuf.msg.GossipStatus
 
addAllMembers(Seq<Member>) - Method in class akka.cluster.protobuf.msg.Gossip
 
addAllMembers(TraversableOnce<Member>) - Method in class akka.cluster.protobuf.msg.Gossip
 
addAllMetricNames(String) - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
addAllMetrics(Seq<NodeMetrics.Metric>) - Method in class akka.cluster.protobuf.msg.NodeMetrics
 
addAllMetrics(TraversableOnce<NodeMetrics.Metric>) - Method in class akka.cluster.protobuf.msg.NodeMetrics
 
addAllNacks(Iterable<? extends Long>) - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
addAllNodeMetrics(Seq<NodeMetrics>) - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
addAllNodeMetrics(TraversableOnce<NodeMetrics>) - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
addAllPattern(Iterable<? extends ContainerFormats.Selection>) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
addAllRoles(String) - Method in class akka.cluster.protobuf.msg.Gossip
 
addAllRoles(Seq<String>) - Method in class akka.cluster.protobuf.msg.Join
 
addAllRoles(TraversableOnce<String>) - Method in class akka.cluster.protobuf.msg.Join
 
addAllRolesIndexes(Seq<Object>) - Method in class akka.cluster.protobuf.msg.Member
 
addAllRolesIndexes(TraversableOnce<Object>) - Method in class akka.cluster.protobuf.msg.Member
 
addAllSeen(Seq<GossipOverview.Seen>) - Method in class akka.cluster.protobuf.msg.GossipOverview
 
addAllSeen(TraversableOnce<GossipOverview.Seen>) - Method in class akka.cluster.protobuf.msg.GossipOverview
 
addAllUnreachable(Seq<Member>) - Method in class akka.cluster.protobuf.msg.GossipOverview
 
addAllUnreachable(TraversableOnce<Member>) - Method in class akka.cluster.protobuf.msg.GossipOverview
 
addAllVersions(Seq<VectorClock.Version>) - Method in class akka.cluster.protobuf.msg.VectorClock
 
addAllVersions(TraversableOnce<VectorClock.Version>) - Method in class akka.cluster.protobuf.msg.VectorClock
 
addArgs(com.google.protobuf.ByteString) - Method in class akka.remote.WireFormats.PropsData.Builder
 
addBuffer() - Method in interface akka.contrib.pattern.Aggregator
 
addClasses(String) - Method in class akka.remote.WireFormats.PropsData.Builder
 
addedSchemeIdentifier() - Method in class akka.remote.transport.AbstractTransportAdapterHandle
 
addedSchemeIdentifier() - Method in interface akka.remote.transport.SchemeAugmenter
 
addedSchemeIdentifier() - Method in class akka.remote.transport.ThrottlerTransportAdapter
 
addFilter(EventFilter) - Method in class akka.testkit.TestEventListener
 
addLogger(akka.actor.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
addMembers(Member) - Method in class akka.cluster.protobuf.msg.Gossip
 
addMetrics(NodeMetrics.Metric) - Method in class akka.cluster.protobuf.msg.NodeMetrics
 
addNacks(long) - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
addNode(AbstractNodeQueue.Node<T>) - Method in class akka.dispatch.AbstractNodeQueue
 
addNodeMetrics(NodeMetrics) - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
addPattern(ContainerFormats.Selection) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
addPattern(int, ContainerFormats.Selection) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
addPattern(ContainerFormats.Selection.Builder) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
addPattern(int, ContainerFormats.Selection.Builder) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
addPatternBuilder() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
addPatternBuilder(int) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
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.ChildActorPath
 
address() - Method in class akka.actor.IO.Connect
 
address() - Method in class akka.actor.IO.Connected
 
address() - Method in class akka.actor.IO.Listen
 
address() - Method in class akka.actor.IO.Listening
 
address() - Method in class akka.actor.RootActorPath
 
address() - Method in class akka.cluster.Member
INTERNAL API
address() - Method in class akka.cluster.NodeMetrics
 
Address - Class in akka.cluster.protobuf.msg
 
Address(String, String, int, Option<String>) - Constructor for class akka.cluster.protobuf.msg.Address
 
address() - Method in class akka.cluster.protobuf.msg.UniqueAddress
 
address() - Method in class akka.cluster.StandardMetrics.Cpu
 
address() - Method in class akka.cluster.StandardMetrics.HeapMemory
 
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.SetThrottle
 
Address$ - Class in akka.actor
Returns a String representation formatted as:
Address$() - Constructor for class akka.actor.Address$
 
Address$ - Class in akka.cluster.protobuf.msg
 
Address$() - Constructor for class akka.cluster.protobuf.msg.Address$
 
ADDRESS_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.UniqueAddress$
 
ADDRESS_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.UniqueAddress
 
ADDRESS_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Hello
 
ADDRESS_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
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() - Method in class akka.cluster.protobuf.msg.GossipOverview.Seen
 
addressIndex() - Method in class akka.cluster.protobuf.msg.Member
 
addressIndex() - Method in class akka.cluster.protobuf.msg.NodeMetrics
 
ADDRESSINDEX_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.GossipOverview.Seen$
 
ADDRESSINDEX_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.Member$
 
ADDRESSINDEX_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.Member
 
ADDRESSINDEX_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.NodeMetrics$
 
ADDRESSINDEX_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.NodeMetrics
 
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.
addressTerminated() - Method in class akka.actor.Terminated
 
addressToSocketAddress(Address) - Method in class akka.remote.transport.netty.NettyTransport
 
addressUid() - Method in class akka.remote.AddressUidExtension
 
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$
 
addRoles(String) - Method in class akka.cluster.protobuf.msg.Join
 
addRolesIndexes(int) - Method in class akka.cluster.protobuf.msg.Member
 
addSeen(GossipOverview.Seen) - Method in class akka.cluster.protobuf.msg.GossipOverview
 
addTime() - Method in class akka.actor.mailbox.filebased.filequeue.QItem
 
addToCache(Seq<Tuple2<Object, Set<Object>>>) - Method in interface akka.event.SubchannelClassification
 
addUnreachable(Member) - Method in class akka.cluster.protobuf.msg.GossipOverview
 
addVersions(VectorClock.Version) - Method in class akka.cluster.protobuf.msg.VectorClock
 
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 class akka.testkit.AkkaSpec
 
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
 
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$
 
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.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.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.throttle - package akka.contrib.throttle
 
akka.dispatch - package akka.dispatch
 
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.kernel - package akka.kernel
 
akka.osgi - package akka.osgi
 
akka.osgi.aries.blueprint - package akka.osgi.aries.blueprint
 
akka.osgi.impl - package akka.osgi.impl
 
akka.pattern - package akka.pattern
 
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.util.internal - package akka.util.internal
 
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) - 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
 
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
 
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$
 
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() - Method in class akka.cluster.protobuf.msg.Gossip
 
allAddresses() - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
ALLADDRESSES_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.Gossip$
 
ALLADDRESSES_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.Gossip
 
ALLADDRESSES_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.MetricsGossip$
 
ALLADDRESSES_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.MetricsGossip
 
allButSelf() - Method in class akka.contrib.pattern.DistributedPubSubMediator.SendToAll
 
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
 
AllForOneStrategy(int, Duration, Function<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.AllForOneStrategy
 
AllForOneStrategy(int, Duration, Iterable<Class<? extends Throwable>>) - Constructor for class akka.actor.AllForOneStrategy
 
AllForOneStrategy() - Method in interface akka.actor.dsl.Creators.Act
 
AllForOneStrategy$ - Class in akka.actor
 
AllForOneStrategy$() - Constructor for class akka.actor.AllForOneStrategy$
 
allHashes() - Method in class akka.cluster.protobuf.msg.Gossip
 
allHashes() - Method in class akka.cluster.protobuf.msg.GossipStatus
 
ALLHASHES_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.Gossip$
 
ALLHASHES_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.Gossip
 
ALLHASHES_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.GossipStatus$
 
ALLHASHES_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.GossipStatus
 
AllLogLevels() - Method in class akka.event.Logging$
 
AllLogLevels() - Static method in class akka.event.Logging
 
allMetricNames() - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
ALLMETRICNAMES_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.MetricsGossip$
 
ALLMETRICNAMES_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.MetricsGossip
 
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.ClusterRouterSettings
 
allRoles() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
All node roles in the cluster
allRoles() - Method in class akka.cluster.protobuf.msg.Gossip
 
ALLROLES_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.Gossip$
 
ALLROLES_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.Gossip
 
alone() - Method in interface akka.transactor.Transactor
Default coordination - no other transactors.
alpha() - Method in class akka.cluster.protobuf.msg.NodeMetrics.EWMA
 
ALPHA_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.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) - Static method in class akka.dispatch.BalancingDispatcherConfigurator
 
anchor() - Method in class akka.actor.ActorSelection
 
ap() - Method in class akka.testkit.TestActor.SetAutoPilot
 
append(Tcp.WriteCommand) - Method in interface 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) - 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 name "default", 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 name "default", the specified Config, and specified ClassLoader
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 name "default", 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 name "default", the specified Config, and specified ClassLoader
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(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 interface akka.actor.IndirectActorProducer
 
apply(A) - Method in class akka.actor.IO.Iteratee$
Wrap the provided value within a IO.Done IO.Iteratee.
apply() - Method in class akka.actor.IO.Iteratee$
Returns Iteratee.unit
apply(IO.Input) - Method in class akka.actor.IO.Iteratee
Processes the given IO.Input, returning the resulting Iteratee and the remaining Input.
apply(IO.Input) - Method in interface akka.actor.IO.IterateeRef
 
apply(Function0<IO.IterateeRef<V>>) - Method in class akka.actor.IO.IterateeRef.Map$
Uses a factory to create the initial IterateeRef for each new key.
apply(IO.Input) - Method in class akka.actor.IO.IterateeRefAsync
 
apply(IO.Input) - Method in class akka.actor.IO.IterateeRefSync
 
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$
Scala API: Returns a Props that has default values except for "creator" which will be a function that creates an instance of the supplied type using the default constructor.
apply(Function0<Actor>) - Method in class akka.actor.Props$
Scala API: Returns a Props that has default values except for "creator" which will be a function that creates an instance using the supplied thunk.
apply(Function0<T>, ClassTag<T>) - Method in class akka.actor.Props$
Scala API: Returns a Props that has default values except for "creator" which will be a function that creates an instance using the supplied thunk.
apply(Creator<? extends Actor>) - Method in class akka.actor.Props$
Returns a Props that has default values except for "creator" which will be a function that creates an instance using the supplied thunk.
apply(Function0<Actor>, String, RouterConfig, Deploy) - Method in class akka.actor.Props$
The deprecated legacy constructor.
apply(Class<?>, Seq<Object>) - Method in class akka.actor.Props$
Scala API: create a Props given a class and its constructor arguments.
apply(ClassTag<T>) - Static method in class akka.actor.Props
Scala API: Returns a Props that has default values except for "creator" which will be a function that creates an instance of the supplied type using the default constructor.
apply(Function0<Actor>) - Static method in class akka.actor.Props
Scala API: Returns a Props that has default values except for "creator" which will be a function that creates an instance using the supplied thunk.
apply(Function0<T>, ClassTag<T>) - Static method in class akka.actor.Props
Scala API: Returns a Props that has default values except for "creator" which will be a function that creates an instance using the supplied thunk.
apply(Creator<? extends Actor>) - Static method in class akka.actor.Props
Returns a Props that has default values except for "creator" which will be a function that creates an instance using the supplied thunk.
apply(Function0<Actor>, String, RouterConfig, Deploy) - Static method in class akka.actor.Props
The deprecated legacy constructor.
apply(Class<?>, Seq<Object>) - Static method in class akka.actor.Props
Scala API: create a Props given a class and its constructor arguments.
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(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(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(ExtendedActorSystem, ClusterSettings) - Method in interface akka.cluster.MetricsCollector
 
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(String) - Method in class akka.cluster.VectorClock.Node$
 
apply() - Method in class akka.cluster.VectorClock.Timestamp$
 
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(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(String, Class<?>, Object) - Method in class akka.event.Logging.Error$
 
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(T, LogSource<T>) - Method in interface akka.event.LogSource
Convenience converter access: given an implicit LogSource, generate the string representation and originating class.
apply(T, ActorSystem, LogSource<T>) - Method in interface 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(HasLogging) - Method in class akka.io.BackpressureBuffer
 
apply(PipelineContext) - Method in class akka.io.DelimiterFraming
 
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(PipelineContext) - Method in class akka.io.LengthFieldFrame
 
apply(Context) - Method in class akka.io.PipelineStage
Implement this method to generate this stage’s pair of command and event functions.
apply(Function1<CmdAbove, Iterable<Either<EvtAbove, CmdBelow>>>, Function1<EvtBelow, Iterable<Either<EvtAbove, CmdBelow>>>, PartialFunction<Object, Iterable<Either<EvtAbove, CmdBelow>>>) - Method in class akka.io.PipePairFactory$
Scala API: construct a PipePair from the two given functions; useful for not capturing $outer references.
apply(Function1<CmdAbove, Iterable<Either<EvtAbove, CmdBelow>>>, Function1<EvtBelow, Iterable<Either<EvtAbove, CmdBelow>>>, PartialFunction<Object, Iterable<Either<EvtAbove, CmdBelow>>>) - Static method in class akka.io.PipePairFactory
Scala API: construct a PipePair from the two given functions; useful for not capturing $outer references.
apply(HasLogging) - Method in class akka.io.SslTlsSupport
 
apply(PipelineContext) - Method in class akka.io.StringByteStringAdapter
 
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(PipelineContext) - Method in class akka.io.TcpReadWriteAdapter
 
apply(HasActorContext) - Method in class akka.io.TickGenerator
 
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(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(T) - Method in interface akka.japi.Procedure
 
apply(org.osgi.framework.BundleContext) - Method in class akka.osgi.impl.BundleDelegatingClassLoader$
 
apply(org.osgi.framework.BundleContext) - Static method in class akka.osgi.impl.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(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(A) - Method in class akka.remote.transport.TestTransport.SwitchableLoggedBehavior
Applies the current behavior, and invokes the callback.
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(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(String) - Method in class akka.routing.FromConfig$
 
apply(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(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(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(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(ActorRef) - Method in class akka.testkit.ExtractRoute$
 
apply(ActorRef) - Static method in class akka.testkit.ExtractRoute
 
apply(Function0<T>, ActorSystem) - Method in class akka.testkit.TestActorRef$
 
apply(Function0<T>, String, 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>, ActorSystem) - Static method in class akka.testkit.TestActorRef
 
apply(Function0<T>, String, 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>, Predef.$less$colon$less<T, FSM<S, D>>, ActorSystem) - Method in class akka.testkit.TestFSMRef$
 
apply(Function0<T>, String, Predef.$less$colon$less<T, FSM<S, D>>, ActorSystem) - Method in class akka.testkit.TestFSMRef$
 
apply(Function0<T>, Predef.$less$colon$less<T, FSM<S, D>>, ActorSystem) - Static method in class akka.testkit.TestFSMRef
 
apply(Function0<T>, String, 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(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(int) - Method in class akka.util.ByteString.ByteString1
 
apply(int) - Method in class akka.util.ByteString.ByteString1C
 
apply(int) - Method in class akka.util.ByteString.ByteStrings
 
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(long) - Method in class akka.util.Timeout$
 
apply(long, TimeUnit) - Method in class akka.util.Timeout$
 
apply(long) - Static method in class akka.util.Timeout
 
apply(long, TimeUnit) - Static method in class akka.util.Timeout
 
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
 
args() - Method in class akka.actor.Props
 
ARGS_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.PropsData
 
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
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 “ask” 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.
asReadable() - Method in interface akka.actor.IO.Handle
 
asReadable() - Method in interface akka.actor.IO.ReadHandle
 
asScala() - Method in class akka.japi.Option
 
asScala() - Method in class akka.japi.Option.Some
 
asServer() - Method in interface akka.actor.IO.Handle
 
asServer() - Method in class akka.actor.IO.ServerHandle
 
associate(ActorRef, ActorRef) - Method in interface akka.event.ActorClassification
 
associate(Address) - Method in class akka.remote.transport.AbstractTransportAdapter
 
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
 
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) - 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$
 
associationListener() - Method in class akka.remote.transport.ActorTransportAdapterManager
 
AssociationRegistry - Class in akka.remote.transport
Resets the state of the registry.
AssociationRegistry() - Constructor for class akka.remote.transport.AssociationRegistry
 
AssociationRegistry$ - Class in akka.remote.transport
Resets the state of the registry.
AssociationRegistry$() - Constructor for class akka.remote.transport.AssociationRegistry$
 
asSocket() - Method in interface akka.actor.IO.Handle
 
asSocket() - Method in class akka.actor.IO.SocketHandle
 
asWritable() - Method in interface akka.actor.IO.Handle
 
asWritable() - Method in interface akka.actor.IO.WriteHandle
 
async(IO.Iteratee<A>, ExecutionContext) - Method in class akka.actor.IO.IterateeRef$
Creates an IO.IterateeRefAsync containing an initial IO.Iteratee.
async(ExecutionContext) - Method in class akka.actor.IO.IterateeRef$
Creates an empty IO.IterateeRefAsync.
async(ExecutionContext) - Method in class akka.actor.IO.IterateeRef.Map$
Creates an empty IO.IterateeRefAsync for each new key.
atFullThrottle() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinPool
 
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.
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(akka.actor.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).
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.
AutoDown() - Method in class akka.cluster.ClusterSettings
 
autopilot() - Method in class akka.testkit.TestActor
 
availableTokens() - Method in class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket
 
average() - Method in class akka.cluster.Metric
 
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.
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.
awaitDone(Duration) - Method in class akka.testkit.EventFilter
 
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(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
BackoffPeriod() - Method in class akka.remote.RemoteSettings
 
backoffRate() - Method in class akka.routing.DefaultResizer
Fraction of routees to be removed when the resizer reaches the backoffThreshold.
backoffThreshold() - Method in class akka.routing.DefaultResizer
Minimum fraction of busy routees before backing off.
BackpressureBuffer - Class in akka.io
This pipeline stage implements a configurable buffer for transforming the per-write ACK/NACK-based backpressure model of a TCP connection actor into an edge-triggered back-pressure model: the upper stages will receive notification when the buffer runs full (BackpressureBuffer.HighWatermarkReached) and when it subsequently empties (BackpressureBuffer.LowWatermarkReached).
BackpressureBuffer(long, long, long) - Constructor for class akka.io.BackpressureBuffer
 
BackpressureBuffer$ - Class in akka.io
 
BackpressureBuffer$() - Constructor for class akka.io.BackpressureBuffer$
 
BackpressureBuffer.Ack - Class in akka.io
 
BackpressureBuffer.Ack(int, Tcp.Event) - Constructor for class akka.io.BackpressureBuffer.Ack
 
BackpressureBuffer.Ack$ - Class in akka.io
 
BackpressureBuffer.Ack$() - Constructor for class akka.io.BackpressureBuffer.Ack$
 
BackpressureBuffer.HighWatermarkReached - Interface in akka.io
Message type which is sent when the buffer’s high watermark has been reached, which means that further write requests should not be sent until the low watermark has been reached again.
BackpressureBuffer.HighWatermarkReached$ - Class in akka.io
 
BackpressureBuffer.HighWatermarkReached$() - Constructor for class akka.io.BackpressureBuffer.HighWatermarkReached$
 
BackpressureBuffer.LowWatermarkReached - Interface in akka.io
Message type which is sent when the buffer’s fill level falls below the low watermark, which means that writing can commence again.
BackpressureBuffer.LowWatermarkReached$ - Class in akka.io
 
BackpressureBuffer.LowWatermarkReached$() - Constructor for class akka.io.BackpressureBuffer.LowWatermarkReached$
 
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
 
bandwidth() - Method in class akka.actor.IO.PerformancePreferences
 
BARRIER_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
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
 
BatchAcceptLimit() - Method in class akka.io.TcpExt.Settings
 
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.
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.
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 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 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
 
bind(ActorRef, InetSocketAddress, int, Iterable<Inet.SocketOption>) - 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>) - 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.
BlueprintActorSystemFactory - Class in akka.osgi.aries.blueprint
A set of helper/factory classes to build a Akka system using Blueprint.
BlueprintActorSystemFactory(org.osgi.framework.BundleContext, String, Option<ClassLoader>) - Constructor for class akka.osgi.aries.blueprint.BlueprintActorSystemFactory
 
BlueprintActorSystemFactory(org.osgi.framework.BundleContext, String) - Constructor for class akka.osgi.aries.blueprint.BlueprintActorSystemFactory
 
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
 
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 connections 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$
 
BroadcastLike - Interface in akka.routing
The core pieces of the routing logic is located in this trait to be able to extend.
BroadcastRouter - Class in akka.routing
A Router that uses broadcasts a message to all its connections.
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$
 
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$
 
buf() - Method in class akka.remote.AckedReceiveBuffer
 
buffer(T) - Method in class akka.remote.AckedSendBuffer
Puts a new message in the buffer.
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
build() - Method in class akka.cluster.protobuf.msg.Address
 
build() - Method in class akka.cluster.protobuf.msg.Empty
 
build() - Method in class akka.cluster.protobuf.msg.Gossip
 
build() - Method in class akka.cluster.protobuf.msg.GossipEnvelope
 
build() - Method in class akka.cluster.protobuf.msg.GossipOverview
 
build() - Method in class akka.cluster.protobuf.msg.GossipOverview.Seen
 
build() - Method in class akka.cluster.protobuf.msg.GossipStatus
 
build() - Method in class akka.cluster.protobuf.msg.Join
 
build() - Method in class akka.cluster.protobuf.msg.Member
 
build() - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
build() - Method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope
 
build() - Method in class akka.cluster.protobuf.msg.NodeMetrics
 
build() - Method in class akka.cluster.protobuf.msg.NodeMetrics.EWMA
 
build() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Metric
 
build() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number
 
build() - Method in class akka.cluster.protobuf.msg.UniqueAddress
 
build() - Method in class akka.cluster.protobuf.msg.VectorClock
 
build() - Method in class akka.cluster.protobuf.msg.VectorClock.Version
 
build() - Method in class akka.cluster.protobuf.msg.Welcome
 
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
 
buildFunctionTriple(Ctx, PipelineStage<Ctx, CmdAbove, CmdBelow, EvtAbove, EvtBelow>) - Method in class akka.io.PipelineFactory$
Scala API: build the pipeline and return a pair of functions representing the command and event pipelines.
buildFunctionTriple(Ctx, PipelineStage<Ctx, CmdAbove, CmdBelow, EvtAbove, EvtBelow>) - Static method in class akka.io.PipelineFactory
Scala API: build the pipeline and return a pair of functions representing the command and event pipelines.
buildPartial() - Method in class akka.cluster.protobuf.msg.Address
 
buildPartial() - Method in class akka.cluster.protobuf.msg.Empty
 
buildPartial() - Method in class akka.cluster.protobuf.msg.Gossip
 
buildPartial() - Method in class akka.cluster.protobuf.msg.GossipEnvelope
 
buildPartial() - Method in class akka.cluster.protobuf.msg.GossipOverview
 
buildPartial() - Method in class akka.cluster.protobuf.msg.GossipOverview.Seen
 
buildPartial() - Method in class akka.cluster.protobuf.msg.GossipStatus
 
buildPartial() - Method in class akka.cluster.protobuf.msg.Join
 
buildPartial() - Method in class akka.cluster.protobuf.msg.Member
 
buildPartial() - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
buildPartial() - Method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope
 
buildPartial() - Method in class akka.cluster.protobuf.msg.NodeMetrics
 
buildPartial() - Method in class akka.cluster.protobuf.msg.NodeMetrics.EWMA
 
buildPartial() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Metric
 
buildPartial() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number
 
buildPartial() - Method in class akka.cluster.protobuf.msg.UniqueAddress
 
buildPartial() - Method in class akka.cluster.protobuf.msg.VectorClock
 
buildPartial() - Method in class akka.cluster.protobuf.msg.VectorClock.Version
 
buildPartial() - Method in class akka.cluster.protobuf.msg.Welcome
 
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
 
buildWithSink(Ctx, PipelineStage<Ctx, CmdAbove, CmdBelow, EvtAbove, EvtBelow>, PipelineSink<CmdBelow, EvtAbove>) - Method in class akka.io.PipelineFactory$
Java API: build the pipeline attaching the given callback object to its outputs.
buildWithSink(Ctx, PipelineStage<Ctx, CmdAbove, CmdBelow, EvtAbove, EvtBelow>, PipelineSink<CmdBelow, EvtAbove>) - Static method in class akka.io.PipelineFactory
Java API: build the pipeline attaching the given callback object to its outputs.
buildWithSinkFunctions(Ctx, PipelineStage<Ctx, CmdAbove, CmdBelow, EvtAbove, EvtBelow>, Function1<Try<CmdBelow>, BoxedUnit>, Function1<Try<EvtAbove>, BoxedUnit>) - Method in class akka.io.PipelineFactory$
Scala API: build the pipeline attaching the given command and event sinks to its outputs.
buildWithSinkFunctions(Ctx, PipelineStage<Ctx, CmdAbove, CmdBelow, EvtAbove, EvtBelow>, Function1<Try<CmdBelow>, BoxedUnit>, Function1<Try<EvtAbove>, BoxedUnit>) - Static method in class akka.io.PipelineFactory
Scala API: build the pipeline attaching the given command and event sinks to its outputs.
BundleDelegatingClassLoader - Class in akka.osgi.impl
 
BundleDelegatingClassLoader(org.osgi.framework.Bundle, Option<ClassLoader>) - Constructor for class akka.osgi.impl.BundleDelegatingClassLoader
 
BundleDelegatingClassLoader(org.osgi.framework.Bundle) - Constructor for class akka.osgi.impl.BundleDelegatingClassLoader
 
BundleDelegatingClassLoader$ - Class in akka.osgi.impl
 
BundleDelegatingClassLoader$() - Constructor for class akka.osgi.impl.BundleDelegatingClassLoader$
 
bus() - Method in class akka.event.BusLogging
 
bus() - Method in class akka.event.Logging.InitializeLogger
 
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.IO.Chunk
 
bytes() - Method in class akka.actor.IO.Read
 
bytes() - Method in class akka.actor.IO.Write
 
bytes() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
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.ByteString1C - Class in akka.util
A compact (unsliced) and unfragmented ByteString, implementation of ByteString1C.
ByteString.ByteStrings - Class in akka.util
A ByteString with 2 or more fragments.
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

cache() - Method in interface akka.event.SubchannelClassification
 
cachingConfig() - Method in class akka.dispatch.Dispatchers
 
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
 
CallingThreadMailbox - Class in akka.testkit
 
CallingThreadMailbox(akka.actor.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.
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
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.
cancel() - Method in interface akka.util.internal.Timeout
Deprecated. Cancels the TimerTask associated with this handle.
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.
cancelTimer(String) - Method in interface akka.actor.FSM
Cancel named timer, ensuring that the message is not subsequently delivered (no race).
cancelTimer(String) - Method in class akka.testkit.TestFSMRef
Proxy for FSM.cancelTimer.
capacity() - Method in interface akka.actor.UnrestrictedStash
 
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<ActorRef>) - 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
 
cause() - Method in class akka.actor.FSM.Failure
 
cause() - Method in class akka.actor.IO.Closed
 
cause() - Method in class akka.actor.IO.Error
 
cause() - Method in class akka.actor.IO.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.event.Logging.Error
 
cause() - Method in class akka.io.Tcp.ErrorClosed
 
cause() - Method in class akka.remote.AssociationErrorEvent
 
cause() - Method in class akka.remote.RemotingErrorEvent
 
cause() - Method in exception akka.remote.transport.Transport.InvalidAssociationException
 
channelGroup() - Method in class akka.remote.transport.netty.NettyTransport
 
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
checkMissingAndUnexpected(Seq<Object>, Seq<Object>, String, String) - Method in interface akka.testkit.TestKitBase
 
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_NAME_VALUE - Static variable in enum akka.remote.ContainerFormats.PatternType
 
CHILD_PATTERN_VALUE - Static variable in enum akka.remote.ContainerFormats.PatternType
 
ChildActorPath - Class in akka.actor
INTERNAL API
ChildActorPath(ActorPath, String) - Constructor for class akka.actor.ChildActorPath
 
children() - Method in interface akka.actor.ActorContext
Returns all supervised children; this method returns a view (i.e.
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$
 
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(akka.event.EventBus.Event) - Method in interface akka.event.ActorClassification
Returns the Classifier associated with the specified Event
classify(Object) - Method in class akka.event.EventStream
 
classify(akka.event.EventBus.Event) - Method in interface akka.event.LookupClassification
Returns the Classifier associated with the given Event
classify(akka.event.EventBus.Event) - 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() - 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(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.Address
 
clear() - Method in class akka.cluster.protobuf.msg.Empty
 
clear() - Method in class akka.cluster.protobuf.msg.Gossip
 
clear() - Method in class akka.cluster.protobuf.msg.GossipEnvelope
 
clear() - Method in class akka.cluster.protobuf.msg.GossipOverview
 
clear() - Method in class akka.cluster.protobuf.msg.GossipOverview.Seen
 
clear() - Method in class akka.cluster.protobuf.msg.GossipStatus
 
clear() - Method in class akka.cluster.protobuf.msg.Join
 
clear() - Method in class akka.cluster.protobuf.msg.Member
 
clear() - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
clear() - Method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope
 
clear() - Method in class akka.cluster.protobuf.msg.NodeMetrics
 
clear() - Method in class akka.cluster.protobuf.msg.NodeMetrics.EWMA
 
clear() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Metric
 
clear() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number
 
clear() - Method in class akka.cluster.protobuf.msg.UniqueAddress
 
clear() - Method in class akka.cluster.protobuf.msg.VectorClock
 
clear() - Method in class akka.cluster.protobuf.msg.VectorClock.Version
 
clear() - Method in class akka.cluster.protobuf.msg.Welcome
 
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
 
clearAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
clearAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
clearAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
clearAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
clearAllAddresses() - Method in class akka.cluster.protobuf.msg.Gossip
 
clearAllAddresses() - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
clearAllHashes() - Method in class akka.cluster.protobuf.msg.Gossip
 
clearAllHashes() - Method in class akka.cluster.protobuf.msg.GossipStatus
 
clearAllMetricNames() - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
clearAllRoles() - Method in class akka.cluster.protobuf.msg.Gossip
 
clearArgs() - Method in class akka.remote.WireFormats.PropsData.Builder
 
clearBarrier() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
clearClasses() - Method in class akka.remote.WireFormats.PropsData.Builder
 
clearClazz() - Method in class akka.remote.WireFormats.PropsData.Builder
 
clearCommandType() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
clearConfig() - Method in class akka.remote.WireFormats.DeployData.Builder
 
clearCookie() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
clearCumulativeAck() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
clearDeploy() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
clearDeploy() - Method in class akka.remote.WireFormats.PropsData.Builder
 
clearDirection() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
clearDispatcher() - Method in class akka.remote.WireFormats.DeployData.Builder
 
clearDone() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
clearedList() - Method in class akka.util.ByteIterator.MultiByteArrayIterator$
 
clearEnclosedMessage() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
clearEnvelope() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
clearEwma() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Metric
 
clearExitValue() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
clearFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
clearFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
clearHandshakeInfo() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
clearHello() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
clearHost() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
clearHostname() - Method in class akka.remote.WireFormats.AddressData.Builder
 
clearInstruction() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
clearLog() - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Clears the activity log.
clearMatcher() - Method in class akka.remote.ContainerFormats.Selection.Builder
 
clearMembers() - Method in class akka.cluster.protobuf.msg.Gossip
 
clearMessage() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
clearMessage() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
clearMessageManifest() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
clearMessageManifest() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
clearMetrics() - Method in class akka.cluster.protobuf.msg.NodeMetrics
 
clearNacks() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
clearName() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
clearName() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
clearNode() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
clearNodeMetrics() - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
clearOp() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
clearOrigin() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
clearPath() - Method in class akka.remote.WireFormats.ActorRefData.Builder
 
clearPath() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
clearPath() - Method in class akka.remote.WireFormats.DeployData.Builder
 
clearPattern() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
clearPayload() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
clearPort() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
clearPort() - Method in class akka.remote.WireFormats.AddressData.Builder
 
clearProps() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
clearProtocol() - Method in class akka.cluster.protobuf.msg.Address
 
clearProtocol() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
clearProtocol() - Method in class akka.remote.WireFormats.AddressData.Builder
 
clearRateMBit() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
clearRecipient() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
clearRoles() - Method in class akka.cluster.protobuf.msg.Join
 
clearRolesIndexes() - Method in class akka.cluster.protobuf.msg.Member
 
clearRouterConfig() - Method in class akka.remote.WireFormats.DeployData.Builder
 
clearScope() - Method in class akka.remote.WireFormats.DeployData.Builder
 
clearSeen() - Method in class akka.cluster.protobuf.msg.GossipOverview
 
clearSender() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
clearSeq() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
clearSerialized() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number
 
clearSerializerId() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
clearSerializerId() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
clearSupervisor() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
clearSystem() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
clearSystem() - Method in class akka.remote.WireFormats.AddressData.Builder
 
clearTimeout() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
clearTimestamp() - Method in class akka.cluster.protobuf.msg.VectorClock
 
clearType() - Method in class akka.remote.ContainerFormats.Selection.Builder
 
clearUid() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
clearUnreachable() - Method in class akka.cluster.protobuf.msg.GossipOverview
 
clearValue32() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number
 
clearValue64() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number
 
clearVersions() - Method in class akka.cluster.protobuf.msg.VectorClock
 
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 interface akka.remote.testconductor.Player
 
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
 
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.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.DefaultScheduler
 
close() - Method in interface akka.actor.IO.Handle
Sends a request to the IOManager to close the Channel associated with this IO.Handle.
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.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 - 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$
 
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.contrib.pattern.ClusterReceptionist
 
cluster() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
cluster() - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
Cluster$ - Class in akka.cluster
Cluster Extension Id and factory for creating Cluster extension.
Cluster$() - Constructor for class akka.cluster.Cluster$
 
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.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$ - 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
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.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.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 Exiting.
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.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.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$
 
ClusterMessage - Interface in akka.cluster
Base trait for all cluster messages.
ClusterMessages - Class in akka.cluster.protobuf.msg
 
ClusterMessages() - Constructor for class akka.cluster.protobuf.msg.ClusterMessages
 
ClusterMessages$ - Class in akka.cluster.protobuf.msg
 
ClusterMessages$() - Constructor for class akka.cluster.protobuf.msg.ClusterMessages$
 
ClusterMessageSerializer - Class in akka.cluster.protobuf
Protobuf serializer of cluster messages.
ClusterMessageSerializer(ExtendedActorSystem) - Constructor for class akka.cluster.protobuf.ClusterMessageSerializer
 
ClusterNodeMBean - Interface in akka.cluster
Interface for the cluster JMX MBean.
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$
 
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$
 
ClusterRouterConfig - Class in akka.cluster.routing
RouterConfig implementation for deployment on cluster nodes.
ClusterRouterConfig(RouterConfig, ClusterRouterSettings) - Constructor for class akka.cluster.routing.ClusterRouterConfig
 
ClusterRouterConfig$ - Class in akka.cluster.routing
 
ClusterRouterConfig$() - Constructor for class akka.cluster.routing.ClusterRouterConfig$
 
ClusterRouterSettings - Class in akka.cluster.routing
totalInstances of cluster router must be > 0 maxInstancesPerNode of cluster router must be > 0 maxInstancesPerNode of cluster router must be 1 when routeesPath is defined
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$
 
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
 
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(Function1<Option<Object>, 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
 
ClusterSingletonPropsFactory - Interface in akka.contrib.pattern
Java API.
cmd() - Method in interface akka.io.PipelineContext
INTERNAL API: do not touch!
cmd() - Method in class akka.io.Tcp.CommandFailed
 
cmd() - Method in class akka.io.TcpPipelineHandler.Init.Command
 
cmd() - Method in class akka.io.TcpPipelineHandler.Management
 
cmd() - Method in class akka.io.Udp.CommandFailed
 
cmd() - Method in class akka.io.UdpConnected.CommandFailed
 
cmdHolder() - Method in interface akka.io.PipelineContext
INTERNAL API: do not touch!
cmp() - Method in class akka.dispatch.BoundedPriorityMailbox
 
cmp() - Method in class akka.dispatch.UnboundedPriorityMailbox
 
collectDelta(Map<Address, Object>) - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
combine(PipelineStage<Ctx, CmdAbove, CmdBelow, EvtAbove, EvtBelow>, PipelineStage<Ctx, CmdAbove, CmdBelow, EvtAbove, EvtBelow>) - Method in class akka.io.PipelineStage$
Java API: combine the two stages such that the command pipeline of the left stage is used and the event pipeline of the right, discarding the other two sub-pipelines.
combine(PipelineStage<Ctx, CmdAbove, CmdBelow, EvtAbove, EvtBelow>, PipelineStage<Ctx, CmdAbove, CmdBelow, EvtAbove, EvtBelow>) - Static method in class akka.io.PipelineStage
Java API: combine the two stages such that the command pipeline of the left stage is used and the event pipeline of the right, discarding the other two sub-pipelines.
command(Cmd) - Method in class akka.io.TcpPipelineHandler.Init
Java API: construct a command to be sent to the TcpPipelineHandler actor.
CommandAckTimeout() - Method in class akka.remote.RemoteSettings
 
commandPipeline() - Method in interface akka.io.PipePair
The command pipeline transforms injected commands from the upper stage into commands for the stage below, but it can also emit events for the upper stage.
commands() - Method in class akka.io.PipelinePorts
 
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.
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(VectorClock.Timestamp) - Method in class akka.cluster.VectorClock.Timestamp
 
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
 
compareClassifiers(akka.event.EventBus.Classifier, akka.event.EventBus.Classifier) - 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(akka.event.EventBus.Subscriber, akka.event.EventBus.Subscriber) - Method in interface akka.event.LookupClassification
Provides a total ordering of Subscribers (think java.util.Comparator.compare)
compareSubscribers(akka.event.EventBus.Subscriber, akka.event.EventBus.Subscriber) - 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
 
compress(com.google.protobuf.MessageLite) - Method in class akka.cluster.protobuf.ClusterMessageSerializer
 
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
 
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’s port to which all Players connect, it issues commands to their akka.remote.testconductor.NetworkFailureInjector and provides support for barriers using the BarrierCoordinator.
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 “name” section (if that exists), falling back to system defaults.
config() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
config() - Method in class akka.cluster.ClusterSettings
 
config() - Method in class akka.dispatch.MessageDispatcherConfigurator
 
config() - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
config() - Method in class akka.osgi.aries.blueprint.BlueprintActorSystemFactory
 
config() - Method in class akka.remote.RemoteSettings
 
config() - Method in class akka.remote.testconductor.TestConductorExt.Settings
 
config() - Method in class akka.serialization.Serialization.Settings
 
config() - Method in class akka.testkit.TestKitSettings
 
config() - Method in class akka.transactor.TransactorSettings
 
CONFIG_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DeployData
 
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(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.RemoteSettings
 
configureExecutor() - Method in class akka.dispatch.MessageDispatcherConfigurator
 
ConfigVersion() - Method in class akka.actor.ActorSystem.Settings
 
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.
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
 
connect(SocketAddress, Seq<IO.SocketOption>, ActorRef) - Method in class akka.actor.IOManager
Create a SocketChannel connecting to an address.
connect(String, int, ActorRef) - Method in class akka.actor.IOManager
Create a SocketChannel connecting to a host and port.
connect(InetSocketAddress, InetSocketAddress, Iterable<Inet.SocketOption>, FiniteDuration) - Method in class akka.io.TcpMessage$
The Connect message is sent to the TCP manager actor, which is obtained via TcpExt.getManager().
connect(InetSocketAddress, InetSocketAddress, Iterable<Inet.SocketOption>) - Method in class akka.io.TcpMessage$
Connect to the given remoteAddress with an optional localAddress to bind to given the specified Socket Options
connect(InetSocketAddress, Iterable<Inet.SocketOption>) - Method in class akka.io.TcpMessage$
Connect to the given remoteAddress without binding to a local address.
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, FiniteDuration) - Method in class akka.io.TcpMessage$
Connect to the given remoteAddress with a connection timeout without binding to a local address and without specifying options.
connect(InetSocketAddress, InetSocketAddress, Iterable<Inet.SocketOption>, FiniteDuration) - 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, InetSocketAddress, Iterable<Inet.SocketOption>) - Static method in class akka.io.TcpMessage
Connect to the given remoteAddress with an optional localAddress to bind to given the specified Socket Options
connect(InetSocketAddress, Iterable<Inet.SocketOption>) - Static method in class akka.io.TcpMessage
Connect to the given remoteAddress without binding to a local address.
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(InetSocketAddress, FiniteDuration) - Static method in class akka.io.TcpMessage
Connect to the given remoteAddress with a connection timeout 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$
 
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$
 
connectionTime() - Method in class akka.actor.IO.PerformancePreferences
 
ConnectionTimeout() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
ConnectTimeout() - Method in class akka.remote.testconductor.TestConductorExt.Settings
 
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$
 
ConsistentHashingLike - Interface in akka.routing
The core pieces of the routing logic is located in this trait to be able to extend.
ConsistentHashingRouter - Class in akka.routing
A Router that uses consistent hashing to select a connection based on the sent message.
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$
 
consistentHashKey() - Method in interface akka.routing.ConsistentHashingRouter.ConsistentHashable
 
consistentHashKey() - Method in class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope
 
Consumer - Interface in akka.camel
Mixed in by Actor implementations that consume message from Camel endpoints.
contacts() - Method in class akka.contrib.pattern.ClusterClient
 
ContainerFormats - Class in akka.remote
 
ContainerFormats.PatternType - Enum in akka.remote
 
ContainerFormats.Selection - Class in akka.remote
 
ContainerFormats.Selection.Builder - Class in akka.remote
 
ContainerFormats.SelectionEnvelope - Class in akka.remote
 
ContainerFormats.SelectionEnvelope.Builder - Class in akka.remote
 
ContainerFormats.SelectionEnvelopeOrBuilder - Interface in akka.remote
 
ContainerFormats.SelectionOrBuilder - Interface in akka.remote
 
contains(Object) - Method in class akka.util.BoundedBlockingQueue
 
containsAll(Collection<?>) - Method in class akka.util.BoundedBlockingQueue
 
context() - Method in interface akka.actor.Actor
Stores the context for this actor, including self, and sender.
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.osgi.OsgiActorSystemFactory
 
context() - Method in class akka.routing.RouteeProvider
 
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
 
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
 
Conversions() - Method in class akka.camel.CamelSettings
 
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
 
copy(MemberStatus) - Method in class akka.cluster.Member
 
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
 
corePoolSize() - Method in class akka.dispatch.ThreadPoolConfig
 
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
 
count() - Method in class akka.event.DeadLetterListener
 
count() - Method in class akka.io.Tcp.WriteFile
 
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.testkit.TestActorRefSpec$
 
counter() - Static method in class akka.testkit.TestActorRefSpec
 
cpuCombined() - Method in class akka.cluster.SigarMetricsCollector
(SIGAR) Returns the combined CPU sum of User + Sys + Nice + Wait, in percentage.
CpuCombined() - Method in class akka.cluster.StandardMetrics$
 
cpuCombined() - Method in class akka.cluster.StandardMetrics.Cpu
 
CpuCombined() - Static method in class akka.cluster.StandardMetrics
 
CpuMetricsSelector - Class in akka.cluster.routing
MetricsSelector that uses the combined CPU metrics.
CpuMetricsSelector() - Constructor for class akka.cluster.routing.CpuMetricsSelector
 
CpuMetricsSelector$ - Class in akka.cluster.routing
MetricsSelector that uses the combined CPU metrics.
CpuMetricsSelector$() - Constructor for class akka.cluster.routing.CpuMetricsSelector$
 
create() - Method in class akka.actor.ActorSystem$
Creates a new ActorSystem with the name "default", obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
create(String) - Method in class akka.actor.ActorSystem$
Creates a new ActorSystem with the specified name, obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
create(String, com.typesafe.config.Config) - Method in class akka.actor.ActorSystem$
Creates a new ActorSystem with the name "default", and the specified Config, then obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
create(String, com.typesafe.config.Config, ClassLoader) - Method in class akka.actor.ActorSystem$
Creates a new ActorSystem with the name "default", the specified Config, and specified ClassLoader
create() - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the name "default", obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
create(String) - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the specified name, obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
create(String, com.typesafe.config.Config) - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the name "default", and the specified Config, then obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
create(String, com.typesafe.config.Config, ClassLoader) - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the name "default", the specified Config, and specified ClassLoader
create() - Method in class akka.actor.DefaultSupervisorStrategy
 
create(ActorSystem) - Method in class akka.actor.Inbox$
Create a new Inbox within the given system.
create(ActorSystem) - Static method in class akka.actor.Inbox
Create a new Inbox within the given system.
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.actor.mailbox.filebased.FileBasedMailboxType
 
create(Class<?>, Object...) - Method in class akka.actor.Props$
Java API: create a Props given a class and its constructor arguments.
create(Class<?>, Seq<Object>) - Method in class akka.actor.Props$
Java API: create a Props given a class and its constructor arguments.
create(Creator<T>) - Method in class akka.actor.Props$
Create new Props from the given Creator.
create(Class<?>, Object...) - Static method in class akka.actor.Props
Java API: create a Props given a class and its constructor arguments.
create(Class<?>, Seq<Object>) - Static method in class akka.actor.Props
Java API: create a Props given a class and its constructor arguments.
create(Creator<T>) - Static method in class akka.actor.Props
Create new Props from the given Creator.
create() - Method in class akka.actor.StoppingSupervisorStrategy
 
create() - Method in interface akka.actor.SupervisorStrategyConfigurator
 
create(T, ExecutionContext) - Method in class akka.agent.Agent$
Java API: Factory method for creating an Agent.
create(T, ExecutionContext) - Static method in class akka.agent.Agent
Java API: Factory method for creating an Agent.
create(String, Number, Option<Object>) - Method in class akka.cluster.Metric$
Creates a new Metric instance if the value is valid, otherwise None is returned.
create(String, Try<Number>, Option<Object>) - Method in class akka.cluster.Metric$
Creates a new Metric instance if the Try is successful and the value is valid, otherwise None is returned.
create(String, Number, Option<Object>) - Static method in class akka.cluster.Metric
Creates a new Metric instance if the value is valid, otherwise None is returned.
create(String, Try<Number>, Option<Object>) - Static method in class akka.cluster.Metric
Creates a new Metric instance if the Try is successful and the value is valid, otherwise None is returned.
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.contrib.mailbox.PeekMailboxType
 
create(Object) - Method in interface akka.contrib.pattern.ClusterSingletonPropsFactory
Create the Props from the handOverData sent from previous singleton.
create(MailboxType) - Method in class akka.dispatch.BalancingDispatcherConfigurator
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.BoundedDequeBasedMailbox
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.BoundedMailbox
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.BoundedPriorityMailbox
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in interface akka.dispatch.MailboxType
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.SingleConsumerOnlyUnboundedMailbox
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.UnboundedDequeBasedMailbox
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.UnboundedMailbox
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.UnboundedPriorityMailbox
 
create(PipelineContext, AbstractPipePair<CmdAbove, CmdBelow, EvtAbove, EvtBelow>) - Method in class akka.io.PipePairFactory$
Java API: construct a PipePair from the given AbstractPipePair.
create(PipelineContext, AbstractSymmetricPipePair<Above, Below>) - Method in class akka.io.PipePairFactory$
Java API: construct a PipePair from the given AbstractSymmetricPipePair.
create(PipelineContext, AbstractPipePair<CmdAbove, CmdBelow, EvtAbove, EvtBelow>) - Static method in class akka.io.PipePairFactory
Java API: construct a PipePair from the given AbstractPipePair.
create(PipelineContext, AbstractSymmetricPipePair<Above, Below>) - Static method in class akka.io.PipePairFactory
Java API: construct a PipePair from the given AbstractSymmetricPipePair.
create(Iterable<Tcp.WriteCommand>) - Method in class akka.io.Tcp.WriteCommand$
Java API: combines the given number of write commands into one atomic WriteCommand.
create() - Method in interface akka.japi.Creator
This method must return a different instance upon every call.
create() - Method in class akka.osgi.aries.blueprint.BlueprintActorSystemFactory
 
create(Scheduler, int, FiniteDuration, FiniteDuration) - Method in class akka.pattern.CircuitBreaker$
Java API: Create a new CircuitBreaker.
create(Scheduler, int, FiniteDuration, FiniteDuration) - Static method in class akka.pattern.CircuitBreaker
Java API: Create a new CircuitBreaker.
create(Transport, ExtendedActorSystem) - Method in class akka.remote.transport.FailureInjectorProvider
 
create(Transport, ExtendedActorSystem) - Method in class akka.remote.transport.ThrottlerProvider
 
create(Transport, ExtendedActorSystem) - Method in interface akka.remote.transport.TransportAdapterProvider
Create the transport adapter that wraps an underlying transport.
create(Iterable<ActorRef>) - Method in class akka.routing.BroadcastRouter$
 
create(Iterable<ActorRef>) - Static method in class akka.routing.BroadcastRouter
 
create(Iterable<T>, int) - Method in class akka.routing.ConsistentHash$
Java API: Factory method to create a ConsistentHash
create(Iterable<T>, int) - Static method in class akka.routing.ConsistentHash
Java API: Factory method to create a ConsistentHash
create(Iterable<ActorRef>) - Method in class akka.routing.ConsistentHashingRouter$
 
create(Iterable<ActorRef>) - Static method in class akka.routing.ConsistentHashingRouter
 
create(Iterable<ActorRef>) - Method in class akka.routing.RandomRouter$
 
create(Iterable<ActorRef>) - Static method in class akka.routing.RandomRouter
 
create(Iterable<ActorRef>) - Method in class akka.routing.RoundRobinRouter$
 
create(Iterable<ActorRef>) - Static method in class akka.routing.RoundRobinRouter
 
create(Iterable<ActorRef>, FiniteDuration) - Method in class akka.routing.ScatterGatherFirstCompletedRouter$
 
create(Iterable<ActorRef>, FiniteDuration) - Static method in class akka.routing.ScatterGatherFirstCompletedRouter
 
create(Iterable<ActorRef>) - Method in class akka.routing.SmallestMailboxRouter$
 
create(Iterable<ActorRef>) - Static method in class akka.routing.SmallestMailboxRouter
 
create(ActorSystem, Props, String) - Method in class akka.testkit.TestActorRef$
Java API: create a TestActorRef in the given system for the given props, with the given name.
create(ActorSystem, Props) - Method in class akka.testkit.TestActorRef$
Java API: create a TestActorRef in the given system for the given props, with a random name.
create(ActorSystem, Props, String) - Static method in class akka.testkit.TestActorRef
Java API: create a TestActorRef in the given system for the given props, with the given name.
create(ActorSystem, Props) - Static method in class akka.testkit.TestActorRef
Java API: create a TestActorRef in the given system for the given props, with a random name.
createActor() - Method in class akka.cluster.routing.ClusterRouterConfig
 
createActor() - Method in class akka.remote.routing.RemoteRouterConfig
 
createActor() - Method in interface akka.routing.RouterConfig
The router "head" actor.
createActorSystem(String) - Method in class akka.osgi.OsgiActorSystemFactory
Creates the ActorSystem, using the name specified
createActorSystem(Option<String>) - Method in class akka.osgi.OsgiActorSystemFactory
Creates the ActorSystem, using the name specified.
createActorSystemBean(org.apache.aries.blueprint.ParserContext, Element, org.apache.aries.blueprint.mutable.MutableBeanMetadata) - Method in class akka.osgi.aries.blueprint.NamespaceHandler
 
createCustomRoute(RouteeProvider) - Method in class akka.routing.CustomRouterConfig
 
createExecutorService() - Method in interface akka.dispatch.ExecutorServiceFactory
 
createExecutorService() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory
 
createExecutorService() - Method in class akka.dispatch.ThreadPoolConfig.ThreadPoolExecutorServiceFactory
 
createExecutorServiceFactory(String, ThreadFactory) - Method in interface akka.dispatch.ExecutorServiceFactoryProvider
 
createExecutorServiceFactory(String, ThreadFactory) - Method in class akka.dispatch.ForkJoinExecutorConfigurator
 
createExecutorServiceFactory(String, ThreadFactory) - Method in class akka.dispatch.ThreadPoolConfig
 
createExecutorServiceFactory(String, ThreadFactory) - Method in class akka.dispatch.ThreadPoolExecutorConfigurator
 
createExtension(ExtendedActorSystem) - Method in class akka.actor.ActorDSL.Extension$
 
createExtension(ExtendedActorSystem) - Method in interface akka.actor.ExtensionId
Is used by Akka to instantiate the Extension identified by this ExtensionId, internal use only.
createExtension(ExtendedActorSystem) - Method in class akka.actor.ExtensionKey
 
createExtension(ExtendedActorSystem) - Method in class akka.actor.IOManager$
 
createExtension(ExtendedActorSystem) - Static method in class akka.actor.IOManager
 
createExtension(ExtendedActorSystem) - Method in class akka.actor.TypedActor$
 
createExtension(ExtendedActorSystem) - Static method in class akka.actor.TypedActor
 
createExtension(ExtendedActorSystem) - Method in class akka.camel.CamelExtension$
Creates a new instance of Camel and makes sure it gets stopped when the actor system is shutdown.
createExtension(ExtendedActorSystem) - Static method in class akka.camel.CamelExtension
Creates a new instance of Camel and makes sure it gets stopped when the actor system is shutdown.
createExtension(ExtendedActorSystem) - Method in class akka.cluster.Cluster$
 
createExtension(ExtendedActorSystem) - Static method in class akka.cluster.Cluster
 
createExtension(ExtendedActorSystem) - Method in class akka.contrib.mailbox.PeekMailboxExtension$
 
createExtension(ExtendedActorSystem) - Static method in class akka.contrib.mailbox.PeekMailboxExtension
 
createExtension(ExtendedActorSystem) - Method in class akka.contrib.pattern.ClusterReceptionistExtension$
 
createExtension(ExtendedActorSystem) - Static method in class akka.contrib.pattern.ClusterReceptionistExtension
 
createExtension(ExtendedActorSystem) - Method in class akka.contrib.pattern.DistributedPubSubExtension$
 
createExtension(ExtendedActorSystem) - Static method in class akka.contrib.pattern.DistributedPubSubExtension
 
createExtension(ExtendedActorSystem) - Method in class akka.io.Tcp$
 
createExtension(ExtendedActorSystem) - Static method in class akka.io.Tcp
 
createExtension(ExtendedActorSystem) - Method in class akka.io.Udp$
 
createExtension(ExtendedActorSystem) - Static method in class akka.io.Udp
 
createExtension(ExtendedActorSystem) - Method in class akka.io.UdpConnected$
 
createExtension(ExtendedActorSystem) - Static method in class akka.io.UdpConnected
 
createExtension(ExtendedActorSystem) - Method in class akka.remote.AddressUidExtension$
 
createExtension(ExtendedActorSystem) - Static method in class akka.remote.AddressUidExtension
 
createExtension(ExtendedActorSystem) - Method in class akka.remote.testconductor.TestConductor$
 
createExtension(ExtendedActorSystem) - Static method in class akka.remote.testconductor.TestConductor
 
createExtension(ExtendedActorSystem) - Method in class akka.remote.transport.TransportAdaptersExtension$
 
createExtension(ExtendedActorSystem) - Static method in class akka.remote.transport.TransportAdaptersExtension
 
createExtension(ExtendedActorSystem) - Method in class akka.serialization.SerializationExtension$
 
createExtension(ExtendedActorSystem) - Static method in class akka.serialization.SerializationExtension
 
createExtension(ExtendedActorSystem) - Method in class akka.testkit.TestKitExtension$
 
createExtension(ExtendedActorSystem) - Static method in class akka.testkit.TestKitExtension
 
createExtension(ExtendedActorSystem) - Method in class akka.transactor.TransactorExtension$
 
createExtension(ExtendedActorSystem) - Static method in class akka.transactor.TransactorExtension
 
createExtension(ExtendedActorSystem) - Method in class akka.zeromq.ZeroMQExtension$
 
createExtension(ExtendedActorSystem) - Static method in class akka.zeromq.ZeroMQExtension
 
createFactoryBean(org.apache.aries.blueprint.ParserContext, String) - Method in class akka.osgi.aries.blueprint.NamespaceHandler
 
createInstanceFor(Class<?>, Seq<Tuple2<Class<?>, Object>>, ClassTag<T>) - Method in class akka.actor.DynamicAccess
Convenience method which given a Class[_] object and a constructor description will create a new instance of that class.
createInstanceFor(String, Seq<Tuple2<Class<?>, Object>>, ClassTag<T>) - Method in class akka.actor.DynamicAccess
Obtain an object conforming to the type T, which is expected to be instantiated from a class designated by the fully-qualified class name given, where the constructor is selected and invoked according to the args argument.
createInstanceFor(Class<?>, Seq<Tuple2<Class<?>, Object>>, ClassTag<T>) - Method in class akka.actor.ReflectiveDynamicAccess
 
createInstanceFor(String, Seq<Tuple2<Class<?>, Object>>, ClassTag<T>) - Method in class akka.actor.ReflectiveDynamicAccess
 
createMailbox(akka.actor.Cell, MailboxType) - Method in class akka.dispatch.BalancingDispatcher
 
createMailbox(akka.actor.Cell, MailboxType) - Method in class akka.dispatch.Dispatcher
INTERNAL API
createMailbox(akka.actor.Cell, MailboxType) - Method in class akka.dispatch.MessageDispatcher
Creates and returns a mailbox for the given actor.
createMailbox(akka.actor.Cell, MailboxType) - Method in class akka.testkit.CallingThreadDispatcher
 
createMailboxTestActor(Props, String) - Method in class akka.actor.mailbox.DurableMailboxSpec
 
createRoute(RouteeProvider) - Method in interface akka.cluster.routing.AdaptiveLoadBalancingRouterLike
 
createRoute(RouteeProvider) - Method in class akka.cluster.routing.ClusterRouterConfig
 
createRoute(RouteeProvider) - Method in class akka.remote.routing.RemoteRouterConfig
 
createRoute(RouteeProvider) - Method in interface akka.routing.BroadcastLike
 
createRoute(RouteeProvider) - Method in interface akka.routing.ConsistentHashingLike
 
createRoute(RouteeProvider) - Method in class akka.routing.CustomRouterConfig
 
createRoute(RouteeProvider) - Method in class akka.routing.FromConfig
 
createRoute(RouteeProvider) - Method in class akka.routing.NoRouter$
 
createRoute(RouteeProvider) - Static method in class akka.routing.NoRouter
 
createRoute(RouteeProvider) - Method in interface akka.routing.RandomLike
 
createRoute(RouteeProvider) - Method in interface akka.routing.RoundRobinLike
 
createRoute(RouteeProvider) - Method in interface akka.routing.RouterConfig
Implement the routing logic by returning a partial function of partial function from (sender, message) to a set of destinations.
createRoute(RouteeProvider) - Method in interface akka.routing.ScatterGatherFirstCompletedLike
 
createRoute(RouteeProvider) - Method in interface akka.routing.SmallestMailboxLike
 
createRouteeProvider(ActorContext, Props) - Method in class akka.cluster.routing.ClusterRouterConfig
 
createRouteeProvider(ActorContext, Props) - Method in class akka.remote.routing.RemoteRouterConfig
 
createRouteeProvider(ActorContext, Props) - Method in interface akka.routing.RouterConfig
The RouteeProvider responsible for creating or looking up routees.
createRoutees(int) - Method in class akka.remote.routing.RemoteRouteeProvider
 
createRoutees(int) - Method in class akka.routing.RouteeProvider
Creates new routees from specified Props and registers them.
createThreadPoolConfigBuilder(com.typesafe.config.Config, DispatcherPrerequisites) - Method in class akka.dispatch.ThreadPoolExecutorConfigurator
 
createTimeout(TimerTask, long) - Method in class akka.util.internal.HashedWheelTimer
Deprecated.  
CreationTimeout() - Method in class akka.actor.ActorSystem.Settings
 
creator() - Method in class akka.actor.Props
 
creator() - Method in class akka.actor.TypedProps
 
Creator<T> - Interface in akka.japi
A constructor/factory, takes no parameters but creates a new value of type T every call.
CreatorConsumerClass() - Method in interface akka.actor.IndirectActorProducer
 
CreatorFunctionConsumerClass() - Method in interface akka.actor.IndirectActorProducer
 
Creators - Interface in akka.actor.dsl
 
Creators.Act - Interface in akka.actor.dsl
This trait provides a DSL for writing the inner workings of an actor, e.g.
Creators.ActWithStash - Interface in akka.actor.dsl
Use this trait when defining an Actor with Stash, since just using actor()(new Act with Stash{}) will not be able to see the Stash component due to type erasure.
Crypt - Class in akka.util
 
Crypt() - Constructor for class akka.util.Crypt
 
Crypt$ - Class in akka.util
 
Crypt$() - Constructor for class akka.util.Crypt$
 
ctdLock() - Method in class akka.testkit.CallingThreadMailbox
 
ctx() - Method in class akka.io.TcpPipelineHandler
 
cumulativeAck() - Method in class akka.remote.Ack
 
cumulativeAck() - Method in class akka.remote.AckedReceiveBuffer
 
CUMULATIVEACK_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AcknowledgementInfo
 
currentAge() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
currentBytes() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
currentDeadline() - Method in class akka.actor.dsl.Inbox.InboxActor
 
currentItems() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
currentMsg() - Method in class akka.actor.dsl.Inbox.InboxActor
 
CurrentRoutees - Class in akka.routing
Sending this message to a router will make it send back its currently used routees.
CurrentRoutees() - Constructor for class akka.routing.CurrentRoutees
 
CurrentRoutees$ - Class in akka.routing
 
CurrentRoutees$() - Constructor for class akka.routing.CurrentRoutees$
 
currentSelect() - Method in class akka.actor.dsl.Inbox.InboxActor
 
currentState() - Method in interface akka.actor.FSM
 
currentState() - Method in class akka.actor.FSM.StopEvent
 
currentSystem() - Method in class akka.serialization.JavaSerializer$
This holds a reference to the current ActorSystem (the surrounding context) during serialization and deserialization.
currentSystem() - Static method in class akka.serialization.JavaSerializer
This holds a reference to the current ActorSystem (the surrounding context) during serialization and deserialization.
currentTimeMillisToUTCString(long) - Method in class akka.util.Helpers$
Converts a "currentTimeMillis"-obtained timestamp accordingly: "$hours%02d:$minutes%02d:$seconds%02d.$ms%03dUTC"
currentTimeMillisToUTCString(long) - Static method in class akka.util.Helpers
Converts a "currentTimeMillis"-obtained timestamp accordingly: "$hours%02d:$minutes%02d:$seconds%02d.$ms%03dUTC"
currentTransportInformation() - Method in class akka.serialization.Serialization$
This holds a reference to the current transport serialization information used for serializing local actor refs.
currentTransportInformation() - Static method in class akka.serialization.Serialization
This holds a reference to the current transport serialization information used for serializing local actor refs.
currentXid() - Method in class akka.actor.mailbox.filebased.filequeue.tools.QueueDumper
 
custom(PartialFunction<Logging.LogEvent, Object>, int) - Method in class akka.testkit.EventFilter$
Create a custom event filter.
custom(PartialFunction<Logging.LogEvent, Object>, int) - Static method in class akka.testkit.EventFilter
Create a custom event filter.
CustomEventFilter - Class in akka.testkit
Custom event filter when the others do not fit the bill.
CustomEventFilter(PartialFunction<Logging.LogEvent, Object>, int) - Constructor for class akka.testkit.CustomEventFilter
 
CustomEventFilter$ - Class in akka.testkit
 
CustomEventFilter$() - Constructor for class akka.testkit.CustomEventFilter$
 
CustomRoute - Interface in akka.routing
Java API helper for creating a single-destination routing.
CustomRouterConfig - Class in akka.routing
Java API for a custom router factory.
CustomRouterConfig() - Constructor for class akka.routing.CustomRouterConfig
 

D

daemonic() - Method in class akka.dispatch.MonitorableThreadFactory
 
Daemonicity() - Method in class akka.actor.ActorSystem.Settings
 
data() - Method in class akka.actor.mailbox.filebased.filequeue.QItem
 
data() - Method in class akka.io.Tcp.Received
 
data() - Method in class akka.io.Tcp.Write
 
data() - Method in class akka.io.Udp.Received
 
data() - Method in class akka.io.UdpConnected.Received
 
date() - Method in interface akka.event.Logging.StdOutLogger
 
dateFormat() - Method in interface akka.event.Logging.StdOutLogger
 
deactivationFutureFor(ActorRef, Timeout, ExecutionContext) - Method in interface akka.camel.Activation
Produces a Future which will be completed when the given endpoint has been deactivated or or if it times out, which will happen after the specified Timeout.
dead() - Method in exception akka.actor.DeathPactException
 
DeadLetter - Class in akka.actor
When a message is sent to an Actor that is terminated before receiving the message, it will be sent as a DeadLetter to the ActorSystem's EventStream
DeadLetter(Object, ActorRef, ActorRef) - Constructor for class akka.actor.DeadLetter
 
DeadLetter$ - Class in akka.actor
 
DeadLetter$() - Constructor for class akka.actor.DeadLetter$
 
DeadLetterListener - Class in akka.event
 
DeadLetterListener() - Constructor for class akka.event.DeadLetterListener
 
deadLetters() - Method in interface akka.actor.ActorRefProvider
Dead letter destination for this provider.
deadLetters() - Method in class akka.actor.ActorSystem
Actor reference where messages are re-routed to which were addressed to stopped or non-existing actors.
DeadLettersFilter - Class in akka.testkit
Filter which matches DeadLetter events, if the wrapped message conforms to the given type.
DeadLettersFilter(Class<?>, int) - Constructor for class akka.testkit.DeadLettersFilter
 
DeadLettersFilter$ - Class in akka.testkit
 
DeadLettersFilter$() - Constructor for class akka.testkit.DeadLettersFilter$
 
deadline() - Method in class akka.actor.dsl.Inbox.Get
 
deadline() - Method in interface akka.actor.dsl.Inbox.Query
 
deadline() - Method in class akka.actor.dsl.Inbox.Select
 
deadlineOrder() - Method in interface akka.actor.dsl.Inbox
 
Deafen - Class in akka.routing
 
Deafen(ActorRef) - Constructor for class akka.routing.Deafen
 
Deafen$ - Class in akka.routing
 
Deafen$() - Constructor for class akka.routing.Deafen$
 
dealias(Iterable<Either<Evt, Cmd>>) - Method in class akka.io.AbstractPipePair
INTERNAL API: Dealias a possibly optimized return value such that it can be safely used; this is never needed when only using public API.
dealias(Iterable<Either<Evt, Cmd>>) - Method in interface akka.io.PipelineContext
INTERNAL API: Dealias a possibly optimized return value such that it can be safely used; this is never needed when only using public API.
DeathPactException - Exception in akka.actor
A DeathPactException is thrown by an Actor that receives a Terminated(someActor) message that it doesn't handle itself, effectively crashing the Actor and escalating to the supervisor.
DeathPactException$ - Class in akka.actor
 
DeathPactException$() - Constructor for class akka.actor.DeathPactException$
 
debug() - Static method in class akka.dispatch.MessageDispatcher
 
debug(Logging.Debug) - Method in interface akka.event.Logging.StdOutLogger
 
debug(String) - Method in interface akka.event.LoggingAdapter
Log message at debug level.
debug(String, Object) - Method in interface akka.event.LoggingAdapter
Message template with 1 replacement argument.
debug(String, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 2 replacement arguments.
debug(String, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 3 replacement arguments.
debug(String, Object, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 4 replacement arguments.
debug(String, String, String, String, int) - Method in class akka.testkit.EventFilter$
Create a filter for Debug events.
debug(String, String, String, String, int) - Static method in class akka.testkit.EventFilter
Create a filter for Debug events.
DebugAutoReceive() - Method in class akka.actor.ActorSystem.Settings
 
debugConfig(boolean) - Method in class akka.remote.testkit.MultiNodeConfig
Include for verbose debug logging
debugEvent() - Method in interface akka.actor.FSM
 
debugEvent() - Method in interface akka.actor.LoggingFSM
 
DebugEventStream() - Method in class akka.actor.ActorSystem.Settings
 
DebugFilter - Class in akka.testkit
Filter which matches Debug events, if they satisfy the given criteria: source, if given, applies a filter on the event’s origin message applies a filter on the event’s message (either with String.startsWith or Regex.findFirstIn().isDefined) If you want to match all Debug events, the most efficient is to use Left("").
DebugFilter(Option<String>, Either<String, Regex>, boolean, int) - Constructor for class akka.testkit.DebugFilter
 
DebugFilter(String, String, boolean, boolean, int) - Constructor for class akka.testkit.DebugFilter
Java API: create a DebugFilter
DebugFilter$ - Class in akka.testkit
 
DebugFilter$() - Constructor for class akka.testkit.DebugFilter$
 
debugFormat() - Method in interface akka.event.Logging.StdOutLogger
 
DebugLevel() - Method in class akka.event.Logging$
 
DebugLevel() - Static method in class akka.event.Logging
 
DebugLifecycle() - Method in class akka.actor.ActorSystem.Settings
 
DebugRouterMisconfiguration() - Method in class akka.actor.ActorSystem.Settings
 
DebugUnhandledMessage() - Method in class akka.actor.ActorSystem.Settings
 
decider() - Method in class akka.actor.AllForOneStrategy
 
decider() - Method in class akka.actor.OneForOneStrategy
 
decider() - Method in class akka.actor.SupervisorStrategy
Returns the Decider that is associated with this SupervisorStrategy.
decodeString(String) - Method in class akka.util.ByteString.ByteString1
 
decodeString(String) - Method in class akka.util.ByteString.ByteString1C
 
decodeString(String) - Method in class akka.util.ByteString.ByteStrings
 
decodeString(String) - Method in class akka.util.ByteString
Decodes this ByteString using a charset to produce a String.
decompress(byte[]) - Method in class akka.cluster.protobuf.ClusterMessageSerializer
 
decorate(Node, org.osgi.service.blueprint.reflect.ComponentMetadata, org.apache.aries.blueprint.ParserContext) - Method in class akka.osgi.aries.blueprint.NamespaceHandler
 
decr() - Method in class akka.actor.mailbox.filebased.filequeue.Counter
 
decr(long) - Method in class akka.actor.mailbox.filebased.filequeue.Counter
 
defaultAllowCoreThreadTimeout() - Method in class akka.dispatch.ThreadPoolConfig$
 
defaultAllowCoreThreadTimeout() - Static method in class akka.dispatch.ThreadPoolConfig
 
defaultBacklog() - Method in class akka.actor.IOManager.Settings
 
defaultClock() - Method in class akka.remote.FailureDetector$
 
defaultClock() - Method in interface akka.remote.FailureDetector
 
defaultCorePoolSize() - Method in class akka.dispatch.ThreadPoolConfig$
 
defaultCorePoolSize() - Static method in class akka.dispatch.ThreadPoolConfig
 
defaultCreator() - Method in class akka.actor.Props$
The defaultCreator, simply throws an UnsupportedOperationException when applied, which is used when creating a Props
defaultCreator() - Static method in class akka.actor.Props
The defaultCreator, simply throws an UnsupportedOperationException when applied, which is used when creating a Props
defaultDecider() - Method in class akka.actor.SupervisorStrategy$
When supervisorStrategy is not specified for an actor this Decider is used by default in the supervisor strategy.
defaultDecider() - Static method in class akka.actor.SupervisorStrategy
When supervisorStrategy is not specified for an actor this Decider is used by default in the supervisor strategy.
defaultDeploy() - Method in class akka.actor.Props$
The default Deploy instance which is used when creating a Props
defaultDeploy() - Static method in class akka.actor.Props
The default Deploy instance which is used when creating a Props
defaultDispatcherConfig() - Method in class akka.dispatch.Dispatchers
 
defaultDispatcherId() - Method in class akka.actor.TypedProps$
 
defaultDispatcherId() - Static method in class akka.actor.TypedProps
 
DefaultDispatcherId() - Method in class akka.dispatch.Dispatchers$
The id of the default dispatcher, also the full key of the configuration of the default dispatcher.
DefaultDispatcherId() - Static method in class akka.dispatch.Dispatchers
The id of the default dispatcher, also the full key of the configuration of the default dispatcher.
DefaultFailureDetectorRegistry<A> - Class in akka.remote
A lock-less thread-safe implementation of FailureDetectorRegistry.
DefaultFailureDetectorRegistry(Function0<FailureDetector>) - Constructor for class akka.remote.DefaultFailureDetectorRegistry
 
defaultGlobalDispatcher() - Method in class akka.dispatch.Dispatchers
The one and only default dispatcher.
defaultInstance() - Method in class akka.cluster.protobuf.msg.Address$
 
defaultInstance() - Static method in class akka.cluster.protobuf.msg.Address
 
defaultInstance() - Method in class akka.cluster.protobuf.msg.Empty$
 
defaultInstance() - Static method in class akka.cluster.protobuf.msg.Empty
 
defaultInstance() - Method in class akka.cluster.protobuf.msg.Gossip$
 
defaultInstance() - Static method in class akka.cluster.protobuf.msg.Gossip
 
defaultInstance() - Method in class akka.cluster.protobuf.msg.GossipEnvelope$
 
defaultInstance() - Static method in class akka.cluster.protobuf.msg.GossipEnvelope
 
defaultInstance() - Method in class akka.cluster.protobuf.msg.GossipOverview$
 
defaultInstance() - Static method in class akka.cluster.protobuf.msg.GossipOverview
 
defaultInstance() - Method in class akka.cluster.protobuf.msg.GossipOverview.Seen$
 
defaultInstance() - Method in class akka.cluster.protobuf.msg.GossipStatus$
 
defaultInstance() - Static method in class akka.cluster.protobuf.msg.GossipStatus
 
defaultInstance() - Method in class akka.cluster.protobuf.msg.Join$
 
defaultInstance() - Static method in class akka.cluster.protobuf.msg.Join
 
defaultInstance() - Method in class akka.cluster.protobuf.msg.Member$
 
defaultInstance() - Static method in class akka.cluster.protobuf.msg.Member
 
defaultInstance() - Method in class akka.cluster.protobuf.msg.MetricsGossip$
 
defaultInstance() - Static method in class akka.cluster.protobuf.msg.MetricsGossip
 
defaultInstance() - Method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope$
 
defaultInstance() - Static method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope
 
defaultInstance() - Method in class akka.cluster.protobuf.msg.NodeMetrics$
 
defaultInstance() - Static method in class akka.cluster.protobuf.msg.NodeMetrics
 
defaultInstance() - Method in class akka.cluster.protobuf.msg.NodeMetrics.EWMA$
 
defaultInstance() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Metric$
 
defaultInstance() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number$
 
defaultInstance() - Method in class akka.cluster.protobuf.msg.UniqueAddress$
 
defaultInstance() - Static method in class akka.cluster.protobuf.msg.UniqueAddress
 
defaultInstance() - Method in class akka.cluster.protobuf.msg.VectorClock$
 
defaultInstance() - Static method in class akka.cluster.protobuf.msg.VectorClock
 
defaultInstance() - Method in class akka.cluster.protobuf.msg.VectorClock.Version$
 
defaultInstance() - Method in class akka.cluster.protobuf.msg.Welcome$
 
defaultInstance() - Static method in class akka.cluster.protobuf.msg.Welcome
 
defaultLoader() - Method in class akka.actor.TypedProps$
 
defaultLoader() - Static method in class akka.actor.TypedProps
 
DefaultMailboxId() - Method in class akka.dispatch.Mailboxes$
 
defaultMaxPoolSize() - Method in class akka.dispatch.ThreadPoolConfig$
 
defaultMaxPoolSize() - Static method in class akka.dispatch.ThreadPoolConfig
 
DefaultOSGiLogger - Class in akka.osgi
Logger for OSGi environment.
DefaultOSGiLogger() - Constructor for class akka.osgi.DefaultOSGiLogger
 
DefaultPollTimeout() - Method in class akka.zeromq.ZeroMQExtension
 
defaultProps(Set<ActorSelection>) - Method in class akka.contrib.pattern.ClusterClient$
Java API: Factory method for ClusterClient Props with default values.
defaultProps(Set<ActorSelection>) - Static method in class akka.contrib.pattern.ClusterClient
Java API: Factory method for ClusterClient Props with default values.
defaultProps(String, Object, String, ClusterSingletonPropsFactory) - Method in class akka.contrib.pattern.ClusterSingletonManager$
Java API: Factory method for ClusterSingletonManager Props with default values.
defaultProps(String, Object, String, ClusterSingletonPropsFactory) - Static method in class akka.contrib.pattern.ClusterSingletonManager
Java API: Factory method for ClusterSingletonManager Props with default values.
defaultProps(String) - Method in class akka.contrib.pattern.DistributedPubSubMediator$
Java API: Factory method for DistributedPubSubMediator Props with default values.
defaultProps(String) - Static method in class akka.contrib.pattern.DistributedPubSubMediator
Java API: Factory method for DistributedPubSubMediator Props with default values.
defaultRejectionPolicy() - Method in class akka.dispatch.ThreadPoolConfig$
 
defaultRejectionPolicy() - Static method in class akka.dispatch.ThreadPoolConfig
 
DefaultResizer - Class in akka.routing
Creates a new DefaultResizer from the given configuration
DefaultResizer(int, int, int, double, double, double, FiniteDuration, int) - Constructor for class akka.routing.DefaultResizer
 
DefaultResizer(int, int) - Constructor for class akka.routing.DefaultResizer
Java API constructor for default values except bounds.
DefaultResizer$ - Class in akka.routing
 
DefaultResizer$() - Constructor for class akka.routing.DefaultResizer$
 
DefaultReturnTimeout() - Method in class akka.actor.TypedActorExtension
Default timeout for typed actor methods with non-void return type
defaultRoutedProps() - Method in class akka.actor.Props$
The defaultRoutedProps is NoRouter which is used when creating a Props
defaultRoutedProps() - Static method in class akka.actor.Props
The defaultRoutedProps is NoRouter which is used when creating a Props
DefaultScheduler - Class in akka.actor
A scheduler implementation based on a HashedWheelTimer.
DefaultScheduler(com.typesafe.config.Config, LoggingAdapter, ThreadFactory) - Constructor for class akka.actor.DefaultScheduler
 
defaultStartAndStopDuration() - Method in class akka.testkit.Coroner$
 
defaultStartAndStopDuration() - Static method in class akka.testkit.Coroner
 
defaultStrategy() - Method in class akka.actor.SupervisorStrategy$
When supervisorStrategy is not specified for an actor this is used by default.
defaultStrategy() - Static method in class akka.actor.SupervisorStrategy
When supervisorStrategy is not specified for an actor this is used by default.
DefaultSupervisorStrategy - Class in akka.actor
 
DefaultSupervisorStrategy() - Constructor for class akka.actor.DefaultSupervisorStrategy
 
defaultSupervisorStrategy() - Method in interface akka.routing.Router
 
defaultTimeout() - Method in class akka.actor.TypedProps$
 
defaultTimeout() - Static method in class akka.actor.TypedProps
 
defaultTimeout() - Method in class akka.dispatch.ThreadPoolConfig$
 
defaultTimeout() - Static method in class akka.dispatch.ThreadPoolConfig
 
DefaultTimeout - Interface in akka.testkit
 
DefaultTimeout() - Method in class akka.testkit.TestBarrier$
 
DefaultTimeout() - Static method in class akka.testkit.TestBarrier
 
DefaultTimeout() - Method in class akka.testkit.TestKitSettings
 
DefaultTimeout() - Method in class akka.testkit.TestLatch$
 
DefaultTimeout() - Static method in class akka.testkit.TestLatch
 
DefaultVirtualNodesFactor() - Method in class akka.actor.ActorSystem.Settings
 
delayedStop(Scheduler, Iterable<ActorRef>, FiniteDuration) - Method in class akka.routing.RouteeProvider
Give concurrent messages a chance to be placed in mailbox before sending PoisonPill.
delete(String) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
DelimiterFraming - Class in akka.io
Pipeline stage for delimiter byte based framing and de-framing.
DelimiterFraming(int, ByteString, boolean) - Constructor for class akka.io.DelimiterFraming
 
DelimiterFraming$ - Class in akka.io
 
DelimiterFraming$() - Constructor for class akka.io.DelimiterFraming$
 
Deploy - Class in akka.actor
This class represents deployment configuration for a given actor path.
Deploy(String, com.typesafe.config.Config, RouterConfig, Scope, String, String) - Constructor for class akka.actor.Deploy
 
Deploy(RouterConfig) - Constructor for class akka.actor.Deploy
Java API to create a Deploy with the given RouterConfig
Deploy(RouterConfig, Scope) - Constructor for class akka.actor.Deploy
Java API to create a Deploy with the given RouterConfig with Scope
Deploy(Scope) - Constructor for class akka.actor.Deploy
Java API to create a Deploy with the given Scope
deploy() - Method in class akka.actor.Props
 
deploy() - Method in class akka.actor.TypedProps
 
Deploy$ - Class in akka.actor
 
Deploy$() - Constructor for class akka.actor.Deploy$
 
DEPLOY_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DaemonMsgCreateData
 
DEPLOY_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.PropsData
 
deployer() - Method in interface akka.actor.ActorRefProvider
The Deployer associated with this ActorRefProvider
deployOn(RoleName, String) - Method in class akka.remote.testkit.MultiNodeConfig
 
deployOnAll(String) - Method in class akka.remote.testkit.MultiNodeConfig
 
DequeBasedMessageQueue - Interface in akka.dispatch
 
DequeBasedMessageQueueSemantics - Interface in akka.dispatch
DequeBasedMessageQueue refines QueueBasedMessageQueue to be backed by a java.util.Deque.
dequeue() - Method in class akka.actor.mailbox.filebased.FileBasedMessageQueue
 
dequeue() - Method in class akka.contrib.mailbox.PeekMailbox
 
dequeue() - Method in interface akka.dispatch.BoundedDequeBasedMessageQueue
 
dequeue() - Method in interface akka.dispatch.BoundedQueueBasedMessageQueue
 
dequeue() - Method in interface akka.dispatch.MessageQueue
Try to dequeue the next message from this queue, return null failing that.
dequeue() - Method in class akka.dispatch.NodeMessageQueue
 
dequeue() - Method in interface akka.dispatch.UnboundedDequeBasedMessageQueue
 
dequeue() - Method in interface akka.dispatch.UnboundedQueueBasedMessageQueue
 
dequeue() - Method in class akka.testkit.CallingThreadMailbox
 
deregisterAssociation(Tuple2<Address, Address>) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Removes an association.
descendant(Iterable<String>) - Method in interface akka.actor.ActorPath
Java API: Recursively create a descendant’s path by appending all child names.
descendant(Iterable<String>) - Method in class akka.actor.ActorSystem
Java API: Recursively create a descendant’s path by appending all child names.
deserialize(byte[]) - Method in interface akka.actor.mailbox.DurableMessageSerialization
Deserializes an array of Bytes that were serialized using the DurableMessageSerialization.serialize method, into an Envelope.
deserialize(byte[], int, Option<Class<? extends T>>) - Method in class akka.serialization.Serialization
Deserializes the given array of bytes using the specified serializer id, using the optional type hint to the Serializer and the optional ClassLoader ot load it into.
deserialize(byte[], Class<T>) - Method in class akka.serialization.Serialization
Deserializes the given array of bytes using the specified type to look up what Serializer should be used.
deserializeActorRef(ExtendedActorSystem, WireFormats.ActorRefData) - Method in class akka.remote.serialization.ProtobufSerializer$
Helper to materialize (lookup) an ActorRef from Akka's protobuf representation in the supplied ActorSystem.
deserializeActorRef(ExtendedActorSystem, WireFormats.ActorRefData) - Static method in class akka.remote.serialization.ProtobufSerializer
Helper to materialize (lookup) an ActorRef from Akka's protobuf representation in the supplied ActorSystem.
Deserializer - Interface in akka.zeromq
A base trait for message deserializers
Destination - Class in akka.routing
For every message sent to a router, its route determines a set of destinations, where for each recipient a different sender may be specified; typically the sender should match the sender of the original request, but e.g.
Destination(ActorRef, ActorRef) - Constructor for class akka.routing.Destination
 
Destination$ - Class in akka.routing
 
Destination$() - Constructor for class akka.routing.Destination$
 
destinationsFor(ActorRef, Object) - Method in interface akka.routing.CustomRoute
use akka.japi.Util.immutableSeq to convert a java.lang.Iterable to the return type needed for destinationsFor, or if you just want to return a single Destination, use akka.japi.Util.immutableSingletonSeq
destroy() - Method in class akka.osgi.aries.blueprint.BlueprintActorSystemFactory
 
destroyJournal() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
detach(akka.actor.ActorCell) - Method in class akka.dispatch.MessageDispatcher
Detaches the specified actor instance from this dispatcher
digest(byte[], MessageDigest) - Method in class akka.util.Crypt$
 
digest(byte[], MessageDigest) - Static method in class akka.util.Crypt
 
dilated(Duration) - Method in class akka.testkit.JavaTestKit
 
dilated(ActorSystem) - Method in class akka.testkit.TestDuration
 
dilated(Duration, ActorSystem) - Method in class akka.testkit.TestKit$
Java API: Scale timeouts (durations) during tests with the configured 'akka.test.timefactor'.
dilated(Duration, ActorSystem) - Static method in class akka.testkit.TestKit
Java API: Scale timeouts (durations) during tests with the configured 'akka.test.timefactor'.
DirectBufferSize() - Method in class akka.io.TcpExt.Settings
 
direction() - Method in class akka.remote.transport.ThrottlerTransportAdapter.SetThrottle
 
DIRECTION_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
disassociate() - Method in interface akka.remote.transport.AssociationHandle
Closes the underlying transport link, if needed.
disassociate() - Method in class akka.remote.transport.TestAssociationHandle
 
DISASSOCIATE_QUARANTINED_VALUE - Static variable in enum akka.remote.WireFormats.CommandType
 
DISASSOCIATE_SHUTTING_DOWN_VALUE - Static variable in enum akka.remote.WireFormats.CommandType
 
DISASSOCIATE_VALUE - Static variable in enum akka.remote.WireFormats.CommandType
 
disassociateBehavior() - Method in class akka.remote.transport.TestTransport
The TestTransport.SwitchableLoggedBehavior for the disassociate() method on handles.
DisassociatedEvent - Class in akka.remote
 
DisassociatedEvent(Address, Address, boolean) - Constructor for class akka.remote.DisassociatedEvent
 
DisassociatedEvent$ - Class in akka.remote
 
DisassociatedEvent$() - Constructor for class akka.remote.DisassociatedEvent$
 
discardExpired() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
DiscardOldWhenFull() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
discardOldWhenFull() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
discardOldWhenFull() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
disconnect() - Method in class akka.io.UdpConnectedMessage$
Send this message to a connection actor (which had previously sent the UdpConnected.Connected message) in order to close the socket.
disconnect() - Static method in class akka.io.UdpConnectedMessage
Send this message to a connection actor (which had previously sent the UdpConnected.Connected message) in order to close the socket.
disconnect(RoleName, RoleName) - Method in interface akka.remote.testconductor.Conductor
Tell the remote support to shutdown the connection to the given remote peer.
Disconnect_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.FailType
 
dispatch(akka.actor.ActorCell, Envelope) - Method in class akka.dispatch.BalancingDispatcher
 
dispatch(akka.actor.ActorCell, Envelope) - Method in class akka.dispatch.Dispatcher
INTERNAL API
dispatch(akka.actor.ActorCell, Envelope) - Method in class akka.dispatch.MessageDispatcher
Will be called when the dispatcher is to queue an invocation for execution
dispatch(akka.actor.ActorCell, Envelope) - Method in class akka.testkit.CallingThreadDispatcher
 
dispatcher() - Method in interface akka.actor.ActorContext
Returns the dispatcher (MessageDispatcher) that is used for this Actor.
dispatcher() - Method in interface akka.actor.ActorRefFactory
Returns the default MessageDispatcher associated with this ActorRefFactory
dispatcher() - Method in class akka.actor.ActorSystem
Default dispatcher as configured.
dispatcher() - Method in class akka.actor.Deploy
 
dispatcher() - Method in class akka.actor.Props
Convenience method for extracting the dispatcher information from the contained Deploy instance.
dispatcher() - Method in class akka.actor.TypedActor$
Returns the default dispatcher (for a TypedActor) when inside a method call in a TypedActor.
dispatcher() - Static method in class akka.actor.TypedActor
Returns the default dispatcher (for a TypedActor) when inside a method call in a TypedActor.
dispatcher() - Method in class akka.actor.TypedProps
 
dispatcher() - Method in class akka.dispatch.BalancingDispatcherConfigurator
Returns the same dispatcher instance for each invocation
Dispatcher - Class in akka.dispatch
The event-based Dispatcher binds a set of Actors to a thread pool backed up by a BlockingQueue.
Dispatcher(MessageDispatcherConfigurator, String, int, Duration, ExecutorServiceFactoryProvider, FiniteDuration) - Constructor for class akka.dispatch.Dispatcher
 
dispatcher() - Method in class akka.dispatch.DispatcherConfigurator
Returns the same dispatcher instance for each invocation
dispatcher() - Method in class akka.dispatch.MessageDispatcherConfigurator
Returns an instance of MessageDispatcher given the configuration.
dispatcher() - Method in class akka.dispatch.PinnedDispatcherConfigurator
Creates new dispatcher for each invocation.
Dispatcher() - Method in class akka.remote.RemoteSettings
 
dispatcher() - Method in class akka.testkit.CallingThreadDispatcherConfigurator
 
dispatcher() - Method in class akka.testkit.TestActorRef
 
DISPATCHER_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DeployData
 
DispatcherConfigurator - Class in akka.dispatch
Configurator for creating Dispatcher.
DispatcherConfigurator(com.typesafe.config.Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.DispatcherConfigurator
 
DispatcherPrerequisites - Interface in akka.dispatch
DispatcherPrerequisites represents useful contextual pieces when constructing a MessageDispatcher
dispatchers() - Method in class akka.actor.ActorSystem
Helper object for looking up configured dispatchers.
Dispatchers - Class in akka.dispatch
Dispatchers are to be defined in configuration to allow for tuning for different environments.
Dispatchers(ActorSystem.Settings, DispatcherPrerequisites) - Constructor for class akka.dispatch.Dispatchers
 
Dispatchers$ - Class in akka.dispatch
 
Dispatchers$() - Constructor for class akka.dispatch.Dispatchers$
 
displayThreadCounts() - Method in interface akka.testkit.WatchedByCoroner
 
dissociate(ActorRef) - Method in interface akka.event.ActorClassification
 
dissociate(ActorRef, ActorRef) - Method in interface akka.event.ActorClassification
 
DistributedPubSubExtension - Class in akka.contrib.pattern
 
DistributedPubSubExtension(ExtendedActorSystem) - Constructor for class akka.contrib.pattern.DistributedPubSubExtension
 
DistributedPubSubExtension$ - Class in akka.contrib.pattern
Extension that starts a DistributedPubSubMediator actor with settings defined in config section akka.contrib.cluster.pub-sub.
DistributedPubSubExtension$() - Constructor for class akka.contrib.pattern.DistributedPubSubExtension$
 
DistributedPubSubMediator - Class in akka.contrib.pattern
This actor manages a registry of actor references and replicates the entries to peer actors among all cluster nodes or a group of nodes tagged with a specific role.
DistributedPubSubMediator(Option<String>, FiniteDuration, FiniteDuration) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator
 
DistributedPubSubMediator$ - Class in akka.contrib.pattern
 
DistributedPubSubMediator$() - Constructor for class akka.contrib.pattern.DistributedPubSubMediator$
 
DistributedPubSubMediator.Count$ - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Count$() - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Count$
 
DistributedPubSubMediator.Publish - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Publish(String, Object) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Publish
 
DistributedPubSubMediator.Publish$ - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Publish$() - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Publish$
 
DistributedPubSubMediator.Put - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Put(ActorRef) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Put
 
DistributedPubSubMediator.Put$ - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Put$() - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Put$
 
DistributedPubSubMediator.Remove - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Remove(String) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Remove
 
DistributedPubSubMediator.Remove$ - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Remove$() - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Remove$
 
DistributedPubSubMediator.Send - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Send(String, Object, boolean) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Send
 
DistributedPubSubMediator.Send$ - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Send$() - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Send$
 
DistributedPubSubMediator.SendToAll - Class in akka.contrib.pattern
 
DistributedPubSubMediator.SendToAll(String, Object, boolean) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.SendToAll
 
DistributedPubSubMediator.SendToAll(String, Object) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.SendToAll
 
DistributedPubSubMediator.SendToAll$ - Class in akka.contrib.pattern
 
DistributedPubSubMediator.SendToAll$() - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.SendToAll$
 
DistributedPubSubMediator.Subscribe - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Subscribe(String, ActorRef) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Subscribe
 
DistributedPubSubMediator.Subscribe$ - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Subscribe$() - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Subscribe$
 
DistributedPubSubMediator.SubscribeAck - Class in akka.contrib.pattern
 
DistributedPubSubMediator.SubscribeAck(DistributedPubSubMediator.Subscribe) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.SubscribeAck
 
DistributedPubSubMediator.SubscribeAck$ - Class in akka.contrib.pattern
 
DistributedPubSubMediator.SubscribeAck$() - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.SubscribeAck$
 
DistributedPubSubMediator.Unsubscribe - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Unsubscribe(String, ActorRef) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Unsubscribe
 
DistributedPubSubMediator.Unsubscribe$ - Class in akka.contrib.pattern
 
DistributedPubSubMediator.Unsubscribe$() - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.Unsubscribe$
 
DistributedPubSubMediator.UnsubscribeAck - Class in akka.contrib.pattern
 
DistributedPubSubMediator.UnsubscribeAck(DistributedPubSubMediator.Unsubscribe) - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.UnsubscribeAck
 
DistributedPubSubMediator.UnsubscribeAck$ - Class in akka.contrib.pattern
 
DistributedPubSubMediator.UnsubscribeAck$() - Constructor for class akka.contrib.pattern.DistributedPubSubMediator.UnsubscribeAck$
 
doMatch(String, Object) - Method in class akka.testkit.EventFilter
internal implementation helper, no guaranteed API
DONE_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
doNothing() - Method in class akka.dispatch.MonitorableThreadFactory$
 
doNothing() - Static method in class akka.dispatch.MonitorableThreadFactory
 
doNothing() - Method in interface akka.transactor.Transactor
Default catch-all for the different Receive methods.
Double() - Method in class akka.cluster.protobuf.msg.NodeMetrics.NumberType$
 
Double_VALUE() - Method in class akka.cluster.protobuf.msg.NodeMetrics.NumberType$
 
down(Address) - Method in class akka.cluster.Cluster
Send command to DOWN the node specified by 'address'.
down(String) - Method in interface akka.cluster.ClusterNodeMBean
Send command to DOWN the node specified by 'address'.
down() - Method in class akka.cluster.MemberStatus$
Java API: retrieve the “down” status singleton
down() - Static method in class akka.cluster.MemberStatus
Java API: retrieve the “down” status singleton
Down() - Method in class akka.cluster.protobuf.msg.MemberStatus$
 
Down() - Static method in class akka.cluster.protobuf.msg.MemberStatus
 
Down_VALUE() - Method in class akka.cluster.protobuf.msg.MemberStatus$
 
Down_VALUE() - Static method in class akka.cluster.protobuf.msg.MemberStatus
 
drainTo(Collection<? super E>) - Method in class akka.util.BoundedBlockingQueue
 
drainTo(Collection<? super E>, int) - Method in class akka.util.BoundedBlockingQueue
 
drop(int) - Method in class akka.actor.IO$
An Iteratee that ignores the specified number of bytes.
drop(int) - Static method in class akka.actor.IO
An Iteratee that ignores the specified number of bytes.
drop(int) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
drop(int) - Method in class akka.util.ByteIterator
 
drop(int) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
drop(int) - Method in class akka.util.ByteString
 
dropRight(int) - Method in class akka.util.ByteString
 
dropWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
dropWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator
 
dropWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
dropWhile(Function1<Object, Object>) - Method in class akka.util.ByteString
 
DSLDefaultTimeout() - Method in class akka.actor.ActorDSL.Extension
 
DSLInboxQueueSize() - Method in interface akka.actor.dsl.Inbox.InboxExtension
 
DummyClassForStringSources - Class in akka.event
This is a “marker” class which is inserted as originator class into Logging.LogEvent when the string representation was supplied directly.
DummyClassForStringSources() - Constructor for class akka.event.DummyClassForStringSources
 
dumpConfig() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
dumpConfig(String) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
dumpItem(JournalItem) - Method in class akka.actor.mailbox.filebased.filequeue.tools.QueueDumper
 
dumpStats() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
duplicate() - Method in class akka.util.ByteIterator
 
DurableMailboxSettings - Interface in akka.actor.mailbox
Conventional organization of durable mailbox settings:
DurableMailboxSpec - Class in akka.actor.mailbox
Reusable test fixture for durable mailboxes.
DurableMailboxSpec(ActorSystem, String) - Constructor for class akka.actor.mailbox.DurableMailboxSpec
 
DurableMailboxSpec(String, String) - Constructor for class akka.actor.mailbox.DurableMailboxSpec
Subclass must define dispatcher in the supplied config for the specific backend.
DurableMailboxSpec$ - Class in akka.actor.mailbox
 
DurableMailboxSpec$() - Constructor for class akka.actor.mailbox.DurableMailboxSpec$
 
DurableMailboxSpecActorFactory - Class in akka.actor.mailbox
 
DurableMailboxSpecActorFactory() - Constructor for class akka.actor.mailbox.DurableMailboxSpecActorFactory
 
DurableMailboxSpecActorFactory$ - Class in akka.actor.mailbox
 
DurableMailboxSpecActorFactory$() - Constructor for class akka.actor.mailbox.DurableMailboxSpecActorFactory$
 
DurableMailboxSpecActorFactory.AccumulatorActor - Class in akka.actor.mailbox
 
DurableMailboxSpecActorFactory.AccumulatorActor() - Constructor for class akka.actor.mailbox.DurableMailboxSpecActorFactory.AccumulatorActor
 
DurableMailboxSpecActorFactory.MailboxTestActor - Class in akka.actor.mailbox
 
DurableMailboxSpecActorFactory.MailboxTestActor() - Constructor for class akka.actor.mailbox.DurableMailboxSpecActorFactory.MailboxTestActor
 
DurableMessageQueue - Class in akka.actor.mailbox
 
DurableMessageQueue(ActorRef, ExtendedActorSystem) - Constructor for class akka.actor.mailbox.DurableMessageQueue
 
DurableMessageQueueWithSerialization - Class in akka.actor.mailbox
Java API DurableMessageQueue with functionality to serialize and deserialize Envelopes (messages)
DurableMessageQueueWithSerialization(ActorRef, ExtendedActorSystem) - Constructor for class akka.actor.mailbox.DurableMessageQueueWithSerialization
 
DurableMessageSerialization - Interface in akka.actor.mailbox
DurableMessageSerialization can be mixed into a DurableMessageQueue and adds functionality to serialize and deserialize Envelopes (messages)
duration() - Method in class akka.contrib.throttle.Throttler.Rate
 
duration(String) - Static method in class akka.testkit.JavaTestKit
 
duration() - Method in class akka.util.Timeout
 
duration() - Method in class akka.zeromq.PollTimeoutDuration
 
durationInMillis() - Method in class akka.contrib.throttle.Throttler.Rate
The duration in milliseconds.
durationToTimeout(FiniteDuration) - Method in class akka.util.Timeout$
 
durationToTimeout(FiniteDuration) - Static method in class akka.util.Timeout
 
DynamicAccess - Class in akka.actor
The DynamicAccess implementation is the class which is used for loading all configurable parts of an actor system (the ReflectiveDynamicAccess is the default implementation).
DynamicAccess() - Constructor for class akka.actor.DynamicAccess
 
dynamicAccess() - Method in class akka.actor.ExtendedActorSystem
ClassLoader wrapper which is used for reflective accesses internally.
dynamicAccess() - Method in interface akka.dispatch.DispatcherPrerequisites
 

E

each(T) - Method in class akka.dispatch.Foreach
This method will be invoked once when/if a Future that this callback is registered on becomes successfully completed
ec() - Method in class akka.remote.transport.AbstractTransportAdapter
 
Effect - Interface in akka.japi
An executable piece of code that takes no parameters and doesn't return any value.
ElementRegex() - Method in class akka.actor.ActorPath$
This Regular Expression is used to validate a path element (Actor Name).
ElementRegex() - Method in interface akka.actor.ActorPath
This Regular Expression is used to validate a path element (Actor Name).
elements() - Method in interface akka.actor.ActorPath
Sequence of names for this path from root to this.
elements() - Method in class akka.actor.ChildActorPath
 
elements() - Method in class akka.actor.RootActorPath
 
empty() - Method in class akka.actor.IO.Chunk$
Represents the empty Chunk
empty() - Method in class akka.actor.IO.IterateeRef.Map
 
empty() - Method in class akka.actor.Props$
A Props instance whose creator will create an actor that doesn't respond to any message
empty() - Static method in class akka.actor.Props
A Props instance whose creator will create an actor that doesn't respond to any message
Empty - Class in akka.cluster.protobuf.msg
 
Empty() - Constructor for class akka.cluster.protobuf.msg.Empty
 
empty() - Method in class akka.contrib.pattern.WorkList$
 
empty() - Static method in class akka.contrib.pattern.WorkList
 
empty() - Method in interface akka.event.ActorClassification
 
empty() - Method in class akka.io.Tcp.Write$
The empty Write doesn't write anything and isn't acknowledged.
empty() - Method in class akka.util.ByteIterator.ByteArrayIterator$
 
empty() - Method in class akka.util.ByteIterator.MultiByteArrayIterator$
 
empty() - Method in class akka.util.ByteString$
 
empty() - Static method in class akka.util.ByteString
 
empty() - Method in class akka.util.CompactByteString$
 
empty() - Static method in class akka.util.CompactByteString
 
empty() - Method in class akka.zeromq.ZMQMessage$
 
empty() - Static method in class akka.zeromq.ZMQMessage
 
Empty$ - Class in akka.cluster.protobuf.msg
 
Empty$() - Constructor for class akka.cluster.protobuf.msg.Empty$
 
emptyActorPath() - Method in class akka.actor.ActorPath$
 
emptyActorPath() - Method in interface akka.actor.ActorPath
 
EnableSsl() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
ENCLOSEDMESSAGE_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.SelectionEnvelope
 
end() - Method in interface akka.testkit.TestKitBase
 
endpoint() - Method in class akka.zeromq.Bind
 
endpoint() - Method in class akka.zeromq.Connect
 
endpoint() - Method in interface akka.zeromq.SocketConnectOption
 
endpointUri() - Method in interface akka.camel.Consumer
Must return the Camel endpoint URI that the consumer wants to consume messages from.
endpointUri() - Method in class akka.camel.javaapi.UntypedConsumerActor
 
endpointUri() - Method in class akka.camel.javaapi.UntypedProducerActor
 
endpointUri() - Method in interface akka.camel.ProducerSupport
Returns the Camel endpoint URI to produce messages to.
engineGenerateSeed(int) - Method in class akka.remote.security.provider.AES128CounterInetRNG
Unused method Returns the given number of seed bytes.
engineGenerateSeed(int) - Method in class akka.remote.security.provider.AES128CounterSecureRNG
Unused method Returns the given number of seed bytes.
engineGenerateSeed(int) - Method in class akka.remote.security.provider.AES256CounterInetRNG
Unused method Returns the given number of seed bytes.
engineGenerateSeed(int) - Method in class akka.remote.security.provider.AES256CounterSecureRNG
Unused method Returns the given number of seed bytes.
engineNextBytes(byte[]) - Method in class akka.remote.security.provider.AES128CounterInetRNG
Generates a user-specified number of random bytes.
engineNextBytes(byte[]) - Method in class akka.remote.security.provider.AES128CounterSecureRNG
Generates a user-specified number of random bytes.
engineNextBytes(byte[]) - Method in class akka.remote.security.provider.AES256CounterInetRNG
Generates a user-specified number of random bytes.
engineNextBytes(byte[]) - Method in class akka.remote.security.provider.AES256CounterSecureRNG
Generates a user-specified number of random bytes.
engineSetSeed(byte[]) - Method in class akka.remote.security.provider.AES128CounterInetRNG
This is managed internally by AESCounterRNG
engineSetSeed(byte[]) - Method in class akka.remote.security.provider.AES128CounterSecureRNG
This is managed internally by AESCounterRNG
engineSetSeed(byte[]) - Method in class akka.remote.security.provider.AES256CounterInetRNG
This is managed internally by AESCounterRNG
engineSetSeed(byte[]) - Method in class akka.remote.security.provider.AES256CounterSecureRNG
This is managed internally by AESCounterRNG
enqueue(ActorRef, Envelope) - Method in class akka.actor.mailbox.filebased.FileBasedMessageQueue
 
enqueue(ByteString) - Method in class akka.actor.WriteBuffer
 
enqueue(ActorRef, Envelope) - Method in interface akka.dispatch.BoundedDequeBasedMessageQueue
 
enqueue(ActorRef, Envelope) - Method in interface akka.dispatch.BoundedQueueBasedMessageQueue
 
enqueue(ActorRef, Envelope) - Method in interface akka.dispatch.MessageQueue
Try to enqueue the message to this queue, or throw an exception.
enqueue(ActorRef, Envelope) - Method in class akka.dispatch.NodeMessageQueue
 
enqueue(ActorRef, Envelope) - Method in interface akka.dispatch.UnboundedDequeBasedMessageQueue
 
enqueue(ActorRef, Envelope) - Method in interface akka.dispatch.UnboundedQueueBasedMessageQueue
 
enqueue(ActorRef, Envelope) - Method in class akka.testkit.CallingThreadMailbox
 
enqueueFirst(ActorRef, Envelope) - Method in interface akka.dispatch.BoundedDequeBasedMessageQueue
 
enqueueFirst(ActorRef, Envelope) - Method in interface akka.dispatch.DequeBasedMessageQueueSemantics
 
enqueueFirst(ActorRef, Envelope) - Method in interface akka.dispatch.UnboundedDequeBasedMessageQueue
 
enqueueMessage(Object) - Method in class akka.actor.dsl.Inbox.InboxActor
 
enqueueQuery(Inbox.Query) - Method in class akka.actor.dsl.Inbox.InboxActor
 
enter(Seq<String>) - Method in interface akka.remote.testconductor.Player
Enter the named barriers, one after the other, in the order given.
enter(Timeout, Seq<String>) - Method in interface akka.remote.testconductor.Player
Enter the named barriers, one after the other, in the order given.
Enter_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
 
enterBarrier(Seq<String>) - Method in class akka.remote.testkit.MultiNodeSpec
Enter the named barriers in the order given.
Envelope - Class in akka.dispatch
 
Envelope$ - Class in akka.dispatch
 
Envelope$() - Constructor for class akka.dispatch.Envelope$
 
ENVELOPE_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
EnvHome() - Method in class akka.actor.ActorSystem$
 
EnvHome() - Static method in class akka.actor.ActorSystem
 
equals(Object) - Method in class akka.actor.ActorRef
Equals takes path and the unique id of the actor cell into account.
equals(Object) - Method in class akka.actor.ActorSelection
 
equals(Object) - Method in class akka.actor.ChildActorPath
 
equals(Object) - Method in interface akka.actor.ExtensionId
 
equals(Object) - Method in class akka.cluster.Member
 
equals(Object) - Method in class akka.cluster.Metric
 
equals(Object) - Method in class akka.cluster.NodeMetrics
 
erase() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
error(Logging.Error) - Method in interface akka.event.Logging.StdOutLogger
 
error(Throwable, String) - Method in interface akka.event.LoggingAdapter
Log message at error level, including the exception that caused the error.
error(Throwable, String, Object) - Method in interface akka.event.LoggingAdapter
Message template with 1 replacement argument.
error(Throwable, String, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 2 replacement arguments.
error(Throwable, String, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 3 replacement arguments.
error(Throwable, String, Object, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 4 replacement arguments.
error(String) - Method in interface akka.event.LoggingAdapter
Log message at error level, without providing the exception that caused the error.
error(String, Object) - Method in interface akka.event.LoggingAdapter
Message template with 1 replacement argument.
error(String, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 2 replacement arguments.
error(String, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 3 replacement arguments.
error(String, Object, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 4 replacement arguments.
error(String, String, String, String, int) - Method in class akka.testkit.EventFilter$
Create a filter for Error events which do not have a cause set (i.e.
error(String, String, String, String, int) - Static method in class akka.testkit.EventFilter
Create a filter for Error events which do not have a cause set (i.e.
ErrorFilter - Class in akka.testkit
Filter which matches Error events, if they satisfy the given criteria: throwable applies an upper bound on the type of exception contained in the Error event source, if given, applies a filter on the event’s origin message applies a filter on the event’s message (either with String.startsWith or Regex.findFirstIn().isDefined); if the message itself does not match, the match is retried with the contained Exception’s message; if both are null, the filter always matches if at the same time the Exception’s stack trace is empty (this catches JVM-omitted “fast-throw” exceptions) If you want to match all Error events, the most efficient is to use Left("").
ErrorFilter(Class<?>, Option<String>, Either<String, Regex>, boolean, int) - Constructor for class akka.testkit.ErrorFilter
 
ErrorFilter(Class<?>, String, String, boolean, boolean, int) - Constructor for class akka.testkit.ErrorFilter
Java API: create an ErrorFilter
ErrorFilter(Class<?>) - Constructor for class akka.testkit.ErrorFilter
Java API: filter only on the given type of exception
ErrorFilter$ - Class in akka.testkit
 
ErrorFilter$() - Constructor for class akka.testkit.ErrorFilter$
 
errorFormat() - Method in interface akka.event.Logging.StdOutLogger
 
errorFormatWithoutCause() - Method in interface akka.event.Logging.StdOutLogger
 
ErrorLevel() - Method in class akka.event.Logging$
Log level in numeric form, used when deciding whether a certain log statement should generate a log event.
ErrorLevel() - Static method in class akka.event.Logging
Log level in numeric form, used when deciding whether a certain log statement should generate a log event.
Escalate() - Method in interface akka.actor.dsl.Creators.Act
 
escalate() - Method in class akka.actor.SupervisorStrategy$
Java API: Returning this directive escalates the failure to the supervisor of the supervisor, by rethrowing the cause of the failure, i.e.
escalate() - Static method in class akka.actor.SupervisorStrategy
Java API: Returning this directive escalates the failure to the supervisor of the supervisor, by rethrowing the cause of the failure, i.e.
escalateDefault() - Method in class akka.actor.SupervisorStrategy$
 
escalateDefault() - Static method in class akka.actor.SupervisorStrategy
 
establishing() - Method in class akka.contrib.pattern.ClusterClient
 
event() - Method in class akka.actor.FSM.Event
 
event() - Method in class akka.actor.FSM.LogEntry
 
event() - Method in class akka.event.Logging.LogEventException
 
event() - Method in class akka.io.Tcp.Abort$
The corresponding event which is sent as an acknowledgment once the close operation is finished.
event() - Method in class akka.io.Tcp.Close$
The corresponding event which is sent as an acknowledgment once the close operation is finished.
event() - Method in interface akka.io.Tcp.CloseCommand
The corresponding event which is sent as an acknowledgment once the close operation is finished.
event() - Method in class akka.io.Tcp.ConfirmedClose$
The corresponding event which is sent as an acknowledgment once the close operation is finished.
event(Object) - Method in class akka.io.TcpPipelineHandler.Init
Java API: extract a wrapped event received from the TcpPipelineHandler actor.
EventBus - Interface in akka.event
Represents the base type for EventBuses Internally has an Event type, a Classifier type and a Subscriber type
EventFilter - Class in akka.testkit
Facilities for selectively filtering out expected events from logging so that you can keep your test run’s console output clean and do not miss real error messages.
EventFilter(int) - Constructor for class akka.testkit.EventFilter
 
EventFilter$ - Class in akka.testkit
Facilities for selectively filtering out expected events from logging so that you can keep your test run’s console output clean and do not miss real error messages.
EventFilter$() - Constructor for class akka.testkit.EventFilter$
 
EventHandlers() - Method in class akka.actor.ActorSystem.Settings
 
EventHandlerStartTimeout() - Method in class akka.actor.ActorSystem.Settings
 
eventName() - Method in class akka.remote.AssociatedEvent
 
eventName() - Method in class akka.remote.AssociationErrorEvent
 
eventName() - Method in interface akka.remote.AssociationEvent
 
eventName() - Method in class akka.remote.DisassociatedEvent
 
eventPipeline() - Method in interface akka.io.PipePair
The event pipeline transforms injected event from the lower stage into event for the stage above, but it can also emit commands for the stage below.
events() - Method in interface akka.actor.LoggingFSM
 
events() - Method in class akka.io.PipelinePorts
 
eventStream() - Method in class akka.actor.ActorSystem
Main event bus of this actor system, used for example for logging.
eventStream() - Method in interface akka.dispatch.DispatcherPrerequisites
 
eventStream() - Method in class akka.dispatch.MessageDispatcher
 
eventStream() - Method in class akka.dispatch.TaskInvocation
 
eventStream() - Method in class akka.event.DeadLetterListener
 
EventStream - Class in akka.event
 
EventStream(boolean) - Constructor for class akka.event.EventStream
 
EventStream$ - Class in akka.event
 
EventStream$() - Constructor for class akka.event.EventStream$
 
evt() - Method in interface akka.io.PipelineContext
INTERNAL API: do not touch!
evt() - Method in class akka.io.TcpPipelineHandler.Init.Event
 
evt() - Method in class akka.io.TcpPipelineHandler.TcpEvent
 
evtHolder() - Method in interface akka.io.PipelineContext
INTERNAL API: do not touch!
ewma() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Metric
 
EWMA_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Metric$
 
exceptionHandler() - Method in class akka.dispatch.MonitorableThreadFactory
 
exec() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinTask
 
exec() - Method in class akka.testkit.JavaTestKit.EventFilter
 
execute(Runnable) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
execute(Runnable) - Method in class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinPool
 
executeTask(TaskInvocation) - Method in class akka.dispatch.Dispatcher
INTERNAL API
executeTask(TaskInvocation) - Method in class akka.dispatch.MessageDispatcher
INTERNAL API
executeTask(TaskInvocation) - Method in class akka.testkit.CallingThreadDispatcher
 
executionContext() - Method in class akka.remote.transport.netty.NettyTransport
 
ExecutionContexts - Class in akka.dispatch
ExecutionContexts is the Java API for ExecutionContexts
ExecutionContexts() - Constructor for class akka.dispatch.ExecutionContexts
 
ExecutionContexts$ - Class in akka.dispatch
ExecutionContexts is the Java API for ExecutionContexts
ExecutionContexts$() - Constructor for class akka.dispatch.ExecutionContexts$
 
executor() - Method in interface akka.dispatch.ExecutorServiceDelegate
 
executorService() - Method in class akka.dispatch.Dispatcher
 
ExecutorServiceConfigurator - Class in akka.dispatch
An ExecutorServiceConfigurator is a class that given some prerequisites and a configuration can create instances of ExecutorService
ExecutorServiceConfigurator(com.typesafe.config.Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.ExecutorServiceConfigurator
 
ExecutorServiceDelegate - Interface in akka.dispatch
As the name says
ExecutorServiceFactory - Interface in akka.dispatch
Function0 without the fun stuff (mostly for the sake of the Java API side of things)
ExecutorServiceFactoryProvider - Interface in akka.dispatch
Generic way to specify an ExecutorService to a Dispatcher, create it with the given name if desired
existenceConfirmed() - Method in class akka.actor.Terminated
 
existsAssociation(Address, Address) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Tests if an association was registered.
exit(RoleName, int) - Method in interface akka.remote.testconductor.Conductor
Tell the remote node to shut itself down using System.exit with the given exitValue.
Exit_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.FailType
 
exiting() - Method in class akka.cluster.MemberStatus$
Java API: retrieve the “exiting” status singleton
exiting() - Static method in class akka.cluster.MemberStatus
Java API: retrieve the “exiting” status singleton
Exiting() - Method in class akka.cluster.protobuf.msg.MemberStatus$
 
Exiting() - Static method in class akka.cluster.protobuf.msg.MemberStatus
 
Exiting_VALUE() - Method in class akka.cluster.protobuf.msg.MemberStatus$
 
Exiting_VALUE() - Static method in class akka.cluster.protobuf.msg.MemberStatus
 
EXITVALUE_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
expect(PartialFunction<Object, BoxedUnit>) - Method in interface akka.contrib.pattern.Aggregator
Adds the partial function to the receive set and keeping it in the receive set till removed.
expectedTestDuration() - Method in class akka.testkit.AkkaSpec
 
expectedTestDuration() - Method in interface akka.testkit.WatchedByCoroner
 
expectList() - Method in interface akka.contrib.pattern.Aggregator
 
expectMsg(T) - Method in interface akka.testkit.TestKitBase
Same as expectMsg(remaining, obj), but correctly treating the timeFactor.
expectMsg(FiniteDuration, T) - Method in interface akka.testkit.TestKitBase
Receive one message from the test actor and assert that it equals the given object.
expectMsg_internal(Duration, T) - Method in interface akka.testkit.TestKitBase
 
expectMsgAllClassOf(Seq<Class<? extends T>>) - Method in interface akka.testkit.TestKitBase
Same as expectMsgAllClassOf(remaining, obj...), but correctly treating the timeFactor.
expectMsgAllClassOf(FiniteDuration, Seq<Class<? extends T>>) - Method in interface akka.testkit.TestKitBase
Receive a number of messages from the test actor matching the given number of classes and assert that for each given class one is received which is of that class (equality, not conformance).
expectMsgAllConformingOf(Seq<Class<? extends T>>) - Method in interface akka.testkit.TestKitBase
Same as expectMsgAllConformingOf(remaining, obj...), but correctly treating the timeFactor.
expectMsgAllConformingOf(FiniteDuration, Seq<Class<? extends T>>) - Method in interface akka.testkit.TestKitBase
Receive a number of messages from the test actor matching the given number of classes and assert that for each given class one is received which conforms to that class (and vice versa).
expectMsgAllOf(Object...) - Method in class akka.testkit.JavaTestKit
Same as expectMsgAllOf(remaining(), obj...), but correctly treating the timeFactor.
expectMsgAllOf(FiniteDuration, Object...) - Method in class akka.testkit.JavaTestKit
Receive a number of messages from the test actor matching the given number of objects and assert that for each given object one is received which equals it and vice versa.
expectMsgAllOf(Seq<T>) - Method in interface akka.testkit.TestKitBase
Same as expectMsgAllOf(remaining, obj...), but correctly treating the timeFactor.
expectMsgAllOf(FiniteDuration, Seq<T>) - Method in interface akka.testkit.TestKitBase
Receive a number of messages from the test actor matching the given number of objects and assert that for each given object one is received which equals it and vice versa.
expectMsgAllOf_internal(FiniteDuration, Seq<T>) - Method in interface akka.testkit.TestKitBase
 
expectMsgAnyClassOf(Class<? extends T>...) - Method in class akka.testkit.JavaTestKit
Same as expectMsgAnyClassOf(remaining(), obj...), but correctly treating the timeFactor.
expectMsgAnyClassOf(FiniteDuration, Class<?>...) - Method in class akka.testkit.JavaTestKit
Receive one message from the test actor and assert that it conforms to one of the given classes.
expectMsgAnyClassOf(Seq<Class<? extends C>>) - Method in interface akka.testkit.TestKitBase
Same as expectMsgAnyClassOf(remaining, obj...), but correctly treating the timeFactor.
expectMsgAnyClassOf(FiniteDuration, Seq<Class<? extends C>>) - Method in interface akka.testkit.TestKitBase
Receive one message from the test actor and assert that it conforms to one of the given classes.
expectMsgAnyClassOf_internal(FiniteDuration, Seq<Class<? extends C>>) - Method in interface akka.testkit.TestKitBase
 
expectMsgAnyOf(Object...) - Method in class akka.testkit.JavaTestKit
Same as expectMsgAnyOf(remaining(), obj...), but correctly treating the timeFactor.
expectMsgAnyOf(FiniteDuration, Object...) - Method in class akka.testkit.JavaTestKit
Receive one message from the test actor and assert that it equals one of the given objects.
expectMsgAnyOf(Seq<T>) - Method in interface akka.testkit.TestKitBase
Same as expectMsgAnyOf(remaining, obj...), but correctly treating the timeFactor.
expectMsgAnyOf(FiniteDuration, Seq<T>) - Method in interface akka.testkit.TestKitBase
Receive one message from the test actor and assert that it equals one of the given objects.
expectMsgAnyOf_internal(FiniteDuration, Seq<T>) - Method in interface akka.testkit.TestKitBase
 
expectMsgClass(Class<T>) - Method in class akka.testkit.JavaTestKit
Same as expectMsgClass(remaining(), clazz), but correctly treating the timeFactor.
expectMsgClass(FiniteDuration, Class<T>) - Method in class akka.testkit.JavaTestKit
Receive one message from the test actor and assert that it conforms to the given class.
expectMsgClass(Class<C>) - Method in interface akka.testkit.TestKitBase
Same as expectMsgClass(remaining, c), but correctly treating the timeFactor.
expectMsgClass(FiniteDuration, Class<C>) - Method in interface akka.testkit.TestKitBase
Receive one message from the test actor and assert that it conforms to the given class.
expectMsgClass_internal(FiniteDuration, Class<C>) - Method in interface akka.testkit.TestKitBase
 
expectMsgEquals(T) - Method in class akka.testkit.JavaTestKit
Same as expectMsgEquals(remaining(), obj), but correctly treating the timeFactor.
expectMsgEquals(FiniteDuration, T) - Method in class akka.testkit.JavaTestKit
Receive one message from the test actor and assert that it equals the given object.
expectMsgPF(Duration, String, PartialFunction<Object, T>) - Method in interface akka.testkit.TestKitBase
Receive one message from the test actor and assert that the given partial function accepts it.
expectMsgType(ClassTag<T>) - Method in interface akka.testkit.TestKitBase
Same as expectMsgType[T](remaining), but correctly treating the timeFactor.
expectMsgType(FiniteDuration, ClassTag<T>) - Method in interface akka.testkit.TestKitBase
Receive one message from the test actor and assert that it conforms to the given type (after erasure).
expectNoMsg() - Method in class akka.testkit.JavaTestKit
Same as expectNoMsg(remaining()), but correctly treating the timeFactor.
expectNoMsg(FiniteDuration) - Method in class akka.testkit.JavaTestKit
Assert that no message is received for the specified time.
expectNoMsg() - Method in interface akka.testkit.TestKitBase
Same as expectNoMsg(remaining), but correctly treating the timeFactor.
expectNoMsg(FiniteDuration) - Method in interface akka.testkit.TestKitBase
Assert that no message is received for the specified time.
expectNoMsg_internal(FiniteDuration) - Method in interface akka.testkit.TestKitBase
 
expectOnce(PartialFunction<Object, BoxedUnit>) - Method in interface akka.contrib.pattern.Aggregator
Adds the partial function to the receive set, to be removed on first match.
expectTerminated(Duration, ActorRef) - Method in class akka.testkit.JavaTestKit
Assert that the given ActorRef is Terminated within the specified time.
expectTerminated(ActorRef) - Method in class akka.testkit.JavaTestKit
Same as expectTerminated(remaining(), target), but correctly treating the timeFactor.
expectTerminated(ActorRef, Duration) - Method in interface akka.testkit.TestKitBase
Receive one message from the test actor and assert that it is the Terminated message of the given ActorRef.
expiredQueue() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
expiredQueue() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
expiry() - Method in class akka.actor.mailbox.filebased.filequeue.QItem
 
ExtendedActorSystem - Class in akka.actor
More powerful interface to the actor system’s implementation which is presented to extensions (see Extension).
ExtendedActorSystem() - Constructor for class akka.actor.ExtendedActorSystem
 
extendHash(int, int, int, int) - Method in class akka.routing.MurmurHash$
Incorporates a new value into an existing hash.
extendHash(int, int, int, int) - Static method in class akka.routing.MurmurHash
Incorporates a new value into an existing hash.
extension(ExtensionId<T>) - Method in class akka.actor.ActorSystem
Returns the payload that is associated with the provided extension throws an IllegalStateException if it is not registered.
Extension - Interface in akka.actor
The basic ActorSystem covers all that is needed for locally running actors, using futures and so on.
ExtensionId<T extends Extension> - Interface in akka.actor
Identifies an Extension Lookup of Extensions is done by object identity, so the Id must be the same wherever it's used, otherwise you'll get the same extension loaded multiple times.
ExtensionIdProvider - Interface in akka.actor
To be able to load an ExtensionId from the configuration, a class that implements ExtensionIdProvider must be specified.
ExtensionKey<T extends Extension> - Class in akka.actor
This is a one-stop-shop if all you want is an extension which is constructed with the ExtendedActorSystem as its only constructor argument:
ExtensionKey(ClassTag<T>) - Constructor for class akka.actor.ExtensionKey
 
ExtensionKey(Class<T>) - Constructor for class akka.actor.ExtensionKey
 
extractCpu(NodeMetrics) - Method in class akka.cluster.StandardMetrics$
Java API to extract Cpu data from nodeMetrics, if the nodeMetrics contains necessary cpu metrics, otherwise it returns null.
extractCpu(NodeMetrics) - Static method in class akka.cluster.StandardMetrics
Java API to extract Cpu data from nodeMetrics, if the nodeMetrics contains necessary cpu metrics, otherwise it returns null.
extractDeliverable() - Method in class akka.remote.AckedReceiveBuffer
Extract all messages that could be safely delivered, an updated ack to be sent to the sender, and an updated buffer that has the messages removed that can be delivered.
extractHeapMemory(NodeMetrics) - Method in class akka.cluster.StandardMetrics$
Java API to extract HeapMemory data from nodeMetrics, if the nodeMetrics contains necessary heap metrics, otherwise it returns null.
extractHeapMemory(NodeMetrics) - Static method in class akka.cluster.StandardMetrics
Java API to extract HeapMemory data from nodeMetrics, if the nodeMetrics contains necessary heap metrics, otherwise it returns null.
extractInterfaces(Class<?>) - Method in class akka.actor.TypedProps$
 
extractInterfaces(Class<?>) - Static method in class akka.actor.TypedProps
 
ExtractRoute - Class in akka.testkit
This object can be used to extract the Route out of a RoutedActorRef.
ExtractRoute() - Constructor for class akka.testkit.ExtractRoute
 
ExtractRoute$ - Class in akka.testkit
This object can be used to extract the Route out of a RoutedActorRef.
ExtractRoute$() - Constructor for class akka.testkit.ExtractRoute$
 
extraTime() - Method in interface akka.actor.dsl.Inbox
 

F

f() - Method in class akka.actor.IO.Next
 
f() - Method in class akka.routing.WithListeners
 
Fail_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
 
failed(Throwable) - Method in class akka.dispatch.Futures$
creates an already completed Promise with the specified exception
failed(Throwable) - Static method in class akka.dispatch.Futures
creates an already completed Promise with the specified exception
Failed_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
 
FAILURE_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
FAILURE_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
failureDetector() - Method in class akka.cluster.Cluster
 
FailureDetector - Interface in akka.remote
A failure detector must be a thread-safe mutable construct that registers heartbeat events of a resource and is able to decide the availability of that monitored resource.
FailureDetector$ - Class in akka.remote
 
FailureDetector$() - Constructor for class akka.remote.FailureDetector$
 
FailureDetector.Clock - Class in akka.remote
Abstraction of a clock that returns time in milliseconds.
FailureDetector.Clock() - Constructor for class akka.remote.FailureDetector.Clock
 
FailureDetectorConfig() - Method in class akka.cluster.ClusterSettings
 
FailureDetectorImplementationClass() - Method in class akka.cluster.ClusterSettings
 
FailureDetectorRegistry<A> - Interface in akka.remote
Interface for a registry of Akka failure detectors.
FailureInjectorException - Exception in akka.remote.transport
 
FailureInjectorException(String) - Constructor for exception akka.remote.transport.FailureInjectorException
 
FailureInjectorException$ - Class in akka.remote.transport
 
FailureInjectorException$() - Constructor for class akka.remote.transport.FailureInjectorException$
 
FailureInjectorProvider - Class in akka.remote.transport
 
FailureInjectorProvider() - Constructor for class akka.remote.transport.FailureInjectorProvider
 
failureMessage() - Method in interface akka.io.Tcp.Command
 
failureMessage() - Method in interface akka.io.Udp.Command
 
failureMessage() - Method in interface akka.io.UdpConnected.Command
 
fallbackClassLoader() - Method in class akka.osgi.OsgiActorSystemFactory
 
fallbackConfig() - Method in class akka.actor.mailbox.DurableMailboxSpec$
 
fallbackConfig() - Static method in class akka.actor.mailbox.DurableMailboxSpec
 
FALSE() - Method in class akka.testkit.TestActor$
 
FALSE() - Static method in class akka.testkit.TestActor
 
FileBasedMailboxSettings - Class in akka.actor.mailbox.filebased
 
FileBasedMailboxSettings(ActorSystem.Settings, com.typesafe.config.Config) - Constructor for class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
FileBasedMailboxType - Class in akka.actor.mailbox.filebased
 
FileBasedMailboxType(ActorSystem.Settings, com.typesafe.config.Config) - Constructor for class akka.actor.mailbox.filebased.FileBasedMailboxType
 
FileBasedMessageQueue - Class in akka.actor.mailbox.filebased
 
FileBasedMessageQueue(ActorRef, ExtendedActorSystem, FileBasedMailboxSettings) - Constructor for class akka.actor.mailbox.filebased.FileBasedMessageQueue
 
FileDescriptor - Class in akka.zeromq
Gets the file descriptor associated with the ZeroMQ socket
FileDescriptor() - Constructor for class akka.zeromq.FileDescriptor
 
fileDescriptor() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its file descriptor configuration.
fileDescriptor() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its file descriptor configuration.
FileDescriptor$ - Class in akka.zeromq
Gets the file descriptor associated with the ZeroMQ socket
FileDescriptor$() - Constructor for class akka.zeromq.FileDescriptor$
 
fileIoDispatcher() - Method in class akka.io.TcpExt
 
FileIODispatcher() - Method in class akka.io.TcpExt.Settings
 
filenames() - Method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper$
 
filenames() - Static method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper
 
filePath() - Method in class akka.io.Tcp.WriteFile
 
fillArray(int, Function2<byte[], Object, BoxedUnit>) - Method in class akka.util.ByteStringBuilder
 
fillByteBuffer(int, ByteOrder, Function1<ByteBuffer, BoxedUnit>) - Method in class akka.util.ByteStringBuilder
 
fillInStackTrace() - Method in interface akka.OnlyCauseStackTrace
 
fillReadBehind(Function1<QItem, BoxedUnit>) - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
Filter - Class in akka.dispatch
Java API (not recommended): Callback for the Future.filter operation that creates a new Future which will conditionally contain the success of another Future.
Filter() - Constructor for class akka.dispatch.Filter
 
filter(int, int) - Method in class akka.routing.DefaultResizer
This method can be used to smooth the capacity delta by considering the current pressure and current capacity.
filter(Logging.LogEvent) - Method in class akka.testkit.TestEventListener
 
Filter$ - Class in akka.dispatch
Java API (not recommended): Callback for the Future.filter operation that creates a new Future which will conditionally contain the success of another Future.
Filter$() - Constructor for class akka.dispatch.Filter$
 
filterOf(Function<T, Boolean>) - Method in class akka.dispatch.Filter$
 
filterOf(Function<T, Boolean>) - Static method in class akka.dispatch.Filter
 
filters() - Method in class akka.testkit.TestEvent.Mute
 
filters() - Method in class akka.testkit.TestEvent.UnMute
 
filters() - Method in class akka.testkit.TestEventListener
 
finalize() - Method in class akka.actor.dsl.Inbox.Inbox
Overridden finalizer which will try to stop the actor once this Inbox is no longer referenced.
finalizeHash(int) - Method in class akka.routing.MurmurHash$
Once all hashes have been incorporated, this performs a final mixing
finalizeHash(int) - Static method in class akka.routing.MurmurHash
Once all hashes have been incorporated, this performs a final mixing
find(Iterable<Future<T>>, Function<T, Boolean>, ExecutionContext) - Method in class akka.dispatch.Futures$
Returns a Future that will hold the optional result of the first Future with a result that matches the predicate
find(Iterable<Future<T>>, Function<T, Boolean>, ExecutionContext) - Static method in class akka.dispatch.Futures
Returns a Future that will hold the optional result of the first Future with a result that matches the predicate
findAvailableId(org.apache.aries.blueprint.ParserContext) - Method in class akka.osgi.aries.blueprint.NamespaceHandler
 
findClass(String) - Method in class akka.osgi.impl.BundleDelegatingClassLoader
 
findResource(String) - Method in class akka.osgi.impl.BundleDelegatingClassLoader
 
findResources(String) - Method in class akka.osgi.impl.BundleDelegatingClassLoader
 
findSerializerFor(Object) - Method in class akka.serialization.Serialization
Returns the Serializer configured for the given object, returns the NullSerializer if it's null.
findValue(K, Function1<V, Object>) - Method in class akka.util.Index
 
FinishConnectRetries() - Method in class akka.io.TcpExt.Settings
 
firstCompletedOf(Iterable<Future<T>>, ExecutionContext) - Method in class akka.dispatch.Futures$
Returns a Future to the result of the first future in the list that is completed
firstCompletedOf(Iterable<Future<T>>, ExecutionContext) - Static method in class akka.dispatch.Futures
Returns a Future to the result of the first future in the list that is completed
firstHeartbeatEstimate() - Method in class akka.remote.PhiAccrualFailureDetector
 
fishForMessage(Duration, String, PartialFunction<Object, Object>) - Method in interface akka.testkit.TestKitBase
Hybrid of expectMsgPF and receiveWhile: receive messages while the partial function matches and returns false.
flatMap(Function1<A, IO.Iteratee<B>>) - Method in class akka.actor.IO.Iteratee
Applies a function to the result of this Iteratee, resulting in a new Iteratee.
flatMap(Function1<A, IO.Iteratee<A>>) - Method in interface akka.actor.IO.IterateeRef
 
flatMap(Function1<A, IO.Iteratee<A>>) - Method in class akka.actor.IO.IterateeRefAsync
 
flatMap(Function1<A, IO.Iteratee<A>>) - Method in class akka.actor.IO.IterateeRefSync
 
flatMap(Function1<T, Agent<B>>) - Method in class akka.agent.Agent
Flatmap this agent to a new agent, applying the function to the internal state.
Float() - Method in class akka.cluster.protobuf.msg.NodeMetrics.NumberType$
 
Float_VALUE() - Method in class akka.cluster.protobuf.msg.NodeMetrics.NumberType$
 
flush() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
flush(String) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
flushAllExpired() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
flushExpired(String) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
FlushWait() - Method in class akka.remote.RemoteSettings
 
fold(B, M, Function2<B, A, IO.Iteratee<B>>) - Method in class akka.actor.IO$
An Iteratee that folds over a Traversable by applying a function that returns an Iteratee.
fold(B, M, Function2<B, A, IO.Iteratee<B>>) - Static method in class akka.actor.IO
An Iteratee that folds over a Traversable by applying a function that returns an Iteratee.
fold(R, Iterable<Future<T>>, Function2<R, T, R>, ExecutionContext) - Method in class akka.dispatch.Futures$
A non-blocking fold over the specified futures, with the start value of the given zero.
fold(R, Iterable<Future<T>>, Function2<R, T, R>, ExecutionContext) - Static method in class akka.dispatch.Futures
A non-blocking fold over the specified futures, with the start value of the given zero.
fold(Function0<T>, Function0<T>) - Method in class akka.util.Switch
Executes the provided callbacks depending on if the switch is either on or off waiting for any pending changes to happen before (locking) Be careful of longrunning or blocking within the provided action as it can lead to deadlocks or bad performance
foldLeft(B, Function2<B, Object, B>) - Method in class akka.util.ByteIterator
 
foreach(Function1<T, U>) - Method in class akka.agent.Agent
Applies the function to the internal state.
Foreach<T> - Class in akka.dispatch
Callback for the Future.foreach operation that will be invoked if the Future that this callback is registered on becomes completed with a success.
Foreach() - Constructor for class akka.dispatch.Foreach
 
foreach(Function1<Object, U>) - Method in class akka.util.ByteIterator
 
foreach(Function1<Object, U>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
foreach(Function1<Object, U>) - Method in class akka.util.ByteString
 
foreach(Function2<K, V, BoxedUnit>) - Method in class akka.util.Index
Applies the supplied function to all keys and their values
ForkJoinExecutorConfigurator - Class in akka.dispatch
 
ForkJoinExecutorConfigurator(com.typesafe.config.Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator
 
ForkJoinExecutorConfigurator$ - Class in akka.dispatch
 
ForkJoinExecutorConfigurator$() - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator$
 
ForkJoinExecutorConfigurator.AkkaForkJoinPool - Class in akka.dispatch
INTERNAL AKKA USAGE ONLY
ForkJoinExecutorConfigurator.AkkaForkJoinPool(int, ForkJoinPool.ForkJoinWorkerThreadFactory, Thread.UncaughtExceptionHandler) - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinPool
 
ForkJoinExecutorConfigurator.AkkaForkJoinTask - Class in akka.dispatch
INTERNAL AKKA USAGE ONLY
ForkJoinExecutorConfigurator.AkkaForkJoinTask(Runnable) - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinTask
 
ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory - Class in akka.dispatch
 
ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory(ForkJoinPool.ForkJoinWorkerThreadFactory, int) - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory
 
format(String, Seq<Object>) - Method in interface akka.event.LoggingAdapter
 
format(TimeUnit, Duration) - Method in interface akka.testkit.TestKitBase
 
format1(String, Object) - Method in interface akka.event.LoggingAdapter
 
formatTimestamp(long) - Method in class akka.event.slf4j.Slf4jLogger
Override this method to provide a differently formatted timestamp
forMax(Duration) - Method in class akka.actor.FSM.State
Modify state transition descriptor to include a state timeout for the next state.
forward(Object, ActorContext) - Method in class akka.actor.ActorRef
Forwards the message and passes the original sender actor as the sender.
forward(ActorRef) - Method in class akka.testkit.JavaTestKit
 
forward(ActorRef, Object) - Method in class akka.testkit.TestProbe
Forward this message as if in the TestActor's receive method with self.forward.
frame(int) - Method in class akka.zeromq.ZMQMessage
 
FrameLengthFieldLength() - Static method in class akka.remote.transport.netty.NettyTransport
 
frames() - Method in class akka.zeromq.Send
 
frames() - Method in class akka.zeromq.ZMQMessage
 
from() - Method in class akka.actor.FSM.Transition
 
from() - Method in class akka.cluster.protobuf.msg.GossipEnvelope
 
from() - Method in class akka.cluster.protobuf.msg.GossipStatus
 
from() - Method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope
 
from() - Method in class akka.cluster.protobuf.msg.Welcome
 
from(String) - Method in class akka.testkit.JavaTestKit.EventFilter
 
FROM_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.GossipEnvelope$
 
FROM_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.GossipEnvelope
 
FROM_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.GossipStatus$
 
FROM_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.GossipStatus
 
FROM_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope$
 
FROM_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope
 
FROM_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.Welcome$
 
FROM_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.Welcome
 
fromActor() - Method in class akka.event.LogSource$
 
fromActor() - Method in interface akka.event.LogSource
 
fromActorRef() - Method in class akka.event.LogSource$
 
fromActorRef() - Method in interface akka.event.LogSource
 
fromActorSystem(ActorSystem) - Method in class akka.event.EventStream$
 
fromActorSystem(ActorSystem) - Static method in class akka.event.EventStream
 
fromAnyClass() - Method in class akka.event.LogSource$
 
fromAnyClass() - Method in interface akka.event.LogSource
 
fromAnyRef(Object) - Method in class akka.event.LogSource$
construct string representation for any object according to rules above with fallback to its Class’s simple name.
fromAnyRef(Object, ActorSystem) - Method in class akka.event.LogSource$
construct string representation for any object according to rules above (including the actor system’s address) with fallback to its Class’s simple name.
fromAnyRef(Object) - Method in interface akka.event.LogSource
construct string representation for any object according to rules above with fallback to its Class’s simple name.
fromAnyRef(Object, ActorSystem) - Method in interface akka.event.LogSource
construct string representation for any object according to rules above (including the actor system’s address) with fallback to its Class’s simple name.
fromArray(byte[]) - Method in class akka.util.ByteString$
Creates a new ByteString by copying a byte array.
fromArray(byte[], int, int) - Method in class akka.util.ByteString$
Creates a new ByteString by copying length bytes starting at offset from an Array.
fromArray(byte[]) - Static method in class akka.util.ByteString
Creates a new ByteString by copying a byte array.
fromArray(byte[], int, int) - Static method in class akka.util.ByteString
Creates a new ByteString by copying length bytes starting at offset from an Array.
fromArray(byte[], int, int) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by copying length bytes starting at offset from an Array.
fromArray(byte[], int, int) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by copying length bytes starting at offset from an Array.
fromBinary(byte[], Option<Class<?>>) - Method in class akka.cluster.protobuf.ClusterMessageSerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in class akka.remote.serialization.MessageContainerSerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in class akka.remote.serialization.ProtobufSerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in class akka.serialization.ByteArraySerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in class akka.serialization.JavaSerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in class akka.serialization.JSerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in class akka.serialization.NullSerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in interface akka.serialization.Serializer
Produces an object from an array of bytes, with an optional type-hint; the class should be loaded using ActorSystem.dynamicAccess.
fromBinary(byte[]) - Method in interface akka.serialization.Serializer
Java API: deserialize without type hint
fromBinary(byte[], Class<?>) - Method in interface akka.serialization.Serializer
Java API: deserialize with type hint
fromBinaryJava(byte[], Class<?>) - Method in class akka.serialization.JSerializer
This method must be implemented, manifest may be null.
fromByteBuffer(ByteBuffer) - Method in class akka.util.ByteString$
Creates a new ByteString by copying bytes out of a ByteBuffer.
fromByteBuffer(ByteBuffer) - Static method in class akka.util.ByteString
Creates a new ByteString by copying bytes out of a ByteBuffer.
fromClass() - Method in class akka.event.LogSource$
 
fromClass() - Method in interface akka.event.LogSource
 
FromConfig - Class in akka.routing
Java API: Router configuration which has no default, i.e.
FromConfig(String, SupervisorStrategy) - Constructor for class akka.routing.FromConfig
 
FromConfig() - Constructor for class akka.routing.FromConfig
 
FromConfig$ - Class in akka.routing
Router configuration which has no default, i.e.
FromConfig$() - Constructor for class akka.routing.FromConfig$
 
fromExecutor(Executor) - Method in class akka.dispatch.ExecutionContexts$
Returns a new ExecutionContextExecutor which will delegate execution to the underlying Executor, and which will use the default error reporter.
fromExecutor(Executor, Procedure<Throwable>) - Method in class akka.dispatch.ExecutionContexts$
Returns a new ExecutionContextExecutor which will delegate execution to the underlying Executor, and which will use the provided error reporter.
fromExecutor(Executor) - Static method in class akka.dispatch.ExecutionContexts
Returns a new ExecutionContextExecutor which will delegate execution to the underlying Executor, and which will use the default error reporter.
fromExecutor(Executor, Procedure<Throwable>) - Static method in class akka.dispatch.ExecutionContexts
Returns a new ExecutionContextExecutor which will delegate execution to the underlying Executor, and which will use the provided error reporter.
fromExecutorService(ExecutorService) - Method in class akka.dispatch.ExecutionContexts$
Returns a new ExecutionContextExecutorService which will delegate execution to the underlying ExecutorService, and which will use the default error reporter.
fromExecutorService(ExecutorService, Procedure<Throwable>) - Method in class akka.dispatch.ExecutionContexts$
Returns a new ExecutionContextExecutorService which will delegate execution to the underlying ExecutorService, and which will use the provided error reporter.
fromExecutorService(ExecutorService) - Static method in class akka.dispatch.ExecutionContexts
Returns a new ExecutionContextExecutorService which will delegate execution to the underlying ExecutorService, and which will use the default error reporter.
fromExecutorService(ExecutorService, Procedure<Throwable>) - Static method in class akka.dispatch.ExecutionContexts
Returns a new ExecutionContextExecutorService which will delegate execution to the underlying ExecutorService, and which will use the provided error reporter.
fromHash(String) - Method in class akka.cluster.VectorClock.Node$
 
fromScalaOption(Option<T>) - Method in class akka.japi.Option$
Converts a Scala Option to a Java Option
fromScalaOption(Option<T>) - Static method in class akka.japi.Option
Converts a Scala Option to a Java Option
fromString(String) - Method in class akka.actor.ActorPath$
Parse string as actor path; throws java.net.MalformedURLException if unable to do so.
fromString(String) - Method in interface akka.actor.ActorPath
Parse string as actor path; throws java.net.MalformedURLException if unable to do so.
fromString() - Method in class akka.event.LogSource$
 
fromString() - Method in interface akka.event.LogSource
 
fromString(String) - Method in class akka.util.ByteString$
Creates a new ByteString which will contain the UTF-8 representation of the given String
fromString(String, String) - Method in class akka.util.ByteString$
Creates a new ByteString which will contain the representation of the given String in the given charset
fromString(String) - Static method in class akka.util.ByteString
Creates a new ByteString which will contain the UTF-8 representation of the given String
fromString(String, String) - Static method in class akka.util.ByteString
Creates a new ByteString which will contain the representation of the given String in the given charset
FSM<S,D> - Interface in akka.actor
Finite State Machine actor trait.
FSM$ - Class in akka.actor
 
FSM$() - Constructor for class akka.actor.FSM$
 
FSM.$minus$greater$ - Class in akka.actor
This extractor is just convenience for matching a (S, S) pair, including a reminder what the new state is.
FSM.$minus$greater$() - Constructor for class akka.actor.FSM.$minus$greater$
 
FSM.CurrentState<S> - Class in akka.actor
Message type which is sent directly to the subscribed actor in FSM.SubscribeTransitionCallBack before sending any FSM.Transition messages.
FSM.CurrentState(ActorRef, S) - Constructor for class akka.actor.FSM.CurrentState
 
FSM.CurrentState$ - Class in akka.actor
 
FSM.CurrentState$() - Constructor for class akka.actor.FSM.CurrentState$
 
FSM.Event - Class in akka.actor
All messages sent to the FSM will be wrapped inside an Event, which allows pattern matching to extract both state and data.
FSM.Event(Object, D) - Constructor for class akka.actor.FSM.Event
 
FSM.Event$ - Class in akka.actor
 
FSM.Event$() - Constructor for class akka.actor.FSM.Event$
 
FSM.Failure - Class in akka.actor
Signifies that the FSM is shutting itself down because of an error, e.g.
FSM.Failure(Object) - Constructor for class akka.actor.FSM.Failure
 
FSM.Failure$ - Class in akka.actor
 
FSM.Failure$() - Constructor for class akka.actor.FSM.Failure$
 
FSM.LogEntry<S,D> - Class in akka.actor
Log Entry of the LoggingFSM, can be obtained by calling getLog.
FSM.LogEntry(S, D, Object) - Constructor for class akka.actor.FSM.LogEntry
 
FSM.LogEntry$ - Class in akka.actor
 
FSM.LogEntry$() - Constructor for class akka.actor.FSM.LogEntry$
 
FSM.Normal$ - Class in akka.actor
Default reason if calling stop().
FSM.Normal$() - Constructor for class akka.actor.FSM.Normal$
 
FSM.NullFunction$ - Class in akka.actor
A partial function value which does not match anything and can be used to “reset” whenUnhandled and onTermination handlers.
FSM.NullFunction$() - Constructor for class akka.actor.FSM.NullFunction$
 
FSM.Reason - Interface in akka.actor
Reason why this FSM is shutting down.
FSM.Shutdown$ - Class in akka.actor
Reason given when someone was calling system.stop(fsm) from outside; also applies to Stop supervision directive.
FSM.Shutdown$() - Constructor for class akka.actor.FSM.Shutdown$
 
FSM.State<S,D> - Class in akka.actor
This captures all of the managed state of the FSM: the state name, the state data, possibly custom timeout, stop reason and replies accumulated while processing the last message.
FSM.State(S, D, Option<FiniteDuration>, Option<FSM.Reason>, List<Object>) - Constructor for class akka.actor.FSM.State
 
FSM.State$ - Class in akka.actor
 
FSM.State$() - Constructor for class akka.actor.FSM.State$
 
FSM.StateTimeout$ - Class in akka.actor
This case object is received in case of a state timeout.
FSM.StateTimeout$() - Constructor for class akka.actor.FSM.StateTimeout$
 
FSM.StopEvent - Class in akka.actor
Case class representing the state of the FSM whithin the onTermination block.
FSM.StopEvent(FSM.Reason, S, D) - Constructor for class akka.actor.FSM.StopEvent
 
FSM.StopEvent$ - Class in akka.actor
 
FSM.StopEvent$() - Constructor for class akka.actor.FSM.StopEvent$
 
FSM.SubscribeTransitionCallBack - Class in akka.actor
Send this to an FSM to request first the FSM.CurrentState and then a series of FSM.Transition updates.
FSM.SubscribeTransitionCallBack(ActorRef) - Constructor for class akka.actor.FSM.SubscribeTransitionCallBack
 
FSM.SubscribeTransitionCallBack$ - Class in akka.actor
 
FSM.SubscribeTransitionCallBack$() - Constructor for class akka.actor.FSM.SubscribeTransitionCallBack$
 
FSM.TimeoutMarker - Class in akka.actor
INTERNAL API
FSM.TimeoutMarker(long) - Constructor for class akka.actor.FSM.TimeoutMarker
 
FSM.TimeoutMarker$ - Class in akka.actor
 
FSM.TimeoutMarker$() - Constructor for class akka.actor.FSM.TimeoutMarker$
 
FSM.Timer - Class in akka.actor
INTERNAL API
FSM.Timer(String, Object, boolean, int, ActorContext) - Constructor for class akka.actor.FSM.Timer
 
FSM.Timer$ - Class in akka.actor
 
FSM.Timer$() - Constructor for class akka.actor.FSM.Timer$
 
FSM.TransformHelper - Class in akka.actor
 
FSM.TransformHelper(PartialFunction<FSM.Event, FSM.State<S, D>>) - Constructor for class akka.actor.FSM.TransformHelper
 
FSM.Transition<S> - Class in akka.actor
Message type which is used to communicate transitions between states to all subscribed listeners (use FSM.SubscribeTransitionCallBack).
FSM.Transition(ActorRef, S, S) - Constructor for class akka.actor.FSM.Transition
 
FSM.Transition$ - Class in akka.actor
 
FSM.Transition$() - Constructor for class akka.actor.FSM.Transition$
 
FSM.UnsubscribeTransitionCallBack - Class in akka.actor
Unsubscribe from FSM.Transition notifications which was effected by sending the corresponding FSM.SubscribeTransitionCallBack.
FSM.UnsubscribeTransitionCallBack(ActorRef) - Constructor for class akka.actor.FSM.UnsubscribeTransitionCallBack
 
FSM.UnsubscribeTransitionCallBack$ - Class in akka.actor
 
FSM.UnsubscribeTransitionCallBack$() - Constructor for class akka.actor.FSM.UnsubscribeTransitionCallBack$
 
FsmDebugEvent() - Method in class akka.actor.ActorSystem.Settings
 
fsmRef() - Method in class akka.actor.FSM.CurrentState
 
fsmRef() - Method in class akka.actor.FSM.Transition
 
full() - Method in interface akka.actor.LoggingFSM
 
Function<T,R> - Interface in akka.japi
A Function interface.
Function2<T1,T2,R> - Interface in akka.japi
A Function interface.
future() - Method in class akka.actor.IO.IterateeRefAsync
Returns a Future which will hold the future value of this IterateeRefAsync
future() - Method in class akka.agent.Agent
A future to the current value that will be completed after any currently queued updates.
future(Callable<T>, ExecutionContext) - Method in class akka.dispatch.Futures$
Starts an asynchronous computation and returns a Future object with the result of that computation.
future(Callable<T>, ExecutionContext) - Static method in class akka.dispatch.Futures
Starts an asynchronous computation and returns a Future object with the result of that computation.
future() - Method in class akka.pattern.PipeToSupport.PipeableFuture
 
Futures - Class in akka.dispatch
Futures is the Java API for Futures and Promises
Futures() - Constructor for class akka.dispatch.Futures
 
Futures$ - Class in akka.dispatch
Futures is the Java API for Futures and Promises
Futures$() - Constructor for class akka.dispatch.Futures$
 
FutureTimeoutSupport - Interface in akka.pattern
Copyright (C) 2009-2013 Typesafe Inc.

G

gen(Object) - Method in class akka.dispatch.PriorityGenerator
 
generateSecureCookie() - Method in class akka.util.Crypt$
 
generateSecureCookie() - Static method in class akka.util.Crypt
 
generateSeed(int) - Method in class akka.remote.security.provider.InternetSeedGenerator
Generates a seed by trying each of the available strategies in turn until one succeeds.
generation() - Method in interface akka.actor.FSM
 
generation() - Method in class akka.actor.FSM.TimeoutMarker
 
generation() - Method in class akka.actor.FSM.Timer
 
genString(T) - Method in interface akka.event.LogSource
 
genString(T, ActorSystem) - Method in interface akka.event.LogSource
 
get(ActorSystem) - Method in class akka.actor.ActorDSL.Extension$
Java API: retrieve the ActorDSL extension for the given system.
get(ActorSystem) - Method in interface akka.actor.ExtensionId
Returns an instance of the extension identified by this ExtensionId instance.
get() - Method in class akka.actor.IO.Iteratee
Passes an akka.actor.IO.EOF to this Iteratee and returns the result if available.
get(K) - Method in class akka.actor.IO.IterateeRef.Map
 
get(ActorSystem) - Method in class akka.actor.TypedActor$
 
get(ActorContext) - Method in class akka.actor.TypedActor$
Returns a contextual TypedActorFactory of this extension, this means that any TypedActors created by this TypedActorExtension will be children to the specified context, this allows for creating hierarchies of TypedActors.
get(ActorSystem) - Static method in class akka.actor.TypedActor
 
get(ActorContext) - Static method in class akka.actor.TypedActor
Returns a contextual TypedActorFactory of this extension, this means that any TypedActors created by this TypedActorExtension will be children to the specified context, this allows for creating hierarchies of TypedActors.
get() - Method in class akka.agent.Agent
Java API: Read the internal state of the agent.
get(ActorSystem) - Method in class akka.camel.CamelExtension$
 
get(ActorSystem) - Static method in class akka.camel.CamelExtension
 
get(ActorSystem) - Method in class akka.cluster.Cluster$
 
get(ActorSystem) - Static method in class akka.cluster.Cluster
 
get(ActorSystem) - Method in class akka.contrib.pattern.ClusterReceptionistExtension$
 
get(ActorSystem) - Static method in class akka.contrib.pattern.ClusterReceptionistExtension
 
get(ActorSystem) - Method in class akka.contrib.pattern.DistributedPubSubExtension$
 
get(ActorSystem) - Static method in class akka.contrib.pattern.DistributedPubSubExtension
 
get(ActorSystem) - Method in class akka.io.Tcp$
Java API: retrieve the Tcp extension for the given system.
get(ActorSystem) - Static method in class akka.io.Tcp
Java API: retrieve the Tcp extension for the given system.
get(ActorSystem) - Method in class akka.io.Udp$
Java API: retrieve the Udp extension for the given system.
get(ActorSystem) - Static method in class akka.io.Udp
Java API: retrieve the Udp extension for the given system.
get(ActorSystem) - Method in class akka.io.UdpConnected$
Java API: retrieve the UdpConnected extension for the given system.
get(ActorSystem) - Static method in class akka.io.UdpConnected
Java API: retrieve the UdpConnected extension for the given system.
get() - Method in class akka.japi.Option
 
get() - Method in class akka.japi.Option.Some
 
get(ActorSystem) - Method in class akka.remote.AddressUidExtension$
 
get(ActorSystem) - Static method in class akka.remote.AddressUidExtension
 
get(ActorSystem) - Method in class akka.remote.testconductor.TestConductor$
Java API: retrieve the TestConductor extension for the given system.
get(ActorSystem) - Static method in class akka.remote.testconductor.TestConductor
Java API: retrieve the TestConductor extension for the given system.
get(String) - Method in class akka.remote.transport.AssociationRegistry$
 
get(String) - Static method in class akka.remote.transport.AssociationRegistry
 
get(ActorSystem) - Method in class akka.remote.transport.TransportAdaptersExtension$
 
get(ActorSystem) - Static method in class akka.remote.transport.TransportAdaptersExtension
 
get(ActorSystem) - Method in class akka.serialization.SerializationExtension$
 
get(ActorSystem) - Static method in class akka.serialization.SerializationExtension
 
get() - Method in class akka.testkit.JavaTestKit.ExpectMsg
 
get() - Method in class akka.testkit.JavaTestKit.ReceiveWhile
 
get(ActorSystem) - Method in class akka.testkit.TestKitExtension$
 
get(ActorSystem) - Static method in class akka.testkit.TestKitExtension
 
get(ActorSystem) - Method in class akka.transactor.TransactorExtension$
 
get(ActorSystem) - Static method in class akka.transactor.TransactorExtension
 
get(ActorSystem) - Method in class akka.zeromq.ZeroMQExtension$
 
get(ActorSystem) - Static method in class akka.zeromq.ZeroMQExtension
 
getAck() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
getAck() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
getAck() - Method in interface akka.remote.WireFormats.AckAndEnvelopeContainerOrBuilder
 
getAckBuilder() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
getAckOrBuilder() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
getAckOrBuilder() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
getAckOrBuilder() - Method in interface akka.remote.WireFormats.AckAndEnvelopeContainerOrBuilder
 
getActivation() - Method in class akka.camel.javaapi.UntypedConsumerActor
Java API: Returns the Activation interface that can be used to wait on activation or de-activation of Camel endpoints.
getActivation() - Method in class akka.camel.javaapi.UntypedProducerActor
''Java API'': Returns the Activation interface that can be used to wait on activation or de-activation of Camel endpoints.
getActor() - Method in exception akka.actor.ActorInitializationException
 
getActor() - Method in class akka.actor.Terminated
 
getActorRefFor(Object) - Method in class akka.actor.ContextualTypedActorFactory
 
getActorRefFor(Object) - Method in class akka.actor.TypedActorExtension
Retrieves the underlying ActorRef for the supplied TypedActor proxy, or null if none found
getActorRefFor(Object) - Method in interface akka.actor.TypedActorFactory
Retrieves the underlying ActorRef for the supplied TypedActor proxy, or null if none found
getActorSystemConfiguration(org.osgi.framework.BundleContext) - Method in class akka.osgi.ActorSystemActivator
Override this method to define a configuration for your ActorSystem instance.
getActorSystemName(org.osgi.framework.BundleContext) - Method in class akka.osgi.ActorSystemActivator
By default, the ActorSystem name will be set to bundle--ActorSystem.
getAdapterProvider(String) - Method in class akka.remote.transport.TransportAdapters
 
getAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
getAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
getAddr() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressRequestOrBuilder
 
getAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
getAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
getAddr() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
 
getAddrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
getAddrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
getAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
getAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
getAddress() - Method in interface akka.remote.testconductor.TestConductorProtocol.HelloOrBuilder
 
getAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
getAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
getAddress() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
 
getAddressBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
getAddressBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
getAddressFor(RoleName) - Method in interface akka.remote.testconductor.Player
Query remote transport address of named node.
getAddressOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
getAddressOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
getAddressOrBuilder() - Method in interface akka.remote.testconductor.TestConductorProtocol.HelloOrBuilder
 
getAddressOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
getAddressOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
getAddressOrBuilder() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
 
getAddressTerminated() - Method in class akka.actor.Terminated
 
getAddrOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
getAddrOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
getAddrOrBuilder() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressRequestOrBuilder
 
getAddrOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
getAddrOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
getAddrOrBuilder() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
 
getAllRoles() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
Java API: All node roles in the cluster
getArgs(int) - Method in class akka.remote.WireFormats.PropsData.Builder
 
getArgs(int) - Method in class akka.remote.WireFormats.PropsData
 
getArgs(int) - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
 
getArgsCount() - Method in class akka.remote.WireFormats.PropsData.Builder
 
getArgsCount() - Method in class akka.remote.WireFormats.PropsData
 
getArgsCount() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
 
getArgsList() - Method in class akka.remote.WireFormats.PropsData.Builder
 
getArgsList() - Method in class akka.remote.WireFormats.PropsData
 
getArgsList() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
 
getBarrier() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
getBarrier() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
getBarrier() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
 
getBarrierBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
getBarrierOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
getBarrierOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
getBarrierOrBuilder() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
 
getBodyAs(Class<T>, org.apache.camel.CamelContext) - Method in class akka.camel.CamelMessage
Java API: Returns the body of the message converted to the type as given by the clazz parameter.
getByte() - Method in class akka.util.ByteIterator
Get a single Byte from this iterator.
getByteBuffers() - Method in class akka.util.ByteString
Java API: Returns an Iterable of read-only ByteBuffers that directly wraps this ByteStrings all fragments.
getBytes(byte[], int, int) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
getBytes(byte[]) - Method in class akka.util.ByteIterator
Get a specific number of Bytes from this iterator.
getBytes(byte[], int, int) - Method in class akka.util.ByteIterator
Get a specific number of Bytes from this iterator.
getBytes(byte[], int, int) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
getCallerName(Class<?>) - Method in class akka.testkit.AkkaSpec$
 
getCallerName(Class<?>) - Static method in class akka.testkit.AkkaSpec
 
getCamelContext() - Method in class akka.camel.javaapi.UntypedConsumerActor
Java API: Returns the org.apache.camel.impl.DefaultCamelContext
getCamelContext() - Method in class akka.camel.javaapi.UntypedProducerActor
Returns the CamelContext.
getCause() - Method in class akka.event.Logging.LogEventException
 
getCause() - Method in exception akka.pattern.AskTimeoutException
 
getCause() - Method in class akka.remote.AssociationErrorEvent
 
getCause() - Method in class akka.remote.RemotingErrorEvent
 
getChild(String) - Method in interface akka.actor.UntypedActorContext
Returns a reference to the named child or null if no child with that name exists.
getChildren() - Method in interface akka.actor.UntypedActorContext
Returns an unmodifiable Java Collection containing the linked actors, please note that the backing map is thread-safe but not immutable
getClasses(int) - Method in class akka.remote.WireFormats.PropsData.Builder
 
getClasses(int) - Method in class akka.remote.WireFormats.PropsData
 
getClasses(int) - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
 
getClassesCount() - Method in class akka.remote.WireFormats.PropsData.Builder
 
getClassesCount() - Method in class akka.remote.WireFormats.PropsData
 
getClassesCount() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
 
getClassesList() - Method in class akka.remote.WireFormats.PropsData.Builder
 
getClassesList() - Method in class akka.remote.WireFormats.PropsData
 
getClassesList() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
 
getClassFor(String, ClassTag<T>) - Method in class akka.actor.DynamicAccess
Obtain a Class[_] object loaded with the right class loader (i.e.
getClassFor(String, ClassTag<T>) - Method in class akka.actor.ReflectiveDynamicAccess
 
getClazz(T) - Method in interface akka.event.LogSource
 
getClazz() - Method in class akka.remote.WireFormats.PropsData.Builder
 
getClazz() - Method in class akka.remote.WireFormats.PropsData
 
getClazz() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
 
getClusterStatus() - Method in interface akka.cluster.ClusterNodeMBean
 
getCmd() - Method in class akka.io.TcpPipelineHandler.Init.Command
 
getCmd() - Method in class akka.io.TcpPipelineHandler.Management
 
getCommandType() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
getCommandType() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
getCommandType() - Method in interface akka.remote.WireFormats.AkkaControlMessageOrBuilder
 
getConfig() - Method in class akka.remote.WireFormats.DeployData.Builder
 
getConfig() - Method in class akka.remote.WireFormats.DeployData
 
getConfig() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
 
getContext() - Method in class akka.actor.UntypedActor
Returns this UntypedActor's UntypedActorContext The UntypedActorContext is not thread safe so do not expose it outside of the UntypedActor.
getContext() - Method in interface akka.io.HasActorContext
Retrieve the ActorContext for this pipeline’s context.
getCookie() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
getCookie() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
getCookie() - Method in interface akka.remote.WireFormats.AkkaHandshakeInfoOrBuilder
 
getCumulativeAck() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
getCumulativeAck() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
getCumulativeAck() - Method in interface akka.remote.WireFormats.AcknowledgementInfoOrBuilder
 
getDefaultAddress() - Method in interface akka.actor.ActorRefProvider
Obtain the external address of the default transport.
getDefaultInstance() - Method in class akka.cluster.protobuf.msg.Address$
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.Address
 
getDefaultInstance() - Method in class akka.cluster.protobuf.msg.Empty$
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.Empty
 
getDefaultInstance() - Method in class akka.cluster.protobuf.msg.Gossip$
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.Gossip
 
getDefaultInstance() - Method in class akka.cluster.protobuf.msg.GossipEnvelope$
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.GossipEnvelope
 
getDefaultInstance() - Method in class akka.cluster.protobuf.msg.GossipOverview$
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.GossipOverview
 
getDefaultInstance() - Method in class akka.cluster.protobuf.msg.GossipOverview.Seen$
 
getDefaultInstance() - Method in class akka.cluster.protobuf.msg.GossipStatus$
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.GossipStatus
 
getDefaultInstance() - Method in class akka.cluster.protobuf.msg.Join$
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.Join
 
getDefaultInstance() - Method in class akka.cluster.protobuf.msg.Member$
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.Member
 
getDefaultInstance() - Method in class akka.cluster.protobuf.msg.MetricsGossip$
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.MetricsGossip
 
getDefaultInstance() - Method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope$
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope
 
getDefaultInstance() - Method in class akka.cluster.protobuf.msg.NodeMetrics$
 
getDefaultInstance() - Method in class akka.cluster.protobuf.msg.NodeMetrics.EWMA$
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.NodeMetrics
 
getDefaultInstance() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Metric$
 
getDefaultInstance() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number$
 
getDefaultInstance() - Method in class akka.cluster.protobuf.msg.UniqueAddress$
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.UniqueAddress
 
getDefaultInstance() - Method in class akka.cluster.protobuf.msg.VectorClock$
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.VectorClock
 
getDefaultInstance() - Method in class akka.cluster.protobuf.msg.VectorClock.Version$
 
getDefaultInstance() - Method in class akka.cluster.protobuf.msg.Welcome$
 
getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.Welcome
 
getDefaultInstance() - Static method in class akka.remote.ContainerFormats.Selection
 
getDefaultInstance() - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
getDefaultInstance() - Static method in class akka.remote.testconductor.TestConductorProtocol.Address
 
getDefaultInstance() - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
getDefaultInstance() - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
getDefaultInstance() - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
getDefaultInstance() - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
getDefaultInstance() - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.ActorRefData
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.AddressData
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.DeployData
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.PropsData
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.SerializedMessage
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.Address
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.Empty
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.Gossip
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.GossipEnvelope
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.GossipOverview
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.GossipOverview.Seen
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.GossipStatus
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.Join
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.Member
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.NodeMetrics.EWMA
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.NodeMetrics
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Metric
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.UniqueAddress
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.VectorClock
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.VectorClock.Version
 
getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.Welcome
 
getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.Selection.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.Selection
 
getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.ActorRefData.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.ActorRefData
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AddressData.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AddressData
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.DeployData.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.DeployData
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.PropsData.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.PropsData
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.WireFormats.SerializedMessage
 
getDeploy() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
getDeploy() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
getDeploy() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
 
getDeploy() - Method in class akka.remote.WireFormats.PropsData.Builder
 
getDeploy() - Method in class akka.remote.WireFormats.PropsData
 
getDeploy() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
 
getDeployBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
getDeployBuilder() - Method in class akka.remote.WireFormats.PropsData.Builder
 
getDeployOrBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
getDeployOrBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
getDeployOrBuilder() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
 
getDeployOrBuilder() - Method in class akka.remote.WireFormats.PropsData.Builder
 
getDeployOrBuilder() - Method in class akka.remote.WireFormats.PropsData
 
getDeployOrBuilder() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
 
getDescriptor() - Static method in class akka.remote.ContainerFormats
 
getDescriptor() - Static method in enum akka.remote.ContainerFormats.PatternType
 
getDescriptor() - Static method in class akka.remote.ContainerFormats.Selection.Builder
 
getDescriptor() - Static method in class akka.remote.ContainerFormats.Selection
 
getDescriptor() - Static method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
getDescriptor() - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.Address
 
getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
getDescriptor() - Static method in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
 
getDescriptor() - Static method in enum akka.remote.testconductor.TestConductorProtocol.Direction
 
getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
getDescriptor() - Static method in enum akka.remote.testconductor.TestConductorProtocol.FailType
 
getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol
 
getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
getDescriptor() - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
getDescriptor() - Static method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
getDescriptor() - Static method in class akka.remote.WireFormats.ActorRefData.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.ActorRefData
 
getDescriptor() - Static method in class akka.remote.WireFormats.AddressData.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.AddressData
 
getDescriptor() - Static method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
getDescriptor() - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
getDescriptor() - Static method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
getDescriptor() - Static method in enum akka.remote.WireFormats.CommandType
 
getDescriptor() - Static method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
getDescriptor() - Static method in class akka.remote.WireFormats.DeployData.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.DeployData
 
getDescriptor() - Static method in class akka.remote.WireFormats
 
getDescriptor() - Static method in class akka.remote.WireFormats.PropsData.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.PropsData
 
getDescriptor() - Static method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
getDescriptor() - Static method in class akka.remote.WireFormats.SerializedMessage.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.SerializedMessage
 
getDescriptorForType() - Method in enum akka.remote.ContainerFormats.PatternType
 
getDescriptorForType() - Method in class akka.remote.ContainerFormats.Selection.Builder
 
getDescriptorForType() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
getDescriptorForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
getDescriptorForType() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
getDescriptorForType() - Method in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
 
getDescriptorForType() - Method in enum akka.remote.testconductor.TestConductorProtocol.Direction
 
getDescriptorForType() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
getDescriptorForType() - Method in enum akka.remote.testconductor.TestConductorProtocol.FailType
 
getDescriptorForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
getDescriptorForType() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
getDescriptorForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
getDescriptorForType() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
getDescriptorForType() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
getDescriptorForType() - Method in class akka.remote.WireFormats.ActorRefData.Builder
 
getDescriptorForType() - Method in class akka.remote.WireFormats.AddressData.Builder
 
getDescriptorForType() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
getDescriptorForType() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
getDescriptorForType() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
getDescriptorForType() - Method in enum akka.remote.WireFormats.CommandType
 
getDescriptorForType() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
getDescriptorForType() - Method in class akka.remote.WireFormats.DeployData.Builder
 
getDescriptorForType() - Method in class akka.remote.WireFormats.PropsData.Builder
 
getDescriptorForType() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
getDescriptorForType() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
getDirection() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
getDirection() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
getDirection() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
 
getDispatcher() - Method in class akka.remote.WireFormats.DeployData.Builder
 
getDispatcher() - Method in class akka.remote.WireFormats.DeployData
 
getDispatcher() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
 
getDone() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
getDone() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
getDone() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
 
getDouble(ByteOrder) - Method in class akka.util.ByteIterator
 
getDoubles(double[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
getDoubles(double[], ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Doubles from this iterator.
getDoubles(double[], int, int, ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Doubles from this iterator.
getDoubles(double[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
getElements() - Method in interface akka.actor.ActorPath
Java API: Sequence of names for this path from root to this.
getEnclosedMessage() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
getEnclosedMessage() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
getEnclosedMessage() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
 
getEndpointUri() - Method in class akka.camel.javaapi.UntypedConsumerActor
Java API: Returns the Camel endpoint URI to consume messages from.
getEndpointUri() - Method in class akka.camel.javaapi.UntypedProducerActor
Returns the Camel endpoint URI to produce messages to.
getEnvelope() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
getEnvelope() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
getEnvelope() - Method in interface akka.remote.WireFormats.AckAndEnvelopeContainerOrBuilder
 
getEnvelopeBuilder() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
getEnvelopeOrBuilder() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
getEnvelopeOrBuilder() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
getEnvelopeOrBuilder() - Method in interface akka.remote.WireFormats.AckAndEnvelopeContainerOrBuilder
 
getErrorCause() - Method in interface akka.io.Tcp.ConnectionClosed
If isErrorClosed returns true, then the error condition can be retrieved by this method.
getErrorCause() - Method in class akka.io.Tcp.ErrorClosed
 
getEvt() - Method in class akka.io.TcpPipelineHandler.Init.Event
 
getEvt() - Method in class akka.io.TcpPipelineHandler.TcpEvent
 
getExistenceConfirmed() - Method in class akka.actor.Terminated
 
getExitValue() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
getExitValue() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
getExitValue() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
 
getExternalAddressFor(Address) - Method in interface akka.actor.ActorRefProvider
Obtain the address which is to be used within sender references when sending to the given other address or none if the other address cannot be reached from this system (i.e.
getFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
getFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
getFailure() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
 
getFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
getFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
getFailure() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
 
getFailureBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
getFailureOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
getFailureOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
getFailureOrBuilder() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
 
getFloat(ByteOrder) - Method in class akka.util.ByteIterator
 
getFloats(float[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
getFloats(float[], ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Floats from this iterator.
getFloats(float[], int, int, ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Floats from this iterator.
getFloats(float[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
getHandshakeInfo() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
getHandshakeInfo() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
getHandshakeInfo() - Method in interface akka.remote.WireFormats.AkkaControlMessageOrBuilder
 
getHandshakeInfoBuilder() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
getHandshakeInfoOrBuilder() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
getHandshakeInfoOrBuilder() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
getHandshakeInfoOrBuilder() - Method in interface akka.remote.WireFormats.AkkaControlMessageOrBuilder
 
getHeaderAs(String, Class<T>, org.apache.camel.CamelContext) - Method in class akka.camel.CamelMessage
Java API: Returns the header by given name parameter.
getHeaders(Set<String>) - Method in class akka.camel.CamelMessage
Java API: Returns those headers from this message whose name is contained in names.
getHeaders() - Method in class akka.camel.CamelMessage
Java API: Returns all headers from this message.
getHello() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
getHello() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
getHello() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
 
getHelloBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
getHelloOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
getHelloOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
getHelloOrBuilder() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
 
getHost() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
getHost() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
getHost() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
 
getHostname() - Method in class akka.remote.WireFormats.AddressData.Builder
 
getHostname() - Method in class akka.remote.WireFormats.AddressData
 
getHostname() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
 
getInstance() - Method in class akka.actor.Kill$
Java API: get the singleton instance
getInstance() - Static method in class akka.actor.Kill
Java API: get the singleton instance
getInstance() - Method in class akka.actor.LocalScope$
Java API: get the singleton instance
getInstance() - Static method in class akka.actor.LocalScope
Java API: get the singleton instance
getInstance() - Method in class akka.actor.NoScopeGiven$
Java API: get the singleton instance
getInstance() - Static method in class akka.actor.NoScopeGiven
Java API: get the singleton instance
getInstance() - Method in class akka.actor.PoisonPill$
Java API: get the singleton instance
getInstance() - Static method in class akka.actor.PoisonPill
Java API: get the singleton instance
getInstance() - Method in class akka.actor.ReceiveTimeout$
Java API: get the singleton instance
getInstance() - Static method in class akka.actor.ReceiveTimeout
Java API: get the singleton instance
getInstance() - Method in class akka.camel.Ack$
Java API to get the Ack singleton
getInstance() - Static method in class akka.camel.Ack
Java API to get the Ack singleton
getInstance() - Method in class akka.cluster.ClusterScope$
Java API: get the singleton instance
getInstance() - Static method in class akka.cluster.ClusterScope
Java API: get the singleton instance
getInstance() - Method in class akka.cluster.routing.CpuMetricsSelector$
Java API: get the singleton instance
getInstance() - Static method in class akka.cluster.routing.CpuMetricsSelector
Java API: get the singleton instance
getInstance() - Method in class akka.cluster.routing.HeapMetricsSelector$
Java API: get the singleton instance
getInstance() - Static method in class akka.cluster.routing.HeapMetricsSelector
Java API: get the singleton instance
getInstance() - Method in class akka.cluster.routing.MixMetricsSelector$
Java API: get the default singleton instance
getInstance() - Static method in class akka.cluster.routing.MixMetricsSelector
Java API: get the default singleton instance
getInstance() - Method in class akka.cluster.routing.SystemLoadAverageMetricsSelector$
Java API: get the singleton instance
getInstance() - Static method in class akka.cluster.routing.SystemLoadAverageMetricsSelector
Java API: get the singleton instance
getInstance() - Method in class akka.event.Logging.LoggerInitialized$
Java API: get the singleton instance
getInstance() - Method in class akka.event.NoLogging$
Java API to return the reference to NoLogging
getInstance() - Static method in class akka.event.NoLogging
Java API to return the reference to NoLogging
getInstance() - Method in class akka.remote.security.provider.InternetSeedGenerator$
 
getInstance() - Static method in class akka.remote.security.provider.InternetSeedGenerator
 
getInstance() - Method in class akka.remote.transport.ThrottlerTransportAdapter.Blackhole$
Java API: get the singleton instance
getInstance() - Method in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Both$
Java API: get the singleton instance
getInstance() - Method in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Receive$
Java API: get the singleton instance
getInstance() - Method in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Send$
Java API: get the singleton instance
getInstance() - Method in class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociateAck$
Java API: get the singleton instance
getInstance() - Method in class akka.remote.transport.ThrottlerTransportAdapter.SetThrottleAck$
Java API: get the singleton instance
getInstance() - Method in class akka.remote.transport.ThrottlerTransportAdapter.Unthrottled$
Java API: get the singleton instance
getInstance() - Method in class akka.routing.CurrentRoutees$
Java API: get the singleton instance
getInstance() - Static method in class akka.routing.CurrentRoutees
Java API: get the singleton instance
getInstance() - Method in class akka.routing.FromConfig$
Java API: get the singleton instance
getInstance() - Static method in class akka.routing.FromConfig
Java API: get the singleton instance
getInstance() - Method in class akka.routing.NoRouter$
Java API: get the singleton instance
getInstance() - Static method in class akka.routing.NoRouter
Java API: get the singleton instance
getInstance() - Method in class akka.zeromq.Closed$
Java API: get the singleton instance
getInstance() - Static method in class akka.zeromq.Closed
Java API: get the singleton instance
getInstance() - Method in class akka.zeromq.Connecting$
Java API: get the singleton instance
getInstance() - Static method in class akka.zeromq.Connecting
Java API: get the singleton instance
getInstruction() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
getInstruction() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
getInstruction() - Method in interface akka.remote.WireFormats.AkkaProtocolMessageOrBuilder
 
getInstructionBuilder() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
getInstructionOrBuilder() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
getInstructionOrBuilder() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
getInstructionOrBuilder() - Method in interface akka.remote.WireFormats.AkkaProtocolMessageOrBuilder
 
getInt(ByteOrder) - Method in class akka.util.ByteIterator
Get a single Int from this iterator.
getInts(int[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
getInts(int[], ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Ints from this iterator.
getInts(int[], int, int, ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Ints from this iterator.
getInts(int[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
getLastSender() - Method in class akka.testkit.JavaTestKit
 
getLeader() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
Java API: get address of current leader, or null if none
getLeader() - Method in class akka.cluster.ClusterEvent.LeaderChanged
Java API
getLeader() - Method in class akka.cluster.ClusterEvent.RoleLeaderChanged
Java API
getLeader() - Method in interface akka.cluster.ClusterNodeMBean
Get the address of the current leader.
getListenAddresses() - Method in class akka.remote.RemotingListenEvent
 
getLocalAddress() - Method in interface akka.remote.AssociationEvent
 
getLog() - Method in interface akka.actor.LoggingFSM
Retrieve current rolling log in oldest-first order.
getLogger(ActorSystem, Object) - Method in class akka.event.Logging$
Obtain LoggingAdapter for the given actor system and source object.
getLogger(LoggingBus, Object) - Method in class akka.event.Logging$
Obtain LoggingAdapter for the given logging bus and source object.
getLogger(ActorSystem, Object) - Static method in class akka.event.Logging
Obtain LoggingAdapter for the given actor system and source object.
getLogger(LoggingBus, Object) - Static method in class akka.event.Logging
Obtain LoggingAdapter for the given logging bus and source object.
getLogger() - Method in interface akka.io.HasLogging
Retrieve the LoggingAdapter for this pipeline’s context.
getLong(ByteOrder) - Method in class akka.util.ByteIterator
Get a single Long from this iterator.
getLongPart(int, ByteOrder) - Method in class akka.util.ByteIterator
Get a Long from this iterator where only the least significant n bytes were encoded.
getLongs(long[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
getLongs(long[], ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Longs from this iterator.
getLongs(long[], int, int, ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Longs from this iterator.
getLongs(long[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
getManagedClasses() - Method in class akka.osgi.aries.blueprint.NamespaceHandler
 
getManager() - Method in class akka.io.TcpExt
Java API: retrieve a reference to the manager actor.
getManager() - Method in class akka.io.UdpConnectedExt
Java API: retrieve the UDP manager actor’s reference.
getManager() - Method in class akka.io.UdpExt
Java API: retrieve the UDP manager actor’s reference.
getMatcher() - Method in class akka.remote.ContainerFormats.Selection.Builder
 
getMatcher() - Method in class akka.remote.ContainerFormats.Selection
 
getMatcher() - Method in interface akka.remote.ContainerFormats.SelectionOrBuilder
 
getMembers() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
Java API: get current member list.
getMembers() - Method in interface akka.cluster.ClusterNodeMBean
Comma separated addresses of member nodes, sorted in the cluster ring order.
getMemberStatus() - Method in interface akka.cluster.ClusterNodeMBean
Member status for this node.
getMessage() - Method in class akka.actor.UnhandledMessage
 
getMessage() - Method in exception akka.camel.ActorNotRegisteredException
 
getMessage() - Method in class akka.event.Logging.LogEventException
 
getMessage() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
getMessage() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
getMessage() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
 
getMessage() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
getMessage() - Method in class akka.remote.WireFormats.SerializedMessage
 
getMessage() - Method in interface akka.remote.WireFormats.SerializedMessageOrBuilder
 
getMessage() - Method in class akka.transactor.Coordinated
Java API: get the message for this Coordinated.
getMessageBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
getMessageManifest() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
getMessageManifest() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
getMessageManifest() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
 
getMessageManifest() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
getMessageManifest() - Method in class akka.remote.WireFormats.SerializedMessage
 
getMessageManifest() - Method in interface akka.remote.WireFormats.SerializedMessageOrBuilder
 
getMessageOrBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
getMessageOrBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
getMessageOrBuilder() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
 
getMetrics() - Method in class akka.cluster.NodeMetrics
Java API
getNacks(int) - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
getNacks(int) - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
getNacks(int) - Method in interface akka.remote.WireFormats.AcknowledgementInfoOrBuilder
 
getNacksCount() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
getNacksCount() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
getNacksCount() - Method in interface akka.remote.WireFormats.AcknowledgementInfoOrBuilder
 
getNacksList() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
getNacksList() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
getNacksList() - Method in interface akka.remote.WireFormats.AcknowledgementInfoOrBuilder
 
getName() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
getName() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
getName() - Method in interface akka.remote.testconductor.TestConductorProtocol.EnterBarrierOrBuilder
 
getName() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
getName() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
getName() - Method in interface akka.remote.testconductor.TestConductorProtocol.HelloOrBuilder
 
getNextOldestChanged() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
getNode() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
getNode() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
getNode() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressRequestOrBuilder
 
getNodeMetrics() - Method in class akka.cluster.ClusterEvent.ClusterMetricsChanged
Java API
getNodes() - Method in interface akka.remote.testconductor.Conductor
Obtain the list of remote host names currently registered.
getNumber() - Method in enum akka.remote.ContainerFormats.PatternType
 
getNumber() - Method in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
 
getNumber() - Method in enum akka.remote.testconductor.TestConductorProtocol.Direction
 
getNumber() - Method in enum akka.remote.testconductor.TestConductorProtocol.FailType
 
getNumber() - Method in enum akka.remote.WireFormats.CommandType
 
getObjectFor(String, ClassTag<T>) - Method in class akka.actor.DynamicAccess
Obtain the Scala “object” instance for the given fully-qualified class name, if there is one.
getObjectFor(String, ClassTag<T>) - Method in class akka.actor.ReflectiveDynamicAccess
 
getOp() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
getOp() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
getOp() - Method in interface akka.remote.testconductor.TestConductorProtocol.EnterBarrierOrBuilder
 
getOrigin() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
getOrigin() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
getOrigin() - Method in interface akka.remote.WireFormats.AkkaHandshakeInfoOrBuilder
 
getOriginBuilder() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
getOriginOrBuilder() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
getOriginOrBuilder() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
getOriginOrBuilder() - Method in interface akka.remote.WireFormats.AkkaHandshakeInfoOrBuilder
 
getPath() - Method in class akka.remote.WireFormats.ActorRefData.Builder
 
getPath() - Method in class akka.remote.WireFormats.ActorRefData
 
getPath() - Method in interface akka.remote.WireFormats.ActorRefDataOrBuilder
 
getPath() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
getPath() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
getPath() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
 
getPath() - Method in class akka.remote.WireFormats.DeployData.Builder
 
getPath() - Method in class akka.remote.WireFormats.DeployData
 
getPath() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
 
getPattern(int) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
getPattern(int) - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
getPattern(int) - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
 
getPatternBuilder(int) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
getPatternBuilderList() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
getPatternCount() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
getPatternCount() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
getPatternCount() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
 
getPatternList() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
getPatternList() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
getPatternList() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
 
getPatternOrBuilder(int) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
getPatternOrBuilder(int) - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
getPatternOrBuilder(int) - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
 
getPatternOrBuilderList() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
getPatternOrBuilderList() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
getPatternOrBuilderList() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
 
getPayload() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
getPayload() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
getPayload() - Method in interface akka.remote.WireFormats.AkkaProtocolMessageOrBuilder
 
getPort() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
getPort() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
getPort() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
 
getPort() - Method in class akka.remote.WireFormats.AddressData.Builder
 
getPort() - Method in class akka.remote.WireFormats.AddressData
 
getPort() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
 
getProducerTemplate() - Method in class akka.camel.javaapi.UntypedConsumerActor
Java API: Returns the org.apache.camel.ProducerTemplate
getProducerTemplate() - Method in class akka.camel.javaapi.UntypedProducerActor
Returns the ProducerTemplate.
getProps() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
getProps() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
getProps() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
 
getPropsBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
getPropsOrBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
getPropsOrBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
getPropsOrBuilder() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
 
getProtocol() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
getProtocol() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
getProtocol() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
 
getProtocol() - Method in class akka.remote.WireFormats.AddressData.Builder
 
getProtocol() - Method in class akka.remote.WireFormats.AddressData
 
getProtocol() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
 
getRateMBit() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
getRateMBit() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
getRateMBit() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
 
getRawResult() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinTask
 
getRecipient() - Method in class akka.actor.UnhandledMessage
 
getRecipient() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
getRecipient() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
getRecipient() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
 
getRecipientBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
getRecipientOrBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
getRecipientOrBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
getRecipientOrBuilder() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
 
getRef() - Method in class akka.actor.ActorIdentity
Java API: ActorRef of the actor replying to the request or null if no actor matched the request.
getRef() - Method in class akka.actor.dsl.Inbox.Inbox
 
getRef() - Method in class akka.actor.Inbox
Obtain a reference to the internal actor, which can then for example be registered with the event stream or whatever else you may want to do with an ActorRef.
getRef() - Method in class akka.testkit.JavaTestKit
Shorthand to get the testActor.
getRemainingTime() - Method in class akka.testkit.JavaTestKit
 
getRemainingTimeOr(FiniteDuration) - Method in class akka.testkit.JavaTestKit
 
getRemoteAddress() - Method in interface akka.remote.AssociationEvent
 
getRemoteReadHandlerFor(TestAssociationHandle) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Returns the event handler corresponding to the remote endpoint of the given local handle.
getRoleLeader(String) - Method in class akka.cluster.ClusterEvent.CurrentClusterState
Java API: get address of current leader within the role set, or null if no node with that role
getRoles() - Method in class akka.cluster.Member
Java API
getRouteDefinitionHandler() - Method in interface akka.camel.Consumer
Java API: Returns the Mapper function that will be used as a route definition handler for creating custom route to this consumer.
getRoutees() - Method in class akka.routing.RouteeProvider
Java API: All routees of the router
getRouterConfig() - Method in class akka.remote.WireFormats.DeployData.Builder
 
getRouterConfig() - Method in class akka.remote.WireFormats.DeployData
 
getRouterConfig() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
 
getSchemaLocation(String) - Method in class akka.osgi.aries.blueprint.NamespaceHandler
 
getScope() - Method in class akka.remote.WireFormats.DeployData.Builder
 
getScope() - Method in class akka.remote.WireFormats.DeployData
 
getScope() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
 
getSeenBy() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
Java API: get current “seen-by” set.
getSelf() - Method in class akka.actor.UntypedActor
Returns the ActorRef for this actor.
getSelfRoles() - Method in class akka.cluster.Cluster
Java API: roles that this member has
getSender() - Method in class akka.actor.UnhandledMessage
 
getSender() - Method in class akka.actor.UntypedActor
The reference sender Actor of the currently processed message.
getSender() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
getSender() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
getSender() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
 
getSenderBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
getSenderOrBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
getSenderOrBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
getSenderOrBuilder() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
 
getSeq() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
getSeq() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
getSeq() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.Address
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.Empty
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.Gossip
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.GossipEnvelope
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.GossipOverview
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.GossipOverview.Seen
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.GossipStatus
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.Join
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.Member
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.NodeMetrics.EWMA
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.NodeMetrics
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Metric
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.UniqueAddress
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.VectorClock
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.VectorClock.Version
 
getSerializedSize() - Method in class akka.cluster.protobuf.msg.Welcome
 
getSerializedSize() - Method in class akka.remote.ContainerFormats.Selection
 
getSerializedSize() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
getSerializedSize() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
getSerializedSize() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
getSerializedSize() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
getSerializedSize() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
getSerializedSize() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
getSerializedSize() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
getSerializedSize() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
getSerializedSize() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
getSerializedSize() - Method in class akka.remote.WireFormats.ActorRefData
 
getSerializedSize() - Method in class akka.remote.WireFormats.AddressData
 
getSerializedSize() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
getSerializedSize() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
getSerializedSize() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
getSerializedSize() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
getSerializedSize() - Method in class akka.remote.WireFormats.DeployData
 
getSerializedSize() - Method in class akka.remote.WireFormats.PropsData
 
getSerializedSize() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
getSerializedSize() - Method in class akka.remote.WireFormats.SerializedMessage
 
getSerializerId() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
getSerializerId() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
getSerializerId() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
 
getSerializerId() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
getSerializerId() - Method in class akka.remote.WireFormats.SerializedMessage
 
getSerializerId() - Method in interface akka.remote.WireFormats.SerializedMessageOrBuilder
 
getShort(ByteOrder) - Method in class akka.util.ByteIterator
Get a single Short from this iterator.
getShorts(short[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
getShorts(short[], ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Shorts from this iterator.
getShorts(short[], int, int, ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Shorts from this iterator.
getShorts(short[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
getShutdownTimeout() - Method in class akka.actor.LightArrayRevolverScheduler
Overridable for tests
getSupervisor() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
getSupervisor() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
getSupervisor() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
 
getSupervisorBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
getSupervisorOrBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
getSupervisorOrBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
getSupervisorOrBuilder() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
 
getSystem() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
getSystem() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
getSystem() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
 
getSystem() - Method in class akka.remote.WireFormats.AddressData.Builder
 
getSystem() - Method in class akka.remote.WireFormats.AddressData
 
getSystem() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
 
getSystem() - Method in class akka.testkit.JavaTestKit
 
getTask() - Method in interface akka.util.internal.Timeout
Deprecated. Returns the TimerTask which is associated with this handle.
getTestActor() - Method in class akka.testkit.JavaTestKit
ActorRef of the test actor.
getTimeout() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
getTimeout() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
getTimeout() - Method in interface akka.remote.testconductor.TestConductorProtocol.EnterBarrierOrBuilder
 
getTimer() - Method in interface akka.util.internal.Timeout
Deprecated. Returns the Timer that created this handle.
getTimestamp() - Method in class akka.io.TickGenerator.Tick
 
getToArray(Object, int, int, int, Function0<A>, Function3<Object, Object, Object, BoxedUnit>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
getType() - Method in class akka.remote.ContainerFormats.Selection.Builder
 
getType() - Method in class akka.remote.ContainerFormats.Selection
 
getType() - Method in interface akka.remote.ContainerFormats.SelectionOrBuilder
 
getUid() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
getUid() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
getUid() - Method in interface akka.remote.WireFormats.AkkaHandshakeInfoOrBuilder
 
getUnreachable() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
Java API: get current unreachable set.
getUnreachable() - Method in interface akka.cluster.ClusterNodeMBean
Comma separated addresses of unreachable member nodes.
getValueDescriptor() - Method in enum akka.remote.ContainerFormats.PatternType
 
getValueDescriptor() - Method in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
 
getValueDescriptor() - Method in enum akka.remote.testconductor.TestConductorProtocol.Direction
 
getValueDescriptor() - Method in enum akka.remote.testconductor.TestConductorProtocol.FailType
 
getValueDescriptor() - Method in enum akka.remote.WireFormats.CommandType
 
GIGABYTE() - Method in class akka.actor.mailbox.filebased.filequeue.tools.Util$
 
GIGABYTE() - Static method in class akka.actor.mailbox.filebased.filequeue.tools.Util
 
global() - Method in class akka.dispatch.ExecutionContexts$
 
global() - Static method in class akka.dispatch.ExecutionContexts
 
GlobalHome() - Method in class akka.actor.ActorSystem$
 
GlobalHome() - Static method in class akka.actor.ActorSystem
 
Gossip - Class in akka.cluster.protobuf.msg
 
Gossip(Seq<UniqueAddress>, Seq<String>, Seq<String>, Seq<Member>, GossipOverview, VectorClock) - Constructor for class akka.cluster.protobuf.msg.Gossip
 
gossip() - Method in class akka.cluster.protobuf.msg.GossipEnvelope
 
gossip() - Method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope
 
gossip() - Method in class akka.cluster.protobuf.msg.Welcome
 
gossip() - Method in class akka.contrib.pattern.DistributedPubSubMediator
Gossip to peer nodes.
gossip(Object, ActorRef) - Method in interface akka.routing.Listeners
Sends the supplied message to all current listeners using the provided sender as sender.
Gossip$ - Class in akka.cluster.protobuf.msg
 
Gossip$() - Constructor for class akka.cluster.protobuf.msg.Gossip$
 
GOSSIP_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.GossipEnvelope$
 
GOSSIP_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.GossipEnvelope
 
GOSSIP_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope$
 
GOSSIP_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope
 
GOSSIP_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.Welcome$
 
GOSSIP_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.Welcome
 
GossipDifferentViewProbability() - Method in class akka.cluster.ClusterSettings
 
GossipEnvelope - Class in akka.cluster.protobuf.msg
 
GossipEnvelope(UniqueAddress, UniqueAddress, Gossip) - Constructor for class akka.cluster.protobuf.msg.GossipEnvelope
 
GossipEnvelope$ - Class in akka.cluster.protobuf.msg
 
GossipEnvelope$() - Constructor for class akka.cluster.protobuf.msg.GossipEnvelope$
 
GossipInterval() - Method in class akka.cluster.ClusterSettings
 
GossipOverview - Class in akka.cluster.protobuf.msg
 
GossipOverview(Seq<GossipOverview.Seen>, Seq<Member>) - Constructor for class akka.cluster.protobuf.msg.GossipOverview
 
GossipOverview$ - Class in akka.cluster.protobuf.msg
 
GossipOverview$() - Constructor for class akka.cluster.protobuf.msg.GossipOverview$
 
GossipOverview.Seen - Class in akka.cluster.protobuf.msg
 
GossipOverview.Seen(int, VectorClock) - Constructor for class akka.cluster.protobuf.msg.GossipOverview.Seen
 
GossipOverview.Seen$ - Class in akka.cluster.protobuf.msg
 
GossipOverview.Seen$() - Constructor for class akka.cluster.protobuf.msg.GossipOverview.Seen$
 
GossipStatus - Class in akka.cluster.protobuf.msg
 
GossipStatus(UniqueAddress, Seq<String>, VectorClock) - Constructor for class akka.cluster.protobuf.msg.GossipStatus
 
GossipStatus$ - Class in akka.cluster.protobuf.msg
 
GossipStatus$() - Constructor for class akka.cluster.protobuf.msg.GossipStatus$
 
gossipTask() - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
gossipTo(Address) - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
gotoHandingOver(ActorRef, boolean, Option<Object>, Option<ActorRef>) - Method in class akka.contrib.pattern.ClusterSingletonManager
 
gotoOldest(Option<Object>) - Method in class akka.contrib.pattern.ClusterSingletonManager
 
gracefulClose(org.jboss.netty.channel.Channel, ExecutionContext) - Static method in class akka.remote.transport.netty.NettyTransport
 
gracefulStop(ActorRef, FiniteDuration, Object) - Method in interface akka.pattern.GracefulStopSupport
Returns a Future that will be completed with success (value true) when existing messages of the target actor has been processed and the actor has been terminated.
gracefulStop(ActorRef, FiniteDuration) - Method in class akka.pattern.Patterns$
Returns a Future that will be completed with success (value true) when existing messages of the target actor has been processed and the actor has been terminated.
gracefulStop(ActorRef, FiniteDuration) - Static method in class akka.pattern.Patterns
Returns a Future that will be completed with success (value true) when existing messages of the target actor has been processed and the actor has been terminated.
GracefulStopSupport - Interface in akka.pattern
 
guard() - Method in interface akka.event.LoggingBus
 
guardian() - Method in interface akka.actor.ActorRefFactory
Father of all children created by this interface.
guardian() - Method in interface akka.actor.ActorRefProvider
Reference to the supervisor used for all top-level user actors.
guardian() - Method in class akka.actor.ExtendedActorSystem
The top-level supervisor of all actors created using system.actorOf(...).

H

handle() - Method in class akka.actor.IO.Close
 
handle() - Method in class akka.actor.IO.Closed
 
handle() - Method in class akka.actor.IO.Read
 
handle() - Method in class akka.actor.IO.Write
 
handleChildTerminated(ActorContext, ActorRef, Iterable<ActorRef>) - Method in class akka.actor.AllForOneStrategy
 
handleChildTerminated(ActorContext, ActorRef, Iterable<ActorRef>) - Method in class akka.actor.OneForOneStrategy
 
handleChildTerminated(ActorContext, ActorRef, Iterable<ActorRef>) - Method in class akka.actor.SupervisorStrategy
This method is called after the child has been removed from the set of children.
handleEvent() - Method in interface akka.actor.FSM
 
handleEventDefault() - Method in interface akka.actor.FSM
 
handleFailure(ActorContext, ActorRef, Throwable, ChildRestartStats, Iterable<ChildRestartStats>) - Method in class akka.actor.SupervisorStrategy
This is the main entry point: in case of a child’s failure, this method must try to handle the failure by resuming, restarting or stopping the child (and returning true), or it returns false to escalate the failure, which will lead to this actor re-throwing the exception which caused the failure.
handleMessage(Object) - Method in interface akka.contrib.pattern.Aggregator
Handles messages and matches against the expect list.
handler() - Method in class akka.io.Tcp.Bind
 
handler() - Method in class akka.io.Tcp.Register
 
handler() - Method in class akka.io.Udp.Bind
 
handler() - Method in class akka.io.UdpConnected.Connect
 
handleTransition(S, S) - Method in interface akka.actor.FSM
 
handOverDone(Option<ActorRef>, Option<Object>) - Method in class akka.contrib.pattern.ClusterSingletonManager
 
HandshakeInfo - Class in akka.remote.transport
 
HandshakeInfo(Address, int, Option<String>) - Constructor for class akka.remote.transport.HandshakeInfo
 
HandshakeInfo$ - Class in akka.remote.transport
 
HandshakeInfo$() - Constructor for class akka.remote.transport.HandshakeInfo$
 
HANDSHAKEINFO_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AkkaControlMessage
 
hasAck() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
hasAck() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
hasAck() - Method in interface akka.remote.WireFormats.AckAndEnvelopeContainerOrBuilder
 
HasActorContext - Interface in akka.io
This trait expresses that the pipeline’s context needs to live within an actor and provide its ActorContext.
hasAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
hasAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
hasAddr() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressRequestOrBuilder
 
hasAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
hasAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
hasAddr() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
 
hasAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
hasAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
hasAddress() - Method in interface akka.remote.testconductor.TestConductorProtocol.HelloOrBuilder
 
hasAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
hasAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
hasAddress() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
 
hasBarrier() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
hasBarrier() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
hasBarrier() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
 
hasClazz() - Method in class akka.remote.WireFormats.PropsData.Builder
 
hasClazz() - Method in class akka.remote.WireFormats.PropsData
 
hasClazz() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
 
hasCommandType() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
hasCommandType() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
hasCommandType() - Method in interface akka.remote.WireFormats.AkkaControlMessageOrBuilder
 
hasConfig() - Method in class akka.remote.WireFormats.DeployData.Builder
 
hasConfig() - Method in class akka.remote.WireFormats.DeployData
 
hasConfig() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
 
hasCookie() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
hasCookie() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
hasCookie() - Method in interface akka.remote.WireFormats.AkkaHandshakeInfoOrBuilder
 
hasCumulativeAck() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
hasCumulativeAck() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
hasCumulativeAck() - Method in interface akka.remote.WireFormats.AcknowledgementInfoOrBuilder
 
hasDeploy() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
hasDeploy() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
hasDeploy() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
 
hasDeploy() - Method in class akka.remote.WireFormats.PropsData.Builder
 
hasDeploy() - Method in class akka.remote.WireFormats.PropsData
 
hasDeploy() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
 
hasDirection() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
hasDirection() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
hasDirection() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
 
hasDispatcher(String) - Method in class akka.dispatch.Dispatchers
Checks that the configuration provides a section for the given dispatcher.
hasDispatcher() - Method in class akka.remote.WireFormats.DeployData.Builder
 
hasDispatcher() - Method in class akka.remote.WireFormats.DeployData
 
hasDispatcher() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
 
hasDone() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
hasDone() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
hasDone() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
 
hasEnclosedMessage() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
hasEnclosedMessage() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
hasEnclosedMessage() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
 
hasEnvelope() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
hasEnvelope() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
hasEnvelope() - Method in interface akka.remote.WireFormats.AckAndEnvelopeContainerOrBuilder
 
hasExitValue() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
hasExitValue() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
hasExitValue() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
 
hasExtension(ExtensionId<? extends Extension>) - Method in class akka.actor.ActorSystem
Returns whether the specified extension is already registered, this method can potentially block, waiting for the initialization of the payload, if is in the process of registration from another Thread of execution
hasFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
hasFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
hasFailure() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
 
hasFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
hasFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
hasFailure() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
 
hasGlobalScope() - Method in class akka.actor.Address
Returns true if this Address is usable globally.
hash(int, Object) - Method in class akka.util.HashCode$
 
hash(int, boolean) - Method in class akka.util.HashCode$
 
hash(int, char) - Method in class akka.util.HashCode$
 
hash(int, int) - Method in class akka.util.HashCode$
 
hash(int, long) - Method in class akka.util.HashCode$
 
hash(int, float) - Method in class akka.util.HashCode$
 
hash(int, double) - Method in class akka.util.HashCode$
 
hash(int, Object) - Static method in class akka.util.HashCode
 
hash(int, boolean) - Static method in class akka.util.HashCode
 
hash(int, char) - Static method in class akka.util.HashCode
 
hash(int, int) - Static method in class akka.util.HashCode
 
hash(int, long) - Static method in class akka.util.HashCode
 
hash(int, float) - Static method in class akka.util.HashCode
 
hash(int, double) - Static method in class akka.util.HashCode
 
hasHandshakeInfo() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
hasHandshakeInfo() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
hasHandshakeInfo() - Method in interface akka.remote.WireFormats.AkkaControlMessageOrBuilder
 
hashCode() - Method in class akka.actor.ActorRef
 
hashCode() - Method in class akka.actor.ActorSelection
 
hashCode() - Method in class akka.actor.ChildActorPath
 
hashCode() - Method in interface akka.actor.ExtensionId
 
hashCode() - Method in interface akka.actor.IO.Handle
 
hashCode() - Method in class akka.cluster.Member
 
hashCode() - Method in class akka.cluster.Metric
 
hashCode() - Method in class akka.cluster.NodeMetrics
 
HashCode - Class in akka.util
Set of methods which allow easy implementation of hashCode.
HashCode() - Constructor for class akka.util.HashCode
 
HashCode$ - Class in akka.util
Set of methods which allow easy implementation of hashCode.
HashCode$() - Constructor for class akka.util.HashCode$
 
HashedWheelTimer - Class in akka.util.internal
Deprecated. 
HashedWheelTimer(LoggingAdapter, ThreadFactory, Duration, int) - Constructor for class akka.util.internal.HashedWheelTimer
Deprecated. Creates a new timer.
hasHello() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
hasHello() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
hasHello() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
 
hashIndex() - Method in class akka.cluster.protobuf.msg.VectorClock.Version
 
HASHINDEX_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.VectorClock.Version$
 
hashKey() - Method in class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope
 
hashKey(Object) - Method in interface akka.routing.ConsistentHashingRouter.ConsistentHashMapper
 
hashMapping() - Method in interface akka.routing.ConsistentHashingLike
 
hashMapping() - Method in class akka.routing.ConsistentHashingRouter
 
hasHost() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
hasHost() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
hasHost() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
 
hasHostname() - Method in class akka.remote.WireFormats.AddressData.Builder
 
hasHostname() - Method in class akka.remote.WireFormats.AddressData
 
hasHostname() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
 
hasInstruction() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
hasInstruction() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
hasInstruction() - Method in interface akka.remote.WireFormats.AkkaProtocolMessageOrBuilder
 
hasLocalScope() - Method in class akka.actor.Address
Returns true if this Address is only defined locally.
HasLogging - Interface in akka.io
This trait expresses that the pipeline’s context needs to provide a logging facility.
hasMatcher() - Method in class akka.remote.ContainerFormats.Selection.Builder
 
hasMatcher() - Method in class akka.remote.ContainerFormats.Selection
 
hasMatcher() - Method in interface akka.remote.ContainerFormats.SelectionOrBuilder
 
hasMessage() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
hasMessage() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
hasMessage() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
 
hasMessage() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
hasMessage() - Method in class akka.remote.WireFormats.SerializedMessage
 
hasMessage() - Method in interface akka.remote.WireFormats.SerializedMessageOrBuilder
 
hasMessageManifest() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
hasMessageManifest() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
hasMessageManifest() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
 
hasMessageManifest() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
hasMessageManifest() - Method in class akka.remote.WireFormats.SerializedMessage
 
hasMessageManifest() - Method in interface akka.remote.WireFormats.SerializedMessageOrBuilder
 
hasMessages() - Method in class akka.actor.mailbox.filebased.FileBasedMessageQueue
 
hasMessages() - Method in interface akka.dispatch.MessageQueue
Indicates whether this queue is non-empty.
hasMessages() - Method in class akka.dispatch.NodeMessageQueue
 
hasMessages() - Method in interface akka.dispatch.QueueBasedMessageQueue
 
hasMessages(ActorRef) - Method in interface akka.routing.SmallestMailboxLike
Returns true if the actor currently has any pending messages in the mailbox, i.e.
hasMessages() - Method in class akka.testkit.CallingThreadMailbox
 
hasName() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
hasName() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
hasName() - Method in interface akka.remote.testconductor.TestConductorProtocol.EnterBarrierOrBuilder
 
hasName() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
hasName() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
hasName() - Method in interface akka.remote.testconductor.TestConductorProtocol.HelloOrBuilder
 
hasNext() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
hasNext() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
hasNode() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
hasNode() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
hasNode() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressRequestOrBuilder
 
hasOp() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
hasOp() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
hasOp() - Method in interface akka.remote.testconductor.TestConductorProtocol.EnterBarrierOrBuilder
 
hasOrigin() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
hasOrigin() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
hasOrigin() - Method in interface akka.remote.WireFormats.AkkaHandshakeInfoOrBuilder
 
hasPath() - Method in class akka.remote.WireFormats.ActorRefData.Builder
 
hasPath() - Method in class akka.remote.WireFormats.ActorRefData
 
hasPath() - Method in interface akka.remote.WireFormats.ActorRefDataOrBuilder
 
hasPath() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
hasPath() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
hasPath() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
 
hasPath() - Method in class akka.remote.WireFormats.DeployData.Builder
 
hasPath() - Method in class akka.remote.WireFormats.DeployData
 
hasPath() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
 
hasPayload() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
hasPayload() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
hasPayload() - Method in interface akka.remote.WireFormats.AkkaProtocolMessageOrBuilder
 
hasPort() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
hasPort() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
hasPort() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
 
hasPort() - Method in class akka.remote.WireFormats.AddressData.Builder
 
hasPort() - Method in class akka.remote.WireFormats.AddressData
 
hasPort() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
 
hasProps() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
hasProps() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
hasProps() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
 
hasProtocol() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
hasProtocol() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
hasProtocol() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
 
hasProtocol() - Method in class akka.remote.WireFormats.AddressData.Builder
 
hasProtocol() - Method in class akka.remote.WireFormats.AddressData
 
hasProtocol() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
 
hasRateMBit() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
hasRateMBit() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
hasRateMBit() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
 
hasRecipient() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
hasRecipient() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
hasRecipient() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
 
hasRole(String) - Method in class akka.cluster.Member
 
hasRouterConfig() - Method in class akka.remote.WireFormats.DeployData.Builder
 
hasRouterConfig() - Method in class akka.remote.WireFormats.DeployData
 
hasRouterConfig() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
 
hasScope() - Method in class akka.remote.WireFormats.DeployData.Builder
 
hasScope() - Method in class akka.remote.WireFormats.DeployData
 
hasScope() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
 
hasSender() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
hasSender() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
hasSender() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
 
hasSeq() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
hasSeq() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
hasSeq() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
 
HasSequenceNumber - Interface in akka.remote
Messages that are to be buffered in AckedSendBuffer or AckedReceiveBuffer has to implement this interface to provide the sequence needed by the buffers.
HasSequenceNumber$ - Class in akka.remote
Increments the sequence number.
HasSequenceNumber$() - Constructor for class akka.remote.HasSequenceNumber$
 
hasSerializerId() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
hasSerializerId() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
hasSerializerId() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
 
hasSerializerId() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
hasSerializerId() - Method in class akka.remote.WireFormats.SerializedMessage
 
hasSerializerId() - Method in interface akka.remote.WireFormats.SerializedMessageOrBuilder
 
hasSupervisor() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
hasSupervisor() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
hasSupervisor() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
 
hasSystem() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
hasSystem() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
hasSystem() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
 
hasSystem() - Method in class akka.remote.WireFormats.AddressData.Builder
 
hasSystem() - Method in class akka.remote.WireFormats.AddressData
 
hasSystem() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
 
hasTimeout() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
hasTimeout() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
hasTimeout() - Method in interface akka.remote.testconductor.TestConductorProtocol.EnterBarrierOrBuilder
 
hasType() - Method in class akka.remote.ContainerFormats.Selection.Builder
 
hasType() - Method in class akka.remote.ContainerFormats.Selection
 
hasType() - Method in interface akka.remote.ContainerFormats.SelectionOrBuilder
 
hasUid() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
hasUid() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
hasUid() - Method in interface akka.remote.WireFormats.AkkaHandshakeInfoOrBuilder
 
head() - Method in class akka.contrib.pattern.WorkList
 
head() - Method in class akka.io.Tcp.CompoundWrite
 
head() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
head() - Method in class akka.util.ByteIterator
 
head() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
head() - Method in class akka.util.ByteString
 
headerAs(String, ClassTag<T>, org.apache.camel.CamelContext) - Method in class akka.camel.CamelMessage
Returns the header by given name parameter in a Try.
headers() - Method in exception akka.camel.AkkaCamelException
 
headers() - Method in class akka.camel.CamelMessage
 
headers(Set<String>) - Method in class akka.camel.CamelMessage
Returns those headers from this message whose name is contained in names.
headersToCopy() - Method in interface akka.camel.ProducerSupport
Returns the names of message headers to copy from a request message to a response message.
headersToCopyDefault() - Method in interface akka.camel.ProducerSupport
CamelMessage headers to copy by default from request message to response-message.
heapCommitted(MemoryUsage) - Method in class akka.cluster.JmxMetricsCollector
(JMX) Returns the current sum of heap memory guaranteed to be available to the JVM from all heap memory pools (in bytes).
heapMax(MemoryUsage) - Method in class akka.cluster.JmxMetricsCollector
(JMX) Returns the maximum amount of memory (in bytes) that can be used for JVM memory management.
HeapMemoryCommitted() - Method in class akka.cluster.StandardMetrics$
 
HeapMemoryCommitted() - Static method in class akka.cluster.StandardMetrics
 
HeapMemoryMax() - Method in class akka.cluster.StandardMetrics$
 
HeapMemoryMax() - Static method in class akka.cluster.StandardMetrics
 
heapMemoryUsage() - Method in class akka.cluster.JmxMetricsCollector
Current heap to be passed in to heapUsed, heapCommitted and heapMax
HeapMemoryUsed() - Method in class akka.cluster.StandardMetrics$
 
HeapMemoryUsed() - Static method in class akka.cluster.StandardMetrics
 
HeapMetricsSelector - Class in akka.cluster.routing
MetricsSelector that uses the heap metrics.
HeapMetricsSelector() - Constructor for class akka.cluster.routing.HeapMetricsSelector
 
HeapMetricsSelector$ - Class in akka.cluster.routing
MetricsSelector that uses the heap metrics.
HeapMetricsSelector$() - Constructor for class akka.cluster.routing.HeapMetricsSelector$
 
heapUsed(MemoryUsage) - Method in class akka.cluster.JmxMetricsCollector
(JMX) Returns the current sum of heap memory used from all heap memory pools (in bytes).
heartbeat(A) - Method in class akka.remote.DefaultFailureDetectorRegistry
 
heartbeat() - Method in interface akka.remote.FailureDetector
Notifies the FailureDetector that a heartbeat arrived from the monitored resource.
heartbeat(A) - Method in interface akka.remote.FailureDetectorRegistry
Records a heartbeat for a resource.
heartbeat() - Method in class akka.remote.PhiAccrualFailureDetector
 
HEARTBEAT_VALUE - Static variable in enum akka.remote.WireFormats.CommandType
 
HeartbeatExpectedResponseAfter() - Method in class akka.cluster.ClusterSettings
 
HeartbeatInterval() - Method in class akka.cluster.ClusterSettings
 
HeartbeatRequestDelay() - Method in class akka.cluster.ClusterSettings
 
HeartbeatRequestTimeToLive() - Method in class akka.cluster.ClusterSettings
 
HELLO_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
Helpers - Class in akka.util
 
Helpers() - Constructor for class akka.util.Helpers
 
Helpers$ - Class in akka.util
 
Helpers$() - Constructor for class akka.util.Helpers$
 
Helpers.Requiring<A> - Class in akka.util
Implicit class providing requiring methods.
Helpers.Requiring(A) - Constructor for class akka.util.Helpers.Requiring
 
Helpers.Requiring$ - Class in akka.util
 
Helpers.Requiring$() - Constructor for class akka.util.Helpers.Requiring$
 
hex() - Method in class akka.util.Crypt$
 
hex() - Static method in class akka.util.Crypt
 
hexify(byte[]) - Method in class akka.util.Crypt$
 
hexify(byte[]) - Static method in class akka.util.Crypt
 
highestPriorityOf(Member, Member) - Method in class akka.cluster.Member$
Picks the Member with the highest "priority" MemberStatus.
highestPriorityOf(Member, Member) - Static method in class akka.cluster.Member
Picks the Member with the highest "priority" MemberStatus.
HighWatermark - Class in akka.zeromq
The HighWatermark option shall set the high water mark for the specified socket.
HighWatermark(long) - Constructor for class akka.zeromq.HighWatermark
 
HighWatermark$ - Class in akka.zeromq
 
HighWatermark$() - Constructor for class akka.zeromq.HighWatermark$
 
Home() - Method in class akka.actor.ActorSystem.Settings
 
host() - Method in class akka.actor.Address
 
HOST_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Address
 
hostname() - Method in class akka.cluster.protobuf.msg.Address
 
Hostname() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
HOSTNAME_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.Address$
 
HOSTNAME_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.Address
 
HOSTNAME_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AddressData
 
hostPort() - Method in class akka.actor.Address
Returns a String representation formatted as:

I

i() - Method in class akka.testkit.TestActor.SetIgnore
 
id() - Method in class akka.dispatch.Dispatcher
 
id() - Method in class akka.dispatch.MessageDispatcher
Identifier of this dispatcher, corresponds to the full key of the dispatcher configuration.
Id() - Method in class akka.testkit.CallingThreadDispatcher$
 
Id() - Static method in class akka.testkit.CallingThreadDispatcher
 
id() - Method in class akka.testkit.CallingThreadDispatcher
 
id() - Method in class akka.zeromq.SocketType.ZMQSocketType
 
idCounter() - Method in class akka.osgi.aries.blueprint.NamespaceHandler
 
identifier() - Method in class akka.cluster.protobuf.ClusterMessageSerializer
 
identifier() - Method in class akka.remote.serialization.MessageContainerSerializer
 
identifier() - Method in class akka.remote.serialization.ProtobufSerializer
 
identifier() - Method in class akka.serialization.ByteArraySerializer
 
identifier() - Method in class akka.serialization.JavaSerializer
 
identifier() - Method in class akka.serialization.NullSerializer
 
identifier() - Method in interface akka.serialization.Serializer
Completely unique value to identify this implementation of Serializer, used to optimize network traffic Values from 0 to 16 is reserved for Akka internal usage
Identify - Class in akka.actor
A message all Actors will understand, that when processed will reply with ActorIdentity containing the ActorRef.
Identify(Object) - Constructor for class akka.actor.Identify
 
Identify$ - Class in akka.actor
 
Identify$() - Constructor for class akka.actor.Identify$
 
Identity - Class in akka.zeromq
Sets the identity of the specified socket.
Identity(byte[]) - Constructor for class akka.zeromq.Identity
 
identity() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its identity configuration.
identity() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its identity configuration.
Identity$ - Class in akka.zeromq
Gets the Identity value
Identity$() - Constructor for class akka.zeromq.Identity$
 
identityHashComparator(Comparator<T>) - Method in class akka.util.Helpers$
Create a comparator which will efficiently use System.identityHashCode, unless that happens to be the same for two non-equals objects, in which case the supplied “real” comparator is used; the comparator must be consistent with equals, otherwise it would not be an enhancement over the identityHashCode.
identityHashComparator(Comparator<T>) - Static method in class akka.util.Helpers
Create a comparator which will efficiently use System.identityHashCode, unless that happens to be the same for two non-equals objects, in which case the supplied “real” comparator is used; the comparator must be consistent with equals, otherwise it would not be an enhancement over the identityHashCode.
identityRouteMapper() - Method in interface akka.camel.Consumer
 
idle() - Method in class akka.contrib.pattern.ReliableProxy$
 
idle() - Static method in class akka.contrib.pattern.ReliableProxy
 
ifOff(Function0<BoxedUnit>) - Method in class akka.util.Switch
Executes the provided action and returns if the action was executed or not, if the switch is IMMEDIATELY off (i.e.
ifOffYield(Function0<T>) - Method in class akka.util.Switch
Executes the provided action and returns its value if the switch is IMMEDIATELY off (i.e.
ifOn(Function0<BoxedUnit>) - Method in class akka.util.Switch
Executes the provided action and returns if the action was executed or not, if the switch is IMMEDIATELY on (i.e.
ifOnYield(Function0<T>) - Method in class akka.util.Switch
Executes the provided action and returns its value if the switch is IMMEDIATELY on (i.e.
ignore(Object) - Method in class akka.testkit.JavaTestKit.IgnoreMsg
 
ignore() - Method in class akka.testkit.TestActor
 
ignoreMsg(PartialFunction<Object, Object>) - Method in interface akka.testkit.TestKitBase
Ignore all messages in the test actor for which the given partial function returns true.
ignoreNoMsg() - Method in class akka.testkit.JavaTestKit
Stop ignoring messages in the test actor.
ignoreNoMsg() - Method in interface akka.testkit.TestKitBase
Stop ignoring messages in the test actor.
IllegalActorStateException - Exception in akka.actor
IllegalActorStateException is thrown when a core invariant in the Actor implementation has been violated.
IllegalActorStateException$ - Class in akka.actor
 
IllegalActorStateException$() - Constructor for class akka.actor.IllegalActorStateException$
 
immutableSeq(Class<?>[]) - Method in class akka.japi.Util$
Returns an immutable.Seq representing the provided array of Classes, an overloading of the generic immutableSeq in Util, to accommodate for erasure.
immutableSeq(Object) - Method in class akka.japi.Util$
Turns an array into an immutable Scala sequence (by copying it).
immutableSeq(Iterable<T>) - Method in class akka.japi.Util$
Turns an Iterable into an immutable Scala sequence (by copying it).
immutableSeq(Class<?>[]) - Static method in class akka.japi.Util
Returns an immutable.Seq representing the provided array of Classes, an overloading of the generic immutableSeq in Util, to accommodate for erasure.
immutableSeq(Object) - Static method in class akka.japi.Util
Turns an array into an immutable Scala sequence (by copying it).
immutableSeq(Iterable<T>) - Static method in class akka.japi.Util
Turns an Iterable into an immutable Scala sequence (by copying it).
immutableSingletonSeq(T) - Method in class akka.japi.Util$
 
immutableSingletonSeq(T) - Static method in class akka.japi.Util
 
ImplicitSender - Interface in akka.testkit
 
InaccessibleQueuePath - Exception in akka.actor.mailbox.filebased.filequeue
 
InaccessibleQueuePath() - Constructor for exception akka.actor.mailbox.filebased.filequeue.InaccessibleQueuePath
 
inbound() - Method in class akka.remote.AssociatedEvent
 
inbound() - Method in class akka.remote.AssociationErrorEvent
 
inbound() - Method in interface akka.remote.AssociationEvent
 
inbound() - Method in class akka.remote.DisassociatedEvent
 
inbound() - Method in class akka.remote.transport.TestAssociationHandle
 
Inbox - Interface in akka.actor.dsl
 
inbox(ActorSystem) - Method in interface akka.actor.dsl.Inbox
Create a new actor which will internally queue up messages it gets so that they can be interrogated with the akka.actor.dsl.Inbox!.Inbox!.receive and akka.actor.dsl.Inbox!.Inbox!.select methods.
Inbox - Class in akka.actor
An Inbox is an actor-like object which is interrogated from the outside.
Inbox() - Constructor for class akka.actor.Inbox
 
Inbox$ - Class in akka.actor
 
Inbox$() - Constructor for class akka.actor.Inbox$
 
Inbox.Get - Class in akka.actor.dsl
 
Inbox.Get(Deadline, ActorRef) - Constructor for class akka.actor.dsl.Inbox.Get
 
Inbox.Get$ - Class in akka.actor.dsl
 
Inbox.Get$() - Constructor for class akka.actor.dsl.Inbox.Get$
 
Inbox.Inbox - Class in akka.actor.dsl
 
Inbox.Inbox(ActorSystem) - Constructor for class akka.actor.dsl.Inbox.Inbox
 
Inbox.InboxActor - Class in akka.actor.dsl
 
Inbox.InboxActor(int) - Constructor for class akka.actor.dsl.Inbox.InboxActor
 
Inbox.InboxExtension - Interface in akka.actor.dsl
 
Inbox.Kick$ - Class in akka.actor.dsl
 
Inbox.Kick$() - Constructor for class akka.actor.dsl.Inbox.Kick$
 
Inbox.Query - Interface in akka.actor.dsl
 
Inbox.Select - Class in akka.actor.dsl
 
Inbox.Select(Deadline, PartialFunction<Object, Object>, ActorRef) - Constructor for class akka.actor.dsl.Inbox.Select
 
Inbox.Select$ - Class in akka.actor.dsl
 
Inbox.Select$() - Constructor for class akka.actor.dsl.Inbox.Select$
 
Inbox.StartWatch - Class in akka.actor.dsl
 
Inbox.StartWatch(ActorRef) - Constructor for class akka.actor.dsl.Inbox.StartWatch
 
Inbox.StartWatch$ - Class in akka.actor.dsl
 
Inbox.StartWatch$() - Constructor for class akka.actor.dsl.Inbox.StartWatch$
 
inboxNr() - Method in interface akka.actor.dsl.Inbox.InboxExtension
 
inboxProps() - Method in interface akka.actor.dsl.Inbox.InboxExtension
 
inc() - Method in class akka.remote.SeqNo
Increments the sequence number.
include(Seq<ActorRef>) - Method in interface akka.transactor.Transactor
Include other actors in this coordinated transaction and send them the same message as received.
include(ActorRef) - Method in class akka.transactor.UntypedTransactor
For including one other actor in this coordinated transaction and sending them the same message as received.
include(ActorRef, Object) - Method in class akka.transactor.UntypedTransactor
For including one other actor in this coordinated transaction and specifying the message to send.
includeManifest() - Method in class akka.cluster.protobuf.ClusterMessageSerializer
 
includeManifest() - Method in class akka.remote.serialization.MessageContainerSerializer
 
includeManifest() - Method in class akka.remote.serialization.ProtobufSerializer
 
includeManifest() - Method in class akka.serialization.ByteArraySerializer
 
includeManifest() - Method in class akka.serialization.JavaSerializer
 
includeManifest() - Method in class akka.serialization.NullSerializer
 
includeManifest() - Method in interface akka.serialization.Serializer
Returns whether this serializer needs a manifest in the fromBinary method
includes(ThrottlerTransportAdapter.Direction) - Method in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Both$
 
includes(ThrottlerTransportAdapter.Direction) - Method in interface akka.remote.transport.ThrottlerTransportAdapter.Direction
 
includes(ThrottlerTransportAdapter.Direction) - Method in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Receive$
 
includes(ThrottlerTransportAdapter.Direction) - Method in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Send$
 
incr() - Method in class akka.actor.mailbox.filebased.filequeue.Counter
 
incr(long) - Method in class akka.actor.mailbox.filebased.filequeue.Counter
 
Index<K,V> - Class in akka.util
An implementation of a ConcurrentMultiMap Adds/remove is serialized over the specified key Reads are fully concurrent <-- el-cheapo
Index(int, Comparator<V>) - Constructor for class akka.util.Index
 
Index(int, Function2<V, V, Object>) - Constructor for class akka.util.Index
 
indexOf(byte) - Method in class akka.util.ByteIterator
 
indexOf(B) - Method in class akka.util.ByteIterator
 
indexOf(B) - Method in class akka.util.ByteString
 
indexWhere(Function1<Object, Object>) - Method in class akka.util.ByteIterator
 
indexWhere(Function1<Object, Object>) - Method in class akka.util.ByteString
 
IndirectActorProducer - Interface in akka.actor
This interface defines a class of actor creation strategies deviating from the usual default of just reflectively instantiating the Actor subclass.
Inet - Class in akka.io
 
Inet() - Constructor for class akka.io.Inet
 
Inet$ - Class in akka.io
 
Inet$() - Constructor for class akka.io.Inet$
 
Inet.SO$ - Class in akka.io
 
Inet.SO$() - Constructor for class akka.io.Inet.SO$
 
Inet.SO$.ReceiveBufferSize - Class in akka.io
Inet.SocketOption to set the SO_RCVBUF option
Inet.SO$.ReceiveBufferSize(int) - Constructor for class akka.io.Inet.SO$.ReceiveBufferSize
 
Inet.SO$.ReuseAddress - Class in akka.io
Inet.SocketOption to enable or disable SO_REUSEADDR
Inet.SO$.ReuseAddress(boolean) - Constructor for class akka.io.Inet.SO$.ReuseAddress
 
Inet.SO$.SendBufferSize - Class in akka.io
Inet.SocketOption to set the SO_SNDBUF option.
Inet.SO$.SendBufferSize(int) - Constructor for class akka.io.Inet.SO$.SendBufferSize
 
Inet.SO$.TrafficClass - Class in akka.io
Inet.SocketOption to set the traffic class or type-of-service octet in the IP header for packets sent from this socket.
Inet.SO$.TrafficClass(int) - Constructor for class akka.io.Inet.SO$.TrafficClass
 
Inet.SocketOption - Interface in akka.io
SocketOption is a package of data (from the user) and associated behavior (how to apply that to a socket).
Inet.SoForwarders - Interface in akka.io
 
Inet.SoJavaFactories - Interface in akka.io
 
info(Logging.Info) - Method in interface akka.event.Logging.StdOutLogger
 
info(String) - Method in interface akka.event.LoggingAdapter
Log message at info level.
info(String, Object) - Method in interface akka.event.LoggingAdapter
Message template with 1 replacement argument.
info(String, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 2 replacement arguments.
info(String, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 3 replacement arguments.
info(String, Object, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 4 replacement arguments.
info() - Method in class akka.remote.transport.ActorTransportAdapter.DisassociateUnderlying
 
info() - Method in class akka.remote.transport.AssociationHandle.Disassociated
 
info(String, String, String, String, int) - Method in class akka.testkit.EventFilter$
Create a filter for Info events.
info(String, String, String, String, int) - Static method in class akka.testkit.EventFilter
Create a filter for Info events.
InfoFilter - Class in akka.testkit
Filter which matches Info events, if they satisfy the given criteria: source, if given, applies a filter on the event’s origin message applies a filter on the event’s message (either with String.startsWith or Regex.findFirstIn().isDefined) If you want to match all Info events, the most efficient is to use Left("").
InfoFilter(Option<String>, Either<String, Regex>, boolean, int) - Constructor for class akka.testkit.InfoFilter
 
InfoFilter(String, String, boolean, boolean, int) - Constructor for class akka.testkit.InfoFilter
Java API: create an InfoFilter
InfoFilter$ - Class in akka.testkit
 
InfoFilter$() - Constructor for class akka.testkit.InfoFilter$
 
infoFormat() - Method in interface akka.event.Logging.StdOutLogger
 
InfoLevel() - Method in class akka.event.Logging$
 
InfoLevel() - Static method in class akka.event.Logging
 
InfoLogger() - Method in class akka.cluster.Cluster
Accessor for nested Scala object
inhabitants() - Method in class akka.dispatch.MessageDispatcher
 
init(ActorSystemImpl) - Method in interface akka.actor.ActorRefProvider
Initialization of an ActorRefProvider happens in two steps: first construction of the object with settings, eventStream, etc.
init() - Method in class akka.util.ByteString
 
initialCapacity() - Method in class akka.dispatch.UnboundedPriorityMailbox
 
initialisedReceive(org.osgi.service.log.LogService) - Method in class akka.osgi.DefaultOSGiLogger
Behaviour of the Eventhanlder that is setup (has received a LogService)
initialize() - Method in interface akka.actor.FSM
Verify existence of initial state and setup timers.
initialize() - Method in interface akka.actor.mailbox.DurableMailboxSettings
Obtain default extracted mailbox config section from userConfig and system.
initialParticipants() - Method in class akka.remote.testkit.MultiNodeSpec
TO BE DEFINED BY USER: Defines the number of participants required for starting the test.
injectCommand(Cmd) - Method in interface akka.io.PipelineInjector
Inject the given command into the connected pipeline.
injectEvent(Evt) - Method in interface akka.io.PipelineInjector
Inject the given event into the connected pipeline.
inReadBehind() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
inReadBehind() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
instance - Static variable in class akka.util.Unsafe
 
INSTRUCTION_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AkkaProtocolMessage
 
Integer() - Method in class akka.cluster.protobuf.msg.NodeMetrics.NumberType$
 
Integer_VALUE() - Method in class akka.cluster.protobuf.msg.NodeMetrics.NumberType$
 
intercept(Function0<T>, ActorSystem) - Method in class akka.testkit.EventFilter
Apply this filter while executing the given code block.
interceptAssociate(Address, Promise<AssociationHandle>) - Method in class akka.remote.transport.AbstractTransportAdapter
 
interceptAssociate(Address, Promise<AssociationHandle>) - Method in class akka.remote.transport.ActorTransportAdapter
 
interceptListen(Address, Future<Transport.AssociationEventListener>) - Method in class akka.remote.transport.AbstractTransportAdapter
 
interceptListen(Address, Future<Transport.AssociationEventListener>) - Method in class akka.remote.transport.ActorTransportAdapter
 
interfaces() - Method in class akka.actor.TypedProps
 
internal(T) - Method in class akka.dispatch.Foreach
 
internal(T) - Method in class akka.dispatch.japi.BooleanFunctionBridge
 
internal(T) - Method in class akka.dispatch.japi.CallbackBridge
 
internal(Throwable) - Method in class akka.dispatch.japi.RecoverBridge
 
internal(T) - Method in class akka.dispatch.japi.UnitFunctionBridge
 
internal(Try<T>) - Method in class akka.dispatch.OnComplete
 
internal(Throwable) - Method in class akka.dispatch.OnFailure
 
internal(T) - Method in class akka.dispatch.OnSuccess
 
internal(Throwable) - Method in class akka.dispatch.Recover
 
internalExpectMsgAllClassOf(FiniteDuration, Seq<Class<? extends T>>) - Method in interface akka.testkit.TestKitBase
 
internalExpectMsgAllConformingOf(FiniteDuration, Seq<Class<? extends T>>) - Method in interface akka.testkit.TestKitBase
 
internalGetFieldAccessorTable() - Method in class akka.remote.ContainerFormats.Selection.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.ContainerFormats.Selection
 
internalGetFieldAccessorTable() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
internalGetFieldAccessorTable() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
internalGetFieldAccessorTable() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
internalGetFieldAccessorTable() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
internalGetFieldAccessorTable() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
internalGetFieldAccessorTable() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
internalGetFieldAccessorTable() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.ActorRefData.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.ActorRefData
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AddressData.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AddressData
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.DeployData.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.DeployData
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.PropsData.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.PropsData
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.SerializedMessage
 
internalGetValueMap() - Method in class akka.cluster.protobuf.msg.MemberStatus$
 
internalGetValueMap() - Static method in class akka.cluster.protobuf.msg.MemberStatus
 
internalGetValueMap() - Method in class akka.cluster.protobuf.msg.NodeMetrics.NumberType$
 
internalGetValueMap() - Static method in enum akka.remote.ContainerFormats.PatternType
 
internalGetValueMap() - Static method in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
 
internalGetValueMap() - Static method in enum akka.remote.testconductor.TestConductorProtocol.Direction
 
internalGetValueMap() - Static method in enum akka.remote.testconductor.TestConductorProtocol.FailType
 
internalGetValueMap() - Static method in enum akka.remote.WireFormats.CommandType
 
InternetSeedGenerator - Class in akka.remote.security.provider
 
InternetSeedGenerator() - Constructor for class akka.remote.security.provider.InternetSeedGenerator
 
InternetSeedGenerator$ - Class in akka.remote.security.provider
INTERNAL API Seed generator that maintains multiple strategies for seed generation and will delegate to the best one available for the current operating environment.
InternetSeedGenerator$() - Constructor for class akka.remote.security.provider.InternetSeedGenerator$
 
intToTimeout(int) - Method in class akka.util.Timeout$
 
intToTimeout(int) - Static method in class akka.util.Timeout
 
InvalidActorNameException - Exception in akka.actor
An InvalidActorNameException is thrown when you try to convert something, usually a String, to an Actor name which doesn't validate.
InvalidActorNameException(String) - Constructor for exception akka.actor.InvalidActorNameException
 
InvalidActorNameException$ - Class in akka.actor
 
InvalidActorNameException$() - Constructor for class akka.actor.InvalidActorNameException$
 
InvalidMessageException - Exception in akka.actor
InvalidMessageException is thrown when an invalid message is sent to an Actor; Currently only null is an invalid message.
InvalidMessageException$ - Class in akka.actor
 
InvalidMessageException$() - Constructor for class akka.actor.InvalidMessageException$
 
invokeAll(Collection<? extends Callable<T>>) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
invokeAny(Collection<? extends Callable<T>>) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
IO - Class in akka.actor
IO messages and iteratees.
IO() - Constructor for class akka.actor.IO
 
IO - Class in akka.io
Entry point to Akka’s IO layer.
IO() - Constructor for class akka.io.IO
 
IO$ - Class in akka.actor
IO messages and iteratees.
IO$() - Constructor for class akka.actor.IO$
 
IO$ - Class in akka.io
Entry point to Akka’s IO layer.
IO$() - Constructor for class akka.io.IO$
 
IO.Accept - Class in akka.actor
Message to an IOManager to accept a new connection with the given IO.SocketOptions.
IO.Accept(IO.SocketHandle, IO.ServerHandle, Seq<IO.SocketOption>) - Constructor for class akka.actor.IO.Accept
 
IO.Accept$ - Class in akka.actor
 
IO.Accept$() - Constructor for class akka.actor.IO.Accept$
 
IO.Backlog - Class in akka.actor
IO.ServerSocketOption to set the maximum backlog of connections.
IO.Backlog(int) - Constructor for class akka.actor.IO.Backlog
 
IO.Backlog$ - Class in akka.actor
 
IO.Backlog$() - Constructor for class akka.actor.IO.Backlog$
 
IO.Chunk - Class in akka.actor
Part of an IO.Input stream that contains a chunk of bytes.
IO.Chunk(ByteString) - Constructor for class akka.actor.IO.Chunk
 
IO.Chunk$ - Class in akka.actor
 
IO.Chunk$() - Constructor for class akka.actor.IO.Chunk$
 
IO.Close - Class in akka.actor
Message to an IOManager to close the Channel.
IO.Close(IO.Handle) - Constructor for class akka.actor.IO.Close
 
IO.Close$ - Class in akka.actor
 
IO.Close$() - Constructor for class akka.actor.IO.Close$
 
IO.Closed - Class in akka.actor
Message from an IOManager that the Channel has closed.
IO.Closed(IO.Handle, IO.Input) - Constructor for class akka.actor.IO.Closed
 
IO.Closed$ - Class in akka.actor
 
IO.Closed$() - Constructor for class akka.actor.IO.Closed$
 
IO.Connect - Class in akka.actor
Message to an IOManager to create a SocketChannel connected to the provided address with the given IO.SocketOptions.
IO.Connect(IO.SocketHandle, SocketAddress, Seq<IO.SocketOption>) - Constructor for class akka.actor.IO.Connect
 
IO.Connect$ - Class in akka.actor
 
IO.Connect$() - Constructor for class akka.actor.IO.Connect$
 
IO.Connected - Class in akka.actor
Message from an IOManager that the SocketChannel has successfully connected.
IO.Connected(IO.SocketHandle, SocketAddress) - Constructor for class akka.actor.IO.Connected
 
IO.Connected$ - Class in akka.actor
 
IO.Connected$() - Constructor for class akka.actor.IO.Connected$
 
IO.DivergentIterateeException - Exception in akka.actor
 
IO.DivergentIterateeException() - Constructor for exception akka.actor.IO.DivergentIterateeException
 
IO.Done<A> - Class in akka.actor
An Iteratee representing a result, usually returned by the successful completion of an Iteratee.
IO.Done(A) - Constructor for class akka.actor.IO.Done
 
IO.Done$ - Class in akka.actor
 
IO.Done$() - Constructor for class akka.actor.IO.Done$
 
IO.EOF$ - Class in akka.actor
Part of an IO.Input stream that represents the end of the stream.
IO.EOF$() - Constructor for class akka.actor.IO.EOF$
 
IO.Error - Class in akka.actor
Part of an IO.Input stream that represents an error in the stream.
IO.Error(Throwable) - Constructor for class akka.actor.IO.Error
 
IO.Error$ - Class in akka.actor
 
IO.Error$() - Constructor for class akka.actor.IO.Error$
 
IO.Extension - Interface in akka.io
 
IO.Failure - Class in akka.actor
An IO.Iteratee that represents an erronous end state.
IO.Failure(Throwable) - Constructor for class akka.actor.IO.Failure
 
IO.Failure$ - Class in akka.actor
 
IO.Failure$() - Constructor for class akka.actor.IO.Failure$
 
IO.Handle - Interface in akka.actor
An immutable handle to a Java NIO Channel.
IO.Input - Interface in akka.actor
Represents part of a stream of bytes that can be processed by an IO.Iteratee.
IO.IOMessage - Interface in akka.actor
Messages used to communicate with an IOManager.
IO.Iteratee<A> - Class in akka.actor
A basic Iteratee implementation of Oleg's Iteratee (http://okmij.org/ftp/Streams.html).
IO.Iteratee() - Constructor for class akka.actor.IO.Iteratee
 
IO.Iteratee$ - Class in akka.actor
 
IO.Iteratee$() - Constructor for class akka.actor.IO.Iteratee$
 
IO.IterateeRef<A> - Interface in akka.actor
A mutable reference to an Iteratee designed for use within an Actor.
IO.IterateeRef$ - Class in akka.actor
 
IO.IterateeRef$() - Constructor for class akka.actor.IO.IterateeRef$
 
IO.IterateeRef.Map<K,V> - Class in akka.actor
A mutable Map to contain multiple IterateeRefs.
IO.IterateeRef.Map$ - Class in akka.actor
 
IO.IterateeRef.Map$() - Constructor for class akka.actor.IO.IterateeRef.Map$
 
IO.IterateeRefAsync<A> - Class in akka.actor
A mutable reference to an IO.Iteratee.
IO.IterateeRefAsync(IO.Iteratee<A>, ExecutionContext) - Constructor for class akka.actor.IO.IterateeRefAsync
 
IO.IterateeRefSync<A> - Class in akka.actor
A mutable reference to an IO.Iteratee.
IO.IterateeRefSync(IO.Iteratee<A>) - Constructor for class akka.actor.IO.IterateeRefSync
 
IO.KeepAlive - Class in akka.actor
IO.SocketOption to enable or disable SO_KEEPALIVE
IO.KeepAlive(boolean) - Constructor for class akka.actor.IO.KeepAlive
 
IO.KeepAlive$ - Class in akka.actor
 
IO.KeepAlive$() - Constructor for class akka.actor.IO.KeepAlive$
 
IO.Listen - Class in akka.actor
Message to an IOManager to create a ServerSocketChannel listening on the provided address with the given IO.ServerSocketOptions.
IO.Listen(IO.ServerHandle, SocketAddress, Seq<IO.ServerSocketOption>) - Constructor for class akka.actor.IO.Listen
 
IO.Listen$ - Class in akka.actor
 
IO.Listen$() - Constructor for class akka.actor.IO.Listen$
 
IO.Listening - Class in akka.actor
Message from an IOManager that the ServerSocketChannel is now listening for connections.
IO.Listening(IO.ServerHandle, SocketAddress) - Constructor for class akka.actor.IO.Listening
 
IO.Listening$ - Class in akka.actor
 
IO.Listening$() - Constructor for class akka.actor.IO.Listening$
 
IO.NewClient - Class in akka.actor
Message from an IOManager that a new connection has been made to the ServerSocketChannel and needs to be accepted.
IO.NewClient(IO.ServerHandle) - Constructor for class akka.actor.IO.NewClient
 
IO.NewClient$ - Class in akka.actor
 
IO.NewClient$() - Constructor for class akka.actor.IO.NewClient$
 
IO.Next<A> - Class in akka.actor
An IO.Iteratee that still requires more input to calculate it's result.
IO.Next(Function1<IO.Input, Tuple2<IO.Iteratee<A>, IO.Input>>) - Constructor for class akka.actor.IO.Next
 
IO.Next$ - Class in akka.actor
 
IO.Next$() - Constructor for class akka.actor.IO.Next$
 
IO.OOBInline - Class in akka.actor
IO.SocketOption to enable or disable OOBINLINE (receipt of TCP urgent data) By default, this option is disabled and TCP urgent data received on a IO.SocketHandle is silently discarded.
IO.OOBInline(boolean) - Constructor for class akka.actor.IO.OOBInline
 
IO.OOBInline$ - Class in akka.actor
 
IO.OOBInline$() - Constructor for class akka.actor.IO.OOBInline$
 
IO.PerformancePreferences - Class in akka.actor
IO.SocketOption to set performance preferences for this IO.SocketHandle.
IO.PerformancePreferences(int, int, int) - Constructor for class akka.actor.IO.PerformancePreferences
 
IO.PerformancePreferences$ - Class in akka.actor
 
IO.PerformancePreferences$() - Constructor for class akka.actor.IO.PerformancePreferences$
 
IO.Read - Class in akka.actor
Message from an IOManager that contains bytes read from the SocketChannel.
IO.Read(IO.ReadHandle, ByteString) - Constructor for class akka.actor.IO.Read
 
IO.Read$ - Class in akka.actor
 
IO.Read$() - Constructor for class akka.actor.IO.Read$
 
IO.ReadHandle - Interface in akka.actor
A IO.Handle to a ReadableByteChannel.
IO.ReceiveBufferSize - Class in akka.actor
IO.SocketOption to set the SO_RCVBUF option for this IO.SocketHandle.
IO.ReceiveBufferSize(int) - Constructor for class akka.actor.IO.ReceiveBufferSize
 
IO.ReceiveBufferSize$ - Class in akka.actor
 
IO.ReceiveBufferSize$() - Constructor for class akka.actor.IO.ReceiveBufferSize$
 
IO.ReuseAddress - Class in akka.actor
IO.SocketOption to enable or disable SO_REUSEADDR
IO.ReuseAddress(boolean) - Constructor for class akka.actor.IO.ReuseAddress
 
IO.ReuseAddress$ - Class in akka.actor
 
IO.ReuseAddress$() - Constructor for class akka.actor.IO.ReuseAddress$
 
IO.SendBufferSize - Class in akka.actor
IO.SocketOption to set the SO_SNDBUF option for this IO.SocketHandle.
IO.SendBufferSize(int) - Constructor for class akka.actor.IO.SendBufferSize
 
IO.SendBufferSize$ - Class in akka.actor
 
IO.SendBufferSize$() - Constructor for class akka.actor.IO.SendBufferSize$
 
IO.ServerHandle - Class in akka.actor
A IO.Handle to a ServerSocketChannel.
IO.ServerHandle(ActorRef, ActorRef, UUID) - Constructor for class akka.actor.IO.ServerHandle
 
IO.ServerHandle$ - Class in akka.actor
 
IO.ServerHandle$() - Constructor for class akka.actor.IO.ServerHandle$
 
IO.ServerSocketOption - Interface in akka.actor
Options to be set when setting up a IO.ServerHandle
IO.SocketHandle - Class in akka.actor
A IO.Handle to a SocketChannel.
IO.SocketHandle(ActorRef, ActorRef, UUID) - Constructor for class akka.actor.IO.SocketHandle
 
IO.SocketHandle$ - Class in akka.actor
 
IO.SocketHandle$() - Constructor for class akka.actor.IO.SocketHandle$
 
IO.SocketOption - Interface in akka.actor
Options to be set when setting up a IO.SocketHandle
IO.SoLinger - Class in akka.actor
IO.SocketOption to enable or disable SO_LINGER with the specified linger time in seconds.
IO.SoLinger(Option<Object>) - Constructor for class akka.actor.IO.SoLinger
 
IO.SoLinger$ - Class in akka.actor
 
IO.SoLinger$() - Constructor for class akka.actor.IO.SoLinger$
 
IO.SoTimeout - Class in akka.actor
IO.SocketOption to set SO_TIMEOUT to the specified timeout rounded down to the nearest millisecond.
IO.SoTimeout(Duration) - Constructor for class akka.actor.IO.SoTimeout
 
IO.SoTimeout$ - Class in akka.actor
 
IO.SoTimeout$() - Constructor for class akka.actor.IO.SoTimeout$
 
IO.TcpNoDelay - Class in akka.actor
IO.SocketOption to enable or disable TCP_NODELAY (disable or enable Nagle's algorithm)
IO.TcpNoDelay(boolean) - Constructor for class akka.actor.IO.TcpNoDelay
 
IO.TcpNoDelay$ - Class in akka.actor
 
IO.TcpNoDelay$() - Constructor for class akka.actor.IO.TcpNoDelay$
 
IO.TrafficClass - Class in akka.actor
IO.SocketOption to set the traffic class or type-of-service octet in the IP header for packets sent from this IO.SocketHandle.
IO.TrafficClass(int) - Constructor for class akka.actor.IO.TrafficClass
 
IO.TrafficClass$ - Class in akka.actor
 
IO.TrafficClass$() - Constructor for class akka.actor.IO.TrafficClass$
 
IO.Write - Class in akka.actor
Message to an IOManager to write to the SocketChannel.
IO.Write(IO.WriteHandle, ByteString) - Constructor for class akka.actor.IO.Write
 
IO.Write$ - Class in akka.actor
 
IO.Write$() - Constructor for class akka.actor.IO.Write$
 
IO.WriteHandle - Interface in akka.actor
A IO.Handle to a WritableByteChannel.
ioManager() - Method in interface akka.actor.IO.Handle
 
ioManager() - Method in class akka.actor.IO.ServerHandle
 
ioManager() - Method in class akka.actor.IO.SocketHandle
 
IOManager - Class in akka.actor
IOManager contains a reference to the IOManagerActor for an ActorSystem.
IOManager$ - Class in akka.actor
Create a SocketChannel connecting to a host and port.
IOManager$() - Constructor for class akka.actor.IOManager$
 
IOManager.Settings - Class in akka.actor
 
IOManager.Settings(int, int, int) - Constructor for class akka.actor.IOManager.Settings
 
IOManager.Settings$ - Class in akka.actor
 
IOManager.Settings$() - Constructor for class akka.actor.IOManager.Settings$
 
IOManagerActor - Class in akka.actor
An Actor that performs IO using a Java NIO Selector.
IOManagerActor(IOManager.Settings) - Constructor for class akka.actor.IOManagerActor
 
isAborted() - Method in class akka.io.Tcp.Aborted$
 
isAborted() - Method in interface akka.io.Tcp.ConnectionClosed
true iff the connection has been closed in response to an Abort command.
isAvailable() - Method in interface akka.cluster.ClusterNodeMBean
Returns true if the node is not unreachable and not Down and not Removed.
isAvailable(A) - Method in class akka.remote.DefaultFailureDetectorRegistry
 
isAvailable() - Method in interface akka.remote.FailureDetector
Returns true if the resource is considered to be up and healthy and returns false otherwise.
isAvailable(A) - Method in interface akka.remote.FailureDetectorRegistry
Returns true if the resource is considered to be up and healthy and returns false otherwise.
isAvailable() - Method in class akka.remote.PhiAccrualFailureDetector
 
isBatchable() - Method in class akka.dispatch.TaskInvocation
 
isCancelled() - Method in interface akka.actor.Cancellable
Returns true if and only if this Cancellable has been successfully cancelled
isCancelled() - Method in class akka.actor.LightArrayRevolverScheduler.TaskHolder
 
isCancelled() - Method in interface akka.util.internal.Timeout
Deprecated. Returns true if and only if the TimerTask associated with this handle has been cancelled.
isClosed() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
isCompact() - Method in class akka.util.ByteString.ByteString1
 
isCompact() - Method in class akka.util.ByteString.ByteStrings
 
isCompact() - Method in class akka.util.ByteString
Check whether this ByteString is compact in memory.
isCompact() - Method in class akka.util.CompactByteString
 
isConfirmed() - Method in class akka.io.Tcp.ConfirmedClosed$
 
isConfirmed() - Method in interface akka.io.Tcp.ConnectionClosed
true iff the connection has been fully closed in response to a ConfirmedClose command.
isDebugEnabled() - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
isDebugEnabled() - Method in class akka.event.BusLogging
 
isDebugEnabled() - Method in interface akka.event.LoggingAdapter
 
isDebugEnabled() - Method in class akka.event.NoLogging$
 
isDebugEnabled() - Static method in class akka.event.NoLogging
 
isDefined() - Method in class akka.japi.Option
 
isDefinedAt(Object) - Method in class akka.actor.Actor.emptyBehavior$
 
isDefinedAt(Object) - Method in class akka.actor.FSM.NullFunction$
 
isDefinedAt(T) - Method in class akka.dispatch.japi.CallbackBridge
 
isDefinedAt(Throwable) - Method in class akka.dispatch.japi.RecoverBridge
 
isDefinedAt(Object) - Method in class akka.event.LoggingReceive
 
isDefinedAt(A) - Method in class akka.japi.JavaPartialFunction
 
isDefinedAt(Object) - Method in class akka.routing.ConsistentHashingRouter.emptyConsistentHashMapping$
 
isDeleted() - Method in class akka.contrib.pattern.WorkList.Entry
 
isEmpty() - Method in class akka.actor.WriteBuffer
 
isEmpty() - Method in class akka.dispatch.AbstractNodeQueue
 
isEmpty() - Method in class akka.japi.Option
 
isEmpty() - Method in class akka.japi.Option.Some
 
isEmpty() - Method in class akka.routing.ConsistentHash
Is the node ring empty, i.e.
isEmpty() - Method in class akka.util.BoundedBlockingQueue
 
isEmpty() - Method in class akka.util.Index
 
isEnabled(Logging.LogLevel) - Method in interface akka.event.LoggingAdapter
 
isEqual(K, K) - Method in interface akka.util.Subclassification
True if and only if x and y are of the same class.
isErrorClosed() - Method in interface akka.io.Tcp.ConnectionClosed
true iff the connection has been closed due to an IO error.
isErrorClosed() - Method in class akka.io.Tcp.ErrorClosed
 
isErrorEnabled() - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
isErrorEnabled() - Method in class akka.event.BusLogging
 
isErrorEnabled() - Method in interface akka.event.LoggingAdapter
 
isErrorEnabled() - Method in class akka.event.NoLogging$
 
isErrorEnabled() - Static method in class akka.event.NoLogging
 
isExpired() - Method in interface akka.util.internal.Timeout
Deprecated. Returns true if and only if the TimerTask associated with this handle has been expired.
isInbound() - Method in interface akka.remote.AssociationEvent
 
isInfoEnabled() - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
isInfoEnabled() - Method in class akka.event.BusLogging
 
isInfoEnabled() - Method in interface akka.event.LoggingAdapter
 
isInfoEnabled() - Method in class akka.event.NoLogging$
 
isInfoEnabled() - Static method in class akka.event.NoLogging
 
isInitialized() - Method in class akka.cluster.protobuf.msg.Address
 
isInitialized() - Method in class akka.cluster.protobuf.msg.Empty
 
isInitialized() - Method in class akka.cluster.protobuf.msg.Gossip
 
isInitialized() - Method in class akka.cluster.protobuf.msg.GossipEnvelope
 
isInitialized() - Method in class akka.cluster.protobuf.msg.GossipOverview
 
isInitialized() - Method in class akka.cluster.protobuf.msg.GossipOverview.Seen
 
isInitialized() - Method in class akka.cluster.protobuf.msg.GossipStatus
 
isInitialized() - Method in class akka.cluster.protobuf.msg.Join
 
isInitialized() - Method in class akka.cluster.protobuf.msg.Member
 
isInitialized() - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
isInitialized() - Method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope
 
isInitialized() - Method in class akka.cluster.protobuf.msg.NodeMetrics.EWMA
 
isInitialized() - Method in class akka.cluster.protobuf.msg.NodeMetrics
 
isInitialized() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Metric
 
isInitialized() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number
 
isInitialized() - Method in class akka.cluster.protobuf.msg.UniqueAddress
 
isInitialized() - Method in class akka.cluster.protobuf.msg.VectorClock
 
isInitialized() - Method in class akka.cluster.protobuf.msg.VectorClock.Version
 
isInitialized() - Method in class akka.cluster.protobuf.msg.Welcome
 
isInitialized() - Method in class akka.remote.ContainerFormats.Selection.Builder
 
isInitialized() - Method in class akka.remote.ContainerFormats.Selection
 
isInitialized() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
isInitialized() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
isInitialized() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
isInitialized() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
isInitialized() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
isInitialized() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
isInitialized() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
isInitialized() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
isInitialized() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
isInitialized() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
isInitialized() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
isInitialized() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
isInitialized() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
isInitialized() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
isInitialized() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
isInitialized() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
isInitialized() - Method in class akka.remote.WireFormats.ActorRefData.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.ActorRefData
 
isInitialized() - Method in class akka.remote.WireFormats.AddressData.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.AddressData
 
isInitialized() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
isInitialized() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
isInitialized() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
isInitialized() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
isInitialized() - Method in class akka.remote.WireFormats.DeployData.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.DeployData
 
isInitialized() - Method in class akka.remote.WireFormats.PropsData.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.PropsData
 
isInitialized() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
isInitialized() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.SerializedMessage
 
isMonitoring(A) - Method in class akka.remote.DefaultFailureDetectorRegistry
 
isMonitoring() - Method in interface akka.remote.FailureDetector
Returns true if the failure detector has received any heartbeats and started monitoring of the resource.
isMonitoring(A) - Method in interface akka.remote.FailureDetectorRegistry
Returns true if the failure detector has received any heartbeats and started monitoring of the resource.
isMonitoring() - Method in class akka.remote.PhiAccrualFailureDetector
 
isNode(Seq<RoleName>) - Method in class akka.remote.testkit.MultiNodeSpec
Verify that the running node matches one of the given nodes
isOff() - Method in class akka.util.Switch
Returns whether the switch is IMMEDDIATELY off (no locking)
isOlderThan(Member) - Method in class akka.cluster.Member
Is this member older, has been part of cluster longer, than another member.
isOn() - Method in class akka.util.Switch
Returns whether the switch is IMMEDIATELY on (no locking)
isOneWay() - Method in class akka.actor.TypedActor.MethodCall
 
isOneway() - Method in class akka.camel.javaapi.UntypedProducerActor
If set to false (default), this producer expects a response message from the Camel endpoint.
isOpen() - Method in class akka.testkit.TestLatch
 
isPeerClosed() - Method in interface akka.io.Tcp.ConnectionClosed
true iff the connection has been closed by the peer; in case keepOpenOnPeerClosed is in effect as per the Tcp.Register command, this connection’s reading half is now closed.
isPeerClosed() - Method in class akka.io.Tcp.PeerClosed$
 
isProcessingMessage(ActorRef) - Method in interface akka.routing.SmallestMailboxLike
Returns true if the actor is currently processing a message.
isReplaying() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
isResponsibleFor(Address) - Method in class akka.remote.transport.AbstractTransportAdapter
 
isResponsibleFor(Address) - Method in class akka.remote.transport.netty.NettyTransport
 
isResponsibleFor(Address) - Method in class akka.remote.transport.TestTransport
 
isResponsibleFor(Address) - Method in interface akka.remote.transport.Transport
A function that decides whether the specific transport instance is responsible for delivering to a given address.
isRouteesPathDefined() - Method in class akka.cluster.routing.ClusterRouterSettings
 
isShutdown() - Method in interface akka.dispatch.ExecutorServiceDelegate
 
isSingleton() - Method in interface akka.cluster.ClusterNodeMBean
Does the cluster consist of only one member?
isSmooth() - Method in class akka.cluster.Metric
 
isStateTimerActive() - Method in interface akka.actor.FSM
INTERNAL API, used for testing.
isStateTimerActive() - Method in class akka.testkit.TestFSMRef
Proxy for FSM.timerActive_?.
isSubclass(K, K) - Method in interface akka.util.Subclassification
True if and only if x is a subclass of y; equal classes must be considered sub-classes!
isSuccessor(SeqNo) - Method in class akka.remote.SeqNo
Checks if this sequence number is an immediate successor of the provided one.
isSuspended(ActorRef) - Method in interface akka.routing.SmallestMailboxLike
Returns true if the actor is currently suspended.
isTerminated() - Method in class akka.actor.ActorRef
Is the actor shut down? The contract is that if this method returns true, then it will never be false again.
isTerminated() - Method in class akka.actor.ActorSystem
Query the termination status: if it returns true, all callbacks have run and the ActorSystem has been fully stopped, i.e.
isTerminated() - Method in class akka.cluster.Cluster
Returns true if this cluster instance has be shutdown.
isTerminated() - Method in class akka.contrib.pattern.ClusterReceptionistExtension
Returns true if this member is not tagged with the role configured for the receptionist.
isTerminated() - Method in class akka.contrib.pattern.DistributedPubSubExtension
Returns true if this member is not tagged with the role configured for the mediator.
isTerminated() - Method in interface akka.dispatch.ExecutorServiceDelegate
 
isThroughputDeadlineTimeDefined() - Method in class akka.dispatch.MessageDispatcher
INTERNAL API
isTimeForResize(long) - Method in class akka.routing.DefaultResizer
 
isTimeForResize(long) - Method in interface akka.routing.Resizer
Is it time for resizing.
isTimerActive(String) - Method in interface akka.actor.FSM
Inquire whether the named timer is still active.
isTimerActive(String) - Method in class akka.testkit.TestFSMRef
Proxy for FSM.isTimerActive.
isTypedActor(Object) - Method in class akka.actor.ContextualTypedActorFactory
 
isTypedActor(Object) - Method in class akka.actor.TypedActorExtension
Returns wether the supplied AnyRef is a TypedActor proxy or not
isTypedActor(Object) - Method in interface akka.actor.TypedActorFactory
Returns wether the supplied AnyRef is a TypedActor proxy or not
isWarningEnabled() - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
isWarningEnabled() - Method in class akka.event.BusLogging
 
isWarningEnabled() - Method in interface akka.event.LoggingAdapter
 
isWarningEnabled() - Method in class akka.event.NoLogging$
 
isWarningEnabled() - Static method in class akka.event.NoLogging
 
isWindows() - Method in class akka.util.Helpers$
 
isWindows() - Static method in class akka.util.Helpers
 
item() - Method in class akka.actor.mailbox.filebased.filequeue.JournalItem.Add
 
iterator() - Method in class akka.actor.IO.IterateeRef.Map
 
iterator() - Method in class akka.io.Tcp.CompoundWrite
 
iterator() - Method in class akka.japi.Option
 
iterator() - Method in class akka.util.BoundedBlockingQueue
 
iterator() - Method in class akka.util.ByteString.ByteString1
 
iterator() - Method in class akka.util.ByteString.ByteString1C
 
iterator() - Method in class akka.util.ByteString.ByteStrings
 
iterator() - Method in class akka.util.ByteString
 

J

japi - Class in akka.dispatch
This class contains bridge classes between Scala and Java.
japi() - Constructor for class akka.dispatch.japi
 
JAPI - Class in akka.japi
 
JAPI() - Constructor for class akka.japi.JAPI
 
japi$ - Class in akka.dispatch
This class contains bridge classes between Scala and Java.
japi$() - Constructor for class akka.dispatch.japi$
 
japi.BooleanFunctionBridge<T> - Class in akka.dispatch
 
japi.BooleanFunctionBridge() - Constructor for class akka.dispatch.japi.BooleanFunctionBridge
 
japi.CallbackBridge<T> - Class in akka.dispatch
 
japi.CallbackBridge() - Constructor for class akka.dispatch.japi.CallbackBridge
 
japi.RecoverBridge<T> - Class in akka.dispatch
 
japi.RecoverBridge() - Constructor for class akka.dispatch.japi.RecoverBridge
 
japi.UnitFunctionBridge<T> - Class in akka.dispatch
 
japi.UnitFunctionBridge() - Constructor for class akka.dispatch.japi.UnitFunctionBridge
 
java2ScalaOption(Option<A>) - Method in class akka.japi.Option$
 
java2ScalaOption(Option<A>) - Static method in class akka.japi.Option
 
JavaLogger - Class in akka.contrib.jul
java.util.logging logger.
JavaLogger() - Constructor for class akka.contrib.jul.JavaLogger
 
JavaLogging - Interface in akka.contrib.jul
Makes the Akka Logging API available as the log field, using java.util.logging as the backend.
JavaLoggingAdapter - Interface in akka.contrib.jul
 
JavaLoggingEventHandler - Class in akka.contrib.jul
 
JavaLoggingEventHandler() - Constructor for class akka.contrib.jul.JavaLoggingEventHandler
 
JavaPartialFunction<A,B> - Class in akka.japi
Helper for implementing a *pure* partial function: it will possibly be invoked multiple times for a single “application”, because its only abstract method is used for both isDefinedAt() and apply(); the former is mapped to isCheck == true and the latter to isCheck == false for those cases where this is important to know.
JavaPartialFunction() - Constructor for class akka.japi.JavaPartialFunction
 
JavaPartialFunction$ - Class in akka.japi
 
JavaPartialFunction$() - Constructor for class akka.japi.JavaPartialFunction$
 
JavaPartialFunction.NoMatch$ - Exception in akka.japi
 
JavaPartialFunction.NoMatch$() - Constructor for exception akka.japi.JavaPartialFunction.NoMatch$
 
JavaPartialFunction.NoMatchException - Exception in akka.japi
 
JavaPartialFunction.NoMatchException() - Constructor for exception akka.japi.JavaPartialFunction.NoMatchException
 
JavaSerializer - Class in akka.serialization
This Serializer uses standard Java Serialization
JavaSerializer(ExtendedActorSystem) - Constructor for class akka.serialization.JavaSerializer
 
JavaSerializer$ - Class in akka.serialization
 
JavaSerializer$() - Constructor for class akka.serialization.JavaSerializer$
 
JavaSerializer.CurrentSystem - Class in akka.serialization
 
JavaSerializer.CurrentSystem() - Constructor for class akka.serialization.JavaSerializer.CurrentSystem
 
JavaTestKit - Class in akka.testkit
Java API: Test kit for testing actors.
JavaTestKit(ActorSystem) - Constructor for class akka.testkit.JavaTestKit
 
JavaTestKit.AwaitAssert - Class in akka.testkit
Await until the given assert does not throw an exception or the timeout expires, whichever comes first.
JavaTestKit.AwaitAssert() - Constructor for class akka.testkit.JavaTestKit.AwaitAssert
 
JavaTestKit.AwaitAssert(Duration) - Constructor for class akka.testkit.JavaTestKit.AwaitAssert
 
JavaTestKit.AwaitAssert(Duration, Duration) - Constructor for class akka.testkit.JavaTestKit.AwaitAssert
 
JavaTestKit.AwaitCond - Class in akka.testkit
Await until the given condition evaluates to true or the timeout expires, whichever comes first.
JavaTestKit.AwaitCond() - Constructor for class akka.testkit.JavaTestKit.AwaitCond
 
JavaTestKit.AwaitCond(Duration) - Constructor for class akka.testkit.JavaTestKit.AwaitCond
 
JavaTestKit.AwaitCond(Duration, Duration) - Constructor for class akka.testkit.JavaTestKit.AwaitCond
 
JavaTestKit.AwaitCond(Duration, Duration, String) - Constructor for class akka.testkit.JavaTestKit.AwaitCond
 
JavaTestKit.EventFilter<T> - Class in akka.testkit
Facilities for selectively filtering out expected events from logging so that you can keep your test run’s console output clean and do not miss real error messages.
JavaTestKit.EventFilter(Class<?>) - Constructor for class akka.testkit.JavaTestKit.EventFilter
 
JavaTestKit.ExpectMsg<T> - Class in akka.testkit
Receive one message from the test actor and assert that the given matching function accepts it.
JavaTestKit.ExpectMsg(String) - Constructor for class akka.testkit.JavaTestKit.ExpectMsg
 
JavaTestKit.ExpectMsg(Duration, String) - Constructor for class akka.testkit.JavaTestKit.ExpectMsg
 
JavaTestKit.IgnoreMsg - Class in akka.testkit
Ignore all messages in the test actor for which the given function returns true.
JavaTestKit.IgnoreMsg() - Constructor for class akka.testkit.JavaTestKit.IgnoreMsg
 
JavaTestKit.ReceiveWhile<T> - Class in akka.testkit
Receive a series of messages until one does not match the given match function or the idle timeout is met (disabled by default) or the overall maximum duration is elapsed.
JavaTestKit.ReceiveWhile(Class<T>) - Constructor for class akka.testkit.JavaTestKit.ReceiveWhile
 
JavaTestKit.ReceiveWhile(Class<T>, Duration) - Constructor for class akka.testkit.JavaTestKit.ReceiveWhile
 
JavaTestKit.ReceiveWhile(Class<T>, Duration, int) - Constructor for class akka.testkit.JavaTestKit.ReceiveWhile
 
JavaTestKit.ReceiveWhile(Class<T>, Duration, Duration, int) - Constructor for class akka.testkit.JavaTestKit.ReceiveWhile
 
JavaTestKit.Within - Class in akka.testkit
Execute code block while bounding its execution time between min and max.
JavaTestKit.Within(FiniteDuration) - Constructor for class akka.testkit.JavaTestKit.Within
 
JavaTestKit.Within(FiniteDuration, FiniteDuration) - Constructor for class akka.testkit.JavaTestKit.Within
 
JavaTestKitSpec - Class in akka.testkit
 
JavaTestKitSpec() - Constructor for class akka.testkit.JavaTestKitSpec
 
JmxEnabled() - Method in class akka.cluster.ClusterSettings
 
JmxMetricsCollector - Class in akka.cluster
Loads JVM and system metrics through JMX monitoring beans.
JmxMetricsCollector(Address, double) - Constructor for class akka.cluster.JmxMetricsCollector
 
JmxMetricsCollector(ActorSystem) - Constructor for class akka.cluster.JmxMetricsCollector
This constructor is used when creating an instance from configured FQCN
JmxStatistics() - Method in class akka.camel.CamelSettings
 
join(Address) - Method in class akka.cluster.Cluster
Try to join this cluster node with the node specified by 'address'.
join(String) - Method in interface akka.cluster.ClusterNodeMBean
Try to join this cluster node with the node specified by 'address'.
Join - Class in akka.cluster.protobuf.msg
 
Join(UniqueAddress, Seq<String>) - Constructor for class akka.cluster.protobuf.msg.Join
 
Join$ - Class in akka.cluster.protobuf.msg
 
Join$() - Constructor for class akka.cluster.protobuf.msg.Join$
 
joining() - Method in class akka.cluster.MemberStatus$
Java API: retrieve the “joining” status singleton
joining() - Static method in class akka.cluster.MemberStatus
Java API: retrieve the “joining” status singleton
Joining() - Method in class akka.cluster.protobuf.msg.MemberStatus$
 
Joining() - Static method in class akka.cluster.protobuf.msg.MemberStatus
 
Joining_VALUE() - Method in class akka.cluster.protobuf.msg.MemberStatus$
 
Joining_VALUE() - Static method in class akka.cluster.protobuf.msg.MemberStatus
 
joinSeedNodes(Seq<Address>) - Method in class akka.cluster.Cluster
Join the specified seed nodes without defining them in config.
Journal - Class in akka.actor.mailbox.filebased.filequeue
Codes for working with the journal file for a PersistentQueue.
Journal(String, Function0<Object>, LoggingAdapter) - Constructor for class akka.actor.mailbox.filebased.filequeue.Journal
 
JournalItem - Interface in akka.actor.mailbox.filebased.filequeue
 
JournalItem$ - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem$() - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem$
 
JournalItem.Add - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.Add(QItem) - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.Add
 
JournalItem.Add$ - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.Add$() - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.Add$
 
JournalItem.ConfirmRemove - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.ConfirmRemove(int) - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.ConfirmRemove
 
JournalItem.ConfirmRemove$ - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.ConfirmRemove$() - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.ConfirmRemove$
 
JournalItem.EndOfFile$ - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.EndOfFile$() - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.EndOfFile$
 
JournalItem.Remove$ - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.Remove$() - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.Remove$
 
JournalItem.RemoveTentative$ - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.RemoveTentative$() - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.RemoveTentative$
 
JournalItem.SavedXid - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.SavedXid(int) - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.SavedXid
 
JournalItem.SavedXid$ - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.SavedXid$() - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.SavedXid$
 
JournalItem.Unremove - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.Unremove(int) - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.Unremove
 
JournalItem.Unremove$ - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.Unremove$() - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.Unremove$
 
journalSize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
JSerializer - Class in akka.serialization
Java API for creating a Serializer: make sure to include a constructor which takes exactly one argument of type ExtendedActorSystem, because that is the preferred constructor which will be invoked when reflectively instantiating the JSerializer (also possible with empty constructor).
JSerializer() - Constructor for class akka.serialization.JSerializer
 
JvmExitOnFatalError() - Method in class akka.actor.ActorSystem.Settings
 

K

keepAlive(boolean) - Method in class akka.io.TcpSO$
Inet.SocketOption to enable or disable SO_KEEPALIVE
keepAlive(boolean) - Static method in class akka.io.TcpSO
Inet.SocketOption to enable or disable SO_KEEPALIVE
KeepJournal() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
keepJournal() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
keepJournal() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
keepOpenOnPeerClosed() - Method in class akka.io.Tcp.Register
 
keepRunning() - Method in class akka.testkit.TestActor.AutoPilot
 
key() - Method in class akka.remote.transport.TestAssociationHandle
Key used in TestTransport.AssociationRegistry to identify associations.
keys() - Method in class akka.util.Index
Returns the key set.
Kill - Class in akka.actor
Java API: get the singleton instance
Kill() - Constructor for class akka.actor.Kill
 
Kill$ - Class in akka.actor
A message all Actors will understand, that when processed will make the Actor throw an ActorKilledException, which will trigger supervision.
Kill$() - Constructor for class akka.actor.Kill$
 
KILOBYTE() - Method in class akka.actor.mailbox.filebased.filequeue.tools.Util$
 
KILOBYTE() - Static method in class akka.actor.mailbox.filebased.filequeue.tools.Util
 

L

last() - Method in class akka.util.ByteString
 
lastDelivered() - Method in class akka.remote.AckedReceiveBuffer
 
lastMessage() - Method in interface akka.testkit.TestKitBase
 
lastSender() - Method in interface akka.testkit.TestKitBase
 
lastSerial() - Method in class akka.contrib.pattern.ReliableProxy.Receiver
 
lastValidPosition() - Method in exception akka.actor.mailbox.filebased.filequeue.BrokenItemException
 
lastWasNoMsg() - Method in interface akka.testkit.TestKitBase
if last assertion was expectNoMsg, disable timing failure upon within() block end.
latency() - Method in class akka.actor.IO.PerformancePreferences
 
leader() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
 
leader() - Method in class akka.cluster.ClusterEvent.LeaderChanged
 
leader() - Method in class akka.cluster.ClusterEvent.RoleLeaderChanged
 
LeaderActionsInterval() - Method in class akka.cluster.ClusterSettings
 
leaderStatusOrdering() - Method in class akka.cluster.Member$
INTERNAL API Orders the members by their address except that members with status Joining, Exiting and Down are ordered last (in that order).
leaderStatusOrdering() - Static method in class akka.cluster.Member
INTERNAL API Orders the members by their address except that members with status Joining, Exiting and Down are ordered last (in that order).
leave(Address) - Method in class akka.cluster.Cluster
Send command to issue state transition to LEAVING for the node specified by 'address'.
leave(String) - Method in interface akka.cluster.ClusterNodeMBean
Send command to issue state transition to LEAVING for the node specified by 'address'.
leaving() - Method in class akka.cluster.MemberStatus$
Java API: retrieve the “leaving” status singleton
leaving() - Static method in class akka.cluster.MemberStatus
Java API: retrieve the “leaving” status singleton
Leaving() - Method in class akka.cluster.protobuf.msg.MemberStatus$
 
Leaving() - Static method in class akka.cluster.protobuf.msg.MemberStatus
 
Leaving_VALUE() - Method in class akka.cluster.protobuf.msg.MemberStatus$
 
Leaving_VALUE() - Static method in class akka.cluster.protobuf.msg.MemberStatus
 
len() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
len() - Method in class akka.util.ByteIterator
 
len() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
length() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
length() - Method in class akka.actor.WriteBuffer
 
length() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
length() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
length() - Method in class akka.util.ByteString.ByteString1
 
length() - Method in class akka.util.ByteString.ByteString1C
 
length() - Method in class akka.util.ByteString.ByteStrings
 
length() - Method in class akka.util.ByteStringBuilder
 
LengthFieldFrame - Class in akka.io
Pipeline stage for length-field encoded framing.
LengthFieldFrame(int, ByteOrder, int, boolean) - Constructor for class akka.io.LengthFieldFrame
 
LengthFieldFrame$ - Class in akka.io
 
LengthFieldFrame$() - Constructor for class akka.io.LengthFieldFrame$
 
level() - Method in class akka.event.Logging.Debug
 
level() - Method in class akka.event.Logging.Error
 
level() - Method in class akka.event.Logging.Info
 
level() - Method in interface akka.event.Logging.LogEvent
The LogLevel of this LogEvent
level() - Method in class akka.event.Logging.Warning
 
levelFor(String) - Method in class akka.event.Logging$
Returns the LogLevel associated with the given string, valid inputs are upper or lowercase (not mixed) versions of: "error", "warning", "info" and "debug"
levelFor(Class<? extends Logging.LogEvent>) - Method in class akka.event.Logging$
Returns the LogLevel associated with the given event class.
levelFor(String) - Static method in class akka.event.Logging
Returns the LogLevel associated with the given string, valid inputs are upper or lowercase (not mixed) versions of: "error", "warning", "info" and "debug"
levelFor(Class<? extends Logging.LogEvent>) - Static method in class akka.event.Logging
Returns the LogLevel associated with the given event class.
LightArrayRevolverScheduler - Class in akka.actor
This scheduler implementation is based on a revolving wheel of buckets, like Netty’s HashedWheelTimer, which it advances at a fixed tick rate and dispatches tasks it finds in the current bucket to their respective ExecutionContexts.
LightArrayRevolverScheduler(com.typesafe.config.Config, LoggingAdapter, ThreadFactory) - Constructor for class akka.actor.LightArrayRevolverScheduler
 
LightArrayRevolverScheduler$ - Class in akka.actor
 
LightArrayRevolverScheduler$() - Constructor for class akka.actor.LightArrayRevolverScheduler$
 
LightArrayRevolverScheduler.TaskHolder - Class in akka.actor
INTERNAL API
LightArrayRevolverScheduler.TaskHolder(Runnable, int, ExecutionContext) - Constructor for class akka.actor.LightArrayRevolverScheduler.TaskHolder
 
LightArrayRevolverScheduler.TimerTask - Interface in akka.actor
INTERNAL API
lineSeparator() - Method in class akka.util.Crypt$
 
lineSeparator() - Static method in class akka.util.Crypt
 
linger() - Method in class akka.actor.IO.SoLinger
 
Linger - Class in akka.zeromq
Configure this socket to have a linger of the specified value
Linger(long) - Constructor for class akka.zeromq.Linger
 
linger() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its linger configuration.
linger() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its linger configuration.
Linger$ - Class in akka.zeromq
Gets the linger option @see akka.zeromq.Linger
Linger$() - Constructor for class akka.zeromq.Linger$
 
linkedBlockingQueue() - Method in class akka.dispatch.ThreadPoolConfig$
 
linkedBlockingQueue(int) - Method in class akka.dispatch.ThreadPoolConfig$
 
linkedBlockingQueue() - Static method in class akka.dispatch.ThreadPoolConfig
 
linkedBlockingQueue(int) - Static method in class akka.dispatch.ThreadPoolConfig
 
listen(SocketAddress, Seq<IO.ServerSocketOption>, ActorRef) - Method in class akka.actor.IOManager
Create a ServerSocketChannel listening on an address.
listen(SocketAddress, ActorRef) - Method in class akka.actor.IOManager
Create a ServerSocketChannel listening on an address.
listen(String, int, Seq<IO.ServerSocketOption>, ActorRef) - Method in class akka.actor.IOManager
Create a ServerSocketChannel listening on a host and port.
listen() - Method in class akka.remote.transport.AbstractTransportAdapter
 
listen() - Method in class akka.remote.transport.netty.NettyTransport
 
listen() - Method in class akka.remote.transport.TestTransport
 
listen() - Method in interface akka.remote.transport.Transport
Asynchronously attempts to setup the transport layer to listen and accept incoming associations.
Listen - Class in akka.routing
 
Listen(ActorRef) - Constructor for class akka.routing.Listen
 
Listen$ - Class in akka.routing
 
Listen$() - Constructor for class akka.routing.Listen$
 
listenAddress() - Method in class akka.remote.transport.ActorTransportAdapter.ListenUnderlying
 
listenAddresses() - Method in class akka.remote.RemotingListenEvent
 
listenBehavior() - Method in class akka.remote.transport.TestTransport
The TestTransport.SwitchableLoggedBehavior for the listen() method.
listener() - Method in class akka.remote.transport.ActorTransportAdapter.ListenerRegistered
 
listener() - Method in class akka.routing.Deafen
 
listener() - Method in class akka.routing.Listen
 
Listener - Class in akka.zeromq
An option containing the listener for the socket
Listener(ActorRef) - Constructor for class akka.zeromq.Listener
 
listener() - Method in class akka.zeromq.Listener
 
Listener$ - Class in akka.zeromq
 
Listener$() - Constructor for class akka.zeromq.Listener$
 
listenerManagement() - Method in interface akka.routing.Listeners
Chain this into the receive function.
ListenerMessage - Interface in akka.routing
 
Listeners - Interface in akka.routing
Listeners is a generic trait to implement listening capability on an Actor.
listeners() - Method in interface akka.routing.Listeners
 
loadClass(String, boolean) - Method in class akka.osgi.impl.BundleDelegatingClassLoader
 
loader() - Method in class akka.actor.TypedProps
 
loadQueues() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
local() - Method in class akka.actor.Deploy$
 
local() - Static method in class akka.actor.Deploy
 
local() - Method in class akka.cluster.routing.ClusterRouterConfig
 
local() - Method in class akka.remote.routing.RemoteRouterConfig
 
localAddress() - Method in class akka.io.Tcp.Bind
 
localAddress() - Method in class akka.io.Tcp.Bound
 
localAddress() - Method in class akka.io.Tcp.Connect
 
localAddress() - Method in class akka.io.Tcp.Connected
 
localAddress() - Method in class akka.io.Udp.Bind
 
localAddress() - Method in class akka.io.Udp.Bound
 
localAddress() - Method in class akka.io.UdpConnected.Connect
 
localAddress() - Method in class akka.remote.AssociatedEvent
 
localAddress() - Method in class akka.remote.AssociationErrorEvent
 
localAddress() - Method in interface akka.remote.AssociationEvent
 
localAddress() - Method in class akka.remote.DisassociatedEvent
 
localAddress() - Method in class akka.remote.transport.AbstractTransportAdapterHandle
 
localAddress() - Method in class akka.remote.transport.ActorTransportAdapterManager
 
localAddress() - Method in interface akka.remote.transport.AssociationHandle
Address of the local endpoint.
localAddress() - Method in class akka.remote.transport.TestAssociationHandle
 
localAddress() - Method in class akka.remote.transport.TestTransport.AssociateAttempt
 
localAddress() - Method in class akka.remote.transport.TestTransport
 
localAffinity() - Method in class akka.contrib.pattern.ClusterClient.Send
 
localAffinity() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Send
 
LocalScope - Class in akka.actor
 
LocalScope() - Constructor for class akka.actor.LocalScope
 
LocalScope$ - Class in akka.actor
The Local Scope is the default one, which is assumed on all deployments which do not set a different scope.
LocalScope$() - Constructor for class akka.actor.LocalScope$
 
lock() - Method in class akka.util.BoundedBlockingQueue
 
locked(Function0<T>) - Method in class akka.util.Switch
Executes the given code while holding this switch’s lock, i.e.
log() - Method in interface akka.actor.ActorLogging
 
log() - Method in class akka.actor.ActorSystem
Convenient logging adapter for logging to the ActorSystem.eventStream.
log(Level, Throwable, Logging.LogEvent) - Method in class akka.contrib.jul.JavaLogger
 
log() - Method in interface akka.contrib.jul.JavaLogging
 
log(Level, Throwable, String) - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
log(Logging.LogLevel, String) - Method in interface akka.event.LoggingAdapter
Log message at the specified log level.
log(Logging.LogLevel, String, Object) - Method in interface akka.event.LoggingAdapter
Message template with 1 replacement argument.
log(Logging.LogLevel, String, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 2 replacement arguments.
log(Logging.LogLevel, String, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 3 replacement arguments.
log(Logging.LogLevel, String, Object, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 4 replacement arguments.
log() - Method in interface akka.event.slf4j.SLF4JLogging
 
log() - Method in class akka.remote.testkit.MultiNodeSpec
 
log() - Method in class akka.serialization.Serialization
 
log() - Method in class akka.testkit.AkkaSpec
 
log() - Method in class akka.testkit.CallingThreadDispatcher
 
logActivity(TestTransport.Activity) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Logs a transport activity.
logClass() - Method in class akka.event.BusLogging
 
logClass() - Method in class akka.event.Logging.Debug
 
logClass() - Method in class akka.event.Logging.Error
 
logClass() - Method in class akka.event.Logging.Info
 
logClass() - Method in interface akka.event.Logging.LogEvent
The class of the source of this event
logClass() - Method in class akka.event.Logging.Warning
 
LogConfigOnStart() - Method in class akka.actor.ActorSystem.Settings
 
logConfiguration() - Method in class akka.actor.ActorSystem
Log the configuration.
LogDeadLetters() - Method in class akka.actor.ActorSystem.Settings
 
LogDeadLettersDuringShutdown() - Method in class akka.actor.ActorSystem.Settings
 
logDepth() - Method in interface akka.actor.LoggingFSM
 
logFailure(ActorContext, ActorRef, Throwable, SupervisorStrategy.Directive) - Method in class akka.actor.SupervisorStrategy
Default logging of actor failures when SupervisorStrategy.loggingEnabled() is true.
logger() - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
Logger - Class in akka.event.slf4j
Logger is a factory for obtaining SLF4J-Loggers
Logger() - Constructor for class akka.event.slf4j.Logger
 
Logger$ - Class in akka.event.slf4j
Logger is a factory for obtaining SLF4J-Loggers
Logger$() - Constructor for class akka.event.slf4j.Logger$
 
loggerInitialized() - Method in class akka.event.Logging$
Java API to create a LoggerInitialized message.
loggerInitialized() - Static method in class akka.event.Logging
Java API to create a LoggerInitialized message.
Loggers() - Method in class akka.actor.ActorSystem.Settings
 
loggers() - Method in interface akka.event.LoggingBus
 
LoggerStartTimeout() - Method in class akka.actor.ActorSystem.Settings
 
Logging - Class in akka.event
Main entry point for Akka logging: log levels and message types (aka channels) defined for the main transport medium, the main event bus.
Logging() - Constructor for class akka.event.Logging
 
Logging$ - Class in akka.event
Main entry point for Akka logging: log levels and message types (aka channels) defined for the main transport medium, the main event bus.
Logging$() - Constructor for class akka.event.Logging$
 
Logging.Debug - Class in akka.event
For DEBUG Logging
Logging.Debug(String, Class<?>, Object) - Constructor for class akka.event.Logging.Debug
 
Logging.Debug$ - Class in akka.event
 
Logging.Debug$() - Constructor for class akka.event.Logging.Debug$
 
Logging.DefaultLogger - Class in akka.event
Actor wrapper around the standard output logger.
Logging.DefaultLogger() - Constructor for class akka.event.Logging.DefaultLogger
 
Logging.Error - Class in akka.event
For ERROR Logging
Logging.Error(Throwable, String, Class<?>, Object) - Constructor for class akka.event.Logging.Error
 
Logging.Error(String, Class<?>, Object) - Constructor for class akka.event.Logging.Error
 
Logging.Error$ - Class in akka.event
 
Logging.Error$() - Constructor for class akka.event.Logging.Error$
 
Logging.Error.NoCause$ - Class in akka.event
Null Object used for errors without cause Throwable
Logging.Error.NoCause$() - Constructor for class akka.event.Logging.Error.NoCause$
 
Logging.Info - Class in akka.event
For INFO Logging
Logging.Info(String, Class<?>, Object) - Constructor for class akka.event.Logging.Info
 
Logging.Info$ - Class in akka.event
 
Logging.Info$() - Constructor for class akka.event.Logging.Info$
 
Logging.InitializeLogger - Class in akka.event
Message which is sent to each default logger (i.e.
Logging.InitializeLogger(LoggingBus) - Constructor for class akka.event.Logging.InitializeLogger
 
Logging.InitializeLogger$ - Class in akka.event
 
Logging.InitializeLogger$() - Constructor for class akka.event.Logging.InitializeLogger$
 
Logging.LogEvent - Interface in akka.event
Base type of LogEvents
Logging.LogEventException - Class in akka.event
Exception that wraps a LogEvent.
Logging.LogEventException(Logging.LogEvent, Throwable) - Constructor for class akka.event.Logging.LogEventException
 
Logging.LoggerException - Exception in akka.event
Artificial exception injected into Error events if no Throwable is supplied; used for getting a stack dump of error locations.
Logging.LoggerException() - Constructor for exception akka.event.Logging.LoggerException
 
Logging.LoggerInitializationException - Exception in akka.event
LoggerInitializationException is thrown to indicate that there was a problem initializing a logger
Logging.LoggerInitializationException(String) - Constructor for exception akka.event.Logging.LoggerInitializationException
 
Logging.LoggerInitialized - Class in akka.event
Response message each logger must send within 1 second after receiving the InitializeLogger request.
Logging.LoggerInitialized() - Constructor for class akka.event.Logging.LoggerInitialized
 
Logging.LoggerInitialized$ - Class in akka.event
 
Logging.LoggerInitialized$() - Constructor for class akka.event.Logging.LoggerInitialized$
 
Logging.LogLevel - Class in akka.event
Marker trait for annotating LogLevel, which must be Int after erasure.
Logging.LogLevel(int) - Constructor for class akka.event.Logging.LogLevel
 
Logging.LogLevel$ - Class in akka.event
 
Logging.LogLevel$() - Constructor for class akka.event.Logging.LogLevel$
 
Logging.StandardOutLogger - Class in akka.event
Actor-less logging implementation for synchronous logging to standard output.
Logging.StandardOutLogger() - Constructor for class akka.event.Logging.StandardOutLogger
 
Logging.StdOutLogger - Interface in akka.event
 
Logging.Warning - Class in akka.event
For WARNING Logging
Logging.Warning(String, Class<?>, Object) - Constructor for class akka.event.Logging.Warning
 
Logging.Warning$ - Class in akka.event
 
Logging.Warning$() - Constructor for class akka.event.Logging.Warning$
 
LoggingAdapter - Interface in akka.event
Logging wrapper to make nicer and optimize: provide template versions which evaluate .toString only if the log level is actually enabled.
LoggingBus - Interface in akka.event
This trait brings log level handling to the EventStream: it reads the log levels for the initial logging (StandardOutLogger) and the loggers & level for after-init logging, possibly keeping the StandardOutLogger enabled if it is part of the configured loggers.
loggingEnabled() - Method in class akka.actor.AllForOneStrategy
 
loggingEnabled() - Method in class akka.actor.OneForOneStrategy
 
loggingEnabled() - Method in class akka.actor.SupervisorStrategy
Logging of actor failures is done when this is true.
loggingExecutionContext() - Method in interface akka.contrib.jul.JavaLoggingAdapter
Override-able option for asynchronous logging
LoggingFSM<S,D> - Interface in akka.actor
Stackable trait for FSM which adds a rolling event log and debug logging capabilities (analogous to LoggingReceive).
LoggingReceive - Class in akka.event
This decorator adds invocation logging to a Receive function.
LoggingReceive(Option<Object>, PartialFunction<Object, BoxedUnit>, ActorContext) - Constructor for class akka.event.LoggingReceive
 
LoggingReceive$ - Class in akka.event
 
LoggingReceive$() - Constructor for class akka.event.LoggingReceive$
 
LogInfo() - Method in class akka.cluster.ClusterSettings
 
logInfo(String) - Method in class akka.contrib.pattern.ClusterSingletonManager
 
logInfo(String, Object) - Method in class akka.contrib.pattern.ClusterSingletonManager
 
logInfo(String, Object, Object) - Method in class akka.contrib.pattern.ClusterSingletonManager
 
LogLevel() - Method in class akka.actor.ActorSystem.Settings
 
logLevel() - Method in interface akka.event.LoggingBus
Query currently set log level.
logLevel() - Method in class akka.remote.AssociatedEvent
 
logLevel() - Method in class akka.remote.AssociationErrorEvent
 
logLevel() - Method in class akka.remote.DisassociatedEvent
 
logLevel() - Method in class akka.remote.RemotingErrorEvent
 
logLevel() - Method in interface akka.remote.RemotingLifecycleEvent
 
logLevel() - Method in class akka.remote.RemotingListenEvent
 
logLevel() - Method in class akka.remote.RemotingShutdownEvent$
 
logLevel() - Static method in class akka.remote.RemotingShutdownEvent
 
logMessage(org.osgi.service.log.LogService, Logging.LogEvent) - Method in class akka.osgi.DefaultOSGiLogger
Logs a message in an OSGi LogService
LogReceive() - Method in class akka.remote.RemoteSettings
 
LogRemoteLifecycleEvents() - Method in class akka.remote.RemoteSettings
 
LogSend() - Method in class akka.remote.RemoteSettings
 
logSnapshot() - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Takes a thread-safe snapshot of the current state of the activity log.
logSource() - Method in class akka.event.BusLogging
 
logSource() - Method in class akka.event.Logging.Debug
 
logSource() - Method in class akka.event.Logging.Error
 
logSource() - Method in class akka.event.Logging.Info
 
logSource() - Method in interface akka.event.Logging.LogEvent
The source of this event
logSource() - Method in class akka.event.Logging.Warning
 
LogSource<T> - Interface in akka.event
This trait defines the interface to be provided by a “log source formatting rule” as used by Logging’s apply/create method.
LogSource$ - Class in akka.event
This object holds predefined formatting rules for log sources.
LogSource$() - Constructor for class akka.event.LogSource$
 
logTermination(FSM.Reason) - Method in interface akka.actor.FSM
By default FSM.Failure is logged at error level and other reason types are not logged.
Long() - Method in class akka.cluster.protobuf.msg.NodeMetrics.NumberType$
 
Long_VALUE() - Method in class akka.cluster.protobuf.msg.NodeMetrics.NumberType$
 
LongRunningTest - Class in akka.testkit
 
LongRunningTest() - Constructor for class akka.testkit.LongRunningTest
 
LongRunningTest$ - Class in akka.testkit
 
LongRunningTest$() - Constructor for class akka.testkit.LongRunningTest$
 
longToTimeout(long) - Method in class akka.util.Timeout$
 
longToTimeout(long) - Static method in class akka.util.Timeout
 
lookup() - Method in class akka.actor.ActorDSL.Extension$
 
lookup() - Method in interface akka.actor.ExtensionIdProvider
Returns the canonical ExtensionId for this Extension
lookup() - Method in class akka.actor.ExtensionKey
 
lookup() - Method in class akka.actor.IOManager$
 
lookup() - Static method in class akka.actor.IOManager
 
lookup() - Method in class akka.actor.TypedActor$
 
lookup() - Static method in class akka.actor.TypedActor
 
lookup() - Method in class akka.camel.CamelExtension$
 
lookup() - Static method in class akka.camel.CamelExtension
 
lookup() - Method in class akka.cluster.Cluster$
 
lookup() - Static method in class akka.cluster.Cluster
 
lookup() - Method in class akka.contrib.mailbox.PeekMailboxExtension$
 
lookup() - Static method in class akka.contrib.mailbox.PeekMailboxExtension
 
lookup() - Method in class akka.contrib.pattern.ClusterReceptionistExtension$
 
lookup() - Static method in class akka.contrib.pattern.ClusterReceptionistExtension
 
lookup() - Method in class akka.contrib.pattern.DistributedPubSubExtension$
 
lookup() - Static method in class akka.contrib.pattern.DistributedPubSubExtension
 
lookup(String) - Method in class akka.dispatch.Dispatchers
Returns a dispatcher as specified in configuration.
lookup() - Method in class akka.io.Tcp$
 
lookup() - Static method in class akka.io.Tcp
 
lookup() - Method in class akka.io.Udp$
 
lookup() - Static method in class akka.io.Udp
 
lookup() - Method in class akka.io.UdpConnected$
 
lookup() - Static method in class akka.io.UdpConnected
 
lookup() - Method in class akka.remote.AddressUidExtension$
 
lookup() - Static method in class akka.remote.AddressUidExtension
 
lookup() - Method in class akka.remote.testconductor.TestConductor$
 
lookup() - Static method in class akka.remote.testconductor.TestConductor
 
lookup() - Method in class akka.remote.transport.TransportAdaptersExtension$
 
lookup() - Static method in class akka.remote.transport.TransportAdaptersExtension
 
lookup() - Method in class akka.serialization.SerializationExtension$
 
lookup() - Static method in class akka.serialization.SerializationExtension
 
lookup() - Method in class akka.transactor.TransactorExtension$
 
lookup() - Static method in class akka.transactor.TransactorExtension
 
lookup() - Method in class akka.zeromq.ZeroMQExtension$
 
lookup() - Static method in class akka.zeromq.ZeroMQExtension
 
LookupClassification - Interface in akka.event
Maps Subscribers to Classifiers using equality on Classifier to store a Set of Subscribers (hence the need for compareSubscribers) Maps Events to Classifiers through the classify-method (so it knows who to publish to)
LookupEventBus<E,S,C> - Class in akka.event.japi
See documentation for LookupClassification E is the Event type S is the Subscriber type C is the Classifier type
LookupEventBus() - Constructor for class akka.event.japi.LookupEventBus
 
lookupRoot() - Method in interface akka.actor.ActorRefFactory
INTERNAL API
lowerBound() - Method in class akka.routing.DefaultResizer
The fewest number of routees the router should ever have.

M

mailbox() - Method in class akka.actor.Deploy
 
mailbox() - Method in class akka.actor.Props
Convenience method for extracting the mailbox information from the contained Deploy instance.
mailbox() - Method in interface akka.actor.UnrestrictedStash
 
mailboxes() - Method in class akka.actor.ActorSystem
Helper object for looking up configured mailbox types.
mailboxes() - Method in interface akka.dispatch.DispatcherPrerequisites
 
mailboxes() - Method in class akka.dispatch.MessageDispatcher
 
Mailboxes$ - Class in akka.dispatch
 
Mailboxes$() - Constructor for class akka.dispatch.Mailboxes$
 
MailboxType - Interface in akka.dispatch
MailboxType is a factory to create MessageQueues for an optionally provided ActorContext.
mailboxType() - Method in class akka.testkit.CallingThreadMailbox
 
main(String[]) - Method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper$
 
main(String[]) - Static method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper
 
Main - Class in akka.kernel
Main class for running the microkernel.
Main() - Constructor for class akka.kernel.Main
 
main(String[]) - Method in class akka.kernel.Main$
 
main(String[]) - Static method in class akka.kernel.Main
 
Main - Class in akka
Main class to start an ActorSystem with one top level application supervisor actor.
Main() - Constructor for class akka.Main
 
main(String[]) - Method in class akka.Main$
 
main(String[]) - Static method in class akka.Main
 
Main$ - Class in akka.kernel
Main class for running the microkernel.
Main$() - Constructor for class akka.kernel.Main$
 
Main$ - Class in akka
Main class to start an ActorSystem with one top level application supervisor actor.
Main$() - Constructor for class akka.Main$
 
Main.Terminator - Class in akka
 
Main.Terminator(ActorRef) - Constructor for class akka.Main.Terminator
 
major() - Method in class akka.zeromq.ZeroMQVersion
 
makeCommand(CmdBelow) - Method in class akka.io.AbstractPipePair
Helper method for wrapping a command which shall be emitted.
makeContext(ActorContext) - Method in class akka.io.TcpPipelineHandler.Init
This method must be implemented to return the PipelineContext necessary for the operation of the given PipelineStage.
makeDecider(Seq<Class<? extends Throwable>>) - Method in class akka.actor.SupervisorStrategy$
Decider builder which just checks whether one of the given Throwables matches the cause and restarts, otherwise escalates.
makeDecider(Iterable<Class<? extends Throwable>>) - Method in class akka.actor.SupervisorStrategy$
Decider builder which just checks whether one of the given Throwables matches the cause and restarts, otherwise escalates.
makeDecider(Iterable<Tuple2<Class<? extends Throwable>, SupervisorStrategy.Directive>>) - Method in class akka.actor.SupervisorStrategy$
Decider builder for Iterables of cause-directive pairs, e.g.
makeDecider(Function<Throwable, SupervisorStrategy.Directive>) - Method in class akka.actor.SupervisorStrategy$
Converts a Java Decider into a Scala Decider
makeDecider(Seq<Class<? extends Throwable>>) - Static method in class akka.actor.SupervisorStrategy
Decider builder which just checks whether one of the given Throwables matches the cause and restarts, otherwise escalates.
makeDecider(Iterable<Class<? extends Throwable>>) - Static method in class akka.actor.SupervisorStrategy
Decider builder which just checks whether one of the given Throwables matches the cause and restarts, otherwise escalates.
makeDecider(Iterable<Tuple2<Class<? extends Throwable>, SupervisorStrategy.Directive>>) - Static method in class akka.actor.SupervisorStrategy
Decider builder for Iterables of cause-directive pairs, e.g.
makeDecider(Function<Throwable, SupervisorStrategy.Directive>) - Static method in class akka.actor.SupervisorStrategy
Converts a Java Decider into a Scala Decider
makeEvent(EvtAbove) - Method in class akka.io.AbstractPipePair
Helper method for wrapping an event which shall be emitted.
makePattern(String) - Method in class akka.util.Helpers$
 
makePattern(String) - Static method in class akka.util.Helpers
 
makeTransition(FSM.State<S, D>) - Method in interface akka.actor.FSM
 
management() - Method in class akka.io.PipelinePorts
 
managementCommand(Object) - Method in interface akka.io.PipelineInjector
Send a management command to all stages (in an unspecified order).
managementCommand(Object) - Method in class akka.remote.transport.ThrottlerTransportAdapter
 
managementCommand(Object) - Method in interface akka.remote.transport.Transport
This method allows upper layers to send management commands to the transport.
ManagementDispatcher() - Method in class akka.io.TcpExt.Settings
 
managementPort() - Method in interface akka.io.PipePair
The management port allows sending broadcast messages to all stages within this pipeline.
manager() - Method in interface akka.io.IO.Extension
 
manager() - Method in class akka.io.TcpExt
 
manager() - Method in class akka.io.UdpConnectedExt
 
manager() - Method in class akka.io.UdpExt
 
manager() - Method in class akka.remote.transport.ActorTransportAdapter
 
managerName() - Method in class akka.remote.transport.ActorTransportAdapter
 
managerName() - Method in class akka.remote.transport.ThrottlerTransportAdapter
 
managerProps() - Method in class akka.remote.transport.ActorTransportAdapter
 
managerProps() - Method in class akka.remote.transport.ThrottlerTransportAdapter
 
map(Function1<A, B>) - Method in class akka.actor.IO.Iteratee
Applies a function to transform the result of this Iteratee.
map(Function1<A, A>) - Method in interface akka.actor.IO.IterateeRef
 
map(Function1<A, A>) - Method in class akka.actor.IO.IterateeRefAsync
 
map(Function1<A, A>) - Method in class akka.actor.IO.IterateeRefSync
 
map(Function1<T, B>) - Method in class akka.agent.Agent
Map this agent to a new agent, applying the function to the internal state.
mapBody(Function1<A, B>) - Method in class akka.camel.CamelMessage
Returns a new CamelMessage with a transformed body using a transformer function.
mapBody(Mapper<A, B>) - Method in class akka.camel.CamelMessage
Java API: Returns a new CamelMessage with a transformed body using a transformer function.
mapI(Function1<Object, Object>) - Method in class akka.util.ByteString
map method that will automatically cast Int back into Byte.
Mapper<T,R> - Class in akka.dispatch
Callback for the Future.map and Future.flatMap operations that will be invoked if the Future that this callback is registered on becomes completed with a success.
Mapper() - Constructor for class akka.dispatch.Mapper
 
mappings() - Method in interface akka.event.ActorClassification
 
mapSize() - Method in interface akka.event.ActorClassification
This is a size hint for the number of Classifiers you expect to have (use powers of 2)
mapSize() - Method in interface akka.event.LookupClassification
This is a size hint for the number of Classifiers you expect to have (use powers of 2)
mapSize() - Method in class akka.util.Index
 
mapToConfig(Map<String, Object>) - Method in class akka.testkit.AkkaSpec$
 
mapToConfig(Map<String, Object>) - Static method in class akka.testkit.AkkaSpec
 
Marker() - Method in class akka.contrib.mailbox.PeekMailbox
 
match(Object) - Method in class akka.testkit.JavaTestKit.ExpectMsg
 
match(Object) - Method in class akka.testkit.JavaTestKit.ReceiveWhile
 
MATCHER_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.Selection
 
matches(akka.event.EventBus.Classifier, akka.event.EventBus.Event) - Method in interface akka.event.ScanningClassification
Returns whether the specified Classifier matches the specified Event
matches(Logging.LogEvent) - Method in class akka.testkit.CustomEventFilter
 
matches(Logging.LogEvent) - Method in class akka.testkit.DeadLettersFilter
 
matches(Logging.LogEvent) - Method in class akka.testkit.DebugFilter
 
matches(Logging.LogEvent) - Method in class akka.testkit.ErrorFilter
 
matches(Logging.LogEvent) - Method in class akka.testkit.EventFilter
This method decides whether to filter the event (true) or not (false).
matches(Logging.LogEvent) - Method in class akka.testkit.InfoFilter
 
matches(String) - Method in class akka.testkit.JavaTestKit.EventFilter
 
matches(Logging.LogEvent) - Method in class akka.testkit.WarningFilter
 
matchingRole(Member) - Method in class akka.contrib.pattern.ClusterReceptionist
 
matchingRole(Member) - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
max() - Method in class akka.cluster.StandardMetrics.HeapMemory
 
max(VectorClock.Timestamp) - Method in class akka.cluster.VectorClock.Timestamp
 
MaxAge() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
maxAge() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
maxAge() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
maxCapacity() - Method in class akka.util.BoundedBlockingQueue
 
MaxChannels() - Method in class akka.io.SelectionHandlerSettings
 
MaxChannelsPerSelector() - Method in class akka.io.SelectionHandlerSettings
 
MaxChannelsPerSelector() - Method in class akka.io.TcpExt.Settings
 
maxCount() - Method in class akka.event.DeadLetterListener
 
MaxDirectBufferPoolSize() - Method in class akka.io.TcpExt.Settings
 
MaxFrameSize() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
maxFrequency() - Method in class akka.actor.AbstractScheduler
The maximum supported task frequency of this scheduler, i.e.
maxFrequency() - Method in class akka.actor.DefaultScheduler
 
maxFrequency() - Method in class akka.actor.LightArrayRevolverScheduler
 
maxFrequency() - Method in interface akka.actor.Scheduler
The maximum supported task frequency of this scheduler, i.e.
maximumOverhead() - Method in class akka.remote.transport.AbstractTransportAdapter
 
maximumOverhead() - Method in class akka.remote.transport.ThrottlerTransportAdapter
 
maximumPayloadBytes() - Method in class akka.remote.transport.AbstractTransportAdapter
 
maximumPayloadBytes() - Method in class akka.remote.transport.netty.NettyTransport
 
maximumPayloadBytes() - Method in class akka.remote.transport.TestTransport
 
maximumPayloadBytes() - Method in interface akka.remote.transport.Transport
Defines the maximum size of payload this transport is able to deliver.
MaximumRetriesInWindow() - Method in class akka.remote.RemoteSettings
 
maxInstancesPerNode() - Method in class akka.cluster.routing.ClusterRouterSettings
 
MaxItems() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
maxItems() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
maxItems() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
MaxItemSize() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
maxItemSize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
maxItemSize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
MaxJournalOverflow() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
maxJournalOverflow() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
maxJournalOverflow() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
MaxJournalSize() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
maxJournalSize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
maxJournalSize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
MaxJournalSizeAbsolute() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
maxJournalSizeAbsolute() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
maxJournalSizeAbsolute() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
MaxMemorySize() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
maxMemorySize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
maxMemorySize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
maxMessageSize() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its max message size configuration.
maxMessageSize() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its max message size configuration.
MaxMsgSize - Class in akka.zeromq
Limits the size of the inbound message.
MaxMsgSize(long) - Constructor for class akka.zeromq.MaxMsgSize
 
MaxMsgSize$ - Class in akka.zeromq
 
MaxMsgSize$() - Constructor for class akka.zeromq.MaxMsgSize$
 
maxNodes() - Method in class akka.remote.testkit.MultiNodeSpec$
Number of nodes node taking part in this test.
maxNodes() - Static method in class akka.remote.testkit.MultiNodeSpec
Number of nodes node taking part in this test.
maxNrOfRetries() - Method in class akka.actor.AllForOneStrategy
 
maxNrOfRetries() - Method in class akka.actor.OneForOneStrategy
 
maxNrOfRetriesCount() - Method in class akka.actor.ChildRestartStats
 
maxPoolSize() - Method in class akka.dispatch.ThreadPoolConfig
 
maxSampleSize() - Method in class akka.remote.PhiAccrualFailureDetector
 
maxSeq() - Method in class akka.remote.AckedSendBuffer
 
MaxSize() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
maxSize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
maxSize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
md5(String) - Method in class akka.util.Crypt$
 
md5(byte[]) - Method in class akka.util.Crypt$
 
md5(String) - Static method in class akka.util.Crypt
 
md5(byte[]) - Static method in class akka.util.Crypt
 
mdcAkkaSourceAttributeName() - Method in class akka.event.slf4j.Slf4jLogger
 
mdcAkkaTimestamp() - Method in class akka.event.slf4j.Slf4jLogger
 
mdcThreadAttributeName() - Method in class akka.event.slf4j.Slf4jLogger
 
mediator() - Method in class akka.contrib.pattern.DistributedPubSubExtension
The DistributedPubSubMediator
MEGABYTE() - Method in class akka.actor.mailbox.filebased.filequeue.tools.Util$
 
MEGABYTE() - Static method in class akka.actor.mailbox.filebased.filequeue.tools.Util
 
member() - Method in interface akka.cluster.ClusterEvent.MemberEvent
 
member() - Method in class akka.cluster.ClusterEvent.MemberExited
 
member() - Method in class akka.cluster.ClusterEvent.MemberRemoved
 
member() - Method in class akka.cluster.ClusterEvent.MemberUp
 
member() - Method in class akka.cluster.ClusterEvent.UnreachableMember
 
Member - Class in akka.cluster
Represents the address, current status, and roles of a cluster member node.
Member - Class in akka.cluster.protobuf.msg
 
Member(int, int, MemberStatus.EnumVal, Seq<Object>) - Constructor for class akka.cluster.protobuf.msg.Member
 
Member$ - Class in akka.cluster
Module with factory and ordering methods for Member instances.
Member$() - Constructor for class akka.cluster.Member$
 
Member$ - Class in akka.cluster.protobuf.msg
 
Member$() - Constructor for class akka.cluster.protobuf.msg.Member$
 
members() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
 
members() - Method in class akka.cluster.protobuf.msg.Gossip
 
MEMBERS_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.Gossip$
 
MEMBERS_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.Gossip
 
MemberStatus - Class in akka.cluster
Defines the current status of a cluster member node
MemberStatus() - Constructor for class akka.cluster.MemberStatus
 
MemberStatus - Class in akka.cluster.protobuf.msg
 
MemberStatus() - Constructor for class akka.cluster.protobuf.msg.MemberStatus
 
MemberStatus$ - Class in akka.cluster
 
MemberStatus$() - Constructor for class akka.cluster.MemberStatus$
 
MemberStatus$ - Class in akka.cluster.protobuf.msg
 
MemberStatus$() - Constructor for class akka.cluster.protobuf.msg.MemberStatus$
 
MemberStatus.Down$ - Class in akka.cluster
 
MemberStatus.Down$() - Constructor for class akka.cluster.MemberStatus.Down$
 
MemberStatus.EnumVal - Interface in akka.cluster.protobuf.msg
 
MemberStatus.Exiting$ - Class in akka.cluster
 
MemberStatus.Exiting$() - Constructor for class akka.cluster.MemberStatus.Exiting$
 
MemberStatus.Joining$ - Class in akka.cluster
 
MemberStatus.Joining$() - Constructor for class akka.cluster.MemberStatus.Joining$
 
MemberStatus.Leaving$ - Class in akka.cluster
 
MemberStatus.Leaving$() - Constructor for class akka.cluster.MemberStatus.Leaving$
 
MemberStatus.Removed$ - Class in akka.cluster
 
MemberStatus.Removed$() - Constructor for class akka.cluster.MemberStatus.Removed$
 
MemberStatus.Up$ - Class in akka.cluster
 
MemberStatus.Up$() - Constructor for class akka.cluster.MemberStatus.Up$
 
memoryBytes() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
memoryLength() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
merge(NodeMetrics) - Method in class akka.cluster.NodeMetrics
Returns the most recent data.
merge(VectorClock) - Method in class akka.cluster.VectorClock
Merges this VectorClock with another VectorClock.
mergeAck(WireFormats.AcknowledgementInfo) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
mergeAddr(TestConductorProtocol.Address) - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
mergeAddr(TestConductorProtocol.AddressRequest) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
mergeAddress(TestConductorProtocol.Address) - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
mergeAddress(TestConductorProtocol.Address) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
mergeBarrier(TestConductorProtocol.EnterBarrier) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
mergeDeploy(WireFormats.DeployData) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
mergeDeploy(WireFormats.DeployData) - Method in class akka.remote.WireFormats.PropsData.Builder
 
mergeEnvelope(WireFormats.RemoteEnvelope) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
mergeFailure(TestConductorProtocol.InjectFailure) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.Address
 
mergeFrom(Address) - Method in class akka.cluster.protobuf.msg.Address
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.Empty
 
mergeFrom(Empty) - Method in class akka.cluster.protobuf.msg.Empty
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.Gossip
 
mergeFrom(Gossip) - Method in class akka.cluster.protobuf.msg.Gossip
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.GossipEnvelope
 
mergeFrom(GossipEnvelope) - Method in class akka.cluster.protobuf.msg.GossipEnvelope
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.GossipOverview
 
mergeFrom(GossipOverview) - Method in class akka.cluster.protobuf.msg.GossipOverview
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.GossipOverview.Seen
 
mergeFrom(GossipOverview.Seen) - Method in class akka.cluster.protobuf.msg.GossipOverview.Seen
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.GossipStatus
 
mergeFrom(GossipStatus) - Method in class akka.cluster.protobuf.msg.GossipStatus
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.Join
 
mergeFrom(Join) - Method in class akka.cluster.protobuf.msg.Join
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.Member
 
mergeFrom(Member) - Method in class akka.cluster.protobuf.msg.Member
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
mergeFrom(MetricsGossip) - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope
 
mergeFrom(MetricsGossipEnvelope) - Method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.NodeMetrics.EWMA
 
mergeFrom(NodeMetrics.EWMA) - Method in class akka.cluster.protobuf.msg.NodeMetrics.EWMA
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.NodeMetrics
 
mergeFrom(NodeMetrics) - Method in class akka.cluster.protobuf.msg.NodeMetrics
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.NodeMetrics.Metric
 
mergeFrom(NodeMetrics.Metric) - Method in class akka.cluster.protobuf.msg.NodeMetrics.Metric
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number
 
mergeFrom(NodeMetrics.Number) - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.UniqueAddress
 
mergeFrom(UniqueAddress) - Method in class akka.cluster.protobuf.msg.UniqueAddress
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.VectorClock
 
mergeFrom(VectorClock) - Method in class akka.cluster.protobuf.msg.VectorClock
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.VectorClock.Version
 
mergeFrom(VectorClock.Version) - Method in class akka.cluster.protobuf.msg.VectorClock.Version
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.Welcome
 
mergeFrom(Welcome) - Method in class akka.cluster.protobuf.msg.Welcome
 
mergeFrom(AckedReceiveBuffer<T>) - Method in class akka.remote.AckedReceiveBuffer
Merges two receive buffers.
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.ContainerFormats.Selection.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.ContainerFormats.Selection.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.WireFormats.ActorRefData.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.WireFormats.ActorRefData.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.WireFormats.AddressData.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.WireFormats.AddressData.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.WireFormats.DeployData.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.WireFormats.DeployData.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.WireFormats.PropsData.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.WireFormats.PropsData.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
mergeHandshakeInfo(WireFormats.AkkaHandshakeInfo) - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
mergeHello(TestConductorProtocol.Hello) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
mergeInstruction(WireFormats.AkkaControlMessage) - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
mergeMessage(WireFormats.SerializedMessage) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
mergeOrigin(WireFormats.AddressData) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
mergeProps(WireFormats.PropsData) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
mergeRecipient(WireFormats.ActorRefData) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
mergeSender(WireFormats.ActorRefData) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
mergeSupervisor(WireFormats.ActorRefData) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
message() - Method in exception akka.actor.ActorKilledException
 
message() - Method in class akka.actor.DeadLetter
 
message() - Method in exception akka.actor.IllegalActorStateException
 
message() - Method in exception akka.actor.InvalidActorNameException
 
message() - Method in exception akka.actor.InvalidMessageException
 
message() - Method in class akka.actor.UnhandledMessage
 
message() - Method in class akka.contrib.throttle.TimerBasedThrottler.Message
 
message() - Method in class akka.dispatch.Envelope
 
message() - Method in class akka.event.Logging.Debug
 
message() - Method in class akka.event.Logging.Error
 
message() - Method in class akka.event.Logging.Info
 
message() - Method in interface akka.event.Logging.LogEvent
The message, may be any object or null.
message() - Method in class akka.event.Logging.Warning
 
message() - Method in class akka.routing.Broadcast
 
message() - Method in class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope
 
message() - Method in interface akka.routing.RouterEnvelope
 
message() - Method in class akka.testkit.DebugFilter
 
message() - Method in class akka.testkit.ErrorFilter
 
message() - Method in class akka.testkit.EventFilter
 
message() - Method in class akka.testkit.InfoFilter
 
message(String) - Method in class akka.testkit.JavaTestKit.EventFilter
 
message() - Method in class akka.testkit.WarningFilter
 
message() - Method in class akka.transactor.Coordinated
 
message() - Method in class akka.transactor.SendTo
 
MESSAGE_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.RemoteEnvelope
 
MESSAGE_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.SerializedMessage
 
messageClass() - Method in class akka.testkit.DeadLettersFilter
 
MessageContainerSerializer - Class in akka.remote.serialization
 
MessageContainerSerializer(ExtendedActorSystem) - Constructor for class akka.remote.serialization.MessageContainerSerializer
 
MessageDispatcher - Class in akka.dispatch
 
MessageDispatcher(MessageDispatcherConfigurator) - Constructor for class akka.dispatch.MessageDispatcher
 
MessageDispatcherConfigurator - Class in akka.dispatch
Base class to be used for hooking in new dispatchers into Dispatchers.
MessageDispatcherConfigurator(com.typesafe.config.Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.MessageDispatcherConfigurator
 
MessageExchangeId() - Method in class akka.camel.CamelMessage$
CamelMessage header to correlate request with response messages.
MessageExchangeId() - Static method in class akka.camel.CamelMessage
CamelMessage header to correlate request with response messages.
messageFormat() - Method in class akka.osgi.DefaultOSGiLogger
 
messageId() - Method in class akka.actor.Identify
 
MESSAGEMANIFEST_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.SelectionEnvelope
 
MESSAGEMANIFEST_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.SerializedMessage
 
messageOption() - Method in exception akka.actor.PreRestartException
 
messagePredicate() - Method in class akka.actor.dsl.Inbox.InboxActor
 
messageQueue() - Method in class akka.dispatch.BalancingDispatcher
INTERNAL API
MessageQueue - Interface in akka.dispatch
A MessageQueue is one of the core components in forming an Akka Mailbox.
messages() - Method in class akka.actor.dsl.Inbox.InboxActor
 
messagesPerResize() - Method in class akka.routing.DefaultResizer
Number of messages between resize operation.
method() - Method in class akka.actor.TypedActor.MethodCall
 
Metric - Class in akka.cluster
Metrics key/value.
metric(String) - Method in class akka.cluster.NodeMetrics
 
Metric$ - Class in akka.cluster
Factory for creating valid Metric instances.
Metric$() - Constructor for class akka.cluster.Metric$
 
metrics() - Method in class akka.cluster.JmxMetricsCollector
 
metrics() - Method in class akka.cluster.NodeMetrics
 
metrics() - Method in class akka.cluster.protobuf.msg.NodeMetrics
 
metrics() - Method in class akka.cluster.SigarMetricsCollector
 
METRICS_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.NodeMetrics$
 
METRICS_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.NodeMetrics
 
MetricsCollector - Interface in akka.cluster
Implementations of cluster system metrics extends this trait.
MetricsCollectorClass() - Method in class akka.cluster.ClusterSettings
 
MetricsEnabled() - Method in class akka.cluster.ClusterSettings
 
MetricsGossip - Class in akka.cluster.protobuf.msg
 
MetricsGossip(Seq<Address>, Seq<String>, Seq<NodeMetrics>) - Constructor for class akka.cluster.protobuf.msg.MetricsGossip
 
MetricsGossip$ - Class in akka.cluster.protobuf.msg
 
MetricsGossip$() - Constructor for class akka.cluster.protobuf.msg.MetricsGossip$
 
MetricsGossipEnvelope - Class in akka.cluster.protobuf.msg
 
MetricsGossipEnvelope(Address, MetricsGossip, boolean) - Constructor for class akka.cluster.protobuf.msg.MetricsGossipEnvelope
 
MetricsGossipEnvelope$ - Class in akka.cluster.protobuf.msg
 
MetricsGossipEnvelope$() - Constructor for class akka.cluster.protobuf.msg.MetricsGossipEnvelope$
 
MetricsGossipInterval() - Method in class akka.cluster.ClusterSettings
 
MetricsInterval() - Method in class akka.cluster.ClusterSettings
 
MetricsMovingAverageHalfLife() - Method in class akka.cluster.ClusterSettings
 
metricsSelector() - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
 
metricsSelector() - Method in interface akka.cluster.routing.AdaptiveLoadBalancingRouterLike
 
MetricsSelector - Interface in akka.cluster.routing
A MetricsSelector is responsible for producing weights from the node metrics.
MinNrOfMembers() - Method in class akka.cluster.ClusterSettings
 
MinNrOfMembersOfRole() - Method in class akka.cluster.ClusterSettings
 
minor() - Method in class akka.zeromq.ZeroMQVersion
 
minStdDeviation() - Method in class akka.remote.PhiAccrualFailureDetector
 
MixMetricsSelector - Class in akka.cluster.routing
MetricsSelector that combines other selectors and aggregates their capacity values.
MixMetricsSelector(IndexedSeq<CapacityMetricsSelector>) - Constructor for class akka.cluster.routing.MixMetricsSelector
 
MixMetricsSelector$ - Class in akka.cluster.routing
Singleton instance of the default MixMetricsSelector, which uses [akka.cluster.routing.HeapMetricsSelector], [akka.cluster.routing.CpuMetricsSelector], and [akka.cluster.routing.SystemLoadAverageMetricsSelector]
MixMetricsSelector$() - Constructor for class akka.cluster.routing.MixMetricsSelector$
 
MixMetricsSelectorBase - Class in akka.cluster.routing
Base class for MetricsSelector that combines other selectors and aggregates their capacity.
MixMetricsSelectorBase(IndexedSeq<CapacityMetricsSelector>) - Constructor for class akka.cluster.routing.MixMetricsSelectorBase
 
MixMetricsSelectorBase(Iterable<CapacityMetricsSelector>) - Constructor for class akka.cluster.routing.MixMetricsSelectorBase
Java API: construct a mix-selector from a sequence of selectors
mkChild(Props, String) - Method in class akka.actor.ActorDSL.Extension
 
mkKey(ActorRef) - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
mkKey(ActorPath) - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
mkProps(Class<?>, Function0<Actor>) - Method in interface akka.actor.dsl.Creators
 
mode() - Method in class akka.remote.transport.ThrottlerTransportAdapter.SetThrottle
 
MODULE$ - Static variable in class akka.actor.Actor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorDSL$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorIdentity$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorInitializationException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorKilledException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorNotFound$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorPath$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorPathExtractor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorRef$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorSelection$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorSystem$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Address$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.AddressFromURIString$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.AllForOneStrategy$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ChildRestartStats$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ContextualTypedActorFactory$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.DeadLetter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.DeathPactException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Deploy$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.FSM$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Identify$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.IllegalActorStateException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Inbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.InvalidActorNameException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.InvalidMessageException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.IO$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.IOManager$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Kill$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.LightArrayRevolverScheduler$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.LocalScope$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.DurableMailboxSpec$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.DurableMailboxSpecActorFactory$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.filebased.filequeue.BrokenItemException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.filebased.filequeue.JournalItem$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.filebased.filequeue.QItem$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.filebased.filequeue.tools.QDumper$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.filebased.filequeue.tools.Util$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.NoScopeGiven$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.OneForOneStrategy$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.OriginalRestartException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.PoisonPill$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.PostRestartException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.PreRestartException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Props$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ReceiveTimeout$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.RelativeActorPath$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.RootActorPath$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.StashOverflowException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Status$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.SupervisorStrategy$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Terminated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.TypedActor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.TypedProps$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.UnhandledMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.agent.Agent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.Ack$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.CamelExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.CamelMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.internal.component.CamelPath$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.Cluster$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterScope$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.Member$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.MemberStatus$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.Metric$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.NodeMetrics$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.protobuf.msg.Address$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.protobuf.msg.ClusterMessages$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.protobuf.msg.Empty$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.protobuf.msg.Gossip$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.protobuf.msg.GossipEnvelope$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.protobuf.msg.GossipOverview$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.protobuf.msg.GossipStatus$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.protobuf.msg.Join$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.protobuf.msg.Member$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.protobuf.msg.MemberStatus$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.protobuf.msg.MetricsGossip$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.protobuf.msg.MetricsGossipEnvelope$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.protobuf.msg.NodeMetrics$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.protobuf.msg.UniqueAddress$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.protobuf.msg.VectorClock$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.protobuf.msg.Welcome$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.AdaptiveLoadBalancingRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.ClusterRouterConfig$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.ClusterRouterSettings$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.CpuMetricsSelector$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.HeapMetricsSelector$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.MixMetricsSelector$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.SystemLoadAverageMetricsSelector$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.StandardMetrics$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.mailbox.PeekMailboxExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ClusterClient$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ClusterReceptionist$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ClusterReceptionistExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ClusterSingletonManager$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.DistributedPubSubExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.DistributedPubSubMediator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ReliableProxy$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.WorkList$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.throttle.Throttler$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.BoundedDequeBasedMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.BoundedMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.BoundedPriorityMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.Dispatchers$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.Envelope$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.ExecutionContexts$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.Filter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.ForkJoinExecutorConfigurator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.Futures$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.japi$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.Mailboxes$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.MonitorableThreadFactory$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.PriorityGenerator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.SingleConsumerOnlyUnboundedMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.TaskInvocation$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.ThreadPoolConfig$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.ThreadPoolConfigBuilder$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.UnboundedDequeBasedMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.UnboundedMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.UnboundedPriorityMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.EventStream$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.Logging$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.LoggingReceive$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.LogSource$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.NoLogging$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.slf4j.Logger$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.BackpressureBuffer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.DelimiterFraming$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Inet$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.IO$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.LengthFieldFrame$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.PipelineFactory$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.PipelinePorts$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.PipelineStage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.PipePairFactory$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.SslTlsSupport$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.StringByteStringAdapter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.TcpMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.TcpPipelineHandler$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.TcpSO$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.TickGenerator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Udp$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.UdpConnected$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.UdpConnectedMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.UdpMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.UdpSO$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.JavaPartialFunction$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.Option$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.Util$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.kernel.Main$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.Main$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.osgi.aries.blueprint.NamespaceHandler$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.osgi.impl.BundleDelegatingClassLoader$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.osgi.OsgiActorSystemFactory$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.osgi.UnregisteringLogService$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.pattern.AskableActorRef$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.pattern.AskableActorSelection$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.pattern.CircuitBreaker$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.pattern.CircuitBreakerOpenException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.pattern.Patterns$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.Ack$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.AckedReceiveBuffer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.AckedSendBuffer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.AddressUidExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.AssociatedEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.AssociationErrorEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.DisassociatedEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.FailureDetector$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.HasSequenceNumber$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteScope$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemotingErrorEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemotingListenEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemotingShutdownEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.routing.RemoteRouterConfig$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.security.provider.AkkaProvider$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.security.provider.InternetSeedGenerator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.SeqNo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.serialization.ProtobufSerializer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.RoleName$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testconductor.TestConductor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.testkit.MultiNodeSpec$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ActorTransportAdapter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AssociationHandle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AssociationRegistry$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.FailureInjectorException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.HandshakeInfo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.netty.NettyFutureBridge$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.netty.NettyTransportSettings$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.TestAssociationHandle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.TestTransport$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.Transport$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.TransportAdaptersExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.Broadcast$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.BroadcastRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ConsistentHash$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ConsistentHashingRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.CurrentRoutees$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.Deafen$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.DefaultResizer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.Destination$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.FromConfig$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.Listen$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.MurmurHash$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.NoRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RandomRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RoundRobinRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RouterRoutees$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ScatterGatherFirstCompletedRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.SmallestMailboxRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.WithListeners$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.serialization.JavaSerializer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.serialization.NullSerializer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.serialization.Serialization$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.serialization.SerializationExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.AkkaSpec$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.CallingThreadDispatcher$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.Coroner$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.CustomEventFilter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.DeadLettersFilter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.DebugFilter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.ErrorFilter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.EventFilter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.ExtractRoute$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.InfoFilter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.LongRunningTest$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.PerformanceTest$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestActor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestActorRef$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestActorRefSpec$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestBarrier$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestFSMRef$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestKit$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestKitExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestLatch$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestProbe$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TimingTest$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.WarningFilter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.transactor.Coordinated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.transactor.SendTo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.transactor.TransactorExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.BoxedType$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.ByteIterator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.ByteString$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.CompactByteString$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.Crypt$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.HashCode$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.Helpers$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.Switch$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.Timeout$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Affinity$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Backlog$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Bind$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Closed$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Connect$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Connecting$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Context$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.FileDescriptor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.HighWatermark$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Identity$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Linger$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Listener$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.MaxMsgSize$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.MulticastHops$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.MulticastLoop$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.PollDispatcher$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.PollTimeoutDuration$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Rate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.ReceiveBufferSize$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.ReceiveHighWatermark$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.ReconnectIVL$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.ReconnectIVLMax$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.RecoveryInterval$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Send$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.SendBufferSize$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.SendHighWatermark$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.SocketType$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Subscribe$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Swap$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Unsubscribe$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.ZeroMQ$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.ZeroMQExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.ZeroMQVersion$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.ZMQMessage$
Static reference to the singleton instance of this Scala object.
MonitorableThreadFactory - Class in akka.dispatch
 
MonitorableThreadFactory(String, boolean, Option<ClassLoader>, Thread.UncaughtExceptionHandler, AtomicLong) - Constructor for class akka.dispatch.MonitorableThreadFactory
 
MonitorableThreadFactory$ - Class in akka.dispatch
 
MonitorableThreadFactory$() - Constructor for class akka.dispatch.MonitorableThreadFactory$
 
MonitoredByNrOfMembers() - Method in class akka.cluster.ClusterSettings
 
msg() - Method in class akka.actor.FSM.Timer
 
msg() - Method in class akka.contrib.pattern.ClusterClient.Publish
 
msg() - Method in class akka.contrib.pattern.ClusterClient.Send
 
msg() - Method in class akka.contrib.pattern.ClusterClient.SendToAll
 
msg() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Publish
 
msg() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Send
 
msg() - Method in class akka.contrib.pattern.DistributedPubSubMediator.SendToAll
 
msg() - Method in class akka.contrib.pattern.ReliableProxy.Message
 
msg() - Method in class akka.io.TcpPipelineHandler.Tell
 
msg() - Method in exception akka.remote.transport.FailureInjectorException
 
msg() - Method in exception akka.remote.transport.Transport.InvalidAssociationException
 
msg() - Method in interface akka.testkit.TestActor.Message
 
msg() - Method in class akka.testkit.TestActor.NullMessage$
 
msg() - Method in class akka.testkit.TestActor.RealMessage
 
msg() - Method in class akka.testkit.TestActorRefSpec.Logger
 
msgAvailable() - Method in class akka.testkit.JavaTestKit
Query queue status.
msgAvailable() - Method in interface akka.testkit.TestKitBase
Query queue status.
msgsPer(int, TimeUnit) - Method in class akka.contrib.throttle.Throttler.RateInt
 
msgsPer(FiniteDuration) - Method in class akka.contrib.throttle.Throttler.RateInt
 
msgsPerHour() - Method in class akka.contrib.throttle.Throttler.RateInt
 
msgsPerMinute() - Method in class akka.contrib.throttle.Throttler.RateInt
 
msgsPerSecond() - Method in class akka.contrib.throttle.Throttler.RateInt
 
MulticastHops - Class in akka.zeromq
Sets the time-to-live field in every multicast packet sent from this socket.
MulticastHops(long) - Constructor for class akka.zeromq.MulticastHops
 
multicastHops() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its multicast hops configuration.
multicastHops() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its multicast hops configuration.
MulticastHops$ - Class in akka.zeromq
Gets the MulticastHops
MulticastHops$() - Constructor for class akka.zeromq.MulticastHops$
 
MulticastLoop - Class in akka.zeromq
Controls whether data sent via multicast transports using the specified socket can also be received by the sending host via loop-back.
MulticastLoop(boolean) - Constructor for class akka.zeromq.MulticastLoop
 
multicastLoop() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its multicast loop configuration.
multicastLoop() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its multicast loop configuration.
MulticastLoop$ - Class in akka.zeromq
Gets the MulticastLoop
MulticastLoop$() - Constructor for class akka.zeromq.MulticastLoop$
 
MultiNodeConfig - Class in akka.remote.testkit
Configure the role names and participants of the test, including configuration settings.
MultiNodeConfig() - Constructor for class akka.remote.testkit.MultiNodeConfig
 
MultiNodeSpec - Class in akka.remote.testkit
Note: To be able to run tests with everything ignored or excluded by tags you must not use testconductor, or helper methods that use testconductor, from the constructor of your test class.
MultiNodeSpec(RoleName, ActorSystem, Seq<RoleName>, Function1<RoleName, Seq<String>>) - Constructor for class akka.remote.testkit.MultiNodeSpec
 
MultiNodeSpec(MultiNodeConfig) - Constructor for class akka.remote.testkit.MultiNodeSpec
 
MultiNodeSpec$ - Class in akka.remote.testkit
 
MultiNodeSpec$() - Constructor for class akka.remote.testkit.MultiNodeSpec$
 
MultiNodeSpec.AwaitHelper<T> - Class in akka.remote.testkit
 
MultiNodeSpec.AwaitHelper(Awaitable<T>) - Constructor for class akka.remote.testkit.MultiNodeSpec.AwaitHelper
 
multiNodeSpecAfterAll() - Method in class akka.remote.testkit.MultiNodeSpec
 
multiNodeSpecAfterAll() - Method in interface akka.remote.testkit.MultiNodeSpecCallbacks
Call this after the all test cases have run.
multiNodeSpecBeforeAll() - Method in class akka.remote.testkit.MultiNodeSpec
 
multiNodeSpecBeforeAll() - Method in interface akka.remote.testkit.MultiNodeSpecCallbacks
Call this before the start of the test run.
MultiNodeSpecCallbacks - Interface in akka.remote.testkit
Use this to hook MultiNodeSpec into your test framework lifecycle, either by having your test extend MultiNodeSpec and call these methods or by creating a trait that calls them and then mixing that trait with your test together with MultiNodeSpec.
MultipleConsumerSemantics - Interface in akka.dispatch
This is a marker trait for message queues which support multiple consumers, as is required by the BalancingDispatcher.
MurmurHash - Class in akka.routing
An object designed to generate well-distributed non-cryptographic hashes.
MurmurHash() - Constructor for class akka.routing.MurmurHash
 
MurmurHash$ - Class in akka.routing
An object designed to generate well-distributed non-cryptographic hashes.
MurmurHash$() - Constructor for class akka.routing.MurmurHash$
 
muteDeadLetters(Seq<Class<?>>, ActorSystem) - Method in class akka.remote.testkit.MultiNodeSpec
 
muteDeadLetters(Seq<Class<?>>, ActorSystem) - Method in class akka.testkit.AkkaSpec
 
myself() - Method in class akka.remote.testkit.MultiNodeConfig
 
myself() - Method in class akka.remote.testkit.MultiNodeSpec
 
myVersions() - Method in class akka.contrib.pattern.DistributedPubSubMediator
 

N

nacked() - Method in class akka.remote.AckedSendBuffer
 
nacks() - Method in class akka.remote.Ack
 
NACKS_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AcknowledgementInfo
 
name() - Method in interface akka.actor.ActorPath
The name of the actor that this path refers to.
name() - Method in class akka.actor.ActorSystem
The name of this actor system, used to distinguish multiple ones within the same JVM & class loader.
name() - Method in class akka.actor.ActorSystem.Settings
 
name() - Method in class akka.actor.ChildActorPath
 
name() - Method in class akka.actor.FSM.Timer
 
name() - Method in interface akka.actor.mailbox.DurableMailboxSettings
Name of this mailbox type for purposes of configuration scoping.
name() - Method in class akka.actor.mailbox.DurableMessageQueue
 
name() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
name() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
name() - Method in class akka.actor.RootActorPath
 
name() - Method in class akka.cluster.Metric
 
name() - Method in class akka.dispatch.MonitorableThreadFactory
 
name() - Method in class akka.remote.testconductor.RoleName
 
name() - Method in class akka.zeromq.PollDispatcher
 
NAME_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
NAME_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Hello
 
nameIndex() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Metric
 
NAMEINDEX_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Metric$
 
NamespaceHandler - Class in akka.osgi.aries.blueprint
Aries Blueprint namespace handler implementation.
NamespaceHandler() - Constructor for class akka.osgi.aries.blueprint.NamespaceHandler
 
NamespaceHandler$ - Class in akka.osgi.aries.blueprint
 
NamespaceHandler$() - Constructor for class akka.osgi.aries.blueprint.NamespaceHandler$
 
nanoTimeOfLastSend() - Method in class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket
 
NettyFutureBridge - Class in akka.remote.transport.netty
 
NettyFutureBridge() - Constructor for class akka.remote.transport.netty.NettyFutureBridge
 
NettyFutureBridge$ - Class in akka.remote.transport.netty
 
NettyFutureBridge$() - Constructor for class akka.remote.transport.netty.NettyFutureBridge$
 
NettyTransport - Class in akka.remote.transport.netty
 
NettyTransport(NettyTransportSettings, ExtendedActorSystem) - Constructor for class akka.remote.transport.netty.NettyTransport
 
NettyTransport(ExtendedActorSystem, com.typesafe.config.Config) - Constructor for class akka.remote.transport.netty.NettyTransport
 
NettyTransportException - Exception in akka.remote.transport.netty
 
NettyTransportException(String, Throwable) - Constructor for exception akka.remote.transport.netty.NettyTransportException
 
NettyTransportException(String) - Constructor for exception akka.remote.transport.netty.NettyTransportException
 
NettyTransportSettings - Class in akka.remote.transport.netty
 
NettyTransportSettings(com.typesafe.config.Config) - Constructor for class akka.remote.transport.netty.NettyTransportSettings
 
NettyTransportSettings$ - Class in akka.remote.transport.netty
 
NettyTransportSettings$() - Constructor for class akka.remote.transport.netty.NettyTransportSettings$
 
NettyTransportSettings.Mode - Interface in akka.remote.transport.netty
 
NettyTransportSettings.Tcp$ - Class in akka.remote.transport.netty
 
NettyTransportSettings.Tcp$() - Constructor for class akka.remote.transport.netty.NettyTransportSettings.Tcp$
 
NettyTransportSettings.Udp$ - Class in akka.remote.transport.netty
 
NettyTransportSettings.Udp$() - Constructor for class akka.remote.transport.netty.NettyTransportSettings.Udp$
 
newActorCell(akka.actor.ActorSystemImpl, akka.actor.InternalActorRef, Props, MessageDispatcher, akka.actor.InternalActorRef) - Method in class akka.testkit.TestActorRef
 
newBuilder() - Method in class akka.cluster.protobuf.msg.Address$
 
newBuilder(Address) - Method in class akka.cluster.protobuf.msg.Address$
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.Address
 
newBuilder(Address) - Static method in class akka.cluster.protobuf.msg.Address
 
newBuilder() - Method in class akka.cluster.protobuf.msg.Empty$
 
newBuilder(Empty) - Method in class akka.cluster.protobuf.msg.Empty$
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.Empty
 
newBuilder(Empty) - Static method in class akka.cluster.protobuf.msg.Empty
 
newBuilder() - Method in class akka.cluster.protobuf.msg.Gossip$
 
newBuilder(Gossip) - Method in class akka.cluster.protobuf.msg.Gossip$
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.Gossip
 
newBuilder(Gossip) - Static method in class akka.cluster.protobuf.msg.Gossip
 
newBuilder() - Method in class akka.cluster.protobuf.msg.GossipEnvelope$
 
newBuilder(GossipEnvelope) - Method in class akka.cluster.protobuf.msg.GossipEnvelope$
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.GossipEnvelope
 
newBuilder(GossipEnvelope) - Static method in class akka.cluster.protobuf.msg.GossipEnvelope
 
newBuilder() - Method in class akka.cluster.protobuf.msg.GossipOverview$
 
newBuilder(GossipOverview) - Method in class akka.cluster.protobuf.msg.GossipOverview$
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.GossipOverview
 
newBuilder(GossipOverview) - Static method in class akka.cluster.protobuf.msg.GossipOverview
 
newBuilder() - Method in class akka.cluster.protobuf.msg.GossipOverview.Seen$
 
newBuilder(GossipOverview.Seen) - Method in class akka.cluster.protobuf.msg.GossipOverview.Seen$
 
newBuilder() - Method in class akka.cluster.protobuf.msg.GossipStatus$
 
newBuilder(GossipStatus) - Method in class akka.cluster.protobuf.msg.GossipStatus$
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.GossipStatus
 
newBuilder(GossipStatus) - Static method in class akka.cluster.protobuf.msg.GossipStatus
 
newBuilder() - Method in class akka.cluster.protobuf.msg.Join$
 
newBuilder(Join) - Method in class akka.cluster.protobuf.msg.Join$
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.Join
 
newBuilder(Join) - Static method in class akka.cluster.protobuf.msg.Join
 
newBuilder() - Method in class akka.cluster.protobuf.msg.Member$
 
newBuilder(Member) - Method in class akka.cluster.protobuf.msg.Member$
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.Member
 
newBuilder(Member) - Static method in class akka.cluster.protobuf.msg.Member
 
newBuilder() - Method in class akka.cluster.protobuf.msg.MetricsGossip$
 
newBuilder(MetricsGossip) - Method in class akka.cluster.protobuf.msg.MetricsGossip$
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.MetricsGossip
 
newBuilder(MetricsGossip) - Static method in class akka.cluster.protobuf.msg.MetricsGossip
 
newBuilder() - Method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope$
 
newBuilder(MetricsGossipEnvelope) - Method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope$
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope
 
newBuilder(MetricsGossipEnvelope) - Static method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope
 
newBuilder() - Method in class akka.cluster.protobuf.msg.NodeMetrics$
 
newBuilder(NodeMetrics) - Method in class akka.cluster.protobuf.msg.NodeMetrics$
 
newBuilder() - Method in class akka.cluster.protobuf.msg.NodeMetrics.EWMA$
 
newBuilder(NodeMetrics.EWMA) - Method in class akka.cluster.protobuf.msg.NodeMetrics.EWMA$
 
newBuilder() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Metric$
 
newBuilder(NodeMetrics.Metric) - Method in class akka.cluster.protobuf.msg.NodeMetrics.Metric$
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.NodeMetrics
 
newBuilder(NodeMetrics) - Static method in class akka.cluster.protobuf.msg.NodeMetrics
 
newBuilder() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number$
 
newBuilder(NodeMetrics.Number) - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number$
 
newBuilder() - Method in class akka.cluster.protobuf.msg.UniqueAddress$
 
newBuilder(UniqueAddress) - Method in class akka.cluster.protobuf.msg.UniqueAddress$
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.UniqueAddress
 
newBuilder(UniqueAddress) - Static method in class akka.cluster.protobuf.msg.UniqueAddress
 
newBuilder() - Method in class akka.cluster.protobuf.msg.VectorClock$
 
newBuilder(VectorClock) - Method in class akka.cluster.protobuf.msg.VectorClock$
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.VectorClock
 
newBuilder(VectorClock) - Static method in class akka.cluster.protobuf.msg.VectorClock
 
newBuilder() - Method in class akka.cluster.protobuf.msg.VectorClock.Version$
 
newBuilder(VectorClock.Version) - Method in class akka.cluster.protobuf.msg.VectorClock.Version$
 
newBuilder() - Method in class akka.cluster.protobuf.msg.Welcome$
 
newBuilder(Welcome) - Method in class akka.cluster.protobuf.msg.Welcome$
 
newBuilder() - Static method in class akka.cluster.protobuf.msg.Welcome
 
newBuilder(Welcome) - Static method in class akka.cluster.protobuf.msg.Welcome
 
newBuilder() - Static method in class akka.remote.ContainerFormats.Selection
 
newBuilder(ContainerFormats.Selection) - Static method in class akka.remote.ContainerFormats.Selection
 
newBuilder() - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
newBuilder(ContainerFormats.SelectionEnvelope) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
newBuilder() - Static method in class akka.remote.testconductor.TestConductorProtocol.Address
 
newBuilder(TestConductorProtocol.Address) - Static method in class akka.remote.testconductor.TestConductorProtocol.Address
 
newBuilder() - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
newBuilder(TestConductorProtocol.AddressRequest) - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
newBuilder() - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
newBuilder(TestConductorProtocol.EnterBarrier) - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
newBuilder() - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
newBuilder(TestConductorProtocol.Hello) - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
newBuilder() - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
newBuilder(TestConductorProtocol.InjectFailure) - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
newBuilder() - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
newBuilder(TestConductorProtocol.Wrapper) - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
newBuilder() - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
newBuilder(WireFormats.AckAndEnvelopeContainer) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
newBuilder() - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
newBuilder(WireFormats.AcknowledgementInfo) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
newBuilder() - Static method in class akka.remote.WireFormats.ActorRefData
 
newBuilder(WireFormats.ActorRefData) - Static method in class akka.remote.WireFormats.ActorRefData
 
newBuilder() - Static method in class akka.remote.WireFormats.AddressData
 
newBuilder(WireFormats.AddressData) - Static method in class akka.remote.WireFormats.AddressData
 
newBuilder() - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
newBuilder(WireFormats.AkkaControlMessage) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
newBuilder() - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
newBuilder(WireFormats.AkkaHandshakeInfo) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
newBuilder() - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
newBuilder(WireFormats.AkkaProtocolMessage) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
newBuilder() - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
newBuilder(WireFormats.DaemonMsgCreateData) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
newBuilder() - Static method in class akka.remote.WireFormats.DeployData
 
newBuilder(WireFormats.DeployData) - Static method in class akka.remote.WireFormats.DeployData
 
newBuilder() - Static method in class akka.remote.WireFormats.PropsData
 
newBuilder(WireFormats.PropsData) - Static method in class akka.remote.WireFormats.PropsData
 
newBuilder() - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
newBuilder(WireFormats.RemoteEnvelope) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
newBuilder() - Static method in class akka.remote.WireFormats.SerializedMessage
 
newBuilder(WireFormats.SerializedMessage) - Static method in class akka.remote.WireFormats.SerializedMessage
 
newBuilder() - Method in class akka.util.ByteString$
 
newBuilder() - Method in class akka.util.ByteString
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.Address
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.Empty
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.Gossip
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.GossipEnvelope
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.GossipOverview
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.GossipOverview.Seen
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.GossipStatus
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.Join
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.Member
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.NodeMetrics.EWMA
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Metric
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.NodeMetrics
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.UniqueAddress
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.VectorClock
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.VectorClock.Version
 
newBuilderForType() - Method in class akka.cluster.protobuf.msg.Welcome
 
newBuilderForType() - Method in class akka.remote.ContainerFormats.Selection
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.ContainerFormats.Selection
 
newBuilderForType() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
newBuilderForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
newBuilderForType() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
newBuilderForType() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
newBuilderForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
newBuilderForType() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
newBuilderForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
newBuilderForType() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
newBuilderForType() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
newBuilderForType() - Method in class akka.remote.WireFormats.ActorRefData
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.ActorRefData
 
newBuilderForType() - Method in class akka.remote.WireFormats.AddressData
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.AddressData
 
newBuilderForType() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.AkkaControlMessage
 
newBuilderForType() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
newBuilderForType() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
newBuilderForType() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
newBuilderForType() - Method in class akka.remote.WireFormats.DeployData
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.DeployData
 
newBuilderForType() - Method in class akka.remote.WireFormats.PropsData
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.PropsData
 
newBuilderForType() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.RemoteEnvelope
 
newBuilderForType() - Method in class akka.remote.WireFormats.SerializedMessage
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.SerializedMessage
 
newDealerSocket(SocketOption[]) - Method in class akka.zeromq.ZeroMQExtension
Java API factory method to create the actor representing the ZeroMQ Dealer socket.
newDealerSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Java API: Factory method to create the Props to build a ZeroMQ Dealer socket actor.
newPubSocket(SocketOption[]) - Method in class akka.zeromq.ZeroMQExtension
Java API factory method to create the actor representing the ZeroMQ Publisher socket.
newPubSocket(Bind) - Method in class akka.zeromq.ZeroMQExtension
Convenience for creating a publisher socket.
newPubSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Java API: Factory method to create the Props to build a ZeroMQ Publisher socket actor.
newPullSocket(SocketOption[]) - Method in class akka.zeromq.ZeroMQExtension
Java API factory method to create the actor representing the ZeroMQ Pull socket.
newPullSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Java API: Factory method to create the Props to build a ZeroMQ Pull socket actor.
newPushSocket(SocketOption[]) - Method in class akka.zeromq.ZeroMQExtension
Java API factory method to create the actor representing the ZeroMQ Push socket.
newPushSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Java API: Factory method to create the Props to build a ZeroMQ Push socket actor.
newReceiver() - Method in interface akka.actor.dsl.Inbox.InboxExtension
 
newRepSocket(SocketOption[]) - Method in class akka.zeromq.ZeroMQExtension
Java API factory method to create the actor representing the ZeroMQ Rep socket.
newRepSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Java API: Factory method to create the Props to build a ZeroMQ Rep socket actor.
newReqSocket(SocketOption[]) - Method in class akka.zeromq.ZeroMQExtension
Java API factory method to create the actor representing the ZeroMQ Req socket.
newReqSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Java API: Factory method to create the Props to build a ZeroMQ Req socket actor.
newRouterSocket(SocketOption[]) - Method in class akka.zeromq.ZeroMQExtension
Java API factory method to create the actor representing the ZeroMQ Router socket.
newRouterSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Java API: Factory method to create the Props to build a ZeroMQ Router socket actor.
newSocket(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Factory method to create the actor representing the ZeroMQ socket.
newSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Factory method to create the Props to build the ZeroMQ socket actor.
NewSocketTimeout() - Method in class akka.zeromq.ZeroMQExtension
 
newSubSocket(SocketOption[]) - Method in class akka.zeromq.ZeroMQExtension
Java API factory method to create the actor representing the ZeroMQ Subscriber socket.
newSubSocket(Connect, Listener, Subscribe) - Method in class akka.zeromq.ZeroMQExtension
Convenience for creating a subscriber socket.
newSubSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Java API: Factory method to create the Props to build a ZeroMQ Subscriber socket actor.
newThread(ForkJoinPool) - Method in class akka.dispatch.MonitorableThreadFactory
 
newThread(Runnable) - Method in class akka.dispatch.MonitorableThreadFactory
 
newTimeout(TimerTask, FiniteDuration) - Method in class akka.util.internal.HashedWheelTimer
Deprecated.  
newTimeout(TimerTask, FiniteDuration) - Method in interface akka.util.internal.Timer
Deprecated. Schedules the specified TimerTask for one-time execution after the specified delay.
next() - Method in class akka.contrib.pattern.WorkList.Entry
 
next() - Method in class akka.dispatch.AbstractNodeQueue.Node
 
next() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
next() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
next() - Method in class akka.util.ByteIterator
 
nextId() - Method in class akka.remote.transport.ActorTransportAdapterManager
 
nextMagicA(int) - Method in class akka.routing.MurmurHash$
Given a magic integer from the first stream, compute the next
nextMagicA(int) - Static method in class akka.routing.MurmurHash
Given a magic integer from the first stream, compute the next
nextMagicB(int) - Method in class akka.routing.MurmurHash$
Given a magic integer from the second stream, compute the next
nextMagicB(int) - Static method in class akka.routing.MurmurHash
Given a magic integer from the second stream, compute the next
nextSerial() - Method in class akka.contrib.pattern.ReliableProxy
 
nextState() - Method in interface akka.actor.FSM
 
nextStateData() - Method in interface akka.actor.FSM
Return next state data (available in onTransition handlers)
nextVersion() - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
no() - Method in class akka.zeromq.Linger$
 
no() - Static method in class akka.zeromq.Linger
 
noAck(Object) - Method in class akka.io.TcpMessage$
Each Tcp.WriteCommand can optionally request a positive acknowledgment to be sent to the commanding actor.
noAck() - Method in class akka.io.TcpMessage$
Default Tcp.NoAck instance which is used when no acknowledgment information is explicitly provided.
noAck(Object) - Static method in class akka.io.TcpMessage
Each Tcp.WriteCommand can optionally request a positive acknowledgment to be sent to the commanding actor.
noAck() - Static method in class akka.io.TcpMessage
Default Tcp.NoAck instance which is used when no acknowledgment information is explicitly provided.
noAck(Object) - Method in class akka.io.UdpConnectedMessage$
Each UdpConnected.Send can optionally request a positive acknowledgment to be sent to the commanding actor.
noAck() - Method in class akka.io.UdpConnectedMessage$
Default UdpConnected.NoAck instance which is used when no acknowledgment information is explicitly provided.
noAck(Object) - Static method in class akka.io.UdpConnectedMessage
Each UdpConnected.Send can optionally request a positive acknowledgment to be sent to the commanding actor.
noAck() - Static method in class akka.io.UdpConnectedMessage
Default UdpConnected.NoAck instance which is used when no acknowledgment information is explicitly provided.
noAck(Object) - Method in class akka.io.UdpMessage$
Each Udp.Send can optionally request a positive acknowledgment to be sent to the commanding actor.
noAck() - Method in class akka.io.UdpMessage$
Default Udp.NoAck instance which is used when no acknowledgment information is explicitly provided.
noAck(Object) - Static method in class akka.io.UdpMessage
Each Udp.Send can optionally request a positive acknowledgment to be sent to the commanding actor.
noAck() - Static method in class akka.io.UdpMessage
Default Udp.NoAck instance which is used when no acknowledgment information is explicitly provided.
noAutoPilot() - Method in class akka.testkit.TestActor.AutoPilot
 
nobody() - Method in interface akka.transactor.Transactor
Empty set of transactors to send to.
nobody() - Method in class akka.transactor.UntypedTransactor
Empty set of transactors to send to.
noCause() - Method in class akka.event.Logging$
Null Object used for errors without cause Throwable
noCause() - Static method in class akka.event.Logging
Null Object used for errors without cause Throwable
node() - Method in class akka.cluster.protobuf.msg.Join
 
node() - Method in class akka.remote.RemoteScope
 
node(RoleName) - Method in class akka.remote.testkit.MultiNodeSpec
Query the controller for the transport address of the given node (by role name) and return that as an ActorPath for easy composition:
NODE_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.Join$
 
NODE_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.Join
 
NODE_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
nodeConfig(Seq<RoleName>, Seq<com.typesafe.config.Config>) - Method in class akka.remote.testkit.MultiNodeConfig
Register a config override for a specific participant.
nodeConfig() - Method in class akka.remote.testkit.MultiNodeSpec$
 
nodeConfig() - Static method in class akka.remote.testkit.MultiNodeSpec
 
nodeFor(byte[]) - Method in class akka.routing.ConsistentHash
Get the node responsible for the data key.
nodeFor(String) - Method in class akka.routing.ConsistentHash
Get the node responsible for the data key.
NodeMessageQueue - Class in akka.dispatch
 
NodeMessageQueue() - Constructor for class akka.dispatch.NodeMessageQueue
 
nodeMetrics() - Method in class akka.cluster.ClusterEvent.ClusterMetricsChanged
 
NodeMetrics - Class in akka.cluster
The snapshot of current sampled health metrics for any monitored process.
NodeMetrics(Address, long, Set<Metric>) - Constructor for class akka.cluster.NodeMetrics
 
nodeMetrics() - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
NodeMetrics - Class in akka.cluster.protobuf.msg
 
NodeMetrics(int, long, Seq<NodeMetrics.Metric>) - Constructor for class akka.cluster.protobuf.msg.NodeMetrics
 
NodeMetrics$ - Class in akka.cluster
 
NodeMetrics$() - Constructor for class akka.cluster.NodeMetrics$
 
NodeMetrics$ - Class in akka.cluster.protobuf.msg
 
NodeMetrics$() - Constructor for class akka.cluster.protobuf.msg.NodeMetrics$
 
NodeMetrics.EWMA - Class in akka.cluster.protobuf.msg
 
NodeMetrics.EWMA(double, double) - Constructor for class akka.cluster.protobuf.msg.NodeMetrics.EWMA
 
NodeMetrics.EWMA$ - Class in akka.cluster.protobuf.msg
 
NodeMetrics.EWMA$() - Constructor for class akka.cluster.protobuf.msg.NodeMetrics.EWMA$
 
NodeMetrics.Metric - Class in akka.cluster.protobuf.msg
 
NodeMetrics.Metric(int, NodeMetrics.Number, Option<NodeMetrics.EWMA>) - Constructor for class akka.cluster.protobuf.msg.NodeMetrics.Metric
 
NodeMetrics.Metric$ - Class in akka.cluster.protobuf.msg
 
NodeMetrics.Metric$() - Constructor for class akka.cluster.protobuf.msg.NodeMetrics.Metric$
 
NodeMetrics.Number - Class in akka.cluster.protobuf.msg
 
NodeMetrics.Number(akka.cluster.protobuf.msg.NodeMetrics.NumberType.EnumVal, Option<Object>, Option<Object>, Option<com.google.protobuf.ByteString>) - Constructor for class akka.cluster.protobuf.msg.NodeMetrics.Number
 
NodeMetrics.Number$ - Class in akka.cluster.protobuf.msg
 
NodeMetrics.Number$() - Constructor for class akka.cluster.protobuf.msg.NodeMetrics.Number$
 
NodeMetrics.NumberType$ - Class in akka.cluster.protobuf.msg
 
NodeMetrics.NumberType$() - Constructor for class akka.cluster.protobuf.msg.NodeMetrics.NumberType$
 
NodeMetrics.NumberType$.EnumVal - Interface in akka.cluster.protobuf.msg
 
NODEMETRICS_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.MetricsGossip$
 
NODEMETRICS_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.MetricsGossip
 
nodes() - Method in class akka.contrib.pattern.ClusterReceptionist
 
nodes() - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
nodes() - Method in class akka.remote.routing.RemoteRouterConfig
 
NoDispatcherGiven() - Method in class akka.actor.Deploy$
 
NoDispatcherGiven() - Static method in class akka.actor.Deploy
 
noIncrement(Object) - Method in class akka.transactor.Coordinated
Create a new Coordinated object but *do not* increment the number of members by one.
NoLogging - Class in akka.event
NoLogging is a LoggingAdapter that does absolutely nothing – no logging at all.
NoLogging() - Constructor for class akka.event.NoLogging
 
NoLogging$ - Class in akka.event
NoLogging is a LoggingAdapter that does absolutely nothing – no logging at all.
NoLogging$() - Constructor for class akka.event.NoLogging$
 
NoMailboxGiven() - Method in class akka.actor.Deploy$
 
NoMailboxGiven() - Static method in class akka.actor.Deploy
 
NoMailboxRequirement() - Method in class akka.dispatch.Mailboxes$
 
noMatch() - Method in class akka.japi.JavaPartialFunction$
 
noMatch() - Static method in class akka.japi.JavaPartialFunction
 
noMatch() - Method in class akka.testkit.JavaTestKit.ExpectMsg
 
noMatch() - Method in class akka.testkit.JavaTestKit.ReceiveWhile
 
nonAcked() - Method in class akka.remote.AckedSendBuffer
 
none() - Method in class akka.cluster.Member$
 
none() - Static method in class akka.cluster.Member
 
none() - Method in class akka.japi.Option$
Option factory that creates None
none() - Static method in class akka.japi.Option
Option factory that creates None
normally() - Method in interface akka.transactor.Transactor
Bypass transactionality and behave like a normal actor.
normally(Object) - Method in class akka.transactor.UntypedTransactor
Bypass transactionality and behave like a normal actor.
NoRouter - Class in akka.routing
Routing configuration that indicates no routing; this is also the default value which hence overrides the merge strategy in order to accept values from lower-precedence sources.
NoRouter() - Constructor for class akka.routing.NoRouter
 
NoRouter$ - Class in akka.routing
 
NoRouter$() - Constructor for class akka.routing.NoRouter$
 
NoScopeGiven - Class in akka.actor
This is the default value and as such allows overrides.
NoScopeGiven() - Constructor for class akka.actor.NoScopeGiven
 
NoScopeGiven$ - Class in akka.actor
 
NoScopeGiven$() - Constructor for class akka.actor.NoScopeGiven$
 
noSender() - Method in class akka.actor.Actor$
Default placeholder (null) used for "!" to indicate that there is no sender of the message, that will be translated to the receiving system's deadLetters.
noSender() - Method in interface akka.actor.Actor
Default placeholder (null) used for "!" to indicate that there is no sender of the message, that will be translated to the receiving system's deadLetters.
noSender() - Method in class akka.actor.ActorRef$
Use this value as an argument to ActorRef.tell(java.lang.Object, akka.actor.ActorRef) if there is not actor to reply to (e.g.
noSender() - Static method in class akka.actor.ActorRef
Use this value as an argument to ActorRef.tell(java.lang.Object, akka.actor.ActorRef) if there is not actor to reply to (e.g.
NoSerializationVerificationNeeded - Interface in akka.actor
Marker trait to signal that this class should not be verified for serializability.
nothing() - Method in interface akka.io.PipelineContext
A shared (and shareable) instance of an empty Iterable[Either[EvtAbove, CmdBelow}.
notify(AssociationHandle.HandleEvent) - Method in class akka.remote.transport.AssociationHandle.ActorHandleEventListener
 
notify(AssociationHandle.HandleEvent) - Method in interface akka.remote.transport.AssociationHandle.HandleEventListener
Called by the transport to notify the listener about a HandleEvent
notify(Transport.AssociationEvent) - Method in class akka.remote.transport.Transport.ActorAssociationEventListener
 
notify(Transport.AssociationEvent) - Method in interface akka.remote.transport.Transport.AssociationEventListener
Called by the transport to notify the listener about an AssociationEvent
notifyDebug(String) - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
notifyDebug(String) - Method in class akka.event.BusLogging
 
notifyDebug(String) - Method in interface akka.event.LoggingAdapter
 
notifyDebug(String) - Method in class akka.event.NoLogging$
 
notifyDebug(String) - Static method in class akka.event.NoLogging
 
notifyError(String) - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
notifyError(Throwable, String) - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
notifyError(String) - Method in class akka.event.BusLogging
 
notifyError(Throwable, String) - Method in class akka.event.BusLogging
 
notifyError(String) - Method in interface akka.event.LoggingAdapter
 
notifyError(Throwable, String) - Method in interface akka.event.LoggingAdapter
 
notifyError(String) - Method in class akka.event.NoLogging$
 
notifyError(Throwable, String) - Method in class akka.event.NoLogging$
 
notifyError(String) - Static method in class akka.event.NoLogging
 
notifyError(Throwable, String) - Static method in class akka.event.NoLogging
 
notifyInfo(String) - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
notifyInfo(String) - Method in class akka.event.BusLogging
 
notifyInfo(String) - Method in interface akka.event.LoggingAdapter
 
notifyInfo(String) - Method in class akka.event.NoLogging$
 
notifyInfo(String) - Static method in class akka.event.NoLogging
 
notifyLog(Logging.LogLevel, String) - Method in interface akka.event.LoggingAdapter
 
notifyWarning(String) - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
notifyWarning(String) - Method in class akka.event.BusLogging
 
notifyWarning(String) - Method in interface akka.event.LoggingAdapter
 
notifyWarning(String) - Method in class akka.event.NoLogging$
 
notifyWarning(String) - Static method in class akka.event.NoLogging
 
now() - Method in class akka.testkit.TestKit$
Obtain current timestamp as Duration for relative measurements (using System.nanoTime).
now() - Static method in class akka.testkit.TestKit
Obtain current timestamp as Duration for relative measurements (using System.nanoTime).
now() - Method in interface akka.testkit.TestKitBase
Obtain current time (System.nanoTime) as Duration.
nrOfInstances() - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
 
nrOfInstances() - Method in interface akka.cluster.routing.AdaptiveLoadBalancingRouterLike
 
nrOfInstances() - Method in interface akka.routing.BroadcastLike
 
nrOfInstances() - Method in class akka.routing.BroadcastRouter
 
nrOfInstances() - Method in interface akka.routing.ConsistentHashingLike
 
nrOfInstances() - Method in class akka.routing.ConsistentHashingRouter
 
nrOfInstances() - Method in interface akka.routing.RandomLike
 
nrOfInstances() - Method in class akka.routing.RandomRouter
 
nrOfInstances() - Method in interface akka.routing.RoundRobinLike
 
nrOfInstances() - Method in class akka.routing.RoundRobinRouter
 
nrOfInstances() - Method in interface akka.routing.ScatterGatherFirstCompletedLike
 
nrOfInstances() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
nrOfInstances() - Method in interface akka.routing.SmallestMailboxLike
 
nrOfInstances() - Method in class akka.routing.SmallestMailboxRouter
 
NrOfSelectors() - Method in class akka.io.TcpExt.Settings
 
nullAsBytes() - Method in class akka.serialization.NullSerializer
 
NullSerializer - Class in akka.serialization
This is a special Serializer that Serializes and deserializes nulls only
NullSerializer() - Constructor for class akka.serialization.NullSerializer
 
NullSerializer$ - Class in akka.serialization
 
NullSerializer$() - Constructor for class akka.serialization.NullSerializer$
 
num() - Method in class akka.actor.mailbox.DurableMailboxSpecActorFactory.AccumulatorActor
 
num() - Method in class akka.io.BackpressureBuffer.Ack
 
number() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Metric
 
NUMBER_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Metric$
 
numberOfCalls() - Method in class akka.contrib.throttle.Throttler.Rate
 
numberOfCalls() - Method in class akka.contrib.throttle.Throttler.RateInt
 
numberOfConnections() - Method in class akka.actor.IO.Backlog
 
NumberOfEndHeartbeats() - Method in class akka.cluster.ClusterSettings
 
numberOfMessages() - Method in class akka.actor.mailbox.filebased.FileBasedMessageQueue
 
numberOfMessages() - Method in interface akka.dispatch.MessageQueue
Should return the current number of messages held in this queue; may always return 0 if no other value is available efficiently.
numberOfMessages() - Method in class akka.dispatch.NodeMessageQueue
 
numberOfMessages() - Method in interface akka.dispatch.QueueBasedMessageQueue
 
numberOfMessages(ActorRef) - Method in interface akka.routing.SmallestMailboxLike
Returns the number of pending messages in the mailbox of the actor.
numberOfMessages() - Method in class akka.testkit.CallingThreadMailbox
 

O

occurrences(int) - Method in class akka.testkit.JavaTestKit.EventFilter
 
offer(E) - Method in class akka.util.BoundedBlockingQueue
 
offer(E, long, TimeUnit) - Method in class akka.util.BoundedBlockingQueue
 
offset() - Method in class akka.actor.mailbox.filebased.filequeue.tools.QueueDumper
 
oldestChangedBuffer() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
oldestChangedReceived() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
on() - Method in class akka.actor.IO.KeepAlive
 
on() - Method in class akka.actor.IO.OOBInline
 
on() - Method in class akka.actor.IO.ReuseAddress
 
on() - Method in class akka.actor.IO.TcpNoDelay
 
on() - Method in class akka.io.Inet.SO$.ReuseAddress
 
on() - Method in class akka.io.Tcp.SO$.KeepAlive
 
on() - Method in class akka.io.Tcp.SO$.OOBInline
 
on() - Method in class akka.io.Tcp.SO$.TcpNoDelay
 
on() - Method in class akka.io.Udp.SO$.Broadcast
 
onClose(Function0<BoxedUnit>) - Method in class akka.pattern.CircuitBreaker
Adds a callback to execute when circuit breaker state closes
onClose(Runnable) - Method in class akka.pattern.CircuitBreaker
JavaAPI for onClose
onCommand(CmdAbove) - Method in class akka.io.AbstractPipePair
Commands reaching this pipe pair are transformed into a sequence of commands for the next or events for the previous stage.
onCommand(Cmd) - Method in class akka.io.PipelineSink
This callback is invoked for every command generated by the pipeline.
onCommandFailure(Throwable) - Method in class akka.io.PipelineSink
This callback is invoked if an exception occurred while processing an injected command.
OnComplete<T> - Class in akka.dispatch
Callback for when a Future is completed with either failure or a success SAM (Single Abstract Method) class
OnComplete() - Constructor for class akka.dispatch.OnComplete
 
onComplete(Throwable, T) - Method in class akka.dispatch.OnComplete
This method will be invoked once when/if a Future that this callback is registered on becomes completed with a failure or a success.
OneForOneStrategy() - Method in interface akka.actor.dsl.Creators.Act
 
OneForOneStrategy - Class in akka.actor
Applies the fault handling Directive (Resume, Restart, Stop) specified in the Decider to the child actor that failed, as opposed to AllForOneStrategy that applies it to all children.
OneForOneStrategy(int, Duration, boolean, PartialFunction<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.OneForOneStrategy
 
OneForOneStrategy(int, Duration, Function<Throwable, SupervisorStrategy.Directive>, boolean) - Constructor for class akka.actor.OneForOneStrategy
 
OneForOneStrategy(int, Duration, Function<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.OneForOneStrategy
 
OneForOneStrategy(int, Duration, Iterable<Class<? extends Throwable>>) - Constructor for class akka.actor.OneForOneStrategy
 
OneForOneStrategy$ - Class in akka.actor
 
OneForOneStrategy$() - Constructor for class akka.actor.OneForOneStrategy$
 
onEvent(EvtBelow) - Method in class akka.io.AbstractPipePair
Events reaching this pipe pair are transformed into a sequence of commands for the next or events for the previous stage.
onEvent(Evt) - Method in class akka.io.PipelineSink
This callback is invoked for every event generated by the pipeline.
onEventFailure(Throwable) - Method in class akka.io.PipelineSink
This callback is invoked if an exception occurred while processing an injected event.
oneway() - Method in class akka.camel.javaapi.UntypedProducerActor
 
Oneway - Interface in akka.camel
A one-way producer.
oneway() - Method in interface akka.camel.Oneway
 
oneway() - Method in interface akka.camel.ProducerSupport
If set to false (default), this producer expects a response message from the Camel endpoint.
OnFailure - Class in akka.dispatch
Callback for when a Future is completed with a failure SAM (Single Abstract Method) class
OnFailure() - Constructor for class akka.dispatch.OnFailure
 
onFailure(Throwable) - Method in class akka.dispatch.OnFailure
This method will be invoked once when/if a Future that this callback is registered on becomes completed with a failure
onHalfOpen(Function0<BoxedUnit>) - Method in class akka.pattern.CircuitBreaker
Adds a callback to execute when circuit breaker transitions to half-open
onHalfOpen(Runnable) - Method in class akka.pattern.CircuitBreaker
JavaAPI for onHalfOpen
OnlyCauseStackTrace - Interface in akka
Mix in this trait to suppress the StackTrace for the instance of the exception but not the cause, scala.util.control.NoStackTrace suppresses all the StackTraces.
onManagementCommand(Object) - Method in class akka.io.AbstractPipePair
Management commands are sent to all stages in a broadcast fashion, conceptually in parallel (but not actually executing a stage reentrantly in case of events or commands being generated in response to a management command).
onOpen(Function0<BoxedUnit>) - Method in class akka.pattern.CircuitBreaker
Adds a callback to execute when circuit breaker opens
onOpen(Runnable) - Method in class akka.pattern.CircuitBreaker
Java API for onOpen
onReceive(Object, ActorRef) - Method in interface akka.actor.TypedActor.Receiver
 
onReceive(Object) - Method in class akka.actor.UntypedActor
To be implemented by concrete UntypedActor, this defines the behavior of the UntypedActor.
onReceive(Object) - Method in class akka.camel.javaapi.UntypedProducerActor
Default implementation of UntypedActor.onReceive
onReceive(Object) - Method in class akka.transactor.UntypedTransactor
Implement a general pattern for using coordinated transactions.
onRouteDefinition() - Method in interface akka.camel.Consumer
Returns the route definition handler for creating a custom route to this consumer.
onRouteResponse(Object) - Method in class akka.camel.javaapi.UntypedProducerActor
Called after a response was received from the endpoint specified by endpointUri.
OnSuccess<T> - Class in akka.dispatch
Callback for when a Future is completed successfully SAM (Single Abstract Method) class
OnSuccess() - Constructor for class akka.dispatch.OnSuccess
 
onSuccess(T) - Method in class akka.dispatch.OnSuccess
This method will be invoked once when/if a Future that this callback is registered on becomes successfully completed
onTermination(PartialFunction<FSM.StopEvent, BoxedUnit>) - Method in interface akka.actor.FSM
Set handler which is called upon termination of this FSM actor.
onTransformOutgoingMessage(Object) - Method in class akka.camel.javaapi.UntypedProducerActor
Called before the message is sent to the endpoint specified by getEndpointUri.
onTransformResponse(Object) - Method in class akka.camel.javaapi.UntypedProducerActor
Called before the response message is sent to original sender.
onTransition(PartialFunction<Tuple2<S, S>, BoxedUnit>) - Method in interface akka.actor.FSM
Set handler which is called upon each state transition, i.e.
oobInline(boolean) - Method in class akka.io.TcpSO$
Inet.SocketOption to enable or disable OOBINLINE (receipt of TCP urgent data) By default, this option is disabled and TCP urgent data is silently discarded.
oobInline(boolean) - Static method in class akka.io.TcpSO
Inet.SocketOption to enable or disable OOBINLINE (receipt of TCP urgent data) By default, this option is disabled and TCP urgent data is silently discarded.
OP_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
open() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
open() - Method in class akka.testkit.TestLatch
 
openTransactionCount() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
openTransactionIds() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
openTransactions() - Method in class akka.actor.mailbox.filebased.filequeue.tools.QueueDumper
 
operations() - Method in class akka.actor.mailbox.filebased.filequeue.tools.QueueDumper
 
Option<A> - Class in akka.japi
This class represents optional values.
Option() - Constructor for class akka.japi.Option
 
option(A) - Method in class akka.japi.Option$
Option factory that creates None if v is null, Some(v) otherwise.
option(A) - Static method in class akka.japi.Option
Option factory that creates None if v is null, Some(v) otherwise.
Option$ - Class in akka.japi
 
Option$() - Constructor for class akka.japi.Option$
 
Option.Some<A> - Class in akka.japi
Class Some[A] represents existing values of type A.
Option.Some(A) - Constructor for class akka.japi.Option.Some
 
Option.Some$ - Class in akka.japi
 
Option.Some$() - Constructor for class akka.japi.Option.Some$
 
options() - Method in class akka.actor.IO.Accept
 
options() - Method in class akka.actor.IO.Connect
 
options() - Method in class akka.actor.IO.Listen
 
options() - Method in class akka.io.Tcp.Bind
 
options() - Method in class akka.io.Tcp.Connect
 
options() - Method in class akka.io.Udp.Bind
 
options() - Method in class akka.io.Udp.SimpleSender
 
options() - Method in class akka.io.UdpConnected.Connect
 
ord() - Method in class akka.remote.SeqNo$
 
ord() - Static method in class akka.remote.SeqNo
 
ordering() - Method in class akka.cluster.Member$
Member ordering type class, sorts members by host and port.
ordering() - Static method in class akka.cluster.Member
Member ordering type class, sorts members by host and port.
origin() - Method in class akka.remote.transport.HandshakeInfo
 
ORIGIN_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AkkaHandshakeInfo
 
originalCause() - Method in exception akka.actor.PostRestartException
 
originalCause() - Method in exception akka.actor.PreRestartException
 
originalLocalAddress() - Method in class akka.remote.transport.AbstractTransportAdapterHandle
 
originalRemoteAddress() - Method in class akka.remote.transport.AbstractTransportAdapterHandle
 
OriginalRestartException - Class in akka.actor
This is an extractor for retrieving the original cause (i.e.
OriginalRestartException() - Constructor for class akka.actor.OriginalRestartException
 
OriginalRestartException$ - Class in akka.actor
This is an extractor for retrieving the original cause (i.e.
OriginalRestartException$() - Constructor for class akka.actor.OriginalRestartException$
 
OsgiActorSystemFactory - Class in akka.osgi
Factory class to create ActorSystem implementations in an OSGi environment.
OsgiActorSystemFactory(org.osgi.framework.BundleContext, Option<ClassLoader>, com.typesafe.config.Config) - Constructor for class akka.osgi.OsgiActorSystemFactory
 
OsgiActorSystemFactory$ - Class in akka.osgi
 
OsgiActorSystemFactory$() - Constructor for class akka.osgi.OsgiActorSystemFactory$
 
otherHasNewerVersions(Map<Address, Object>) - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
otherthread() - Method in class akka.testkit.TestActorRefSpec$
 
otherthread() - Static method in class akka.testkit.TestActorRefSpec
 
overlay(Function0<T>) - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
OverlaySetting<T> - Class in akka.actor.mailbox.filebased.filequeue
 
OverlaySetting(Function0<T>) - Constructor for class akka.actor.mailbox.filebased.filequeue.OverlaySetting
 
overview() - Method in class akka.cluster.protobuf.msg.Gossip
 
OVERVIEW_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.Gossip$
 
OVERVIEW_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.Gossip
 
owner() - Method in interface akka.actor.IO.Handle
 
owner() - Method in class akka.actor.IO.ServerHandle
 
owner() - Method in class akka.actor.IO.SocketHandle
 
owner() - Method in class akka.actor.mailbox.DurableMessageQueue
 
ownerPath() - Method in class akka.actor.mailbox.DurableMessageQueue
 
ownerPathString() - Method in class akka.actor.mailbox.DurableMessageQueue
 

P

pack() - Method in class akka.actor.mailbox.filebased.filequeue.QItem
 
PacketSplitThreshold() - Method in class akka.remote.testconductor.TestConductorExt.Settings
 
parallelism() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory
 
parameters() - Method in class akka.actor.TypedActor.MethodCall
 
parent() - Method in interface akka.actor.ActorContext
Returns the supervising parent ActorRef.
parent() - Method in interface akka.actor.ActorPath
The path for the parent actor.
parent() - Method in class akka.actor.ChildActorPath
 
parent() - Method in class akka.actor.RootActorPath
 
PARENT_VALUE - Static variable in enum akka.remote.ContainerFormats.PatternType
 
parse(String) - Method in class akka.actor.AddressFromURIString$
Java API: Try to construct an Address from the given String or throw a java.net.MalformedURLException.
parse(String) - Static method in class akka.actor.AddressFromURIString
Java API: Try to construct an Address from the given String or throw a java.net.MalformedURLException.
parse(Element, org.apache.aries.blueprint.ParserContext) - Method in class akka.osgi.aries.blueprint.NamespaceHandler
 
parseActorSystem(Element, org.apache.aries.blueprint.ParserContext) - Method in class akka.osgi.aries.blueprint.NamespaceHandler
 
parseArgs(List<String>) - Method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper$
 
parseArgs(List<String>) - Static method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper
 
parseConfig(Element, org.apache.aries.blueprint.ParserContext, org.apache.aries.blueprint.mutable.MutableBeanMetadata) - Method in class akka.osgi.aries.blueprint.NamespaceHandler
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.ContainerFormats.Selection
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.Selection
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.testconductor.TestConductorProtocol.Address
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Address
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.ActorRefData
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.ActorRefData
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.AddressData
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AddressData
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.DeployData
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DeployData
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.PropsData
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.PropsData
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.SerializedMessage
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.SerializedMessage
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.ContainerFormats.Selection
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.Selection
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.Selection
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.Selection
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.ContainerFormats.Selection
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.Selection
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.testconductor.TestConductorProtocol.Address
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Address
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Address
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Address
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.testconductor.TestConductorProtocol.Address
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Address
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.WireFormats.ActorRefData
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.ActorRefData
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.ActorRefData
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.ActorRefData
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.WireFormats.ActorRefData
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.ActorRefData
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.WireFormats.AddressData
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AddressData
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AddressData
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AddressData
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.WireFormats.AddressData
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AddressData
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.WireFormats.DeployData
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DeployData
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DeployData
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DeployData
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.WireFormats.DeployData
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DeployData
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.WireFormats.PropsData
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.PropsData
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.PropsData
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.PropsData
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.WireFormats.PropsData
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.PropsData
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.WireFormats.SerializedMessage
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.SerializedMessage
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.SerializedMessage
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.SerializedMessage
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.WireFormats.SerializedMessage
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.SerializedMessage
 
passThrough(RoleName, RoleName, ThrottlerTransportAdapter.Direction) - Method in interface akka.remote.testconductor.Conductor
Switch the Netty pipeline of the remote support into pass through mode for sending and/or receiving.
patch() - Method in class akka.zeromq.ZeroMQVersion
 
path() - Method in class akka.actor.ActorRef
Returns the path for this actor (from this actor up to the root actor).
path() - Method in class akka.actor.ActorSelection
 
path() - Method in class akka.actor.Deploy
 
path() - Method in class akka.contrib.pattern.ClusterClient.Send
 
path() - Method in class akka.contrib.pattern.ClusterClient.SendToAll
 
path() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Remove
 
path() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Send
 
path() - Method in class akka.contrib.pattern.DistributedPubSubMediator.SendToAll
 
path() - Method in class akka.event.Logging.StandardOutLogger
 
PATH_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.ActorRefData
 
PATH_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DaemonMsgCreateData
 
PATH_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DeployData
 
PATTERN_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.SelectionEnvelope
 
Patterns - Class in akka.pattern
 
Patterns() - Constructor for class akka.pattern.Patterns
 
Patterns$ - Class in akka.pattern
 
Patterns$() - Constructor for class akka.pattern.Patterns$
 
pauseReads() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
payload() - Method in class akka.io.Udp.Send
 
payload() - Method in class akka.io.UdpConnected.Send
 
payload() - Method in class akka.remote.transport.AssociationHandle.InboundPayload
 
payload() - Method in class akka.remote.transport.TestTransport.WriteAttempt
 
payload() - Method in interface akka.zeromq.PubSubOption
 
payload() - Method in class akka.zeromq.Subscribe
 
payload() - Method in class akka.zeromq.Unsubscribe
 
PAYLOAD_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AkkaProtocolMessage
 
peek(int) - Method in class akka.actor.IO$
An Iteratee that returns a ByteString of the request length, but does not consume the Input.
peek(int) - Static method in class akka.actor.IO
An Iteratee that returns a ByteString of the request length, but does not consume the Input.
peek() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
Peek at the head item in the queue, if there is one.
peek() - Method in class akka.dispatch.AbstractNodeQueue
 
peek() - Method in class akka.util.BoundedBlockingQueue
 
PeekMailbox - Class in akka.contrib.mailbox
 
PeekMailbox(ActorRef, ActorSystem, int) - Constructor for class akka.contrib.mailbox.PeekMailbox
 
PeekMailboxExtension - Class in akka.contrib.mailbox
 
PeekMailboxExtension(ExtendedActorSystem) - Constructor for class akka.contrib.mailbox.PeekMailboxExtension
 
PeekMailboxExtension$ - Class in akka.contrib.mailbox
 
PeekMailboxExtension$() - Constructor for class akka.contrib.mailbox.PeekMailboxExtension$
 
PeekMailboxType - Class in akka.contrib.mailbox
configure the mailbox via dispatcher configuration:
PeekMailboxType(ActorSystem.Settings, com.typesafe.config.Config) - Constructor for class akka.contrib.mailbox.PeekMailboxType
 
peekNode() - Method in class akka.dispatch.AbstractNodeQueue
 
peer(Address) - Method in class akka.contrib.pattern.ClusterSingletonManager
 
PerformanceTest - Class in akka.testkit
 
PerformanceTest() - Constructor for class akka.testkit.PerformanceTest
 
PerformanceTest$ - Class in akka.testkit
 
PerformanceTest$() - Constructor for class akka.testkit.PerformanceTest$
 
PeriodicTasksInitialDelay() - Method in class akka.cluster.ClusterSettings
 
permanent() - Method in class akka.contrib.pattern.WorkList.Entry
 
PersistentQueue - Class in akka.actor.mailbox.filebased.filequeue
 
PersistentQueue(String, String, FileBasedMailboxSettings, LoggingAdapter) - Constructor for class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
PersistentQueue$ - Class in akka.actor.mailbox.filebased.filequeue
 
PersistentQueue$() - Constructor for class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
phi() - Method in class akka.remote.PhiAccrualFailureDetector
The suspicion level of the accrual failure detector.
PhiAccrualFailureDetector - Class in akka.remote
Implementation of 'The Phi Accrual Failure Detector' by Hayashibara et al.
PhiAccrualFailureDetector(double, int, FiniteDuration, FiniteDuration, FiniteDuration, FailureDetector.Clock) - Constructor for class akka.remote.PhiAccrualFailureDetector
 
PhiAccrualFailureDetector(com.typesafe.config.Config, EventStream) - Constructor for class akka.remote.PhiAccrualFailureDetector
Constructor that reads parameters from config.
pickHighestPriority(Set<Member>, Set<Member>) - Method in class akka.cluster.Member$
 
pickHighestPriority(Set<Member>, Set<Member>) - Static method in class akka.cluster.Member
 
pid() - Method in class akka.cluster.SigarMetricsCollector
 
pingTask() - Method in class akka.contrib.pattern.ClusterClient
 
PinnedDispatcher - Class in akka.dispatch
Dedicates a unique thread for each actor passed in as reference.
PinnedDispatcher(MessageDispatcherConfigurator, akka.actor.ActorCell, String, FiniteDuration, ThreadPoolConfig) - Constructor for class akka.dispatch.PinnedDispatcher
 
PinnedDispatcherConfigurator - Class in akka.dispatch
Configurator for creating PinnedDispatcher.
PinnedDispatcherConfigurator(com.typesafe.config.Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.PinnedDispatcherConfigurator
 
pipe(Future<T>, ExecutionContext) - Method in class akka.pattern.Patterns$
Register an onComplete callback on this Future to send the result to the given ActorRef or ActorSelection.
pipe(Future<T>, ExecutionContext) - Static method in class akka.pattern.Patterns
Register an onComplete callback on this Future to send the result to the given ActorRef or ActorSelection.
pipe(Future<T>, ExecutionContext) - Method in interface akka.pattern.PipeToSupport
Import this implicit conversion to gain the pipeTo method on Future:
PipelineContext - Interface in akka.io
This base trait of each pipeline’s context provides optimized facilities for generating single commands or events (i.e.
PipelineFactory - Class in akka.io
This class contains static factory methods which turn a pipeline context and a PipelineStage into readily usable pipelines.
PipelineFactory() - Constructor for class akka.io.PipelineFactory
 
PipelineFactory$ - Class in akka.io
This class contains static factory methods which turn a pipeline context and a PipelineStage into readily usable pipelines.
PipelineFactory$() - Constructor for class akka.io.PipelineFactory$
 
PipelineInjector<Cmd,Evt> - Interface in akka.io
A handle for injecting commands and events into a pipeline.
PipelinePorts<CmdAbove,CmdBelow,EvtAbove,EvtBelow> - Class in akka.io
 
PipelinePorts(Function1<CmdAbove, Tuple2<Iterable<EvtAbove>, Iterable<CmdBelow>>>, Function1<EvtBelow, Tuple2<Iterable<EvtAbove>, Iterable<CmdBelow>>>, PartialFunction<Object, Tuple2<Iterable<EvtAbove>, Iterable<CmdBelow>>>) - Constructor for class akka.io.PipelinePorts
 
PipelinePorts$ - Class in akka.io
 
PipelinePorts$() - Constructor for class akka.io.PipelinePorts$
 
PipelineSink<Cmd,Evt> - Class in akka.io
A sink which can be attached by PipelineFactory.buildWithSink(Ctx, akka.io.PipelineStage, akka.io.PipelineSink) to a pipeline when it is being built.
PipelineSink() - Constructor for class akka.io.PipelineSink
 
PipelineStage<Context extends PipelineContext,CmdAbove,CmdBelow,EvtAbove,EvtBelow> - Class in akka.io
A pipeline stage which can be combined with other stages to build a protocol stack.
PipelineStage() - Constructor for class akka.io.PipelineStage
 
PipelineStage$ - Class in akka.io
 
PipelineStage$() - Constructor for class akka.io.PipelineStage$
 
PipePair<CmdAbove,CmdBelow,EvtAbove,EvtBelow> - Interface in akka.io
Scala API: A pair of pipes, one for commands and one for events, plus a management port.
PipePairFactory - Class in akka.io
This class contains static factory methods which produce PipePair instances; those are needed within the implementation of PipelineStage.apply(Context).
PipePairFactory() - Constructor for class akka.io.PipePairFactory
 
PipePairFactory$ - Class in akka.io
This class contains static factory methods which produce PipePair instances; those are needed within the implementation of PipelineStage.apply(Context).
PipePairFactory$() - Constructor for class akka.io.PipePairFactory$
 
pipes() - Method in class akka.io.TcpPipelineHandler
 
pipeTo(ActorRef, ActorRef) - Method in class akka.pattern.PipeToSupport.PipeableFuture
 
pipeToSelection(ActorSelection, ActorRef) - Method in class akka.pattern.PipeToSupport.PipeableFuture
 
PipeToSupport - Interface in akka.pattern
 
PipeToSupport.PipeableFuture<T> - Class in akka.pattern
 
PipeToSupport.PipeableFuture(Future<T>, ExecutionContext) - Constructor for class akka.pattern.PipeToSupport.PipeableFuture
 
Player - Interface in akka.remote.testconductor
The Player is the client component of the TestConductorExt extension.
PoisonPill - Class in akka.actor
 
PoisonPill() - Constructor for class akka.actor.PoisonPill
 
poisonPill(Object) - Method in interface akka.actor.TypedActorFactory
Sends a PoisonPill the underlying ActorRef for the supplied TypedActor proxy, if any, returns whether it could find the find the ActorRef or not
PoisonPill$ - Class in akka.actor
A message all Actors will understand, that when processed will terminate the Actor permanently.
PoisonPill$() - Constructor for class akka.actor.PoisonPill$
 
poll() - Method in class akka.dispatch.AbstractNodeQueue
 
poll(long, TimeUnit) - Method in class akka.util.BoundedBlockingQueue
 
poll() - Method in class akka.util.BoundedBlockingQueue
 
PollDispatcher - Class in akka.zeromq
An option containing the configuration key for the poller loop dispatcher
PollDispatcher(String) - Constructor for class akka.zeromq.PollDispatcher
 
PollDispatcher$ - Class in akka.zeromq
 
PollDispatcher$() - Constructor for class akka.zeromq.PollDispatcher$
 
poller() - Method in class akka.zeromq.Context
 
pollNode() - Method in class akka.dispatch.AbstractNodeQueue
 
PollTimeoutDuration - Class in akka.zeromq
An option containing the duration a poll cycle should wait for a message before it loops
PollTimeoutDuration(FiniteDuration) - Constructor for class akka.zeromq.PollTimeoutDuration
 
PollTimeoutDuration$ - Class in akka.zeromq
 
PollTimeoutDuration$() - Constructor for class akka.zeromq.PollTimeoutDuration$
 
pollTimeUnit() - Method in class akka.zeromq.ZeroMQExtension
 
pop() - Method in class akka.remote.transport.TestTransport.SwitchableLoggedBehavior
Restores the previous behavior.
port() - Method in class akka.actor.Address
 
port() - Method in class akka.cluster.protobuf.msg.Address
 
PORT_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.Address$
 
PORT_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.Address
 
PORT_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Address
 
PORT_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AddressData
 
PortSelector() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
pos() - Method in interface akka.actor.LoggingFSM
 
position() - Method in class akka.io.Tcp.WriteFile
 
PossiblyHarmful - Interface in akka.actor
Marker trait to indicate that a message might be potentially harmful, this is used to block messages coming in over remoting.
postRestart(Throwable) - Method in interface akka.actor.Actor
User overridable callback: By default it calls preStart().
postRestart(Throwable) - Method in interface akka.actor.dsl.Creators.Act
 
postRestart(Throwable) - Method in interface akka.actor.TypedActor.PostRestart
User overridable callback: By default it calls preStart().
postRestart(Throwable) - Method in class akka.actor.UntypedActor
User overridable callback: By default it calls preStart().
postRestart(Throwable) - Method in class akka.event.DeadLetterListener
 
PostRestartException - Exception in akka.actor
A PostRestartException is thrown when constructor or postRestart() method fails during a restart attempt.
PostRestartException$ - Class in akka.actor
 
PostRestartException$() - Constructor for class akka.actor.PostRestartException$
 
postStop() - Method in interface akka.actor.Actor
User overridable callback.
postStop() - Method in interface akka.actor.dsl.Creators.Act
 
postStop() - Method in interface akka.actor.FSM
Call onTermination hook; if you want to retain this behavior when overriding make sure to call super.postStop().
postStop() - Method in class akka.actor.IOManagerActor
 
postStop() - Method in interface akka.actor.TypedActor.PostStop
User overridable callback.
postStop() - Method in interface akka.actor.UnrestrictedStash
Overridden callback.
postStop() - Method in class akka.actor.UntypedActor
User overridable callback.
postStop() - Method in class akka.contrib.pattern.ClusterClient
 
postStop() - Method in class akka.contrib.pattern.ClusterReceptionist
 
postStop() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
postStop() - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
postStop() - Method in class akka.event.DeadLetterListener
 
postStop() - Method in class akka.testkit.TestActor
 
predicate() - Method in class akka.actor.dsl.Inbox.Select
 
PredicateClassifier - Interface in akka.event
Can be mixed into an EventBus to specify that the Classifier type is a Function from Event to Boolean (predicate)
prepend(T) - Method in interface akka.actor.mailbox.filebased.filequeue.Prependable
 
prepend(Tcp.SimpleWriteCommand) - Method in interface akka.io.Tcp.WriteCommand
Java API: prepends this command with another Write or WriteFile to form a CompoundWrite.
prepend(Iterable<Tcp.WriteCommand>) - Method in interface akka.io.Tcp.WriteCommand
Java API: prepends this command with a number of other writes.
Prependable<T> - Interface in akka.actor.mailbox.filebased.filequeue
 
prerequisites() - Method in class akka.dispatch.Dispatchers
 
prerequisites() - Method in class akka.dispatch.MessageDispatcherConfigurator
 
preRestart(Throwable, Option<Object>) - Method in interface akka.actor.Actor
User overridable callback: '''By default it disposes of all children and then calls postStop().'''
preRestart(Throwable, Option<Object>) - Method in interface akka.actor.dsl.Creators.Act
 
preRestart(Throwable, Option<Object>) - Method in interface akka.actor.TypedActor.PreRestart
User overridable callback: '''By default it disposes of all children and then calls postStop().'''
preRestart(Throwable, Option<Object>) - Method in interface akka.actor.UnrestrictedStash
Overridden callback.
preRestart(Throwable, Option<Object>) - Method in class akka.actor.UntypedActor
User overridable callback: '''By default it disposes of all children and then calls postStop().'''

Is called on a crashed Actor right BEFORE it is restarted to allow clean up of resources before Actor is terminated.

preRestart(Throwable, Option<Object>) - Method in class akka.event.DeadLetterListener
 
preRestart(Throwable, Option<Object>) - Method in interface akka.routing.Router
 
PreRestartException - Exception in akka.actor
A PreRestartException is thrown when the preRestart() method failed; this exception is not propagated to the supervisor, as it originates from the already failed instance, hence it is only visible as log entry on the event stream.
PreRestartException$ - Class in akka.actor
 
PreRestartException$() - Constructor for class akka.actor.PreRestartException$
 
pressure(IndexedSeq<ActorRef>) - Method in class akka.routing.DefaultResizer
Number of routees considered busy, or above 'pressure level'.
pressureThreshold() - Method in class akka.routing.DefaultResizer
Threshold to evaluate if routee is considered to be busy (under pressure).
preStart() - Method in interface akka.actor.Actor
User overridable callback.
preStart() - Method in interface akka.actor.dsl.Creators.Act
 
preStart() - Method in interface akka.actor.TypedActor.PreStart
User overridable callback.
preStart() - Method in class akka.actor.UntypedActor
User overridable callback.
preStart() - Method in interface akka.camel.Consumer
Registers the consumer endpoint.
preStart() - Method in interface akka.camel.ProducerSupport
 
preStart() - Method in class akka.contrib.pattern.ClusterReceptionist
 
preStart() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
preStart() - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
preStart() - Method in class akka.event.DeadLetterListener
 
previousStatus() - Method in class akka.cluster.ClusterEvent.MemberRemoved
 
print(Object) - Method in interface akka.event.Logging.StdOutLogger
 
printActors() - Static method in class akka.dispatch.MessageDispatcher
 
printedWarning() - Method in class akka.actor.dsl.Inbox.InboxActor
 
printReport(String, PrintStream) - Method in class akka.testkit.Coroner$
Print a report containing diagnostic information.
printReport(String, PrintStream) - Static method in class akka.testkit.Coroner
Print a report containing diagnostic information.
PriorityGenerator - Class in akka.dispatch
A PriorityGenerator is a convenience API to create a Comparator that orders the messages of a PriorityDispatcher
PriorityGenerator() - Constructor for class akka.dispatch.PriorityGenerator
 
PriorityGenerator$ - Class in akka.dispatch
 
PriorityGenerator$() - Constructor for class akka.dispatch.PriorityGenerator$
 
Procedure<T> - Interface in akka.japi
A Procedure is like a Function, but it doesn't produce a return value.
process(Function1<T, Object>) - Method in class akka.contrib.pattern.WorkList
Tries to process each entry using the processing function.
processEvent(FSM.Event, Object) - Method in interface akka.actor.FSM
 
processEvent(FSM.Event, Object) - Method in interface akka.actor.LoggingFSM
 
processFailure(ActorContext, boolean, ActorRef, Throwable, ChildRestartStats, Iterable<ChildRestartStats>) - Method in class akka.actor.AllForOneStrategy
 
processFailure(ActorContext, boolean, ActorRef, Throwable, ChildRestartStats, Iterable<ChildRestartStats>) - Method in class akka.actor.OneForOneStrategy
 
processFailure(ActorContext, boolean, ActorRef, Throwable, ChildRestartStats, Iterable<ChildRestartStats>) - Method in class akka.actor.SupervisorStrategy
This method is called to act on the failure of a child: restart if the flag is true, stop otherwise.
processing() - Method in interface akka.contrib.pattern.Aggregator
 
processMsg(Object, Object) - Method in interface akka.actor.FSM
 
processors() - Method in class akka.cluster.JmxMetricsCollector
(JMX) Returns the number of available processors Creates a new instance each time.
Processors() - Method in class akka.cluster.StandardMetrics$
 
processors() - Method in class akka.cluster.StandardMetrics.Cpu
 
Processors() - Static method in class akka.cluster.StandardMetrics
 
produce() - Method in interface akka.actor.IndirectActorProducer
This factory method must produce a fresh actor instance upon each invocation.
produce() - Method in interface akka.camel.ProducerSupport
Produces msg to the endpoint specified by endpointUri.
produce(org.apache.camel.Endpoint, org.apache.camel.processor.SendProcessor, Object, org.apache.camel.ExchangePattern) - Method in class akka.camel.ProducerSupport.ProducerChild
Initiates a message exchange of given pattern with the endpoint specified by endpointUri.
Producer - Interface in akka.camel
Mixed in by Actor implementations to produce messages to Camel endpoints.
ProducerSupport - Interface in akka.camel
Support trait for producing messages to Camel endpoints.
ProducerSupport.ProducerChild - Class in akka.camel
 
ProducerSupport.ProducerChild(org.apache.camel.Endpoint, org.apache.camel.processor.SendProcessor) - Constructor for class akka.camel.ProducerSupport.ProducerChild
 
ProducesMessageQueue<T extends MessageQueue> - Interface in akka.dispatch
 
promise() - Method in class akka.dispatch.Futures$
Creates a promise object which can be completed with a value.
promise() - Static method in class akka.dispatch.Futures
Creates a promise object which can be completed with a value.
props() - Method in interface akka.actor.ActorContext
Retrieve the Props which were used to create this actor.
Props - Class in akka.actor
Props is a configuration object using in creating an Actor; it is immutable, so it is thread-safe and fully shareable.
Props(Deploy, Class<?>, Seq<Object>) - Constructor for class akka.actor.Props
 
Props() - Constructor for class akka.actor.Props
Deprecated. use Props.create(clazz, args ...) instead
Props(UntypedActorFactory) - Constructor for class akka.actor.Props
Deprecated. use Props.create(clazz, args ...) instead; this method has been deprecated because it encourages creating Props which contain non-serializable inner classes, making them also non-serializable
Props(Class<? extends Actor>) - Constructor for class akka.actor.Props
Deprecated. use Props.create(clazz) instead; deprecated since it duplicates another API
props(Set<ActorSelection>, FiniteDuration, FiniteDuration) - Method in class akka.contrib.pattern.ClusterClient$
Scala API: Factory method for ClusterClient Props.
props(Set<ActorSelection>, FiniteDuration, FiniteDuration) - Method in class akka.contrib.pattern.ClusterClient$
Java API: Factory method for ClusterClient Props.
props(Set<ActorSelection>, FiniteDuration, FiniteDuration) - Static method in class akka.contrib.pattern.ClusterClient
Scala API: Factory method for ClusterClient Props.
props(Set<ActorSelection>, FiniteDuration, FiniteDuration) - Static method in class akka.contrib.pattern.ClusterClient
Java API: Factory method for ClusterClient Props.
props(ActorRef, Option<String>, int, FiniteDuration) - Method in class akka.contrib.pattern.ClusterReceptionist$
Scala API: Factory method for ClusterReceptionist Props.
props(ActorRef, String, int, FiniteDuration) - Method in class akka.contrib.pattern.ClusterReceptionist$
Java API: Factory method for ClusterReceptionist Props.
props(ActorRef, String) - Method in class akka.contrib.pattern.ClusterReceptionist$
Java API: Factory method for ClusterReceptionist Props with default values.
props(ActorRef, Option<String>, int, FiniteDuration) - Static method in class akka.contrib.pattern.ClusterReceptionist
Scala API: Factory method for ClusterReceptionist Props.
props(ActorRef, String, int, FiniteDuration) - Static method in class akka.contrib.pattern.ClusterReceptionist
Java API: Factory method for ClusterReceptionist Props.
props(ActorRef, String) - Static method in class akka.contrib.pattern.ClusterReceptionist
Java API: Factory method for ClusterReceptionist Props with default values.
props(Function1<Option<Object>, Props>, String, Object, Option<String>, int, int, FiniteDuration) - Method in class akka.contrib.pattern.ClusterSingletonManager$
Scala API: Factory method for ClusterSingletonManager Props.
props(String, Object, String, int, int, FiniteDuration, ClusterSingletonPropsFactory) - Method in class akka.contrib.pattern.ClusterSingletonManager$
Java API: Factory method for ClusterSingletonManager Props.
props(Function1<Option<Object>, Props>, String, Object, Option<String>, int, int, FiniteDuration) - Static method in class akka.contrib.pattern.ClusterSingletonManager
Scala API: Factory method for ClusterSingletonManager Props.
props(String, Object, String, int, int, FiniteDuration, ClusterSingletonPropsFactory) - Static method in class akka.contrib.pattern.ClusterSingletonManager
Java API: Factory method for ClusterSingletonManager Props.
props(Option<String>, FiniteDuration, FiniteDuration) - Method in class akka.contrib.pattern.DistributedPubSubMediator$
Scala API: Factory method for DistributedPubSubMediator Props.
props(String, FiniteDuration, FiniteDuration) - Method in class akka.contrib.pattern.DistributedPubSubMediator$
Java API: Factory method for DistributedPubSubMediator Props.
props(Option<String>, FiniteDuration, FiniteDuration) - Static method in class akka.contrib.pattern.DistributedPubSubMediator
Scala API: Factory method for DistributedPubSubMediator Props.
props(String, FiniteDuration, FiniteDuration) - Static method in class akka.contrib.pattern.DistributedPubSubMediator
Java API: Factory method for DistributedPubSubMediator Props.
props(TcpPipelineHandler.Init<Ctx, Cmd, Evt>, ActorRef, ActorRef) - Method in class akka.io.TcpPipelineHandler$
create Props for a pipeline handler
props(TcpPipelineHandler.Init<Ctx, Cmd, Evt>, ActorRef, ActorRef) - Static method in class akka.io.TcpPipelineHandler
create Props for a pipeline handler
props(BlockingDeque<TestActor.Message>) - Method in class akka.testkit.TestActor$
 
props(BlockingDeque<TestActor.Message>) - Static method in class akka.testkit.TestActor
 
props() - Method in class akka.testkit.TestActorRef
 
Props$ - Class in akka.actor
 
Props$() - Constructor for class akka.actor.Props$
 
PROPS_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DaemonMsgCreateData
 
ProtobufSerializer - Class in akka.remote.serialization
This Serializer serializes com.google.protobuf.Messages
ProtobufSerializer() - Constructor for class akka.remote.serialization.ProtobufSerializer
 
ProtobufSerializer$ - Class in akka.remote.serialization
 
ProtobufSerializer$() - Constructor for class akka.remote.serialization.ProtobufSerializer$
 
protocol() - Method in class akka.actor.Address
 
protocol() - Method in class akka.cluster.protobuf.msg.Address
 
PROTOCOL_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.Address$
 
PROTOCOL_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.Address
 
PROTOCOL_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Address
 
PROTOCOL_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AddressData
 
provider() - Method in interface akka.actor.ActorRefFactory
INTERNAL API
provider() - Method in class akka.actor.ExtendedActorSystem
The ActorRefProvider is the only entity which creates all actor references within this actor system.
provider() - Method in class akka.event.Logging.StandardOutLogger
 
ProviderClass() - Method in class akka.actor.ActorSystem.Settings
 
prune() - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
pruneInterval() - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
pruneTask() - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
publish(String, Object, boolean) - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
publish(akka.event.EventBus.Event) - Method in interface akka.event.ActorClassification
 
publish(akka.event.EventBus.Event) - Method in interface akka.event.EventBus
Publishes the specified Event to this bus
publish(Object, ActorRef) - Method in class akka.event.EventStream
 
publish(akka.event.EventBus.Event, akka.event.EventBus.Subscriber) - Method in interface akka.event.LookupClassification
Publishes the given Event to the given Subscriber
publish(akka.event.EventBus.Event) - Method in interface akka.event.LookupClassification
 
publish(akka.event.EventBus.Event, akka.event.EventBus.Subscriber) - Method in interface akka.event.ScanningClassification
Publishes the specified Event to the specified Subscriber
publish(akka.event.EventBus.Event) - Method in interface akka.event.ScanningClassification
 
publish(akka.event.EventBus.Event, akka.event.EventBus.Subscriber) - Method in interface akka.event.SubchannelClassification
Publishes the given Event to the given Subscriber
publish(akka.event.EventBus.Event) - Method in interface akka.event.SubchannelClassification
 
publishCurrentClusterState() - Method in class akka.cluster.Cluster
Publish current (full) state of the cluster to subscribers, that are subscribing to ClusterEvent.ClusterDomainEvent or ClusterEvent.CurrentClusterState.
PublishStatsInterval() - Method in class akka.cluster.ClusterSettings
 
PubSubOption - Interface in akka.zeromq
A base trait for pubsub options for the ZeroMQ socket
push(Function1<A, Future<B>>) - Method in class akka.remote.transport.TestTransport.SwitchableLoggedBehavior
Changes the current behavior to the provided one.
pushConstant(B) - Method in class akka.remote.transport.TestTransport.SwitchableLoggedBehavior
Changes the behavior to return a completed future with the given constant value.
pushDelayed() - Method in class akka.remote.transport.TestTransport.SwitchableLoggedBehavior
Enables control of the completion of the previously active behavior.
pushError(Throwable) - Method in class akka.remote.transport.TestTransport.SwitchableLoggedBehavior
Changes the current behavior to return a failed future containing the given Throwable.
pushTimeOut() - Method in class akka.dispatch.BoundedDequeBasedMailbox.MessageQueue
 
pushTimeOut() - Method in class akka.dispatch.BoundedDequeBasedMailbox
 
pushTimeOut() - Method in interface akka.dispatch.BoundedDequeBasedMessageQueue
 
pushTimeOut() - Method in class akka.dispatch.BoundedMailbox.MessageQueue
 
pushTimeOut() - Method in class akka.dispatch.BoundedMailbox
 
pushTimeOut() - Method in interface akka.dispatch.BoundedMessageQueueSemantics
 
pushTimeOut() - Method in class akka.dispatch.BoundedPriorityMailbox.MessageQueue
 
pushTimeOut() - Method in class akka.dispatch.BoundedPriorityMailbox
 
put(String, Option<ActorRef>) - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
put(E) - Method in class akka.util.BoundedBlockingQueue
 
put(K, V) - Method in class akka.util.Index
Associates the value of type V with the key of type K
putByte(byte) - Method in class akka.util.ByteStringBuilder
Add a single Byte to this builder.
putBytes(byte[]) - Method in class akka.util.ByteStringBuilder
Add a number of Bytes from an array to this builder.
putBytes(byte[], int, int) - Method in class akka.util.ByteStringBuilder
Add a number of Bytes from an array to this builder.
putDouble(double, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a single Double to this builder.
putDoubles(double[], ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Doubles from an array to this builder.
putDoubles(double[], int, int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Doubles from an array to this builder.
putFloat(float, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a single Float to this builder.
putFloats(float[], ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Floats from an array to this builder.
putFloats(float[], int, int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Floats from an array to this builder.
putInt(int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a single Int to this builder.
putInts(int[], ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Ints from an array to this builder.
putInts(int[], int, int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Ints from an array to this builder.
putLong(long, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a single Long to this builder.
putLongPart(long, int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add the n least significant bytes of the given Long to this builder.
putLongs(long[], ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Longs from an array to this builder.
putLongs(long[], int, int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Longs from an array to this builder.
putShort(int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a single Short to this builder.
putShorts(short[], ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Shorts from an array to this builder.
putShorts(short[], int, int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Shorts from an array to this builder.

Q

QDumper - Class in akka.actor.mailbox.filebased.filequeue.tools
 
QDumper() - Constructor for class akka.actor.mailbox.filebased.filequeue.tools.QDumper
 
QDumper$ - Class in akka.actor.mailbox.filebased.filequeue.tools
 
QDumper$() - Constructor for class akka.actor.mailbox.filebased.filequeue.tools.QDumper$
 
QItem - Class in akka.actor.mailbox.filebased.filequeue
 
QItem(long, long, byte[], int) - Constructor for class akka.actor.mailbox.filebased.filequeue.QItem
 
QItem$ - Class in akka.actor.mailbox.filebased.filequeue
 
QItem$() - Constructor for class akka.actor.mailbox.filebased.filequeue.QItem$
 
QuarantineDuration() - Method in class akka.remote.RemoteSettings
 
QueryTimeout() - Method in class akka.remote.testconductor.TestConductorExt.Settings
 
queue() - Method in class akka.actor.mailbox.filebased.filequeue.tools.QueueDumper
 
queue() - Method in class akka.contrib.mailbox.PeekMailbox
 
queue() - Method in class akka.contrib.throttle.TimerBasedThrottler.Data
 
queue() - Method in class akka.dispatch.BoundedDequeBasedMailbox.MessageQueue
 
queue() - Method in interface akka.dispatch.BoundedDequeBasedMessageQueue
 
queue() - Method in class akka.dispatch.BoundedMailbox.MessageQueue
 
queue() - Method in class akka.dispatch.BoundedPriorityMailbox.MessageQueue
 
queue() - Method in interface akka.dispatch.BoundedQueueBasedMessageQueue
 
queue() - Method in interface akka.dispatch.DequeBasedMessageQueue
 
queue() - Method in interface akka.dispatch.QueueBasedMessageQueue
 
queue() - Method in class akka.dispatch.UnboundedDequeBasedMailbox.MessageQueue
 
queue() - Method in class akka.dispatch.UnboundedMailbox.MessageQueue
 
queue() - Method in class akka.dispatch.UnboundedPriorityMailbox.MessageQueue
 
queue() - Method in class akka.testkit.CallingThreadMailbox
 
queue() - Method in interface akka.testkit.TestKitBase
 
QueueBasedMessageQueue - Interface in akka.dispatch
A QueueBasedMessageQueue is a MessageQueue backed by a java.util.Queue.
QueueCollection - Class in akka.actor.mailbox.filebased.filequeue
 
QueueCollection(String, FileBasedMailboxSettings, LoggingAdapter) - Constructor for class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
QueueDumper - Class in akka.actor.mailbox.filebased.filequeue.tools
 
QueueDumper(String, LoggingAdapter) - Constructor for class akka.actor.mailbox.filebased.filequeue.tools.QueueDumper
 
queueFactory() - Method in class akka.dispatch.ThreadPoolConfig
 
queueHits() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
queueMisses() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
queueNames() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
QueuePath() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
quiet() - Method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper$
 
quiet() - Static method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper
 

R

rampup(int, int) - Method in class akka.routing.DefaultResizer
Computes a proposed positive (or zero) capacity delta using the configured rampupRate.
rampupRate() - Method in class akka.routing.DefaultResizer
Percentage to increase capacity whenever all routees are busy.
random() - Method in class akka.util.Crypt$
 
random() - Static method in class akka.util.Crypt
 
RandomLike - Interface in akka.routing
The core pieces of the routing logic is located in this trait to be able to extend.
RandomRouter - Class in akka.routing
A Router that randomly selects one of the target connections to send a message to.
RandomRouter(int, Iterable<String>, Option<Resizer>, String, SupervisorStrategy) - Constructor for class akka.routing.RandomRouter
 
RandomRouter(int) - Constructor for class akka.routing.RandomRouter
Java API: Constructor that sets nrOfInstances to be created.
RandomRouter(Iterable<String>) - Constructor for class akka.routing.RandomRouter
Java API: Constructor that sets the routees to be used.
RandomRouter(Resizer) - Constructor for class akka.routing.RandomRouter
Java API: Constructor that sets the resizer to be used.
RandomRouter$ - Class in akka.routing
 
RandomRouter$() - Constructor for class akka.routing.RandomRouter$
 
rate() - Method in class akka.contrib.throttle.Throttler.SetRate
 
rate() - Method in class akka.contrib.throttle.TimerBasedThrottler
 
Rate - Class in akka.zeromq
Sets the maximum send or receive data rate for multicast transports such as pgm using the specified socket.
Rate(long) - Constructor for class akka.zeromq.Rate
 
rate() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its rate configuration.
rate() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its rate configuration.
Rate$ - Class in akka.zeromq
Gets the send or receive rate for the socket
Rate$() - Constructor for class akka.zeromq.Rate$
 
RATEMBIT_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
rawValue() - Method in class akka.remote.SeqNo
 
readBufferSize() - Method in class akka.actor.IOManager.Settings
 
readHandlerPromise() - Method in interface akka.remote.transport.AssociationHandle
The Promise returned by this call must be completed with an AssociationHandle.HandleEventListener to register a listener responsible for handling incoming payload.
readHandlerPromise() - Method in class akka.remote.transport.TestAssociationHandle
 
readJournalEntry(FileChannel) - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
readView() - Method in class akka.cluster.Cluster
 
ready() - Method in class akka.remote.transport.ActorTransportAdapterManager
 
ready(Duration, CanAwait) - Method in class akka.testkit.TestLatch
 
reason() - Method in class akka.actor.FSM.StopEvent
 
receive() - Method in interface akka.actor.Actor
This defines the initial actor behavior, it must return a partial function with the actor logic.
receive() - Method in interface akka.actor.dsl.Creators.Act
Default behavior of the actor is empty, use become to change this.
receive(FiniteDuration) - Method in class akka.actor.dsl.Inbox.Inbox
Receive a single message from the internal receiver actor.
receive() - Method in class akka.actor.dsl.Inbox.InboxActor
 
receive() - Method in interface akka.actor.FSM
 
receive(FiniteDuration) - Method in class akka.actor.Inbox
Receive the next message from this Inbox.
receive() - Method in class akka.actor.IOManagerActor
 
receive() - Method in class akka.actor.mailbox.DurableMailboxSpecActorFactory.AccumulatorActor
 
receive() - Method in class akka.actor.mailbox.DurableMailboxSpecActorFactory.MailboxTestActor
 
receive(String) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
receive() - Method in class akka.actor.UntypedActor
 
receive() - Method in interface akka.camel.Producer
Implementation of Actor.receive.
receive() - Method in class akka.camel.ProducerSupport.ProducerChild
 
receive() - Method in class akka.contrib.jul.JavaLogger
 
receive() - Method in interface akka.contrib.pattern.Aggregator
Receive function for handling the aggregations.
receive() - Method in class akka.contrib.pattern.ClusterClient
 
receive() - Method in class akka.contrib.pattern.ClusterReceptionist
 
receive() - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
receive() - Method in class akka.contrib.pattern.ReliableProxy.Receiver
 
receive() - Method in class akka.event.DeadLetterListener
 
receive() - Method in class akka.event.Logging.DefaultLogger
 
receive() - Method in class akka.event.slf4j.Slf4jLogger
 
receive() - Method in class akka.io.TcpPipelineHandler
 
receive() - Method in class akka.Main.Terminator
 
receive() - Method in class akka.osgi.DefaultOSGiLogger
 
receive(T) - Method in class akka.remote.AckedReceiveBuffer
Puts a sequenced message in the receive buffer returning a new buffer.
receive() - Method in class akka.remote.transport.ActorTransportAdapterManager
 
receive() - Method in interface akka.routing.Router
 
receive() - Method in class akka.testkit.TestActor
 
receive(Object) - Method in class akka.testkit.TestActorRef
Directly inject messages into actor receive behavior.
receive(Object, ActorRef) - Method in class akka.testkit.TestActorRef
Directly inject messages into actor receive behavior.
receive() - Method in class akka.testkit.TestActorRefSpec.Logger
 
receive() - Method in class akka.testkit.TestActorRefSpec.ReceiveTimeoutActor
 
receive() - Method in interface akka.testkit.TestActorRefSpec.TActor
 
receive() - Method in class akka.testkit.TestEventListener
 
receive() - Method in interface akka.transactor.Transactor
Implement a general pattern for using coordinated transactions.
Receive_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.Direction
 
ReceiveBufferSize() - Method in interface akka.io.Inet.SoForwarders
Inet.SocketOption to set the SO_RCVBUF option
receiveBufferSize(int) - Method in interface akka.io.Inet.SoJavaFactories
Inet.SocketOption to set the SO_RCVBUF option
ReceiveBufferSize() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
ReceiveBufferSize - Class in akka.zeromq
The ReceiveBufferSize option shall set the underlying kernel receive buffer size for the socket to the specified size in bytes.
ReceiveBufferSize(long) - Constructor for class akka.zeromq.ReceiveBufferSize
 
receiveBufferSize() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its receive bufferSize configuration.
receiveBufferSize() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its receive bufferSize configuration.
ReceiveBufferSize$ - Class in akka.zeromq
Gets the ReceiveBufferSize
ReceiveBufferSize$() - Constructor for class akka.zeromq.ReceiveBufferSize$
 
ReceivedMessageSizeLimit() - Method in class akka.io.TcpExt.Settings
 
ReceiveHighWatermark - Class in akka.zeromq
The ReceiveHighWatermark option shall set the high water mark for inbound messages on the specified socket.
ReceiveHighWatermark(long) - Constructor for class akka.zeromq.ReceiveHighWatermark
 
receiveHighWatermark() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its receive high watermark configuration.
receiveHighWatermark() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its receive high watermark configuration.
ReceiveHighWatermark$ - Class in akka.zeromq
Gets the ReceiveHighWatermark
ReceiveHighWatermark$() - Constructor for class akka.zeromq.ReceiveHighWatermark$
 
receiveN(int) - Method in class akka.testkit.JavaTestKit
Same as receiveN(n, remaining()), but correctly treating the timeFactor.
receiveN(int, FiniteDuration) - Method in class akka.testkit.JavaTestKit
Receive N messages in a row before the given deadline.
receiveN(int) - Method in interface akka.testkit.TestKitBase
Same as receiveN(n, remaining) but correctly taking into account Duration.timeFactor.
receiveN(int, FiniteDuration) - Method in interface akka.testkit.TestKitBase
Receive N messages in a row before the given deadline.
receiveN_internal(int, Duration) - Method in interface akka.testkit.TestKitBase
 
receiveOne(Duration) - Method in class akka.testkit.JavaTestKit
Receive one message from the internal queue of the TestActor.
receiveOne(Duration) - Method in interface akka.testkit.TestKitBase
Receive one message from the internal queue of the TestActor.
receiver() - Method in class akka.actor.dsl.Inbox.Inbox
 
receiver(ActorRef) - Method in class akka.contrib.pattern.ReliableProxy$
 
receiver(ActorRef) - Static method in class akka.contrib.pattern.ReliableProxy
 
receiver() - Method in class akka.io.TcpPipelineHandler.Tell
 
receiveT() - Method in class akka.testkit.TestActorRefSpec.ReplyActor
 
receiveT() - Method in class akka.testkit.TestActorRefSpec.SenderActor
 
receiveT() - Method in interface akka.testkit.TestActorRefSpec.TActor
 
receiveT() - Method in class akka.testkit.TestActorRefSpec.WorkerActor
 
receiveTimeout() - Method in interface akka.actor.ActorContext
Gets the current receive timeout.
ReceiveTimeout - Class in akka.actor
 
ReceiveTimeout() - Constructor for class akka.actor.ReceiveTimeout
 
ReceiveTimeout$ - Class in akka.actor
When using ActorContext.setReceiveTimeout, the singleton instance of ReceiveTimeout will be sent to the Actor when there hasn't been any message for that long.
ReceiveTimeout$() - Constructor for class akka.actor.ReceiveTimeout$
 
receiveWhile(Duration, Duration, int, PartialFunction<Object, T>) - Method in interface akka.testkit.TestKitBase
Receive a series of messages until one does not match the given partial function or the idle timeout is met (disabled by default) or the overall maximum duration is elapsed.
recipient() - Method in class akka.actor.DeadLetter
 
recipient() - Method in class akka.actor.UnhandledMessage
 
recipient() - Method in class akka.remote.transport.TestTransport.WriteAttempt
 
recipient() - Method in class akka.routing.Destination
 
RECIPIENT_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.RemoteEnvelope
 
ReconnectBackoff() - Method in class akka.remote.testconductor.TestConductorExt.Settings
 
ReconnectIVL - Class in akka.zeromq
Sets the recovery interval for multicast transports using the specified socket.
ReconnectIVL(long) - Constructor for class akka.zeromq.ReconnectIVL
 
reconnectIVL() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its reconnect interval configuration.
reconnectIVL() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its reconnect interval configuration.
ReconnectIVL$ - Class in akka.zeromq
Gets the recover interval @see akka.zeromq.ReconnectIVL
ReconnectIVL$() - Constructor for class akka.zeromq.ReconnectIVL$
 
ReconnectIVLMax - Class in akka.zeromq
The ReconnectIVLMax option shall set the maximum reconnection interval for the specified socket.
ReconnectIVLMax(long) - Constructor for class akka.zeromq.ReconnectIVLMax
 
reconnectIVLMax() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its max reconnect interval configuration.
reconnectIVLMax() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its max reconnect interval configuration.
ReconnectIVLMax$ - Class in akka.zeromq
Gets the max reconnect IVL
ReconnectIVLMax$() - Constructor for class akka.zeromq.ReconnectIVLMax$
 
Recover<T> - Class in akka.dispatch
Callback for the Future.recover operation that conditionally turns failures into successes.
Recover() - Constructor for class akka.dispatch.Recover
 
recover(Throwable) - Method in class akka.dispatch.Recover
This method will be invoked once when/if the Future this recover callback is registered on becomes completed with a failure.
RecoveryInterval - Class in akka.zeromq
Sets the recovery interval for multicast transports using the specified socket.
RecoveryInterval(long) - Constructor for class akka.zeromq.RecoveryInterval
 
recoveryInterval() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its recovery interval configuration.
recoveryInterval() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its recovery interval configuration.
RecoveryInterval$ - Class in akka.zeromq
Gets the RecoveryInterval
RecoveryInterval$() - Constructor for class akka.zeromq.RecoveryInterval$
 
reduce(Iterable<Future<T>>, Function2<R, T, R>, ExecutionContext) - Method in class akka.dispatch.Futures$
Reduces the results of the supplied futures and binary function.
reduce(Iterable<Future<T>>, Function2<R, T, R>, ExecutionContext) - Static method in class akka.dispatch.Futures
Reduces the results of the supplied futures and binary function.
ReentrantGuard - Class in akka.util
 
ReentrantGuard() - Constructor for class akka.util.ReentrantGuard
 
ref() - Method in class akka.actor.ActorIdentity
 
ref() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Put
 
ref() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Subscribe
 
ref() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Unsubscribe
 
ref() - Method in class akka.contrib.pattern.WorkList.Entry
 
ref() - Method in interface akka.routing.Router
 
ref() - Method in class akka.testkit.TestActor.UnWatch
 
ref() - Method in class akka.testkit.TestActor.Watch
 
ref() - Method in class akka.testkit.TestProbe
Shorthand to get the testActor.
ReflectiveDynamicAccess - Class in akka.actor
This is the default DynamicAccess implementation used by ExtendedActorSystem unless overridden.
ReflectiveDynamicAccess(ClassLoader) - Constructor for class akka.actor.ReflectiveDynamicAccess
 
refreshContactsTask() - Method in class akka.contrib.pattern.ClusterClient
 
register(S, PartialFunction<FSM.Event, FSM.State<S, D>>, Option<FiniteDuration>) - Method in interface akka.actor.FSM
 
register() - Method in interface akka.camel.Consumer
 
register() - Method in interface akka.camel.ProducerSupport
 
register(ActorRef, PeekMailbox) - Method in class akka.contrib.mailbox.PeekMailboxExtension
 
register(akka.actor.ActorCell) - Method in class akka.dispatch.BalancingDispatcher
 
register(akka.actor.ActorCell) - Method in class akka.dispatch.MessageDispatcher
If you override it, you must call it.
register(akka.actor.ActorCell) - Method in class akka.dispatch.PinnedDispatcher
 
register(ActorRef, boolean, boolean) - Method in class akka.io.TcpMessage$
This message must be sent to a TCP connection actor after receiving the Tcp.Connected message.
register(ActorRef) - Method in class akka.io.TcpMessage$
The same as register(handler, false, false).
register(ActorRef, boolean, boolean) - Static method in class akka.io.TcpMessage
This message must be sent to a TCP connection actor after receiving the Tcp.Connected message.
register(ActorRef) - Static method in class akka.io.TcpMessage
The same as register(handler, false, false).
register(akka.actor.ActorCell) - Method in class akka.testkit.CallingThreadDispatcher
 
registerAllExtensions(com.google.protobuf.ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages$
 
registerAllExtensions(com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.cluster.protobuf.msg.ClusterMessages
 
registerAllExtensions(com.google.protobuf.ExtensionRegistry) - Static method in class akka.remote.ContainerFormats
 
registerAllExtensions(com.google.protobuf.ExtensionRegistry) - Static method in class akka.remote.testconductor.TestConductorProtocol
 
registerAllExtensions(com.google.protobuf.ExtensionRegistry) - Static method in class akka.remote.WireFormats
 
registerExtension(ExtensionId<T>) - Method in class akka.actor.ActorSystem
Registers the provided extension and creates its payload, if this extension isn't already registered This method has putIfAbsent-semantics, this method can potentially block, waiting for the initialization of the payload, if is in the process of registration from another Thread of execution
registerForExecution(Mailbox, boolean, boolean) - Method in class akka.dispatch.Dispatcher
Returns if it was registered
registerForExecution(Mailbox, boolean, boolean) - Method in class akka.dispatch.MessageDispatcher
Suggest to register the provided mailbox for execution
registerForExecution(akka.dispatch.Mailbox, boolean, boolean) - Method in class akka.testkit.CallingThreadDispatcher
 
registerListenerPair(Tuple2<Address, Address>, Tuple2<AssociationHandle.HandleEventListener, AssociationHandle.HandleEventListener>) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Registers a Future of two handle event listeners corresponding to the two endpoints of an association.
registerOnMemberUp(Function0<T>) - Method in class akka.cluster.Cluster
The supplied thunk will be run, once, when current cluster member is Up.
registerOnMemberUp(Runnable) - Method in class akka.cluster.Cluster
Java API: The supplied callback will be run, once, when current cluster member is Up.
registerOnTermination(Function0<T>) - Method in class akka.actor.ActorSystem
Register a block of code (callback) to run after ActorSystem.shutdown has been issued and all actors in this actor system have been stopped.
registerOnTermination(Runnable) - Method in class akka.actor.ActorSystem
Java API: Register a block of code (callback) to run after ActorSystem.shutdown has been issued and all actors in this actor system have been stopped.
registerRoutees(Iterable<ActorRef>) - Method in class akka.routing.RouteeProvider
Adds the routees to the router.
registerRoutees(Iterable<ActorRef>) - Method in class akka.routing.RouteeProvider
Java API: Adds the routees to the router.
registerRouteesFor(Iterable<String>) - Method in class akka.remote.routing.RemoteRouteeProvider
 
registerRouteesFor(Iterable<String>) - Method in class akka.routing.RouteeProvider
Looks up routes with specified paths and registers them.
registerRouteesFor(Iterable<String>) - Method in class akka.routing.RouteeProvider
Java API: Looks up routes with specified paths and registers them.
registerService(ActorRef) - Method in class akka.contrib.pattern.ClusterReceptionistExtension
Register an actor that should be reachable for the clients.
registerService(org.osgi.framework.BundleContext, ActorSystem) - Method in class akka.osgi.ActorSystemActivator
Register the actor system in the OSGi service registry.
registerSubscriber(String, ActorRef) - Method in class akka.contrib.pattern.ClusterReceptionistExtension
Register an actor that should be reachable for the clients to a named topic.
registerTempActor(InternalActorRef, ActorPath) - Method in interface akka.actor.ActorRefProvider
Registers an actorRef at a path returned by tempPath(); do NOT pass in any other path.
RegisterTimeout() - Method in class akka.io.TcpExt.Settings
 
registerTransport(TestTransport, Future<Transport.AssociationEventListener>) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Records a mapping between an address and the corresponding (transport, associationEventListener) pair.
registry() - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
registry() - Method in class akka.remote.transport.TestTransport
 
rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class akka.dispatch.SaneRejectedExecutionHandler
 
rejectionPolicy() - Method in class akka.dispatch.ThreadPoolConfig
 
RelativeActorPath - Class in akka.actor
Extractor for so-called “relative actor paths” as in “relative URI”, not in “relative to some actor”.
RelativeActorPath() - Constructor for class akka.actor.RelativeActorPath
 
RelativeActorPath$ - Class in akka.actor
Extractor for so-called “relative actor paths” as in “relative URI”, not in “relative to some actor”.
RelativeActorPath$() - Constructor for class akka.actor.RelativeActorPath$
 
release(ByteBuffer) - Method in interface akka.io.BufferPool
 
ReliableProxy - Class in akka.contrib.pattern
A ReliableProxy is a means to wrap a remote actor reference in order to obtain certain improved delivery guarantees:
ReliableProxy(ActorRef, FiniteDuration) - Constructor for class akka.contrib.pattern.ReliableProxy
 
ReliableProxy$ - Class in akka.contrib.pattern
 
ReliableProxy$() - Constructor for class akka.contrib.pattern.ReliableProxy$
 
ReliableProxy.Ack - Class in akka.contrib.pattern
 
ReliableProxy.Ack(int) - Constructor for class akka.contrib.pattern.ReliableProxy.Ack
 
ReliableProxy.Ack$ - Class in akka.contrib.pattern
 
ReliableProxy.Ack$() - Constructor for class akka.contrib.pattern.ReliableProxy.Ack$
 
ReliableProxy.Active$ - Class in akka.contrib.pattern
 
ReliableProxy.Active$() - Constructor for class akka.contrib.pattern.ReliableProxy.Active$
 
ReliableProxy.Idle$ - Class in akka.contrib.pattern
 
ReliableProxy.Idle$() - Constructor for class akka.contrib.pattern.ReliableProxy.Idle$
 
ReliableProxy.Message - Class in akka.contrib.pattern
 
ReliableProxy.Message(Object, ActorRef, int) - Constructor for class akka.contrib.pattern.ReliableProxy.Message
 
ReliableProxy.Message$ - Class in akka.contrib.pattern
 
ReliableProxy.Message$() - Constructor for class akka.contrib.pattern.ReliableProxy.Message$
 
ReliableProxy.Receiver - Class in akka.contrib.pattern
 
ReliableProxy.Receiver(ActorRef) - Constructor for class akka.contrib.pattern.ReliableProxy.Receiver
 
ReliableProxy.State - Interface in akka.contrib.pattern
 
ReliableProxy.Tick$ - Class in akka.contrib.pattern
 
ReliableProxy.Tick$() - Constructor for class akka.contrib.pattern.ReliableProxy.Tick$
 
remaining() - Method in class akka.testkit.JavaTestKit
Obtain time remaining for execution of the innermost enclosing Within block or missing that it returns the properly dilated default for this case from settings (key "akka.test.single-expect-default").
remaining() - Method in interface akka.testkit.TestKitBase
Obtain time remaining for execution of the innermost enclosing within block or missing that it returns the properly dilated default for this case from settings (key "akka.test.single-expect-default").
remainingCapacity() - Method in class akka.util.BoundedBlockingQueue
 
remainingDuration() - Method in exception akka.pattern.CircuitBreakerOpenException
 
remainingOr(FiniteDuration) - Method in class akka.testkit.JavaTestKit
Obtain time remaining for execution of the innermost enclosing Within block or missing that it returns the given duration.
remainingOr(FiniteDuration) - Method in interface akka.testkit.TestKitBase
Obtain time remaining for execution of the innermost enclosing within block or missing that it returns the given duration.
remainingOrDilated(Duration) - Method in interface akka.testkit.TestKitBase
 
remote() - Method in class akka.remote.transport.TestTransport.DisassociateAttempt
 
remoteAddress() - Method in class akka.io.Tcp.Connect
 
remoteAddress() - Method in class akka.io.Tcp.Connected
 
remoteAddress() - Method in class akka.io.UdpConnected.Connect
 
remoteAddress() - Method in class akka.remote.AssociatedEvent
 
remoteAddress() - Method in class akka.remote.AssociationErrorEvent
 
remoteAddress() - Method in interface akka.remote.AssociationEvent
 
remoteAddress() - Method in class akka.remote.DisassociatedEvent
 
remoteAddress() - Method in class akka.remote.transport.AbstractTransportAdapterHandle
 
remoteAddress() - Method in class akka.remote.transport.ActorTransportAdapter.AssociateUnderlying
 
remoteAddress() - Method in interface akka.remote.transport.AssociationHandle
Address of the remote endpoint.
remoteAddress() - Method in class akka.remote.transport.TestAssociationHandle
 
remoteAddress() - Method in class akka.remote.transport.TestTransport.AssociateAttempt
 
RemoteLifecycleEventsLogLevel() - Method in class akka.remote.RemoteSettings
 
remoteListenerRelativeTo(TestAssociationHandle, Tuple2<AssociationHandle.HandleEventListener, AssociationHandle.HandleEventListener>) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Returns the remote endpoint for a pair of endpoints relative to the owner of the supplied handle.
RemoteRouteeProvider - Class in akka.remote.routing
Factory and registry for routees of the router.
RemoteRouteeProvider(Iterable<Address>, ActorContext, Props, Option<Resizer>) - Constructor for class akka.remote.routing.RemoteRouteeProvider
 
RemoteRouterConfig - Class in akka.remote.routing
RouterConfig implementation for remote deployment on defined target nodes.
RemoteRouterConfig(RouterConfig, Iterable<Address>) - Constructor for class akka.remote.routing.RemoteRouterConfig
 
RemoteRouterConfig(RouterConfig, Iterable<Address>) - Constructor for class akka.remote.routing.RemoteRouterConfig
 
RemoteRouterConfig(RouterConfig, Address[]) - Constructor for class akka.remote.routing.RemoteRouterConfig
 
RemoteRouterConfig$ - Class in akka.remote.routing
 
RemoteRouterConfig$() - Constructor for class akka.remote.routing.RemoteRouterConfig$
 
RemoteScope - Class in akka.remote
 
RemoteScope(Address) - Constructor for class akka.remote.RemoteScope
 
RemoteScope$ - Class in akka.remote
 
RemoteScope$() - Constructor for class akka.remote.RemoteScope$
 
RemoteSettings - Class in akka.remote
 
RemoteSettings(com.typesafe.config.Config) - Constructor for class akka.remote.RemoteSettings
 
RemoteTransportException - Exception in akka.remote
RemoteTransportException represents a general failure within a RemoteTransport, such as inability to start, wrong configuration etc.
RemoteTransportException(String, Throwable) - Constructor for exception akka.remote.RemoteTransportException
 
RemoteTransportExceptionNoStackTrace - Exception in akka.remote
RemoteTransportException without stack trace.
RemoteTransportExceptionNoStackTrace(String, Throwable) - Constructor for exception akka.remote.RemoteTransportExceptionNoStackTrace
 
RemotingErrorEvent - Class in akka.remote
 
RemotingErrorEvent(Throwable) - Constructor for class akka.remote.RemotingErrorEvent
 
RemotingErrorEvent$ - Class in akka.remote
 
RemotingErrorEvent$() - Constructor for class akka.remote.RemotingErrorEvent$
 
RemotingLifecycleEvent - Interface in akka.remote
 
RemotingListenEvent - Class in akka.remote
 
RemotingListenEvent(Set<Address>) - Constructor for class akka.remote.RemotingListenEvent
 
RemotingListenEvent$ - Class in akka.remote
 
RemotingListenEvent$() - Constructor for class akka.remote.RemotingListenEvent$
 
RemotingShutdownEvent - Class in akka.remote
 
RemotingShutdownEvent() - Constructor for class akka.remote.RemotingShutdownEvent
 
RemotingShutdownEvent$ - Class in akka.remote
 
RemotingShutdownEvent$() - Constructor for class akka.remote.RemotingShutdownEvent$
 
remove() - Method in class akka.actor.mailbox.filebased.FileBasedMessageQueue
Completely delete the queue.
remove() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
remove(boolean) - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
Remove and return an item from the queue, if there is one.
remove() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
Remove and return an item from the queue, if there is one.
remove(String, int, boolean, boolean, Function1<Option<QItem>, BoxedUnit>) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
Retrieve an item from a queue and pass it to a continuation.
remove(T) - Method in class akka.contrib.pattern.WorkList
Removes an entry from the work list
remove(A) - Method in class akka.remote.DefaultFailureDetectorRegistry
 
remove(A) - Method in interface akka.remote.FailureDetectorRegistry
Removes the heartbeat management for a resource.
remove(T) - Method in class akka.routing.ConsistentHash
Java API: Removes a node from the node ring.
remove(Object) - Method in class akka.util.BoundedBlockingQueue
 
remove(K, V) - Method in class akka.util.Index
Disassociates the value of type V from the key of type K
remove(K) - Method in class akka.util.Index
Disassociates all the values for the specified key
removeAll() - Method in class akka.contrib.pattern.WorkList
Removes all entries from this WorkList
removeAll(Collection<?>) - Method in class akka.util.BoundedBlockingQueue
 
removed() - Method in class akka.cluster.MemberStatus$
Java API: retrieve the “removed” status singleton
removed() - Static method in class akka.cluster.MemberStatus
Java API: retrieve the “removed” status singleton
Removed() - Method in class akka.cluster.protobuf.msg.MemberStatus$
 
Removed() - Static method in class akka.cluster.protobuf.msg.MemberStatus
 
removed() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
Removed_VALUE() - Method in class akka.cluster.protobuf.msg.MemberStatus$
 
Removed_VALUE() - Static method in class akka.cluster.protobuf.msg.MemberStatus
 
removedTimeToLiveMillis() - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
removeFilter(EventFilter) - Method in class akka.testkit.TestEventListener
 
removeFromCache(Seq<Tuple2<Object, Set<Object>>>) - Method in interface akka.event.SubchannelClassification
 
removeNode(RoleName) - Method in interface akka.remote.testconductor.Conductor
Remove a remote host from the list, so that the remaining nodes may still pass subsequent barriers.
removePattern(int) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
removeRoutees(int, FiniteDuration) - Method in class akka.routing.RouteeProvider
Remove specified number of routees by unregister them and sending PoisonPill after the specified delay.
removeScheme(String) - Method in interface akka.remote.transport.SchemeAugmenter
 
removeScheme(Address) - Method in interface akka.remote.transport.SchemeAugmenter
 
removeTentative() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
removeValue(V) - Method in class akka.util.Index
Removes the specified value from all keys
repeat() - Method in class akka.actor.FSM.Timer
 
repeat(IO.Iteratee<T>) - Method in class akka.actor.IO$
An Iteratee that continually repeats an Iteratee.
repeat(IO.Iteratee<T>) - Static method in class akka.actor.IO
An Iteratee that continually repeats an Iteratee.
replay(String, Function1<JournalItem, BoxedUnit>) - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
replayJournal() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
replies() - Method in class akka.actor.FSM.State
 
reply() - Method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope
 
reply(Object) - Method in class akka.testkit.JavaTestKit
 
reply(Object) - Method in class akka.testkit.TestProbe
Send message to the sender of the last dequeued message.
REPLY_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope$
 
REPLY_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope
 
replying(Object) - Method in class akka.actor.FSM.State
Send reply to sender of the current message, if available.
ReplyTimeout() - Method in class akka.camel.CamelSettings
Configured setting, when endpoint is out-capable (can produce responses) replyTimeout is the maximum time the endpoint can take to send the response before the message exchange fails.
replyTimeout() - Method in interface akka.camel.Consumer
When endpoint is out-capable (can produce responses) replyTimeout is the maximum time the endpoint can take to send the response before the message exchange fails.
replyTo() - Method in class akka.testkit.TestActorRefSpec.ReplyActor
 
reportFailure(Throwable) - Method in class akka.dispatch.MessageDispatcher
 
Request - Interface in akka.zeromq
Marker trait representing request messages for zeromq
requester() - Method in class akka.remote.transport.TestTransport.DisassociateAttempt
 
requestRestartPermission(Tuple2<Option<Object>, Option<Object>>) - Method in class akka.actor.ChildRestartStats
 
RequiresMessageQueue<T> - Interface in akka.dispatch
Trait to signal that an Actor requires a certain type of message queue semantics.
requireTestConductorTranport() - Method in interface akka.remote.testconductor.Conductor
 
requiring(boolean, Function0<Object>) - Method in class akka.util.Helpers.Requiring
Check that a condition is true.
requiring(Function1<A, Object>, Function0<Object>) - Method in class akka.util.Helpers.Requiring
Check that a condition is true for the value.
RESCHEDULED() - Static method in class akka.dispatch.MessageDispatcher
 
ResendBufferCapacityReachedException - Exception in akka.remote
 
ResendBufferCapacityReachedException(int) - Constructor for exception akka.remote.ResendBufferCapacityReachedException
 
ResendUnfulfillableException - Exception in akka.remote
 
ResendUnfulfillableException() - Constructor for exception akka.remote.ResendUnfulfillableException
 
reset() - Method in class akka.remote.DefaultFailureDetectorRegistry
 
reset() - Method in interface akka.remote.FailureDetectorRegistry
Removes all resources and any associated failure detector state.
reset() - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Resets the state of the registry.
reset() - Method in class akka.testkit.TestBarrier
 
reset() - Method in class akka.testkit.TestLatch
 
resetStreamCache() - Method in class akka.camel.CamelMessage
Reset StreamCache body.
resize(RouteeProvider) - Method in class akka.routing.DefaultResizer
 
resize(RouteeProvider) - Method in interface akka.routing.Resizer
Decide if the capacity of the router need to be changed.
resizer() - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
 
resizer() - Method in class akka.cluster.routing.ClusterRouterConfig
 
resizer() - Method in class akka.remote.routing.RemoteRouterConfig
 
resizer() - Method in class akka.routing.BroadcastRouter
 
resizer() - Method in class akka.routing.ConsistentHashingRouter
 
resizer() - Method in class akka.routing.RandomRouter
 
Resizer - Interface in akka.routing
Routers with dynamically resizable number of routees is implemented by providing a Resizer implementation in RouterConfig.
resizer() - Method in class akka.routing.RoundRobinRouter
 
resizer() - Method in class akka.routing.RouteeProvider
 
resizer() - Method in interface akka.routing.RouterConfig
Routers with dynamically resizable number of routees return the Resizer to use.
resizer() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
resizer() - Method in class akka.routing.SmallestMailboxRouter
 
resolveActorRef(String) - Method in interface akka.actor.ActorRefProvider
Create actor reference for a specified path.
resolveActorRef(ActorPath) - Method in interface akka.actor.ActorRefProvider
Create actor reference for a specified path.
resolveClass(ObjectStreamClass) - Method in class akka.util.ClassLoaderObjectInputStream
 
resolveOne(Timeout) - Method in class akka.actor.ActorSelection
Resolve the ActorRef matching this selection.
resolveOne(FiniteDuration) - Method in class akka.actor.ActorSelection
Resolve the ActorRef matching this selection.
Response - Interface in akka.zeromq
Base trait for the events raised by a ZeroMQ socket actor
responseTunnel(ActorRef) - Method in class akka.contrib.pattern.ClusterReceptionist
 
Restart() - Method in interface akka.actor.dsl.Creators.Act
 
restart() - Method in class akka.actor.SupervisorStrategy$
Java API: Returning this directive discards the old Actor instance and replaces it with a new, then resumes message processing.
restart() - Static method in class akka.actor.SupervisorStrategy
Java API: Returning this directive discards the old Actor instance and replaces it with a new, then resumes message processing.
restartChild(ActorRef, Throwable, boolean) - Method in class akka.actor.SupervisorStrategy
Restart the given child, possibly suspending it first.
restartTimeWindowStartNanos() - Method in class akka.actor.ChildRestartStats
 
result() - Method in class akka.actor.IO.Done
 
result(Duration, CanAwait) - Method in class akka.testkit.TestLatch
 
result() - Method in class akka.util.ByteStringBuilder
 
Resume() - Method in interface akka.actor.dsl.Creators.Act
 
resume() - Method in class akka.actor.SupervisorStrategy$
Java API: Returning this directive resumes message processing for the failed Actor
resume() - Static method in class akka.actor.SupervisorStrategy
Java API: Returning this directive resumes message processing for the failed Actor
resume(akka.actor.ActorCell) - Method in class akka.dispatch.MessageDispatcher
 
resume(akka.actor.ActorCell) - Method in class akka.testkit.CallingThreadDispatcher
 
resumeChild(ActorRef, Throwable) - Method in class akka.actor.SupervisorStrategy
Resume the previously failed child: do never apply this to a child which is not the currently failing child.
resumeReading() - Method in class akka.io.TcpMessage$
This command needs to be sent to the connection actor after a Tcp.SuspendReading command in order to resume reading from the socket.
resumeReading() - Static method in class akka.io.TcpMessage
This command needs to be sent to the connection actor after a Tcp.SuspendReading command in order to resume reading from the socket.
resumeReading() - Method in class akka.io.UdpConnectedMessage$
This message must be sent to the listener actor to re-enable reading from the socket after a UdpConnected.SuspendReading command.
resumeReading() - Static method in class akka.io.UdpConnectedMessage
This message must be sent to the listener actor to re-enable reading from the socket after a UdpConnected.SuspendReading command.
resumeReading() - Method in class akka.io.UdpMessage$
This message must be sent to the listener actor to re-enable reading from the socket after a Udp.SuspendReading command.
resumeReading() - Static method in class akka.io.UdpMessage
This message must be sent to the listener actor to re-enable reading from the socket after a Udp.SuspendReading command.
resumeReads() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
resumeWriting() - Method in class akka.io.TcpMessage$
When useResumeWriting is in effect as was indicated in the Tcp.Register message then this command needs to be sent to the connection actor in order to re-enable writing after a Tcp.CommandFailed event.
resumeWriting() - Static method in class akka.io.TcpMessage
When useResumeWriting is in effect as was indicated in the Tcp.Register message then this command needs to be sent to the connection actor in order to re-enable writing after a Tcp.CommandFailed event.
retainAll(Collection<?>) - Method in class akka.util.BoundedBlockingQueue
 
RetryGateClosedFor() - Method in class akka.remote.RemoteSettings
 
RetryUnsuccessfulJoinAfter() - Method in class akka.cluster.ClusterSettings
 
RetryWindow() - Method in class akka.remote.RemoteSettings
 
returnsFuture() - Method in class akka.actor.TypedActor.MethodCall
 
returnsJOption() - Method in class akka.actor.TypedActor.MethodCall
 
returnsOption() - Method in class akka.actor.TypedActor.MethodCall
 
reusableQueue(BlockingQueue<Runnable>) - Method in class akka.dispatch.ThreadPoolConfig$
 
reusableQueue(Function0<BlockingQueue<Runnable>>) - Method in class akka.dispatch.ThreadPoolConfig$
 
reusableQueue(BlockingQueue<Runnable>) - Static method in class akka.dispatch.ThreadPoolConfig
 
reusableQueue(Function0<BlockingQueue<Runnable>>) - Static method in class akka.dispatch.ThreadPoolConfig
 
ReuseAddress() - Method in interface akka.io.Inet.SoForwarders
Inet.SocketOption to enable or disable SO_REUSEADDR
reuseAddress(boolean) - Method in interface akka.io.Inet.SoJavaFactories
Inet.SocketOption to enable or disable SO_REUSEADDR
role() - Method in class akka.cluster.ClusterEvent.RoleLeaderChanged
 
role(String) - Method in class akka.remote.testkit.MultiNodeConfig
Construct a RoleName and return it, to be used as an identifier in the test.
roleLeader(String) - Method in class akka.cluster.ClusterEvent.CurrentClusterState
get address of current leader, if any, within the role set
roleLeaderMap() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
 
RoleName - Class in akka.remote.testconductor
 
RoleName(String) - Constructor for class akka.remote.testconductor.RoleName
 
RoleName$ - Class in akka.remote.testconductor
 
RoleName$() - Constructor for class akka.remote.testconductor.RoleName$
 
Roles() - Method in class akka.cluster.ClusterSettings
 
roles() - Method in class akka.cluster.Member
 
roles() - Method in class akka.cluster.protobuf.msg.Join
 
roles() - Method in class akka.remote.testkit.MultiNodeSpec
All registered roles
ROLES_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.Join$
 
ROLES_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.Join
 
rolesIndexes() - Method in class akka.cluster.protobuf.msg.Member
 
ROLESINDEXES_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.Member$
 
ROLESINDEXES_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.Member
 
roll(int, List<QItem>, Iterable<QItem>) - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
root() - Method in interface akka.actor.ActorPath
Walk up the tree to obtain and return the RootActorPath.
root() - Method in class akka.actor.ChildActorPath
 
root() - Method in class akka.actor.RootActorPath
 
root() - Method in class akka.event.slf4j.Logger$
Returns the SLF4J Root Logger
root() - Static method in class akka.event.slf4j.Logger
Returns the SLF4J Root Logger
RootActorPath - Class in akka.actor
Root of the hierarchy of ActorPaths.
RootActorPath(Address, String) - Constructor for class akka.actor.RootActorPath
 
RootActorPath$ - Class in akka.actor
 
RootActorPath$() - Constructor for class akka.actor.RootActorPath$
 
rootGuardian() - Method in interface akka.actor.ActorRefProvider
Reference to the supervisor of guardian and systemGuardian; this is exposed so that the ActorSystemImpl can use it as lookupRoot, i.e.
rootGuardianAt(Address) - Method in interface akka.actor.ActorRefProvider
Reference to the supervisor of guardian and systemGuardian at the specified address; this is exposed so that the ActorRefFactory can use it as lookupRoot, i.e.
rootPath() - Method in interface akka.actor.ActorRefProvider
The root path for all actors within this actor system, not including any remote address information.
RoundRobinLike - Interface in akka.routing
The core pieces of the routing logic is located in this trait to be able to extend.
RoundRobinRouter - Class in akka.routing
A Router that uses round-robin to select a connection.
RoundRobinRouter(int, Iterable<String>, Option<Resizer>, String, SupervisorStrategy) - Constructor for class akka.routing.RoundRobinRouter
 
RoundRobinRouter(int) - Constructor for class akka.routing.RoundRobinRouter
Java API: Constructor that sets nrOfInstances to be created.
RoundRobinRouter(Iterable<String>) - Constructor for class akka.routing.RoundRobinRouter
Java API: Constructor that sets the routees to be used.
RoundRobinRouter(Resizer) - Constructor for class akka.routing.RoundRobinRouter
Java API: Constructor that sets the resizer to be used.
RoundRobinRouter$ - Class in akka.routing
 
RoundRobinRouter$() - Constructor for class akka.routing.RoundRobinRouter$
 
routeeProps() - Method in class akka.routing.RouteeProvider
 
RouteeProvider - Class in akka.routing
Factory and registry for routees of the router.
RouteeProvider(ActorContext, Props, Option<Resizer>) - Constructor for class akka.routing.RouteeProvider
 
routees() - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
 
routees() - Method in interface akka.cluster.routing.AdaptiveLoadBalancingRouterLike
 
routees() - Method in interface akka.routing.BroadcastLike
 
routees() - Method in class akka.routing.BroadcastRouter
 
routees() - Method in interface akka.routing.ConsistentHashingLike
 
routees() - Method in class akka.routing.ConsistentHashingRouter
 
routees() - Method in interface akka.routing.RandomLike
 
routees() - Method in class akka.routing.RandomRouter
 
routees() - Method in interface akka.routing.RoundRobinLike
 
routees() - Method in class akka.routing.RoundRobinRouter
 
routees() - Method in class akka.routing.RouteeProvider
All routees of the router
routees() - Method in class akka.routing.RouterRoutees
 
routees() - Method in interface akka.routing.ScatterGatherFirstCompletedLike
 
routees() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
routees() - Method in interface akka.routing.SmallestMailboxLike
 
routees() - Method in class akka.routing.SmallestMailboxRouter
 
routeesPath() - Method in class akka.cluster.routing.ClusterRouterSettings
 
routeesPathElements() - Method in class akka.cluster.routing.ClusterRouterSettings
 
Router - Interface in akka.routing
Base trait for Router actors.
Router.Resize$ - Class in akka.routing
 
Router.Resize$() - Constructor for class akka.routing.Router.Resize$
 
routerConfig() - Method in class akka.actor.Deploy
 
routerConfig() - Method in class akka.actor.Props
Convenience method for extracting the router configuration from the contained Deploy instance.
RouterConfig - Interface in akka.routing
This trait represents a router factory: it produces the actual router actor and creates the routing table (a function which determines the recipients for each message which is to be dispatched).
ROUTERCONFIG_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DeployData
 
routerDispatcher() - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
 
routerDispatcher() - Method in interface akka.cluster.routing.AdaptiveLoadBalancingRouterLike
 
routerDispatcher() - Method in class akka.cluster.routing.ClusterRouterConfig
 
routerDispatcher() - Method in class akka.remote.routing.RemoteRouterConfig
 
routerDispatcher() - Method in class akka.routing.BroadcastRouter
 
routerDispatcher() - Method in class akka.routing.ConsistentHashingRouter
 
routerDispatcher() - Method in class akka.routing.FromConfig
 
routerDispatcher() - Method in class akka.routing.NoRouter$
 
routerDispatcher() - Static method in class akka.routing.NoRouter
 
routerDispatcher() - Method in class akka.routing.RandomRouter
 
routerDispatcher() - Method in class akka.routing.RoundRobinRouter
 
routerDispatcher() - Method in interface akka.routing.RouterConfig
Dispatcher ID to use for running the “head” actor, i.e.
routerDispatcher() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
routerDispatcher() - Method in class akka.routing.SmallestMailboxRouter
 
RouterEnvelope - Interface in akka.routing
Only the contained message will be forwarded to the destination, i.e.
routeResponse(Object) - Method in class akka.camel.javaapi.UntypedProducerActor
 
routeResponse(Object) - Method in interface akka.camel.ProducerSupport
Called after a response was received from the endpoint specified by endpointUri.
routerReceive() - Method in interface akka.routing.Router
 
RouterRoutees - Class in akka.routing
Message used to carry information about what routees the router is currently using.
RouterRoutees(Iterable<ActorRef>) - Constructor for class akka.routing.RouterRoutees
 
RouterRoutees$ - Class in akka.routing
 
RouterRoutees$() - Constructor for class akka.routing.RouterRoutees$
 
run() - Method in class akka.actor.LightArrayRevolverScheduler.TaskHolder
 
run() - Method in class akka.dispatch.TaskInvocation
 
run() - Method in class akka.testkit.JavaTestKit.EventFilter
 
run() - Method in class akka.testkit.JavaTestKit.Within
 
run(ActorRef, Object) - Method in class akka.testkit.TestActor.AutoPilot
 
run(ActorRef, Object) - Method in class akka.testkit.TestActor.KeepRunning$
 
run(ActorRef, Object) - Method in class akka.testkit.TestActor.NoAutoPilot$
 
run(Timeout) - Method in interface akka.util.internal.TimerTask
Deprecated. Executed after the delay specified with Timer#newTimeout(TimerTask, long, java.util.concurrent.TimeUnit) .
runnable() - Method in class akka.dispatch.TaskInvocation
 
runOn(Seq<RoleName>, Function0<BoxedUnit>) - Method in class akka.remote.testkit.MultiNodeSpec
Execute the given block of code only on the given nodes (names according to the roleMap).

S

sameAs(Metric) - Method in class akka.cluster.Metric
Returns true if that is tracking the same metric as this.
sameAs(NodeMetrics) - Method in class akka.cluster.NodeMetrics
Returns true if that address is the same as this
sample() - Method in class akka.cluster.JmxMetricsCollector
Samples and collects new data points.
sample() - Method in interface akka.cluster.MetricsCollector
Samples and collects new data points.
SaneRejectedExecutionHandler - Class in akka.dispatch
The RejectedExecutionHandler used by Akka, it improves on CallerRunsPolicy by throwing a RejectedExecutionException if the executor isShutdown.
SaneRejectedExecutionHandler() - Constructor for class akka.dispatch.SaneRejectedExecutionHandler
 
scala2JavaOption(Option<A>) - Method in class akka.japi.Option$
 
scala2JavaOption(Option<A>) - Static method in class akka.japi.Option
 
ScalaActorRef - Interface in akka.actor
This trait represents the Scala Actor API There are implicit conversions in ../actor/Implicits.scala from ActorRef -> ScalaActorRef and back
ScalaActorSelection - Interface in akka.actor
Contains the Scala API (!-method) for ActorSelections) which provides automatic tracking of the sender, as per the usual implicit ActorRef pattern.
scaledPoolSize(int, double, int) - Method in class akka.dispatch.ThreadPoolConfig$
 
scaledPoolSize(int, double, int) - Static method in class akka.dispatch.ThreadPoolConfig
 
ScanningClassification - Interface in akka.event
Maps Classifiers to Subscribers and selects which Subscriber should receive which publication through scanning through all Subscribers through the matches(classifier, event) method
ScanningEventBus<E,S,C> - Class in akka.event.japi
See documentation for ScanningClassification E is the Event type S is the Subscriber type C is the Classifier type
ScanningEventBus() - Constructor for class akka.event.japi.ScanningEventBus
 
ScatterGatherFirstCompletedLike - Interface in akka.routing
The core pieces of the routing logic is located in this trait to be able to extend.
ScatterGatherFirstCompletedRouter - Class in akka.routing
Simple router that broadcasts the message to all routees, and replies with the first response.
ScatterGatherFirstCompletedRouter(int, Iterable<String>, FiniteDuration, Option<Resizer>, String, SupervisorStrategy) - Constructor for class akka.routing.ScatterGatherFirstCompletedRouter
 
ScatterGatherFirstCompletedRouter(int, FiniteDuration) - Constructor for class akka.routing.ScatterGatherFirstCompletedRouter
Java API: Constructor that sets nrOfInstances to be created.
ScatterGatherFirstCompletedRouter(Iterable<String>, FiniteDuration) - Constructor for class akka.routing.ScatterGatherFirstCompletedRouter
Java API: Constructor that sets the routees to be used.
ScatterGatherFirstCompletedRouter(Resizer, FiniteDuration) - Constructor for class akka.routing.ScatterGatherFirstCompletedRouter
Java API: Constructor that sets the resizer to be used.
ScatterGatherFirstCompletedRouter$ - Class in akka.routing
 
ScatterGatherFirstCompletedRouter$() - Constructor for class akka.routing.ScatterGatherFirstCompletedRouter$
 
schedule(FiniteDuration, FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.AbstractScheduler
Schedules a function to be run repeatedly with an initial delay and a frequency.
schedule(FiniteDuration, FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.DefaultScheduler
 
schedule(ActorRef, FiniteDuration) - Method in class akka.actor.FSM.Timer
 
schedule(FiniteDuration, FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.LightArrayRevolverScheduler
 
schedule(FiniteDuration, FiniteDuration, ActorRef, Object, ExecutionContext, ActorRef) - Method in interface akka.actor.Scheduler
Schedules a message to be sent repeatedly with an initial delay and frequency.
schedule(FiniteDuration, FiniteDuration, Function0<BoxedUnit>, ExecutionContext) - Method in interface akka.actor.Scheduler
Schedules a function to be run repeatedly with an initial delay and a frequency.
schedule(FiniteDuration, FiniteDuration, Runnable, ExecutionContext) - Method in interface akka.actor.Scheduler
Schedules a function to be run repeatedly with an initial delay and a frequency.
SCHEDULED() - Static method in class akka.dispatch.MessageDispatcher
 
scheduleOnce(FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.AbstractScheduler
Schedules a Runnable to be run once with a delay, i.e.
scheduleOnce(FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.DefaultScheduler
 
scheduleOnce(FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.LightArrayRevolverScheduler
 
scheduleOnce(FiniteDuration, ActorRef, Object, ExecutionContext, ActorRef) - Method in interface akka.actor.Scheduler
Schedules a message to be sent once with a delay, i.e.
scheduleOnce(FiniteDuration, Function0<BoxedUnit>, ExecutionContext) - Method in interface akka.actor.Scheduler
Schedules a function to be run once with a delay, i.e.
scheduleOnce(FiniteDuration, Runnable, ExecutionContext) - Method in interface akka.actor.Scheduler
Schedules a Runnable to be run once with a delay, i.e.
scheduler() - Method in class akka.actor.ActorSystem
Light-weight scheduler for running asynchronous tasks after some deadline in the future.
Scheduler - Interface in akka.actor
An Akka scheduler service.
scheduler() - Method in class akka.cluster.Cluster
INTERNAL API
scheduler() - Method in interface akka.dispatch.DispatcherPrerequisites
 
SchedulerClass() - Method in class akka.actor.ActorSystem.Settings
 
SchedulerTickDuration() - Method in class akka.cluster.ClusterSettings
 
SchedulerTicksPerWheel() - Method in class akka.cluster.ClusterSettings
 
scheduleTick() - Method in class akka.contrib.pattern.ReliableProxy
 
SchemeAugmenter - Interface in akka.remote.transport
 
schemeIdentifier() - Method in class akka.remote.transport.AbstractTransportAdapter
 
schemeIdentifier() - Method in class akka.remote.transport.netty.NettyTransport
 
schemeIdentifier() - Method in class akka.remote.transport.TestTransport
 
SchemeIdentifier() - Method in class akka.remote.transport.ThrottlerTransportAdapter$
 
SchemeIdentifier() - Static method in class akka.remote.transport.ThrottlerTransportAdapter
 
schemeIdentifier() - Method in interface akka.remote.transport.Transport
Returns a string that will be used as the scheme part of the URLs corresponding to this transport
scope() - Method in class akka.actor.Deploy
 
Scope - Interface in akka.actor
The scope of a Deploy serves two purposes: as a marker for pattern matching the “scope” (i.e.
SCOPE_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DeployData
 
SEED() - Method in class akka.util.HashCode$
 
SEED() - Static method in class akka.util.HashCode
 
SeedNodes() - Method in class akka.cluster.ClusterSettings
 
SeedNodeTimeout() - Method in class akka.cluster.ClusterSettings
 
seen() - Method in class akka.cluster.protobuf.msg.GossipOverview
 
SEEN_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.GossipOverview$
 
SEEN_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.GossipOverview
 
seenBy() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
 
select(FiniteDuration, PartialFunction<Object, T>) - Method in class akka.actor.dsl.Inbox.Inbox
Receive a single message for which the given partial function is defined and return the transformed result, using the internal receiver actor.
selectInterval() - Method in class akka.actor.IOManager.Settings
 
selection() - Method in exception akka.actor.ActorNotFound
 
SelectionHandlerSettings - Class in akka.io
 
SelectionHandlerSettings(com.typesafe.config.Config) - Constructor for class akka.io.SelectionHandlerSettings
 
SelectorAssociationRetries() - Method in class akka.io.SelectionHandlerSettings
 
SelectorDispatcher() - Method in class akka.io.SelectionHandlerSettings
 
selectors() - Method in class akka.cluster.routing.MixMetricsSelector
 
selectRandomNode(IndexedSeq<Address>) - Method in class akka.contrib.pattern.DistributedPubSubMediator
 
self() - Method in interface akka.actor.Actor
The 'self' field holds the ActorRef for this actor.
self() - Method in interface akka.actor.ActorContext
 
self() - Method in class akka.actor.TypedActor$
Returns the reference to the proxy when called inside a method call in a TypedActor
self() - Static method in class akka.actor.TypedActor
Returns the reference to the proxy when called inside a method call in a TypedActor
self() - Method in class akka.testkit.CallingThreadMailbox
 
self() - Method in interface akka.testkit.ImplicitSender
 
selfAddress() - Method in class akka.cluster.Cluster
The address of this cluster member.
selfAddressOption() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
selfExited() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
selfIndex() - Method in class akka.remote.testkit.MultiNodeSpec$
Index of this node in the roles sequence.
selfIndex() - Static method in class akka.remote.testkit.MultiNodeSpec
Index of this node in the roles sequence.
selfName() - Method in class akka.remote.testkit.MultiNodeSpec$
Name (or IP address; must be resolvable using InetAddress.getByName) of the host this node is running on.
selfName() - Static method in class akka.remote.testkit.MultiNodeSpec
Name (or IP address; must be resolvable using InetAddress.getByName) of the host this node is running on.
selfPort() - Method in class akka.remote.testkit.MultiNodeSpec$
Port number of this node.
selfPort() - Static method in class akka.remote.testkit.MultiNodeSpec
Port number of this node.
selfRoles() - Method in class akka.cluster.Cluster
roles that this member has
selfUniqueAddress() - Method in class akka.cluster.Cluster
INTERNAL API
send(ActorRef, Object) - Method in class akka.actor.dsl.Inbox.Inbox
 
send(ActorRef, Object) - Method in class akka.actor.Inbox
Have the internal actor act as the sender of the given message which will be sent to the given target.
send(T) - Method in class akka.agent.Agent
Dispatch a new value for the internal state.
send(Function1<T, T>) - Method in class akka.agent.Agent
Dispatch a function to update the internal state.
send(Object) - Method in class akka.contrib.pattern.ReliableProxy
 
send(ByteString, Object) - Method in class akka.io.UdpConnectedMessage$
This message is understood by the connection actors to send data to their designated destination.
send(ByteString) - Method in class akka.io.UdpConnectedMessage$
Send without requesting acknowledgment.
send(ByteString, Object) - Static method in class akka.io.UdpConnectedMessage
This message is understood by the connection actors to send data to their designated destination.
send(ByteString) - Static method in class akka.io.UdpConnectedMessage
Send without requesting acknowledgment.
send(ByteString, InetSocketAddress, Udp.Event) - Method in class akka.io.UdpMessage$
This message is understood by the “simple sender” which can be obtained by sending the Udp.SimpleSender query to the UdpExt.manager() as well as by the listener actors which are created in response to Udp.Bind.
send(ByteString, InetSocketAddress) - Method in class akka.io.UdpMessage$
The same as send(payload, target, noAck()).
send(ByteString, InetSocketAddress, Udp.Event) - Static method in class akka.io.UdpMessage
This message is understood by the “simple sender” which can be obtained by sending the Udp.SimpleSender query to the UdpExt.manager() as well as by the listener actors which are created in response to Udp.Bind.
send(ByteString, InetSocketAddress) - Static method in class akka.io.UdpMessage
The same as send(payload, target, noAck()).
send(ActorRef, Object) - Method in class akka.testkit.JavaTestKit
 
send(ActorRef, Object) - Method in class akka.testkit.TestProbe
Send message to an actor while using the probe's TestActor as the sender.
Send - Class in akka.zeromq
Send a message over the zeromq socket
Send(Seq<ByteString>) - Constructor for class akka.zeromq.Send
 
Send$ - Class in akka.zeromq
 
Send$() - Constructor for class akka.zeromq.Send$
 
Send_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.Direction
 
SendBufferSize() - Method in interface akka.io.Inet.SoForwarders
Inet.SocketOption to set the SO_SNDBUF option.
sendBufferSize(int) - Method in interface akka.io.Inet.SoJavaFactories
Inet.SocketOption to set the SO_SNDBUF option.
SendBufferSize() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
SendBufferSize - Class in akka.zeromq
The SendBufferSize option shall set the underlying kernel transmit buffer size for the socket to the specified size in bytes.
SendBufferSize(long) - Constructor for class akka.zeromq.SendBufferSize
 
sendBufferSize() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its send buffer size configuration.
sendBufferSize() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its send buffer size configuration.
SendBufferSize$ - Class in akka.zeromq
Gets the SendBufferSize
SendBufferSize$() - Constructor for class akka.zeromq.SendBufferSize$
 
sendCurrentClusterState(ActorRef) - Method in class akka.cluster.Cluster
Publish current (full) state of the cluster to the specified receiver.
sender() - Method in interface akka.actor.Actor
The reference sender Actor of the last received message.
sender() - Method in interface akka.actor.ActorContext
Returns the sender 'ActorRef' of the current message.
sender() - Method in class akka.actor.DeadLetter
 
sender() - Method in class akka.actor.UnhandledMessage
 
sender() - Method in class akka.contrib.pattern.ReliableProxy.Message
 
sender() - Method in class akka.contrib.throttle.TimerBasedThrottler.Message
 
sender() - Method in class akka.dispatch.Envelope
 
sender() - Method in class akka.io.TcpPipelineHandler.Tell
 
sender() - Method in class akka.io.Udp.Received
 
sender() - Method in class akka.remote.transport.TestTransport.WriteAttempt
 
sender() - Method in class akka.routing.Destination
 
sender() - Method in interface akka.testkit.TestActor.Message
 
sender() - Method in class akka.testkit.TestActor.NullMessage$
 
sender() - Method in class akka.testkit.TestActor.RealMessage
 
sender() - Method in class akka.testkit.TestProbe
Get sender of last received message.
SENDER_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.RemoteEnvelope
 
senderFromInbox(Inbox.Inbox) - Method in interface akka.actor.dsl.Inbox
 
sendGetContacts() - Method in class akka.contrib.pattern.ClusterClient
 
SendHighWatermark - Class in akka.zeromq
The SendHighWatermark option shall set the high water mark for outbound messages on the specified socket.
SendHighWatermark(long) - Constructor for class akka.zeromq.SendHighWatermark
 
sendHighWatermark() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its send high watermark configuration.
sendHighWatermark() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its send high watermark configuration.
SendHighWatermark$ - Class in akka.zeromq
Gets the SendHWM
SendHighWatermark$() - Constructor for class akka.zeromq.SendHighWatermark$
 
sendOff(Function1<T, T>, ExecutionContext) - Method in class akka.agent.Agent
Dispatch a function to update the internal state but on its own thread.
SendTo - Class in akka.transactor
Used for specifying actor refs and messages to send to during coordination.
SendTo(ActorRef, Option<Object>) - Constructor for class akka.transactor.SendTo
 
sendTo(Seq<Tuple2<ActorRef, Object>>) - Method in interface akka.transactor.Transactor
Include other actors in this coordinated transaction and specify the message to send by providing ActorRef -> Message pairs.
sendTo(ActorRef) - Method in class akka.transactor.UntypedTransactor
For including another actor in this coordinated transaction and sending them the same message as received.
sendTo(ActorRef, Object) - Method in class akka.transactor.UntypedTransactor
For including another actor in this coordinated transaction and specifying the message to send.
SendTo$ - Class in akka.transactor
 
SendTo$() - Constructor for class akka.transactor.SendTo$
 
seq(T...) - Static method in class akka.japi.JAPI
 
seq() - Method in interface akka.remote.HasSequenceNumber
Sequence number of the message
SEQ_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.RemoteEnvelope
 
seqCauseDirective2Decider(Iterable<Tuple2<Class<? extends Throwable>, SupervisorStrategy.Directive>>) - Method in interface akka.actor.SupervisorStrategyLowPriorityImplicits
Implicit conversion from Seq of Cause-Directive pairs to a Decider.
SeqNo - Class in akka.remote
Implements a 64 bit sequence number with proper wrap-around ordering.
SeqNo(long) - Constructor for class akka.remote.SeqNo
 
SeqNo$ - Class in akka.remote
 
SeqNo$() - Constructor for class akka.remote.SeqNo$
 
seqOrdering() - Method in class akka.remote.AckedReceiveBuffer
 
seqOrdering() - Method in class akka.remote.HasSequenceNumber$
 
seqOrdering() - Method in interface akka.remote.HasSequenceNumber
 
seqThrowable2Decider(Seq<Class<? extends Throwable>>) - Method in class akka.actor.SupervisorStrategy$
Implicit conversion from Seq of Throwables to a Decider.
seqThrowable2Decider(Seq<Class<? extends Throwable>>) - Static method in class akka.actor.SupervisorStrategy
Implicit conversion from Seq of Throwables to a Decider.
sequence(Iterable<Future<A>>, ExecutionContext) - Method in class akka.dispatch.Futures$
Simple version of Futures$.traverse(java.lang.Iterable, akka.japi.Function>, scala.concurrent.ExecutionContext).
sequence(Iterable<Future<A>>, ExecutionContext) - Static method in class akka.dispatch.Futures
Simple version of Futures.traverse(java.lang.Iterable, akka.japi.Function>, scala.concurrent.ExecutionContext).
sequence(PipelineStage<? super Ctx, CmdAbove, CmdBelow, EvtAbove, EvtBelow>, PipelineStage<? super Ctx, CmdBelow, CmdBelowBelow, EvtBelow, EvtBelowBelow>) - Method in class akka.io.PipelineStage$
Java API: attach the two given stages such that the command output of the first is fed into the command input of the second, and the event output of the second is fed into the event input of the first.
sequence(PipelineStage<? super Ctx, CmdAbove, CmdBelow, EvtAbove, EvtBelow>, PipelineStage<? super Ctx, CmdBelow, CmdBelowBelow, EvtBelow, EvtBelowBelow>) - Static method in class akka.io.PipelineStage
Java API: attach the two given stages such that the command output of the first is fed into the command input of the second, and the event output of the second is fed into the event input of the first.
serial() - Method in class akka.contrib.pattern.ReliableProxy.Ack
 
serial() - Method in class akka.contrib.pattern.ReliableProxy.Message
 
Serialization - Class in akka.serialization
Serialization module.
Serialization(ExtendedActorSystem) - Constructor for class akka.serialization.Serialization
 
Serialization$ - Class in akka.serialization
 
Serialization$() - Constructor for class akka.serialization.Serialization$
 
Serialization.Settings - Class in akka.serialization
 
Serialization.Settings(com.typesafe.config.Config) - Constructor for class akka.serialization.Serialization.Settings
 
SerializationBindings() - Method in class akka.serialization.Serialization.Settings
 
SerializationExtension - Class in akka.serialization
SerializationExtension is an Akka Extension to interact with the Serialization that is built into Akka
SerializationExtension() - Constructor for class akka.serialization.SerializationExtension
 
SerializationExtension$ - Class in akka.serialization
SerializationExtension is an Akka Extension to interact with the Serialization that is built into Akka
SerializationExtension$() - Constructor for class akka.serialization.SerializationExtension$
 
serialize(Envelope) - Method in interface akka.actor.mailbox.DurableMessageSerialization
Serializes the given Envelope into an Array of Bytes using an efficient serialization/deserialization strategy
serialize(Object) - Method in class akka.serialization.Serialization
Serializes the given AnyRef/java.lang.Object according to the Serialization configuration to either an Array of Bytes or an Exception if one was thrown.
serializeActorRef(ActorRef) - Method in class akka.remote.serialization.ProtobufSerializer$
Helper to serialize an ActorRef to Akka's protobuf representation.
serializeActorRef(ActorRef) - Static method in class akka.remote.serialization.ProtobufSerializer
Helper to serialize an ActorRef to Akka's protobuf representation.
SerializeAllCreators() - Method in class akka.actor.ActorSystem.Settings
 
SerializeAllMessages() - Method in class akka.actor.ActorSystem.Settings
 
serialized() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number
 
Serialized() - Method in class akka.cluster.protobuf.msg.NodeMetrics.NumberType$
 
SERIALIZED_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number$
 
Serialized_VALUE() - Method in class akka.cluster.protobuf.msg.NodeMetrics.NumberType$
 
serializedActorPath(ActorRef) - Method in class akka.serialization.Serialization$
The serialized path of an actorRef, based on the current transport serialization information.
serializedActorPath(ActorRef) - Static method in class akka.serialization.Serialization
The serialized path of an actorRef, based on the current transport serialization information.
Serializer - Interface in akka.serialization
A Serializer represents a bimap between an object and an array of bytes representing that object.
serializerByIdentity() - Method in class akka.serialization.Serialization
Maps from a Serializer Identity (Int) to a Serializer instance (optimization)
serializerFor(Class<?>) - Method in class akka.serialization.Serialization
Returns the configured Serializer for the given Class.
SERIALIZERID_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.SelectionEnvelope
 
SERIALIZERID_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.SerializedMessage
 
serializerOf(String) - Method in class akka.serialization.Serialization
Tries to load the specified Serializer by the fully-qualified name; the actual loading is performed by the system’s DynamicAccess.
Serializers() - Method in class akka.serialization.Serialization.Settings
 
server() - Method in class akka.actor.IO.Accept
 
server() - Method in class akka.actor.IO.Listen
 
server() - Method in class akka.actor.IO.Listening
 
server() - Method in class akka.actor.IO.NewClient
 
serverName() - Method in class akka.remote.testkit.MultiNodeSpec$
Name (or IP address; must be resolvable using InetAddress.getByName) of the host that the server node is running on.
serverName() - Static method in class akka.remote.testkit.MultiNodeSpec
Name (or IP address; must be resolvable using InetAddress.getByName) of the host that the server node is running on.
serverPort() - Method in class akka.remote.testkit.MultiNodeSpec$
Port number of the node that's running the server system.
serverPort() - Static method in class akka.remote.testkit.MultiNodeSpec
Port number of the node that's running the server system.
ServerSocketWorkerPoolSize() - Method in class akka.remote.testconductor.TestConductorExt.Settings
 
ServerSocketWorkerPoolSize() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
serviceForReference(org.osgi.framework.BundleContext, org.osgi.framework.ServiceReference) - Method in class akka.osgi.ActorSystemActivator
Convenience method to find a service by its reference.
set(long) - Method in class akka.actor.mailbox.filebased.filequeue.Counter
 
set(Option<T>) - Method in class akka.actor.mailbox.filebased.filequeue.OverlaySetting
 
setAck(WireFormats.AcknowledgementInfo) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
setAck(WireFormats.AcknowledgementInfo.Builder) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
setAddr(TestConductorProtocol.Address) - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
setAddr(TestConductorProtocol.Address.Builder) - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
setAddr(TestConductorProtocol.AddressRequest) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
setAddr(TestConductorProtocol.AddressRequest.Builder) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
setAddress(TestConductorProtocol.Address) - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
setAddress(TestConductorProtocol.Address.Builder) - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
setAddress(TestConductorProtocol.Address) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
setAddress(TestConductorProtocol.Address.Builder) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
setAllAddresses(int, UniqueAddress) - Method in class akka.cluster.protobuf.msg.Gossip
 
setAllAddresses(int, Address) - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
setAllHashes(int, String) - Method in class akka.cluster.protobuf.msg.Gossip
 
setAllHashes(int, String) - Method in class akka.cluster.protobuf.msg.GossipStatus
 
setAllMetricNames(int, String) - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
setAllowCoreThreadTimeout(boolean) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
setAllRoles(int, String) - Method in class akka.cluster.protobuf.msg.Gossip
 
setArgs(int, com.google.protobuf.ByteString) - Method in class akka.remote.WireFormats.PropsData.Builder
 
setAutoPilot(TestActor.AutoPilot) - Method in class akka.testkit.JavaTestKit
Install an AutoPilot to drive the testActor: the AutoPilot will be run for each received message and can be used to send or forward messages, etc.
setAutoPilot(TestActor.AutoPilot) - Method in interface akka.testkit.TestKitBase
Install an AutoPilot to drive the testActor: the AutoPilot will be run for each received message and can be used to send or forward messages, etc.
setBarrier(TestConductorProtocol.EnterBarrier) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
setBarrier(TestConductorProtocol.EnterBarrier.Builder) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
setClasses(int, String) - Method in class akka.remote.WireFormats.PropsData.Builder
 
setClazz(String) - Method in class akka.remote.WireFormats.PropsData.Builder
 
setCommandType(WireFormats.CommandType) - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
setConfig(String) - Method in class akka.osgi.aries.blueprint.BlueprintActorSystemFactory
 
setConfig(com.google.protobuf.ByteString) - Method in class akka.remote.WireFormats.DeployData.Builder
 
setCookie(String) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
setCorePoolSize(int) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
setCorePoolSizeFromFactor(int, double, int) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
setCumulativeAck(long) - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
setDeploy(WireFormats.DeployData) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
setDeploy(WireFormats.DeployData.Builder) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
setDeploy(WireFormats.DeployData) - Method in class akka.remote.WireFormats.PropsData.Builder
 
setDeploy(WireFormats.DeployData.Builder) - Method in class akka.remote.WireFormats.PropsData.Builder
 
setDirection(TestConductorProtocol.Direction) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
setDispatcher(String) - Method in class akka.remote.WireFormats.DeployData.Builder
 
setDone(String) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
setEnclosedMessage(com.google.protobuf.ByteString) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
setEnvelope(WireFormats.RemoteEnvelope) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
setEnvelope(WireFormats.RemoteEnvelope.Builder) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
setEwma(NodeMetrics.EWMA) - Method in class akka.cluster.protobuf.msg.NodeMetrics.Metric
 
setExitValue(int) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
setFailure(TestConductorProtocol.FailType) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
setFailure(TestConductorProtocol.InjectFailure) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
setFailure(TestConductorProtocol.InjectFailure.Builder) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
setHandshakeInfo(WireFormats.AkkaHandshakeInfo) - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
setHandshakeInfo(WireFormats.AkkaHandshakeInfo.Builder) - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
setHello(TestConductorProtocol.Hello) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
setHello(TestConductorProtocol.Hello.Builder) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
 
setHost(String) - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
setHostname(String) - Method in class akka.remote.WireFormats.AddressData.Builder
 
setInstruction(WireFormats.AkkaControlMessage) - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
setInstruction(WireFormats.AkkaControlMessage.Builder) - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
setKeepAliveTime(Duration) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
setKeepAliveTimeInMillis(long) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
setLogLevel(Logging.LogLevel) - Method in interface akka.event.LoggingBus
Change log level: default loggers (i.e.
setMatcher(String) - Method in class akka.remote.ContainerFormats.Selection.Builder
 
setMaxPoolSize(int) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
setMaxPoolSizeFromFactor(int, double, int) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
setMembers(int, Member) - Method in class akka.cluster.protobuf.msg.Gossip
 
setMessage(WireFormats.SerializedMessage) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
setMessage(WireFormats.SerializedMessage.Builder) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
setMessage(com.google.protobuf.ByteString) - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
setMessageManifest(com.google.protobuf.ByteString) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
setMessageManifest(com.google.protobuf.ByteString) - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
setMetrics(int, NodeMetrics.Metric) - Method in class akka.cluster.protobuf.msg.NodeMetrics
 
setNacks(int, long) - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
setName(String) - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
setName(String) - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
 
setNext(AbstractNodeQueue.Node<T>) - Method in class akka.dispatch.AbstractNodeQueue.Node
 
setNode(String) - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
 
setNodeMetrics(int, NodeMetrics) - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
setOp(TestConductorProtocol.BarrierOp) - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
setOrigin(WireFormats.AddressData) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
setOrigin(WireFormats.AddressData.Builder) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
setPath(String) - Method in class akka.remote.WireFormats.ActorRefData.Builder
 
setPath(String) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
setPath(String) - Method in class akka.remote.WireFormats.DeployData.Builder
 
setPattern(int, ContainerFormats.Selection) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
setPattern(int, ContainerFormats.Selection.Builder) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
setPayload(com.google.protobuf.ByteString) - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
setPort(int) - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
setPort(int) - Method in class akka.remote.WireFormats.AddressData.Builder
 
setProps(WireFormats.PropsData) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
setProps(WireFormats.PropsData.Builder) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
setProtocol(String) - Method in class akka.cluster.protobuf.msg.Address
 
setProtocol(String) - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
setProtocol(String) - Method in class akka.remote.WireFormats.AddressData.Builder
 
setQueueFactory(Function0<BlockingQueue<Runnable>>) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
setRateMBit(float) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
 
setRawResult(BoxedUnit) - Method in class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinTask
 
setReceiveTimeout(Duration) - Method in interface akka.actor.ActorContext
Defines the inactivity timeout after which the sending of a ReceiveTimeout message is triggered.
setRecipient(WireFormats.ActorRefData) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
setRecipient(WireFormats.ActorRefData.Builder) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
setRoles(int, String) - Method in class akka.cluster.protobuf.msg.Join
 
setRolesIndexes(int, int) - Method in class akka.cluster.protobuf.msg.Member
 
setRouterConfig(com.google.protobuf.ByteString) - Method in class akka.remote.WireFormats.DeployData.Builder
 
setScope(com.google.protobuf.ByteString) - Method in class akka.remote.WireFormats.DeployData.Builder
 
setSeen(int, GossipOverview.Seen) - Method in class akka.cluster.protobuf.msg.GossipOverview
 
setSender(WireFormats.ActorRefData) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
setSender(WireFormats.ActorRefData.Builder) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
setSeq(long) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
setSerialized(com.google.protobuf.ByteString) - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number
 
setSerializerId(int) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
setSerializerId(int) - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
setState(S, D, FiniteDuration, Option<FSM.Reason>) - Method in class akka.testkit.TestFSMRef
Change FSM state; any value left out defaults to the current FSM state (timeout defaults to None).
setStateTimeout(S, Option<FiniteDuration>) - Method in interface akka.actor.FSM
Set state timeout explicitly.
setSupervisor(WireFormats.ActorRefData) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
setSupervisor(WireFormats.ActorRefData.Builder) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
setSystem(String) - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
 
setSystem(String) - Method in class akka.remote.WireFormats.AddressData.Builder
 
setTimeout(long) - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
 
setTimer(String, Object, FiniteDuration, boolean) - Method in interface akka.actor.FSM
Schedule named timer to deliver message after given delay, possibly repeating.
setTimer(String, Object, FiniteDuration, boolean) - Method in class akka.testkit.TestFSMRef
Proxy for FSM.setTimer.
setTimestamp(long) - Method in class akka.cluster.protobuf.msg.VectorClock
 
settings() - Method in interface akka.actor.ActorRefProvider
The Settings associated with this ActorRefProvider
settings() - Method in class akka.actor.ActorSystem
The core settings extracted from the supplied configuration.
settings() - Method in class akka.actor.IOManager
 
settings() - Method in class akka.actor.IOManagerActor
 
settings() - Method in class akka.actor.mailbox.filebased.FileBasedMessageQueue
 
settings() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
settings() - Method in interface akka.camel.Camel
The settings for the CamelExtension
settings() - Method in class akka.cluster.Cluster
 
settings() - Method in class akka.cluster.routing.ClusterRouterConfig
 
settings() - Method in interface akka.dispatch.DispatcherPrerequisites
 
settings() - Method in class akka.dispatch.Dispatchers
 
Settings() - Method in class akka.io.TcpExt
 
settings() - Method in class akka.io.UdpConnectedExt
 
settings() - Method in class akka.io.UdpExt
 
Settings() - Method in class akka.remote.testconductor.TestConductorExt
 
settings() - Method in class akka.remote.transport.netty.NettyTransport
 
settings() - Method in class akka.remote.transport.TransportAdapters
 
settings() - Method in class akka.serialization.Serialization
 
settings() - Method in interface akka.transactor.Transactor
 
setType(ContainerFormats.PatternType) - Method in class akka.remote.ContainerFormats.Selection.Builder
 
setUid(long) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
setUnreachable(int, Member) - Method in class akka.cluster.protobuf.msg.GossipOverview
 
setup() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
setUpStdoutLogger(ActorSystem.Settings) - Method in interface akka.event.LoggingBus
 
setValue32(int) - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number
 
setValue64(long) - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number
 
setVersions(int, VectorClock.Version) - Method in class akka.cluster.protobuf.msg.VectorClock
 
sha1(String) - Method in class akka.util.Crypt$
 
sha1(byte[]) - Method in class akka.util.Crypt$
 
sha1(String) - Static method in class akka.util.Crypt
 
sha1(byte[]) - Static method in class akka.util.Crypt
 
shutdown() - Method in class akka.actor.ActorSystem
Stop this actor system.
shutdown() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
Shutdown this queue collection.
shutdown() - Method in class akka.dispatch.Dispatcher
INTERNAL API
shutdown() - Method in interface akka.dispatch.ExecutorServiceDelegate
 
shutdown() - Method in class akka.dispatch.MessageDispatcher
Called one time every time an actor is detached from this dispatcher and this dispatcher has no actors left attached Must be idempotent
shutdown() - Method in interface akka.kernel.Bootable
Callback run on microkernel shutdown.
shutdown(RoleName) - Method in interface akka.remote.testconductor.Conductor
Tell the actor system at the remote node to shut itself down.
shutdown() - Method in class akka.remote.transport.AbstractTransportAdapter
 
shutdown() - Method in class akka.remote.transport.ActorTransportAdapter
 
shutdown() - Method in class akka.remote.transport.netty.NettyTransport
 
shutdown() - Method in class akka.remote.transport.TestTransport
 
shutdown() - Method in interface akka.remote.transport.Transport
Shuts down the transport layer and releases all the corresponding resources.
shutdown() - Method in class akka.testkit.CallingThreadDispatcher
 
shutdown(ActorSystem, Duration, Boolean) - Method in class akka.testkit.JavaTestKit
Shut down an actor system and wait for termination.
shutdown(ActorSystem) - Method in class akka.testkit.JavaTestKit
 
shutdown(ActorSystem, Duration) - Method in class akka.testkit.JavaTestKit
 
shutdown(ActorSystem, Boolean) - Method in class akka.testkit.JavaTestKit
 
shutdown(ActorSystem, Duration, boolean) - Method in interface akka.testkit.TestKitBase
Shut down an actor system and wait for termination.
Shutdown_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.FailType
 
shutdownActorSystem(ActorSystem, Duration, Boolean) - Static method in class akka.testkit.JavaTestKit
Shut down an actor system and wait for termination.
shutdownActorSystem(ActorSystem) - Static method in class akka.testkit.JavaTestKit
 
shutdownActorSystem(ActorSystem, Duration) - Method in class akka.testkit.JavaTestKit
 
shutdownActorSystem(ActorSystem, Boolean) - Method in class akka.testkit.JavaTestKit
 
shutdownActorSystem(ActorSystem, Duration, boolean) - Method in class akka.testkit.TestKit$
Shut down an actor system and wait for termination.
shutdownActorSystem(ActorSystem, Duration, boolean) - Static method in class akka.testkit.TestKit
Shut down an actor system and wait for termination.
shutdownBehavior() - Method in class akka.remote.transport.TestTransport
The TestTransport.SwitchableLoggedBehavior for the shutdown() method.
shutdownNow() - Method in interface akka.dispatch.ExecutorServiceDelegate
 
ShutdownTimeout() - Method in class akka.actor.LightArrayRevolverScheduler
 
shutdownTimeout() - Method in class akka.dispatch.Dispatcher
 
shutdownTimeout() - Method in class akka.dispatch.MessageDispatcher
When the dispatcher no longer has any actors registered, how long will it wait until it shuts itself down, defaulting to your akka configs "akka.actor.default-dispatcher.shutdown-timeout" or default specified in reference.conf
ShutdownTimeout() - Method in class akka.remote.RemoteSettings
 
shutdownTimeout() - Method in class akka.remote.testkit.MultiNodeSpec
 
shutdownTimeout() - Method in class akka.testkit.CallingThreadDispatcher
 
SigarMetricsCollector - Class in akka.cluster
Loads metrics through Hyperic SIGAR and JMX monitoring beans.
SigarMetricsCollector(Address, double, Object) - Constructor for class akka.cluster.SigarMetricsCollector
 
SigarMetricsCollector(ActorSystem) - Constructor for class akka.cluster.SigarMetricsCollector
This constructor is used when creating an instance from configured FQCN
simpleName(Object) - Method in class akka.event.Logging$
Returns a 'safe' getSimpleName for the provided object's Class
simpleName(Class<?>) - Method in class akka.event.Logging$
Returns a 'safe' getSimpleName for the provided Class
simpleName(Object) - Static method in class akka.event.Logging
Returns a 'safe' getSimpleName for the provided object's Class
simpleName(Class<?>) - Static method in class akka.event.Logging
Returns a 'safe' getSimpleName for the provided Class
simpleSender(Iterable<Inet.SocketOption>) - Method in class akka.io.UdpMessage$
Retrieve a reference to a “simple sender” actor of the UDP extension.
simpleSender() - Method in class akka.io.UdpMessage$
Retrieve a simple sender without specifying options.
simpleSender(Iterable<Inet.SocketOption>) - Static method in class akka.io.UdpMessage
Retrieve a reference to a “simple sender” actor of the UDP extension.
simpleSender() - Static method in class akka.io.UdpMessage
Retrieve a simple sender without specifying options.
singleCommand(CmdBelow) - Method in class akka.io.AbstractPipePair
Wrap a single command for efficient return to the pipeline’s machinery.
singleCommand(Cmd) - Method in interface akka.io.PipelineContext
Scala API: Wrap a single command for efficient return to the pipeline’s machinery.
SingleConsumerOnlyUnboundedMailbox - Class in akka.dispatch
SingleConsumerOnlyUnboundedMailbox is a high-performance, multiple producer—single consumer, unbounded MailboxType, the only drawback is that you can't have multiple consumers, which rules out using it with BalancingDispatcher for instance.
SingleConsumerOnlyUnboundedMailbox() - Constructor for class akka.dispatch.SingleConsumerOnlyUnboundedMailbox
 
SingleConsumerOnlyUnboundedMailbox(ActorSystem.Settings, com.typesafe.config.Config) - Constructor for class akka.dispatch.SingleConsumerOnlyUnboundedMailbox
 
SingleConsumerOnlyUnboundedMailbox$ - Class in akka.dispatch
 
SingleConsumerOnlyUnboundedMailbox$() - Constructor for class akka.dispatch.SingleConsumerOnlyUnboundedMailbox$
 
singleEvent(EvtAbove) - Method in class akka.io.AbstractPipePair
Wrap a single event for efficient return to the pipeline’s machinery.
singleEvent(Evt) - Method in interface akka.io.PipelineContext
Scala API: Wrap a single event for efficient return to the pipeline’s machinery.
SingleExpectDefaultTimeout() - Method in class akka.testkit.TestKitSettings
 
size() - Method in class akka.actor.IO.ReceiveBufferSize
 
size() - Method in class akka.actor.IO.SendBufferSize
 
size() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
size() - Method in class akka.io.Inet.SO$.ReceiveBufferSize
 
size() - Method in class akka.io.Inet.SO$.SendBufferSize
 
size() - Method in class akka.util.BoundedBlockingQueue
 
sizeHint(int) - Method in class akka.util.ByteStringBuilder
 
Slf4jEventHandler - Class in akka.event.slf4j
 
Slf4jEventHandler() - Constructor for class akka.event.slf4j.Slf4jEventHandler
 
Slf4jLogger - Class in akka.event.slf4j
SLF4J logger.
Slf4jLogger() - Constructor for class akka.event.slf4j.Slf4jLogger
 
SLF4JLogging - Interface in akka.event.slf4j
Base trait for all classes that wants to be able use the SLF4J logging infrastructure.
slice(int, int) - Method in class akka.util.ByteIterator
 
slice(int, int) - Method in class akka.util.ByteString.ByteString1C
 
slice(int, int) - Method in class akka.util.ByteString
 
SmallestMailboxLike - Interface in akka.routing
The core pieces of the routing logic is located in this trait to be able to extend.
SmallestMailboxRouter - Class in akka.routing
A Router that tries to send to the non-suspended routee with fewest messages in mailbox.
SmallestMailboxRouter(int, Iterable<String>, Option<Resizer>, String, SupervisorStrategy) - Constructor for class akka.routing.SmallestMailboxRouter
 
SmallestMailboxRouter(int) - Constructor for class akka.routing.SmallestMailboxRouter
Java API: Constructor that sets nrOfInstances to be created.
SmallestMailboxRouter(Iterable<String>) - Constructor for class akka.routing.SmallestMailboxRouter
Java API: Constructor that sets the routees to be used.
SmallestMailboxRouter(Resizer) - Constructor for class akka.routing.SmallestMailboxRouter
Java API: Constructor that sets the resizer to be used.
SmallestMailboxRouter$ - Class in akka.routing
 
SmallestMailboxRouter$() - Constructor for class akka.routing.SmallestMailboxRouter$
 
smoothValue() - Method in class akka.cluster.Metric
The numerical value of the average, if defined, otherwise the latest value
sockAddr() - Method in interface akka.remote.testconductor.Conductor
Obtain the port to which the controller’s socket is actually bound.
socket() - Method in class akka.actor.IO.Accept
 
socket() - Method in class akka.actor.IO.Connect
 
socket() - Method in class akka.actor.IO.Connected
 
socket(SocketType.ZMQSocketType) - Method in class akka.zeromq.Context
 
SocketConnectOption - Interface in akka.zeromq
A base trait for connection options for a ZeroMQ socket
SocketMeta - Interface in akka.zeromq
Marker trait representing the base for all meta operations for a socket such as the context, listener, socket type and poller dispatcher
SocketOption - Interface in akka.zeromq
Marker trait representing the base for all socket options
SocketOptionQuery - Interface in akka.zeromq
A marker trait to group option queries together
SocketType - Class in akka.zeromq
The different socket types you can create with zeromq
SocketType() - Constructor for class akka.zeromq.SocketType
 
SocketType$ - Class in akka.zeromq
The different socket types you can create with zeromq
SocketType$() - Constructor for class akka.zeromq.SocketType$
 
SocketType.Dealer$ - Class in akka.zeromq
A dealer socket
SocketType.Dealer$() - Constructor for class akka.zeromq.SocketType.Dealer$
 
SocketType.Pair$ - Class in akka.zeromq
A Pair socket
SocketType.Pair$() - Constructor for class akka.zeromq.SocketType.Pair$
 
SocketType.Pub$ - Class in akka.zeromq
A Publisher socket
SocketType.Pub$() - Constructor for class akka.zeromq.SocketType.Pub$
 
SocketType.Pull$ - Class in akka.zeromq
A pull socket
SocketType.Pull$() - Constructor for class akka.zeromq.SocketType.Pull$
 
SocketType.Push$ - Class in akka.zeromq
A push socket
SocketType.Push$() - Constructor for class akka.zeromq.SocketType.Push$
 
SocketType.Rep$ - Class in akka.zeromq
A reply socket
SocketType.Rep$() - Constructor for class akka.zeromq.SocketType.Rep$
 
SocketType.Req$ - Class in akka.zeromq
A request socket
SocketType.Req$() - Constructor for class akka.zeromq.SocketType.Req$
 
SocketType.Router$ - Class in akka.zeromq
A router socket
SocketType.Router$() - Constructor for class akka.zeromq.SocketType.Router$
 
SocketType.Sub$ - Class in akka.zeromq
A subscriber socket
SocketType.Sub$() - Constructor for class akka.zeromq.SocketType.Sub$
 
SocketType.ZMQSocketType - Class in akka.zeromq
 
SocketType.ZMQSocketType(int) - Constructor for class akka.zeromq.SocketType.ZMQSocketType
 
some(A) - Method in class akka.japi.Option$
Option factory that creates Some
some(A) - Static method in class akka.japi.Option
Option factory that creates Some
source() - Method in class akka.testkit.DebugFilter
 
source() - Method in class akka.testkit.ErrorFilter
 
source() - Method in class akka.testkit.EventFilter
 
source() - Method in class akka.testkit.InfoFilter
 
source() - Method in class akka.testkit.WarningFilter
 
span(Function1<Object, Object>) - Method in class akka.util.ByteIterator
 
span(Function1<Object, Object>) - Method in class akka.util.ByteString
 
spawn(String, Function0<BoxedUnit>) - Method in class akka.testkit.AkkaSpec
 
splitAt(int) - Method in class akka.util.ByteString
 
SslSettings() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
SslTlsSupport - Class in akka.io
This pipeline stage implements SSL / TLS support, using an externally configured SSLEngine.
SslTlsSupport(SSLEngine) - Constructor for class akka.io.SslTlsSupport
 
SslTlsSupport$ - Class in akka.io
 
SslTlsSupport$() - Constructor for class akka.io.SslTlsSupport$
 
stackTraceFor(Throwable) - Method in class akka.event.Logging$
Returns the StackTrace for the given Throwable as a String
stackTraceFor(Throwable) - Static method in class akka.event.Logging
Returns the StackTrace for the given Throwable as a String
stages() - Method in class akka.io.TcpPipelineHandler.Init
 
StandardMetrics - Class in akka.cluster
Definitions of the built-in standard metrics.
StandardMetrics() - Constructor for class akka.cluster.StandardMetrics
 
StandardMetrics$ - Class in akka.cluster
Definitions of the built-in standard metrics.
StandardMetrics$() - Constructor for class akka.cluster.StandardMetrics$
 
StandardMetrics.Cpu - Class in akka.cluster
 
StandardMetrics.Cpu(Address, long, Option<Object>, Option<Object>, int) - Constructor for class akka.cluster.StandardMetrics.Cpu
 
StandardMetrics.Cpu$ - Class in akka.cluster
 
StandardMetrics.Cpu$() - Constructor for class akka.cluster.StandardMetrics.Cpu$
 
StandardMetrics.HeapMemory - Class in akka.cluster
The amount of used and committed memory will always be <= max if max is defined.
StandardMetrics.HeapMemory(Address, long, long, long, Option<Object>) - Constructor for class akka.cluster.StandardMetrics.HeapMemory
 
StandardMetrics.HeapMemory$ - Class in akka.cluster
 
StandardMetrics.HeapMemory$() - Constructor for class akka.cluster.StandardMetrics.HeapMemory$
 
StandardOutLogger() - Method in class akka.event.Logging$
 
StandardOutLogger() - Static method in class akka.event.Logging
 
start(org.osgi.framework.BundleContext) - Method in class akka.osgi.ActorSystemActivator
Sets up a new ActorSystem
start() - Method in class akka.util.internal.HashedWheelTimer
Deprecated. Starts the background thread explicitly.
startAndStopDuration() - Method in interface akka.testkit.WatchedByCoroner
 
startClient(RoleName, InetSocketAddress) - Method in interface akka.remote.testconductor.Player
Connect to the conductor on the given port (the host is taken from setting akka.testconductor.host).
startController(int, RoleName, InetSocketAddress) - Method in interface akka.remote.testconductor.Conductor
Start the Controller, which in turn will bind to a TCP port as specified in the akka.testconductor.port config property, where 0 denotes automatic allocation.
startCoroner() - Method in interface akka.testkit.WatchedByCoroner
 
startDefaultLoggers(akka.actor.ActorSystemImpl) - Method in interface akka.event.LoggingBus
Internal Akka use only
startHash(int) - Method in class akka.routing.MurmurHash$
Begin a new hash with a seed value.
startHash(int) - Static method in class akka.routing.MurmurHash
Begin a new hash with a seed value.
startMagicA() - Method in class akka.routing.MurmurHash$
The initial magic integers in the first stream.
startMagicA() - Static method in class akka.routing.MurmurHash
The initial magic integers in the first stream.
startMagicB() - Method in class akka.routing.MurmurHash$
The initial magic integer in the second stream.
startMagicB() - Static method in class akka.routing.MurmurHash
The initial magic integer in the second stream.
startReadBehind() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
startStdoutLogger(ActorSystem.Settings) - Method in interface akka.event.LoggingBus
Internal Akka use only
startsWith(String) - Method in class akka.testkit.JavaTestKit.EventFilter
 
startTime() - Method in class akka.actor.ActorSystem
Start-up time in milliseconds since the epoch.
startup() - Method in interface akka.kernel.Bootable
Callback run on microkernel startup.
StartupTimeout() - Method in class akka.remote.RemoteSettings
 
startWith(S, D, Option<FiniteDuration>) - Method in interface akka.actor.FSM
Set initial state.
Stash - Interface in akka.actor
The Stash trait enables an actor to temporarily stash away messages that can not or should not be handled using the actor's current behavior.
stash() - Method in interface akka.actor.UnrestrictedStash
Adds the current message (the message that the actor received last) to the actor's stash.
StashOverflowException - Exception in akka.actor
Is thrown when the size of the Stash exceeds the capacity of the Stash
StashOverflowException(String, Throwable) - Constructor for exception akka.actor.StashOverflowException
 
StashOverflowException$ - Class in akka.actor
 
StashOverflowException$() - Constructor for class akka.actor.StashOverflowException$
 
state() - Method in class akka.actor.FSM.CurrentState
 
stateData() - Method in class akka.actor.FSM.Event
 
stateData() - Method in class akka.actor.FSM.LogEntry
 
stateData() - Method in class akka.actor.FSM.State
 
stateData() - Method in interface akka.actor.FSM
Return current state data (i.e.
stateData() - Method in class akka.actor.FSM.StopEvent
 
stateData() - Method in class akka.testkit.TestFSMRef
Get current state data of this FSM.
stateFunctions() - Method in interface akka.actor.FSM
 
stateName() - Method in class akka.actor.FSM.LogEntry
 
stateName() - Method in class akka.actor.FSM.State
 
stateName() - Method in interface akka.actor.FSM
Return current state name (i.e.
stateName() - Method in class akka.testkit.TestFSMRef
Get current state name of this FSM.
states() - Method in interface akka.actor.LoggingFSM
 
StateTimeout() - Method in interface akka.actor.FSM
This case object is received in case of a state timeout.
stateTimeouts() - Method in interface akka.actor.FSM
 
stats(String) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
Status - Class in akka.actor
Classes for passing status back to the sender.
Status() - Constructor for class akka.actor.Status
 
status() - Method in class akka.actor.Status.Success
 
status() - Method in class akka.cluster.Member
 
status() - Method in class akka.cluster.protobuf.msg.Member
 
Status$ - Class in akka.actor
Classes for passing status back to the sender.
Status$() - Constructor for class akka.actor.Status$
 
Status.Failure - Class in akka.actor
This class/message type is preferably used to indicate failure of some operation performed.
Status.Failure(Throwable) - Constructor for class akka.actor.Status.Failure
 
Status.Failure$ - Class in akka.actor
 
Status.Failure$() - Constructor for class akka.actor.Status.Failure$
 
Status.Status - Interface in akka.actor
 
Status.Success - Class in akka.actor
This class/message type is preferably used to indicate success of some operation performed.
Status.Success(Object) - Constructor for class akka.actor.Status.Success
 
Status.Success$ - Class in akka.actor
 
Status.Success$() - Constructor for class akka.actor.Status.Success$
 
STATUS_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.Member$
 
STATUS_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.Member
 
statusPromise() - Method in class akka.remote.transport.ActorTransportAdapter.AssociateUnderlying
 
stay() - Method in interface akka.actor.FSM
Produce "empty" transition descriptor.
StdoutLogLevel() - Method in class akka.actor.ActorSystem.Settings
 
stop(ActorRef) - Method in interface akka.actor.ActorRefFactory
Stop the actor pointed to by the given ActorRef; this is an asynchronous operation, i.e.
Stop() - Method in interface akka.actor.dsl.Creators.Act
 
stop() - Method in interface akka.actor.FSM
Produce change descriptor to stop this FSM actor with reason "Normal".
stop(FSM.Reason) - Method in interface akka.actor.FSM
Produce change descriptor to stop this FSM actor including specified reason.
stop(FSM.Reason, D) - Method in interface akka.actor.FSM
Produce change descriptor to stop this FSM actor including specified reason.
stop() - Method in class akka.actor.SupervisorStrategy$
Java API: Returning this directive stops the Actor
stop() - Static method in class akka.actor.SupervisorStrategy
Java API: Returning this directive stops the Actor
stop(Object) - Method in interface akka.actor.TypedActorFactory
Stops the underlying ActorRef for the supplied TypedActor proxy, if any, returns whether it could find the find the ActorRef or not
stop(org.osgi.framework.BundleContext) - Method in class akka.osgi.ActorSystemActivator
Shuts down the ActorSystem when the bundle is stopped and, if necessary, unregisters a service registration.
stop() - Method in class akka.util.internal.HashedWheelTimer
Deprecated.  
stop() - Method in interface akka.util.internal.Timer
Deprecated. Releases all resources acquired by this Timer and cancels all tasks which were scheduled but not executed yet.
stopCoroner() - Method in interface akka.testkit.WatchedByCoroner
 
stopDefaultLoggers(ActorSystem) - Method in interface akka.event.LoggingBus
Internal Akka use only
stopDelay() - Method in class akka.routing.DefaultResizer
When the resizer reduce the capacity the abandoned routee actors are stopped with PoisonPill after this delay.
stoppingStrategy() - Method in class akka.actor.SupervisorStrategy$
This strategy resembles Erlang in that failing children are always terminated (one-for-one).
stoppingStrategy() - Static method in class akka.actor.SupervisorStrategy
This strategy resembles Erlang in that failing children are always terminated (one-for-one).
StoppingSupervisorStrategy - Class in akka.actor
 
StoppingSupervisorStrategy() - Constructor for class akka.actor.StoppingSupervisorStrategy
 
stopReason() - Method in class akka.actor.FSM.State
 
stopRouterWhenAllRouteesRemoved() - Method in class akka.cluster.routing.ClusterRouterConfig
 
stopRouterWhenAllRouteesRemoved() - Method in interface akka.routing.RouterConfig
 
StreamingCache() - Method in class akka.camel.CamelSettings
enables or disables streamingCache on the Camel Context
streamMustContain(InputStream, String) - Method in class akka.actor.mailbox.DurableMailboxSpec
 
StringByteStringAdapter - Class in akka.io
Simple convenience pipeline stage for turning Strings into ByteStrings and vice versa.
StringByteStringAdapter(String) - Constructor for class akka.io.StringByteStringAdapter
 
StringByteStringAdapter$ - Class in akka.io
 
StringByteStringAdapter$() - Constructor for class akka.io.StringByteStringAdapter$
 
stringHash(String) - Method in class akka.routing.MurmurHash$
Compute a high-quality hash of a string
stringHash(String) - Static method in class akka.routing.MurmurHash
Compute a high-quality hash of a string
SubchannelClassification - Interface in akka.event
Classification which respects relationships between channels: subscribing to one channel automatically and idempotently subscribes to all sub-channels.
SubchannelEventBus<E,S,C> - Class in akka.event.japi
See documentation for SubchannelClassification E is the Event type S is the Subscriber type C is the Classifier type
SubchannelEventBus() - Constructor for class akka.event.japi.SubchannelEventBus
 
subclassification() - Method in class akka.event.EventStream
 
subclassification() - Method in interface akka.event.SubchannelClassification
 
Subclassification<K> - Interface in akka.util
Typeclass which describes a classification hierarchy.
submit(Callable<T>) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
submit(Runnable, T) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
submit(Runnable) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
subscribe(ActorRef, Class<?>) - Method in class akka.cluster.Cluster
Subscribe to cluster domain events.
subscribe() - Method in class akka.contrib.pattern.DistributedPubSubMediator.SubscribeAck
 
subscribe(ActorRef, ActorRef) - Method in interface akka.event.ActorClassification
 
subscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.EventBus
Attempts to register the subscriber to the specified Classifier
subscribe(ActorRef, Class<?>) - Method in class akka.event.EventStream
 
subscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.LookupClassification
 
subscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.ScanningClassification
 
subscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.SubchannelClassification
 
Subscribe - Class in akka.zeromq
The Subscribe option establishes a new message filter on a akka.zeromq.SocketType.Pub socket.
Subscribe(ByteString) - Constructor for class akka.zeromq.Subscribe
 
Subscribe(String) - Constructor for class akka.zeromq.Subscribe
 
Subscribe$ - Class in akka.zeromq
 
Subscribe$() - Constructor for class akka.zeromq.Subscribe$
 
subscribers() - Method in interface akka.event.LookupClassification
 
subscribers() - Method in interface akka.event.ScanningClassification
 
subscriptions() - Method in interface akka.event.SubchannelClassification
 
Succeeded_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
 
successful(T) - Method in class akka.dispatch.Futures$
Creates an already completed Promise with the specified result
successful(T) - Static method in class akka.dispatch.Futures
Creates an already completed Promise with the specified result
superviseWith(SupervisorStrategy) - Method in interface akka.actor.dsl.Creators.Act
Set the supervisor strategy of this actor, i.e.
supervisor() - Method in interface akka.camel.Camel
INTERNAL API Returns the camel supervisor actor.
SUPERVISOR_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DaemonMsgCreateData
 
supervisorStrategy() - Method in interface akka.actor.Actor
User overridable definition the strategy to use for supervising child actors.
supervisorStrategy() - Method in interface akka.actor.dsl.Creators.Act
 
SupervisorStrategy - Class in akka.actor
An Akka SupervisorStrategy is the policy to apply for crashing children.
SupervisorStrategy() - Constructor for class akka.actor.SupervisorStrategy
 
supervisorStrategy() - Method in interface akka.actor.TypedActor.Supervisor
User overridable definition the strategy to use for supervising child actors.
supervisorStrategy() - Method in class akka.actor.UntypedActor
User overridable definition the strategy to use for supervising child actors.
supervisorStrategy() - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
 
supervisorStrategy() - Method in class akka.cluster.routing.ClusterRouterConfig
 
supervisorStrategy() - Method in class akka.contrib.pattern.ReliableProxy
 
supervisorStrategy() - Method in class akka.remote.routing.RemoteRouterConfig
 
supervisorStrategy() - Method in class akka.routing.BroadcastRouter
 
supervisorStrategy() - Method in class akka.routing.ConsistentHashingRouter
 
supervisorStrategy() - Method in class akka.routing.FromConfig
 
supervisorStrategy() - Method in class akka.routing.NoRouter$
 
supervisorStrategy() - Static method in class akka.routing.NoRouter
 
supervisorStrategy() - Method in class akka.routing.RandomRouter
 
supervisorStrategy() - Method in class akka.routing.RoundRobinRouter
 
supervisorStrategy() - Method in interface akka.routing.RouterConfig
SupervisorStrategy for the created Router actor.
supervisorStrategy() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
supervisorStrategy() - Method in class akka.routing.SmallestMailboxRouter
 
SupervisorStrategy$ - Class in akka.actor
 
SupervisorStrategy$() - Constructor for class akka.actor.SupervisorStrategy$
 
SupervisorStrategy.Directive - Interface in akka.actor
 
SupervisorStrategy.Escalate$ - Class in akka.actor
Escalates the failure to the supervisor of the supervisor, by rethrowing the cause of the failure, i.e.
SupervisorStrategy.Escalate$() - Constructor for class akka.actor.SupervisorStrategy.Escalate$
 
SupervisorStrategy.Restart$ - Class in akka.actor
Discards the old Actor instance and replaces it with a new, then resumes message processing.
SupervisorStrategy.Restart$() - Constructor for class akka.actor.SupervisorStrategy.Restart$
 
SupervisorStrategy.Resume$ - Class in akka.actor
Resumes message processing for the failed Actor
SupervisorStrategy.Resume$() - Constructor for class akka.actor.SupervisorStrategy.Resume$
 
SupervisorStrategy.Stop$ - Class in akka.actor
Stops the Actor
SupervisorStrategy.Stop$() - Constructor for class akka.actor.SupervisorStrategy.Stop$
 
SupervisorStrategyClass() - Method in class akka.actor.ActorSystem.Settings
 
SupervisorStrategyConfigurator - Interface in akka.actor
Implement this interface in order to configure the supervisorStrategy for the top-level guardian actor (/user).
SupervisorStrategyLowPriorityImplicits - Interface in akka.actor
 
suspend(akka.actor.ActorCell) - Method in class akka.dispatch.MessageDispatcher
After the call to this method, the dispatcher mustn't begin any new message processing for the specified reference
suspend(akka.actor.ActorCell) - Method in class akka.testkit.CallingThreadDispatcher
 
suspendReading() - Method in class akka.io.TcpMessage$
Sending this command to the connection actor will disable reading from the TCP socket.
suspendReading() - Static method in class akka.io.TcpMessage
Sending this command to the connection actor will disable reading from the TCP socket.
suspendReading() - Method in class akka.io.UdpConnectedMessage$
Send this message to a listener actor (which sent a Udp.Bound message) to have it stop reading datagrams from the network.
suspendReading() - Static method in class akka.io.UdpConnectedMessage
Send this message to a listener actor (which sent a Udp.Bound message) to have it stop reading datagrams from the network.
suspendReading() - Method in class akka.io.UdpMessage$
Send this message to a listener actor (which sent a Udp.Bound message) to have it stop reading datagrams from the network.
suspendReading() - Static method in class akka.io.UdpMessage
Send this message to a listener actor (which sent a Udp.Bound message) to have it stop reading datagrams from the network.
suspendSwitch() - Method in class akka.testkit.CallingThreadMailbox
 
Swap - Class in akka.zeromq
The Swap option shall set the disk offload (swap) size for the specified socket.
Swap(long) - Constructor for class akka.zeromq.Swap
 
swap() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its swap configuration.
swap() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its swap configuration.
Swap$ - Class in akka.zeromq
Gets the Swap
Swap$() - Constructor for class akka.zeromq.Swap$
 
Switch - Class in akka.util
An atomic switch that can be either on or off
Switch(boolean) - Constructor for class akka.util.Switch
 
Switch$ - Class in akka.util
 
Switch$() - Constructor for class akka.util.Switch$
 
switchOff(Function0<BoxedUnit>) - Method in class akka.util.Switch
Executes the provided action if the lock is on under a lock, so be _very_ careful with longrunning/blocking operations in it Only executes the action if the switch is on, and switches it off immediately after obtaining the lock Will switch it back on if the provided action throws an exception
switchOff() - Method in class akka.util.Switch
Switches the switch off (if on), uses locking
switchOn(Function0<BoxedUnit>) - Method in class akka.util.Switch
Executes the provided action if the lock is off under a lock, so be _very_ careful with longrunning/blocking operations in it Only executes the action if the switch is off, and switches it on immediately after obtaining the lock Will switch it back off if the provided action throws an exception
switchOn() - Method in class akka.util.Switch
Switches the switch on (if off), uses locking
symmetricHash(TraversableOnce<T>, int) - Method in class akka.routing.MurmurHash$
Compute a hash that is symmetric in its arguments--that is, where the order of appearance of elements does not matter.
symmetricHash(TraversableOnce<T>, int) - Static method in class akka.routing.MurmurHash
Compute a hash that is symmetric in its arguments--that is, where the order of appearance of elements does not matter.
SymmetricPipelineStage<Context extends PipelineContext,Above,Below> - Class in akka.io
A PipelineStage which is symmetric in command and event types, i.e.
SymmetricPipelineStage() - Constructor for class akka.io.SymmetricPipelineStage
 
SymmetricPipePair<Above,Below> - Interface in akka.io
A convenience type for expressing a PipePair which has the same types for commands and events.
sync(IO.Iteratee<A>) - Method in class akka.actor.IO.IterateeRef$
Creates an IO.IterateeRefSync containing an initial IO.Iteratee.
sync() - Method in class akka.actor.IO.IterateeRef$
Creates an empty IO.IterateeRefSync.
sync() - Method in class akka.actor.IO.IterateeRef.Map$
Creates an empty IO.IterateeRefSync for each new key.
synchronousQueue(boolean) - Method in class akka.dispatch.ThreadPoolConfig$
 
synchronousQueue(boolean) - Static method in class akka.dispatch.ThreadPoolConfig
 
SyncJournal() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
syncJournal() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
syncJournal() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
SysMsgAckTimeout() - Method in class akka.remote.RemoteSettings
 
SysMsgBufferSize() - Method in class akka.remote.RemoteSettings
 
SysResendTimeout() - Method in class akka.remote.RemoteSettings
 
system() - Method in interface akka.actor.ActorContext
The system that the actor belongs to.
system() - Method in class akka.actor.ActorDSL.Extension
 
system() - Method in class akka.actor.Address
 
system() - Method in class akka.actor.mailbox.DurableMessageQueue
 
system() - Method in class akka.actor.TypedActorExtension
 
system() - Method in interface akka.camel.Camel
INTERNAL API Returns the associated ActorSystem.
system() - Method in class akka.cluster.Cluster
 
system() - Method in class akka.cluster.protobuf.ClusterMessageSerializer
 
system() - Method in class akka.cluster.protobuf.msg.Address
 
system() - Method in class akka.contrib.mailbox.PeekMailboxExtension
 
system() - Method in class akka.osgi.aries.blueprint.BlueprintActorSystemFactory
 
system() - Method in class akka.remote.AddressUidExtension
 
system() - Method in class akka.remote.serialization.MessageContainerSerializer
 
system() - Method in class akka.remote.testconductor.TestConductorExt
 
system() - Method in class akka.remote.transport.netty.NettyTransport
 
system() - Method in class akka.serialization.JavaSerializer
 
system() - Method in class akka.serialization.Serialization
 
system() - Method in class akka.testkit.CallingThreadMailbox
 
system() - Method in class akka.testkit.TestKit
 
system() - Method in interface akka.testkit.TestKitBase
 
SYSTEM_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.Address$
 
SYSTEM_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.Address
 
SYSTEM_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Address
 
SYSTEM_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AddressData
 
systemDispatch(akka.actor.ActorCell, akka.dispatch.sysmsg.SystemMessage) - Method in class akka.dispatch.Dispatcher
INTERNAL API
systemDispatch(akka.actor.ActorCell, akka.dispatch.sysmsg.SystemMessage) - Method in class akka.dispatch.MessageDispatcher
Will be called when the dispatcher is to queue an invocation for execution
systemDispatch(akka.actor.ActorCell, akka.dispatch.sysmsg.SystemMessage) - Method in class akka.testkit.CallingThreadDispatcher
 
systemGuardian() - Method in interface akka.actor.ActorRefProvider
Reference to the supervisor used for all top-level system actors.
systemGuardian() - Method in class akka.actor.ExtendedActorSystem
The top-level supervisor of all system-internal services like logging.
SystemHome() - Method in class akka.actor.ActorSystem$
 
SystemHome() - Static method in class akka.actor.ActorSystem
 
systemImpl() - Method in interface akka.actor.ActorRefFactory
INTERNAL API
systemLoadAverage() - Method in class akka.cluster.JmxMetricsCollector
JMX Returns the OS-specific average load on the CPUs in the system, for the past 1 minute.
systemLoadAverage() - Method in class akka.cluster.SigarMetricsCollector
(SIGAR / JMX) Returns the OS-specific average load on the CPUs in the system, for the past 1 minute.
SystemLoadAverage() - Method in class akka.cluster.StandardMetrics$
 
systemLoadAverage() - Method in class akka.cluster.StandardMetrics.Cpu
 
SystemLoadAverage() - Static method in class akka.cluster.StandardMetrics
 
SystemLoadAverageMetricsSelector - Class in akka.cluster.routing
MetricsSelector that uses the system load average metrics.
SystemLoadAverageMetricsSelector() - Constructor for class akka.cluster.routing.SystemLoadAverageMetricsSelector
 
SystemLoadAverageMetricsSelector$ - Class in akka.cluster.routing
MetricsSelector that uses the system load average metrics.
SystemLoadAverageMetricsSelector$() - Constructor for class akka.cluster.routing.SystemLoadAverageMetricsSelector$
 
systemName() - Method in class akka.cluster.ClusterSettings
 
systemSettings() - Method in interface akka.actor.mailbox.DurableMailboxSettings
A reference to the enclosing actor system.
systemSettings() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 

T

t() - Method in class akka.testkit.TestActorRefSpec.WrappedTerminated
 
tail() - Method in class akka.contrib.pattern.WorkList
 
tail() - Method in class akka.util.ByteString
 
tailCommand() - Method in class akka.io.Tcp.CompoundWrite
 
take(int) - Method in class akka.actor.IO$
An Iteratee that returns a ByteString of the requested length.
take(int) - Static method in class akka.actor.IO
An Iteratee that returns a ByteString of the requested length.
take() - Method in class akka.util.BoundedBlockingQueue
 
take(int) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
take(int) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
take(int) - Method in class akka.util.ByteIterator
 
take(int) - Method in class akka.util.ByteString
 
takeAll() - Method in class akka.actor.IO$
An Iteratee that returns the remaining ByteString until an EOF is given.
takeAll() - Static method in class akka.actor.IO
An Iteratee that returns the remaining ByteString until an EOF is given.
takeAny() - Method in class akka.actor.IO$
An Iteratee that returns any input it receives
takeAny() - Static method in class akka.actor.IO
An Iteratee that returns any input it receives
takeList(int, IO.Iteratee<A>) - Method in class akka.actor.IO$
An Iteratee that creates a list made up of the results of an Iteratee.
takeList(int, IO.Iteratee<A>) - Static method in class akka.actor.IO
An Iteratee that creates a list made up of the results of an Iteratee.
takeRight(int) - Method in class akka.util.ByteString
 
takeUntil(ByteString, boolean) - Method in class akka.actor.IO$
An Iteratee that returns the ByteString prefix up until the supplied delimiter.
takeUntil(ByteString, boolean) - Static method in class akka.actor.IO
An Iteratee that returns the ByteString prefix up until the supplied delimiter.
takeWhile(Function1<Object, Object>) - Method in class akka.actor.IO$
An Iteratee that will collect bytes as long as a predicate is true.
takeWhile(Function1<Object, Object>) - Static method in class akka.actor.IO
An Iteratee that will collect bytes as long as a predicate is true.
takeWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
takeWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
takeWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator
 
takeWhile(Function1<Object, Object>) - Method in class akka.util.ByteString
 
target() - Method in class akka.actor.dsl.Inbox.StartWatch
 
target() - Method in class akka.contrib.throttle.Throttler.SetTarget
 
target() - Method in class akka.contrib.throttle.TimerBasedThrottler.Data
 
target() - Method in class akka.io.Udp.Send
 
task() - Method in class akka.actor.LightArrayRevolverScheduler.TaskHolder
 
TaskInvocation - Class in akka.dispatch
 
TaskInvocation(EventStream, Runnable, Function0<BoxedUnit>) - Constructor for class akka.dispatch.TaskInvocation
 
TaskInvocation$ - Class in akka.dispatch
 
TaskInvocation$() - Constructor for class akka.dispatch.TaskInvocation$
 
tc() - Method in class akka.actor.IO.TrafficClass
 
tc() - Method in class akka.io.Inet.SO$.TrafficClass
 
Tcp - Class in akka.io
TCP Extension for Akka’s IO layer.
Tcp() - Constructor for class akka.io.Tcp
 
Tcp$ - Class in akka.io
TCP Extension for Akka’s IO layer.
Tcp$() - Constructor for class akka.io.Tcp$
 
Tcp.Abort$ - Class in akka.io
An abort operation will not flush pending writes and will issue a TCP ABORT command to the O/S kernel which should result in a TCP_RST packet being sent to the peer.
Tcp.Abort$() - Constructor for class akka.io.Tcp.Abort$
 
Tcp.Aborted$ - Class in akka.io
The connection has been aborted in response to an Abort command.
Tcp.Aborted$() - Constructor for class akka.io.Tcp.Aborted$
 
Tcp.Bind - Class in akka.io
The Bind message is send to the TCP manager actor, which is obtained via TcpExt.manager() in order to bind to a listening socket.
Tcp.Bind(ActorRef, InetSocketAddress, int, Traversable<Inet.SocketOption>) - Constructor for class akka.io.Tcp.Bind
 
Tcp.Bind$ - Class in akka.io
 
Tcp.Bind$() - Constructor for class akka.io.Tcp.Bind$
 
Tcp.Bound - Class in akka.io
The sender of a Tcp.Bind command will—in case of success—receive confirmation in this form.
Tcp.Bound(InetSocketAddress) - Constructor for class akka.io.Tcp.Bound
 
Tcp.Bound$ - Class in akka.io
 
Tcp.Bound$() - Constructor for class akka.io.Tcp.Bound$
 
Tcp.Close$ - Class in akka.io
A normal close operation will first flush pending writes and then close the socket.
Tcp.Close$() - Constructor for class akka.io.Tcp.Close$
 
Tcp.CloseCommand - Interface in akka.io
Common interface for all commands which aim to close down an open connection.
Tcp.Closed$ - Class in akka.io
The connection has been closed normally in response to a Close command.
Tcp.Closed$() - Constructor for class akka.io.Tcp.Closed$
 
Tcp.Command - Interface in akka.io
This is the common trait for all commands understood by TCP actors.
Tcp.CommandFailed - Class in akka.io
Whenever a command cannot be completed, the queried actor will reply with this message, wrapping the original command which failed.
Tcp.CommandFailed(Tcp.Command) - Constructor for class akka.io.Tcp.CommandFailed
 
Tcp.CommandFailed$ - Class in akka.io
 
Tcp.CommandFailed$() - Constructor for class akka.io.Tcp.CommandFailed$
 
Tcp.CompoundWrite - Class in akka.io
A write command which aggregates two other write commands.
Tcp.CompoundWrite(Tcp.SimpleWriteCommand, Tcp.WriteCommand) - Constructor for class akka.io.Tcp.CompoundWrite
 
Tcp.CompoundWrite$ - Class in akka.io
 
Tcp.CompoundWrite$() - Constructor for class akka.io.Tcp.CompoundWrite$
 
Tcp.ConfirmedClose$ - Class in akka.io
A confirmed close operation will flush pending writes and half-close the connection, waiting for the peer to close the other half.
Tcp.ConfirmedClose$() - Constructor for class akka.io.Tcp.ConfirmedClose$
 
Tcp.ConfirmedClosed$ - Class in akka.io
The connection has been half-closed by us and then half-close by the peer in response to a ConfirmedClose command.
Tcp.ConfirmedClosed$() - Constructor for class akka.io.Tcp.ConfirmedClosed$
 
Tcp.Connect - Class in akka.io
The Connect message is sent to the TCP manager actor, which is obtained via TcpExt.manager().
Tcp.Connect(InetSocketAddress, Option<InetSocketAddress>, Traversable<Inet.SocketOption>, Option<FiniteDuration>) - Constructor for class akka.io.Tcp.Connect
 
Tcp.Connect$ - Class in akka.io
 
Tcp.Connect$() - Constructor for class akka.io.Tcp.Connect$
 
Tcp.Connected - Class in akka.io
The connection actor sends this message either to the sender of a Tcp.Connect command (for outbound) or to the handler for incoming connections designated in the Tcp.Bind message.
Tcp.Connected(InetSocketAddress, InetSocketAddress) - Constructor for class akka.io.Tcp.Connected
 
Tcp.Connected$ - Class in akka.io
 
Tcp.Connected$() - Constructor for class akka.io.Tcp.Connected$
 
Tcp.ConnectionClosed - Interface in akka.io
This is the common interface for all events which indicate that a connection has been closed or half-closed.
Tcp.ErrorClosed - Class in akka.io
The connection has been closed due to an IO error.
Tcp.ErrorClosed(String) - Constructor for class akka.io.Tcp.ErrorClosed
 
Tcp.ErrorClosed$ - Class in akka.io
 
Tcp.ErrorClosed$() - Constructor for class akka.io.Tcp.ErrorClosed$
 
Tcp.Event - Interface in akka.io
Common interface for all events generated by the TCP layer actors.
Tcp.Message - Interface in akka.io
The common interface for Tcp.WriteCommand and Tcp.Event.
Tcp.NoAck - Class in akka.io
Each Tcp.WriteCommand can optionally request a positive acknowledgment to be sent to the commanding actor.
Tcp.NoAck(Object) - Constructor for class akka.io.Tcp.NoAck
 
Tcp.NoAck$ - Class in akka.io
Default Tcp.NoAck instance which is used when no acknowledgment information is explicitly provided.
Tcp.NoAck$() - Constructor for class akka.io.Tcp.NoAck$
 
Tcp.PeerClosed$ - Class in akka.io
The peer has closed its writing half of the connection.
Tcp.PeerClosed$() - Constructor for class akka.io.Tcp.PeerClosed$
 
Tcp.Received - Class in akka.io
Whenever data are read from a socket they will be transferred within this class to the handler actor which was designated in the Tcp.Register message.
Tcp.Received(ByteString) - Constructor for class akka.io.Tcp.Received
 
Tcp.Received$ - Class in akka.io
 
Tcp.Received$() - Constructor for class akka.io.Tcp.Received$
 
Tcp.Register - Class in akka.io
This message must be sent to a TCP connection actor after receiving the Tcp.Connected message.
Tcp.Register(ActorRef, boolean, boolean) - Constructor for class akka.io.Tcp.Register
 
Tcp.Register$ - Class in akka.io
 
Tcp.Register$() - Constructor for class akka.io.Tcp.Register$
 
Tcp.ResumeReading$ - Class in akka.io
This command needs to be sent to the connection actor after a SuspendReading command in order to resume reading from the socket.
Tcp.ResumeReading$() - Constructor for class akka.io.Tcp.ResumeReading$
 
Tcp.ResumeWriting$ - Class in akka.io
When useResumeWriting is in effect as was indicated in the Tcp.Register message then this command needs to be sent to the connection actor in order to re-enable writing after a Tcp.CommandFailed event.
Tcp.ResumeWriting$() - Constructor for class akka.io.Tcp.ResumeWriting$
 
Tcp.SimpleWriteCommand - Interface in akka.io
Common supertype of Tcp.Write and Tcp.WriteFile.
Tcp.SO$ - Class in akka.io
Scala API: this object contains all applicable socket options for TCP.
Tcp.SO$() - Constructor for class akka.io.Tcp.SO$
 
Tcp.SO$.KeepAlive - Class in akka.io
Inet.SocketOption to enable or disable SO_KEEPALIVE
Tcp.SO$.KeepAlive(boolean) - Constructor for class akka.io.Tcp.SO$.KeepAlive
 
Tcp.SO$.OOBInline - Class in akka.io
Inet.SocketOption to enable or disable OOBINLINE (receipt of TCP urgent data) By default, this option is disabled and TCP urgent data is silently discarded.
Tcp.SO$.OOBInline(boolean) - Constructor for class akka.io.Tcp.SO$.OOBInline
 
Tcp.SO$.TcpNoDelay - Class in akka.io
Inet.SocketOption to enable or disable TCP_NODELAY (disable or enable Nagle's algorithm)
Tcp.SO$.TcpNoDelay(boolean) - Constructor for class akka.io.Tcp.SO$.TcpNoDelay
 
Tcp.SuspendReading$ - Class in akka.io
Sending this command to the connection actor will disable reading from the TCP socket.
Tcp.SuspendReading$() - Constructor for class akka.io.Tcp.SuspendReading$
 
Tcp.Unbind$ - Class in akka.io
In order to close down a listening socket, send this message to that socket’s actor (that is the actor which previously had sent the Tcp.Bound message).
Tcp.Unbind$() - Constructor for class akka.io.Tcp.Unbind$
 
Tcp.Unbound - Interface in akka.io
The sender of an Unbind command will receive confirmation through this message once the listening socket has been closed.
Tcp.Unbound$ - Class in akka.io
 
Tcp.Unbound$() - Constructor for class akka.io.Tcp.Unbound$
 
Tcp.Write - Class in akka.io
Write data to the TCP connection.
Tcp.Write(ByteString, Tcp.Event) - Constructor for class akka.io.Tcp.Write
 
Tcp.Write$ - Class in akka.io
 
Tcp.Write$() - Constructor for class akka.io.Tcp.Write$
 
Tcp.WriteCommand - Interface in akka.io
Common interface for all write commands, currently Tcp.Write, Tcp.WriteFile and Tcp.CompoundWrite.
Tcp.WriteCommand$ - Class in akka.io
 
Tcp.WriteCommand$() - Constructor for class akka.io.Tcp.WriteCommand$
 
Tcp.WriteFile - Class in akka.io
Write count bytes starting at position from file at filePath to the connection.
Tcp.WriteFile(String, long, long, Tcp.Event) - Constructor for class akka.io.Tcp.WriteFile
 
Tcp.WriteFile$ - Class in akka.io
 
Tcp.WriteFile$() - Constructor for class akka.io.Tcp.WriteFile$
 
Tcp.WritingResumed - Interface in akka.io
When useResumeWriting is in effect as indicated in the Tcp.Register message, the ResumeWriting command will be acknowledged by this message type, upon which it is safe to send at least one write.
Tcp.WritingResumed$ - Class in akka.io
 
Tcp.WritingResumed$() - Constructor for class akka.io.Tcp.WritingResumed$
 
TcpExt - Class in akka.io
 
TcpExt(ExtendedActorSystem) - Constructor for class akka.io.TcpExt
 
TcpExt.Settings - Class in akka.io
 
TcpKeepalive() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
TcpMessage - Class in akka.io
 
TcpMessage() - Constructor for class akka.io.TcpMessage
 
TcpMessage$ - Class in akka.io
 
TcpMessage$() - Constructor for class akka.io.TcpMessage$
 
tcpNoDelay(boolean) - Method in class akka.io.TcpSO$
Inet.SocketOption to enable or disable TCP_NODELAY (disable or enable Nagle's algorithm)
tcpNoDelay(boolean) - Static method in class akka.io.TcpSO
Inet.SocketOption to enable or disable TCP_NODELAY (disable or enable Nagle's algorithm)
TcpNodelay() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
TcpPipelineHandler<Ctx extends PipelineContext,Cmd,Evt> - Class in akka.io
This actor wraps a pipeline and forwards commands and events between that one and a Tcp connection actor.
TcpPipelineHandler(TcpPipelineHandler.Init<Ctx, Cmd, Evt>, ActorRef, ActorRef) - Constructor for class akka.io.TcpPipelineHandler
 
TcpPipelineHandler$ - Class in akka.io
 
TcpPipelineHandler$() - Constructor for class akka.io.TcpPipelineHandler$
 
TcpPipelineHandler.Init<Ctx extends PipelineContext,Cmd,Evt> - Class in akka.io
This class wraps up a pipeline with its external (i.e.
TcpPipelineHandler.Init(PipelineStage<? extends PipelineContext, Cmd, Tcp.Command, Evt, Tcp.Event>) - Constructor for class akka.io.TcpPipelineHandler.Init
 
TcpPipelineHandler.Init.Command - Class in akka.io
Wrapper class for commands to be sent to the TcpPipelineHandler actor.
TcpPipelineHandler.Init.Command(Cmd) - Constructor for class akka.io.TcpPipelineHandler.Init.Command
 
TcpPipelineHandler.Init.Event - Class in akka.io
Wrapper class for events emitted by the TcpPipelineHandler actor.
TcpPipelineHandler.Init.Event(Evt) - Constructor for class akka.io.TcpPipelineHandler.Init.Event
 
TcpPipelineHandler.Management - Class in akka.io
Wrapper class for management commands sent to the TcpPipelineHandler actor.
TcpPipelineHandler.Management(Object) - Constructor for class akka.io.TcpPipelineHandler.Management
 
TcpPipelineHandler.Management$ - Class in akka.io
 
TcpPipelineHandler.Management$() - Constructor for class akka.io.TcpPipelineHandler.Management$
 
TcpPipelineHandler.TcpEvent - Class in akka.io
The pipeline may want to emit a Tcp.Event to the registered handler actor, which is enabled by emitting this Tcp.Command wrapping an event instead.
TcpPipelineHandler.TcpEvent(Tcp.Event) - Constructor for class akka.io.TcpPipelineHandler.TcpEvent
 
TcpPipelineHandler.TcpEvent$ - Class in akka.io
 
TcpPipelineHandler.TcpEvent$() - Constructor for class akka.io.TcpPipelineHandler.TcpEvent$
 
TcpPipelineHandler.Tell - Class in akka.io
This is a new Tcp.Command which the pipeline can emit to effect the sending a message to another actor.
TcpPipelineHandler.Tell(ActorRef, Object, ActorRef) - Constructor for class akka.io.TcpPipelineHandler.Tell
 
TcpPipelineHandler.Tell$ - Class in akka.io
 
TcpPipelineHandler.Tell$() - Constructor for class akka.io.TcpPipelineHandler.Tell$
 
TcpPipelineHandler.WithinActorContext - Interface in akka.io
This interface bundles logging and ActorContext for Java.
TcpReadWriteAdapter - Class in akka.io
Adapts a ByteString oriented pipeline stage to a stage that communicates via Tcp Commands and Events.
TcpReadWriteAdapter() - Constructor for class akka.io.TcpReadWriteAdapter
 
TcpReuseAddr() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
TcpSO - Class in akka.io
Java API for accessing socket options.
TcpSO() - Constructor for class akka.io.TcpSO
 
TcpSO$ - Class in akka.io
Java API for accessing socket options.
TcpSO$() - Constructor for class akka.io.TcpSO$
 
team() - Method in class akka.dispatch.BalancingDispatcher
INTERNAL API
teamWork() - Method in class akka.dispatch.BalancingDispatcher
 
tell(Object, ActorRef) - Method in class akka.actor.ActorRef
Java API: Sends the specified message to the sender, i.e.
tell(Object) - Method in class akka.actor.ActorSelection
 
tell(Object, ActorRef) - Method in class akka.actor.ActorSelection
 
tempContainer() - Method in interface akka.actor.ActorRefProvider
Returns the actor reference representing the “/temp” path.
template() - Method in interface akka.camel.Camel
The Camel ProducerTemplate.
tempPath() - Method in interface akka.actor.ActorRefProvider
Generates and returns a unique actor path below “/temp”.
term() - Method in class akka.zeromq.Context
 
terminate(FSM.State<S, D>) - Method in interface akka.actor.FSM
 
Terminated - Class in akka.actor
When Death Watch is used, the watcher will receive a Terminated(watched) message when watched is terminated.
Terminated$ - Class in akka.actor
 
Terminated$() - Constructor for class akka.actor.Terminated$
 
terminateEvent() - Method in interface akka.actor.FSM
 
terminationFuture() - Method in interface akka.actor.ActorRefProvider
This Future is completed upon termination of this ActorRefProvider, which is usually initiated by stopping the guardian via ActorSystem.stop().
test() - Method in class akka.testkit.CustomEventFilter
 
TestActor - Class in akka.testkit
 
TestActor(BlockingDeque<TestActor.Message>) - Constructor for class akka.testkit.TestActor
 
testActor() - Method in interface akka.testkit.TestKitBase
ActorRef of the test actor.
TestActor$ - Class in akka.testkit
 
TestActor$() - Constructor for class akka.testkit.TestActor$
 
TestActor.AutoPilot - Class in akka.testkit
 
TestActor.AutoPilot() - Constructor for class akka.testkit.TestActor.AutoPilot
 
TestActor.KeepRunning$ - Class in akka.testkit
 
TestActor.KeepRunning$() - Constructor for class akka.testkit.TestActor.KeepRunning$
 
TestActor.Message - Interface in akka.testkit
 
TestActor.NoAutoPilot$ - Class in akka.testkit
 
TestActor.NoAutoPilot$() - Constructor for class akka.testkit.TestActor.NoAutoPilot$
 
TestActor.NullMessage$ - Class in akka.testkit
 
TestActor.NullMessage$() - Constructor for class akka.testkit.TestActor.NullMessage$
 
TestActor.RealMessage - Class in akka.testkit
 
TestActor.RealMessage(Object, ActorRef) - Constructor for class akka.testkit.TestActor.RealMessage
 
TestActor.RealMessage$ - Class in akka.testkit
 
TestActor.RealMessage$() - Constructor for class akka.testkit.TestActor.RealMessage$
 
TestActor.SetAutoPilot - Class in akka.testkit
 
TestActor.SetAutoPilot(TestActor.AutoPilot) - Constructor for class akka.testkit.TestActor.SetAutoPilot
 
TestActor.SetAutoPilot$ - Class in akka.testkit
 
TestActor.SetAutoPilot$() - Constructor for class akka.testkit.TestActor.SetAutoPilot$
 
TestActor.SetIgnore - Class in akka.testkit
 
TestActor.SetIgnore(Option<PartialFunction<Object, Object>>) - Constructor for class akka.testkit.TestActor.SetIgnore
 
TestActor.SetIgnore$ - Class in akka.testkit
 
TestActor.SetIgnore$() - Constructor for class akka.testkit.TestActor.SetIgnore$
 
TestActor.UnWatch - Class in akka.testkit
 
TestActor.UnWatch(ActorRef) - Constructor for class akka.testkit.TestActor.UnWatch
 
TestActor.UnWatch$ - Class in akka.testkit
 
TestActor.UnWatch$() - Constructor for class akka.testkit.TestActor.UnWatch$
 
TestActor.Watch - Class in akka.testkit
 
TestActor.Watch(ActorRef) - Constructor for class akka.testkit.TestActor.Watch
 
TestActor.Watch$ - Class in akka.testkit
 
TestActor.Watch$() - Constructor for class akka.testkit.TestActor.Watch$
 
testActorId() - Method in class akka.testkit.TestKit$
 
testActorId() - Static method in class akka.testkit.TestKit
 
TestActorRef<T extends Actor> - Class in akka.testkit
This special ActorRef is exclusively for use during unit testing in a single-threaded environment.
TestActorRef(ActorSystem, Props, ActorRef, String) - Constructor for class akka.testkit.TestActorRef
 
TestActorRef$ - Class in akka.testkit
 
TestActorRef$() - Constructor for class akka.testkit.TestActorRef$
 
TestActorRefSpec - Class in akka.testkit
Forwarding Terminated to non-watching testActor is not possible, and therefore the Terminated message is wrapped.
TestActorRefSpec() - Constructor for class akka.testkit.TestActorRefSpec
 
TestActorRefSpec$ - Class in akka.testkit
Test whether TestActorRef behaves as an ActorRef should, besides its own spec.
TestActorRefSpec$() - Constructor for class akka.testkit.TestActorRefSpec$
 
TestActorRefSpec.Logger - Class in akka.testkit
 
TestActorRefSpec.Logger() - Constructor for class akka.testkit.TestActorRefSpec.Logger
 
TestActorRefSpec.ReceiveTimeoutActor - Class in akka.testkit
 
TestActorRefSpec.ReceiveTimeoutActor(ActorRef) - Constructor for class akka.testkit.TestActorRefSpec.ReceiveTimeoutActor
 
TestActorRefSpec.ReplyActor - Class in akka.testkit
 
TestActorRefSpec.ReplyActor() - Constructor for class akka.testkit.TestActorRefSpec.ReplyActor
 
TestActorRefSpec.SenderActor - Class in akka.testkit
 
TestActorRefSpec.SenderActor(ActorRef) - Constructor for class akka.testkit.TestActorRefSpec.SenderActor
 
TestActorRefSpec.TActor - Interface in akka.testkit
 
TestActorRefSpec.WorkerActor - Class in akka.testkit
 
TestActorRefSpec.WorkerActor() - Constructor for class akka.testkit.TestActorRefSpec.WorkerActor
 
TestActorRefSpec.WrappedTerminated - Class in akka.testkit
Forwarding Terminated to non-watching testActor is not possible, and therefore the Terminated message is wrapped.
TestActorRefSpec.WrappedTerminated(Terminated) - Constructor for class akka.testkit.TestActorRefSpec.WrappedTerminated
 
TestActorRefSpec.WrappedTerminated$ - Class in akka.testkit
 
TestActorRefSpec.WrappedTerminated$() - Constructor for class akka.testkit.TestActorRefSpec.WrappedTerminated$
 
TestAssociationHandle - Class in akka.remote.transport
 
TestAssociationHandle(Address, Address, TestTransport, boolean) - Constructor for class akka.remote.transport.TestAssociationHandle
 
TestAssociationHandle$ - Class in akka.remote.transport
 
TestAssociationHandle$() - Constructor for class akka.remote.transport.TestAssociationHandle$
 
TestBarrier - Class in akka.testkit
 
TestBarrier(int) - Constructor for class akka.testkit.TestBarrier
 
TestBarrier$ - Class in akka.testkit
A cyclic barrier wrapper for use in testing.
TestBarrier$() - Constructor for class akka.testkit.TestBarrier$
 
TestBarrierTimeoutException - Exception in akka.testkit
 
TestBarrierTimeoutException(String) - Constructor for exception akka.testkit.TestBarrierTimeoutException
 
TestConductor - Class in akka.remote.testconductor
Access to the TestConductorExt extension:
TestConductor() - Constructor for class akka.remote.testconductor.TestConductor
 
testConductor() - Method in class akka.remote.testkit.MultiNodeSpec
Access to the barriers, failure injection, etc.
TestConductor$ - Class in akka.remote.testconductor
Access to the TestConductorExt extension:
TestConductor$() - Constructor for class akka.remote.testconductor.TestConductor$
 
TestConductorExt - Class in akka.remote.testconductor
This binds together the Conductor and Player roles inside an Akka Extension.
TestConductorExt(ExtendedActorSystem) - Constructor for class akka.remote.testconductor.TestConductorExt
 
TestConductorExt.Settings - Class in akka.remote.testconductor
 
TestConductorExt.Settings() - Constructor for class akka.remote.testconductor.TestConductorExt.Settings
 
TestConductorProtocol - Class in akka.remote.testconductor
 
TestConductorProtocol.Address - Class in akka.remote.testconductor
 
TestConductorProtocol.Address.Builder - Class in akka.remote.testconductor
 
TestConductorProtocol.AddressOrBuilder - Interface in akka.remote.testconductor
 
TestConductorProtocol.AddressRequest - Class in akka.remote.testconductor
 
TestConductorProtocol.AddressRequest.Builder - Class in akka.remote.testconductor
 
TestConductorProtocol.AddressRequestOrBuilder - Interface in akka.remote.testconductor
 
TestConductorProtocol.BarrierOp - Enum in akka.remote.testconductor
 
TestConductorProtocol.Direction - Enum in akka.remote.testconductor
 
TestConductorProtocol.EnterBarrier - Class in akka.remote.testconductor
 
TestConductorProtocol.EnterBarrier.Builder - Class in akka.remote.testconductor
 
TestConductorProtocol.EnterBarrierOrBuilder - Interface in akka.remote.testconductor
 
TestConductorProtocol.FailType - Enum in akka.remote.testconductor
 
TestConductorProtocol.Hello - Class in akka.remote.testconductor
 
TestConductorProtocol.Hello.Builder - Class in akka.remote.testconductor
 
TestConductorProtocol.HelloOrBuilder - Interface in akka.remote.testconductor
 
TestConductorProtocol.InjectFailure - Class in akka.remote.testconductor
 
TestConductorProtocol.InjectFailure.Builder - Class in akka.remote.testconductor
 
TestConductorProtocol.InjectFailureOrBuilder - Interface in akka.remote.testconductor
 
TestConductorProtocol.Wrapper - Class in akka.remote.testconductor
 
TestConductorProtocol.Wrapper.Builder - Class in akka.remote.testconductor
 
TestConductorProtocol.WrapperOrBuilder - Interface in akka.remote.testconductor
 
testConf() - Method in class akka.testkit.AkkaSpec$
 
testConf() - Static method in class akka.testkit.AkkaSpec
 
TestDuration - Class in akka.testkit
Wrapper for implicit conversion to add dilated function to Duration.
TestDuration(FiniteDuration) - Constructor for class akka.testkit.TestDuration
 
TestEvent - Interface in akka.testkit
Implementation helpers of the EventFilter facilities: send Mute to the TestEventListener to install a filter, and UnMute to deinstall it.
TestEvent$ - Class in akka.testkit
Implementation helpers of the EventFilter facilities: send Mute to the TestEventFilter to install a filter, and UnMute to deinstall it.
TestEvent$() - Constructor for class akka.testkit.TestEvent$
 
TestEvent.Mute - Class in akka.testkit
 
TestEvent.Mute(Seq<EventFilter>) - Constructor for class akka.testkit.TestEvent.Mute
 
TestEvent.Mute(Iterable<EventFilter>) - Constructor for class akka.testkit.TestEvent.Mute
Java API: create a Mute command from a list of filters
TestEvent.Mute$ - Class in akka.testkit
 
TestEvent.Mute$() - Constructor for class akka.testkit.TestEvent.Mute$
 
TestEvent.UnMute - Class in akka.testkit
 
TestEvent.UnMute(Seq<EventFilter>) - Constructor for class akka.testkit.TestEvent.UnMute
 
TestEvent.UnMute(Iterable<EventFilter>) - Constructor for class akka.testkit.TestEvent.UnMute
Java API: create an UnMute command from a list of filters
TestEvent.UnMute$ - Class in akka.testkit
Java API: create a Mute command from a list of filters
TestEvent.UnMute$() - Constructor for class akka.testkit.TestEvent.UnMute$
 
TestEventFilterLeeway() - Method in class akka.testkit.TestKitSettings
 
TestEventListener - Class in akka.testkit
EventListener for running tests, which allows selectively filtering out expected messages.
TestEventListener() - Constructor for class akka.testkit.TestEventListener
 
TestFSMRef<S,D,T extends Actor> - Class in akka.testkit
This is a specialised form of the TestActorRef with support for querying and setting the state of a FSM.
TestFSMRef(ActorSystem, Props, ActorRef, String, Predef.$less$colon$less<T, FSM<S, D>>) - Constructor for class akka.testkit.TestFSMRef
 
TestFSMRef$ - Class in akka.testkit
 
TestFSMRef$() - Constructor for class akka.testkit.TestFSMRef$
 
TestFSMRefSpec - Class in akka.testkit
 
TestFSMRefSpec() - Constructor for class akka.testkit.TestFSMRefSpec
 
TestKit - Class in akka.testkit
Test kit for testing actors.
TestKit(ActorSystem) - Constructor for class akka.testkit.TestKit
 
TestKit$ - Class in akka.testkit
 
TestKit$() - Constructor for class akka.testkit.TestKit$
 
TestKitBase - Interface in akka.testkit
Implementation trait behind the TestKit class: you may use this if inheriting from a concrete class is not possible.
TestKitExtension - Class in akka.testkit
 
TestKitExtension() - Constructor for class akka.testkit.TestKitExtension
 
TestKitExtension$ - Class in akka.testkit
 
TestKitExtension$() - Constructor for class akka.testkit.TestKitExtension$
 
testKitSettings() - Method in interface akka.testkit.TestKitBase
 
TestKitSettings - Class in akka.testkit
 
TestKitSettings(com.typesafe.config.Config) - Constructor for class akka.testkit.TestKitSettings
 
TestLatch - Class in akka.testkit
 
TestLatch(int, ActorSystem) - Constructor for class akka.testkit.TestLatch
 
TestLatch$ - Class in akka.testkit
A count down latch wrapper for use in testing.
TestLatch$() - Constructor for class akka.testkit.TestLatch$
 
TestProbe - Class in akka.testkit
TestKit-based probe which allows sending, reception and reply.
TestProbe(ActorSystem) - Constructor for class akka.testkit.TestProbe
 
TestProbe$ - Class in akka.testkit
 
TestProbe$() - Constructor for class akka.testkit.TestProbe$
 
TestProbeSpec - Class in akka.testkit
 
TestProbeSpec() - Constructor for class akka.testkit.TestProbeSpec
 
TestTimeFactor() - Method in class akka.testkit.TestKitSettings
 
TestTimeSpec - Class in akka.testkit
 
TestTimeSpec() - Constructor for class akka.testkit.TestTimeSpec
 
testTransport(boolean) - Method in class akka.remote.testkit.MultiNodeConfig
To be able to use blackhole, passThrough, and throttle you must activate the failure injector and throttler transport adapters by specifying testTransport(on = true) in your MultiNodeConfig.
TestTransport - Class in akka.remote.transport
Transport implementation to be used for testing.
TestTransport(Address, TestTransport.AssociationRegistry, int, String) - Constructor for class akka.remote.transport.TestTransport
 
TestTransport(ExtendedActorSystem, com.typesafe.config.Config) - Constructor for class akka.remote.transport.TestTransport
 
TestTransport$ - Class in akka.remote.transport
 
TestTransport$() - Constructor for class akka.remote.transport.TestTransport$
 
TestTransport.Activity - Interface in akka.remote.transport
Base trait for activities that are logged by TestTransport.
TestTransport.AssociateAttempt - Class in akka.remote.transport
 
TestTransport.AssociateAttempt(Address, Address) - Constructor for class akka.remote.transport.TestTransport.AssociateAttempt
 
TestTransport.AssociateAttempt$ - Class in akka.remote.transport
 
TestTransport.AssociateAttempt$() - Constructor for class akka.remote.transport.TestTransport.AssociateAttempt$
 
TestTransport.AssociationRegistry - Class in akka.remote.transport
Shared state among TestTransport instances.
TestTransport.AssociationRegistry() - Constructor for class akka.remote.transport.TestTransport.AssociationRegistry
 
TestTransport.DisassociateAttempt - Class in akka.remote.transport
 
TestTransport.DisassociateAttempt(Address, Address) - Constructor for class akka.remote.transport.TestTransport.DisassociateAttempt
 
TestTransport.DisassociateAttempt$ - Class in akka.remote.transport
 
TestTransport.DisassociateAttempt$() - Constructor for class akka.remote.transport.TestTransport.DisassociateAttempt$
 
TestTransport.ListenAttempt - Class in akka.remote.transport
 
TestTransport.ListenAttempt(Address) - Constructor for class akka.remote.transport.TestTransport.ListenAttempt
 
TestTransport.ListenAttempt$ - Class in akka.remote.transport
 
TestTransport.ListenAttempt$() - Constructor for class akka.remote.transport.TestTransport.ListenAttempt$
 
TestTransport.ShutdownAttempt - Class in akka.remote.transport
 
TestTransport.ShutdownAttempt(Address) - Constructor for class akka.remote.transport.TestTransport.ShutdownAttempt
 
TestTransport.ShutdownAttempt$ - Class in akka.remote.transport
 
TestTransport.ShutdownAttempt$() - Constructor for class akka.remote.transport.TestTransport.ShutdownAttempt$
 
TestTransport.SwitchableLoggedBehavior<A,B> - Class in akka.remote.transport
Test utility to make behavior of functions that return some Future[B] controllable from tests.
TestTransport.SwitchableLoggedBehavior(Function1<A, Future<B>>, Function1<A, BoxedUnit>) - Constructor for class akka.remote.transport.TestTransport.SwitchableLoggedBehavior
 
TestTransport.WriteAttempt - Class in akka.remote.transport
 
TestTransport.WriteAttempt(Address, Address, ByteString) - Constructor for class akka.remote.transport.TestTransport.WriteAttempt
 
TestTransport.WriteAttempt$ - Class in akka.remote.transport
 
TestTransport.WriteAttempt$() - Constructor for class akka.remote.transport.TestTransport.WriteAttempt$
 
theStash() - Method in interface akka.actor.UnrestrictedStash
 
thread() - Method in interface akka.event.Logging.LogEvent
The thread that created this log event
thread() - Method in class akka.testkit.TestActorRefSpec$
 
thread() - Static method in class akka.testkit.TestActorRefSpec
 
threadFactory() - Method in class akka.actor.ExtendedActorSystem
A ThreadFactory that can be used if the transport needs to create any Threads
threadFactory() - Method in interface akka.dispatch.DispatcherPrerequisites
 
threadFactory() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory
 
threadFactory() - Method in class akka.dispatch.ThreadPoolConfig.ThreadPoolExecutorServiceFactory
 
ThreadPoolConfig - Class in akka.dispatch
A small configuration DSL to create ThreadPoolExecutors that can be provided as an ExecutorServiceFactoryProvider to Dispatcher
ThreadPoolConfig(boolean, int, int, Duration, Function0<BlockingQueue<Runnable>>, RejectedExecutionHandler) - Constructor for class akka.dispatch.ThreadPoolConfig
 
threadPoolConfig() - Method in class akka.dispatch.ThreadPoolExecutorConfigurator
 
ThreadPoolConfig$ - Class in akka.dispatch
 
ThreadPoolConfig$() - Constructor for class akka.dispatch.ThreadPoolConfig$
 
ThreadPoolConfig.ThreadPoolExecutorServiceFactory - Class in akka.dispatch
 
ThreadPoolConfig.ThreadPoolExecutorServiceFactory(ThreadFactory) - Constructor for class akka.dispatch.ThreadPoolConfig.ThreadPoolExecutorServiceFactory
 
ThreadPoolConfigBuilder - Class in akka.dispatch
A DSL to configure and create a MessageDispatcher with a ThreadPoolExecutor
ThreadPoolConfigBuilder(ThreadPoolConfig) - Constructor for class akka.dispatch.ThreadPoolConfigBuilder
 
ThreadPoolConfigBuilder$ - Class in akka.dispatch
 
ThreadPoolConfigBuilder$() - Constructor for class akka.dispatch.ThreadPoolConfigBuilder$
 
ThreadPoolExecutorConfigurator - Class in akka.dispatch
 
ThreadPoolExecutorConfigurator(com.typesafe.config.Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.ThreadPoolExecutorConfigurator
 
threadTimeout() - Method in class akka.dispatch.ThreadPoolConfig
 
threshold() - Method in class akka.remote.PhiAccrualFailureDetector
 
throttle(RoleName, RoleName, ThrottlerTransportAdapter.Direction, double) - Method in interface akka.remote.testconductor.Conductor
Make the remoting pipeline on the node throttle data sent to or received from the given remote peer.
Throttle_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.FailType
 
Throttler - Class in akka.contrib.throttle
== Throttling == A throttler is an actor that is defined through a target actor and a rate (of type Throttler.Rate).
Throttler() - Constructor for class akka.contrib.throttle.Throttler
 
Throttler$ - Class in akka.contrib.throttle
== Throttling == A throttler is an actor that is defined through a target actor and a rate (of type Throttler.Rate).
Throttler$() - Constructor for class akka.contrib.throttle.Throttler$
 
Throttler.Rate - Class in akka.contrib.throttle
A rate used for throttling.
Throttler.Rate(int, FiniteDuration) - Constructor for class akka.contrib.throttle.Throttler.Rate
 
Throttler.Rate$ - Class in akka.contrib.throttle
 
Throttler.Rate$() - Constructor for class akka.contrib.throttle.Throttler.Rate$
 
Throttler.RateInt - Class in akka.contrib.throttle
Helper for some syntactic sugar.
Throttler.RateInt(int) - Constructor for class akka.contrib.throttle.Throttler.RateInt
 
Throttler.RateInt$ - Class in akka.contrib.throttle
 
Throttler.RateInt$() - Constructor for class akka.contrib.throttle.Throttler.RateInt$
 
Throttler.SetRate - Class in akka.contrib.throttle
Set the rate of a throttler.
Throttler.SetRate(Throttler.Rate) - Constructor for class akka.contrib.throttle.Throttler.SetRate
 
Throttler.SetRate$ - Class in akka.contrib.throttle
 
Throttler.SetRate$() - Constructor for class akka.contrib.throttle.Throttler.SetRate$
 
Throttler.SetTarget - Class in akka.contrib.throttle
Set the target of a throttler.
Throttler.SetTarget(Option<ActorRef>) - Constructor for class akka.contrib.throttle.Throttler.SetTarget
 
Throttler.SetTarget(ActorRef) - Constructor for class akka.contrib.throttle.Throttler.SetTarget
Java API:
Throttler.SetTarget$ - Class in akka.contrib.throttle
 
Throttler.SetTarget$() - Constructor for class akka.contrib.throttle.Throttler.SetTarget$
 
ThrottlerProvider - Class in akka.remote.transport
 
ThrottlerProvider() - Constructor for class akka.remote.transport.ThrottlerProvider
 
ThrottlerTransportAdapter - Class in akka.remote.transport
Java API: get the singleton instance
ThrottlerTransportAdapter(Transport, ExtendedActorSystem) - Constructor for class akka.remote.transport.ThrottlerTransportAdapter
 
ThrottlerTransportAdapter$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter$
 
ThrottlerTransportAdapter.Blackhole$ - Class in akka.remote.transport
Java API: get the singleton instance
ThrottlerTransportAdapter.Blackhole$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.Blackhole$
 
ThrottlerTransportAdapter.Direction - Interface in akka.remote.transport
 
ThrottlerTransportAdapter.Direction$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.Direction$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.Direction$
 
ThrottlerTransportAdapter.Direction.Both$ - Class in akka.remote.transport
Java API: get the singleton instance
ThrottlerTransportAdapter.Direction.Both$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.Direction.Both$
 
ThrottlerTransportAdapter.Direction.Receive$ - Class in akka.remote.transport
Java API: get the singleton instance
ThrottlerTransportAdapter.Direction.Receive$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.Direction.Receive$
 
ThrottlerTransportAdapter.Direction.Send$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.Direction.Send$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.Direction.Send$
 
ThrottlerTransportAdapter.ForceDisassociate - Class in akka.remote.transport
Management Command to force dissocation of an address.
ThrottlerTransportAdapter.ForceDisassociate(Address) - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociate
 
ThrottlerTransportAdapter.ForceDisassociate$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.ForceDisassociate$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociate$
 
ThrottlerTransportAdapter.ForceDisassociateAck$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.ForceDisassociateAck$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociateAck$
 
ThrottlerTransportAdapter.SetThrottle - Class in akka.remote.transport
Java API: get the singleton instance
ThrottlerTransportAdapter.SetThrottle(Address, ThrottlerTransportAdapter.Direction, ThrottlerTransportAdapter.ThrottleMode) - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.SetThrottle
 
ThrottlerTransportAdapter.SetThrottle$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.SetThrottle$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.SetThrottle$
 
ThrottlerTransportAdapter.SetThrottleAck$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.SetThrottleAck$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.SetThrottleAck$
 
ThrottlerTransportAdapter.ThrottleMode - Interface in akka.remote.transport
Java API: get the singleton instance
ThrottlerTransportAdapter.TokenBucket - Class in akka.remote.transport
 
ThrottlerTransportAdapter.TokenBucket(int, double, long, int) - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket
 
ThrottlerTransportAdapter.TokenBucket$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.TokenBucket$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket$
 
ThrottlerTransportAdapter.Unthrottled$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.Unthrottled$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.Unthrottled$
 
throughput() - Method in class akka.dispatch.Dispatcher
 
throughput() - Method in class akka.dispatch.MessageDispatcher
INTERNAL API
throughput() - Method in class akka.testkit.CallingThreadDispatcher
 
throughputDeadlineTime() - Method in class akka.dispatch.Dispatcher
 
throughputDeadlineTime() - Method in class akka.dispatch.MessageDispatcher
INTERNAL API
throughputDeadlineTime() - Method in class akka.testkit.CallingThreadDispatcher
 
throwable() - Method in class akka.testkit.ErrorFilter
 
TickDuration() - Method in class akka.actor.DefaultScheduler
 
TickDuration() - Method in class akka.actor.LightArrayRevolverScheduler
 
TickGenerator<Cmd,Evt> - Class in akka.io
This pipeline stage does not alter the events or commands
TickGenerator(FiniteDuration) - Constructor for class akka.io.TickGenerator
 
TickGenerator$ - Class in akka.io
 
TickGenerator$() - Constructor for class akka.io.TickGenerator$
 
TickGenerator.Tick - Class in akka.io
This message type is emitted by the TickGenerator to the whole pipeline, informing all stages about the time at which this Tick was emitted (relative to some arbitrary epoch).
TickGenerator.Tick(FiniteDuration) - Constructor for class akka.io.TickGenerator.Tick
 
TickGenerator.Tick$ - Class in akka.io
 
TickGenerator.Tick$() - Constructor for class akka.io.TickGenerator.Tick$
 
TickGenerator.Trigger - Interface in akka.io
This message type is used by the TickGenerator to trigger the rescheduling of the next Tick.
ticks() - Method in class akka.actor.LightArrayRevolverScheduler.TaskHolder
 
TicksPerWheel() - Method in class akka.actor.DefaultScheduler
 
time() - Method in class akka.cluster.VectorClock.Timestamp
 
timeout() - Method in class akka.actor.FSM.State
 
timeout() - Method in class akka.actor.IO.SoTimeout
 
timeout() - Method in class akka.actor.TypedProps
 
timeout() - Method in class akka.io.Tcp.Connect
 
timeout() - Method in interface akka.testkit.DefaultTimeout
 
Timeout - Interface in akka.util.internal
Deprecated. 
Timeout - Class in akka.util
 
Timeout(FiniteDuration) - Constructor for class akka.util.Timeout
 
Timeout(long) - Constructor for class akka.util.Timeout
 
Timeout(long, TimeUnit) - Constructor for class akka.util.Timeout
 
Timeout$ - Class in akka.util
 
Timeout$() - Constructor for class akka.util.Timeout$
 
TIMEOUT_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
timeoutFuture() - Method in interface akka.actor.FSM
 
Timer - Interface in akka.util.internal
Deprecated. 
TimerBasedThrottler - Class in akka.contrib.throttle
A throttler that uses a timer to control the message delivery rate.
TimerBasedThrottler(Throttler.Rate) - Constructor for class akka.contrib.throttle.TimerBasedThrottler
 
TimerBasedThrottler.Active$ - Class in akka.contrib.throttle
 
TimerBasedThrottler.Active$() - Constructor for class akka.contrib.throttle.TimerBasedThrottler.Active$
 
TimerBasedThrottler.Data - Class in akka.contrib.throttle
 
TimerBasedThrottler.Data(Option<ActorRef>, int, Queue<TimerBasedThrottler.Message>) - Constructor for class akka.contrib.throttle.TimerBasedThrottler.Data
 
TimerBasedThrottler.Data$ - Class in akka.contrib.throttle
 
TimerBasedThrottler.Data$() - Constructor for class akka.contrib.throttle.TimerBasedThrottler.Data$
 
TimerBasedThrottler.Idle$ - Class in akka.contrib.throttle
 
TimerBasedThrottler.Idle$() - Constructor for class akka.contrib.throttle.TimerBasedThrottler.Idle$
 
TimerBasedThrottler.Message - Class in akka.contrib.throttle
 
TimerBasedThrottler.Message(Object, ActorRef) - Constructor for class akka.contrib.throttle.TimerBasedThrottler.Message
 
TimerBasedThrottler.Message$ - Class in akka.contrib.throttle
 
TimerBasedThrottler.Message$() - Constructor for class akka.contrib.throttle.TimerBasedThrottler.Message$
 
TimerBasedThrottler.State - Interface in akka.contrib.throttle
 
TimerBasedThrottler.Tick$ - Class in akka.contrib.throttle
 
TimerBasedThrottler.Tick$() - Constructor for class akka.contrib.throttle.TimerBasedThrottler.Tick$
 
timerGen() - Method in interface akka.actor.FSM
 
timers() - Method in interface akka.actor.FSM
 
TimerTask - Interface in akka.util.internal
Deprecated. 
timestamp() - Method in class akka.cluster.NodeMetrics
 
timestamp() - Method in class akka.cluster.protobuf.msg.NodeMetrics
 
timestamp() - Method in class akka.cluster.protobuf.msg.VectorClock
 
timestamp() - Method in class akka.cluster.protobuf.msg.VectorClock.Version
 
timestamp() - Method in class akka.cluster.StandardMetrics.Cpu
 
timestamp() - Method in class akka.cluster.StandardMetrics.HeapMemory
 
timestamp() - Method in interface akka.event.Logging.LogEvent
When this LogEvent was created according to System.currentTimeMillis
timestamp(Logging.LogEvent) - Method in interface akka.event.Logging.StdOutLogger
 
timestamp() - Method in class akka.io.TickGenerator.Tick
 
TIMESTAMP_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.NodeMetrics$
 
TIMESTAMP_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.NodeMetrics
 
TIMESTAMP_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.VectorClock$
 
TIMESTAMP_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.VectorClock
 
TIMESTAMP_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.VectorClock.Version$
 
timeToAvailable(long, int) - Method in class akka.remote.transport.ThrottlerTransportAdapter.Blackhole$
 
timeToAvailable(long, int) - Method in interface akka.remote.transport.ThrottlerTransportAdapter.ThrottleMode
 
timeToAvailable(long, int) - Method in class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket
 
timeToAvailable(long, int) - Method in class akka.remote.transport.ThrottlerTransportAdapter.Unthrottled$
 
TimingTest - Class in akka.testkit
 
TimingTest() - Constructor for class akka.testkit.TimingTest
 
TimingTest$ - Class in akka.testkit
 
TimingTest$() - Constructor for class akka.testkit.TimingTest$
 
to() - Method in class akka.actor.FSM.Transition
 
to(ActorRef) - Method in class akka.camel.ActorRouteDefinition
Sends the message to an ActorRef endpoint.
to(ActorRef, boolean, Duration) - Method in class akka.camel.ActorRouteDefinition
Sends the message to an ActorRef endpoint
to() - Method in class akka.cluster.protobuf.msg.GossipEnvelope
 
to(ActorRef) - Method in class akka.pattern.PipeToSupport.PipeableFuture
 
to(ActorRef, ActorRef) - Method in class akka.pattern.PipeToSupport.PipeableFuture
 
to(ActorSelection) - Method in class akka.pattern.PipeToSupport.PipeableFuture
 
to(ActorSelection, ActorRef) - Method in class akka.pattern.PipeToSupport.PipeableFuture
 
TO_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.GossipEnvelope$
 
TO_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.GossipEnvelope
 
toAll(ActorRef, Iterable<ActorRef>) - Method in interface akka.routing.RouterConfig
 
toArray() - Method in class akka.util.BoundedBlockingQueue
 
toArray(X[]) - Method in class akka.util.BoundedBlockingQueue
 
toArray(ClassTag<B>) - Method in class akka.util.ByteIterator
 
toArray() - Method in class akka.util.ByteString
Java API: copy this ByteString into a fresh byte array
toArray(ClassTag<B>) - Method in class akka.util.ByteString
 
toBinary(Object) - Method in class akka.cluster.protobuf.ClusterMessageSerializer
 
toBinary(Object) - Method in class akka.remote.serialization.MessageContainerSerializer
 
toBinary(Object) - Method in class akka.remote.serialization.ProtobufSerializer
 
toBinary(Object) - Method in class akka.serialization.ByteArraySerializer
 
toBinary(Object) - Method in class akka.serialization.JavaSerializer
 
toBinary(Object) - Method in class akka.serialization.NullSerializer
 
toBinary(Object) - Method in interface akka.serialization.Serializer
Serializes the given object into an Array of Byte
toBuilder() - Method in class akka.cluster.protobuf.msg.Address
 
toBuilder() - Method in class akka.cluster.protobuf.msg.Empty
 
toBuilder() - Method in class akka.cluster.protobuf.msg.Gossip
 
toBuilder() - Method in class akka.cluster.protobuf.msg.GossipEnvelope
 
toBuilder() - Method in class akka.cluster.protobuf.msg.GossipOverview.Seen
 
toBuilder() - Method in class akka.cluster.protobuf.msg.GossipOverview
 
toBuilder() - Method in class akka.cluster.protobuf.msg.GossipStatus
 
toBuilder() - Method in class akka.cluster.protobuf.msg.Join
 
toBuilder() - Method in class akka.cluster.protobuf.msg.Member
 
toBuilder() - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
toBuilder() - Method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope
 
toBuilder() - Method in class akka.cluster.protobuf.msg.NodeMetrics.EWMA
 
toBuilder() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Metric
 
toBuilder() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number
 
toBuilder() - Method in class akka.cluster.protobuf.msg.NodeMetrics
 
toBuilder() - Method in class akka.cluster.protobuf.msg.UniqueAddress
 
toBuilder() - Method in class akka.cluster.protobuf.msg.VectorClock
 
toBuilder() - Method in class akka.cluster.protobuf.msg.VectorClock.Version
 
toBuilder() - Method in class akka.cluster.protobuf.msg.Welcome
 
toBuilder() - Method in class akka.remote.ContainerFormats.Selection
 
toBuilder() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
toBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
toBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
toBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
toBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
toBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
toBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
toBuilder() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
toBuilder() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
toBuilder() - Method in class akka.remote.WireFormats.ActorRefData
 
toBuilder() - Method in class akka.remote.WireFormats.AddressData
 
toBuilder() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
toBuilder() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
toBuilder() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
toBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
toBuilder() - Method in class akka.remote.WireFormats.DeployData
 
toBuilder() - Method in class akka.remote.WireFormats.PropsData
 
toBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
toBuilder() - Method in class akka.remote.WireFormats.SerializedMessage
 
toByteBuffer() - Method in class akka.util.ByteString
Creates a new ByteBuffer with a copy of all bytes contained in this ByteString.
toByteString() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
toByteString() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
toByteString() - Method in class akka.util.ByteIterator
 
token() - Method in class akka.io.Tcp.NoAck
 
token() - Method in class akka.io.Udp.NoAck
 
token() - Method in class akka.io.UdpConnected.NoAck
 
tokensPerSecond() - Method in class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket
 
toList() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
topic() - Method in class akka.contrib.pattern.ClusterClient.Publish
 
topic() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Publish
 
topic() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Subscribe
 
topic() - Method in class akka.contrib.pattern.DistributedPubSubMediator.Unsubscribe
 
toScala(ActorSelection) - Method in class akka.actor.ActorSelection$
 
toScala(ActorSelection) - Static method in class akka.actor.ActorSelection
 
toSeq() - Method in class akka.util.ByteIterator
 
toSerializationFormat() - Method in interface akka.actor.ActorPath
Generate full String representation including the uid for the actor cell instance as URI fragment.
toSerializationFormat() - Method in class akka.actor.ChildActorPath
 
toSerializationFormat() - Method in class akka.actor.RootActorPath
 
toSerializationFormatWithAddress(Address) - Method in interface akka.actor.ActorPath
Generate full String representation including the uid for the actor cell instance as URI fragment, replacing the Address in the RootActor Path with the given one unless this path’s address includes host and port information.
toSerializationFormatWithAddress(Address) - Method in class akka.actor.ChildActorPath
 
toSerializationFormatWithAddress(Address) - Method in class akka.actor.RootActorPath
 
toString() - Method in class akka.actor.ActorRef
 
toString() - Method in class akka.actor.ActorSelection
 
toString() - Method in class akka.actor.ActorSystem.Settings
Returns the String representation of the Config that this Settings is backed by
toString() - Method in class akka.actor.Address
Returns the canonical String representation of this Address formatted as:
toString() - Method in class akka.actor.ChildActorPath
 
toString() - Method in class akka.actor.mailbox.filebased.filequeue.Counter
 
toString() - Method in class akka.actor.RootActorPath
 
toString() - Method in class akka.camel.CamelMessage
 
toString() - Method in class akka.cluster.Member
 
toString() - Method in class akka.cluster.VectorClock.Timestamp
 
toString() - Method in class akka.cluster.VectorClock
 
toString() - Method in class akka.dispatch.Dispatcher
 
toString() - Method in class akka.event.Logging.StandardOutLogger
 
toString() - Method in class akka.osgi.impl.BundleDelegatingClassLoader
 
toString() - Method in class akka.remote.Ack
 
toString() - Method in class akka.remote.AckedReceiveBuffer
 
toString() - Method in class akka.remote.AckedSendBuffer
 
toString() - Method in class akka.remote.AssociationErrorEvent
 
toString() - Method in interface akka.remote.AssociationEvent
 
toString() - Method in class akka.remote.RemotingErrorEvent
 
toString() - Method in class akka.remote.RemotingListenEvent
 
toString() - Method in class akka.remote.RemotingShutdownEvent$
 
toString() - Static method in class akka.remote.RemotingShutdownEvent
 
toString() - Method in class akka.remote.SeqNo
 
toString() - Method in class akka.remote.transport.AssociationHandle.InboundPayload
 
toString() - Method in class akka.remote.transport.netty.NettyTransportSettings.Tcp$
 
toString() - Method in class akka.remote.transport.netty.NettyTransportSettings.Udp$
 
toString() - Method in class akka.remote.transport.TestTransport
 
toString() - Method in class akka.testkit.TestActorRef
 
toString() - Method in class akka.zeromq.ZeroMQVersion
 
toStringWithAddress(Address) - Method in interface akka.actor.ActorPath
Generate String representation, replacing the Address in the RootActor Path with the given one unless this path’s address includes host and port information.
toStringWithAddress(Address) - Method in class akka.actor.ChildActorPath
 
toStringWithAddress(Address) - Method in class akka.actor.RootActorPath
 
total2pf(Function2<S, S, BoxedUnit>) - Method in interface akka.actor.FSM
Convenience wrapper for using a total function instead of a partial function literal.
totalAdded() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
totalDiscarded() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
totalExpired() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
totalInstances() - Method in class akka.cluster.routing.ClusterRouterSettings
 
totalItems() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
toUri(ActorRef) - Method in class akka.camel.internal.component.CamelPath$
Converts the actorRef to a Camel URI (string) which can be used in custom routes.
toUri(ActorRef, boolean, Duration) - Method in class akka.camel.internal.component.CamelPath$
Converts the actorRef to a Camel URI (string) which can be used in custom routes.
toUri(ActorRef) - Static method in class akka.camel.internal.component.CamelPath
Converts the actorRef to a Camel URI (string) which can be used in custom routes.
toUri(ActorRef, boolean, Duration) - Static method in class akka.camel.internal.component.CamelPath
Converts the actorRef to a Camel URI (string) which can be used in custom routes.
TraceLogging() - Method in class akka.io.SelectionHandlerSettings
 
TrafficClass() - Method in interface akka.io.Inet.SoForwarders
Inet.SocketOption to set the traffic class or type-of-service octet in the IP header for packets sent from this socket.
trafficClass(int) - Method in interface akka.io.Inet.SoJavaFactories
Inet.SocketOption to set the traffic class or type-of-service octet in the IP header for packets sent from this socket.
Transactor - Interface in akka.transactor
An actor with built-in support for coordinated transactions.
TransactorExtension - Class in akka.transactor
TransactorExtension is an Akka Extension to hold settings for transactors.
TransactorExtension() - Constructor for class akka.transactor.TransactorExtension
 
TransactorExtension$ - Class in akka.transactor
TransactorExtension is an Akka Extension to hold settings for transactors.
TransactorExtension$() - Constructor for class akka.transactor.TransactorExtension$
 
TransactorSettings - Class in akka.transactor
 
TransactorSettings(com.typesafe.config.Config) - Constructor for class akka.transactor.TransactorSettings
 
transcend(boolean, Function0<BoxedUnit>) - Method in class akka.util.Switch
 
TransferToLimit() - Method in class akka.io.TcpExt.Settings
 
transform(PartialFunction<FSM.Event, FSM.State<S, D>>) - Method in interface akka.actor.FSM
 
transformOutgoingMessage(Object) - Method in class akka.camel.javaapi.UntypedProducerActor
 
transformOutgoingMessage(Object) - Method in interface akka.camel.ProducerSupport
Called before the message is sent to the endpoint specified by endpointUri.
transformResponse(Object) - Method in class akka.camel.javaapi.UntypedProducerActor
 
transformResponse(Object) - Method in interface akka.camel.ProducerSupport
Called before the response message is sent to the original sender.
transitionEvent() - Method in interface akka.actor.FSM
 
transport() - Method in class akka.remote.testconductor.TestConductorExt
Remote transport used by the actor ref provider.
transport() - Method in class akka.remote.transport.TestAssociationHandle
 
Transport - Interface in akka.remote.transport
An SPI layer for implementing asynchronous transport mechanisms.
Transport$ - Class in akka.remote.transport
 
Transport$() - Constructor for class akka.remote.transport.Transport$
 
Transport.ActorAssociationEventListener - Class in akka.remote.transport
Class to convert ordinary ActorRef instances to an AssociationEventListener.
Transport.ActorAssociationEventListener(ActorRef) - Constructor for class akka.remote.transport.Transport.ActorAssociationEventListener
 
Transport.ActorAssociationEventListener$ - Class in akka.remote.transport
 
Transport.ActorAssociationEventListener$() - Constructor for class akka.remote.transport.Transport.ActorAssociationEventListener$
 
Transport.AssociationEvent - Interface in akka.remote.transport
 
Transport.AssociationEventListener - Interface in akka.remote.transport
An interface that needs to be implemented by the user of a transport to listen to association events
Transport.InboundAssociation - Class in akka.remote.transport
Message sent to a Transport.AssociationEventListener registered to a transport (via the Promise returned by akka.remote.transport.Transport.listen) when an inbound association request arrives.
Transport.InboundAssociation(AssociationHandle) - Constructor for class akka.remote.transport.Transport.InboundAssociation
 
Transport.InboundAssociation$ - Class in akka.remote.transport
 
Transport.InboundAssociation$() - Constructor for class akka.remote.transport.Transport.InboundAssociation$
 
Transport.InvalidAssociationException - Exception in akka.remote.transport
Indicates that the association setup request is invalid, and it is impossible to recover (malformed IP address, hostname, etc.).
Transport.InvalidAssociationException(String, Throwable) - Constructor for exception akka.remote.transport.Transport.InvalidAssociationException
 
Transport.InvalidAssociationException$ - Class in akka.remote.transport
 
Transport.InvalidAssociationException$() - Constructor for class akka.remote.transport.Transport.InvalidAssociationException$
 
TransportAdapterProvider - Interface in akka.remote.transport
 
TransportAdapters - Class in akka.remote.transport
 
TransportAdapters(ExtendedActorSystem) - Constructor for class akka.remote.transport.TransportAdapters
 
TransportAdaptersExtension - Class in akka.remote.transport
 
TransportAdaptersExtension() - Constructor for class akka.remote.transport.TransportAdaptersExtension
 
TransportAdaptersExtension$ - Class in akka.remote.transport
 
TransportAdaptersExtension$() - Constructor for class akka.remote.transport.TransportAdaptersExtension$
 
transportFor(Address) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Returns the Transport bound to the given address.
TransportMode() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
Transports() - Method in class akka.remote.RemoteSettings
 
transportsReady(Seq<Address>) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Indicates if all given transports were successfully registered.
traverse(M, Function1<A, IO.Iteratee<B>>, CanBuildFrom<M, B, M>) - Method in class akka.actor.IO$
An Iteratee that applies an Iteratee to each element of a Traversable and finally returning a single Iteratee containing a Traversable of the results.
traverse(M, Function1<A, IO.Iteratee<B>>, CanBuildFrom<M, B, M>) - Static method in class akka.actor.IO
An Iteratee that applies an Iteratee to each element of a Traversable and finally returning a single Iteratee containing a Traversable of the results.
traverse(Iterable<A>, Function<A, Future<B>>, ExecutionContext) - Method in class akka.dispatch.Futures$
Transforms a JIterable[A] into a Future[JIterable[B} using the provided Function A ⇒ Future[B].
traverse(Iterable<A>, Function<A, Future<B>>, ExecutionContext) - Static method in class akka.dispatch.Futures
Transforms a JIterable[A] into a Future[JIterable[B} using the provided Function A ⇒ Future[B].
tries() - Method in class akka.contrib.mailbox.PeekMailbox
 
tryConsumeTokens(long, int) - Method in class akka.remote.transport.ThrottlerTransportAdapter.Blackhole$
 
tryConsumeTokens(long, int) - Method in interface akka.remote.transport.ThrottlerTransportAdapter.ThrottleMode
 
tryConsumeTokens(long, int) - Method in class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket
 
tryConsumeTokens(long, int) - Method in class akka.remote.transport.ThrottlerTransportAdapter.Unthrottled$
 
tunnel() - Method in class akka.contrib.pattern.ReliableProxy
 
type() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number
 
TYPE_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number$
 
TYPE_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.Selection
 
typedActor() - Method in class akka.actor.ContextualTypedActorFactory
 
TypedActor - Class in akka.actor
This represents the TypedActor Akka Extension, access to the functionality is done through a given ActorSystem.
TypedActor() - Constructor for class akka.actor.TypedActor
 
typedActor() - Method in class akka.actor.TypedActorExtension
 
typedActor() - Method in interface akka.actor.TypedActorFactory
Underlying dependency to a TypedActorExtension, which can either be contextual or ActorSystem "global"
TypedActor$ - Class in akka.actor
This represents the TypedActor Akka Extension, access to the functionality is done through a given ActorSystem.
TypedActor$() - Constructor for class akka.actor.TypedActor$
 
TypedActor.MethodCall - Class in akka.actor
This class represents a Method call, and has a reference to the Method to be called and the parameters to supply It's sent to the ActorRef backing the TypedActor and can be serialized and deserialized
TypedActor.MethodCall(Method, Object[]) - Constructor for class akka.actor.TypedActor.MethodCall
 
TypedActor.MethodCall$ - Class in akka.actor
 
TypedActor.MethodCall$() - Constructor for class akka.actor.TypedActor.MethodCall$
 
TypedActor.PostRestart - Interface in akka.actor
 
TypedActor.PostStop - Interface in akka.actor
Mix this into your TypedActor to be able to hook into its lifecycle
TypedActor.PreRestart - Interface in akka.actor
Mix this into your TypedActor to be able to hook into its lifecycle
TypedActor.PreStart - Interface in akka.actor
Mix this into your TypedActor to be able to hook into its lifecycle
TypedActor.Receiver - Interface in akka.actor
Mix this into your TypedActor to be able to intercept Terminated messages
TypedActor.Supervisor - Interface in akka.actor
Mix this into your TypedActor to be able to define supervisor strategy
TypedActorExtension - Class in akka.actor
 
TypedActorExtension(ExtendedActorSystem) - Constructor for class akka.actor.TypedActorExtension
 
TypedActorFactory - Interface in akka.actor
A TypedActorFactory is something that can created TypedActor instances.
typedActorOf(TypedProps<T>) - Method in interface akka.actor.TypedActorFactory
Creates a new TypedActor with the specified properties
typedActorOf(TypedProps<T>, String) - Method in interface akka.actor.TypedActorFactory
Creates a new TypedActor with the specified properties
typedActorOf(TypedProps<T>, ActorRef) - Method in interface akka.actor.TypedActorFactory
Creates a TypedActor that intercepts the calls and forwards them as TypedActor.MethodCall to the provided ActorRef.
TypedCreatorFunctionConsumerClass() - Method in interface akka.actor.IndirectActorProducer
 
TypedProps<T> - Class in akka.actor
TypedProps is a TypedActor configuration object, that is thread safe and fully sharable.
TypedProps(Seq<Class<?>>, Function0<T>, String, Deploy, Option<Timeout>, Option<ClassLoader>) - Constructor for class akka.actor.TypedProps
 
TypedProps(Class<T>) - Constructor for class akka.actor.TypedProps
Uses the supplied class as the factory for the TypedActor implementation, and that has the specified interface, or if the interface class is not an interface, all the interfaces it implements, appended in the sequence of interfaces.
TypedProps(Class<? super T>, Creator<T>) - Constructor for class akka.actor.TypedProps
Java API: Uses the supplied Creator as the factory for the TypedActor implementation, and that has the specified interface, or if the interface class is not an interface, all the interfaces it implements, appended in the sequence of interfaces.
TypedProps(Class<? super T>, Class<T>) - Constructor for class akka.actor.TypedProps
Java API: Uses the supplied class as the factory for the TypedActor implementation, and that has the specified interface, or if the interface class is not an interface, all the interfaces it implements, appended in the sequence of interfaces.
TypedProps$ - Class in akka.actor
TypedProps is a TypedActor configuration object, that is thread safe and fully sharable.
TypedProps$() - Constructor for class akka.actor.TypedProps$
 

U

Udp - Class in akka.io
UDP Extension for Akka’s IO layer.
Udp() - Constructor for class akka.io.Udp
 
Udp$ - Class in akka.io
UDP Extension for Akka’s IO layer.
Udp$() - Constructor for class akka.io.Udp$
 
Udp.Bind - Class in akka.io
Send this message to the UdpExt.manager() in order to bind to the given local port (or an automatically assigned one if the port number is zero).
Udp.Bind(ActorRef, InetSocketAddress, Traversable<Inet.SocketOption>) - Constructor for class akka.io.Udp.Bind
 
Udp.Bind$ - Class in akka.io
 
Udp.Bind$() - Constructor for class akka.io.Udp.Bind$
 
Udp.Bound - Class in akka.io
This message is sent by the listener actor in response to a Udp.Bind command.
Udp.Bound(InetSocketAddress) - Constructor for class akka.io.Udp.Bound
 
Udp.Bound$ - Class in akka.io
 
Udp.Bound$() - Constructor for class akka.io.Udp.Bound$
 
Udp.Command - Interface in akka.io
The common type of all commands supported by the UDP implementation.
Udp.CommandFailed - Class in akka.io
When a command fails it will be replied to with this message type, wrapping the failing command object.
Udp.CommandFailed(Udp.Command) - Constructor for class akka.io.Udp.CommandFailed
 
Udp.CommandFailed$ - Class in akka.io
 
Udp.CommandFailed$() - Constructor for class akka.io.Udp.CommandFailed$
 
Udp.Event - Interface in akka.io
The common type of all events emitted by the UDP implementation.
Udp.Message - Interface in akka.io
The common interface for Udp.Command and Udp.Event.
Udp.NoAck - Class in akka.io
Each Udp.Send can optionally request a positive acknowledgment to be sent to the commanding actor.
Udp.NoAck(Object) - Constructor for class akka.io.Udp.NoAck
 
Udp.NoAck$ - Class in akka.io
Default Udp.NoAck instance which is used when no acknowledgment information is explicitly provided.
Udp.NoAck$() - Constructor for class akka.io.Udp.NoAck$
 
Udp.Received - Class in akka.io
When a listener actor receives a datagram from its socket it will send it to the handler designated in the Udp.Bind message using this message type.
Udp.Received(ByteString, InetSocketAddress) - Constructor for class akka.io.Udp.Received
 
Udp.Received$ - Class in akka.io
 
Udp.Received$() - Constructor for class akka.io.Udp.Received$
 
Udp.ResumeReading$ - Class in akka.io
This message must be sent to the listener actor to re-enable reading from the socket after a SuspendReading command.
Udp.ResumeReading$() - Constructor for class akka.io.Udp.ResumeReading$
 
Udp.Send - Class in akka.io
This message is understood by the “simple sender” which can be obtained by sending the Udp.SimpleSender query to the UdpExt.manager() as well as by the listener actors which are created in response to Udp.Bind.
Udp.Send(ByteString, InetSocketAddress, Udp.Event) - Constructor for class akka.io.Udp.Send
 
Udp.Send$ - Class in akka.io
 
Udp.Send$() - Constructor for class akka.io.Udp.Send$
 
Udp.SimpleSender - Class in akka.io
Retrieve a reference to a “simple sender” actor of the UDP extension.
Udp.SimpleSender(Traversable<Inet.SocketOption>) - Constructor for class akka.io.Udp.SimpleSender
 
Udp.SimpleSender$ - Class in akka.io
 
Udp.SimpleSender$() - Constructor for class akka.io.Udp.SimpleSender$
 
Udp.SimpleSenderReady - Interface in akka.io
The “simple sender” sends this message type in response to a Udp.SimpleSender query.
Udp.SimpleSenderReady$ - Class in akka.io
 
Udp.SimpleSenderReady$() - Constructor for class akka.io.Udp.SimpleSenderReady$
 
Udp.SO$ - Class in akka.io
Scala API: This object provides access to all socket options applicable to UDP sockets.
Udp.SO$() - Constructor for class akka.io.Udp.SO$
 
Udp.SO$.Broadcast - Class in akka.io
Inet.SocketOption to set the SO_BROADCAST option
Udp.SO$.Broadcast(boolean) - Constructor for class akka.io.Udp.SO$.Broadcast
 
Udp.SuspendReading$ - Class in akka.io
Send this message to a listener actor (which sent a Udp.Bound message) to have it stop reading datagrams from the network.
Udp.SuspendReading$() - Constructor for class akka.io.Udp.SuspendReading$
 
Udp.Unbind$ - Class in akka.io
Send this message to the listener actor that previously sent a Udp.Bound message in order to close the listening socket.
Udp.Unbind$() - Constructor for class akka.io.Udp.Unbind$
 
Udp.Unbound - Interface in akka.io
This message is sent by the listener actor in response to an Unbind command after the socket has been closed.
Udp.Unbound$ - Class in akka.io
 
Udp.Unbound$() - Constructor for class akka.io.Udp.Unbound$
 
UdpConnected - Class in akka.io
UDP Extension for Akka’s IO layer.
UdpConnected() - Constructor for class akka.io.UdpConnected
 
UdpConnected$ - Class in akka.io
UDP Extension for Akka’s IO layer.
UdpConnected$() - Constructor for class akka.io.UdpConnected$
 
UdpConnected.Command - Interface in akka.io
The common type of all commands supported by the UDP implementation.
UdpConnected.CommandFailed - Class in akka.io
When a command fails it will be replied to with this message type, wrapping the failing command object.
UdpConnected.CommandFailed(UdpConnected.Command) - Constructor for class akka.io.UdpConnected.CommandFailed
 
UdpConnected.CommandFailed$ - Class in akka.io
 
UdpConnected.CommandFailed$() - Constructor for class akka.io.UdpConnected.CommandFailed$
 
UdpConnected.Connect - Class in akka.io
Send this message to the UdpExt.manager() in order to bind to a local port (optionally with the chosen localAddress) and create a UDP socket which is restricted to sending to and receiving from the given remoteAddress.
UdpConnected.Connect(ActorRef, InetSocketAddress, Option<InetSocketAddress>, Traversable<Inet.SocketOption>) - Constructor for class akka.io.UdpConnected.Connect
 
UdpConnected.Connect$ - Class in akka.io
 
UdpConnected.Connect$() - Constructor for class akka.io.UdpConnected.Connect$
 
UdpConnected.Connected - Interface in akka.io
This message is sent by the connection actor to the actor which sent the UdpConnected.Connect message when the UDP socket has been bound to the local and remote addresses given.
UdpConnected.Connected$ - Class in akka.io
 
UdpConnected.Connected$() - Constructor for class akka.io.UdpConnected.Connected$
 
UdpConnected.Disconnect$ - Class in akka.io
Send this message to a connection actor (which had previously sent the UdpConnected.Connected message) in order to close the socket.
UdpConnected.Disconnect$() - Constructor for class akka.io.UdpConnected.Disconnect$
 
UdpConnected.Disconnected - Interface in akka.io
This message is sent by the connection actor to the actor which sent the Disconnect message when the UDP socket has been closed.
UdpConnected.Disconnected$ - Class in akka.io
 
UdpConnected.Disconnected$() - Constructor for class akka.io.UdpConnected.Disconnected$
 
UdpConnected.Event - Interface in akka.io
The common type of all events emitted by the UDP implementation.
UdpConnected.Message - Interface in akka.io
The common interface for UdpConnected.Command and UdpConnected.Event.
UdpConnected.NoAck - Class in akka.io
Each UdpConnected.Send can optionally request a positive acknowledgment to be sent to the commanding actor.
UdpConnected.NoAck(Object) - Constructor for class akka.io.UdpConnected.NoAck
 
UdpConnected.NoAck$ - Class in akka.io
Default UdpConnected.NoAck instance which is used when no acknowledgment information is explicitly provided.
UdpConnected.NoAck$() - Constructor for class akka.io.UdpConnected.NoAck$
 
UdpConnected.Received - Class in akka.io
When a connection actor receives a datagram from its socket it will send it to the handler designated in the Udp.Bind message using this message type.
UdpConnected.Received(ByteString) - Constructor for class akka.io.UdpConnected.Received
 
UdpConnected.Received$ - Class in akka.io
 
UdpConnected.Received$() - Constructor for class akka.io.UdpConnected.Received$
 
UdpConnected.ResumeReading$ - Class in akka.io
This message must be sent to the listener actor to re-enable reading from the socket after a SuspendReading command.
UdpConnected.ResumeReading$() - Constructor for class akka.io.UdpConnected.ResumeReading$
 
UdpConnected.Send - Class in akka.io
This message is understood by the connection actors to send data to their designated destination.
UdpConnected.Send(ByteString, Object) - Constructor for class akka.io.UdpConnected.Send
 
UdpConnected.Send$ - Class in akka.io
 
UdpConnected.Send$() - Constructor for class akka.io.UdpConnected.Send$
 
UdpConnected.SuspendReading$ - Class in akka.io
Send this message to a listener actor (which sent a Udp.Bound message) to have it stop reading datagrams from the network.
UdpConnected.SuspendReading$() - Constructor for class akka.io.UdpConnected.SuspendReading$
 
UdpConnectedExt - Class in akka.io
 
UdpConnectedExt(ExtendedActorSystem) - Constructor for class akka.io.UdpConnectedExt
 
UdpConnectedMessage - Class in akka.io
Java API: factory methods for the message types used when communicating with the UdpConnected service.
UdpConnectedMessage() - Constructor for class akka.io.UdpConnectedMessage
 
UdpConnectedMessage$ - Class in akka.io
Java API: factory methods for the message types used when communicating with the UdpConnected service.
UdpConnectedMessage$() - Constructor for class akka.io.UdpConnectedMessage$
 
udpConnectionTable() - Method in class akka.remote.transport.netty.NettyTransport
INTERNAL API
UdpExt - Class in akka.io
 
UdpExt(ExtendedActorSystem) - Constructor for class akka.io.UdpExt
 
UdpMessage - Class in akka.io
Java API: factory methods for the message types used when communicating with the Udp service.
UdpMessage() - Constructor for class akka.io.UdpMessage
 
UdpMessage$ - Class in akka.io
Java API: factory methods for the message types used when communicating with the Udp service.
UdpMessage$() - Constructor for class akka.io.UdpMessage$
 
UdpSO - Class in akka.io
 
UdpSO() - Constructor for class akka.io.UdpSO
 
UdpSO$ - Class in akka.io
 
UdpSO$() - Constructor for class akka.io.UdpSO$
 
uid() - Method in interface akka.actor.ActorPath
INTERNAL API Unique identifier of the actor.
uid() - Method in class akka.actor.ChildActorPath
 
uid() - Method in class akka.actor.ChildRestartStats
 
uid() - Method in class akka.cluster.protobuf.msg.UniqueAddress
 
uid() - Method in class akka.remote.transport.HandshakeInfo
 
UID_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.UniqueAddress$
 
UID_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.UniqueAddress
 
UID_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AkkaHandshakeInfo
 
unapply(ActorInitializationException) - Method in class akka.actor.ActorInitializationException$
 
unapply(ActorInitializationException) - Static method in exception akka.actor.ActorInitializationException
 
unapply(String) - Method in class akka.actor.ActorPathExtractor$
 
unapply(String) - Static method in class akka.actor.ActorPathExtractor
 
unapply(String) - Method in class akka.actor.AddressFromURIString$
 
unapply(URI) - Method in class akka.actor.AddressFromURIString$
 
unapply(String) - Static method in class akka.actor.AddressFromURIString
 
unapply(URI) - Static method in class akka.actor.AddressFromURIString
 
unapply(Tuple2<S, S>) - Method in class akka.actor.FSM.$minus$greater$
 
unapply(PostRestartException) - Method in class akka.actor.OriginalRestartException$
 
unapply(PostRestartException) - Static method in class akka.actor.OriginalRestartException
 
unapply(Props, int) - Method in class akka.actor.Props$
The deprecated legacy extractor.
unapply(Props, int) - Static method in class akka.actor.Props
The deprecated legacy extractor.
unapply(String) - Method in class akka.actor.RelativeActorPath$
 
unapply(String) - Static method in class akka.actor.RelativeActorPath
 
unapply(NodeMetrics) - Method in class akka.cluster.StandardMetrics.Cpu$
Given a NodeMetrics it returns the Cpu data if the nodeMetrics contains necessary cpu metrics.
unapply(NodeMetrics) - Method in class akka.cluster.StandardMetrics.HeapMemory$
Given a NodeMetrics it returns the HeapMemory data if the nodeMetrics contains necessary heap metrics.
unapply(FromConfig) - Method in class akka.routing.FromConfig$
 
unapply(FromConfig) - Static method in class akka.routing.FromConfig
 
unapply(Coordinated) - Method in class akka.transactor.Coordinated$
 
unapply(Coordinated) - Static method in class akka.transactor.Coordinated
 
unbatchedExecute(Runnable) - Method in class akka.dispatch.MessageDispatcher
 
unbecome() - Method in interface akka.actor.ActorContext
Reverts the Actor behavior to the previous one in the hotswap stack.
unbecome() - Method in interface akka.actor.dsl.Creators.Act
Pop the active behavior from the behavior stack of this actor.
unbind() - Method in class akka.io.TcpMessage$
In order to close down a listening socket, send this message to that socket’s actor (that is the actor which previously had sent the Tcp.Bound message).
unbind() - Static method in class akka.io.TcpMessage
In order to close down a listening socket, send this message to that socket’s actor (that is the actor which previously had sent the Tcp.Bound message).
unbind() - Method in class akka.io.UdpMessage$
Send this message to the listener actor that previously sent a Udp.Bound message in order to close the listening socket.
unbind() - Static method in class akka.io.UdpMessage
Send this message to the listener actor that previously sent a Udp.Bound message in order to close the listening socket.
UnboundedDequeBasedMailbox - Class in akka.dispatch
UnboundedDequeBasedMailbox is an unbounded MailboxType, backed by a Deque.
UnboundedDequeBasedMailbox() - Constructor for class akka.dispatch.UnboundedDequeBasedMailbox
 
UnboundedDequeBasedMailbox(ActorSystem.Settings, com.typesafe.config.Config) - Constructor for class akka.dispatch.UnboundedDequeBasedMailbox
 
UnboundedDequeBasedMailbox$ - Class in akka.dispatch
 
UnboundedDequeBasedMailbox$() - Constructor for class akka.dispatch.UnboundedDequeBasedMailbox$
 
UnboundedDequeBasedMailbox.MessageQueue - Class in akka.dispatch
 
UnboundedDequeBasedMailbox.MessageQueue() - Constructor for class akka.dispatch.UnboundedDequeBasedMailbox.MessageQueue
 
UnboundedDequeBasedMessageQueue - Interface in akka.dispatch
UnboundedDequeBasedMessageQueueSemantics adds unbounded semantics to a DequeBasedMessageQueue, i.e.
UnboundedDequeBasedMessageQueueSemantics - Interface in akka.dispatch
 
UnboundedMailbox - Class in akka.dispatch
UnboundedMailbox is the default unbounded MailboxType used by Akka Actors.
UnboundedMailbox() - Constructor for class akka.dispatch.UnboundedMailbox
 
UnboundedMailbox(ActorSystem.Settings, com.typesafe.config.Config) - Constructor for class akka.dispatch.UnboundedMailbox
 
UnboundedMailbox$ - Class in akka.dispatch
 
UnboundedMailbox$() - Constructor for class akka.dispatch.UnboundedMailbox$
 
UnboundedMailbox.MessageQueue - Class in akka.dispatch
 
UnboundedMailbox.MessageQueue() - Constructor for class akka.dispatch.UnboundedMailbox.MessageQueue
 
UnboundedMessageQueueSemantics - Interface in akka.dispatch
UnboundedMessageQueueSemantics adds unbounded semantics to a QueueBasedMessageQueue, i.e.
UnboundedPriorityMailbox - Class in akka.dispatch
UnboundedPriorityMailbox is an unbounded mailbox that allows for prioritization of its contents.
UnboundedPriorityMailbox(Comparator<Envelope>, int) - Constructor for class akka.dispatch.UnboundedPriorityMailbox
 
UnboundedPriorityMailbox(Comparator<Envelope>) - Constructor for class akka.dispatch.UnboundedPriorityMailbox
 
UnboundedPriorityMailbox$ - Class in akka.dispatch
 
UnboundedPriorityMailbox$() - Constructor for class akka.dispatch.UnboundedPriorityMailbox$
 
UnboundedPriorityMailbox.MessageQueue - Class in akka.dispatch
 
UnboundedPriorityMailbox.MessageQueue(int, Comparator<Envelope>) - Constructor for class akka.dispatch.UnboundedPriorityMailbox.MessageQueue
 
UnboundedQueueBasedMessageQueue - Interface in akka.dispatch
 
UnboundedStash - Interface in akka.actor
The UnboundedStash trait is a version of Stash that enforces an unbounded stash for you actor.
underlyingActor() - Method in class akka.testkit.TestActorRef
Retrieve reference to the underlying actor, where the static type matches the factory used inside the constructor.
unexpect(PartialFunction<Object, BoxedUnit>) - Method in interface akka.contrib.pattern.Aggregator
Removes the partial function from the receive set.
unhandled(Object) - Method in interface akka.actor.Actor
User overridable callback.
unhandled(Object) - Method in class akka.actor.UntypedActor
Recommended convention is to call this method if the message isn't handled in UntypedActor.onReceive(java.lang.Object) (e.g.
UnhandledMessage - Class in akka.actor
This message is published to the EventStream whenever an Actor receives a message it doesn't understand
UnhandledMessage(Object, ActorRef, ActorRef) - Constructor for class akka.actor.UnhandledMessage
 
UnhandledMessage$ - Class in akka.actor
 
UnhandledMessage$() - Constructor for class akka.actor.UnhandledMessage$
 
uninitialisedReceive() - Method in class akka.osgi.DefaultOSGiLogger
Behaviour of the logger that waits for its LogService
uniqueAddress() - Method in class akka.cluster.Member
INTERNAL API
UniqueAddress - Class in akka.cluster.protobuf.msg
 
UniqueAddress(Address, int) - Constructor for class akka.cluster.protobuf.msg.UniqueAddress
 
UniqueAddress$ - Class in akka.cluster.protobuf.msg
 
UniqueAddress$() - Constructor for class akka.cluster.protobuf.msg.UniqueAddress$
 
UniqueId() - Method in class akka.remote.transport.ThrottlerTransportAdapter$
 
UniqueId() - Static method in class akka.remote.transport.ThrottlerTransportAdapter
 
uniqueIdCounter() - Static method in class akka.remote.transport.netty.NettyTransport
 
unit() - Method in class akka.actor.IO.Iteratee$
The single value representing Done(())
UnknownAddressGateClosedFor() - Method in class akka.remote.RemoteSettings
 
unpack(byte[]) - Method in class akka.actor.mailbox.filebased.filequeue.QItem$
 
unpack(byte[]) - Static method in class akka.actor.mailbox.filebased.filequeue.QItem
 
unpackOldAdd(byte[]) - Method in class akka.actor.mailbox.filebased.filequeue.QItem$
 
unpackOldAdd(byte[]) - Static method in class akka.actor.mailbox.filebased.filequeue.QItem
 
unreachable() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
 
unreachable() - Method in class akka.cluster.protobuf.msg.GossipOverview
 
UNREACHABLE_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.GossipOverview$
 
UNREACHABLE_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.GossipOverview
 
UnreachableNodesReaperInterval() - Method in class akka.cluster.ClusterSettings
 
unregister(ActorRef) - Method in class akka.contrib.mailbox.PeekMailboxExtension
 
unregister(akka.actor.ActorCell) - Method in class akka.dispatch.BalancingDispatcher
 
unregister(akka.actor.ActorCell) - Method in class akka.dispatch.MessageDispatcher
If you override it, you must call it.
unregister(akka.actor.ActorCell) - Method in class akka.dispatch.PinnedDispatcher
 
unregister(akka.actor.ActorCell) - Method in class akka.testkit.CallingThreadDispatcher
 
UnregisteringLogService - Class in akka.osgi
Message sent when LogService is unregistred.
UnregisteringLogService() - Constructor for class akka.osgi.UnregisteringLogService
 
UnregisteringLogService$ - Class in akka.osgi
Message sent when LogService is unregistred.
UnregisteringLogService$() - Constructor for class akka.osgi.UnregisteringLogService$
 
unregisterRoutees(Iterable<ActorRef>) - Method in class akka.routing.RouteeProvider
Removes routees from the router.
unregisterRoutees(Iterable<ActorRef>) - Method in class akka.routing.RouteeProvider
Java API: Removes routees from the router.
unregisterService(ActorRef) - Method in class akka.contrib.pattern.ClusterReceptionistExtension
A registered actor will be automatically unregistered when terminated, but it can also be explicitly unregistered before termination.
unregisterSubscriber(String, ActorRef) - Method in class akka.contrib.pattern.ClusterReceptionistExtension
A registered subscriber will be automatically unregistered when terminated, but it can also be explicitly unregistered before termination.
unregisterTempActor(ActorPath) - Method in interface akka.actor.ActorRefProvider
Unregister a temporary actor from the “/temp” path (i.e.
unremove(int) - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
unremove(int) - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
Return a transactionally-removed item to the queue.
unremove(String, int) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
UnrestrictedStash - Interface in akka.actor
A version of Stash that does not enforce any mailbox type.
Unsafe - Class in akka.util
INTERNAL API
Unsafe() - Constructor for class akka.util.Unsafe
 
UNSCHEDULED() - Static method in class akka.dispatch.MessageDispatcher
 
UnstartedPushTimeout() - Method in class akka.actor.ActorSystem.Settings
 
unstashAll() - Method in interface akka.actor.UnrestrictedStash
Prepends all messages in the stash to the mailbox, and then clears the stash.
unsubscribe(ActorRef) - Method in class akka.cluster.Cluster
Unsubscribe to all cluster domain events.
unsubscribe(ActorRef, Class<?>) - Method in class akka.cluster.Cluster
Unsubscribe to a specific type of cluster domain events, matching previous subscribe registration.
unsubscribe() - Method in class akka.contrib.pattern.DistributedPubSubMediator.UnsubscribeAck
 
unsubscribe(ActorRef, ActorRef) - Method in interface akka.event.ActorClassification
 
unsubscribe(ActorRef) - Method in interface akka.event.ActorClassification
 
unsubscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.EventBus
Attempts to deregister the subscriber from the specified Classifier
unsubscribe(akka.event.EventBus.Subscriber) - Method in interface akka.event.EventBus
Attempts to deregister the subscriber from all Classifiers it may be subscribed to
unsubscribe(ActorRef, Class<?>) - Method in class akka.event.EventStream
 
unsubscribe(ActorRef) - Method in class akka.event.EventStream
 
unsubscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.LookupClassification
 
unsubscribe(akka.event.EventBus.Subscriber) - Method in interface akka.event.LookupClassification
 
unsubscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.ScanningClassification
 
unsubscribe(akka.event.EventBus.Subscriber) - Method in interface akka.event.ScanningClassification
 
unsubscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.SubchannelClassification
 
unsubscribe(akka.event.EventBus.Subscriber) - Method in interface akka.event.SubchannelClassification
 
Unsubscribe - Class in akka.zeromq
The Unsubscribe option shall remove an existing message filter on a akka.zeromq.SocketType.Sub socket.
Unsubscribe(ByteString) - Constructor for class akka.zeromq.Unsubscribe
 
Unsubscribe(String) - Constructor for class akka.zeromq.Unsubscribe
 
Unsubscribe$ - Class in akka.zeromq
 
Unsubscribe$() - Constructor for class akka.zeromq.Unsubscribe$
 
UntrustedMode() - Method in class akka.remote.RemoteSettings
 
UntypedActor - Class in akka.actor
Actor base trait that should be extended by or mixed to create an Actor with the semantics of the 'Actor Model': http://en.wikipedia.org/wiki/Actor_model
UntypedActor() - Constructor for class akka.actor.UntypedActor
 
UntypedActorContext - Interface in akka.actor
UntypedActorContext is the UntypedActor equivalent of ActorContext, containing the Java API
UntypedActorFactory - Interface in akka.actor
Factory closure for an UntypedActor, to be used with 'Actors.actorOf(factory)'.
UntypedActorFactoryConsumerClass() - Method in interface akka.actor.IndirectActorProducer
 
UntypedActorWithStash - Class in akka.actor
Actor base class that should be extended to create an actor with a stash.
UntypedActorWithStash() - Constructor for class akka.actor.UntypedActorWithStash
 
UntypedActorWithUnboundedStash - Class in akka.actor
Actor base class with Stash that enforces an unbounded deque for the actor.
UntypedActorWithUnboundedStash() - Constructor for class akka.actor.UntypedActorWithUnboundedStash
 
UntypedActorWithUnrestrictedStash - Class in akka.actor
Actor base class with Stash that does not enforce any mailbox type.
UntypedActorWithUnrestrictedStash() - Constructor for class akka.actor.UntypedActorWithUnrestrictedStash
 
UntypedConsumerActor - Class in akka.camel.javaapi
Subclass this abstract class to create an MDB-style untyped consumer actor.
UntypedConsumerActor() - Constructor for class akka.camel.javaapi.UntypedConsumerActor
 
UntypedProducerActor - Class in akka.camel.javaapi
Subclass this abstract class to create an untyped producer actor.
UntypedProducerActor() - Constructor for class akka.camel.javaapi.UntypedProducerActor
 
UntypedTransactor - Class in akka.transactor
An UntypedActor version of transactor for using from Java.
UntypedTransactor() - Constructor for class akka.transactor.UntypedTransactor
 
unwatch(ActorRef) - Method in interface akka.actor.ActorContext
Unregisters this actor as Monitor for the provided ActorRef.
unwatch(ActorRef) - Method in class akka.testkit.JavaTestKit
Have the testActor stop watching someone (i.e.
unwatch(ActorRef) - Method in class akka.testkit.TestActorRef
Deregisters this actor from being a death monitor of the provided ActorRef This means that this actor will not get a Terminated()-message when the provided actor is permanently terminated.
unwatch(ActorRef) - Method in interface akka.testkit.TestKitBase
Have the testActor stop watching someone (i.e.
up() - Method in class akka.cluster.MemberStatus$
Java API: retrieve the “up” status singleton
up() - Static method in class akka.cluster.MemberStatus
Java API: retrieve the “up” status singleton
Up() - Method in class akka.cluster.protobuf.msg.MemberStatus$
 
Up() - Static method in class akka.cluster.protobuf.msg.MemberStatus
 
Up_VALUE() - Method in class akka.cluster.protobuf.msg.MemberStatus$
 
Up_VALUE() - Static method in class akka.cluster.protobuf.msg.MemberStatus
 
updateSource(LogRecord) - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
upNumber() - Method in class akka.cluster.Member
INTERNAL API
upNumber() - Method in class akka.cluster.protobuf.msg.Member
 
UPNUMBER_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.Member$
 
UPNUMBER_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.Member
 
upperBound() - Method in class akka.routing.DefaultResizer
The most number of routees the router should ever have.
upstreamListener() - Method in class akka.remote.transport.ActorTransportAdapter.ListenUnderlying
 
uptime() - Method in class akka.actor.ActorSystem
Up-time of this actor system in seconds.
usage() - Method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper$
 
usage() - Static method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper
 
used() - Method in class akka.cluster.StandardMetrics.HeapMemory
 
UseDispatcher() - Method in class akka.cluster.ClusterSettings
 
UseDispatcherForIo() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
UsePassiveConnections() - Method in class akka.remote.RemoteSettings
 
userConfig() - Method in interface akka.actor.mailbox.DurableMailboxSettings
A reference to the config section which the user specified for this mailbox’s dispatcher.
userConfig() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
useResumeWriting() - Method in class akka.io.Tcp.Register
 
useRole() - Method in class akka.cluster.routing.ClusterRouterSettings
 
useRoleOption(String) - Method in class akka.cluster.routing.ClusterRouterSettings$
 
useRoleOption(String) - Static method in class akka.cluster.routing.ClusterRouterSettings
 
using(D) - Method in class akka.actor.FSM.State
Modify state transition descriptor with new state data.
using(PartialFunction<FSM.State<S, D>, FSM.State<S, D>>) - Method in class akka.actor.FSM.TransformHelper
 
utf8String() - Method in class akka.util.ByteString
Decodes this ByteString as a UTF-8 encoded String.
Util - Class in akka.actor.mailbox.filebased.filequeue.tools
 
Util() - Constructor for class akka.actor.mailbox.filebased.filequeue.tools.Util
 
Util - Class in akka.japi
This class hold common utilities for Java
Util() - Constructor for class akka.japi.Util
 
Util$ - Class in akka.actor.mailbox.filebased.filequeue.tools
 
Util$() - Constructor for class akka.actor.mailbox.filebased.filequeue.tools.Util$
 
Util$ - Class in akka.japi
This class hold common utilities for Java
Util$() - Constructor for class akka.japi.Util$
 
uuid() - Method in interface akka.actor.IO.Handle
 
uuid() - Method in class akka.actor.IO.ServerHandle
 
uuid() - Method in class akka.actor.IO.SocketHandle
 

V

v() - Method in class akka.japi.Option.Some
 
validate(ThreadFactory) - Method in class akka.dispatch.ForkJoinExecutorConfigurator
 
value() - Method in class akka.actor.IO.IterateeRefSync
Returns the current value of this IterateeRefSync
value() - Method in class akka.cluster.Metric
 
value() - Method in class akka.cluster.protobuf.msg.NodeMetrics.EWMA
 
value - Variable in class akka.dispatch.AbstractNodeQueue.Node
 
value() - Method in class akka.util.Helpers.Requiring
 
value() - Method in class akka.zeromq.Affinity
 
value() - Method in class akka.zeromq.Backlog
 
value() - Method in class akka.zeromq.HighWatermark
 
value() - Method in class akka.zeromq.Identity
 
value() - Method in class akka.zeromq.Linger
 
value() - Method in class akka.zeromq.MaxMsgSize
 
value() - Method in class akka.zeromq.MulticastHops
 
value() - Method in class akka.zeromq.MulticastLoop
 
value() - Method in class akka.zeromq.Rate
 
value() - Method in class akka.zeromq.ReceiveBufferSize
 
value() - Method in class akka.zeromq.ReceiveHighWatermark
 
value() - Method in class akka.zeromq.ReconnectIVL
 
value() - Method in class akka.zeromq.ReconnectIVLMax
 
value() - Method in class akka.zeromq.RecoveryInterval
 
value() - Method in class akka.zeromq.SendBufferSize
 
value() - Method in class akka.zeromq.SendHighWatermark
 
value() - Method in class akka.zeromq.Swap
 
value32() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number
 
VALUE32_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number$
 
value64() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number
 
VALUE64_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number$
 
VALUE_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.NodeMetrics.EWMA$
 
valueComparator() - Method in class akka.util.Index
 
valueIterator(K) - Method in class akka.util.Index
Returns an Iterator of V containing the values for the supplied key, or an empty iterator if the key doesn't exist
valueOf(int) - Method in class akka.cluster.protobuf.msg.MemberStatus$
 
valueOf(int) - Static method in class akka.cluster.protobuf.msg.MemberStatus
 
valueOf(int) - Method in class akka.cluster.protobuf.msg.NodeMetrics.NumberType$
 
valueOf(String) - Static method in enum akka.remote.ContainerFormats.PatternType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum akka.remote.ContainerFormats.PatternType
 
valueOf(com.google.protobuf.Descriptors.EnumValueDescriptor) - Static method in enum akka.remote.ContainerFormats.PatternType
 
valueOf(String) - Static method in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
 
valueOf(com.google.protobuf.Descriptors.EnumValueDescriptor) - Static method in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
 
valueOf(String) - Static method in enum akka.remote.testconductor.TestConductorProtocol.Direction
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum akka.remote.testconductor.TestConductorProtocol.Direction
 
valueOf(com.google.protobuf.Descriptors.EnumValueDescriptor) - Static method in enum akka.remote.testconductor.TestConductorProtocol.Direction
 
valueOf(String) - Static method in enum akka.remote.testconductor.TestConductorProtocol.FailType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum akka.remote.testconductor.TestConductorProtocol.FailType
 
valueOf(com.google.protobuf.Descriptors.EnumValueDescriptor) - Static method in enum akka.remote.testconductor.TestConductorProtocol.FailType
 
valueOf(String) - Static method in enum akka.remote.WireFormats.CommandType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum akka.remote.WireFormats.CommandType
 
valueOf(com.google.protobuf.Descriptors.EnumValueDescriptor) - Static method in enum akka.remote.WireFormats.CommandType
 
values() - Static method in enum akka.remote.ContainerFormats.PatternType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum akka.remote.testconductor.TestConductorProtocol.Direction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum akka.remote.testconductor.TestConductorProtocol.FailType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum akka.remote.WireFormats.CommandType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class akka.util.Index
Returns the union of all value sets.
VectorClock - Class in akka.cluster.protobuf.msg
 
VectorClock(Option<Object>, Seq<VectorClock.Version>) - Constructor for class akka.cluster.protobuf.msg.VectorClock
 
VectorClock - Class in akka.cluster
Representation of a Vector-based clock (counting clock), inspired by Lamport logical clocks.
VectorClock(TreeMap<String, VectorClock.Timestamp>) - Constructor for class akka.cluster.VectorClock
 
VectorClock$ - Class in akka.cluster.protobuf.msg
 
VectorClock$() - Constructor for class akka.cluster.protobuf.msg.VectorClock$
 
VectorClock.After$ - Class in akka.cluster
 
VectorClock.After$() - Constructor for class akka.cluster.VectorClock.After$
 
VectorClock.Before$ - Class in akka.cluster
 
VectorClock.Before$() - Constructor for class akka.cluster.VectorClock.Before$
 
VectorClock.Concurrent$ - Class in akka.cluster
 
VectorClock.Concurrent$() - Constructor for class akka.cluster.VectorClock.Concurrent$
 
VectorClock.Node$ - Class in akka.cluster
 
VectorClock.Node$() - Constructor for class akka.cluster.VectorClock.Node$
 
VectorClock.Ordering - Interface in akka.cluster
 
VectorClock.Same$ - Class in akka.cluster
 
VectorClock.Same$() - Constructor for class akka.cluster.VectorClock.Same$
 
VectorClock.Timestamp - Class in akka.cluster
Timestamp representation a unique 'Ordered' timestamp.
VectorClock.Timestamp(long) - Constructor for class akka.cluster.VectorClock.Timestamp
 
VectorClock.Timestamp$ - Class in akka.cluster
 
VectorClock.Timestamp$() - Constructor for class akka.cluster.VectorClock.Timestamp$
 
VectorClock.Version - Class in akka.cluster.protobuf.msg
 
VectorClock.Version(int, long) - Constructor for class akka.cluster.protobuf.msg.VectorClock.Version
 
VectorClock.Version$ - Class in akka.cluster.protobuf.msg
 
VectorClock.Version$() - Constructor for class akka.cluster.protobuf.msg.VectorClock.Version$
 
verifyConfig(ActorPath) - Method in class akka.routing.FromConfig
 
verifyConfig(ActorPath) - Method in interface akka.routing.RouterConfig
Check that everything is there which is needed.
verifySystemShutdown() - Method in class akka.remote.testkit.MultiNodeSpec
Override this and return true to assert that the shutdown of the ActorSystem was done properly.
Version() - Method in class akka.actor.ActorSystem$
 
Version() - Static method in class akka.actor.ActorSystem
 
version() - Method in class akka.cluster.protobuf.msg.Gossip
 
version() - Method in class akka.cluster.protobuf.msg.GossipOverview.Seen
 
version() - Method in class akka.cluster.protobuf.msg.GossipStatus
 
version() - Method in class akka.zeromq.ZeroMQExtension
The version of the ZeroMQ library
VERSION_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.Gossip$
 
VERSION_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.Gossip
 
VERSION_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.GossipOverview.Seen$
 
VERSION_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.GossipStatus$
 
VERSION_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.GossipStatus
 
versions() - Method in class akka.cluster.protobuf.msg.VectorClock
 
versions() - Method in class akka.cluster.VectorClock
 
VERSIONS_FIELD_NUMBER() - Method in class akka.cluster.protobuf.msg.VectorClock$
 
VERSIONS_FIELD_NUMBER() - Static method in class akka.cluster.protobuf.msg.VectorClock
 
virtualNodesFactor() - Method in class akka.contrib.pattern.ClusterReceptionist
 
virtualNodesFactor() - Method in class akka.routing.ConsistentHash
 
virtualNodesFactor() - Method in interface akka.routing.ConsistentHashingLike
 
virtualNodesFactor() - Method in class akka.routing.ConsistentHashingRouter
 

W

waitNanos(long) - Method in class akka.actor.LightArrayRevolverScheduler
Overridable for tests
walk() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
wantsAck() - Method in interface akka.io.Tcp.WriteCommand
An acknowledgment is only sent if this write command “wants an ack”, which is equivalent to the Tcp.WriteCommand.ack() token not being a of type Tcp.NoAck.
wantsAck() - Method in class akka.io.Udp.Send
 
wantsAck() - Method in class akka.io.UdpConnected.Send
 
warning(Logging.Warning) - Method in interface akka.event.Logging.StdOutLogger
 
warning(String) - Method in interface akka.event.LoggingAdapter
Log message at warning level.
warning(String, Object) - Method in interface akka.event.LoggingAdapter
Message template with 1 replacement argument.
warning(String, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 2 replacement arguments.
warning(String, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 3 replacement arguments.
warning(String, Object, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 4 replacement arguments.
warning(String, String, String, String, int) - Method in class akka.testkit.EventFilter$
Create a filter for Warning events.
warning(String, String, String, String, int) - Static method in class akka.testkit.EventFilter
Create a filter for Warning events.
WarningFilter - Class in akka.testkit
Filter which matches Warning events, if they satisfy the given criteria: source, if given, applies a filter on the event’s origin message applies a filter on the event’s message (either with String.startsWith or Regex.findFirstIn().isDefined) If you want to match all Warning events, the most efficient is to use Left("").
WarningFilter(Option<String>, Either<String, Regex>, boolean, int) - Constructor for class akka.testkit.WarningFilter
 
WarningFilter(String, String, boolean, boolean, int) - Constructor for class akka.testkit.WarningFilter
Java API: create a WarningFilter
WarningFilter$ - Class in akka.testkit
 
WarningFilter$() - Constructor for class akka.testkit.WarningFilter$
 
warningFormat() - Method in interface akka.event.Logging.StdOutLogger
 
WarningLevel() - Method in class akka.event.Logging$
 
WarningLevel() - Static method in class akka.event.Logging
 
watch(ActorRef) - Method in interface akka.actor.ActorContext
Registers this actor as a Monitor for the provided ActorRef.
watch(ActorRef) - Method in class akka.actor.dsl.Inbox.Inbox
Make the inbox’s actor watch the target actor such that reception of the Terminated message can then be awaited.
watch(ActorRef) - Method in class akka.actor.Inbox
Have the internal actor watch the target actor.
watch(FiniteDuration, String, PrintStream, FiniteDuration, boolean) - Method in class akka.testkit.Coroner$
Ask the Coroner to print a report if it is not cancelled by the given deadline.
watch(FiniteDuration, String, PrintStream, FiniteDuration, boolean) - Static method in class akka.testkit.Coroner
Ask the Coroner to print a report if it is not cancelled by the given deadline.
watch(ActorRef) - Method in class akka.testkit.JavaTestKit
Have the testActor watch someone (i.e.
watch(ActorRef) - Method in class akka.testkit.TestActorRef
Registers this actor to be a death monitor of the provided ActorRef This means that this actor will get a Terminated()-message when the provided actor is permanently terminated.
watch(ActorRef) - Method in interface akka.testkit.TestKitBase
Have the testActor watch someone (i.e.
WatchedByCoroner - Interface in akka.testkit
Mixin for tests that should be watched by the Coroner.
WatchFailureDetectorConfig() - Method in class akka.remote.RemoteSettings
 
WatchFailureDetectorImplementationClass() - Method in class akka.remote.RemoteSettings
 
WatchHeartbeatExpectedResponseAfter() - Method in class akka.remote.RemoteSettings
 
WatchHeartBeatInterval() - Method in class akka.remote.RemoteSettings
 
WatchUnreachableReaperInterval() - Method in class akka.remote.RemoteSettings
 
weights(Map<Address, Object>) - Method in class akka.cluster.routing.CapacityMetricsSelector
Converts the capacity values to weights.
weights(Set<NodeMetrics>) - Method in class akka.cluster.routing.CapacityMetricsSelector
The weights per address, based on the capacity produced by the nodeMetrics.
weights(Set<NodeMetrics>) - Method in interface akka.cluster.routing.MetricsSelector
The weights per address, based on the the nodeMetrics.
Welcome - Class in akka.cluster.protobuf.msg
 
Welcome(UniqueAddress, Gossip) - Constructor for class akka.cluster.protobuf.msg.Welcome
 
Welcome$ - Class in akka.cluster.protobuf.msg
 
Welcome$() - Constructor for class akka.cluster.protobuf.msg.Welcome$
 
WheelSize() - Method in class akka.actor.LightArrayRevolverScheduler
 
when(S, FiniteDuration, PartialFunction<FSM.Event, FSM.State<S, D>>) - Method in interface akka.actor.FSM
Insert a new StateFunction at the end of the processing chain for the given state.
whenFailing(Function2<Throwable, Option<Object>, BoxedUnit>) - Method in interface akka.actor.dsl.Creators.Act
Replace the preRestart action with the supplied function.
whenRestarted(Function1<Throwable, BoxedUnit>) - Method in interface akka.actor.dsl.Creators.Act
Replace the postRestart action with the supplied function.
whenStarting(Function0<BoxedUnit>) - Method in interface akka.actor.dsl.Creators.Act
Replace the preStart action with the supplied thunk.
whenStopping(Function0<BoxedUnit>) - Method in interface akka.actor.dsl.Creators.Act
Replace the postStop action with the supplied thunk.
whenUnhandled(PartialFunction<FSM.Event, FSM.State<S, D>>) - Method in interface akka.actor.FSM
Set handler which is called upon reception of unhandled messages.
whileOff(Function0<BoxedUnit>) - Method in class akka.util.Switch
Executes the provided action and returns if the action was executed or not, if the switch is off, waiting for any pending changes to happen before (locking) Be careful of longrunning or blocking within the provided action as it can lead to deadlocks or bad performance
whileOffYield(Function0<T>) - Method in class akka.util.Switch
Executes the provided action and returns its value if the switch is off, waiting for any pending changes to happen before (locking) Be careful of longrunning or blocking within the provided action as it can lead to deadlocks or bad performance
whileOn(Function0<BoxedUnit>) - Method in class akka.util.Switch
Executes the provided action and returns if the action was executed or not, if the switch is on, waiting for any pending changes to happen before (locking) Be careful of longrunning or blocking within the provided action as it can lead to deadlocks or bad performance
whileOnYield(Function0<T>) - Method in class akka.util.Switch
Executes the provided action and returns its value if the switch is on, waiting for any pending changes to happen before (locking) Be careful of longrunning or blocking within the provided action as it can lead to deadlocks or bad performance
wire(T) - Method in class akka.dispatch.MonitorableThreadFactory
 
WireFormats - Class in akka.remote
 
WireFormats.AckAndEnvelopeContainer - Class in akka.remote
 
WireFormats.AckAndEnvelopeContainer.Builder - Class in akka.remote
 
WireFormats.AckAndEnvelopeContainerOrBuilder - Interface in akka.remote
 
WireFormats.AcknowledgementInfo - Class in akka.remote
 
WireFormats.AcknowledgementInfo.Builder - Class in akka.remote
 
WireFormats.AcknowledgementInfoOrBuilder - Interface in akka.remote
 
WireFormats.ActorRefData - Class in akka.remote
 
WireFormats.ActorRefData.Builder - Class in akka.remote
 
WireFormats.ActorRefDataOrBuilder - Interface in akka.remote
 
WireFormats.AddressData - Class in akka.remote
 
WireFormats.AddressData.Builder - Class in akka.remote
 
WireFormats.AddressDataOrBuilder - Interface in akka.remote
 
WireFormats.AkkaControlMessage - Class in akka.remote
 
WireFormats.AkkaControlMessage.Builder - Class in akka.remote
 
WireFormats.AkkaControlMessageOrBuilder - Interface in akka.remote
 
WireFormats.AkkaHandshakeInfo - Class in akka.remote
 
WireFormats.AkkaHandshakeInfo.Builder - Class in akka.remote
 
WireFormats.AkkaHandshakeInfoOrBuilder - Interface in akka.remote
 
WireFormats.AkkaProtocolMessage - Class in akka.remote
 
WireFormats.AkkaProtocolMessage.Builder - Class in akka.remote
 
WireFormats.AkkaProtocolMessageOrBuilder - Interface in akka.remote
 
WireFormats.CommandType - Enum in akka.remote
 
WireFormats.DaemonMsgCreateData - Class in akka.remote
 
WireFormats.DaemonMsgCreateData.Builder - Class in akka.remote
 
WireFormats.DaemonMsgCreateDataOrBuilder - Interface in akka.remote
 
WireFormats.DeployData - Class in akka.remote
 
WireFormats.DeployData.Builder - Class in akka.remote
 
WireFormats.DeployDataOrBuilder - Interface in akka.remote
 
WireFormats.PropsData - Class in akka.remote
 
WireFormats.PropsData.Builder - Class in akka.remote
 
WireFormats.PropsDataOrBuilder - Interface in akka.remote
 
WireFormats.RemoteEnvelope - Class in akka.remote
 
WireFormats.RemoteEnvelope.Builder - Class in akka.remote
 
WireFormats.RemoteEnvelopeOrBuilder - Interface in akka.remote
 
WireFormats.SerializedMessage - Class in akka.remote
 
WireFormats.SerializedMessage.Builder - Class in akka.remote
 
WireFormats.SerializedMessageOrBuilder - Interface in akka.remote
 
withBody(T) - Method in class akka.camel.CamelMessage
Java API: Returns a new CamelMessage with a new body, while keeping the same headers.
withBodyAs(ClassTag<T>, org.apache.camel.CamelContext) - Method in class akka.camel.CamelMessage
Creates a CamelMessage with current body converted to type T.
withBodyAs(Class<T>, org.apache.camel.CamelContext) - Method in class akka.camel.CamelMessage
Java API: Creates a CamelMessage with current body converted to type clazz.
withCircuitBreaker(Function0<Future<T>>) - Method in class akka.pattern.CircuitBreaker
Wraps invocations of asynchronous calls that need to be protected
withClient(ActorRef) - Method in class akka.actor.dsl.Inbox.Get
 
withClient(ActorRef) - Method in interface akka.actor.dsl.Inbox.Query
 
withClient(ActorRef) - Method in class akka.actor.dsl.Inbox.Select
 
withCreator(Function0<Actor>) - Method in class akka.actor.Props
Scala API: Returns a new Props with the specified creator set.
withCreator(Creator<Actor>) - Method in class akka.actor.Props
Deprecated. use Props.create(clazz, args ...) instead; this method has been deprecated because it encourages creating Props which contain non-serializable inner classes, making them also non-serializable
withCreator(Class<? extends Actor>) - Method in class akka.actor.Props
Deprecated. use Props.create(clazz) instead; deprecated since it duplicates another API
withDeploy(Deploy) - Method in class akka.actor.Props
Returns a new Props with the specified deployment configuration.
withDeploy(Deploy) - Method in class akka.actor.TypedProps
Returns a new TypedProps with the specified deployment configuration.
withDispatcher(String) - Method in class akka.actor.Props
Returns a new Props with the specified dispatcher set.
withDispatcher(String) - Method in class akka.actor.TypedProps
Returns a new TypedProps with the specified dispatcher set.
withDispatcher(String) - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.BroadcastRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.ConsistentHashingRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.RandomRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.RoundRobinRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.ScatterGatherFirstCompletedRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.SmallestMailboxRouter
Java API for setting routerDispatcher
withFallback(Deploy) - Method in class akka.actor.Deploy
Do a merge between this and the other Deploy, where values from “this” take precedence.
withFallback(Scope) - Method in class akka.actor.LocalScope$
 
withFallback(Scope) - Static method in class akka.actor.LocalScope
 
withFallback(Scope) - Method in class akka.actor.NoScopeGiven$
 
withFallback(Scope) - Static method in class akka.actor.NoScopeGiven
 
withFallback(Scope) - Method in interface akka.actor.Scope
When merging Deploy instances using withFallback() on the left one, this is propagated to “merging” scopes in the same way.
withFallback(Scope) - Method in class akka.cluster.ClusterScope$
 
withFallback(Scope) - Static method in class akka.cluster.ClusterScope
 
withFallback(RouterConfig) - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in class akka.cluster.routing.ClusterRouterConfig
 
withFallback(Scope) - Method in class akka.remote.RemoteScope
 
withFallback(RouterConfig) - Method in class akka.remote.routing.RemoteRouterConfig
 
withFallback(RouterConfig) - Method in class akka.routing.BroadcastRouter
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in class akka.routing.ConsistentHashingRouter
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in class akka.routing.NoRouter$
 
withFallback(RouterConfig) - Static method in class akka.routing.NoRouter
 
withFallback(RouterConfig) - Method in class akka.routing.RandomRouter
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in class akka.routing.RoundRobinRouter
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in interface akka.routing.RouterConfig
Overridable merge strategy, by default completely prefers “this” (i.e.
withFallback(RouterConfig) - Method in class akka.routing.ScatterGatherFirstCompletedRouter
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in class akka.routing.SmallestMailboxRouter
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFrames(ByteString...) - Method in class akka.zeromq.ZMQMessage$
Java API: create a message from the given frames
withFrames(Seq<ByteString>) - Method in class akka.zeromq.ZMQMessage$
Java API: create a message from the given frames
withFrames(ByteString...) - Static method in class akka.zeromq.ZMQMessage
Java API: create a message from the given frames
withFrames(Seq<ByteString>) - Static method in class akka.zeromq.ZMQMessage
Java API: create a message from the given frames
withGuard(Function0<T>) - Method in class akka.util.ReentrantGuard
 
withHashMapper(ConsistentHashingRouter.ConsistentHashMapper) - Method in class akka.routing.ConsistentHashingRouter
Java API for setting the mapping from message to the data to use for the consistent hash key.
withHeaders(Map<String, A>) - Method in class akka.camel.CamelMessage
Java API: Creates a new CamelMessage with given headers.
within() - Method in interface akka.routing.ScatterGatherFirstCompletedLike
 
within() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
within(FiniteDuration, FiniteDuration, Function0<T>) - Method in interface akka.testkit.TestKitBase
Execute code block while bounding its execution time between min and max.
within(FiniteDuration, Function0<T>) - Method in interface akka.testkit.TestKitBase
Same as calling within(0 seconds, max)(f).
withInterface(Class<? super T>) - Method in class akka.actor.TypedProps
Returns a new TypedProps that has the specified interface, or if the interface class is not an interface, all the interfaces it implements, appended in the sequence of interfaces.
withinTimeRange() - Method in class akka.actor.AllForOneStrategy
 
withinTimeRange() - Method in class akka.actor.OneForOneStrategy
 
WithListeners - Class in akka.routing
 
WithListeners(Function1<ActorRef, BoxedUnit>) - Constructor for class akka.routing.WithListeners
 
WithListeners$ - Class in akka.routing
 
WithListeners$() - Constructor for class akka.routing.WithListeners$
 
withLoader(ClassLoader) - Method in class akka.actor.TypedProps
Java API: return a new TypedProps that will use the specified ClassLoader to create its proxy class in If loader is null, it will use the bootstrap classloader.
withLoader(Option<ClassLoader>) - Method in class akka.actor.TypedProps
Scala API: return a new TypedProps that will use the specified ClassLoader to create its proxy class in If loader is null, it will use the bootstrap classloader.
withLogger(LoggingAdapter, PipelineStage<? extends PipelineContext, Cmd, Tcp.Command, Evt, Tcp.Event>) - Method in class akka.io.TcpPipelineHandler$
 
withLogger(LoggingAdapter, PipelineStage<? extends PipelineContext, Cmd, Tcp.Command, Evt, Tcp.Event>) - Static method in class akka.io.TcpPipelineHandler
 
withMailbox(String) - Method in class akka.actor.Props
Returns a new Props with the specified mailbox set.
withMdc(String, Logging.LogEvent, Function0<BoxedUnit>) - Method in class akka.event.slf4j.Slf4jLogger
 
withName(String) - Method in class akka.dispatch.MonitorableThreadFactory
 
withNewThreadPoolWithArrayBlockingQueueWithCapacityAndFairness(int, boolean) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
withNewThreadPoolWithCustomBlockingQueue(Function0<BlockingQueue<Runnable>>) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
withNewThreadPoolWithCustomBlockingQueue(BlockingQueue<Runnable>) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
withNewThreadPoolWithLinkedBlockingQueueWithCapacity(int) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
withNewThreadPoolWithLinkedBlockingQueueWithUnboundedCapacity() - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
withNewThreadPoolWithSynchronousQueueWithFairness(boolean) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
withoutInterface(Class<? super T>) - Method in class akka.actor.TypedProps
Returns a new TypedProps without the specified interface, or if the interface class is not an interface, all the interfaces it implements.
withResizer(Resizer) - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
Java API for setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.BroadcastRouter
Java API for setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.ConsistentHashingRouter
Java API for setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.RandomRouter
Java API for setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.RoundRobinRouter
Java API for setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.ScatterGatherFirstCompletedRouter
Java API for setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.SmallestMailboxRouter
Java API for setting the resizer to be used.
withRouter(RouterConfig) - Method in class akka.actor.Props
Returns a new Props with the specified router config set.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
Java API for setting the supervisor strategy to be used for the “head” Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.BroadcastRouter
Java API for setting the supervisor strategy to be used for the “head” Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.ConsistentHashingRouter
Java API for setting the supervisor strategy to be used for the “head” Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.FromConfig
Java API for setting the supervisor strategy to be used for the “head” Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.RandomRouter
Java API for setting the supervisor strategy to be used for the “head” Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.RoundRobinRouter
Java API for setting the supervisor strategy to be used for the “head” Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.ScatterGatherFirstCompletedRouter
Java API for setting the supervisor strategy to be used for the “head” Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.SmallestMailboxRouter
Java API for setting the supervisor strategy to be used for the “head” Router actor.
withSyncCircuitBreaker(Function0<T>) - Method in class akka.pattern.CircuitBreaker
Wraps invocations of synchronous calls that need to be protected
withTimeout(Timeout) - Method in class akka.actor.TypedProps
Java API: return a new TypedProps that will use the specified Timeout for its non-void-returning methods, if null is specified, it will use the default timeout as specified in the configuration.
withTimeout(Option<Timeout>) - Method in class akka.actor.TypedProps
Scala API: return a new TypedProps that will use the specified Timeout for its non-void-returning methods, if None is specified, it will use the default timeout as specified in the configuration.
withUid(int) - Method in interface akka.actor.ActorPath
INTERNAL API Creates a new ActorPath with same elements but with the specified uid.
withValue(ExtendedActorSystem, Callable<S>) - Method in class akka.serialization.JavaSerializer.CurrentSystem
Java API: invoke the callable with the current system being set to the given value for this thread.
withVirtualNodesFactor(int) - Method in class akka.routing.ConsistentHashingRouter
Java API for setting the number of virtual nodes per node, used in ConsistentHash
WorkerDispatcher() - Method in class akka.io.SelectionHandlerSettings
 
WorkList<T> - Class in akka.contrib.pattern
Fast, small, and dirty implementation of a linked list that removes transient work entries once they are processed.
WorkList() - Constructor for class akka.contrib.pattern.WorkList
 
WorkList$ - Class in akka.contrib.pattern
Provides the utility methods and constructors to the WorkList class.
WorkList$() - Constructor for class akka.contrib.pattern.WorkList$
 
WorkList.Entry<T> - Class in akka.contrib.pattern
Singly linked list entry implementation for WorkList.
WorkList.Entry(Option<T>, boolean) - Constructor for class akka.contrib.pattern.WorkList.Entry
 
wrappedHandle() - Method in class akka.remote.transport.AbstractTransportAdapterHandle
 
wrappedTransport() - Method in class akka.remote.transport.AbstractTransportAdapter
 
writable() - Method in class akka.remote.transport.TestAssociationHandle
 
write(ByteString) - Method in interface akka.actor.IO.WriteHandle
Sends a request to the IOManager to write to the Channel associated with this IO.Handle.
write(WritableByteChannel) - Method in class akka.actor.WriteBuffer
 
write(ByteString, Tcp.Event) - Method in class akka.io.TcpMessage$
Write data to the TCP connection.
write(ByteString) - Method in class akka.io.TcpMessage$
The same as write(data, noAck()).
write(ByteString, Tcp.Event) - Static method in class akka.io.TcpMessage
Write data to the TCP connection.
write(ByteString) - Static method in class akka.io.TcpMessage
The same as write(data, noAck()).
write(ByteString) - Method in interface akka.remote.transport.AssociationHandle
Asynchronously sends the specified payload to the remote endpoint.
write(ByteString) - Method in class akka.remote.transport.TestAssociationHandle
 
writeBehavior() - Method in class akka.remote.transport.TestTransport
The TestTransport.SwitchableLoggedBehavior for the write() method on handles.
WriteBuffer - Class in akka.actor
 
WriteBuffer(int) - Constructor for class akka.actor.WriteBuffer
 
WriteBufferHighWaterMark() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
WriteBufferLowWaterMark() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
writeFile(String, long, long, Tcp.Event) - Method in class akka.io.TcpMessage$
Write count bytes starting at position from file at filePath to the connection.
writeFile(String, long, long, Tcp.Event) - Static method in class akka.io.TcpMessage
Write count bytes starting at position from file at filePath to the connection.
writeObject(ObjectOutputStream) - Method in interface akka.actor.ActorContext
ActorContexts shouldn't be Serializable
writeReplace() - Method in class akka.remote.ContainerFormats.Selection
 
writeReplace() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
writeReplace() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
writeReplace() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
writeReplace() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
writeReplace() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
writeReplace() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
writeReplace() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
writeReplace() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
writeReplace() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
writeReplace() - Method in class akka.remote.WireFormats.ActorRefData
 
writeReplace() - Method in class akka.remote.WireFormats.AddressData
 
writeReplace() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
writeReplace() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
writeReplace() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
writeReplace() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
writeReplace() - Method in class akka.remote.WireFormats.DeployData
 
writeReplace() - Method in class akka.remote.WireFormats.PropsData
 
writeReplace() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
writeReplace() - Method in class akka.remote.WireFormats.SerializedMessage
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.Address
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.Empty
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.Gossip
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.GossipEnvelope
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.GossipOverview.Seen
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.GossipOverview
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.GossipStatus
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.Join
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.Member
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.MetricsGossip
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.MetricsGossipEnvelope
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.NodeMetrics.EWMA
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.NodeMetrics.Metric
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.NodeMetrics.Number
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.NodeMetrics
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.UniqueAddress
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.VectorClock.Version
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.VectorClock
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.cluster.protobuf.msg.Welcome
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.ContainerFormats.Selection
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.testconductor.TestConductorProtocol.Address
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.WireFormats.ActorRefData
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.WireFormats.AddressData
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.WireFormats.AkkaControlMessage
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.WireFormats.DeployData
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.WireFormats.PropsData
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.WireFormats.RemoteEnvelope
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.WireFormats.SerializedMessage
 

X

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

Z

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

_

_client() - Method in interface akka.remote.testconductor.Player
 
_controller() - Method in interface akka.remote.testconductor.Conductor
 
_logLevel() - Method in interface akka.event.LoggingBus
 
_UNINITIALIZED() - Method in class akka.cluster.protobuf.msg.MemberStatus$
 
_UNINITIALIZED() - Static method in class akka.cluster.protobuf.msg.MemberStatus
 
_UNINITIALIZED() - Method in class akka.cluster.protobuf.msg.NodeMetrics.NumberType$
 

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