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.
AbstractExtensionId<T extends Extension> - Class in akka.actor
Java API for ExtensionId
AbstractExtensionId() - Constructor for class akka.actor.AbstractExtensionId
 
AbstractNodeQueue<T> - Class in akka.dispatch
Lock-free MPSC linked queue implementation based on Dmitriy Vyukov's non-intrusive MPSC queue: http://www.1024cores.net/home/lock-free-algorithms/queues/non-intrusive-mpsc-node-based-queue
AbstractNodeQueue() - Constructor for class akka.dispatch.AbstractNodeQueue
 
AbstractNodeQueue.Node<T> - Class in akka.dispatch
 
AbstractPipelineContext - Class in akka.io
This base trait of each pipeline’s context provides optimized facilities for generating single commands or events (i.e. the fast common case of 1:1 message transformations).
AbstractPipelineContext() - Constructor for class akka.io.AbstractPipelineContext
 
AbstractPipePair<CmdAbove,CmdBelow,EvtAbove,EvtBelow> - Class in akka.io
Java API: A pair of pipes, one for commands and one for events.
AbstractPipePair() - Constructor for class akka.io.AbstractPipePair
 
AbstractScheduler - Class in akka.actor
An Akka scheduler service.
AbstractScheduler() - Constructor for class akka.actor.AbstractScheduler
 
AbstractSchedulerBase - Class in akka.actor
 
AbstractSchedulerBase() - Constructor for class akka.actor.AbstractSchedulerBase
 
AbstractSymmetricPipePair<Above,Below> - Class in akka.io
A convenience type for expressing a AbstractPipePair which has the same types for commands and events.
AbstractSymmetricPipePair() - Constructor for class akka.io.AbstractSymmetricPipePair
 
accept(Seq<IO.SocketOption>, ActorRef) - Method in class akka.actor.IO.ServerHandle
Sends a request to the IOManager to accept an incoming connection to the ServerSocketChannel associated with this IO.Handle.
ack() - Method in class akka.io.BackpressureBuffer.Ack
 
ack() - Method in class akka.io.Tcp.Write
 
ack() - Method in interface akka.io.Tcp.WriteCommand
The acknowledgment token associated with this write command.
ack() - Method in class akka.io.Tcp.WriteFile
 
ack() - Method in class akka.io.Udp.Send
 
ack() - Method in class akka.io.UdpConnected.Send
 
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 An actor has a well-defined (non-cyclic) life-cycle
actor(Function0<T>, ClassTag<T>, ActorRefFactory) - Method in interface akka.actor.dsl.Creators
Create an actor from the given thunk which must produce an Actor.
actor(String, Function0<T>, ClassTag<T>, ActorRefFactory) - Method in interface akka.actor.dsl.Creators
Create an actor from the given thunk which must produce an Actor.
actor(ActorRefFactory, String, Function0<T>, ClassTag<T>) - Method in interface akka.actor.dsl.Creators
Create an actor from the given thunk which must produce an Actor.
actor(ActorRefFactory, Function0<T>, ClassTag<T>) - Method in interface akka.actor.dsl.Creators
Create an actor with an automatically generated name from the given thunk which must produce an Actor.
actor() - Method in class akka.actor.IOManager
A reference to the IOManagerActor that performs the actual IO.
actor() - Method in exception akka.actor.PostRestartException
 
actor() - Method in exception akka.actor.PreRestartException
 
actor() - Method in class akka.actor.Terminated
 
Actor$ - Class in akka.actor
 
Actor$() - Constructor for class akka.actor.Actor$
 
Actor.emptyBehavior$ - Class in akka.actor
emptyBehavior is a Receive-expression that matches no messages at all, ever.
Actor.emptyBehavior$() - Constructor for class akka.actor.Actor.emptyBehavior$
 
actorClass() - Method in interface akka.actor.IndirectActorProducer
This method is used by Props to determine the type of actor which will be created.
actorClass() - Method in class akka.actor.Props
Obtain an upper-bound approximation of the actor class which is going to be created by these Props.
ActorClassification - Interface in akka.event
Maps ActorRefs to ActorRefs to form an EventBus where ActorRefs can listen to other ActorRefs
ActorClassifier - Interface in akka.event
Can be mixed into an EventBus to specify that the Classifier type is ActorRef
ActorContext - Interface in akka.actor
The actor context - the view of the actor cell from the actor.
ActorDSL - Class in akka.actor
This object contains elements which make writing actors and related code more concise, e.g. when trying out actors in the REPL.
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. when trying out actors in the REPL.
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 ".."
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 ".."
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 akka.actor.Kill message
ActorKilledException$ - Class in akka.actor
 
ActorKilledException$() - Constructor for class akka.actor.ActorKilledException$
 
ActorLogging - Interface in akka.actor
Mix in ActorLogging into your Actor to easily obtain a reference to a logger, which is available under the name "log".
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
 
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.
actors() - Static method in class akka.dispatch.MessageDispatcher
 
actorSel() - Method in class akka.pattern.AskableActorSelection
 
actorSelection(String) - Method in interface akka.actor.ActorRefFactory
Construct an ActorSelection from the given path, which is parsed for wildcards (these are replaced by regular expressions internally).
actorSelection(ActorPath) - Method in interface akka.actor.ActorRefFactory
Construct an ActorSelection from the given path, which is parsed for wildcards (these are replaced by regular expressions internally).
ActorSelection - Class in akka.actor
An ActorSelection is a logical view of a section of an ActorSystem's tree of Actors, allowing for broadcasting of messages to that section.
ActorSelection() - Constructor for class akka.actor.ActorSelection
 
ActorSelection$ - Class in akka.actor
An ActorSelection is a logical view of a section of an ActorSystem's tree of Actors, allowing for broadcasting of messages to that section.
ActorSelection$() - Constructor for class akka.actor.ActorSelection$
 
ActorSystem - Class in akka.actor
An actor system is a hierarchical group of actors which share common configuration, e.g. dispatchers, deployments, remote capabilities and addresses.
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
 
address() - Method in interface akka.actor.ActorPath
The Address under which this path can be reached; walks up the tree to the RootActorPath.
Address - Class in akka.actor
The address specifies the physical location under which an Actor can be reached.
Address(String, String) - Constructor for class akka.actor.Address
 
Address(String, String, String, int) - Constructor for class akka.actor.Address
 
address() - Method in class akka.actor.ChildActorPath
 
address() - Method in class akka.actor.IO.Connect
 
address() - Method in class akka.actor.IO.Connected
 
address() - Method in class akka.actor.IO.Listen
 
address() - Method in class akka.actor.IO.Listening
 
address() - Method in class akka.actor.RootActorPath
 
Address$ - 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
 
addToCache(Seq<Tuple2<Object, Set<Object>>>) - Method in interface akka.event.SubchannelClassification
 
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. on the slave socket for servers).
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.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.pattern - package akka.pattern
 
akka.routing - package akka.routing
 
akka.serialization - package akka.serialization
 
akka.util - package akka.util
 
akka.util.internal - package akka.util.internal
 
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
 
