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

A

abort() - Method in class akka.io.TcpMessage$
An abort operation will not flush pending writes and will issue a TCP ABORT command to the O/S kernel which should result in a TCP_RST packet being sent to the peer.
abort() - Static method in class akka.io.TcpMessage
An abort operation will not flush pending writes and will issue a TCP ABORT command to the O/S kernel which should result in a TCP_RST packet being sent to the peer.
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
 
AbstractExtensionId<T extends Extension> - Class in akka.actor
Java API for ExtensionId
AbstractExtensionId() - Constructor for class akka.actor.AbstractExtensionId
 
AbstractFSM<S,D> - Class in akka.actor
Java API: compatible with lambda expressions
AbstractFSM() - Constructor for class akka.actor.AbstractFSM
 
AbstractFSM$ - Class in akka.actor
Java API: compatible with lambda expressions
AbstractFSM$() - Constructor for class akka.actor.AbstractFSM$
 
AbstractLoggingActor - Class in akka.actor
Java API: compatible with lambda expressions
AbstractLoggingActor() - Constructor for class akka.actor.AbstractLoggingActor
 
AbstractLoggingFSM<S,D> - Class in akka.actor
Java API: compatible with lambda expressions
AbstractLoggingFSM() - Constructor for class akka.actor.AbstractLoggingFSM
 
AbstractNodeQueue<T> - Class in akka.dispatch
Lock-free MPSC linked queue implementation based on Dmitriy Vyukov's non-intrusive MPSC queue: http://www.1024cores.net/home/lock-free-algorithms/queues/non-intrusive-mpsc-node-based-queue
AbstractNodeQueue() - Constructor for class akka.dispatch.AbstractNodeQueue
 
AbstractNodeQueue.Node<T> - Class in akka.dispatch
 
AbstractNodeQueue.Node() - Constructor for class akka.dispatch.AbstractNodeQueue.Node
 
AbstractNodeQueue.Node(T) - Constructor for class akka.dispatch.AbstractNodeQueue.Node
 
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
 
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
 
Actor - Interface in akka.actor
Actor base trait that should be extended by or mixed to create an Actor with the semantics of the 'Actor Model': http://en.wikipedia.org/wiki/Actor_model
actor(Function0<T>, ClassTag<T>, ActorRefFactory) - Method in interface akka.actor.dsl.Creators
Create an actor from the given thunk which must produce an Actor.
actor(String, Function0<T>, ClassTag<T>, ActorRefFactory) - Method in interface akka.actor.dsl.Creators
Create an actor from the given thunk which must produce an Actor.
actor(ActorRefFactory, String, Function0<T>, ClassTag<T>) - Method in interface akka.actor.dsl.Creators
Create an actor from the given thunk which must produce an Actor.
actor(ActorRefFactory, Function0<T>, ClassTag<T>) - Method in interface akka.actor.dsl.Creators
Create an actor with an automatically generated name from the given thunk which must produce an Actor.
actor() - Method in exception akka.actor.PostRestartException
 
actor() - Method in exception akka.actor.PreRestartException
 
actor() - Method in class akka.actor.Terminated
 
Actor$ - Class in akka.actor
 
Actor$() - Constructor for class akka.actor.Actor$
 
Actor.emptyBehavior$ - Class in akka.actor
emptyBehavior is a Receive-expression that matches no messages at all, ever.
Actor.emptyBehavior$() - Constructor for class akka.actor.Actor.emptyBehavior$
 
ActorCell$ - Class in akka.actor
Everything in here is completely Akka PRIVATE.
ActorCell$() - Constructor for class akka.actor.ActorCell$
 
actorClass() - Method in interface akka.actor.IndirectActorProducer
This method is used by Props to determine the type of actor which will be created.
actorClass() - Method in class akka.actor.Props
Obtain an upper-bound approximation of the actor class which is going to be created by these Props.
ActorClassification - Interface in akka.event
Maps ActorRefs to ActorRefs to form an EventBus where ActorRefs can listen to other ActorRefs
ActorClassifier - Interface in akka.event
Can be mixed into an EventBus to specify that the Classifier type is ActorRef
ActorContext - Interface in akka.actor
The actor context - the view of the actor cell from the actor.
ActorDSL - Class in akka.actor
This object contains elements which make writing actors and related code more concise, e.g.
ActorDSL() - Constructor for class akka.actor.ActorDSL
 
ActorDSL$ - Class in akka.actor
This object contains elements which make writing actors and related code more concise, e.g.
ActorDSL$() - Constructor for class akka.actor.ActorDSL$
 
ActorDSL.Extension - Class in akka.actor
 
ActorDSL.Extension(ExtendedActorSystem) - Constructor for class akka.actor.ActorDSL.Extension
 
ActorDSL.Extension$ - Class in akka.actor
 
ActorDSL.Extension$() - Constructor for class akka.actor.ActorDSL.Extension$
 
ActorEventBus - Interface in akka.event
Represents an EventBus where the Subscriber type is ActorRef
ActorEventBus<E> - Class in akka.event.japi
See documentation for ActorClassification An EventBus where the Subscribers are ActorRefs and the Classifier is ActorRef Means that ActorRefs "listen" to other ActorRefs E is the Event type
ActorEventBus() - Constructor for class akka.event.japi.ActorEventBus
 
actorFactory() - Method in class akka.actor.ContextualTypedActorFactory
 
actorFactory() - Method in class akka.actor.TypedActorExtension
 
actorFactory() - Method in interface akka.actor.TypedActorFactory
Underlying dependency is to be able to create normal Actors
actorFor(ActorPath) - Method in interface akka.actor.ActorRefFactory
Look-up an actor by path; if it does not exist, returns a reference to the dead-letter mailbox of the ActorSystem.
actorFor(String) - Method in interface akka.actor.ActorRefFactory
Look-up an actor by path represented as string.
actorFor(Iterable<String>) - Method in interface akka.actor.ActorRefFactory
Look-up an actor by applying the given path elements, starting from the current context, where ".." signifies the parent of an actor.
actorFor(Iterable<String>) - Method in interface akka.actor.ActorRefFactory
Java API: Look-up an actor by applying the given path elements, starting from the current context, where ".." signifies the parent of an actor.
actorFor(ActorPath) - Method in interface akka.actor.ActorRefProvider
Create actor reference for a specified local or remote path.
actorFor(InternalActorRef, String) - Method in interface akka.actor.ActorRefProvider
Create actor reference for a specified local or remote path, which will be parsed using java.net.URI.
actorFor(InternalActorRef, Iterable<String>) - Method in interface akka.actor.ActorRefProvider
Create actor reference for the specified child path starting at the given starting point.
ActorIdentity - Class in akka.actor
Reply to Identify.
ActorIdentity(Object, Option<ActorRef>) - Constructor for class akka.actor.ActorIdentity
 
ActorIdentity$ - Class in akka.actor
 
ActorIdentity$() - Constructor for class akka.actor.ActorIdentity$
 
ActorInitializationException - Exception in akka.actor
An ActorInitializationException is thrown when the the initialization logic for an Actor fails.
ActorInitializationException(ActorRef, String, Throwable) - Constructor for exception akka.actor.ActorInitializationException
 
ActorInitializationException$ - Class in akka.actor
 
ActorInitializationException$() - Constructor for class akka.actor.ActorInitializationException$
 
ActorInterruptedException - Exception in akka.actor
When an InterruptedException is thrown inside an Actor, it is wrapped as an ActorInterruptedException as to avoid cascading interrupts to other threads than the originally interrupted one.
ActorKilledException - Exception in akka.actor
ActorKilledException is thrown when an Actor receives the Kill message
ActorKilledException$ - Class in akka.actor
 
ActorKilledException$() - Constructor for class akka.actor.ActorKilledException$
 
ActorLogging - Interface in akka.actor
Scala API: Mix in ActorLogging into your Actor to easily obtain a reference to a logger, which is available under the name "log".
ActorNotFound - Exception in akka.actor
When ActorSelection.resolveOne(akka.util.Timeout) can't identify the actor the Future is completed with this failure.
ActorNotFound(ActorSelection) - Constructor for exception akka.actor.ActorNotFound
 
ActorNotFound$ - Class in akka.actor
 
ActorNotFound$() - Constructor for class akka.actor.ActorNotFound$
 
actorOf(Props) - Method in interface akka.actor.ActorRefFactory
Create new actor as child of this context and give it an automatically generated name (currently similar to base64-encoded integer count, reversed and with “$” prepended, may change in the future).
actorOf(Props, String) - Method in interface akka.actor.ActorRefFactory
Create new actor as child of this context with the given name, which must not be null, empty or start with “$”.
actorOf(ActorSystemImpl, Props, InternalActorRef, ActorPath, boolean, Option<Deploy>, boolean, boolean) - Method in interface akka.actor.ActorRefProvider
Actor factory with create-only semantics: will create an actor as described by props with the given supervisor and path (may be different in case of remote supervision).
ActorPath - Interface in akka.actor
Actor path is a unique path to an actor that shows the creation path up through the actor tree to the root actor.
ActorPath$ - Class in akka.actor
 
ActorPath$() - Constructor for class akka.actor.ActorPath$
 
ActorPathExtractor - Class in akka.actor
Given an ActorPath it returns the Address and the path elements if the path is well-formed
ActorPathExtractor() - Constructor for class akka.actor.ActorPathExtractor
 
ActorPathExtractor$ - Class in akka.actor
Given an ActorPath it returns the Address and the path elements if the path is well-formed
ActorPathExtractor$() - Constructor for class akka.actor.ActorPathExtractor$
 
actorProps() - Method in class akka.actor.TypedProps
Returns the akka.actor.Props representation of this TypedProps
ActorRef - Class in akka.actor
Immutable and serializable handle to an actor, which may or may not reside on the local host or inside the same ActorSystem.
ActorRef() - Constructor for class akka.actor.ActorRef
 
actorRef() - Method in class akka.actor.FSM.SubscribeTransitionCallBack
 
actorRef() - Method in class akka.actor.FSM.UnsubscribeTransitionCallBack
 
actorRef() - Method in class akka.pattern.AskableActorRef
 
ActorRef$ - Class in akka.actor
 
ActorRef$() - Constructor for class akka.actor.ActorRef$
 
ActorRefFactory - Interface in akka.actor
Interface implemented by ActorSystem and ActorContext, the only two places from which you can get fresh actors.
ActorRefProvider - Interface in akka.actor
Interface for all ActorRef providers to implement.
ActorRefRoutee - Class in akka.routing
Routee that sends the messages to an ActorRef.
ActorRefRoutee(ActorRef) - Constructor for class akka.routing.ActorRefRoutee
 
ActorRefRoutee$ - Class in akka.routing
 
ActorRefRoutee$() - Constructor for class akka.routing.ActorRefRoutee$
 
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
 
ActorSelectionMessage$() - Constructor for class akka.actor.ActorSelectionMessage$
 
ActorSelectionRoutee - Class in akka.routing
Routee that sends the messages to an ActorSelection.
ActorSelectionRoutee(ActorSelection) - Constructor for class akka.routing.ActorSelectionRoutee
 
ActorSelectionRoutee$ - Class in akka.routing
 
ActorSelectionRoutee$() - Constructor for class akka.routing.ActorSelectionRoutee$
 
ActorSystem - Class in akka.actor
An actor system is a hierarchical group of actors which share common configuration, e.g.
ActorSystem() - Constructor for class akka.actor.ActorSystem
 
ActorSystem$ - Class in akka.actor
 
ActorSystem$() - Constructor for class akka.actor.ActorSystem$
 
ActorSystem.Settings - Class in akka.actor
Settings are the overall ActorSystem Settings which also provides a convenient access to the Config object.
ActorSystem.Settings(ClassLoader, Config, String) - Constructor for class akka.actor.ActorSystem.Settings
 
add(T) - Method in class akka.dispatch.AbstractNodeQueue
 
add(T) - Method in class akka.routing.ConsistentHash
Java API: Adds a node to the node ring.
addLogger(akka.actor.ActorSystemImpl, Class<? extends Actor>, Logging.LogLevel, String) - Method in interface akka.event.LoggingBus
INTERNAL API
AddLoggingReceive() - Method in class akka.actor.ActorSystem.Settings
 
addNode(AbstractNodeQueue.Node<T>) - Method in class akka.dispatch.AbstractNodeQueue
 
address() - Method in interface akka.actor.ActorPath
The Address under which this path can be reached; walks up the tree to the RootActorPath.
Address - Class in akka.actor
The address specifies the physical location under which an Actor can be reached.
Address(String, String) - Constructor for class akka.actor.Address
 
Address(String, String, String, int) - Constructor for class akka.actor.Address
 
address() - Method in class akka.actor.ChildActorPath
 
address() - Method in class akka.actor.RootActorPath
 
Address$ - Class in akka.actor
Returns a String representation formatted as:
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() - Method in class akka.actor.Terminated
 
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$
 
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.Router
Create a new instance with one more routee and the same RoutingLogic.
addRoutee(ActorRef) - Method in class akka.routing.Router
Create a new instance with one more ActorRefRoutee for the specified ActorRef and the same RoutingLogic.
addRoutee(ActorSelection) - Method in class akka.routing.Router
Create a new instance with one more ActorSelectionRoutee for the specified ActorSelection and the same RoutingLogic.
AddRoutee$ - Class in akka.routing
 
AddRoutee$() - Constructor for class akka.routing.AddRoutee$
 
addToCache(Seq<Tuple2<Object, Set<Object>>>) - Method in interface akka.event.SubchannelClassification
 
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.
afterConnect(Socket) - Method in class akka.io.Inet.SO$.SendBufferSize
 
afterConnect(Socket) - Method in class akka.io.Inet.SO$.TrafficClass
 
afterConnect(Socket) - Method in interface akka.io.Inet.SocketOption
Action to be taken for this option after connect returned (i.e.
afterConnect(Socket) - Method in class akka.io.Tcp.SO$.KeepAlive
 
afterConnect(Socket) - Method in class akka.io.Tcp.SO$.OOBInline
 
afterConnect(Socket) - Method in class akka.io.Tcp.SO$.TcpNoDelay
 
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.pf - package akka.japi.pf
 
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
 
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
 
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
The ActorPath of the anchor actor.
anyEvent(FI.Apply2<Object, D, FSM.State<S, D>>) - Method in class akka.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches on any type of event.
append(Tcp.WriteCommand) - Method in class akka.io.Tcp.SimpleWriteCommand
Java API: appends this command with another WriteCommand to form a CompoundWrite.
append(ByteString) - Method in class akka.util.ByteStringBuilder
Java API: append a ByteString to this builder.
apply(Object) - Method in class akka.actor.Actor.emptyBehavior$
 
apply(ActorRef, String) - 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(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(Class<?>, Seq<Object>) - Method in interface akka.actor.IndirectActorProducer
 
apply(ClassTag<T>) - Method in class akka.actor.Props$
Scala API: Returns a Props that has default values except for "creator" which will be a function that creates an instance of the supplied type using the default constructor.
apply(Function0<T>, ClassTag<T>) - Method in class akka.actor.Props$
Scala API: Returns a Props that has default values except for "creator" which will be a function that creates an instance using the supplied thunk.
apply(Class<?>, Seq<Object>) - Method in class akka.actor.Props$
Scala API: create a Props given a class and its constructor arguments.
apply(ClassTag<T>) - Static method in class akka.actor.Props
Scala API: Returns a Props that has default values except for "creator" which will be a function that creates an instance of the supplied type using the default constructor.
apply(Function0<T>, ClassTag<T>) - Static method in class akka.actor.Props
Scala API: Returns a Props that has default values except for "creator" which will be a function that creates an instance using the supplied thunk.
apply(Class<?>, Seq<Object>) - Static method in class akka.actor.Props
Scala API: create a Props given a class and its constructor arguments.
apply(ActorRef) - 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(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(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(T, LogSource<T>) - Method in interface akka.event.LogSource
Convenience converter access: given an implicit LogSource, generate the string representation and originating class.
apply(T, ActorSystem, LogSource<T>) - Method in interface akka.event.LogSource
Convenience converter access: given an implicit LogSource and ActorSystem, generate the string representation and originating class.
apply(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(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(I) - Method in interface akka.japi.pf.FI.Apply
The application to perform.
apply(I1, I2) - Method in interface akka.japi.pf.FI.Apply2
The application to perform.
apply(I) - Method in interface akka.japi.pf.FI.UnitApply
The application to perform.
apply(I1, I2) - Method in interface akka.japi.pf.FI.UnitApply2
The application to perform.
apply(I1, I2, I3) - Method in interface akka.japi.pf.FI.UnitApply3
The application to perform.
apply() - Method in interface akka.japi.pf.FI.UnitApplyVoid
The application to perform.
apply(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, String) - Method in class akka.pattern.PromiseActorRef$
 
apply() - Method in class akka.routing.BalancingRoutingLogic$
 
apply(Iterable<ActorRef>) - Method in class akka.routing.BroadcastRouter$
Creates a new BroadcastRouter, routing to the specified routees
apply(Iterable<ActorRef>) - Static method in class akka.routing.BroadcastRouter
Creates a new BroadcastRouter, routing to the specified routees
apply() - Method in class akka.routing.BroadcastRoutingLogic$
 
apply() - Static method in class akka.routing.BroadcastRoutingLogic
 
apply(Iterable<T>, int, ClassTag<T>) - Method in class akka.routing.ConsistentHash$
 
apply(Iterable<T>, int, ClassTag<T>) - Static method in class akka.routing.ConsistentHash
 
apply(Iterable<ActorRef>) - Method in class akka.routing.ConsistentHashingRouter$
Creates a new ConsistentHashingRouter, routing to the specified routees
apply(Iterable<ActorRef>) - Static method in class akka.routing.ConsistentHashingRouter
Creates a new ConsistentHashingRouter, routing to the specified routees
apply(Object) - Method in class akka.routing.ConsistentHashingRouter.emptyConsistentHashMapping$
 
apply(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(Iterable<ActorRef>) - Method in class akka.routing.RandomRouter$
Creates a new RandomRouter, routing to the specified routees
apply(Iterable<ActorRef>) - Static method in class akka.routing.RandomRouter
Creates a new RandomRouter, routing to the specified routees
apply() - Method in class akka.routing.RandomRoutingLogic$
 
apply() - Static method in class akka.routing.RandomRoutingLogic
 
apply(Iterable<ActorRef>) - Method in class akka.routing.RoundRobinRouter$
Creates a new RoundRobinRouter, routing to the specified routees
apply(Iterable<ActorRef>) - Static method in class akka.routing.RoundRobinRouter
Creates a new RoundRobinRouter, routing to the specified routees
apply() - Method in class akka.routing.RoundRobinRoutingLogic$
 
apply() - Static method in class akka.routing.RoundRobinRoutingLogic
 
apply(Iterable<ActorRef>, FiniteDuration) - Method in class akka.routing.ScatterGatherFirstCompletedRouter$
Creates a new ScatterGatherFirstCompletedRouter, routing to the specified routees, timing out after the specified Duration
apply(Iterable<ActorRef>, FiniteDuration) - Static method in class akka.routing.ScatterGatherFirstCompletedRouter
Creates a new ScatterGatherFirstCompletedRouter, routing to the specified routees, timing out after the specified Duration
apply(Iterable<ActorRef>) - Method in class akka.routing.SmallestMailboxRouter$
Creates a new SmallestMailboxRouter, routing to the specified routees
apply(Iterable<ActorRef>) - Static method in class akka.routing.SmallestMailboxRouter
Creates a new SmallestMailboxRouter, routing to the specified routees
apply() - Method in class akka.routing.SmallestMailboxRoutingLogic$
 
apply() - Static method in class akka.routing.SmallestMailboxRoutingLogic
 
apply(Class<?>) - Method in class akka.util.BoxedType$
 
apply(Class<?>) - Static method in class akka.util.BoxedType
 
apply(byte[]) - Method in class akka.util.ByteIterator.ByteArrayIterator$
 
apply(byte[], int, int) - Method in class akka.util.ByteIterator.ByteArrayIterator$
 
apply(LinearSeq<ByteIterator.ByteArrayIterator>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator$
 
apply(byte[]) - Method in class akka.util.ByteString$
Creates a new ByteString by copying a byte array.
apply(Seq<Object>) - Method in class akka.util.ByteString$
Creates a new ByteString by copying bytes.
apply(Seq<T>, Integral<T>) - Method in class akka.util.ByteString$
Creates a new ByteString by converting from integral numbers to bytes.
apply(ByteBuffer) - Method in class akka.util.ByteString$
Creates a new ByteString by copying bytes from a ByteBuffer.
apply(String) - Method in class akka.util.ByteString$
Creates a new ByteString by encoding a String as UTF-8.
apply(String, String) - Method in class akka.util.ByteString$
Creates a new ByteString by encoding a String with a charset.
apply(int) - Method in class akka.util.ByteString
 
apply(byte[]) - Method in class akka.util.ByteString.ByteString1$
 
apply(byte[], int, int) - Method in class akka.util.ByteString.ByteString1$
 
apply(int) - Method in class akka.util.ByteString.ByteString1
 
apply(byte[]) - Method in class akka.util.ByteString.ByteString1C$
 
apply(int) - Method in class akka.util.ByteString.ByteString1C
 
apply(Vector<ByteString.ByteString1>) - Method in class akka.util.ByteString.ByteStrings$
 
apply(Vector<ByteString.ByteString1>, int) - Method in class akka.util.ByteString.ByteStrings$
 
apply(ByteString.ByteString1, ByteString.ByteString1) - Method in class akka.util.ByteString.ByteStrings$
 
apply(ByteString.ByteString1, ByteString.ByteStrings) - Method in class akka.util.ByteString.ByteStrings$
 
apply(ByteString.ByteStrings, ByteString.ByteString1) - Method in class akka.util.ByteString.ByteStrings$
 
apply(ByteString.ByteStrings, ByteString.ByteStrings) - Method in class akka.util.ByteString.ByteStrings$
 
apply(int) - Method in class akka.util.ByteString.ByteStrings
 
apply(int) - Method in class akka.util.Collections.EmptyImmutableSeq$
 
apply(From) - Method in class akka.util.Collections.PartialImmutableValuesIterable
 
apply(byte[]) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by copying a byte array.
apply(Seq<Object>) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by copying bytes.
apply(Seq<T>, Integral<T>) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by converting from integral numbers to bytes.
apply(ByteBuffer) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by copying bytes from a ByteBuffer.
apply(String) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by encoding a String as UTF-8.
apply(String, String) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by encoding a String with a charset.
apply(byte[]) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by copying a byte array.
apply(Seq<Object>) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by copying bytes.
apply(Seq<T>, Integral<T>) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by converting from integral numbers to bytes.
apply(ByteBuffer) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by copying bytes from a ByteBuffer.
apply(String) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by encoding a String as UTF-8.
apply(String, String) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by encoding a String with a charset.
apply(int, ExecutionContext) - Method in class akka.util.SerializedSuspendableExecutionContext$
 
apply(long) - Method in class akka.util.Timeout$
Construct a Timeout from the given number of milliseconds.
apply(long, TimeUnit) - Method in class akka.util.Timeout$
Construct a Timeout from the given time unit and factor.
apply(long) - Static method in class akka.util.Timeout
Construct a Timeout from the given number of milliseconds.
apply(long, TimeUnit) - Static method in class akka.util.Timeout
Construct a Timeout from the given time unit and factor.
apply() - Method in class akka.util.WildcardTree$
 
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
 
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) - Method in class akka.pattern.AskableActorSelection
 
ask(ActorRef) - Method in interface akka.pattern.AskSupport
Import this implicit conversion to gain ? and ask methods on ActorRef, which will defer to the ask(actorRef, message)(timeout) method defined here.
ask(ActorRef, Object, Timeout) - Method in interface akka.pattern.AskSupport
Sends a message asynchronously and returns a Future holding the eventual reply message; this means that the target actor needs to send the result to the sender reference provided.
ask(ActorSelection) - Method in interface akka.pattern.AskSupport
Import this implicit conversion to gain ? and ask methods on ActorSelection, which will defer to the ask(actorSelection, message)(timeout) method defined here.
ask(ActorSelection, Object, Timeout) - Method in interface akka.pattern.AskSupport
Sends a message asynchronously and returns a Future holding the eventual reply message; this means that the target actor needs to send the result to the sender reference provided.
ask(ActorRef, Object, Timeout) - Method in class akka.pattern.Patterns$
Java API for akka.pattern.ask: Sends a message asynchronously and returns a Future holding the eventual reply message; this means that the target actor needs to send the result to the sender reference provided.
ask(ActorRef, Object, long) - Method in class akka.pattern.Patterns$
Java API for akka.pattern.ask: Sends a message asynchronously and returns a Future holding the eventual reply message; this means that the target actor needs to send the result to the sender reference provided.
ask(ActorSelection, Object, Timeout) - Method in class akka.pattern.Patterns$
Java API for akka.pattern.ask: Sends a message asynchronously and returns a Future holding the eventual reply message; this means that the target ActorSelection needs to send the result to the sender reference provided.
ask(ActorSelection, Object, long) - Method in class akka.pattern.Patterns$
Java API for akka.pattern.ask: Sends a message asynchronously and returns a Future holding the eventual reply message; this means that the target ActorSelection needs to send the result to the sender reference provided.
ask(ActorRef, Object, Timeout) - Static method in class akka.pattern.Patterns
Java API for akka.pattern.ask: Sends a message asynchronously and returns a Future holding the eventual reply message; this means that the target actor needs to send the result to the sender reference provided.
ask(ActorRef, Object, long) - Static method in class akka.pattern.Patterns
Java API for akka.pattern.ask: Sends a message asynchronously and returns a Future holding the eventual reply message; this means that the target actor needs to send the result to the sender reference provided.
ask(ActorSelection, Object, Timeout) - Static method in class akka.pattern.Patterns
Java API for akka.pattern.ask: Sends a message asynchronously and returns a Future holding the eventual reply message; this means that the target ActorSelection needs to send the result to the sender reference provided.
ask(ActorSelection, Object, long) - Static method in class akka.pattern.Patterns
Java API for akka.pattern.ask: Sends a message asynchronously and returns a Future holding the eventual reply message; this means that the target ActorSelection needs to send the result to the sender reference provided.
AskableActorRef - Class in akka.pattern
 
AskableActorRef(ActorRef) - Constructor for class akka.pattern.AskableActorRef
 
AskableActorRef$ - Class in akka.pattern
 
AskableActorRef$() - Constructor for class akka.pattern.AskableActorRef$
 
AskableActorSelection - Class in akka.pattern
 
AskableActorSelection(ActorSelection) - Constructor for class akka.pattern.AskableActorSelection
 
AskableActorSelection$ - Class in akka.pattern
 
AskableActorSelection$() - Constructor for class akka.pattern.AskableActorSelection$
 
AskSupport - Interface in akka.pattern
This object contains implementation details of the “ask” pattern.
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
 
atFullThrottle() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinPool
 
attach(akka.actor.ActorCell) - Method in class akka.dispatch.MessageDispatcher
Attaches the specified actor instance to this dispatcher, which includes scheduling it to run for the first time (Create() is expected to have been enqueued by the ActorCell upon mailbox creation).
awaitTermination(Duration) - Method in class akka.actor.ActorSystem
Block current thread until the system has been shutdown, or the specified timeout has elapsed.
awaitTermination() - Method in class akka.actor.ActorSystem
Block current thread until the system has been shutdown.
awaitTermination(long, TimeUnit) - Method in interface akka.dispatch.ExecutorServiceDelegate
 

B

backlog() - Method in class akka.io.Tcp.Bind
 
backoff(int, int) - Method in class akka.routing.DefaultResizer
Computes a proposed negative (or zero) capacity delta using the configured backoffThreshold and backoffRate
backoffRate() - Method in class akka.routing.DefaultResizer
Fraction of routees to be removed when the resizer reaches the backoffThreshold.
backoffThreshold() - Method in class akka.routing.DefaultResizer
Minimum fraction of busy routees before backing off.
BalancingDispatcher - Class in akka.dispatch
An executor based event driven dispatcher which will try to redistribute work from busy actors to idle actors.
BalancingDispatcher(MessageDispatcherConfigurator, String, int, Duration, MailboxType, ExecutorServiceFactoryProvider, FiniteDuration, boolean) - Constructor for class akka.dispatch.BalancingDispatcher
 
BalancingDispatcherConfigurator - Class in akka.dispatch
Configurator for creating BalancingDispatcher.
BalancingDispatcherConfigurator(Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.BalancingDispatcherConfigurator
 
BalancingDispatcherConfigurator$ - Class in akka.dispatch
INTERNAL API
BalancingDispatcherConfigurator$() - Constructor for class akka.dispatch.BalancingDispatcherConfigurator$
 
BalancingPool - Class in akka.routing
A router pool that will try to redistribute work from busy routees to idle routees.
BalancingPool(int, SupervisorStrategy, String) - Constructor for class akka.routing.BalancingPool
 
BalancingPool(Config) - Constructor for class akka.routing.BalancingPool
 
BalancingPool(int) - Constructor for class akka.routing.BalancingPool
Java API
BalancingPool$ - Class in akka.routing
 
BalancingPool$() - Constructor for class akka.routing.BalancingPool$
 
BalancingRoutingLogic$ - Class in akka.routing
INTERNAL API
BalancingRoutingLogic$() - Constructor for class akka.routing.BalancingRoutingLogic$
 
base64(long, StringBuilder) - Method in class akka.util.Helpers$
 
base64(long, StringBuilder) - Static method in class akka.util.Helpers
 
base64chars() - Method in class akka.util.Helpers$
 
base64chars() - Static method in class akka.util.Helpers
 
BatchAcceptLimit() - Method in class akka.io.TcpExt.Settings
 
batchSize() - Method in class akka.io.Tcp.ResumeAccepting
 
become(PartialFunction<Object, BoxedUnit>) - Method in interface akka.actor.ActorContext
Changes the Actor's behavior to become the new 'Receive' (PartialFunction[Any, Unit]) handler.
become(PartialFunction<Object, BoxedUnit>, boolean) - Method in interface akka.actor.ActorContext
Changes the Actor's behavior to become the new 'Receive' (PartialFunction[Any, Unit]) handler.
become(PartialFunction<Object, BoxedUnit>) - Method in interface akka.actor.dsl.Creators.Act
Replace the behavior at the top of the behavior stack for this actor.
become(Procedure<Object>) - Method in interface akka.actor.UntypedActorContext
Changes the Actor's behavior to become the new 'Procedure' handler.
become(Procedure<Object>, boolean) - Method in interface akka.actor.UntypedActorContext
Changes the Actor's behavior to become the new 'Procedure' handler.
becomeStacked(PartialFunction<Object, BoxedUnit>) - Method in interface akka.actor.dsl.Creators.Act
Add the given behavior on top of the behavior stack for this actor.
beforeConnect(Socket) - Method in class akka.io.Inet.SO$.ReceiveBufferSize
 
beforeConnect(Socket) - Method in class akka.io.Inet.SO$.ReuseAddress
 
beforeConnect(Socket) - Method in interface akka.io.Inet.SocketOption
Action to be taken for this option before calling connect()
beforeDatagramBind(DatagramSocket) - Method in class akka.io.Inet.SO$.ReceiveBufferSize
 
beforeDatagramBind(DatagramSocket) - Method in class akka.io.Inet.SO$.ReuseAddress
 
beforeDatagramBind(DatagramSocket) - Method in interface akka.io.Inet.SocketOption
 
beforeDatagramBind(DatagramSocket) - Method in class akka.io.Udp.SO$.Broadcast
 
beforeServerSocketBind(ServerSocket) - Method in class akka.io.Inet.SO$.ReceiveBufferSize
 
beforeServerSocketBind(ServerSocket) - Method in class akka.io.Inet.SO$.ReuseAddress
 
beforeServerSocketBind(ServerSocket) - Method in interface akka.io.Inet.SocketOption
 
bind(ActorRef, InetSocketAddress, int, Iterable<Inet.SocketOption>, boolean) - Method in class akka.io.TcpMessage$
The Bind message is send to the TCP manager actor, which is obtained via TcpExt.getManager() in order to bind to a listening socket.
bind(ActorRef, InetSocketAddress, int) - Method in class akka.io.TcpMessage$
Open a listening socket without specifying options.
bind(ActorRef, InetSocketAddress, int, Iterable<Inet.SocketOption>, boolean) - Static method in class akka.io.TcpMessage
The Bind message is send to the TCP manager actor, which is obtained via TcpExt.getManager() in order to bind to a listening socket.
bind(ActorRef, InetSocketAddress, int) - Static method in class akka.io.TcpMessage
Open a listening socket without specifying options.
bind(ActorRef, InetSocketAddress, Iterable<Inet.SocketOption>) - Method in class akka.io.UdpMessage$
Send this message to the UdpExt.manager() in order to bind to the given local port (or an automatically assigned one if the port number is zero).
bind(ActorRef, InetSocketAddress) - Method in class akka.io.UdpMessage$
Bind without specifying options.
bind(ActorRef, InetSocketAddress, Iterable<Inet.SocketOption>) - Static method in class akka.io.UdpMessage
Send this message to the UdpExt.manager() in order to bind to the given local port (or an automatically assigned one if the port number is zero).
bind(ActorRef, InetSocketAddress) - Static method in class akka.io.UdpMessage
Bind without specifying options.
bindings() - Method in class akka.serialization.Serialization
bindings is a Seq of tuple representing the mapping from Class to Serializer.
boss() - Method in class akka.actor.ActorDSL.Extension
 
BoundedBlockingQueue<E> - Class in akka.util
BoundedBlockingQueue wraps any Queue and turns the result into a BlockingQueue with a limited capacity.
BoundedBlockingQueue(int, Queue<E>) - Constructor for class akka.util.BoundedBlockingQueue
 
BoundedDequeBasedMailbox - Class in akka.dispatch
BoundedDequeBasedMailbox is an bounded MailboxType, backed by a Deque.
BoundedDequeBasedMailbox(int, FiniteDuration) - Constructor for class akka.dispatch.BoundedDequeBasedMailbox
 
BoundedDequeBasedMailbox(ActorSystem.Settings, Config) - Constructor for class akka.dispatch.BoundedDequeBasedMailbox
 
BoundedDequeBasedMailbox$ - Class in akka.dispatch
 
BoundedDequeBasedMailbox$() - Constructor for class akka.dispatch.BoundedDequeBasedMailbox$
 
BoundedDequeBasedMailbox.MessageQueue - Class in akka.dispatch
 
BoundedDequeBasedMailbox.MessageQueue(int, FiniteDuration) - Constructor for class akka.dispatch.BoundedDequeBasedMailbox.MessageQueue
 
BoundedDequeBasedMessageQueue - Interface in akka.dispatch
BoundedMessageQueueSemantics adds bounded semantics to a DequeBasedMessageQueue, i.e.
BoundedDequeBasedMessageQueueSemantics - Interface in akka.dispatch
 
BoundedMailbox - Class in akka.dispatch
BoundedMailbox is the default bounded MailboxType used by Akka Actors.
BoundedMailbox(int, FiniteDuration) - Constructor for class akka.dispatch.BoundedMailbox
 
BoundedMailbox(ActorSystem.Settings, Config) - Constructor for class akka.dispatch.BoundedMailbox
 
BoundedMailbox$ - Class in akka.dispatch
 
BoundedMailbox$() - Constructor for class akka.dispatch.BoundedMailbox$
 
BoundedMailbox.MessageQueue - Class in akka.dispatch
 
BoundedMailbox.MessageQueue(int, FiniteDuration) - Constructor for class akka.dispatch.BoundedMailbox.MessageQueue
 
BoundedMessageQueueSemantics - Interface in akka.dispatch
BoundedMessageQueueSemantics adds bounded semantics to a QueueBasedMessageQueue, i.e.
BoundedPriorityMailbox - Class in akka.dispatch
BoundedPriorityMailbox is a bounded mailbox that allows for prioritization of its contents.
BoundedPriorityMailbox(Comparator<Envelope>, int, Duration) - Constructor for class akka.dispatch.BoundedPriorityMailbox
 
BoundedPriorityMailbox$ - Class in akka.dispatch
 
BoundedPriorityMailbox$() - Constructor for class akka.dispatch.BoundedPriorityMailbox$
 
BoundedPriorityMailbox.MessageQueue - Class in akka.dispatch
 
BoundedPriorityMailbox.MessageQueue(int, Comparator<Envelope>, Duration) - Constructor for class akka.dispatch.BoundedPriorityMailbox.MessageQueue
 
BoundedQueueBasedMessageQueue - Interface in akka.dispatch
 
BoxedType - Class in akka.util
 
BoxedType() - Constructor for class akka.util.BoxedType
 
BoxedType$ - Class in akka.util
 
BoxedType$() - Constructor for class akka.util.BoxedType$
 
broadcast(boolean) - Method in class akka.io.UdpSO$
Inet.SocketOption to set the SO_BROADCAST option
broadcast(boolean) - Static method in class akka.io.UdpSO
Inet.SocketOption to set the SO_BROADCAST option
Broadcast - Class in akka.routing
Used to broadcast a message to all routees in a router; only the contained message will be forwarded, i.e.
Broadcast(Object) - Constructor for class akka.routing.Broadcast
 
Broadcast$ - Class in akka.routing
 
Broadcast$() - Constructor for class akka.routing.Broadcast$
 
BroadcastGroup - Class in akka.routing
A router group that broadcasts a message to all its routees.
BroadcastGroup(Iterable<String>, String) - Constructor for class akka.routing.BroadcastGroup
 
BroadcastGroup(Config) - Constructor for class akka.routing.BroadcastGroup
 
BroadcastGroup(Iterable<String>) - Constructor for class akka.routing.BroadcastGroup
Java API
BroadcastGroup$ - Class in akka.routing
 
BroadcastGroup$() - Constructor for class akka.routing.BroadcastGroup$
 
BroadcastPool - Class in akka.routing
A router pool that broadcasts a message to all its routees.
BroadcastPool(int, Option<Resizer>, SupervisorStrategy, String, boolean) - Constructor for class akka.routing.BroadcastPool
 
BroadcastPool(Config) - Constructor for class akka.routing.BroadcastPool
 
BroadcastPool(int) - Constructor for class akka.routing.BroadcastPool
Java API
BroadcastPool$ - Class in akka.routing
 
BroadcastPool$() - Constructor for class akka.routing.BroadcastPool$
 
BroadcastRouter - Class in akka.routing
A Router that uses broadcasts a message to all its connections.
BroadcastRouter(int, Iterable<String>, Option<Resizer>, String, SupervisorStrategy) - Constructor for class akka.routing.BroadcastRouter
 
BroadcastRouter(int) - Constructor for class akka.routing.BroadcastRouter
Java API: Constructor that sets nrOfInstances to be created.
BroadcastRouter(Iterable<String>) - Constructor for class akka.routing.BroadcastRouter
Java API: Constructor that sets the routees to be used.
BroadcastRouter(Resizer) - Constructor for class akka.routing.BroadcastRouter
Java API: Constructor that sets the resizer to be used.
BroadcastRouter$ - Class in akka.routing
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
BroadcastRouter$() - Constructor for class akka.routing.BroadcastRouter$
 
BroadcastRoutingLogic - Class in akka.routing
Broadcasts a message to all its routees.
BroadcastRoutingLogic() - Constructor for class akka.routing.BroadcastRoutingLogic
 
BroadcastRoutingLogic$ - Class in akka.routing
 
BroadcastRoutingLogic$() - Constructor for class akka.routing.BroadcastRoutingLogic$
 
BufferPool - Interface in akka.io
 
bufferPool() - Method in class akka.io.TcpExt
 
bufferPool() - Method in class akka.io.UdpConnectedExt
 
bufferPool() - Method in class akka.io.UdpExt
INTERNAL API
build() - Method in class akka.japi.pf.FSMStateFunctionBuilder
Build a PartialFunction from this builder.
build() - Method in class akka.japi.pf.FSMStopBuilder
Build a PartialFunction from this builder.
build() - Method in class akka.japi.pf.FSMTransitionHandlerBuilder
Build a PartialFunction from this builder.
bus() - Method in class akka.event.BusLogging
 
bus() - Method in class akka.event.Logging.InitializeLogger
 
BusLogging - Class in akka.event
LoggingAdapter that publishes Logging.LogEvent to event stream.
BusLogging(LoggingBus, String, Class<?>) - Constructor for class akka.event.BusLogging
 
ByteArraySerializer - Class in akka.serialization
This is a special Serializer that Serializes and deserializes byte arrays only, (just returns the byte array unchanged/uncopied)
ByteArraySerializer() - Constructor for class akka.serialization.ByteArraySerializer
 
ByteIterator - Class in akka.util
An iterator over a ByteString.
ByteIterator() - Constructor for class akka.util.ByteIterator
 
ByteIterator$ - Class in akka.util
 
ByteIterator$() - Constructor for class akka.util.ByteIterator$
 
ByteIterator.ByteArrayIterator - Class in akka.util
 
ByteIterator.ByteArrayIterator$ - Class in akka.util
 
ByteIterator.ByteArrayIterator$() - Constructor for class akka.util.ByteIterator.ByteArrayIterator$
 
ByteIterator.MultiByteArrayIterator - Class in akka.util
 
ByteIterator.MultiByteArrayIterator$ - Class in akka.util
 
ByteIterator.MultiByteArrayIterator$() - Constructor for class akka.util.ByteIterator.MultiByteArrayIterator$
 
ByteString - Class in akka.util
A rope-like immutable data structure containing bytes.
ByteString() - Constructor for class akka.util.ByteString
 
ByteString$ - Class in akka.util
 
ByteString$() - Constructor for class akka.util.ByteString$
 
ByteString.ByteString1 - Class in akka.util
An unfragmented ByteString.
ByteString.ByteString1$ - Class in akka.util
 
ByteString.ByteString1$() - Constructor for class akka.util.ByteString.ByteString1$
 
ByteString.ByteString1C - Class in akka.util
A compact (unsliced) and unfragmented ByteString, implementation of ByteString1C.
ByteString.ByteString1C$ - Class in akka.util
 
ByteString.ByteString1C$() - Constructor for class akka.util.ByteString.ByteString1C$
 
ByteString.ByteStrings - Class in akka.util
A ByteString with 2 or more fragments.
ByteString.ByteStrings$ - Class in akka.util
 
ByteString.ByteStrings$() - Constructor for class akka.util.ByteString.ByteStrings$
 
ByteStringBuilder - Class in akka.util
A mutable builder for efficiently creating a ByteString.
ByteStringBuilder() - Constructor for class akka.util.ByteStringBuilder
 
bytestrings() - Method in class akka.util.ByteString.ByteStrings
 

C

cache() - Method in interface akka.event.SubchannelClassification
 
cachingConfig() - Method in class akka.dispatch.Dispatchers
 
CachingConfig$ - Class in akka.dispatch
INTERNAL API
CachingConfig$() - Constructor for class akka.dispatch.CachingConfig$
 
callWithCircuitBreaker(Callable<Future<T>>) - Method in class akka.pattern.CircuitBreaker
Java API for CircuitBreaker.withCircuitBreaker(scala.Function0>)
callWithSyncCircuitBreaker(Callable<T>) - Method in class akka.pattern.CircuitBreaker
Java API for CircuitBreaker.withSyncCircuitBreaker(scala.Function0)
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.
cancelTimer(String) - Method in interface akka.actor.FSM
Cancel named timer, ensuring that the message is not subsequently delivered (no race).
capacity() - Method in class akka.dispatch.BoundedDequeBasedMailbox
 
capacity() - Method in class akka.dispatch.BoundedMailbox
 
capacity() - Method in class akka.dispatch.BoundedPriorityMailbox
 
capacity(IndexedSeq<Routee>) - Method in class akka.routing.DefaultResizer
Returns the overall desired change in resizer capacity.
CaseStatement$ - Class in akka.japi.pf
 
CaseStatement$() - Constructor for class akka.japi.pf.CaseStatement$
 
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.event.Logging.Error
 
cause() - Method in class akka.io.Tcp.ErrorClosed
 
change() - Method in class akka.routing.AdjustPoolSize
 
checkedApply(T) - Method in class akka.dispatch.Mapper
Override this method if you need to throw checked exceptions
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
 
ChildActorPath - Class in akka.actor
INTERNAL API
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$
 
children() - Method in interface akka.actor.ActorContext
Returns all supervised children; this method returns a view (i.e.
ChildrenContainer$ - Class in akka.actor.dungeon
INTERNAL API
ChildrenContainer$() - Constructor for class akka.actor.dungeon.ChildrenContainer$
 
ChildRestartStats - Class in akka.actor
ChildRestartStats is the statistics kept by every parent Actor for every child Actor and is used for SupervisorStrategies to know how to deal with problems that occur for the children.
ChildRestartStats(ActorRef, int, long) - Constructor for class akka.actor.ChildRestartStats
 
ChildRestartStats$ - Class in akka.actor
 
ChildRestartStats$() - Constructor for class akka.actor.ChildRestartStats$
 
CircuitBreaker - Class in akka.pattern
Provides circuit breaker functionality to provide stability when working with "dangerous" operations, e.g.
CircuitBreaker(Scheduler, int, FiniteDuration, FiniteDuration, ExecutionContext) - Constructor for class akka.pattern.CircuitBreaker
 
CircuitBreaker(ExecutionContext, Scheduler, int, FiniteDuration, FiniteDuration) - Constructor for class akka.pattern.CircuitBreaker
 
CircuitBreaker$ - Class in akka.pattern
Companion object providing factory methods for Circuit Breaker which runs callbacks in caller's thread
CircuitBreaker$() - Constructor for class akka.pattern.CircuitBreaker$
 
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(akka.event.EventBus.Event) - Method in interface akka.event.ActorClassification
Returns the Classifier associated with the specified Event
classify(Object) - Method in class akka.event.EventStream
 
classify(E) - Method in class akka.event.japi.ActorEventBus
Returns the Classifier associated with the given Event
classify(E) - Method in class akka.event.japi.LookupEventBus
Returns the Classifier associated with the given Event
classify(E) - Method in class akka.event.japi.SubchannelEventBus
Returns the Classifier associated with the given Event
classify(akka.event.EventBus.Event) - Method in interface akka.event.LookupClassification
Returns the Classifier associated with the given Event
classify(akka.event.EventBus.Event) - Method in interface akka.event.SubchannelClassification
Returns the Classifier associated with the given Event
classLoader() - Method in class akka.actor.DynamicAccess
This is the class loader to be used in those special cases where the other factory method are not applicable (e.g.
classLoader() - Method in class akka.actor.ReflectiveDynamicAccess
 
ClassLoaderObjectInputStream - Class in akka.util
ClassLoaderObjectInputStream tries to utilize the provided ClassLoader to load Classes and falls back to ObjectInputStreams resolver.
ClassLoaderObjectInputStream(ClassLoader, InputStream) - Constructor for class akka.util.ClassLoaderObjectInputStream
 
classTag(Class<T>) - Method in class akka.japi.Util$
Returns a ClassTag describing the provided Class.
classTag(Class<T>) - Static method in class akka.japi.Util
Returns a ClassTag describing the provided Class.
clazz() - Method in class akka.actor.Props
 
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
 
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
clearedList() - Method in class akka.util.ByteIterator.MultiByteArrayIterator$
 
clearMDC() - Method in interface akka.event.DiagnosticLoggingAdapter
Clear all entries in the MDC
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.
clone() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
clone() - Method in class akka.util.ByteIterator
 
clone() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
close() - Method in class akka.actor.LightArrayRevolverScheduler
 
close() - Method in class akka.io.TcpMessage$
A normal close operation will first flush pending writes and then close the socket.
close() - Static method in class akka.io.TcpMessage
A normal close operation will first flush pending writes and then close the socket.
Closed() - Method in class akka.dispatch.Mailbox$
 
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.UnboundedPriorityMailbox
 
Collections - Class in akka.util
INTERNAL API
Collections() - Constructor for class akka.util.Collections
 
Collections$ - Class in akka.util
INTERNAL API
Collections$() - Constructor for class akka.util.Collections$
 
Collections.EmptyImmutableSeq$ - Class in akka.util
 
Collections.EmptyImmutableSeq$() - Constructor for class akka.util.Collections.EmptyImmutableSeq$
 
Collections.PartialImmutableValuesIterable<From,To> - Class in akka.util
 
Collections.PartialImmutableValuesIterable() - Constructor for class akka.util.Collections.PartialImmutableValuesIterable
 
compact() - Method in class akka.util.ByteString.ByteString1
 
compact() - Method in class akka.util.ByteString.ByteStrings
 
compact() - Method in class akka.util.ByteString
Create a new ByteString with all contents compacted into a single, full byte array.
compact() - Method in class akka.util.CompactByteString
 
CompactByteString - Class in akka.util
A compact ByteString.
CompactByteString() - Constructor for class akka.util.CompactByteString
 
CompactByteString$ - Class in akka.util
 
CompactByteString$() - Constructor for class akka.util.CompactByteString$
 
compare(Envelope, Envelope) - Method in class akka.dispatch.PriorityGenerator
 
compare(ByteString, ByteString) - Method in class akka.util.ByteString.ByteStrings$
 
compareClassifiers(C, C) - Method in class akka.event.japi.ScanningEventBus
Provides a total ordering of Classifiers (think java.util.Comparator.compare)
compareClassifiers(akka.event.EventBus.Classifier, akka.event.EventBus.Classifier) - Method in interface akka.event.ScanningClassification
Provides a total ordering of Classifiers (think java.util.Comparator.compare)
compareIdentityHash(Object, Object) - Method in class akka.util.Helpers$
 
compareIdentityHash(Object, Object) - Static method in class akka.util.Helpers
 
compareSubscribers(ActorRef, ActorRef) - Method in interface akka.event.ActorEventBus
 
compareSubscribers(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(akka.event.EventBus.Subscriber, akka.event.EventBus.Subscriber) - Method in interface akka.event.LookupClassification
Provides a total ordering of Subscribers (think java.util.Comparator.compare)
compareSubscribers(akka.event.EventBus.Subscriber, akka.event.EventBus.Subscriber) - Method in interface akka.event.ScanningClassification
Provides a total ordering of Subscribers (think java.util.Comparator.compare)
compareTo(ActorRef) - Method in class akka.actor.ActorRef
Comparison takes path and the unique id of the actor cell into account.
compareTo(ActorPath) - Method in class akka.actor.ChildActorPath
 
compareTo(ActorPath) - Method in class akka.actor.RootActorPath
 
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 class akka.dispatch.MessageDispatcherConfigurator
 
config() - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
config() - Method in class akka.serialization.Serialization.Settings
 
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.
connect(InetSocketAddress, InetSocketAddress, Iterable<Inet.SocketOption>, FiniteDuration, boolean) - Method in class akka.io.TcpMessage$
The Connect message is sent to the TCP manager actor, which is obtained via TcpExt.getManager().
connect(InetSocketAddress) - Method in class akka.io.TcpMessage$
Connect to the given remoteAddress without binding to a local address and without specifying options.
connect(InetSocketAddress, InetSocketAddress, Iterable<Inet.SocketOption>, FiniteDuration, boolean) - Static method in class akka.io.TcpMessage
The Connect message is sent to the TCP manager actor, which is obtained via TcpExt.getManager().
connect(InetSocketAddress) - Static method in class akka.io.TcpMessage
Connect to the given remoteAddress without binding to a local address and without specifying options.
connect(ActorRef, InetSocketAddress, InetSocketAddress, Iterable<Inet.SocketOption>) - Method in class akka.io.UdpConnectedMessage$
Send this message to the UdpExt.manager() in order to bind to a local port (optionally with the chosen localAddress) and create a UDP socket which is restricted to sending to and receiving from the given remoteAddress.
connect(ActorRef, InetSocketAddress, Iterable<Inet.SocketOption>) - Method in class akka.io.UdpConnectedMessage$
Connect without specifying the localAddress.
connect(ActorRef, InetSocketAddress) - Method in class akka.io.UdpConnectedMessage$
Connect without specifying the localAddress or options.
connect(ActorRef, InetSocketAddress, InetSocketAddress, Iterable<Inet.SocketOption>) - Static method in class akka.io.UdpConnectedMessage
Send this message to the UdpExt.manager() in order to bind to a local port (optionally with the chosen localAddress) and create a UDP socket which is restricted to sending to and receiving from the given remoteAddress.
connect(ActorRef, InetSocketAddress, Iterable<Inet.SocketOption>) - Static method in class akka.io.UdpConnectedMessage
Connect without specifying the localAddress.
connect(ActorRef, InetSocketAddress) - Static method in class akka.io.UdpConnectedMessage
Connect without specifying the localAddress or options.
connectionSupervisorStrategy() - Method in class akka.io.SelectionHandler$
Special supervisor strategy for parents of TCP connection and listener actors.
ConsistentActorRef$ - Class in akka.routing
 
ConsistentActorRef$() - Constructor for class akka.routing.ConsistentActorRef$
 
ConsistentHash<T> - Class in akka.routing
Consistent Hashing node ring implementation.
ConsistentHash$ - Class in akka.routing
 
ConsistentHash$() - Constructor for class akka.routing.ConsistentHash$
 
ConsistentHashingGroup - Class in akka.routing
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
A Router that uses consistent hashing to select a connection based on the sent message.
ConsistentHashingRouter(int, Iterable<String>, Option<Resizer>, String, SupervisorStrategy, int, PartialFunction<Object, Object>) - Constructor for class akka.routing.ConsistentHashingRouter
 
ConsistentHashingRouter(int) - Constructor for class akka.routing.ConsistentHashingRouter
Java API: Constructor that sets nrOfInstances to be created.
ConsistentHashingRouter(Iterable<String>) - Constructor for class akka.routing.ConsistentHashingRouter
Java API: Constructor that sets the routees to be used.
ConsistentHashingRouter(Resizer) - Constructor for class akka.routing.ConsistentHashingRouter
Java API: Constructor that sets the resizer to be used.
ConsistentHashingRouter$ - Class in akka.routing
 
ConsistentHashingRouter$() - Constructor for class akka.routing.ConsistentHashingRouter$
 
ConsistentHashingRouter.ConsistentHashable - Interface in akka.routing
If you don't define the hashMapping when constructing the ConsistentHashingRouter the messages need to implement this interface to define what data to use for the consistent hash key.
ConsistentHashingRouter.ConsistentHashableEnvelope - Class in akka.routing
If you don't define the hashMapping when constructing the ConsistentHashingRouter and messages can't implement ConsistentHashingRouter.ConsistentHashable themselves they can we wrapped by this envelope instead.
ConsistentHashingRouter.ConsistentHashableEnvelope(Object, Object) - Constructor for class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope
 
ConsistentHashingRouter.ConsistentHashableEnvelope$ - Class in akka.routing
 
ConsistentHashingRouter.ConsistentHashableEnvelope$() - Constructor for class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope$
 
ConsistentHashingRouter.ConsistentHashMapper - Interface in akka.routing
JAVA API Mapping from message to the data to use for the consistent hash key.
ConsistentHashingRouter.emptyConsistentHashMapping$ - Class in akka.routing
 
ConsistentHashingRouter.emptyConsistentHashMapping$() - Constructor for class akka.routing.ConsistentHashingRouter.emptyConsistentHashMapping$
 
ConsistentHashingRoutingLogic - Class in akka.routing
Uses consistent hashing to select a routee based on the sent message.
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
Java API to create router with the supplied 'routees' actors.
ConsistentHashingRoutingLogic$() - Constructor for class akka.routing.ConsistentHashingRoutingLogic$
 
consistentHashKey() - Method in interface akka.routing.ConsistentHashingRouter.ConsistentHashable
 
consistentHashKey() - Method in class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope
 
ConsistentRoutee$ - Class in akka.routing
 
ConsistentRoutee$() - 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 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.
contextClassLoader() - Method in class akka.dispatch.MonitorableThreadFactory
 
contextStack() - 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$
 
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() - 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() - 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$
Java API: create a Props given a class and its constructor arguments.
create(Creator<T>) - Method in class akka.actor.Props$
Create new Props from the given Creator.
create(Class<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
Java API: create a Props given a class and its constructor arguments.
create(Creator<T>) - Static method in class akka.actor.Props
Create new Props from the given Creator.
create(Class<T>, Creator<T>) - Static method in class akka.actor.Props
Create new Props from the given Creator with the type set to the given actorClass.
create() - Method in class akka.actor.StoppingSupervisorStrategy
 
create() - Method in interface akka.actor.SupervisorStrategyConfigurator
 
create(MailboxType) - Method in class akka.dispatch.BalancingDispatcherConfigurator
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.BoundedDequeBasedMailbox
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.BoundedMailbox
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.BoundedPriorityMailbox
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in interface akka.dispatch.MailboxType
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.SingleConsumerOnlyUnboundedMailbox
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.UnboundedDequeBasedMailbox
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.UnboundedMailbox
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.UnboundedPriorityMailbox
 
create(PartialFunction<Object, BoxedUnit>, ActorContext) - Method in class akka.event.LoggingReceive$
Java API: compatible with lambda expressions This is an EXPERIMENTAL feature and is subject to change until it has received more real world testing.
create(PartialFunction<Object, BoxedUnit>, ActorContext) - Static method in class akka.event.LoggingReceive
Java API: compatible with lambda expressions This is an EXPERIMENTAL feature and is subject to change until it has received more real world testing.
create(Iterable<Tcp.WriteCommand>) - Method in class akka.io.Tcp.WriteCommand$
Java API: combines the given number of write commands into one atomic WriteCommand.
create() - Method in interface akka.japi.Creator
This method must return a different instance upon every call.
create(PFBuilder<F, T>) - Static method in class akka.japi.pf.Match
Create a Match from the builder.
create(UnitPFBuilder<F>) - Static method in class akka.japi.pf.UnitMatch
Create a UnitMatch from the builder.
create(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<ActorRef>) - Method in class akka.routing.BroadcastRouter$
 
create(Iterable<ActorRef>) - Static method in class akka.routing.BroadcastRouter
 
create(Iterable<T>, int) - Method in class akka.routing.ConsistentHash$
Java API: Factory method to create a ConsistentHash
create(Iterable<T>, int) - Static method in class akka.routing.ConsistentHash
Java API: Factory method to create a ConsistentHash
create(Iterable<ActorRef>) - Method in class akka.routing.ConsistentHashingRouter$
 
create(Iterable<ActorRef>) - Static method in class akka.routing.ConsistentHashingRouter
 
create(Iterable<ActorRef>) - Method in class akka.routing.RandomRouter$
 
create(Iterable<ActorRef>) - Static method in class akka.routing.RandomRouter
 
create(Iterable<ActorRef>) - Method in class akka.routing.RoundRobinRouter$
 
create(Iterable<ActorRef>) - Static method in class akka.routing.RoundRobinRouter
 
create(Iterable<ActorRef>, FiniteDuration) - Method in class akka.routing.ScatterGatherFirstCompletedRouter$
 
create(Iterable<ActorRef>, FiniteDuration) - Static method in class akka.routing.ScatterGatherFirstCompletedRouter
 
create(Iterable<ActorRef>) - Method in class akka.routing.SmallestMailboxRouter$
 
create(Iterable<ActorRef>) - Static method in class akka.routing.SmallestMailboxRouter
 
Create$ - Class in akka.dispatch.sysmsg
 
Create$() - Constructor for class akka.dispatch.sysmsg.Create$
 
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) - 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(akka.actor.Cell, MailboxType) - Method in class akka.dispatch.BalancingDispatcher
 
createMailbox(akka.actor.Cell, MailboxType) - Method in class akka.dispatch.Dispatcher
INTERNAL API
createMailbox(akka.actor.Cell, MailboxType) - Method in class akka.dispatch.MessageDispatcher
Creates and returns a mailbox for the given actor.
createRouter(ActorSystem) - Method in class akka.routing.BalancingPool
 
createRouter(ActorSystem) - Method in class akka.routing.BroadcastGroup
 
createRouter(ActorSystem) - Method in class akka.routing.BroadcastPool
 
createRouter(ActorSystem) - Method in class akka.routing.BroadcastRouter
 
createRouter(ActorSystem) - Method in class akka.routing.ConsistentHashingGroup
 
createRouter(ActorSystem) - Method in class akka.routing.ConsistentHashingPool
 
createRouter(ActorSystem) - Method in class akka.routing.ConsistentHashingRouter
 
createRouter(ActorSystem) - Method in class akka.routing.FromConfig
 
createRouter(ActorSystem) - Method in class akka.routing.NoRouter$
 
createRouter(ActorSystem) - Static method in class akka.routing.NoRouter
 
createRouter(ActorSystem) - Method in class akka.routing.RandomGroup
 
createRouter(ActorSystem) - Method in class akka.routing.RandomPool
 
createRouter(ActorSystem) - Method in class akka.routing.RandomRouter
 
createRouter(ActorSystem) - Method in class akka.routing.RoundRobinGroup
 
createRouter(ActorSystem) - Method in class akka.routing.RoundRobinPool
 
createRouter(ActorSystem) - Method in class akka.routing.RoundRobinRouter
 
createRouter(ActorSystem) - Method in interface akka.routing.RouterConfig
Create the actual router, responsible for routing messages to routees.
createRouter(ActorSystem) - Method in class akka.routing.ScatterGatherFirstCompletedGroup
 
createRouter(ActorSystem) - Method in class akka.routing.ScatterGatherFirstCompletedPool
 
createRouter(ActorSystem) - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
createRouter(ActorSystem) - Method in class akka.routing.SmallestMailboxPool
 
createRouter(ActorSystem) - Method in class akka.routing.SmallestMailboxRouter
 
createRouterActor() - Method in interface akka.routing.Group
INTERNAL API
createRouterActor() - Method in interface akka.routing.Pool
INTERNAL API
createRouterActor() - Method in interface akka.routing.RouterConfig
INTERNAL API The router "head" actor.
createThreadPoolConfigBuilder(Config, DispatcherPrerequisites) - Method in class akka.dispatch.ThreadPoolExecutorConfigurator
 
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.
CreatorConsumerClass() - Method in class akka.actor.IndirectActorProducer$
 
CreatorConsumerClass() - Method in interface akka.actor.IndirectActorProducer
 
CreatorFunctionConsumerClass() - Method in class akka.actor.IndirectActorProducer$
 
CreatorFunctionConsumerClass() - Method in interface akka.actor.IndirectActorProducer
 
Creators - Interface in akka.actor.dsl
 
Creators.Act - Interface in akka.actor.dsl
This trait provides a DSL for writing the inner workings of an actor, e.g.
Creators.ActWithStash - Interface in akka.actor.dsl
Use this trait when defining an Actor with Stash, since just using actor()(new Act with Stash{}) will not be able to see the Stash component due to type erasure.
Crypt - Class in akka.util
 
Crypt() - Constructor for class akka.util.Crypt
 
Crypt$ - Class in akka.util
 
Crypt$() - Constructor for class akka.util.Crypt$
 
currentDeadline() - Method in class akka.actor.dsl.Inbox.InboxActor
 
currentMsg() - Method in class akka.actor.dsl.Inbox.InboxActor
 
CurrentRoutees - Class in akka.routing
Sending this message to a router will make it send back its currently used routees.
CurrentRoutees() - Constructor for class akka.routing.CurrentRoutees
 
CurrentRoutees$ - Class in akka.routing
 
CurrentRoutees$() - Constructor for class akka.routing.CurrentRoutees$
 
currentSelect() - Method in class akka.actor.dsl.Inbox.InboxActor
 
currentState() - Method in interface akka.actor.FSM
 
currentState() - Method in class akka.actor.FSM.StopEvent
 
currentSystem() - Method in class akka.serialization.JavaSerializer$
This holds a reference to the current ActorSystem (the surrounding context) during serialization and deserialization.
currentSystem() - Static method in class akka.serialization.JavaSerializer
This holds a reference to the current ActorSystem (the surrounding context) during serialization and deserialization.
currentTimeMillisToUTCString(long) - Method in class akka.util.Helpers$
Converts a "currentTimeMillis"-obtained timestamp accordingly:
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
 

D

daemonic() - Method in class akka.dispatch.MonitorableThreadFactory
 
Daemonicity() - Method in class akka.actor.ActorSystem.Settings
 
data() - Method in class akka.io.Tcp.Received
 
data() - Method in class akka.io.Tcp.Write
 
data() - Method in class akka.io.Udp.Received
 
data() - Method in class akka.io.UdpConnected.Received
 
date() - Method in interface akka.event.Logging.StdOutLogger
 
dateFormat() - Method in interface akka.event.Logging.StdOutLogger
 
dead() - Method in exception akka.actor.DeathPactException
 
DeadLetter - Class in akka.actor
When a message is sent to an Actor that is terminated before receiving the message, it will be sent as a DeadLetter to the ActorSystem's EventStream
DeadLetter(Object, ActorRef, ActorRef) - Constructor for class akka.actor.DeadLetter
 
DeadLetter$ - Class in akka.actor
 
DeadLetter$() - Constructor for class akka.actor.DeadLetter$
 
DeadLetterActorRef$ - Class in akka.actor
 
DeadLetterActorRef$() - Constructor for class akka.actor.DeadLetterActorRef$
 
DeadLetterListener - Class in akka.event
 
DeadLetterListener() - Constructor for class akka.event.DeadLetterListener
 
deadLetters() - Method in interface akka.actor.ActorRefProvider
Dead letter destination for this provider.
deadLetters() - Method in class akka.actor.ActorSystem
Actor reference where messages are re-routed to which were addressed to stopped or non-existing actors.
deadline() - Method in class akka.actor.dsl.Inbox.Get
 
deadline() - Method in interface akka.actor.dsl.Inbox.Query
 
deadline() - Method in class akka.actor.dsl.Inbox.Select
 
deadlineOrder() - Method in interface akka.actor.dsl.Inbox
 
Deafen - Class in akka.routing
 
Deafen(ActorRef) - Constructor for class akka.routing.Deafen
 
Deafen$ - Class in akka.routing
 
Deafen$() - Constructor for class akka.routing.Deafen$
 
DeathPactException - Exception in akka.actor
A DeathPactException is thrown by an Actor that receives a Terminated(someActor) message that it doesn't handle itself, effectively crashing the Actor and escalating to the supervisor.
DeathPactException$ - Class in akka.actor
 
DeathPactException$() - Constructor for class akka.actor.DeathPactException$
 
DeathWatchNotification$ - Class in akka.dispatch.sysmsg
 
DeathWatchNotification$() - Constructor for class akka.dispatch.sysmsg.DeathWatchNotification$
 
debug() - Method in class akka.dispatch.Mailbox$
 
debug() - Method in class akka.dispatch.MessageDispatcher$
 
debug() - Static method in class akka.dispatch.MessageDispatcher
 
debug(Logging.Debug) - Method in interface akka.event.Logging.StdOutLogger
 
debug(String) - Method in interface akka.event.LoggingAdapter
Log message at debug level.
debug(String, Object) - Method in interface akka.event.LoggingAdapter
Message template with 1 replacement argument.
debug(String, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 2 replacement arguments.
debug(String, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 3 replacement arguments.
debug(String, Object, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 4 replacement arguments.
DebugAutoReceive() - Method in class akka.actor.ActorSystem.Settings
 
debugEvent() - Method in interface akka.actor.FSM
 
debugEvent() - Method in interface akka.actor.LoggingFSM
 
DebugEventStream() - Method in class akka.actor.ActorSystem.Settings
 
debugFormat() - Method in interface akka.event.Logging.StdOutLogger
 
DebugLevel() - Method in class akka.event.Logging$
 
DebugLevel() - Static method in class akka.event.Logging
 
DebugLifecycle() - Method in class akka.actor.ActorSystem.Settings
 
DebugRouterMisconfiguration() - Method in class akka.actor.ActorSystem.Settings
 
DebugUnhandledMessage() - Method in class akka.actor.ActorSystem.Settings
 
decider() - Method in class akka.actor.AllForOneStrategy
 
decider() - Method in class akka.actor.OneForOneStrategy
 
decider() - Method in class akka.actor.SupervisorStrategy
Returns the Decider that is associated with this SupervisorStrategy.
DeciderBuilder - Class in akka.japi.pf
Used for building a partial function for Actor.supervisorStrategy().
decodeString(String) - Method in class akka.util.ByteString.ByteString1
 
decodeString(String) - Method in class akka.util.ByteString.ByteString1C
 
decodeString(String) - Method in class akka.util.ByteString.ByteStrings
 
decodeString(String) - Method in class akka.util.ByteString
Decodes this ByteString using a charset to produce a String.
defaultAddress(ActorSystem) - Method in class akka.routing.ConsistentHashingRoutingLogic$
Address to use for the selfAddress parameter
defaultAddress(ActorSystem) - Static method in class akka.routing.ConsistentHashingRoutingLogic
Address to use for the selfAddress parameter
defaultAllowCoreThreadTimeout() - Method in class akka.dispatch.ThreadPoolConfig$
 
defaultAllowCoreThreadTimeout() - Static method in class akka.dispatch.ThreadPoolConfig
 
defaultCorePoolSize() - Method in class akka.dispatch.ThreadPoolConfig$
 
defaultCorePoolSize() - Static method in class akka.dispatch.ThreadPoolConfig
 
defaultCreator() - Method in class akka.actor.Props$
The defaultCreator, simply throws an UnsupportedOperationException when applied, which is used when creating a Props
defaultCreator() - Static method in class akka.actor.Props
The defaultCreator, simply throws an UnsupportedOperationException when applied, which is used when creating a Props
defaultDecider() - Method in class akka.actor.SupervisorStrategy$
When supervisorStrategy is not specified for an actor this Decider is used by default in the supervisor strategy.
defaultDecider() - Static method in class akka.actor.SupervisorStrategy
When supervisorStrategy is not specified for an actor this Decider is used by default in the supervisor strategy.
defaultDeploy() - Method in class akka.actor.Props$
The default Deploy instance which is used when creating a Props
defaultDeploy() - Static method in class akka.actor.Props
The default Deploy instance which is used when creating a Props
defaultDispatcherConfig() - Method in class akka.dispatch.Dispatchers
 
defaultDispatcherId() - Method in class akka.actor.TypedProps$
 
defaultDispatcherId() - Static method in class akka.actor.TypedProps
 
DefaultDispatcherId() - Method in class akka.dispatch.Dispatchers$
The id of the default dispatcher, also the full key of the configuration of the default dispatcher.
DefaultDispatcherId() - Static method in class akka.dispatch.Dispatchers
The id of the default dispatcher, also the full key of the configuration of the default dispatcher.
DefaultDispatcherPrerequisites$ - Class in akka.dispatch
 
DefaultDispatcherPrerequisites$() - Constructor for class akka.dispatch.DefaultDispatcherPrerequisites$
 
defaultExecutionContext() - Method in interface akka.dispatch.DispatcherPrerequisites
 
DefaultExecutorServiceConfigurator - Class in akka.dispatch
 
DefaultExecutorServiceConfigurator(Config, DispatcherPrerequisites, ExecutorServiceConfigurator) - Constructor for class akka.dispatch.DefaultExecutorServiceConfigurator
 
defaultGlobalDispatcher() - Method in class akka.dispatch.Dispatchers
The one and only default dispatcher.
defaultLoader() - Method in class akka.actor.TypedProps$
 
defaultLoader() - Static method in class akka.actor.TypedProps
 
DefaultMailboxId() - Method in class akka.dispatch.Mailboxes$
 
defaultMaxPoolSize() - Method in class akka.dispatch.ThreadPoolConfig$
 
defaultMaxPoolSize() - Static method in class akka.dispatch.ThreadPoolConfig
 
defaultRejectionPolicy() - Method in class akka.dispatch.ThreadPoolConfig$
 
defaultRejectionPolicy() - Static method in class akka.dispatch.ThreadPoolConfig
 
DefaultResizer - Class in akka.routing
Implementation of Resizer that adjust the Pool based on specified thresholds.
DefaultResizer(int, int, int, double, double, double, int) - Constructor for class akka.routing.DefaultResizer
 
DefaultResizer(int, int) - Constructor for class akka.routing.DefaultResizer
Java API constructor for default values except bounds.
DefaultResizer$ - Class in akka.routing
 
DefaultResizer$() - Constructor for class akka.routing.DefaultResizer$
 
DefaultReturnTimeout() - Method in class akka.actor.TypedActorExtension
Default timeout for typed actor methods with non-void return type
defaultRoutedProps() - Method in class akka.actor.Props$
The defaultRoutedProps is NoRouter which is used when creating a Props
defaultRoutedProps() - Static method in class akka.actor.Props
The defaultRoutedProps is NoRouter which is used when creating a Props
DefaultState() - Method in class akka.actor.ActorCell$
 
defaultStrategy() - Method in class akka.actor.SupervisorStrategy$
When supervisorStrategy is not specified for an actor this is used by default.
defaultStrategy() - Static method in class akka.actor.SupervisorStrategy
When supervisorStrategy is not specified for an actor this is used by default.
DefaultSupervisorStrategy - Class in akka.actor
 
DefaultSupervisorStrategy() - Constructor for class akka.actor.DefaultSupervisorStrategy
 
defaultSupervisorStrategy() - Method in class akka.routing.Pool$
 
defaultSupervisorStrategy() - Method in interface akka.routing.Pool
 
defaultTimeout() - Method in class akka.actor.TypedProps$
 
defaultTimeout() - Static method in class akka.actor.TypedProps
 
defaultTimeout() - Method in class akka.dispatch.ThreadPoolConfig$
 
defaultTimeout() - Static method in class akka.dispatch.ThreadPoolConfig
 
DefaultVirtualNodesFactor() - Method in class akka.actor.ActorSystem.Settings
 
defined(T) - Method in interface akka.japi.pf.FI.TypedPredicate
The predicate to evaluate.
defined(T, U) - Method in interface akka.japi.pf.FI.TypedPredicate2
The predicate to evaluate.
Deploy - Class in akka.actor
This class represents deployment configuration for a given actor path.
Deploy(String, Config, RouterConfig, Scope, String, String) - Constructor for class akka.actor.Deploy
 
Deploy(RouterConfig) - Constructor for class akka.actor.Deploy
Java API to create a Deploy with the given RouterConfig
Deploy(RouterConfig, Scope) - Constructor for class akka.actor.Deploy
Java API to create a Deploy with the given RouterConfig with Scope
Deploy(Scope) - Constructor for class akka.actor.Deploy
Java API to create a Deploy with the given Scope
deploy() - Method in class akka.actor.Props
 
deploy() - Method in class akka.actor.TypedProps
 
Deploy$ - Class in akka.actor
 
Deploy$() - Constructor for class akka.actor.Deploy$
 
deployer() - Method in interface akka.actor.ActorRefProvider
The Deployer associated with this ActorRefProvider
DeprecatedRouterConfig - Interface in akka.routing
Java API
DequeBasedMessageQueue - Interface in akka.dispatch
 
DequeBasedMessageQueueSemantics - Interface in akka.dispatch
DequeBasedMessageQueue refines QueueBasedMessageQueue to be backed by a java.util.Deque.
dequeue() - Method in interface akka.dispatch.BoundedDequeBasedMessageQueue
 
dequeue() - Method in interface akka.dispatch.BoundedQueueBasedMessageQueue
 
dequeue() - Method in interface akka.dispatch.MessageQueue
Try to dequeue the next message from this queue, return null failing that.
dequeue() - Method in class akka.dispatch.NodeMessageQueue
 
dequeue() - Method in interface akka.dispatch.UnboundedDequeBasedMessageQueue
 
dequeue() - Method in interface akka.dispatch.UnboundedQueueBasedMessageQueue
 
descendant(Iterable<String>) - Method in interface akka.actor.ActorPath
Java API: Recursively create a descendant’s path by appending all child names.
descendant(Iterable<String>) - Method in class akka.actor.ActorSystem
Java API: Recursively create a descendant’s path by appending all child names.
deserialize(byte[], int, Option<Class<? extends T>>) - Method in class akka.serialization.Serialization
Deserializes the given array of bytes using the specified serializer id, using the optional type hint to the Serializer and the optional ClassLoader ot load it into.
deserialize(byte[], Class<T>) - Method in class akka.serialization.Serialization
Deserializes the given array of bytes using the specified type to look up what Serializer should be used.
detach(akka.actor.ActorCell) - Method in class akka.dispatch.MessageDispatcher
Detaches the specified actor instance from this dispatcher
DiagnosticActorLogging - Interface in akka.actor
Scala API: Mix in DiagnosticActorLogging into your Actor to easily obtain a reference to a logger with MDC support, which is available under the name "log".
DiagnosticLoggingAdapter - Interface in akka.event
LoggingAdapter extension which adds MDC support.
digest(byte[], MessageDigest) - Method in class akka.util.Crypt$
 
digest(byte[], MessageDigest) - Static method in class akka.util.Crypt
 
DirectBufferSize() - Method in class akka.io.TcpExt.Settings
 
disconnect() - Method in class akka.io.UdpConnectedMessage$
Send this message to a connection actor (which had previously sent the UdpConnected.Connected message) in order to close the socket.
disconnect() - Static method in class akka.io.UdpConnectedMessage
Send this message to a connection actor (which had previously sent the UdpConnected.Connected message) in order to close the socket.
dispatch(akka.actor.ActorCell, Envelope) - Method in class akka.dispatch.BalancingDispatcher
 
dispatch(akka.actor.ActorCell, Envelope) - Method in class akka.dispatch.Dispatcher
INTERNAL API
dispatch(akka.actor.ActorCell, Envelope) - Method in class akka.dispatch.MessageDispatcher
Will be called when the dispatcher is to queue an invocation for execution
dispatcher() - Method in interface akka.actor.ActorContext
Returns the dispatcher (MessageDispatcher) that is used for this Actor.
dispatcher() - Method in interface akka.actor.ActorRefFactory
Returns the default MessageDispatcher associated with this ActorRefFactory
dispatcher() - Method in class akka.actor.ActorSystem
Default dispatcher as configured.
dispatcher() - Method in class akka.actor.Deploy
 
dispatcher() - Method in class akka.actor.Props
Convenience method for extracting the dispatcher information from the contained Deploy instance.
dispatcher() - Method in class akka.actor.TypedActor$
Returns the default dispatcher (for a TypedActor) when inside a method call in a TypedActor.
dispatcher() - Static method in class akka.actor.TypedActor
Returns the default dispatcher (for a TypedActor) when inside a method call in a TypedActor.
dispatcher() - Method in class akka.actor.TypedProps
 
dispatcher() - Method in class akka.dispatch.BalancingDispatcherConfigurator
Returns the same dispatcher instance for each invocation
Dispatcher - Class in akka.dispatch
The event-based Dispatcher binds a set of Actors to a thread pool backed up by a BlockingQueue.
Dispatcher(MessageDispatcherConfigurator, String, int, Duration, ExecutorServiceFactoryProvider, FiniteDuration) - Constructor for class akka.dispatch.Dispatcher
 
dispatcher() - Method in class akka.dispatch.DispatcherConfigurator
Returns the same dispatcher instance for each invocation
dispatcher() - Method in class akka.dispatch.MessageDispatcherConfigurator
Returns an instance of MessageDispatcher given the configuration.
dispatcher() - Method in class akka.dispatch.PinnedDispatcherConfigurator
Creates new dispatcher for each invocation.
DispatcherConfigurator - Class in akka.dispatch
Configurator for creating Dispatcher.
DispatcherConfigurator(Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.DispatcherConfigurator
 
DispatcherPrerequisites - Interface in akka.dispatch
DispatcherPrerequisites represents useful contextual pieces when constructing a MessageDispatcher
dispatchers() - Method in class akka.actor.ActorSystem
Helper object for looking up configured dispatchers.
Dispatchers - Class in akka.dispatch
Dispatchers are to be defined in configuration to allow for tuning for different environments.
Dispatchers(ActorSystem.Settings, DispatcherPrerequisites) - Constructor for class akka.dispatch.Dispatchers
 
Dispatchers$ - Class in akka.dispatch
 
Dispatchers$() - Constructor for class akka.dispatch.Dispatchers$
 
dissociate(ActorRef) - Method in interface akka.event.ActorClassification
 
dissociate(ActorRef, ActorRef) - Method in interface akka.event.ActorClassification
 
doNothing() - Method in class akka.dispatch.MonitorableThreadFactory$
 
doNothing() - Static method in class akka.dispatch.MonitorableThreadFactory
 
drainTo(Collection<? super E>) - Method in class akka.util.BoundedBlockingQueue
 
drainTo(Collection<? super E>, int) - Method in class akka.util.BoundedBlockingQueue
 
drop(int) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
drop(int) - Method in class akka.util.ByteIterator
 
drop(int) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
drop(int) - Method in class akka.util.ByteString
 
dropRight(int) - Method in class akka.util.ByteString
 
dropWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
dropWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator
 
dropWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
dropWhile(Function1<Object, Object>) - Method in class akka.util.ByteString
 
DSLDefaultTimeout() - Method in class akka.actor.ActorDSL.Extension
 
DSLInboxQueueSize() - Method in interface akka.actor.dsl.Inbox.InboxExtension
 
DummyClassForStringSources - Class in akka.event
This is a “marker” class which is inserted as originator class into Logging.LogEvent when the string representation was supplied directly.
DummyClassForStringSources() - Constructor for class akka.event.DummyClassForStringSources
 
duplicate() - Method in class akka.util.ByteIterator
 
duration() - Method in class akka.util.Timeout
 
durationToTimeout(FiniteDuration) - Method in class akka.util.Timeout$
 
durationToTimeout(FiniteDuration) - Static method in class akka.util.Timeout
 
DynamicAccess - Class in akka.actor
The DynamicAccess implementation is the class which is used for loading all configurable parts of an actor system (the ReflectiveDynamicAccess is the default implementation).
DynamicAccess() - Constructor for class akka.actor.DynamicAccess
 
dynamicAccess() - Method in class akka.actor.ExtendedActorSystem
ClassLoader wrapper which is used for reflective accesses internally.
dynamicAccess() - Method in interface akka.dispatch.DispatcherPrerequisites
 

E

each(T) - Method in class akka.dispatch.Foreach
This method will be invoked once when/if a Future that this callback is registered on becomes successfully completed
EarliestFirstSystemMessageList$ - Class in akka.dispatch.sysmsg
 
EarliestFirstSystemMessageList$() - Constructor for class akka.dispatch.sysmsg.EarliestFirstSystemMessageList$
 
Effect - Interface in akka.japi
An executable piece of code that takes no parameters and doesn't return any value.
ElementRegex() - Method in class akka.actor.ActorPath$
This Regular Expression is used to validate a path element (Actor Name).
ElementRegex() - Method in interface akka.actor.ActorPath
This Regular Expression is used to validate a path element (Actor Name).
elements() - Method in interface akka.actor.ActorPath
Sequence of names for this path from root to this.
elements() - Method in class akka.actor.ChildActorPath
 
elements() - Method in class akka.actor.RootActorPath
 
empty() - Method in class akka.actor.Props$
A Props instance whose creator will create an actor that doesn't respond to any message
empty() - Static method in class akka.actor.Props
A Props instance whose creator will create an actor that doesn't respond to any message
empty() - Method in interface akka.event.ActorClassification
 
empty() - Method in class akka.io.Tcp.Write$
The empty Write doesn't write anything and isn't acknowledged.
empty() - Method in class akka.japi.pf.CaseStatement$
 
empty() - Method in class akka.util.ByteIterator.ByteArrayIterator$
 
empty() - Method in class akka.util.ByteIterator.MultiByteArrayIterator$
 
empty() - Method in class akka.util.ByteString$
 
empty() - Method in class akka.util.ByteString.ByteString1$
 
empty() - Static method in class akka.util.ByteString
 
empty() - Method in class akka.util.CompactByteString$
 
empty() - Static method in class akka.util.CompactByteString
 
emptyActorPath() - Method in class akka.actor.ActorPath$
 
emptyActorPath() - Method in interface akka.actor.ActorPath
 
emptyActorRefSet() - Method in class akka.actor.ActorCell$
 
emptyBehavior() - Method in class akka.actor.AbstractActor$
emptyBehavior is a Receive-expression that matches no messages at all, ever.
emptyBehavior() - Static method in class akka.actor.AbstractActor
emptyBehavior is a Receive-expression that matches no messages at all, ever.
emptyBehaviorStack() - Method in class akka.actor.ActorCell$
 
emptyCancellable() - Method in class akka.actor.ActorCell$
 
emptyConfig() - Method in class akka.dispatch.CachingConfig$
 
emptyMDC() - Method in class akka.event.Logging$
 
emptyMDC() - Static method in class akka.event.Logging
 
emptyPathEntry() - Method in class akka.dispatch.CachingConfig$
 
emptyReceiveTimeoutData() - Method in class akka.actor.dungeon.ReceiveTimeout$
 
ENil() - Method in class akka.dispatch.sysmsg.SystemMessageList$
 
ENil() - Static method in class akka.dispatch.sysmsg.SystemMessageList
 
enqueue(ActorRef, Envelope) - Method in interface akka.dispatch.BoundedDequeBasedMessageQueue
 
enqueue(ActorRef, Envelope) - Method in interface akka.dispatch.BoundedQueueBasedMessageQueue
 
enqueue(ActorRef, Envelope) - Method in interface akka.dispatch.MessageQueue
Try to enqueue the message to this queue, or throw an exception.
enqueue(ActorRef, Envelope) - Method in class akka.dispatch.NodeMessageQueue
 
enqueue(ActorRef, Envelope) - Method in interface akka.dispatch.UnboundedDequeBasedMessageQueue
 
enqueue(ActorRef, Envelope) - Method in interface akka.dispatch.UnboundedQueueBasedMessageQueue
 
enqueueFirst(ActorRef, Envelope) - Method in interface akka.dispatch.BoundedDequeBasedMessageQueue
 
enqueueFirst(ActorRef, Envelope) - Method in interface akka.dispatch.DequeBasedMessageQueueSemantics
 
enqueueFirst(ActorRef, Envelope) - Method in interface akka.dispatch.UnboundedDequeBasedMessageQueue
 
enqueueMessage(Object) - Method in class akka.actor.dsl.Inbox.InboxActor
 
enqueueQuery(Inbox.Query) - Method in class akka.actor.dsl.Inbox.InboxActor
 
enrichWithPoolDispatcher(Props, ActorContext) - Method in interface akka.routing.Pool
INTERNAL API
Envelope - Class in akka.dispatch
 
Envelope$ - Class in akka.dispatch
 
Envelope$() - Constructor for class akka.dispatch.Envelope$
 
EnvHome() - Method in class akka.actor.ActorSystem$
 
EnvHome() - Static method in class akka.actor.ActorSystem
 
equals(Object) - Method in class akka.actor.ActorRef
Equals takes path and the unique id of the actor cell into account.
equals(Object) - Method in class akka.actor.ActorSelection
 
equals(Object) - Method in class akka.actor.ChildActorPath
 
equals(Object) - Method in interface akka.actor.ExtensionId
 
error(Logging.Error) - Method in interface akka.event.Logging.StdOutLogger
 
error(Throwable, String) - Method in interface akka.event.LoggingAdapter
Log message at error level, including the exception that caused the error.
error(Throwable, String, Object) - Method in interface akka.event.LoggingAdapter
Message template with 1 replacement argument.
error(Throwable, String, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 2 replacement arguments.
error(Throwable, String, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 3 replacement arguments.
error(Throwable, String, Object, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 4 replacement arguments.
error(String) - Method in interface akka.event.LoggingAdapter
Log message at error level, without providing the exception that caused the error.
error(String, Object) - Method in interface akka.event.LoggingAdapter
Message template with 1 replacement argument.
error(String, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 2 replacement arguments.
error(String, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 3 replacement arguments.
error(String, Object, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 4 replacement arguments.
errorFormat() - Method in interface akka.event.Logging.StdOutLogger
 
errorFormatWithoutCause() - Method in interface akka.event.Logging.StdOutLogger
 
ErrorLevel() - Method in class akka.event.Logging$
Log level in numeric form, used when deciding whether a certain log statement should generate a log event.
ErrorLevel() - Static method in class akka.event.Logging
Log level in numeric form, used when deciding whether a certain log statement should generate a log event.
Escalate() - Method in interface akka.actor.dsl.Creators.Act
 
escalate() - Method in class akka.actor.SupervisorStrategy$
Java API: Returning this directive escalates the failure to the supervisor of the supervisor, by rethrowing the cause of the failure, i.e.
escalate() - Static method in class akka.actor.SupervisorStrategy
Java API: Returning this directive escalates the failure to the supervisor of the supervisor, by rethrowing the cause of the failure, i.e.
escalateDefault() - Method in class akka.actor.SupervisorStrategy$
 
escalateDefault() - Static method in class akka.actor.SupervisorStrategy
 
Event() - Method in interface akka.actor.FSM
 
event() - Method in class akka.actor.FSM.Event
 
event() - Method in class akka.actor.FSM.LogEntry
 
event() - Method in class akka.event.Logging.LogEventException
 
event() - Method in class akka.io.Tcp.Abort$
The corresponding event which is sent as an acknowledgment once the close operation is finished.
event() - Method in class akka.io.Tcp.Close$
The corresponding event which is sent as an acknowledgment once the close operation is finished.
event() - Method in interface akka.io.Tcp.CloseCommand
The corresponding event which is sent as an acknowledgment once the close operation is finished.
event() - Method in class akka.io.Tcp.ConfirmedClose$
The corresponding event which is sent as an acknowledgment once the close operation is finished.
event(Class<P>, Class<Q>, FI.TypedPredicate2<P, Q>, FI.Apply2<P, Q, FSM.State<S, D>>) - Method in class akka.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches on an event and data type and a predicate.
event(Class<P>, Class<Q>, FI.Apply2<P, Q, FSM.State<S, D>>) - Method in class akka.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches on an event and data type.
event(Class<P>, FI.TypedPredicate2<P, D>, FI.Apply2<P, D, FSM.State<S, D>>) - Method in class akka.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches if the event type and predicate matches.
event(Class<P>, FI.Apply2<P, D, FSM.State<S, D>>) - Method in class akka.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches if the event type and predicate matches.
event(FI.TypedPredicate2<Object, D>, FI.Apply2<Object, D, FSM.State<S, D>>) - Method in class akka.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches if the predicate matches.
event(List<Object>, Class<Q>, FI.Apply2<Object, Q, FSM.State<S, D>>) - Method in class akka.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches on the data type and if any of the event types in the list match or any of the event instances in the list compares equal.
event(List<Object>, FI.Apply2<Object, D, FSM.State<S, D>>) - Method in class akka.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches if any of the event types in the list match or any of the event instances in the list compares equal.
EventBus - Interface in akka.event
Represents the base type for EventBuses Internally has an Event type, a Classifier type and a Subscriber type
EventBus<E,S,C> - Interface in akka.event.japi
Java API: See documentation for EventBus E is the Event type S is the Subscriber type C is the Classifier type
eventEquals(P, Class<Q>, FI.Apply2<P, Q, FSM.State<S, D>>) - Method in class akka.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches on the data type and if the event compares equal.
eventEquals(P, FI.Apply2<P, D, FSM.State<S, D>>) - Method in class akka.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches if event compares equal.
events() - Method in interface akka.actor.LoggingFSM
 
eventStream() - Method in class akka.actor.ActorSystem
Main event bus of this actor system, used for example for logging.
eventStream() - Method in interface akka.dispatch.DispatcherPrerequisites
 
eventStream() - Method in class akka.dispatch.MessageDispatcher
 
eventStream() - Method in class akka.dispatch.TaskInvocation
 
eventStream() - Method in class akka.event.DeadLetterListener
 
EventStream - Class in akka.event
 
EventStream(boolean) - Constructor for class akka.event.EventStream
 
EventStream$ - Class in akka.event
 
EventStream$() - Constructor for class akka.event.EventStream$
 
exceptionHandler() - Method in class akka.dispatch.MonitorableThreadFactory
 
exec() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinTask
 
execute(Runnable) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
execute(Runnable) - Method in class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinPool
 
executeTask(TaskInvocation) - Method in class akka.dispatch.Dispatcher
INTERNAL API
executeTask(TaskInvocation) - Method in class akka.dispatch.MessageDispatcher
INTERNAL API
ExecutionContexts - Class in akka.dispatch
ExecutionContexts is the Java API for ExecutionContexts
ExecutionContexts() - Constructor for class akka.dispatch.ExecutionContexts
 
ExecutionContexts$ - Class in akka.dispatch
ExecutionContexts is the Java API for ExecutionContexts
ExecutionContexts$() - Constructor for class akka.dispatch.ExecutionContexts$
 
ExecutionContexts.sameThreadExecutionContext$ - Class in akka.dispatch
WARNING: Not A General Purpose ExecutionContext!
ExecutionContexts.sameThreadExecutionContext$() - Constructor for class akka.dispatch.ExecutionContexts.sameThreadExecutionContext$
 
executor() - Method in interface akka.dispatch.ExecutorServiceDelegate
 
executorService() - Method in class akka.dispatch.Dispatcher
 
ExecutorServiceConfigurator - Class in akka.dispatch
An ExecutorServiceConfigurator is a class that given some prerequisites and a configuration can create instances of ExecutorService
ExecutorServiceConfigurator(Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.ExecutorServiceConfigurator
 
ExecutorServiceDelegate - Interface in akka.dispatch
As the name says
ExecutorServiceFactory - Interface in akka.dispatch
Function0 without the fun stuff (mostly for the sake of the Java API side of things)
ExecutorServiceFactoryProvider - Interface in akka.dispatch
Generic way to specify an ExecutorService to a Dispatcher, create it with the given name if desired
existenceConfirmed() - Method in class akka.actor.Terminated
 
ExtendedActorSystem - Class in akka.actor
More powerful interface to the actor system’s implementation which is presented to extensions (see Extension).
ExtendedActorSystem() - Constructor for class akka.actor.ExtendedActorSystem
 
extendHash(int, int, int, int) - Method in class akka.routing.MurmurHash$
Incorporates a new value into an existing hash.
extendHash(int, int, int, int) - Static method in class akka.routing.MurmurHash
Incorporates a new value into an existing hash.
extension(ExtensionId<T>) - Method in class akka.actor.ActorSystem
Returns the payload that is associated with the provided extension throws an IllegalStateException if it is not registered.
Extension - Interface in akka.actor
The basic ActorSystem covers all that is needed for locally running actors, using futures and so on.
ExtensionId<T extends Extension> - Interface in akka.actor
Identifies an Extension Lookup of Extensions is done by object identity, so the Id must be the same wherever it's used, otherwise you'll get the same extension loaded multiple times.
ExtensionIdProvider - Interface in akka.actor
To be able to load an ExtensionId from the configuration, a class that implements ExtensionIdProvider must be specified.
ExtensionKey<T extends Extension> - Class in akka.actor
This is a one-stop-shop if all you want is an extension which is constructed with the ExtendedActorSystem as its only constructor argument:
ExtensionKey(ClassTag<T>) - Constructor for class akka.actor.ExtensionKey
 
ExtensionKey(Class<T>) - Constructor for class akka.actor.ExtensionKey
 
extractInterfaces(Class<?>) - Method in class akka.actor.TypedProps$
 
extractInterfaces(Class<?>) - Static method in class akka.actor.TypedProps
 
extraTime() - Method in interface akka.actor.dsl.Inbox
 

F

f() - Method in class akka.routing.WithListeners
 
failed(Throwable) - Method in class akka.dispatch.Futures$
creates an already completed Promise with the specified exception
failed(Throwable) - Static method in class akka.dispatch.Futures
creates an already completed Promise with the specified exception
Failed$ - Class in akka.dispatch.sysmsg
 
Failed$() - Constructor for class akka.dispatch.sysmsg.Failed$
 
failureMessage() - Method in interface akka.io.Tcp.Command
 
failureMessage() - Method in interface akka.io.Udp.Command
 
failureMessage() - Method in interface akka.io.UdpConnected.Command
 
FI - Class in akka.japi.pf
Class that encapsulates all the Functional Interfaces used for creating partial functions.
FI.Apply<I,R> - Interface in akka.japi.pf
Functional interface for an application.
FI.Apply2<I1,I2,R> - Interface in akka.japi.pf
Functional interface for an application.
FI.TypedPredicate<T> - Interface in akka.japi.pf
Functional interface for a predicate.
FI.TypedPredicate2<T,U> - Interface in akka.japi.pf
Functional interface for a predicate.
FI.UnitApply<I> - Interface in akka.japi.pf
Functional interface for an application.
FI.UnitApply2<I1,I2> - Interface in akka.japi.pf
Functional interface for an application.
FI.UnitApply3<I1,I2,I3> - Interface in akka.japi.pf
Functional interface for an application.
FI.UnitApplyVoid - Interface in akka.japi.pf
Functional interface for an application.
fileIoDispatcher() - Method in class akka.io.TcpExt
 
FileIODispatcher() - Method in class akka.io.TcpExt.Settings
 
filePath() - Method in class akka.io.Tcp.WriteFile
 
fillArray(int, Function2<byte[], Object, BoxedUnit>) - Method in class akka.util.ByteStringBuilder
 
fillByteBuffer(int, ByteOrder, Function1<ByteBuffer, BoxedUnit>) - Method in class akka.util.ByteStringBuilder
 
fillInStackTrace() - Method in interface akka.OnlyCauseStackTrace
 
Filter - Class in akka.dispatch
Java API (not recommended): Callback for the Future.filter operation that creates a new Future which will conditionally contain the success of another Future.
Filter() - Constructor for class akka.dispatch.Filter
 
filter(int, int) - Method in class akka.routing.DefaultResizer
This method can be used to smooth the capacity delta by considering the current pressure and current capacity.
Filter$ - Class in akka.dispatch
Java API (not recommended): Callback for the Future.filter operation that creates a new Future which will conditionally contain the success of another Future.
Filter$() - Constructor for class akka.dispatch.Filter$
 
filterOf(Function<T, Boolean>) - Method in class akka.dispatch.Filter$
 
filterOf(Function<T, Boolean>) - Static method in class akka.dispatch.Filter
 
finalize() - Method in class akka.actor.dsl.Inbox.Inbox
Overridden finalizer which will try to stop the actor once this Inbox is no longer referenced.
finalizeHash(int) - Method in class akka.routing.MurmurHash$
Once all hashes have been incorporated, this performs a final mixing
finalizeHash(int) - Static method in class akka.routing.MurmurHash
Once all hashes have been incorporated, this performs a final mixing
find(Iterable<Future<T>>, Function<T, Boolean>, ExecutionContext) - Method in class akka.dispatch.Futures$
Returns a Future that will hold the optional result of the first Future with a result that matches the predicate
find(Iterable<Future<T>>, Function<T, Boolean>, ExecutionContext) - Static method in class akka.dispatch.Futures
Returns a Future that will hold the optional result of the first Future with a result that matches the predicate
findMarker(Class<?>, Class<?>) - Method in class akka.util.Reflect$
 
findMarker(Class<?>, Class<?>) - Static method in class akka.util.Reflect
 
findSerializerFor(Object) - Method in class akka.serialization.Serialization
Returns the Serializer configured for the given object, returns the NullSerializer if it's null.
findValue(K, Function1<V, Object>) - Method in class akka.util.Index
 
FinishConnectRetries() - Method in class akka.io.TcpExt.Settings
 
first() - Method in class akka.japi.Pair
 
firstCompletedOf(Iterable<Future<T>>, ExecutionContext) - Method in class akka.dispatch.Futures$
Returns a Future to the result of the first future in the list that is completed
firstCompletedOf(Iterable<Future<T>>, ExecutionContext) - Static method in class akka.dispatch.Futures
Returns a Future to the result of the first future in the list that is completed
fold(R, Iterable<Future<T>>, Function2<R, T, R>, ExecutionContext) - Method in class akka.dispatch.Futures$
A non-blocking fold over the specified futures, with the start value of the given zero.
fold(R, Iterable<Future<T>>, Function2<R, T, R>, ExecutionContext) - Static method in class akka.dispatch.Futures
A non-blocking fold over the specified futures, with the start value of the given zero.
fold(Function0<T>, Function0<T>) - Method in class akka.util.Switch
Executes the provided callbacks depending on if the switch is either on or off waiting for any pending changes to happen before (locking) Be careful of longrunning or blocking within the provided action as it can lead to deadlocks or bad performance
foldLeft(B, Function2<B, Object, B>) - Method in class akka.util.ByteIterator
 
Foreach<T> - Class in akka.dispatch
Callback for the Future.foreach operation that will be invoked if the Future that this callback is registered on becomes completed with a success.
Foreach() - Constructor for class akka.dispatch.Foreach
 
foreach(Function1<Object, U>) - Method in class akka.util.ByteIterator
 
foreach(Function1<Object, U>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
foreach(Function1<Object, U>) - Method in class akka.util.ByteString
 
foreach(Function1<To, C>) - Method in class akka.util.Collections.PartialImmutableValuesIterable
 
foreach(Function2<K, V, BoxedUnit>) - Method in class akka.util.Index
Applies the supplied function to all keys and their values
ForkJoinExecutorConfigurator - Class in akka.dispatch
 
ForkJoinExecutorConfigurator(Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator
 
ForkJoinExecutorConfigurator$ - Class in akka.dispatch
 
ForkJoinExecutorConfigurator$() - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator$
 
ForkJoinExecutorConfigurator.AkkaForkJoinPool - Class in akka.dispatch
INTERNAL AKKA USAGE ONLY
ForkJoinExecutorConfigurator.AkkaForkJoinPool(int, ForkJoinPool.ForkJoinWorkerThreadFactory, Thread.UncaughtExceptionHandler) - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinPool
 
ForkJoinExecutorConfigurator.AkkaForkJoinTask - Class in akka.dispatch
INTERNAL AKKA USAGE ONLY
ForkJoinExecutorConfigurator.AkkaForkJoinTask(Runnable) - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinTask
 
ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory - Class in akka.dispatch
 
ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory(ForkJoinPool.ForkJoinWorkerThreadFactory, int) - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory
 
format(String, Seq<Object>) - Method in interface akka.event.LoggingAdapter
 
format1(String, Object) - Method in interface akka.event.LoggingAdapter
 
forMax(Duration) - Method in class akka.actor.FSM.State
Modify state transition descriptor to include a state timeout for the next state.
forward(Object, ActorContext) - Method in class akka.actor.ActorRef
Forwards the message and passes the original sender actor as the sender.
forward(Object, ActorContext) - Method in class akka.actor.ActorSelection
Forwards the message and passes the original sender actor as the sender.
from() - Method in class akka.actor.FSM.Transition
 
fromActor() - Method in class akka.event.LogSource$
 
fromActor() - Method in interface akka.event.LogSource
 
fromActorRef() - Method in class akka.event.LogSource$
 
fromActorRef() - Method in interface akka.event.LogSource
 
fromActorSystem(ActorSystem) - Method in class akka.event.EventStream$
 
fromActorSystem(ActorSystem) - Static method in class akka.event.EventStream
 
fromAnyClass() - Method in class akka.event.LogSource$
 
fromAnyClass() - Method in interface akka.event.LogSource
 
fromAnyRef(Object) - Method in class akka.event.LogSource$
construct string representation for any object according to rules above with fallback to its Class’s simple name.
fromAnyRef(Object, ActorSystem) - Method in class akka.event.LogSource$
construct string representation for any object according to rules above (including the actor system’s address) with fallback to its Class’s simple name.
fromAnyRef(Object) - Method in interface akka.event.LogSource
construct string representation for any object according to rules above with fallback to its Class’s simple name.
fromAnyRef(Object, ActorSystem) - Method in interface akka.event.LogSource
construct string representation for any object according to rules above (including the actor system’s address) with fallback to its Class’s simple name.
fromArray(byte[]) - Method in class akka.util.ByteString$
Creates a new ByteString by copying a byte array.
fromArray(byte[], int, int) - Method in class akka.util.ByteString$
Creates a new ByteString by copying length bytes starting at offset from an Array.
fromArray(byte[]) - Static method in class akka.util.ByteString
Creates a new ByteString by copying a byte array.
fromArray(byte[], int, int) - Static method in class akka.util.ByteString
Creates a new ByteString by copying length bytes starting at offset from an Array.
fromArray(byte[], int, int) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by copying length bytes starting at offset from an Array.
fromArray(byte[], int, int) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by copying length bytes starting at offset from an Array.
fromBinary(byte[], Option<Class<?>>) - Method in class akka.serialization.ByteArraySerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in class akka.serialization.JavaSerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in class akka.serialization.JSerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in class akka.serialization.NullSerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in interface akka.serialization.Serializer
Produces an object from an array of bytes, with an optional type-hint; the class should be loaded using ActorSystem.dynamicAccess.
fromBinary(byte[]) - Method in interface akka.serialization.Serializer
Java API: deserialize without type hint
fromBinary(byte[], Class<?>) - Method in interface akka.serialization.Serializer
Java API: deserialize with type hint
fromBinaryJava(byte[], Class<?>) - Method in class akka.serialization.JSerializer
This method must be implemented, manifest may be null.
fromByteBuffer(ByteBuffer) - Method in class akka.util.ByteString$
Creates a new ByteString by copying bytes out of a ByteBuffer.
fromByteBuffer(ByteBuffer) - Static method in class akka.util.ByteString
Creates a new ByteString by copying bytes out of a ByteBuffer.
fromClass() - Method in class akka.event.LogSource$
 
fromClass() - Method in interface akka.event.LogSource
 
fromConfig(Config) - Method in class akka.routing.DefaultResizer$
 
fromConfig(Config) - Static method in class akka.routing.DefaultResizer
 
FromConfig - Class in akka.routing
Java API: Router configuration which has no default, i.e.
FromConfig(Option<Resizer>, SupervisorStrategy, String) - Constructor for class akka.routing.FromConfig
 
FromConfig() - Constructor for class akka.routing.FromConfig
 
FromConfig$ - Class in akka.routing
Router configuration which has no default, i.e.
FromConfig$() - Constructor for class akka.routing.FromConfig$
 
fromExecutor(Executor) - Method in class akka.dispatch.ExecutionContexts$
Returns a new ExecutionContextExecutor which will delegate execution to the underlying Executor, and which will use the default error reporter.
fromExecutor(Executor, Procedure<Throwable>) - Method in class akka.dispatch.ExecutionContexts$
Returns a new ExecutionContextExecutor which will delegate execution to the underlying Executor, and which will use the provided error reporter.
fromExecutor(Executor) - Static method in class akka.dispatch.ExecutionContexts
Returns a new ExecutionContextExecutor which will delegate execution to the underlying Executor, and which will use the default error reporter.
fromExecutor(Executor, Procedure<Throwable>) - Static method in class akka.dispatch.ExecutionContexts
Returns a new ExecutionContextExecutor which will delegate execution to the underlying Executor, and which will use the provided error reporter.
fromExecutorService(ExecutorService) - Method in class akka.dispatch.ExecutionContexts$
Returns a new ExecutionContextExecutorService which will delegate execution to the underlying ExecutorService, and which will use the default error reporter.
fromExecutorService(ExecutorService, Procedure<Throwable>) - Method in class akka.dispatch.ExecutionContexts$
Returns a new ExecutionContextExecutorService which will delegate execution to the underlying ExecutorService, and which will use the provided error reporter.
fromExecutorService(ExecutorService) - Static method in class akka.dispatch.ExecutionContexts
Returns a new ExecutionContextExecutorService which will delegate execution to the underlying ExecutorService, and which will use the default error reporter.
fromExecutorService(ExecutorService, Procedure<Throwable>) - Static method in class akka.dispatch.ExecutionContexts
Returns a new ExecutionContextExecutorService which will delegate execution to the underlying ExecutorService, and which will use the provided error reporter.
fromScalaOption(Option<T>) - Method in class akka.japi.Option$
Converts a Scala Option to a Java Option
fromScalaOption(Option<T>) - Static method in class akka.japi.Option
Converts a Scala Option to a Java Option
fromString(String) - Method in class akka.actor.ActorPath$
Parse string as actor path; throws java.net.MalformedURLException if unable to do so.
fromString(String) - Method in interface akka.actor.ActorPath
Parse string as actor path; throws java.net.MalformedURLException if unable to do so.
fromString() - Method in class akka.event.LogSource$
 
fromString() - Method in interface akka.event.LogSource
 
fromString(String) - Method in class akka.util.ByteString$
Creates a new ByteString which will contain the UTF-8 representation of the given String
fromString(String, String) - Method in class akka.util.ByteString$
Creates a new ByteString which will contain the representation of the given String in the given charset
fromString(String) - Static method in class akka.util.ByteString
Creates a new ByteString which will contain the UTF-8 representation of the given String
fromString(String, String) - Static method in class akka.util.ByteString
Creates a new ByteString which will contain the representation of the given String in the given charset
FSM<S,D> - Interface in akka.actor
Finite State Machine actor trait.
FSM$ - Class in akka.actor
 
FSM$() - Constructor for class akka.actor.FSM$
 
FSM.$minus$greater$ - Class in akka.actor
This extractor is just convenience for matching a (S, S) pair, including a reminder what the new state is.
FSM.$minus$greater$() - Constructor for class akka.actor.FSM.$minus$greater$
 
FSM.CurrentState<S> - Class in akka.actor
Message type which is sent directly to the subscribed actor in FSM.SubscribeTransitionCallBack before sending any FSM.Transition messages.
FSM.CurrentState(ActorRef, S) - Constructor for class akka.actor.FSM.CurrentState
 
FSM.CurrentState$ - Class in akka.actor
 
FSM.CurrentState$() - Constructor for class akka.actor.FSM.CurrentState$
 
FSM.Event<D> - Class in akka.actor
All messages sent to the FSM will be wrapped inside an Event, which allows pattern matching to extract both state and data.
FSM.Event(Object, D) - Constructor for class akka.actor.FSM.Event
 
FSM.Event$ - Class in akka.actor
 
FSM.Event$() - Constructor for class akka.actor.FSM.Event$
 
FSM.Failure - Class in akka.actor
Signifies that the FSM is shutting itself down because of an error, e.g.
FSM.Failure(Object) - Constructor for class akka.actor.FSM.Failure
 
FSM.Failure$ - Class in akka.actor
 
FSM.Failure$() - Constructor for class akka.actor.FSM.Failure$
 
FSM.LogEntry<S,D> - Class in akka.actor
Log Entry of the LoggingFSM, can be obtained by calling getLog.
FSM.LogEntry(S, D, Object) - Constructor for class akka.actor.FSM.LogEntry
 
FSM.LogEntry$ - Class in akka.actor
 
FSM.LogEntry$() - Constructor for class akka.actor.FSM.LogEntry$
 
FSM.Normal$ - Class in akka.actor
Default reason if calling stop().
FSM.Normal$() - Constructor for class akka.actor.FSM.Normal$
 
FSM.NullFunction$ - Class in akka.actor
A partial function value which does not match anything and can be used to “reset” whenUnhandled and onTermination handlers.
FSM.NullFunction$() - Constructor for class akka.actor.FSM.NullFunction$
 
FSM.Reason - Interface in akka.actor
Reason why this FSM is shutting down.
FSM.Shutdown$ - Class in akka.actor
Reason given when someone was calling system.stop(fsm) from outside; also applies to Stop supervision directive.
FSM.Shutdown$() - Constructor for class akka.actor.FSM.Shutdown$
 
FSM.State<S,D> - Class in akka.actor
This captures all of the managed state of the FSM: the state name, the state data, possibly custom timeout, stop reason and replies accumulated while processing the last message.
FSM.State(S, D, Option<FiniteDuration>, Option<FSM.Reason>, List<Object>) - Constructor for class akka.actor.FSM.State
 
FSM.State$ - Class in akka.actor
 
FSM.State$() - Constructor for class akka.actor.FSM.State$
 
FSM.StateTimeout$ - Class in akka.actor
This case object is received in case of a state timeout.
FSM.StateTimeout$() - Constructor for class akka.actor.FSM.StateTimeout$
 
FSM.StopEvent<S,D> - Class in akka.actor
Case class representing the state of the FSM whithin the onTermination block.
FSM.StopEvent(FSM.Reason, S, D) - Constructor for class akka.actor.FSM.StopEvent
 
FSM.StopEvent$ - Class in akka.actor
 
FSM.StopEvent$() - Constructor for class akka.actor.FSM.StopEvent$
 
FSM.SubscribeTransitionCallBack - Class in akka.actor
Send this to an FSM to request first the FSM.CurrentState and then a series of FSM.Transition updates.
FSM.SubscribeTransitionCallBack(ActorRef) - Constructor for class akka.actor.FSM.SubscribeTransitionCallBack
 
FSM.SubscribeTransitionCallBack$ - Class in akka.actor
 
FSM.SubscribeTransitionCallBack$() - Constructor for class akka.actor.FSM.SubscribeTransitionCallBack$
 
FSM.TimeoutMarker - Class in akka.actor
INTERNAL API
FSM.TimeoutMarker(long) - Constructor for class akka.actor.FSM.TimeoutMarker
 
FSM.TimeoutMarker$ - Class in akka.actor
 
FSM.TimeoutMarker$() - Constructor for class akka.actor.FSM.TimeoutMarker$
 
FSM.Timer - Class in akka.actor
INTERNAL API
FSM.Timer(String, Object, boolean, int, ActorContext) - Constructor for class akka.actor.FSM.Timer
 
FSM.Timer$ - Class in akka.actor
 
FSM.Timer$() - Constructor for class akka.actor.FSM.Timer$
 
FSM.TransformHelper - Class in akka.actor
 
FSM.TransformHelper(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Constructor for class akka.actor.FSM.TransformHelper
 
FSM.Transition<S> - Class in akka.actor
Message type which is used to communicate transitions between states to all subscribed listeners (use FSM.SubscribeTransitionCallBack).
FSM.Transition(ActorRef, S, S) - Constructor for class akka.actor.FSM.Transition
 
FSM.Transition$ - Class in akka.actor
 
FSM.Transition$() - Constructor for class akka.actor.FSM.Transition$
 
FSM.UnsubscribeTransitionCallBack - Class in akka.actor
Unsubscribe from FSM.Transition notifications which was effected by sending the corresponding FSM.SubscribeTransitionCallBack.
FSM.UnsubscribeTransitionCallBack(ActorRef) - Constructor for class akka.actor.FSM.UnsubscribeTransitionCallBack
 
FSM.UnsubscribeTransitionCallBack$ - Class in akka.actor
 
FSM.UnsubscribeTransitionCallBack$() - Constructor for class akka.actor.FSM.UnsubscribeTransitionCallBack$
 
FsmDebugEvent() - Method in class akka.actor.ActorSystem.Settings
 
fsmRef() - Method in class akka.actor.FSM.CurrentState
 
fsmRef() - Method in class akka.actor.FSM.Transition
 
FSMStateFunctionBuilder<S,D> - Class in akka.japi.pf
Builder used to create a partial function for FSM.whenUnhandled(scala.PartialFunction, akka.actor.FSM.State>).
FSMStateFunctionBuilder() - Constructor for class akka.japi.pf.FSMStateFunctionBuilder
 
FSMStopBuilder<S,D> - Class in akka.japi.pf
Builder used to create a partial function for FSM.onTermination(scala.PartialFunction, scala.runtime.BoxedUnit>).
FSMStopBuilder() - Constructor for class akka.japi.pf.FSMStopBuilder
 
FSMTransitionHandlerBuilder<S> - Class in akka.japi.pf
Builder used to create a partial function for FSM.onTransition(scala.PartialFunction, scala.runtime.BoxedUnit>).
FSMTransitionHandlerBuilder() - Constructor for class akka.japi.pf.FSMTransitionHandlerBuilder
 
full() - Method in interface akka.actor.LoggingFSM
 
Function<T,R> - Interface in akka.japi
A Function interface.
Function2<T1,T2,R> - Interface in akka.japi
A Function interface.
future(Callable<T>, ExecutionContext) - Method in class akka.dispatch.Futures$
Starts an asynchronous computation and returns a Future object with the result of that computation.
future(Callable<T>, ExecutionContext) - Static method in class akka.dispatch.Futures
Starts an asynchronous computation and returns a Future object with the result of that computation.
future() - Method in class akka.pattern.PipeToSupport.PipeableFuture
 
Futures - Class in akka.dispatch
Futures is the Java API for Futures and Promises
Futures() - Constructor for class akka.dispatch.Futures
 
Futures$ - Class in akka.dispatch
Futures is the Java API for Futures and Promises
Futures$() - Constructor for class akka.dispatch.Futures$
 
FutureTimeoutSupport - Interface in akka.pattern
Copyright (C) 2009-2014 Typesafe Inc.

G

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(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) - 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
 
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
 
getByte() - Method in class akka.util.ByteIterator
Get a single Byte from this iterator.
getByteBuffers() - Method in class akka.util.ByteString
Java API: Returns an Iterable of read-only ByteBuffers that directly wraps this ByteStrings all fragments.
getBytes(byte[], int, int) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
getBytes(byte[]) - Method in class akka.util.ByteIterator
Get a specific number of Bytes from this iterator.
getBytes(byte[], int, int) - Method in class akka.util.ByteIterator
Get a specific number of Bytes from this iterator.
getBytes(byte[], int, int) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
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.UntypedActorContext
Returns a reference to the named child or null if no child with that name exists.
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.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
 
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.
getDefaultAddress() - Method in interface akka.actor.ActorRefProvider
Obtain the external address of the default transport.
getDouble(ByteOrder) - Method in class akka.util.ByteIterator
 
getDoubles(double[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
getDoubles(double[], ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Doubles from this iterator.
getDoubles(double[], int, int, ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Doubles from this iterator.
getDoubles(double[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
getElements() - Method in interface akka.actor.ActorPath
Java API: Sequence of names for this path from root to this.
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.
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.CurrentRoutees$
Java API: get the singleton instance
getInstance() - Static method in class akka.routing.CurrentRoutees
Java API: get the singleton instance
getInstance() - Method in class akka.routing.FromConfig$
Java API: get the singleton instance
getInstance() - Static method in class akka.routing.FromConfig
Java API: get the singleton instance
getInstance() - Method in class akka.routing.GetRoutees$
Java API: get the singleton instance
getInstance() - Static method in class akka.routing.GetRoutees
Java API: get the singleton instance
getInstance() - Method in class akka.routing.NoRouter$
Java API: get the singleton instance
getInstance() - Static method in class akka.routing.NoRouter
Java API: get the singleton instance
getInt(ByteOrder) - Method in class akka.util.ByteIterator
Get a single Int from this iterator.
getInts(int[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
getInts(int[], ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Ints from this iterator.
getInts(int[], int, int, ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Ints from this iterator.
getInts(int[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
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(ByteOrder) - Method in class akka.util.ByteIterator
Get a single Long from this iterator.
getLongPart(int, ByteOrder) - Method in class akka.util.ByteIterator
Get a Long from this iterator where only the least significant n bytes were encoded.
getLongs(long[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
getLongs(long[], ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Longs from this iterator.
getLongs(long[], int, int, ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Longs from this iterator.
getLongs(long[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
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.
getMessage() - Method in class akka.actor.UnhandledMessage
 
getMessage() - Method in class akka.event.Logging.LogEventException
 
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
 
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
 
getPaths() - Method in class akka.routing.GroupBase
 
getRawResult() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinTask
 
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.
GetRoutees - Class in akka.routing
Sending this message to a router will make it send back its currently used routees.
GetRoutees() - Constructor for class akka.routing.GetRoutees
 
getRoutees() - Method in class akka.routing.Routees
Java API
getRoutees() - Method in class akka.routing.RouterRoutees
Java API
getRoutees() - Method in class akka.routing.SeveralRoutees
Java API
GetRoutees$ - Class in akka.routing
 
GetRoutees$() - Constructor for class akka.routing.GetRoutees$
 
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
getToArray(Object, int, int, int, Function0<A>, Function3<Object, Object, Object, BoxedUnit>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
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 interface akka.actor.ActorRefFactory
Father of all children created by this interface.
guardian() - Method in interface akka.actor.ActorRefProvider
Reference to the supervisor used for all top-level user actors.
guardian() - Method in class akka.actor.ExtendedActorSystem
The top-level supervisor of all actors created using system.actorOf(...).

H

handleChildTerminated(ActorContext, ActorRef, Iterable<ActorRef>) - Method in class akka.actor.AllForOneStrategy
 
handleChildTerminated(ActorContext, ActorRef, Iterable<ActorRef>) - Method in class akka.actor.OneForOneStrategy
 
handleChildTerminated(ActorContext, ActorRef, Iterable<ActorRef>) - Method in class akka.actor.SupervisorStrategy
This method is called after the child has been removed from the set of children.
handleEvent() - Method in interface akka.actor.FSM
 
handleEventDefault() - Method in interface akka.actor.FSM
 
handleFailure(ActorContext, ActorRef, Throwable, ChildRestartStats, Iterable<ChildRestartStats>) - Method in class akka.actor.SupervisorStrategy
This is the main entry point: in case of a child’s failure, this method must try to handle the failure by resuming, restarting or stopping the child (and returning true), or it returns false to escalate the failure, which will lead to this actor re-throwing the exception which caused the failure.
handler() - Method in class akka.io.Tcp.Bind
 
handler() - Method in class akka.io.Tcp.Register
 
handler() - Method in class akka.io.Udp.Bind
 
handler() - Method in class akka.io.UdpConnected.Connect
 
handleTransition(S, S) - Method in interface akka.actor.FSM
 
hasDispatcher(String) - Method in class akka.dispatch.Dispatchers
Checks that the configuration provides a section for the given dispatcher.
hasExtension(ExtensionId<? extends Extension>) - Method in class akka.actor.ActorSystem
Returns whether the specified extension is already registered, this method can potentially block, waiting for the initialization of the payload, if is in the process of registration from another Thread of execution
hasGlobalScope() - Method in class akka.actor.Address
Returns true if this Address is usable globally.
hash(int, Object) - Method in class akka.util.HashCode$
 
hash(int, boolean) - Method in class akka.util.HashCode$
 
hash(int, char) - Method in class akka.util.HashCode$
 
hash(int, int) - Method in class akka.util.HashCode$
 
hash(int, long) - Method in class akka.util.HashCode$
 
hash(int, float) - Method in class akka.util.HashCode$
 
hash(int, double) - Method in class akka.util.HashCode$
 
hash(int, Object) - Static method in class akka.util.HashCode
 
hash(int, boolean) - Static method in class akka.util.HashCode
 
hash(int, char) - Static method in class akka.util.HashCode
 
hash(int, int) - Static method in class akka.util.HashCode
 
hash(int, long) - Static method in class akka.util.HashCode
 
hash(int, float) - Static method in class akka.util.HashCode
 
hash(int, double) - Static method in class akka.util.HashCode
 
hashCode() - Method in class akka.actor.ActorRef
 
hashCode() - Method in class akka.actor.ActorSelection
 
hashCode() - Method in class akka.actor.Address
 
hashCode() - Method in class akka.actor.ChildActorPath
 
hashCode() - Method in interface akka.actor.ExtensionId
 
HashCode - Class in akka.util
Set of methods which allow easy implementation of hashCode.
HashCode() - Constructor for class akka.util.HashCode
 
HashCode$ - Class in akka.util
Set of methods which allow easy implementation of hashCode.
HashCode$() - Constructor for class akka.util.HashCode$
 
hashKey() - Method in class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope
 
hashKey(Object) - Method in interface akka.routing.ConsistentHashingRouter.ConsistentHashMapper
 
hashMapping() - Method in class akka.routing.ConsistentHashingGroup
 
hashMapping() - Method in class akka.routing.ConsistentHashingPool
 
hashMapping() - Method in class akka.routing.ConsistentHashingRouter
 
hashMapping() - Method in class akka.routing.ConsistentHashingRoutingLogic
 
hasLocalScope() - Method in class akka.actor.Address
Returns true if this Address is only defined locally.
hasMessages() - Method in interface akka.dispatch.MessageQueue
Indicates whether this queue is non-empty.
hasMessages() - Method in class akka.dispatch.NodeMessageQueue
 
hasMessages() - Method in interface akka.dispatch.QueueBasedMessageQueue
 
hasMessages(Routee) - Method in class akka.routing.SmallestMailboxRoutingLogic
Returns true if the actor currently has any pending messages in the mailbox, i.e.
hasNext() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
hasNext() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
head() - Method in class akka.io.Tcp.CompoundWrite
 
head() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
head() - Method in class akka.util.ByteIterator
 
head() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
head() - Method in class akka.util.ByteString
 
Helpers - Class in akka.util
 
Helpers() - Constructor for class akka.util.Helpers
 
Helpers$ - Class in akka.util
 
Helpers$() - Constructor for class akka.util.Helpers$
 
Helpers.ConfigOps$ - Class in akka.util
 
Helpers.ConfigOps$() - Constructor for class akka.util.Helpers.ConfigOps$
 
Helpers.Requiring<A> - Class in akka.util
Implicit class providing requiring methods.
Helpers.Requiring(A) - Constructor for class akka.util.Helpers.Requiring
 
Helpers.Requiring$ - Class in akka.util
 
Helpers.Requiring$() - Constructor for class akka.util.Helpers.Requiring$
 
hex() - Method in class akka.util.Crypt$
 
hex() - Static method in class akka.util.Crypt
 
hexify(byte[]) - Method in class akka.util.Crypt$
 
hexify(byte[]) - Static method in class akka.util.Crypt
 
Home() - Method in class akka.actor.ActorSystem.Settings
 
host() - Method in class akka.actor.Address
 
hostPort() - Method in class akka.actor.Address
Returns a String representation formatted as:

I

id() - Method in class akka.dispatch.Dispatcher
 
id() - Method in class akka.dispatch.MessageDispatcher
Identifier of this dispatcher, corresponds to the full key of the dispatcher configuration.
identifier() - Method in class akka.serialization.ByteArraySerializer
 
identifier() - Method in class akka.serialization.JavaSerializer
 
identifier() - Method in class akka.serialization.NullSerializer
 
identifier() - Method in interface akka.serialization.Serializer
Completely unique value to identify this implementation of Serializer, used to optimize network traffic Values from 0 to 16 is reserved for Akka internal usage
Identify - Class in akka.actor
A message all Actors will understand, that when processed will reply with ActorIdentity containing the ActorRef.
Identify(Object) - Constructor for class akka.actor.Identify
 
Identify$ - Class in akka.actor
 
Identify$() - Constructor for class akka.actor.Identify$
 
identityHashComparator(Comparator<T>) - Method in class akka.util.Helpers$
Create a comparator which will efficiently use System.identityHashCode, unless that happens to be the same for two non-equals objects, in which case the supplied “real” comparator is used; the comparator must be consistent with equals, otherwise it would not be an enhancement over the identityHashCode.
identityHashComparator(Comparator<T>) - Static method in class akka.util.Helpers
Create a comparator which will efficiently use System.identityHashCode, unless that happens to be the same for two non-equals objects, in which case the supplied “real” comparator is used; the comparator must be consistent with equals, otherwise it would not be an enhancement over the identityHashCode.
ifOff(Function0<BoxedUnit>) - Method in class akka.util.Switch
Executes the provided action and returns if the action was executed or not, if the switch is IMMEDIATELY off (i.e.
ifOffYield(Function0<T>) - Method in class akka.util.Switch
Executes the provided action and returns its value if the switch is IMMEDIATELY off (i.e.
ifOn(Function0<BoxedUnit>) - Method in class akka.util.Switch
Executes the provided action and returns if the action was executed or not, if the switch is IMMEDIATELY on (i.e.
ifOnYield(Function0<T>) - Method in class akka.util.Switch
Executes the provided action and returns its value if the switch is IMMEDIATELY on (i.e.
IllegalActorStateException - Exception in akka.actor
IllegalActorStateException is thrown when a core invariant in the Actor implementation has been violated.
IllegalActorStateException$ - Class in akka.actor
 
IllegalActorStateException$() - Constructor for class akka.actor.IllegalActorStateException$
 
immutableIndexedSeq(Iterable<T>) - Method in class akka.japi.Util$
Turns an Iterable into an immutable Scala IndexedSeq (by copying it).
immutableIndexedSeq(Iterable<T>) - Static method in class akka.japi.Util
Turns an Iterable into an immutable Scala IndexedSeq (by copying it).
immutableSeq(Class<?>[]) - Method in class akka.japi.Util$
Returns an immutable.Seq representing the provided array of Classes, an overloading of the generic immutableSeq in Util, to accommodate for erasure.
immutableSeq(Object) - Method in class akka.japi.Util$
Turns an array into an immutable Scala sequence (by copying it).
immutableSeq(Iterable<T>) - Method in class akka.japi.Util$
Turns an Iterable into an immutable Scala sequence (by copying it).
immutableSeq(Class<?>[]) - Static method in class akka.japi.Util
Returns an immutable.Seq representing the provided array of Classes, an overloading of the generic immutableSeq in Util, to accommodate for erasure.
immutableSeq(Object) - Static method in class akka.japi.Util
Turns an array into an immutable Scala sequence (by copying it).
immutableSeq(Iterable<T>) - Static method in class akka.japi.Util
Turns an Iterable into an immutable Scala sequence (by copying it).
immutableSingletonSeq(T) - Method in class akka.japi.Util$
 
immutableSingletonSeq(T) - Static method in class akka.japi.Util
 
Inbox - Interface in akka.actor.dsl
 
inbox(ActorSystem) - Method in interface akka.actor.dsl.Inbox
Create a new actor which will internally queue up messages it gets so that they can be interrogated with the akka.actor.dsl.Inbox!.Inbox!.receive and akka.actor.dsl.Inbox!.Inbox!.select methods.
Inbox - Class in akka.actor
An Inbox is an actor-like object which is interrogated from the outside.
Inbox() - Constructor for class akka.actor.Inbox
 
Inbox$ - Class in akka.actor.dsl
INTERNAL API
Inbox$() - Constructor for class akka.actor.dsl.Inbox$
 
Inbox$ - Class in akka.actor
 
Inbox$() - Constructor for class akka.actor.Inbox$
 
Inbox.Get - Class in akka.actor.dsl
 
Inbox.Get(Deadline, ActorRef) - Constructor for class akka.actor.dsl.Inbox.Get
 
Inbox.Get$ - Class in akka.actor.dsl
 
Inbox.Get$() - Constructor for class akka.actor.dsl.Inbox.Get$
 
Inbox.Inbox - Class in akka.actor.dsl
 
Inbox.Inbox(ActorSystem) - Constructor for class akka.actor.dsl.Inbox.Inbox
 
Inbox.InboxActor - Class in akka.actor.dsl
 
Inbox.InboxActor(int) - Constructor for class akka.actor.dsl.Inbox.InboxActor
 
Inbox.InboxExtension - Interface in akka.actor.dsl
 
Inbox.Kick$ - Class in akka.actor.dsl
 
Inbox.Kick$() - Constructor for class akka.actor.dsl.Inbox.Kick$
 
Inbox.Query - Interface in akka.actor.dsl
 
Inbox.Select - Class in akka.actor.dsl
 
Inbox.Select(Deadline, PartialFunction<Object, Object>, ActorRef) - Constructor for class akka.actor.dsl.Inbox.Select
 
Inbox.Select$ - Class in akka.actor.dsl
 
Inbox.Select$() - Constructor for class akka.actor.dsl.Inbox.Select$
 
Inbox.StartWatch - Class in akka.actor.dsl
 
Inbox.StartWatch(ActorRef) - Constructor for class akka.actor.dsl.Inbox.StartWatch
 
Inbox.StartWatch$ - Class in akka.actor.dsl
 
Inbox.StartWatch$() - Constructor for class akka.actor.dsl.Inbox.StartWatch$
 
inboxNr() - Method in interface akka.actor.dsl.Inbox.InboxExtension
 
inboxProps() - Method in interface akka.actor.dsl.Inbox.InboxExtension
 
includeManifest() - Method in class akka.serialization.ByteArraySerializer
 
includeManifest() - Method in class akka.serialization.JavaSerializer
 
includeManifest() - Method in class akka.serialization.NullSerializer
 
includeManifest() - Method in interface akka.serialization.Serializer
Returns whether this serializer needs a manifest in the fromBinary method
Index<K,V> - Class in akka.util
An implementation of a ConcurrentMultiMap Adds/remove is serialized over the specified key Reads are fully concurrent <-- el-cheapo
Index(int, Comparator<V>) - Constructor for class akka.util.Index
 
Index(int, Function2<V, V, Object>) - Constructor for class akka.util.Index
 
indexOf(byte) - Method in class akka.util.ByteIterator
 
indexOf(B) - Method in class akka.util.ByteIterator
 
indexOf(B) - Method in class akka.util.ByteString
 
indexWhere(Function1<Object, Object>) - Method in class akka.util.ByteIterator
 
indexWhere(Function1<Object, Object>) - Method in class akka.util.ByteString
 
IndirectActorProducer - Interface in akka.actor
This interface defines a class of actor creation strategies deviating from the usual default of just reflectively instantiating the Actor subclass.
IndirectActorProducer$ - Class in akka.actor
 
IndirectActorProducer$() - Constructor for class akka.actor.IndirectActorProducer$
 
Inet - Class in akka.io
 
Inet() - Constructor for class akka.io.Inet
 
Inet$ - Class in akka.io
 
Inet$() - Constructor for class akka.io.Inet$
 
Inet.SO$ - Class in akka.io
 
Inet.SO$() - Constructor for class akka.io.Inet.SO$
 
Inet.SO$.ReceiveBufferSize - Class in akka.io
Inet.SocketOption to set the SO_RCVBUF option
Inet.SO$.ReceiveBufferSize(int) - Constructor for class akka.io.Inet.SO$.ReceiveBufferSize
 
Inet.SO$.ReuseAddress - Class in akka.io
Inet.SocketOption to enable or disable SO_REUSEADDR
Inet.SO$.ReuseAddress(boolean) - Constructor for class akka.io.Inet.SO$.ReuseAddress
 
Inet.SO$.SendBufferSize - Class in akka.io
Inet.SocketOption to set the SO_SNDBUF option.
Inet.SO$.SendBufferSize(int) - Constructor for class akka.io.Inet.SO$.SendBufferSize
 
Inet.SO$.TrafficClass - Class in akka.io
Inet.SocketOption to set the traffic class or type-of-service octet in the IP header for packets sent from this socket.
Inet.SO$.TrafficClass(int) - Constructor for class akka.io.Inet.SO$.TrafficClass
 
Inet.SocketOption - Interface in akka.io
SocketOption is a package of data (from the user) and associated behavior (how to apply that to a socket).
Inet.SoForwarders - Interface in akka.io
 
Inet.SoJavaFactories - Interface in akka.io
 
info(Logging.Info) - Method in interface akka.event.Logging.StdOutLogger
 
info(String) - Method in interface akka.event.LoggingAdapter
Log message at info level.
info(String, Object) - Method in interface akka.event.LoggingAdapter
Message template with 1 replacement argument.
info(String, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 2 replacement arguments.
info(String, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 3 replacement arguments.
info(String, Object, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 4 replacement arguments.
infoFormat() - Method in interface akka.event.Logging.StdOutLogger
 
InfoLevel() - Method in class akka.event.Logging$
 
InfoLevel() - Static method in class akka.event.Logging
 
inhabitants() - Method in class akka.dispatch.MessageDispatcher
 
init(ActorSystemImpl) - Method in interface akka.actor.ActorRefProvider
Initialization of an ActorRefProvider happens in two steps: first construction of the object with settings, eventStream, etc.
init() - Method in class akka.util.ByteString
 
initialCapacity() - Method in class akka.dispatch.UnboundedPriorityMailbox
 
initialize() - Method in interface akka.actor.FSM
Verify existence of initial state and setup timers.
instance - Static variable in class akka.util.Unsafe
 
interfaces() - Method in class akka.actor.TypedProps
 
internal(T) - Method in class akka.dispatch.Foreach
 
internal(T) - Method in class akka.dispatch.japi.BooleanFunctionBridge
 
internal(T) - Method in class akka.dispatch.japi.CallbackBridge
 
internal(Throwable) - Method in class akka.dispatch.japi.RecoverBridge
 
internal(T) - Method in class akka.dispatch.japi.UnitFunctionBridge
 
internal(Try<T>) - Method in class akka.dispatch.OnComplete
 
internal(Throwable) - Method in class akka.dispatch.OnFailure
 
internal(T) - Method in class akka.dispatch.OnSuccess
 
internal(Throwable) - Method in class akka.dispatch.Recover
 
intToTimeout(int) - Method in class akka.util.Timeout$
 
intToTimeout(int) - Static method in class akka.util.Timeout
 
InvalidActorNameException - Exception in akka.actor
An InvalidActorNameException is thrown when you try to convert something, usually a String, to an Actor name which doesn't validate.
InvalidActorNameException(String) - Constructor for exception akka.actor.InvalidActorNameException
 
InvalidActorNameException$ - Class in akka.actor
 
InvalidActorNameException$() - Constructor for class akka.actor.InvalidActorNameException$
 
InvalidMessageException - Exception in akka.actor
InvalidMessageException is thrown when an invalid message is sent to an Actor; Currently only null is an invalid message.
InvalidMessageException$ - Class in akka.actor
 
InvalidMessageException$() - Constructor for class akka.actor.InvalidMessageException$
 
invalidPathEntry() - Method in class akka.dispatch.CachingConfig$
 
invokeAll(Collection<? extends Callable<T>>) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
invokeAny(Collection<? extends Callable<T>>) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
IO - Class in akka.io
Entry point to Akka’s IO layer.
IO() - Constructor for class akka.io.IO
 
IO$ - Class in akka.io
Entry point to Akka’s IO layer.
IO$() - Constructor for class akka.io.IO$
 
IO.Extension - Interface in akka.io
 
isAborted() - Method in class akka.io.Tcp.Aborted$
 
isAborted() - Method in interface akka.io.Tcp.ConnectionClosed
true iff the connection has been closed in response to an Abort command.
isBatchable() - Method in class akka.dispatch.TaskInvocation
 
isCancelled() - Method in interface akka.actor.Cancellable
Returns true if and only if this Cancellable has been successfully cancelled
isCancelled() - Method in class akka.actor.LightArrayRevolverScheduler.TaskHolder
 
isCompact() - Method in class akka.util.ByteString.ByteString1
 
isCompact() - Method in class akka.util.ByteString.ByteStrings
 
isCompact() - Method in class akka.util.ByteString
Check whether this ByteString is compact in memory.
isCompact() - Method in class akka.util.CompactByteString
 
isConfirmed() - Method in class akka.io.Tcp.ConfirmedClosed$
 
isConfirmed() - Method in interface akka.io.Tcp.ConnectionClosed
true iff the connection has been fully closed in response to a ConfirmedClose command.
isDebugEnabled() - Method in class akka.event.BusLogging
 
isDebugEnabled() - Method in interface akka.event.LoggingAdapter
 
isDebugEnabled() - Method in class akka.event.NoLogging$
 
isDebugEnabled() - Static method in class akka.event.NoLogging
 
isDefined() - Method in class akka.japi.Option
 
isDefinedAt(Object) - Method in class akka.actor.Actor.emptyBehavior$
 
isDefinedAt(Object) - Method in class akka.actor.FSM.NullFunction$
 
isDefinedAt(T) - Method in class akka.dispatch.japi.CallbackBridge
 
isDefinedAt(Throwable) - Method in class akka.dispatch.japi.RecoverBridge
 
isDefinedAt(Object) - Method in class akka.event.LoggingReceive
 
isDefinedAt(A) - Method in class akka.japi.JavaPartialFunction
 
isDefinedAt(Object) - Method in class akka.routing.ConsistentHashingRouter.emptyConsistentHashMapping$
 
isDefinedAt(From) - Method in class akka.util.Collections.PartialImmutableValuesIterable
 
isEmpty() - Method in class akka.dispatch.AbstractNodeQueue
 
isEmpty() - Method in class akka.japi.Option
 
isEmpty() - Method in class akka.japi.Option.Some
 
isEmpty() - Method in class akka.routing.ConsistentHash
Is the node ring empty, i.e.
isEmpty() - Method in class akka.util.BoundedBlockingQueue
 
isEmpty() - Method in class akka.util.Index
 
isEnabled(Logging.LogLevel) - Method in interface akka.event.LoggingAdapter
 
isEqual(K, K) - Method in interface akka.util.Subclassification
True if and only if x and y are of the same class.
isErrorClosed() - Method in interface akka.io.Tcp.ConnectionClosed
true iff the connection has been closed due to an IO error.
isErrorClosed() - Method in class akka.io.Tcp.ErrorClosed
 
isErrorEnabled() - Method in class akka.event.BusLogging
 
isErrorEnabled() - Method in interface akka.event.LoggingAdapter
 
isErrorEnabled() - Method in class akka.event.NoLogging$
 
isErrorEnabled() - Static method in class akka.event.NoLogging
 
isInfoEnabled() - Method in class akka.event.BusLogging
 
isInfoEnabled() - Method in interface akka.event.LoggingAdapter
 
isInfoEnabled() - Method in class akka.event.NoLogging$
 
isInfoEnabled() - Static method in class akka.event.NoLogging
 
isManagementMessage(Object) - Method in interface akka.routing.RouterConfig
Is the message handled by the router head actor or the RouterConfig.routingLogicController(akka.routing.RoutingLogic) actor.
isOff() - Method in class akka.util.Switch
Returns whether the switch is IMMEDDIATELY off (no locking)
isOn() - Method in class akka.util.Switch
Returns whether the switch is IMMEDIATELY on (no locking)
isOneWay() - Method in class akka.actor.TypedActor.MethodCall
 
isPeerClosed() - Method in interface akka.io.Tcp.ConnectionClosed
true iff the connection has been closed by the peer; in case keepOpenOnPeerClosed is in effect as per the Tcp.Register command, this connection’s reading half is now closed.
isPeerClosed() - Method in class akka.io.Tcp.PeerClosed$
 
isProcessingMessage(Routee) - Method in class akka.routing.SmallestMailboxRoutingLogic
Returns true if the actor is currently processing a message.
isShutdown() - Method in interface akka.dispatch.ExecutorServiceDelegate
 
isStateTimerActive() - Method in interface akka.actor.FSM
INTERNAL API, used for testing.
isSubclass(K, K) - Method in interface akka.util.Subclassification
True if and only if x is a subclass of y; equal classes must be considered sub-classes!
isSuspended(Routee) - Method in class akka.routing.SmallestMailboxRoutingLogic
Returns true if the actor is currently suspended.
isTerminated() - Method in class akka.actor.ActorRef
Is the actor shut down? The contract is that if this method returns true, then it will never be false again.
isTerminated() - Method in class akka.actor.ActorSystem
Query the termination status: if it returns true, all callbacks have run and the ActorSystem has been fully stopped, i.e.
isTerminated() - Method in interface akka.dispatch.ExecutorServiceDelegate
 
isTerminated(Routee) - Method in class akka.routing.SmallestMailboxRoutingLogic
 
isThroughputDeadlineTimeDefined() - Method in class akka.dispatch.MessageDispatcher
INTERNAL API
isTimeForResize(long) - Method in class akka.routing.DefaultResizer
 
isTimeForResize(long) - Method in interface akka.routing.Resizer
Is it time for resizing.
isTimerActive(String) - Method in interface akka.actor.FSM
Inquire whether the named timer is still active.
isTypedActor(Object) - Method in class akka.actor.ContextualTypedActorFactory
 
isTypedActor(Object) - Method in class akka.actor.TypedActorExtension
Returns wether the supplied AnyRef is a TypedActor proxy or not
isTypedActor(Object) - Method in interface akka.actor.TypedActorFactory
Returns wether the supplied AnyRef is a TypedActor proxy or not
isWarningEnabled() - Method in class akka.event.BusLogging
 
isWarningEnabled() - Method in interface akka.event.LoggingAdapter
 
isWarningEnabled() - Method in class akka.event.NoLogging$
 
isWarningEnabled() - Static method in class akka.event.NoLogging
 
isWindows() - Method in class akka.util.Helpers$
 
isWindows() - Static method in class akka.util.Helpers
 
iterator() - Method in class akka.io.Tcp.CompoundWrite
 
iterator() - Method in class akka.japi.Option
 
iterator() - Method in class akka.util.BoundedBlockingQueue
 
iterator() - Method in class akka.util.ByteString.ByteString1
 
iterator() - Method in class akka.util.ByteString.ByteString1C
 
iterator() - Method in class akka.util.ByteString.ByteStrings
 
iterator() - Method in class akka.util.ByteString
 
iterator() - Method in class akka.util.Collections.EmptyImmutableSeq$
 
iterator() - Method in class akka.util.Collections.PartialImmutableValuesIterable
 

J

japi - Class in akka.dispatch
This class contains bridge classes between Scala and Java.
japi() - Constructor for class akka.dispatch.japi
 
JAPI - Class in akka.japi
 
JAPI() - Constructor for class akka.japi.JAPI
 
japi$ - Class in akka.dispatch
This class contains bridge classes between Scala and Java.
japi$() - Constructor for class akka.dispatch.japi$
 
japi.BooleanFunctionBridge<T> - Class in akka.dispatch
 
japi.BooleanFunctionBridge() - Constructor for class akka.dispatch.japi.BooleanFunctionBridge
 
japi.CallbackBridge<T> - Class in akka.dispatch
 
japi.CallbackBridge() - Constructor for class akka.dispatch.japi.CallbackBridge
 
japi.RecoverBridge<T> - Class in akka.dispatch
 
japi.RecoverBridge() - Constructor for class akka.dispatch.japi.RecoverBridge
 
japi.UnitFunctionBridge<T> - Class in akka.dispatch
 
japi.UnitFunctionBridge() - Constructor for class akka.dispatch.japi.UnitFunctionBridge
 
java2ScalaOption(Option<A>) - Method in class akka.japi.Option$
 
java2ScalaOption(Option<A>) - Static method in class akka.japi.Option
 
JavaPartialFunction<A,B> - Class in akka.japi
Helper for implementing a *pure* partial function: it will possibly be invoked multiple times for a single “application”, because its only abstract method is used for both isDefinedAt() and apply(); the former is mapped to isCheck == true and the latter to isCheck == false for those cases where this is important to know.
JavaPartialFunction() - Constructor for class akka.japi.JavaPartialFunction
 
JavaPartialFunction$ - Class in akka.japi
 
JavaPartialFunction$() - Constructor for class akka.japi.JavaPartialFunction$
 
JavaPartialFunction.NoMatch$ - Exception in akka.japi
 
JavaPartialFunction.NoMatch$() - Constructor for exception akka.japi.JavaPartialFunction.NoMatch$
 
JavaPartialFunction.NoMatchException - Exception in akka.japi
 
JavaPartialFunction.NoMatchException() - Constructor for exception akka.japi.JavaPartialFunction.NoMatchException
 
JavaSerializer - Class in akka.serialization
This Serializer uses standard Java Serialization
JavaSerializer(ExtendedActorSystem) - Constructor for class akka.serialization.JavaSerializer
 
JavaSerializer$ - Class in akka.serialization
 
JavaSerializer$() - Constructor for class akka.serialization.JavaSerializer$
 
JavaSerializer.CurrentSystem - Class in akka.serialization
 
JavaSerializer.CurrentSystem() - Constructor for class akka.serialization.JavaSerializer.CurrentSystem
 
JSerializer - Class in akka.serialization
Java API for creating a Serializer: make sure to include a constructor which takes exactly one argument of type ExtendedActorSystem, because that is the preferred constructor which will be invoked when reflectively instantiating the JSerializer (also possible with empty constructor).
JSerializer() - Constructor for class akka.serialization.JSerializer
 
JvmExitOnFatalError() - Method in class akka.actor.ActorSystem.Settings
 

K

keepAlive(boolean) - Method in class akka.io.TcpSO$
Inet.SocketOption to enable or disable SO_KEEPALIVE
keepAlive(boolean) - Static method in class akka.io.TcpSO
Inet.SocketOption to enable or disable SO_KEEPALIVE
keepOpenOnPeerClosed() - Method in class akka.io.Tcp.Register
 
keys() - Method in class akka.util.Index
Returns the key set.
Kill - Class in akka.actor
Java API: get the singleton instance
Kill() - Constructor for class akka.actor.Kill
 
Kill$ - Class in akka.actor
A message all Actors will understand, that when processed will make the Actor throw an ActorKilledException, which will trigger supervision.
Kill$() - Constructor for class akka.actor.Kill$
 

L

last() - Method in class akka.util.ByteString
 
LatestFirstSystemMessageList$ - Class in akka.dispatch.sysmsg
 
LatestFirstSystemMessageList$() - Constructor for class akka.dispatch.sysmsg.LatestFirstSystemMessageList$
 
len() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
len() - Method in class akka.util.ByteIterator
 
len() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
length() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
length() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
length() - Method in class akka.util.ByteString.ByteString1
 
length() - Method in class akka.util.ByteString.ByteString1C
 
length() - Method in class akka.util.ByteString.ByteStrings
 
length() - Method in class akka.util.ByteStringBuilder
 
length() - Method in class akka.util.Collections.EmptyImmutableSeq$
 
level() - Method in class akka.event.Logging.Debug
 
level() - Method in class akka.event.Logging.Error
 
level() - Method in class akka.event.Logging.Info
 
level() - Method in interface akka.event.Logging.LogEvent
The LogLevel of this LogEvent
level() - Method in class akka.event.Logging.Warning
 
levelFor(String) - Method in class akka.event.Logging$
Returns the LogLevel associated with the given string, valid inputs are upper or lowercase (not mixed) versions of: "error", "warning", "info" and "debug"
levelFor(Class<? extends Logging.LogEvent>) - Method in class akka.event.Logging$
Returns the LogLevel associated with the given event class.
levelFor(String) - Static method in class akka.event.Logging
Returns the LogLevel associated with the given string, valid inputs are upper or lowercase (not mixed) versions of: "error", "warning", "info" and "debug"
levelFor(Class<? extends Logging.LogEvent>) - Static method in class akka.event.Logging
Returns the LogLevel associated with the given event class.
LightArrayRevolverScheduler - Class in akka.actor
This scheduler implementation is based on a revolving wheel of buckets, like Netty’s HashedWheelTimer, which it advances at a fixed tick rate and dispatches tasks it finds in the current bucket to their respective ExecutionContexts.
LightArrayRevolverScheduler(Config, LoggingAdapter, ThreadFactory) - Constructor for class akka.actor.LightArrayRevolverScheduler
 
LightArrayRevolverScheduler$ - Class in akka.actor
 
LightArrayRevolverScheduler$() - Constructor for class akka.actor.LightArrayRevolverScheduler$
 
LightArrayRevolverScheduler.TaskHolder - Class in akka.actor
INTERNAL API
LightArrayRevolverScheduler.TaskHolder(Runnable, int, ExecutionContext) - Constructor for class akka.actor.LightArrayRevolverScheduler.TaskHolder
 
LightArrayRevolverScheduler.TimerTask - Interface in akka.actor
INTERNAL API
lineSeparator() - Method in class akka.util.Crypt$
 
lineSeparator() - Static method in class akka.util.Crypt
 
linkedBlockingQueue() - Method in class akka.dispatch.ThreadPoolConfig$
 
linkedBlockingQueue(int) - Method in class akka.dispatch.ThreadPoolConfig$
 
linkedBlockingQueue() - Static method in class akka.dispatch.ThreadPoolConfig
 
linkedBlockingQueue(int) - Static method in class akka.dispatch.ThreadPoolConfig
 
Listen - Class in akka.routing
 
Listen(ActorRef) - Constructor for class akka.routing.Listen
 
Listen$ - Class in akka.routing
 
Listen$() - Constructor for class akka.routing.Listen$
 
listener() - Method in class akka.routing.Deafen
 
listener() - Method in class akka.routing.Listen
 
listenerManagement() - Method in interface akka.routing.Listeners
Chain this into the receive function.
ListenerMessage - Interface in akka.routing
 
Listeners - Interface in akka.routing
Listeners is a generic trait to implement listening capability on an Actor.
listeners() - Method in interface akka.routing.Listeners
 
LNil() - Method in class akka.dispatch.sysmsg.SystemMessageList$
 
LNil() - Static method in class akka.dispatch.sysmsg.SystemMessageList
 
loader() - Method in class akka.actor.TypedProps
 
local() - Method in class akka.actor.Deploy$
 
local() - Static method in class akka.actor.Deploy
 
LocalActorRefProvider$ - Class in akka.actor
 
LocalActorRefProvider$() - Constructor for class akka.actor.LocalActorRefProvider$
 
localAddress() - Method in class akka.io.Tcp.Bind
 
localAddress() - Method in class akka.io.Tcp.Bound
 
localAddress() - Method in class akka.io.Tcp.Connect
 
localAddress() - Method in class akka.io.Tcp.Connected
 
localAddress() - Method in class akka.io.Udp.Bind
 
localAddress() - Method in class akka.io.Udp.Bound
 
localAddress() - Method in class akka.io.UdpConnected.Connect
 
LocalScope - Class in akka.actor
 
LocalScope() - Constructor for class akka.actor.LocalScope
 
LocalScope$ - Class in akka.actor
The Local Scope is the default one, which is assumed on all deployments which do not set a different scope.
LocalScope$() - Constructor for class akka.actor.LocalScope$
 
lock() - Method in class akka.util.BoundedBlockingQueue
 
locked(Function0<T>) - Method in class akka.util.Switch
Executes the given code while holding this switch’s lock, i.e.
log() - Method in interface akka.actor.ActorLogging
 
log() - Method in class akka.actor.ActorSystem
Convenient logging adapter for logging to the ActorSystem.eventStream.
log() - Method in interface akka.actor.DiagnosticActorLogging
 
log(Logging.LogLevel, String) - Method in interface akka.event.LoggingAdapter
Log message at the specified log level.
log(Logging.LogLevel, String, Object) - Method in interface akka.event.LoggingAdapter
Message template with 1 replacement argument.
log(Logging.LogLevel, String, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 2 replacement arguments.
log(Logging.LogLevel, String, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 3 replacement arguments.
log(Logging.LogLevel, String, Object, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 4 replacement arguments.
log() - Method in class akka.serialization.Serialization
 
logClass() - Method in class akka.event.BusLogging
 
logClass() - Method in class akka.event.Logging.Debug
 
logClass() - Method in class akka.event.Logging.Error
 
logClass() - Method in class akka.event.Logging.Info
 
logClass() - Method in interface akka.event.Logging.LogEvent
The class of the source of this event
logClass() - Method in class akka.event.Logging.Warning
 
LogConfigOnStart() - Method in class akka.actor.ActorSystem.Settings
 
logConfiguration() - Method in class akka.actor.ActorSystem
Log the configuration.
LogDeadLetters() - Method in class akka.actor.ActorSystem.Settings
 
LogDeadLettersDuringShutdown() - Method in class akka.actor.ActorSystem.Settings
 
logDepth() - Method in interface akka.actor.LoggingFSM
 
logFailure(ActorContext, ActorRef, Throwable, SupervisorStrategy.Directive) - Method in class akka.actor.SupervisorStrategy
Default logging of actor failures when SupervisorStrategy.loggingEnabled() is true.
loggerInitialized() - Method in class akka.event.Logging$
Java API to create a LoggerInitialized message.
loggerInitialized() - Static method in class akka.event.Logging
Java API to create a LoggerInitialized message.
Loggers() - Method in class akka.actor.ActorSystem.Settings
 
loggers() - Method in interface akka.event.LoggingBus
 
LoggerStartTimeout() - Method in class akka.actor.ActorSystem.Settings
 
Logging - Class in akka.event
Main entry point for Akka logging: log levels and message types (aka channels) defined for the main transport medium, the main event bus.
Logging() - Constructor for class akka.event.Logging
 
Logging$ - Class in akka.event
Main entry point for Akka logging: log levels and message types (aka channels) defined for the main transport medium, the main event bus.
Logging$() - Constructor for class akka.event.Logging$
 
Logging.Debug - Class in akka.event
For DEBUG Logging
Logging.Debug(String, Class<?>, Object) - Constructor for class akka.event.Logging.Debug
 
Logging.Debug$ - Class in akka.event
 
Logging.Debug$() - Constructor for class akka.event.Logging.Debug$
 
Logging.Debug2 - Class in akka.event
 
Logging.Debug2(String, Class<?>, Object, Map<String, Object>) - Constructor for class akka.event.Logging.Debug2
 
Logging.DefaultLogger - Class in akka.event
Actor wrapper around the standard output logger.
Logging.DefaultLogger() - Constructor for class akka.event.Logging.DefaultLogger
 
Logging.Error - Class in akka.event
For ERROR Logging
Logging.Error(Throwable, String, Class<?>, Object) - Constructor for class akka.event.Logging.Error
 
Logging.Error(String, Class<?>, Object) - Constructor for class akka.event.Logging.Error
 
Logging.Error$ - Class in akka.event
 
Logging.Error$() - Constructor for class akka.event.Logging.Error$
 
Logging.Error.NoCause$ - Class in akka.event
Null Object used for errors without cause Throwable
Logging.Error.NoCause$() - Constructor for class akka.event.Logging.Error.NoCause$
 
Logging.Error2 - Class in akka.event
 
Logging.Error2(Throwable, String, Class<?>, Object, Map<String, Object>) - Constructor for class akka.event.Logging.Error2
 
Logging.Error2(String, Class<?>, Object, Map<String, Object>) - Constructor for class akka.event.Logging.Error2
 
Logging.Error2$ - Class in akka.event
 
Logging.Error2$() - Constructor for class akka.event.Logging.Error2$
 
Logging.Extension$ - Class in akka.event
INTERNAL API
Logging.Extension$() - Constructor for class akka.event.Logging.Extension$
 
Logging.Info - Class in akka.event
For INFO Logging
Logging.Info(String, Class<?>, Object) - Constructor for class akka.event.Logging.Info
 
Logging.Info$ - Class in akka.event
 
Logging.Info$() - Constructor for class akka.event.Logging.Info$
 
Logging.Info2 - Class in akka.event
 
Logging.Info2(String, Class<?>, Object, Map<String, Object>) - Constructor for class akka.event.Logging.Info2
 
Logging.InitializeLogger - Class in akka.event
Message which is sent to each default logger (i.e.
Logging.InitializeLogger(LoggingBus) - Constructor for class akka.event.Logging.InitializeLogger
 
Logging.InitializeLogger$ - Class in akka.event
 
Logging.InitializeLogger$() - Constructor for class akka.event.Logging.InitializeLogger$
 
Logging.LogEvent - Interface in akka.event
Base type of LogEvents
Logging.LogEventException - Class in akka.event
Exception that wraps a LogEvent.
Logging.LogEventException(Logging.LogEvent, Throwable) - Constructor for class akka.event.Logging.LogEventException
 
Logging.LoggerException - Exception in akka.event
Artificial exception injected into Error events if no Throwable is supplied; used for getting a stack dump of error locations.
Logging.LoggerException() - Constructor for exception akka.event.Logging.LoggerException
 
Logging.LoggerInitializationException - Exception in akka.event
LoggerInitializationException is thrown to indicate that there was a problem initializing a logger
Logging.LoggerInitializationException(String) - Constructor for exception akka.event.Logging.LoggerInitializationException
 
Logging.LoggerInitialized - Class in akka.event
Response message each logger must send within 1 second after receiving the InitializeLogger request.
Logging.LoggerInitialized() - Constructor for class akka.event.Logging.LoggerInitialized
 
Logging.LoggerInitialized$ - Class in akka.event
 
Logging.LoggerInitialized$() - Constructor for class akka.event.Logging.LoggerInitialized$
 
Logging.LogLevel - Class in akka.event
Marker trait for annotating LogLevel, which must be Int after erasure.
Logging.LogLevel(int) - Constructor for class akka.event.Logging.LogLevel
 
Logging.LogLevel$ - Class in akka.event
 
Logging.LogLevel$() - Constructor for class akka.event.Logging.LogLevel$
 
Logging.StandardOutLogger - Class in akka.event
Actor-less logging implementation for synchronous logging to standard output.
Logging.StandardOutLogger() - Constructor for class akka.event.Logging.StandardOutLogger
 
Logging.StdOutLogger - Interface in akka.event
 
Logging.Warning - Class in akka.event
For WARNING Logging
Logging.Warning(String, Class<?>, Object) - Constructor for class akka.event.Logging.Warning
 
Logging.Warning$ - Class in akka.event
 
Logging.Warning$() - Constructor for class akka.event.Logging.Warning$
 
Logging.Warning2 - Class in akka.event
 
Logging.Warning2(String, Class<?>, Object, Map<String, Object>) - Constructor for class akka.event.Logging.Warning2
 
LoggingAdapter - Interface in akka.event
Logging wrapper to make nicer and optimize: provide template versions which evaluate .toString only if the log level is actually enabled.
LoggingBus - Interface in akka.event
This trait brings log level handling to the EventStream: it reads the log levels for the initial logging (StandardOutLogger) and the loggers & level for after-init logging, possibly keeping the StandardOutLogger enabled if it is part of the configured loggers.
loggingEnabled() - Method in class akka.actor.AllForOneStrategy
 
loggingEnabled() - Method in class akka.actor.OneForOneStrategy
 
loggingEnabled() - Method in class akka.actor.SupervisorStrategy
Logging of actor failures is done when this is true.
LoggingFSM<S,D> - Interface in akka.actor
Stackable trait for FSM which adds a rolling event log and debug logging capabilities (analogous to LoggingReceive).
LoggingReceive - Class in akka.event
This decorator adds invocation logging to a Receive function.
LoggingReceive(Option<Object>, PartialFunction<Object, BoxedUnit>, Option<String>, ActorContext) - Constructor for class akka.event.LoggingReceive
 
LoggingReceive(Option<Object>, PartialFunction<Object, BoxedUnit>, ActorContext) - Constructor for class akka.event.LoggingReceive
 
LoggingReceive$ - Class in akka.event
 
LoggingReceive$() - Constructor for class akka.event.LoggingReceive$
 
logic() - Method in class akka.routing.Router
 
LogLevel() - Method in class akka.actor.ActorSystem.Settings
 
logLevel() - Method in interface akka.event.LoggingBus
Query currently set log level.
logSource() - Method in class akka.event.BusLogging
 
logSource() - Method in class akka.event.Logging.Debug
 
logSource() - Method in class akka.event.Logging.Error
 
logSource() - Method in class akka.event.Logging.Info
 
logSource() - Method in interface akka.event.Logging.LogEvent
The source of this event
logSource() - Method in class akka.event.Logging.Warning
 
LogSource<T> - Interface in akka.event
This trait defines the interface to be provided by a “log source formatting rule” as used by Logging’s apply/create method.
LogSource$ - Class in akka.event
This object holds predefined formatting rules for log sources.
LogSource$() - Constructor for class akka.event.LogSource$
 
logTermination(FSM.Reason) - Method in interface akka.actor.FSM
By default FSM.Failure is logged at error level and other reason types are not logged.
longToTimeout(long) - Method in class akka.util.Timeout$
 
longToTimeout(long) - Static method in class akka.util.Timeout
 
lookup() - Method in class akka.actor.ActorDSL.Extension$
 
lookup() - Method in interface akka.actor.ExtensionIdProvider
Returns the canonical ExtensionId for this Extension
lookup() - Method in class akka.actor.ExtensionKey
 
lookup() - Method in class akka.actor.TypedActor$
 
lookup() - Static method in class akka.actor.TypedActor
 
lookup(String) - Method in class akka.dispatch.Dispatchers
Returns a dispatcher as specified in configuration.
lookup() - Method in class akka.event.AddressTerminatedTopic$
 
lookup() - Method in class akka.io.Tcp$
 
lookup() - Static method in class akka.io.Tcp
 
lookup() - Method in class akka.io.Udp$
 
lookup() - Static method in class akka.io.Udp
 
lookup() - Method in class akka.io.UdpConnected$
 
lookup() - Static method in class akka.io.UdpConnected
 
lookup() - Method in class akka.serialization.SerializationExtension$
 
lookup() - Static method in class akka.serialization.SerializationExtension
 
LookupClassification - Interface in akka.event
Maps Subscribers to Classifiers using equality on Classifier to store a Set of Subscribers (hence the need for compareSubscribers) Maps Events to Classifiers through the classify-method (so it knows who to publish to)
LookupEventBus<E,S,C> - Class in akka.event.japi
Java API: See documentation for LookupClassification E is the Event type S is the Subscriber type C is the Classifier type
LookupEventBus() - Constructor for class akka.event.japi.LookupEventBus
 
lookupRoot() - Method in interface akka.actor.ActorRefFactory
INTERNAL API
lowerBound() - Method in class akka.routing.DefaultResizer
The fewest number of routees the router should ever have.

M

mailbox() - Method in class akka.actor.Deploy
 
mailbox() - Method in class akka.actor.Props
Convenience method for extracting the mailbox information from the contained Deploy instance.
Mailbox$ - 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 interface akka.dispatch.DispatcherPrerequisites
 
mailboxes() - Method in class akka.dispatch.MessageDispatcher
 
Mailboxes$ - Class in akka.dispatch
 
Mailboxes$() - Constructor for class akka.dispatch.Mailboxes$
 
MailboxType - Interface in akka.dispatch
MailboxType is a factory to create MessageQueues for an optionally provided ActorContext.
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
 
Main.Terminator(ActorRef) - Constructor for class akka.Main.Terminator
 
makeDecider(Seq<Class<? extends Throwable>>) - Method in class akka.actor.SupervisorStrategy$
Decider builder which just checks whether one of the given Throwables matches the cause and restarts, otherwise escalates.
makeDecider(Iterable<Class<? extends Throwable>>) - Method in class akka.actor.SupervisorStrategy$
Decider builder which just checks whether one of the given Throwables matches the cause and restarts, otherwise escalates.
makeDecider(Iterable<Tuple2<Class<? extends Throwable>, SupervisorStrategy.Directive>>) - Method in class akka.actor.SupervisorStrategy$
Decider builder for Iterables of cause-directive pairs, e.g.
makeDecider(Function<Throwable, SupervisorStrategy.Directive>) - Method in class akka.actor.SupervisorStrategy$
Converts a Java Decider into a Scala Decider
makeDecider(Seq<Class<? extends Throwable>>) - Static method in class akka.actor.SupervisorStrategy
Decider builder which just checks whether one of the given Throwables matches the cause and restarts, otherwise escalates.
makeDecider(Iterable<Class<? extends Throwable>>) - Static method in class akka.actor.SupervisorStrategy
Decider builder which just checks whether one of the given Throwables matches the cause and restarts, otherwise escalates.
makeDecider(Iterable<Tuple2<Class<? extends Throwable>, SupervisorStrategy.Directive>>) - Static method in class akka.actor.SupervisorStrategy
Decider builder for Iterables of cause-directive pairs, e.g.
makeDecider(Function<Throwable, SupervisorStrategy.Directive>) - Static method in class akka.actor.SupervisorStrategy
Converts a Java Decider into a Scala Decider
makePattern(String) - Method in class akka.util.Helpers$
 
makePattern(String) - Static method in class akka.util.Helpers
 
makeTransition(FSM.State<S, D>) - Method in interface akka.actor.FSM
 
ManagementDispatcher() - Method in class akka.io.TcpExt.Settings
 
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
 
mapI(Function1<Object, Object>) - Method in class akka.util.ByteString
map method that will automatically cast Int back into Byte.
Mapper<T,R> - Class in akka.dispatch
Callback for the Future.map and Future.flatMap operations that will be invoked if the Future that this callback is registered on becomes completed with a success.
Mapper() - Constructor for class akka.dispatch.Mapper
 
mappings() - Method in interface akka.event.ActorClassification
 
mapSize() - Method in interface akka.event.ActorClassification
This is a size hint for the number of Classifiers you expect to have (use powers of 2)
mapSize() - Method in class akka.event.japi.ActorEventBus
This is a size hint for the number of Classifiers you expect to have (use powers of 2)
mapSize() - Method in class akka.event.japi.LookupEventBus
This is a size hint for the number of Classifiers you expect to have (use powers of 2)
mapSize() - Method in interface akka.event.LookupClassification
This is a size hint for the number of Classifiers you expect to have (use powers of 2)
mapSize() - Method in class akka.util.Index
 
match(Class<P>, FI.Apply<P, SupervisorStrategy.Directive>) - Static method in class akka.japi.pf.DeciderBuilder
Return a new PFBuilder with a case statement added.
match(Class<P>, FI.TypedPredicate<P>, FI.Apply<P, SupervisorStrategy.Directive>) - Static method in class akka.japi.pf.DeciderBuilder
Return a new PFBuilder with a case statement added.
Match<I,R> - Class in akka.japi.pf
Version of PartialFunction that can be built during runtime from Java.
match(Class<P>, FI.Apply<P, T>) - Static method in class akka.japi.pf.Match
Convenience function to create a PFBuilder with the first case statement added.
match(Class<P>, FI.TypedPredicate<P>, FI.Apply<P, T>) - Static method in class akka.japi.pf.Match
Convenience function to create a PFBuilder with the first case statement added.
match(I) - Method in class akka.japi.pf.Match
Convenience function to make the Java code more readable.
match(Class<P>, FI.Apply<P, R>) - Method in class akka.japi.pf.PFBuilder
Add a new case statement to this builder.
match(Class<P>, FI.TypedPredicate<P>, FI.Apply<P, R>) - Method in class akka.japi.pf.PFBuilder
Add a new case statement to this builder.
match(Class<P>, FI.UnitApply<P>) - Static method in class akka.japi.pf.ReceiveBuilder
Return a new UnitPFBuilder with a case statement added.
match(Class<P>, FI.TypedPredicate<P>, FI.UnitApply<P>) - Static method in class akka.japi.pf.ReceiveBuilder
Return a new UnitPFBuilder with a case statement added.
match(Class<P>, FI.UnitApply<P>) - Static method in class akka.japi.pf.UnitMatch
Convenience function to create a UnitPFBuilder with the first case statement added.
match(Class<P>, FI.TypedPredicate<P>, FI.UnitApply<P>) - Static method in class akka.japi.pf.UnitMatch
Convenience function to create a UnitPFBuilder with the first case statement added.
match(I) - Method in class akka.japi.pf.UnitMatch
Convenience function to make the Java code more readable.
match(Class<P>, FI.UnitApply<P>) - Method in class akka.japi.pf.UnitPFBuilder
Add a new case statement to this builder.
match(Class<P>, FI.TypedPredicate<P>, FI.UnitApply<P>) - Method in class akka.japi.pf.UnitPFBuilder
Add a new case statement to this builder.
matchAny(FI.Apply<Object, SupervisorStrategy.Directive>) - Static method in class akka.japi.pf.DeciderBuilder
Return a new PFBuilder with a case statement added.
matchAny(FI.Apply<Object, T>) - Static method in class akka.japi.pf.Match
Convenience function to create a PFBuilder with the first case statement added.
matchAny(FI.Apply<Object, R>) - Method in class akka.japi.pf.PFBuilder
Add a new case statement to this builder, that matches any argument.
matchAny(FI.UnitApply<Object>) - Static method in class akka.japi.pf.ReceiveBuilder
Return a new UnitPFBuilder with a case statement added.
matchAny(FI.UnitApply<Object>) - Static method in class akka.japi.pf.UnitMatch
Convenience function to create a UnitPFBuilder with the first case statement added.
matchAny(FI.UnitApply<Object>) - Method in class akka.japi.pf.UnitPFBuilder
Add a new case statement to this builder, that matches any argument.
matchAnyEvent(FI.Apply2<Object, D, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
Create an FSMStateFunctionBuilder with the first case statement set.
matchData(Class<DT>, FI.UnitApply<DT>) - Method in class akka.actor.AbstractFSM
Create a UnitPFBuilder with the first case statement set.
matchData(Class<DT>, FI.TypedPredicate<DT>, FI.UnitApply<DT>) - Method in class akka.actor.AbstractFSM
Create a UnitPFBuilder with the first case statement set.
matchEquals(P, FI.Apply<P, T>) - Static method in class akka.japi.pf.Match
Convenience function to create a PFBuilder with the first case statement added.
matchEquals(P, FI.Apply<P, R>) - Method in class akka.japi.pf.PFBuilder
Add a new case statement to this builder.
matchEquals(P, FI.UnitApply<P>) - Static method in class akka.japi.pf.ReceiveBuilder
Return a new UnitPFBuilder with a case statement added.
matchEquals(P, FI.TypedPredicate<P>, FI.UnitApply<P>) - Static method in class akka.japi.pf.ReceiveBuilder
Return a new UnitPFBuilder with a case statement added.
matchEquals(P, FI.UnitApply<P>) - Static method in class akka.japi.pf.UnitMatch
Convenience function to create a UnitPFBuilder with the first case statement added.
matchEquals(P, FI.TypedPredicate<P>, FI.UnitApply<P>) - Static method in class akka.japi.pf.UnitMatch
Convenience function to create a UnitPFBuilder with the first case statement added.
matchEquals(P, FI.UnitApply<P>) - Method in class akka.japi.pf.UnitPFBuilder
Add a new case statement to this builder.
matchEquals(P, FI.TypedPredicate<P>, FI.UnitApply<P>) - Method in class akka.japi.pf.UnitPFBuilder
Add a new case statement to this builder.
matches(C, E) - Method in class akka.event.japi.ScanningEventBus
Returns whether the specified Classifier matches the specified Event
matches(akka.event.EventBus.Classifier, akka.event.EventBus.Event) - 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
Create an FSMStateFunctionBuilder with the first case statement set.
matchEvent(Class<ET>, Class<DT>, FI.Apply2<ET, DT, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
Create an FSMStateFunctionBuilder with the first case statement set.
matchEvent(Class<ET>, FI.TypedPredicate2<ET, D>, FI.Apply2<ET, D, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
Create an FSMStateFunctionBuilder with the first case statement set.
matchEvent(Class<ET>, FI.Apply2<ET, D, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
Create an FSMStateFunctionBuilder with the first case statement set.
matchEvent(FI.TypedPredicate2<Object, D>, FI.Apply2<Object, D, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
Create an FSMStateFunctionBuilder with the first case statement set.
matchEvent(List<Object>, Class<DT>, FI.Apply2<Object, DT, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
Create an FSMStateFunctionBuilder with the first case statement set.
matchEvent(List<Object>, FI.Apply2<Object, D, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
Create an FSMStateFunctionBuilder with the first case statement set.
matchEventEquals(E, Class<DT>, FI.Apply2<E, DT, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
Create an FSMStateFunctionBuilder with the first case statement set.
matchEventEquals(E, FI.Apply2<E, D, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
Create an FSMStateFunctionBuilder with the first case statement set.
matchState(S, S, FI.UnitApplyVoid) - Method in class akka.actor.AbstractFSM
Create an FSMTransitionHandlerBuilder with the first case statement set.
matchState(S, S, FI.UnitApply2<S, S>) - Method in class akka.actor.AbstractFSM
Create an FSMTransitionHandlerBuilder with the first case statement set.
matchStop(FSM.Reason, FI.UnitApply2<S, D>) - Method in class akka.actor.AbstractFSM
Create an FSMStopBuilder with the first case statement set.
matchStop(Class<RT>, FI.UnitApply3<RT, S, D>) - Method in class akka.actor.AbstractFSM
Create an FSMStopBuilder with the first case statement set.
matchStop(Class<RT>, FI.TypedPredicate<RT>, FI.UnitApply3<RT, S, D>) - Method in class akka.actor.AbstractFSM
Create an FSMStopBuilder with the first case statement set.
maxCapacity() - Method in class akka.util.BoundedBlockingQueue
 
MaxChannels() - Method in class akka.io.SelectionHandlerSettings
 
MaxChannelsPerSelector() - Method in class akka.io.SelectionHandlerSettings
 
MaxChannelsPerSelector() - Method in class akka.io.TcpExt.Settings
 
maxCount() - Method in class akka.event.DeadLetterListener
 
MaxDirectBufferPoolSize() - Method in class akka.io.TcpExt.Settings
 
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
 
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 class akka.actor.DeadLetter
 
message() - Method in exception akka.actor.IllegalActorStateException
 
message() - Method in exception akka.actor.InvalidActorNameException
 
message() - Method in exception akka.actor.InvalidMessageException
 
message() - Method in class akka.actor.UnhandledMessage
 
message() - Method in class akka.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
 
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 - Interface in akka.dispatch
A MessageQueue is one of the core components in forming an Akka Mailbox.
messages() - Method in class akka.actor.dsl.Inbox.InboxActor
 
messagesPerResize() - Method in class akka.routing.DefaultResizer
Number of messages between resize operation.
method() - Method in class akka.actor.TypedActor.MethodCall
 
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.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.ActorIdentity$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorInitializationException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorKilledException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorNotFound$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorPath$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorPathExtractor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorRef$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorSelection$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorSelectionMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorSystem$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Address$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.AddressFromURIString$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.AddressTerminated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.AllForOneStrategy$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ChildNameReserved$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ChildRestartStats$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ContextualTypedActorFactory$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.DeadLetter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.DeadLetterActorRef$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.DeathPactException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Deploy$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.dsl.Inbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer$
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.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.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.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.SystemGuardian$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Terminated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.TypedActor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.TypedProps$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.UnhandledMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.BalancingDispatcherConfigurator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.BoundedDequeBasedMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.BoundedMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.BoundedPriorityMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.CachingConfig$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.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.Filter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.ForkJoinExecutorConfigurator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.Futures$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.japi$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.Mailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.Mailboxes$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.MessageDispatcher$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.MonitorableThreadFactory$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.PriorityGenerator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.SingleConsumerOnlyUnboundedMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.Create$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.DeathWatchNotification$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.EarliestFirstSystemMessageList$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.Failed$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.LatestFirstSystemMessageList$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.NoMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.Recreate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.Resume$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.Supervise$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.Suspend$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.SystemMessageList$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.Terminate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.Unwatch$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.Watch$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.TaskInvocation$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.ThreadPoolConfig$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.ThreadPoolConfigBuilder$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.UnboundedDequeBasedMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.UnboundedMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.UnboundedPriorityMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.AddressTerminatedTopic$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.EventStream$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.Logging$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.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.Inet$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.IO$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.SelectionHandler$
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.TcpConnection$
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.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.UdpConnected$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.UdpConnectedMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.UdpMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.UdpSO$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.JavaPartialFunction$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.Option$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.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.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.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.BalancingRoutingLogic$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.Broadcast$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.BroadcastGroup$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.BroadcastPool$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.BroadcastRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.BroadcastRoutingLogic$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ConsistentActorRef$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ConsistentHash$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ConsistentHashingGroup$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ConsistentHashingPool$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ConsistentHashingRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ConsistentHashingRoutingLogic$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ConsistentRoutee$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.CurrentRoutees$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.Deafen$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.DefaultResizer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.FromConfig$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.GetRoutees$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.Listen$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.MurmurHash$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.NoRoutee$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.NoRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.Pool$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RandomGroup$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RandomPool$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RandomRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RandomRoutingLogic$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RemoveRoutee$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ResizablePoolActor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RoundRobinGroup$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RoundRobinPool$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RoundRobinRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RoundRobinRoutingLogic$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RoutedActorCell$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.Routees$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.Router$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RouterRoutees$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ScatterGatherFirstCompletedGroup$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ScatterGatherFirstCompletedPool$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ScatterGatherFirstCompletedRoutees$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ScatterGatherFirstCompletedRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ScatterGatherFirstCompletedRoutingLogic$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.SeveralRoutees$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.SmallestMailboxPool$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.SmallestMailboxRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.SmallestMailboxRoutingLogic$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.WithListeners$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.serialization.JavaSerializer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.serialization.NullSerializer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.serialization.Serialization$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.serialization.SerializationExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.BoxedType$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.ByteIterator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.ByteString$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.Collections$
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.Reflect$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.SerializedSuspendableExecutionContext$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.SubclassifiedIndex$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.Switch$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.Timeout$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.WildcardTree$
Static reference to the singleton instance of this Scala object.
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$
 
msg() - Method in class akka.actor.FSM.Timer
 
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$
 

N

name() - Method in interface akka.actor.ActorPath
The name of the actor that this path refers to.
name() - Method in class akka.actor.ActorSystem
The name of this actor system, used to distinguish multiple ones within the same JVM & class loader.
name() - Method in class akka.actor.ActorSystem.Settings
 
name() - Method in class akka.actor.ChildActorPath
 
name() - Method in class akka.actor.FSM.Timer
 
name() - Method in class akka.actor.RootActorPath
 
name() - Method in class akka.dispatch.MonitorableThreadFactory
 
newBuilder() - Method in class akka.util.ByteString$
 
newBuilder() - Method in class akka.util.ByteString
 
newReceiver() - Method in interface akka.actor.dsl.Inbox.InboxExtension
 
newRoutee(Props, ActorContext) - Method in interface akka.routing.Pool
INTERNAL API
newThread(ForkJoinPool) - Method in class akka.dispatch.MonitorableThreadFactory
 
newThread(Runnable) - Method in class akka.dispatch.MonitorableThreadFactory
 
newUid() - Method in class akka.actor.ActorCell$
 
next() - Method in class akka.dispatch.AbstractNodeQueue.Node
 
next() - Method in class akka.routing.RoundRobinRoutingLogic
 
next() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
next() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
next() - Method in class akka.util.ByteIterator
 
nextMagicA(int) - Method in class akka.routing.MurmurHash$
Given a magic integer from the first stream, compute the next
nextMagicA(int) - Static method in class akka.routing.MurmurHash
Given a magic integer from the first stream, compute the next
nextMagicB(int) - Method in class akka.routing.MurmurHash$
Given a magic integer from the second stream, compute the next
nextMagicB(int) - Static method in class akka.routing.MurmurHash
Given a magic integer from the second stream, compute the next
nextState() - Method in interface akka.actor.FSM
 
nextStateData() - Method in interface akka.actor.FSM
Return next state data (available in onTransition handlers)
noAck(Object) - Method in class akka.io.TcpMessage$
Each Tcp.WriteCommand can optionally request a positive acknowledgment to be sent to the commanding actor.
noAck() - Method in class akka.io.TcpMessage$
Default Tcp.NoAck instance which is used when no acknowledgment information is explicitly provided.
noAck(Object) - Static method in class akka.io.TcpMessage
Each Tcp.WriteCommand can optionally request a positive acknowledgment to be sent to the commanding actor.
noAck() - Static method in class akka.io.TcpMessage
Default Tcp.NoAck instance which is used when no acknowledgment information is explicitly provided.
noAck(Object) - Method in class akka.io.UdpConnectedMessage$
Each UdpConnected.Send can optionally request a positive acknowledgment to be sent to the commanding actor.
noAck() - Method in class akka.io.UdpConnectedMessage$
Default UdpConnected.NoAck instance which is used when no acknowledgment information is explicitly provided.
noAck(Object) - Static method in class akka.io.UdpConnectedMessage
Each UdpConnected.Send can optionally request a positive acknowledgment to be sent to the commanding actor.
noAck() - Static method in class akka.io.UdpConnectedMessage
Default UdpConnected.NoAck instance which is used when no acknowledgment information is explicitly provided.
noAck(Object) - Method in class akka.io.UdpMessage$
Each Udp.Send can optionally request a positive acknowledgment to be sent to the commanding actor.
noAck() - Method in class akka.io.UdpMessage$
Default Udp.NoAck instance which is used when no acknowledgment information is explicitly provided.
noAck(Object) - Static method in class akka.io.UdpMessage
Each Udp.Send can optionally request a positive acknowledgment to be sent to the commanding actor.
noAck() - Static method in class akka.io.UdpMessage
Default Udp.NoAck instance which is used when no acknowledgment information is explicitly provided.
Nobody - Class in akka.actor
This is an internal look-up failure token, not useful for anything else.
Nobody() - Constructor for class akka.actor.Nobody
 
Nobody$ - Class in akka.actor
This is an internal look-up failure token, not useful for anything else.
Nobody$() - Constructor for class akka.actor.Nobody$
 
noCause() - Method in class akka.event.Logging$
Null Object used for errors without cause Throwable
noCause() - Static method in class akka.event.Logging
Null Object used for errors without cause Throwable
nodeFor(byte[]) - Method in class akka.routing.ConsistentHash
Get the node responsible for the data key.
nodeFor(String) - Method in class akka.routing.ConsistentHash
Get the node responsible for the data key.
NodeMessageQueue - Class in akka.dispatch
 
NodeMessageQueue() - Constructor for class akka.dispatch.NodeMessageQueue
 
NoDispatcherGiven() - Method in class akka.actor.Deploy$
 
NoDispatcherGiven() - Static method in class akka.actor.Deploy
 
NoLogging - Class in akka.event
NoLogging is a LoggingAdapter that does absolutely nothing – no logging at all.
NoLogging() - Constructor for class akka.event.NoLogging
 
NoLogging$ - Class in akka.event
NoLogging is a LoggingAdapter that does absolutely nothing – no logging at all.
NoLogging$() - Constructor for class akka.event.NoLogging$
 
NoMailboxGiven() - Method in class akka.actor.Deploy$
 
NoMailboxGiven() - Static method in class akka.actor.Deploy
 
NoMailboxRequirement() - Method in class akka.dispatch.Mailboxes$
 
noMatch() - Method in class akka.japi.JavaPartialFunction$
 
noMatch() - Static method in class akka.japi.JavaPartialFunction
 
NoMessage - Class in akka.dispatch.sysmsg
INTERNAL API
NoMessage() - Constructor for class akka.dispatch.sysmsg.NoMessage
 
NoMessage$ - Class in akka.dispatch.sysmsg
INTERNAL API
NoMessage$() - Constructor for class akka.dispatch.sysmsg.NoMessage$
 
none() - Method in class akka.japi.Option$
Option factory that creates None
none() - Static method in class akka.japi.Option
Option factory that creates None
nonExistingPathEntry() - Method in class akka.dispatch.CachingConfig$
 
Normal() - Method in class akka.actor.AbstractFSM
Default reason if calling stop().
NoRoutee - Class in akka.routing
Routee that doesn't send the message to any routee.
NoRoutee() - Constructor for class akka.routing.NoRoutee
 
NoRoutee$ - Class in akka.routing
Routee that doesn't send the message to any routee.
NoRoutee$() - Constructor for class akka.routing.NoRoutee$
 
NoRouter - Class in akka.routing
Routing configuration that indicates no routing; this is also the default value which hence overrides the merge strategy in order to accept values from lower-precedence sources.
NoRouter() - Constructor for class akka.routing.NoRouter
 
NoRouter$ - Class in akka.routing
 
NoRouter$() - Constructor for class akka.routing.NoRouter$
 
NoScopeGiven - Class in akka.actor
This is the default value and as such allows overrides.
NoScopeGiven() - Constructor for class akka.actor.NoScopeGiven
 
NoScopeGiven$ - Class in akka.actor
 
NoScopeGiven$() - Constructor for class akka.actor.NoScopeGiven$
 
noSender() - Method in class akka.actor.Actor$
Default placeholder (null) used for "!" to indicate that there is no sender of the message, that will be translated to the receiving system's deadLetters.
noSender() - Method in interface akka.actor.Actor
Default placeholder (null) used for "!" to indicate that there is no sender of the message, that will be translated to the receiving system's deadLetters.
noSender() - Method in class akka.actor.ActorRef$
Use this value as an argument to ActorRef.tell(java.lang.Object, akka.actor.ActorRef) if there is not actor to reply to (e.g.
noSender() - Static method in class akka.actor.ActorRef
Use this value as an argument to ActorRef.tell(java.lang.Object, akka.actor.ActorRef) if there is not actor to reply to (e.g.
NoSerializationVerificationNeeded - Interface in akka.actor
Marker trait to signal that this class should not be verified for serializability.
notifyDebug(String) - Method in class akka.event.BusLogging
 
notifyDebug(String) - Method in interface akka.event.LoggingAdapter
 
notifyDebug(String) - Method in class akka.event.NoLogging$
 
notifyDebug(String) - Static method in class akka.event.NoLogging
 
notifyError(String) - Method in class akka.event.BusLogging
 
notifyError(Throwable, String) - Method in class akka.event.BusLogging
 
notifyError(String) - Method in interface akka.event.LoggingAdapter
 
notifyError(Throwable, String) - Method in interface akka.event.LoggingAdapter
 
notifyError(String) - Method in class akka.event.NoLogging$
 
notifyError(Throwable, String) - Method in class akka.event.NoLogging$
 
notifyError(String) - Static method in class akka.event.NoLogging
 
notifyError(Throwable, String) - Static method in class akka.event.NoLogging
 
notifyInfo(String) - Method in class akka.event.BusLogging
 
notifyInfo(String) - Method in interface akka.event.LoggingAdapter
 
notifyInfo(String) - Method in class akka.event.NoLogging$
 
notifyInfo(String) - Static method in class akka.event.NoLogging
 
notifyLog(Logging.LogLevel, String) - Method in interface akka.event.LoggingAdapter
 
notifyWarning(String) - Method in class akka.event.BusLogging
 
notifyWarning(String) - Method in interface akka.event.LoggingAdapter
 
notifyWarning(String) - Method in class akka.event.NoLogging$
 
notifyWarning(String) - Static method in class akka.event.NoLogging
 
nrOfInstances() - Method in class akka.routing.BalancingPool
 
nrOfInstances() - Method in class akka.routing.BroadcastPool
 
nrOfInstances() - Method in class akka.routing.BroadcastRouter
 
nrOfInstances() - Method in class akka.routing.ConsistentHashingPool
 
nrOfInstances() - Method in class akka.routing.ConsistentHashingRouter
 
nrOfInstances() - Method in class akka.routing.FromConfig
 
nrOfInstances() - Method in interface akka.routing.Pool
Initial number of routee instances
nrOfInstances() - Method in class akka.routing.RandomPool
 
nrOfInstances() - Method in class akka.routing.RandomRouter
 
nrOfInstances() - Method in class akka.routing.RoundRobinPool
 
nrOfInstances() - Method in class akka.routing.RoundRobinRouter
 
nrOfInstances() - Method in class akka.routing.ScatterGatherFirstCompletedPool
 
nrOfInstances() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
nrOfInstances() - Method in class akka.routing.SmallestMailboxPool
 
nrOfInstances() - Method in class akka.routing.SmallestMailboxRouter
 
NrOfSelectors() - Method in class akka.io.TcpExt.Settings
 
nullAsBytes() - Method in class akka.serialization.NullSerializer
 
NullFunction() - Method in class akka.actor.AbstractFSM$
A partial function value which does not match anything and can be used to “reset” whenUnhandled and onTermination handlers.
NullFunction() - Static method in class akka.actor.AbstractFSM
A partial function value which does not match anything and can be used to “reset” whenUnhandled and onTermination handlers.
NullSerializer - Class in akka.serialization
This is a special Serializer that Serializes and deserializes nulls only
NullSerializer() - Constructor for class akka.serialization.NullSerializer
 
NullSerializer$ - Class in akka.serialization
 
NullSerializer$() - Constructor for class akka.serialization.NullSerializer$
 
numberOfMessages() - Method in interface akka.dispatch.MessageQueue
Should return the current number of messages held in this queue; may always return 0 if no other value is available efficiently.
numberOfMessages() - Method in class akka.dispatch.NodeMessageQueue
 
numberOfMessages() - Method in interface akka.dispatch.QueueBasedMessageQueue
 
numberOfMessages(Routee) - Method in class akka.routing.SmallestMailboxRoutingLogic
Returns the number of pending messages in the mailbox of the actor.

O

Off() - Method in class akka.util.SerializedSuspendableExecutionContext$
 
offer(E) - Method in class akka.util.BoundedBlockingQueue
 
offer(E, long, TimeUnit) - Method in class akka.util.BoundedBlockingQueue
 
on() - Method in class akka.io.Inet.SO$.ReuseAddress
 
on() - Method in class akka.io.Tcp.SO$.KeepAlive
 
on() - Method in class akka.io.Tcp.SO$.OOBInline
 
on() - Method in class akka.io.Tcp.SO$.TcpNoDelay
 
on() - Method in class akka.io.Udp.SO$.Broadcast
 
On() - Method in class akka.util.SerializedSuspendableExecutionContext$
 
onClose(Function0<BoxedUnit>) - Method in class akka.pattern.CircuitBreaker
Adds a callback to execute when circuit breaker state closes
onClose(Runnable) - Method in class akka.pattern.CircuitBreaker
JavaAPI for onClose
OnComplete<T> - Class in akka.dispatch
Callback for when a Future is completed with either failure or a success SAM (Single Abstract Method) class
OnComplete() - Constructor for class akka.dispatch.OnComplete
 
onComplete(Throwable, T) - Method in class akka.dispatch.OnComplete
This method will be invoked once when/if a Future that this callback is registered on becomes completed with a failure or a success.
OneForOneStrategy() - Method in interface akka.actor.dsl.Creators.Act
 
OneForOneStrategy - Class in akka.actor
Applies the fault handling Directive (Resume, Restart, Stop) specified in the Decider to the child actor that failed, as opposed to AllForOneStrategy that applies it to all children.
OneForOneStrategy(int, Duration, boolean, PartialFunction<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.OneForOneStrategy
 
OneForOneStrategy(int, Duration, Function<Throwable, SupervisorStrategy.Directive>, boolean) - Constructor for class akka.actor.OneForOneStrategy
Java API
OneForOneStrategy(int, Duration, Function<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.OneForOneStrategy
Java API
OneForOneStrategy(int, Duration, Iterable<Class<? extends Throwable>>) - Constructor for class akka.actor.OneForOneStrategy
Java API
OneForOneStrategy(int, Duration, PartialFunction<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.OneForOneStrategy
Java API: compatible with lambda expressions This is an EXPERIMENTAL feature and is subject to change until it has received more real world testing.
OneForOneStrategy(boolean, PartialFunction<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.OneForOneStrategy
Java API: compatible with lambda expressions This is an EXPERIMENTAL feature and is subject to change until it has received more real world testing.
OneForOneStrategy(PartialFunction<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.OneForOneStrategy
Java API: compatible with lambda expressions This is an EXPERIMENTAL feature and is subject to change until it has received more real world testing.
OneForOneStrategy$ - Class in akka.actor
 
OneForOneStrategy$() - Constructor for class akka.actor.OneForOneStrategy$
 
OnFailure - Class in akka.dispatch
Callback for when a Future is completed with a failure SAM (Single Abstract Method) class
OnFailure() - Constructor for class akka.dispatch.OnFailure
 
onFailure(Throwable) - Method in class akka.dispatch.OnFailure
This method will be invoked once when/if a Future that this callback is registered on becomes completed with a failure
onHalfOpen(Function0<BoxedUnit>) - Method in class akka.pattern.CircuitBreaker
Adds a callback to execute when circuit breaker transitions to half-open
onHalfOpen(Runnable) - Method in class akka.pattern.CircuitBreaker
JavaAPI for onHalfOpen
OnlyCauseStackTrace - Interface in akka
Mix in this trait to suppress the StackTrace for the instance of the exception but not the cause, scala.util.control.NoStackTrace suppresses all the StackTraces.
onOpen(Function0<BoxedUnit>) - Method in class akka.pattern.CircuitBreaker
Adds a callback to execute when circuit breaker opens
onOpen(Runnable) - Method in class akka.pattern.CircuitBreaker
Java API for onOpen
onReceive(Object, ActorRef) - Method in interface akka.actor.TypedActor.Receiver
 
onReceive(Object) - Method in class akka.actor.UntypedActor
To be implemented by concrete UntypedActor, this defines the behavior of the UntypedActor.
OnSuccess<T> - Class in akka.dispatch
Callback for when a Future is completed successfully SAM (Single Abstract Method) class
OnSuccess() - Constructor for class akka.dispatch.OnSuccess
 
onSuccess(T) - Method in class akka.dispatch.OnSuccess
This method will be invoked once when/if a Future that this callback is registered on becomes successfully completed
onTermination(FSMStopBuilder<S, D>) - Method in class akka.actor.AbstractFSM
Set handler which is called upon termination of this FSM actor.
onTermination(PartialFunction<FSM.StopEvent<S, D>, BoxedUnit>) - Method in interface akka.actor.FSM
Set handler which is called upon termination of this FSM actor.
onTransition(FSMTransitionHandlerBuilder<S>) - Method in class akka.actor.AbstractFSM
Add a handler which is called upon each state transition, i.e.
onTransition(FI.UnitApply2<S, S>) - Method in class akka.actor.AbstractFSM
Add a handler which is called upon each state transition, i.e.
onTransition(PartialFunction<Tuple2<S, S>, BoxedUnit>) - Method in interface akka.actor.FSM
Set handler which is called upon each state transition, i.e.
oobInline(boolean) - Method in class akka.io.TcpSO$
Inet.SocketOption to enable or disable OOBINLINE (receipt of TCP urgent data) By default, this option is disabled and TCP urgent data is silently discarded.
oobInline(boolean) - Static method in class akka.io.TcpSO
Inet.SocketOption to enable or disable OOBINLINE (receipt of TCP urgent data) By default, this option is disabled and TCP urgent data is silently discarded.
Open() - Method in class akka.dispatch.Mailbox$
 
Option<A> - Class in akka.japi
This class represents optional values.
Option() - Constructor for class akka.japi.Option
 
option(A) - Method in class akka.japi.Option$
Option factory that creates None if v is null, Some(v) otherwise.
option(A) - Static method in class akka.japi.Option
Option factory that creates None if v is null, Some(v) otherwise.
Option$ - Class in akka.japi
 
Option$() - Constructor for class akka.japi.Option$
 
Option.Some<A> - Class in akka.japi
Class Some[A] represents existing values of type A.
Option.Some(A) - Constructor for class akka.japi.Option.Some
 
Option.Some$ - Class in akka.japi
 
Option.Some$() - Constructor for class akka.japi.Option.Some$
 
options() - Method in class akka.io.Tcp.Bind
 
options() - Method in class akka.io.Tcp.Connect
 
options() - Method in class akka.io.Udp.Bind
 
options() - Method in class akka.io.Udp.SimpleSender
 
options() - Method in class akka.io.UdpConnected.Connect
 
originalCause() - Method in exception akka.actor.PostRestartException
 
originalCause() - Method in exception akka.actor.PreRestartException
 
OriginalRestartException - Class in akka.actor
This is an extractor for retrieving the original cause (i.e.
OriginalRestartException() - Constructor for class akka.actor.OriginalRestartException
 
OriginalRestartException$ - Class in akka.actor
This is an extractor for retrieving the original cause (i.e.
OriginalRestartException$() - Constructor for class akka.actor.OriginalRestartException$
 

P

Pair<A,B> - Class in akka.japi
Java API: Represents a tuple of two elements.
Pair(A, B) - Constructor for class akka.japi.Pair
 
Pair$ - Class in akka.japi
 
Pair$() - Constructor for class akka.japi.Pair$
 
parallelism() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory
 
parameters() - Method in class akka.actor.TypedActor.MethodCall
 
parent() - Method in interface akka.actor.ActorContext
Returns the supervising parent ActorRef.
parent() - Method in interface akka.actor.ActorPath
The path for the parent actor.
parent() - Method in class akka.actor.ChildActorPath
 
parent() - Method in class akka.actor.RootActorPath
 
parse(String) - Method in class akka.actor.AddressFromURIString$
Java API: Try to construct an Address from the given String or throw a java.net.MalformedURLException.
parse(String) - Static method in class akka.actor.AddressFromURIString
Java API: Try to construct an Address from the given String or throw a java.net.MalformedURLException.
path() - Method in class akka.actor.ActorRef
Returns the path for this actor (from this actor up to the root actor).
path() - Method in class akka.actor.ActorSelection
 
path() - Method in class akka.actor.Deploy
 
path() - Method in class akka.actor.Nobody$
 
path() - Static method in class akka.actor.Nobody
 
path() - Method in class akka.event.Logging.StandardOutLogger
 
paths() - Method in class akka.routing.BroadcastGroup
 
paths() - Method in class akka.routing.BroadcastRouter
 
paths() - Method in class akka.routing.ConsistentHashingGroup
 
paths() - Method in class akka.routing.ConsistentHashingRouter
 
paths() - Method in interface akka.routing.Group
 
paths() - Method in class akka.routing.GroupBase
 
paths() - Method in class akka.routing.RandomGroup
 
paths() - Method in class akka.routing.RandomRouter
 
paths() - Method in class akka.routing.RoundRobinGroup
 
paths() - Method in class akka.routing.RoundRobinRouter
 
paths() - Method in class akka.routing.ScatterGatherFirstCompletedGroup
 
paths() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
paths() - Method in class akka.routing.SmallestMailboxRouter
 
pathString() - Method in class akka.actor.ActorSelection
String representation of the path elements, starting with "/" and separated with "/".
Patterns - Class in akka.pattern
 
Patterns() - Constructor for class akka.pattern.Patterns
 
Patterns$ - Class in akka.pattern
 
Patterns$() - Constructor for class akka.pattern.Patterns$
 
payload() - Method in class akka.io.Udp.Send
 
payload() - Method in class akka.io.UdpConnected.Send
 
peek() - Method in class akka.dispatch.AbstractNodeQueue
 
peek() - Method in class akka.util.BoundedBlockingQueue
 
peekNode() - Method in class akka.dispatch.AbstractNodeQueue
 
PFBuilder<I,R> - Class in akka.japi.pf
A builder for PartialFunction.
PFBuilder() - Constructor for class akka.japi.pf.PFBuilder
Create a PFBuilder.
PinnedDispatcher - Class in akka.dispatch
Dedicates a unique thread for each actor passed in as reference.
PinnedDispatcher(MessageDispatcherConfigurator, akka.actor.ActorCell, String, FiniteDuration, ThreadPoolConfig) - Constructor for class akka.dispatch.PinnedDispatcher
 
PinnedDispatcherConfigurator - Class in akka.dispatch
Configurator for creating PinnedDispatcher.
PinnedDispatcherConfigurator(Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.PinnedDispatcherConfigurator
 
pipe(Future<T>, ExecutionContext) - Method in class akka.pattern.Patterns$
Register an onComplete callback on this Future to send the result to the given ActorRef or ActorSelection.
pipe(Future<T>, ExecutionContext) - Static method in class akka.pattern.Patterns
Register an onComplete callback on this Future to send the result to the given ActorRef or ActorSelection.
pipe(Future<T>, ExecutionContext) - Method in interface akka.pattern.PipeToSupport
Import this implicit conversion to gain the pipeTo method on Future:
pipeTo(ActorRef, ActorRef) - Method in class akka.pattern.PipeToSupport.PipeableFuture
 
pipeToSelection(ActorSelection, ActorRef) - Method in class akka.pattern.PipeToSupport.PipeableFuture
 
PipeToSupport - Interface in akka.pattern
 
PipeToSupport.PipeableFuture<T> - Class in akka.pattern
 
PipeToSupport.PipeableFuture(Future<T>, ExecutionContext) - Constructor for class akka.pattern.PipeToSupport.PipeableFuture
 
PoisonPill - Class in akka.actor
 
PoisonPill() - Constructor for class akka.actor.PoisonPill
 
poisonPill(Object) - Method in interface akka.actor.TypedActorFactory
Sends a PoisonPill the underlying ActorRef for the supplied TypedActor proxy, if any, returns whether it could find the find the ActorRef or not
PoisonPill$ - Class in akka.actor
A message all Actors will understand, that when processed will terminate the Actor permanently.
PoisonPill$() - Constructor for class akka.actor.PoisonPill$
 
poll() - Method in class akka.dispatch.AbstractNodeQueue
 
poll(long, TimeUnit) - Method in class akka.util.BoundedBlockingQueue
 
poll() - Method in class akka.util.BoundedBlockingQueue
 
pollNode() - Method in class akka.dispatch.AbstractNodeQueue
 
Pool - Interface in akka.routing
RouterConfig for router actor that creates routees as child actors and removes them from the router if they terminate.
Pool$ - Class in akka.routing
 
Pool$() - Constructor for class akka.routing.Pool$
 
PoolBase - Class in akka.routing
Java API: Base class for custom router Pool
PoolBase() - Constructor for class akka.routing.PoolBase
 
port() - Method in class akka.actor.Address
 
pos() - Method in interface akka.actor.LoggingFSM
 
position() - Method in class akka.io.Tcp.WriteFile
 
PossiblyHarmful - Interface in akka.actor
Marker trait to indicate that a message might be potentially harmful, this is used to block messages coming in over remoting.
postRestart(Throwable) - Method in interface akka.actor.Actor
User overridable callback: By default it calls preStart().
postRestart(Throwable) - Method in interface akka.actor.dsl.Creators.Act
 
postRestart(Throwable) - Method in interface akka.actor.TypedActor.PostRestart
User overridable callback: By default it calls preStart().
postRestart(Throwable) - Method in class akka.actor.UntypedActor
User overridable callback: By default it calls preStart().
postRestart(Throwable) - Method in class akka.event.DeadLetterListener
 
PostRestartException - Exception in akka.actor
A PostRestartException is thrown when constructor or postRestart() method fails during a restart attempt.
PostRestartException$ - Class in akka.actor
 
PostRestartException$() - Constructor for class akka.actor.PostRestartException$
 
postStop() - Method in interface akka.actor.Actor
User overridable callback.
postStop() - Method in interface akka.actor.dsl.Creators.Act
 
postStop() - Method in interface akka.actor.FSM
Call onTermination hook; if you want to retain this behavior when overriding make sure to call super.postStop().
postStop() - Method in interface akka.actor.TypedActor.PostStop
User overridable callback.
postStop() - Method in interface akka.actor.UnrestrictedStash
Overridden callback.
postStop() - Method in class akka.actor.UntypedActor
User overridable callback.
postStop() - Method in class akka.event.DeadLetterListener
 
predicate() - Method in class akka.actor.dsl.Inbox.Select
 
Predicate<T> - Interface in akka.japi
Java API: Defines a criteria and determines whether the parameter meets this criteria.
PredicateClassifier - Interface in akka.event
Can be mixed into an EventBus to specify that the Classifier type is a Function from Event to Boolean (predicate)
prepend(Tcp.SimpleWriteCommand) - Method in class akka.io.Tcp.WriteCommand
Java API: prepends this command with another Write or WriteFile to form a CompoundWrite.
prepend(Iterable<Tcp.WriteCommand>) - Method in class akka.io.Tcp.WriteCommand
Java API: prepends this command with a number of other writes.
prerequisites() - Method in class akka.dispatch.Dispatchers
 
prerequisites() - Method in class akka.dispatch.MessageDispatcherConfigurator
 
preRestart(Throwable, Option<Object>) - Method in interface akka.actor.Actor
User overridable callback: '''By default it disposes of all children and then calls postStop().'''
preRestart(Throwable, Option<Object>) - Method in interface akka.actor.dsl.Creators.Act
 
preRestart(Throwable, Option<Object>) - Method in interface akka.actor.TypedActor.PreRestart
User overridable callback: '''By default it disposes of all children and then calls postStop().'''
preRestart(Throwable, Option<Object>) - Method in interface akka.actor.UnrestrictedStash
Overridden callback.
preRestart(Throwable, Option<Object>) - Method in class akka.actor.UntypedActor
User overridable callback: '''By default it disposes of all children and then calls postStop().'''

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

preRestart(Throwable, Option<Object>) - Method in class akka.event.DeadLetterListener
 
PreRestartException - Exception in akka.actor
A PreRestartException is thrown when the preRestart() method failed; this exception is not propagated to the supervisor, as it originates from the already failed instance, hence it is only visible as log entry on the event stream.
PreRestartException$ - Class in akka.actor
 
PreRestartException$() - Constructor for class akka.actor.PreRestartException$
 
pressure(IndexedSeq<Routee>) - Method in class akka.routing.DefaultResizer
Number of routees considered busy, or above 'pressure level'.
pressureThreshold() - Method in class akka.routing.DefaultResizer
Threshold to evaluate if routee is considered to be busy (under pressure).
preStart() - Method in interface akka.actor.Actor
User overridable callback.
preStart() - Method in interface akka.actor.dsl.Creators.Act
 
preStart() - Method in interface akka.actor.TypedActor.PreStart
User overridable callback.
preStart() - Method in class akka.actor.UntypedActor
User overridable callback.
preStart() - Method in class akka.event.DeadLetterListener
 
print(Object) - Method in interface akka.event.Logging.StdOutLogger
 
printActors() - Method in class akka.dispatch.MessageDispatcher$
 
printActors() - Static method in class akka.dispatch.MessageDispatcher
 
printedWarning() - Method in class akka.actor.dsl.Inbox.InboxActor
 
PriorityGenerator - Class in akka.dispatch
A PriorityGenerator is a convenience API to create a Comparator that orders the messages of a PriorityDispatcher
PriorityGenerator() - Constructor for class akka.dispatch.PriorityGenerator
 
PriorityGenerator$ - Class in akka.dispatch
 
PriorityGenerator$() - Constructor for class akka.dispatch.PriorityGenerator$
 
Procedure<T> - Interface in akka.japi
A Procedure is like a Function, but it doesn't produce a return value.
processEvent(FSM.Event<D>, Object) - Method in interface akka.actor.FSM
 
processEvent(FSM.Event<D>, Object) - Method in interface akka.actor.LoggingFSM
 
processFailure(ActorContext, boolean, ActorRef, Throwable, ChildRestartStats, Iterable<ChildRestartStats>) - Method in class akka.actor.AllForOneStrategy
 
processFailure(ActorContext, boolean, ActorRef, Throwable, ChildRestartStats, Iterable<ChildRestartStats>) - Method in class akka.actor.OneForOneStrategy
 
processFailure(ActorContext, boolean, ActorRef, Throwable, ChildRestartStats, Iterable<ChildRestartStats>) - Method in class akka.actor.SupervisorStrategy
This method is called to act on the failure of a child: restart if the flag is true, stop otherwise.
processMsg(Object, Object) - Method in interface akka.actor.FSM
 
produce() - Method in interface akka.actor.IndirectActorProducer
This factory method must produce a fresh actor instance upon each invocation.
ProducesMessageQueue<T extends MessageQueue> - Interface in akka.dispatch
 
promise() - Method in class akka.dispatch.Futures$
Creates a promise object which can be completed with a value.
promise() - Static method in class akka.dispatch.Futures
Creates a promise object which can be completed with a value.
PromiseActorRef$ - Class in akka.pattern
INTERNAL API
PromiseActorRef$() - Constructor for class akka.pattern.PromiseActorRef$
 
props() - Method in interface akka.actor.ActorContext
Retrieve the Props which were used to create this actor.
Props - Class in akka.actor
Props is a configuration object using in creating an Actor; it is immutable, so it is thread-safe and fully shareable.
Props(Deploy, Class<?>, Seq<Object>) - Constructor for class akka.actor.Props
 
props() - Method in class akka.routing.FromConfig
Props for a group router based on the settings defined by this instance.
props() - Method in interface akka.routing.Group
Props for a group router based on the settings defined by this instance.
props(Props) - Method in class akka.routing.NoRouter$
 
props(Props) - Static method in class akka.routing.NoRouter
 
props(Props) - Method in interface akka.routing.Pool
Props for a pool router based on the settings defined by this instance and the supplied Props for the routees created by the router.
Props$ - Class in akka.actor
Factory for Props instances.
Props$() - Constructor for class akka.actor.Props$
 
protocol() - Method in class akka.actor.Address
 
provider() - Method in interface akka.actor.ActorRefFactory
INTERNAL API
provider() - Method in class akka.actor.ExtendedActorSystem
The ActorRefProvider is the only entity which creates all actor references within this actor system.
provider() - Method in class akka.actor.Nobody$
 
provider() - Static method in class akka.actor.Nobody
 
provider() - Method in class akka.dispatch.DefaultExecutorServiceConfigurator
 
provider() - Method in class akka.event.Logging.StandardOutLogger
 
ProviderClass() - Method in class akka.actor.ActorSystem.Settings
 
publish(akka.event.EventBus.Event) - Method in interface akka.event.ActorClassification
 
publish(akka.event.EventBus.Event) - Method in interface akka.event.EventBus
Publishes the specified Event to this bus
publish(Object, ActorRef) - Method in class akka.event.EventStream
 
publish(E) - Method in class akka.event.japi.ActorEventBus
 
publish(E) - Method in interface akka.event.japi.EventBus
Publishes the specified Event to this bus
publish(E, S) - Method in class akka.event.japi.LookupEventBus
Publishes the given Event to the given Subscriber
publish(E) - Method in class akka.event.japi.LookupEventBus
 
publish(E, S) - Method in class akka.event.japi.ScanningEventBus
Publishes the specified Event to the specified Subscriber
publish(E) - Method in class akka.event.japi.ScanningEventBus
 
publish(E, S) - Method in class akka.event.japi.SubchannelEventBus
Publishes the given Event to the given Subscriber
publish(E) - Method in class akka.event.japi.SubchannelEventBus
 
publish(akka.event.EventBus.Event, akka.event.EventBus.Subscriber) - Method in interface akka.event.LookupClassification
Publishes the given Event to the given Subscriber
publish(akka.event.EventBus.Event) - Method in interface akka.event.LookupClassification
 
publish(akka.event.EventBus.Event, akka.event.EventBus.Subscriber) - Method in interface akka.event.ScanningClassification
Publishes the specified Event to the specified Subscriber
publish(akka.event.EventBus.Event) - Method in interface akka.event.ScanningClassification
 
publish(akka.event.EventBus.Event, akka.event.EventBus.Subscriber) - Method in interface akka.event.SubchannelClassification
Publishes the given Event to the given Subscriber
publish(akka.event.EventBus.Event) - Method in interface akka.event.SubchannelClassification
 
pullMode() - Method in class akka.io.Tcp.Bind
 
pullMode() - Method in class akka.io.Tcp.Connect
 
pushTimeOut() - Method in class akka.dispatch.BoundedDequeBasedMailbox.MessageQueue
 
pushTimeOut() - Method in class akka.dispatch.BoundedDequeBasedMailbox
 
pushTimeOut() - Method in interface akka.dispatch.BoundedDequeBasedMessageQueue
 
pushTimeOut() - Method in class akka.dispatch.BoundedMailbox.MessageQueue
 
pushTimeOut() - Method in class akka.dispatch.BoundedMailbox
 
pushTimeOut() - Method in interface akka.dispatch.BoundedMessageQueueSemantics
 
pushTimeOut() - Method in class akka.dispatch.BoundedPriorityMailbox.MessageQueue
 
pushTimeOut() - Method in class akka.dispatch.BoundedPriorityMailbox
 
put(E) - Method in class akka.util.BoundedBlockingQueue
 
put(K, V) - Method in class akka.util.Index
Associates the value of type V with the key of type K
putByte(byte) - Method in class akka.util.ByteStringBuilder
Add a single Byte to this builder.
putBytes(byte[]) - Method in class akka.util.ByteStringBuilder
Add a number of Bytes from an array to this builder.
putBytes(byte[], int, int) - Method in class akka.util.ByteStringBuilder
Add a number of Bytes from an array to this builder.
putDouble(double, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a single Double to this builder.
putDoubles(double[], ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Doubles from an array to this builder.
putDoubles(double[], int, int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Doubles from an array to this builder.
putFloat(float, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a single Float to this builder.
putFloats(float[], ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Floats from an array to this builder.
putFloats(float[], int, int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Floats from an array to this builder.
putInt(int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a single Int to this builder.
putInts(int[], ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Ints from an array to this builder.
putInts(int[], int, int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Ints from an array to this builder.
putLong(long, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a single Long to this builder.
putLongPart(long, int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add the n least significant bytes of the given Long to this builder.
putLongs(long[], ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Longs from an array to this builder.
putLongs(long[], int, int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Longs from an array to this builder.
putShort(int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a single Short to this builder.
putShorts(short[], ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Shorts from an array to this builder.
putShorts(short[], int, int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Shorts from an array to this builder.

Q

queue() - Method in class akka.dispatch.BoundedDequeBasedMailbox.MessageQueue
 
queue() - Method in interface akka.dispatch.BoundedDequeBasedMessageQueue
 
queue() - Method in class akka.dispatch.BoundedMailbox.MessageQueue
 
queue() - Method in class akka.dispatch.BoundedPriorityMailbox.MessageQueue
 
queue() - Method in interface akka.dispatch.BoundedQueueBasedMessageQueue
 
queue() - Method in interface akka.dispatch.DequeBasedMessageQueue
 
queue() - Method in interface akka.dispatch.QueueBasedMessageQueue
 
queue() - Method in class akka.dispatch.UnboundedDequeBasedMailbox.MessageQueue
 
queue() - Method in class akka.dispatch.UnboundedMailbox.MessageQueue
 
queue() - Method in class akka.dispatch.UnboundedPriorityMailbox.MessageQueue
 
QueueBasedMessageQueue - Interface in akka.dispatch
A QueueBasedMessageQueue is a MessageQueue backed by a java.util.Queue.
queueFactory() - Method in class akka.dispatch.ThreadPoolConfig
 

R

rampup(int, int) - Method in class akka.routing.DefaultResizer
Computes a proposed positive (or zero) capacity delta using the configured rampupRate.
rampupRate() - Method in class akka.routing.DefaultResizer
Percentage to increase capacity whenever all routees are busy.
random() - Method in class akka.util.Crypt$
 
random() - Static method in class akka.util.Crypt
 
RandomGroup - Class in akka.routing
A router group that randomly selects one of the target routees to send a message to.
RandomGroup(Iterable<String>, String) - Constructor for class akka.routing.RandomGroup
 
RandomGroup(Config) - Constructor for class akka.routing.RandomGroup
 
RandomGroup(Iterable<String>) - Constructor for class akka.routing.RandomGroup
Java API
RandomGroup$ - Class in akka.routing
 
RandomGroup$() - Constructor for class akka.routing.RandomGroup$
 
RandomPool - Class in akka.routing
A router pool that randomly selects one of the target routees to send a message to.
RandomPool(int, Option<Resizer>, SupervisorStrategy, String, boolean) - Constructor for class akka.routing.RandomPool
 
RandomPool(Config) - Constructor for class akka.routing.RandomPool
 
RandomPool(int) - Constructor for class akka.routing.RandomPool
Java API
RandomPool$ - Class in akka.routing
 
RandomPool$() - Constructor for class akka.routing.RandomPool$
 
RandomRouter - Class in akka.routing
A Router that randomly selects one of the target connections to send a message to.
RandomRouter(int, Iterable<String>, Option<Resizer>, String, SupervisorStrategy) - Constructor for class akka.routing.RandomRouter
 
RandomRouter(int) - Constructor for class akka.routing.RandomRouter
Java API: Constructor that sets nrOfInstances to be created.
RandomRouter(Iterable<String>) - Constructor for class akka.routing.RandomRouter
Java API: Constructor that sets the routees to be used.
RandomRouter(Resizer) - Constructor for class akka.routing.RandomRouter
Java API: Constructor that sets the resizer to be used.
RandomRouter$ - Class in akka.routing
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
RandomRouter$() - Constructor for class akka.routing.RandomRouter$
 
RandomRoutingLogic - Class in akka.routing
Randomly selects one of the target routees to send a message to
RandomRoutingLogic() - Constructor for class akka.routing.RandomRoutingLogic
 
RandomRoutingLogic$ - Class in akka.routing
 
RandomRoutingLogic$() - Constructor for class akka.routing.RandomRoutingLogic$
 
reason() - Method in class akka.actor.FSM.StopEvent
 
receive(PartialFunction<Object, BoxedUnit>) - Method in class akka.actor.AbstractActor
Set up the initial receive behavior of the Actor.
receive() - Method in class akka.actor.AbstractActor
 
receive() - Method in interface akka.actor.Actor
This defines the initial actor behavior, it must return a partial function with the actor logic.
receive() - Method in interface akka.actor.dsl.Creators.Act
Default behavior of the actor is empty, use become to change this.
receive(FiniteDuration) - Method in class akka.actor.dsl.Inbox.Inbox
Receive a single message from the internal receiver actor.
receive() - Method in class akka.actor.dsl.Inbox.InboxActor
 
receive() - Method in interface akka.actor.FSM
 
receive(FiniteDuration) - Method in class akka.actor.Inbox
Receive the next message from this Inbox.
receive() - Method in class akka.actor.UntypedActor
 
receive() - Method in class akka.event.DeadLetterListener
 
receive() - Method in class akka.event.Logging.DefaultLogger
 
receive() - Method in class akka.Main.Terminator
 
ReceiveBufferSize() - Method in interface akka.io.Inet.SoForwarders
Inet.SocketOption to set the SO_RCVBUF option
receiveBufferSize(int) - Method in interface akka.io.Inet.SoJavaFactories
Inet.SocketOption to set the SO_RCVBUF option
ReceiveBuilder - Class in akka.japi.pf
Used for building a partial function for Actor.receive().
ReceivedMessageSizeLimit() - Method in class akka.io.TcpExt.Settings
 
receiver() - Method in class akka.actor.dsl.Inbox.Inbox
 
receiveTimeout() - Method in interface akka.actor.ActorContext
Gets the current receive timeout.
ReceiveTimeout - Class in akka.actor
 
ReceiveTimeout() - Constructor for class akka.actor.ReceiveTimeout
 
ReceiveTimeout$ - Class in akka.actor.dungeon
 
ReceiveTimeout$() - Constructor for class akka.actor.dungeon.ReceiveTimeout$
 
ReceiveTimeout$ - Class in akka.actor
When using ActorContext.setReceiveTimeout, the singleton instance of ReceiveTimeout will be sent to the Actor when there hasn't been any message for that long.
ReceiveTimeout$() - Constructor for class akka.actor.ReceiveTimeout$
 
recipient() - Method in class akka.actor.DeadLetter
 
recipient() - Method in class akka.actor.UnhandledMessage
 
Recover<T> - Class in akka.dispatch
Callback for the Future.recover operation that conditionally turns failures into successes.
Recover() - Constructor for class akka.dispatch.Recover
 
recover(Throwable) - Method in class akka.dispatch.Recover
This method will be invoked once when/if the Future this recover callback is registered on becomes completed with a failure.
Recreate$ - Class in akka.dispatch.sysmsg
 
Recreate$() - Constructor for class akka.dispatch.sysmsg.Recreate$
 
reduce(Iterable<Future<T>>, Function2<R, T, R>, ExecutionContext) - Method in class akka.dispatch.Futures$
Reduces the results of the supplied futures and binary function.
reduce(Iterable<Future<T>>, Function2<R, T, R>, ExecutionContext) - Static method in class akka.dispatch.Futures
Reduces the results of the supplied futures and binary function.
ReentrantGuard - Class in akka.util
 
ReentrantGuard() - Constructor for class akka.util.ReentrantGuard
 
ref() - Method in class akka.actor.ActorIdentity
 
ref() - Method in class akka.routing.ActorRefRoutee
 
Reflect - Class in akka.util
Collection of internal reflection utilities which may or may not be available (most services specific to HotSpot, but fails gracefully).
Reflect() - Constructor for class akka.util.Reflect
 
Reflect$ - Class in akka.util
Collection of internal reflection utilities which may or may not be available (most services specific to HotSpot, but fails gracefully).
Reflect$() - Constructor for class akka.util.Reflect$
 
ReflectiveDynamicAccess - Class in akka.actor
This is the default DynamicAccess implementation used by ExtendedActorSystem unless overridden.
ReflectiveDynamicAccess(ClassLoader) - Constructor for class akka.actor.ReflectiveDynamicAccess
 
register(S, PartialFunction<FSM.Event<D>, FSM.State<S, D>>, Option<FiniteDuration>) - Method in interface akka.actor.FSM
 
register(akka.actor.ActorCell) - Method in class akka.dispatch.BalancingDispatcher
 
register(akka.actor.ActorCell) - Method in class akka.dispatch.MessageDispatcher
If you override it, you must call it.
register(akka.actor.ActorCell) - Method in class akka.dispatch.PinnedDispatcher
 
register(ActorRef, boolean, boolean) - Method in class akka.io.TcpMessage$
This message must be sent to a TCP connection actor after receiving the Tcp.Connected message.
register(ActorRef) - Method in class akka.io.TcpMessage$
The same as register(handler, false, false).
register(ActorRef, boolean, boolean) - Static method in class akka.io.TcpMessage
This message must be sent to a TCP connection actor after receiving the Tcp.Connected message.
register(ActorRef) - Static method in class akka.io.TcpMessage
The same as register(handler, false, false).
registerConfigurator(String, MessageDispatcherConfigurator) - Method in class akka.dispatch.Dispatchers
Register a MessageDispatcherConfigurator that will be used by Dispatchers.lookup(java.lang.String) and Dispatchers.hasDispatcher(java.lang.String) instead of looking up the configurator from the system configuration.
registerExtension(ExtensionId<T>) - Method in class akka.actor.ActorSystem
Registers the provided extension and creates its payload, if this extension isn't already registered This method has putIfAbsent-semantics, this method can potentially block, waiting for the initialization of the payload, if is in the process of registration from another Thread of execution
registerForExecution(Mailbox, boolean, boolean) - Method in class akka.dispatch.Dispatcher
Returns if it was registered
registerForExecution(Mailbox, boolean, boolean) - Method in class akka.dispatch.MessageDispatcher
Suggest to register the provided mailbox for execution
registerOnTermination(Function0<T>) - Method in class akka.actor.ActorSystem
Register a block of code (callback) to run after ActorSystem.shutdown has been issued and all actors in this actor system have been stopped.
registerOnTermination(Runnable) - Method in class akka.actor.ActorSystem
Java API: Register a block of code (callback) to run after ActorSystem.shutdown has been issued and all actors in this actor system have been stopped.
registerTempActor(InternalActorRef, ActorPath) - Method in interface akka.actor.ActorRefProvider
Registers an actorRef at a path returned by tempPath(); do NOT pass in any other path.
RegisterTimeout() - Method in class akka.io.TcpExt.Settings
 
rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class akka.dispatch.SaneRejectedExecutionHandler
 
rejectionPolicy() - Method in class akka.dispatch.ThreadPoolConfig
 
RelativeActorPath - Class in akka.actor
Extractor for so-called “relative actor paths” as in “relative URI”, not in “relative to some actor”.
RelativeActorPath() - Constructor for class akka.actor.RelativeActorPath
 
RelativeActorPath$ - Class in akka.actor
Extractor for so-called “relative actor paths” as in “relative URI”, not in “relative to some actor”.
RelativeActorPath$() - Constructor for class akka.actor.RelativeActorPath$
 
release(ByteBuffer) - Method in interface akka.io.BufferPool
 
remainingCapacity() - Method in class akka.util.BoundedBlockingQueue
 
remainingDuration() - Method in exception akka.pattern.CircuitBreakerOpenException
 
remoteAddress() - Method in class akka.io.Tcp.Connect
 
remoteAddress() - Method in class akka.io.Tcp.Connected
 
remoteAddress() - Method in class akka.io.UdpConnected.Connect
 
remove(T) - Method in class akka.routing.ConsistentHash
Java API: Removes a node from the node ring.
remove(Object) - Method in class akka.util.BoundedBlockingQueue
 
remove(K, V) - Method in class akka.util.Index
Disassociates the value of type V from the key of type K
remove(K) - Method in class akka.util.Index
Disassociates all the values for the specified key
removeAll(Collection<?>) - Method in class akka.util.BoundedBlockingQueue
 
removeFromCache(Seq<Tuple2<Object, Set<Object>>>) - Method in interface akka.event.SubchannelClassification
 
RemoveRoutee - Class in akka.routing
Remove a specific routee by sending this message to the router.
RemoveRoutee(Routee) - Constructor for class akka.routing.RemoveRoutee
 
removeRoutee(Routee) - Method in class akka.routing.Router
Create a new instance without the specified routee.
removeRoutee(ActorRef) - Method in class akka.routing.Router
Create a new instance without the ActorRefRoutee for the specified ActorRef.
removeRoutee(ActorSelection) - Method in class akka.routing.Router
Create a new instance without the ActorSelectionRoutee for the specified ActorSelection.
RemoveRoutee$ - Class in akka.routing
 
RemoveRoutee$() - Constructor for class akka.routing.RemoveRoutee$
 
removeValue(V) - Method in class akka.util.Index
Removes the specified value from all keys
repeat() - Method in class akka.actor.FSM.Timer
 
replies() - Method in class akka.actor.FSM.State
 
replying(Object) - Method in class akka.actor.FSM.State
Send reply to sender of the current message, if available.
reportFailure(Throwable) - Method in class akka.dispatch.ExecutionContexts.sameThreadExecutionContext$
 
reportFailure(Throwable) - Method in class akka.dispatch.MessageDispatcher
 
requestRestartPermission(Tuple2<Option<Object>, Option<Object>>) - Method in class akka.actor.ChildRestartStats
 
RequiresMessageQueue<T> - Interface in akka.dispatch
Trait to signal that an Actor requires a certain type of message queue semantics.
requiring(boolean, Function0<Object>) - Method in class akka.util.Helpers.Requiring
Check that a condition is true.
requiring(Function1<A, Object>, Function0<Object>) - Method in class akka.util.Helpers.Requiring
Check that a condition is true for the value.
RESCHEDULED() - Method in class akka.dispatch.MessageDispatcher$
 
RESCHEDULED() - Static method in class akka.dispatch.MessageDispatcher
 
ResizablePoolActor$ - Class in akka.routing
INTERNAL API
ResizablePoolActor$() - Constructor for class akka.routing.ResizablePoolActor$
 
resize(IndexedSeq<Routee>) - Method in class akka.routing.DefaultResizer
 
resize(IndexedSeq<Routee>) - Method in interface akka.routing.Resizer
Decide if the capacity of the router need to be changed.
resizer() - Method in class akka.routing.BalancingPool
Resizer cannot be used together with BalancingPool
resizer() - Method in class akka.routing.BroadcastPool
 
resizer() - Method in class akka.routing.BroadcastRouter
 
resizer() - Method in class akka.routing.ConsistentHashingPool
 
resizer() - Method in class akka.routing.ConsistentHashingRouter
 
resizer() - Method in class akka.routing.FromConfig
 
resizer() - Method in interface akka.routing.Pool
Pool with dynamically resizable number of routees return the Resizer to use.
resizer() - Method in class akka.routing.RandomPool
 
resizer() - Method in class akka.routing.RandomRouter
 
Resizer - Interface in akka.routing
Pool routers with dynamically resizable number of routees are implemented by providing a Resizer implementation in the Pool configuration.
resizer() - Method in class akka.routing.RoundRobinPool
 
resizer() - Method in class akka.routing.RoundRobinRouter
 
resizer() - Method in class akka.routing.ScatterGatherFirstCompletedPool
 
resizer() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
resizer() - Method in class akka.routing.SmallestMailboxPool
 
resizer() - Method in class akka.routing.SmallestMailboxRouter
 
resolveActorRef(String) - Method in interface akka.actor.ActorRefProvider
Create actor reference for a specified path.
resolveActorRef(ActorPath) - Method in interface akka.actor.ActorRefProvider
Create actor reference for a specified path.
resolveClass(ObjectStreamClass) - Method in class akka.util.ClassLoaderObjectInputStream
 
resolveOne(Timeout) - Method in class akka.actor.ActorSelection
Resolve the ActorRef matching this selection.
resolveOne(FiniteDuration) - Method in class akka.actor.ActorSelection
Resolve the ActorRef matching this selection.
Restart() - Method in interface akka.actor.dsl.Creators.Act
 
restart() - Method in class akka.actor.SupervisorStrategy$
Java API: Returning this directive discards the old Actor instance and replaces it with a new, then resumes message processing.
restart() - Static method in class akka.actor.SupervisorStrategy
Java API: Returning this directive discards the old Actor instance and replaces it with a new, then resumes message processing.
restartChild(ActorRef, Throwable, boolean) - Method in class akka.actor.SupervisorStrategy
Restart the given child, possibly suspending it first.
restartTimeWindowStartNanos() - Method in class akka.actor.ChildRestartStats
 
result() - Method in class akka.util.ByteStringBuilder
 
Resume() - Method in interface akka.actor.dsl.Creators.Act
 
resume() - Method in class akka.actor.SupervisorStrategy$
Java API: Returning this directive resumes message processing for the failed Actor
resume() - Static method in class akka.actor.SupervisorStrategy
Java API: Returning this directive resumes message processing for the failed Actor
resume(akka.actor.ActorCell) - Method in class akka.dispatch.MessageDispatcher
 
Resume$ - Class in akka.dispatch.sysmsg
 
Resume$() - Constructor for class akka.dispatch.sysmsg.Resume$
 
resumeAccepting(int) - Method in class akka.io.TcpMessage$
This message enables the accepting of the next connection if pull reading is enabled for connection actors.
resumeAccepting(int) - Static method in class akka.io.TcpMessage
This message enables the accepting of the next connection if pull reading is enabled for connection actors.
resumeChild(ActorRef, Throwable) - Method in class akka.actor.SupervisorStrategy
Resume the previously failed child: do never apply this to a child which is not the currently failing child.
resumeReading() - Method in class akka.io.TcpMessage$
This command needs to be sent to the connection actor after a Tcp.SuspendReading command in order to resume reading from the socket.
resumeReading() - Static method in class akka.io.TcpMessage
This command needs to be sent to the connection actor after a Tcp.SuspendReading command in order to resume reading from the socket.
resumeReading() - Method in class akka.io.UdpConnectedMessage$
This message must be sent to the listener actor to re-enable reading from the socket after a UdpConnected.SuspendReading command.
resumeReading() - Static method in class akka.io.UdpConnectedMessage
This message must be sent to the listener actor to re-enable reading from the socket after a UdpConnected.SuspendReading command.
resumeReading() - Method in class akka.io.UdpMessage$
This message must be sent to the listener actor to re-enable reading from the socket after a Udp.SuspendReading command.
resumeReading() - Static method in class akka.io.UdpMessage
This message must be sent to the listener actor to re-enable reading from the socket after a Udp.SuspendReading command.
resumeWriting() - Method in class akka.io.TcpMessage$
When useResumeWriting is in effect as was indicated in the Tcp.Register message then this command needs to be sent to the connection actor in order to re-enable writing after a Tcp.CommandFailed event.
resumeWriting() - Static method in class akka.io.TcpMessage
When useResumeWriting is in effect as was indicated in the Tcp.Register message then this command needs to be sent to the connection actor in order to re-enable writing after a Tcp.CommandFailed event.
retainAll(Collection<?>) - Method in class akka.util.BoundedBlockingQueue
 
returnsFuture() - Method in class akka.actor.TypedActor.MethodCall
 
returnsJOption() - Method in class akka.actor.TypedActor.MethodCall
 
returnsOption() - Method in class akka.actor.TypedActor.MethodCall
 
reusableQueue(BlockingQueue<Runnable>) - Method in class akka.dispatch.ThreadPoolConfig$
 
reusableQueue(Function0<BlockingQueue<Runnable>>) - Method in class akka.dispatch.ThreadPoolConfig$
 
reusableQueue(BlockingQueue<Runnable>) - Static method in class akka.dispatch.ThreadPoolConfig
 
reusableQueue(Function0<BlockingQueue<Runnable>>) - Static method in class akka.dispatch.ThreadPoolConfig
 
ReuseAddress() - Method in interface akka.io.Inet.SoForwarders
Inet.SocketOption to enable or disable SO_REUSEADDR
reuseAddress(boolean) - Method in interface akka.io.Inet.SoJavaFactories
Inet.SocketOption to enable or disable SO_REUSEADDR
root() - Method in interface akka.actor.ActorPath
Walk up the tree to obtain and return the RootActorPath.
root() - Method in class akka.actor.ChildActorPath
 
root() - Method in class akka.actor.RootActorPath
 
RootActorPath - Class in akka.actor
Root of the hierarchy of ActorPaths.
RootActorPath(Address, String) - Constructor for class akka.actor.RootActorPath
 
RootActorPath$ - Class in akka.actor
 
RootActorPath$() - Constructor for class akka.actor.RootActorPath$
 
rootGuardian() - Method in interface akka.actor.ActorRefProvider
Reference to the supervisor of guardian and systemGuardian; this is exposed so that the ActorSystemImpl can use it as lookupRoot, i.e.
rootGuardianAt(Address) - Method in interface akka.actor.ActorRefProvider
Reference to the supervisor of guardian and systemGuardian at the specified address; this is exposed so that the ActorRefFactory can use it as lookupRoot, i.e.
rootPath() - Method in interface akka.actor.ActorRefProvider
The root path for all actors within this actor system, not including any remote address information.
RoundRobinGroup - Class in akka.routing
A router group that uses round-robin to select a routee.
RoundRobinGroup(Iterable<String>, String) - Constructor for class akka.routing.RoundRobinGroup
 
RoundRobinGroup(Config) - Constructor for class akka.routing.RoundRobinGroup
 
RoundRobinGroup(Iterable<String>) - Constructor for class akka.routing.RoundRobinGroup
Java API
RoundRobinGroup$ - Class in akka.routing
 
RoundRobinGroup$() - Constructor for class akka.routing.RoundRobinGroup$
 
RoundRobinPool - Class in akka.routing
A router pool that uses round-robin to select a routee.
RoundRobinPool(int, Option<Resizer>, SupervisorStrategy, String, boolean) - Constructor for class akka.routing.RoundRobinPool
 
RoundRobinPool(Config) - Constructor for class akka.routing.RoundRobinPool
 
RoundRobinPool(int) - Constructor for class akka.routing.RoundRobinPool
Java API
RoundRobinPool$ - Class in akka.routing
 
RoundRobinPool$() - Constructor for class akka.routing.RoundRobinPool$
 
RoundRobinRouter - Class in akka.routing
A Router that uses round-robin to select a connection.
RoundRobinRouter(int, Iterable<String>, Option<Resizer>, String, SupervisorStrategy) - Constructor for class akka.routing.RoundRobinRouter
 
RoundRobinRouter(int) - Constructor for class akka.routing.RoundRobinRouter
Java API: Constructor that sets nrOfInstances to be created.
RoundRobinRouter(Iterable<String>) - Constructor for class akka.routing.RoundRobinRouter
Java API: Constructor that sets the routees to be used.
RoundRobinRouter(Resizer) - Constructor for class akka.routing.RoundRobinRouter
Java API: Constructor that sets the resizer to be used.
RoundRobinRouter$ - Class in akka.routing
 
RoundRobinRouter$() - Constructor for class akka.routing.RoundRobinRouter$
 
RoundRobinRoutingLogic - Class in akka.routing
Uses round-robin to select a routee.
RoundRobinRoutingLogic() - Constructor for class akka.routing.RoundRobinRoutingLogic
 
RoundRobinRoutingLogic$ - Class in akka.routing
 
RoundRobinRoutingLogic$() - Constructor for class akka.routing.RoundRobinRoutingLogic$
 
route(Object, ActorRef) - Method in class akka.routing.Router
Send the message to the destination Routee selected by the RoutingLogic.
RoutedActorCell$ - Class in akka.routing
INTERNAL API
RoutedActorCell$() - Constructor for class akka.routing.RoutedActorCell$
 
routee() - Method in class akka.routing.AddRoutee
 
routee() - Method in class akka.routing.RemoveRoutee
 
Routee - Interface in akka.routing
Abstraction of a destination for messages routed via a Router.
routeeFor(String, ActorContext) - Method in interface akka.routing.Group
INTERNAL API
routees() - Method in class akka.routing.BroadcastRouter
 
routees() - Method in class akka.routing.ConsistentHashingRouter
 
routees() - Method in class akka.routing.RandomRouter
 
routees() - Method in class akka.routing.RoundRobinRouter
 
Routees - Class in akka.routing
Message used to carry information about what routees the router is currently using.
Routees(IndexedSeq<Routee>) - Constructor for class akka.routing.Routees
 
routees() - Method in class akka.routing.Routees
 
routees() - Method in class akka.routing.Router
 
routees() - Method in class akka.routing.RouterRoutees
 
routees() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
routees() - Method in class akka.routing.SeveralRoutees
 
routees() - Method in class akka.routing.SmallestMailboxRouter
 
Routees$ - Class in akka.routing
 
Routees$() - Constructor for class akka.routing.Routees$
 
Router - Class in akka.routing
For each message that is sent through the router via the Router.route(java.lang.Object, akka.actor.ActorRef) method the RoutingLogic decides to which Routee to send the message.
Router(RoutingLogic, IndexedSeq<Routee>) - Constructor for class akka.routing.Router
 
Router(RoutingLogic) - Constructor for class akka.routing.Router
Java API
Router(RoutingLogic, Iterable<Routee>) - Constructor for class akka.routing.Router
Java API
Router$ - Class in akka.routing
 
Router$() - Constructor for class akka.routing.Router$
 
routerConfig() - Method in class akka.actor.Deploy
 
routerConfig() - Method in class akka.actor.Props
Convenience method for extracting the router configuration from the contained Deploy instance.
RouterConfig - Interface in akka.routing
This trait represents a router factory: it produces the actual router actor and creates the routing table (a function which determines the recipients for each message which is to be dispatched).
routerDispatcher() - Method in class akka.routing.BalancingPool
 
routerDispatcher() - Method in class akka.routing.BroadcastGroup
 
routerDispatcher() - Method in class akka.routing.BroadcastPool
 
routerDispatcher() - Method in class akka.routing.BroadcastRouter
 
routerDispatcher() - Method in class akka.routing.ConsistentHashingGroup
 
routerDispatcher() - Method in class akka.routing.ConsistentHashingPool
 
routerDispatcher() - Method in class akka.routing.ConsistentHashingRouter
 
routerDispatcher() - Method in class akka.routing.CustomRouterConfig
 
routerDispatcher() - Method in class akka.routing.FromConfig
 
routerDispatcher() - Method in class akka.routing.NoRouter$
 
routerDispatcher() - Static method in class akka.routing.NoRouter
 
routerDispatcher() - Method in class akka.routing.RandomGroup
 
routerDispatcher() - Method in class akka.routing.RandomPool
 
routerDispatcher() - Method in class akka.routing.RandomRouter
 
routerDispatcher() - Method in class akka.routing.RoundRobinGroup
 
routerDispatcher() - Method in class akka.routing.RoundRobinPool
 
routerDispatcher() - Method in class akka.routing.RoundRobinRouter
 
routerDispatcher() - Method in interface akka.routing.RouterConfig
Dispatcher ID to use for running the “head” actor, which handles supervision, death watch and router management messages
routerDispatcher() - Method in class akka.routing.ScatterGatherFirstCompletedGroup
 
routerDispatcher() - Method in class akka.routing.ScatterGatherFirstCompletedPool
 
routerDispatcher() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
routerDispatcher() - Method in class akka.routing.SmallestMailboxPool
 
routerDispatcher() - Method in class akka.routing.SmallestMailboxRouter
 
RouterEnvelope - Interface in akka.routing
Only the contained message will be forwarded to the destination, i.e.
RouterRoutees - Class in akka.routing
Message used to carry information about what routees the router is currently using.
RouterRoutees(IndexedSeq<ActorRef>) - Constructor for class akka.routing.RouterRoutees
 
RouterRoutees$ - Class in akka.routing
 
RouterRoutees$() - Constructor for class akka.routing.RouterRoutees$
 
RoutingLogic - Interface in akka.routing
The interface of the routing logic that is used in a Router to select destination routed messages.
routingLogicController(RoutingLogic) - Method in interface akka.routing.RouterConfig
Possibility to define an actor for controlling the routing logic from external stimuli (e.g.
run() - Method in class akka.actor.LightArrayRevolverScheduler.TaskHolder
 
run() - Method in class akka.dispatch.TaskInvocation
 
runnable() - Method in class akka.dispatch.TaskInvocation
 

S

SaneRejectedExecutionHandler - Class in akka.dispatch
The RejectedExecutionHandler used by Akka, it improves on CallerRunsPolicy by throwing a RejectedExecutionException if the executor isShutdown.
SaneRejectedExecutionHandler() - Constructor for class akka.dispatch.SaneRejectedExecutionHandler
 
scala2JavaOption(Option<A>) - Method in class akka.japi.Option$
 
scala2JavaOption(Option<A>) - Static method in class akka.japi.Option
 
ScalaActorRef - Interface in akka.actor
This trait represents the Scala Actor API There are implicit conversions in ../actor/Implicits.scala from ActorRef -> ScalaActorRef and back
ScalaActorSelection - Interface in akka.actor
Contains the Scala API (!-method) for ActorSelections) which provides automatic tracking of the sender, as per the usual implicit ActorRef pattern.
scaledPoolSize(int, double, int) - Method in class akka.dispatch.ThreadPoolConfig$
 
scaledPoolSize(int, double, int) - Static method in class akka.dispatch.ThreadPoolConfig
 
ScanningClassification - Interface in akka.event
Maps Classifiers to Subscribers and selects which Subscriber should receive which publication through scanning through all Subscribers through the matches(classifier, event) method
ScanningEventBus<E,S,C> - Class in akka.event.japi
See documentation for ScanningClassification E is the Event type S is the Subscriber type C is the Classifier type
ScanningEventBus() - Constructor for class akka.event.japi.ScanningEventBus
 
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
 
ScatterGatherFirstCompletedRoutees$() - Constructor for class akka.routing.ScatterGatherFirstCompletedRoutees$
 
ScatterGatherFirstCompletedRouter - Class in akka.routing
Simple router that broadcasts the message to all routees, and replies with the first response.
ScatterGatherFirstCompletedRouter(int, Iterable<String>, FiniteDuration, Option<Resizer>, String, SupervisorStrategy) - Constructor for class akka.routing.ScatterGatherFirstCompletedRouter
 
ScatterGatherFirstCompletedRouter(int, FiniteDuration) - Constructor for class akka.routing.ScatterGatherFirstCompletedRouter
Java API: Constructor that sets nrOfInstances to be created.
ScatterGatherFirstCompletedRouter(Iterable<String>, FiniteDuration) - Constructor for class akka.routing.ScatterGatherFirstCompletedRouter
Java API: Constructor that sets the routees to be used.
ScatterGatherFirstCompletedRouter(Resizer, FiniteDuration) - Constructor for class akka.routing.ScatterGatherFirstCompletedRouter
Java API: Constructor that sets the resizer to be used.
ScatterGatherFirstCompletedRouter$ - Class in akka.routing
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
ScatterGatherFirstCompletedRouter$() - Constructor for class akka.routing.ScatterGatherFirstCompletedRouter$
 
ScatterGatherFirstCompletedRoutingLogic - Class in akka.routing
Broadcasts the message to all routees, and replies with the first response.
ScatterGatherFirstCompletedRoutingLogic(FiniteDuration) - Constructor for class akka.routing.ScatterGatherFirstCompletedRoutingLogic
 
ScatterGatherFirstCompletedRoutingLogic$ - Class in akka.routing
 
ScatterGatherFirstCompletedRoutingLogic$() - Constructor for class akka.routing.ScatterGatherFirstCompletedRoutingLogic$
 
schedule(FiniteDuration, FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.AbstractScheduler
Schedules a function to be run repeatedly with an initial delay and a frequency.
schedule(ActorRef, FiniteDuration) - Method in class akka.actor.FSM.Timer
 
schedule(FiniteDuration, FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.LightArrayRevolverScheduler
 
schedule(FiniteDuration, FiniteDuration, ActorRef, Object, ExecutionContext, ActorRef) - Method in interface akka.actor.Scheduler
Schedules a message to be sent repeatedly with an initial delay and frequency.
schedule(FiniteDuration, FiniteDuration, Function0<BoxedUnit>, ExecutionContext) - Method in interface akka.actor.Scheduler
Schedules a function to be run repeatedly with an initial delay and a frequency.
schedule(FiniteDuration, FiniteDuration, Runnable, ExecutionContext) - Method in interface akka.actor.Scheduler
Schedules a function to be run repeatedly with an initial delay and a frequency.
Scheduled() - 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 - Interface in akka.actor
An Akka scheduler service.
scheduler() - Method in interface akka.dispatch.DispatcherPrerequisites
 
SchedulerClass() - Method in class akka.actor.ActorSystem.Settings
 
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(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
 
SelectChildName$ - Class in akka.actor
 
SelectChildName$() - Constructor for class akka.actor.SelectChildName$
 
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$() - Constructor for class akka.io.SelectionHandler$
 
SelectionHandlerSettings - Class in akka.io
 
SelectionHandlerSettings(Config) - Constructor for class akka.io.SelectionHandlerSettings
 
SelectorAssociationRetries() - Method in class akka.io.SelectionHandlerSettings
 
SelectorDispatcher() - Method in class akka.io.SelectionHandlerSettings
 
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 interface akka.actor.ActorContext
 
self() - Method in class akka.actor.TypedActor$
Returns the reference to the proxy when called inside a method call in a TypedActor
self() - Static method in class akka.actor.TypedActor
Returns the reference to the proxy when called inside a method call in a TypedActor
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, 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.SeveralRoutees
 
SendBufferSize() - Method in interface akka.io.Inet.SoForwarders
Inet.SocketOption to set the SO_SNDBUF option.
sendBufferSize(int) - Method in interface akka.io.Inet.SoJavaFactories
Inet.SocketOption to set the SO_SNDBUF option.
sender() - Method in interface akka.actor.Actor
The reference sender Actor of the last received message.
sender() - Method in interface akka.actor.ActorContext
Returns the sender 'ActorRef' of the current message.
sender() - Method in class akka.actor.DeadLetter
 
sender() - Method in class akka.actor.UnhandledMessage
 
sender() - Method in class akka.dispatch.Envelope
 
sender() - Method in class akka.io.Udp.Received
 
senderFromInbox(Inbox.Inbox) - Method in interface akka.actor.dsl.Inbox
 
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.
seqThrowable2Decider(Seq<Class<? extends Throwable>>) - Method in class akka.actor.SupervisorStrategy$
Implicit conversion from Seq of Throwables to a Decider.
seqThrowable2Decider(Seq<Class<? extends Throwable>>) - Static method in class akka.actor.SupervisorStrategy
Implicit conversion from Seq of Throwables to a Decider.
sequence(Iterable<Future<A>>, ExecutionContext) - Method in class akka.dispatch.Futures$
Simple version of Futures$.traverse(java.lang.Iterable, akka.japi.Function>, scala.concurrent.ExecutionContext).
sequence(Iterable<Future<A>>, ExecutionContext) - Static method in class akka.dispatch.Futures
Simple version of Futures.traverse(java.lang.Iterable, akka.japi.Function>, scala.concurrent.ExecutionContext).
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$() - Constructor for class akka.serialization.Serialization.Information$
 
Serialization.Settings - Class in akka.serialization
 
Serialization.Settings(Config) - Constructor for class akka.serialization.Serialization.Settings
 
SerializationBindings() - Method in class akka.serialization.Serialization.Settings
 
SerializationExtension - Class in akka.serialization
SerializationExtension is an Akka Extension to interact with the Serialization that is built into Akka
SerializationExtension() - Constructor for class akka.serialization.SerializationExtension
 
SerializationExtension$ - Class in akka.serialization
SerializationExtension is an Akka Extension to interact with the Serialization that is built into Akka
SerializationExtension$() - Constructor for class akka.serialization.SerializationExtension$
 
serialize(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$
 
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
INTERNAL API
SerializedActorRef$() - Constructor for class akka.actor.SerializedActorRef$
 
SerializedSuspendableExecutionContext$ - Class in akka.util
 
SerializedSuspendableExecutionContext$() - Constructor for class akka.util.SerializedSuspendableExecutionContext$
 
Serializer - Interface in akka.serialization
A Serializer represents a bimap between an object and an array of bytes representing that object.
serializerByIdentity() - Method in class akka.serialization.Serialization
Maps from a Serializer Identity (Int) to a Serializer instance (optimization)
serializerFor(Class<?>) - Method in class akka.serialization.Serialization
Returns the configured Serializer for the given Class.
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
 
setAllowCoreThreadTimeout(boolean) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
setCorePoolSize(int) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
setCorePoolSizeFromFactor(int, double, int) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
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(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
 
setReceiveTimeout(Duration) - Method in interface akka.actor.ActorContext
Defines the inactivity timeout after which the sending of a ReceiveTimeout message is triggered.
setStateTimeout(S, Option<FiniteDuration>) - Method in interface akka.actor.FSM
Set state timeout explicitly.
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
Schedule named timer to deliver message after given delay, possibly repeating.
settings() - Method in interface akka.actor.ActorRefProvider
The Settings associated with this ActorRefProvider
settings() - Method in class akka.actor.ActorSystem
The core settings extracted from the supplied configuration.
settings() - Method in interface akka.dispatch.DispatcherPrerequisites
 
settings() - Method in class akka.dispatch.Dispatchers
 
Settings() - Method in class akka.io.TcpExt
 
settings() - Method in class akka.io.UdpConnectedExt
 
settings() - Method in class akka.io.UdpExt
 
settings() - Method in class akka.serialization.Serialization
 
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
 
shouldNotProcessMask() - Method in class akka.dispatch.Mailbox$
 
shouldScheduleMask() - 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.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
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
simpleName(Object) - Method in class akka.event.Logging$
Returns a 'safe' getSimpleName for the provided object's Class
simpleName(Class<?>) - Method in class akka.event.Logging$
Returns a 'safe' getSimpleName for the provided Class
simpleName(Object) - Static method in class akka.event.Logging
Returns a 'safe' getSimpleName for the provided object's Class
simpleName(Class<?>) - Static method in class akka.event.Logging
Returns a 'safe' getSimpleName for the provided Class
simpleSender(Iterable<Inet.SocketOption>) - Method in class akka.io.UdpMessage$
Retrieve a reference to a “simple sender” actor of the UDP extension.
simpleSender() - Method in class akka.io.UdpMessage$
Retrieve a simple sender without specifying options.
simpleSender(Iterable<Inet.SocketOption>) - Static method in class akka.io.UdpMessage
Retrieve a reference to a “simple sender” actor of the UDP extension.
simpleSender() - Static method in class akka.io.UdpMessage
Retrieve a simple sender without specifying options.
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.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
 
sizeHint(int) - Method in class akka.util.ByteStringBuilder
 
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$
 
SmallestMailboxRouter - Class in akka.routing
A Router that tries to send to the non-suspended routee with fewest messages in mailbox.
SmallestMailboxRouter(int, Iterable<String>, Option<Resizer>, String, SupervisorStrategy) - Constructor for class akka.routing.SmallestMailboxRouter
 
SmallestMailboxRouter(int) - Constructor for class akka.routing.SmallestMailboxRouter
Java API: Constructor that sets nrOfInstances to be created.
SmallestMailboxRouter(Iterable<String>) - Constructor for class akka.routing.SmallestMailboxRouter
Java API: Constructor that sets the routees to be used.
SmallestMailboxRouter(Resizer) - Constructor for class akka.routing.SmallestMailboxRouter
Java API: Constructor that sets the resizer to be used.
SmallestMailboxRouter$ - Class in akka.routing
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
SmallestMailboxRouter$() - Constructor for class akka.routing.SmallestMailboxRouter$
 
SmallestMailboxRoutingLogic - Class in akka.routing
Tries to send to the non-suspended routee with fewest messages in mailbox.
SmallestMailboxRoutingLogic() - Constructor for class akka.routing.SmallestMailboxRoutingLogic
 
SmallestMailboxRoutingLogic$ - Class in akka.routing
 
SmallestMailboxRoutingLogic$() - Constructor for class akka.routing.SmallestMailboxRoutingLogic$
 
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
span(Function1<Object, Object>) - Method in class akka.util.ByteIterator
 
span(Function1<Object, Object>) - Method in class akka.util.ByteString
 
splitAt(int) - Method in class akka.util.ByteString
 
splitNameAndUid(String) - Method in class akka.actor.ActorCell$
 
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
 
startDefaultLoggers(akka.actor.ActorSystemImpl) - Method in interface akka.event.LoggingBus
Internal Akka use only
startHash(int) - Method in class akka.routing.MurmurHash$
Begin a new hash with a seed value.
startHash(int) - Static method in class akka.routing.MurmurHash
Begin a new hash with a seed value.
startMagicA() - Method in class akka.routing.MurmurHash$
The initial magic integers in the first stream.
startMagicA() - Static method in class akka.routing.MurmurHash
The initial magic integers in the first stream.
startMagicB() - Method in class akka.routing.MurmurHash$
The initial magic integer in the second stream.
startMagicB() - Static method in class akka.routing.MurmurHash
The initial magic integer in the second stream.
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.
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 - 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.
StashOverflowException - Exception in akka.actor
Is thrown when the size of the Stash exceeds the capacity of the Stash
StashOverflowException(String, Throwable) - Constructor for exception akka.actor.StashOverflowException
 
StashOverflowException$ - Class in akka.actor
 
StashOverflowException$() - Constructor for class akka.actor.StashOverflowException$
 
state() - Method in class akka.actor.FSM.CurrentState
 
state(S, S, FI.UnitApplyVoid) - Method in class akka.japi.pf.FSMTransitionHandlerBuilder
Add a case statement that matches on a from state and a to state.
state(S, S, FI.UnitApply2<S, S>) - Method in class akka.japi.pf.FSMTransitionHandlerBuilder
Add a case statement that matches on a from state and a to state.
stateData() - Method in class akka.actor.FSM.Event
 
stateData() - Method in class akka.actor.FSM.LogEntry
 
stateData() - Method in class akka.actor.FSM.State
 
stateData() - Method in interface akka.actor.FSM
Return current state data (i.e.
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
Return current state name (i.e.
states() - Method in interface akka.actor.LoggingFSM
 
StateTimeout() - Method in interface akka.actor.FSM
This case object is received in case of a state timeout.
stateTimeouts() - Method in interface akka.actor.FSM
 
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(Throwable) - Constructor for class akka.actor.Status.Failure
 
Status.Failure$ - Class in akka.actor
 
Status.Failure$() - Constructor for class akka.actor.Status.Failure$
 
Status.Status - Interface in akka.actor
 
Status.Success - Class in akka.actor
This class/message type is preferably used to indicate success of some operation performed.
Status.Success(Object) - Constructor for class akka.actor.Status.Success
 
Status.Success$ - Class in akka.actor
 
Status.Success$() - Constructor for class akka.actor.Status.Success$
 
stay() - Method in interface akka.actor.FSM
Produce "empty" transition descriptor.
StdoutLogLevel() - Method in class akka.actor.ActorSystem.Settings
 
stop(ActorRef) - Method in interface akka.actor.ActorRefFactory
Stop the actor pointed to by the given ActorRef; this is an asynchronous operation, i.e.
Stop() - Method in interface akka.actor.dsl.Creators.Act
 
stop() - Method in interface akka.actor.FSM
Produce change descriptor to stop this FSM actor with reason "Normal".
stop(FSM.Reason) - Method in interface akka.actor.FSM
Produce change descriptor to stop this FSM actor including specified reason.
stop(FSM.Reason, D) - Method in interface akka.actor.FSM
Produce change descriptor to stop this FSM actor including specified reason.
stop() - Method in class akka.actor.SupervisorStrategy$
Java API: Returning this directive stops the Actor
stop() - Static method in class akka.actor.SupervisorStrategy
Java API: Returning this directive stops the Actor
stop(Object) - Method in interface akka.actor.TypedActorFactory
Stops the underlying ActorRef for the supplied TypedActor proxy, if any, returns whether it could find the find the ActorRef or not
stop(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.
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
 
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
 
stringHash(String) - Method in class akka.routing.MurmurHash$
Compute a high-quality hash of a string
stringHash(String) - Static method in class akka.routing.MurmurHash
Compute a high-quality hash of a string
SubchannelClassification - Interface in akka.event
Classification which respects relationships between channels: subscribing to one channel automatically and idempotently subscribes to all sub-channels.
SubchannelEventBus<E,S,C> - Class in akka.event.japi
See documentation for SubchannelClassification E is the Event type S is the Subscriber type C is the Classifier type
SubchannelEventBus() - Constructor for class akka.event.japi.SubchannelEventBus
 
subclassification() - Method in class akka.event.EventStream
 
subclassification() - Method in class akka.event.japi.SubchannelEventBus
The logic to form sub-class hierarchy
subclassification() - Method in interface akka.event.SubchannelClassification
The logic to form sub-class hierarchy
Subclassification<K> - Interface in akka.util
Typeclass which describes a classification hierarchy.
SubclassifiedIndex$ - Class in akka.util
 
SubclassifiedIndex$() - Constructor for 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(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.EventBus
 
subscribe(ActorRef, Class<?>) - Method in class akka.event.EventStream
 
subscribe(ActorRef, ActorRef) - Method in class akka.event.japi.ActorEventBus
 
subscribe(S, C) - Method in interface akka.event.japi.EventBus
Attempts to register the subscriber to the specified Classifier
subscribe(S, C) - Method in class akka.event.japi.LookupEventBus
 
subscribe(S, C) - Method in class akka.event.japi.ScanningEventBus
 
subscribe(S, C) - Method in class akka.event.japi.SubchannelEventBus
 
subscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.LookupClassification
 
subscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.ScanningClassification
 
subscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.SubchannelClassification
 
subscribers() - Method in interface akka.event.LookupClassification
 
subscribers() - Method in interface akka.event.ScanningClassification
 
subscriptions() - Method in interface akka.event.SubchannelClassification
 
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
 
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.
supervisorStrategy() - Method in interface akka.actor.Actor
User overridable definition the strategy to use for supervising child actors.
supervisorStrategy() - Method in interface akka.actor.dsl.Creators.Act
 
SupervisorStrategy - Class in akka.actor
An Akka SupervisorStrategy is the policy to apply for crashing children.
SupervisorStrategy() - Constructor for class akka.actor.SupervisorStrategy
 
supervisorStrategy() - Method in interface akka.actor.TypedActor.Supervisor
User overridable definition the strategy to use for supervising child actors.
supervisorStrategy() - Method in class akka.actor.UntypedActor
User overridable definition the strategy to use for supervising child actors.
supervisorStrategy() - Method in class akka.routing.BalancingPool
 
supervisorStrategy() - Method in class akka.routing.BroadcastPool
 
supervisorStrategy() - Method in class akka.routing.BroadcastRouter
 
supervisorStrategy() - Method in class akka.routing.ConsistentHashingPool
 
supervisorStrategy() - Method in class akka.routing.ConsistentHashingRouter
 
supervisorStrategy() - Method in class akka.routing.FromConfig
 
supervisorStrategy() - Method in interface akka.routing.Pool
SupervisorStrategy for the head actor, i.e.
supervisorStrategy() - Method in class akka.routing.RandomPool
 
supervisorStrategy() - Method in class akka.routing.RandomRouter
 
supervisorStrategy() - Method in class akka.routing.RoundRobinPool
 
supervisorStrategy() - Method in class akka.routing.RoundRobinRouter
 
supervisorStrategy() - Method in class akka.routing.ScatterGatherFirstCompletedPool
 
supervisorStrategy() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
supervisorStrategy() - Method in class akka.routing.SmallestMailboxPool
 
supervisorStrategy() - Method in class akka.routing.SmallestMailboxRouter
 
SupervisorStrategy$ - Class in akka.actor
 
SupervisorStrategy$() - Constructor for class akka.actor.SupervisorStrategy$
 
SupervisorStrategy.Directive - Interface in akka.actor
 
SupervisorStrategy.Escalate$ - Class in akka.actor
Escalates the failure to the supervisor of the supervisor, by rethrowing the cause of the failure, i.e.
SupervisorStrategy.Escalate$() - Constructor for class akka.actor.SupervisorStrategy.Escalate$
 
SupervisorStrategy.Restart$ - Class in akka.actor
Discards the old Actor instance and replaces it with a new, then resumes message processing.
SupervisorStrategy.Restart$() - Constructor for class akka.actor.SupervisorStrategy.Restart$
 
SupervisorStrategy.Resume$ - Class in akka.actor
Resumes message processing for the failed Actor
SupervisorStrategy.Resume$() - Constructor for class akka.actor.SupervisorStrategy.Resume$
 
SupervisorStrategy.Stop$ - Class in akka.actor
Stops the Actor
SupervisorStrategy.Stop$() - Constructor for class akka.actor.SupervisorStrategy.Stop$
 
SupervisorStrategyClass() - Method in class akka.actor.ActorSystem.Settings
 
SupervisorStrategyConfigurator - Interface in akka.actor
Implement this interface in order to configure the supervisorStrategy for the top-level guardian actor (/user).
SupervisorStrategyLowPriorityImplicits - Interface in akka.actor
 
suspend(akka.actor.ActorCell) - Method in class akka.dispatch.MessageDispatcher
After the call to this method, the dispatcher mustn't begin any new message processing for the specified reference
Suspend$ - Class in akka.dispatch.sysmsg
 
Suspend$() - Constructor for class akka.dispatch.sysmsg.Suspend$
 
Suspended() - Method in class akka.util.SerializedSuspendableExecutionContext$
 
SuspendedState() - Method in class akka.actor.ActorCell$
 
SuspendedWaitForChildrenState() - Method in class akka.actor.ActorCell$
 
suspendMask() - Method in class akka.dispatch.Mailbox$
 
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.
suspendUnit() - Method in class akka.dispatch.Mailbox$
 
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 interface akka.actor.ActorContext
The system that the actor belongs to.
system() - Method in class akka.actor.ActorDSL.Extension
 
system() - Method in class akka.actor.Address
 
system() - Method in class akka.actor.TypedActorExtension
 
system() - Method in class akka.routing.ConsistentHashingRoutingLogic
 
system() - Method in class akka.serialization.JavaSerializer
 
system() - Method in class akka.serialization.Serialization
 
systemActorOf(Props, String) - Method in class akka.actor.ExtendedActorSystem
Create an actor in the "/system" namespace.
systemDispatch(akka.actor.ActorCell, akka.dispatch.sysmsg.SystemMessage) - Method in class akka.dispatch.Dispatcher
INTERNAL API
systemDispatch(akka.actor.ActorCell, akka.dispatch.sysmsg.SystemMessage) - Method in class akka.dispatch.MessageDispatcher
Will be called when the dispatcher is to queue an invocation for execution
systemGuardian() - Method in interface akka.actor.ActorRefProvider
Reference to the supervisor used for all top-level system actors.
systemGuardian() - Method in class akka.actor.ExtendedActorSystem
The top-level supervisor of all system-internal services like logging.
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 akka.actor.Guardian.TerminationHook before systemGuardian is stopped.
SystemGuardian.RegisterTerminationHook$() - Constructor for class akka.actor.SystemGuardian.RegisterTerminationHook$
 
SystemGuardian.TerminationHook$ - Class in akka.actor
 
SystemGuardian.TerminationHook$() - Constructor for class akka.actor.SystemGuardian.TerminationHook$
 
SystemGuardian.TerminationHookDone$ - Class in akka.actor
 
SystemGuardian.TerminationHookDone$() - Constructor for class akka.actor.SystemGuardian.TerminationHookDone$
 
SystemHome() - Method in class akka.actor.ActorSystem$
 
SystemHome() - Static method in class akka.actor.ActorSystem
 
systemImpl() - Method in interface akka.actor.ActorRefFactory
INTERNAL API
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$
 

T

tail() - Method in class akka.util.ByteString
 
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
 
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$ - Class in akka.io
TCP Extension for Akka’s IO layer.
Tcp$() - Constructor for class akka.io.Tcp$
 
Tcp.Abort$ - Class in akka.io
An abort operation will not flush pending writes and will issue a TCP ABORT command to the O/S kernel which should result in a TCP_RST packet being sent to the peer.
Tcp.Abort$() - Constructor for class akka.io.Tcp.Abort$
 
Tcp.Aborted$ - Class in akka.io
The connection has been aborted in response to an Abort command.
Tcp.Aborted$() - Constructor for class akka.io.Tcp.Aborted$
 
Tcp.Bind - Class in akka.io
The Bind message is send to the TCP manager actor, which is obtained via TcpExt.manager() in order to bind to a listening socket.
Tcp.Bind(ActorRef, InetSocketAddress, int, Traversable<Inet.SocketOption>, boolean) - Constructor for class akka.io.Tcp.Bind
 
Tcp.Bind$ - Class in akka.io
 
Tcp.Bind$() - Constructor for class akka.io.Tcp.Bind$
 
Tcp.Bound - Class in akka.io
The sender of a Tcp.Bind command will—in case of success—receive confirmation in this form.
Tcp.Bound(InetSocketAddress) - Constructor for class akka.io.Tcp.Bound
 
Tcp.Bound$ - Class in akka.io
 
Tcp.Bound$() - Constructor for class akka.io.Tcp.Bound$
 
Tcp.Close$ - Class in akka.io
A normal close operation will first flush pending writes and then close the socket.
Tcp.Close$() - Constructor for class akka.io.Tcp.Close$
 
Tcp.CloseCommand - Interface in akka.io
Common interface for all commands which aim to close down an open connection.
Tcp.Closed$ - Class in akka.io
The connection has been closed normally in response to a Close command.
Tcp.Closed$() - Constructor for class akka.io.Tcp.Closed$
 
Tcp.Command - Interface in akka.io
This is the common trait for all commands understood by TCP actors.
Tcp.CommandFailed - Class in akka.io
Whenever a command cannot be completed, the queried actor will reply with this message, wrapping the original command which failed.
Tcp.CommandFailed(Tcp.Command) - Constructor for class akka.io.Tcp.CommandFailed
 
Tcp.CommandFailed$ - Class in akka.io
 
Tcp.CommandFailed$() - Constructor for class akka.io.Tcp.CommandFailed$
 
Tcp.CompoundWrite - Class in akka.io
A write command which aggregates two other write commands.
Tcp.CompoundWrite(Tcp.SimpleWriteCommand, Tcp.WriteCommand) - Constructor for class akka.io.Tcp.CompoundWrite
 
Tcp.CompoundWrite$ - Class in akka.io
 
Tcp.CompoundWrite$() - Constructor for class akka.io.Tcp.CompoundWrite$
 
Tcp.ConfirmedClose$ - Class in akka.io
A confirmed close operation will flush pending writes and half-close the connection, waiting for the peer to close the other half.
Tcp.ConfirmedClose$() - Constructor for class akka.io.Tcp.ConfirmedClose$
 
Tcp.ConfirmedClosed$ - Class in akka.io
The connection has been half-closed by us and then half-close by the peer in response to a ConfirmedClose command.
Tcp.ConfirmedClosed$() - Constructor for class akka.io.Tcp.ConfirmedClosed$
 
Tcp.Connect - Class in akka.io
The Connect message is sent to the TCP manager actor, which is obtained via TcpExt.manager().
Tcp.Connect(InetSocketAddress, Option<InetSocketAddress>, Traversable<Inet.SocketOption>, Option<FiniteDuration>, boolean) - Constructor for class akka.io.Tcp.Connect
 
Tcp.Connect$ - Class in akka.io
 
Tcp.Connect$() - Constructor for class akka.io.Tcp.Connect$
 
Tcp.Connected - Class in akka.io
The connection actor sends this message either to the sender of a Tcp.Connect command (for outbound) or to the handler for incoming connections designated in the Tcp.Bind message.
Tcp.Connected(InetSocketAddress, InetSocketAddress) - Constructor for class akka.io.Tcp.Connected
 
Tcp.Connected$ - Class in akka.io
 
Tcp.Connected$() - Constructor for class akka.io.Tcp.Connected$
 
Tcp.ConnectionClosed - Interface in akka.io
This is the common interface for all events which indicate that a connection has been closed or half-closed.
Tcp.ErrorClosed - Class in akka.io
The connection has been closed due to an IO error.
Tcp.ErrorClosed(String) - Constructor for class akka.io.Tcp.ErrorClosed
 
Tcp.ErrorClosed$ - Class in akka.io
 
Tcp.ErrorClosed$() - Constructor for class akka.io.Tcp.ErrorClosed$
 
Tcp.Event - Interface in akka.io
Common interface for all events generated by the TCP layer actors.
Tcp.Message - Interface in akka.io
The common interface for Tcp.WriteCommand and Tcp.Event.
Tcp.NoAck - Class in akka.io
Each Tcp.WriteCommand can optionally request a positive acknowledgment to be sent to the commanding actor.
Tcp.NoAck(Object) - Constructor for class akka.io.Tcp.NoAck
 
Tcp.NoAck$ - Class in akka.io
Default Tcp.NoAck instance which is used when no acknowledgment information is explicitly provided.
Tcp.NoAck$() - Constructor for class akka.io.Tcp.NoAck$
 
Tcp.PeerClosed$ - Class in akka.io
The peer has closed its writing half of the connection.
Tcp.PeerClosed$() - Constructor for class akka.io.Tcp.PeerClosed$
 
Tcp.Received - Class in akka.io
Whenever data are read from a socket they will be transferred within this class to the handler actor which was designated in the Tcp.Register message.
Tcp.Received(ByteString) - Constructor for class akka.io.Tcp.Received
 
Tcp.Received$ - Class in akka.io
 
Tcp.Received$() - Constructor for class akka.io.Tcp.Received$
 
Tcp.Register - Class in akka.io
This message must be sent to a TCP connection actor after receiving the Tcp.Connected message.
Tcp.Register(ActorRef, boolean, boolean) - Constructor for class akka.io.Tcp.Register
 
Tcp.Register$ - Class in akka.io
 
Tcp.Register$() - Constructor for class akka.io.Tcp.Register$
 
Tcp.ResumeAccepting - Class in akka.io
This message enables the accepting of the next connection if read throttling is enabled for connection actors.
Tcp.ResumeAccepting(int) - Constructor for class akka.io.Tcp.ResumeAccepting
 
Tcp.ResumeAccepting$ - Class in akka.io
 
Tcp.ResumeAccepting$() - Constructor for class akka.io.Tcp.ResumeAccepting$
 
Tcp.ResumeReading$ - Class in akka.io
This command needs to be sent to the connection actor after a SuspendReading command in order to resume reading from the socket.
Tcp.ResumeReading$() - Constructor for class akka.io.Tcp.ResumeReading$
 
Tcp.ResumeWriting$ - Class in akka.io
When useResumeWriting is in effect as was indicated in the Tcp.Register message then this command needs to be sent to the connection actor in order to re-enable writing after a Tcp.CommandFailed event.
Tcp.ResumeWriting$() - Constructor for class akka.io.Tcp.ResumeWriting$
 
Tcp.SimpleWriteCommand - Class in akka.io
Common supertype of Tcp.Write and Tcp.WriteFile.
Tcp.SimpleWriteCommand() - Constructor for class akka.io.Tcp.SimpleWriteCommand
 
Tcp.SO$ - Class in akka.io
Scala API: this object contains all applicable socket options for TCP.
Tcp.SO$() - Constructor for class akka.io.Tcp.SO$
 
Tcp.SO$.KeepAlive - Class in akka.io
Inet.SocketOption to enable or disable SO_KEEPALIVE
Tcp.SO$.KeepAlive(boolean) - Constructor for class akka.io.Tcp.SO$.KeepAlive
 
Tcp.SO$.OOBInline - Class in akka.io
Inet.SocketOption to enable or disable OOBINLINE (receipt of TCP urgent data) By default, this option is disabled and TCP urgent data is silently discarded.
Tcp.SO$.OOBInline(boolean) - Constructor for class akka.io.Tcp.SO$.OOBInline
 
Tcp.SO$.TcpNoDelay - Class in akka.io
Inet.SocketOption to enable or disable TCP_NODELAY (disable or enable Nagle's algorithm)
Tcp.SO$.TcpNoDelay(boolean) - Constructor for class akka.io.Tcp.SO$.TcpNoDelay
 
Tcp.SuspendReading$ - Class in akka.io
Sending this command to the connection actor will disable reading from the TCP socket.
Tcp.SuspendReading$() - Constructor for class akka.io.Tcp.SuspendReading$
 
Tcp.Unbind$ - Class in akka.io
In order to close down a listening socket, send this message to that socket’s actor (that is the actor which previously had sent the Tcp.Bound message).
Tcp.Unbind$() - Constructor for class akka.io.Tcp.Unbind$
 
Tcp.Unbound - Interface in akka.io
The sender of an Unbind command will receive confirmation through this message once the listening socket has been closed.
Tcp.Unbound$ - Class in akka.io
 
Tcp.Unbound$() - Constructor for class akka.io.Tcp.Unbound$
 
Tcp.Write - Class in akka.io
Write data to the TCP connection.
Tcp.Write(ByteString, Tcp.Event) - Constructor for class akka.io.Tcp.Write
 
Tcp.Write$ - Class in akka.io
 
Tcp.Write$() - Constructor for class akka.io.Tcp.Write$
 
Tcp.WriteCommand - Class in akka.io
Common interface for all write commands, currently Tcp.Write, Tcp.WriteFile and Tcp.CompoundWrite.
Tcp.WriteCommand() - Constructor for class akka.io.Tcp.WriteCommand
 
Tcp.WriteCommand$ - Class in akka.io
 
Tcp.WriteCommand$() - Constructor for class akka.io.Tcp.WriteCommand$
 
Tcp.WriteFile - Class in akka.io
Write count bytes starting at position from file at filePath to the connection.
Tcp.WriteFile(String, long, long, Tcp.Event) - Constructor for class akka.io.Tcp.WriteFile
 
Tcp.WriteFile$ - Class in akka.io
 
Tcp.WriteFile$() - Constructor for class akka.io.Tcp.WriteFile$
 
Tcp.WritingResumed - Interface in akka.io
When useResumeWriting is in effect as indicated in the Tcp.Register message, the ResumeWriting command will be acknowledged by this message type, upon which it is safe to send at least one write.
Tcp.WritingResumed$ - Class in akka.io
 
Tcp.WritingResumed$() - Constructor for class akka.io.Tcp.WritingResumed$
 
TcpConnection$ - Class in akka.io
INTERNAL API
TcpConnection$() - Constructor for class akka.io.TcpConnection$
 
TcpExt - Class in akka.io
 
TcpExt(ExtendedActorSystem) - Constructor for class akka.io.TcpExt
 
TcpExt.Settings - Class in akka.io
 
TcpListener$ - Class in akka.io
INTERNAL API
TcpListener$() - Constructor for class akka.io.TcpListener$
 
TcpMessage - Class in akka.io
 
TcpMessage() - Constructor for class akka.io.TcpMessage
 
TcpMessage$ - Class in akka.io
 
TcpMessage$() - Constructor for class akka.io.TcpMessage$
 
tcpNoDelay(boolean) - Method in class akka.io.TcpSO$
Inet.SocketOption to enable or disable TCP_NODELAY (disable or enable Nagle's algorithm)
tcpNoDelay(boolean) - Static method in class akka.io.TcpSO
Inet.SocketOption to enable or disable TCP_NODELAY (disable or enable Nagle's algorithm)
TcpSO - Class in akka.io
Java API for accessing socket options.
TcpSO() - Constructor for class akka.io.TcpSO
 
TcpSO$ - Class in akka.io
Java API for accessing socket options.
TcpSO$() - Constructor for class akka.io.TcpSO$
 
team() - Method in class akka.dispatch.BalancingDispatcher
INTERNAL API
teamWork() - Method in class akka.dispatch.BalancingDispatcher
 
tell(Object, ActorRef) - Method in class akka.actor.ActorRef
Sends the specified message to the sender, i.e.
tell(Object, ActorRef) - Method in class akka.actor.ActorSelection
Sends the specified message to the sender, i.e.
tempContainer() - Method in interface akka.actor.ActorRefProvider
Returns the actor reference representing the “/temp” path.
tempPath() - Method in interface akka.actor.ActorRefProvider
Generates and returns a unique actor path below “/temp”.
terminate(FSM.State<S, D>) - Method in interface akka.actor.FSM
 
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$ - Class in akka.actor
 
Terminated$() - Constructor for class akka.actor.Terminated$
 
terminatedProps() - Method in class akka.actor.ActorCell$
 
terminateEvent() - Method in interface akka.actor.FSM
 
terminationFuture() - Method in interface akka.actor.ActorRefProvider
This Future is completed upon termination of this ActorRefProvider, which is usually initiated by stopping the guardian via ActorSystem.stop().
test(T) - Method in interface akka.japi.Predicate
 
thread() - Method in interface akka.event.Logging.LogEvent
The thread that created this log event
threadFactory() - Method in class akka.actor.ExtendedActorSystem
A ThreadFactory that can be used if the transport needs to create any Threads
threadFactory() - Method in interface akka.dispatch.DispatcherPrerequisites
 
threadFactory() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory
 
threadFactory() - Method in class akka.dispatch.ThreadPoolConfig.ThreadPoolExecutorServiceFactory
 
ThreadPoolConfig - Class in akka.dispatch
A small configuration DSL to create ThreadPoolExecutors that can be provided as an ExecutorServiceFactoryProvider to Dispatcher
ThreadPoolConfig(boolean, int, int, Duration, Function0<BlockingQueue<Runnable>>, RejectedExecutionHandler) - Constructor for class akka.dispatch.ThreadPoolConfig
 
threadPoolConfig() - Method in class akka.dispatch.ThreadPoolExecutorConfigurator
 
ThreadPoolConfig$ - Class in akka.dispatch
 
ThreadPoolConfig$() - Constructor for class akka.dispatch.ThreadPoolConfig$
 
ThreadPoolConfig.ThreadPoolExecutorServiceFactory - Class in akka.dispatch
 
ThreadPoolConfig.ThreadPoolExecutorServiceFactory(ThreadFactory) - Constructor for class akka.dispatch.ThreadPoolConfig.ThreadPoolExecutorServiceFactory
 
ThreadPoolConfigBuilder - Class in akka.dispatch
A DSL to configure and create a MessageDispatcher with a ThreadPoolExecutor
ThreadPoolConfigBuilder(ThreadPoolConfig) - Constructor for class akka.dispatch.ThreadPoolConfigBuilder
 
ThreadPoolConfigBuilder$ - Class in akka.dispatch
 
ThreadPoolConfigBuilder$() - Constructor for class akka.dispatch.ThreadPoolConfigBuilder$
 
ThreadPoolExecutorConfigurator - Class in akka.dispatch
 
ThreadPoolExecutorConfigurator(Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.ThreadPoolExecutorConfigurator
 
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.TypedProps
 
timeout() - Method in class akka.io.Tcp.Connect
 
Timeout - Class in akka.util
 
Timeout(FiniteDuration) - Constructor for class akka.util.Timeout
 
Timeout(long) - Constructor for class akka.util.Timeout
Construct a Timeout from the given number of milliseconds.
Timeout(long, TimeUnit) - Constructor for class akka.util.Timeout
Construct a Timeout from the given time unit and factor.
Timeout$ - Class in akka.util
A Timeout is a wrapper on top of Duration to be more specific about what the duration means.
Timeout$() - Constructor for class akka.util.Timeout$
 
timeoutFuture() - Method in interface akka.actor.FSM
 
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
 
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
toByteBuffer() - Method in class akka.util.ByteString
Creates a new ByteBuffer with a copy of all bytes contained in this ByteString.
toByteString() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
toByteString() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
toByteString() - Method in class akka.util.ByteIterator
 
token() - Method in class akka.io.Tcp.NoAck
 
token() - Method in class akka.io.Udp.NoAck
 
token() - Method in class akka.io.UdpConnected.NoAck
 
toScala(ActorSelection) - Method in class akka.actor.ActorSelection$
 
toScala(ActorSelection) - Static method in class akka.actor.ActorSelection
 
toSeq() - Method in class akka.util.ByteIterator
 
toSerializationFormat() - Method in interface akka.actor.ActorPath
Generate full String representation including the uid for the actor cell instance as URI fragment.
toSerializationFormat() - Method in class akka.actor.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.Address
Returns the canonical String representation of this Address formatted as:
toString() - Method in class akka.actor.ChildActorPath
 
toString() - Method in class akka.actor.RootActorPath
 
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
 
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
Convenience wrapper for using a total function instead of a partial function literal.
TraceLogging() - Method in class akka.io.SelectionHandlerSettings
 
TrafficClass() - Method in interface akka.io.Inet.SoForwarders
Inet.SocketOption to set the traffic class or type-of-service octet in the IP header for packets sent from this socket.
trafficClass(int) - Method in interface akka.io.Inet.SoJavaFactories
Inet.SocketOption to set the traffic class or type-of-service octet in the IP header for packets sent from this socket.
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
 
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].
typedActor() - Method in class akka.actor.ContextualTypedActorFactory
 
TypedActor - Class in akka.actor
This represents the TypedActor Akka Extension, access to the functionality is done through a given ActorSystem.
TypedActor() - Constructor for class akka.actor.TypedActor
 
typedActor() - Method in class akka.actor.TypedActorExtension
 
typedActor() - Method in interface akka.actor.TypedActorFactory
Underlying dependency to a TypedActorExtension, which can either be contextual or ActorSystem "global"
TypedActor$ - Class in akka.actor
This represents the TypedActor Akka Extension, access to the functionality is done through a given ActorSystem.
TypedActor$() - Constructor for class akka.actor.TypedActor$
 
TypedActor.MethodCall - Class in akka.actor
This class represents a Method call, and has a reference to the Method to be called and the parameters to supply It's sent to the ActorRef backing the TypedActor and can be serialized and deserialized
TypedActor.MethodCall(Method, Object[]) - Constructor for class akka.actor.TypedActor.MethodCall
 
TypedActor.MethodCall$ - Class in akka.actor
 
TypedActor.MethodCall$() - Constructor for class akka.actor.TypedActor.MethodCall$
 
TypedActor.PostRestart - Interface in akka.actor
 
TypedActor.PostStop - Interface in akka.actor
Mix this into your TypedActor to be able to hook into its lifecycle
TypedActor.PreRestart - Interface in akka.actor
Mix this into your TypedActor to be able to hook into its lifecycle
TypedActor.PreStart - Interface in akka.actor
Mix this into your TypedActor to be able to hook into its lifecycle
TypedActor.Receiver - Interface in akka.actor
Mix this into your TypedActor to be able to intercept Terminated messages
TypedActor.SerializedMethodCall$ - Class in akka.actor
 
TypedActor.SerializedMethodCall$() - Constructor for class akka.actor.TypedActor.SerializedMethodCall$
 
TypedActor.SerializedTypedActorInvocationHandler$ - Class in akka.actor
 
TypedActor.SerializedTypedActorInvocationHandler$() - Constructor for class akka.actor.TypedActor.SerializedTypedActorInvocationHandler$
 
TypedActor.Supervisor - Interface in akka.actor
Mix this into your TypedActor to be able to define supervisor strategy
TypedActorExtension - Class in akka.actor
 
TypedActorExtension(ExtendedActorSystem) - Constructor for class akka.actor.TypedActorExtension
 
TypedActorFactory - Interface in akka.actor
A TypedActorFactory is something that can created TypedActor instances.
typedActorOf(TypedProps<T>) - Method in interface akka.actor.TypedActorFactory
Creates a new TypedActor with the specified properties
typedActorOf(TypedProps<T>, String) - Method in interface akka.actor.TypedActorFactory
Creates a new TypedActor with the specified properties
typedActorOf(TypedProps<T>, ActorRef) - Method in interface akka.actor.TypedActorFactory
Creates a TypedActor that intercepts the calls and forwards them as TypedActor.MethodCall to the provided ActorRef.
TypedCreatorFunctionConsumerClass() - Method in class akka.actor.IndirectActorProducer$
 
TypedCreatorFunctionConsumerClass() - Method in interface akka.actor.IndirectActorProducer
 
TypedProps<T> - Class in akka.actor
TypedProps is a TypedActor configuration object, that is thread safe and fully sharable.
TypedProps(Seq<Class<?>>, Function0<T>, String, Deploy, Option<Timeout>, Option<ClassLoader>) - Constructor for class akka.actor.TypedProps
 
TypedProps(Class<T>) - Constructor for class akka.actor.TypedProps
Uses the supplied class as the factory for the TypedActor implementation, and that has the specified interface, or if the interface class is not an interface, all the interfaces it implements, appended in the sequence of interfaces.
TypedProps(Class<? super T>, Creator<T>) - Constructor for class akka.actor.TypedProps
Java API: Uses the supplied Creator as the factory for the TypedActor implementation, and that has the specified interface, or if the interface class is not an interface, all the interfaces it implements, appended in the sequence of interfaces.
TypedProps(Class<? super T>, Class<T>) - Constructor for class akka.actor.TypedProps
Java API: Uses the supplied class as the factory for the TypedActor implementation, and that has the specified interface, or if the interface class is not an interface, all the interfaces it implements, appended in the sequence of interfaces.
TypedProps$ - Class in akka.actor
TypedProps is a TypedActor configuration object, that is thread safe and fully sharable.
TypedProps$() - Constructor for class akka.actor.TypedProps$
 

U

Udp - Class in akka.io
UDP Extension for Akka’s IO layer.
Udp() - Constructor for class akka.io.Udp
 
Udp$ - Class in akka.io
UDP Extension for Akka’s IO layer.
Udp$() - Constructor for class akka.io.Udp$
 
Udp.Bind - Class in akka.io
Send this message to the UdpExt.manager() in order to bind to the given local port (or an automatically assigned one if the port number is zero).
Udp.Bind(ActorRef, InetSocketAddress, Traversable<Inet.SocketOption>) - Constructor for class akka.io.Udp.Bind
 
Udp.Bind$ - Class in akka.io
 
Udp.Bind$() - Constructor for class akka.io.Udp.Bind$
 
Udp.Bound - Class in akka.io
This message is sent by the listener actor in response to a Udp.Bind command.
Udp.Bound(InetSocketAddress) - Constructor for class akka.io.Udp.Bound
 
Udp.Bound$ - Class in akka.io
 
Udp.Bound$() - Constructor for class akka.io.Udp.Bound$
 
Udp.Command - Interface in akka.io
The common type of all commands supported by the UDP implementation.
Udp.CommandFailed - Class in akka.io
When a command fails it will be replied to with this message type, wrapping the failing command object.
Udp.CommandFailed(Udp.Command) - Constructor for class akka.io.Udp.CommandFailed
 
Udp.CommandFailed$ - Class in akka.io
 
Udp.CommandFailed$() - Constructor for class akka.io.Udp.CommandFailed$
 
Udp.Event - Interface in akka.io
The common type of all events emitted by the UDP implementation.
Udp.Message - Interface in akka.io
The common interface for Udp.Command and Udp.Event.
Udp.NoAck - Class in akka.io
Each Udp.Send can optionally request a positive acknowledgment to be sent to the commanding actor.
Udp.NoAck(Object) - Constructor for class akka.io.Udp.NoAck
 
Udp.NoAck$ - Class in akka.io
Default Udp.NoAck instance which is used when no acknowledgment information is explicitly provided.
Udp.NoAck$() - Constructor for class akka.io.Udp.NoAck$
 
Udp.Received - Class in akka.io
When a listener actor receives a datagram from its socket it will send it to the handler designated in the Udp.Bind message using this message type.
Udp.Received(ByteString, InetSocketAddress) - Constructor for class akka.io.Udp.Received
 
Udp.Received$ - Class in akka.io
 
Udp.Received$() - Constructor for class akka.io.Udp.Received$
 
Udp.ResumeReading$ - Class in akka.io
This message must be sent to the listener actor to re-enable reading from the socket after a SuspendReading command.
Udp.ResumeReading$() - Constructor for class akka.io.Udp.ResumeReading$
 
Udp.Send - Class in akka.io
This message is understood by the “simple sender” which can be obtained by sending the Udp.SimpleSender query to the UdpExt.manager() as well as by the listener actors which are created in response to Udp.Bind.
Udp.Send(ByteString, InetSocketAddress, Udp.Event) - Constructor for class akka.io.Udp.Send
 
Udp.Send$ - Class in akka.io
 
Udp.Send$() - Constructor for class akka.io.Udp.Send$
 
Udp.SimpleSender - Class in akka.io
Retrieve a reference to a “simple sender” actor of the UDP extension.
Udp.SimpleSender(Traversable<Inet.SocketOption>) - Constructor for class akka.io.Udp.SimpleSender
 
Udp.SimpleSender$ - Class in akka.io
 
Udp.SimpleSender$() - Constructor for class akka.io.Udp.SimpleSender$
 
Udp.SimpleSenderReady - Interface in akka.io
The “simple sender” sends this message type in response to a Udp.SimpleSender query.
Udp.SimpleSenderReady$ - Class in akka.io
 
Udp.SimpleSenderReady$() - Constructor for class akka.io.Udp.SimpleSenderReady$
 
Udp.SO$ - Class in akka.io
Scala API: This object provides access to all socket options applicable to UDP sockets.
Udp.SO$() - Constructor for class akka.io.Udp.SO$
 
Udp.SO$.Broadcast - Class in akka.io
Inet.SocketOption to set the SO_BROADCAST option
Udp.SO$.Broadcast(boolean) - Constructor for class akka.io.Udp.SO$.Broadcast
 
Udp.SuspendReading$ - Class in akka.io
Send this message to a listener actor (which sent a Udp.Bound message) to have it stop reading datagrams from the network.
Udp.SuspendReading$() - Constructor for class akka.io.Udp.SuspendReading$
 
Udp.Unbind$ - Class in akka.io
Send this message to the listener actor that previously sent a Udp.Bound message in order to close the listening socket.
Udp.Unbind$() - Constructor for class akka.io.Udp.Unbind$
 
Udp.Unbound - Interface in akka.io
This message is sent by the listener actor in response to an Unbind command after the socket has been closed.
Udp.Unbound$ - Class in akka.io
 
Udp.Unbound$() - Constructor for class akka.io.Udp.Unbound$
 
UdpConnected - Class in akka.io
UDP Extension for Akka’s IO layer.
UdpConnected() - Constructor for class akka.io.UdpConnected
 
UdpConnected$ - Class in akka.io
UDP Extension for Akka’s IO layer.
UdpConnected$() - Constructor for class akka.io.UdpConnected$
 
UdpConnected.Command - Interface in akka.io
The common type of all commands supported by the UDP implementation.
UdpConnected.CommandFailed - Class in akka.io
When a command fails it will be replied to with this message type, wrapping the failing command object.
UdpConnected.CommandFailed(UdpConnected.Command) - Constructor for class akka.io.UdpConnected.CommandFailed
 
UdpConnected.CommandFailed$ - Class in akka.io
 
UdpConnected.CommandFailed$() - Constructor for class akka.io.UdpConnected.CommandFailed$
 
UdpConnected.Connect - Class in akka.io
Send this message to the UdpExt.manager() in order to bind to a local port (optionally with the chosen localAddress) and create a UDP socket which is restricted to sending to and receiving from the given remoteAddress.
UdpConnected.Connect(ActorRef, InetSocketAddress, Option<InetSocketAddress>, Traversable<Inet.SocketOption>) - Constructor for class akka.io.UdpConnected.Connect
 
UdpConnected.Connect$ - Class in akka.io
 
UdpConnected.Connect$() - Constructor for class akka.io.UdpConnected.Connect$
 
UdpConnected.Connected - Interface in akka.io
This message is sent by the connection actor to the actor which sent the UdpConnected.Connect message when the UDP socket has been bound to the local and remote addresses given.
UdpConnected.Connected$ - Class in akka.io
 
UdpConnected.Connected$() - Constructor for class akka.io.UdpConnected.Connected$
 
UdpConnected.Disconnect$ - Class in akka.io
Send this message to a connection actor (which had previously sent the UdpConnected.Connected message) in order to close the socket.
UdpConnected.Disconnect$() - Constructor for class akka.io.UdpConnected.Disconnect$
 
UdpConnected.Disconnected - Interface in akka.io
This message is sent by the connection actor to the actor which sent the Disconnect message when the UDP socket has been closed.
UdpConnected.Disconnected$ - Class in akka.io
 
UdpConnected.Disconnected$() - Constructor for class akka.io.UdpConnected.Disconnected$
 
UdpConnected.Event - Interface in akka.io
The common type of all events emitted by the UDP implementation.
UdpConnected.Message - Interface in akka.io
The common interface for UdpConnected.Command and UdpConnected.Event.
UdpConnected.NoAck - Class in akka.io
Each UdpConnected.Send can optionally request a positive acknowledgment to be sent to the commanding actor.
UdpConnected.NoAck(Object) - Constructor for class akka.io.UdpConnected.NoAck
 
UdpConnected.NoAck$ - Class in akka.io
Default UdpConnected.NoAck instance which is used when no acknowledgment information is explicitly provided.
UdpConnected.NoAck$() - Constructor for class akka.io.UdpConnected.NoAck$
 
UdpConnected.Received - Class in akka.io
When a connection actor receives a datagram from its socket it will send it to the handler designated in the Udp.Bind message using this message type.
UdpConnected.Received(ByteString) - Constructor for class akka.io.UdpConnected.Received
 
UdpConnected.Received$ - Class in akka.io
 
UdpConnected.Received$() - Constructor for class akka.io.UdpConnected.Received$
 
UdpConnected.ResumeReading$ - Class in akka.io
This message must be sent to the listener actor to re-enable reading from the socket after a SuspendReading command.
UdpConnected.ResumeReading$() - Constructor for class akka.io.UdpConnected.ResumeReading$
 
UdpConnected.Send - Class in akka.io
This message is understood by the connection actors to send data to their designated destination.
UdpConnected.Send(ByteString, Object) - Constructor for class akka.io.UdpConnected.Send
 
UdpConnected.Send$ - Class in akka.io
 
UdpConnected.Send$() - Constructor for class akka.io.UdpConnected.Send$
 
UdpConnected.SuspendReading$ - Class in akka.io
Send this message to a listener actor (which sent a Udp.Bound message) to have it stop reading datagrams from the network.
UdpConnected.SuspendReading$() - Constructor for class akka.io.UdpConnected.SuspendReading$
 
UdpConnectedExt - Class in akka.io
 
UdpConnectedExt(ExtendedActorSystem) - Constructor for class akka.io.UdpConnectedExt
 
UdpConnectedMessage - Class in akka.io
Java API: factory methods for the message types used when communicating with the UdpConnected service.
UdpConnectedMessage() - Constructor for class akka.io.UdpConnectedMessage
 
UdpConnectedMessage$ - Class in akka.io
Java API: factory methods for the message types used when communicating with the UdpConnected service.
UdpConnectedMessage$() - Constructor for class akka.io.UdpConnectedMessage$
 
UdpExt - Class in akka.io
 
UdpExt(ExtendedActorSystem) - Constructor for class akka.io.UdpExt
 
UdpMessage - Class in akka.io
Java API: factory methods for the message types used when communicating with the Udp service.
UdpMessage() - Constructor for class akka.io.UdpMessage
 
UdpMessage$ - Class in akka.io
Java API: factory methods for the message types used when communicating with the Udp service.
UdpMessage$() - Constructor for class akka.io.UdpMessage$
 
UdpSO - Class in akka.io
 
UdpSO() - Constructor for class akka.io.UdpSO
 
UdpSO$ - Class in akka.io
 
UdpSO$() - Constructor for class akka.io.UdpSO$
 
uid() - Method in interface akka.actor.ActorPath
INTERNAL API Unique identifier of the actor.
uid() - Method in class akka.actor.ChildActorPath
 
uid() - Method in class akka.actor.ChildRestartStats
 
unapply(ActorInitializationException) - Method in class akka.actor.ActorInitializationException$
 
unapply(ActorInitializationException) - Static method in exception akka.actor.ActorInitializationException
 
unapply(String) - Method in class akka.actor.ActorPathExtractor$
 
unapply(String) - Static method in class akka.actor.ActorPathExtractor
 
unapply(String) - Method in class akka.actor.AddressFromURIString$
 
unapply(URI) - Method in class akka.actor.AddressFromURIString$
 
unapply(String) - Static method in class akka.actor.AddressFromURIString
 
unapply(URI) - Static method in class akka.actor.AddressFromURIString
 
unapply(Tuple2<S, S>) - Method in class akka.actor.FSM.$minus$greater$
 
unapply(PostRestartException) - Method in class akka.actor.OriginalRestartException$
 
unapply(PostRestartException) - Static method in class akka.actor.OriginalRestartException
 
unapply(String) - Method in class akka.actor.RelativeActorPath$
 
unapply(String) - Static method in class akka.actor.RelativeActorPath
 
unapply(FromConfig) - Method in class akka.routing.FromConfig$
 
unapply(FromConfig) - Static method in class akka.routing.FromConfig
 
unbatchedExecute(Runnable) - Method in class akka.dispatch.ExecutionContexts.sameThreadExecutionContext$
 
unbatchedExecute(Runnable) - Method in class akka.dispatch.MessageDispatcher
 
unbecome() - Method in interface akka.actor.ActorContext
Reverts the Actor behavior to the previous one on the behavior stack.
unbecome() - Method in interface akka.actor.dsl.Creators.Act
Pop the active behavior from the behavior stack of this actor.
unbind() - Method in class akka.io.TcpMessage$
In order to close down a listening socket, send this message to that socket’s actor (that is the actor which previously had sent the Tcp.Bound message).
unbind() - Static method in class akka.io.TcpMessage
In order to close down a listening socket, send this message to that socket’s actor (that is the actor which previously had sent the Tcp.Bound message).
unbind() - Method in class akka.io.UdpMessage$
Send this message to the listener actor that previously sent a Udp.Bound message in order to close the listening socket.
unbind() - Static method in class akka.io.UdpMessage
Send this message to the listener actor that previously sent a Udp.Bound message in order to close the listening socket.
UnboundedDequeBasedMailbox - Class in akka.dispatch
UnboundedDequeBasedMailbox is an unbounded MailboxType, backed by a Deque.
UnboundedDequeBasedMailbox() - Constructor for class akka.dispatch.UnboundedDequeBasedMailbox
 
UnboundedDequeBasedMailbox(ActorSystem.Settings, Config) - Constructor for class akka.dispatch.UnboundedDequeBasedMailbox
 
UnboundedDequeBasedMailbox$ - Class in akka.dispatch
 
UnboundedDequeBasedMailbox$() - Constructor for class akka.dispatch.UnboundedDequeBasedMailbox$
 
UnboundedDequeBasedMailbox.MessageQueue - Class in akka.dispatch
 
UnboundedDequeBasedMailbox.MessageQueue() - Constructor for class akka.dispatch.UnboundedDequeBasedMailbox.MessageQueue
 
UnboundedDequeBasedMessageQueue - Interface in akka.dispatch
UnboundedDequeBasedMessageQueueSemantics adds unbounded semantics to a DequeBasedMessageQueue, i.e.
UnboundedDequeBasedMessageQueueSemantics - Interface in akka.dispatch
 
UnboundedMailbox - Class in akka.dispatch
UnboundedMailbox is the default unbounded MailboxType used by Akka Actors.
UnboundedMailbox() - Constructor for class akka.dispatch.UnboundedMailbox
 
UnboundedMailbox(ActorSystem.Settings, Config) - Constructor for class akka.dispatch.UnboundedMailbox
 
UnboundedMailbox$ - Class in akka.dispatch
 
UnboundedMailbox$() - Constructor for class akka.dispatch.UnboundedMailbox$
 
UnboundedMailbox.MessageQueue - Class in akka.dispatch
 
UnboundedMailbox.MessageQueue() - Constructor for class akka.dispatch.UnboundedMailbox.MessageQueue
 
UnboundedMessageQueueSemantics - Interface in akka.dispatch
UnboundedMessageQueueSemantics adds unbounded semantics to a QueueBasedMessageQueue, i.e.
UnboundedPriorityMailbox - Class in akka.dispatch
UnboundedPriorityMailbox is an unbounded mailbox that allows for prioritization of its contents.
UnboundedPriorityMailbox(Comparator<Envelope>, int) - Constructor for class akka.dispatch.UnboundedPriorityMailbox
 
UnboundedPriorityMailbox(Comparator<Envelope>) - Constructor for class akka.dispatch.UnboundedPriorityMailbox
 
UnboundedPriorityMailbox$ - Class in akka.dispatch
 
UnboundedPriorityMailbox$() - Constructor for class akka.dispatch.UnboundedPriorityMailbox$
 
UnboundedPriorityMailbox.MessageQueue - Class in akka.dispatch
 
UnboundedPriorityMailbox.MessageQueue(int, Comparator<Envelope>) - Constructor for class akka.dispatch.UnboundedPriorityMailbox.MessageQueue
 
UnboundedQueueBasedMessageQueue - Interface in akka.dispatch
 
UnboundedStash - Interface in akka.actor
The UnboundedStash trait is a version of Stash that enforces an unbounded stash for you actor.
undefinedUid() - Method in class akka.actor.ActorCell$
 
unhandled(Object) - Method in interface akka.actor.Actor
User overridable callback.
unhandled(Object) - Method in class akka.actor.UntypedActor
Recommended convention is to call this method if the message isn't handled in UntypedActor.onReceive(java.lang.Object) (e.g.
UnhandledMessage - Class in akka.actor
This message is published to the EventStream whenever an Actor receives a message it doesn't understand
UnhandledMessage(Object, ActorRef, ActorRef) - Constructor for class akka.actor.UnhandledMessage
 
UnhandledMessage$ - Class in akka.actor
 
UnhandledMessage$() - Constructor for class akka.actor.UnhandledMessage$
 
UnitMatch<I> - Class in akka.japi.pf
Version of PartialFunction that can be built during runtime from Java.
UnitPFBuilder<I> - Class in akka.japi.pf
A builder for PartialFunction.
UnitPFBuilder() - Constructor for class akka.japi.pf.UnitPFBuilder
Create a UnitPFBuilder.
unregister(akka.actor.ActorCell) - Method in class akka.dispatch.BalancingDispatcher
 
unregister(akka.actor.ActorCell) - Method in class akka.dispatch.MessageDispatcher
If you override it, you must call it.
unregister(akka.actor.ActorCell) - Method in class akka.dispatch.PinnedDispatcher
 
unregisterTempActor(ActorPath) - Method in interface akka.actor.ActorRefProvider
Unregister a temporary actor from the “/temp” path (i.e.
UnrestrictedStash - Interface in akka.actor
A version of Stash that does not enforce any mailbox type.
Unsafe - Class in akka.util
INTERNAL API
Unsafe() - Constructor for class akka.util.Unsafe
 
UNSCHEDULED() - Method in class akka.dispatch.MessageDispatcher$
 
UNSCHEDULED() - Static method in class akka.dispatch.MessageDispatcher
 
UnstartedPushTimeout() - Method in class akka.actor.ActorSystem.Settings
 
unsubscribe(ActorRef, ActorRef) - Method in interface akka.event.ActorClassification
 
unsubscribe(ActorRef) - Method in interface akka.event.ActorClassification
 
unsubscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.EventBus
Attempts to deregister the subscriber from the specified Classifier
unsubscribe(akka.event.EventBus.Subscriber) - Method in interface akka.event.EventBus
Attempts to deregister the subscriber from all Classifiers it may be subscribed to
unsubscribe(ActorRef, Class<?>) - Method in class akka.event.EventStream
 
unsubscribe(ActorRef) - Method in class akka.event.EventStream
 
unsubscribe(ActorRef, ActorRef) - Method in class akka.event.japi.ActorEventBus
 
unsubscribe(ActorRef) - Method in class akka.event.japi.ActorEventBus
 
unsubscribe(S, C) - Method in interface akka.event.japi.EventBus
Attempts to deregister the subscriber from the specified Classifier
unsubscribe(S) - Method in interface akka.event.japi.EventBus
Attempts to deregister the subscriber from all Classifiers it may be subscribed to
unsubscribe(S, C) - Method in class akka.event.japi.LookupEventBus
 
unsubscribe(S) - Method in class akka.event.japi.LookupEventBus
 
unsubscribe(S, C) - Method in class akka.event.japi.ScanningEventBus
 
unsubscribe(S) - Method in class akka.event.japi.ScanningEventBus
 
unsubscribe(S, C) - Method in class akka.event.japi.SubchannelEventBus
 
unsubscribe(S) - Method in class akka.event.japi.SubchannelEventBus
 
unsubscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.LookupClassification
 
unsubscribe(akka.event.EventBus.Subscriber) - Method in interface akka.event.LookupClassification
 
unsubscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.ScanningClassification
 
unsubscribe(akka.event.EventBus.Subscriber) - Method in interface akka.event.ScanningClassification
 
unsubscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.SubchannelClassification
 
unsubscribe(akka.event.EventBus.Subscriber) - Method in interface akka.event.SubchannelClassification
 
UntypedActor - Class in akka.actor
Actor base trait that should be extended by or mixed to create an Actor with the semantics of the 'Actor Model': http://en.wikipedia.org/wiki/Actor_model
UntypedActor() - Constructor for class akka.actor.UntypedActor
 
UntypedActorContext - Interface in akka.actor
UntypedActorContext is the UntypedActor equivalent of ActorContext, containing the Java API
UntypedActorFactory - Interface in akka.actor
Factory closure for an UntypedActor, to be used with 'Actors.actorOf(factory)'.
UntypedActorFactoryConsumerClass() - Method in class akka.actor.IndirectActorProducer$
 
UntypedActorFactoryConsumerClass() - Method in interface akka.actor.IndirectActorProducer
 
UntypedActorWithStash - Class in akka.actor
Actor base class that should be extended to create an actor with a stash.
UntypedActorWithStash() - Constructor for class akka.actor.UntypedActorWithStash
 
UntypedActorWithUnboundedStash - Class in akka.actor
Actor base class with Stash that enforces an unbounded deque for the actor.
UntypedActorWithUnboundedStash() - Constructor for class akka.actor.UntypedActorWithUnboundedStash
 
UntypedActorWithUnrestrictedStash - Class in akka.actor
Actor base class with Stash that does not enforce any mailbox type.
UntypedActorWithUnrestrictedStash() - Constructor for class akka.actor.UntypedActorWithUnrestrictedStash
 
unwatch(ActorRef) - Method in interface akka.actor.ActorContext
Unregisters this actor as Monitor for the provided ActorRef.
Unwatch$ - Class in akka.dispatch.sysmsg
 
Unwatch$() - Constructor for class akka.dispatch.sysmsg.Unwatch$
 
upperBound() - Method in class akka.routing.DefaultResizer
The most number of routees the router should ever have.
uptime() - Method in class akka.actor.ActorSystem
Up-time of this actor system in seconds.
usePoolDispatcher() - Method in class akka.routing.BroadcastPool
 
usePoolDispatcher() - Method in class akka.routing.ConsistentHashingPool
 
usePoolDispatcher() - Method in interface akka.routing.Pool
Use a dedicated dispatcher for the routees of the pool.
usePoolDispatcher() - Method in class akka.routing.RandomPool
 
usePoolDispatcher() - Method in class akka.routing.RoundRobinPool
 
usePoolDispatcher() - Method in class akka.routing.ScatterGatherFirstCompletedPool
 
usePoolDispatcher() - Method in class akka.routing.SmallestMailboxPool
 
useResumeWriting() - Method in class akka.io.Tcp.Register
 
using(D) - Method in class akka.actor.FSM.State
Modify state transition descriptor with new state data.
using(PartialFunction<FSM.State<S, D>, FSM.State<S, D>>) - Method in class akka.actor.FSM.TransformHelper
 
utf8String() - Method in class akka.util.ByteString
Decodes this ByteString as a UTF-8 encoded String.
Util - Class in akka.japi
This class hold common utilities for Java
Util() - Constructor for class akka.japi.Util
 
Util$ - Class in akka.japi
This class hold common utilities for Java
Util$() - Constructor for class akka.japi.Util$
 

V

v() - Method in class akka.japi.Option.Some
 
validate(ThreadFactory) - Method in class akka.dispatch.ForkJoinExecutorConfigurator
 
value - Variable in class akka.dispatch.AbstractNodeQueue.Node
 
value() - Method in class akka.util.Helpers.Requiring
 
valueComparator() - Method in class akka.util.Index
 
valueIterator(K) - Method in class akka.util.Index
Returns an Iterator of V containing the values for the supplied key, or an empty iterator if the key doesn't exist
values() - Method in class akka.util.Index
Returns the union of all value sets.
valuesIterator() - Method in class akka.util.Collections.PartialImmutableValuesIterable
 
verifyConfig(ActorPath) - Method in class akka.routing.FromConfig
 
verifyConfig(ActorPath) - Method in interface akka.routing.RouterConfig
Check that everything is there which is needed.
Version() - Method in class akka.actor.ActorSystem$
 
Version() - Static method in class akka.actor.ActorSystem
 
virtualNodesFactor() - Method in class akka.routing.ConsistentHash
 
virtualNodesFactor() - Method in class akka.routing.ConsistentHashingGroup
 
virtualNodesFactor() - Method in class akka.routing.ConsistentHashingPool
 
virtualNodesFactor() - Method in class akka.routing.ConsistentHashingRouter
 
virtualNodesFactor() - Method in class akka.routing.ConsistentHashingRoutingLogic
 
vnodes() - Method in class akka.routing.ConsistentHashingRoutingLogic
 

W

waitNanos(long) - Method in class akka.actor.LightArrayRevolverScheduler
Overridable for tests
wantsAck() - Method in class akka.io.Tcp.SimpleWriteCommand
An acknowledgment is only sent if this write command “wants an ack”, which is equivalent to the Tcp.SimpleWriteCommand.ack() token not being a of type Tcp.NoAck.
wantsAck() - Method in class akka.io.Udp.Send
 
wantsAck() - Method in class akka.io.UdpConnected.Send
 
warning(Logging.Warning) - Method in interface akka.event.Logging.StdOutLogger
 
warning(String) - Method in interface akka.event.LoggingAdapter
Log message at warning level.
warning(String, Object) - Method in interface akka.event.LoggingAdapter
Message template with 1 replacement argument.
warning(String, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 2 replacement arguments.
warning(String, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 3 replacement arguments.
warning(String, Object, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
Message template with 4 replacement arguments.
warningFormat() - Method in interface akka.event.Logging.StdOutLogger
 
WarningLevel() - Method in class akka.event.Logging$
 
WarningLevel() - Static method in class akka.event.Logging
 
watch(ActorRef) - Method in interface akka.actor.ActorContext
Registers this actor as a Monitor for the provided ActorRef.
watch(ActorRef) - Method in class akka.actor.dsl.Inbox.Inbox
Make the inbox’s actor watch the target actor such that reception of the Terminated message can then be awaited.
watch(ActorRef) - Method in class akka.actor.Inbox
Have the internal actor watch the target actor.
Watch$ - Class in akka.dispatch.sysmsg
 
Watch$() - Constructor for class akka.dispatch.sysmsg.Watch$
 
WheelSize() - Method in class akka.actor.LightArrayRevolverScheduler
 
when(S, PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
Insert a new StateFunction at the end of the processing chain for the given state.
when(S, FSMStateFunctionBuilder<S, D>) - Method in class akka.actor.AbstractFSM
Insert a new StateFunction at the end of the processing chain for the given state.
when(S, FiniteDuration, FSMStateFunctionBuilder<S, D>) - Method in class akka.actor.AbstractFSM
Insert a new StateFunction at the end of the processing chain for the given state.
when(S, FiniteDuration, PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Method in interface akka.actor.FSM
Insert a new StateFunction at the end of the processing chain for the given state.
whenFailing(Function2<Throwable, Option<Object>, BoxedUnit>) - Method in interface akka.actor.dsl.Creators.Act
Replace the preRestart action with the supplied function.
whenRestarted(Function1<Throwable, BoxedUnit>) - Method in interface akka.actor.dsl.Creators.Act
Replace the postRestart action with the supplied function.
whenStarting(Function0<BoxedUnit>) - Method in interface akka.actor.dsl.Creators.Act
Replace the preStart action with the supplied thunk.
whenStopping(Function0<BoxedUnit>) - Method in interface akka.actor.dsl.Creators.Act
Replace the postStop action with the supplied thunk.
whenUnhandled(FSMStateFunctionBuilder<S, D>) - Method in class akka.actor.AbstractFSM
Set handler which is called upon reception of unhandled messages.
whenUnhandled(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Method in interface akka.actor.FSM
Set handler which is called upon reception of unhandled messages.
whileOff(Function0<BoxedUnit>) - Method in class akka.util.Switch
Executes the provided action and returns if the action was executed or not, if the switch is off, waiting for any pending changes to happen before (locking) Be careful of longrunning or blocking within the provided action as it can lead to deadlocks or bad performance
whileOffYield(Function0<T>) - Method in class akka.util.Switch
Executes the provided action and returns its value if the switch is off, waiting for any pending changes to happen before (locking) Be careful of longrunning or blocking within the provided action as it can lead to deadlocks or bad performance
whileOn(Function0<BoxedUnit>) - Method in class akka.util.Switch
Executes the provided action and returns if the action was executed or not, if the switch is on, waiting for any pending changes to happen before (locking) Be careful of longrunning or blocking within the provided action as it can lead to deadlocks or bad performance
whileOnYield(Function0<T>) - Method in class akka.util.Switch
Executes the provided action and returns its value if the switch is on, waiting for any pending changes to happen before (locking) Be careful of longrunning or blocking within the provided action as it can lead to deadlocks or bad performance
WildcardTree$ - Class in akka.util
 
WildcardTree$() - Constructor for class akka.util.WildcardTree$
 
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
 
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.BroadcastRouter
Java API for setting routerDispatcher
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.ConsistentHashingRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.FromConfig
Setting the dispatcher to be used for the router head actor, which handles supervision, death watch and router management messages.
withDispatcher(String) - Method in class akka.routing.RandomGroup
Setting the dispatcher to be used for the router head actor, which handles router management messages
withDispatcher(String) - Method in class akka.routing.RandomPool
Setting the dispatcher to be used for the router head actor, which handles supervision, death watch and router management messages.
withDispatcher(String) - Method in class akka.routing.RandomRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.RoundRobinGroup
Setting the dispatcher to be used for the router head actor, which handles router management messages
withDispatcher(String) - Method in class akka.routing.RoundRobinPool
Setting the dispatcher to be used for the router head actor, which handles supervision, death watch and router management messages.
withDispatcher(String) - Method in class akka.routing.RoundRobinRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.ScatterGatherFirstCompletedGroup
Setting the dispatcher to be used for the router head actor, which handles router management messages
withDispatcher(String) - Method in class akka.routing.ScatterGatherFirstCompletedPool
Setting the dispatcher to be used for the router head actor, which handles supervision, death watch and router management messages.
withDispatcher(String) - Method in class akka.routing.ScatterGatherFirstCompletedRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.SmallestMailboxPool
Setting the dispatcher to be used for the router head actor, which handles supervision, death watch and router management messages.
withDispatcher(String) - Method in class akka.routing.SmallestMailboxRouter
Java API for setting routerDispatcher
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(RouterConfig) - Method in class akka.routing.BalancingPool
Uses the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one.
withFallback(RouterConfig) - Method in class akka.routing.BroadcastPool
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in class akka.routing.BroadcastRouter
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in class akka.routing.ConsistentHashingGroup
Uses the 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.ConsistentHashingRouter
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in class akka.routing.NoRouter$
 
withFallback(RouterConfig) - Static method in class akka.routing.NoRouter
 
withFallback(RouterConfig) - Method in class akka.routing.RandomPool
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in class akka.routing.RandomRouter
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in class akka.routing.RoundRobinPool
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in class akka.routing.RoundRobinRouter
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in interface akka.routing.RouterConfig
Overridable merge strategy, by default completely prefers this (i.e.
withFallback(RouterConfig) - Method in class akka.routing.ScatterGatherFirstCompletedPool
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in class akka.routing.ScatterGatherFirstCompletedRouter
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in class akka.routing.SmallestMailboxPool
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
withFallback(RouterConfig) - Method in class akka.routing.SmallestMailboxRouter
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e.
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.ConsistentHashingRouter
Java API for setting the mapping from message to the data to use for the consistent hash key.
withHashMapper(ConsistentHashingRouter.ConsistentHashMapper) - Method in class akka.routing.ConsistentHashingRoutingLogic
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.ScatterGatherFirstCompletedRouter
 
within() - Method in class akka.routing.ScatterGatherFirstCompletedRoutingLogic
 
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
 
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
 
withoutInterface(Class<? super T>) - Method in class akka.actor.TypedProps
Returns a new TypedProps without the specified interface, or if the interface class is not an interface, all the interfaces it implements.
withResizer(Resizer) - Method in class akka.routing.BroadcastPool
Setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.BroadcastRouter
Java API for setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.ConsistentHashingPool
Setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.ConsistentHashingRouter
Java API for setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.FromConfig
Setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.RandomPool
Setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.RandomRouter
Java API for setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.RoundRobinPool
Setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.RoundRobinRouter
Java API for setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.ScatterGatherFirstCompletedPool
Setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.ScatterGatherFirstCompletedRouter
Java API for setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.SmallestMailboxPool
Setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.SmallestMailboxRouter
Java API for setting the resizer to be used.
withRoutees(IndexedSeq<Routee>) - Method in class akka.routing.Router
Create a new instance with the specified routees and the same RoutingLogic.
withRouter(RouterConfig) - Method in class akka.actor.Props
Returns a new Props with the specified router config set.
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.BroadcastRouter
Java API for 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.ConsistentHashingRouter
Java API for 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 class akka.routing.RandomPool
Setting the supervisor strategy to be used for the “head” Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.RandomRouter
Java API for setting the supervisor strategy to be used for the “head” Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.RoundRobinPool
Setting the supervisor strategy to be used for the “head” Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.RoundRobinRouter
Java API for setting the supervisor strategy to be used for the “head” Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.ScatterGatherFirstCompletedPool
Setting the supervisor strategy to be used for the “head” Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.ScatterGatherFirstCompletedRouter
Java API for setting the supervisor strategy to be used for the “head” Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.SmallestMailboxPool
Setting the supervisor strategy to be used for the “head” Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.SmallestMailboxRouter
Java API for setting the supervisor strategy to be used for the “head” Router actor.
withSyncCircuitBreaker(Function0<T>) - Method in class akka.pattern.CircuitBreaker
Wraps invocations of synchronous calls that need to be protected
withTimeout(Timeout) - Method in class akka.actor.TypedProps
Java API: return a new TypedProps that will use the specified Timeout for its non-void-returning methods, if null is specified, it will use the default timeout as specified in the configuration.
withTimeout(Option<Timeout>) - Method in class akka.actor.TypedProps
Scala API: return a new TypedProps that will use the specified Timeout for its non-void-returning methods, if None is specified, it will use the default timeout as specified in the configuration.
withUid(int) - Method in interface akka.actor.ActorPath
INTERNAL API Creates a new ActorPath with same elements but with the specified uid.
withValue(ExtendedActorSystem, Callable<S>) - Method in class akka.serialization.JavaSerializer.CurrentSystem
Java API: invoke the callable with the current system being set to the given value for this thread.
withVirtualNodesFactor(int) - Method in class akka.routing.ConsistentHashingGroup
Setting the number of virtual nodes per node, used in ConsistentHash
withVirtualNodesFactor(int) - Method in class akka.routing.ConsistentHashingPool
Setting the number of virtual nodes per node, used in ConsistentHash
withVirtualNodesFactor(int) - Method in class akka.routing.ConsistentHashingRouter
Java API for setting the number of virtual nodes per node, used in ConsistentHash
withVirtualNodesFactor(int) - Method in class akka.routing.ConsistentHashingRoutingLogic
Setting the number of virtual nodes per node, used in ConsistentHash
WorkerDispatcher() - Method in class akka.io.SelectionHandlerSettings
 
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()).
writeFile(String, long, long, Tcp.Event) - Method in class akka.io.TcpMessage$
Write count bytes starting at position from file at filePath to the connection.
writeFile(String, long, long, Tcp.Event) - Static method in class akka.io.TcpMessage
Write count bytes starting at position from file at filePath to the connection.
writeObject(ObjectOutputStream) - Method in interface akka.actor.ActorContext
ActorContexts shouldn't be Serializable

Z

zero() - Method in class akka.util.Timeout$
A timeout with zero duration, will cause most requests to always timeout.
zero() - Static method in class akka.util.Timeout
A timeout with zero duration, will cause most requests to always timeout.

_

_log() - Method in interface akka.actor.ActorLogging
 
_logLevel() - Method in interface akka.event.LoggingBus
 
_mdc() - Method in interface akka.event.DiagnosticLoggingAdapter
 

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