- abort() - Method in class akka.actor.ActorSystemImpl
-
This kind of shutdown attempts to bring the system down and release its
resources more forcefully than plain shutdown.
- abort() - Method in class akka.io.TcpConnection
-
- abort() - Method in class akka.io.TcpMessage$
-
An abort operation will not flush pending writes and will issue a TCP ABORT
command to the O/S kernel which should result in a TCP_RST packet being sent
to the peer.
- abort() - Static method in class akka.io.TcpMessage
-
An abort operation will not flush pending writes and will issue a TCP ABORT
command to the O/S kernel which should result in a TCP_RST packet being sent
to the peer.
- Abort$() - Constructor for class akka.io.Tcp.Abort$
-
- Aborted$() - Constructor for class akka.io.Tcp.Aborted$
-
- aborting() - Method in class akka.actor.ActorSystemImpl
-
- AbstractActor - Class in akka.actor
-
Java API: compatible with lambda expressions
- AbstractActor() - Constructor for class akka.actor.AbstractActor
-
- AbstractActor$ - Class in akka.actor
-
Java API: compatible with lambda expressions
- AbstractActor$() - Constructor for class akka.actor.AbstractActor$
-
- AbstractActorContext - Interface in akka.actor
-
AbstractActorContext is the AbstractActor equivalent of ActorContext,
containing the Java API
- AbstractActorWithStash - Class in akka.actor
-
Java API: compatible with lambda expressions
- AbstractActorWithStash() - Constructor for class akka.actor.AbstractActorWithStash
-
- AbstractActorWithUnboundedStash - Class in akka.actor
-
Java API: compatible with lambda expressions
- AbstractActorWithUnboundedStash() - Constructor for class akka.actor.AbstractActorWithUnboundedStash
-
- AbstractActorWithUnrestrictedStash - Class in akka.actor
-
Java API: compatible with lambda expressions
- AbstractActorWithUnrestrictedStash() - Constructor for class akka.actor.AbstractActorWithUnrestrictedStash
-
- AbstractBatch() - Constructor for class akka.dispatch.BatchingExecutor.AbstractBatch
-
- AbstractBoundedNodeQueue<T> - Class in akka.dispatch
-
Lock-free bounded non-blocking multiple-producer single-consumer queue based on the works of:
Andriy Plokhotnuyk (https://github.com/plokhotnyuk)
- https://github.com/plokhotnyuk/actors/blob/2e65abb7ce4cbfcb1b29c98ee99303d6ced6b01f/src/test/scala/akka/dispatch/Mailboxes.scala
(Apache V2: https://github.com/plokhotnyuk/actors/blob/master/LICENSE)
Dmitriy Vyukov's non-intrusive MPSC queue:
- http://www.1024cores.net/home/lock-free-algorithms/queues/non-intrusive-mpsc-node-based-queue
(Simplified BSD)
- AbstractBoundedNodeQueue(int) - Constructor for class akka.dispatch.AbstractBoundedNodeQueue
-
- AbstractBoundedNodeQueue.Node<T> - Class in akka.dispatch
-
- AbstractExtensionId<T extends Extension> - Class in akka.actor
-
Java API for ExtensionId
- AbstractExtensionId() - Constructor for class akka.actor.AbstractExtensionId
-
- AbstractFSM<S,D> - Class in akka.actor
-
Java API: compatible with lambda expressions
- AbstractFSM() - Constructor for class akka.actor.AbstractFSM
-
- AbstractFSM$ - Class in akka.actor
-
Java API: compatible with lambda expressions
- AbstractFSM$() - Constructor for class akka.actor.AbstractFSM$
-
- AbstractFSMWithStash<S,D> - Class in akka.actor
-
Java API: compatible with lambda expressions
- AbstractFSMWithStash() - Constructor for class akka.actor.AbstractFSMWithStash
-
- AbstractLoggingActor - Class in akka.actor
-
Java API: compatible with lambda expressions
- AbstractLoggingActor() - Constructor for class akka.actor.AbstractLoggingActor
-
- AbstractLoggingFSM<S,D> - Class in akka.actor
-
Java API: compatible with lambda expressions
- AbstractLoggingFSM() - Constructor for class akka.actor.AbstractLoggingFSM
-
- AbstractNodeQueue<T> - Class in akka.dispatch
-
Lock-free MPSC linked queue implementation based on Dmitriy Vyukov's non-intrusive MPSC queue:
http://www.1024cores.net/home/lock-free-algorithms/queues/non-intrusive-mpsc-node-based-queue
- AbstractNodeQueue() - Constructor for class akka.dispatch.AbstractNodeQueue
-
- AbstractNodeQueue.Node<T> - Class in akka.dispatch
-
- 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
-
- AbstractSocketOption() - Constructor for class akka.io.Inet.AbstractSocketOption
-
- AbstractSocketOptionV2() - Constructor for class akka.io.Inet.AbstractSocketOptionV2
-
- acceptAllPending(ChannelRegistration, int) - Method in class akka.io.TcpListener
-
- acceptLimit() - Method in class akka.io.TcpListener
-
- ack() - Method in class akka.io.Tcp.SimpleWriteCommand
-
The acknowledgment token associated with this write command.
- ack() - Method in class akka.io.Tcp.Write
-
- ack() - Method in class akka.io.Tcp.WriteFile
-
- ack() - Method in class akka.io.Udp.Send
-
- ack() - Method in class akka.io.UdpConnected.Send
-
- acquire() - Method in interface akka.io.BufferPool
-
- acquire() - Method in class akka.io.DirectByteBufferPool
-
- Actor - Interface in akka.actor
-
- actor() - Method in class akka.actor.ActorCell
-
- actor(Function0<T>, ClassTag<T>, ActorRefFactory) - Method in interface akka.actor.dsl.Creators
-
Create an actor from the given thunk which must produce an
Actor
.
- actor(String, Function0<T>, ClassTag<T>, ActorRefFactory) - Method in interface akka.actor.dsl.Creators
-
Create an actor from the given thunk which must produce an
Actor
.
- actor(ActorRefFactory, String, Function0<T>, ClassTag<T>) - Method in interface akka.actor.dsl.Creators
-
Create an actor from the given thunk which must produce an
Actor
.
- actor(ActorRefFactory, Function0<T>, ClassTag<T>) - Method in interface akka.actor.dsl.Creators
-
Create an actor with an automatically generated name from the given thunk
which must produce an
Actor
.
- actor() - Method in exception akka.actor.PostRestartException
-
- actor() - Method in exception akka.actor.PreRestartException
-
- actor() - Method in class akka.actor.Terminated
-
- actor() - Method in class akka.actor.TypedActor.SerializedTypedActorInvocationHandler
-
- actor() - Method in class akka.actor.TypedActor.TypedActorInvocationHandler
-
- actor() - Method in class akka.dispatch.Mailbox
-
- actor() - Method in class akka.dispatch.sysmsg.DeathWatchNotification
-
- actor() - Method in class akka.event.ActorClassificationUnsubscriber.Register
-
- actor() - Method in class akka.event.ActorClassificationUnsubscriber.Unregister
-
- actor() - Method in class akka.event.EventStreamUnsubscriber.Register
-
- actor() - Method in class akka.event.EventStreamUnsubscriber.UnregisterIfNoMoreSubscribedChannels
-
- 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.ignoringBehavior$ - Class in akka.actor
-
ignoringBehavior is a Receive-expression that consumes and ignores all messages.
- ActorCell - Class in akka.actor
-
Everything in here is completely Akka PRIVATE.
- ActorCell(ActorSystemImpl, InternalActorRef, Props, akka.dispatch.MessageDispatcher, InternalActorRef) - Constructor for class akka.actor.ActorCell
-
- actorCell() - Method in interface akka.actor.StashSupport
-
- ActorCell$ - Class in akka.actor
-
Everything in here is completely Akka PRIVATE.
- ActorCell$() - Constructor for class akka.actor.ActorCell$
-
- actorClass() - Method in class akka.actor.ArgsReflectConstructor
-
- actorClass() - Method in class akka.actor.CreatorConsumer
-
- actorClass() - Method in class akka.actor.CreatorFunctionConsumer
-
- actorClass() - Method in interface akka.actor.IndirectActorProducer
-
This method is used by
Props
to determine the type of actor which will
be created.
- actorClass() - Method in class akka.actor.NoArgsReflectConstructor
-
- actorClass() - Method in class akka.actor.Props
-
Obtain an upper-bound approximation of the actor class which is going to
be created by these Props.
- actorClass() - Method in class akka.actor.TypedCreatorFunctionConsumer
-
- actorClass() - Method in interface akka.io.DnsProvider
-
- actorClass() - Method in class akka.io.InetAddressDnsProvider
-
- actorClass() - Method in class akka.routing.RoutedActorCell.RouterActorCreator
-
- ActorClassification - Interface in akka.event
-
Maps ActorRefs to ActorRefs to form an EventBus where ActorRefs can listen to other ActorRefs
- ActorClassificationUnsubscriber - Class in akka.event
-
INTERNAL API
- ActorClassificationUnsubscriber(ManagedActorClassification, boolean) - Constructor for class akka.event.ActorClassificationUnsubscriber
-
- ActorClassificationUnsubscriber$ - Class in akka.event
-
INTERNAL API
- ActorClassificationUnsubscriber$() - Constructor for class akka.event.ActorClassificationUnsubscriber$
-
- ActorClassificationUnsubscriber.Register - Class in akka.event
-
- ActorClassificationUnsubscriber.Register$ - Class in akka.event
-
- ActorClassificationUnsubscriber.Unregister - Class in akka.event
-
- ActorClassificationUnsubscriber.Unregister$ - Class in akka.event
-
- 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.
- actorContext() - Method in class akka.actor.LocalActorRef
-
- 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$ - Class in akka.actor
-
- ActorEventBus - Interface in akka.event
-
Represents an EventBus where the Subscriber type is ActorRef
- ActorEventBus<E> - Class in akka.event.japi
-
Java API: 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
-
INTERNAL API
- actorFor(String) - Method in interface akka.actor.ActorRefFactory
-
INTERNAL API
- actorFor(Iterable<String>) - Method in interface akka.actor.ActorRefFactory
-
INTERNAL API
- actorFor(Iterable<String>) - Method in interface akka.actor.ActorRefFactory
-
INTERNAL API
- actorFor(ActorPath) - Method in interface akka.actor.ActorRefProvider
-
INTERNAL API
- actorFor(InternalActorRef, String) - Method in interface akka.actor.ActorRefProvider
-
INTERNAL API
- actorFor(InternalActorRef, Iterable<String>) - Method in interface akka.actor.ActorRefProvider
-
INTERNAL API
- actorFor(InternalActorRef, String) - Method in class akka.actor.LocalActorRefProvider
-
- actorFor(ActorPath) - Method in class akka.actor.LocalActorRefProvider
-
- actorFor(InternalActorRef, Iterable<String>) - Method in class akka.actor.LocalActorRefProvider
-
- ActorIdentity - Class in akka.actor
-
- 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 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.
- ActorInterruptedException(Throwable) - Constructor for exception akka.actor.ActorInterruptedException
-
- ActorKilledException - Exception in akka.actor
-
ActorKilledException is thrown when an Actor receives the
Kill
message
- ActorKilledException(String) - Constructor for exception akka.actor.ActorKilledException
-
- ActorKilledException$ - Class in akka.actor
-
- ActorKilledException$() - Constructor for class akka.actor.ActorKilledException$
-
- ActorLogging - Interface in akka.actor
-
Scala API: Mix in ActorLogging into your Actor to easily obtain a reference to a logger,
which is available under the name "log".
- ActorNotFound - Exception in akka.actor
-
- ActorNotFound(ActorSelection) - Constructor for exception akka.actor.ActorNotFound
-
- ActorNotFound$ - Class in akka.actor
-
- ActorNotFound$() - Constructor for class akka.actor.ActorNotFound$
-
- 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).
- actorOf(Props, String) - Method in class akka.actor.ActorSystemImpl
-
- actorOf(Props) - Method in class akka.actor.ActorSystemImpl
-
- actorOf(Props) - Method in interface akka.actor.dungeon.Children
-
- actorOf(Props, String) - Method in interface akka.actor.dungeon.Children
-
- actorOf(ActorSystemImpl, Props, InternalActorRef, ActorPath, boolean, Option<Deploy>, boolean, boolean) - Method in class akka.actor.LocalActorRefProvider
-
- 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$
-
- ActorPaths - Class in akka.actor
-
Java API
- ActorPaths() - Constructor for class akka.actor.ActorPaths
-
- ActorPaths$ - Class in akka.actor
-
Java API
- ActorPaths$() - Constructor for class akka.actor.ActorPaths$
-
- 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.
- ActorRefRoutee - Class in akka.routing
-
- ActorRefRoutee(ActorRef) - Constructor for class akka.routing.ActorRefRoutee
-
- ActorRefRoutee$ - Class in akka.routing
-
- ActorRefRoutee$() - Constructor for class akka.routing.ActorRefRoutee$
-
- ActorRefScope - Interface in akka.actor
-
All ActorRefs have a scope which describes where they live.
- ActorRefWithCell - Class in akka.actor
-
Common trait of all actor refs which actually have a Cell, most notably
LocalActorRef and RepointableActorRef.
- ActorRefWithCell() - Constructor for class akka.actor.ActorRefWithCell
-
- actors() - Method in class akka.dispatch.MessageDispatcher$
-
- actors() - Static method in class akka.dispatch.MessageDispatcher
-
- actorSel() - Method in class akka.pattern.AskableActorSelection
-
- actorSelection(String) - Method in interface akka.actor.ActorRefFactory
-
Construct an
ActorSelection
from the given path, which is
parsed for wildcards (these are replaced by regular expressions
internally).
- actorSelection(ActorPath) - Method in interface akka.actor.ActorRefFactory
-
Construct an
ActorSelection
from the given path, which is
parsed for wildcards (these are replaced by regular expressions
internally).
- ActorSelection - Class in akka.actor
-
An ActorSelection is a logical view of a section of an ActorSystem's tree of Actors,
allowing for broadcasting of messages to that section.
- ActorSelection() - Constructor for class akka.actor.ActorSelection
-
- ActorSelection$ - Class in akka.actor
-
An ActorSelection is a logical view of a section of an ActorSystem's tree of Actors,
allowing for broadcasting of messages to that section.
- ActorSelection$() - Constructor for class akka.actor.ActorSelection$
-
- ActorSelectionMessage - Class in akka.actor
-
INTERNAL API
ActorRefFactory.actorSelection returns a ActorSelection which sends these
nested path descriptions whenever using ! on them, the idea being that the
message is delivered by traversing the various actor paths involved.
- ActorSelectionMessage(Object, Iterable<SelectionPathElement>, boolean) - Constructor for class akka.actor.ActorSelectionMessage
-
- ActorSelectionMessage$ - Class in akka.actor
-
- ActorSelectionMessage$() - Constructor for class akka.actor.ActorSelectionMessage$
-
- ActorSelectionRoutee - Class in akka.routing
-
- ActorSelectionRoutee(ActorSelection) - Constructor for class akka.routing.ActorSelectionRoutee
-
- ActorSelectionRoutee$ - Class in akka.routing
-
- ActorSelectionRoutee$() - Constructor for class akka.routing.ActorSelectionRoutee$
-
- ActorSystem - Class in akka.actor
-
An actor system is a hierarchical group of actors which share common
configuration, e.g.
- ActorSystem() - Constructor for class akka.actor.ActorSystem
-
- ActorSystem$ - Class in akka.actor
-
- ActorSystem$() - Constructor for class akka.actor.ActorSystem$
-
- ActorSystem.Settings - Class in akka.actor
-
Settings are the overall ActorSystem Settings which also provides a convenient access to the Config object.
- ActorSystemImpl - Class in akka.actor
-
- ActorSystemImpl(String, Config, ClassLoader, Option<ExecutionContext>, Option<Props>) - Constructor for class akka.actor.ActorSystemImpl
-
- ActorSystemImpl.TerminationCallbacks<T> - Class in akka.actor
-
- actorVar() - Method in class akka.actor.TypedActor.TypedActorInvocationHandler
-
- add(Runnable) - Method in class akka.actor.ActorSystemImpl.TerminationCallbacks
-
Adds a Runnable that will be executed on ActorSystem termination.
- add(String, ChildRestartStats) - Method in interface akka.actor.dungeon.ChildrenContainer
-
- add(String, ChildRestartStats) - Method in interface akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer
-
- add(String, ChildRestartStats) - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
-
- add(String, ChildRestartStats) - Method in class akka.actor.dungeon.ChildrenContainer.TerminatedChildrenContainer$
-
- add(String, ChildRestartStats) - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
-
- add(T) - Method in class akka.dispatch.AbstractBoundedNodeQueue
-
- add(T) - Method in class akka.dispatch.AbstractNodeQueue
-
- add(ActorRef, ActorRef) - Method in class akka.event.ManagedActorClassification.ManagedActorClassificationMappings
-
- add(T) - Method in class akka.routing.ConsistentHash
-
Java API: Adds a node to the node ring.
- addChild(String, InternalActorRef) - Method in class akka.actor.VirtualPathContainer
-
- addKey(K) - Method in class akka.util.SubclassifiedIndex
-
Add key to this index which inherits its value set from the most specific
super-class which is known.
- addLogger(ActorSystemImpl, Class<? extends Actor>, Logging.LogLevel, String) - Method in interface akka.event.LoggingBus
-
INTERNAL API
- AddLoggingReceive() - Method in class akka.actor.ActorSystem.Settings
-
- addNode(AbstractBoundedNodeQueue.Node<T>) - Method in class akka.dispatch.AbstractBoundedNodeQueue
-
- addNode(AbstractNodeQueue.Node<T>) - Method in class akka.dispatch.AbstractNodeQueue
-
- addr() - Method in class akka.io.Dns.Resolved
-
- address() - Method in interface akka.actor.ActorPath
-
The Address under which this path can be reached; walks up the tree to
the RootActorPath.
- Address - Class in akka.actor
-
The address specifies the physical location under which an Actor can be
reached.
- Address(String, String) - Constructor for class akka.actor.Address
-
- Address(String, String, String, int) - Constructor for class akka.actor.Address
-
- address() - Method in class akka.actor.AddressTerminated
-
- address() - Method in class akka.actor.ChildActorPath
-
- address() - Method in class akka.actor.RootActorPath
-
- address() - Method in class akka.serialization.Serialization.Information
-
- Address$ - Class in akka.actor
-
- Address$() - Constructor for class akka.actor.Address$
-
- 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$
-
- AddressTerminated - Class in akka.actor
-
INTERNAL API
- AddressTerminated(Address) - Constructor for class akka.actor.AddressTerminated
-
- addressTerminated(Address) - Method in interface akka.actor.dungeon.DeathWatch
-
- addressTerminated() - Method in class akka.actor.Terminated
-
- addressTerminated() - Method in class akka.dispatch.sysmsg.DeathWatchNotification
-
- AddressTerminated$ - Class in akka.actor
-
- AddressTerminated$() - Constructor for class akka.actor.AddressTerminated$
-
- AddressTerminatedTopic - Class in akka.event
-
INTERNAL API
- AddressTerminatedTopic() - Constructor for class akka.event.AddressTerminatedTopic
-
- AddressTerminatedTopic$ - Class in akka.event
-
INTERNAL API
- AddressTerminatedTopic$() - Constructor for class akka.event.AddressTerminatedTopic$
-
- addrOption() - Method in class akka.io.Dns.Resolved
-
- AddRoutee - Class in akka.routing
-
Add a routee by sending this message to the router.
- AddRoutee(Routee) - Constructor for class akka.routing.AddRoutee
-
- addRoutee(Routee) - Method in class akka.routing.RoutedActorCell
-
- addRoutee(Routee) - Method in class akka.routing.Router
-
Create a new instance with one more routee and the same
RoutingLogic
.
- addRoutee(ActorRef) - Method in class akka.routing.Router
-
- addRoutee(ActorSelection) - Method in class akka.routing.Router
-
- AddRoutee$ - Class in akka.routing
-
- AddRoutee$() - Constructor for class akka.routing.AddRoutee$
-
- addRoutees(Iterable<Routee>) - Method in class akka.routing.RoutedActorCell
-
Add routees to the Router
.
- addToCache(Seq<Tuple2<Object, Set<Object>>>) - Method in interface akka.event.SubchannelClassification
-
- addValue(K, V) - Method in class akka.util.SubclassifiedIndex
-
Add value to all keys which are subclasses of the given key.
- addWatcher(ActorRef, ActorRef) - Method in interface akka.actor.dungeon.DeathWatch
-
- AdjustPoolSize - Class in akka.routing
-
Increase or decrease the number of routees in a
Pool
.
- AdjustPoolSize(int) - Constructor for class akka.routing.AdjustPoolSize
-
- AdjustPoolSize$ - Class in akka.routing
-
- AdjustPoolSize$() - Constructor for class akka.routing.AdjustPoolSize$
-
- advance() - Method in interface akka.actor.LoggingFSM
-
- 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.
- afterBind(DatagramSocket) - Method in interface akka.io.Inet.SocketOptionV2
-
Action to be taken for this option after connect returned (i.e.
- afterBind(ServerSocket) - Method in interface akka.io.Inet.SocketOptionV2
-
Action to be taken for this option after connect returned (i.e.
- 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(DatagramSocket) - Method in interface akka.io.Inet.SocketOptionV2
-
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
-
- akka - package akka
-
- akka.actor - package akka.actor
-
- akka.actor.dsl - package akka.actor.dsl
-
- akka.actor.dungeon - package akka.actor.dungeon
-
- akka.dispatch - package akka.dispatch
-
- akka.dispatch.sysmsg - package akka.dispatch.sysmsg
-
- akka.event - package akka.event
-
- akka.event.japi - package akka.event.japi
-
- akka.io - package akka.io
-
- akka.japi - package akka.japi
-
- akka.japi.function - package akka.japi.function
-
- akka.japi.pf - package akka.japi.pf
-
- akka.japi.tuple - package akka.japi.tuple
-
- akka.pattern - package akka.pattern
-
- akka.routing - package akka.routing
-
- akka.serialization - package akka.serialization
-
- akka.util - package akka.util
-
- AkkaException - Exception in akka
-
Akka base Exception.
- AkkaException(String, Throwable) - Constructor for exception akka.AkkaException
-
- AkkaException(String) - Constructor for exception akka.AkkaException
-
- AkkaForkJoinPool(int, ForkJoinPool.ForkJoinWorkerThreadFactory, Thread.UncaughtExceptionHandler, boolean) - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinPool
-
- AkkaForkJoinPool(int, ForkJoinPool.ForkJoinWorkerThreadFactory, Thread.UncaughtExceptionHandler) - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinPool
-
- AkkaForkJoinTask(Runnable) - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinTask
-
- AkkaForkJoinWorkerThread(ForkJoinPool) - Constructor for class akka.dispatch.MonitorableThreadFactory.AkkaForkJoinWorkerThread
-
- AllDeadLetters - Interface in akka.actor
-
Subscribe to this class to be notified about all DeadLetters (also the suppressed ones).
- AllForOneStrategy - Class in akka.actor
-
Applies the fault handling
Directive
(Resume, Restart, Stop) specified in the
Decider
to all children when one fails, as opposed to
OneForOneStrategy
that applies
it only to the child actor that failed.
- AllForOneStrategy(int, Duration, boolean, PartialFunction<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.AllForOneStrategy
-
- AllForOneStrategy(int, Duration, Function<Throwable, SupervisorStrategy.Directive>, boolean) - Constructor for class akka.actor.AllForOneStrategy
-
Java API
- AllForOneStrategy(int, Duration, Function<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.AllForOneStrategy
-
Java API
- AllForOneStrategy(int, Duration, Iterable<Class<? extends Throwable>>) - Constructor for class akka.actor.AllForOneStrategy
-
Java API
- AllForOneStrategy(int, Duration, PartialFunction<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.AllForOneStrategy
-
Java API: compatible with lambda expressions
This is an EXPERIMENTAL feature and is subject to change until it has received more real world testing.
- AllForOneStrategy(boolean, PartialFunction<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.AllForOneStrategy
-
Java API: compatible with lambda expressions
This is an EXPERIMENTAL feature and is subject to change until it has received more real world testing.
- AllForOneStrategy(PartialFunction<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.AllForOneStrategy
-
Java API: compatible with lambda expressions
This is an EXPERIMENTAL feature and is subject to change until it has received more real world testing.
- AllForOneStrategy() - Method in interface akka.actor.dsl.Creators.Act
-
- AllForOneStrategy$ - Class in akka.actor
-
- AllForOneStrategy$() - Constructor for class akka.actor.AllForOneStrategy$
-
- AllLogLevels() - Method in class akka.event.Logging$
-
- AllLogLevels() - Static method in class akka.event.Logging
-
- allowCorePoolTimeout() - Method in class akka.dispatch.ThreadPoolConfig
-
- AllRead$() - Constructor for class akka.io.TcpConnection.AllRead$
-
- amendConfig(Config) - Method in class akka.dispatch.BalancingDispatcherConfigurator$
-
- amendConfig(Config) - Static method in class akka.dispatch.BalancingDispatcherConfigurator
-
- anchor() - Method in class akka.actor.ActorSelection
-
- anchorPath() - Method in class akka.actor.ActorSelection
-
- anyEvent(FI.Apply2<Object, D, FSM.State<S, D>>) - Method in class akka.japi.pf.FSMStateFunctionBuilder
-
Add a case statement that matches on any type of event.
- apiCommand() - Method in class akka.io.SelectionHandler.WorkerForCommand
-
- append(Tcp.WriteCommand) - Method in class akka.io.Tcp.SimpleWriteCommand
-
Java API: appends this command with another WriteCommand
to form a CompoundWrite
.
- append(ByteString) - Method in class akka.util.ByteStringBuilder
-
Java API: append a ByteString to this builder.
- apply(Object) - Method in class akka.actor.Actor.emptyBehavior$
-
- apply(Object) - Method in class akka.actor.Actor.ignoringBehavior$
-
- apply(ActorRef, String, Throwable) - Method in class akka.actor.ActorInitializationException$
-
- apply(String) - Method in class akka.actor.ActorInitializationException$
-
- apply(ActorRef, String, Throwable) - Static method in exception akka.actor.ActorInitializationException
-
- apply(String) - Static method in exception akka.actor.ActorInitializationException
-
- apply(ActorRef, String) - Method in class akka.actor.ActorSelection$
-
Construct an ActorSelection from the given string representing a path
relative to the given target.
- apply(ActorRef, Iterable<String>) - Method in class akka.actor.ActorSelection$
-
Construct an ActorSelection from the given string representing a path
relative to the given target.
- apply(ActorRef, String) - Static method in class akka.actor.ActorSelection
-
Construct an ActorSelection from the given string representing a path
relative to the given target.
- apply(ActorRef, Iterable<String>) - Static method in class akka.actor.ActorSelection
-
Construct an ActorSelection from the given string representing a path
relative to the given target.
- apply() - Method in class akka.actor.ActorSystem$
-
Creates a new ActorSystem with the name "default",
obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader,
then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader
associated with the ActorSystem class.
- apply(String) - Method in class akka.actor.ActorSystem$
-
Creates a new ActorSystem with the specified name,
obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader,
then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader
associated with the ActorSystem class.
- apply(String, Config) - Method in class akka.actor.ActorSystem$
-
Creates a new ActorSystem with the specified name, and the specified Config, then
obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader,
then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader
associated with the ActorSystem class.
- apply(String, Config, ClassLoader) - Method in class akka.actor.ActorSystem$
-
Creates a new ActorSystem with the specified name, the specified Config, and specified ClassLoader
- apply(String, Option<Config>, Option<ClassLoader>, Option<ExecutionContext>) - Method in class akka.actor.ActorSystem$
-
Creates a new ActorSystem with the specified name,
the specified ClassLoader if given, otherwise obtains the current ClassLoader by first inspecting the current
threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then
falls back to the ClassLoader associated with the ActorSystem class.
- apply() - Static method in class akka.actor.ActorSystem
-
Creates a new ActorSystem with the name "default",
obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader,
then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader
associated with the ActorSystem class.
- apply(String) - Static method in class akka.actor.ActorSystem
-
Creates a new ActorSystem with the specified name,
obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader,
then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader
associated with the ActorSystem class.
- apply(String, Config) - Static method in class akka.actor.ActorSystem
-
Creates a new ActorSystem with the specified name, and the specified Config, then
obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader,
then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader
associated with the ActorSystem class.
- apply(String, Config, ClassLoader) - Static method in class akka.actor.ActorSystem
-
Creates a new ActorSystem with the specified name, the specified Config, and specified ClassLoader
- apply(String, Option<Config>, Option<ClassLoader>, Option<ExecutionContext>) - Static method in class akka.actor.ActorSystem
-
Creates a new ActorSystem with the specified name,
the specified ClassLoader if given, otherwise obtains the current ClassLoader by first inspecting the current
threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then
falls back to the ClassLoader associated with the ActorSystem class.
- apply(String, String) - Method in class akka.actor.Address$
-
Constructs a new Address with the specified protocol and system name
- apply(String, String, String, int) - Method in class akka.actor.Address$
-
Constructs a new Address with the specified protocol, system name, host and port
- apply(String, String) - Static method in class akka.actor.Address
-
Constructs a new Address with the specified protocol and system name
- apply(String, String, String, int) - Static method in class akka.actor.Address
-
Constructs a new Address with the specified protocol, system name, host and port
- apply(String) - Method in class akka.actor.AddressFromURIString$
-
Try to construct an Address from the given String or throw a java.net.MalformedURLException.
- apply(String) - Static method in class akka.actor.AddressFromURIString
-
Try to construct an Address from the given String or throw a java.net.MalformedURLException.
- apply(ChildStats) - Method in class akka.actor.dungeon.ChildrenContainer.ChildrenIterable
-
- apply(ChildStats) - Method in class akka.actor.dungeon.ChildrenContainer.ChildRestartsIterable
-
- apply(TreeMap<String, ChildStats>) - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer$
-
- apply(ActorSystem) - Method in interface akka.actor.ExtensionId
-
Returns an instance of the extension identified by this ExtensionId instance.
- apply(Object) - Method in class akka.actor.FSM.NullFunction$
-
- apply(Class<?>, Seq<Object>) - Method in class akka.actor.IndirectActorProducer$
-
- apply(ClassTag<T>) - Method in class akka.actor.Props$
-
- apply(Function0<T>, ClassTag<T>) - Method in class akka.actor.Props$
-
- apply(Class<?>, Seq<Object>) - Method in class akka.actor.Props$
-
- apply(ClassTag<T>) - Static method in class akka.actor.Props
-
- apply(Function0<T>, ClassTag<T>) - Static method in class akka.actor.Props
-
- apply(Class<?>, Seq<Object>) - Static method in class akka.actor.Props
-
- apply(ActorRef) - Method in class akka.actor.SerializedActorRef$
-
- apply(ActorRef) - Static method in class akka.actor.SerializedActorRef
-
- apply(ActorContext) - Method in class akka.actor.TypedActor$
-
Returns a contextual TypedActorFactory of this extension, this means that any TypedActors created by this TypedActorExtension
will be children to the specified context, this allows for creating hierarchies of TypedActors.
- apply(ActorContext) - Static method in class akka.actor.TypedActor
-
Returns a contextual TypedActorFactory of this extension, this means that any TypedActors created by this TypedActorExtension
will be children to the specified context, this allows for creating hierarchies of TypedActors.
- apply(Object) - Method in class akka.actor.TypedActor.MethodCall
-
Invokes the Method on the supplied instance
- apply(Class<T>) - Method in class akka.actor.TypedProps$
-
Uses the supplied class as the factory for the TypedActor implementation,
proxying all the interfaces it implements.
- apply(Class<? super T>, Class<T>) - Method in class akka.actor.TypedProps$
-
Uses the supplied class as the factory for the TypedActor implementation,
and that has the specified interface,
or if the interface class is not an interface, all the interfaces it implements,
appended in the sequence of interfaces.
- apply(Class<? super T>, Function0<T>) - Method in class akka.actor.TypedProps$
-
Uses the supplied thunk as the factory for the TypedActor implementation,
and that has the specified interface,
or if the interface class is not an interface, all the interfaces it implements,
appended in the sequence of interfaces.
- apply(ClassTag<T>) - Method in class akka.actor.TypedProps$
-
Uses the supplied class as the factory for the TypedActor implementation,
proxying all the interfaces it implements.
- apply(Seq<Class<?>>, Function0<T>) - Method in class akka.actor.TypedProps$
-
INTERNAL API
- apply(Class<T>) - Static method in class akka.actor.TypedProps
-
Uses the supplied class as the factory for the TypedActor implementation,
proxying all the interfaces it implements.
- apply(Class<? super T>, Class<T>) - Static method in class akka.actor.TypedProps
-
Uses the supplied class as the factory for the TypedActor implementation,
and that has the specified interface,
or if the interface class is not an interface, all the interfaces it implements,
appended in the sequence of interfaces.
- apply(Class<? super T>, Function0<T>) - Static method in class akka.actor.TypedProps
-
Uses the supplied thunk as the factory for the TypedActor implementation,
and that has the specified interface,
or if the interface class is not an interface, all the interfaces it implements,
appended in the sequence of interfaces.
- apply(ClassTag<T>) - Static method in class akka.actor.TypedProps
-
Uses the supplied class as the factory for the TypedActor implementation,
proxying all the interfaces it implements.
- apply(Seq<Class<?>>, Function0<T>) - Static method in class akka.actor.TypedProps
-
INTERNAL API
- apply(Object, ActorRef, ActorSystem) - Method in class akka.dispatch.Envelope$
-
- apply(Object, ActorRef, ActorSystem) - Static method in class akka.dispatch.Envelope
-
- apply(T) - Method in class akka.dispatch.japi.BooleanFunctionBridge
-
- apply(T) - Method in class akka.dispatch.japi.CallbackBridge
-
- apply(Throwable) - Method in class akka.dispatch.japi.RecoverBridge
-
- apply(T) - Method in class akka.dispatch.japi.UnitFunctionBridge
-
- apply(T) - Method in class akka.dispatch.Mapper
-
Override this method to perform the map operation, by default delegates to "checkedApply"
which by default throws an UnsupportedOperationException.
- apply(Function1<Object, Object>) - Method in class akka.dispatch.PriorityGenerator$
-
Creates a PriorityGenerator that uses the supplied function as priority generator
- apply(Function1<Object, Object>) - Static method in class akka.dispatch.PriorityGenerator
-
Creates a PriorityGenerator that uses the supplied function as priority generator
- apply(ActorSystem, T, LogSource<T>) - Method in class akka.event.Logging$
-
Obtain LoggingAdapter for the given actor system and source object.
- apply(LoggingBus, T, LogSource<T>) - Method in class akka.event.Logging$
-
Obtain LoggingAdapter for the given logging bus and source object.
- apply(Actor) - Method in class akka.event.Logging$
-
Obtain LoggingAdapter with MDC support for the given actor.
- apply(ActorSystem, T, LogSource<T>) - Static method in class akka.event.Logging
-
Obtain LoggingAdapter for the given actor system and source object.
- apply(LoggingBus, T, LogSource<T>) - Static method in class akka.event.Logging
-
Obtain LoggingAdapter for the given logging bus and source object.
- apply(Actor) - Static method in class akka.event.Logging
-
Obtain LoggingAdapter with MDC support for the given actor.
- apply(String, Class<?>, Object, Map<String, Object>) - Method in class akka.event.Logging.Debug$
-
- apply(String, Class<?>, Object) - Method in class akka.event.Logging.Error$
-
- apply(Throwable, String, Class<?>, Object, Map<String, Object>) - Method in class akka.event.Logging.Error$
-
- apply(String, Class<?>, Object, Map<String, Object>) - Method in class akka.event.Logging.Error$
-
- apply(String, Class<?>, Object, Map<String, Object>) - Method in class akka.event.Logging.Info$
-
- apply(String, Class<?>, Object, Map<String, Object>) - Method in class akka.event.Logging.Warning$
-
- apply(PartialFunction<Object, BoxedUnit>, ActorContext) - Method in class akka.event.LoggingReceive$
-
Wrap a Receive partial function in a logging enclosure, which sends a
debug message to the event bus each time before a message is matched.
- apply(Object) - Method in class akka.event.LoggingReceive
-
- apply(T, LogSource<T>) - Method in class akka.event.LogSource$
-
Convenience converter access: given an implicit LogSource
, generate the
string representation and originating class.
- apply(T, ActorSystem, LogSource<T>) - Method in class akka.event.LogSource$
-
Convenience converter access: given an implicit
LogSource
and
ActorSystem
, generate the string representation and
originating class.
- apply(String, Iterable<InetAddress>) - Method in class akka.io.Dns.Resolved$
-
- apply() - Method in class akka.io.Inet.DatagramChannelCreator$
-
- apply(ExtensionId<T>, ActorSystem) - Method in class akka.io.IO$
-
Scala API: obtain a reference to the manager actor for the given IO extension,
for example
Tcp
or
Udp
.
- apply(ExtensionId<T>, ActorSystem) - Static method in class akka.io.IO
-
Scala API: obtain a reference to the manager actor for the given IO extension,
for example
Tcp
or
Udp
.
- apply(ByteString) - Method in class akka.io.Tcp.Write$
-
Create a new unacknowledged Write command with the given data.
- apply(Iterable<Tcp.WriteCommand>) - Method in class akka.io.Tcp.WriteCommand$
-
Combines the given number of write commands into one atomic WriteCommand
.
- apply(ByteString, InetSocketAddress) - Method in class akka.io.Udp.Send$
-
- apply(ByteString) - Method in class akka.io.UdpConnected.Send$
-
- apply() - Method in interface akka.japi.Effect
-
- apply(T) - Method in interface akka.japi.Function
-
- apply() - Method in interface akka.japi.function.Effect
-
- apply(T) - Method in interface akka.japi.function.Function
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Method in interface akka.japi.function.Function10
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Method in interface akka.japi.function.Function11
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Method in interface akka.japi.function.Function12
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Method in interface akka.japi.function.Function13
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Method in interface akka.japi.function.Function14
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Method in interface akka.japi.function.Function15
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Method in interface akka.japi.function.Function16
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Method in interface akka.japi.function.Function17
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Method in interface akka.japi.function.Function18
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Method in interface akka.japi.function.Function19
-
- apply(T1, T2) - Method in interface akka.japi.function.Function2
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Method in interface akka.japi.function.Function20
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Method in interface akka.japi.function.Function21
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Method in interface akka.japi.function.Function22
-
- apply(T1, T2, T3) - Method in interface akka.japi.function.Function3
-
- apply(T1, T2, T3, T4) - Method in interface akka.japi.function.Function4
-
- apply(T1, T2, T3, T4, T5) - Method in interface akka.japi.function.Function5
-
- apply(T1, T2, T3, T4, T5, T6) - Method in interface akka.japi.function.Function6
-
- apply(T1, T2, T3, T4, T5, T6, T7) - Method in interface akka.japi.function.Function7
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8) - Method in interface akka.japi.function.Function8
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in interface akka.japi.function.Function9
-
- apply(T) - Method in interface akka.japi.function.Procedure
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Method in interface akka.japi.function.Procedure10
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Method in interface akka.japi.function.Procedure11
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Method in interface akka.japi.function.Procedure12
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Method in interface akka.japi.function.Procedure13
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Method in interface akka.japi.function.Procedure14
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Method in interface akka.japi.function.Procedure15
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Method in interface akka.japi.function.Procedure16
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Method in interface akka.japi.function.Procedure17
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Method in interface akka.japi.function.Procedure18
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Method in interface akka.japi.function.Procedure19
-
- apply(T1, T2) - Method in interface akka.japi.function.Procedure2
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Method in interface akka.japi.function.Procedure20
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Method in interface akka.japi.function.Procedure21
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Method in interface akka.japi.function.Procedure22
-
- apply(T1, T2, T3) - Method in interface akka.japi.function.Procedure3
-
- apply(T1, T2, T3, T4) - Method in interface akka.japi.function.Procedure4
-
- apply(T1, T2, T3, T4, T5) - Method in interface akka.japi.function.Procedure5
-
- apply(T1, T2, T3, T4, T5, T6) - Method in interface akka.japi.function.Procedure6
-
- apply(T1, T2, T3, T4, T5, T6, T7) - Method in interface akka.japi.function.Procedure7
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8) - Method in interface akka.japi.function.Procedure8
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in interface akka.japi.function.Procedure9
-
- apply(T1, T2) - Method in interface akka.japi.Function2
-
- apply(A, boolean) - Method in class akka.japi.JavaPartialFunction
-
- apply(A) - Method in class akka.japi.JavaPartialFunction
-
- apply(F) - Method in class akka.japi.pf.CaseStatement
-
- apply(I) - Method in interface akka.japi.pf.FI.Apply
-
The application to perform.
- apply(I1, I2) - Method in interface akka.japi.pf.FI.Apply2
-
The application to perform.
- apply(I) - Method in interface akka.japi.pf.FI.UnitApply
-
The application to perform.
- apply(I1, I2) - Method in interface akka.japi.pf.FI.UnitApply2
-
The application to perform.
- apply(I1, I2, I3) - Method in interface akka.japi.pf.FI.UnitApply3
-
The application to perform.
- apply(I1, I2, I3, I4) - Method in interface akka.japi.pf.FI.UnitApply4
-
The application to perform.
- apply() - Method in interface akka.japi.pf.FI.UnitApplyVoid
-
The application to perform.
- apply(F) - Method in class akka.japi.pf.UnitCaseStatement
-
- apply(T) - Method in interface akka.japi.Procedure
-
- apply(Scheduler, int, FiniteDuration, FiniteDuration) - Method in class akka.pattern.CircuitBreaker$
-
Create a new CircuitBreaker.
- apply(Scheduler, int, FiniteDuration, FiniteDuration) - Static method in class akka.pattern.CircuitBreaker
-
Create a new CircuitBreaker.
- apply(ActorRefProvider, Timeout, Object, String, ActorRef) - Method in class akka.pattern.PromiseActorRef$
-
- apply(ActorRefProvider, Timeout, String) - Method in class akka.pattern.PromiseActorRef$
-
- apply(ActorRefProvider, Timeout, Object, String, ActorRef) - Static method in class akka.pattern.PromiseActorRef
-
- apply(ActorRefProvider, Timeout, String) - Static method in class akka.pattern.PromiseActorRef
-
- apply() - Method in class akka.routing.BalancingRoutingLogic$
-
- apply() - Static method in class akka.routing.BalancingRoutingLogic
-
- apply() - Method in class akka.routing.BroadcastRoutingLogic$
-
- apply() - Static method in class akka.routing.BroadcastRoutingLogic
-
- apply(Iterable<T>, int, ClassTag<T>) - Method in class akka.routing.ConsistentHash$
-
- apply(Iterable<T>, int, ClassTag<T>) - Static method in class akka.routing.ConsistentHash
-
- apply(Object) - Method in class akka.routing.ConsistentHashingRouter.emptyConsistentHashMapping$
-
- apply(Config) - Method in class akka.routing.DefaultResizer$
-
Creates a new DefaultResizer from the given configuration
- apply(Config) - Static method in class akka.routing.DefaultResizer
-
Creates a new DefaultResizer from the given configuration
- apply(Option<Resizer>, SupervisorStrategy, String) - Method in class akka.routing.FromConfig$
-
- apply(Option<Resizer>, SupervisorStrategy, String) - Static method in class akka.routing.FromConfig
-
- apply() - Method in class akka.routing.RandomRoutingLogic$
-
- apply() - Static method in class akka.routing.RandomRoutingLogic
-
- apply() - Method in class akka.routing.RoundRobinRoutingLogic$
-
- apply() - Static method in class akka.routing.RoundRobinRoutingLogic
-
- apply() - Method in class akka.routing.SmallestMailboxRoutingLogic$
-
- apply() - Static method in class akka.routing.SmallestMailboxRoutingLogic
-
- apply(Class<?>) - Method in class akka.util.BoxedType$
-
- apply(Class<?>) - Static method in class akka.util.BoxedType
-
- apply(byte[]) - Method in class akka.util.ByteIterator.ByteArrayIterator$
-
- apply(byte[], int, int) - Method in class akka.util.ByteIterator.ByteArrayIterator$
-
- apply(LinearSeq<ByteIterator.ByteArrayIterator>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator$
-
- apply(byte[]) - Method in class akka.util.ByteString$
-
Creates a new ByteString by copying a byte array.
- apply(Seq<Object>) - Method in class akka.util.ByteString$
-
Creates a new ByteString by copying bytes.
- apply(Seq<T>, Integral<T>) - Method in class akka.util.ByteString$
-
Creates a new ByteString by converting from integral numbers to bytes.
- apply(ByteBuffer) - Method in class akka.util.ByteString$
-
Creates a new ByteString by copying bytes from a ByteBuffer.
- apply(String) - Method in class akka.util.ByteString$
-
Creates a new ByteString by encoding a String as UTF-8.
- apply(String, String) - Method in class akka.util.ByteString$
-
Creates a new ByteString by encoding a String with a charset.
- apply(int) - Method in class akka.util.ByteString
-
- apply(byte[]) - Method in class akka.util.ByteString.ByteString1$
-
- apply(byte[], int, int) - Method in class akka.util.ByteString.ByteString1$
-
- apply(int) - Method in class akka.util.ByteString.ByteString1
-
- apply(byte[]) - Method in class akka.util.ByteString.ByteString1C$
-
- apply(int) - Method in class akka.util.ByteString.ByteString1C
-
- apply(Vector<ByteString.ByteString1>) - Method in class akka.util.ByteString.ByteStrings$
-
- apply(Vector<ByteString.ByteString1>, int) - Method in class akka.util.ByteString.ByteStrings$
-
- apply(ByteString.ByteString1, ByteString.ByteString1) - Method in class akka.util.ByteString.ByteStrings$
-
- apply(ByteString.ByteString1, ByteString.ByteStrings) - Method in class akka.util.ByteString.ByteStrings$
-
- apply(ByteString.ByteStrings, ByteString.ByteString1) - Method in class akka.util.ByteString.ByteStrings$
-
- apply(ByteString.ByteStrings, ByteString.ByteStrings) - Method in class akka.util.ByteString.ByteStrings$
-
- apply(int) - Method in class akka.util.ByteString.ByteStrings
-
- apply(byte) - Method in class akka.util.ByteString.Companion$
-
- apply(int) - Method in class akka.util.Collections.EmptyImmutableSeq$
-
- apply(From) - Method in class akka.util.Collections.PartialImmutableValuesIterable
-
- apply(byte[]) - Method in class akka.util.CompactByteString$
-
Creates a new CompactByteString by copying a byte array.
- apply(Seq<Object>) - Method in class akka.util.CompactByteString$
-
Creates a new CompactByteString by copying bytes.
- apply(Seq<T>, Integral<T>) - Method in class akka.util.CompactByteString$
-
Creates a new CompactByteString by converting from integral numbers to bytes.
- apply(ByteBuffer) - Method in class akka.util.CompactByteString$
-
Creates a new CompactByteString by copying bytes from a ByteBuffer.
- apply(String) - Method in class akka.util.CompactByteString$
-
Creates a new CompactByteString by encoding a String as UTF-8.
- apply(String, String) - Method in class akka.util.CompactByteString$
-
Creates a new CompactByteString by encoding a String with a charset.
- apply(byte[]) - Static method in class akka.util.CompactByteString
-
Creates a new CompactByteString by copying a byte array.
- apply(Seq<Object>) - Static method in class akka.util.CompactByteString
-
Creates a new CompactByteString by copying bytes.
- apply(Seq<T>, Integral<T>) - Static method in class akka.util.CompactByteString
-
Creates a new CompactByteString by converting from integral numbers to bytes.
- apply(ByteBuffer) - Static method in class akka.util.CompactByteString
-
Creates a new CompactByteString by copying bytes from a ByteBuffer.
- apply(String) - Static method in class akka.util.CompactByteString
-
Creates a new CompactByteString by encoding a String as UTF-8.
- apply(String, String) - Static method in class akka.util.CompactByteString
-
Creates a new CompactByteString by encoding a String with a charset.
- apply(Object) - Method in class akka.util.LineNumbers$
-
Scala API: Obtain line number information for the class defining the given object.
- apply(Object) - Static method in class akka.util.LineNumbers
-
Scala API: Obtain line number information for the class defining the given object.
- apply(int, ExecutionContext) - Method in class akka.util.SerializedSuspendableExecutionContext$
-
- apply(int, ExecutionContext) - Static method in class akka.util.SerializedSuspendableExecutionContext
-
- apply(long, TimeUnit) - Method in class akka.util.Timeout$
-
Construct a Timeout from the given time unit and factor.
- apply(long, TimeUnit) - Static method in class akka.util.Timeout
-
Construct a Timeout from the given time unit and factor.
- apply() - Method in class akka.util.WildcardTree$
-
- apply() - Static method in class akka.util.WildcardTree
-
- 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
-
- ArgsReflectConstructor - Class in akka.actor
-
INTERNAL API
- ArgsReflectConstructor(Class<? extends Actor>, Seq<Object>) - Constructor for class akka.actor.ArgsReflectConstructor
-
- aroundPostRestart(Throwable) - Method in interface akka.actor.Actor
-
Can be overridden to intercept calls to postRestart
.
- aroundPostStop() - Method in interface akka.actor.Actor
-
Can be overridden to intercept calls to postStop
.
- aroundPreRestart(Throwable, Option<Object>) - Method in interface akka.actor.Actor
-
Can be overridden to intercept calls to preRestart
.
- aroundPreStart() - Method in interface akka.actor.Actor
-
Can be overridden to intercept calls to preStart
.
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.actor.Actor
-
INTERNAL API.
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.actor.DiagnosticActorLogging
-
- 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, ActorRef) - Method in class akka.pattern.AskableActorRef
-
- ask(Object, Timeout) - Method in class akka.pattern.AskableActorSelection
-
- ask(Object, Timeout, ActorRef) - 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(ActorRef, Object, ActorRef, Timeout) - Method in interface akka.pattern.AskSupport
-
- 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(ActorSelection, Object, ActorRef, Timeout) - Method in interface akka.pattern.AskSupport
-
- 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.
- AskTimeoutException - Exception in akka.pattern
-
This is what is used to complete a Future that is returned from an ask/? call,
when it times out.
- AskTimeoutException(String, Throwable) - Constructor for exception akka.pattern.AskTimeoutException
-
- AskTimeoutException(String) - Constructor for exception akka.pattern.AskTimeoutException
-
- asOutputStream() - Method in class akka.util.ByteStringBuilder
-
Directly wraps this ByteStringBuilder in an OutputStream.
- asScala() - Method in class akka.japi.Option
-
- asScala() - Method in class akka.japi.Option.Some
-
- associate(ActorRef, ActorRef) - Method in interface akka.event.ActorClassification
-
- associate(ActorRef, ActorRef) - Method in interface akka.event.ManagedActorClassification
-
- async() - Method in class akka.dispatch.sysmsg.Supervise
-
- asyncMode() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory
-
- atFullThrottle() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinPool
-
- atFullThrottle() - Method in interface akka.dispatch.LoadMetrics
-
- atKey(String) - Method in class akka.dispatch.CachingConfig
-
- atPath(String) - Method in class akka.dispatch.CachingConfig
-
- attach(ActorCell) - Method in class akka.dispatch.MessageDispatcher
-
Attaches the specified actor instance to this dispatcher, which includes
scheduling it to run for the first time (Create() is expected to have
been enqueued by the ActorCell upon mailbox creation).
- attach() - Method in class akka.util.SerializedSuspendableExecutionContext
-
- attachChild(Props, boolean) - Method in interface akka.actor.dungeon.Children
-
- attachChild(Props, String, boolean) - Method in interface akka.actor.dungeon.Children
-
- AutoReceivedMessage - Interface in akka.actor
-
INTERNAL API
- autoReceiveMessage(akka.dispatch.Envelope) - Method in class akka.actor.ActorCell
-
- awaitTermination(Duration) - Method in class akka.actor.ActorSystem
-
Block current thread until the system has been shutdown, or the specified
timeout has elapsed.
- awaitTermination() - Method in class akka.actor.ActorSystem
-
Block current thread until the system has been shutdown.
- awaitTermination(Duration) - Method in class akka.actor.ActorSystemImpl
-
- awaitTermination() - Method in class akka.actor.ActorSystemImpl
-
- awaitTermination(long, TimeUnit) - Method in interface akka.dispatch.ExecutorServiceDelegate
-
- c() - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
-
- c() - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
-
- cache() - Method in interface akka.event.SubchannelClassification
-
- cache() - Method in class akka.io.DnsExt
-
- cache() - Method in interface akka.io.DnsProvider
-
- cache() - Method in class akka.io.InetAddressDnsProvider
-
- cached(String, ActorSystem) - Method in class akka.io.Dns$
-
- cached(String) - Method in class akka.io.Dns
-
- cached(String) - Method in class akka.io.SimpleDnsCache
-
- CachingConfig - Class in akka.dispatch
-
INTERNAL API
- CachingConfig(Config) - Constructor for class akka.dispatch.CachingConfig
-
- cachingConfig() - Method in class akka.dispatch.Dispatchers
-
- CachingConfig$ - Class in akka.dispatch
-
INTERNAL API
- CachingConfig$() - Constructor for class akka.dispatch.CachingConfig$
-
- CachingConfig.PathEntry - Interface in akka.dispatch
-
- CachingConfig.StringPathEntry - Class in akka.dispatch
-
- CachingConfig.StringPathEntry$ - Class in akka.dispatch
-
- CachingConfig.ValuePathEntry - Class in akka.dispatch
-
- CachingConfig.ValuePathEntry$ - Class in akka.dispatch
-
- CallbackBridge() - Constructor for class akka.dispatch.japi.CallbackBridge
-
- callWithCircuitBreaker(Callable<Future<T>>) - Method in class akka.pattern.CircuitBreaker
-
- callWithSyncCircuitBreaker(Callable<T>) - Method in class akka.pattern.CircuitBreaker
-
- canBeScheduledForExecution(boolean, boolean) - Method in class akka.dispatch.Mailbox
-
- canBuildFrom() - Method in class akka.util.ByteString$
-
- canBuildFrom() - Static method in class akka.util.ByteString
-
- cancel() - Method in interface akka.actor.Cancellable
-
Cancels this Cancellable and returns true if that was successful.
- cancel() - Method in class akka.actor.FSM.Timer
-
- cancel() - Method in class akka.actor.LightArrayRevolverScheduler.TaskHolder
-
- Cancellable - Interface in akka.actor
-
Signifies something that can be cancelled
There is no strict guarantee that the implementation is thread-safe,
but it should be good practice to make it so.
- cancelReceiveTimeout() - Method in interface akka.actor.dungeon.ReceiveTimeout
-
- cancelTimer(String) - Method in interface akka.actor.FSM
-
- capacity() - Method in interface akka.actor.StashSupport
-
- capacity() - Method in class akka.dispatch.AbstractBoundedNodeQueue
-
- capacity() - Method in class akka.dispatch.BoundedControlAwareMailbox
-
- capacity() - Method in class akka.dispatch.BoundedControlAwareMailbox.MessageQueue
-
- 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.dispatch.BoundedStablePriorityMailbox
-
- capacity() - Method in class akka.dispatch.NonBlockingBoundedMailbox
-
- capacity(IndexedSeq<Routee>) - Method in class akka.routing.DefaultResizer
-
Returns the overall desired change in resizer capacity.
- CaseStatement<F,P,T> - Class in akka.japi.pf
-
- CaseStatement(FI.Predicate, FI.Apply<P, T>) - Constructor for class akka.japi.pf.CaseStatement
-
- CaseStatement$ - Class in akka.japi.pf
-
- CaseStatement$() - Constructor for class akka.japi.pf.CaseStatement$
-
- cause() - Method in class akka.actor.dungeon.ChildrenContainer.Recreation
-
- cause() - Method in class akka.actor.FSM.Failure
-
- cause() - Method in exception akka.actor.PostRestartException
-
- cause() - Method in exception akka.actor.PreRestartException
-
- cause() - Method in class akka.actor.Status.Failure
-
- cause() - Method in class akka.dispatch.sysmsg.Failed
-
- cause() - Method in class akka.dispatch.sysmsg.Recreate
-
- cause() - Method in class akka.event.Logging.Error
-
- cause() - Method in class akka.io.Tcp.ErrorClosed
-
- causedByFailure() - Method in class akka.dispatch.sysmsg.Resume
-
- Cell - Interface in akka.actor
-
INTERNAL API
- cell() - Method in class akka.routing.RouterActor
-
- change() - Method in class akka.routing.AdjustPoolSize
-
- channel() - Method in class akka.io.TcpConnection
-
- channel() - Method in class akka.io.TcpListener
-
- channel() - Method in class akka.io.TcpListener.FailedRegisterIncoming
-
- channel() - Method in class akka.io.TcpListener.RegisterIncoming
-
- channel() - Method in class akka.io.UdpConnection
-
- channel() - Method in class akka.io.UdpListener
-
- channel() - Method in class akka.io.UdpSender
-
- channel() - Method in interface akka.io.WithUdpSend
-
- ChannelAcceptable$() - Constructor for class akka.io.SelectionHandler.ChannelAcceptable$
-
- ChannelConnectable$() - Constructor for class akka.io.SelectionHandler.ChannelConnectable$
-
- ChannelReadable$() - Constructor for class akka.io.SelectionHandler.ChannelReadable$
-
- ChannelRegistration - Interface in akka.io
-
Implementations of this interface are sent as actor messages back to a channel actor as
a result of it having called register
on the ChannelRegistry
.
- ChannelRegistry - Interface in akka.io
-
Interface behind which we hide our selector management logic from the connection actors
- ChannelWritable$() - Constructor for class akka.io.SelectionHandler.ChannelWritable$
-
- checkedApply(T) - Method in class akka.dispatch.Mapper
-
Override this method if you need to throw checked exceptions
- checkName(String) - Method in interface akka.actor.dungeon.Children
-
- checkReceiveTimeout() - Method in interface akka.actor.dungeon.ReceiveTimeout
-
- checkValid(Config, Seq<String>) - Method in class akka.dispatch.CachingConfig
-
- checkValid(Config, String[]) - Method in class akka.dispatch.CachingConfig
-
- child(String) - Method in interface akka.actor.ActorContext
-
Get the child with the given name if it exists.
- child(String) - Method in interface akka.actor.ActorPath
-
Java API: Create a new child actor path.
- child(String) - Method in class akka.actor.ActorSystem
-
Java API: Create a new child actor path.
- child() - Method in class akka.actor.ChildRestartStats
-
- child(String) - Method in interface akka.actor.dungeon.Children
-
- child() - Method in class akka.actor.StopChild
-
- child() - Method in class akka.dispatch.sysmsg.Failed
-
- child() - Method in class akka.dispatch.sysmsg.Supervise
-
- ChildActorPath - Class in akka.actor
-
- ChildActorPath(ActorPath, String, int) - Constructor for class akka.actor.ChildActorPath
-
- ChildActorPath(ActorPath, String) - Constructor for class akka.actor.ChildActorPath
-
- ChildNameReserved - Class in akka.actor
-
INTERNAL API
- ChildNameReserved() - Constructor for class akka.actor.ChildNameReserved
-
- ChildNameReserved$ - Class in akka.actor
-
INTERNAL API
- ChildNameReserved$() - Constructor for class akka.actor.ChildNameReserved$
-
- childProps() - Method in class akka.io.SelectionHandler.WorkerForCommand
-
- children() - Method in interface akka.actor.ActorContext
-
Returns all supervised children; this method returns a view (i.e.
- children() - Method in class akka.actor.ActorRefWithCell
-
- Children - Interface in akka.actor.dungeon
-
- children() - Method in interface akka.actor.dungeon.Children
-
- children() - Method in interface akka.actor.dungeon.ChildrenContainer
-
- children() - Method in interface akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer
-
- children() - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
-
- children() - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
-
- children() - Method in class akka.actor.LocalActorRef
-
- children() - Method in class akka.actor.RepointableActorRef
-
- children() - Method in class akka.util.WildcardTree
-
- ChildrenContainer - Interface in akka.actor.dungeon
-
INTERNAL API
- ChildrenContainer$ - Class in akka.actor.dungeon
-
INTERNAL API
- ChildrenContainer$() - Constructor for class akka.actor.dungeon.ChildrenContainer$
-
- ChildrenContainer.ChildrenIterable - Class in akka.actor.dungeon
-
- ChildrenContainer.ChildRestartsIterable - Class in akka.actor.dungeon
-
- ChildrenContainer.Creation - Class in akka.actor.dungeon
-
- ChildrenContainer.Creation$ - Class in akka.actor.dungeon
-
- ChildrenContainer.EmptyChildrenContainer - Interface in akka.actor.dungeon
-
- ChildrenContainer.EmptyChildrenContainer$ - Class in akka.actor.dungeon
-
This is the empty container, shared among all leaf actors.
- ChildrenContainer.NormalChildrenContainer - Class in akka.actor.dungeon
-
Normal children container: we do have at least one child, but none of our
children are currently terminating (which is the time period between
calling context.stop(child) and processing the ChildTerminated() system
message).
- ChildrenContainer.NormalChildrenContainer$ - Class in akka.actor.dungeon
-
- ChildrenContainer.Recreation - Class in akka.actor.dungeon
-
- ChildrenContainer.Recreation$ - Class in akka.actor.dungeon
-
- ChildrenContainer.SuspendReason - Interface in akka.actor.dungeon
-
- ChildrenContainer.TerminatedChildrenContainer$ - Class in akka.actor.dungeon
-
This is the empty container which is installed after the last child has
terminated while stopping; it is necessary to distinguish from the normal
empty state while calling handleChildTerminated() for the last time.
- ChildrenContainer.TerminatingChildrenContainer - Class in akka.actor.dungeon
-
Waiting state: there are outstanding termination requests (i.e.
- ChildrenContainer.TerminatingChildrenContainer$ - Class in akka.actor.dungeon
-
- ChildrenContainer.Termination$ - Class in akka.actor.dungeon
-
- ChildrenContainer.UserRequest$ - Class in akka.actor.dungeon
-
- ChildrenContainer.WaitingForChildren - Interface in akka.actor.dungeon
-
- ChildrenIterable(MapLike<?, ChildStats, ?>) - Constructor for class akka.actor.dungeon.ChildrenContainer.ChildrenIterable
-
- childrenRefs() - Method in interface akka.actor.Cell
-
All children of this actor, including only reserved-names.
- childrenRefs() - Method in interface akka.actor.dungeon.Children
-
- childrenRefs() - Method in class akka.actor.UnstartedCell
-
- ChildRestartsIterable(MapLike<?, ChildStats, ?>) - Constructor for class akka.actor.dungeon.ChildrenContainer.ChildRestartsIterable
-
- ChildRestartStats - Class in akka.actor
-
ChildRestartStats is the statistics kept by every parent Actor for every child Actor
and is used for SupervisorStrategies to know how to deal with problems that occur for the children.
- ChildRestartStats(ActorRef, int, long) - Constructor for class akka.actor.ChildRestartStats
-
- ChildRestartStats$ - Class in akka.actor
-
- ChildRestartStats$() - Constructor for class akka.actor.ChildRestartStats$
-
- ChildStats - Interface in akka.actor
-
INTERNAL API
- CircuitBreaker - Class in akka.pattern
-
Provides circuit breaker functionality to provide stability when working with "dangerous" operations, e.g.
- CircuitBreaker(Scheduler, int, FiniteDuration, FiniteDuration, ExecutionContext) - Constructor for class akka.pattern.CircuitBreaker
-
- CircuitBreaker(ExecutionContext, Scheduler, int, FiniteDuration, FiniteDuration) - Constructor for class akka.pattern.CircuitBreaker
-
- CircuitBreaker$ - Class in akka.pattern
-
Companion object providing factory methods for Circuit Breaker which runs callbacks in caller's thread
- CircuitBreaker$() - Constructor for class akka.pattern.CircuitBreaker$
-
- 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$
-
- classFor(Logging.LogLevel) - Method in class akka.event.Logging$
-
Returns the event class associated with the given LogLevel
- classFor(Logging.LogLevel) - Static method in class akka.event.Logging
-
Returns the event class associated with the given LogLevel
- classify(ActorClassification) - Method in interface akka.event.ActorClassification
-
Returns the Classifier associated with the specified Event
- classify(Object) - Method in class akka.event.EventStream
-
- classify(E) - Method in class akka.event.japi.ActorEventBus
-
Returns the Classifier associated with the given Event
- classify(E) - Method in class akka.event.japi.LookupEventBus
-
Returns the Classifier associated with the given Event
- classify(E) - Method in class akka.event.japi.ManagedActorEventBus
-
Returns the Classifier associated with the given Event
- classify(E) - Method in class akka.event.japi.SubchannelEventBus
-
Returns the Classifier associated with the given Event
- classify(LookupClassification) - Method in interface akka.event.LookupClassification
-
Returns the Classifier associated with the given Event
- classify(ManagedActorClassification) - Method in interface akka.event.ManagedActorClassification
-
Returns the Classifier associated with the specified Event
- classify(SubchannelClassification) - Method in interface akka.event.SubchannelClassification
-
Returns the Classifier associated with the given Event
- classLoader() - Method in class akka.actor.DynamicAccess
-
This is the class loader to be used in those special cases where the
other factory method are not applicable (e.g.
- classLoader() - Method in class akka.actor.ReflectiveDynamicAccess
-
- ClassLoaderObjectInputStream - Class in akka.util
-
ClassLoaderObjectInputStream tries to utilize the provided ClassLoader to load Classes and falls
back to ObjectInputStreams resolver.
- ClassLoaderObjectInputStream(ClassLoader, InputStream) - Constructor for class akka.util.ClassLoaderObjectInputStream
-
- classTag(Class<T>) - Method in class akka.japi.Util$
-
Returns a ClassTag describing the provided Class.
- classTag(Class<T>) - Static method in class akka.japi.Util
-
Returns a ClassTag describing the provided Class.
- clazz(Object) - Method in class akka.actor.ActorCell
-
- clazz() - Method in class akka.actor.Props
-
- cleanUp(ActorRef, MessageQueue) - Method in class akka.dispatch.BoundedNodeMessageQueue
-
- cleanUp() - Method in class akka.dispatch.Mailbox
-
Overridable callback to clean up the mailbox,
called when an actor is unregistered.
- cleanUp(ActorRef, MessageQueue) - Method in interface akka.dispatch.MessageQueue
-
Called when the mailbox this queue belongs to is disposed of.
- cleanUp(ActorRef, MessageQueue) - Method in class akka.dispatch.NodeMessageQueue
-
- cleanUp(ActorRef, MessageQueue) - Method in interface akka.dispatch.QueueBasedMessageQueue
-
- cleanup() - Method in class akka.dispatch.TaskInvocation
-
- cleanUp(ActorRef, MessageQueue) - Method in class akka.event.LoggerMailbox
-
- cleanup() - Method in interface akka.io.PeriodicCacheCleanup
-
- cleanup() - Method in class akka.io.SimpleDnsCache
-
- 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
- clearActorCellFields(ActorCell) - Method in class akka.actor.ActorCell
-
- clearActorFields(Actor, boolean) - Method in class akka.actor.ActorCell
-
- clearedList() - Method in class akka.util.ByteIterator.MultiByteArrayIterator$
-
- clearFailed() - Method in interface akka.actor.dungeon.FaultHandling
-
- clearMDC() - Method in interface akka.event.DiagnosticLoggingAdapter
-
Clear all entries in the MDC
- clearStash() - Method in interface akka.actor.StashSupport
-
INTERNAL API.
- 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
-
- clientPredicate() - Method in class akka.actor.dsl.Inbox.InboxActor
-
- clients() - Method in class akka.actor.dsl.Inbox.InboxActor
-
- clientsByTimeout() - Method in class akka.actor.dsl.Inbox.InboxActor
-
- clock() - Method in class akka.actor.LightArrayRevolverScheduler
-
Clock implementation is replaceable (for testing); the implementation must
return a monotonically increasing series of Long nanoseconds.
- clock() - Method in class akka.io.SimpleDnsCache
-
- clone() - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- clone() - Method in class akka.util.ByteIterator
-
- clone() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- close() - Method in class akka.actor.LightArrayRevolverScheduler
-
Shutdown the scheduler.
- 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.
- Close$() - Constructor for class akka.io.Tcp.Close$
-
- Closed() - Method in class akka.dispatch.Mailbox$
-
- Closed() - Static method in class akka.dispatch.Mailbox
-
- Closed$() - Constructor for class akka.io.Tcp.Closed$
-
- closedEvent() - Method in class akka.io.TcpConnection.CloseInformation
-
- closedMessage() - Method in class akka.io.TcpConnection
-
- CloseInformation(Set<ActorRef>, Tcp.Event) - Constructor for class akka.io.TcpConnection.CloseInformation
-
- CloseInformation$() - Constructor for class akka.io.TcpConnection.CloseInformation$
-
- closeReason() - Method in class akka.io.TcpConnection
-
- closing(TcpConnection.ConnectionInfo, Option<ActorRef>) - Method in class akka.io.TcpConnection
-
connection is closed on our side and we're waiting from confirmation from the other side
- closingWithPendingWrite(TcpConnection.ConnectionInfo, Option<ActorRef>, Tcp.ConnectionClosed) - Method in class akka.io.TcpConnection
-
connection is closing but a write has to be finished first
- cmd() - Method in class akka.io.Tcp.CommandFailed
-
- cmd() - Method in class akka.io.Udp.CommandFailed
-
- cmd() - Method in class akka.io.UdpConnected.CommandFailed
-
- cmp() - Method in class akka.dispatch.BoundedPriorityMailbox
-
- cmp() - Method in class akka.dispatch.BoundedStablePriorityMailbox
-
- cmp() - Method in class akka.dispatch.UnboundedPriorityMailbox
-
- cmp() - Method in class akka.dispatch.UnboundedStablePriorityMailbox
-
- cmp() - Method in class akka.util.PriorityQueueStabilizer.WrappedElementComparator
-
- Collections - Class in akka.util
-
INTERNAL API
- Collections() - Constructor for class akka.util.Collections
-
- Collections$ - Class in akka.util
-
INTERNAL API
- Collections$() - Constructor for class akka.util.Collections$
-
- Collections.EmptyImmutableSeq$ - Class in akka.util
-
- Collections.PartialImmutableValuesIterable<From,To> - Class in akka.util
-
- command() - Method in class akka.io.SelectionHandler.Retry
-
- commander() - Method in class akka.io.SelectionHandler.WorkerForCommand
-
- commander() - Method in class akka.io.TcpConnection.EmptyPendingWrite$
-
- commander() - Method in class akka.io.TcpConnection.PendingBufferWrite
-
- commander() - Method in class akka.io.TcpConnection.PendingWrite
-
- commander() - Method in class akka.io.TcpConnection.PendingWriteFile
-
- CommandFailed(Tcp.Command) - Constructor for class akka.io.Tcp.CommandFailed
-
- CommandFailed(Udp.Command) - Constructor for class akka.io.Udp.CommandFailed
-
- CommandFailed(UdpConnected.Command) - Constructor for class akka.io.UdpConnected.CommandFailed
-
- CommandFailed$() - Constructor for class akka.io.Tcp.CommandFailed$
-
- CommandFailed$() - Constructor for class akka.io.Udp.CommandFailed$
-
- CommandFailed$() - Constructor for class akka.io.UdpConnected.CommandFailed$
-
- 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$
-
- Companion$() - Constructor for class akka.util.ByteString.Companion$
-
- compare(Envelope, Envelope) - Method in class akka.dispatch.PriorityGenerator
-
- compare(ByteString, ByteString) - Method in class akka.util.ByteString.ByteStrings$
-
- compare(PriorityQueueStabilizer.WrappedElement<E>, PriorityQueueStabilizer.WrappedElement<E>) - Method in class akka.util.PriorityQueueStabilizer.WrappedElementComparator
-
- compareClassifiers(C, C) - Method in class akka.event.japi.ScanningEventBus
-
Provides a total ordering of Classifiers (think java.util.Comparator.compare)
- compareClassifiers(ScanningClassification, ScanningClassification) - Method in interface akka.event.ScanningClassification
-
Provides a total ordering of Classifiers (think java.util.Comparator.compare)
- compareIdentityHash(Object, Object) - Method in class akka.util.Helpers$
-
- compareIdentityHash(Object, Object) - Static method in class akka.util.Helpers
-
- compareSubscribers(ActorRef, ActorRef) - Method in interface akka.event.ActorEventBus
-
- compareSubscribers(S, S) - Method in class akka.event.japi.LookupEventBus
-
Provides a total ordering of Subscribers (think java.util.Comparator.compare)
- compareSubscribers(S, S) - Method in class akka.event.japi.ScanningEventBus
-
Provides a total ordering of Subscribers (think java.util.Comparator.compare)
- compareSubscribers(LookupClassification, LookupClassification) - Method in interface akka.event.LookupClassification
-
Provides a total ordering of Subscribers (think java.util.Comparator.compare)
- compareSubscribers(ScanningClassification, ScanningClassification) - Method in interface akka.event.ScanningClassification
-
Provides a total ordering of Subscribers (think java.util.Comparator.compare)
- compareTo(ActorRef) - Method in class akka.actor.ActorRef
-
Comparison takes path and the unique id of the actor cell into account.
- compareTo(ActorPath) - Method in class akka.actor.ChildActorPath
-
- compareTo(ActorPath) - Method in class akka.actor.RootActorPath
-
- completeConnect(ChannelRegistration, ActorRef, Traversable<Inet.SocketOption>) - Method in class akka.io.TcpConnection
-
used in subclasses to start the common machinery above once a channel is connected
- CompoundWrite(Tcp.SimpleWriteCommand, Tcp.WriteCommand) - Constructor for class akka.io.Tcp.CompoundWrite
-
- CompoundWrite$() - Constructor for class akka.io.Tcp.CompoundWrite$
-
- 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
-
- 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.dispatch.CachingConfig.PathEntry
-
- config() - Method in class akka.dispatch.CachingConfig.StringPathEntry
-
- config() - Method in class akka.dispatch.CachingConfig.ValuePathEntry
-
- config(String) - Method in class akka.dispatch.Dispatchers
-
INTERNAL API
- config(String, Config) - Method in class akka.dispatch.Dispatchers
-
INTERNAL API
- config() - Method in class akka.dispatch.MessageDispatcherConfigurator
-
- config() - Method in class akka.dispatch.ThreadPoolConfigBuilder
-
- config() - Method in class akka.serialization.Serialization.Settings
-
- config() - Method in class akka.util.Helpers.ConfigOps
-
- ConfigOps(Config) - Constructor for class akka.util.Helpers.ConfigOps
-
- ConfigOps$() - Constructor for class akka.util.Helpers.ConfigOps$
-
- 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(Seq<Option<Function1<ThreadPoolConfigBuilder, ThreadPoolConfigBuilder>>>) - Method in class akka.dispatch.ThreadPoolConfigBuilder
-
- 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.
- ConfirmedClose$() - Constructor for class akka.io.Tcp.ConfirmedClose$
-
- ConfirmedClosed$() - Constructor for class akka.io.Tcp.ConfirmedClosed$
-
- Connect(InetSocketAddress, Option<InetSocketAddress>, Traversable<Inet.SocketOption>, Option<FiniteDuration>, boolean) - Constructor for class akka.io.Tcp.Connect
-
- connect(InetSocketAddress, InetSocketAddress, Iterable<Inet.SocketOption>, FiniteDuration, boolean) - Method in class akka.io.TcpMessage$
-
The Connect message is sent to the TCP manager actor, which is obtained via
TcpExt.getManager()
.
- connect(InetSocketAddress) - Method in class akka.io.TcpMessage$
-
Connect to the given remoteAddress
without binding to a local address and without
specifying options.
- connect(InetSocketAddress, InetSocketAddress, Iterable<Inet.SocketOption>, FiniteDuration, boolean) - Static method in class akka.io.TcpMessage
-
The Connect message is sent to the TCP manager actor, which is obtained via
TcpExt.getManager()
.
- connect(InetSocketAddress) - Static method in class akka.io.TcpMessage
-
Connect to the given remoteAddress
without binding to a local address and without
specifying options.
- Connect(ActorRef, InetSocketAddress, Option<InetSocketAddress>, Traversable<Inet.SocketOption>) - Constructor for class akka.io.UdpConnected.Connect
-
- 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$() - Constructor for class akka.io.Tcp.Connect$
-
- Connect$() - Constructor for class akka.io.UdpConnected.Connect$
-
- Connected(InetSocketAddress, InetSocketAddress) - Constructor for class akka.io.Tcp.Connected
-
- connected(TcpConnection.ConnectionInfo) - Method in class akka.io.TcpConnection
-
normal connected state
- connected(ChannelRegistration) - Method in class akka.io.UdpConnection
-
- Connected$() - Constructor for class akka.io.Tcp.Connected$
-
- Connected$() - Constructor for class akka.io.UdpConnected.Connected$
-
- connecting(ChannelRegistration, int) - Method in class akka.io.TcpOutgoingConnection
-
- ConnectionInfo(ChannelRegistration, ActorRef, boolean, boolean) - Constructor for class akka.io.TcpConnection.ConnectionInfo
-
- ConnectionInfo$() - Constructor for class akka.io.TcpConnection.ConnectionInfo$
-
- connectionSupervisorStrategy() - Method in class akka.io.SelectionHandler$
-
Special supervisor strategy for parents of TCP connection and listener actors.
- connectionSupervisorStrategy() - Static method in class akka.io.SelectionHandler
-
Special supervisor strategy for parents of TCP connection and listener actors.
- ConsistentHash<T> - Class in akka.routing
-
Consistent Hashing node ring implementation.
- ConsistentHash$ - Class in akka.routing
-
- ConsistentHash$() - Constructor for class akka.routing.ConsistentHash$
-
- ConsistentHashableEnvelope(Object, Object) - Constructor for class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope
-
- ConsistentHashableEnvelope$() - Constructor for class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope$
-
- ConsistentHashingGroup - Class in akka.routing
-
A router group that uses consistent hashing to select a routee based on the
sent message.
- ConsistentHashingGroup(Iterable<String>, int, PartialFunction<Object, Object>, String) - Constructor for class akka.routing.ConsistentHashingGroup
-
- ConsistentHashingGroup(Config) - Constructor for class akka.routing.ConsistentHashingGroup
-
- ConsistentHashingGroup(Iterable<String>) - Constructor for class akka.routing.ConsistentHashingGroup
-
Java API
- ConsistentHashingGroup$ - Class in akka.routing
-
- ConsistentHashingGroup$() - Constructor for class akka.routing.ConsistentHashingGroup$
-
- ConsistentHashingPool - Class in akka.routing
-
A router pool that uses consistent hashing to select a routee based on the
sent message.
- ConsistentHashingPool(int, Option<Resizer>, int, PartialFunction<Object, Object>, SupervisorStrategy, String, boolean) - Constructor for class akka.routing.ConsistentHashingPool
-
- ConsistentHashingPool(Config) - Constructor for class akka.routing.ConsistentHashingPool
-
- ConsistentHashingPool(int) - Constructor for class akka.routing.ConsistentHashingPool
-
Java API
- ConsistentHashingPool$ - Class in akka.routing
-
- ConsistentHashingPool$() - Constructor for class akka.routing.ConsistentHashingPool$
-
- ConsistentHashingRouter - Class in akka.routing
-
- ConsistentHashingRouter() - Constructor for class akka.routing.ConsistentHashingRouter
-
- 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
-
- ConsistentHashingRouter.ConsistentHashableEnvelope$ - Class in akka.routing
-
- 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
-
- ConsistentHashingRoutingLogic - Class in akka.routing
-
- ConsistentHashingRoutingLogic(ActorSystem, int, PartialFunction<Object, Object>) - Constructor for class akka.routing.ConsistentHashingRoutingLogic
-
- ConsistentHashingRoutingLogic(ActorSystem) - Constructor for class akka.routing.ConsistentHashingRoutingLogic
-
Java API
- ConsistentHashingRoutingLogic$ - Class in akka.routing
-
- ConsistentHashingRoutingLogic$() - Constructor for class akka.routing.ConsistentHashingRoutingLogic$
-
- consistentHashKey() - Method in class akka.io.Dns.Resolve
-
- consistentHashKey() - Method in interface akka.routing.ConsistentHashingRouter.ConsistentHashable
-
- consistentHashKey() - Method in class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope
-
- ConsistentRoutee - Class in akka.routing
-
INTERNAL API
Important to use ActorRef with full address, with host and port, in the hash ring,
so that same ring is produced on different nodes.
- ConsistentRoutee(Routee, Address) - Constructor for class akka.routing.ConsistentRoutee
-
- ConsistentRoutee$ - Class in akka.routing
-
- ConsistentRoutee$() - Constructor for class akka.routing.ConsistentRoutee$
-
- 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 interface akka.actor.StashSupport
-
INTERNAL API.
- context() - Method in class akka.actor.TypedActor$
-
Returns the ActorContext (for a TypedActor) when inside a method call in a TypedActor.
- context() - Static method in class akka.actor.TypedActor
-
Returns the ActorContext (for a TypedActor) when inside a method call in a TypedActor.
- context() - Method in class akka.routing.TailChoppingRoutingLogic
-
- context() - Method in class akka.util.SerializedSuspendableExecutionContext
-
- contextClassLoader() - Method in class akka.dispatch.MonitorableThreadFactory
-
- contextStack() - Method in class akka.actor.ActorCell$
-
- contextStack() - Static method in class akka.actor.ActorCell
-
- ContextualTypedActorFactory - Class in akka.actor
-
ContextualTypedActorFactory allows TypedActors to create children, effectively forming the same Actor Supervision Hierarchies
as normal Actors can.
- ContextualTypedActorFactory(TypedActorExtension, ActorContext) - Constructor for class akka.actor.ContextualTypedActorFactory
-
- ContextualTypedActorFactory$ - Class in akka.actor
-
- ContextualTypedActorFactory$() - Constructor for class akka.actor.ContextualTypedActorFactory$
-
- ControlAwareMessageQueueSemantics - Interface in akka.dispatch
-
ControlAwareMessageQueue handles messages that extend
ControlMessage
with priority.
- ControlMessage - Interface in akka.dispatch
-
Messages that extend this trait will be handled with priority by control aware mailboxes.
- controlQueue() - Method in class akka.dispatch.BoundedControlAwareMailbox.MessageQueue
-
- controlQueue() - Method in interface akka.dispatch.ControlAwareMessageQueueSemantics
-
- controlQueue() - Method in class akka.dispatch.UnboundedControlAwareMailbox.MessageQueue
-
- copy(S, D, Option<FiniteDuration>, Option<FSM.Reason>, List<Object>) - Method in class akka.actor.FSM.SilentState
-
- copy(S, D, Option<FiniteDuration>, Option<FSM.Reason>, List<Object>) - Method in class akka.actor.FSM.State
-
- 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.
- corePoolSize() - Method in class akka.dispatch.ThreadPoolConfig
-
- correlationId() - Method in class akka.actor.ActorIdentity
-
- count - Variable in class akka.dispatch.AbstractBoundedNodeQueue.Node
-
- count() - Method in class akka.dispatch.AbstractNodeQueue
-
- count() - Method in class akka.event.DeadLetterListener
-
- count() - Method in class akka.io.Tcp.WriteFile
-
- counter() - Method in class akka.dispatch.MonitorableThreadFactory
-
- create(Option<ActorInitializationException>) - Method in class akka.actor.ActorCell
-
- create() - Method in class akka.actor.ActorSystem$
-
Creates a new ActorSystem with the name "default",
obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader,
then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader
associated with the ActorSystem class.
- create(String) - Method in class akka.actor.ActorSystem$
-
Creates a new ActorSystem with the specified name,
obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader,
then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader
associated with the ActorSystem class.
- create(String, Config) - Method in class akka.actor.ActorSystem$
-
Creates a new ActorSystem with the specified name, and the specified Config, then
obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader,
then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader
associated with the ActorSystem class.
- create(String, Config, ClassLoader) - Method in class akka.actor.ActorSystem$
-
Creates a new ActorSystem with the specified name, the specified Config, and specified ClassLoader
- create(String, Config, ClassLoader, ExecutionContext) - Method in class akka.actor.ActorSystem$
-
Creates a new ActorSystem with the specified name, the specified Config, the specified ClassLoader,
and the specified ExecutionContext.
- create() - Static method in class akka.actor.ActorSystem
-
Creates a new ActorSystem with the name "default",
obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader,
then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader
associated with the ActorSystem class.
- create(String) - Static method in class akka.actor.ActorSystem
-
Creates a new ActorSystem with the specified name,
obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader,
then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader
associated with the ActorSystem class.
- create(String, Config) - Static method in class akka.actor.ActorSystem
-
Creates a new ActorSystem with the specified name, and the specified Config, then
obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader,
then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader
associated with the ActorSystem class.
- create(String, Config, ClassLoader) - Static method in class akka.actor.ActorSystem
-
Creates a new ActorSystem with the specified name, the specified Config, and specified ClassLoader
- create(String, Config, ClassLoader, ExecutionContext) - Static method in class akka.actor.ActorSystem
-
Creates a new ActorSystem with the specified name, the specified Config, the specified ClassLoader,
and the specified ExecutionContext.
- create() - Method in class akka.actor.DefaultSupervisorStrategy
-
- create(ActorSystem) - Method in class akka.actor.Inbox$
-
Create a new Inbox within the given system.
- create(ActorSystem) - Static method in class akka.actor.Inbox
-
Create a new Inbox within the given system.
- create(Class<?>, Object...) - Method in class akka.actor.Props$
-
Java API: create a Props given a class and its constructor arguments.
- create(Class<?>, Seq<Object>) - Method in class akka.actor.Props$
-
- create(Creator<T>) - Method in class akka.actor.Props$
-
Create new Props from the given
Creator
.
- create(Class<T>, Creator<T>) - Method in class akka.actor.Props$
-
Create new Props from the given
Creator
with the type set to the given actorClass.
- create(Class<?>, Object...) - Static method in class akka.actor.Props
-
Java API: create a Props given a class and its constructor arguments.
- create(Class<?>, Seq<Object>) - Static method in class akka.actor.Props
-
- create(<any>) - Static method in class akka.actor.Props
-
Create new Props from the given
Creator
.
- create(Class<T>, <any>) - Static method in class akka.actor.Props
-
Create new Props from the given
Creator
with the type set to the given actorClass.
- create() - Method in class akka.actor.StoppingSupervisorStrategy
-
- create() - Method in interface akka.actor.SupervisorStrategyConfigurator
-
- create(MailboxType) - Method in class akka.dispatch.BalancingDispatcherConfigurator
-
- create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.BoundedControlAwareMailbox
-
- 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 class akka.dispatch.BoundedStablePriorityMailbox
-
- create(Option<ActorRef>, Option<ActorSystem>) - Method in interface akka.dispatch.MailboxType
-
- create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.NonBlockingBoundedMailbox
-
- create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.SingleConsumerOnlyUnboundedMailbox
-
- Create - Class in akka.dispatch.sysmsg
-
INTERNAL API
- Create(Option<ActorInitializationException>) - Constructor for class akka.dispatch.sysmsg.Create
-
- create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.UnboundedControlAwareMailbox
-
- 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(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.UnboundedStablePriorityMailbox
-
- create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.event.LoggerMailboxType
-
- create(PartialFunction<Object, BoxedUnit>, ActorContext) - Method in class akka.event.LoggingReceive$
-
Java API: compatible with lambda expressions
This is an EXPERIMENTAL feature and is subject to change until it has received more real world testing.
- create(PartialFunction<Object, BoxedUnit>, ActorContext) - Static method in class akka.event.LoggingReceive
-
Java API: compatible with lambda expressions
This is an EXPERIMENTAL feature and is subject to change until it has received more real world testing.
- create() - Method in class akka.io.Inet.DatagramChannelCreator
-
Open and return new DatagramChannel.
- create(Iterable<Tcp.WriteCommand>) - Method in class akka.io.Tcp.WriteCommand$
-
Java API: combines the given number of write commands into one atomic WriteCommand
.
- create() - Method in interface akka.japi.Creator
-
This method must return a different instance upon every call.
- create() - Method in interface akka.japi.function.Creator
-
This method must return a different instance upon every call.
- create(A, B) - Method in class akka.japi.Pair$
-
- create(A, B) - Static method in class akka.japi.Pair
-
- create(PFBuilder<F, T>) - Static method in class akka.japi.pf.Match
-
Create a
Match
from the builder.
- create(UnitPFBuilder<F>) - Static method in class akka.japi.pf.UnitMatch
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Method in class akka.japi.tuple.Tuple10$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Static method in class akka.japi.tuple.Tuple10
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Method in class akka.japi.tuple.Tuple11$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Static method in class akka.japi.tuple.Tuple11
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Method in class akka.japi.tuple.Tuple12$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Static method in class akka.japi.tuple.Tuple12
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Method in class akka.japi.tuple.Tuple13$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Static method in class akka.japi.tuple.Tuple13
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Method in class akka.japi.tuple.Tuple14$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Static method in class akka.japi.tuple.Tuple14
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Method in class akka.japi.tuple.Tuple15$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Static method in class akka.japi.tuple.Tuple15
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Method in class akka.japi.tuple.Tuple16$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Static method in class akka.japi.tuple.Tuple16
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Method in class akka.japi.tuple.Tuple17$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Static method in class akka.japi.tuple.Tuple17
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Method in class akka.japi.tuple.Tuple18$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Static method in class akka.japi.tuple.Tuple18
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Method in class akka.japi.tuple.Tuple19$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Static method in class akka.japi.tuple.Tuple19
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Method in class akka.japi.tuple.Tuple20$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Static method in class akka.japi.tuple.Tuple20
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Method in class akka.japi.tuple.Tuple21$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Static method in class akka.japi.tuple.Tuple21
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Method in class akka.japi.tuple.Tuple22$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Static method in class akka.japi.tuple.Tuple22
-
- create(T1, T2, T3) - Method in class akka.japi.tuple.Tuple3$
-
- create(T1, T2, T3) - Static method in class akka.japi.tuple.Tuple3
-
- create(T1, T2, T3, T4) - Method in class akka.japi.tuple.Tuple4$
-
- create(T1, T2, T3, T4) - Static method in class akka.japi.tuple.Tuple4
-
- create(T1, T2, T3, T4, T5) - Method in class akka.japi.tuple.Tuple5$
-
- create(T1, T2, T3, T4, T5) - Static method in class akka.japi.tuple.Tuple5
-
- create(T1, T2, T3, T4, T5, T6) - Method in class akka.japi.tuple.Tuple6$
-
- create(T1, T2, T3, T4, T5, T6) - Static method in class akka.japi.tuple.Tuple6
-
- create(T1, T2, T3, T4, T5, T6, T7) - Method in class akka.japi.tuple.Tuple7$
-
- create(T1, T2, T3, T4, T5, T6, T7) - Static method in class akka.japi.tuple.Tuple7
-
- create(T1, T2, T3, T4, T5, T6, T7, T8) - Method in class akka.japi.tuple.Tuple8$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8) - Static method in class akka.japi.tuple.Tuple8
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in class akka.japi.tuple.Tuple9$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Static method in class akka.japi.tuple.Tuple9
-
- create(Scheduler, int, FiniteDuration, FiniteDuration) - Method in class akka.pattern.CircuitBreaker$
-
Java API: Create a new CircuitBreaker.
- create(Scheduler, int, FiniteDuration, FiniteDuration) - Static method in class akka.pattern.CircuitBreaker
-
Java API: Create a new CircuitBreaker.
- create(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$ - Class in akka.dispatch.sysmsg
-
- Create$() - Constructor for class akka.dispatch.sysmsg.Create$
-
- createActorRefProxy(TypedProps<T>, AtomicReference<R>, Function0<ActorRef>) - Method in class akka.actor.TypedActorExtension
-
INTERNAL API
- createDynamicAccess() - Method in class akka.actor.ActorSystemImpl
-
This is an extension point: by overriding this method, subclasses can
control all reflection activities of an actor system.
- createExecutorService() - Method in interface akka.dispatch.ExecutorServiceFactory
-
- createExecutorService() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory
-
- createExecutorService() - Method in class akka.dispatch.ThreadPoolConfig.ThreadPoolExecutorServiceFactory
-
- createExecutorServiceFactory(String, ThreadFactory) - Method in class akka.dispatch.DefaultExecutorServiceConfigurator
-
- createExecutorServiceFactory(String, ThreadFactory) - Method in interface akka.dispatch.ExecutorServiceFactoryProvider
-
- createExecutorServiceFactory(String, ThreadFactory) - Method in class akka.dispatch.ForkJoinExecutorConfigurator
-
- createExecutorServiceFactory(String, ThreadFactory) - Method in class akka.dispatch.ThreadPoolConfig
-
- createExecutorServiceFactory(String, ThreadFactory) - Method in class akka.dispatch.ThreadPoolExecutorConfigurator
-
- createExtension(ExtendedActorSystem) - Method in class akka.actor.ActorDSL.Extension$
-
- createExtension(ExtendedActorSystem) - Method in interface akka.actor.ExtensionId
-
Is used by Akka to instantiate the Extension identified by this ExtensionId,
internal use only.
- createExtension(ExtendedActorSystem) - Method in class akka.actor.ExtensionKey
-
- createExtension(ExtendedActorSystem) - Method in class akka.actor.TypedActor$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.actor.TypedActor
-
- createExtension(ExtendedActorSystem) - Method in class akka.event.AddressTerminatedTopic$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.event.AddressTerminatedTopic
-
- createExtension(ExtendedActorSystem) - Method in class akka.io.Dns$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.io.Dns
-
- 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.serialization.SerializationExtension$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.serialization.SerializationExtension
-
- createInstanceFor(Class<?>, Seq<Tuple2<Class<?>, Object>>, ClassTag<T>) - Method in class akka.actor.DynamicAccess
-
Convenience method which given a Class[_]
object and a constructor description
will create a new instance of that class.
- createInstanceFor(String, Seq<Tuple2<Class<?>, Object>>, ClassTag<T>) - Method in class akka.actor.DynamicAccess
-
Obtain an object conforming to the type T, which is expected to be
instantiated from a class designated by the fully-qualified class name
given, where the constructor is selected and invoked according to the
args
argument.
- createInstanceFor(Class<?>, Seq<Tuple2<Class<?>, Object>>, ClassTag<T>) - Method in class akka.actor.ReflectiveDynamicAccess
-
- createInstanceFor(String, Seq<Tuple2<Class<?>, Object>>, ClassTag<T>) - Method in class akka.actor.ReflectiveDynamicAccess
-
- createMailbox(Cell, MailboxType) - Method in class akka.dispatch.BalancingDispatcher
-
- createMailbox(Cell, MailboxType) - Method in class akka.dispatch.Dispatcher
-
INTERNAL API
- createMailbox(Cell, MailboxType) - Method in class akka.dispatch.MessageDispatcher
-
Creates and returns a mailbox for the given actor.
- createRouter(ActorSystem) - Method in class akka.routing.BalancingPool
-
- createRouter(ActorSystem) - Method in class akka.routing.BroadcastGroup
-
- createRouter(ActorSystem) - Method in class akka.routing.BroadcastPool
-
- createRouter(ActorSystem) - Method in class akka.routing.ConsistentHashingGroup
-
- createRouter(ActorSystem) - Method in class akka.routing.ConsistentHashingPool
-
- createRouter(ActorSystem) - Method in class akka.routing.FromConfig
-
- createRouter(ActorSystem) - Method in class akka.routing.NoRouter$
-
- createRouter(ActorSystem) - Static method in class akka.routing.NoRouter
-
- createRouter(ActorSystem) - Method in class akka.routing.RandomGroup
-
- createRouter(ActorSystem) - Method in class akka.routing.RandomPool
-
- createRouter(ActorSystem) - Method in class akka.routing.RoundRobinGroup
-
- createRouter(ActorSystem) - Method in class akka.routing.RoundRobinPool
-
- createRouter(ActorSystem) - Method in interface akka.routing.RouterConfig
-
Create the actual router, responsible for routing messages to routees.
- createRouter(ActorSystem) - Method in class akka.routing.ScatterGatherFirstCompletedGroup
-
- createRouter(ActorSystem) - Method in class akka.routing.ScatterGatherFirstCompletedPool
-
- createRouter(ActorSystem) - Method in class akka.routing.SmallestMailboxPool
-
- createRouter(ActorSystem) - Method in class akka.routing.TailChoppingGroup
-
- createRouter(ActorSystem) - Method in class akka.routing.TailChoppingPool
-
- createRouterActor() - Method in class akka.routing.CustomRouterConfig
-
INTERNAL API
- createRouterActor() - Method in class akka.routing.FromConfig
-
INTERNAL API
- createRouterActor() - Method in interface akka.routing.Group
-
INTERNAL API
- createRouterActor() - Method in class akka.routing.NoRouter$
-
INTERNAL API
- createRouterActor() - Static method in class akka.routing.NoRouter
-
INTERNAL API
- createRouterActor() - Method in interface akka.routing.Pool
-
INTERNAL API
- createRouterActor() - Method in interface akka.routing.RouterConfig
-
INTERNAL API
The router "head" actor.
- createRouterConfig(String, String, Config, Config) - Method in class akka.actor.Deployer
-
Factory method for creating RouterConfig
- createScheduler() - Method in class akka.actor.ActorSystemImpl
-
Create the scheduler service.
- createStash(ActorContext, ActorRef) - Method in interface akka.actor.StashFactory
-
- createThreadPoolConfigBuilder(Config, DispatcherPrerequisites) - Method in class akka.dispatch.ThreadPoolExecutorConfigurator
-
- Creation() - Constructor for class akka.actor.dungeon.ChildrenContainer.Creation
-
- Creation$() - Constructor for class akka.actor.dungeon.ChildrenContainer.Creation$
-
- CreationTimeout() - Method in class akka.actor.ActorSystem.Settings
-
- creator() - Method in class akka.actor.TypedProps
-
- Creator<T> - Interface in akka.japi
-
A constructor/factory, takes no parameters but creates a new value of type T every call.
- Creator<T> - Interface in akka.japi.function
-
A constructor/factory, takes no parameters but creates a new value of type T every call.
- CreatorConsumer - Class in akka.actor
-
INTERNAL API
- CreatorConsumer(Class<? extends Actor>, Creator<Actor>) - Constructor for class akka.actor.CreatorConsumer
-
- CreatorConsumerClass() - Method in class akka.actor.IndirectActorProducer$
-
- CreatorFunctionConsumer - Class in akka.actor
-
INTERNAL API
- CreatorFunctionConsumer(Function0<Actor>) - Constructor for class akka.actor.CreatorFunctionConsumer
-
- CreatorFunctionConsumerClass() - Method in class akka.actor.IndirectActorProducer$
-
- Creators - Interface in akka.actor.dsl
-
- Creators.Act - Interface in akka.actor.dsl
-
This trait provides a DSL for writing the inner workings of an actor, e.g.
- Creators.ActWithStash - Interface in akka.actor.dsl
-
Use this trait when defining an
Actor
with
Stash
,
since just using
actor()(new Act with Stash{})
will not be able to see the
Stash component due to type erasure.
- Crypt - Class in akka.util
-
- Crypt() - Constructor for class akka.util.Crypt
-
- Crypt$ - Class in akka.util
-
- Crypt$() - Constructor for class akka.util.Crypt$
-
- CurrentChild(Option<ActorRef>) - Constructor for class akka.pattern.BackoffSupervisor.CurrentChild
-
- CurrentChild$() - Constructor for class akka.pattern.BackoffSupervisor.CurrentChild$
-
- currentDeadline() - Method in class akka.actor.dsl.Inbox.InboxActor
-
- currentFailureCount() - Method in class akka.pattern.CircuitBreaker
-
Retrieves current failure count.
- currentMessage() - Method in class akka.actor.ActorCell
-
- currentMsg() - Method in class akka.actor.dsl.Inbox.InboxActor
-
- currentSelect() - Method in class akka.actor.dsl.Inbox.InboxActor
-
- currentState() - Method in interface akka.actor.FSM
-
- CurrentState(ActorRef, S) - Constructor for class akka.actor.FSM.CurrentState
-
- currentState() - Method in class akka.actor.FSM.StopEvent
-
- CurrentState$() - Constructor for class akka.actor.FSM.CurrentState$
-
- currentStatus() - Method in class akka.dispatch.Mailbox
-
- currentSystem() - Method in class akka.serialization.JavaSerializer$
-
This holds a reference to the current ActorSystem (the surrounding context)
during serialization and deserialization.
- currentSystem() - Static method in class akka.serialization.JavaSerializer
-
This holds a reference to the current ActorSystem (the surrounding context)
during serialization and deserialization.
- CurrentSystem() - Constructor for class akka.serialization.JavaSerializer.CurrentSystem
-
- currentTimeMillisToUTCString(long) - Method in class akka.util.Helpers$
-
Converts a "currentTimeMillis"-obtained timestamp accordingly:
- currentTimeMillisToUTCString(long) - Static method in class akka.util.Helpers
-
Converts a "currentTimeMillis"-obtained timestamp accordingly:
- currentTransportInformation() - Method in class akka.serialization.Serialization$
-
This holds a reference to the current transport serialization information used for
serializing local actor refs.
- currentTransportInformation() - Static method in class akka.serialization.Serialization
-
This holds a reference to the current transport serialization information used for
serializing local actor refs.
- CustomRouterConfig - Class in akka.routing
-
If a custom router implementation is not a
Group
nor
a
Pool
it may extend this base class.
- CustomRouterConfig() - Constructor for class akka.routing.CustomRouterConfig
-
- gen(Object) - Method in class akka.dispatch.PriorityGenerator
-
- generateSecureCookie() - Method in class akka.util.Crypt$
-
- generateSecureCookie() - Static method in class akka.util.Crypt
-
- 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(Deadline, ActorRef) - Constructor for class akka.actor.dsl.Inbox.Get
-
- get(ActorSystem) - Method in interface akka.actor.ExtensionId
-
Returns an instance of the extension identified by this ExtensionId instance.
- get(ActorSystem) - Method in class akka.actor.TypedActor$
-
- get(ActorContext) - Method in class akka.actor.TypedActor$
-
Returns a contextual TypedActorFactory of this extension, this means that any TypedActors created by this TypedActorExtension
will be children to the specified context, this allows for creating hierarchies of TypedActors.
- get(ActorSystem) - Static method in class akka.actor.TypedActor
-
- get(ActorContext) - Static method in class akka.actor.TypedActor
-
Returns a contextual TypedActorFactory of this extension, this means that any TypedActors created by this TypedActorExtension
will be children to the specified context, this allows for creating hierarchies of TypedActors.
- get(ActorSystem) - Method in class akka.event.AddressTerminatedTopic$
-
- get(ActorSystem) - Static method in class akka.event.AddressTerminatedTopic
-
- get(ActorRef) - Method in class akka.event.ManagedActorClassification.ManagedActorClassificationMappings
-
- get(ActorSystem) - Method in class akka.io.Dns$
-
Java API: retrieve the Udp extension for the given system.
- get(ActorSystem) - Static method in class akka.io.Dns
-
Java API: retrieve the Udp extension for the given system.
- 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.serialization.SerializationExtension$
-
- get(ActorSystem) - Static method in class akka.serialization.SerializationExtension
-
- get(T) - Method in class akka.util.TypedMultiMap
-
Obtain all mappings for the given key.
- Get$() - Constructor for class akka.actor.dsl.Inbox.Get$
-
- 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
- getAddressTerminated() - Method in class akka.actor.Terminated
-
- getAllChildStats() - Method in interface akka.actor.dungeon.Children
-
- getAnyRef(String) - Method in class akka.dispatch.CachingConfig
-
- getAnyRefList(String) - Method in class akka.dispatch.CachingConfig
-
- getBoolean(String) - Method in class akka.dispatch.CachingConfig
-
- getBooleanList(String) - Method in class akka.dispatch.CachingConfig
-
- getByName(String) - Method in interface akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer
-
- getByName(String) - Method in interface akka.actor.dungeon.ChildrenContainer
-
- getByName(String) - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
-
- getByName(String) - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
-
- getByRef(ActorRef) - Method in interface akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer
-
- getByRef(ActorRef) - Method in interface akka.actor.dungeon.ChildrenContainer
-
- getByRef(ActorRef) - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
-
- getByRef(ActorRef) - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
-
- getByte() - Method in class akka.util.ByteIterator
-
Get a single Byte from this iterator.
- getByteBuffers() - Method in class akka.util.ByteString
-
Java API: Returns an Iterable of read-only ByteBuffers that directly wraps this ByteStrings
all fragments.
- getBytes(String) - Method in class akka.dispatch.CachingConfig
-
- getBytes(byte[], int, int) - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- getBytes(byte[]) - Method in class akka.util.ByteIterator
-
Get a specific number of Bytes from this iterator.
- getBytes(byte[], int, int) - Method in class akka.util.ByteIterator
-
Get a specific number of Bytes from this iterator.
- getBytes(int) - Method in class akka.util.ByteIterator
-
Get a specific number of Bytes from this iterator.
- getBytes(byte[], int, int) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- getBytesList(String) - Method in class akka.dispatch.CachingConfig
-
- getByteString(int) - Method in class akka.util.ByteIterator
-
Get a ByteString with specific number of Bytes from this iterator.
- getCallerClass() - Method in class akka.util.Reflect$
-
This optionally holds a function which looks N levels above itself
on the call stack and returns the Class[_]
object for the code
executing in that stack frame.
- getCallerClass() - Static method in class akka.util.Reflect
-
This optionally holds a function which looks N levels above itself
on the call stack and returns the Class[_]
object for the code
executing in that stack frame.
- getCause() - Method in class akka.event.Logging.LogEventException
-
- getCause() - Method in exception akka.pattern.AskTimeoutException
-
- getChild(String) - Method in interface akka.actor.AbstractActorContext
-
Returns a reference to the named child or null if no child with
that name exists.
- getChild(String) - Method in interface akka.actor.dungeon.Children
-
- getChild(Iterator<String>) - Method in class akka.actor.InternalActorRef
-
Obtain ActorRef by possibly traversing the actor tree or looking it up at
some provider-specific location.
- getChild(Iterator<String>) - Method in class akka.actor.LocalActorRef
-
- getChild(Iterator<String>) - Method in interface akka.actor.MinimalActorRef
-
- getChild(Iterator<String>) - Method in class akka.actor.RepointableActorRef
-
- getChild(String) - Method in interface akka.actor.UntypedActorContext
-
Returns a reference to the named child or null if no child with
that name exists.
- getChild(String) - Method in class akka.actor.VirtualPathContainer
-
- getChild(Iterator<String>) - Method in class akka.actor.VirtualPathContainer
-
- getChildByName(String) - Method in interface akka.actor.Cell
-
Get the stats for the named child, if that exists.
- getChildByName(String) - Method in interface akka.actor.dungeon.Children
-
- getChildByName(String) - Method in class akka.actor.UnstartedCell
-
- getChildByRef(ActorRef) - Method in interface akka.actor.dungeon.Children
-
- getChildren() - Method in interface akka.actor.AbstractActorContext
-
Returns an unmodifiable Java Collection containing the linked actors,
please note that the backing map is thread-safe but not immutable
- getChildren() - Method in interface akka.actor.dungeon.Children
-
- getChildren() - Method in interface akka.actor.UntypedActorContext
-
Returns an unmodifiable Java Collection containing the linked actors,
please note that the backing map is thread-safe but not immutable
- 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
-
- getConfig(String) - Method in class akka.dispatch.CachingConfig
-
- getConfigList(String) - Method in class akka.dispatch.CachingConfig
-
- getContext() - Method in class akka.actor.AbstractActor
-
Returns this AbstractActor's AbstractActorContext
The AbstractActorContext is not thread safe so do not expose it outside of the
AbstractActor.
- getContext() - Method in class akka.actor.UntypedActor
-
Returns this UntypedActor's UntypedActorContext
The UntypedActorContext is not thread safe so do not expose it outside of the
UntypedActor.
- getCurrentChild() - Method in class akka.pattern.BackoffSupervisor$
-
- getCurrentChild() - Static method in class akka.pattern.BackoffSupervisor
-
- GetCurrentChild$() - Constructor for class akka.pattern.BackoffSupervisor.GetCurrentChild$
-
- getDefaultAddress() - Method in interface akka.actor.ActorRefProvider
-
Obtain the external address of the default transport.
- getDefaultAddress() - Method in class akka.actor.LocalActorRefProvider
-
- getDouble(String) - Method in class akka.dispatch.CachingConfig
-
- getDouble(ByteOrder) - Method in class akka.util.ByteIterator
-
- getDoubleList(String) - Method in class akka.dispatch.CachingConfig
-
- getDoubles(double[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- getDoubles(double[], ByteOrder) - Method in class akka.util.ByteIterator
-
Get a number of Doubles from this iterator.
- getDoubles(double[], int, int, ByteOrder) - Method in class akka.util.ByteIterator
-
Get a number of Doubles from this iterator.
- getDoubles(double[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- getDuration(String, TimeUnit) - Method in class akka.dispatch.CachingConfig
-
- getDuration(String) - Method in class akka.dispatch.CachingConfig
-
- getDurationList(String, TimeUnit) - Method in class akka.dispatch.CachingConfig
-
- getDurationList(String) - Method in class akka.dispatch.CachingConfig
-
- getElements() - Method in interface akka.actor.ActorPath
-
Java API: Sequence of names for this path from root to this.
- 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
-
- getExistenceConfirmed() - Method in class akka.actor.Terminated
-
- getExternalAddressFor(Address) - Method in interface akka.actor.ActorRefProvider
-
Obtain the address which is to be used within sender references when
sending to the given other address or none if the other address cannot be
reached from this system (i.e.
- getExternalAddressFor(Address) - Method in class akka.actor.LocalActorRefProvider
-
- 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
-
- 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.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.routing.FromConfig$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.routing.FromConfig
-
Java API: get the singleton instance
- getInstance() - Method in class akka.routing.GetRoutees$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.routing.GetRoutees
-
Java API: get the singleton instance
- getInstance() - Method in class akka.routing.NoRouter$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.routing.NoRouter
-
Java API: get the singleton instance
- getInt(String) - Method in class akka.dispatch.CachingConfig
-
- getInt(ByteOrder) - Method in class akka.util.ByteIterator
-
Get a single Int from this iterator.
- getIntList(String) - Method in class akka.dispatch.CachingConfig
-
- getInts(int[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- getInts(int[], ByteOrder) - Method in class akka.util.ByteIterator
-
Get a number of Ints from this iterator.
- getInts(int[], int, int, ByteOrder) - Method in class akka.util.ByteIterator
-
Get a number of Ints from this iterator.
- getInts(int[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- getIsNull(String) - Method in class akka.dispatch.CachingConfig
-
- getList(String) - Method in class akka.dispatch.CachingConfig
-
- getLog() - Method in interface akka.actor.LoggingFSM
-
Retrieve current rolling log in oldest-first order.
- getLogger(ActorSystem, Object) - Method in class akka.event.Logging$
-
Obtain LoggingAdapter for the given actor system and source object.
- getLogger(LoggingBus, Object) - Method in class akka.event.Logging$
-
Obtain LoggingAdapter for the given logging bus and source object.
- getLogger(UntypedActor) - Method in class akka.event.Logging$
-
Obtain LoggingAdapter with MDC support for the given actor.
- getLogger(ActorSystem, Object) - Static method in class akka.event.Logging
-
Obtain LoggingAdapter for the given actor system and source object.
- getLogger(LoggingBus, Object) - Static method in class akka.event.Logging
-
Obtain LoggingAdapter for the given logging bus and source object.
- getLogger(UntypedActor) - Static method in class akka.event.Logging
-
Obtain LoggingAdapter with MDC support for the given actor.
- getLong(String) - Method in class akka.dispatch.CachingConfig
-
- getLong(ByteOrder) - Method in class akka.util.ByteIterator
-
Get a single Long from this iterator.
- getLongList(String) - Method in class akka.dispatch.CachingConfig
-
- getLongPart(int, ByteOrder) - Method in class akka.util.ByteIterator
-
Get a Long from this iterator where only the least significant n
bytes were encoded.
- getLongs(long[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- getLongs(long[], ByteOrder) - Method in class akka.util.ByteIterator
-
Get a number of Longs from this iterator.
- getLongs(long[], int, int, ByteOrder) - Method in class akka.util.ByteIterator
-
Get a number of Longs from this iterator.
- getLongs(long[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- getMailboxRequirement(Config) - Method in class akka.dispatch.Mailboxes
-
- getMailboxType(Props, Config) - Method in class akka.dispatch.Mailboxes
-
Finds out the mailbox type for an actor based on configuration, props and requirements.
- getManager() - Method in class akka.io.TcpExt
-
Java API: retrieve a reference to the manager actor.
- getManager() - Method in class akka.io.UdpConnectedExt
-
Java API: retrieve the UDP manager actor’s reference.
- getManager() - Method in class akka.io.UdpExt
-
Java API: retrieve the UDP manager actor’s reference.
- getMDC() - Method in interface akka.event.DiagnosticLoggingAdapter
-
Java API:
Mapped Diagnostic Context for application defined values
which can be used in PatternLayout when akka.event.slf4j.Slf4jLogger
is configured.
- getMDC() - Method in interface akka.event.Logging.LogEvent
-
Java API: Retrieve the contents of the MDC.
- getMemorySize(String) - Method in class akka.dispatch.CachingConfig
-
- getMemorySizeList(String) - Method in class akka.dispatch.CachingConfig
-
- getMessage() - Method in class akka.actor.UnhandledMessage
-
- getMessage() - Method in class akka.event.Logging.LogEventException
-
- getMillisDuration(String) - Method in class akka.util.Helpers.ConfigOps
-
- getMilliseconds(String) - Method in class akka.dispatch.CachingConfig
-
- getMillisecondsList(String) - Method in class akka.dispatch.CachingConfig
-
- getNanosDuration(String) - Method in class akka.util.Helpers.ConfigOps
-
- getNanoseconds(String) - Method in class akka.dispatch.CachingConfig
-
- getNanosecondsList(String) - Method in class akka.dispatch.CachingConfig
-
- getNumber(String) - Method in class akka.dispatch.CachingConfig
-
- getNumberList(String) - Method in class akka.dispatch.CachingConfig
-
- getObject(String) - Method in class akka.dispatch.CachingConfig
-
- 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
-
- getObjectList(String) - Method in class akka.dispatch.CachingConfig
-
- getOrElse(B) - Method in class akka.japi.Option
-
Returns a
if this is some(a)
or defaultValue
if
this is none
.
- getOrElse(B) - Method in class akka.japi.Option.Some
-
- getParent() - Method in class akka.actor.InternalActorRef
-
Obtain parent of this ref; used by getChild for ".." paths.
- getParent() - Method in class akka.actor.LocalActorRef
-
- getParent() - Method in interface akka.actor.MinimalActorRef
-
- getParent() - Method in class akka.actor.RepointableActorRef
-
- getParent() - Method in class akka.actor.VirtualPathContainer
-
- getParent() - Method in class akka.pattern.PromiseActorRef
-
- getPaths() - Method in class akka.routing.GroupBase
-
- getPaths(ActorSystem) - Method in class akka.routing.GroupBase
-
- getProducedMessageQueueType(MailboxType) - Method in class akka.dispatch.Mailboxes
-
- getRawResult() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinTask
-
- getRawResult() - Method in class akka.dispatch.Mailbox
-
- getRecipient() - Method in class akka.actor.UnhandledMessage
-
- 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.pattern.BackoffSupervisor.CurrentChild
-
Java API: The ActorRef
of the current child, if any
- getRequiredType(Class<? extends Actor>) - Method in class akka.dispatch.Mailboxes
-
Return the required message queue type for this class if any.
- getResolver() - Method in class akka.io.DnsExt
-
- GetRoutees - Class in akka.routing
-
Sending this message to a router will make it send back its currently used routees.
- GetRoutees() - Constructor for class akka.routing.GetRoutees
-
- getRoutees() - Method in class akka.routing.Routees
-
Java API
- getRoutees() - Method in class akka.routing.SeveralRoutees
-
Java API
- GetRoutees$ - Class in akka.routing
-
- GetRoutees$() - Constructor for class akka.routing.GetRoutees$
-
- getSelf() - Method in class akka.actor.UntypedActor
-
Returns the ActorRef for this actor.
- getSender() - Method in class akka.actor.UnhandledMessage
-
- getSender() - Method in class akka.actor.UntypedActor
-
The reference sender Actor of the currently processed message.
- getShort(ByteOrder) - Method in class akka.util.ByteIterator
-
Get a single Short from this iterator.
- getShorts(short[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- getShorts(short[], ByteOrder) - Method in class akka.util.ByteIterator
-
Get a number of Shorts from this iterator.
- getShorts(short[], int, int, ByteOrder) - Method in class akka.util.ByteIterator
-
Get a number of Shorts from this iterator.
- getShorts(short[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- getShutdownTimeout() - Method in class akka.actor.LightArrayRevolverScheduler
-
Overridable for tests
- getSingleChild(String) - Method in class akka.actor.ActorRefWithCell
-
- getSingleChild(String) - Method in interface akka.actor.Cell
-
Method for looking up a single child beneath this actor.
- getSingleChild(String) - Method in interface akka.actor.dungeon.Children
-
- getSingleChild(String) - Method in class akka.actor.LocalActorRef
-
Method for looking up a single child beneath this actor.
- getSingleChild(String) - Method in class akka.actor.RepointableActorRef
-
Method for looking up a single child beneath this actor.
- getSingleChild(String) - Method in class akka.actor.UnstartedCell
-
- getString(String) - Method in class akka.dispatch.CachingConfig
-
- getStringList(String) - Method in class akka.dispatch.CachingConfig
-
- getToArray(Object, int, int, int, Function0<A>, Function3<Object, Object, Object, BoxedUnit>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- getValue(String) - Method in class akka.dispatch.CachingConfig
-
- 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(Object, ActorRef) - Method in interface akka.routing.Listeners
-
Sends the supplied message to all current listeners using the provided sender() as sender.
- goTo(S) - Method in class akka.actor.AbstractFSM
-
Produce transition to other state.
- gracefulStop(ActorRef, FiniteDuration, Object) - Method in interface akka.pattern.GracefulStopSupport
-
Returns a Future
that will be completed with success (value true
) when
existing messages of the target actor has been processed and the actor has been
terminated.
- gracefulStop(ActorRef, FiniteDuration) - Method in class akka.pattern.Patterns$
-
Returns a Future
that will be completed with success (value true
) when
existing messages of the target actor has been processed and the actor has been
terminated.
- gracefulStop(ActorRef, FiniteDuration, Object) - Method in class akka.pattern.Patterns$
-
Returns a Future
that will be completed with success (value true
) when
existing messages of the target actor has been processed and the actor has been
terminated.
- gracefulStop(ActorRef, FiniteDuration) - Static method in class akka.pattern.Patterns
-
Returns a Future
that will be completed with success (value true
) when
existing messages of the target actor has been processed and the actor has been
terminated.
- gracefulStop(ActorRef, FiniteDuration, Object) - Static method in class akka.pattern.Patterns
-
Returns a Future
that will be completed with success (value true
) when
existing messages of the target actor has been processed and the actor has been
terminated.
- GracefulStopSupport - Interface in akka.pattern
-
- Group - Interface in akka.routing
-
RouterConfig
for router actor with routee actors that are created external to the
router and the router sends messages to the specified path using actor selection,
without watching for termination.
- GroupBase - Class in akka.routing
-
Java API: Base class for custom router
Group
- GroupBase() - Constructor for class akka.routing.GroupBase
-
- guard() - Method in interface akka.event.LoggingBus
-
- guardian() - Method in class akka.actor.ActorCell
-
- guardian() - Method in interface akka.actor.ActorRefFactory
-
Father of all children created by this interface.
- guardian() - Method in interface akka.actor.ActorRefProvider
-
Reference to the supervisor used for all top-level user actors.
- guardian() - Method in class akka.actor.ActorSystemImpl
-
- guardian() - Method in class akka.actor.ExtendedActorSystem
-
The top-level supervisor of all actors created using system.actorOf(...).
- guardian() - Method in class akka.actor.LocalActorRefProvider
-
- guardianProps() - Method in class akka.actor.ActorSystemImpl
-
- guardianStrategy() - Method in class akka.actor.LocalActorRefProvider
-
Overridable supervision strategy to be used by the “/user” guardian.
- mailbox() - Method in class akka.actor.Deploy
-
- mailbox() - Method in interface akka.actor.dungeon.Dispatch
-
- mailbox() - Method in class akka.actor.Props
-
Convenience method for extracting the mailbox information from the
contained
Deploy
instance.
- mailbox() - Method in interface akka.actor.StashSupport
-
INTERNAL API.
- Mailbox - Class in akka.dispatch
-
Mailbox and InternalMailbox is separated in two classes because ActorCell is needed for implementation,
but can't be exposed to user defined mailbox subclasses.
- Mailbox(MessageQueue) - Constructor for class akka.dispatch.Mailbox
-
- Mailbox$ - Class in akka.dispatch
-
INTERNAL API
- Mailbox$() - Constructor for class akka.dispatch.Mailbox$
-
- mailboxes() - Method in class akka.actor.ActorSystem
-
Helper object for looking up configured mailbox types.
- mailboxes() - Method in class akka.actor.ActorSystemImpl
-
- mailboxes() - Method in class akka.dispatch.DefaultDispatcherPrerequisites
-
- mailboxes() - Method in interface akka.dispatch.DispatcherPrerequisites
-
- Mailboxes - Class in akka.dispatch
-
- Mailboxes(ActorSystem.Settings, EventStream, DynamicAccess, ActorRef) - Constructor for class akka.dispatch.Mailboxes
-
- mailboxes() - Method in class akka.dispatch.MessageDispatcher
-
- Mailboxes$ - Class in akka.dispatch
-
- Mailboxes$() - Constructor for class akka.dispatch.Mailboxes$
-
- mailboxType() - Method in class akka.actor.RepointableActorRef
-
- MailboxType - Interface in akka.dispatch
-
MailboxType is a factory to create MessageQueues for an optionally
provided ActorContext.
- 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
-
Main class to start an
ActorSystem
with one
top level application supervisor actor.
- Main$() - Constructor for class akka.Main$
-
- Main.Terminator - Class in akka
-
- maintainAddressTerminatedSubscription(ActorRef, Function0<T>) - Method in interface akka.actor.dungeon.DeathWatch
-
Starts subscription to AddressTerminated if not already subscribing and the
block adds a non-local ref to watching or watchedBy.
- makeChild(ActorCell, Props, String, boolean, boolean) - Method in interface akka.actor.dungeon.Children
-
- makeDecider(Seq<Class<? extends Throwable>>) - Method in class akka.actor.SupervisorStrategy$
-
Decider builder which just checks whether one of
the given Throwables matches the cause and restarts, otherwise escalates.
- makeDecider(Iterable<Class<? extends Throwable>>) - Method in class akka.actor.SupervisorStrategy$
-
Decider builder which just checks whether one of
the given Throwables matches the cause and restarts, otherwise escalates.
- makeDecider(Iterable<Tuple2<Class<? extends Throwable>, SupervisorStrategy.Directive>>) - Method in class akka.actor.SupervisorStrategy$
-
Decider builder for Iterables of cause-directive pairs, e.g.
- makeDecider(Function<Throwable, SupervisorStrategy.Directive>) - Method in class akka.actor.SupervisorStrategy$
-
Converts a Java Decider into a Scala Decider
- makeDecider(Seq<Class<? extends Throwable>>) - Static method in class akka.actor.SupervisorStrategy
-
Decider builder which just checks whether one of
the given Throwables matches the cause and restarts, otherwise escalates.
- makeDecider(Iterable<Class<? extends Throwable>>) - Static method in class akka.actor.SupervisorStrategy
-
Decider builder which just checks whether one of
the given Throwables matches the cause and restarts, otherwise escalates.
- makeDecider(Iterable<Tuple2<Class<? extends Throwable>, SupervisorStrategy.Directive>>) - Static method in class akka.actor.SupervisorStrategy
-
Decider builder for Iterables of cause-directive pairs, e.g.
- makeDecider(<any>) - Static method in class akka.actor.SupervisorStrategy
-
Converts a Java Decider into a Scala Decider
- makePattern(String) - Method in class akka.util.Helpers$
-
- makePattern(String) - Static method in class akka.util.Helpers
-
- makeTransition(FSM.State<S, D>) - Method in interface akka.actor.FSM
-
- ManagedActorClassification - Interface in akka.event
-
Maps ActorRefs to ActorRefs to form an EventBus where ActorRefs can listen to other ActorRefs.
- ManagedActorClassification.ManagedActorClassificationMappings - Class in akka.event
-
- ManagedActorClassificationMappings(int, Map<ActorRef, TreeSet<ActorRef>>) - Constructor for class akka.event.ManagedActorClassification.ManagedActorClassificationMappings
-
- ManagedActorEventBus<E> - Class in akka.event.japi
-
Java API: See documentation for
ManagedActorClassification
An EventBus where the Subscribers are ActorRefs and the Classifier is ActorRef
Means that ActorRefs "listen" to other ActorRefs
E is the Event type
- ManagedActorEventBus(ActorSystem) - Constructor for class akka.event.japi.ManagedActorEventBus
-
- ManagementDispatcher() - Method in class akka.io.TcpExt.Settings
-
- ManagementDispatcher() - Method in class akka.io.Udp.UdpSettings
-
- manager() - Method in class akka.io.DnsExt
-
- 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
-
- managerClass() - Method in interface akka.io.DnsProvider
-
- managerClass() - Method in class akka.io.InetAddressDnsProvider
-
- manifest(Object) - Method in class akka.serialization.SerializerWithStringManifest
-
Return the manifest (type hint) that will be provided in the fromBinary method.
- 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
-
- mappings() - Method in interface akka.event.ManagedActorClassification
-
- mapSize() - Method in interface akka.event.ActorClassification
-
This is a size hint for the number of Classifiers you expect to have (use powers of 2)
- mapSize() - Method in class akka.event.japi.ActorEventBus
-
This is a size hint for the number of Classifiers you expect to have (use powers of 2)
- mapSize() - Method in class akka.event.japi.LookupEventBus
-
This is a size hint for the number of Classifiers you expect to have (use powers of 2)
- mapSize() - Method in class akka.event.japi.ManagedActorEventBus
-
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 interface akka.event.ManagedActorClassification
-
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
-
- match(Class<P>, FI.Apply<P, SupervisorStrategy.Directive>) - Static method in class akka.japi.pf.DeciderBuilder
-
Return a new
PFBuilder
with a case statement added.
- match(Class<P>, FI.TypedPredicate<P>, FI.Apply<P, SupervisorStrategy.Directive>) - Static method in class akka.japi.pf.DeciderBuilder
-
Return a new
PFBuilder
with a case statement added.
- Match<I,R> - Class in akka.japi.pf
-
Version of PartialFunction
that can be built during
runtime from Java.
- match(Class<? extends P>, FI.Apply<? extends P, T>) - Static method in class akka.japi.pf.Match
-
Convenience function to create a
PFBuilder
with the first
case statement added.
- match(Class<? extends P>, FI.TypedPredicate<? extends P>, FI.Apply<? extends P, T>) - Static method in class akka.japi.pf.Match
-
Convenience function to create a
PFBuilder
with the first
case statement added.
- match(I) - Method in class akka.japi.pf.Match
-
Convenience function to make the Java code more readable.
- match(Class<? extends P>, FI.Apply<? extends P, R>) - Method in class akka.japi.pf.PFBuilder
-
Add a new case statement to this builder.
- match(Class<? extends P>, FI.TypedPredicate<? extends P>, FI.Apply<? extends P, R>) - Method in class akka.japi.pf.PFBuilder
-
Add a new case statement to this builder.
- match(Class<? extends P>, FI.UnitApply<? extends P>) - Static method in class akka.japi.pf.ReceiveBuilder
-
- match(Class<? extends P>, FI.TypedPredicate<? extends P>, FI.UnitApply<? extends P>) - Static method in class akka.japi.pf.ReceiveBuilder
-
- match(Class<? extends P>, FI.UnitApply<? extends P>) - Static method in class akka.japi.pf.UnitMatch
-
Convenience function to create a
UnitPFBuilder
with the first
case statement added.
- match(Class<? extends P>, FI.TypedPredicate<? extends P>, FI.UnitApply<? extends P>) - Static method in class akka.japi.pf.UnitMatch
-
Convenience function to create a
UnitPFBuilder
with the first
case statement added.
- match(I) - Method in class akka.japi.pf.UnitMatch
-
Convenience function to make the Java code more readable.
- match(Class<? extends P>, FI.UnitApply<? extends P>) - Method in class akka.japi.pf.UnitPFBuilder
-
Add a new case statement to this builder.
- match(Class<? extends P>, FI.TypedPredicate<? extends P>, FI.UnitApply<? extends P>) - Method in class akka.japi.pf.UnitPFBuilder
-
Add a new case statement to this builder.
- matchAny(FI.Apply<Object, SupervisorStrategy.Directive>) - Static method in class akka.japi.pf.DeciderBuilder
-
Return a new
PFBuilder
with a case statement added.
- matchAny(FI.Apply<Object, T>) - Static method in class akka.japi.pf.Match
-
Convenience function to create a
PFBuilder
with the first
case statement added.
- matchAny(FI.Apply<Object, R>) - Method in class akka.japi.pf.PFBuilder
-
Add a new case statement to this builder, that matches any argument.
- matchAny(FI.UnitApply<Object>) - Static method in class akka.japi.pf.ReceiveBuilder
-
- matchAny(FI.UnitApply<Object>) - Static method in class akka.japi.pf.UnitMatch
-
Convenience function to create a
UnitPFBuilder
with the first
case statement added.
- matchAny(FI.UnitApply<Object>) - Method in class akka.japi.pf.UnitPFBuilder
-
Add a new case statement to this builder, that matches any argument.
- matchAnyEvent(FI.Apply2<Object, D, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
-
- matchData(Class<DT>, FI.UnitApply<DT>) - Method in class akka.actor.AbstractFSM
-
- matchData(Class<DT>, FI.TypedPredicate<DT>, FI.UnitApply<DT>) - Method in class akka.actor.AbstractFSM
-
- matchEquals(P, FI.Apply<P, T>) - Static method in class akka.japi.pf.Match
-
Convenience function to create a
PFBuilder
with the first
case statement added.
- matchEquals(P, FI.Apply<P, R>) - Method in class akka.japi.pf.PFBuilder
-
Add a new case statement to this builder.
- matchEquals(P, FI.UnitApply<P>) - Static method in class akka.japi.pf.ReceiveBuilder
-
- matchEquals(P, FI.TypedPredicate<P>, FI.UnitApply<P>) - Static method in class akka.japi.pf.ReceiveBuilder
-
- matchEquals(P, FI.UnitApply<P>) - Static method in class akka.japi.pf.UnitMatch
-
Convenience function to create a
UnitPFBuilder
with the first
case statement added.
- matchEquals(P, FI.TypedPredicate<P>, FI.UnitApply<P>) - Static method in class akka.japi.pf.UnitMatch
-
Convenience function to create a
UnitPFBuilder
with the first
case statement added.
- matchEquals(P, FI.UnitApply<P>) - Method in class akka.japi.pf.UnitPFBuilder
-
Add a new case statement to this builder.
- matchEquals(P, FI.TypedPredicate<P>, FI.UnitApply<P>) - Method in class akka.japi.pf.UnitPFBuilder
-
Add a new case statement to this builder.
- matches(C, E) - Method in class akka.event.japi.ScanningEventBus
-
Returns whether the specified Classifier matches the specified Event
- matches(ScanningClassification, ScanningClassification) - Method in interface akka.event.ScanningClassification
-
Returns whether the specified Classifier matches the specified Event
- matchEvent(Class<ET>, Class<DT>, FI.TypedPredicate2<ET, DT>, FI.Apply2<ET, DT, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
-
- matchEvent(Class<ET>, Class<DT>, FI.Apply2<ET, DT, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
-
- matchEvent(Class<ET>, FI.TypedPredicate2<ET, D>, FI.Apply2<ET, D, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
-
- matchEvent(Class<ET>, FI.Apply2<ET, D, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
-
- matchEvent(FI.TypedPredicate2<Object, D>, FI.Apply2<Object, D, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
-
- matchEvent(List<Object>, Class<DT>, FI.Apply2<Object, DT, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
-
- matchEvent(List<Object>, FI.Apply2<Object, D, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
-
- matchEventEquals(E, Class<DT>, FI.Apply2<E, DT, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
-
- matchEventEquals(E, FI.Apply2<E, D, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
-
- matchState(S, S, FI.UnitApplyVoid) - Method in class akka.actor.AbstractFSM
-
- matchState(S, S, FI.UnitApply2<S, S>) - Method in class akka.actor.AbstractFSM
-
- matchStop(FSM.Reason, FI.UnitApply2<S, D>) - Method in class akka.actor.AbstractFSM
-
- matchStop(Class<RT>, FI.UnitApply3<RT, S, D>) - Method in class akka.actor.AbstractFSM
-
- matchStop(Class<RT>, FI.TypedPredicate<RT>, FI.UnitApply3<RT, S, D>) - Method in class akka.actor.AbstractFSM
-
- maxCapacity() - Method in class akka.util.BoundedBlockingQueue
-
- MaxChannels() - Method in class akka.io.SelectionHandlerSettings
-
- MaxChannelsPerSelector() - Method in class akka.io.SelectionHandlerSettings
-
- MaxChannelsPerSelector() - Method in class akka.io.TcpExt.Settings
-
- MaxChannelsPerSelector() - Method in class akka.io.Udp.UdpSettings
-
- maxCount() - Method in class akka.event.DeadLetterListener
-
- MaxDirectBufferPoolSize() - Method in class akka.io.TcpExt.Settings
-
- MaxDirectBufferPoolSize() - Method in class akka.io.Udp.UdpSettings
-
- maxFrequency() - Method in class akka.actor.AbstractScheduler
-
The maximum supported task frequency of this scheduler, i.e.
- maxFrequency() - Method in class akka.actor.LightArrayRevolverScheduler
-
- maxFrequency() - Method in interface akka.actor.Scheduler
-
The maximum supported task frequency of this scheduler, i.e.
- maxNrOfRetries() - Method in class akka.actor.AllForOneStrategy
-
- maxNrOfRetries() - Method in class akka.actor.OneForOneStrategy
-
- maxNrOfRetriesCount() - Method in class akka.actor.ChildRestartStats
-
- maxNrOfRetriesOption(int) - Method in class akka.actor.SupervisorStrategy$
-
- maxNrOfRetriesOption(int) - Static method in class akka.actor.SupervisorStrategy
-
- maxPoolSize() - Method in class akka.dispatch.ThreadPoolConfig
-
- md5(String) - Method in class akka.util.Crypt$
-
- md5(byte[]) - Method in class akka.util.Crypt$
-
- md5(String) - Static method in class akka.util.Crypt
-
- md5(byte[]) - Static method in class akka.util.Crypt
-
- mdc(Object) - Method in interface akka.actor.DiagnosticActorLogging
-
- mdc() - Method in interface akka.event.DiagnosticLoggingAdapter
-
Scala API:
Mapped Diagnostic Context for application defined values
which can be used in PatternLayout when akka.event.slf4j.Slf4jLogger
is configured.
- mdc(Map<String, Object>) - Method in interface akka.event.DiagnosticLoggingAdapter
-
Scala API:
Sets the values to be added to the MDC (Mapped Diagnostic Context) before the log is appended.
- mdc() - Method in class akka.event.Logging.Debug2
-
- mdc() - Method in class akka.event.Logging.Error2
-
- mdc() - Method in class akka.event.Logging.Info2
-
- mdc() - Method in interface akka.event.Logging.LogEvent
-
Extra values for adding to MDC
- mdc() - Method in class akka.event.Logging.Warning2
-
- mdc() - Method in interface akka.event.LoggingAdapter
-
- message() - Method in exception akka.actor.ActorKilledException
-
- message() - Method in interface akka.actor.AllDeadLetters
-
- message() - Method in class akka.actor.DeadLetter
-
- message() - Method in exception akka.actor.IllegalActorStateException
-
- message() - Method in exception akka.actor.InvalidActorNameException
-
- message() - Method in exception akka.actor.InvalidMessageException
-
- message() - Method in class akka.actor.SuppressedDeadLetter
-
- message() - Method in class akka.actor.UnhandledMessage
-
- message() - Method in class akka.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
-
- messageClassName() - Method in class akka.pattern.PromiseActorRef
-
- MessageDispatcher - Class in akka.dispatch
-
- MessageDispatcher(MessageDispatcherConfigurator) - Constructor for class akka.dispatch.MessageDispatcher
-
- MessageDispatcher$ - Class in akka.dispatch
-
INTERNAL API
- MessageDispatcher$() - Constructor for class akka.dispatch.MessageDispatcher$
-
- MessageDispatcherConfigurator - Class in akka.dispatch
-
Base class to be used for hooking in new dispatchers into Dispatchers.
- MessageDispatcherConfigurator(Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.MessageDispatcherConfigurator
-
- messageId() - Method in class akka.actor.Identify
-
- 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(int, FiniteDuration) - Constructor for class akka.dispatch.BoundedControlAwareMailbox.MessageQueue
-
- MessageQueue(int, FiniteDuration) - Constructor for class akka.dispatch.BoundedDequeBasedMailbox.MessageQueue
-
- MessageQueue(int, FiniteDuration) - Constructor for class akka.dispatch.BoundedMailbox.MessageQueue
-
- MessageQueue(int, Comparator<Envelope>, Duration) - Constructor for class akka.dispatch.BoundedPriorityMailbox.MessageQueue
-
- MessageQueue(int, Comparator<Envelope>, Duration) - Constructor for class akka.dispatch.BoundedStablePriorityMailbox.MessageQueue
-
- messageQueue() - Method in class akka.dispatch.Mailbox
-
- MessageQueue - Interface in akka.dispatch
-
A MessageQueue is one of the core components in forming an Akka Mailbox.
- MessageQueue() - Constructor for class akka.dispatch.UnboundedControlAwareMailbox.MessageQueue
-
- MessageQueue() - Constructor for class akka.dispatch.UnboundedDequeBasedMailbox.MessageQueue
-
- MessageQueue() - Constructor for class akka.dispatch.UnboundedMailbox.MessageQueue
-
- MessageQueue(int, Comparator<Envelope>) - Constructor for class akka.dispatch.UnboundedPriorityMailbox.MessageQueue
-
- MessageQueue(int, Comparator<Envelope>) - Constructor for class akka.dispatch.UnboundedStablePriorityMailbox.MessageQueue
-
- messages() - Method in class akka.actor.dsl.Inbox.InboxActor
-
- messagesPerResize() - Method in class akka.routing.DefaultResizer
-
- method() - Method in class akka.actor.TypedActor.MethodCall
-
- MethodCall(Method, Object[]) - Constructor for class akka.actor.TypedActor.MethodCall
-
- MethodCall$() - Constructor for class akka.actor.TypedActor.MethodCall$
-
- methodName() - Method in class akka.actor.TypedActor.SerializedMethodCall
-
- MinimalActorRef - Interface in akka.actor
-
Trait for ActorRef implementations where all methods contain default stubs.
- mkChild(Props, String) - Method in class akka.actor.ActorDSL.Extension
-
- mkProps(Class<?>, Function0<Actor>) - Method in interface akka.actor.dsl.Creators
-
- MODULE$ - Static variable in class akka.actor.AbstractActor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.AbstractFSM$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Actor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Actor.emptyBehavior$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Actor.ignoringBehavior$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorCell$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorDSL$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorDSL.Extension$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorIdentity$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorInitializationException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorKilledException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorNotFound$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorPath$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorPathExtractor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorPaths$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorRef$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorSelection$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorSelectionMessage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorSystem$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Address$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.AddressFromURIString$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.AddressTerminated$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.AllForOneStrategy$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ChildNameReserved$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ChildRestartStats$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ContextualTypedActorFactory$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.DeadLetter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.DeadLetterActorRef$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.DeathPactException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Deploy$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dsl.Inbox$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dsl.Inbox.Get$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dsl.Inbox.Kick$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dsl.Inbox.Select$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dsl.Inbox.StartWatch$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer.Creation$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer.Recreation$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer.TerminatedChildrenContainer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer.Termination$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer.UserRequest$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dungeon.ReceiveTimeout$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.$minus$greater$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.CurrentState$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.Event$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.Failure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.LogEntry$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.Normal$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.NullFunction$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.Shutdown$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.State$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.StateTimeout$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.StopEvent$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.SubscribeTransitionCallBack$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.TimeoutMarker$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.Timer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.Transition$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.UnsubscribeTransitionCallBack$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Identify$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.IllegalActorStateException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Inbox$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.IndirectActorProducer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.InvalidActorNameException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.InvalidMessageException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Kill$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.LightArrayRevolverScheduler$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.LocalActorRefProvider$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.LocalScope$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Nobody$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.NoScopeGiven$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.OneForOneStrategy$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.OriginalRestartException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.PoisonPill$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.PostRestartException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.PreRestartException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Props$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ReceiveTimeout$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.RelativeActorPath$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.RootActorPath$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SchedulerException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SelectChildName$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SelectChildPattern$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SelectParent$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SerializedActorRef$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.StashOverflowException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Status$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Status.Failure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Status.Success$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.StopChild$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SupervisorStrategy$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SupervisorStrategy.Escalate$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SupervisorStrategy.Restart$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SupervisorStrategy.Resume$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SupervisorStrategy.Stop$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SuppressedDeadLetter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SystemGuardian$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SystemGuardian.RegisterTerminationHook$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SystemGuardian.TerminationHook$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SystemGuardian.TerminationHookDone$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Terminated$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.TypedActor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.TypedActor.MethodCall$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.TypedActor.SerializedMethodCall$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.TypedActor.SerializedTypedActorInvocationHandler$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.TypedProps$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.UnhandledMessage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.BalancingDispatcherConfigurator$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.BoundedControlAwareMailbox$
-
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.BoundedStablePriorityMailbox$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.CachingConfig$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.CachingConfig.StringPathEntry$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.CachingConfig.ValuePathEntry$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.DefaultDispatcherPrerequisites$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.Dispatchers$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.Envelope$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.ExecutionContexts$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.ExecutionContexts.sameThreadExecutionContext$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.Filter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.ForkJoinExecutorConfigurator$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.Futures$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.japi$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.Mailbox$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.Mailboxes$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.MessageDispatcher$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.MonitorableThreadFactory$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.NonBlockingBoundedMailbox$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.PriorityGenerator$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.SingleConsumerOnlyUnboundedMailbox$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.Create$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.DeathWatchNotification$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.EarliestFirstSystemMessageList$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.Failed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.LatestFirstSystemMessageList$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.NoMessage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.Recreate$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.Resume$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.Supervise$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.Suspend$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.SystemMessageList$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.Terminate$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.Unwatch$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.Watch$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.TaskInvocation$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.ThreadPoolConfig$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.ThreadPoolConfigBuilder$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.UnboundedControlAwareMailbox$
-
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.dispatch.UnboundedStablePriorityMailbox$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.ActorClassificationUnsubscriber$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.ActorClassificationUnsubscriber.Register$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.ActorClassificationUnsubscriber.Unregister$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.AddressTerminatedTopic$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.EventStream$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.EventStreamUnsubscriber$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.EventStreamUnsubscriber.Register$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.EventStreamUnsubscriber.UnregisterIfNoMoreSubscribedChannels$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.Logging$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.Logging.Debug$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.Logging.Error$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.Logging.Error.NoCause$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.Logging.Error2$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.Logging.Extension$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.Logging.Info$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.Logging.InitializeLogger$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.Logging.LoggerInitialized$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.Logging.LogLevel$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.Logging.Warning$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.LoggingReceive$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.LogSource$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.NoLogging$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Dns$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Dns.Resolve$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Dns.Resolved$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Inet$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Inet.DatagramChannelCreator$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Inet.SO$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.IO$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.SelectionHandler$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.SelectionHandler.ChannelAcceptable$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.SelectionHandler.ChannelConnectable$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.SelectionHandler.ChannelReadable$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.SelectionHandler.ChannelWritable$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.SelectionHandler.Retry$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.SelectionHandler.WorkerForCommand$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.SimpleDnsCache$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.SimpleDnsManager$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.Abort$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.Aborted$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.Bind$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.Bound$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.Close$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.Closed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.CommandFailed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.CompoundWrite$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.ConfirmedClose$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.ConfirmedClosed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.Connect$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.Connected$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.ErrorClosed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.NoAck$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.PeerClosed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.Received$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.Register$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.ResumeAccepting$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.ResumeReading$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.ResumeWriting$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.SO$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.SuspendReading$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.Unbind$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.Unbound$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.Write$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.WriteCommand$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.WriteFile$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.WritingResumed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpConnection$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpConnection.AllRead$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpConnection.CloseInformation$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpConnection.ConnectionInfo$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpConnection.EmptyPendingWrite$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpConnection.EndOfStream$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpConnection.MoreDataWaiting$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpConnection.UpdatePendingWriteAndThen$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpConnection.WriteFileFailed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpListener$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpListener.FailedRegisterIncoming$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpListener.RegisterIncoming$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpMessage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpSO$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp.Bind$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp.Bound$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp.CommandFailed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp.NoAck$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp.Received$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp.ResumeReading$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp.Send$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp.SimpleSender$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp.SimpleSenderReady$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp.SO$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp.SuspendReading$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp.Unbind$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp.Unbound$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpConnected$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpConnected.CommandFailed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpConnected.Connect$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpConnected.Connected$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpConnected.Disconnect$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpConnected.Disconnected$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpConnected.NoAck$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpConnected.Received$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpConnected.ResumeReading$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpConnected.Send$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpConnected.SuspendReading$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpConnectedMessage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpMessage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpSO$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.JavaPartialFunction$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in exception akka.japi.JavaPartialFunction.NoMatch$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.Option$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.Option.Some$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.Pair$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.pf.CaseStatement$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple10$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple11$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple12$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple13$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple14$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple15$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple16$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple17$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple18$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple19$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple20$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple21$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple22$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple3$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple4$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple5$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple6$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple7$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple8$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple9$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.Util$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.Main$
-
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.BackoffSupervisor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.BackoffSupervisor.CurrentChild$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.BackoffSupervisor.GetCurrentChild$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.CircuitBreaker$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.CircuitBreakerOpenException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.Patterns$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.PromiseActorRef$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ActorRefRoutee$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ActorSelectionRoutee$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.AddRoutee$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.AdjustPoolSize$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.BalancingPool$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.BalancingPoolDeploy$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.BalancingRoutingLogic$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.Broadcast$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.BroadcastGroup$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.BroadcastPool$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.BroadcastRoutingLogic$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ConsistentHash$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ConsistentHashingGroup$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ConsistentHashingPool$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ConsistentHashingRouter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ConsistentHashingRouter.emptyConsistentHashMapping$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ConsistentHashingRoutingLogic$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ConsistentRoutee$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.Deafen$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.DefaultResizer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.FromConfig$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.GetRoutees$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.Listen$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.MurmurHash$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.NoRoutee$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.NoRouter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.Pool$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.RandomGroup$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.RandomPool$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.RandomRoutingLogic$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.RemoveRoutee$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ResizablePoolActor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ResizablePoolActor.Resize$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.RoundRobinGroup$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.RoundRobinPool$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.RoundRobinRoutingLogic$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.RoutedActorCell$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.Routees$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.Router$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ScatterGatherFirstCompletedGroup$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ScatterGatherFirstCompletedPool$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ScatterGatherFirstCompletedRoutees$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ScatterGatherFirstCompletedRoutingLogic$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.SeveralRoutees$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.SmallestMailboxPool$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.SmallestMailboxRoutingLogic$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.TailChoppingGroup$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.TailChoppingPool$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.TailChoppingRoutees$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.TailChoppingRoutingLogic$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.WithListeners$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.serialization.JavaSerializer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.serialization.NullSerializer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.serialization.Serialization$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.serialization.Serialization.Information$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.serialization.SerializationExtension$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.BoxedType$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.ByteIterator$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.ByteIterator.ByteArrayIterator$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.ByteIterator.MultiByteArrayIterator$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.ByteString$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.ByteString.ByteString1$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.ByteString.ByteString1C$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.ByteString.ByteStrings$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.ByteString.Companion$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.Collections$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.Collections.EmptyImmutableSeq$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.CompactByteString$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.Crypt$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.HashCode$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.Helpers$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.Helpers.ConfigOps$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.Helpers.Requiring$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.LineNumbers$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.LineNumbers.NoSourceInfo$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.LineNumbers.SourceFile$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.LineNumbers.SourceFileLines$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.LineNumbers.UnknownSourceFormat$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.PriorityQueueStabilizer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.Reflect$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.SerializedSuspendableExecutionContext$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.SubclassifiedIndex$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.Switch$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.Timeout$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.TypedMultiMap$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.WildcardTree$
-
Static reference to the singleton instance of this Scala object.
- MonitorableThreadFactory - Class in akka.dispatch
-
- MonitorableThreadFactory(String, boolean, Option<ClassLoader>, Thread.UncaughtExceptionHandler, AtomicLong) - Constructor for class akka.dispatch.MonitorableThreadFactory
-
- MonitorableThreadFactory$ - Class in akka.dispatch
-
- MonitorableThreadFactory$() - Constructor for class akka.dispatch.MonitorableThreadFactory$
-
- MonitorableThreadFactory.AkkaForkJoinWorkerThread - Class in akka.dispatch
-
- MoreDataWaiting$() - Constructor for class akka.io.TcpConnection.MoreDataWaiting$
-
- msg() - Method in class akka.actor.ActorSelectionMessage
-
- msg() - Method in class akka.actor.FSM.Timer
-
- msg() - Method in exception akka.actor.SchedulerException
-
- MultiByteArrayIterator$() - Constructor for class akka.util.ByteIterator.MultiByteArrayIterator$
-
- 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$
-
- safeShutdownOutput() - Method in class akka.io.TcpConnection
-
- sameThreadExecutionContext$() - Constructor for class akka.dispatch.ExecutionContexts.sameThreadExecutionContext$
-
- 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
-
Java API: See documentation for
ScanningClassification
E is the Event type
S is the Subscriber type
C is the Classifier type
- ScanningEventBus() - Constructor for class akka.event.japi.ScanningEventBus
-
- ScatterGatherFirstCompletedGroup - Class in akka.routing
-
A router group that broadcasts the message to all routees, and replies with the first response.
- ScatterGatherFirstCompletedGroup(Iterable<String>, FiniteDuration, String) - Constructor for class akka.routing.ScatterGatherFirstCompletedGroup
-
- ScatterGatherFirstCompletedGroup(Config) - Constructor for class akka.routing.ScatterGatherFirstCompletedGroup
-
- ScatterGatherFirstCompletedGroup(Iterable<String>, FiniteDuration) - Constructor for class akka.routing.ScatterGatherFirstCompletedGroup
-
Java API
- ScatterGatherFirstCompletedGroup$ - Class in akka.routing
-
- ScatterGatherFirstCompletedGroup$() - Constructor for class akka.routing.ScatterGatherFirstCompletedGroup$
-
- ScatterGatherFirstCompletedPool - Class in akka.routing
-
A router pool that broadcasts the message to all routees, and replies with the first response.
- ScatterGatherFirstCompletedPool(int, Option<Resizer>, FiniteDuration, SupervisorStrategy, String, boolean) - Constructor for class akka.routing.ScatterGatherFirstCompletedPool
-
- ScatterGatherFirstCompletedPool(Config) - Constructor for class akka.routing.ScatterGatherFirstCompletedPool
-
- ScatterGatherFirstCompletedPool(int, FiniteDuration) - Constructor for class akka.routing.ScatterGatherFirstCompletedPool
-
Java API
- ScatterGatherFirstCompletedPool$ - Class in akka.routing
-
- ScatterGatherFirstCompletedPool$() - Constructor for class akka.routing.ScatterGatherFirstCompletedPool$
-
- ScatterGatherFirstCompletedRoutees - Class in akka.routing
-
INTERNAL API
- ScatterGatherFirstCompletedRoutees(IndexedSeq<Routee>, FiniteDuration) - Constructor for class akka.routing.ScatterGatherFirstCompletedRoutees
-
- ScatterGatherFirstCompletedRoutees$ - Class in akka.routing
-
- ScatterGatherFirstCompletedRoutees$() - Constructor for class akka.routing.ScatterGatherFirstCompletedRoutees$
-
- ScatterGatherFirstCompletedRoutingLogic - Class in akka.routing
-
Broadcasts the message to all routees, and replies with the first response.
- ScatterGatherFirstCompletedRoutingLogic(FiniteDuration) - Constructor for class akka.routing.ScatterGatherFirstCompletedRoutingLogic
-
- ScatterGatherFirstCompletedRoutingLogic$ - Class in akka.routing
-
- ScatterGatherFirstCompletedRoutingLogic$() - Constructor for class akka.routing.ScatterGatherFirstCompletedRoutingLogic$
-
- schedule(FiniteDuration, FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.AbstractScheduler
-
Schedules a function to be run repeatedly with an initial delay and
a frequency.
- schedule(ActorRef, FiniteDuration) - Method in class akka.actor.FSM.Timer
-
- schedule(FiniteDuration, FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.LightArrayRevolverScheduler
-
- schedule(FiniteDuration, FiniteDuration, ActorRef, Object, ExecutionContext, ActorRef) - Method in interface akka.actor.Scheduler
-
Schedules a message to be sent repeatedly with an initial delay and
frequency.
- schedule(FiniteDuration, FiniteDuration, Function0<BoxedUnit>, ExecutionContext) - Method in interface akka.actor.Scheduler
-
Schedules a function to be run repeatedly with an initial delay and a
frequency.
- schedule(FiniteDuration, FiniteDuration, Runnable, ExecutionContext) - Method in interface akka.actor.Scheduler
-
Schedules a Runnable
to be run repeatedly with an initial delay and
a frequency.
- Scheduled() - Method in class akka.dispatch.Mailbox$
-
- Scheduled() - Static method in class akka.dispatch.Mailbox
-
- SCHEDULED() - Method in class akka.dispatch.MessageDispatcher$
-
- SCHEDULED() - Static method in class akka.dispatch.MessageDispatcher
-
- scheduleOnce(FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.AbstractScheduler
-
Schedules a Runnable to be run once with a delay, i.e.
- scheduleOnce(FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.LightArrayRevolverScheduler
-
- scheduleOnce(FiniteDuration, ActorRef, Object, ExecutionContext, ActorRef) - Method in interface akka.actor.Scheduler
-
Schedules a message to be sent once with a delay, i.e.
- scheduleOnce(FiniteDuration, Function0<BoxedUnit>, ExecutionContext) - Method in interface akka.actor.Scheduler
-
Schedules a function to be run once with a delay, i.e.
- scheduleOnce(FiniteDuration, Runnable, ExecutionContext) - Method in interface akka.actor.Scheduler
-
Schedules a Runnable to be run once with a delay, i.e.
- scheduler() - Method in class akka.actor.ActorSystem
-
Light-weight scheduler for running asynchronous tasks after some deadline
in the future.
- scheduler() - Method in class akka.actor.ActorSystemImpl
-
- Scheduler - Interface in akka.actor
-
An Akka scheduler service.
- scheduler() - Method in class akka.dispatch.DefaultDispatcherPrerequisites
-
- scheduler() - Method in interface akka.dispatch.DispatcherPrerequisites
-
- scheduler() - Method in class akka.routing.TailChoppingRoutees
-
- scheduler() - Method in class akka.routing.TailChoppingRoutingLogic
-
- SchedulerClass() - Method in class akka.actor.ActorSystem.Settings
-
- SchedulerException - Exception in akka.actor
-
This exception is thrown by Scheduler.schedule* when scheduling is not
possible, e.g.
- SchedulerException(String) - Constructor for exception akka.actor.SchedulerException
-
- SchedulerException$ - Class in akka.actor
-
- SchedulerException$() - Constructor for class akka.actor.SchedulerException$
-
- 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.
- second() - Method in class akka.japi.Pair
-
- SEED() - Method in class akka.util.HashCode$
-
- SEED() - Static method in class akka.util.HashCode
-
- select(FiniteDuration, PartialFunction<Object, T>) - Method in class akka.actor.dsl.Inbox.Inbox
-
Receive a single message for which the given partial function is defined
and return the transformed result, using the internal receiver
actor.
- Select(Deadline, PartialFunction<Object, Object>, ActorRef) - Constructor for class akka.actor.dsl.Inbox.Select
-
- select(Object, IndexedSeq<Routee>) - Method in class akka.routing.BalancingRoutingLogic
-
- select(Object, IndexedSeq<Routee>) - Method in class akka.routing.BroadcastRoutingLogic
-
- select(Object, IndexedSeq<Routee>) - Method in class akka.routing.ConsistentHashingRoutingLogic
-
- select(Object, IndexedSeq<Routee>) - Method in class akka.routing.RandomRoutingLogic
-
- select(Object, IndexedSeq<Routee>) - Method in class akka.routing.RoundRobinRoutingLogic
-
- select(Object, IndexedSeq<Routee>) - Method in interface akka.routing.RoutingLogic
-
Pick the destination for a given message.
- select(Object, IndexedSeq<Routee>) - Method in class akka.routing.ScatterGatherFirstCompletedRoutingLogic
-
- select(Object, IndexedSeq<Routee>) - Method in class akka.routing.SmallestMailboxRoutingLogic
-
- select(Object, IndexedSeq<Routee>) - Method in class akka.routing.TailChoppingRoutingLogic
-
- Select$() - Constructor for class akka.actor.dsl.Inbox.Select$
-
- SelectChildName - Class in akka.actor
-
INTERNAL API
- SelectChildName(String) - Constructor for class akka.actor.SelectChildName
-
- SelectChildName$ - Class in akka.actor
-
- SelectChildName$() - Constructor for class akka.actor.SelectChildName$
-
- SelectChildPattern - Class in akka.actor
-
INTERNAL API
- SelectChildPattern(String) - Constructor for class akka.actor.SelectChildPattern
-
- SelectChildPattern$ - Class in akka.actor
-
- SelectChildPattern$() - Constructor for class akka.actor.SelectChildPattern$
-
- selection() - Method in exception akka.actor.ActorNotFound
-
- selection() - Method in class akka.routing.ActorSelectionRoutee
-
- SelectionHandler - Class in akka.io
-
- SelectionHandler(SelectionHandlerSettings) - Constructor for class akka.io.SelectionHandler
-
- SelectionHandler$ - Class in akka.io
-
- SelectionHandler$() - Constructor for class akka.io.SelectionHandler$
-
- SelectionHandler.ChannelAcceptable$ - Class in akka.io
-
- SelectionHandler.ChannelConnectable$ - Class in akka.io
-
- SelectionHandler.ChannelReadable$ - Class in akka.io
-
- SelectionHandler.ChannelWritable$ - Class in akka.io
-
- SelectionHandler.HasFailureMessage - Interface in akka.io
-
- SelectionHandler.Retry - Class in akka.io
-
- SelectionHandler.Retry$ - Class in akka.io
-
- SelectionHandler.SelectorBasedManager - Class in akka.io
-
- SelectionHandler.WorkerForCommand - Class in akka.io
-
- SelectionHandler.WorkerForCommand$ - Class in akka.io
-
- SelectionHandlerSettings - Class in akka.io
-
- SelectionHandlerSettings(Config) - Constructor for class akka.io.SelectionHandlerSettings
-
- SelectionPathElement - Interface in akka.actor
-
INTERNAL API
- selector() - Method in class akka.io.UdpListener
-
- SelectorAssociationRetries() - Method in class akka.io.SelectionHandlerSettings
-
- SelectorBasedManager(SelectionHandlerSettings, int) - Constructor for class akka.io.SelectionHandler.SelectorBasedManager
-
- SelectorDispatcher() - Method in class akka.io.SelectionHandlerSettings
-
- selectorPool() - Method in class akka.io.SelectionHandler.SelectorBasedManager
-
- SelectParent - Class in akka.actor
-
INTERNAL API
- SelectParent() - Constructor for class akka.actor.SelectParent
-
- SelectParent$ - Class in akka.actor
-
INTERNAL API
- SelectParent$() - Constructor for class akka.actor.SelectParent$
-
- self() - Method in interface akka.actor.Actor
-
The 'self' field holds the ActorRef for this actor.
- self() - Method in class akka.actor.ActorCell
-
- self() - Method in interface akka.actor.ActorContext
-
- self() - Method in interface akka.actor.Cell
-
The “self” reference which this Cell is attached to.
- self() - Method in interface akka.actor.StashSupport
-
INTERNAL API.
- self() - Method in class akka.actor.TypedActor$
-
Returns the reference to the proxy when called inside a method call in a TypedActor
- self() - Static method in class akka.actor.TypedActor
-
Returns the reference to the proxy when called inside a method call in a TypedActor
- self() - Method in class akka.actor.UnstartedCell
-
- selfAddress() - Method in class akka.routing.ConsistentRoutee
-
- 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(ByteString, InetSocketAddress, Udp.Event) - Constructor for class akka.io.Udp.Send
-
- Send(ByteString, Object) - Constructor for class akka.io.UdpConnected.Send
-
- 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(Object, ActorRef) - Method in class akka.routing.ActorRefRoutee
-
- send(Object, ActorRef) - Method in class akka.routing.ActorSelectionRoutee
-
- send(Object, ActorRef) - Method in class akka.routing.NoRoutee$
-
- send(Object, ActorRef) - Static method in class akka.routing.NoRoutee
-
- send(Object, ActorRef) - Method in interface akka.routing.Routee
-
- send(Object, ActorRef) - Method in class akka.routing.ScatterGatherFirstCompletedRoutees
-
- send(Object, ActorRef) - Method in class akka.routing.SeveralRoutees
-
- send(Object, ActorRef) - Method in class akka.routing.TailChoppingRoutees
-
- Send$() - Constructor for class akka.io.Udp.Send$
-
- Send$() - Constructor for class akka.io.UdpConnected.Send$
-
- SendBufferSize(int) - Constructor for class akka.io.Inet.SO$.SendBufferSize
-
- SendBufferSize() - Method in interface akka.io.Inet.SoForwarders
-
- sendBufferSize(int) - Method in interface akka.io.Inet.SoJavaFactories
-
- sender() - Method in interface akka.actor.Actor
-
The reference sender Actor of the last received message.
- sender() - Method in class akka.actor.ActorCell
-
- sender() - Method in interface akka.actor.ActorContext
-
Returns the sender 'ActorRef' of the current message.
- sender() - Method in interface akka.actor.AllDeadLetters
-
- sender() - Method in class akka.actor.DeadLetter
-
- sender() - Method in class akka.actor.SuppressedDeadLetter
-
- sender() - Method in class akka.actor.UnhandledMessage
-
- sender() - Method in class akka.dispatch.Envelope
-
- sender() - Method in class akka.io.Udp.Received
-
- senderFromInbox(akka.actor.dsl.Inbox.Inbox) - Method in interface akka.actor.dsl.Inbox
-
- sendHandlers(ChannelRegistration) - Method in interface akka.io.WithUdpSend
-
- sendMessage(akka.dispatch.Envelope) - Method in interface akka.actor.Cell
-
Enqueue a message to be sent to the actor; may or may not actually
schedule the actor to run, depending on which type of cell it is.
- sendMessage(Object, ActorRef) - Method in interface akka.actor.Cell
-
Enqueue a message to be sent to the actor; may or may not actually
schedule the actor to run, depending on which type of cell it is.
- sendMessage(Envelope) - Method in interface akka.actor.dungeon.Dispatch
-
- sendMessage(Envelope) - Method in class akka.actor.UnstartedCell
-
- sendMessage(Envelope) - Method in class akka.routing.ResizablePoolCell
-
- sendMessage(Envelope) - Method in class akka.routing.RoutedActorCell
-
Route the message via the router to the selected destination.
- sendSystemMessage(akka.dispatch.sysmsg.SystemMessage) - Method in interface akka.actor.Cell
-
Enqueue a message to be sent to the actor; may or may not actually
schedule the actor to run, depending on which type of cell it is.
- sendSystemMessage(SystemMessage) - Method in interface akka.actor.dungeon.Dispatch
-
- sendSystemMessage(SystemMessage) - Method in class akka.actor.EmptyLocalActorRef
-
- sendSystemMessage(akka.dispatch.sysmsg.SystemMessage) - Method in class akka.actor.InternalActorRef
-
- sendSystemMessage(akka.dispatch.sysmsg.SystemMessage) - Method in class akka.actor.LocalActorRef
-
- sendSystemMessage(SystemMessage) - Method in interface akka.actor.MinimalActorRef
-
- sendSystemMessage(SystemMessage) - Method in class akka.actor.RepointableActorRef
-
- sendSystemMessage(SystemMessage) - Method in class akka.actor.UnstartedCell
-
- sendSystemMessage(SystemMessage) - Method in class akka.pattern.PromiseActorRef
-
- seq() - Method in class akka.event.ActorClassificationUnsubscriber.Register
-
- seq() - Method in class akka.event.ActorClassificationUnsubscriber.Unregister
-
- seq(T...) - Static method in class akka.japi.JAPI
-
- 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
.
- seqNr() - Method in class akka.event.ManagedActorClassification.ManagedActorClassificationMappings
-
- seqNum() - Method in interface akka.util.PriorityQueueStabilizer
-
- seqNum() - Method in class akka.util.PriorityQueueStabilizer.WrappedElement
-
- 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$
-
- sequence(Iterable<Future<A>>, ExecutionContext) - Static method in class akka.dispatch.Futures
-
- Serialization - Class in akka.serialization
-
Serialization module.
- Serialization(ExtendedActorSystem) - Constructor for class akka.serialization.Serialization
-
- Serialization$ - Class in akka.serialization
-
- Serialization$() - Constructor for class akka.serialization.Serialization$
-
- Serialization.Information - Class in akka.serialization
-
Serialization information needed for serializing local actor refs.
- Serialization.Information$ - Class in akka.serialization
-
- Serialization.Settings - Class in akka.serialization
-
- 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$
-
- SerializationIdentifiers() - Method in interface akka.serialization.BaseSerializer
-
Configuration namespace of serialization identifiers in the reference.conf
.
- SerializationIdentity() - Method in class akka.util.ByteString.ByteString1$
-
- SerializationIdentity() - Method in class akka.util.ByteString.ByteString1C$
-
- SerializationIdentity() - Method in class akka.util.ByteString.ByteStrings$
-
- SerializationIdentity() - Method in interface akka.util.ByteString.Companion
-
- 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.
- SerializeAllCreators() - Method in class akka.actor.ActorSystem.Settings
-
- SerializeAllMessages() - Method in class akka.actor.ActorSystem.Settings
-
- serialized() - Method in class akka.actor.DeadLetterActorRef$
-
- serialized() - Static method in class akka.actor.DeadLetterActorRef
-
- serializedActorPath(ActorRef) - Method in class akka.serialization.Serialization$
-
The serialized path of an actorRef, based on the current transport serialization information.
- serializedActorPath(ActorRef) - Static method in class akka.serialization.Serialization
-
The serialized path of an actorRef, based on the current transport serialization information.
- SerializedActorRef - Class in akka.actor
-
Memento pattern for serializing ActorRefs transparently
INTERNAL API
- SerializedActorRef(ActorRef) - Constructor for class akka.actor.SerializedActorRef
-
- SerializedActorRef$ - Class in akka.actor
-
INTERNAL API
- SerializedActorRef$() - Constructor for class akka.actor.SerializedActorRef$
-
- SerializedDeadLetterActorRef() - Constructor for class akka.actor.DeadLetterActorRef.SerializedDeadLetterActorRef
-
- SerializedMethodCall(Class<?>, String, Class<?>[], Tuple3<Object, Class<?>, byte[]>[]) - Constructor for class akka.actor.TypedActor.SerializedMethodCall
-
- SerializedMethodCall$() - Constructor for class akka.actor.TypedActor.SerializedMethodCall$
-
- SerializedNobody - Class in akka.actor
-
INTERNAL API
- SerializedNobody() - Constructor for class akka.actor.SerializedNobody
-
- serializedParameters() - Method in class akka.actor.TypedActor.SerializedMethodCall
-
- SerializedStandardOutLogger() - Constructor for class akka.event.Logging.SerializedStandardOutLogger
-
- SerializedSuspendableExecutionContext - Class in akka.util
-
This ExecutionContext
allows to wrap an underlying ExecutionContext
and provide guaranteed serial execution
of tasks submitted to it.
- SerializedSuspendableExecutionContext(int, ExecutionContext) - Constructor for class akka.util.SerializedSuspendableExecutionContext
-
- SerializedSuspendableExecutionContext$ - Class in akka.util
-
- SerializedSuspendableExecutionContext$() - Constructor for class akka.util.SerializedSuspendableExecutionContext$
-
- SerializedTypedActorInvocationHandler(ActorRef, FiniteDuration) - Constructor for class akka.actor.TypedActor.SerializedTypedActorInvocationHandler
-
- SerializedTypedActorInvocationHandler$() - Constructor for class akka.actor.TypedActor.SerializedTypedActorInvocationHandler$
-
- 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.
- 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
-
- SerializerWithStringManifest - Class in akka.serialization
-
A Serializer represents a bimap between an object and an array of bytes representing that object.
- SerializerWithStringManifest() - Constructor for class akka.serialization.SerializerWithStringManifest
-
- setActor(ActorCell) - Method in class akka.dispatch.Mailbox
-
- setActorFields(Actor, ActorContext, ActorRef) - Method in class akka.actor.ActorCell
-
- setAllowCoreThreadTimeout(boolean) - Method in class akka.dispatch.ThreadPoolConfigBuilder
-
- setAsIdle() - Method in class akka.dispatch.Mailbox
-
Reset Scheduled status, keeping primary status as is.
- setAsScheduled() - Method in class akka.dispatch.Mailbox
-
Set Scheduled status, keeping primary status as is.
- setChildrenTerminationReason(ChildrenContainer.SuspendReason) - Method in interface akka.actor.dungeon.Children
-
- setCorePoolSize(int) - Method in class akka.dispatch.ThreadPoolConfigBuilder
-
- setCorePoolSizeFromFactor(int, double, int) - Method in class akka.dispatch.ThreadPoolConfigBuilder
-
- setFailed(ActorRef) - Method in interface akka.actor.dungeon.FaultHandling
-
- 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.
- setMaxPoolSize(int) - Method in class akka.dispatch.ThreadPoolConfigBuilder
-
- setMaxPoolSizeFromFactor(int, double, int) - Method in class akka.dispatch.ThreadPoolConfigBuilder
-
- setMDC(Map<String, Object>) - Method in interface akka.event.DiagnosticLoggingAdapter
-
Java API:
Sets the values to be added to the MDC (Mapped Diagnostic Context) before the log is appended.
- setNext(AbstractBoundedNodeQueue.Node<T>) - Method in class akka.dispatch.AbstractBoundedNodeQueue.Node
-
- setNext(AbstractNodeQueue.Node<T>) - Method in class akka.dispatch.AbstractNodeQueue.Node
-
- setQueueFactory(Function0<BlockingQueue<Runnable>>) - Method in class akka.dispatch.ThreadPoolConfigBuilder
-
- setRawResult(BoxedUnit) - Method in class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinTask
-
- setRawResult(BoxedUnit) - Method in class akka.dispatch.Mailbox
-
- setReceiveTimeout(Duration) - Method in interface akka.actor.ActorContext
-
Defines the inactivity timeout after which the sending of a
ReceiveTimeout
message is triggered.
- setReceiveTimeout(Duration) - Method in interface akka.actor.dungeon.ReceiveTimeout
-
- setStateTimeout(S, Option<FiniteDuration>) - Method in interface akka.actor.FSM
-
- setStatus(int) - Method in class akka.dispatch.Mailbox
-
- setTerminated() - Method in interface akka.actor.dungeon.Children
-
- setTimer(String, Object, FiniteDuration) - Method in class akka.actor.AbstractFSM
-
Schedule named timer to deliver message after given delay, possibly repeating.
- setTimer(String, Object, FiniteDuration, boolean) - Method in interface akka.actor.FSM
-
- 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(ClassLoader, Config, String) - Constructor for class akka.actor.ActorSystem.Settings
-
- settings() - Method in class akka.actor.ActorSystemImpl
-
- settings() - Method in class akka.actor.Deployer
-
- settings() - Method in class akka.actor.LocalActorRefProvider
-
- settings() - Method in class akka.dispatch.DefaultDispatcherPrerequisites
-
- settings() - Method in interface akka.dispatch.DispatcherPrerequisites
-
- settings() - Method in class akka.dispatch.Dispatchers
-
- settings() - Method in class akka.dispatch.Mailboxes
-
- Settings() - Method in class akka.io.DnsExt
-
- Settings(Config) - Constructor for class akka.io.DnsExt.Settings
-
- Settings() - Method in class akka.io.TcpExt
-
- Settings(Config) - Constructor for class akka.io.TcpExt.Settings
-
- settings() - Method in class akka.io.UdpConnectedExt
-
- settings() - Method in class akka.io.UdpExt
-
- settings() - Method in interface akka.io.WithUdpSend
-
- settings() - Method in class akka.serialization.Serialization
-
- Settings(Config) - Constructor for class akka.serialization.Serialization.Settings
-
- setUpStdoutLogger(ActorSystem.Settings) - Method in interface akka.event.LoggingBus
-
- SeveralRoutees - Class in akka.routing
-
Routee
that sends each message to all
routees
.
- SeveralRoutees(IndexedSeq<Routee>) - Constructor for class akka.routing.SeveralRoutees
-
- SeveralRoutees(Iterable<Routee>) - Constructor for class akka.routing.SeveralRoutees
-
Java API
- SeveralRoutees$ - Class in akka.routing
-
- SeveralRoutees$() - Constructor for class akka.routing.SeveralRoutees$
-
- sha1(String) - Method in class akka.util.Crypt$
-
- sha1(byte[]) - Method in class akka.util.Crypt$
-
- sha1(String) - Static method in class akka.util.Crypt
-
- sha1(byte[]) - Static method in class akka.util.Crypt
-
- shallDie(ActorRef) - Method in interface akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer
-
- shallDie(ActorRef) - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
-
- shallDie(ActorRef) - Method in interface akka.actor.dungeon.ChildrenContainer
-
- shallDie(ActorRef) - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
-
- shouldNotProcessMask() - Method in class akka.dispatch.Mailbox$
-
- shouldNotProcessMask() - Static method in class akka.dispatch.Mailbox
-
- shouldProcessMessage() - Method in class akka.dispatch.Mailbox
-
- shouldScheduleMask() - Method in class akka.dispatch.Mailbox$
-
- shouldScheduleMask() - Static method in class akka.dispatch.Mailbox
-
- Shutdown() - Method in class akka.actor.AbstractFSM
-
Reason given when someone was calling system.stop(fsm)
from outside;
also applies to Stop
supervision directive.
- shutdown() - Method in class akka.actor.ActorSystem
-
Stop this actor system.
- shutdown() - Method in class akka.actor.ActorSystemImpl
-
- shutdown() - Method in class akka.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$() - Constructor for class akka.actor.FSM.Shutdown$
-
- 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
- signDeathPact(ActorRef) - Method in class akka.io.TcpConnection
-
- SilentState(S, D, Option<FiniteDuration>, Option<FSM.Reason>, List<Object>) - Constructor for class akka.actor.FSM.SilentState
-
- SimpleDnsCache - Class in akka.io
-
- SimpleDnsCache() - Constructor for class akka.io.SimpleDnsCache
-
- SimpleDnsCache$ - Class in akka.io
-
- SimpleDnsCache$() - Constructor for class akka.io.SimpleDnsCache$
-
- SimpleDnsManager - Class in akka.io
-
- SimpleDnsManager(DnsExt) - Constructor for class akka.io.SimpleDnsManager
-
- SimpleDnsManager$ - Class in akka.io
-
- SimpleDnsManager$() - Constructor for class akka.io.SimpleDnsManager$
-
- 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(Traversable<Inet.SocketOption>) - Constructor for class akka.io.Udp.SimpleSender
-
- 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.
- SimpleSender$() - Constructor for class akka.io.Udp.SimpleSender$
-
- SimpleSenderReady$() - Constructor for class akka.io.Udp.SimpleSenderReady$
-
- SimpleWriteCommand() - Constructor for class akka.io.Tcp.SimpleWriteCommand
-
- 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 BalancingPool (BalancingDispatcher) for instance.
- SingleConsumerOnlyUnboundedMailbox() - Constructor for class akka.dispatch.SingleConsumerOnlyUnboundedMailbox
-
- SingleConsumerOnlyUnboundedMailbox(ActorSystem.Settings, Config) - Constructor for class akka.dispatch.SingleConsumerOnlyUnboundedMailbox
-
- SingleConsumerOnlyUnboundedMailbox$ - Class in akka.dispatch
-
- SingleConsumerOnlyUnboundedMailbox$() - Constructor for class akka.dispatch.SingleConsumerOnlyUnboundedMailbox$
-
- size() - Method in class akka.dispatch.AbstractBoundedNodeQueue
-
Returns an approximation of the queue's "current" size
- size() - Method in class akka.dispatch.sysmsg.EarliestFirstSystemMessageList
-
Indicates if the list is empty or not.
- size() - Method in class akka.dispatch.sysmsg.LatestFirstSystemMessageList
-
Indicates if the list is empty or not.
- size() - Method in class akka.io.Inet.SO$.ReceiveBufferSize
-
- size() - Method in class akka.io.Inet.SO$.SendBufferSize
-
- size() - Method in class akka.util.BoundedBlockingQueue
-
- size() - Method in class akka.util.Collections.PartialImmutableValuesIterable
-
- size() - Method in interface akka.util.PriorityQueueStabilizer
-
- size() - Method in class akka.util.SerializedSuspendableExecutionContext
-
O(N)
- sizeHint(int) - Method in class akka.util.ByteStringBuilder
-
- sizeInner(SystemMessage, int) - Method in class akka.dispatch.sysmsg.SystemMessageList$
-
- sizeInner(SystemMessage, int) - Static method in class akka.dispatch.sysmsg.SystemMessageList
-
- 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
-
- SmallestMailboxPool - Class in akka.routing
-
A router pool that tries to send to the non-suspended routee with fewest messages in mailbox.
- SmallestMailboxPool(int, Option<Resizer>, SupervisorStrategy, String, boolean) - Constructor for class akka.routing.SmallestMailboxPool
-
- SmallestMailboxPool(Config) - Constructor for class akka.routing.SmallestMailboxPool
-
- SmallestMailboxPool(int) - Constructor for class akka.routing.SmallestMailboxPool
-
Java API
- SmallestMailboxPool$ - Class in akka.routing
-
- SmallestMailboxPool$() - Constructor for class akka.routing.SmallestMailboxPool$
-
- SmallestMailboxRoutingLogic - Class in akka.routing
-
Tries to send to the non-suspended routee with fewest messages in mailbox.
- SmallestMailboxRoutingLogic() - Constructor for class akka.routing.SmallestMailboxRoutingLogic
-
- SmallestMailboxRoutingLogic$ - Class in akka.routing
-
- SmallestMailboxRoutingLogic$() - Constructor for class akka.routing.SmallestMailboxRoutingLogic$
-
- SO$() - Constructor for class akka.io.Inet.SO$
-
- SO$() - Constructor for class akka.io.Tcp.SO$
-
- SO$() - Constructor for class akka.io.Udp.SO$
-
- 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
- Some(A) - Constructor for class akka.japi.Option.Some
-
- Some$() - Constructor for class akka.japi.Option.Some$
-
- sort(Iterable<Tuple2<Class<? extends Throwable>, SupervisorStrategy.Directive>>) - Method in class akka.actor.SupervisorStrategy$
-
Sort so that subtypes always precede their supertypes, but without
obeying any order between unrelated subtypes (insert sort).
- sort(Iterable<Tuple2<Class<? extends Throwable>, SupervisorStrategy.Directive>>) - Static method in class akka.actor.SupervisorStrategy
-
Sort so that subtypes always precede their supertypes, but without
obeying any order between unrelated subtypes (insert sort).
- SourceFile(String) - Constructor for class akka.util.LineNumbers.SourceFile
-
- SourceFile$() - Constructor for class akka.util.LineNumbers.SourceFile$
-
- SourceFileLines(String, int, int) - Constructor for class akka.util.LineNumbers.SourceFileLines
-
- SourceFileLines$() - Constructor for class akka.util.LineNumbers.SourceFileLines$
-
- span(Function1<Object, Object>) - Method in class akka.util.ByteIterator
-
- span(Function1<Object, Object>) - Method in class akka.util.ByteString
-
- spawnChildWithCapacityProtection(SelectionHandler.WorkerForCommand, int) - Method in class akka.io.SelectionHandler
-
- specialHandle(Object, ActorRef) - Method in class akka.actor.DeadLetterActorRef
-
- specialHandle(Object, ActorRef) - Method in class akka.actor.EmptyLocalActorRef
-
- split(String, String) - Method in interface akka.actor.PathUtils
-
- splitAt(int) - Method in class akka.util.ByteString
-
- splitNameAndUid(String) - Method in class akka.actor.ActorCell$
-
- splitNameAndUid(String) - Static method in class akka.actor.ActorCell
-
- StablePriorityBlockingQueue<E> - Class in akka.util
-
StablePriorityBlockingQueue is a blocking priority queue that preserves order for elements of equal priority.
- StablePriorityBlockingQueue(int, Comparator<E>) - Constructor for class akka.util.StablePriorityBlockingQueue
-
- StablePriorityQueue<E> - Class in akka.util
-
StablePriorityQueue is a priority queue that preserves order for elements of equal priority.
- StablePriorityQueue(int, Comparator<E>) - Constructor for class akka.util.StablePriorityQueue
-
- 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
- StandardOutLogger() - Method in class akka.event.Logging$
-
- StandardOutLogger() - Static method in class akka.event.Logging
-
- StandardOutLogger() - Constructor for class akka.event.Logging.StandardOutLogger
-
- start() - Method in class akka.actor.ActorSystemImpl
-
- start() - Method in interface akka.actor.Cell
-
Start the cell: enqueued message must not be processed before this has
been called.
- start() - Method in interface akka.actor.dungeon.Dispatch
-
Start this cell, i.e.
- start() - Method in class akka.actor.InternalActorRef
-
- start() - Method in class akka.actor.LocalActorRef
-
Starts the actor after initialization.
- start() - Method in interface akka.actor.MinimalActorRef
-
- start() - Method in class akka.actor.RepointableActorRef
-
- start() - Method in class akka.actor.UnstartedCell
-
- start(ActorSystem, ManagedActorClassification, boolean) - Method in class akka.event.ActorClassificationUnsubscriber$
-
- start(ActorSystem, ManagedActorClassification, boolean) - Static method in class akka.event.ActorClassificationUnsubscriber
-
- start(ActorSystem, EventStream) - Method in class akka.event.EventStreamUnsubscriber$
-
- start(ActorSystem, EventStream) - Static method in class akka.event.EventStreamUnsubscriber
-
- start() - Method in class akka.routing.RoutedActorCell
-
- startChild() - Method in class akka.pattern.BackoffSupervisor
-
- startDefaultLoggers(ActorSystemImpl) - Method in interface akka.event.LoggingBus
-
Internal Akka use only
- startHash(int) - Method in class akka.routing.MurmurHash$
-
Begin a new hash with a seed value.
- startHash(int) - Static method in class akka.routing.MurmurHash
-
Begin a new hash with a seed value.
- startMagicA() - Method in class akka.routing.MurmurHash$
-
The initial magic integers in the first stream.
- startMagicA() - Static method in class akka.routing.MurmurHash
-
The initial magic integers in the first stream.
- startMagicB() - Method in class akka.routing.MurmurHash$
-
The initial magic integer in the second stream.
- startMagicB() - Static method in class akka.routing.MurmurHash
-
The initial magic integer in the second stream.
- startStdoutLogger(ActorSystem.Settings) - Method in interface akka.event.LoggingBus
-
Internal Akka use only
- startTime() - Method in class akka.actor.ActorSystem
-
Start-up time in milliseconds since the epoch.
- startUnsubscriber() - Method in class akka.event.EventStream
-
''Must'' be called after actor system is "ready".
- StartWatch(ActorRef) - Constructor for class akka.actor.dsl.Inbox.StartWatch
-
- StartWatch$() - Constructor for class akka.actor.dsl.Inbox.StartWatch$
-
- startWith(S, D) - Method in class akka.actor.AbstractFSM
-
Set initial state.
- startWith(S, D, FiniteDuration) - Method in class akka.actor.AbstractFSM
-
Set initial state.
- startWith(S, D, Option<FiniteDuration>) - Method in interface akka.actor.FSM
-
Set initial state.
- stash(akka.dispatch.sysmsg.SystemMessage) - Method in class akka.actor.ActorCell
-
- Stash - Interface in akka.actor
-
The Stash
trait enables an actor to temporarily stash away messages that can not or
should not be handled using the actor's current behavior.
- stash() - Method in interface akka.actor.StashSupport
-
Adds the current message (the message that the actor received last) to the
actor's stash.
- StashFactory - Interface in akka.actor
-
INTERNAL API.
- StashOverflowException - Exception in akka.actor
-
Is thrown when the size of the Stash exceeds the capacity of the Stash
- StashOverflowException(String, Throwable) - Constructor for exception akka.actor.StashOverflowException
-
- StashOverflowException$ - Class in akka.actor
-
- StashOverflowException$() - Constructor for class akka.actor.StashOverflowException$
-
- StashSupport - Interface in akka.actor
-
INTERNAL API.
- StashWhenFailed - Interface in akka.dispatch.sysmsg
-
INTERNAL API
- StashWhenWaitingForChildren - Interface in akka.dispatch.sysmsg
-
INTERNAL API
- state() - Method in class akka.actor.FSM.CurrentState
-
- State(S, D, Option<FiniteDuration>, Option<FSM.Reason>, List<Object>) - Constructor for class akka.actor.FSM.State
-
- state(S, S, FI.UnitApplyVoid) - Method in class akka.japi.pf.FSMTransitionHandlerBuilder
-
Add a case statement that matches on a from state and a to state.
- state(S, S, FI.UnitApply2<S, S>) - Method in class akka.japi.pf.FSMTransitionHandlerBuilder
-
Add a case statement that matches on a from state and a to state.
- State$() - Constructor for class akka.actor.FSM.State$
-
- stateData() - Method in class akka.actor.FSM.Event
-
- stateData() - Method in class akka.actor.FSM.LogEntry
-
- stateData() - Method in class akka.actor.FSM.State
-
- stateData() - Method in interface akka.actor.FSM
-
- stateData() - Method in class akka.actor.FSM.StopEvent
-
- 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
-
- 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.
- StateTimeout$() - Constructor for class akka.actor.FSM.StateTimeout$
-
- stateTimeouts() - Method in interface akka.actor.FSM
-
- stats() - Method in interface akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer
-
- stats() - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
-
- stats() - Method in interface akka.actor.dungeon.ChildrenContainer
-
- stats() - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
-
- 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$ - 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$ - Class in akka.actor
-
- 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$ - Class in akka.actor
-
- 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(ActorRef) - Method in class akka.actor.ActorSystemImpl
-
- stop() - Method in interface akka.actor.Cell
-
Recursively terminate this actor and all its children.
- Stop() - Method in interface akka.actor.dsl.Creators.Act
-
- stop(ActorRef) - Method in interface akka.actor.dungeon.Children
-
- stop() - Method in interface akka.actor.dungeon.Dispatch
-
- stop() - Method in interface akka.actor.FSM
-
Produce change descriptor to stop this FSM actor with reason "Normal".
- stop(FSM.Reason) - Method in interface akka.actor.FSM
-
Produce change descriptor to stop this FSM actor including specified reason.
- stop(FSM.Reason, D) - Method in interface akka.actor.FSM
-
Produce change descriptor to stop this FSM actor including specified reason.
- stop() - Method in class akka.actor.InternalActorRef
-
- stop() - Method in class akka.actor.LocalActorRef
-
Shuts down the actor and its message queue
- stop() - Method in interface akka.actor.MinimalActorRef
-
- stop() - Method in class akka.actor.RepointableActorRef
-
- stop() - Method in class akka.actor.SupervisorStrategy$
-
Java API: Returning this directive stops the Actor
- stop() - Static method in class akka.actor.SupervisorStrategy
-
Java API: Returning this directive stops the Actor
- stop(Object) - Method in interface akka.actor.TypedActorFactory
-
Stops the underlying ActorRef for the supplied TypedActor proxy,
if any, returns whether it could find the find the ActorRef or not
- stop() - Method in class akka.actor.UnstartedCell
-
- stop(FSM.Reason, FI.UnitApply2<S, D>) - Method in class akka.japi.pf.FSMStopBuilder
-
Add a case statement that matches on an FSM.Reason
.
- stop(Class<P>, FI.UnitApply3<P, S, D>) - Method in class akka.japi.pf.FSMStopBuilder
-
Add a case statement that matches on a reason type.
- stop(Class<P>, FI.TypedPredicate<P>, FI.UnitApply3<P, S, D>) - Method in class akka.japi.pf.FSMStopBuilder
-
Add a case statement that matches on a reason type and a predicate.
- stop() - Method in class akka.pattern.PromiseActorRef
-
- Stop$() - Constructor for class akka.actor.SupervisorStrategy.Stop$
-
- StopChild - Class in akka.actor
-
Internal Akka use only, used in implementation of system.stop(child).
- StopChild(ActorRef) - Constructor for class akka.actor.StopChild
-
- StopChild$ - Class in akka.actor
-
- StopChild$() - Constructor for class akka.actor.StopChild$
-
- stopDefaultLoggers(ActorSystem) - Method in interface akka.event.LoggingBus
-
Internal Akka use only
- StopEvent() - Method in interface akka.actor.FSM
-
- StopEvent(FSM.Reason, S, D) - Constructor for class akka.actor.FSM.StopEvent
-
- StopEvent$() - Constructor for class akka.actor.FSM.StopEvent$
-
- stopIfAllRouteesRemoved() - Method in class akka.routing.RouterActor
-
- 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 interface akka.routing.Pool
-
- stopRouterWhenAllRouteesRemoved() - Method in interface akka.routing.RouterConfig
-
- stopScheduler() - Method in class akka.actor.ActorSystemImpl
-
- stopWith(TcpConnection.CloseInformation) - Method in class akka.io.TcpConnection
-
- 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
- StringPathEntry(boolean, boolean, Config, String) - Constructor for class akka.dispatch.CachingConfig.StringPathEntry
-
- StringPathEntry$() - Constructor for class akka.dispatch.CachingConfig.StringPathEntry$
-
- 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
-
Java API: See documentation for
SubchannelClassification
E is the Event type
S is the Subscriber type
C is the Classifier type
- SubchannelEventBus() - Constructor for class akka.event.japi.SubchannelEventBus
-
- subclassification() - Method in class akka.event.EventStream
-
- subclassification() - Method in class akka.event.japi.SubchannelEventBus
-
The logic to form sub-class hierarchy
- subclassification() - Method in interface akka.event.SubchannelClassification
-
The logic to form sub-class hierarchy
- Subclassification<K> - Interface in akka.util
-
Typeclass which describes a classification hierarchy.
- SubclassifiedIndex<K,V> - Class in akka.util
-
Mutable index which respects sub-class relationships between keys:
- SubclassifiedIndex(Subclassification<K>) - Constructor for class akka.util.SubclassifiedIndex
-
- SubclassifiedIndex$ - Class in akka.util
-
- SubclassifiedIndex$() - Constructor for class akka.util.SubclassifiedIndex$
-
- SubclassifiedIndex.Nonroot<K,V> - Class in akka.util
-
- subkeys() - Method in class akka.util.SubclassifiedIndex
-
- submit(Callable<T>) - Method in interface akka.dispatch.ExecutorServiceDelegate
-
- submit(Runnable, T) - Method in interface akka.dispatch.ExecutorServiceDelegate
-
- submit(Runnable) - Method in interface akka.dispatch.ExecutorServiceDelegate
-
- subscribe(ActorRef, ActorRef) - Method in interface akka.event.ActorClassification
-
- subscribe(ActorRef) - Method in class akka.event.AddressTerminatedTopic
-
- subscribe(EventBus, EventBus) - Method in interface akka.event.EventBus
-
- subscribe(ActorRef, Class<?>) - Method in class akka.event.EventStream
-
- subscribe(ActorRef, ActorRef) - Method in class akka.event.japi.ActorEventBus
-
- subscribe(S, C) - Method in interface akka.event.japi.EventBus
-
Attempts to register the subscriber to the specified Classifier
- subscribe(S, C) - Method in class akka.event.japi.LookupEventBus
-
- subscribe(ActorRef, ActorRef) - Method in class akka.event.japi.ManagedActorEventBus
-
- subscribe(S, C) - Method in class akka.event.japi.ScanningEventBus
-
- subscribe(S, C) - Method in class akka.event.japi.SubchannelEventBus
-
- subscribe(LookupClassification, LookupClassification) - Method in interface akka.event.LookupClassification
-
- subscribe(ActorRef, ActorRef) - Method in interface akka.event.ManagedActorClassification
-
- subscribe(ScanningClassification, ScanningClassification) - Method in interface akka.event.ScanningClassification
-
- subscribe(SubchannelClassification, SubchannelClassification) - Method in interface akka.event.SubchannelClassification
-
- subscribeAddressTerminated() - Method in interface akka.actor.dungeon.DeathWatch
-
- subscribers() - Method in interface akka.event.LookupClassification
-
- subscribers() - Method in interface akka.event.ScanningClassification
-
- SubscribeTransitionCallBack(ActorRef) - Constructor for class akka.actor.FSM.SubscribeTransitionCallBack
-
- SubscribeTransitionCallBack$() - Constructor for class akka.actor.FSM.SubscribeTransitionCallBack$
-
- subscriptions() - Method in interface akka.event.SubchannelClassification
-
- Success(Object) - Constructor for class akka.actor.Status.Success
-
- Success$() - Constructor for class akka.actor.Status.Success$
-
- successful(T) - Method in class akka.dispatch.Futures$
-
Creates an already completed Promise with the specified result
- successful(T) - Static method in class akka.dispatch.Futures
-
Creates an already completed Promise with the specified result
- Supervise - Class in akka.dispatch.sysmsg
-
INTERNAL API
- Supervise(ActorRef, boolean) - Constructor for class akka.dispatch.sysmsg.Supervise
-
- Supervise$ - Class in akka.dispatch.sysmsg
-
- Supervise$() - Constructor for class akka.dispatch.sysmsg.Supervise$
-
- superviseWith(SupervisorStrategy) - Method in interface akka.actor.dsl.Creators.Act
-
Set the supervisor strategy of this actor, i.e.
- supervisor() - Method in class akka.actor.RepointableActorRef
-
- supervisor() - Method in class akka.actor.UnstartedCell
-
- supervisorStrategy() - Method in interface akka.actor.Actor
-
User overridable definition the strategy to use for supervising
child actors.
- supervisorStrategy() - Method in interface akka.actor.dsl.Creators.Act
-
- SupervisorStrategy - Class in akka.actor
-
An Akka SupervisorStrategy is the policy to apply for crashing children.
- SupervisorStrategy() - Constructor for class akka.actor.SupervisorStrategy
-
- supervisorStrategy() - Method in interface akka.actor.TypedActor.Supervisor
-
User overridable definition the strategy to use for supervising
child actors.
- supervisorStrategy() - Method in class akka.actor.TypedActor.TypedActor
-
- supervisorStrategy() - Method in class akka.actor.UntypedActor
-
User overridable definition the strategy to use for supervising
child actors.
- supervisorStrategy() - Method in class akka.io.SelectionHandler.SelectorBasedManager
-
- supervisorStrategy() - Method in class akka.io.SelectionHandler
-
- supervisorStrategy() - Method in class akka.io.TcpListener
-
- supervisorStrategy() - Method in class akka.routing.BalancingPool
-
- supervisorStrategy() - Method in class akka.routing.BroadcastPool
-
- supervisorStrategy() - Method in class akka.routing.ConsistentHashingPool
-
- supervisorStrategy() - Method in class akka.routing.FromConfig
-
- supervisorStrategy() - Method in interface akka.routing.Pool
-
SupervisorStrategy for the head actor, i.e.
- supervisorStrategy() - Method in class akka.routing.RandomPool
-
- supervisorStrategy() - Method in class akka.routing.RoundRobinPool
-
- supervisorStrategy() - Method in class akka.routing.RouterPoolActor
-
- supervisorStrategy() - Method in class akka.routing.ScatterGatherFirstCompletedPool
-
- supervisorStrategy() - Method in class akka.routing.SmallestMailboxPool
-
- supervisorStrategy() - Method in class akka.routing.TailChoppingPool
-
- SupervisorStrategy$ - Class in akka.actor
-
- SupervisorStrategy$() - Constructor for class akka.actor.SupervisorStrategy$
-
- SupervisorStrategy.Directive - Interface in akka.actor
-
- SupervisorStrategy.Escalate$ - Class in akka.actor
-
Escalates the failure to the supervisor of the supervisor,
by rethrowing the cause of the failure, i.e.
- SupervisorStrategy.Restart$ - Class in akka.actor
-
Discards the old Actor instance and replaces it with a new,
then resumes message processing.
- SupervisorStrategy.Resume$ - Class in akka.actor
-
Resumes message processing for the failed Actor
- SupervisorStrategy.Stop$ - Class in akka.actor
-
Stops the Actor
- SupervisorStrategyClass() - Method in class akka.actor.ActorSystem.Settings
-
- SupervisorStrategyConfigurator - Interface in akka.actor
-
Implement this interface in order to configure the supervisorStrategy for
the top-level guardian actor (/user
).
- SupervisorStrategyLowPriorityImplicits - Interface in akka.actor
-
- SuppressedDeadLetter - Class in akka.actor
-
Similar to
DeadLetter
with the slight twist of NOT being logged by the default dead letters listener.
- SuppressedDeadLetter(DeadLetterSuppression, ActorRef, ActorRef) - Constructor for class akka.actor.SuppressedDeadLetter
-
- SuppressedDeadLetter$ - Class in akka.actor
-
- SuppressedDeadLetter$() - Constructor for class akka.actor.SuppressedDeadLetter$
-
- suspend() - Method in interface akka.actor.Cell
-
Recursively suspend this actor and all its children.
- suspend() - Method in interface akka.actor.dungeon.Dispatch
-
- suspend() - Method in class akka.actor.InternalActorRef
-
- suspend() - Method in class akka.actor.LocalActorRef
-
Suspends the actor so that it will not process messages until resumed.
- suspend() - Method in interface akka.actor.MinimalActorRef
-
- suspend() - Method in class akka.actor.RepointableActorRef
-
- suspend() - Method in class akka.actor.UnstartedCell
-
- suspend() - Method in class akka.dispatch.Mailbox
-
Increment the suspend count by one.
- suspend(ActorCell) - Method in class akka.dispatch.MessageDispatcher
-
After the call to this method, the dispatcher mustn't begin any new message processing for the specified reference
- Suspend - Class in akka.dispatch.sysmsg
-
INTERNAL API
- Suspend() - Constructor for class akka.dispatch.sysmsg.Suspend
-
- suspend() - Method in class akka.util.SerializedSuspendableExecutionContext
-
Suspends execution of tasks until resume
is called,
this operation is idempotent.
- Suspend$ - Class in akka.dispatch.sysmsg
-
- Suspend$() - Constructor for class akka.dispatch.sysmsg.Suspend$
-
- suspendChildren(Set<ActorRef>) - Method in interface akka.actor.dungeon.Children
-
- suspendCount() - Method in class akka.dispatch.Mailbox
-
- Suspended() - Method in class akka.util.SerializedSuspendableExecutionContext$
-
- Suspended() - Static method in class akka.util.SerializedSuspendableExecutionContext
-
- SuspendedState() - Method in class akka.actor.ActorCell$
-
- SuspendedState() - Static method in class akka.actor.ActorCell
-
- SuspendedWaitForChildrenState() - Method in class akka.actor.ActorCell$
-
- SuspendedWaitForChildrenState() - Static method in class akka.actor.ActorCell
-
- suspendMask() - Method in class akka.dispatch.Mailbox$
-
- suspendMask() - Static method in class akka.dispatch.Mailbox
-
- suspendNonRecursive() - Method in interface akka.actor.dungeon.FaultHandling
-
- suspendReading(TcpConnection.ConnectionInfo) - Method in class akka.io.TcpConnection
-
- suspendReading() - Method in class akka.io.TcpMessage$
-
Sending this command to the connection actor will disable reading from the TCP
socket.
- suspendReading() - Static method in class akka.io.TcpMessage
-
Sending this command to the connection actor will disable reading from the TCP
socket.
- suspendReading() - Method in class akka.io.UdpConnectedMessage$
-
Send this message to a listener actor (which sent a
Udp.Bound
message) to
have it stop reading datagrams from the network.
- suspendReading() - Static method in class akka.io.UdpConnectedMessage
-
Send this message to a listener actor (which sent a
Udp.Bound
message) to
have it stop reading datagrams from the network.
- suspendReading() - Method in class akka.io.UdpMessage$
-
Send this message to a listener actor (which sent a
Udp.Bound
message) to
have it stop reading datagrams from the network.
- suspendReading() - Static method in class akka.io.UdpMessage
-
Send this message to a listener actor (which sent a
Udp.Bound
message) to
have it stop reading datagrams from the network.
- SuspendReading$() - Constructor for class akka.io.Tcp.SuspendReading$
-
- SuspendReading$() - Constructor for class akka.io.Udp.SuspendReading$
-
- SuspendReading$() - Constructor for class akka.io.UdpConnected.SuspendReading$
-
- suspendUnit() - Method in class akka.dispatch.Mailbox$
-
- suspendUnit() - Static method in class akka.dispatch.Mailbox
-
- swapCell(Cell) - Method in class akka.actor.RepointableActorRef
-
- swapChildrenRefs(ChildrenContainer, ChildrenContainer) - Method in interface akka.actor.dungeon.Children
-
- swapLookup(Cell) - Method in class akka.actor.RepointableActorRef
-
- swapMailbox(Mailbox) - Method in interface akka.actor.dungeon.Dispatch
-
- Switch - Class in akka.util
-
An atomic switch that can be either on or off
- Switch(boolean) - Constructor for class akka.util.Switch
-
- Switch$ - Class in akka.util
-
- Switch$() - Constructor for class akka.util.Switch$
-
- switchOff(Function0<BoxedUnit>) - Method in class akka.util.Switch
-
Executes the provided action if the lock is on under a lock, so be _very_ careful with longrunning/blocking operations in it
Only executes the action if the switch is on, and switches it off immediately after obtaining the lock
Will switch it back on if the provided action throws an exception
- switchOff() - Method in class akka.util.Switch
-
Switches the switch off (if on), uses locking
- switchOn(Function0<BoxedUnit>) - Method in class akka.util.Switch
-
Executes the provided action if the lock is off under a lock, so be _very_ careful with longrunning/blocking operations in it
Only executes the action if the switch is off, and switches it on immediately after obtaining the lock
Will switch it back off if the provided action throws an exception
- switchOn() - Method in class akka.util.Switch
-
Switches the switch on (if off), uses locking
- symmetricHash(TraversableOnce<T>, int) - Method in class akka.routing.MurmurHash$
-
Compute a hash that is symmetric in its arguments--that is,
where the order of appearance of elements does not matter.
- symmetricHash(TraversableOnce<T>, int) - Static method in class akka.routing.MurmurHash
-
Compute a hash that is symmetric in its arguments--that is,
where the order of appearance of elements does not matter.
- synchronousQueue(boolean) - Method in class akka.dispatch.ThreadPoolConfig$
-
- synchronousQueue(boolean) - Static method in class akka.dispatch.ThreadPoolConfig
-
- system() - Method in class akka.actor.ActorCell
-
- system() - Method in interface akka.actor.ActorContext
-
The system that the actor belongs to.
- system() - Method in class akka.actor.ActorDSL.Extension
-
- system() - Method in class akka.actor.Address
-
- system() - Method in interface akka.actor.Cell
-
The system within which this Cell lives.
- system() - Method in class akka.actor.RepointableActorRef
-
- system() - Method in class akka.actor.TypedActorExtension
-
- system() - Method in class akka.actor.UnstartedCell
-
- system() - Method in interface akka.event.ManagedActorClassification
-
- system() - Method in class akka.routing.ConsistentHashingRoutingLogic
-
- system() - Method in interface akka.serialization.BaseSerializer
-
Actor system which is required by most serializer implementations.
- system() - Method in class akka.serialization.ByteArraySerializer
-
- system() - Method in class akka.serialization.JavaSerializer
-
- system() - Method in class akka.serialization.Serialization.Information
-
- system() - Method in class akka.serialization.Serialization
-
- systemActorOf(Props, String) - Method in class akka.actor.ActorSystemImpl
-
- systemActorOf(Props, String) - Method in class akka.actor.ExtendedActorSystem
-
Create an actor in the "/system" namespace.
- systemDispatch(ActorCell, SystemMessage) - Method in class akka.dispatch.Dispatcher
-
INTERNAL API
- systemDispatch(ActorCell, SystemMessage) - Method in class akka.dispatch.MessageDispatcher
-
Will be called when the dispatcher is to queue an invocation for execution
- systemDrain(LatestFirstSystemMessageList) - Method in interface akka.dispatch.DefaultSystemMessageQueue
-
- systemDrain(LatestFirstSystemMessageList) - Method in interface akka.dispatch.SystemMessageQueue
-
Dequeue all messages from system queue and return them as single-linked list.
- systemEnqueue(ActorRef, SystemMessage) - Method in interface akka.dispatch.DefaultSystemMessageQueue
-
- systemEnqueue(ActorRef, SystemMessage) - Method in interface akka.dispatch.SystemMessageQueue
-
Enqueue a new system message, e.g.
- systemGuardian() - Method in interface akka.actor.ActorRefProvider
-
Reference to the supervisor used for all top-level system actors.
- systemGuardian() - Method in class akka.actor.ActorSystemImpl
-
- systemGuardian() - Method in class akka.actor.ExtendedActorSystem
-
The top-level supervisor of all system-internal services like logging.
- systemGuardian() - Method in class akka.actor.LocalActorRefProvider
-
- SystemGuardian - Class in akka.actor
-
INTERNAL API
- SystemGuardian() - Constructor for class akka.actor.SystemGuardian
-
- SystemGuardian$ - Class in akka.actor
-
INTERNAL API
- SystemGuardian$() - Constructor for class akka.actor.SystemGuardian$
-
- SystemGuardian.RegisterTerminationHook$ - Class in akka.actor
-
For the purpose of orderly shutdown it's possible
to register interest in the termination of systemGuardian
and receive a notification TerminationHook
before systemGuardian is stopped.
- SystemGuardian.TerminationHook$ - Class in akka.actor
-
- SystemGuardian.TerminationHookDone$ - Class in akka.actor
-
- systemGuardianStrategy() - Method in class akka.actor.LocalActorRefProvider
-
Overridable supervision strategy to be used by the “/user” guardian.
- SystemHome() - Method in class akka.actor.ActorSystem$
-
- SystemHome() - Static method in class akka.actor.ActorSystem
-
- systemImpl() - Method in class akka.actor.ActorCell
-
- systemImpl() - Method in interface akka.actor.ActorRefFactory
-
INTERNAL API
- systemImpl() - Method in class akka.actor.ActorSystemImpl
-
- systemImpl() - Method in interface akka.actor.Cell
-
The system internals where this Cell lives.
- systemImpl() - Method in class akka.actor.UnstartedCell
-
- systemInvoke(akka.dispatch.sysmsg.SystemMessage) - Method in class akka.actor.ActorCell
-
- SystemMessage - Interface in akka.dispatch.sysmsg
-
System messages are handled specially: they form their own queue within
each actor’s mailbox.
- SystemMessageList - Class in akka.dispatch.sysmsg
-
INTERNAL API
- SystemMessageList() - Constructor for class akka.dispatch.sysmsg.SystemMessageList
-
- SystemMessageList$ - Class in akka.dispatch.sysmsg
-
INTERNAL API
- SystemMessageList$() - Constructor for class akka.dispatch.sysmsg.SystemMessageList$
-
- SystemMessageQueue - Interface in akka.dispatch
-
INTERNAL API
- systemQueueGet() - Method in class akka.dispatch.Mailbox
-
- systemQueuePut(LatestFirstSystemMessageList, LatestFirstSystemMessageList) - Method in class akka.dispatch.Mailbox
-
- t1() - Method in class akka.japi.tuple.Tuple10
-
- t1() - Method in class akka.japi.tuple.Tuple11
-
- t1() - Method in class akka.japi.tuple.Tuple12
-
- t1() - Method in class akka.japi.tuple.Tuple13
-
- t1() - Method in class akka.japi.tuple.Tuple14
-
- t1() - Method in class akka.japi.tuple.Tuple15
-
- t1() - Method in class akka.japi.tuple.Tuple16
-
- t1() - Method in class akka.japi.tuple.Tuple17
-
- t1() - Method in class akka.japi.tuple.Tuple18
-
- t1() - Method in class akka.japi.tuple.Tuple19
-
- t1() - Method in class akka.japi.tuple.Tuple20
-
- t1() - Method in class akka.japi.tuple.Tuple21
-
- t1() - Method in class akka.japi.tuple.Tuple22
-
- t1() - Method in class akka.japi.tuple.Tuple3
-
- t1() - Method in class akka.japi.tuple.Tuple4
-
- t1() - Method in class akka.japi.tuple.Tuple5
-
- t1() - Method in class akka.japi.tuple.Tuple6
-
- t1() - Method in class akka.japi.tuple.Tuple7
-
- t1() - Method in class akka.japi.tuple.Tuple8
-
- t1() - Method in class akka.japi.tuple.Tuple9
-
- t10() - Method in class akka.japi.tuple.Tuple10
-
- t10() - Method in class akka.japi.tuple.Tuple11
-
- t10() - Method in class akka.japi.tuple.Tuple12
-
- t10() - Method in class akka.japi.tuple.Tuple13
-
- t10() - Method in class akka.japi.tuple.Tuple14
-
- t10() - Method in class akka.japi.tuple.Tuple15
-
- t10() - Method in class akka.japi.tuple.Tuple16
-
- t10() - Method in class akka.japi.tuple.Tuple17
-
- t10() - Method in class akka.japi.tuple.Tuple18
-
- t10() - Method in class akka.japi.tuple.Tuple19
-
- t10() - Method in class akka.japi.tuple.Tuple20
-
- t10() - Method in class akka.japi.tuple.Tuple21
-
- t10() - Method in class akka.japi.tuple.Tuple22
-
- t11() - Method in class akka.japi.tuple.Tuple11
-
- t11() - Method in class akka.japi.tuple.Tuple12
-
- t11() - Method in class akka.japi.tuple.Tuple13
-
- t11() - Method in class akka.japi.tuple.Tuple14
-
- t11() - Method in class akka.japi.tuple.Tuple15
-
- t11() - Method in class akka.japi.tuple.Tuple16
-
- t11() - Method in class akka.japi.tuple.Tuple17
-
- t11() - Method in class akka.japi.tuple.Tuple18
-
- t11() - Method in class akka.japi.tuple.Tuple19
-
- t11() - Method in class akka.japi.tuple.Tuple20
-
- t11() - Method in class akka.japi.tuple.Tuple21
-
- t11() - Method in class akka.japi.tuple.Tuple22
-
- t12() - Method in class akka.japi.tuple.Tuple12
-
- t12() - Method in class akka.japi.tuple.Tuple13
-
- t12() - Method in class akka.japi.tuple.Tuple14
-
- t12() - Method in class akka.japi.tuple.Tuple15
-
- t12() - Method in class akka.japi.tuple.Tuple16
-
- t12() - Method in class akka.japi.tuple.Tuple17
-
- t12() - Method in class akka.japi.tuple.Tuple18
-
- t12() - Method in class akka.japi.tuple.Tuple19
-
- t12() - Method in class akka.japi.tuple.Tuple20
-
- t12() - Method in class akka.japi.tuple.Tuple21
-
- t12() - Method in class akka.japi.tuple.Tuple22
-
- t13() - Method in class akka.japi.tuple.Tuple13
-
- t13() - Method in class akka.japi.tuple.Tuple14
-
- t13() - Method in class akka.japi.tuple.Tuple15
-
- t13() - Method in class akka.japi.tuple.Tuple16
-
- t13() - Method in class akka.japi.tuple.Tuple17
-
- t13() - Method in class akka.japi.tuple.Tuple18
-
- t13() - Method in class akka.japi.tuple.Tuple19
-
- t13() - Method in class akka.japi.tuple.Tuple20
-
- t13() - Method in class akka.japi.tuple.Tuple21
-
- t13() - Method in class akka.japi.tuple.Tuple22
-
- t14() - Method in class akka.japi.tuple.Tuple14
-
- t14() - Method in class akka.japi.tuple.Tuple15
-
- t14() - Method in class akka.japi.tuple.Tuple16
-
- t14() - Method in class akka.japi.tuple.Tuple17
-
- t14() - Method in class akka.japi.tuple.Tuple18
-
- t14() - Method in class akka.japi.tuple.Tuple19
-
- t14() - Method in class akka.japi.tuple.Tuple20
-
- t14() - Method in class akka.japi.tuple.Tuple21
-
- t14() - Method in class akka.japi.tuple.Tuple22
-
- t15() - Method in class akka.japi.tuple.Tuple15
-
- t15() - Method in class akka.japi.tuple.Tuple16
-
- t15() - Method in class akka.japi.tuple.Tuple17
-
- t15() - Method in class akka.japi.tuple.Tuple18
-
- t15() - Method in class akka.japi.tuple.Tuple19
-
- t15() - Method in class akka.japi.tuple.Tuple20
-
- t15() - Method in class akka.japi.tuple.Tuple21
-
- t15() - Method in class akka.japi.tuple.Tuple22
-
- t16() - Method in class akka.japi.tuple.Tuple16
-
- t16() - Method in class akka.japi.tuple.Tuple17
-
- t16() - Method in class akka.japi.tuple.Tuple18
-
- t16() - Method in class akka.japi.tuple.Tuple19
-
- t16() - Method in class akka.japi.tuple.Tuple20
-
- t16() - Method in class akka.japi.tuple.Tuple21
-
- t16() - Method in class akka.japi.tuple.Tuple22
-
- t17() - Method in class akka.japi.tuple.Tuple17
-
- t17() - Method in class akka.japi.tuple.Tuple18
-
- t17() - Method in class akka.japi.tuple.Tuple19
-
- t17() - Method in class akka.japi.tuple.Tuple20
-
- t17() - Method in class akka.japi.tuple.Tuple21
-
- t17() - Method in class akka.japi.tuple.Tuple22
-
- t18() - Method in class akka.japi.tuple.Tuple18
-
- t18() - Method in class akka.japi.tuple.Tuple19
-
- t18() - Method in class akka.japi.tuple.Tuple20
-
- t18() - Method in class akka.japi.tuple.Tuple21
-
- t18() - Method in class akka.japi.tuple.Tuple22
-
- t19() - Method in class akka.japi.tuple.Tuple19
-
- t19() - Method in class akka.japi.tuple.Tuple20
-
- t19() - Method in class akka.japi.tuple.Tuple21
-
- t19() - Method in class akka.japi.tuple.Tuple22
-
- t2() - Method in class akka.japi.tuple.Tuple10
-
- t2() - Method in class akka.japi.tuple.Tuple11
-
- t2() - Method in class akka.japi.tuple.Tuple12
-
- t2() - Method in class akka.japi.tuple.Tuple13
-
- t2() - Method in class akka.japi.tuple.Tuple14
-
- t2() - Method in class akka.japi.tuple.Tuple15
-
- t2() - Method in class akka.japi.tuple.Tuple16
-
- t2() - Method in class akka.japi.tuple.Tuple17
-
- t2() - Method in class akka.japi.tuple.Tuple18
-
- t2() - Method in class akka.japi.tuple.Tuple19
-
- t2() - Method in class akka.japi.tuple.Tuple20
-
- t2() - Method in class akka.japi.tuple.Tuple21
-
- t2() - Method in class akka.japi.tuple.Tuple22
-
- t2() - Method in class akka.japi.tuple.Tuple3
-
- t2() - Method in class akka.japi.tuple.Tuple4
-
- t2() - Method in class akka.japi.tuple.Tuple5
-
- t2() - Method in class akka.japi.tuple.Tuple6
-
- t2() - Method in class akka.japi.tuple.Tuple7
-
- t2() - Method in class akka.japi.tuple.Tuple8
-
- t2() - Method in class akka.japi.tuple.Tuple9
-
- t20() - Method in class akka.japi.tuple.Tuple20
-
- t20() - Method in class akka.japi.tuple.Tuple21
-
- t20() - Method in class akka.japi.tuple.Tuple22
-
- t21() - Method in class akka.japi.tuple.Tuple21
-
- t21() - Method in class akka.japi.tuple.Tuple22
-
- t22() - Method in class akka.japi.tuple.Tuple22
-
- t3() - Method in class akka.japi.tuple.Tuple10
-
- t3() - Method in class akka.japi.tuple.Tuple11
-
- t3() - Method in class akka.japi.tuple.Tuple12
-
- t3() - Method in class akka.japi.tuple.Tuple13
-
- t3() - Method in class akka.japi.tuple.Tuple14
-
- t3() - Method in class akka.japi.tuple.Tuple15
-
- t3() - Method in class akka.japi.tuple.Tuple16
-
- t3() - Method in class akka.japi.tuple.Tuple17
-
- t3() - Method in class akka.japi.tuple.Tuple18
-
- t3() - Method in class akka.japi.tuple.Tuple19
-
- t3() - Method in class akka.japi.tuple.Tuple20
-
- t3() - Method in class akka.japi.tuple.Tuple21
-
- t3() - Method in class akka.japi.tuple.Tuple22
-
- t3() - Method in class akka.japi.tuple.Tuple3
-
- t3() - Method in class akka.japi.tuple.Tuple4
-
- t3() - Method in class akka.japi.tuple.Tuple5
-
- t3() - Method in class akka.japi.tuple.Tuple6
-
- t3() - Method in class akka.japi.tuple.Tuple7
-
- t3() - Method in class akka.japi.tuple.Tuple8
-
- t3() - Method in class akka.japi.tuple.Tuple9
-
- t4() - Method in class akka.japi.tuple.Tuple10
-
- t4() - Method in class akka.japi.tuple.Tuple11
-
- t4() - Method in class akka.japi.tuple.Tuple12
-
- t4() - Method in class akka.japi.tuple.Tuple13
-
- t4() - Method in class akka.japi.tuple.Tuple14
-
- t4() - Method in class akka.japi.tuple.Tuple15
-
- t4() - Method in class akka.japi.tuple.Tuple16
-
- t4() - Method in class akka.japi.tuple.Tuple17
-
- t4() - Method in class akka.japi.tuple.Tuple18
-
- t4() - Method in class akka.japi.tuple.Tuple19
-
- t4() - Method in class akka.japi.tuple.Tuple20
-
- t4() - Method in class akka.japi.tuple.Tuple21
-
- t4() - Method in class akka.japi.tuple.Tuple22
-
- t4() - Method in class akka.japi.tuple.Tuple4
-
- t4() - Method in class akka.japi.tuple.Tuple5
-
- t4() - Method in class akka.japi.tuple.Tuple6
-
- t4() - Method in class akka.japi.tuple.Tuple7
-
- t4() - Method in class akka.japi.tuple.Tuple8
-
- t4() - Method in class akka.japi.tuple.Tuple9
-
- t5() - Method in class akka.japi.tuple.Tuple10
-
- t5() - Method in class akka.japi.tuple.Tuple11
-
- t5() - Method in class akka.japi.tuple.Tuple12
-
- t5() - Method in class akka.japi.tuple.Tuple13
-
- t5() - Method in class akka.japi.tuple.Tuple14
-
- t5() - Method in class akka.japi.tuple.Tuple15
-
- t5() - Method in class akka.japi.tuple.Tuple16
-
- t5() - Method in class akka.japi.tuple.Tuple17
-
- t5() - Method in class akka.japi.tuple.Tuple18
-
- t5() - Method in class akka.japi.tuple.Tuple19
-
- t5() - Method in class akka.japi.tuple.Tuple20
-
- t5() - Method in class akka.japi.tuple.Tuple21
-
- t5() - Method in class akka.japi.tuple.Tuple22
-
- t5() - Method in class akka.japi.tuple.Tuple5
-
- t5() - Method in class akka.japi.tuple.Tuple6
-
- t5() - Method in class akka.japi.tuple.Tuple7
-
- t5() - Method in class akka.japi.tuple.Tuple8
-
- t5() - Method in class akka.japi.tuple.Tuple9
-
- t6() - Method in class akka.japi.tuple.Tuple10
-
- t6() - Method in class akka.japi.tuple.Tuple11
-
- t6() - Method in class akka.japi.tuple.Tuple12
-
- t6() - Method in class akka.japi.tuple.Tuple13
-
- t6() - Method in class akka.japi.tuple.Tuple14
-
- t6() - Method in class akka.japi.tuple.Tuple15
-
- t6() - Method in class akka.japi.tuple.Tuple16
-
- t6() - Method in class akka.japi.tuple.Tuple17
-
- t6() - Method in class akka.japi.tuple.Tuple18
-
- t6() - Method in class akka.japi.tuple.Tuple19
-
- t6() - Method in class akka.japi.tuple.Tuple20
-
- t6() - Method in class akka.japi.tuple.Tuple21
-
- t6() - Method in class akka.japi.tuple.Tuple22
-
- t6() - Method in class akka.japi.tuple.Tuple6
-
- t6() - Method in class akka.japi.tuple.Tuple7
-
- t6() - Method in class akka.japi.tuple.Tuple8
-
- t6() - Method in class akka.japi.tuple.Tuple9
-
- t7() - Method in class akka.japi.tuple.Tuple10
-
- t7() - Method in class akka.japi.tuple.Tuple11
-
- t7() - Method in class akka.japi.tuple.Tuple12
-
- t7() - Method in class akka.japi.tuple.Tuple13
-
- t7() - Method in class akka.japi.tuple.Tuple14
-
- t7() - Method in class akka.japi.tuple.Tuple15
-
- t7() - Method in class akka.japi.tuple.Tuple16
-
- t7() - Method in class akka.japi.tuple.Tuple17
-
- t7() - Method in class akka.japi.tuple.Tuple18
-
- t7() - Method in class akka.japi.tuple.Tuple19
-
- t7() - Method in class akka.japi.tuple.Tuple20
-
- t7() - Method in class akka.japi.tuple.Tuple21
-
- t7() - Method in class akka.japi.tuple.Tuple22
-
- t7() - Method in class akka.japi.tuple.Tuple7
-
- t7() - Method in class akka.japi.tuple.Tuple8
-
- t7() - Method in class akka.japi.tuple.Tuple9
-
- t8() - Method in class akka.japi.tuple.Tuple10
-
- t8() - Method in class akka.japi.tuple.Tuple11
-
- t8() - Method in class akka.japi.tuple.Tuple12
-
- t8() - Method in class akka.japi.tuple.Tuple13
-
- t8() - Method in class akka.japi.tuple.Tuple14
-
- t8() - Method in class akka.japi.tuple.Tuple15
-
- t8() - Method in class akka.japi.tuple.Tuple16
-
- t8() - Method in class akka.japi.tuple.Tuple17
-
- t8() - Method in class akka.japi.tuple.Tuple18
-
- t8() - Method in class akka.japi.tuple.Tuple19
-
- t8() - Method in class akka.japi.tuple.Tuple20
-
- t8() - Method in class akka.japi.tuple.Tuple21
-
- t8() - Method in class akka.japi.tuple.Tuple22
-
- t8() - Method in class akka.japi.tuple.Tuple8
-
- t8() - Method in class akka.japi.tuple.Tuple9
-
- t9() - Method in class akka.japi.tuple.Tuple10
-
- t9() - Method in class akka.japi.tuple.Tuple11
-
- t9() - Method in class akka.japi.tuple.Tuple12
-
- t9() - Method in class akka.japi.tuple.Tuple13
-
- t9() - Method in class akka.japi.tuple.Tuple14
-
- t9() - Method in class akka.japi.tuple.Tuple15
-
- t9() - Method in class akka.japi.tuple.Tuple16
-
- t9() - Method in class akka.japi.tuple.Tuple17
-
- t9() - Method in class akka.japi.tuple.Tuple18
-
- t9() - Method in class akka.japi.tuple.Tuple19
-
- t9() - Method in class akka.japi.tuple.Tuple20
-
- t9() - Method in class akka.japi.tuple.Tuple21
-
- t9() - Method in class akka.japi.tuple.Tuple22
-
- t9() - Method in class akka.japi.tuple.Tuple9
-
- tail() - Method in class akka.dispatch.sysmsg.EarliestFirstSystemMessageList
-
Gives back the list containing all the elements except the first.
- tail() - Method in class akka.dispatch.sysmsg.LatestFirstSystemMessageList
-
Gives back the list containing all the elements except the first.
- tail() - Method in class akka.util.ByteString
-
- TailChoppingGroup - Class in akka.routing
-
A router group with retry logic, intended for cases where a return message is expected in
response to a message sent to the routee.
- TailChoppingGroup(Iterable<String>, FiniteDuration, FiniteDuration, String) - Constructor for class akka.routing.TailChoppingGroup
-
- TailChoppingGroup(Config) - Constructor for class akka.routing.TailChoppingGroup
-
- TailChoppingGroup(Iterable<String>, FiniteDuration, FiniteDuration) - Constructor for class akka.routing.TailChoppingGroup
-
Java API
- TailChoppingGroup$ - Class in akka.routing
-
- TailChoppingGroup$() - Constructor for class akka.routing.TailChoppingGroup$
-
- TailChoppingPool - Class in akka.routing
-
A router pool with retry logic, intended for cases where a return message is expected in
response to a message sent to the routee.
- TailChoppingPool(int, Option<Resizer>, FiniteDuration, FiniteDuration, SupervisorStrategy, String, boolean) - Constructor for class akka.routing.TailChoppingPool
-
- TailChoppingPool(Config) - Constructor for class akka.routing.TailChoppingPool
-
- TailChoppingPool(int, FiniteDuration, FiniteDuration) - Constructor for class akka.routing.TailChoppingPool
-
Java API
- TailChoppingPool$ - Class in akka.routing
-
- TailChoppingPool$() - Constructor for class akka.routing.TailChoppingPool$
-
- TailChoppingRoutees - Class in akka.routing
-
INTERNAL API
- TailChoppingRoutees(Scheduler, IndexedSeq<Routee>, FiniteDuration, FiniteDuration, ExecutionContext) - Constructor for class akka.routing.TailChoppingRoutees
-
- TailChoppingRoutees$ - Class in akka.routing
-
- TailChoppingRoutees$() - Constructor for class akka.routing.TailChoppingRoutees$
-
- TailChoppingRoutingLogic - Class in akka.routing
-
As each message is sent to the router, the routees are randomly ordered.
- TailChoppingRoutingLogic(Scheduler, FiniteDuration, FiniteDuration, ExecutionContext) - Constructor for class akka.routing.TailChoppingRoutingLogic
-
- TailChoppingRoutingLogic$ - Class in akka.routing
-
- TailChoppingRoutingLogic$() - Constructor for class akka.routing.TailChoppingRoutingLogic$
-
- tailCommand() - Method in class akka.io.Tcp.CompoundWrite
-
- take() - Method in class akka.util.BoundedBlockingQueue
-
- take(int) - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- take(int) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- take(int) - Method in class akka.util.ByteIterator
-
- take(int) - Method in class akka.util.ByteString
-
- takeRight(int) - Method in class akka.util.ByteString
-
- takeWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- takeWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- takeWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator
-
- takeWhile(Function1<Object, Object>) - Method in class akka.util.ByteString
-
- target() - Method in class akka.actor.dsl.Inbox.StartWatch
-
- target() - Method in class akka.io.Udp.Send
-
- task() - Method in class akka.actor.LightArrayRevolverScheduler.TaskHolder
-
- TaskHolder(Runnable, int, ExecutionContext) - Constructor for class akka.actor.LightArrayRevolverScheduler.TaskHolder
-
- TaskInvocation - Class in akka.dispatch
-
- TaskInvocation(EventStream, Runnable, Function0<BoxedUnit>) - Constructor for class akka.dispatch.TaskInvocation
-
- TaskInvocation$ - Class in akka.dispatch
-
- TaskInvocation$() - Constructor for class akka.dispatch.TaskInvocation$
-
- tc() - Method in class akka.io.Inet.SO$.TrafficClass
-
- Tcp - Class in akka.io
-
TCP Extension for Akka’s IO layer.
- Tcp() - Constructor for class akka.io.Tcp
-
- tcp() - Method in class akka.io.TcpConnection
-
- Tcp$ - Class in akka.io
-
TCP Extension for Akka’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.Aborted$ - Class in akka.io
-
The connection has been aborted in response to an Abort
command.
- 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$ - Class in akka.io
-
- 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$ - Class in akka.io
-
- Tcp.Close$ - Class in akka.io
-
A normal close operation will first flush pending writes and then close the
socket.
- 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.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$ - Class in akka.io
-
- Tcp.CompoundWrite - Class in akka.io
-
A write command which aggregates two other write commands.
- Tcp.CompoundWrite$ - Class in akka.io
-
- 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.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.Connect - Class in akka.io
-
The Connect message is sent to the TCP manager actor, which is obtained via
TcpExt.manager()
.
- Tcp.Connect$ - Class in akka.io
-
- 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$ - Class in akka.io
-
- 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$ - Class in akka.io
-
- Tcp.Event - Interface in akka.io
-
Common interface for all events generated by the TCP layer actors.
- Tcp.Message - Interface in akka.io
-
- Tcp.NoAck - Class in akka.io
-
Each
Tcp.WriteCommand
can optionally request a positive acknowledgment to be sent
to the commanding actor.
- Tcp.NoAck$ - Class in akka.io
-
Default
Tcp.NoAck
instance which is used when no acknowledgment information is
explicitly provided.
- Tcp.PeerClosed$ - Class in akka.io
-
The peer has closed its writing half of the connection.
- 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$ - Class in akka.io
-
- Tcp.Register - Class in akka.io
-
This message must be sent to a TCP connection actor after receiving the
Tcp.Connected
message.
- Tcp.Register$ - Class in akka.io
-
- Tcp.ResumeAccepting - Class in akka.io
-
This message enables the accepting of the next connection if read throttling is enabled
for connection actors.
- Tcp.ResumeAccepting$ - Class in akka.io
-
- 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.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.SimpleWriteCommand - Class in akka.io
-
- Tcp.SO$ - Class in akka.io
-
Scala API: this object contains all applicable socket options for TCP.
- Tcp.SO$.KeepAlive - Class in akka.io
-
- 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$.TcpNoDelay - Class in akka.io
-
Inet.SocketOption
to enable or disable TCP_NODELAY
(disable or enable Nagle's algorithm)
- Tcp.SuspendReading$ - Class in akka.io
-
Sending this command to the connection actor will disable reading from the TCP
socket.
- 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.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.Write - Class in akka.io
-
Write data to the TCP connection.
- Tcp.Write$ - Class in akka.io
-
- Tcp.WriteCommand - Class in akka.io
-
Common interface for all write commands.
- Tcp.WriteCommand$ - Class in akka.io
-
- Tcp.WriteFile - Class in akka.io
-
Write count
bytes starting at position
from file at filePath
to the connection.
- Tcp.WriteFile$ - Class in akka.io
-
- 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
-
- TcpConnection - Class in akka.io
-
Base class for TcpIncomingConnection and TcpOutgoingConnection.
- TcpConnection(TcpExt, SocketChannel, boolean) - Constructor for class akka.io.TcpConnection
-
- TcpConnection$ - Class in akka.io
-
INTERNAL API
- TcpConnection$() - Constructor for class akka.io.TcpConnection$
-
- TcpConnection.AllRead$ - Class in akka.io
-
- TcpConnection.CloseInformation - Class in akka.io
-
Used to transport information to the postStop method to notify
interested party about a connection close.
- TcpConnection.CloseInformation$ - Class in akka.io
-
- TcpConnection.ConnectionInfo - Class in akka.io
-
Groups required connection-related data that are only available once the connection has been fully established.
- TcpConnection.ConnectionInfo$ - Class in akka.io
-
- TcpConnection.EmptyPendingWrite$ - Class in akka.io
-
- TcpConnection.EndOfStream$ - Class in akka.io
-
- TcpConnection.MoreDataWaiting$ - Class in akka.io
-
- TcpConnection.PendingBufferWrite - Class in akka.io
-
- TcpConnection.PendingWrite - Class in akka.io
-
- TcpConnection.PendingWriteFile - Class in akka.io
-
- TcpConnection.ReadResult - Interface in akka.io
-
- TcpConnection.UpdatePendingWriteAndThen - Class in akka.io
-
- TcpConnection.UpdatePendingWriteAndThen$ - Class in akka.io
-
- TcpConnection.WriteFileFailed - Class in akka.io
-
- TcpConnection.WriteFileFailed$ - Class in akka.io
-
- TcpExt - Class in akka.io
-
- TcpExt(ExtendedActorSystem) - Constructor for class akka.io.TcpExt
-
- TcpExt.Settings - Class in akka.io
-
- TcpIncomingConnection - Class in akka.io
-
An actor handling the connection state machine for an incoming, already connected
SocketChannel.
- TcpIncomingConnection(TcpExt, SocketChannel, ChannelRegistry, ActorRef, Traversable<Inet.SocketOption>, boolean) - Constructor for class akka.io.TcpIncomingConnection
-
- TcpListener - Class in akka.io
-
INTERNAL API
- TcpListener(ActorRef, TcpExt, ChannelRegistry, ActorRef, Tcp.Bind) - Constructor for class akka.io.TcpListener
-
- TcpListener$ - Class in akka.io
-
INTERNAL API
- TcpListener$() - Constructor for class akka.io.TcpListener$
-
- TcpListener.FailedRegisterIncoming - Class in akka.io
-
- TcpListener.FailedRegisterIncoming$ - Class in akka.io
-
- TcpListener.RegisterIncoming - Class in akka.io
-
- TcpListener.RegisterIncoming$ - Class in akka.io
-
- TcpManager - Class in akka.io
-
INTERNAL API
- TcpManager(TcpExt) - Constructor for class akka.io.TcpManager
-
- TcpMessage - Class in akka.io
-
- TcpMessage() - Constructor for class akka.io.TcpMessage
-
- TcpMessage$ - Class in akka.io
-
- TcpMessage$() - Constructor for class akka.io.TcpMessage$
-
- TcpNoDelay(boolean) - Constructor for class akka.io.Tcp.SO$.TcpNoDelay
-
- 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)
- TcpOutgoingConnection - Class in akka.io
-
An actor handling the connection state machine for an outgoing connection
to be established.
- TcpOutgoingConnection(TcpExt, ChannelRegistry, ActorRef, Tcp.Connect) - Constructor for class akka.io.TcpOutgoingConnection
-
- TcpSO - Class in akka.io
-
Java API for accessing socket options.
- TcpSO() - Constructor for class akka.io.TcpSO
-
- TcpSO$ - Class in akka.io
-
Java API for accessing socket options.
- TcpSO$() - Constructor for class akka.io.TcpSO$
-
- team() - Method in class akka.dispatch.BalancingDispatcher
-
INTERNAL API
- teamWork() - Method in class akka.dispatch.BalancingDispatcher
-
- tell(Object, ActorRef) - Method in class akka.actor.ActorRef
-
Sends the specified message to this ActorRef, i.e.
- tell(Object, ActorRef) - Method in class akka.actor.ActorSelection
-
Sends the specified message to this ActorSelection, i.e.
- tellWatchersWeDied() - Method in interface akka.actor.dungeon.DeathWatch
-
- tempContainer() - Method in interface akka.actor.ActorRefProvider
-
Returns the actor reference representing the “/temp” path.
- tempContainer() - Method in class akka.actor.LocalActorRefProvider
-
- tempPath() - Method in interface akka.actor.ActorRefProvider
-
Generates and returns a unique actor path below “/temp”.
- tempPath() - Method in class akka.actor.LocalActorRefProvider
-
- terminate() - Method in class akka.actor.ActorSystem
-
Terminates this actor system.
- terminate() - Method in class akka.actor.ActorSystemImpl
-
- terminate() - Method in interface akka.actor.dungeon.FaultHandling
-
- terminate(FSM.State<S, D>) - Method in interface akka.actor.FSM
-
- Terminate - Class in akka.dispatch.sysmsg
-
INTERNAL API
- Terminate() - Constructor for class akka.dispatch.sysmsg.Terminate
-
- Terminate$ - Class in akka.dispatch.sysmsg
-
- Terminate$() - Constructor for class akka.dispatch.sysmsg.Terminate$
-
- Terminated - Class in akka.actor
-
When Death Watch is used, the watcher will receive a Terminated(watched)
message when watched is terminated.
- Terminated(ActorRef, boolean, boolean) - Constructor for class akka.actor.Terminated
-
- Terminated$ - Class in akka.actor
-
- Terminated$() - Constructor for class akka.actor.Terminated$
-
- TerminatedChildrenContainer$() - Constructor for class akka.actor.dungeon.ChildrenContainer.TerminatedChildrenContainer$
-
- terminatedProps() - Method in class akka.actor.ActorCell$
-
- terminatedProps() - Static method in class akka.actor.ActorCell
-
- terminatedQueued() - Method in interface akka.actor.dungeon.DeathWatch
-
- terminatedQueuedFor(ActorRef) - Method in interface akka.actor.dungeon.DeathWatch
-
- terminateEvent() - Method in interface akka.actor.FSM
-
- TerminatingChildrenContainer(TreeMap<String, ChildStats>, Set<ActorRef>, ChildrenContainer.SuspendReason) - Constructor for class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
-
- TerminatingChildrenContainer$() - Constructor for class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer$
-
- Termination$() - Constructor for class akka.actor.dungeon.ChildrenContainer.Termination$
-
- TerminationCallbacks(Future<T>, ExecutionContext) - Constructor for class akka.actor.ActorSystemImpl.TerminationCallbacks
-
- terminationFuture() - Method in interface akka.actor.ActorRefProvider
-
This Future is completed upon termination of this ActorRefProvider, which
is usually initiated by stopping the guardian via ActorSystem.stop().
- terminationFuture() - Method in class akka.actor.ActorSystemImpl.TerminationCallbacks
-
Returns a Future which will be completed once all registered callbacks have been executed.
- terminationFuture() - Method in class akka.actor.LocalActorRefProvider
-
- TerminationHook$() - Constructor for class akka.actor.SystemGuardian.TerminationHook$
-
- TerminationHookDone$() - Constructor for class akka.actor.SystemGuardian.TerminationHookDone$
-
- Terminator(ActorRef) - Constructor for class akka.Main.Terminator
-
- test(T) - Method in interface akka.japi.function.Predicate
-
- test(T) - Method in interface akka.japi.Predicate
-
- theOneWhoWalksTheBubblesOfSpaceTime() - Method in class akka.actor.LocalActorRefProvider
-
Top-level anchor for the supervision hierarchy of this actor system.
- theStash() - Method in interface akka.actor.StashSupport
-
- thread() - Method in interface akka.event.Logging.LogEvent
-
The thread that created this log event
- threadFactory() - Method in class akka.actor.ActorSystemImpl
-
- threadFactory() - Method in class akka.actor.ExtendedActorSystem
-
A ThreadFactory that can be used if the transport needs to create any Threads
- threadFactory() - Method in class akka.dispatch.DefaultDispatcherPrerequisites
-
- threadFactory() - Method in interface akka.dispatch.DispatcherPrerequisites
-
- threadFactory() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory
-
- threadFactory() - Method in class akka.dispatch.ThreadPoolConfig.ThreadPoolExecutorServiceFactory
-
- ThreadPoolConfig - Class in akka.dispatch
-
- ThreadPoolConfig(boolean, int, int, Duration, Function0<BlockingQueue<Runnable>>, RejectedExecutionHandler) - Constructor for class akka.dispatch.ThreadPoolConfig
-
- threadPoolConfig() - Method in class akka.dispatch.ThreadPoolExecutorConfigurator
-
- ThreadPoolConfig$ - Class in akka.dispatch
-
- ThreadPoolConfig$() - Constructor for class akka.dispatch.ThreadPoolConfig$
-
- ThreadPoolConfig.ThreadPoolExecutorServiceFactory - Class in akka.dispatch
-
- 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(Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.ThreadPoolExecutorConfigurator
-
- ThreadPoolExecutorServiceFactory(ThreadFactory) - Constructor for class akka.dispatch.ThreadPoolConfig.ThreadPoolExecutorServiceFactory
-
- threadTimeout() - Method in class akka.dispatch.ThreadPoolConfig
-
- throughput() - Method in class akka.dispatch.Dispatcher
-
- throughput() - Method in class akka.dispatch.MessageDispatcher
-
INTERNAL API
- throughputDeadlineTime() - Method in class akka.dispatch.Dispatcher
-
- throughputDeadlineTime() - Method in class akka.dispatch.MessageDispatcher
-
INTERNAL API
- TickDuration() - Method in class akka.actor.LightArrayRevolverScheduler
-
- ticks() - Method in class akka.actor.LightArrayRevolverScheduler.TaskHolder
-
- timeout() - Method in class akka.actor.FSM.State
-
- timeout() - Method in class akka.actor.TypedActor.SerializedTypedActorInvocationHandler
-
- timeout() - Method in class akka.actor.TypedActor.TypedActorInvocationHandler
-
- timeout() - Method in class akka.actor.TypedProps
-
- timeout() - Method in class akka.io.Tcp.Connect
-
- Timeout - Class in akka.util
-
- Timeout(FiniteDuration) - Constructor for class akka.util.Timeout
-
- Timeout(long, TimeUnit) - Constructor for class akka.util.Timeout
-
Construct a Timeout from the given time unit and factor.
- Timeout$ - Class in akka.util
-
A Timeout is a wrapper on top of Duration to be more specific about what the duration means.
- Timeout$() - Constructor for class akka.util.Timeout$
-
- timeoutFuture() - Method in interface akka.actor.FSM
-
- TimeoutMarker(long) - Constructor for class akka.actor.FSM.TimeoutMarker
-
- TimeoutMarker$() - Constructor for class akka.actor.FSM.TimeoutMarker$
-
- Timer(String, Object, boolean, int, ActorContext) - Constructor for class akka.actor.FSM.Timer
-
- Timer$() - Constructor for class akka.actor.FSM.Timer$
-
- timerGen() - Method in interface akka.actor.FSM
-
- timers() - Method in interface akka.actor.FSM
-
- 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
-
- to() - Method in class akka.actor.FSM.Transition
-
- 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() - Method in class akka.util.LineNumbers.SourceFileLines
-
- 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.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
- toBinary(Object) - Method in class akka.serialization.SerializerWithStringManifest
-
Serializes the given object into an Array of Byte
- toByteBuffer() - Method in class akka.util.ByteString
-
Creates a new ByteBuffer with a copy of all bytes contained in this
ByteString.
- toByteString() - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- toByteString() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- toByteString() - Method in class akka.util.ByteIterator
-
- toByteString1() - Method in class akka.util.ByteString.ByteString1C
-
- toDie() - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
-
- token() - Method in class akka.io.Tcp.NoAck
-
- token() - Method in class akka.io.Udp.NoAck
-
- token() - Method in class akka.io.UdpConnected.NoAck
-
- toScala(ActorSelection) - Method in class akka.actor.ActorSelection$
-
- toScala(ActorSelection) - Static method in class akka.actor.ActorSelection
-
- toScala() - Method in class akka.japi.Pair
-
- toScala() - Method in class akka.japi.tuple.Tuple10
-
- toScala() - Method in class akka.japi.tuple.Tuple11
-
- toScala() - Method in class akka.japi.tuple.Tuple12
-
- toScala() - Method in class akka.japi.tuple.Tuple13
-
- toScala() - Method in class akka.japi.tuple.Tuple14
-
- toScala() - Method in class akka.japi.tuple.Tuple15
-
- toScala() - Method in class akka.japi.tuple.Tuple16
-
- toScala() - Method in class akka.japi.tuple.Tuple17
-
- toScala() - Method in class akka.japi.tuple.Tuple18
-
- toScala() - Method in class akka.japi.tuple.Tuple19
-
- toScala() - Method in class akka.japi.tuple.Tuple20
-
- toScala() - Method in class akka.japi.tuple.Tuple21
-
- toScala() - Method in class akka.japi.tuple.Tuple22
-
- toScala() - Method in class akka.japi.tuple.Tuple3
-
- toScala() - Method in class akka.japi.tuple.Tuple4
-
- toScala() - Method in class akka.japi.tuple.Tuple5
-
- toScala() - Method in class akka.japi.tuple.Tuple6
-
- toScala() - Method in class akka.japi.tuple.Tuple7
-
- toScala() - Method in class akka.japi.tuple.Tuple8
-
- toScala() - Method in class akka.japi.tuple.Tuple9
-
- toSeq() - Method in class akka.util.ByteIterator
-
- toSerializationFormat() - Method in interface akka.actor.ActorPath
-
Generate full String representation including the
uid for the actor cell instance as URI fragment.
- toSerializationFormat() - Method in class akka.actor.ActorSelection
-
String representation of the actor selection suitable for storage and recreation.
- toSerializationFormat() - Method in class akka.actor.ChildActorPath
-
- toSerializationFormat() - Method in class akka.actor.RootActorPath
-
- toSerializationFormatWithAddress(Address) - Method in interface akka.actor.ActorPath
-
Generate full String representation including the uid for the actor cell
instance as URI fragment, replacing the Address in the RootActor Path
with the given one unless this path’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.ActorSystemImpl
-
- toString() - Method in class akka.actor.Address
-
Returns the canonical String representation of this Address formatted as:
- toString() - Method in class akka.actor.ChildActorPath
-
- toString() - Method in class akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer$
-
- toString() - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
-
- toString() - Method in class akka.actor.dungeon.ChildrenContainer.TerminatedChildrenContainer$
-
- toString() - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
-
- toString() - Method in class akka.actor.RootActorPath
-
- toString() - Method in class akka.actor.SelectChildName
-
- toString() - Method in class akka.actor.SelectChildPattern
-
- toString() - Method in class akka.actor.SelectParent$
-
- toString() - Static method in class akka.actor.SelectParent
-
- toString() - Method in class akka.dispatch.Dispatcher
-
- toString() - Method in class akka.event.Logging.StandardOutLogger
-
- toString() - Method in class akka.routing.ConsistentRoutee
-
- toString() - Method in class akka.util.ByteString
-
- toString() - Method in class akka.util.LineNumbers.SourceFile
-
- toString() - Method in class akka.util.LineNumbers.SourceFileLines
-
- toString() - Method in class akka.util.SerializedSuspendableExecutionContext
-
- toString() - Method in class akka.util.SubclassifiedIndex.Nonroot
-
- toString() - Method in class akka.util.SubclassifiedIndex
-
- toString() - Method in class akka.util.TypedMultiMap
-
- 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
-
- toStringWithoutAddress() - Method in interface akka.actor.ActorPath
-
String representation of the path elements, excluding the address
information.
- total2pf(Function2<S, S, BoxedUnit>) - Method in interface akka.actor.FSM
-
- toTypedActorInvocationHandler(ActorSystem) - Method in class akka.actor.TypedActor.SerializedTypedActorInvocationHandler
-
- TraceLogging() - Method in class akka.io.SelectionHandlerSettings
-
- TrafficClass(int) - Constructor for class akka.io.Inet.SO$.TrafficClass
-
- 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.
- transcend(boolean, Function0<BoxedUnit>) - Method in class akka.util.Switch
-
- TransferToLimit() - Method in class akka.io.TcpExt.Settings
-
- transform(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Method in interface akka.actor.FSM
-
- TransformHelper(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Constructor for class akka.actor.FSM.TransformHelper
-
- Transition(ActorRef, S, S) - Constructor for class akka.actor.FSM.Transition
-
- Transition$() - Constructor for class akka.actor.FSM.Transition$
-
- transitionEvent() - Method in interface akka.actor.FSM
-
- 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].
- Tuple10<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10> - Class in akka.japi.tuple
-
- Tuple10(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Constructor for class akka.japi.tuple.Tuple10
-
- Tuple10$ - Class in akka.japi.tuple
-
Used to create tuples with 10 elements in Java.
- Tuple10$() - Constructor for class akka.japi.tuple.Tuple10$
-
- Tuple11<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11> - Class in akka.japi.tuple
-
- Tuple11(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Constructor for class akka.japi.tuple.Tuple11
-
- Tuple11$ - Class in akka.japi.tuple
-
Used to create tuples with 11 elements in Java.
- Tuple11$() - Constructor for class akka.japi.tuple.Tuple11$
-
- Tuple12<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12> - Class in akka.japi.tuple
-
- Tuple12(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Constructor for class akka.japi.tuple.Tuple12
-
- Tuple12$ - Class in akka.japi.tuple
-
Used to create tuples with 12 elements in Java.
- Tuple12$() - Constructor for class akka.japi.tuple.Tuple12$
-
- Tuple13<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13> - Class in akka.japi.tuple
-
- Tuple13(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Constructor for class akka.japi.tuple.Tuple13
-
- Tuple13$ - Class in akka.japi.tuple
-
Used to create tuples with 13 elements in Java.
- Tuple13$() - Constructor for class akka.japi.tuple.Tuple13$
-
- Tuple14<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14> - Class in akka.japi.tuple
-
- Tuple14(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Constructor for class akka.japi.tuple.Tuple14
-
- Tuple14$ - Class in akka.japi.tuple
-
Used to create tuples with 14 elements in Java.
- Tuple14$() - Constructor for class akka.japi.tuple.Tuple14$
-
- Tuple15<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15> - Class in akka.japi.tuple
-
- Tuple15(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Constructor for class akka.japi.tuple.Tuple15
-
- Tuple15$ - Class in akka.japi.tuple
-
Used to create tuples with 15 elements in Java.
- Tuple15$() - Constructor for class akka.japi.tuple.Tuple15$
-
- Tuple16<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16> - Class in akka.japi.tuple
-
- Tuple16(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Constructor for class akka.japi.tuple.Tuple16
-
- Tuple16$ - Class in akka.japi.tuple
-
Used to create tuples with 16 elements in Java.
- Tuple16$() - Constructor for class akka.japi.tuple.Tuple16$
-
- Tuple17<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17> - Class in akka.japi.tuple
-
- Tuple17(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Constructor for class akka.japi.tuple.Tuple17
-
- Tuple17$ - Class in akka.japi.tuple
-
Used to create tuples with 17 elements in Java.
- Tuple17$() - Constructor for class akka.japi.tuple.Tuple17$
-
- Tuple18<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18> - Class in akka.japi.tuple
-
- Tuple18(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Constructor for class akka.japi.tuple.Tuple18
-
- Tuple18$ - Class in akka.japi.tuple
-
Used to create tuples with 18 elements in Java.
- Tuple18$() - Constructor for class akka.japi.tuple.Tuple18$
-
- Tuple19<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19> - Class in akka.japi.tuple
-
- Tuple19(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Constructor for class akka.japi.tuple.Tuple19
-
- Tuple19$ - Class in akka.japi.tuple
-
Used to create tuples with 19 elements in Java.
- Tuple19$() - Constructor for class akka.japi.tuple.Tuple19$
-
- Tuple20<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20> - Class in akka.japi.tuple
-
- Tuple20(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Constructor for class akka.japi.tuple.Tuple20
-
- Tuple20$ - Class in akka.japi.tuple
-
Used to create tuples with 20 elements in Java.
- Tuple20$() - Constructor for class akka.japi.tuple.Tuple20$
-
- Tuple21<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21> - Class in akka.japi.tuple
-
- Tuple21(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Constructor for class akka.japi.tuple.Tuple21
-
- Tuple21$ - Class in akka.japi.tuple
-
Used to create tuples with 21 elements in Java.
- Tuple21$() - Constructor for class akka.japi.tuple.Tuple21$
-
- Tuple22<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22> - Class in akka.japi.tuple
-
- Tuple22(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Constructor for class akka.japi.tuple.Tuple22
-
- Tuple22$ - Class in akka.japi.tuple
-
Used to create tuples with 22 elements in Java.
- Tuple22$() - Constructor for class akka.japi.tuple.Tuple22$
-
- Tuple3<T1,T2,T3> - Class in akka.japi.tuple
-
- Tuple3(T1, T2, T3) - Constructor for class akka.japi.tuple.Tuple3
-
- Tuple3$ - Class in akka.japi.tuple
-
Used to create tuples with 3 elements in Java.
- Tuple3$() - Constructor for class akka.japi.tuple.Tuple3$
-
- Tuple4<T1,T2,T3,T4> - Class in akka.japi.tuple
-
- Tuple4(T1, T2, T3, T4) - Constructor for class akka.japi.tuple.Tuple4
-
- Tuple4$ - Class in akka.japi.tuple
-
Used to create tuples with 4 elements in Java.
- Tuple4$() - Constructor for class akka.japi.tuple.Tuple4$
-
- Tuple5<T1,T2,T3,T4,T5> - Class in akka.japi.tuple
-
- Tuple5(T1, T2, T3, T4, T5) - Constructor for class akka.japi.tuple.Tuple5
-
- Tuple5$ - Class in akka.japi.tuple
-
Used to create tuples with 5 elements in Java.
- Tuple5$() - Constructor for class akka.japi.tuple.Tuple5$
-
- Tuple6<T1,T2,T3,T4,T5,T6> - Class in akka.japi.tuple
-
- Tuple6(T1, T2, T3, T4, T5, T6) - Constructor for class akka.japi.tuple.Tuple6
-
- Tuple6$ - Class in akka.japi.tuple
-
Used to create tuples with 6 elements in Java.
- Tuple6$() - Constructor for class akka.japi.tuple.Tuple6$
-
- Tuple7<T1,T2,T3,T4,T5,T6,T7> - Class in akka.japi.tuple
-
- Tuple7(T1, T2, T3, T4, T5, T6, T7) - Constructor for class akka.japi.tuple.Tuple7
-
- Tuple7$ - Class in akka.japi.tuple
-
Used to create tuples with 7 elements in Java.
- Tuple7$() - Constructor for class akka.japi.tuple.Tuple7$
-
- Tuple8<T1,T2,T3,T4,T5,T6,T7,T8> - Class in akka.japi.tuple
-
- Tuple8(T1, T2, T3, T4, T5, T6, T7, T8) - Constructor for class akka.japi.tuple.Tuple8
-
- Tuple8$ - Class in akka.japi.tuple
-
Used to create tuples with 8 elements in Java.
- Tuple8$() - Constructor for class akka.japi.tuple.Tuple8$
-
- Tuple9<T1,T2,T3,T4,T5,T6,T7,T8,T9> - Class in akka.japi.tuple
-
- Tuple9(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Constructor for class akka.japi.tuple.Tuple9
-
- Tuple9$ - Class in akka.japi.tuple
-
Used to create tuples with 9 elements in Java.
- Tuple9$() - Constructor for class akka.japi.tuple.Tuple9$
-
- 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(AtomicReference<R>, Function0<T>, Seq<Class<?>>) - Constructor for class akka.actor.TypedActor.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$ - Class in akka.actor
-
- TypedActor.PostRestart - Interface in akka.actor
-
- TypedActor.PostStop - Interface in akka.actor
-
Mix this into your TypedActor to be able to hook into its lifecycle
- TypedActor.PreRestart - Interface in akka.actor
-
Mix this into your TypedActor to be able to hook into its lifecycle
- TypedActor.PreStart - Interface in akka.actor
-
Mix this into your TypedActor to be able to hook into its lifecycle
- TypedActor.Receiver - Interface in akka.actor
-
Mix this into your TypedActor to be able to intercept Terminated messages
- TypedActor.SerializedMethodCall - Class in akka.actor
-
INTERNAL API
- TypedActor.SerializedMethodCall$ - Class in akka.actor
-
- TypedActor.SerializedTypedActorInvocationHandler - Class in akka.actor
-
INTERNAL API
- TypedActor.SerializedTypedActorInvocationHandler$ - Class in akka.actor
-
- TypedActor.Supervisor - Interface in akka.actor
-
Mix this into your TypedActor to be able to define supervisor strategy
- TypedActor.TypedActor<R,T extends R> - Class in akka.actor
-
INTERNAL API
- TypedActor.TypedActorInvocationHandler - Class in akka.actor
-
INTERNAL API
- 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.
- TypedActorInvocationHandler(TypedActorExtension, AtomicReference<ActorRef>, Timeout) - Constructor for class akka.actor.TypedActor.TypedActorInvocationHandler
-
- typedActorOf(TypedProps<T>) - Method in interface akka.actor.TypedActorFactory
-
Creates a new TypedActor with the specified properties
- typedActorOf(TypedProps<T>, String) - Method in interface akka.actor.TypedActorFactory
-
Creates a new TypedActor with the specified properties
- typedActorOf(TypedProps<T>, ActorRef) - Method in interface akka.actor.TypedActorFactory
-
Creates a TypedActor that intercepts the calls and forwards them as
TypedActor.MethodCall
to the provided ActorRef.
- TypedCreatorFunctionConsumer - Class in akka.actor
-
INTERNAL API
- TypedCreatorFunctionConsumer(Class<? extends Actor>, Function0<Actor>) - Constructor for class akka.actor.TypedCreatorFunctionConsumer
-
- TypedCreatorFunctionConsumerClass() - Method in class akka.actor.IndirectActorProducer$
-
- TypedMultiMap<T,K> - Class in akka.util
-
An immutable multi-map that expresses the value type as a type function of the key
type.
- TypedMultiMap$ - Class in akka.util
-
- TypedMultiMap$() - Constructor for class akka.util.TypedMultiMap$
-
- TypedProps<T> - Class in akka.actor
-
- TypedProps(Seq<Class<?>>, Function0<T>, String, Deploy, Option<Timeout>, Option<ClassLoader>) - Constructor for class akka.actor.TypedProps
-
- TypedProps(Class<T>) - Constructor for class akka.actor.TypedProps
-
Uses the supplied class as the factory for the TypedActor implementation,
and that has the specified interface,
or if the interface class is not an interface, all the interfaces it implements,
appended in the sequence of interfaces.
- TypedProps(Class<? super T>, Creator<T>) - Constructor for class akka.actor.TypedProps
-
Java API: Uses the supplied Creator as the factory for the TypedActor implementation,
and that has the specified interface,
or if the interface class is not an interface, all the interfaces it implements,
appended in the sequence of interfaces.
- TypedProps(Class<? super T>, Class<T>) - Constructor for class akka.actor.TypedProps
-
Java API: Uses the supplied class as the factory for the TypedActor implementation,
and that has the specified interface,
or if the interface class is not an interface, all the interfaces it implements,
appended in the sequence of interfaces.
- TypedProps$ - Class in akka.actor
-
TypedProps is a TypedActor configuration object, that is thread safe and fully sharable.
- TypedProps$() - Constructor for class akka.actor.TypedProps$
-
- waitingForChildrenOrNull() - Method in interface akka.actor.dungeon.Children
-
- waitingForRegistration(ChannelRegistration, ActorRef) - Method in class akka.io.TcpConnection
-
connection established, waiting for registration from user handler
- waitNanos(long) - Method in class akka.actor.LightArrayRevolverScheduler
-
Overridable for tests
- wantsAck() - Method in class akka.io.Tcp.SimpleWriteCommand
-
- 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, Class<?>, Object) - Constructor for class akka.event.Logging.Warning
-
- 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$() - Constructor for class akka.event.Logging.Warning$
-
- Warning2(String, Class<?>, Object, Map<String, Object>) - Constructor for class akka.event.Logging.Warning2
-
- 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 interface akka.actor.dungeon.DeathWatch
-
- watch(ActorRef) - Method in class akka.actor.Inbox
-
Have the internal actor watch the target actor.
- Watch - Class in akka.dispatch.sysmsg
-
INTERNAL API
- Watch(InternalActorRef, InternalActorRef) - Constructor for class akka.dispatch.sysmsg.Watch
-
- Watch$ - Class in akka.dispatch.sysmsg
-
- Watch$() - Constructor for class akka.dispatch.sysmsg.Watch$
-
- watchedActorTerminated(ActorRef, boolean, boolean) - Method in interface akka.actor.dungeon.DeathWatch
-
When this actor is watching the subject of
Terminated
message
it will be propagated to user's receive.
- watchedBy() - Method in interface akka.actor.dungeon.DeathWatch
-
- watchee() - Method in class akka.dispatch.sysmsg.Unwatch
-
- watchee() - Method in class akka.dispatch.sysmsg.Watch
-
- watcher() - Method in class akka.dispatch.sysmsg.Unwatch
-
- watcher() - Method in class akka.dispatch.sysmsg.Watch
-
- watching() - Method in interface akka.actor.dungeon.DeathWatch
-
- watchingContains(ActorRef) - Method in interface akka.actor.dungeon.DeathWatch
-
- WheelSize() - Method in class akka.actor.LightArrayRevolverScheduler
-
- when(S, PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
-
Insert a new StateFunction at the end of the processing chain for the
given state.
- when(S, FSMStateFunctionBuilder<S, D>) - Method in class akka.actor.AbstractFSM
-
Insert a new StateFunction at the end of the processing chain for the
given state.
- when(S, FiniteDuration, FSMStateFunctionBuilder<S, D>) - Method in class akka.actor.AbstractFSM
-
Insert a new StateFunction at the end of the processing chain for the
given state.
- when(S, FiniteDuration, PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Method in interface akka.actor.FSM
-
Insert a new StateFunction at the end of the processing chain for the
given state.
- whenFailing(Function2<Throwable, Option<Object>, BoxedUnit>) - Method in interface akka.actor.dsl.Creators.Act
-
Replace the preRestart
action with the supplied function.
- whenRestarted(Function1<Throwable, BoxedUnit>) - Method in interface akka.actor.dsl.Creators.Act
-
Replace the postRestart
action with the supplied function.
- whenStarting(Function0<BoxedUnit>) - Method in interface akka.actor.dsl.Creators.Act
-
Replace the preStart
action with the supplied thunk.
- whenStopping(Function0<BoxedUnit>) - Method in interface akka.actor.dsl.Creators.Act
-
Replace the postStop
action with the supplied thunk.
- whenTerminated() - Method in class akka.actor.ActorSystem
-
Returns a Future which will be completed after the ActorSystem has been terminated
and termination hooks have been executed.
- whenTerminated() - Method in class akka.actor.ActorSystemImpl
-
- whenUnhandled(FSMStateFunctionBuilder<S, D>) - Method in class akka.actor.AbstractFSM
-
Set handler which is called upon reception of unhandled messages.
- whenUnhandled(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Method in interface akka.actor.FSM
-
- whileOff(Function0<BoxedUnit>) - Method in class akka.util.Switch
-
Executes the provided action and returns if the action was executed or not, if the switch is off, waiting for any pending changes to happen before (locking)
Be careful of longrunning or blocking within the provided action as it can lead to deadlocks or bad performance
- whileOffYield(Function0<T>) - Method in class akka.util.Switch
-
Executes the provided action and returns its value if the switch is off, waiting for any pending changes to happen before (locking)
Be careful of longrunning or blocking within the provided action as it can lead to deadlocks or bad performance
- whileOn(Function0<BoxedUnit>) - Method in class akka.util.Switch
-
Executes the provided action and returns if the action was executed or not, if the switch is on, waiting for any pending changes to happen before (locking)
Be careful of longrunning or blocking within the provided action as it can lead to deadlocks or bad performance
- whileOnYield(Function0<T>) - Method in class akka.util.Switch
-
Executes the provided action and returns its value if the switch is on, waiting for any pending changes to happen before (locking)
Be careful of longrunning or blocking within the provided action as it can lead to deadlocks or bad performance
- wildcardFanOut() - Method in class akka.actor.ActorSelectionMessage
-
- WildcardTree<T> - Class in akka.util
-
- WildcardTree(Option<T>, Map<String, WildcardTree<T>>) - Constructor for class akka.util.WildcardTree
-
- WildcardTree$ - Class in akka.util
-
- WildcardTree$() - Constructor for class akka.util.WildcardTree$
-
- WindowsConnectionAbortWorkaroundEnabled() - Method in class akka.io.TcpExt.Settings
-
- wire(T) - Method in class akka.dispatch.MonitorableThreadFactory
-
- withCircuitBreaker(Function0<Future<T>>) - Method in class akka.pattern.CircuitBreaker
-
Wraps invocations of asynchronous calls that need to be protected
- withClient(ActorRef) - Method in class akka.actor.dsl.Inbox.Get
-
- withClient(ActorRef) - Method in interface akka.actor.dsl.Inbox.Query
-
- withClient(ActorRef) - Method in class akka.actor.dsl.Inbox.Select
-
- withContext(Function0<U>) - Method in class akka.actor.TypedActor.TypedActor
-
- 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.routing.BalancingPool
-
Setting the dispatcher to be used for the router head actor, which handles
supervision, death watch and router management messages.
- withDispatcher(String) - Method in class akka.routing.BroadcastGroup
-
Setting the dispatcher to be used for the router head actor, which handles
router management messages
- withDispatcher(String) - Method in class akka.routing.BroadcastPool
-
Setting the dispatcher to be used for the router head actor, which handles
supervision, death watch and router management messages.
- withDispatcher(String) - Method in class akka.routing.ConsistentHashingGroup
-
Setting the dispatcher to be used for the router head actor, which handles
router management messages
- withDispatcher(String) - Method in class akka.routing.ConsistentHashingPool
-
Setting the dispatcher to be used for the router head actor, which handles
supervision, death watch and router management messages.
- withDispatcher(String) - Method in class akka.routing.FromConfig
-
Setting the dispatcher to be used for the router head actor, which handles
supervision, death watch and router management messages.
- withDispatcher(String) - Method in class akka.routing.RandomGroup
-
Setting the dispatcher to be used for the router head actor, which handles
router management messages
- withDispatcher(String) - Method in class akka.routing.RandomPool
-
Setting the dispatcher to be used for the router head actor, which handles
supervision, death watch and router management messages.
- withDispatcher(String) - Method in class akka.routing.RoundRobinGroup
-
Setting the dispatcher to be used for the router head actor, which handles
router management messages
- withDispatcher(String) - Method in class akka.routing.RoundRobinPool
-
Setting the dispatcher to be used for the router head actor, which handles
supervision, death watch and router management messages.
- withDispatcher(String) - Method in class akka.routing.ScatterGatherFirstCompletedGroup
-
Setting the dispatcher to be used for the router head actor, which handles
router management messages
- withDispatcher(String) - Method in class akka.routing.ScatterGatherFirstCompletedPool
-
Setting the dispatcher to be used for the router head actor, which handles
supervision, death watch and router management messages.
- withDispatcher(String) - Method in class akka.routing.SmallestMailboxPool
-
Setting the dispatcher to be used for the router head actor, which handles
supervision, death watch and router management messages.
- withDispatcher(String) - Method in class akka.routing.TailChoppingGroup
-
Setting the dispatcher to be used for the router head actor, which handles
router management messages
- withDispatcher(String) - Method in class akka.routing.TailChoppingPool
-
Setting the dispatcher to be used for the router head actor, which handles
supervision, death watch and router management messages.
- withFallback(Deploy) - Method in class akka.actor.Deploy
-
Do a merge between this and the other Deploy, where values from “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(ConfigMergeable) - Method in class akka.dispatch.CachingConfig
-
- withFallback(RouterConfig) - Method in class akka.routing.BalancingPool
-
Uses the supervisor strategy of the given RouterConfig
if this RouterConfig doesn't have one.
- withFallback(RouterConfig) - Method in class akka.routing.BroadcastPool
-
Uses the resizer and/or the supervisor strategy of the given RouterConfig
if this RouterConfig doesn't have one, i.e.
- withFallback(RouterConfig) - Method in class akka.routing.ConsistentHashingGroup
-
Uses the hashMapping
defined in code, since that can't be defined in configuration.
- withFallback(RouterConfig) - Method in class akka.routing.ConsistentHashingPool
-
Uses the resizer and/or the supervisor strategy of the given RouterConfig
if this RouterConfig doesn't have one, i.e.
- withFallback(RouterConfig) - Method in class akka.routing.NoRouter$
-
- withFallback(RouterConfig) - Static method in class akka.routing.NoRouter
-
- withFallback(RouterConfig) - Method in class akka.routing.RandomPool
-
Uses the resizer and/or the supervisor strategy of the given RouterConfig
if this RouterConfig doesn't have one, i.e.
- withFallback(RouterConfig) - Method in class akka.routing.RoundRobinPool
-
Uses the resizer and/or the supervisor strategy of the given RouterConfig
if this RouterConfig doesn't have one, i.e.
- withFallback(RouterConfig) - Method in interface akka.routing.RouterConfig
-
Overridable merge strategy, by default completely prefers this
(i.e.
- withFallback(RouterConfig) - Method in class akka.routing.ScatterGatherFirstCompletedPool
-
Uses the resizer and/or the supervisor strategy of the given RouterConfig
if this RouterConfig doesn't have one, i.e.
- withFallback(RouterConfig) - Method in class akka.routing.SmallestMailboxPool
-
Uses the resizer and/or the supervisor strategy of the given RouterConfig
if this RouterConfig doesn't have one, i.e.
- withFallback(RouterConfig) - Method in class akka.routing.TailChoppingPool
-
Uses the resizer and/or the supervisor strategy of the given RouterConfig
if this RouterConfig doesn't have one, i.e.
- withGuard(Function0<T>) - Method in class akka.util.ReentrantGuard
-
- withHashMapper(ConsistentHashingRouter.ConsistentHashMapper) - Method in class akka.routing.ConsistentHashingGroup
-
Java API: Setting the mapping from message to the data to use for the consistent hash key.
- withHashMapper(ConsistentHashingRouter.ConsistentHashMapper) - Method in class akka.routing.ConsistentHashingPool
-
Java API: Setting the mapping from message to the data to use for the consistent hash key.
- withHashMapper(ConsistentHashingRouter.ConsistentHashMapper) - Method in class akka.routing.ConsistentHashingRoutingLogic
-
Java API: Setting the mapping from message to the data to use for the consistent hash key.
- within() - Method in class akka.routing.ScatterGatherFirstCompletedGroup
-
- within() - Method in class akka.routing.ScatterGatherFirstCompletedPool
-
- within() - Method in class akka.routing.ScatterGatherFirstCompletedRoutees
-
- within() - Method in class akka.routing.ScatterGatherFirstCompletedRoutingLogic
-
- within() - Method in class akka.routing.TailChoppingGroup
-
- within() - Method in class akka.routing.TailChoppingPool
-
- within() - Method in class akka.routing.TailChoppingRoutees
-
- within() - Method in class akka.routing.TailChoppingRoutingLogic
-
- withInterface(Class<? super T>) - Method in class akka.actor.TypedProps
-
Returns a new TypedProps that has the specified interface,
or if the interface class is not an interface, all the interfaces it implements,
appended in the sequence of interfaces.
- withinTimeRange() - Method in class akka.actor.AllForOneStrategy
-
- withinTimeRange() - Method in class akka.actor.OneForOneStrategy
-
- withinTimeRangeOption(Duration) - Method in class akka.actor.SupervisorStrategy$
-
- withinTimeRangeOption(Duration) - Static method in class akka.actor.SupervisorStrategy
-
- withLabel(String, PartialFunction<Object, BoxedUnit>, ActorContext) - Method in class akka.event.LoggingReceive$
-
Create a decorated logger which will append " in state " + label
to each message it logs.
- withLabel(String, PartialFunction<Object, BoxedUnit>, ActorContext) - Static method in class akka.event.LoggingReceive
-
Create a decorated logger which will append " in state " + label
to each message it logs.
- WithListeners - Class in akka.routing
-
- WithListeners(Function1<ActorRef, BoxedUnit>) - Constructor for class akka.routing.WithListeners
-
- WithListeners$ - Class in akka.routing
-
- WithListeners$() - Constructor for class akka.routing.WithListeners$
-
- withLoader(ClassLoader) - Method in class akka.actor.TypedProps
-
Java API: return a new TypedProps that will use the specified ClassLoader to create its proxy class in
If loader is null, it will use the bootstrap classloader.
- withLoader(Option<ClassLoader>) - Method in class akka.actor.TypedProps
-
Scala API: return a new TypedProps that will use the specified ClassLoader to create its proxy class in
If loader is null, it will use the bootstrap classloader.
- withMailbox(String) - Method in class akka.actor.Props
-
Returns a new Props with the specified mailbox set.
- 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
-
- withNotification(boolean) - Method in class akka.actor.FSM.State
-
INTERNAL API.
- withOnlyPath(String) - Method in class akka.dispatch.CachingConfig
-
- withoutInterface(Class<? super T>) - Method in class akka.actor.TypedProps
-
Returns a new TypedProps without the specified interface,
or if the interface class is not an interface, all the interfaces it implements.
- withoutPath(String) - Method in class akka.dispatch.CachingConfig
-
- withResizer(Resizer) - Method in class akka.routing.BroadcastPool
-
Setting the resizer to be used.
- withResizer(Resizer) - Method in class akka.routing.ConsistentHashingPool
-
Setting the resizer to be used.
- withResizer(Resizer) - Method in class akka.routing.FromConfig
-
Setting the resizer to be used.
- withResizer(Resizer) - Method in interface akka.routing.PoolOverrideUnsetConfig
-
- withResizer(Resizer) - Method in class akka.routing.RandomPool
-
Setting the resizer to be used.
- withResizer(Resizer) - Method in class akka.routing.RoundRobinPool
-
Setting the resizer to be used.
- withResizer(Resizer) - Method in class akka.routing.ScatterGatherFirstCompletedPool
-
Setting the resizer to be used.
- withResizer(Resizer) - Method in class akka.routing.SmallestMailboxPool
-
Setting the resizer to be used.
- withResizer(Resizer) - Method in class akka.routing.TailChoppingPool
-
Setting the resizer to be used.
- withRoutees(IndexedSeq<Routee>) - Method in class akka.routing.Router
-
Create a new instance with the specified routees and the same
RoutingLogic
.
- withRouter(akka.routing.RouterConfig) - Method in class akka.actor.Props
-
Returns a new Props with the specified router config set.
- withStopReason(FSM.Reason) - Method in class akka.actor.FSM.State
-
INTERNAL API.
- withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.BalancingPool
-
Setting the supervisor strategy to be used for the “head” Router actor.
- withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.BroadcastPool
-
Setting the supervisor strategy to be used for the “head” Router actor.
- withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.ConsistentHashingPool
-
Setting the supervisor strategy to be used for the “head” Router actor.
- withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.FromConfig
-
Setting the supervisor strategy to be used for the “head” Router actor.
- withSupervisorStrategy(SupervisorStrategy) - Method in interface akka.routing.PoolOverrideUnsetConfig
-
- withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.RandomPool
-
Setting the supervisor strategy to be used for the “head” Router actor.
- withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.RoundRobinPool
-
Setting the supervisor strategy to be used for the “head” Router actor.
- withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.ScatterGatherFirstCompletedPool
-
Setting the supervisor strategy to be used for the “head” Router actor.
- withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.SmallestMailboxPool
-
Setting the supervisor strategy to be used for the “head” Router actor.
- withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.TailChoppingPool
-
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.
- WithUdpSend - Interface in akka.io
-
INTERNAL API
- withUid(int) - Method in interface akka.actor.ActorPath
-
INTERNAL API
Creates a new ActorPath with same elements but with the specified uid
.
- withUid(int) - Method in class akka.actor.ChildActorPath
-
INTERNAL API
- withUid(int) - Method in class akka.actor.RootActorPath
-
INTERNAL API
- withValue(String, ConfigValue) - Method in class akka.dispatch.CachingConfig
-
- withValue(ExtendedActorSystem, Callable<S>) - Method in class akka.serialization.JavaSerializer.CurrentSystem
-
Java API: invoke the callable with the current system being set to the given value for this thread.
- withVirtualNodesFactor(int) - Method in class akka.routing.ConsistentHashingGroup
-
- withVirtualNodesFactor(int) - Method in class akka.routing.ConsistentHashingPool
-
- withVirtualNodesFactor(int) - Method in class akka.routing.ConsistentHashingRoutingLogic
-
- work() - Method in class akka.io.TcpConnection.UpdatePendingWriteAndThen
-
- WorkerDispatcher() - Method in class akka.io.SelectionHandlerSettings
-
- WorkerForCommand(SelectionHandler.HasFailureMessage, ActorRef, Function1<ChannelRegistry, Props>) - Constructor for class akka.io.SelectionHandler.WorkerForCommand
-
- WorkerForCommand$() - Constructor for class akka.io.SelectionHandler.WorkerForCommand$
-
- workerForCommandHandler(PartialFunction<SelectionHandler.HasFailureMessage, Function1<ChannelRegistry, Props>>) - Method in class akka.io.SelectionHandler.SelectorBasedManager
-
- WrappedElement(E, long) - Constructor for class akka.util.PriorityQueueStabilizer.WrappedElement
-
- WrappedElementComparator(Comparator<E>) - Constructor for class akka.util.PriorityQueueStabilizer.WrappedElementComparator
-
- Write(ByteString, Tcp.Event) - Constructor for class akka.io.Tcp.Write
-
- 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$() - Constructor for class akka.io.Tcp.Write$
-
- WriteCommand() - Constructor for class akka.io.Tcp.WriteCommand
-
- WriteCommand$() - Constructor for class akka.io.Tcp.WriteCommand$
-
- WriteFile(String, long, long, Tcp.Event) - Constructor for class akka.io.Tcp.WriteFile
-
- 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.
- WriteFile$() - Constructor for class akka.io.Tcp.WriteFile$
-
- WriteFileFailed(IOException) - Constructor for class akka.io.TcpConnection.WriteFileFailed
-
- WriteFileFailed$() - Constructor for class akka.io.TcpConnection.WriteFileFailed$
-
- writeObject(ObjectOutputStream) - Method in interface akka.actor.ActorContext
-
ActorContexts shouldn't be Serializable
- writePending() - Method in class akka.io.TcpConnection
-
- writePending() - Method in class akka.io.UdpConnection
-
- writeReplace() - Method in class akka.actor.DeadLetterActorRef
-
- writeReplace() - Method in class akka.actor.LocalActorRef
-
- writeReplace() - Method in interface akka.actor.MinimalActorRef
-
- writeReplace() - Method in class akka.actor.Nobody$
-
- writeReplace() - Static method in class akka.actor.Nobody
-
- writeReplace() - Method in class akka.actor.RepointableActorRef
-
- writeReplace() - Method in class akka.event.Logging.StandardOutLogger
-
- writeReplace() - Method in class akka.util.ByteString.ByteString1
-
- writeReplace() - Method in class akka.util.ByteString.ByteStrings
-
- writeToOutputStream(ObjectOutputStream) - Method in class akka.util.ByteString.ByteString1
-
- writeToOutputStream(ObjectOutputStream) - Method in class akka.util.ByteString.ByteString1C
-
- writeToOutputStream(ObjectOutputStream) - Method in class akka.util.ByteString.ByteStrings
-
- writeToOutputStream(ObjectOutputStream) - Method in class akka.util.ByteString
-
- WritingResumed$() - Constructor for class akka.io.Tcp.WritingResumed$
-