AllForOneStrategy(int, Duration, Function<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.AllForOneStrategy
 
AllForOneStrategy(int, Duration, Iterable<Class<? extends Throwable>>) - Constructor for class akka.actor.AllForOneStrategy
 
AllForOneStrategy() - Method in interface akka.actor.dsl.Creators.Act
 
AllForOneStrategy$ - Class in akka.actor
 
AllForOneStrategy$() - Constructor for class akka.actor.AllForOneStrategy$
 
AllLogLevels() - Method in class akka.event.Logging$
 
AllLogLevels() - Static method in class akka.event.Logging
 
allowCorePoolTimeout() - Method in class akka.dispatch.ThreadPoolConfig
 
amendConfig(Config) - Static method in class akka.dispatch.BalancingDispatcherConfigurator
 
anchor() - Method in class akka.actor.ActorSelection
 
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 name "default", and the specified Config, then obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
apply(String, Config, ClassLoader) - Method in class akka.actor.ActorSystem$
Creates a new ActorSystem with the name "default", the specified Config, and specified ClassLoader
apply() - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the name "default", obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
apply(String) - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the specified name, obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
apply(String, Config) - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the name "default", and the specified Config, then obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
apply(String, Config, ClassLoader) - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the name "default", the specified Config, and specified ClassLoader
apply(String, String) - Method in class akka.actor.Address$
Constructs a new Address with the specified protocol and system name
apply(String, String, String, int) - Method in class akka.actor.Address$
Constructs a new Address with the specified protocol, system name, host and port
apply(String, String) - Static method in class akka.actor.Address
Constructs a new Address with the specified protocol and system name
apply(String, String, String, int) - Static method in class akka.actor.Address
Constructs a new Address with the specified protocol, system name, host and port
apply(String) - Method in class akka.actor.AddressFromURIString$
Try to construct an Address from the given String or throw a java.net.MalformedURLException.
apply(String) - Static method in class akka.actor.AddressFromURIString
Try to construct an Address from the given String or throw a java.net.MalformedURLException.
apply(ActorSystem) - Method in interface akka.actor.ExtensionId
Returns an instance of the extension identified by this ExtensionId instance.
apply(Object) - Method in class akka.actor.FSM.NullFunction$
 
apply(A) - Method in class akka.actor.IO.Iteratee$
Wrap the provided value within a IO.Done IO.Iteratee.
apply() - Method in class akka.actor.IO.Iteratee$
Returns Iteratee.unit
apply(IO.Input) - Method in class akka.actor.IO.Iteratee
Processes the given IO.Input, returning the resulting Iteratee and the remaining Input.
apply(IO.Input) - Method in interface akka.actor.IO.IterateeRef
 
apply(Function0<IO.IterateeRef<V>>) - Method in class akka.actor.IO.IterateeRef.Map$
Uses a factory to create the initial IterateeRef for each new key.
apply(IO.Input) - Method in class akka.actor.IO.IterateeRefAsync
 
apply(IO.Input) - Method in class akka.actor.IO.IterateeRefSync
 
apply(ClassTag<T>) - Method in class akka.actor.Props$
Returns a Props that has default values except for "creator" which will be a function that creates an instance of the supplied type using the default constructor.
apply(Function0<Actor>) - Method in class akka.actor.Props$
Returns a Props that has default values except for "creator" which will be a function that creates an instance using the supplied thunk.
apply(Creator<? extends Actor>) - Method in class akka.actor.Props$
Returns a Props that has default values except for "creator" which will be a function that creates an instance using the supplied thunk.
apply(Function0<Actor>, String, RouterConfig, Deploy) - Method in class akka.actor.Props$
The deprecated legacy constructor.
apply(Class<?>, Seq<Object>) - Method in class akka.actor.Props$
Scala API: create a Props given a class and its constructor arguments.
apply(ClassTag<T>) - Static method in class akka.actor.Props
Returns a Props that has default values except for "creator" which will be a function that creates an instance of the supplied type using the default constructor.
apply(Function0<Actor>) - Static method in class akka.actor.Props
Returns a Props that has default values except for "creator" which will be a function that creates an instance using the supplied thunk.
apply(Creator<? extends Actor>) - Static method in class akka.actor.Props
Returns a Props that has default values except for "creator" which will be a function that creates an instance using the supplied thunk.
apply(Function0<Actor>, String, RouterConfig, Deploy) - Static method in class akka.actor.Props
The deprecated legacy constructor.
apply(Class<?>, Seq<Object>) - Static method in class akka.actor.Props
Scala API: create a Props given a class and its constructor arguments.
apply(ActorContext) - Method in class akka.actor.TypedActor$
Returns a contextual TypedActorFactory of this extension, this means that any TypedActors created by this TypedActorExtension will be children to the specified context, this allows for creating hierarchies of TypedActors.
apply(ActorContext) - Static method in class akka.actor.TypedActor
Returns a contextual TypedActorFactory of this extension, this means that any TypedActors created by this TypedActorExtension will be children to the specified context, this allows for creating hierarchies of TypedActors.
apply(Object) - Method in class akka.actor.TypedActor.MethodCall
Invokes the Method on the supplied instance
apply(Class<T>) - Method in class akka.actor.TypedProps$
Uses the supplied class as the factory for the TypedActor implementation, proxying all the interfaces it implements.
apply(Class<? super T>, Class<T>) - Method in class akka.actor.TypedProps$
Uses the supplied class as the factory for the TypedActor implementation, and that has the specified interface, or if the interface class is not an interface, all the interfaces it implements, appended in the sequence of interfaces.
apply(Class<? super T>, Function0<T>) - Method in class akka.actor.TypedProps$
Uses the supplied thunk as the factory for the TypedActor implementation, and that has the specified interface, or if the interface class is not an interface, all the interfaces it implements, appended in the sequence of interfaces.
apply(ClassTag<T>) - Method in class akka.actor.TypedProps$
Uses the supplied class as the factory for the TypedActor implementation, proxying all the interfaces it implements.
apply(Class<T>) - Static method in class akka.actor.TypedProps
Uses the supplied class as the factory for the TypedActor implementation, proxying all the interfaces it implements.
apply(Class<? super T>, Class<T>) - Static method in class akka.actor.TypedProps
Uses the supplied class as the factory for the TypedActor implementation, and that has the specified interface, or if the interface class is not an interface, all the interfaces it implements, appended in the sequence of interfaces.
apply(Class<? super T>, Function0<T>) - Static method in class akka.actor.TypedProps
Uses the supplied thunk as the factory for the TypedActor implementation, and that has the specified interface, or if the interface class is not an interface, all the interfaces it implements, appended in the sequence of interfaces.
apply(ClassTag<T>) - Static method in class akka.actor.TypedProps
Uses the supplied class as the factory for the TypedActor implementation, proxying all the interfaces it implements.
apply(Object, ActorRef, ActorSystem) - Method in class akka.dispatch.Envelope$
 
apply(Object, ActorRef, ActorSystem) - Static method in class akka.dispatch.Envelope
 
apply(T) - Method in class akka.dispatch.japi.BooleanFunctionBridge
 
apply(T) - Method in class akka.dispatch.japi.CallbackBridge
 
apply(Throwable) - Method in class akka.dispatch.japi.RecoverBridge
 
apply(T) - Method in class akka.dispatch.japi.UnitFunctionBridge
 
apply(T) - Method in class akka.dispatch.Mapper
Override this method to perform the map operation, by default delegates to "checkedApply" which by default throws an UnsupportedOperationException.
apply(Function1<Object, Object>) - Method in class akka.dispatch.PriorityGenerator$
Creates a PriorityGenerator that uses the supplied function as priority generator
apply(Function1<Object, Object>) - Static method in class akka.dispatch.PriorityGenerator
Creates a PriorityGenerator that uses the supplied function as priority generator
apply(ActorSystem, T, LogSource<T>) - Method in class akka.event.Logging$
Obtain LoggingAdapter for the given actor system and source object.
apply(LoggingBus, T, LogSource<T>) - Method in class akka.event.Logging$
Obtain LoggingAdapter for the given logging bus and source object.
apply(ActorSystem, T, LogSource<T>) - Static method in class akka.event.Logging
Obtain LoggingAdapter for the given actor system and source object.
apply(LoggingBus, T, LogSource<T>) - Static method in class akka.event.Logging
Obtain LoggingAdapter for the given logging bus and source object.
apply(String, Class<?>, Object) - Method in class akka.event.Logging.Error$
 
apply(PartialFunction<Object, BoxedUnit>, ActorContext) - Method in class akka.event.LoggingReceive$
Wrap a Receive partial function in a logging enclosure, which sends a debug message to the event bus each time before a message is matched.
apply(Object) - Method in class akka.event.LoggingReceive
 
apply(T, LogSource<T>) - Method in class akka.event.LogSource$
Convenience converter access: given an implicit LogSource, generate the string representation and originating class.
apply(T, ActorSystem, LogSource<T>) - Method in class akka.event.LogSource$
Convenience converter access: given an implicit LogSource and ActorSystem, generate the string representation and originating class.
apply(T, LogSource<T>) - Method in interface akka.event.LogSource
Convenience converter access: given an implicit LogSource, generate the string representation and originating class.
apply(T, ActorSystem, LogSource<T>) - Method in interface akka.event.LogSource
Convenience converter access: given an implicit LogSource and ActorSystem, generate the string representation and originating class.
apply(HasLogging) - Method in class akka.io.BackpressureBuffer
 
apply(PipelineContext) - Method in class akka.io.DelimiterFraming
 
apply(ExtensionKey<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(ExtensionKey<T>, ActorSystem) - Static method in class akka.io.IO
Scala API: obtain a reference to the manager actor for the given IO extension, for example Tcp or Udp.
apply(PipelineContext) - Method in class akka.io.LengthFieldFrame
 
apply(Context) - Method in class akka.io.PipelineStage
Implement this method to generate this stage’s pair of command and event functions.
apply(Function1<CmdAbove, Iterable<Either<EvtAbove, CmdBelow>>>, Function1<EvtBelow, Iterable<Either<EvtAbove, CmdBelow>>>, PartialFunction<Object, Iterable<Either<EvtAbove, CmdBelow>>>) - Method in class akka.io.PipePairFactory$
Scala API: construct a PipePair from the two given functions; useful for not capturing $outer references.
apply(Function1<CmdAbove, Iterable<Either<EvtAbove, CmdBelow>>>, Function1<EvtBelow, Iterable<Either<EvtAbove, CmdBelow>>>, PartialFunction<Object, Iterable<Either<EvtAbove, CmdBelow>>>) - Static method in class akka.io.PipePairFactory
Scala API: construct a PipePair from the two given functions; useful for not capturing $outer references.
apply(HasLogging) - Method in class akka.io.SslTlsSupport
 
apply(PipelineContext) - Method in class akka.io.StringByteStringAdapter
 
apply(ByteString) - Method in class akka.io.Tcp.Write$
Create a new unacknowledged Write command with the given data.
apply(PipelineContext) - Method in class akka.io.TcpReadWriteAdapter
 
apply(HasActorContext) - Method in class akka.io.TickGenerator
 
apply(ByteString, InetSocketAddress) - Method in class akka.io.Udp.Send$
 
apply(ByteString) - Method in class akka.io.UdpConnected.Send$
 
apply() - Method in interface akka.japi.Effect
 
apply(T) - Method in interface akka.japi.Function
 
apply(T1, T2) - Method in interface akka.japi.Function2
 
apply(A, boolean) - Method in class akka.japi.JavaPartialFunction
 
apply(A) - Method in class akka.japi.JavaPartialFunction
 
apply(T) - Method in interface akka.japi.Procedure
 
apply(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(Iterable<ActorRef>) - Method in class akka.routing.BroadcastRouter$
Creates a new BroadcastRouter, routing to the specified routees
apply(Iterable<ActorRef>) - Static method in class akka.routing.BroadcastRouter
Creates a new BroadcastRouter, routing to the specified routees
apply(Iterable<T>, int, ClassTag<T>) - Method in class akka.routing.ConsistentHash$
 
apply(Iterable<T>, int, ClassTag<T>) - Static method in class akka.routing.ConsistentHash
 
apply(Iterable<ActorRef>) - Method in class akka.routing.ConsistentHashingRouter$
Creates a new ConsistentHashingRouter, routing to the specified routees
apply(Iterable<ActorRef>) - Static method in class akka.routing.ConsistentHashingRouter
Creates a new ConsistentHashingRouter, routing to the specified routees
apply(Object) - Method in class akka.routing.ConsistentHashingRouter.emptyConsistentHashMapping$
 
apply(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(String) - Method in class akka.routing.FromConfig$
 
apply(String) - Static method in class akka.routing.FromConfig
 
apply(Iterable<ActorRef>) - Method in class akka.routing.RandomRouter$
Creates a new RandomRouter, routing to the specified routees
apply(Iterable<ActorRef>) - Static method in class akka.routing.RandomRouter
Creates a new RandomRouter, routing to the specified routees
apply(Iterable<ActorRef>) - Method in class akka.routing.RoundRobinRouter$
Creates a new RoundRobinRouter, routing to the specified routees
apply(Iterable<ActorRef>) - Static method in class akka.routing.RoundRobinRouter
Creates a new RoundRobinRouter, routing to the specified routees
apply(Iterable<ActorRef>, FiniteDuration) - Method in class akka.routing.ScatterGatherFirstCompletedRouter$
Creates a new ScatterGatherFirstCompletedRouter, routing to the specified routees, timing out after the specified Duration
apply(Iterable<ActorRef>, FiniteDuration) - Static method in class akka.routing.ScatterGatherFirstCompletedRouter
Creates a new ScatterGatherFirstCompletedRouter, routing to the specified routees, timing out after the specified Duration
apply(Iterable<ActorRef>) - Method in class akka.routing.SmallestMailboxRouter$
Creates a new SmallestMailboxRouter, routing to the specified routees
apply(Iterable<ActorRef>) - Static method in class akka.routing.SmallestMailboxRouter
Creates a new SmallestMailboxRouter, routing to the specified routees
apply(Class<?>) - Method in class akka.util.BoxedType$
 
apply(Class<?>) - Static method in class akka.util.BoxedType
 
apply(byte[]) - Method in class akka.util.ByteIterator.ByteArrayIterator$
 
apply(byte[], int, int) - Method in class akka.util.ByteIterator.ByteArrayIterator$
 
apply(LinearSeq<ByteIterator.ByteArrayIterator>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator$
 
apply(byte[]) - Method in class akka.util.ByteString$
Creates a new ByteString by copying a byte array.
apply(Seq<Object>) - Method in class akka.util.ByteString$
Creates a new ByteString by copying bytes.
apply(Seq<T>, Integral<T>) - Method in class akka.util.ByteString$
Creates a new ByteString by converting from integral numbers to bytes.
apply(ByteBuffer) - Method in class akka.util.ByteString$
Creates a new ByteString by copying bytes from a ByteBuffer.
apply(String) - Method in class akka.util.ByteString$
Creates a new ByteString by encoding a String as UTF-8.
apply(String, String) - Method in class akka.util.ByteString$
Creates a new ByteString by encoding a String with a charset.
apply(int) - Method in class akka.util.ByteString
 
apply(int) - Method in class akka.util.ByteString.ByteString1
 
apply(int) - Method in class akka.util.ByteString.ByteString1C
 
apply(int) - Method in class akka.util.ByteString.ByteStrings
 
apply(byte[]) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by copying a byte array.
apply(Seq<Object>) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by copying bytes.
apply(Seq<T>, Integral<T>) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by converting from integral numbers to bytes.
apply(ByteBuffer) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by copying bytes from a ByteBuffer.
apply(String) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by encoding a String as UTF-8.
apply(String, String) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by encoding a String with a charset.
apply(byte[]) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by copying a byte array.
apply(Seq<Object>) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by copying bytes.
apply(Seq<T>, Integral<T>) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by converting from integral numbers to bytes.
apply(ByteBuffer) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by copying bytes from a ByteBuffer.
apply(String) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by encoding a String as UTF-8.
apply(String, String) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by encoding a String with a charset.
apply(long) - Method in class akka.util.Timeout$
 
apply(long, TimeUnit) - Method in class akka.util.Timeout$
 
apply(long) - Static method in class akka.util.Timeout
 
apply(long, TimeUnit) - Static method in class akka.util.Timeout
 
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
 
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 ?
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 ?
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(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.
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/?
AskTimeoutException(String, Throwable) - Constructor for exception akka.pattern.AskTimeoutException
 
AskTimeoutException(String) - Constructor for exception akka.pattern.AskTimeoutException
 
asOutputStream() - Method in class akka.util.ByteStringBuilder
Directly wraps this ByteStringBuilder in an OutputStream.
asReadable() - Method in interface akka.actor.IO.Handle
 
asReadable() - Method in interface akka.actor.IO.ReadHandle
 
asScala() - Method in class akka.japi.Option
 
asScala() - Method in class akka.japi.Option.Some
 
asServer() - Method in interface akka.actor.IO.Handle
 
asServer() - Method in class akka.actor.IO.ServerHandle
 
associate(ActorRef, ActorRef) - Method in interface akka.event.ActorClassification
 
asSocket() - Method in interface akka.actor.IO.Handle
 
asSocket() - Method in class akka.actor.IO.SocketHandle
 
asWritable() - Method in interface akka.actor.IO.Handle
 
asWritable() - Method in interface akka.actor.IO.WriteHandle
 
async(IO.Iteratee<A>, ExecutionContext) - Method in class akka.actor.IO.IterateeRef$
Creates an IO.IterateeRefAsync containing an initial IO.Iteratee.
async(ExecutionContext) - Method in class akka.actor.IO.IterateeRef$
Creates an empty IO.IterateeRefAsync.
async(ExecutionContext) - Method in class akka.actor.IO.IterateeRef.Map$
Creates an empty IO.IterateeRefAsync for each new key.
atFullThrottle() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinPool
 
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.
BackpressureBuffer - Class in akka.io
This pipeline stage implements a configurable buffer for transforming the per-write ACK/NACK-based backpressure model of a TCP connection actor into an edge-triggered back-pressure model: the upper stages will receive notification when the buffer runs full (BackpressureBuffer.HighWatermarkReached) and when it subsequently empties (BackpressureBuffer.LowWatermarkReached).
BackpressureBuffer(long, long, long) - Constructor for class akka.io.BackpressureBuffer
 
BackpressureBuffer$ - Class in akka.io
 
BackpressureBuffer$() - Constructor for class akka.io.BackpressureBuffer$
 
BackpressureBuffer.Ack - Class in akka.io
 
BackpressureBuffer.Ack(int, Tcp.Event) - Constructor for class akka.io.BackpressureBuffer.Ack
 
BackpressureBuffer.Ack$ - Class in akka.io
 
BackpressureBuffer.Ack$() - Constructor for class akka.io.BackpressureBuffer.Ack$
 
BackpressureBuffer.HighWatermarkReached - Interface in akka.io
Message type which is sent when the buffer’s high watermark has been reached, which means that further write requests should not be sent until the low watermark has been reached again.
BackpressureBuffer.HighWatermarkReached$ - Class in akka.io
 
BackpressureBuffer.HighWatermarkReached$() - Constructor for class akka.io.BackpressureBuffer.HighWatermarkReached$
 
BackpressureBuffer.LowWatermarkReached - Interface in akka.io
Message type which is sent when the buffer’s fill level falls below the low watermark, which means that writing can commence again.
BackpressureBuffer.LowWatermarkReached$ - Class in akka.io
 
BackpressureBuffer.LowWatermarkReached$() - Constructor for class akka.io.BackpressureBuffer.LowWatermarkReached$
 
BalancingDispatcher - Class in akka.dispatch
An executor based event driven dispatcher which will try to redistribute work from busy actors to idle actors.
BalancingDispatcher(MessageDispatcherConfigurator, String, int, Duration, MailboxType, ExecutorServiceFactoryProvider, FiniteDuration, boolean) - Constructor for class akka.dispatch.BalancingDispatcher
 
BalancingDispatcherConfigurator - Class in akka.dispatch
Configurator for creating BalancingDispatcher.
BalancingDispatcherConfigurator(Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.BalancingDispatcherConfigurator
 
bandwidth() - Method in class akka.actor.IO.PerformancePreferences
 
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
 
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>) - Method in class akka.io.TcpMessage$
The Bind message is send to the TCP manager actor, which is obtained via TcpExt.getManager() in order to bind to a listening socket.
bind(ActorRef, InetSocketAddress, int) - Method in class akka.io.TcpMessage$
Open a listening socket without specifying options.
bind(ActorRef, InetSocketAddress, int, Iterable<Inet.SocketOption>) - Static method in class akka.io.TcpMessage
The Bind message is send to the TCP manager actor, which is obtained via TcpExt.getManager() in order to bind to a listening socket.
bind(ActorRef, InetSocketAddress, int) - Static method in class akka.io.TcpMessage
Open a listening socket without specifying options.
bind(ActorRef, InetSocketAddress, Iterable<Inet.SocketOption>) - Method in class akka.io.UdpMessage$
Send this message to the UdpExt.manager() in order to bind to the given local port (or an automatically assigned one if the port number is zero).
bind(ActorRef, InetSocketAddress) - Method in class akka.io.UdpMessage$
Bind without specifying options.
bind(ActorRef, InetSocketAddress, Iterable<Inet.SocketOption>) - Static method in class akka.io.UdpMessage
Send this message to the UdpExt.manager() in order to bind to the given local port (or an automatically assigned one if the port number is zero).
bind(ActorRef, InetSocketAddress) - Static method in class akka.io.UdpMessage
Bind without specifying options.
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. blocking enqueue with timeout.
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. blocking enqueue with timeout.
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 For more information see DatagramSocket.setBroadcast(boolean)
broadcast(boolean) - Static method in class akka.io.UdpSO
Inet.SocketOption to set the SO_BROADCAST option For more information see DatagramSocket.setBroadcast(boolean)
Broadcast - Class in akka.routing
Used to broadcast a message to all connections in a router; only the contained message will be forwarded, i.e. the Broadcast(...)
Broadcast(Object) - Constructor for class akka.routing.Broadcast
 
Broadcast$ - Class in akka.routing
 
Broadcast$() - Constructor for class akka.routing.Broadcast$
 
BroadcastLike - Interface in akka.routing
The core pieces of the routing logic is located in this trait to be able to extend.
BroadcastRouter - Class in akka.routing
A Router that uses broadcasts a message to all its connections.
BroadcastRouter(int, Iterable<String>, Option<Resizer>, String, SupervisorStrategy) - Constructor for class akka.routing.BroadcastRouter
 
BroadcastRouter(int) - Constructor for class akka.routing.BroadcastRouter
Java API: Constructor that sets nrOfInstances to be created.
BroadcastRouter(Iterable<String>) - Constructor for class akka.routing.BroadcastRouter
Java API: Constructor that sets the routees to be used.
BroadcastRouter(Resizer) - Constructor for class akka.routing.BroadcastRouter
Java API: Constructor that sets the resizer to be used.
BroadcastRouter$ - Class in akka.routing
 
BroadcastRouter$() - Constructor for class akka.routing.BroadcastRouter$
 
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
buildFunctionTriple(Ctx, PipelineStage<Ctx, CmdAbove, CmdBelow, EvtAbove, EvtBelow>) - Method in class akka.io.PipelineFactory$
Scala API: build the pipeline and return a pair of functions representing the command and event pipelines.
buildFunctionTriple(Ctx, PipelineStage<Ctx, CmdAbove, CmdBelow, EvtAbove, EvtBelow>) - Static method in class akka.io.PipelineFactory
Scala API: build the pipeline and return a pair of functions representing the command and event pipelines.
buildWithSink(Ctx, PipelineStage<Ctx, CmdAbove, CmdBelow, EvtAbove, EvtBelow>, PipelineSink<CmdBelow, EvtAbove>) - Method in class akka.io.PipelineFactory$
Java API: build the pipeline attaching the given callback object to its outputs.
buildWithSink(Ctx, PipelineStage<Ctx, CmdAbove, CmdBelow, EvtAbove, EvtBelow>, PipelineSink<CmdBelow, EvtAbove>) - Static method in class akka.io.PipelineFactory
Java API: build the pipeline attaching the given callback object to its outputs.
buildWithSinkFunctions(Ctx, PipelineStage<Ctx, CmdAbove, CmdBelow, EvtAbove, EvtBelow>, Function1<Try<CmdBelow>, BoxedUnit>, Function1<Try<EvtAbove>, BoxedUnit>) - Method in class akka.io.PipelineFactory$
Scala API: build the pipeline attaching the given command and event sinks to its outputs.
buildWithSinkFunctions(Ctx, PipelineStage<Ctx, CmdAbove, CmdBelow, EvtAbove, EvtBelow>, Function1<Try<CmdBelow>, BoxedUnit>, Function1<Try<EvtAbove>, BoxedUnit>) - Static method in class akka.io.PipelineFactory
Scala API: build the pipeline attaching the given command and event sinks to its outputs.
bus() - Method in class akka.event.BusLogging
 
bus() - Method in class akka.event.Logging.InitializeLogger
 
BusLogging - Class in akka.event
 
BusLogging(LoggingBus, String, Class<?>) - Constructor for class akka.event.BusLogging
 
ByteArraySerializer - Class in akka.serialization
This is a special Serializer that Serializes and deserializes byte arrays only, (just returns the byte array unchanged/uncopied)
ByteArraySerializer() - Constructor for class akka.serialization.ByteArraySerializer
 
ByteIterator - Class in akka.util
An iterator over a ByteString.
ByteIterator() - Constructor for class akka.util.ByteIterator
 
ByteIterator$ - Class in akka.util
 
ByteIterator$() - Constructor for class akka.util.ByteIterator$
 
ByteIterator.ByteArrayIterator - Class in akka.util
 
ByteIterator.ByteArrayIterator$ - Class in akka.util
 
ByteIterator.ByteArrayIterator$() - Constructor for class akka.util.ByteIterator.ByteArrayIterator$
 
ByteIterator.MultiByteArrayIterator - Class in akka.util
 
ByteIterator.MultiByteArrayIterator$ - Class in akka.util
 
ByteIterator.MultiByteArrayIterator$() - Constructor for class akka.util.ByteIterator.MultiByteArrayIterator$
 
bytes() - Method in class akka.actor.IO.Chunk
 
bytes() - Method in class akka.actor.IO.Read
 
bytes() - Method in class akka.actor.IO.Write
 
ByteString - Class in akka.util
A rope-like immutable data structure containing bytes.
ByteString() - Constructor for class akka.util.ByteString
 
ByteString$ - Class in akka.util
 
ByteString$() - Constructor for class akka.util.ByteString$
 
ByteString.ByteString1 - Class in akka.util
An unfragmented ByteString.
ByteString.ByteString1C - Class in akka.util
A compact (unsliced) and unfragmented ByteString, implementation of ByteString1C.
ByteString.ByteStrings - Class in akka.util
A ByteString with 2 or more fragments.
ByteStringBuilder - Class in akka.util
A mutable builder for efficiently creating a ByteString.
ByteStringBuilder() - Constructor for class akka.util.ByteStringBuilder
 
bytestrings() - Method in class akka.util.ByteString.ByteStrings
 

C

cache() - Method in interface akka.event.SubchannelClassification
 
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
 
cancel() - Method in interface akka.util.internal.Timeout
Deprecated. Cancels the TimerTask associated with this handle.
Cancellable - Interface in akka.actor
Signifies something that can be cancelled There is no strict guarantee that the implementation is thread-safe, but it should be good practice to make it so.
cancelTimer(String) - Method in interface akka.actor.FSM
Cancel named timer, ensuring that the message is not subsequently delivered (no race).
capacity() - Method in interface akka.actor.UnrestrictedStash
 
capacity() - Method in class akka.dispatch.BoundedDequeBasedMailbox
 
capacity() - Method in class akka.dispatch.BoundedMailbox
 
capacity() - Method in class akka.dispatch.BoundedPriorityMailbox
 
capacity(IndexedSeq<ActorRef>) - Method in class akka.routing.DefaultResizer
Returns the overall desired change in resizer capacity.
cause() - Method in class akka.actor.FSM.Failure
 
cause() - Method in class akka.actor.IO.Closed
 
cause() - Method in class akka.actor.IO.Error
 
cause() - Method in class akka.actor.IO.Failure
 
cause() - Method in exception akka.actor.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
 
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
 
children() - Method in interface akka.actor.ActorContext
Returns all supervised children; this method returns a view (i.e. a lazy collection) onto the internal collection of children.
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. calls to remote systems Transitions through three states: - In *Closed* state, calls pass through until the maxFailures count is reached.
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(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. when constructing a ClassLoaderBinaryInputStream).
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$
 
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.DefaultScheduler
 
close() - Method in interface akka.actor.IO.Handle
Sends a request to the IOManager to close the Channel associated with this IO.Handle.
close() - Method in class akka.actor.LightArrayRevolverScheduler
 
close() - Method in class akka.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.
cmd() - Method in interface akka.io.PipelineContext
INTERNAL API: do not touch!
cmd() - Method in class akka.io.Tcp.CommandFailed
 
cmd() - Method in class akka.io.TcpPipelineHandler.Init.Command
 
cmd() - Method in class akka.io.TcpPipelineHandler.Management
 
cmd() - Method in class akka.io.Udp.CommandFailed
 
cmd() - Method in class akka.io.UdpConnected.CommandFailed
 
cmdHolder() - Method in interface akka.io.PipelineContext
INTERNAL API: do not touch!
cmp() - Method in class akka.dispatch.BoundedPriorityMailbox
 
cmp() - Method in class akka.dispatch.UnboundedPriorityMailbox
 
combine(PipelineStage<Ctx, CmdAbove, CmdBelow, EvtAbove, EvtBelow>, PipelineStage<Ctx, CmdAbove, CmdBelow, EvtAbove, EvtBelow>) - Method in class akka.io.PipelineStage$
Java API: combine the two stages such that the command pipeline of the left stage is used and the event pipeline of the right, discarding the other two sub-pipelines.
combine(PipelineStage<Ctx, CmdAbove, CmdBelow, EvtAbove, EvtBelow>, PipelineStage<Ctx, CmdAbove, CmdBelow, EvtAbove, EvtBelow>) - Static method in class akka.io.PipelineStage
Java API: combine the two stages such that the command pipeline of the left stage is used and the event pipeline of the right, discarding the other two sub-pipelines.
command(Cmd) - Method in class akka.io.TcpPipelineHandler.Init
Java API: construct a command to be sent to the TcpPipelineHandler actor.
commandPipeline() - Method in interface akka.io.PipePair
The command pipeline transforms injected commands from the upper stage into commands for the stage below, but it can also emit events for the upper stage.
commands() - Method in class akka.io.PipelinePorts
 
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
 
compareClassifiers(akka.event.EventBus.Classifier, akka.event.EventBus.Classifier) - Method in interface akka.event.ScanningClassification
Provides a total ordering of Classifiers (think java.util.Comparator.compare)
compareIdentityHash(Object, Object) - Method in class akka.util.Helpers$
 
compareIdentityHash(Object, Object) - Static method in class akka.util.Helpers
 
compareSubscribers(ActorRef, ActorRef) - Method in interface akka.event.ActorEventBus
 
compareSubscribers(akka.event.EventBus.Subscriber, akka.event.EventBus.Subscriber) - Method in interface akka.event.LookupClassification
Provides a total ordering of Subscribers (think java.util.Comparator.compare)
compareSubscribers(akka.event.EventBus.Subscriber, akka.event.EventBus.Subscriber) - Method in interface akka.event.ScanningClassification
Provides a total ordering of Subscribers (think java.util.Comparator.compare)
compareTo(ActorRef) - Method in class akka.actor.ActorRef
Comparison takes path and the unique id of the actor cell into account.
compareTo(ActorPath) - Method in class akka.actor.ChildActorPath
 
compareTo(ActorPath) - Method in class akka.actor.RootActorPath
 
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(SocketAddress, Seq<IO.SocketOption>, ActorRef) - Method in class akka.actor.IOManager
Create a SocketChannel connecting to an address.
connect(String, int, ActorRef) - Method in class akka.actor.IOManager
Create a SocketChannel connecting to a host and port.
connect(InetSocketAddress, InetSocketAddress, Iterable<Inet.SocketOption>, FiniteDuration) - Method in class akka.io.TcpMessage$
The Connect message is sent to the TCP manager actor, which is obtained via TcpExt.getManager().
connect(InetSocketAddress, InetSocketAddress, Iterable<Inet.SocketOption>) - Method in class akka.io.TcpMessage$
Connect to the given remoteAddress with an optional localAddress to bind to given the specified Socket Options
connect(InetSocketAddress, Iterable<Inet.SocketOption>) - Method in class akka.io.TcpMessage$
Connect to the given remoteAddress without binding to a local address.
connect(InetSocketAddress) - Method in class akka.io.TcpMessage$
Connect to the given remoteAddress without binding to a local address and without specifying options.
connect(InetSocketAddress, FiniteDuration) - Method in class akka.io.TcpMessage$
Connect to the given remoteAddress with a connection timeout without binding to a local address and without specifying options.
connect(InetSocketAddress, InetSocketAddress, Iterable<Inet.SocketOption>, FiniteDuration) - Static method in class akka.io.TcpMessage
The Connect message is sent to the TCP manager actor, which is obtained via TcpExt.getManager().
connect(InetSocketAddress, InetSocketAddress, Iterable<Inet.SocketOption>) - Static method in class akka.io.TcpMessage
Connect to the given remoteAddress with an optional localAddress to bind to given the specified Socket Options
connect(InetSocketAddress, Iterable<Inet.SocketOption>) - Static method in class akka.io.TcpMessage
Connect to the given remoteAddress without binding to a local address.
connect(InetSocketAddress) - Static method in class akka.io.TcpMessage
Connect to the given remoteAddress without binding to a local address and without specifying options.
connect(InetSocketAddress, FiniteDuration) - Static method in class akka.io.TcpMessage
Connect to the given remoteAddress with a connection timeout without binding to a local address and without specifying options.
connect(ActorRef, InetSocketAddress, InetSocketAddress, Iterable<Inet.SocketOption>) - Method in class akka.io.UdpConnectedMessage$
Send this message to the UdpExt.manager() in order to bind to a local port (optionally with the chosen localAddress) and create a UDP socket which is restricted to sending to and receiving from the given remoteAddress.
connect(ActorRef, InetSocketAddress, Iterable<Inet.SocketOption>) - Method in class akka.io.UdpConnectedMessage$
Connect without specifying the localAddress.
connect(ActorRef, InetSocketAddress) - Method in class akka.io.UdpConnectedMessage$
Connect without specifying the localAddress or options.
connect(ActorRef, InetSocketAddress, InetSocketAddress, Iterable<Inet.SocketOption>) - Static method in class akka.io.UdpConnectedMessage
Send this message to the UdpExt.manager() in order to bind to a local port (optionally with the chosen localAddress) and create a UDP socket which is restricted to sending to and receiving from the given remoteAddress.
connect(ActorRef, InetSocketAddress, Iterable<Inet.SocketOption>) - Static method in class akka.io.UdpConnectedMessage
Connect without specifying the localAddress.
connect(ActorRef, InetSocketAddress) - Static method in class akka.io.UdpConnectedMessage
Connect without specifying the localAddress or options.
connectionTime() - Method in class akka.actor.IO.PerformancePreferences
 
ConsistentHash<T> - Class in akka.routing
Consistent Hashing node ring implementation.
ConsistentHash$ - Class in akka.routing
 
ConsistentHash$() - Constructor for class akka.routing.ConsistentHash$
 
ConsistentHashingLike - Interface in akka.routing
The core pieces of the routing logic is located in this trait to be able to extend.
ConsistentHashingRouter - Class in akka.routing
A Router that uses consistent hashing to select a connection based on the sent message.
ConsistentHashingRouter(int, Iterable<String>, Option<Resizer>, String, SupervisorStrategy, int, PartialFunction<Object, Object>) - Constructor for class akka.routing.ConsistentHashingRouter
 
ConsistentHashingRouter(int) - Constructor for class akka.routing.ConsistentHashingRouter
Java API: Constructor that sets nrOfInstances to be created.
ConsistentHashingRouter(Iterable<String>) - Constructor for class akka.routing.ConsistentHashingRouter
Java API: Constructor that sets the routees to be used.
ConsistentHashingRouter(Resizer) - Constructor for class akka.routing.ConsistentHashingRouter
Java API: Constructor that sets the resizer to be used.
ConsistentHashingRouter$ - Class in akka.routing
 
ConsistentHashingRouter$() - Constructor for class akka.routing.ConsistentHashingRouter$
 
ConsistentHashingRouter.ConsistentHashable - Interface in akka.routing
If you don't define the hashMapping when constructing the ConsistentHashingRouter the messages need to implement this interface to define what data to use for the consistent hash key.
ConsistentHashingRouter.ConsistentHashableEnvelope - Class in akka.routing
If you don't define the hashMapping when constructing the ConsistentHashingRouter and messages can't implement ConsistentHashingRouter.ConsistentHashable themselves they can we wrapped by this envelope instead.
ConsistentHashingRouter.ConsistentHashableEnvelope(Object, Object) - Constructor for class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope
 
ConsistentHashingRouter.ConsistentHashableEnvelope$ - Class in akka.routing
 
ConsistentHashingRouter.ConsistentHashableEnvelope$() - Constructor for class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope$
 
ConsistentHashingRouter.ConsistentHashMapper - Interface in akka.routing
JAVA API Mapping from message to the data to use for the consistent hash key.
ConsistentHashingRouter.emptyConsistentHashMapping$ - Class in akka.routing
 
ConsistentHashingRouter.emptyConsistentHashMapping$() - Constructor for class akka.routing.ConsistentHashingRouter.emptyConsistentHashMapping$
 
consistentHashKey() - Method in interface akka.routing.ConsistentHashingRouter.ConsistentHashable
 
consistentHashKey() - Method in class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope
 
contains(Object) - Method in class akka.util.BoundedBlockingQueue
 
containsAll(Collection<?>) - Method in class akka.util.BoundedBlockingQueue
 
context() - Method in interface akka.actor.Actor
Stores the context for this actor, including self, and sender.
context() - Method in class akka.actor.TypedActor$
Returns the ActorContext (for a TypedActor) when inside a method call in a TypedActor.
context() - Static method in class akka.actor.TypedActor
Returns the ActorContext (for a TypedActor) when inside a method call in a TypedActor.
context() - Method in class akka.routing.RouteeProvider
 
contextClassLoader() - Method in class akka.dispatch.MonitorableThreadFactory
 
ContextualTypedActorFactory - Class in akka.actor
ContextualTypedActorFactory allows TypedActors to create children, effectively forming the same Actor Supervision Hierarchies as normal Actors can.
ContextualTypedActorFactory(TypedActorExtension, ActorContext) - Constructor for class akka.actor.ContextualTypedActorFactory
 
ContextualTypedActorFactory$ - Class in akka.actor
 
ContextualTypedActorFactory$() - Constructor for class akka.actor.ContextualTypedActorFactory$
 
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.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 name "default", and the specified Config, then obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
create(String, Config, ClassLoader) - Method in class akka.actor.ActorSystem$
Creates a new ActorSystem with the name "default", the specified Config, and specified ClassLoader
create() - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the name "default", obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
create(String) - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the specified name, obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
create(String, Config) - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the name "default", and the specified Config, then obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
create(String, Config, ClassLoader) - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the name "default", the specified Config, and specified ClassLoader
create() - Method in class akka.actor.DefaultSupervisorStrategy
 
create(ActorSystem) - Method in class akka.actor.Inbox$
Create a new Inbox within the given system.
create(ActorSystem) - Static method in class akka.actor.Inbox
Create a new Inbox within the given system.
create(Class<?>, Object...) - Method in class akka.actor.Props$
Java API: create a Props given a class and its constructor arguments.
create(Class<?>, Seq<Object>) - Method in class akka.actor.Props$
Java API: create a Props given a class and its constructor arguments.
create(Creator<T>) - Method in class akka.actor.Props$
Create new Props from the given Creator.
create(Class<?>, Object...) - Static method in class akka.actor.Props
Java API: create a Props given a class and its constructor arguments.
create(Class<?>, Seq<Object>) - Static method in class akka.actor.Props
Java API: create a Props given a class and its constructor arguments.
create(Creator<T>) - Static method in class akka.actor.Props
Create new Props from the given Creator.
create() - Method in class akka.actor.StoppingSupervisorStrategy
 
create() - Method in interface akka.actor.SupervisorStrategyConfigurator
 
create(MailboxType) - Method in class akka.dispatch.BalancingDispatcherConfigurator
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.BoundedDequeBasedMailbox
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.BoundedMailbox
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.BoundedPriorityMailbox
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in interface akka.dispatch.MailboxType
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.SingleConsumerOnlyUnboundedMailbox
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.UnboundedDequeBasedMailbox
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.UnboundedMailbox
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.UnboundedPriorityMailbox
 
create(PipelineContext, AbstractPipePair<CmdAbove, CmdBelow, EvtAbove, EvtBelow>) - Method in class akka.io.PipePairFactory$
Java API: construct a PipePair from the given AbstractPipePair.
create(PipelineContext, AbstractSymmetricPipePair<Above, Below>) - Method in class akka.io.PipePairFactory$
Java API: construct a PipePair from the given AbstractSymmetricPipePair.
create(PipelineContext, AbstractPipePair<CmdAbove, CmdBelow, EvtAbove, EvtBelow>) - Static method in class akka.io.PipePairFactory
Java API: construct a PipePair from the given AbstractPipePair.
create(PipelineContext, AbstractSymmetricPipePair<Above, Below>) - Static method in class akka.io.PipePairFactory
Java API: construct a PipePair from the given AbstractSymmetricPipePair.
create() - Method in interface akka.japi.Creator
This method must return a different instance upon every call.
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
 
createActor() - Method in interface akka.routing.RouterConfig
The router "head" actor.
createCustomRoute(RouteeProvider) - Method in class akka.routing.CustomRouterConfig
 
createExecutorService() - Method in interface akka.dispatch.ExecutorServiceFactory
 
createExecutorService() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory
 
createExecutorService() - Method in class akka.dispatch.ThreadPoolConfig.ThreadPoolExecutorServiceFactory
 
createExecutorServiceFactory(String, ThreadFactory) - Method in interface akka.dispatch.ExecutorServiceFactoryProvider
 
createExecutorServiceFactory(String, ThreadFactory) - Method in class akka.dispatch.ForkJoinExecutorConfigurator
 
createExecutorServiceFactory(String, ThreadFactory) - Method in class akka.dispatch.ThreadPoolConfig
 
createExecutorServiceFactory(String, ThreadFactory) - Method in class akka.dispatch.ThreadPoolExecutorConfigurator
 
createExtension(ExtendedActorSystem) - Method in interface akka.actor.ExtensionId
Is used by Akka to instantiate the Extension identified by this ExtensionId, internal use only.
createExtension(ExtendedActorSystem) - Method in class akka.actor.ExtensionKey
 
createExtension(ExtendedActorSystem) - Method in class akka.actor.IOManager$
 
createExtension(ExtendedActorSystem) - Static method in class akka.actor.IOManager
 
createExtension(ExtendedActorSystem) - Method in class akka.actor.TypedActor$
 
createExtension(ExtendedActorSystem) - Static method in class akka.actor.TypedActor
 
createExtension(ExtendedActorSystem) - Method in class akka.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.
createRoute(RouteeProvider) - Method in interface akka.routing.BroadcastLike
 
createRoute(RouteeProvider) - Method in interface akka.routing.ConsistentHashingLike
 
createRoute(RouteeProvider) - Method in class akka.routing.CustomRouterConfig
 
createRoute(RouteeProvider) - Method in class akka.routing.FromConfig
 
createRoute(RouteeProvider) - Method in class akka.routing.NoRouter$
 
createRoute(RouteeProvider) - Static method in class akka.routing.NoRouter
 
createRoute(RouteeProvider) - Method in interface akka.routing.RandomLike
 
createRoute(RouteeProvider) - Method in interface akka.routing.RoundRobinLike
 
createRoute(RouteeProvider) - Method in interface akka.routing.RouterConfig
Implement the routing logic by returning a partial function of partial function from (sender, message) to a set of destinations.
createRoute(RouteeProvider) - Method in interface akka.routing.ScatterGatherFirstCompletedLike
 
createRoute(RouteeProvider) - Method in interface akka.routing.SmallestMailboxLike
 
createRouteeProvider(ActorContext, Props) - Method in interface akka.routing.RouterConfig
The RouteeProvider responsible for creating or looking up routees.
createRoutees(int) - Method in class akka.routing.RouteeProvider
Creates new routees from specified Props and registers them.
createThreadPoolConfigBuilder(Config, DispatcherPrerequisites) - Method in class akka.dispatch.ThreadPoolExecutorConfigurator
 
createTimeout(TimerTask, long) - Method in class akka.util.internal.HashedWheelTimer
Deprecated.  
CreationTimeout() - Method in class akka.actor.ActorSystem.Settings
 
creator() - Method in class akka.actor.Props
 
creator() - Method in class akka.actor.TypedProps
 
Creator<T> - Interface in akka.japi
A constructor/factory, takes no parameters but creates a new value of type T every call.
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$
 
ctx() - Method in class akka.io.TcpPipelineHandler
 
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: "$hours%02d:$minutes%02d:$seconds%02d.
currentTimeMillisToUTCString(long) - Static method in class akka.util.Helpers
Converts a "currentTimeMillis"-obtained timestamp accordingly: "$hours%02d:$minutes%02d:$seconds%02d.
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.
CustomRoute - Interface in akka.routing
Java API helper for creating a single-destination routing.
CustomRouterConfig - Class in akka.routing
Java API for a custom router factory.
CustomRouterConfig() - Constructor for class akka.routing.CustomRouterConfig
 

D

daemonic() - Method in class akka.dispatch.MonitorableThreadFactory
 
Daemonicity() - Method in class akka.actor.ActorSystem.Settings
 
data() - Method in class akka.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$
 
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$
 
dealias(Iterable<Either<Evt, Cmd>>) - Method in class akka.io.AbstractPipePair
INTERNAL API: Dealias a possibly optimized return value such that it can be safely used; this is never needed when only using public API.
dealias(Iterable<Either<Evt, Cmd>>) - Method in interface akka.io.PipelineContext
INTERNAL API: Dealias a possibly optimized return value such that it can be safely used; this is never needed when only using public API.
DeathPactException - Exception in akka.actor
A DeathPactException is thrown by an Actor that receives a Terminated(someActor) message that it doesn't handle itself, effectively crashing the Actor and escalating to the supervisor.
DeathPactException$ - Class in akka.actor
 
DeathPactException$() - Constructor for class akka.actor.DeathPactException$
 
debug() - Static method in class akka.dispatch.MessageDispatcher
 
debug(Logging.Debug) - Method in interface akka.event.Logging.StdOutLogger
 
debug(String) - Method in interface akka.event.LoggingAdapter
 
debug(String, Object) - Method in interface akka.event.LoggingAdapter
 
debug(String, Object, Object) - Method in interface akka.event.LoggingAdapter
 
debug(String, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
 
debug(String, Object, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
 
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.
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.
defaultAllowCoreThreadTimeout() - Method in class akka.dispatch.ThreadPoolConfig$
 
defaultAllowCoreThreadTimeout() - Static method in class akka.dispatch.ThreadPoolConfig
 
defaultBacklog() - Method in class akka.actor.IOManager.Settings
 
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.
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
Creates a new DefaultResizer from the given configuration
DefaultResizer(int, int, int, double, double, double, FiniteDuration, int) - Constructor for class akka.routing.DefaultResizer
 
DefaultResizer(int, int) - Constructor for class akka.routing.DefaultResizer
Java API constructor for default values except bounds.
DefaultResizer$ - Class in akka.routing
 
DefaultResizer$() - Constructor for class akka.routing.DefaultResizer$
 
DefaultReturnTimeout() - Method in class akka.actor.TypedActorExtension
Default timeout for typed actor methods with non-void return type
defaultRoutedProps() - Method in class akka.actor.Props$
The defaultRoutedProps is NoRouter which is used when creating a Props
defaultRoutedProps() - Static method in class akka.actor.Props
The defaultRoutedProps is NoRouter which is used when creating a Props
DefaultScheduler - Class in akka.actor
A scheduler implementation based on a HashedWheelTimer.
DefaultScheduler(Config, LoggingAdapter, ThreadFactory) - Constructor for class akka.actor.DefaultScheduler
 
defaultStrategy() - Method in class akka.actor.SupervisorStrategy$
When supervisorStrategy is not specified for an actor this is used by default.
defaultStrategy() - Static method in class akka.actor.SupervisorStrategy
When supervisorStrategy is not specified for an actor this is used by default.
DefaultSupervisorStrategy - Class in akka.actor
 
DefaultSupervisorStrategy() - Constructor for class akka.actor.DefaultSupervisorStrategy
 
defaultSupervisorStrategy() - Method in interface akka.routing.Router
 
defaultTimeout() - Method in class akka.actor.TypedProps$
 
defaultTimeout() - Static method in class akka.actor.TypedProps
 
defaultTimeout() - Method in class akka.dispatch.ThreadPoolConfig$
 
defaultTimeout() - Static method in class akka.dispatch.ThreadPoolConfig
 
DefaultVirtualNodesFactor() - Method in class akka.actor.ActorSystem.Settings
 
delayedStop(Scheduler, Iterable<ActorRef>, FiniteDuration) - Method in class akka.routing.RouteeProvider
Give concurrent messages a chance to be placed in mailbox before sending PoisonPill.
DelimiterFraming - Class in akka.io
Pipeline stage for delimiter byte based framing and de-framing.
DelimiterFraming(int, ByteString, boolean) - Constructor for class akka.io.DelimiterFraming
 
DelimiterFraming$ - Class in akka.io
 
DelimiterFraming$() - Constructor for class akka.io.DelimiterFraming$
 
Deploy - Class in akka.actor
This class represents deployment configuration for a given actor path.
Deploy(String, 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
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.
Destination - Class in akka.routing
For every message sent to a router, its route determines a set of destinations, where for each recipient a different sender may be specified; typically the sender should match the sender of the original request, but e.g. the scatter- gather router needs to receive the replies with an AskActorRef instead.
Destination(ActorRef, ActorRef) - Constructor for class akka.routing.Destination
 
Destination$ - Class in akka.routing
 
Destination$() - Constructor for class akka.routing.Destination$
 
destinationsFor(ActorRef, Object) - Method in interface akka.routing.CustomRoute
use akka.japi.Util.immutableSeq to convert a java.lang.Iterable to the return type needed for destinationsFor, or if you just want to return a single Destination, use akka.japi.Util.immutableSingletonSeq
detach(akka.actor.ActorCell) - Method in class akka.dispatch.MessageDispatcher
Detaches the specified actor instance from this dispatcher
digest(byte[], MessageDigest) - Method in class akka.util.Crypt$
 
digest(byte[], MessageDigest) - Static method in class akka.util.Crypt
 
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 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 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 INTERNAL API
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.actor.IO$
An Iteratee that ignores the specified number of bytes.
drop(int) - Static method in class akka.actor.IO
An Iteratee that ignores the specified number of bytes.
drop(int) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
drop(int) - Method in class akka.util.ByteIterator
 
drop(int) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
drop(int) - Method in class akka.util.ByteString
 
dropRight(int) - Method in class akka.util.ByteString
 
dropWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
dropWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator
 
dropWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
dropWhile(Function1<Object, Object>) - Method in class akka.util.ByteString
 
DSLDefaultTimeout() - Method in class akka.actor.ActorDSL.Extension
 
DSLInboxQueueSize() - Method in interface akka.actor.dsl.Inbox.InboxExtension
 
DummyClassForStringSources - Class in akka.event
This is a “marker” class which is inserted as originator class into Logging.LogEvent when the string representation was supplied directly.
DummyClassForStringSources() - Constructor for class akka.event.DummyClassForStringSources
 
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
INTERNAL API Value class supporting list operations on system messages.
EarliestFirstSystemMessageList(SystemMessage) - Constructor for class akka.dispatch.sysmsg.EarliestFirstSystemMessageList
 
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.IO.Chunk$
Represents the empty Chunk
empty() - Method in class akka.actor.IO.IterateeRef.Map
 
empty() - Method in class akka.actor.Props$
A Props instance whose creator will create an actor that doesn't respond to any message
empty() - Static method in class akka.actor.Props
A Props instance whose creator will create an actor that doesn't respond to any message
empty() - Method in interface akka.event.ActorClassification
 
empty() - Method in class akka.io.Tcp.Write$
The empty Write doesn't write anything and isn't acknowledged.
empty() - Method in class akka.util.ByteIterator.ByteArrayIterator$
 
empty() - Method in class akka.util.ByteIterator.MultiByteArrayIterator$
 
empty() - Method in class akka.util.ByteString$
 
empty() - Static method in class akka.util.ByteString
 
empty() - Method in class akka.util.CompactByteString$
 
empty() - Static method in class akka.util.CompactByteString
 
emptyActorPath() - Method in class akka.actor.ActorPath$
 
emptyActorPath() - Method in interface akka.actor.ActorPath
 
ENil() - Method in class akka.dispatch.sysmsg.SystemMessageList$
 
ENil() - Static method in class akka.dispatch.sysmsg.SystemMessageList
 
enqueue(ByteString) - Method in class akka.actor.WriteBuffer
 
enqueue(ActorRef, Envelope) - Method in interface akka.dispatch.BoundedDequeBasedMessageQueue
 
enqueue(ActorRef, Envelope) - Method in interface akka.dispatch.BoundedQueueBasedMessageQueue
 
enqueue(ActorRef, Envelope) - Method in interface akka.dispatch.MessageQueue
Try to enqueue the message to this queue, or throw an exception.
enqueue(ActorRef, Envelope) - Method in class akka.dispatch.NodeMessageQueue
 
enqueue(ActorRef, Envelope) - Method in interface akka.dispatch.UnboundedDequeBasedMessageQueue
 
enqueue(ActorRef, Envelope) - Method in interface akka.dispatch.UnboundedQueueBasedMessageQueue
 
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
 
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
 
error(Throwable, String, Object) - Method in interface akka.event.LoggingAdapter
 
error(Throwable, String, Object, Object) - Method in interface akka.event.LoggingAdapter
 
error(Throwable, String, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
 
error(Throwable, String, Object, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
 
error(String) - Method in interface akka.event.LoggingAdapter
 
error(String, Object) - Method in interface akka.event.LoggingAdapter
 
error(String, Object, Object) - Method in interface akka.event.LoggingAdapter
 
error(String, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
 
error(String, Object, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
 
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. the supervisor fails with the same exception as the child.
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. the supervisor fails with the same exception as the child.
escalateDefault() - Method in class akka.actor.SupervisorStrategy$
 
escalateDefault() - Static method in class akka.actor.SupervisorStrategy
 
event() - Method in class akka.actor.FSM.Event
 
event() - Method in class akka.actor.FSM.LogEntry
 
event() - Method in class akka.event.Logging.LogEventException
 
event() - Method in class akka.io.Tcp.Abort$
The corresponding event which is sent as an acknowledgment once the close operation is finished.
event() - Method in class akka.io.Tcp.Close$
The corresponding event which is sent as an acknowledgment once the close operation is finished.
event() - Method in interface akka.io.Tcp.CloseCommand
The corresponding event which is sent as an acknowledgment once the close operation is finished.
event() - Method in class akka.io.Tcp.ConfirmedClose$
The corresponding event which is sent as an acknowledgment once the close operation is finished.
event(Object) - Method in class akka.io.TcpPipelineHandler.Init
Java API: extract a wrapped event received from the TcpPipelineHandler actor.
EventBus - Interface in akka.event
Represents the base type for EventBuses Internally has an Event type, a Classifier type and a Subscriber type For the Java API, see akka.event.japi
EventHandlers() - Method in class akka.actor.ActorSystem.Settings
 
EventHandlerStartTimeout() - Method in class akka.actor.ActorSystem.Settings
 
eventPipeline() - Method in interface akka.io.PipePair
The event pipeline transforms injected event from the lower stage into event for the stage above, but it can also emit commands for the stage below.
events() - Method in interface akka.actor.LoggingFSM
 
events() - Method in class akka.io.PipelinePorts
 
eventStream() - Method in class akka.actor.ActorSystem
Main event bus of this actor system, used for example for logging.
eventStream() - Method in interface akka.dispatch.DispatcherPrerequisites
 
eventStream() - Method in class akka.dispatch.MessageDispatcher
 
eventStream() - Method in class akka.dispatch.TaskInvocation
 
EventStream - Class in akka.event
 
EventStream(boolean) - Constructor for class akka.event.EventStream
 
EventStream$ - Class in akka.event
 
EventStream$() - Constructor for class akka.event.EventStream$
 
evt() - Method in interface akka.io.PipelineContext
INTERNAL API: do not touch!
evt() - Method in class akka.io.TcpPipelineHandler.Init.Event
 
evt() - Method in class akka.io.TcpPipelineHandler.TcpEvent
 
evtHolder() - Method in interface akka.io.PipelineContext
INTERNAL API: do not touch!
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$
 
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: object MyExt extends ExtensionKey[Ext] class Ext(system: ExtendedActorSystem) extends Extension { ... } Java API: public class MyExt extends Extension { static final ExtensionKey<MyExt> key = new ExtensionKey<MyExt>(MyExt.class); public MyExt(ExtendedActorSystem system) { ... } }
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.actor.IO.Next
 
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
failureMessage() - Method in interface akka.io.Tcp.Command
 
failureMessage() - Method in interface akka.io.Udp.Command
 
failureMessage() - Method in interface akka.io.UdpConnected.Command
 
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
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
 
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
flatMap(Function1<A, IO.Iteratee<B>>) - Method in class akka.actor.IO.Iteratee
Applies a function to the result of this Iteratee, resulting in a new Iteratee.
flatMap(Function1<A, IO.Iteratee<A>>) - Method in interface akka.actor.IO.IterateeRef
 
flatMap(Function1<A, IO.Iteratee<A>>) - Method in class akka.actor.IO.IterateeRefAsync
 
flatMap(Function1<A, IO.Iteratee<A>>) - Method in class akka.actor.IO.IterateeRefSync
 
fold(B, M, Function2<B, A, IO.Iteratee<B>>) - Method in class akka.actor.IO$
An Iteratee that folds over a Traversable by applying a function that returns an Iteratee.
fold(B, M, Function2<B, A, IO.Iteratee<B>>) - Static method in class akka.actor.IO
An Iteratee that folds over a Traversable by applying a function that returns an Iteratee.
fold(R, Iterable<Future<T>>, Function2<R, T, R>, ExecutionContext) - Method in class akka.dispatch.Futures$
A non-blocking fold over the specified futures, with the start value of the given zero.
fold(R, Iterable<Future<T>>, Function2<R, T, R>, ExecutionContext) - Static method in class akka.dispatch.Futures
A non-blocking fold over the specified futures, with the start value of the given zero.
fold(Function0<T>, Function0<T>) - Method in class akka.util.Switch
Executes the provided callbacks depending on if the switch is either on or off waiting for any pending changes to happen before (locking) Be careful of longrunning or blocking within the provided action as it can lead to deadlocks or bad performance
foldLeft(B, Function2<B, Object, B>) - Method in class akka.util.ByteIterator
 
Foreach<T> - Class in akka.dispatch
Callback for the Future.foreach operation that will be invoked if the Future that this callback is registered on becomes completed with a success.
Foreach() - Constructor for class akka.dispatch.Foreach
 
foreach(Function1<Object, U>) - Method in class akka.util.ByteIterator
 
foreach(Function1<Object, U>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
foreach(Function1<Object, U>) - Method in class akka.util.ByteString
 
foreach(Function2<K, V, BoxedUnit>) - Method in class akka.util.Index
Applies the supplied function to all keys and their values
ForkJoinExecutorConfigurator - Class in akka.dispatch
 
ForkJoinExecutorConfigurator(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.
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 - Class in akka.routing
Java API: Router configuration which has no default, i.e. external configuration is required.
FromConfig(String, SupervisorStrategy) - Constructor for class akka.routing.FromConfig
 
FromConfig() - Constructor for class akka.routing.FromConfig
 
FromConfig$ - Class in akka.routing
Router configuration which has no default, i.e. external configuration is required.
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 akka.actor.FSM.SubscribeTransitionCallback before sending any FSM.Transition messages.
FSM.CurrentState(ActorRef, S) - Constructor for class akka.actor.FSM.CurrentState
 
FSM.CurrentState$ - Class in akka.actor
 
FSM.CurrentState$() - Constructor for class akka.actor.FSM.CurrentState$
 
FSM.Event - Class in akka.actor
All messages sent to the FSM will be wrapped inside an Event, which allows pattern matching to extract both state and data.
FSM.Event(Object, D) - Constructor for class akka.actor.FSM.Event
 
FSM.Event$ - Class in akka.actor
 
FSM.Event$() - Constructor for class akka.actor.FSM.Event$
 
FSM.Failure - Class in akka.actor
Signifies that the FSM is shutting itself down because of an error, e.g. if the state to transition into does not exist.
FSM.Failure(Object) - Constructor for class akka.actor.FSM.Failure
 
FSM.Failure$ - Class in akka.actor
 
FSM.Failure$() - Constructor for class akka.actor.FSM.Failure$
 
FSM.LogEntry<S,D> - Class in akka.actor
Log Entry of the LoggingFSM, can be obtained by calling getLog.
FSM.LogEntry(S, D, Object) - Constructor for class akka.actor.FSM.LogEntry
 
FSM.LogEntry$ - Class in akka.actor
 
FSM.LogEntry$() - Constructor for class akka.actor.FSM.LogEntry$
 
FSM.Normal$ - Class in akka.actor
Default reason if calling stop().
FSM.Normal$() - Constructor for class akka.actor.FSM.Normal$
 
FSM.NullFunction$ - Class in akka.actor
A partial function value which does not match anything and can be used to “reset” whenUnhandled and onTermination handlers.
FSM.NullFunction$() - Constructor for class akka.actor.FSM.NullFunction$
 
FSM.Reason - Interface in akka.actor
Reason why this FSM is shutting down.
FSM.Shutdown$ - Class in akka.actor
Reason given when someone was calling system.stop(fsm) from outside; also applies to Stop supervision directive.
FSM.Shutdown$() - Constructor for class akka.actor.FSM.Shutdown$
 
FSM.State<S,D> - Class in akka.actor
This captures all of the managed state of the FSM: the state name, the state data, possibly custom timeout, stop reason and replies accumulated while processing the last message.
FSM.State(S, D, Option<FiniteDuration>, Option<FSM.Reason>, List<Object>) - Constructor for class akka.actor.FSM.State
 
FSM.State$ - Class in akka.actor
 
FSM.State$() - Constructor for class akka.actor.FSM.State$
 
FSM.StateTimeout$ - Class in akka.actor
This case object is received in case of a state timeout.
FSM.StateTimeout$() - Constructor for class akka.actor.FSM.StateTimeout$
 
FSM.StopEvent - Class in akka.actor
Case class representing the state of the FSM whithin the onTermination block.
FSM.StopEvent(FSM.Reason, S, D) - Constructor for class akka.actor.FSM.StopEvent
 
FSM.StopEvent$ - Class in akka.actor
 
FSM.StopEvent$() - Constructor for class akka.actor.FSM.StopEvent$
 
FSM.SubscribeTransitionCallBack - Class in akka.actor
Send this to an FSM to request first the akka.actor.CurrentState and then a series of akka.actor.Transition updates.
FSM.SubscribeTransitionCallBack(ActorRef) - Constructor for class akka.actor.FSM.SubscribeTransitionCallBack
 
FSM.SubscribeTransitionCallBack$ - Class in akka.actor
 
FSM.SubscribeTransitionCallBack$() - Constructor for class akka.actor.FSM.SubscribeTransitionCallBack$
 
FSM.TimeoutMarker - Class in akka.actor
INTERNAL API
FSM.TimeoutMarker(long) - Constructor for class akka.actor.FSM.TimeoutMarker
 
FSM.TimeoutMarker$ - Class in akka.actor
 
FSM.TimeoutMarker$() - Constructor for class akka.actor.FSM.TimeoutMarker$
 
FSM.Timer - Class in akka.actor
INTERNAL API
FSM.Timer(String, Object, boolean, int, ActorContext) - Constructor for class akka.actor.FSM.Timer
 
FSM.Timer$ - Class in akka.actor
 
FSM.Timer$() - Constructor for class akka.actor.FSM.Timer$
 
FSM.TransformHelper - Class in akka.actor
 
FSM.TransformHelper(PartialFunction<FSM.Event, FSM.State<S, D>>) - Constructor for class akka.actor.FSM.TransformHelper
 
FSM.Transition<S> - Class in akka.actor
Message type which is used to communicate transitions between states to all subscribed listeners (use akka.actor.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 akka.actor.FSM.SubscribeTransitionCallback.
FSM.UnsubscribeTransitionCallBack(ActorRef) - Constructor for class akka.actor.FSM.UnsubscribeTransitionCallBack
 
FSM.UnsubscribeTransitionCallBack$ - Class in akka.actor
 
FSM.UnsubscribeTransitionCallBack$() - Constructor for class akka.actor.FSM.UnsubscribeTransitionCallBack$
 
FsmDebugEvent() - Method in class akka.actor.ActorSystem.Settings
 
fsmRef() - Method in class akka.actor.FSM.CurrentState
 
fsmRef() - Method in class akka.actor.FSM.Transition
 
full() - Method in interface akka.actor.LoggingFSM
 
Function<T,R> - Interface in akka.japi
A Function interface.
Function2<T1,T2,R> - Interface in akka.japi
A Function interface.
future() - Method in class akka.actor.IO.IterateeRefAsync
Returns a Future which will hold the future value of this IterateeRefAsync
future(Callable<T>, ExecutionContext) - Method in class akka.dispatch.Futures$
Starts an asynchronous computation and returns a Future object with the result of that computation.
future(Callable<T>, ExecutionContext) - Static method in class akka.dispatch.Futures
Starts an asynchronous computation and returns a Future object with the result of that computation.
future() - Method in class akka.pattern.PipeToSupport.PipeableFuture
 
Futures - Class in akka.dispatch
Futures is the Java API for Futures and Promises
Futures() - Constructor for class akka.dispatch.Futures
 
Futures$ - Class in akka.dispatch
Futures is the Java API for Futures and Promises
Futures$() - Constructor for class akka.dispatch.Futures$
 
FutureTimeoutSupport - Interface in akka.pattern
Copyright (C) 2009-2013 Typesafe Inc.

G

gen(Object) - Method in class akka.dispatch.PriorityGenerator
 
generateSecureCookie() - Method in class akka.util.Crypt$
 
generateSecureCookie() - Static method in class akka.util.Crypt
 
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 interface akka.actor.ExtensionId
Returns an instance of the extension identified by this ExtensionId instance.
get() - Method in class akka.actor.IO.Iteratee
Passes an akka.actor.IO.EOF to this Iteratee and returns the result if available.
get(K) - Method in class akka.actor.IO.IterateeRef.Map
 
get(ActorSystem) - Method in class akka.actor.TypedActor$
 
get(ActorContext) - Method in class akka.actor.TypedActor$
Returns a contextual TypedActorFactory of this extension, this means that any TypedActors created by this TypedActorExtension will be children to the specified context, this allows for creating hierarchies of TypedActors.
get(ActorSystem) - Static method in class akka.actor.TypedActor
 
get(ActorContext) - Static method in class akka.actor.TypedActor
Returns a contextual TypedActorFactory of this extension, this means that any TypedActors created by this TypedActorExtension will be children to the specified context, this allows for creating hierarchies of TypedActors.
get(ActorSystem) - Method in class akka.io.Tcp$
Java API: retrieve Tcp extension for the given system.
get(ActorSystem) - Static method in class akka.io.Tcp
Java API: retrieve 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
 
getCause() - Method in class akka.event.Logging.LogEventException
 
getCause() - Method in exception akka.pattern.AskTimeoutException
 
getChild(String) - Method in interface akka.actor.UntypedActorContext
Returns a reference to the named child or null if no child with that name exists.
getChildren() - Method in interface akka.actor.UntypedActorContext
Returns an unmodifiable Java Collection containing the linked actors, please note that the backing map is thread-safe but not immutable
getClassFor(String, ClassTag<T>) - Method in class akka.actor.DynamicAccess
Obtain a Class[_] object loaded with the right class loader (i.e. the one returned by classLoader).
getClassFor(String, ClassTag<T>) - Method in class akka.actor.ReflectiveDynamicAccess
 
getClazz(T) - Method in interface akka.event.LogSource
 
getCmd() - Method in class akka.io.TcpPipelineHandler.Init.Command
 
getCmd() - Method in class akka.io.TcpPipelineHandler.Management
 
getContext() - Method in class akka.actor.UntypedActor
Returns this UntypedActor's UntypedActorContext The UntypedActorContext is not thread safe so do not expose it outside of the UntypedActor.
getContext() - Method in interface akka.io.HasActorContext
Retrieve the ActorContext for this pipeline’s context.
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
 
getEvt() - Method in class akka.io.TcpPipelineHandler.Init.Event
 
getEvt() - Method in class akka.io.TcpPipelineHandler.TcpEvent
 
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. no means of communication known; no attempt is made to verify actual reachability).
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.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(ActorSystem, Object) - Static method in class akka.event.Logging
Obtain LoggingAdapter for the given actor system and source object.
getLogger(LoggingBus, Object) - Static method in class akka.event.Logging
Obtain LoggingAdapter for the given logging bus and source object.
getLogger() - Method in interface akka.io.HasLogging
Retrieve the LoggingAdapter for this pipeline’s context.
getLong(ByteOrder) - Method in class akka.util.ByteIterator
Get a single Long from this iterator.
getLongPart(int, ByteOrder) - Method in class akka.util.ByteIterator
Get a Long from this iterator where only the least significant n bytes were encoded.
getLongs(long[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
getLongs(long[], ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Longs from this iterator.
getLongs(long[], int, int, ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Longs from this iterator.
getLongs(long[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
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.
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
 
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() - Method in class akka.routing.RouteeProvider
Java API: All routees of the router
getSelf() - Method in class akka.actor.UntypedActor
Returns the 'self' reference.
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
getTask() - Method in interface akka.util.internal.Timeout
Deprecated. Returns the TimerTask which is associated with this handle.
getTimer() - Method in interface akka.util.internal.Timeout
Deprecated. Returns the Timer that created this handle.
getTimestamp() - Method in class akka.io.TickGenerator.Tick
 
getToArray(Object, int, int, int, Function0<A>, Function3<Object, Object, Object, BoxedUnit>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
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.
gracefulStop(ActorRef, FiniteDuration, Object) - Method in interface akka.pattern.GracefulStopSupport
Returns a Future that will be completed with success (value true) when existing messages of the target actor has been processed and the actor has been terminated.
gracefulStop(ActorRef, FiniteDuration) - Method in class akka.pattern.Patterns$
Returns a Future that will be completed with success (value true) when existing messages of the target actor has been processed and the actor has been terminated.
gracefulStop(ActorRef, FiniteDuration) - Static method in class akka.pattern.Patterns
Returns a Future that will be completed with success (value true) when existing messages of the target actor has been processed and the actor has been terminated.
GracefulStopSupport - Interface in akka.pattern
 
guard() - Method in interface akka.event.LoggingBus
 
guardian() - Method in interface akka.actor.ActorRefFactory
Father of all children created by this interface.
guardian() - Method in interface akka.actor.ActorRefProvider
Reference to the supervisor used for all top-level user actors.
guardian() - Method in class akka.actor.ExtendedActorSystem
The top-level supervisor of all actors created using system.actorOf(...).

H

handle() - Method in class akka.actor.IO.Close
 
handle() - Method in class akka.actor.IO.Closed
 
handle() - Method in class akka.actor.IO.Read
 
handle() - Method in class akka.actor.IO.Write
 
handleChildTerminated(ActorContext, ActorRef, Iterable<ActorRef>) - Method in class akka.actor.AllForOneStrategy
 
handleChildTerminated(ActorContext, ActorRef, Iterable<ActorRef>) - Method in class akka.actor.OneForOneStrategy
 
handleChildTerminated(ActorContext, ActorRef, Iterable<ActorRef>) - Method in class akka.actor.SupervisorStrategy
This method is called after the child has been removed from the set of children.
handleEvent() - Method in interface akka.actor.FSM
 
handleEventDefault() - Method in interface akka.actor.FSM
 
handleFailure(ActorContext, ActorRef, Throwable, ChildRestartStats, Iterable<ChildRestartStats>) - Method in class akka.actor.SupervisorStrategy
This is the main entry point: in case of a child’s failure, this method must try to handle the failure by resuming, restarting or stopping the child (and returning true), or it returns false to escalate the failure, which will lead to this actor re-throwing the exception which caused the failure.
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
 
HasActorContext - Interface in akka.io
This trait expresses that the pipeline’s context needs to live within an actor and provide its ActorContext.
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.ChildActorPath
 
hashCode() - Method in interface akka.actor.ExtensionId
 
hashCode() - Method in interface akka.actor.IO.Handle
 
HashCode - Class in akka.util
Set of methods which allow easy implementation of hashCode.
HashCode() - Constructor for class akka.util.HashCode
 
HashCode$ - Class in akka.util
Set of methods which allow easy implementation of hashCode.
HashCode$() - Constructor for class akka.util.HashCode$
 
HashedWheelTimer - Class in akka.util.internal
Deprecated. 
HashedWheelTimer(LoggingAdapter, ThreadFactory, Duration, int) - Constructor for class akka.util.internal.HashedWheelTimer
Deprecated. Creates a new timer.
hashKey() - Method in class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope
 
hashKey(Object) - Method in interface akka.routing.ConsistentHashingRouter.ConsistentHashMapper
 
hashMapping() - Method in interface akka.routing.ConsistentHashingLike
 
hashMapping() - Method in class akka.routing.ConsistentHashingRouter
 
hasLocalScope() - Method in class akka.actor.Address
Returns true if this Address is only defined locally.
HasLogging - Interface in akka.io
This trait expresses that the pipeline’s context needs to provide a logging facility.
hasMessages() - Method in interface akka.dispatch.MessageQueue
Indicates whether this queue is non-empty.
hasMessages() - Method in class akka.dispatch.NodeMessageQueue
 
hasMessages() - Method in interface akka.dispatch.QueueBasedMessageQueue
 
hasMessages(ActorRef) - Method in interface akka.routing.SmallestMailboxLike
Returns true if the actor currently has any pending messages in the mailbox, i.e. the mailbox is not empty.
hasNext() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
hasNext() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
head() - Method in class akka.dispatch.sysmsg.EarliestFirstSystemMessageList
 
head() - Method in class akka.dispatch.sysmsg.LatestFirstSystemMessageList
 
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.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. no lock involved)
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. no lock involved)
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. no lock involved)
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. no lock involved)
IllegalActorStateException - Exception in akka.actor
IllegalActorStateException is thrown when a core invariant in the Actor implementation has been violated.
IllegalActorStateException$ - Class in akka.actor
 
IllegalActorStateException$() - Constructor for class akka.actor.IllegalActorStateException$
 
immutableSeq(Class<?>[]) - Method in class akka.japi.Util$
Returns an immutable.Seq representing the provided array of Classes, an overloading of the generic immutableSeq in Util, to accommodate for erasure.
immutableSeq(Object) - Method in class akka.japi.Util$
Turns an array into an immutable Scala sequence (by copying it).
immutableSeq(Iterable<T>) - Method in class akka.japi.Util$
Turns an Iterable into an immutable Scala sequence (by copying it).
immutableSeq(Class<?>[]) - Static method in class akka.japi.Util
Returns an immutable.Seq representing the provided array of Classes, an overloading of the generic immutableSeq in Util, to accommodate for erasure.
immutableSeq(Object) - Static method in class akka.japi.Util
Turns an array into an immutable Scala sequence (by copying it).
immutableSeq(Iterable<T>) - Static method in class akka.japi.Util
Turns an Iterable into an immutable Scala sequence (by copying it).
immutableSingletonSeq(T) - Method in class akka.japi.Util$
 
immutableSingletonSeq(T) - Static method in class akka.japi.Util
 
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 {@link akka.actor.dsl.Inbox!.
Inbox - Class in akka.actor
An Inbox is an actor-like object which is interrogated from the outside.
Inbox() - Constructor for class akka.actor.Inbox
 
Inbox$ - Class in akka.actor
 
Inbox$() - Constructor for class akka.actor.Inbox$
 
Inbox.Get - Class in akka.actor.dsl
 
Inbox.Get(Deadline, ActorRef) - Constructor for class akka.actor.dsl.Inbox.Get
 
Inbox.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.StartWatch - Class in akka.actor.dsl
 
Inbox.StartWatch(ActorRef) - 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.
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
akka.io.Tcp.SocketOption to set the SO_RCVBUF option For more information see java.net.Socket.setReceiveBufferSize
Inet.SO$.ReceiveBufferSize(int) - Constructor for class akka.io.Inet.SO$.ReceiveBufferSize
 
Inet.SO$.ReuseAddress - Class in akka.io
akka.io.Tcp.SocketOption to enable or disable SO_REUSEADDR For more information see java.net.Socket.setReuseAddress
Inet.SO$.ReuseAddress(boolean) - Constructor for class akka.io.Inet.SO$.ReuseAddress
 
Inet.SO$.SendBufferSize - Class in akka.io
akka.io.Tcp.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
akka.io.Tcp.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
 
info(String, Object) - Method in interface akka.event.LoggingAdapter
 
info(String, Object, Object) - Method in interface akka.event.LoggingAdapter
 
info(String, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
 
info(String, Object, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
 
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.
injectCommand(Cmd) - Method in interface akka.io.PipelineInjector
Inject the given command into the connected pipeline.
injectEvent(Evt) - Method in interface akka.io.PipelineInjector
Inject the given event into the connected pipeline.
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$
 
invokeAll(Collection<? extends Callable<T>>) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
invokeAny(Collection<? extends Callable<T>>) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
IO - Class in akka.actor
IO messages and iteratees.
IO() - Constructor for class akka.actor.IO
 
IO - Class in akka.io
Entry point to Akka’s IO layer.
IO() - Constructor for class akka.io.IO
 
IO$ - Class in akka.actor
IO messages and iteratees.
IO$() - Constructor for class akka.actor.IO$
 
IO$ - Class in akka.io
Entry point to Akka’s IO layer.
IO$() - Constructor for class akka.io.IO$
 
IO.Accept - Class in akka.actor
Message to an IOManager to accept a new connection with the given IO.SocketOptions.
IO.Accept(IO.SocketHandle, IO.ServerHandle, Seq<IO.SocketOption>) - Constructor for class akka.actor.IO.Accept
 
IO.Accept$ - Class in akka.actor
 
IO.Accept$() - Constructor for class akka.actor.IO.Accept$
 
IO.Backlog - Class in akka.actor
IO.ServerSocketOption to set the maximum backlog of connections. 0 or negative means that the platform default will be used.
IO.Backlog(int) - Constructor for class akka.actor.IO.Backlog
 
IO.Backlog$ - Class in akka.actor
 
IO.Backlog$() - Constructor for class akka.actor.IO.Backlog$
 
IO.Chunk - Class in akka.actor
Part of an IO.Input stream that contains a chunk of bytes.
IO.Chunk(ByteString) - Constructor for class akka.actor.IO.Chunk
 
IO.Chunk$ - Class in akka.actor
 
IO.Chunk$() - Constructor for class akka.actor.IO.Chunk$
 
IO.Close - Class in akka.actor
Message to an IOManager to close the Channel.
IO.Close(IO.Handle) - Constructor for class akka.actor.IO.Close
 
IO.Close$ - Class in akka.actor
 
IO.Close$() - Constructor for class akka.actor.IO.Close$
 
IO.Closed - Class in akka.actor
Message from an IOManager that the Channel has closed.
IO.Closed(IO.Handle, IO.Input) - Constructor for class akka.actor.IO.Closed
 
IO.Closed$ - Class in akka.actor
 
IO.Closed$() - Constructor for class akka.actor.IO.Closed$
 
IO.Connect - Class in akka.actor
Message to an IOManager to create a SocketChannel connected to the provided address with the given IO.SocketOptions.
IO.Connect(IO.SocketHandle, SocketAddress, Seq<IO.SocketOption>) - Constructor for class akka.actor.IO.Connect
 
IO.Connect$ - Class in akka.actor
 
IO.Connect$() - Constructor for class akka.actor.IO.Connect$
 
IO.Connected - Class in akka.actor
Message from an IOManager that the SocketChannel has successfully connected.
IO.Connected(IO.SocketHandle, SocketAddress) - Constructor for class akka.actor.IO.Connected
 
IO.Connected$ - Class in akka.actor
 
IO.Connected$() - Constructor for class akka.actor.IO.Connected$
 
IO.DivergentIterateeException - Exception in akka.actor
 
IO.DivergentIterateeException() - Constructor for exception akka.actor.IO.DivergentIterateeException
 
IO.Done<A> - Class in akka.actor
An Iteratee representing a result, usually returned by the successful completion of an Iteratee.
IO.Done(A) - Constructor for class akka.actor.IO.Done
 
IO.Done$ - Class in akka.actor
 
IO.Done$() - Constructor for class akka.actor.IO.Done$
 
IO.EOF$ - Class in akka.actor
Part of an IO.Input stream that represents the end of the stream.
IO.EOF$() - Constructor for class akka.actor.IO.EOF$
 
IO.Error - Class in akka.actor
Part of an IO.Input stream that represents an error in the stream.
IO.Error(Throwable) - Constructor for class akka.actor.IO.Error
 
IO.Error$ - Class in akka.actor
 
IO.Error$() - Constructor for class akka.actor.IO.Error$
 
IO.Extension - Interface in akka.io
 
IO.Failure - Class in akka.actor
An IO.Iteratee that represents an erronous end state.
IO.Failure(Throwable) - Constructor for class akka.actor.IO.Failure
 
IO.Failure$ - Class in akka.actor
 
IO.Failure$() - Constructor for class akka.actor.IO.Failure$
 
IO.Handle - Interface in akka.actor
An immutable handle to a Java NIO Channel.
IO.Input - Interface in akka.actor
Represents part of a stream of bytes that can be processed by an IO.Iteratee.
IO.IOMessage - Interface in akka.actor
Messages used to communicate with an IOManager.
IO.Iteratee<A> - Class in akka.actor
A basic Iteratee implementation of Oleg's Iteratee (http://okmij.org/ftp/Streams.html).
IO.Iteratee() - Constructor for class akka.actor.IO.Iteratee
 
IO.Iteratee$ - Class in akka.actor
 
IO.Iteratee$() - Constructor for class akka.actor.IO.Iteratee$
 
IO.IterateeRef<A> - Interface in akka.actor
A mutable reference to an Iteratee designed for use within an Actor.
IO.IterateeRef$ - Class in akka.actor
 
IO.IterateeRef$() - Constructor for class akka.actor.IO.IterateeRef$
 
IO.IterateeRef.Map<K,V> - Class in akka.actor
A mutable Map to contain multiple IterateeRefs.
IO.IterateeRef.Map$ - Class in akka.actor
 
IO.IterateeRef.Map$() - Constructor for class akka.actor.IO.IterateeRef.Map$
 
IO.IterateeRefAsync<A> - Class in akka.actor
A mutable reference to an IO.Iteratee.
IO.IterateeRefAsync(IO.Iteratee<A>, ExecutionContext) - Constructor for class akka.actor.IO.IterateeRefAsync
 
IO.IterateeRefSync<A> - Class in akka.actor
A mutable reference to an IO.Iteratee.
IO.IterateeRefSync(IO.Iteratee<A>) - Constructor for class akka.actor.IO.IterateeRefSync
 
IO.KeepAlive - Class in akka.actor
IO.SocketOption to enable or disable SO_KEEPALIVE For more information see java.net.Socket.setKeepAlive
IO.KeepAlive(boolean) - Constructor for class akka.actor.IO.KeepAlive
 
IO.KeepAlive$ - Class in akka.actor
 
IO.KeepAlive$() - Constructor for class akka.actor.IO.KeepAlive$
 
IO.Listen - Class in akka.actor
Message to an IOManager to create a ServerSocketChannel listening on the provided address with the given IO.ServerSocketOptions.
IO.Listen(IO.ServerHandle, SocketAddress, Seq<IO.ServerSocketOption>) - Constructor for class akka.actor.IO.Listen
 
IO.Listen$ - Class in akka.actor
 
IO.Listen$() - Constructor for class akka.actor.IO.Listen$
 
IO.Listening - Class in akka.actor
Message from an IOManager that the ServerSocketChannel is now listening for connections.
IO.Listening(IO.ServerHandle, SocketAddress) - Constructor for class akka.actor.IO.Listening
 
IO.Listening$ - Class in akka.actor
 
IO.Listening$() - Constructor for class akka.actor.IO.Listening$
 
IO.NewClient - Class in akka.actor
Message from an IOManager that a new connection has been made to the ServerSocketChannel and needs to be accepted.
IO.NewClient(IO.ServerHandle) - Constructor for class akka.actor.IO.NewClient
 
IO.NewClient$ - Class in akka.actor
 
IO.NewClient$() - Constructor for class akka.actor.IO.NewClient$
 
IO.Next<A> - Class in akka.actor
An IO.Iteratee that still requires more input to calculate it's result.
IO.Next(Function1<IO.Input, Tuple2<IO.Iteratee<A>, IO.Input>>) - Constructor for class akka.actor.IO.Next
 
IO.Next$ - Class in akka.actor
 
IO.Next$() - Constructor for class akka.actor.IO.Next$
 
IO.OOBInline - Class in akka.actor
IO.SocketOption to enable or disable OOBINLINE (receipt of TCP urgent data) By default, this option is disabled and TCP urgent data received on a IO.SocketHandle is silently discarded.
IO.OOBInline(boolean) - Constructor for class akka.actor.IO.OOBInline
 
IO.OOBInline$ - Class in akka.actor
 
IO.OOBInline$() - Constructor for class akka.actor.IO.OOBInline$
 
IO.PerformancePreferences - Class in akka.actor
IO.SocketOption to set performance preferences for this IO.SocketHandle.
IO.PerformancePreferences(int, int, int) - Constructor for class akka.actor.IO.PerformancePreferences
 
IO.PerformancePreferences$ - Class in akka.actor
 
IO.PerformancePreferences$() - Constructor for class akka.actor.IO.PerformancePreferences$
 
IO.Read - Class in akka.actor
Message from an IOManager that contains bytes read from the SocketChannel.
IO.Read(IO.ReadHandle, ByteString) - Constructor for class akka.actor.IO.Read
 
IO.Read$ - Class in akka.actor
 
IO.Read$() - Constructor for class akka.actor.IO.Read$
 
IO.ReadHandle - Interface in akka.actor
A IO.Handle to a ReadableByteChannel.
IO.ReceiveBufferSize - Class in akka.actor
IO.SocketOption to set the SO_RCVBUF option for this IO.SocketHandle.
IO.ReceiveBufferSize(int) - Constructor for class akka.actor.IO.ReceiveBufferSize
 
IO.ReceiveBufferSize$ - Class in akka.actor
 
IO.ReceiveBufferSize$() - Constructor for class akka.actor.IO.ReceiveBufferSize$
 
IO.ReuseAddress - Class in akka.actor
IO.SocketOption to enable or disable SO_REUSEADDR For more information see java.net.Socket.setReuseAddress
IO.ReuseAddress(boolean) - Constructor for class akka.actor.IO.ReuseAddress
 
IO.ReuseAddress$ - Class in akka.actor
 
IO.ReuseAddress$() - Constructor for class akka.actor.IO.ReuseAddress$
 
IO.SendBufferSize - Class in akka.actor
IO.SocketOption to set the SO_SNDBUF option for this IO.SocketHandle.
IO.SendBufferSize(int) - Constructor for class akka.actor.IO.SendBufferSize
 
IO.SendBufferSize$ - Class in akka.actor
 
IO.SendBufferSize$() - Constructor for class akka.actor.IO.SendBufferSize$
 
IO.ServerHandle - Class in akka.actor
A IO.Handle to a ServerSocketChannel.
IO.ServerHandle(ActorRef, ActorRef, UUID) - Constructor for class akka.actor.IO.ServerHandle
 
IO.ServerHandle$ - Class in akka.actor
 
IO.ServerHandle$() - Constructor for class akka.actor.IO.ServerHandle$
 
IO.ServerSocketOption - Interface in akka.actor
Options to be set when setting up a IO.ServerHandle
IO.SocketHandle - Class in akka.actor
A IO.Handle to a SocketChannel.
IO.SocketHandle(ActorRef, ActorRef, UUID) - Constructor for class akka.actor.IO.SocketHandle
 
IO.SocketHandle$ - Class in akka.actor
 
IO.SocketHandle$() - Constructor for class akka.actor.IO.SocketHandle$
 
IO.SocketOption - Interface in akka.actor
Options to be set when setting up a IO.SocketHandle
IO.SoLinger - Class in akka.actor
IO.SocketOption to enable or disable SO_LINGER with the specified linger time in seconds.
IO.SoLinger(Option<Object>) - Constructor for class akka.actor.IO.SoLinger
 
IO.SoLinger$ - Class in akka.actor
 
IO.SoLinger$() - Constructor for class akka.actor.IO.SoLinger$
 
IO.SoTimeout - Class in akka.actor
IO.SocketOption to set SO_TIMEOUT to the specified timeout rounded down to the nearest millisecond.
IO.SoTimeout(Duration) - Constructor for class akka.actor.IO.SoTimeout
 
IO.SoTimeout$ - Class in akka.actor
 
IO.SoTimeout$() - Constructor for class akka.actor.IO.SoTimeout$
 
IO.TcpNoDelay - Class in akka.actor
IO.SocketOption to enable or disable TCP_NODELAY (disable or enable Nagle's algorithm) For more information see java.net.Socket.setTcpNoDelay
IO.TcpNoDelay(boolean) - Constructor for class akka.actor.IO.TcpNoDelay
 
IO.TcpNoDelay$ - Class in akka.actor
 
IO.TcpNoDelay$() - Constructor for class akka.actor.IO.TcpNoDelay$
 
IO.TrafficClass - Class in akka.actor
IO.SocketOption to set the traffic class or type-of-service octet in the IP header for packets sent from this IO.SocketHandle.
IO.TrafficClass(int) - Constructor for class akka.actor.IO.TrafficClass
 
IO.TrafficClass$ - Class in akka.actor
 
IO.TrafficClass$() - Constructor for class akka.actor.IO.TrafficClass$
 
IO.Write - Class in akka.actor
Message to an IOManager to write to the SocketChannel.
IO.Write(IO.WriteHandle, ByteString) - Constructor for class akka.actor.IO.Write
 
IO.Write$ - Class in akka.actor
 
IO.Write$() - Constructor for class akka.actor.IO.Write$
 
IO.WriteHandle - Interface in akka.actor
A IO.Handle to a WritableByteChannel.
ioManager() - Method in interface akka.actor.IO.Handle
 
ioManager() - Method in class akka.actor.IO.ServerHandle
 
ioManager() - Method in class akka.actor.IO.SocketHandle
 
IOManager - Class in akka.actor
IOManager contains a reference to the IOManagerActor for an ActorSystem.
IOManager$ - Class in akka.actor
Create a SocketChannel connecting to a host and port.
IOManager$() - Constructor for class akka.actor.IOManager$
 
IOManager.Settings - Class in akka.actor
 
IOManager.Settings(int, int, int) - Constructor for class akka.actor.IOManager.Settings
 
IOManager.Settings$ - Class in akka.actor
 
IOManager.Settings$() - Constructor for class akka.actor.IOManager.Settings$
 
IOManagerActor - Class in akka.actor
An Actor that performs IO using a Java NIO Selector.
IOManagerActor(IOManager.Settings) - Constructor for class akka.actor.IOManagerActor
 
isAborted() - Method in class akka.io.Tcp.Aborted$
 
isAborted() - Method in interface akka.io.Tcp.ConnectionClosed
true iff the connection has been closed in response to an Abort command.
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 Java & Scala API
isCancelled() - Method in class akka.actor.LightArrayRevolverScheduler.TaskHolder
 
isCancelled() - Method in interface akka.util.internal.Timeout
Deprecated. Returns true if and only if the TimerTask associated with this handle has been cancelled.
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$
 
isEmpty() - Method in class akka.actor.WriteBuffer
 
isEmpty() - Method in class akka.dispatch.AbstractNodeQueue
 
isEmpty() - Method in class akka.dispatch.sysmsg.EarliestFirstSystemMessageList
Indicates if the list is empty or not.
isEmpty() - Method in class akka.dispatch.sysmsg.LatestFirstSystemMessageList
Indicates if the list is empty or not.
isEmpty() - Method in class akka.japi.Option
 
isEmpty() - Method in class akka.japi.Option.Some
 
isEmpty() - Method in class akka.routing.ConsistentHash
Is the node ring empty, i.e. no nodes added or all removed.
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
 
isExpired() - Method in interface akka.util.internal.Timeout
Deprecated. Returns true if and only if the TimerTask associated with this handle has been expired.
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
 
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(ActorRef) - Method in interface akka.routing.SmallestMailboxLike
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(ActorRef) - Method in interface akka.routing.SmallestMailboxLike
Returns true if the actor is currently suspended.
isTerminated() - Method in class akka.actor.ActorRef
Is the actor shut down?
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
 
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.actor.IO.IterateeRef.Map
 
iterator() - Method in class akka.japi.Option
 
iterator() - Method in class akka.util.BoundedBlockingQueue
 
iterator() - Method in class akka.util.ByteString.ByteString1
 
iterator() - Method in class akka.util.ByteString.ByteString1C
 
iterator() - Method in class akka.util.ByteString.ByteStrings
 
iterator() - Method in class akka.util.ByteString
 

J

japi - Class in akka.dispatch
This class contains bridge classes between Scala and Java.
japi() - Constructor for class akka.dispatch.japi
 
JAPI - Class in akka.japi
 
JAPI() - Constructor for class akka.japi.JAPI
 
japi$ - Class in akka.dispatch
This class contains bridge classes between Scala and Java.
japi$() - Constructor for class akka.dispatch.japi$
 
japi.BooleanFunctionBridge<T> - Class in akka.dispatch
 
japi.BooleanFunctionBridge() - Constructor for class akka.dispatch.japi.BooleanFunctionBridge
 
japi.CallbackBridge<T> - Class in akka.dispatch
 
japi.CallbackBridge() - Constructor for class akka.dispatch.japi.CallbackBridge
 
japi.RecoverBridge<T> - Class in akka.dispatch
 
japi.RecoverBridge() - Constructor for class akka.dispatch.japi.RecoverBridge
 
japi.UnitFunctionBridge<T> - Class in akka.dispatch
 
japi.UnitFunctionBridge() - Constructor for class akka.dispatch.japi.UnitFunctionBridge
 
java2ScalaOption(Option<A>) - Method in class akka.japi.Option$
 
java2ScalaOption(Option<A>) - Static method in class akka.japi.Option
 
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 For more information see java.net.Socket.setKeepAlive
keepAlive(boolean) - Static method in class akka.io.TcpSO
Inet.SocketOption to enable or disable SO_KEEPALIVE For more information see java.net.Socket.setKeepAlive
keepOpenOnPeerClosed() - Method in class akka.io.Tcp.Register
 
keys() - Method in class akka.util.Index
Returns the key set.
Kick() - Method in interface akka.actor.dsl.Inbox
 
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
 
latency() - Method in class akka.actor.IO.PerformancePreferences
 
LatestFirstSystemMessageList - Class in akka.dispatch.sysmsg
INTERNAL API Value class supporting list operations on system messages.
LatestFirstSystemMessageList(SystemMessage) - Constructor for class akka.dispatch.sysmsg.LatestFirstSystemMessageList
 
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.actor.WriteBuffer
 
length() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
length() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
length() - Method in class akka.util.ByteString.ByteString1
 
length() - Method in class akka.util.ByteString.ByteString1C
 
length() - Method in class akka.util.ByteString.ByteStrings
 
length() - Method in class akka.util.ByteStringBuilder
 
LengthFieldFrame - Class in akka.io
Pipeline stage for length-field encoded framing.
LengthFieldFrame(int, ByteOrder, int, boolean) - Constructor for class akka.io.LengthFieldFrame
 
LengthFieldFrame$ - Class in akka.io
 
LengthFieldFrame$() - Constructor for class akka.io.LengthFieldFrame$
 
level() - Method in class akka.event.Logging.Debug
 
level() - Method in class akka.event.Logging.Error
 
level() - Method in class akka.event.Logging.Info
 
level() - Method in interface akka.event.Logging.LogEvent
The LogLevel of this LogEvent
level() - Method in class akka.event.Logging.Warning
 
levelFor(String) - Method in class akka.event.Logging$
Returns the LogLevel associated with the given string, valid inputs are upper or lowercase (not mixed) versions of: "error", "warning", "info" and "debug"
levelFor(Class<? extends Logging.LogEvent>) - Method in class akka.event.Logging$
Returns the LogLevel associated with the given event class.
levelFor(String) - Static method in class akka.event.Logging
Returns the LogLevel associated with the given string, valid inputs are upper or lowercase (not mixed) versions of: "error", "warning", "info" and "debug"
levelFor(Class<? extends Logging.LogEvent>) - Static method in class akka.event.Logging
Returns the LogLevel associated with the given event class.
LightArrayRevolverScheduler - Class in akka.actor
This scheduler implementation is based on a revolving wheel of buckets, like Netty’s HashedWheelTimer, which it advances at a fixed tick rate and dispatches tasks it finds in the current bucket to their respective ExecutionContexts.
LightArrayRevolverScheduler(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, LightArrayRevolverScheduler.TaskHolder, int, ExecutionContext) - Constructor for class akka.actor.LightArrayRevolverScheduler.TaskHolder
 
LightArrayRevolverScheduler.TimerTask - Interface in akka.actor
INTERNAL API
lineSeparator() - Method in class akka.util.Crypt$
 
lineSeparator() - Static method in class akka.util.Crypt
 
linger() - Method in class akka.actor.IO.SoLinger
 
linkedBlockingQueue() - Method in class akka.dispatch.ThreadPoolConfig$
 
linkedBlockingQueue(int) - Method in class akka.dispatch.ThreadPoolConfig$
 
linkedBlockingQueue() - Static method in class akka.dispatch.ThreadPoolConfig
 
linkedBlockingQueue(int) - Static method in class akka.dispatch.ThreadPoolConfig
 
listen(SocketAddress, Seq<IO.ServerSocketOption>, ActorRef) - Method in class akka.actor.IOManager
Create a ServerSocketChannel listening on an address.
listen(SocketAddress, ActorRef) - Method in class akka.actor.IOManager
Create a ServerSocketChannel listening on an address.
listen(String, int, Seq<IO.ServerSocketOption>, ActorRef) - Method in class akka.actor.IOManager
Create a ServerSocketChannel listening on a host and port.
Listen - 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
 
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. protected from concurrent modification of the switch status.
log() - Method in interface akka.actor.ActorLogging
 
log() - Method in class akka.actor.ActorSystem
Convenient logging adapter for logging to the ActorSystem.eventStream.
log(Logging.LogLevel, String) - Method in interface akka.event.LoggingAdapter
 
log(Logging.LogLevel, String, Object) - Method in interface akka.event.LoggingAdapter
 
log(Logging.LogLevel, String, Object, Object) - Method in interface akka.event.LoggingAdapter
 
log(Logging.LogLevel, String, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
 
log(Logging.LogLevel, String, Object, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
 
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.
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.DefaultLogger - Class in akka.event
Actor wrapper around the standard output logger.
Logging.DefaultLogger() - Constructor for class akka.event.Logging.DefaultLogger
 
Logging.Error - Class in akka.event
For ERROR Logging
Logging.Error(Throwable, String, Class<?>, Object) - Constructor for class akka.event.Logging.Error
 
Logging.Error(String, Class<?>, Object) - Constructor for class akka.event.Logging.Error
 
Logging.Error$ - Class in akka.event
 
Logging.Error$() - Constructor for class akka.event.Logging.Error$
 
Logging.Error.NoCause$ - Class in akka.event
Null Object used for errors without cause Throwable
Logging.Error.NoCause$() - Constructor for class akka.event.Logging.Error.NoCause$
 
Logging.Info - Class in akka.event
For INFO Logging
Logging.Info(String, Class<?>, Object) - Constructor for class akka.event.Logging.Info
 
Logging.Info$ - Class in akka.event
 
Logging.Info$() - Constructor for class akka.event.Logging.Info$
 
Logging.InitializeLogger - Class in akka.event
Message which is sent to each default logger (i.e. from configuration file) after its creation but before attaching it to the logging bus.
Logging.InitializeLogger(LoggingBus) - Constructor for class akka.event.Logging.InitializeLogger
 
Logging.InitializeLogger$ - Class in akka.event
 
Logging.InitializeLogger$() - Constructor for class akka.event.Logging.InitializeLogger$
 
Logging.LogEvent - Interface in akka.event
Base type of LogEvents
Logging.LogEventException - Class in akka.event
Exception that wraps a LogEvent.
Logging.LogEventException(Logging.LogEvent, Throwable) - Constructor for class akka.event.Logging.LogEventException
 
Logging.LoggerException - Exception in akka.event
Artificial exception injected into Error events if no Throwable is supplied; used for getting a stack dump of error locations.
Logging.LoggerException() - Constructor for exception akka.event.Logging.LoggerException
 
Logging.LoggerInitializationException - Exception in akka.event
LoggerInitializationException is thrown to indicate that there was a problem initializing a logger
Logging.LoggerInitializationException(String) - Constructor for exception akka.event.Logging.LoggerInitializationException
 
Logging.LoggerInitialized - Class in akka.event
Response message each logger must send within 1 second after receiving the InitializeLogger request.
Logging.LoggerInitialized() - Constructor for class akka.event.Logging.LoggerInitialized
 
Logging.LoggerInitialized$ - Class in akka.event
 
Logging.LoggerInitialized$() - Constructor for class akka.event.Logging.LoggerInitialized$
 
Logging.LogLevel - Class in akka.event
Marker trait for annotating LogLevel, which must be Int after erasure.
Logging.LogLevel(int) - Constructor for class akka.event.Logging.LogLevel
 
Logging.LogLevel$ - Class in akka.event
 
Logging.LogLevel$() - Constructor for class akka.event.Logging.LogLevel$
 
Logging.StandardOutLogger - Class in akka.event
Actor-less logging implementation for synchronous logging to standard output.
Logging.StandardOutLogger() - Constructor for class akka.event.Logging.StandardOutLogger
 
Logging.StdOutLogger - Interface in akka.event
 
Logging.Warning - Class in akka.event
For WARNING Logging
Logging.Warning(String, Class<?>, Object) - Constructor for class akka.event.Logging.Warning
 
Logging.Warning$ - Class in akka.event
 
Logging.Warning$() - Constructor for class akka.event.Logging.Warning$
 
LoggingAdapter - Interface in akka.event
Logging wrapper to make nicer and optimize: provide template versions which evaluate .toString only if the log level is actually enabled.
LoggingBus - Interface in akka.event
This trait brings log level handling to the EventStream: it reads the log levels for the initial logging (StandardOutLogger) and the loggers & level for after-init logging, possibly keeping the StandardOutLogger enabled if it is part of the configured loggers.
loggingEnabled() - Method in class akka.actor.AllForOneStrategy
 
loggingEnabled() - Method in class akka.actor.OneForOneStrategy
 
loggingEnabled() - Method in class akka.actor.SupervisorStrategy
Logging of actor failures is done when this is true.
LoggingFSM<S,D> - Interface in akka.actor
Stackable trait for FSM which adds a rolling event log and debug logging capabilities (analogous to LoggingReceive).
LoggingReceive - Class in akka.event
This decorator adds invocation logging to a Receive function.
LoggingReceive(Option<Object>, PartialFunction<Object, BoxedUnit>, ActorContext) - Constructor for class akka.event.LoggingReceive
 
LoggingReceive$ - Class in akka.event
 
LoggingReceive$() - Constructor for class akka.event.LoggingReceive$
 
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 interface akka.actor.ExtensionIdProvider
Returns the canonical ExtensionId for this Extension
lookup() - Method in class akka.actor.ExtensionKey
 
lookup() - Method in class akka.actor.IOManager$
 
lookup() - Static method in class akka.actor.IOManager
 
lookup() - Method in class akka.actor.TypedActor$
 
lookup() - Static method in class akka.actor.TypedActor
 
lookup(String) - Method in class akka.dispatch.Dispatchers
Returns a dispatcher as specified in configuration.
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) The compareSubscribers need to provide a total ordering of the Subscribers
LookupEventBus<E,S,C> - Class in akka.event.japi
See documentation for LookupClassification E is the Event type S is the Subscriber type C is the Classifier type
LookupEventBus() - Constructor for class akka.event.japi.LookupEventBus
 
lookupRoot() - Method in interface akka.actor.ActorRefFactory
INTERNAL API
lowerBound() - Method in class akka.routing.DefaultResizer
The fewest number of routees the router should ever have.

M

mailbox() - Method in class akka.actor.Deploy
 
mailbox() - Method in class akka.actor.Props
Convenience method for extracting the mailbox information from the contained Deploy instance.
mailbox() - Method in interface akka.actor.UnrestrictedStash
 
mailboxes() - Method in class akka.actor.ActorSystem
Helper object for looking up configured mailbox types.
mailboxes() - Method in interface akka.dispatch.DispatcherPrerequisites
 
mailboxes() - Method in class akka.dispatch.MessageDispatcher
 
Mailboxes$ - Class in akka.dispatch
 
Mailboxes$() - Constructor for class akka.dispatch.Mailboxes$
 
MailboxType - Interface in akka.dispatch
MailboxType is a factory to create MessageQueues for an optionally provided ActorContext.
Main - Class in akka
Copyright (C) 2009-2013 Typesafe Inc.
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
Copyright (C) 2009-2013 Typesafe Inc.
Main$() - Constructor for class akka.Main$
 
Main.Terminator - Class in akka
 
Main.Terminator(ActorRef) - Constructor for class akka.Main.Terminator
 
makeCommand(CmdBelow) - Method in class akka.io.AbstractPipePair
Helper method for wrapping a command which shall be emitted.
makeContext(ActorContext) - Method in class akka.io.TcpPipelineHandler.Init
This method must be implemented to return the PipelineContext necessary for the operation of the given PipelineStage.
makeDecider(Seq<Class<? extends Throwable>>) - Method in class akka.actor.SupervisorStrategy$
Decider builder which just checks whether one of the given Throwables matches the cause and restarts, otherwise escalates.
makeDecider(Iterable<Class<? extends Throwable>>) - Method in class akka.actor.SupervisorStrategy$
Decider builder which just checks whether one of the given Throwables matches the cause and restarts, otherwise escalates.
makeDecider(Iterable<Tuple2<Class<? extends Throwable>, SupervisorStrategy.Directive>>) - Method in class akka.actor.SupervisorStrategy$
Decider builder for Iterables of cause-directive pairs, e.g. a map obtained from configuration; will sort the pairs so that the most specific type is checked before all its subtypes, allowing carving out subtrees of the Throwable hierarchy.
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. a map obtained from configuration; will sort the pairs so that the most specific type is checked before all its subtypes, allowing carving out subtrees of the Throwable hierarchy.
makeDecider(Function<Throwable, SupervisorStrategy.Directive>) - Static method in class akka.actor.SupervisorStrategy
Converts a Java Decider into a Scala Decider
makeEvent(EvtAbove) - Method in class akka.io.AbstractPipePair
Helper method for wrapping an event which shall be emitted.
makePattern(String) - Method in class akka.util.Helpers$
 
makePattern(String) - Static method in class akka.util.Helpers
 
makeTransition(FSM.State<S, D>) - Method in interface akka.actor.FSM
 
management() - Method in class akka.io.PipelinePorts
 
managementCommand(Object) - Method in interface akka.io.PipelineInjector
Send a management command to all stages (in an unspecified order).
ManagementDispatcher() - Method in class akka.io.TcpExt.Settings
 
managementPort() - Method in interface akka.io.PipePair
The management port allows sending broadcast messages to all stages within this pipeline.
manager() - Method in interface akka.io.IO.Extension
 
manager() - Method in class akka.io.TcpExt
 
manager() - Method in class akka.io.UdpConnectedExt
 
manager() - Method in class akka.io.UdpExt
 
map(Function1<A, B>) - Method in class akka.actor.IO.Iteratee
Applies a function to transform the result of this Iteratee.
map(Function1<A, A>) - Method in interface akka.actor.IO.IterateeRef
 
map(Function1<A, A>) - Method in class akka.actor.IO.IterateeRefAsync
 
map(Function1<A, A>) - Method in class akka.actor.IO.IterateeRefSync
 
mapI(Function1<Object, Object>) - Method in class akka.util.ByteString
map method that will automatically cast Int back into Byte.
Mapper<T,R> - Class in akka.dispatch
Callback for the Future.map and Future.flatMap operations that will be invoked if the Future that this callback is registered on becomes completed with a success.
Mapper() - Constructor for class akka.dispatch.Mapper
 
mappings() - Method in interface akka.event.ActorClassification
 
mapSize() - Method in interface akka.event.ActorClassification
This is a size hint for the number of Classifiers you expect to have (use powers of 2)
mapSize() - Method in interface akka.event.LookupClassification
This is a size hint for the number of Classifiers you expect to have (use powers of 2)
mapSize() - Method in class akka.util.Index
 
matches(akka.event.EventBus.Classifier, akka.event.EventBus.Event) - Method in interface akka.event.ScanningClassification
Returns whether the specified Classifier matches the specified Event
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
 
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. the inverse of the minimum time interval between executions of a recurring task, in Hz.
maxFrequency() - Method in class akka.actor.DefaultScheduler
 
maxFrequency() - Method in class akka.actor.LightArrayRevolverScheduler
 
maxFrequency() - Method in interface akka.actor.Scheduler
The maximum supported task frequency of this scheduler, i.e. the inverse of the minimum time interval between executions of a recurring task, in Hz.
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
 
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
 
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.Actor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorDSL$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorIdentity$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorInitializationException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorKilledException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.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.ActorSelection$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ActorSystem$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Address$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.AddressFromURIString$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.AllForOneStrategy$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ChildRestartStats$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ContextualTypedActorFactory$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.DeadLetter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.DeathPactException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Deploy$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.FSM$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Identify$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.IllegalActorStateException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Inbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.InvalidActorNameException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.InvalidMessageException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.IO$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.IOManager$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Kill$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.LightArrayRevolverScheduler$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.LocalScope$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.NoScopeGiven$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.OneForOneStrategy$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.OriginalRestartException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.PoisonPill$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.PostRestartException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.PreRestartException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Props$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ReceiveTimeout$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.RelativeActorPath$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.RootActorPath$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.StashOverflowException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Status$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.SupervisorStrategy$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Terminated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.TypedActor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.TypedProps$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.UnhandledMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.BoundedDequeBasedMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.BoundedMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.BoundedPriorityMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.Dispatchers$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.Envelope$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.ExecutionContexts$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.Filter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.ForkJoinExecutorConfigurator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.Futures$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.japi$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.Mailboxes$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.MonitorableThreadFactory$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.PriorityGenerator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.SingleConsumerOnlyUnboundedMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.sysmsg.EarliestFirstSystemMessageList$
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.SystemMessageList$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.TaskInvocation$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.ThreadPoolConfig$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.ThreadPoolConfigBuilder$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.UnboundedDequeBasedMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.UnboundedMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.UnboundedPriorityMailbox$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.EventStream$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.Logging$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.LoggingReceive$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.LogSource$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.NoLogging$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.BackpressureBuffer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.DelimiterFraming$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Inet$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.IO$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.LengthFieldFrame$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.PipelineFactory$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.PipelinePorts$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.PipelineStage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.PipePairFactory$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.SslTlsSupport$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.StringByteStringAdapter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Tcp$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.TcpMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.TcpPipelineHandler$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.TcpSO$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.TickGenerator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.Udp$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.UdpConnected$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.UdpConnectedMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.UdpMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.io.UdpSO$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.JavaPartialFunction$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.Option$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.Util$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.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.routing.Broadcast$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.BroadcastRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ConsistentHash$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ConsistentHashingRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.CurrentRoutees$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.Deafen$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.DefaultResizer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.Destination$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.FromConfig$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.Listen$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.MurmurHash$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.NoRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RandomRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RoundRobinRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RouterRoutees$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ScatterGatherFirstCompletedRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.SmallestMailboxRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.WithListeners$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.serialization.JavaSerializer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.serialization.NullSerializer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.serialization.Serialization$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.serialization.SerializationExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.BoxedType$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.ByteIterator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.ByteString$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.CompactByteString$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.Crypt$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.HashCode$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.Helpers$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.Switch$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.Timeout$
Static reference to the singleton instance of this Scala object.
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
 
msg() - Method in class akka.io.TcpPipelineHandler.Tell
 
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
 
newThread(ForkJoinPool) - Method in class akka.dispatch.MonitorableThreadFactory
 
newThread(Runnable) - Method in class akka.dispatch.MonitorableThreadFactory
 
newTimeout(TimerTask, FiniteDuration) - Method in class akka.util.internal.HashedWheelTimer
Deprecated.  
newTimeout(TimerTask, FiniteDuration) - Method in interface akka.util.internal.Timer
Deprecated. Schedules the specified TimerTask for one-time execution after the specified delay.
next() - Method in class akka.actor.LightArrayRevolverScheduler.TaskHolder
 
next() - Method in class akka.dispatch.AbstractNodeQueue.Node
 
next() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
next() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
next() - Method in class akka.util.ByteIterator
 
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 WriteCommand can optionally request a positive acknowledgment to be sent to the commanding actor.
noAck() - Method in class akka.io.TcpMessage$
Default NoAck instance which is used when no acknowledgment information is explicitly provided.
noAck(Object) - Static method in class akka.io.TcpMessage
Each WriteCommand can optionally request a positive acknowledgment to be sent to the commanding actor.
noAck() - Static method in class akka.io.TcpMessage
Default NoAck instance which is used when no acknowledgment information is explicitly provided.
noAck(Object) - Method in class akka.io.UdpConnectedMessage$
Each Send can optionally request a positive acknowledgment to be sent to the commanding actor.
noAck() - Method in class akka.io.UdpConnectedMessage$
Default NoAck instance which is used when no acknowledgment information is explicitly provided.
noAck(Object) - Static method in class akka.io.UdpConnectedMessage
Each Send can optionally request a positive acknowledgment to be sent to the commanding actor.
noAck() - Static method in class akka.io.UdpConnectedMessage
Default NoAck instance which is used when no acknowledgment information is explicitly provided.
noAck(Object) - Method in class akka.io.UdpMessage$
Each Send can optionally request a positive acknowledgment to be sent to the commanding actor.
noAck() - Method in class akka.io.UdpMessage$
Default NoAck instance which is used when no acknowledgment information is explicitly provided.
noAck(Object) - Static method in class akka.io.UdpMessage
Each Send can optionally request a positive acknowledgment to be sent to the commanding actor.
noAck() - Static method in class akka.io.UdpMessage
Default NoAck instance which is used when no acknowledgment information is explicitly provided.
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
 
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
nonEmpty() - Method in class akka.dispatch.sysmsg.EarliestFirstSystemMessageList
Indicates if the list has at least one element or not.
nonEmpty() - Method in class akka.dispatch.sysmsg.LatestFirstSystemMessageList
Indicates if the list has at least one element or not.
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 "!"
noSender() - Method in interface akka.actor.Actor
Default placeholder (null) used for "!"
NoSerializationVerificationNeeded - Interface in akka.actor
Marker trait to signal that this class should not be verified for serializability.
nothing() - Method in interface akka.io.PipelineContext
A shared (and shareable) instance of an empty Iterable[Either[EvtAbove, CmdBelow}.
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 interface akka.routing.BroadcastLike
 
nrOfInstances() - Method in class akka.routing.BroadcastRouter
 
nrOfInstances() - Method in interface akka.routing.ConsistentHashingLike
 
nrOfInstances() - Method in class akka.routing.ConsistentHashingRouter
 
nrOfInstances() - Method in interface akka.routing.RandomLike
 
nrOfInstances() - Method in class akka.routing.RandomRouter
 
nrOfInstances() - Method in interface akka.routing.RoundRobinLike
 
nrOfInstances() - Method in class akka.routing.RoundRobinRouter
 
nrOfInstances() - Method in interface akka.routing.ScatterGatherFirstCompletedLike
 
nrOfInstances() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
nrOfInstances() - Method in interface akka.routing.SmallestMailboxLike
 
nrOfInstances() - Method in class akka.routing.SmallestMailboxRouter
 
NrOfSelectors() - Method in class akka.io.TcpExt.Settings
 
nullAsBytes() - Method in class akka.serialization.NullSerializer
 
NullSerializer - Class in akka.serialization
This is a special Serializer that Serializes and deserializes nulls only
NullSerializer() - Constructor for class akka.serialization.NullSerializer
 
NullSerializer$ - Class in akka.serialization
 
NullSerializer$() - Constructor for class akka.serialization.NullSerializer$
 
num() - Method in class akka.io.BackpressureBuffer.Ack
 
numberOfConnections() - Method in class akka.actor.IO.Backlog
 
numberOfMessages() - Method in interface akka.dispatch.MessageQueue
Should return the current number of messages held in this queue; may always return 0 if no other value is available efficiently.
numberOfMessages() - Method in class akka.dispatch.NodeMessageQueue
 
numberOfMessages() - Method in interface akka.dispatch.QueueBasedMessageQueue
 
numberOfMessages(ActorRef) - Method in interface akka.routing.SmallestMailboxLike
Returns the number of pending messages in the mailbox of the actor.

O

offer(E) - Method in class akka.util.BoundedBlockingQueue
 
offer(E, long, TimeUnit) - Method in class akka.util.BoundedBlockingQueue
 
on() - Method in class akka.actor.IO.KeepAlive
 
on() - Method in class akka.actor.IO.OOBInline
 
on() - Method in class akka.actor.IO.ReuseAddress
 
on() - Method in class akka.actor.IO.TcpNoDelay
 
on() - Method in class akka.io.Inet.SO$.ReuseAddress
 
on() - Method in class akka.io.Tcp.SO$.KeepAlive
 
on() - Method in class akka.io.Tcp.SO$.OOBInline
 
on() - Method in class akka.io.Tcp.SO$.TcpNoDelay
 
on() - Method in class akka.io.Udp.SO$.Broadcast
 
onClose(Function0<BoxedUnit>) - Method in class akka.pattern.CircuitBreaker
Adds a callback to execute when circuit breaker state closes The callback is run in the ExecutionContext supplied in the constructor.
onClose(Runnable) - Method in class akka.pattern.CircuitBreaker
JavaAPI for onClose
onCommand(CmdAbove) - Method in class akka.io.AbstractPipePair
Commands reaching this pipe pair are transformed into a sequence of commands for the next or events for the previous stage.
onCommand(Cmd) - Method in class akka.io.PipelineSink
This callback is invoked for every command generated by the pipeline.
onCommandFailure(Throwable) - Method in class akka.io.PipelineSink
This callback is invoked if an exception occurred while processing an injected command.
OnComplete<T> - Class in akka.dispatch
Callback for when a Future is completed with either failure or a success SAM (Single Abstract Method) class Java API
OnComplete() - Constructor for class akka.dispatch.OnComplete
 
onComplete(Throwable, T) - Method in class akka.dispatch.OnComplete
This method will be invoked once when/if a Future that this callback is registered on becomes completed with a failure or a success.
OneForOneStrategy() - Method in interface akka.actor.dsl.Creators.Act
 
OneForOneStrategy - Class in akka.actor
Applies the fault handling Directive (Resume, Restart, Stop) specified in the Decider to the child actor that failed, as opposed to AllForOneStrategy that applies it to all children.
OneForOneStrategy(int, Duration, boolean, PartialFunction<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.OneForOneStrategy
 
OneForOneStrategy(int, Duration, Function<Throwable, SupervisorStrategy.Directive>, boolean) - Constructor for class akka.actor.OneForOneStrategy
 
OneForOneStrategy(int, Duration, Function<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.OneForOneStrategy
 
OneForOneStrategy(int, Duration, Iterable<Class<? extends Throwable>>) - Constructor for class akka.actor.OneForOneStrategy
 
OneForOneStrategy$ - Class in akka.actor
 
OneForOneStrategy$() - Constructor for class akka.actor.OneForOneStrategy$
 
onEvent(EvtBelow) - Method in class akka.io.AbstractPipePair
Events reaching this pipe pair are transformed into a sequence of commands for the next or events for the previous stage.
onEvent(Evt) - Method in class akka.io.PipelineSink
This callback is invoked for every event generated by the pipeline.
onEventFailure(Throwable) - Method in class akka.io.PipelineSink
This callback is invoked if an exception occurred while processing an injected event.
OnFailure - Class in akka.dispatch
Callback for when a Future is completed with a failure SAM (Single Abstract Method) class Java API
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 The callback is run in the ExecutionContext supplied in the constructor.
onHalfOpen(Runnable) - Method in class akka.pattern.CircuitBreaker
JavaAPI for onHalfOpen
OnlyCauseStackTrace - Interface in akka
Mix in this trait to suppress the StackTrace for the instance of the exception but not the cause, scala.util.control.NoStackTrace suppresses all the StackTraces.
onManagementCommand(Object) - Method in class akka.io.AbstractPipePair
Management commands are sent to all stages in a broadcast fashion, conceptually in parallel (but not actually executing a stage reentrantly in case of events or commands being generated in response to a management command).
onOpen(Function0<BoxedUnit>) - Method in class akka.pattern.CircuitBreaker
Adds a callback to execute when circuit breaker opens The callback is run in the ExecutionContext supplied in the constructor.
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 Java API
OnSuccess() - Constructor for class akka.dispatch.OnSuccess
 
onSuccess(T) - Method in class akka.dispatch.OnSuccess
This method will be invoked once when/if a Future that this callback is registered on becomes successfully completed
onTermination(PartialFunction<FSM.StopEvent, BoxedUnit>) - Method in interface akka.actor.FSM
Set handler which is called upon termination of this FSM actor.
onTransition(PartialFunction<Tuple2<S, S>, BoxedUnit>) - Method in interface akka.actor.FSM
Set handler which is called upon each state transition, i.e. not when staying in the same state.
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.
Option<A> - Class in akka.japi
This class represents optional values.
Option() - Constructor for class akka.japi.Option
 
option(A) - Method in class akka.japi.Option$
Option factory that creates None if v is null, Some(v) otherwise.
option(A) - Static method in class akka.japi.Option
Option factory that creates None if v is null, Some(v) otherwise.
Option$ - Class in akka.japi
 
Option$() - Constructor for class akka.japi.Option$
 
Option.Some<A> - Class in akka.japi
Class Some[A] represents existing values of type A.
Option.Some(A) - Constructor for class akka.japi.Option.Some
 
Option.Some$ - Class in akka.japi
 
Option.Some$() - Constructor for class akka.japi.Option.Some$
 
options() - Method in class akka.actor.IO.Accept
 
options() - Method in class akka.actor.IO.Connect
 
options() - Method in class akka.actor.IO.Listen
 
options() - Method in class akka.io.Tcp.Bind
 
options() - Method in class akka.io.Tcp.Connect
 
options() - Method in class akka.io.Udp.Bind
 
options() - Method in class akka.io.Udp.SimpleSender
 
options() - Method in class akka.io.UdpConnected.Connect
 
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. the first failure) from a PostRestartException.
OriginalRestartException() - Constructor for class akka.actor.OriginalRestartException
 
OriginalRestartException$ - Class in akka.actor
This is an extractor for retrieving the original cause (i.e. the first failure) from a PostRestartException.
OriginalRestartException$() - Constructor for class akka.actor.OriginalRestartException$
 
owner() - Method in interface akka.actor.IO.Handle
 
owner() - Method in class akka.actor.IO.ServerHandle
 
owner() - Method in class akka.actor.IO.SocketHandle
 

P

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.event.Logging.StandardOutLogger
 
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(int) - Method in class akka.actor.IO$
An Iteratee that returns a ByteString of the request length, but does not consume the Input.
peek(int) - Static method in class akka.actor.IO
An Iteratee that returns a ByteString of the request length, but does not consume the Input.
peek() - Method in class akka.dispatch.AbstractNodeQueue
 
peek() - Method in class akka.util.BoundedBlockingQueue
 
peekNode() - Method in class akka.dispatch.AbstractNodeQueue
 
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 actor reference.
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 actor reference.
pipe(Future<T>, ExecutionContext) - Method in interface akka.pattern.PipeToSupport
Import this implicit conversion to gain the pipeTo method on Future: import akka.pattern.pipe Future { doExpensiveCalc() } pipeTo nextActor or pipe(someFuture) to nextActor
PipelineContext - Interface in akka.io
This base trait of each pipeline’s context provides optimized facilities for generating single commands or events (i.e. the fast common case of 1:1 message transformations).
PipelineFactory - Class in akka.io
This class contains static factory methods which turn a pipeline context and a PipelineStage into readily usable pipelines.
PipelineFactory() - Constructor for class akka.io.PipelineFactory
 
PipelineFactory$ - Class in akka.io
This class contains static factory methods which turn a pipeline context and a PipelineStage into readily usable pipelines.
PipelineFactory$() - Constructor for class akka.io.PipelineFactory$
 
PipelineInjector<Cmd,Evt> - Interface in akka.io
A handle for injecting commands and events into a pipeline.
PipelinePorts<CmdAbove,CmdBelow,EvtAbove,EvtBelow> - Class in akka.io
 
PipelinePorts(Function1<CmdAbove, Tuple2<Iterable<EvtAbove>, Iterable<CmdBelow>>>, Function1<EvtBelow, Tuple2<Iterable<EvtAbove>, Iterable<CmdBelow>>>, PartialFunction<Object, Tuple2<Iterable<EvtAbove>, Iterable<CmdBelow>>>) - Constructor for class akka.io.PipelinePorts
 
PipelinePorts$ - Class in akka.io
 
PipelinePorts$() - Constructor for class akka.io.PipelinePorts$
 
PipelineSink<Cmd,Evt> - Class in akka.io
A sink which can be attached by PipelineFactory.buildWithSink(Ctx, akka.io.PipelineStage, akka.io.PipelineSink) to a pipeline when it is being built.
PipelineSink() - Constructor for class akka.io.PipelineSink
 
PipelineStage<Context extends PipelineContext,CmdAbove,CmdBelow,EvtAbove,EvtBelow> - Class in akka.io
A pipeline stage which can be combined with other stages to build a protocol stack.
PipelineStage() - Constructor for class akka.io.PipelineStage
 
PipelineStage$ - Class in akka.io
 
PipelineStage$() - Constructor for class akka.io.PipelineStage$
 
PipePair<CmdAbove,CmdBelow,EvtAbove,EvtBelow> - Interface in akka.io
Scala API: A pair of pipes, one for commands and one for events, plus a management port.
PipePairFactory - Class in akka.io
This class contains static factory methods which produce PipePair instances; those are needed within the implementation of PipelineStage.apply(Context).
PipePairFactory() - Constructor for class akka.io.PipePairFactory
 
PipePairFactory$ - Class in akka.io
This class contains static factory methods which produce PipePair instances; those are needed within the implementation of PipelineStage.apply(Context).
PipePairFactory$() - Constructor for class akka.io.PipePairFactory$
 
pipes() - Method in class akka.io.TcpPipelineHandler
 
pipeTo(ActorRef, ActorRef) - Method in class akka.pattern.PipeToSupport.PipeableFuture
 
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
 
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().
PostRestartException - Exception in akka.actor
A PostRestartException is thrown when constructor or postRestart() method fails during a restart attempt.
PostRestartException$ - Class in akka.actor
 
PostRestartException$() - Constructor for class akka.actor.PostRestartException$
 
postStop() - Method in interface akka.actor.Actor
User overridable callback.
postStop() - Method in interface akka.actor.dsl.Creators.Act
 
postStop() - Method in interface akka.actor.FSM
Call onTermination hook; if you want to retain this behavior when overriding make sure to call super.postStop().
postStop() - Method in class akka.actor.IOManagerActor
 
postStop() - Method in interface akka.actor.TypedActor.PostStop
User overridable callback.
postStop() - Method in interface akka.actor.UnrestrictedStash
Overridden callback.
postStop() - Method in class akka.actor.UntypedActor
User overridable callback.
predicate() - Method in class akka.actor.dsl.Inbox.Select
 
PredicateClassifier - Interface in akka.event
Can be mixed into an EventBus to specify that the Classifier type is a Function from Event to Boolean (predicate)
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().'''
preRestart(Throwable, Option<Object>) - Method in interface akka.routing.Router
 
PreRestartException - Exception in akka.actor
A PreRestartException is thrown when the preRestart() method failed; this exception is not propagated to the supervisor, as it originates from the already failed instance, hence it is only visible as log entry on the event stream.
PreRestartException$ - Class in akka.actor
 
PreRestartException$() - Constructor for class akka.actor.PreRestartException$
 
pressure(IndexedSeq<ActorRef>) - Method in class akka.routing.DefaultResizer
Number of routees considered busy, or above 'pressure level'.
pressureThreshold() - Method in class akka.routing.DefaultResizer
Threshold to evaluate if routee is considered to be busy (under pressure).
preStart() - Method in interface akka.actor.Actor
User overridable callback.
preStart() - Method in interface akka.actor.dsl.Creators.Act
 
preStart() - Method in interface akka.actor.TypedActor.PreStart
User overridable callback.
preStart() - Method in class akka.actor.UntypedActor
User overridable callback.
print(Object) - Method in interface akka.event.Logging.StdOutLogger
 
printActors() - Static method in class akka.dispatch.MessageDispatcher
 
printedWarning() - Method in class akka.actor.dsl.Inbox.InboxActor
 
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, Object) - Method in interface akka.actor.FSM
 
processEvent(FSM.Event, Object) - Method in interface akka.actor.LoggingFSM
 
processFailure(ActorContext, boolean, ActorRef, Throwable, ChildRestartStats, Iterable<ChildRestartStats>) - Method in class akka.actor.AllForOneStrategy
 
processFailure(ActorContext, boolean, ActorRef, Throwable, ChildRestartStats, Iterable<ChildRestartStats>) - Method in class akka.actor.OneForOneStrategy
 
processFailure(ActorContext, boolean, ActorRef, Throwable, ChildRestartStats, Iterable<ChildRestartStats>) - Method in class akka.actor.SupervisorStrategy
This method is called to act on the failure of a child: restart if the flag is true, stop otherwise.
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.
props() - Method in interface akka.actor.ActorContext
Retrieve the Props which were used to create this actor.
Props - Class in akka.actor
Props is a configuration object using in creating an Actor; it is immutable, so it is thread-safe and fully shareable.
Props(Deploy, Class<?>, Seq<Object>) - Constructor for class akka.actor.Props
 
Props() - Constructor for class akka.actor.Props
Deprecated. use Props.create(clazz, args ...) instead
Props(UntypedActorFactory) - Constructor for class akka.actor.Props
Deprecated. use Props.create(clazz, args ...) instead; this method has been deprecated because it encourages creating Props which contain non-serializable inner classes, making them also non-serializable
Props(Class<? extends Actor>) - Constructor for class akka.actor.Props
Deprecated. use Props.create(clazz) instead; deprecated since it duplicates another API
props(TcpPipelineHandler.Init<Ctx, Cmd, Evt>, ActorRef, ActorRef) - Method in class akka.io.TcpPipelineHandler$
create Props for a pipeline handler
props(TcpPipelineHandler.Init<Ctx, Cmd, Evt>, ActorRef, ActorRef) - Static method in class akka.io.TcpPipelineHandler
create Props for a pipeline handler
Props$ - Class in akka.actor
 
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.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(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
 
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
 
RandomLike - Interface in akka.routing
The core pieces of the routing logic is located in this trait to be able to extend.
RandomRouter - Class in akka.routing
A Router that randomly selects one of the target connections to send a message to.
RandomRouter(int, Iterable<String>, Option<Resizer>, String, SupervisorStrategy) - Constructor for class akka.routing.RandomRouter
 
RandomRouter(int) - Constructor for class akka.routing.RandomRouter
Java API: Constructor that sets nrOfInstances to be created.
RandomRouter(Iterable<String>) - Constructor for class akka.routing.RandomRouter
Java API: Constructor that sets the routees to be used.
RandomRouter(Resizer) - Constructor for class akka.routing.RandomRouter
Java API: Constructor that sets the resizer to be used.
RandomRouter$ - Class in akka.routing
 
RandomRouter$() - Constructor for class akka.routing.RandomRouter$
 
readBufferSize() - Method in class akka.actor.IOManager.Settings
 
reason() - Method in class akka.actor.FSM.StopEvent
 
receive() - Method in interface akka.actor.Actor
This defines the initial actor behavior, it must return a partial function with the actor logic.
receive() - Method in interface akka.actor.dsl.Creators.Act
Default behavior of the actor is empty, use become to change this.
receive(FiniteDuration) - Method in class akka.actor.dsl.Inbox.Inbox
Receive a single message from the internal receiver actor.
receive() - Method in class akka.actor.dsl.Inbox.InboxActor
 
receive() - Method in interface akka.actor.FSM
 
receive(FiniteDuration) - Method in class akka.actor.Inbox
Receive the next message from this Inbox.
receive() - Method in class akka.actor.IOManagerActor
 
receive() - Method in class akka.actor.UntypedActor
 
receive() - Method in class akka.event.Logging.DefaultLogger
 
receive() - Method in class akka.io.TcpPipelineHandler
 
receive() - Method in class akka.Main.Terminator
 
receive() - Method in interface akka.routing.Router
 
ReceiveBufferSize() - Method in interface akka.io.Inet.SoForwarders
akka.io.Tcp.SocketOption to set the SO_RCVBUF option For more information see java.net.Socket.setReceiveBufferSize
receiveBufferSize(int) - Method in interface akka.io.Inet.SoJavaFactories
akka.io.Tcp.SocketOption to set the SO_RCVBUF option For more information see java.net.Socket.setReceiveBufferSize
ReceivedMessageSizeLimit() - Method in class akka.io.TcpExt.Settings
 
receiver() - Method in class akka.actor.dsl.Inbox.Inbox
 
receiver() - Method in class akka.io.TcpPipelineHandler.Tell
 
receiveTimeout() - Method in interface akka.actor.ActorContext
Gets the current receive timeout.
ReceiveTimeout - Class in akka.actor
 
ReceiveTimeout() - Constructor for class akka.actor.ReceiveTimeout
 
ReceiveTimeout$ - Class in akka.actor
When using ActorContext.setReceiveTimeout, the singleton instance of ReceiveTimeout will be sent to the Actor when there hasn't been any message for that long.
ReceiveTimeout$() - Constructor for class akka.actor.ReceiveTimeout$
 
recipient() - Method in class akka.actor.DeadLetter
 
recipient() - Method in class akka.actor.UnhandledMessage
 
recipient() - Method in class akka.routing.Destination
 
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.
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 interface akka.routing.Router
 
ReflectiveDynamicAccess - Class in akka.actor
This is the default DynamicAccess implementation used by ActorSystemImpl unless overridden.
ReflectiveDynamicAccess(ClassLoader) - Constructor for class akka.actor.ReflectiveDynamicAccess
 
register(S, PartialFunction<FSM.Event, 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 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 Connected message.
register(ActorRef) - Static method in class akka.io.TcpMessage
The same as register(handler, false, false).
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 INTERNAL API
registerForExecution(Mailbox, boolean, boolean) - Method in class akka.dispatch.MessageDispatcher
Suggest to register the provided mailbox for execution INTERNAL API
registerOnTermination(Function0<T>) - Method in class akka.actor.ActorSystem
Register a block of code (callback) to run after ActorSystem.shutdown has been issued and all actors in this actor system have been stopped.
registerOnTermination(Runnable) - Method in class akka.actor.ActorSystem
Java API: Register a block of code (callback) to run after ActorSystem.shutdown has been issued and all actors in this actor system have been stopped.
registerRoutees(Iterable<ActorRef>) - Method in class akka.routing.RouteeProvider
Adds the routees to the router.
registerRoutees(Iterable<ActorRef>) - Method in class akka.routing.RouteeProvider
Java API: Adds the routees to the router.
registerRouteesFor(Iterable<String>) - Method in class akka.routing.RouteeProvider
Looks up routes with specified paths and registers them.
registerRouteesFor(Iterable<String>) - Method in class akka.routing.RouteeProvider
Java API: Looks up routes with specified paths and registers them.
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
 
removeRoutees(int, FiniteDuration) - Method in class akka.routing.RouteeProvider
Remove specified number of routees by unregister them and sending PoisonPill after the specified delay.
removeValue(V) - Method in class akka.util.Index
Removes the specified value from all keys
repeat() - Method in class akka.actor.FSM.Timer
 
repeat(IO.Iteratee<T>) - Method in class akka.actor.IO$
An Iteratee that continually repeats an Iteratee.
repeat(IO.Iteratee<T>) - Static method in class akka.actor.IO
An Iteratee that continually repeats an Iteratee.
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.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() - Static method in class akka.dispatch.MessageDispatcher
 
resize(RouteeProvider) - Method in class akka.routing.DefaultResizer
 
resize(RouteeProvider) - Method in interface akka.routing.Resizer
Decide if the capacity of the router need to be changed.
resizer() - Method in class akka.routing.BroadcastRouter
 
resizer() - Method in class akka.routing.ConsistentHashingRouter
 
resizer() - Method in class akka.routing.RandomRouter
 
Resizer - Interface in akka.routing
Routers with dynamically resizable number of routees is implemented by providing a Resizer implementation in RouterConfig.
resizer() - Method in class akka.routing.RoundRobinRouter
 
resizer() - Method in class akka.routing.RouteeProvider
 
resizer() - Method in interface akka.routing.RouterConfig
Routers with dynamically resizable number of routees return the Resizer to use.
resizer() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
resizer() - Method in class akka.routing.SmallestMailboxRouter
 
resolveActorRef(String) - Method in interface akka.actor.ActorRefProvider
Create actor reference for a specified path.
resolveActorRef(ActorPath) - Method in interface akka.actor.ActorRefProvider
Create actor reference for a specified path.
resolveClass(ObjectStreamClass) - Method in class akka.util.ClassLoaderObjectInputStream
 
Restart() - Method in interface akka.actor.dsl.Creators.Act
 
restart() - Method in class akka.actor.SupervisorStrategy$
Java API: Returning this directive discards the old Actor instance and replaces it with a new, then resumes message processing.
restart() - Static method in class akka.actor.SupervisorStrategy
Java API: Returning this directive discards the old Actor instance and replaces it with a new, then resumes message processing.
restartChild(ActorRef, Throwable, boolean) - Method in class akka.actor.SupervisorStrategy
Restart the given child, possibly suspending it first.
restartTimeWindowStartNanos() - Method in class akka.actor.ChildRestartStats
 
result() - Method in class akka.actor.IO.Done
 
result() - 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
 
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 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 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 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 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 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 SuspendReading command.
resumeWriting() - Method in class akka.io.TcpMessage$
When useResumeWriting is in effect as was indicated in the Register message then this command needs to be sent to the connection actor in order to re-enable writing after a CommandFailed event.
resumeWriting() - Static method in class akka.io.TcpMessage
When useResumeWriting is in effect as was indicated in the Register message then this command needs to be sent to the connection actor in order to re-enable writing after a 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
akka.io.Tcp.SocketOption to enable or disable SO_REUSEADDR For more information see java.net.Socket.setReuseAddress
reuseAddress(boolean) - Method in interface akka.io.Inet.SoJavaFactories
akka.io.Tcp.SocketOption to enable or disable SO_REUSEADDR For more information see java.net.Socket.setReuseAddress
reverse() - Method in class akka.dispatch.sysmsg.EarliestFirstSystemMessageList
Reverses the list.
reverse() - Method in class akka.dispatch.sysmsg.LatestFirstSystemMessageList
Reverses the list.
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.
RoundRobinLike - Interface in akka.routing
The core pieces of the routing logic is located in this trait to be able to extend.
RoundRobinRouter - Class in akka.routing
A Router that uses round-robin to select a connection.
RoundRobinRouter(int, Iterable<String>, Option<Resizer>, String, SupervisorStrategy) - Constructor for class akka.routing.RoundRobinRouter
 
RoundRobinRouter(int) - Constructor for class akka.routing.RoundRobinRouter
Java API: Constructor that sets nrOfInstances to be created.
RoundRobinRouter(Iterable<String>) - Constructor for class akka.routing.RoundRobinRouter
Java API: Constructor that sets the routees to be used.
RoundRobinRouter(Resizer) - Constructor for class akka.routing.RoundRobinRouter
Java API: Constructor that sets the resizer to be used.
RoundRobinRouter$ - Class in akka.routing
 
RoundRobinRouter$() - Constructor for class akka.routing.RoundRobinRouter$
 
rounds() - Method in class akka.actor.LightArrayRevolverScheduler.TaskHolder
 
routeeProps() - Method in class akka.routing.RouteeProvider
 
RouteeProvider - Class in akka.routing
Factory and registry for routees of the router.
RouteeProvider(ActorContext, Props, Option<Resizer>) - Constructor for class akka.routing.RouteeProvider
 
routees() - Method in interface akka.routing.BroadcastLike
 
routees() - Method in class akka.routing.BroadcastRouter
 
routees() - Method in interface akka.routing.ConsistentHashingLike
 
routees() - Method in class akka.routing.ConsistentHashingRouter
 
routees() - Method in interface akka.routing.RandomLike
 
routees() - Method in class akka.routing.RandomRouter
 
routees() - Method in interface akka.routing.RoundRobinLike
 
routees() - Method in class akka.routing.RoundRobinRouter
 
routees() - Method in class akka.routing.RouteeProvider
All routees of the router
routees() - Method in class akka.routing.RouterRoutees
 
routees() - Method in interface akka.routing.ScatterGatherFirstCompletedLike
 
routees() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
routees() - Method in interface akka.routing.SmallestMailboxLike
 
routees() - Method in class akka.routing.SmallestMailboxRouter
 
Router - Interface in akka.routing
Base trait for Router actors.
Router.Resize$ - Class in akka.routing
 
Router.Resize$() - Constructor for class akka.routing.Router.Resize$
 
routerConfig() - Method in class akka.actor.Deploy
 
routerConfig() - Method in class akka.actor.Props
Convenience method for extracting the router configuration from the contained Deploy instance.
RouterConfig - Interface in akka.routing
This trait represents a router factory: it produces the actual router actor and creates the routing table (a function which determines the recipients for each message which is to be dispatched).
routerDispatcher() - Method in class akka.routing.BroadcastRouter
 
routerDispatcher() - Method in class akka.routing.ConsistentHashingRouter
 
routerDispatcher() - Method in class akka.routing.FromConfig
 
routerDispatcher() - Method in class akka.routing.NoRouter$
 
routerDispatcher() - Static method in class akka.routing.NoRouter
 
routerDispatcher() - Method in class akka.routing.RandomRouter
 
routerDispatcher() - Method in class akka.routing.RoundRobinRouter
 
routerDispatcher() - Method in interface akka.routing.RouterConfig
Dispatcher ID to use for running the “head” actor, i.e. the Router.
routerDispatcher() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
routerDispatcher() - Method in class akka.routing.SmallestMailboxRouter
 
RouterEnvelope - Interface in akka.routing
Only the contained message will be forwarded to the destination, i.e. the envelope will be stripped off.
routerReceive() - Method in interface akka.routing.Router
 
RouterRoutees - Class in akka.routing
Message used to carry information about what routees the router is currently using.
RouterRoutees(Iterable<ActorRef>) - Constructor for class akka.routing.RouterRoutees
 
RouterRoutees$ - Class in akka.routing
 
RouterRoutees$() - Constructor for class akka.routing.RouterRoutees$
 
run() - Method in class akka.actor.LightArrayRevolverScheduler.TaskHolder
utility method to directly run the task, e.g. as clean-up action
run() - Method in class akka.dispatch.TaskInvocation
 
run(Timeout) - Method in interface akka.util.internal.TimerTask
Deprecated. Executed after the delay specified with Timer#newTimeout(TimerTask, long, java.util.concurrent.TimeUnit) .
runnable() - Method in class akka.dispatch.TaskInvocation
 

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 ..
ScalaActorSelection - Interface in akka.actor
Contains the Scala API (!
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 Note: the compareClassifiers and compareSubscribers must together form an absolute ordering (think java.util.Comparator.compare)
ScanningEventBus<E,S,C> - Class in akka.event.japi
See documentation for ScanningClassification E is the Event type S is the Subscriber type C is the Classifier type
ScanningEventBus() - Constructor for class akka.event.japi.ScanningEventBus
 
ScatterGatherFirstCompletedLike - Interface in akka.routing
The core pieces of the routing logic is located in this trait to be able to extend.
ScatterGatherFirstCompletedRouter - Class in akka.routing
Simple router that broadcasts the message to all routees, and replies with the first response.
ScatterGatherFirstCompletedRouter(int, Iterable<String>, FiniteDuration, Option<Resizer>, String, SupervisorStrategy) - Constructor for class akka.routing.ScatterGatherFirstCompletedRouter
 
ScatterGatherFirstCompletedRouter(int, FiniteDuration) - Constructor for class akka.routing.ScatterGatherFirstCompletedRouter
Java API: Constructor that sets nrOfInstances to be created.
ScatterGatherFirstCompletedRouter(Iterable<String>, FiniteDuration) - Constructor for class akka.routing.ScatterGatherFirstCompletedRouter
Java API: Constructor that sets the routees to be used.
ScatterGatherFirstCompletedRouter(Resizer, FiniteDuration) - Constructor for class akka.routing.ScatterGatherFirstCompletedRouter
Java API: Constructor that sets the resizer to be used.
ScatterGatherFirstCompletedRouter$ - Class in akka.routing
 
ScatterGatherFirstCompletedRouter$() - Constructor for class akka.routing.ScatterGatherFirstCompletedRouter$
 
schedule(FiniteDuration, FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.AbstractScheduler
Schedules a function to be run repeatedly with an initial delay and a frequency.
schedule(FiniteDuration, FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.DefaultScheduler
 
schedule(ActorRef, FiniteDuration) - Method in class akka.actor.FSM.Timer
 
schedule(FiniteDuration, FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.LightArrayRevolverScheduler
 
schedule(FiniteDuration, FiniteDuration, ActorRef, Object, ExecutionContext, ActorRef) - Method in interface akka.actor.Scheduler
Schedules a message to be sent repeatedly with an initial delay and frequency.
schedule(FiniteDuration, FiniteDuration, Function0<BoxedUnit>, ExecutionContext) - Method in interface akka.actor.Scheduler
Schedules a function to be run repeatedly with an initial delay and a frequency.
schedule(FiniteDuration, FiniteDuration, Runnable, ExecutionContext) - Method in interface akka.actor.Scheduler
Schedules a function to be run repeatedly with an initial delay and a frequency.
SCHEDULED() - Static method in class akka.dispatch.MessageDispatcher
 
scheduleOnce(FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.AbstractScheduler
Schedules a Runnable to be run once with a delay, i.e. a time period that has to pass before the runnable is executed.
scheduleOnce(FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.DefaultScheduler
 
scheduleOnce(FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.LightArrayRevolverScheduler
 
scheduleOnce(FiniteDuration, ActorRef, Object, ExecutionContext, ActorRef) - Method in interface akka.actor.Scheduler
Schedules a message to be sent once with a delay, i.e. a time period that has to pass before the message is sent.
scheduleOnce(FiniteDuration, Function0<BoxedUnit>, ExecutionContext) - Method in interface akka.actor.Scheduler
Schedules a function to be run once with a delay, i.e. a time period that has to pass before the function is run.
scheduleOnce(FiniteDuration, Runnable, ExecutionContext) - Method in interface akka.actor.Scheduler
Schedules a Runnable to be run once with a delay, i.e. a time period that has to pass before the runnable is executed.
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. local/remote/cluster) as well as for extending the information carried by the final Deploy class.
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.
selectInterval() - Method in class akka.actor.IOManager.Settings
 
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
 
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 Example:

class FooImpl extends Foo { def doFoo { val myself = TypedActor.self[Foo] } } Useful when you want to send a reference to this TypedActor to someone else.

self() - Static method in class akka.actor.TypedActor
Returns the reference to the proxy when called inside a method call in a TypedActor Example:

class FooImpl extends Foo { def doFoo { val myself = TypedActor.self[Foo] } } Useful when you want to send a reference to this TypedActor to someone else.

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 SimpleSender query to the UdpExt.manager() as well as by the listener actors which are created in response to 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 SimpleSender query to the UdpExt.manager() as well as by the listener actors which are created in response to Bind.
send(ByteString, InetSocketAddress) - Static method in class akka.io.UdpMessage
The same as send(payload, target, noAck()).
SendBufferSize() - Method in interface akka.io.Inet.SoForwarders
akka.io.Tcp.SocketOption to set the SO_SNDBUF option.
sendBufferSize(int) - Method in interface akka.io.Inet.SoJavaFactories
akka.io.Tcp.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.TcpPipelineHandler.Tell
 
sender() - Method in class akka.io.Udp.Received
 
sender() - Method in class akka.routing.Destination
 
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).
sequence(PipelineStage<? super Ctx, CmdAbove, CmdBelow, EvtAbove, EvtBelow>, PipelineStage<? super Ctx, CmdBelow, CmdBelowBelow, EvtBelow, EvtBelowBelow>) - Method in class akka.io.PipelineStage$
Java API: attach the two given stages such that the command output of the first is fed into the command input of the second, and the event output of the second is fed into the event input of the first.
sequence(PipelineStage<? super Ctx, CmdAbove, CmdBelow, EvtAbove, EvtBelow>, PipelineStage<? super Ctx, CmdBelow, CmdBelowBelow, EvtBelow, EvtBelowBelow>) - Static method in class akka.io.PipelineStage
Java API: attach the two given stages such that the command output of the first is fed into the command input of the second, and the event output of the second is fed into the event input of the first.
Serialization - Class in akka.serialization
Serialization module.
Serialization(ExtendedActorSystem) - Constructor for class akka.serialization.Serialization
 
Serialization$ - Class in akka.serialization
 
Serialization$() - Constructor for class akka.serialization.Serialization$
 
Serialization.Settings - Class in akka.serialization
 
Serialization.Settings(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
 
serializedActorPath(ActorRef) - Method in class akka.serialization.Serialization$
The serialized path of an actorRef, based on the current transport serialization information.
serializedActorPath(ActorRef) - Static method in class akka.serialization.Serialization
The serialized path of an actorRef, based on the current transport serialization information.
Serializer - Interface in akka.serialization
A Serializer represents a bimap between an object and an array of bytes representing that object.
serializerByIdentity() - Method in class akka.serialization.Serialization
Maps from a Serializer Identity (Int) to a Serializer instance (optimization)
serializerFor(Class<?>) - Method in class akka.serialization.Serialization
Returns the configured Serializer for the given Class.
serializerOf(String) - Method in class akka.serialization.Serialization
Tries to load the specified Serializer by the fully-qualified name; the actual loading is performed by the system’s DynamicAccess.
Serializers() - Method in class akka.serialization.Serialization.Settings
 
server() - Method in class akka.actor.IO.Accept
 
server() - Method in class akka.actor.IO.Listen
 
server() - Method in class akka.actor.IO.Listening
 
server() - Method in class akka.actor.IO.NewClient
 
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. from configuration file) are subscribed/unsubscribed as necessary so that they listen to all levels which are at least as severe as the given one.
setMaxPoolSize(int) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
setMaxPoolSizeFromFactor(int, double, int) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
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, 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 class akka.actor.IOManager
 
settings() - Method in class akka.actor.IOManagerActor
 
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
 
sha1(String) - Method in class akka.util.Crypt$
 
sha1(byte[]) - Method in class akka.util.Crypt$
 
sha1(String) - Static method in class akka.util.Crypt
 
sha1(byte[]) - Static method in class akka.util.Crypt
 
shutdown() - Method in class akka.actor.ActorSystem
Stop this actor system.
shutdown() - Method in class akka.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 INTERNAL API
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 INTERNAL API
simpleName(Object) - Method in class akka.event.Logging$
Returns a 'safe' getSimpleName for the provided object's Class
simpleName(Class<?>) - Method in class akka.event.Logging$
Returns a 'safe' getSimpleName for the provided Class
simpleName(Object) - Static method in class akka.event.Logging
Returns a 'safe' getSimpleName for the provided object's Class
simpleName(Class<?>) - Static method in class akka.event.Logging
Returns a 'safe' getSimpleName for the provided Class
simpleSender(Iterable<Inet.SocketOption>) - Method in class akka.io.UdpMessage$
Retrieve a reference to a “simple sender” actor of the UDP extension.
simpleSender() - Method in class akka.io.UdpMessage$
Retrieve a simple sender without specifying options.
simpleSender(Iterable<Inet.SocketOption>) - Static method in class akka.io.UdpMessage
Retrieve a reference to a “simple sender” actor of the UDP extension.
simpleSender() - Static method in class akka.io.UdpMessage
Retrieve a simple sender without specifying options.
singleCommand(CmdBelow) - Method in class akka.io.AbstractPipePair
Wrap a single command for efficient return to the pipeline’s machinery.
singleCommand(Cmd) - Method in interface akka.io.PipelineContext
Scala API: Wrap a single command for efficient return to the pipeline’s machinery.
SingleConsumerOnlyUnboundedMailbox - Class in akka.dispatch
SingleConsumerOnlyUnboundedMailbox is a high-performance, multiple producer—single consumer, unbounded MailboxType, the only drawback is that you can't have multiple consumers, which rules out using it with BalancingDispatcher for instance.
SingleConsumerOnlyUnboundedMailbox() - Constructor for class akka.dispatch.SingleConsumerOnlyUnboundedMailbox
 
SingleConsumerOnlyUnboundedMailbox(ActorSystem.Settings, Config) - Constructor for class akka.dispatch.SingleConsumerOnlyUnboundedMailbox
 
SingleConsumerOnlyUnboundedMailbox$ - Class in akka.dispatch
 
SingleConsumerOnlyUnboundedMailbox$() - Constructor for class akka.dispatch.SingleConsumerOnlyUnboundedMailbox$
 
singleEvent(EvtAbove) - Method in class akka.io.AbstractPipePair
Wrap a single event for efficient return to the pipeline’s machinery.
singleEvent(Evt) - Method in interface akka.io.PipelineContext
Scala API: Wrap a single event for efficient return to the pipeline’s machinery.
size() - Method in class akka.actor.IO.ReceiveBufferSize
 
size() - Method in class akka.actor.IO.SendBufferSize
 
size() - Method in class akka.dispatch.sysmsg.EarliestFirstSystemMessageList
Indicates if the list is empty or not.
size() - Method in class akka.dispatch.sysmsg.LatestFirstSystemMessageList
Indicates if the list is empty or not.
size() - Method in class akka.io.Inet.SO$.ReceiveBufferSize
 
size() - Method in class akka.io.Inet.SO$.SendBufferSize
 
size() - Method in class akka.util.BoundedBlockingQueue
 
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
 
SmallestMailboxLike - Interface in akka.routing
The core pieces of the routing logic is located in this trait to be able to extend.
SmallestMailboxRouter - Class in akka.routing
A Router that tries to send to the non-suspended routee with fewest messages in mailbox.
SmallestMailboxRouter(int, Iterable<String>, Option<Resizer>, String, SupervisorStrategy) - Constructor for class akka.routing.SmallestMailboxRouter
 
SmallestMailboxRouter(int) - Constructor for class akka.routing.SmallestMailboxRouter
Java API: Constructor that sets nrOfInstances to be created.
SmallestMailboxRouter(Iterable<String>) - Constructor for class akka.routing.SmallestMailboxRouter
Java API: Constructor that sets the routees to be used.
SmallestMailboxRouter(Resizer) - Constructor for class akka.routing.SmallestMailboxRouter
Java API: Constructor that sets the resizer to be used.
SmallestMailboxRouter$ - Class in akka.routing
 
SmallestMailboxRouter$() - Constructor for class akka.routing.SmallestMailboxRouter$
 
socket() - Method in class akka.actor.IO.Accept
 
socket() - Method in class akka.actor.IO.Connect
 
socket() - Method in class akka.actor.IO.Connected
 
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
 
SslTlsSupport - Class in akka.io
This pipeline stage implements SSL / TLS support, using an externally configured SSLEngine.
SslTlsSupport(SSLEngine) - Constructor for class akka.io.SslTlsSupport
 
SslTlsSupport$ - Class in akka.io
 
SslTlsSupport$() - Constructor for class akka.io.SslTlsSupport$
 
stackTraceFor(Throwable) - Method in class akka.event.Logging$
Returns the StackTrace for the given Throwable as a String
stackTraceFor(Throwable) - Static method in class akka.event.Logging
Returns the StackTrace for the given Throwable as a String
stages() - Method in class akka.io.TcpPipelineHandler.Init
 
StandardOutLogger() - Method in class akka.event.Logging$
 
StandardOutLogger() - Static method in class akka.event.Logging
 
start() - Method in class akka.util.internal.HashedWheelTimer
Deprecated. Starts the background thread explicitly.
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, Option<FiniteDuration>) - Method in interface akka.actor.FSM
Set initial state.
Stash - Interface in akka.actor
The Stash trait enables an actor to temporarily stash away messages that can not or should not be handled using the actor's current behavior.
stash() - Method in interface akka.actor.UnrestrictedStash
Adds the current message (the message that the actor received last) to the actor's stash.
StashOverflowException - Exception in akka.actor
Is thrown when the size of the Stash exceeds the capacity of the Stash
StashOverflowException(String, Throwable) - Constructor for exception akka.actor.StashOverflowException
 
StashOverflowException$ - Class in akka.actor
 
StashOverflowException$() - Constructor for class akka.actor.StashOverflowException$
 
StashWhenFailed - Interface in akka.dispatch.sysmsg
 
StashWhenWaitingForChildren - Interface in akka.dispatch.sysmsg
 
state() - Method in class akka.actor.FSM.CurrentState
 
stateData() - Method in class akka.actor.FSM.Event
 
stateData() - Method in class akka.actor.FSM.LogEntry
 
stateData() - Method in class akka.actor.FSM.State
 
stateData() - Method in interface akka.actor.FSM
Return current state data (i.e. object of type D)
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. object of type S)
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. involves a message send.
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.LightArrayRevolverScheduler
 
stop() - Method in class akka.actor.SupervisorStrategy$
Java API: Returning this directive stops the Actor
stop() - Static method in class akka.actor.SupervisorStrategy
Java API: Returning this directive stops the Actor
stop(Object) - Method in interface akka.actor.TypedActorFactory
Stops the underlying ActorRef for the supplied TypedActor proxy, if any, returns whether it could find the find the ActorRef or not
stop() - Method in class akka.util.internal.HashedWheelTimer
Deprecated.  
stop() - Method in interface akka.util.internal.Timer
Deprecated. Releases all resources acquired by this Timer and cancels all tasks which were scheduled but not executed yet.
stopDefaultLoggers(ActorSystem) - Method in interface akka.event.LoggingBus
Internal Akka use only
stopDelay() - Method in class akka.routing.DefaultResizer
When the resizer reduce the capacity the abandoned routee actors are stopped with PoisonPill after this delay.
stoppingStrategy() - Method in class akka.actor.SupervisorStrategy$
This strategy resembles Erlang in that failing children are always terminated (one-for-one).
stoppingStrategy() - Static method in class akka.actor.SupervisorStrategy
This strategy resembles Erlang in that failing children are always terminated (one-for-one).
StoppingSupervisorStrategy - Class in akka.actor
 
StoppingSupervisorStrategy() - Constructor for class akka.actor.StoppingSupervisorStrategy
 
stopReason() - Method in class akka.actor.FSM.State
 
stopRouterWhenAllRouteesRemoved() - Method in interface akka.routing.RouterConfig
 
StringByteStringAdapter - Class in akka.io
Simple convenience pipeline stage for turning Strings into ByteStrings and vice versa.
StringByteStringAdapter(String) - Constructor for class akka.io.StringByteStringAdapter
 
StringByteStringAdapter$ - Class in akka.io
 
StringByteStringAdapter$() - Constructor for class akka.io.StringByteStringAdapter$
 
stringHash(String) - Method in class akka.routing.MurmurHash$
Compute a high-quality hash of a string
stringHash(String) - Static method in class akka.routing.MurmurHash
Compute a high-quality hash of a string
SubchannelClassification - Interface in akka.event
Classification which respects relationships between channels: subscribing to one channel automatically and idempotently subscribes to all sub-channels.
SubchannelEventBus<E,S,C> - Class in akka.event.japi
See documentation for SubchannelClassification E is the Event type S is the Subscriber type C is the Classifier type
SubchannelEventBus() - Constructor for class akka.event.japi.SubchannelEventBus
 
subclassification() - Method in class akka.event.EventStream
 
subclassification() - Method in interface akka.event.SubchannelClassification
 
Subclassification<K> - Interface in akka.util
Typeclass which describes a classification hierarchy.
submit(Callable<T>) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
submit(Runnable, T) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
submit(Runnable) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
subscribe(ActorRef, ActorRef) - Method in interface akka.event.ActorClassification
 
subscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.EventBus
Attempts to register the subscriber to the specified Classifier
subscribe(ActorRef, Class<?>) - Method in class akka.event.EventStream
 
subscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.LookupClassification
 
subscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.ScanningClassification
 
subscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.SubchannelClassification
 
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
superviseWith(SupervisorStrategy) - Method in interface akka.actor.dsl.Creators.Act
Set the supervisor strategy of this actor, i.e. how it supervises its children.
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.BroadcastRouter
 
supervisorStrategy() - Method in class akka.routing.ConsistentHashingRouter
 
supervisorStrategy() - Method in class akka.routing.FromConfig
 
supervisorStrategy() - Method in class akka.routing.NoRouter$
 
supervisorStrategy() - Static method in class akka.routing.NoRouter
 
supervisorStrategy() - Method in class akka.routing.RandomRouter
 
supervisorStrategy() - Method in class akka.routing.RoundRobinRouter
 
supervisorStrategy() - Method in interface akka.routing.RouterConfig
SupervisorStrategy for the created Router actor.
supervisorStrategy() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
supervisorStrategy() - Method in class akka.routing.SmallestMailboxRouter
 
SupervisorStrategy$ - Class in akka.actor
 
SupervisorStrategy$() - Constructor for class akka.actor.SupervisorStrategy$
 
SupervisorStrategy.Directive - Interface in akka.actor
 
SupervisorStrategy.Escalate$ - Class in akka.actor
Escalates the failure to the supervisor of the supervisor, by rethrowing the cause of the failure, i.e. the supervisor fails with the same exception as the child.
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
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 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 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 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 Bound message) to have it stop reading datagrams from the network.
Switch - Class in akka.util
An atomic switch that can be either on or off
Switch(boolean) - Constructor for class akka.util.Switch
 
Switch$ - Class in akka.util
 
Switch$() - Constructor for class akka.util.Switch$
 
switchOff(Function0<BoxedUnit>) - Method in class akka.util.Switch
Executes the provided action if the lock is on under a lock, so be _very_ careful with longrunning/blocking operations in it Only executes the action if the switch is on, and switches it off immediately after obtaining the lock Will switch it back on if the provided action throws an exception
switchOff() - Method in class akka.util.Switch
Switches the switch off (if on), uses locking
switchOn(Function0<BoxedUnit>) - Method in class akka.util.Switch
Executes the provided action if the lock is off under a lock, so be _very_ careful with longrunning/blocking operations in it Only executes the action if the switch is off, and switches it on immediately after obtaining the lock Will switch it back off if the provided action throws an exception
switchOn() - Method in class akka.util.Switch
Switches the switch on (if off), uses locking
symmetricHash(TraversableOnce<T>, int) - Method in class akka.routing.MurmurHash$
Compute a hash that is symmetric in its arguments--that is, where the order of appearance of elements does not matter.
symmetricHash(TraversableOnce<T>, int) - Static method in class akka.routing.MurmurHash
Compute a hash that is symmetric in its arguments--that is, where the order of appearance of elements does not matter.
SymmetricPipelineStage<Context extends PipelineContext,Above,Below> - Class in akka.io
A PipelineStage which is symmetric in command and event types, i.e. it only has one command and event type above and one below.
SymmetricPipelineStage() - Constructor for class akka.io.SymmetricPipelineStage
 
SymmetricPipePair<Above,Below> - Interface in akka.io
A convenience type for expressing a PipePair which has the same types for commands and events.
sync(IO.Iteratee<A>) - Method in class akka.actor.IO.IterateeRef$
Creates an IO.IterateeRefSync containing an initial IO.Iteratee.
sync() - Method in class akka.actor.IO.IterateeRef$
Creates an empty IO.IterateeRefSync.
sync() - Method in class akka.actor.IO.IterateeRef.Map$
Creates an empty IO.IterateeRefSync for each new key.
synchronousQueue(boolean) - Method in class akka.dispatch.ThreadPoolConfig$
 
synchronousQueue(boolean) - Static method in class akka.dispatch.ThreadPoolConfig
 
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.serialization.JavaSerializer
 
system() - Method in class akka.serialization.Serialization
 
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 INTERNAL API
systemGuardian() - Method in interface akka.actor.ActorRefProvider
Reference to the supervisor used for all top-level system actors.
systemGuardian() - Method in class akka.actor.ExtendedActorSystem
The top-level supervisor of all system-internal services like logging.
SystemHome() - Method in class akka.actor.ActorSystem$
 
SystemHome() - Static method in class akka.actor.ActorSystem
 
systemImpl() - Method in interface akka.actor.ActorRefFactory
INTERNAL API
SystemMessageList - Class in akka.dispatch.sysmsg
INTERNAL API Helper companion object for LatestFirstSystemMessageList and EarliestFirstSystemMessageList
SystemMessageList() - Constructor for class akka.dispatch.sysmsg.SystemMessageList
 
SystemMessageList$ - Class in akka.dispatch.sysmsg
INTERNAL API Helper companion object for LatestFirstSystemMessageList and EarliestFirstSystemMessageList
SystemMessageList$() - Constructor for class akka.dispatch.sysmsg.SystemMessageList$
 

T

tail() - Method in class akka.dispatch.sysmsg.EarliestFirstSystemMessageList
Gives back the list containing all the elements except the first.
tail() - Method in class akka.dispatch.sysmsg.LatestFirstSystemMessageList
Gives back the list containing all the elements except the first.
tail() - Method in class akka.util.ByteString
 
take(int) - Method in class akka.actor.IO$
An Iteratee that returns a ByteString of the requested length.
take(int) - Static method in class akka.actor.IO
An Iteratee that returns a ByteString of the requested length.
take() - Method in class akka.util.BoundedBlockingQueue
 
take(int) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
take(int) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
take(int) - Method in class akka.util.ByteIterator
 
take(int) - Method in class akka.util.ByteString
 
takeAll() - Method in class akka.actor.IO$
An Iteratee that returns the remaining ByteString until an EOF is given.
takeAll() - Static method in class akka.actor.IO
An Iteratee that returns the remaining ByteString until an EOF is given.
takeAny() - Method in class akka.actor.IO$
An Iteratee that returns any input it receives
takeAny() - Static method in class akka.actor.IO
An Iteratee that returns any input it receives
takeList(int, IO.Iteratee<A>) - Method in class akka.actor.IO$
An Iteratee that creates a list made up of the results of an Iteratee.
takeList(int, IO.Iteratee<A>) - Static method in class akka.actor.IO
An Iteratee that creates a list made up of the results of an Iteratee.
takeRight(int) - Method in class akka.util.ByteString
 
takeUntil(ByteString, boolean) - Method in class akka.actor.IO$
An Iteratee that returns the ByteString prefix up until the supplied delimiter.
takeUntil(ByteString, boolean) - Static method in class akka.actor.IO
An Iteratee that returns the ByteString prefix up until the supplied delimiter.
takeWhile(Function1<Object, Object>) - Method in class akka.actor.IO$
An Iteratee that will collect bytes as long as a predicate is true.
takeWhile(Function1<Object, Object>) - Static method in class akka.actor.IO
An Iteratee that will collect bytes as long as a predicate is true.
takeWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
takeWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
takeWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator
 
takeWhile(Function1<Object, Object>) - Method in class akka.util.ByteString
 
target() - Method in class akka.actor.dsl.Inbox.StartWatch
 
target() - Method in class akka.io.Udp.Send
 
task() - Method in class akka.actor.LightArrayRevolverScheduler.TaskHolder
 
TaskInvocation - Class in akka.dispatch
 
TaskInvocation(EventStream, Runnable, Function0<BoxedUnit>) - Constructor for class akka.dispatch.TaskInvocation
 
TaskInvocation$ - Class in akka.dispatch
 
TaskInvocation$() - Constructor for class akka.dispatch.TaskInvocation$
 
tc() - Method in class akka.actor.IO.TrafficClass
 
tc() - Method in class akka.io.Inet.SO$.TrafficClass
 
Tcp - Class in akka.io
TCP Extension for Akka’s IO layer.
Tcp() - Constructor for class akka.io.Tcp
 
Tcp$ - Class in akka.io
TCP Extension for Akka’s IO layer.
Tcp$() - Constructor for class akka.io.Tcp$
 
Tcp.Abort$ - Class in akka.io
An abort operation will not flush pending writes and will issue a TCP ABORT command to the O/S kernel which should result in a TCP_RST packet being sent to the peer.
Tcp.Abort$() - Constructor for class akka.io.Tcp.Abort$
 
Tcp.Aborted$ - Class in akka.io
The connection has been aborted in response to an Abort command.
Tcp.Aborted$() - Constructor for class akka.io.Tcp.Aborted$
 
Tcp.Bind - Class in akka.io
The Bind message is send to the TCP manager actor, which is obtained via TcpExt.manager() in order to bind to a listening socket.
Tcp.Bind(ActorRef, InetSocketAddress, int, Traversable<Inet.SocketOption>) - Constructor for class akka.io.Tcp.Bind
 
Tcp.Bind$ - Class in akka.io
 
Tcp.Bind$() - Constructor for class akka.io.Tcp.Bind$
 
Tcp.Bound - Class in akka.io
The sender of a Tcp.Bind command will—in case of success—receive confirmation in this form.
Tcp.Bound(InetSocketAddress) - Constructor for class akka.io.Tcp.Bound
 
Tcp.Bound$ - Class in akka.io
 
Tcp.Bound$() - Constructor for class akka.io.Tcp.Bound$
 
Tcp.Close$ - Class in akka.io
A normal close operation will first flush pending writes and then close the socket.
Tcp.Close$() - Constructor for class akka.io.Tcp.Close$
 
Tcp.CloseCommand - Interface in akka.io
Common interface for all commands which aim to close down an open connection.
Tcp.Closed$ - Class in akka.io
The connection has been closed normally in response to a Close command.
Tcp.Closed$() - Constructor for class akka.io.Tcp.Closed$
 
Tcp.Command - Interface in akka.io
This is the common trait for all commands understood by TCP actors.
Tcp.CommandFailed - Class in akka.io
Whenever a command cannot be completed, the queried actor will reply with this message, wrapping the original command which failed.
Tcp.CommandFailed(Tcp.Command) - Constructor for class akka.io.Tcp.CommandFailed
 
Tcp.CommandFailed$ - Class in akka.io
 
Tcp.CommandFailed$() - Constructor for class akka.io.Tcp.CommandFailed$
 
Tcp.ConfirmedClose$ - Class in akka.io
A confirmed close operation will flush pending writes and half-close the connection, waiting for the peer to close the other half.
Tcp.ConfirmedClose$() - Constructor for class akka.io.Tcp.ConfirmedClose$
 
Tcp.ConfirmedClosed$ - Class in akka.io
The connection has been half-closed by us and then half-close by the peer in response to a ConfirmedClose command.
Tcp.ConfirmedClosed$() - Constructor for class akka.io.Tcp.ConfirmedClosed$
 
Tcp.Connect - Class in akka.io
The Connect message is sent to the TCP manager actor, which is obtained via TcpExt.manager().
Tcp.Connect(InetSocketAddress, Option<InetSocketAddress>, Traversable<Inet.SocketOption>, Option<FiniteDuration>) - Constructor for class akka.io.Tcp.Connect
 
Tcp.Connect$ - Class in akka.io
 
Tcp.Connect$() - Constructor for class akka.io.Tcp.Connect$
 
Tcp.Connected - Class in akka.io
The connection actor sends this message either to the sender of a Tcp.Connect command (for outbound) or to the handler for incoming connections designated in the Tcp.Bind message.
Tcp.Connected(InetSocketAddress, InetSocketAddress) - Constructor for class akka.io.Tcp.Connected
 
Tcp.Connected$ - Class in akka.io
 
Tcp.Connected$() - Constructor for class akka.io.Tcp.Connected$
 
Tcp.ConnectionClosed - Interface in akka.io
This is the common interface for all events which indicate that a connection has been closed or half-closed.
Tcp.ErrorClosed - Class in akka.io
The connection has been closed due to an IO error.
Tcp.ErrorClosed(String) - Constructor for class akka.io.Tcp.ErrorClosed
 
Tcp.ErrorClosed$ - Class in akka.io
 
Tcp.ErrorClosed$() - Constructor for class akka.io.Tcp.ErrorClosed$
 
Tcp.Event - Interface in akka.io
Common interface for all events generated by the TCP layer actors.
Tcp.Message - Interface in akka.io
The common interface for Tcp.Command and Tcp.Event.
Tcp.NoAck - Class in akka.io
Each Tcp.WriteCommand can optionally request a positive acknowledgment to be sent to the commanding actor.
Tcp.NoAck(Object) - Constructor for class akka.io.Tcp.NoAck
 
Tcp.NoAck$ - Class in akka.io
Default Tcp.NoAck instance which is used when no acknowledgment information is explicitly provided.
Tcp.NoAck$() - Constructor for class akka.io.Tcp.NoAck$
 
Tcp.PeerClosed$ - Class in akka.io
The peer has closed its writing half of the connection.
Tcp.PeerClosed$() - Constructor for class akka.io.Tcp.PeerClosed$
 
Tcp.Received - Class in akka.io
Whenever data are read from a socket they will be transferred within this class to the handler actor which was designated in the Tcp.Register message.
Tcp.Received(ByteString) - Constructor for class akka.io.Tcp.Received
 
Tcp.Received$ - Class in akka.io
 
Tcp.Received$() - Constructor for class akka.io.Tcp.Received$
 
Tcp.Register - Class in akka.io
This message must be sent to a TCP connection actor after receiving the Tcp.Connected message.
Tcp.Register(ActorRef, boolean, boolean) - Constructor for class akka.io.Tcp.Register
 
Tcp.Register$ - Class in akka.io
 
Tcp.Register$() - Constructor for class akka.io.Tcp.Register$
 
Tcp.ResumeReading$ - Class in akka.io
This command needs to be sent to the connection actor after a SuspendReading command in order to resume reading from the socket.
Tcp.ResumeReading$() - Constructor for class akka.io.Tcp.ResumeReading$
 
Tcp.ResumeWriting$ - Class in akka.io
When useResumeWriting is in effect as was indicated in the Tcp.Register message then this command needs to be sent to the connection actor in order to re-enable writing after a Tcp.CommandFailed event.
Tcp.ResumeWriting$() - Constructor for class akka.io.Tcp.ResumeWriting$
 
Tcp.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 For more information see java.net.Socket.setKeepAlive
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) Please note, that TCP_NODELAY is enabled by default.
Tcp.SO$.TcpNoDelay(boolean) - Constructor for class akka.io.Tcp.SO$.TcpNoDelay
 
Tcp.SuspendReading$ - Class in akka.io
Sending this command to the connection actor will disable reading from the TCP socket.
Tcp.SuspendReading$() - Constructor for class akka.io.Tcp.SuspendReading$
 
Tcp.Unbind$ - Class in akka.io
In order to close down a listening socket, send this message to that socket’s actor (that is the actor which previously had sent the Tcp.Bound message).
Tcp.Unbind$() - Constructor for class akka.io.Tcp.Unbind$
 
Tcp.Unbound - Interface in akka.io
The sender of an Unbind command will receive confirmation through this message once the listening socket has been closed.
Tcp.Unbound$ - Class in akka.io
 
Tcp.Unbound$() - Constructor for class akka.io.Tcp.Unbound$
 
Tcp.Write - Class in akka.io
Write data to the TCP connection.
Tcp.Write(ByteString, Tcp.Event) - Constructor for class akka.io.Tcp.Write
 
Tcp.Write$ - Class in akka.io
 
Tcp.Write$() - Constructor for class akka.io.Tcp.Write$
 
Tcp.WriteCommand - Interface in akka.io
Common interface for all write commands, currently Tcp.Write and Tcp.WriteFile.
Tcp.WriteFile - Class in akka.io
Write count bytes starting at position from file at filePath to the connection.
Tcp.WriteFile(String, long, long, Tcp.Event) - Constructor for class akka.io.Tcp.WriteFile
 
Tcp.WriteFile$ - Class in akka.io
 
Tcp.WriteFile$() - Constructor for class akka.io.Tcp.WriteFile$
 
Tcp.WritingResumed - Interface in akka.io
When useResumeWriting is in effect as indicated in the Tcp.Register message, the ResumeWriting command will be acknowledged by this message type, upon which it is safe to send at least one write.
Tcp.WritingResumed$ - Class in akka.io
 
Tcp.WritingResumed$() - Constructor for class akka.io.Tcp.WritingResumed$
 
TcpExt - Class in akka.io
 
TcpExt(ExtendedActorSystem) - Constructor for class akka.io.TcpExt
 
TcpExt.Settings - Class in akka.io
 
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) Please note, that TCP_NODELAY is enabled by default.
tcpNoDelay(boolean) - Static method in class akka.io.TcpSO
Inet.SocketOption to enable or disable TCP_NODELAY (disable or enable Nagle's algorithm) Please note, that TCP_NODELAY is enabled by default.
TcpPipelineHandler<Ctx extends PipelineContext,Cmd,Evt> - Class in akka.io
This actor wraps a pipeline and forwards commands and events between that one and a Tcp connection actor.
TcpPipelineHandler(TcpPipelineHandler.Init<Ctx, Cmd, Evt>, ActorRef, ActorRef) - Constructor for class akka.io.TcpPipelineHandler
 
TcpPipelineHandler$ - Class in akka.io
 
TcpPipelineHandler$() - Constructor for class akka.io.TcpPipelineHandler$
 
TcpPipelineHandler.Init<Ctx extends PipelineContext,Cmd,Evt> - Class in akka.io
This class wraps up a pipeline with its external (i.e.
TcpPipelineHandler.Init(PipelineStage<? extends PipelineContext, Cmd, Tcp.Command, Evt, Tcp.Event>) - Constructor for class akka.io.TcpPipelineHandler.Init
 
TcpPipelineHandler.Init.Command - Class in akka.io
Wrapper class for commands to be sent to the TcpPipelineHandler actor.
TcpPipelineHandler.Init.Command(Cmd) - Constructor for class akka.io.TcpPipelineHandler.Init.Command
 
TcpPipelineHandler.Init.Event - Class in akka.io
Wrapper class for events emitted by the TcpPipelineHandler actor.
TcpPipelineHandler.Init.Event(Evt) - Constructor for class akka.io.TcpPipelineHandler.Init.Event
 
TcpPipelineHandler.Management - Class in akka.io
Wrapper class for management commands sent to the TcpPipelineHandler actor.
TcpPipelineHandler.Management(Object) - Constructor for class akka.io.TcpPipelineHandler.Management
 
TcpPipelineHandler.Management$ - Class in akka.io
 
TcpPipelineHandler.Management$() - Constructor for class akka.io.TcpPipelineHandler.Management$
 
TcpPipelineHandler.TcpEvent - Class in akka.io
The pipeline may want to emit a Tcp.Event to the registered handler actor, which is enabled by emitting this Tcp.Command wrapping an event instead.
TcpPipelineHandler.TcpEvent(Tcp.Event) - Constructor for class akka.io.TcpPipelineHandler.TcpEvent
 
TcpPipelineHandler.TcpEvent$ - Class in akka.io
 
TcpPipelineHandler.TcpEvent$() - Constructor for class akka.io.TcpPipelineHandler.TcpEvent$
 
TcpPipelineHandler.Tell - Class in akka.io
This is a new Tcp.Command which the pipeline can emit to effect the sending a message to another actor.
TcpPipelineHandler.Tell(ActorRef, Object, ActorRef) - Constructor for class akka.io.TcpPipelineHandler.Tell
 
TcpPipelineHandler.Tell$ - Class in akka.io
 
TcpPipelineHandler.Tell$() - Constructor for class akka.io.TcpPipelineHandler.Tell$
 
TcpPipelineHandler.WithinActorContext - Interface in akka.io
This interface bundles logging and ActorContext for Java.
TcpReadWriteAdapter - Class in akka.io
Adapts a ByteString oriented pipeline stage to a stage that communicates via Tcp Commands and Events.
TcpReadWriteAdapter() - Constructor for class akka.io.TcpReadWriteAdapter
 
TcpSO - Class in akka.io
Java API for accessing socket options.
TcpSO() - Constructor for class akka.io.TcpSO
 
TcpSO$ - Class in akka.io
Java API for accessing socket options.
TcpSO$() - Constructor for class akka.io.TcpSO$
 
team() - Method in class akka.dispatch.BalancingDispatcher
INTERNAL API
teamWork() - Method in class akka.dispatch.BalancingDispatcher
 
tell(Object, ActorRef) - Method in class akka.actor.ActorRef
Java API: Sends the specified message to the sender, i.e. fire-and-forget semantics, including the sender reference if possible (pass null if there is nobody to reply to).
tell(Object) - Method in class akka.actor.ActorSelection
 
tell(Object, ActorRef) - Method in class akka.actor.ActorSelection
 
tempContainer() - Method in interface akka.actor.ActorRefProvider
Returns the actor reference representing the “/temp” path.
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
 
Terminated - Class in akka.actor
When Death Watch is used, the watcher will receive a Terminated(watched) message when watched is terminated.
Terminated$ - Class in akka.actor
 
Terminated$() - Constructor for class akka.actor.Terminated$
 
terminateEvent() - Method in interface akka.actor.FSM
 
terminationFuture() - Method in interface akka.actor.ActorRefProvider
This Future is completed upon termination of this ActorRefProvider, which is usually initiated by stopping the guardian via ActorSystem.stop().
theStash() - Method in interface akka.actor.UnrestrictedStash
 
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.DefaultScheduler
 
TickDuration() - Method in class akka.actor.LightArrayRevolverScheduler
 
TickGenerator<Cmd,Evt> - Class in akka.io
This pipeline stage does not alter the events or commands
TickGenerator(FiniteDuration) - Constructor for class akka.io.TickGenerator
 
TickGenerator$ - Class in akka.io
 
TickGenerator$() - Constructor for class akka.io.TickGenerator$
 
TickGenerator.Tick - Class in akka.io
This message type is emitted by the TickGenerator to the whole pipeline, informing all stages about the time at which this Tick was emitted (relative to some arbitrary epoch).
TickGenerator.Tick(FiniteDuration) - Constructor for class akka.io.TickGenerator.Tick
 
TickGenerator.Tick$ - Class in akka.io
 
TickGenerator.Tick$() - Constructor for class akka.io.TickGenerator.Tick$
 
TickGenerator.Trigger - Interface in akka.io
This message type is used by the TickGenerator to trigger the rescheduling of the next Tick.
TicksPerWheel() - Method in class akka.actor.DefaultScheduler
 
timeout() - Method in class akka.actor.FSM.State
 
timeout() - Method in class akka.actor.IO.SoTimeout
 
timeout() - Method in class akka.actor.TypedProps
 
timeout() - Method in class akka.io.Tcp.Connect
 
Timeout - Interface in akka.util.internal
Deprecated. 
Timeout - Class in akka.util
 
Timeout(FiniteDuration) - Constructor for class akka.util.Timeout
 
Timeout(long) - Constructor for class akka.util.Timeout
 
Timeout(long, TimeUnit) - Constructor for class akka.util.Timeout
 
Timeout$ - Class in akka.util
 
Timeout$() - Constructor for class akka.util.Timeout$
 
timeoutFuture() - Method in interface akka.actor.FSM
 
Timer - Interface in akka.util.internal
Deprecated. 
timerGen() - Method in interface akka.actor.FSM
 
timers() - Method in interface akka.actor.FSM
 
TimerTask - Interface in akka.util.internal
Deprecated. 
timestamp() - Method in interface akka.event.Logging.LogEvent
When this LogEvent was created according to System.currentTimeMillis
timestamp(Logging.LogEvent) - Method in interface akka.event.Logging.StdOutLogger
 
timestamp() - Method in class akka.io.TickGenerator.Tick
 
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
 
toAll(ActorRef, Iterable<ActorRef>) - Method in interface akka.routing.RouterConfig
 
toArray() - Method in class akka.util.BoundedBlockingQueue
 
toArray(X[]) - Method in class akka.util.BoundedBlockingQueue
 
toArray(ClassTag<B>) - Method in class akka.util.ByteIterator
 
toArray() - Method in class akka.util.ByteString
Java API: copy this ByteString into a fresh byte array
toArray(ClassTag<B>) - Method in class akka.util.ByteString
 
toBinary(Object) - Method in class akka.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.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.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
 
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
akka.io.Tcp.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
akka.io.Tcp.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, FSM.State<S, D>>) - Method in interface akka.actor.FSM
 
transitionEvent() - Method in interface akka.actor.FSM
 
traverse(M, Function1<A, IO.Iteratee<B>>, CanBuildFrom<M, B, M>) - Method in class akka.actor.IO$
An Iteratee that applies an Iteratee to each element of a Traversable and finally returning a single Iteratee containing a Traversable of the results.
traverse(M, Function1<A, IO.Iteratee<B>>, CanBuildFrom<M, B, M>) - Static method in class akka.actor.IO
An Iteratee that applies an Iteratee to each element of a Traversable and finally returning a single Iteratee containing a Traversable of the results.
traverse(Iterable<A>, Function<A, Future<B>>, ExecutionContext) - Method in class akka.dispatch.Futures$
Transforms a JIterable[A] into a Future[JIterable[B} using the provided Function A ⇒ Future[B].
traverse(Iterable<A>, Function<A, Future<B>>, ExecutionContext) - Static method in class akka.dispatch.Futures
Transforms a JIterable[A] into a Future[JIterable[B} using the provided Function A ⇒ Future[B].
typedActor() - Method in class akka.actor.ContextualTypedActorFactory
 
TypedActor - Class in akka.actor
This represents the TypedActor Akka Extension, access to the functionality is done through a given ActorSystem.
TypedActor() - Constructor for class akka.actor.TypedActor
 
typedActor() - Method in class akka.actor.TypedActorExtension
 
typedActor() - Method in interface akka.actor.TypedActorFactory
Underlying dependency to a TypedActorExtension, which can either be contextual or ActorSystem "global"
TypedActor$ - Class in akka.actor
This represents the TypedActor Akka Extension, access to the functionality is done through a given ActorSystem.
TypedActor$() - Constructor for class akka.actor.TypedActor$
 
TypedActor.MethodCall - Class in akka.actor
This class represents a Method call, and has a reference to the Method to be called and the parameters to supply It's sent to the ActorRef backing the TypedActor and can be serialized and deserialized
TypedActor.MethodCall(Method, Object[]) - Constructor for class akka.actor.TypedActor.MethodCall
 
TypedActor.MethodCall$ - Class in akka.actor
 
TypedActor.MethodCall$() - Constructor for class akka.actor.TypedActor.MethodCall$
 
TypedActor.PostRestart - Interface in akka.actor
 
TypedActor.PostStop - Interface in akka.actor
Mix this into your TypedActor to be able to hook into its lifecycle
TypedActor.PreRestart - Interface in akka.actor
Mix this into your TypedActor to be able to hook into its lifecycle
TypedActor.PreStart - Interface in akka.actor
Mix this into your TypedActor to be able to hook into its lifecycle
TypedActor.Receiver - Interface in akka.actor
Mix this into your TypedActor to be able to intercept Terminated messages
TypedActor.Supervisor - Interface in akka.actor
Mix this into your TypedActor to be able to define supervisor strategy
TypedActorExtension - Class in akka.actor
 
TypedActorExtension(ExtendedActorSystem) - Constructor for class akka.actor.TypedActorExtension
 
TypedActorFactory - Interface in akka.actor
A TypedActorFactory is something that can created TypedActor instances.
typedActorOf(TypedProps<T>) - Method in interface akka.actor.TypedActorFactory
Creates a new TypedActor with the specified properties
typedActorOf(TypedProps<T>, String) - Method in interface akka.actor.TypedActorFactory
Creates a new TypedActor with the specified properties
typedActorOf(TypedProps<T>, ActorRef) - Method in interface akka.actor.TypedActorFactory
Creates a TypedActor that intercepts the calls and forwards them as TypedActor.MethodCall to the provided ActorRef.
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 For more information see DatagramSocket.setBroadcast(boolean)
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 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 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(Props, int) - Method in class akka.actor.Props$
The deprecated legacy extractor.
unapply(Props, int) - Static method in class akka.actor.Props
The deprecated legacy extractor.
unapply(String) - Method in class akka.actor.RelativeActorPath$
 
unapply(String) - Static method in class akka.actor.RelativeActorPath
 
unapply(FromConfig) - Method in class akka.routing.FromConfig$
 
unapply(FromConfig) - Static method in class akka.routing.FromConfig
 
unbatchedExecute(Runnable) - Method in class akka.dispatch.MessageDispatcher
 
unbecome() - Method in interface akka.actor.ActorContext
Reverts the Actor behavior to the previous one in the hotswap stack.
unbecome() - Method in interface akka.actor.dsl.Creators.Act
Pop the active behavior from the behavior stack of this actor.
unbind() - Method in class akka.io.TcpMessage$
In order to close down a listening socket, send this message to that socket’s actor (that is the actor which previously had sent the 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 Bound message).
unbind() - Method in class akka.io.UdpMessage$
Send this message to the listener actor that previously sent a 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 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. a non-blocking enqueue and dequeue.
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. a non-blocking enqueue and dequeue.
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.
unhandled(Object) - Method in interface akka.actor.Actor
User overridable callback.
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$
 
unit() - Method in class akka.actor.IO.Iteratee$
The single value representing Done(())
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
 
unregisterRoutees(Iterable<ActorRef>) - Method in class akka.routing.RouteeProvider
Removes routees from the router.
unregisterRoutees(Iterable<ActorRef>) - Method in class akka.routing.RouteeProvider
Java API: Removes routees from the router.
unregisterTempActor(ActorPath) - Method in interface akka.actor.ActorRefProvider
Unregister a temporary actor from the “/temp” path (i.e. obtained from tempPath()); do NOT pass in any other path.
UnrestrictedStash - Interface in akka.actor
 
Unsafe - Class in akka.util
INTERNAL API
Unsafe() - Constructor for class akka.util.Unsafe
 
UNSCHEDULED() - Static method in class akka.dispatch.MessageDispatcher
 
UnstartedPushTimeout() - Method in class akka.actor.ActorSystem.Settings
 
unstashAll() - Method in interface akka.actor.UnrestrictedStash
Prepends all messages in the stash to the mailbox, and then clears the stash.
unsubscribe(ActorRef, ActorRef) - Method in interface akka.event.ActorClassification
 
unsubscribe(ActorRef) - Method in interface akka.event.ActorClassification
 
unsubscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.EventBus
Attempts to deregister the subscriber from the specified Classifier
unsubscribe(akka.event.EventBus.Subscriber) - Method in interface akka.event.EventBus
Attempts to deregister the subscriber from all Classifiers it may be subscribed to
unsubscribe(ActorRef, Class<?>) - Method in class akka.event.EventStream
 
unsubscribe(ActorRef) - Method in class akka.event.EventStream
 
unsubscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.LookupClassification
 
unsubscribe(akka.event.EventBus.Subscriber) - Method in interface akka.event.LookupClassification
 
unsubscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.ScanningClassification
 
unsubscribe(akka.event.EventBus.Subscriber) - Method in interface akka.event.ScanningClassification
 
unsubscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.SubchannelClassification
 
unsubscribe(akka.event.EventBus.Subscriber) - Method in interface akka.event.SubchannelClassification
 
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 This class is the Java cousin to the Actor Scala interface.
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)'.
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 that enforces an unbounded stash for the actor.
UntypedActorWithUnboundedStash() - Constructor for class akka.actor.UntypedActorWithUnboundedStash
 
unwatch(ActorRef) - Method in interface akka.actor.ActorContext
Unregisters this actor as Monitor for the provided ActorRef.
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.
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$
 
uuid() - Method in interface akka.actor.IO.Handle
 
uuid() - Method in class akka.actor.IO.ServerHandle
 
uuid() - Method in class akka.actor.IO.SocketHandle
 

V

v() - Method in class akka.japi.Option.Some
 
validate(ThreadFactory) - Method in class akka.dispatch.ForkJoinExecutorConfigurator
 
value() - Method in class akka.actor.IO.IterateeRefSync
Returns the current value of this IterateeRefSync
value() - Method in class akka.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.
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 interface akka.routing.ConsistentHashingLike
 
virtualNodesFactor() - Method in class akka.routing.ConsistentHashingRouter
 

W

waitNanos(long) - Method in class akka.actor.LightArrayRevolverScheduler
Overridable for tests
wantsAck() - Method in interface akka.io.Tcp.WriteCommand
An acknowledgment is only sent if this write command “wants an ack”, which is equivalent to the Tcp.WriteCommand.ack() token not being a of type Tcp.NoAck.
wantsAck() - Method in class akka.io.Udp.Send
 
wantsAck() - Method in class akka.io.UdpConnected.Send
 
warning(Logging.Warning) - Method in interface akka.event.Logging.StdOutLogger
 
warning(String) - Method in interface akka.event.LoggingAdapter
 
warning(String, Object) - Method in interface akka.event.LoggingAdapter
 
warning(String, Object, Object) - Method in interface akka.event.LoggingAdapter
 
warning(String, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
 
warning(String, Object, Object, Object, Object) - Method in interface akka.event.LoggingAdapter
 
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.
WheelShift() - Method in class akka.actor.LightArrayRevolverScheduler
 
when(S, FiniteDuration, PartialFunction<FSM.Event, FSM.State<S, D>>) - Method in interface akka.actor.FSM
Insert a new StateFunction at the end of the processing chain for the given state.
whenFailing(Function2<Throwable, Option<Object>, BoxedUnit>) - Method in interface akka.actor.dsl.Creators.Act
Replace the preRestart action with the supplied function.
whenRestarted(Function1<Throwable, BoxedUnit>) - Method in interface akka.actor.dsl.Creators.Act
Replace the postRestart action with the supplied function.
whenStarting(Function0<BoxedUnit>) - Method in interface akka.actor.dsl.Creators.Act
Replace the preStart action with the supplied thunk.
whenStopping(Function0<BoxedUnit>) - Method in interface akka.actor.dsl.Creators.Act
Replace the postStop action with the supplied thunk.
whenUnhandled(PartialFunction<FSM.Event, FSM.State<S, D>>) - Method in interface akka.actor.FSM
Set handler which is called upon reception of unhandled messages.
whileOff(Function0<BoxedUnit>) - Method in class akka.util.Switch
Executes the provided action and returns if the action was executed or not, if the switch is off, waiting for any pending changes to happen before (locking) Be careful of longrunning or blocking within the provided action as it can lead to deadlocks or bad performance
whileOffYield(Function0<T>) - Method in class akka.util.Switch
Executes the provided action and returns its value if the switch is off, waiting for any pending changes to happen before (locking) Be careful of longrunning or blocking within the provided action as it can lead to deadlocks or bad performance
whileOn(Function0<BoxedUnit>) - Method in class akka.util.Switch
Executes the provided action and returns if the action was executed or not, if the switch is on, waiting for any pending changes to happen before (locking) Be careful of longrunning or blocking within the provided action as it can lead to deadlocks or bad performance
whileOnYield(Function0<T>) - Method in class akka.util.Switch
Executes the provided action and returns its value if the switch is on, waiting for any pending changes to happen before (locking) Be careful of longrunning or blocking within the provided action as it can lead to deadlocks or bad performance
wire(T) - Method in class akka.dispatch.MonitorableThreadFactory
 
withCircuitBreaker(Function0<Future<T>>) - Method in class akka.pattern.CircuitBreaker
Wraps invocations of asynchronous calls that need to be protected
withClient(ActorRef) - Method in class akka.actor.dsl.Inbox.Get
 
withClient(ActorRef) - Method in interface akka.actor.dsl.Inbox.Query
 
withClient(ActorRef) - Method in class akka.actor.dsl.Inbox.Select
 
withCreator(Function0<Actor>) - Method in class akka.actor.Props
Scala API: Returns a new Props with the specified creator set.
withCreator(Creator<Actor>) - Method in class akka.actor.Props
Deprecated. use Props.create(clazz, args ...) instead; this method has been deprecated because it encourages creating Props which contain non-serializable inner classes, making them also non-serializable
withCreator(Class<? extends Actor>) - Method in class akka.actor.Props
Deprecated. use Props.create(clazz) instead; deprecated since it duplicates another API
withDeploy(Deploy) - Method in class akka.actor.Props
Returns a new Props with the specified deployment configuration.
withDeploy(Deploy) - Method in class akka.actor.TypedProps
Returns a new TypedProps with the specified deployment configuration.
withDispatcher(String) - Method in class akka.actor.Props
Returns a new Props with the specified dispatcher set.
withDispatcher(String) - Method in class akka.actor.TypedProps
Returns a new TypedProps with the specified dispatcher set.
withDispatcher(String) - Method in class akka.routing.BroadcastRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.ConsistentHashingRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.RandomRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.RoundRobinRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.ScatterGatherFirstCompletedRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.SmallestMailboxRouter
Java API for setting routerDispatcher
withFallback(Deploy) - Method in class akka.actor.Deploy
Do a merge between this and the other Deploy, where values from “this” take precedence.
withFallback(Scope) - Method in class akka.actor.LocalScope$
 
withFallback(Scope) - Static method in class akka.actor.LocalScope
 
withFallback(Scope) - Method in class akka.actor.NoScopeGiven$
 
withFallback(Scope) - Static method in class akka.actor.NoScopeGiven
 
withFallback(Scope) - Method in interface akka.actor.Scope
When merging Deploy instances using withFallback() on the left one, this is propagated to “merging” scopes in the same way.
withFallback(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. the resizer defined in code is used if resizer was not defined in config.
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. the resizer defined in code is used if resizer was not defined in config.
withFallback(RouterConfig) - Method in class akka.routing.NoRouter$
 
withFallback(RouterConfig) - Static method in class akka.routing.NoRouter
 
withFallback(RouterConfig) - Method in class akka.routing.RandomRouter
Uses the resizer and/or the supervisor strategy of the given Routerconfig if this RouterConfig doesn't have one, i.e. the resizer defined in code is used if resizer was not defined in config.
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. the resizer defined in code is used if resizer was not defined in config.
withFallback(RouterConfig) - Method in interface akka.routing.RouterConfig
Overridable merge strategy, by default completely prefers “this” (i.e. no merge).
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. the resizer defined in code is used if resizer was not defined in config.
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. the resizer defined in code is used if resizer was not defined in config.
withGuard(Function0<T>) - Method in class akka.util.ReentrantGuard
 
withHashMapper(ConsistentHashingRouter.ConsistentHashMapper) - Method in class akka.routing.ConsistentHashingRouter
Java API for setting the mapping from message to the data to use for the consistent hash key.
within() - Method in interface akka.routing.ScatterGatherFirstCompletedLike
 
within() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
withInterface(Class<? super T>) - Method in class akka.actor.TypedProps
Returns a new TypedProps that has the specified interface, or if the interface class is not an interface, all the interfaces it implements, appended in the sequence of interfaces.
withinTimeRange() - Method in class akka.actor.AllForOneStrategy
 
withinTimeRange() - Method in class akka.actor.OneForOneStrategy
 
WithListeners - Class in akka.routing
 
WithListeners(Function1<ActorRef, BoxedUnit>) - Constructor for class akka.routing.WithListeners
 
WithListeners$ - Class in akka.routing
 
WithListeners$() - Constructor for class akka.routing.WithListeners$
 
withLoader(ClassLoader) - Method in class akka.actor.TypedProps
Java API: return a new TypedProps that will use the specified ClassLoader to create its proxy class in If loader is null, it will use the bootstrap classloader.
withLoader(Option<ClassLoader>) - Method in class akka.actor.TypedProps
Scala API: return a new TypedProps that will use the specified ClassLoader to create its proxy class in If loader is null, it will use the bootstrap classloader.
withLogger(LoggingAdapter, PipelineStage<? extends PipelineContext, Cmd, Tcp.Command, Evt, Tcp.Event>) - Method in class akka.io.TcpPipelineHandler$
 
withLogger(LoggingAdapter, PipelineStage<? extends PipelineContext, Cmd, Tcp.Command, Evt, Tcp.Event>) - Static method in class akka.io.TcpPipelineHandler
 
withMailbox(String) - Method in class akka.actor.Props
Returns a new Props with the specified mailbox set.
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.BroadcastRouter
Java API for setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.ConsistentHashingRouter
Java API for setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.RandomRouter
Java API for setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.RoundRobinRouter
Java API for setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.ScatterGatherFirstCompletedRouter
Java API for setting the resizer to be used.
withResizer(Resizer) - Method in class akka.routing.SmallestMailboxRouter
Java API for setting the resizer to be used.
withRouter(RouterConfig) - Method in class akka.actor.Props
Returns a new Props with the specified router config set.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.BroadcastRouter
Java API for setting the supervisor strategy to be used for the “head” Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.ConsistentHashingRouter
Java API for setting the supervisor strategy to be used for the “head” Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.FromConfig
Java API for setting the supervisor strategy to be used for the “head” Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.RandomRouter
Java API for setting the supervisor strategy to be used for the “head” Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.RoundRobinRouter
Java API for setting the supervisor strategy to be used for the “head” Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.ScatterGatherFirstCompletedRouter
Java API for setting the supervisor strategy to be used for the “head” Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.SmallestMailboxRouter
Java API for setting the supervisor strategy to be used for the “head” Router actor.
withSyncCircuitBreaker(Function0<T>) - Method in class akka.pattern.CircuitBreaker
Wraps invocations of synchronous calls that need to be protected Calls are run in caller's thread
withTimeout(Timeout) - Method in class akka.actor.TypedProps
Java API: return a new TypedProps that will use the specified Timeout for its non-void-returning methods, if null is specified, it will use the default timeout as specified in the configuration.
withTimeout(Option<Timeout>) - Method in class akka.actor.TypedProps
Scala API: return a new TypedProps that will use the specified Timeout for its non-void-returning methods, if None is specified, it will use the default timeout as specified in the configuration.
withUid(int) - Method in interface akka.actor.ActorPath
INTERNAL API Creates a new ActorPath with same elements but with the specified uid.
withValue(ExtendedActorSystem, Callable<S>) - Method in class akka.serialization.JavaSerializer.CurrentSystem
Java API: invoke the callable with the current system being set to the given value for this thread.
withVirtualNodesFactor(int) - Method in class akka.routing.ConsistentHashingRouter
Java API for setting the number of virtual nodes per node, used in ConsistentHash
WorkerDispatcher() - Method in class akka.io.SelectionHandlerSettings
 
write(ByteString) - Method in interface akka.actor.IO.WriteHandle
Sends a request to the IOManager to write to the Channel associated with this IO.Handle.
write(WritableByteChannel) - Method in class akka.actor.WriteBuffer
 
write(ByteString, Tcp.Event) - Method in class akka.io.TcpMessage$
Write data to the TCP connection.
write(ByteString) - Method in class akka.io.TcpMessage$
The same as write(data, noAck()).
write(ByteString, Tcp.Event) - Static method in class akka.io.TcpMessage
Write data to the TCP connection.
write(ByteString) - Static method in class akka.io.TcpMessage
The same as write(data, noAck()).
WriteBuffer - Class in akka.actor
 
WriteBuffer(int) - Constructor for class akka.actor.WriteBuffer
 
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.

_

_logLevel() - Method in interface akka.event.LoggingBus
 

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