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

A

AbstractExtensionId<T extends Extension> - Class in akka.actor
Java API for ExtensionId
AbstractExtensionId() - Constructor for class akka.actor.AbstractExtensionId
 
accept(Seq<IO.SocketOption>, ActorRef) - Method in class akka.actor.IO.ServerHandle
Sends a request to the IOManager to accept an incoming connection to the ServerSocketChannel associated with this IO.Handle.
acceptableHeartbeatPause() - Method in class akka.cluster.AccrualFailureDetector
 
AccrualFailureDetector - Class in akka.cluster
 
AccrualFailureDetector(ActorSystem, double, int, Duration, Duration, Duration, Function0<Object>) - Constructor for class akka.cluster.AccrualFailureDetector
 
AccrualFailureDetector(ActorSystem, ClusterSettings) - Constructor for class akka.cluster.AccrualFailureDetector
Constructor that picks configuration from the settings.
AccrualFailureDetector$ - Class in akka.cluster
 
AccrualFailureDetector$() - Constructor for class akka.cluster.AccrualFailureDetector$
 
Ack - Class in akka.camel
Positive acknowledgement message (used for application-acknowledged message receipts).
Ack() - Constructor for class akka.camel.Ack
 
ack() - Method in class akka.contrib.mailbox.PeekMailbox
 
ack(ActorContext) - Method in class akka.contrib.mailbox.PeekMailboxExtension$
 
ack(ActorContext) - Method in class akka.contrib.mailbox.PeekMailboxExtension
 
Ack$ - Class in akka.camel
Positive acknowledgement message (used for application-acknowledged message receipts).
Ack$() - Constructor for class akka.camel.Ack$
 
Activation - Interface in akka.camel
Activation trait that can be used to wait on activation or de-activation of Camel endpoints.
activationFutureFor(ActorRef, Timeout, ExecutionContext) - Method in interface akka.camel.Activation
Produces a Future with the specified endpoint that will be completed when the endpoint has been activated, or if it times out, which will happen after the specified Timeout.
ActivationTimeout() - Method in class akka.camel.CamelSettings
Configured setting for how long the actor should wait for activation before it fails.
activationTimeout() - Method in interface akka.camel.Consumer
How long the actor should wait for activation before it fails.
active() - Method in class akka.contrib.pattern.ReliableProxy$
 
active() - Static method in class akka.contrib.pattern.ReliableProxy
 
Actor - Interface in akka.actor
Actor base trait that should be extended by or mixed to create an Actor with the semantics of the 'Actor Model': http://en.wikipedia.org/wiki/Actor_model 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() - Method in class akka.transactor.SendTo
 
Actor$ - Class in akka.actor
 
Actor$() - Constructor for class akka.actor.Actor$
 
Actor.emptyBehavior$ - Class in akka.actor
emptyBehavior is a Receive-expression that matches no messages at all, ever.
Actor.emptyBehavior$() - Constructor for class akka.actor.Actor.emptyBehavior$
 
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.
actorFor(InternalActorRef, String) - Method in class akka.actor.LocalActorRefProvider
 
actorFor(ActorPath) - Method in class akka.actor.LocalActorRefProvider
 
actorFor(InternalActorRef, Iterable<String>) - Method in class akka.actor.LocalActorRefProvider
 
actorFor(ActorPath) - Method in class akka.remote.RemoteActorRefProvider
 
actorFor(akka.actor.InternalActorRef, String) - Method in class akka.remote.RemoteActorRefProvider
 
actorFor(akka.actor.InternalActorRef, Iterable<String>) - Method in class akka.remote.RemoteActorRefProvider
 
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".
ActorNotRegisteredException - Exception in akka.camel
Thrown to indicate that the actor referenced by an endpoint URI cannot be found in the actor system.
ActorNotRegisteredException(String) - Constructor for exception akka.camel.ActorNotRegisteredException
 
actorOf(Props) - Method in interface akka.actor.ActorRefFactory
Create new actor as child of this context and give it an automatically generated name (currently similar to base64-encoded integer count, reversed and with “$” prepended, may change in the future).
actorOf(Props, String) - Method in interface akka.actor.ActorRefFactory
Create new actor as child of this context with the given name, which must not be null, empty or start with “$”.
actorOf(ActorSystemImpl, Props, InternalActorRef, ActorPath, boolean, Option<Deploy>, boolean, boolean) - Method in interface akka.actor.ActorRefProvider
Actor factory with create-only semantics: will create an actor as described by props with the given supervisor and path (may be different in case of remote supervision).
actorOf(ActorSystemImpl, Props, InternalActorRef, ActorPath, boolean, Option<Deploy>, boolean, boolean) - Method in class akka.actor.LocalActorRefProvider
 
actorOf(akka.actor.ActorSystemImpl, Props, akka.actor.InternalActorRef, ActorPath, boolean, Option<Deploy>, boolean, boolean) - Method in class akka.remote.RemoteActorRefProvider
 
ActorPath - Interface in akka.actor
Actor path is a unique path to an actor that shows the creation path up through the actor tree to the root actor.
ActorPath$ - 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.AskSupport.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.
ActorRouteDefinition<T extends > - Class in akka.camel
Wraps a org.apache.camel.model.ProcessorDefinition.
ActorRouteDefinition(<any>) - Constructor for class akka.camel.ActorRouteDefinition
 
actors() - Static method in class akka.dispatch.MessageDispatcher
 
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 - 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, com.typesafe.config.Config, String) - Constructor for class akka.actor.ActorSystem.Settings
 
ActorSystemActivator - Class in akka.osgi
Abstract bundle activator implementation to bootstrap and configure an actor system in an OSGi environment.
ActorSystemActivator() - Constructor for class akka.osgi.ActorSystemActivator
 
actorSystemConfig(org.osgi.framework.BundleContext) - Method in class akka.osgi.aries.blueprint.BlueprintActorSystemFactory
Strategy method to create the Config for the ActorSystem, ensuring that the default/reference configuration is loaded from the akka-actor bundle.
actorSystemConfig(org.osgi.framework.BundleContext) - Method in class akka.osgi.OsgiActorSystemFactory
Strategy method to create the Config for the ActorSystem, ensuring that the default/reference configuration is loaded from the akka-actor bundle.
actorSystemName(Option<String>) - Method in class akka.osgi.OsgiActorSystemFactory
Determine the name for the ActorSystem Returns a default value of bundle--ActorSystem is no name is being specified
AdaptiveLoadBalancingRouter - Class in akka.cluster.routing
A Router that performs load balancing of messages to cluster nodes based on cluster metric data.
AdaptiveLoadBalancingRouter(MetricsSelector, int, Iterable<String>, Option<Resizer>, String, SupervisorStrategy) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingRouter
 
AdaptiveLoadBalancingRouter(MetricsSelector, int) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingRouter
Java API: Constructor that sets nrOfInstances to be created.
AdaptiveLoadBalancingRouter(MetricsSelector, Iterable<String>) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingRouter
Java API: Constructor that sets the routees to be used.
AdaptiveLoadBalancingRouter(MetricsSelector, Resizer) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingRouter
Java API: Constructor that sets the resizer to be used.
AdaptiveLoadBalancingRouter$ - Class in akka.cluster.routing
 
AdaptiveLoadBalancingRouter$() - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingRouter$
 
AdaptiveLoadBalancingRouterLike - Interface in akka.cluster.routing
INTERNAL API.
add(QItem) - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
add(byte[], long) - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
Add a value to the end of the queue, transactionally.
add(byte[]) - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
add(String, byte[], int) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
Add an item to a named queue.
add(String, byte[]) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
add(T) - Method in class akka.routing.ConsistentHash
Java API: Adds a node to the node ring.
addAllMetadata(Iterable<? extends RemoteProtocol.MetadataEntryProtocol>) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
addDowned(Address) - Method in class akka.contrib.pattern.ClusterSingletonManager
 
addFilter(EventFilter) - Method in class akka.testkit.TestEventListener
 
addLogger(akka.actor.ActorSystemImpl, Class<? extends Actor>, Logging.LogLevel, String) - Method in interface akka.event.LoggingBus
INTERNAL API
AddLoggingReceive() - Method in class akka.actor.ActorSystem.Settings
 
addMetadata(RemoteProtocol.MetadataEntryProtocol) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
addMetadata(int, RemoteProtocol.MetadataEntryProtocol) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
addMetadata(RemoteProtocol.MetadataEntryProtocol.Builder) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
addMetadata(int, RemoteProtocol.MetadataEntryProtocol.Builder) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
addMetadataBuilder() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
addMetadataBuilder(int) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
addNameToBuffer(StringBuffer, String, String) - Method in class akka.jmx.Client
 
addRemoved(Address) - Method in class akka.contrib.pattern.ClusterSingletonManager
 
address() - Method in interface akka.actor.ActorPath
The Address under which this path can be reached; walks up the tree to the RootActorPath.
Address - Class in akka.actor
The address specifies the physical location under which an Actor can be reached.
Address(String, String) - Constructor for class akka.actor.Address
 
Address(String, String, String, int) - Constructor for class akka.actor.Address
 
address() - Method in class akka.actor.ChildActorPath
 
address() - Method in class akka.actor.IO.Connect
 
address() - Method in class akka.actor.IO.Connected
 
address() - Method in class akka.actor.IO.Listen
 
address() - Method in class akka.actor.IO.Listening
 
address() - Method in class akka.actor.RootActorPath
 
address() - Method in class akka.cluster.ClusterUserAction.Down
 
address() - Method in class akka.cluster.ClusterUserAction.Join
 
address() - Method in class akka.cluster.ClusterUserAction.Leave
 
address() - Method in class akka.cluster.Member
 
address() - Method in class akka.cluster.NodeMetrics
 
address() - Method in class akka.cluster.StandardMetrics.Cpu
 
address() - Method in class akka.cluster.StandardMetrics.HeapMemory
 
address() - Method in class akka.remote.RemoteTransport
Address to be used in RootActorPath of refs generated for this transport.
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$
 
addressOrdering() - Method in class akka.cluster.Member$
Address ordering type class, sorts addresses by host and port.
addressOrdering() - Static method in class akka.cluster.Member
Address ordering type class, sorts addresses by host and port.
addressTerminated() - Method in class akka.actor.Terminated
 
addTime() - Method in class akka.actor.mailbox.filebased.filequeue.QItem
 
addToCache(Seq<Tuple2<Object, Set<Object>>>) - Method in interface akka.event.SubchannelClassification
 
advance() - Method in interface akka.actor.LoggingFSM
 
AES128CounterInetRNG - Class in akka.remote.security.provider
Internal API This class is a wrapper around the 128-bit AESCounterRNG algorithm provided by http://maths.uncommons.org/ It uses the default seed generator which uses one of the following 3 random seed sources: Depending on availability: random.org, /dev/random, and SecureRandom (provided by Java) The only method used by netty ssl is engineNextBytes(bytes)
AES128CounterInetRNG() - Constructor for class akka.remote.security.provider.AES128CounterInetRNG
 
AES128CounterSecureRNG - Class in akka.remote.security.provider
Internal API This class is a wrapper around the 128-bit AESCounterRNG algorithm provided by http://maths.uncommons.org/ The only method used by netty ssl is engineNextBytes(bytes) This RNG is good to use to prevent startup delay when you don't have Internet access to random.org
AES128CounterSecureRNG() - Constructor for class akka.remote.security.provider.AES128CounterSecureRNG
 
AES256CounterInetRNG - Class in akka.remote.security.provider
Internal API This class is a wrapper around the 256-bit AESCounterRNG algorithm provided by http://maths.uncommons.org/ It uses the default seed generator which uses one of the following 3 random seed sources: Depending on availability: random.org, /dev/random, and SecureRandom (provided by Java) The only method used by netty ssl is engineNextBytes(bytes)
AES256CounterInetRNG() - Constructor for class akka.remote.security.provider.AES256CounterInetRNG
 
AES256CounterSecureRNG - Class in akka.remote.security.provider
Internal API This class is a wrapper around the 256-bit AESCounterRNG algorithm provided by http://maths.uncommons.org/ The only method used by netty ssl is engineNextBytes(bytes) This RNG is good to use to prevent startup delay when you don't have Internet access to random.org
AES256CounterSecureRNG() - Constructor for class akka.remote.security.provider.AES256CounterSecureRNG
 
Affinity - Class in akka.zeromq
The Affinity option shall set the I/O thread affinity for newly created connections on the specified socket.
Affinity(long) - Constructor for class akka.zeromq.Affinity
 
affinity() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its affinity configuration.
affinity() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its affinity configuration.
Affinity$ - Class in akka.zeromq
Gets the Affinity value
Affinity$() - Constructor for class akka.zeromq.Affinity$
 
after(FiniteDuration, Scheduler, Function0<Future<T>>, ExecutionContext) - Method in interface akka.pattern.FutureTimeoutSupport
Returns a Future that will be completed with the success or failure of the provided value after the specified duration.
after(FiniteDuration, Scheduler, ExecutionContext, Callable<Future<T>>) - Method in class akka.pattern.Patterns$
Returns a Future that will be completed with the success or failure of the provided Callable after the specified duration.
after(FiniteDuration, Scheduler, ExecutionContext, Future<T>) - Method in class akka.pattern.Patterns$
Returns a Future that will be completed with the success or failure of the provided value after the specified duration.
after(FiniteDuration, Scheduler, ExecutionContext, Callable<Future<T>>) - Static method in class akka.pattern.Patterns
Returns a Future that will be completed with the success or failure of the provided Callable after the specified duration.
after(FiniteDuration, Scheduler, ExecutionContext, Future<T>) - Static method in class akka.pattern.Patterns
Returns a Future that will be completed with the success or failure of the provided value after the specified duration.
after() - Method in interface akka.transactor.Transactor
A Receive block that runs after the coordinated transaction.
after(Object) - Method in class akka.transactor.UntypedTransactor
A Receive block that runs after the coordinated transaction.
afterAll() - Method in class akka.actor.mailbox.DurableMailboxSpec
 
afterAll() - Method in class akka.testkit.AkkaSpec
 
Agent<T> - Class in akka.agent
The Agent class was inspired by agents in Clojure.
Agent(T, ActorRefFactory, ActorSystem) - Constructor for class akka.agent.Agent
 
Agent(T, ActorSystem) - Constructor for class akka.agent.Agent
 
Agent$ - Class in akka.agent
Factory method for creating an Agent.
Agent$() - Constructor for class akka.agent.Agent$
 
akka - package akka
 
akka.actor - package akka.actor
 
akka.actor.dsl - package akka.actor.dsl
 
akka.actor.mailbox - package akka.actor.mailbox
 
akka.actor.mailbox.filebased - package akka.actor.mailbox.filebased
 
akka.actor.mailbox.filebased.filequeue - package akka.actor.mailbox.filebased.filequeue
 
akka.actor.mailbox.filebased.filequeue.tools - package akka.actor.mailbox.filebased.filequeue.tools
 
akka.agent - package akka.agent
 
akka.camel - package akka.camel
 
akka.camel.internal.component - package akka.camel.internal.component
 
akka.camel.javaapi - package akka.camel.javaapi
 
akka.cluster - package akka.cluster
 
akka.cluster.routing - package akka.cluster.routing
 
akka.contrib.jul - package akka.contrib.jul
 
akka.contrib.mailbox - package akka.contrib.mailbox
 
akka.contrib.pattern - package akka.contrib.pattern
 
akka.contrib.throttle - package akka.contrib.throttle
 
akka.dispatch - package akka.dispatch
 
akka.event - package akka.event
 
akka.event.japi - package akka.event.japi
 
akka.event.slf4j - package akka.event.slf4j
 
akka.japi - package akka.japi
 
akka.jmx - package akka.jmx
 
akka.kernel - package akka.kernel
 
akka.osgi - package akka.osgi
 
akka.osgi.aries.blueprint - package akka.osgi.aries.blueprint
 
akka.osgi.impl - package akka.osgi.impl
 
akka.pattern - package akka.pattern
 
akka.remote - package akka.remote
 
akka.remote.routing - package akka.remote.routing
 
akka.remote.security.provider - package akka.remote.security.provider
 
akka.remote.serialization - package akka.remote.serialization
 
akka.routing - package akka.routing
 
akka.serialization - package akka.serialization
 
akka.testkit - package akka.testkit
 
akka.transactor - package akka.transactor
 
akka.util - package akka.util
 
akka.util.internal - package akka.util.internal
 
akka.zeromq - package akka.zeromq
 
akkaActorClassLoader() - Method in class akka.osgi.OsgiActorSystemFactory$
Class loader of akka-actor bundle.
akkaActorClassLoader() - Static method in class akka.osgi.OsgiActorSystemFactory
Class loader of akka-actor bundle.
AkkaCamelException - Exception in akka.camel
An exception indicating that the exchange to the camel endpoint failed.
AkkaCamelException(Throwable) - Constructor for exception akka.camel.AkkaCamelException
 
AkkaException - Exception in akka
Akka base Exception.
AkkaException(String, Throwable) - Constructor for exception akka.AkkaException
 
AkkaException(String) - Constructor for exception akka.AkkaException
 
AkkaProvider - Class in akka.remote.security.provider
A provider that for AES128CounterRNGFast, a cryptographically secure random number generator through SecureRandom
AkkaProvider() - Constructor for class akka.remote.security.provider.AkkaProvider
 
AkkaProvider$ - Class in akka.remote.security.provider
A provider that for AES128CounterRNGFast, a cryptographically secure random number generator through SecureRandom
AkkaProvider$() - Constructor for class akka.remote.security.provider.AkkaProvider$
 
AkkaSpec - Class in akka.testkit
 
AkkaSpec(ActorSystem) - Constructor for class akka.testkit.AkkaSpec
 
AkkaSpec(com.typesafe.config.Config) - Constructor for class akka.testkit.AkkaSpec
 
AkkaSpec() - Constructor for class akka.testkit.AkkaSpec
 
AkkaSpec$ - Class in akka.testkit
 
AkkaSpec$() - Constructor for class akka.testkit.AkkaSpec$
 
AkkaSpecSpec - Class in akka.testkit
 
AkkaSpecSpec() - Constructor for class akka.testkit.AkkaSpecSpec
 
all() - Method in class akka.zeromq.Subscribe$
 
all() - Static method in class akka.zeromq.Subscribe
 
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, PartialFunction<Throwable, SupervisorStrategy.Directive>) - 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(int, Duration, Class<?>[]) - 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
 
allowLocalRoutees() - Method in class akka.cluster.routing.ClusterRouterSettings
 
alone() - Method in interface akka.transactor.Transactor
Default coordination - no other transactors.
alpha(FiniteDuration, FiniteDuration) - Method in class akka.cluster.EWMA$
Calculate the alpha (decay factor) used in EWMA from specified half-life and interval between observations.
alter(Function1<T, T>, Timeout) - Method in class akka.agent.Agent
Dispatch a function to update the internal state, and return a Future where that new state can be obtained within the given timeout.
alter(Function<T, T>, FiniteDuration) - Method in class akka.agent.Agent
Java API Dispatch a function to update the internal state, and return a Future where that new state can be obtained within the given timeout
alterOff(Function1<T, T>, Timeout, ExecutionContext) - Method in class akka.agent.Agent
Dispatch a function to update the internal state but on its own thread, and return a Future where that new state can be obtained within the given timeout.
alterOff(Function<T, T>, FiniteDuration, ExecutionContext) - Method in class akka.agent.Agent
Java API: Dispatch a function to update the internal state but on its own thread, and return a Future where that new state can be obtained within the given timeout.
ap() - Method in class akka.testkit.TestActor.SetAutoPilot
 
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, String) - Static method in class akka.actor.ActorSelection
Construct an ActorSelection from the given string representing a path relative to the given target.
apply() - Method in class akka.actor.ActorSystem$
Creates a new ActorSystem with the name "default", obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
apply(String) - Method in class akka.actor.ActorSystem$
Creates a new ActorSystem with the specified name, obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
apply(String, com.typesafe.config.Config) - Method in class akka.actor.ActorSystem$
Creates a new ActorSystem with the name "default", and the specified Config, then obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
apply(String, com.typesafe.config.Config, ClassLoader) - Method in class akka.actor.ActorSystem$
Creates a new ActorSystem with the name "default", the specified Config, and specified ClassLoader
apply() - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the name "default", obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
apply(String) - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the specified name, obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
apply(String, com.typesafe.config.Config) - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the name "default", and the specified Config, then obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
apply(String, com.typesafe.config.Config, ClassLoader) - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the name "default", the specified Config, and specified ClassLoader
apply(String, String) - Method in class akka.actor.Address$
Constructs a new Address with the specified protocol and system name
apply(String, String, String, int) - Method in class akka.actor.Address$
Constructs a new Address with the specified protocol, system name, host and port
apply(String, String) - Static method in class akka.actor.Address
Constructs a new Address with the specified protocol and system name
apply(String, String, String, int) - Static method in class akka.actor.Address
Constructs a new Address with the specified protocol, system name, host and port
apply(String) - Method in class akka.actor.AddressFromURIString$
Try to construct an Address from the given String or throw a java.net.MalformedURLException.
apply(String) - Static method in class akka.actor.AddressFromURIString
Try to construct an Address from the given String or throw a java.net.MalformedURLException.
apply(ActorSystem) - Method in interface akka.actor.ExtensionId
Returns an instance of the extension identified by this ExtensionId instance.
apply(Object) - Method in class akka.actor.FSM.NullFunction$
 
apply(A) - Method in class akka.actor.IO.Iteratee$
Wrap the provided value within a IO.Done IO.Iteratee.
apply() - Method in class akka.actor.IO.Iteratee$
Returns Iteratee.unit
apply(IO.Input) - Method in class akka.actor.IO.Iteratee
Processes the given IO.Input, returning the resulting Iteratee and the remaining Input.
apply(IO.Input) - Method in interface akka.actor.IO.IterateeRef
 
apply(Function0<IO.IterateeRef<V>>) - Method in class akka.actor.IO.IterateeRef.Map$
Uses a factory to create the initial IterateeRef for each new key.
apply(IO.Input) - Method in class akka.actor.IO.IterateeRefAsync
 
apply(IO.Input) - Method in class akka.actor.IO.IterateeRefSync
 
apply() - Method in class akka.actor.mailbox.filebased.filequeue.Counter
 
apply() - Method in class akka.actor.mailbox.filebased.filequeue.OverlaySetting
 
apply() - Method in class akka.actor.mailbox.filebased.filequeue.tools.QueueDumper
 
apply(ClassTag<T>) - Method in class akka.actor.Props$
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(Class<? 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 of the supplied class 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(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(Class<? 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 of the supplied class 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(ActorContext) - Method in class akka.actor.TypedActor$
Returns a contextual TypedActorFactory of this extension, this means that any TypedActors created by this TypedActorExtension will be children to the specified context, this allows for creating hierarchies of TypedActors.
apply(ActorContext) - Static method in class akka.actor.TypedActor
Returns a contextual TypedActorFactory of this extension, this means that any TypedActors created by this TypedActorExtension will be children to the specified context, this allows for creating hierarchies of TypedActors.
apply(Object) - Method in class akka.actor.TypedActor.MethodCall
Invokes the Method on the supplied instance
apply(Class<T>) - Method in class akka.actor.TypedProps$
Uses the supplied class as the factory for the TypedActor implementation, proxying all the interfaces it implements.
apply(Class<? super T>, Class<T>) - Method in class akka.actor.TypedProps$
Uses the supplied class as the factory for the TypedActor implementation, and that has the specified interface, or if the interface class is not an interface, all the interfaces it implements, appended in the sequence of interfaces.
apply(Class<? super T>, Function0<T>) - Method in class akka.actor.TypedProps$
Uses the supplied thunk as the factory for the TypedActor implementation, and that has the specified interface, or if the interface class is not an interface, all the interfaces it implements, appended in the sequence of interfaces.
apply(ClassTag<T>) - Method in class akka.actor.TypedProps$
Uses the supplied class as the factory for the TypedActor implementation, proxying all the interfaces it implements.
apply(Class<T>) - Static method in class akka.actor.TypedProps
Uses the supplied class as the factory for the TypedActor implementation, proxying all the interfaces it implements.
apply(Class<? super T>, Class<T>) - Static method in class akka.actor.TypedProps
Uses the supplied class as the factory for the TypedActor implementation, and that has the specified interface, or if the interface class is not an interface, all the interfaces it implements, appended in the sequence of interfaces.
apply(Class<? super T>, Function0<T>) - Static method in class akka.actor.TypedProps
Uses the supplied thunk as the factory for the TypedActor implementation, and that has the specified interface, or if the interface class is not an interface, all the interfaces it implements, appended in the sequence of interfaces.
apply(ClassTag<T>) - Static method in class akka.actor.TypedProps
Uses the supplied class as the factory for the TypedActor implementation, proxying all the interfaces it implements.
apply(T, ActorSystem) - Method in class akka.agent.Agent$
 
apply() - Method in class akka.agent.Agent
Read the internal state of the agent.
apply(Address, MemberStatus) - Method in class akka.cluster.Member$
 
apply(Address, MemberStatus) - Static method in class akka.cluster.Member
 
apply(int, int, boolean) - Method in class akka.cluster.routing.ClusterRouterSettings$
Settings for create and deploy of the routees
apply(int, int) - Method in class akka.cluster.routing.ClusterRouterSettings$
Settings for remote deployment of the routees, allowed to use routees on own node
apply(int, String, boolean) - Method in class akka.cluster.routing.ClusterRouterSettings$
Settings for lookup of the routees
apply(int, String) - Method in class akka.cluster.routing.ClusterRouterSettings$
Settings for lookup of the routees, allowed to use routees on own node
apply(int, int, boolean) - Static method in class akka.cluster.routing.ClusterRouterSettings
Settings for create and deploy of the routees
apply(int, int) - Static method in class akka.cluster.routing.ClusterRouterSettings
Settings for remote deployment of the routees, allowed to use routees on own node
apply(int, String, boolean) - Static method in class akka.cluster.routing.ClusterRouterSettings
Settings for lookup of the routees
apply(int, String) - Static method in class akka.cluster.routing.ClusterRouterSettings
Settings for lookup of the routees, allowed to use routees on own node
apply(String) - Method in class akka.cluster.VectorClock.Node$
 
apply() - Method in class akka.cluster.VectorClock.Timestamp$
 
apply(Object, ActorRef, ActorSystem) - Method in class akka.dispatch.Envelope$
 
apply(Object, ActorRef, ActorSystem) - Static method in class akka.dispatch.Envelope
 
apply(T) - Method in class akka.dispatch.japi.BooleanFunctionBridge
 
apply(T) - Method in class akka.dispatch.japi.CallbackBridge
 
apply(Throwable) - Method in class akka.dispatch.japi.RecoverBridge
 
apply(T) - Method in class akka.dispatch.japi.UnitFunctionBridge
 
apply(T) - Method in class akka.dispatch.Mapper
Override this method to perform the map operation, by default delegates to "checkedApply" which by default throws an UnsupportedOperationException.
apply(Function1<Object, Object>) - Method in class akka.dispatch.PriorityGenerator$
Creates a PriorityGenerator that uses the supplied function as priority generator
apply(Function1<Object, Object>) - Static method in class akka.dispatch.PriorityGenerator
Creates a PriorityGenerator that uses the supplied function as priority generator
apply(ActorSystem, T, LogSource<T>) - Method in class akka.event.Logging$
Obtain LoggingAdapter for the given actor system and source object.
apply(LoggingBus, T, LogSource<T>) - Method in class akka.event.Logging$
Obtain LoggingAdapter for the given logging bus and source object.
apply(ActorSystem, T, LogSource<T>) - Static method in class akka.event.Logging
Obtain LoggingAdapter for the given actor system and source object.
apply(LoggingBus, T, LogSource<T>) - Static method in class akka.event.Logging
Obtain LoggingAdapter for the given logging bus and source object.
apply(String, Class<?>, Object) - Method in class akka.event.Logging.Error$
 
apply(PartialFunction<Object, BoxedUnit>, ActorContext) - Method in class akka.event.LoggingReceive$
Wrap a Receive partial function in a logging enclosure, which sends a debug message to the event bus each time before a message is matched.
apply(Object) - Method in class akka.event.LoggingReceive
 
apply(T, LogSource<T>) - Method in class akka.event.LogSource$
Convenience converter access: given an implicit LogSource, generate the string representation and originating class.
apply(T, ActorSystem, LogSource<T>) - Method in class akka.event.LogSource$
Convenience converter access: given an implicit LogSource and ActorSystem, generate the string representation and originating class.
apply(T, LogSource<T>) - Method in interface akka.event.LogSource
Convenience converter access: given an implicit LogSource, generate the string representation and originating class.
apply(T, ActorSystem, LogSource<T>) - Method in interface akka.event.LogSource
Convenience converter access: given an implicit LogSource and ActorSystem, generate the string representation and originating class.
apply(String) - Method in class akka.event.slf4j.Logger$
 
apply(Class<?>, String) - Method in class akka.event.slf4j.Logger$
 
apply(String) - Static method in class akka.event.slf4j.Logger
 
apply(Class<?>, String) - Static method in class akka.event.slf4j.Logger
 
apply() - Method in interface akka.japi.Effect
 
apply(T) - Method in interface akka.japi.Function
 
apply(T1, T2) - Method in interface akka.japi.Function2
 
apply(A, boolean) - Method in class akka.japi.JavaPartialFunction
 
apply(A) - Method in class akka.japi.JavaPartialFunction
 
apply(T) - Method in interface akka.japi.Procedure
 
apply(org.osgi.framework.BundleContext) - Method in class akka.osgi.impl.BundleDelegatingClassLoader$
 
apply(org.osgi.framework.BundleContext) - Static method in class akka.osgi.impl.BundleDelegatingClassLoader
 
apply(org.osgi.framework.BundleContext) - Method in class akka.osgi.OsgiActorSystemFactory$
 
apply(org.osgi.framework.BundleContext) - Static method in class akka.osgi.OsgiActorSystemFactory
 
apply(Scheduler, int, FiniteDuration, FiniteDuration) - Method in class akka.pattern.CircuitBreaker$
Create a new CircuitBreaker.
apply(Scheduler, int, FiniteDuration, FiniteDuration) - Static method in class akka.pattern.CircuitBreaker
Create a new CircuitBreaker.
apply(Iterable<ActorRef>) - Method in class akka.routing.BroadcastRouter$
Creates a new BroadcastRouter, routing to the specified routees
apply(Iterable<ActorRef>) - Static method in class akka.routing.BroadcastRouter
Creates a new BroadcastRouter, routing to the specified routees
apply(Iterable<T>, int, ClassTag<T>) - Method in class akka.routing.ConsistentHash$
 
apply(Iterable<T>, int, ClassTag<T>) - Static method in class akka.routing.ConsistentHash
 
apply(Iterable<ActorRef>) - Method in class akka.routing.ConsistentHashingRouter$
Creates a new ConsistentHashingRouter, routing to the specified routees
apply(Iterable<ActorRef>) - Static method in class akka.routing.ConsistentHashingRouter
Creates a new ConsistentHashingRouter, routing to the specified routees
apply(Object) - Method in class akka.routing.ConsistentHashingRouter.emptyConsistentHashMapping$
 
apply(com.typesafe.config.Config) - Method in class akka.routing.DefaultResizer$
Creates a new DefaultResizer from the given configuration
apply(com.typesafe.config.Config) - Static method in class akka.routing.DefaultResizer
Creates a new DefaultResizer from the given configuration
apply(String) - Method in class akka.routing.FromConfig$
 
apply(String) - Static method in class akka.routing.FromConfig
 
apply(Iterable<ActorRef>) - Method in class akka.routing.RandomRouter$
Creates a new RandomRouter, routing to the specified routees
apply(Iterable<ActorRef>) - Static method in class akka.routing.RandomRouter
Creates a new RandomRouter, routing to the specified routees
apply(Iterable<ActorRef>) - Method in class akka.routing.RoundRobinRouter$
Creates a new RoundRobinRouter, routing to the specified routees
apply(Iterable<ActorRef>) - Static method in class akka.routing.RoundRobinRouter
Creates a new RoundRobinRouter, routing to the specified routees
apply(Iterable<ActorRef>, FiniteDuration) - Method in class akka.routing.ScatterGatherFirstCompletedRouter$
Creates a new ScatterGatherFirstCompletedRouter, routing to the specified routees, timing out after the specified Duration
apply(Iterable<ActorRef>, FiniteDuration) - Static method in class akka.routing.ScatterGatherFirstCompletedRouter
Creates a new ScatterGatherFirstCompletedRouter, routing to the specified routees, timing out after the specified Duration
apply(Iterable<ActorRef>) - Method in class akka.routing.SmallestMailboxRouter$
Creates a new SmallestMailboxRouter, routing to the specified routees
apply(Iterable<ActorRef>) - Static method in class akka.routing.SmallestMailboxRouter
Creates a new SmallestMailboxRouter, routing to the specified routees
apply(String, String, String, String, int, ClassTag<A>) - Method in class akka.testkit.EventFilter$
Create a filter for Error events.
apply(Logging.LogEvent) - Method in class akka.testkit.EventFilter
 
apply(ActorRef) - Method in class akka.testkit.ExtractRoute$
 
apply(ActorRef) - Static method in class akka.testkit.ExtractRoute
 
apply(Function0<T>, ActorSystem) - Method in class akka.testkit.TestActorRef$
 
apply(Function0<T>, String, ActorSystem) - Method in class akka.testkit.TestActorRef$
 
apply(Props, ActorSystem) - Method in class akka.testkit.TestActorRef$
 
apply(Props, String, ActorSystem) - Method in class akka.testkit.TestActorRef$
 
apply(Props, ActorRef, String, ActorSystem) - Method in class akka.testkit.TestActorRef$
 
apply(ClassTag<T>, ActorSystem) - Method in class akka.testkit.TestActorRef$
 
apply(String, ClassTag<T>, ActorSystem) - Method in class akka.testkit.TestActorRef$
 
apply(Function0<T>, ActorSystem) - Static method in class akka.testkit.TestActorRef
 
apply(Function0<T>, String, ActorSystem) - Static method in class akka.testkit.TestActorRef
 
apply(Props, ActorSystem) - Static method in class akka.testkit.TestActorRef
 
apply(Props, String, ActorSystem) - Static method in class akka.testkit.TestActorRef
 
apply(Props, ActorRef, String, ActorSystem) - Static method in class akka.testkit.TestActorRef
 
apply(ClassTag<T>, ActorSystem) - Static method in class akka.testkit.TestActorRef
 
apply(String, ClassTag<T>, ActorSystem) - Static method in class akka.testkit.TestActorRef
 
apply(int) - Method in class akka.testkit.TestBarrier$
 
apply(int) - Static method in class akka.testkit.TestBarrier
 
apply(EventFilter, Seq<EventFilter>) - Method in class akka.testkit.TestEvent.Mute$
 
apply(EventFilter, Seq<EventFilter>) - Method in class akka.testkit.TestEvent.UnMute$
 
apply(Function0<T>, Predef.$less$colon$less<T, FSM<S, D>>, ActorSystem) - Method in class akka.testkit.TestFSMRef$
 
apply(Function0<T>, String, Predef.$less$colon$less<T, FSM<S, D>>, ActorSystem) - Method in class akka.testkit.TestFSMRef$
 
apply(Function0<T>, Predef.$less$colon$less<T, FSM<S, D>>, ActorSystem) - Static method in class akka.testkit.TestFSMRef
 
apply(Function0<T>, String, Predef.$less$colon$less<T, FSM<S, D>>, ActorSystem) - Static method in class akka.testkit.TestFSMRef
 
apply(int, ActorSystem) - Method in class akka.testkit.TestLatch$
 
apply(int, ActorSystem) - Static method in class akka.testkit.TestLatch
 
apply(ActorSystem) - Method in class akka.testkit.TestProbe$
 
apply(ActorSystem) - Static method in class akka.testkit.TestProbe
 
apply(Object, Timeout) - Method in class akka.transactor.Coordinated$
Creates a new Coordinated with the given message and Timeout
apply(Object) - Method in class akka.transactor.Coordinated
Create a new Coordinated object and increment the number of members by one.
apply(Class<?>) - Method in class akka.util.BoxedType$
 
apply(Class<?>) - Static method in class akka.util.BoxedType
 
apply(byte[]) - Method in class akka.util.ByteIterator.ByteArrayIterator$
 
apply(byte[], int, int) - Method in class akka.util.ByteIterator.ByteArrayIterator$
 
apply(LinearSeq<ByteIterator.ByteArrayIterator>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator$
 
apply(byte[]) - Method in class akka.util.ByteString$
Creates a new ByteString by copying a byte array.
apply(Seq<Object>) - Method in class akka.util.ByteString$
Creates a new ByteString by copying bytes.
apply(Seq<T>, Integral<T>) - Method in class akka.util.ByteString$
Creates a new ByteString by converting from integral numbers to bytes.
apply(ByteBuffer) - Method in class akka.util.ByteString$
Creates a new ByteString by copying bytes from a ByteBuffer.
apply(String) - Method in class akka.util.ByteString$
Creates a new ByteString by encoding a String as UTF-8.
apply(String, String) - Method in class akka.util.ByteString$
Creates a new ByteString by encoding a String with a charset.
apply(int) - Method in class akka.util.ByteString
 
apply(int) - Method in class akka.util.ByteString.ByteString1
 
apply(int) - Method in class akka.util.ByteString.ByteString1C
 
apply(int) - Method in class akka.util.ByteString.ByteStrings
 
apply(byte[]) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by copying a byte array.
apply(Seq<Object>) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by copying bytes.
apply(Seq<T>, Integral<T>) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by converting from integral numbers to bytes.
apply(ByteBuffer) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by copying bytes from a ByteBuffer.
apply(String) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by encoding a String as UTF-8.
apply(String, String) - Method in class akka.util.CompactByteString$
Creates a new CompactByteString by encoding a String with a charset.
apply(byte[]) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by copying a byte array.
apply(Seq<Object>) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by copying bytes.
apply(Seq<T>, Integral<T>) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by converting from integral numbers to bytes.
apply(ByteBuffer) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by copying bytes from a ByteBuffer.
apply(String) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by encoding a String as UTF-8.
apply(String, String) - Static method in class akka.util.CompactByteString
Creates a new CompactByteString by encoding a String with a charset.
apply(long) - Method in class akka.util.Timeout$
 
apply(long, TimeUnit) - Method in class akka.util.Timeout$
 
apply(long) - Static method in class akka.util.Timeout
 
apply(long, TimeUnit) - Static method in class akka.util.Timeout
 
apply(int) - Method in class akka.zeromq.Context$
 
apply(int) - Static method in class akka.zeromq.Context
 
apply(Seq<Frame>) - Method in interface akka.zeromq.Deserializer
 
apply(String) - Method in class akka.zeromq.Frame$
 
apply(String) - Static method in class akka.zeromq.Frame
 
apply(String) - Method in class akka.zeromq.Subscribe$
 
apply(String) - Static method in class akka.zeromq.Subscribe
 
apply(String) - Method in class akka.zeromq.Unsubscribe$
 
apply(String) - Static method in class akka.zeromq.Unsubscribe
 
apply(byte[]) - Method in class akka.zeromq.ZMQMessage$
 
apply(com.google.protobuf.Message) - Method in class akka.zeromq.ZMQMessage$
 
apply(byte[]) - Static method in class akka.zeromq.ZMQMessage
 
apply(com.google.protobuf.Message) - Static method in class akka.zeromq.ZMQMessage
 
apply(Seq<Frame>) - Method in class akka.zeromq.ZMQMessageDeserializer
 
applyOrElse(A1, Function1<A1, B1>) - Method in class akka.japi.JavaPartialFunction
 
applyState(FSM.State<S, D>) - Method in interface akka.actor.FSM
 
ARRAY_OF_BYTE_ARRAY() - Method in class akka.remote.serialization.ProtobufSerializer
 
arrayBlockingQueue(int, boolean) - Method in class akka.dispatch.ThreadPoolConfig$
 
arrayBlockingQueue(int, boolean) - Static method in class akka.dispatch.ThreadPoolConfig
 
arrayHash(Object) - Method in class akka.routing.MurmurHash$
Compute a high-quality hash of an array
arrayHash(Object) - Static method in class akka.routing.MurmurHash
Compute a high-quality hash of an array
arrayToSeq(Object) - Method in class akka.japi.Util$
Turns an array into a Scala sequence.
arrayToSeq(Class<?>[]) - Method in class akka.japi.Util$
Returns a Scala sequence representing the provided array of Classes, an overloading of the generic arrayToSeq in Util, to accommodate for erasure.
arrayToSeq(Object) - Static method in class akka.japi.Util
Turns an array into a Scala sequence.
arrayToSeq(Class<?>[]) - Static method in class akka.japi.Util
Returns a Scala sequence representing the provided array of Classes, an overloading of the generic arrayToSeq in Util, to accommodate for erasure.
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
 
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(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(Object, Timeout) - Method in class akka.pattern.AskSupport.AskableActorRef
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.
AskSupport - Interface in akka.pattern
This object contains implementation details of the “ask” pattern.
AskSupport.AskableActorRef - Class in akka.pattern
Implementation detail of the “ask” pattern enrichment of ActorRef
AskSupport.AskableActorRef(ActorRef) - Constructor for class akka.pattern.AskSupport.AskableActorRef
 
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
 
atomic(Function1<scala.concurrent.stm.InTxn, A>) - Method in class akka.transactor.Coordinated
Delimits the coordinated transaction.
atomic(Runnable) - Method in class akka.transactor.Coordinated
Java API: coordinated atomic method that accepts a java.lang.Runnable.
atomic(Callable<A>) - Method in class akka.transactor.Coordinated
Java API: coordinated atomic method that accepts a java.util.concurrent.Callable.
atomically() - Method in interface akka.transactor.Transactor
The Receive block to run inside the coordinated transaction.
atomically(Object) - Method in class akka.transactor.UntypedTransactor
The Receive block to run inside the coordinated transaction.
atStartup() - Method in class akka.actor.mailbox.DurableMailboxSpec
May be implemented in concrete subclass to do additional things once before test cases are run.
atStartup() - Method in class akka.testkit.AkkaSpec
 
attach(akka.actor.ActorCell) - Method in class akka.dispatch.MessageDispatcher
Attaches the specified actor instance to this dispatcher, which includes scheduling it to run for the first time (Create() is expected to have been enqueued by the ActorCell upon mailbox creation).
atTermination() - Method in class akka.actor.mailbox.DurableMailboxSpec
May be implemented in concrete subclass to do additional things once after all test cases have been run.
atTermination() - Method in class akka.testkit.AkkaSpec
 
AutoAck() - Method in class akka.camel.CamelSettings
Configured setting which determines whether one-way communications between an endpoint and this consumer actor should be auto-acknowledged or application-acknowledged.
autoAck() - Method in interface akka.camel.Consumer
Determines whether one-way communications between an endpoint and this consumer actor should be auto-acknowledged or application-acknowledged.
AutoDown() - Method in class akka.cluster.ClusterSettings
 
AutoJoin() - Method in class akka.cluster.ClusterSettings
 
autopilot() - Method in class akka.testkit.TestActor
 
await(Timeout) - Method in class akka.agent.Agent
Gets this agent's value after all currently queued updates have completed.
await(ActorSystem) - Method in class akka.testkit.TestBarrier
 
await(FiniteDuration, ActorSystem) - Method in class akka.testkit.TestBarrier
 
await() - Method in class akka.transactor.Coordinated
An empty coordinated atomic block.
awaitCond(Function0<Object>, Duration, Duration, boolean) - Method in class akka.testkit.TestKit$
Await until the given condition evaluates to true or the timeout expires, whichever comes first.
awaitCond(Function0<Object>, Duration, Duration, boolean) - Static method in class akka.testkit.TestKit
Await until the given condition evaluates to true or the timeout expires, whichever comes first.
awaitCond(Function0<Object>, Duration, Duration) - Method in interface akka.testkit.TestKitBase
Await until the given condition evaluates to true or the timeout expires, whichever comes first.
awaitDone(Duration) - Method in class akka.testkit.EventFilter
 
awaitTermination(Duration) - Method in class akka.actor.ActorSystem
Block current thread until the system has been shutdown, or the specified timeout has elapsed.
awaitTermination() - Method in class akka.actor.ActorSystem
Block current thread until the system has been shutdown.
awaitTermination(long, TimeUnit) - Method in interface akka.dispatch.ExecutorServiceDelegate
 

B

backendName() - Method in class akka.actor.mailbox.DurableMailboxSpec
 
Backlog - Class in akka.zeromq
The Backlog option shall set the maximum length of the queue of outstanding peer connections for the specified socket; this only applies to connection-oriented transports.
Backlog(long) - Constructor for class akka.zeromq.Backlog
 
backlog() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its backlog configuration.
backlog() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its backlog configuration.
Backlog$ - Class in akka.zeromq
Gets the backlog
Backlog$() - Constructor for class akka.zeromq.Backlog$
 
backoff(int, int) - Method in class akka.routing.DefaultResizer
Computes a proposed negative (or zero) capacity delta using the configured backoffThreshold and backoffRate
backoffRate() - Method in class akka.routing.DefaultResizer
Fraction of routees to be removed when the resizer reaches the backoffThreshold.
backoffThreshold() - Method in class akka.routing.DefaultResizer
Minimum fraction of busy routees before backing off.
BalancingDispatcher - Class in akka.dispatch
An executor based event driven dispatcher which will try to redistribute work from busy actors to idle actors.
BalancingDispatcher(DispatcherPrerequisites, String, int, Duration, MailboxType, ExecutorServiceFactoryProvider, FiniteDuration, boolean) - Constructor for class akka.dispatch.BalancingDispatcher
 
BalancingDispatcherConfigurator - Class in akka.dispatch
Configurator for creating BalancingDispatcher.
BalancingDispatcherConfigurator(com.typesafe.config.Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.BalancingDispatcherConfigurator
 
bandwidth() - Method in class akka.actor.IO.PerformancePreferences
 
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
 
become(PartialFunction<Object, BoxedUnit>, boolean) - Method in interface akka.actor.ActorContext
Changes the Actor's behavior to become the new 'Receive' (PartialFunction[Any, Unit]) handler.
become(PartialFunction<Object, BoxedUnit>) - Method in interface akka.actor.dsl.Creators.Act
Replace the behavior at the top of the behavior stack for this actor.
become(Procedure<Object>) - Method in interface akka.actor.UntypedActorContext
Changes the Actor's behavior to become the new 'Procedure' handler.
become(Procedure<Object>, boolean) - Method in interface akka.actor.UntypedActorContext
Changes the Actor's behavior to become the new 'Procedure' handler.
becomeStacked(PartialFunction<Object, BoxedUnit>) - Method in interface akka.actor.dsl.Creators.Act
Add the given behavior on top of the behavior stack for this actor.
before() - Method in interface akka.transactor.Transactor
A Receive block that runs before the coordinated transaction is entered.
before(Object) - Method in class akka.transactor.UntypedTransactor
A Receive block that runs before the coordinated transaction is entered.
beforeAll() - Method in class akka.actor.mailbox.DurableMailboxSpec
 
beforeAll() - Method in class akka.testkit.AkkaSpec
 
beforeEach() - Method in class akka.testkit.TestActorRefSpec
 
Bind - Class in akka.zeromq
Start listening with this server socket on the specified address
Bind(String) - Constructor for class akka.zeromq.Bind
 
Bind$ - Class in akka.zeromq
 
Bind$() - Constructor for class akka.zeromq.Bind$
 
bindings() - Method in class akka.serialization.Serialization
bindings is a Seq of tuple representing the mapping from Class to Serializer.
BlueprintActorSystemFactory - Class in akka.osgi.aries.blueprint
A set of helper/factory classes to build a Akka system using Blueprint.
BlueprintActorSystemFactory(org.osgi.framework.BundleContext, String, Option<ClassLoader>) - Constructor for class akka.osgi.aries.blueprint.BlueprintActorSystemFactory
 
BlueprintActorSystemFactory(org.osgi.framework.BundleContext, String) - Constructor for class akka.osgi.aries.blueprint.BlueprintActorSystemFactory
 
body() - Method in class akka.camel.CamelMessage
 
bodyAs(ClassTag<T>, org.apache.camel.CamelContext) - Method in class akka.camel.CamelMessage
Returns the body of the message converted to the type T.
Bootable - Interface in akka.kernel
To use the microkernel at least one 'boot class' needs to be specified.
boss() - Method in class akka.actor.ActorDSL.Extension
 
BoundedBlockingQueue<E> - Class in akka.util
BoundedBlockingQueue wraps any Queue and turns the result into a BlockingQueue with a limited capacity
BoundedBlockingQueue(int, Queue<E>) - Constructor for class akka.util.BoundedBlockingQueue
 
BoundedDequeBasedMailbox - Class in akka.dispatch
BoundedDequeBasedMailbox is an bounded MailboxType, backed by a Deque.
BoundedDequeBasedMailbox(int, FiniteDuration) - Constructor for class akka.dispatch.BoundedDequeBasedMailbox
 
BoundedDequeBasedMailbox(ActorSystem.Settings, com.typesafe.config.Config) - Constructor for class akka.dispatch.BoundedDequeBasedMailbox
 
BoundedDequeBasedMailbox$ - Class in akka.dispatch
 
BoundedDequeBasedMailbox$() - Constructor for class akka.dispatch.BoundedDequeBasedMailbox$
 
BoundedDequeBasedMessageQueueSemantics - Interface in akka.dispatch
BoundedMessageQueueSemantics adds bounded semantics to a DequeBasedMessageQueue, i.e. blocking enqueue with timeout
BoundedMailbox - Class in akka.dispatch
BoundedMailbox is the default bounded MailboxType used by Akka Actors.
BoundedMailbox(int, FiniteDuration) - Constructor for class akka.dispatch.BoundedMailbox
 
BoundedMailbox(ActorSystem.Settings, com.typesafe.config.Config) - Constructor for class akka.dispatch.BoundedMailbox
 
BoundedMailbox$ - Class in akka.dispatch
 
BoundedMailbox$() - Constructor for class akka.dispatch.BoundedMailbox$
 
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 priorization of its contents.
BoundedPriorityMailbox(Comparator<Envelope>, int, Duration) - Constructor for class akka.dispatch.BoundedPriorityMailbox
 
BoxedType - Class in akka.util
 
BoxedType() - Constructor for class akka.util.BoxedType
 
BoxedType$ - Class in akka.util
 
BoxedType$() - Constructor for class akka.util.BoxedType$
 
breaker() - Method in class akka.actor.mailbox.filebased.FileBasedMessageQueue
 
Broadcast - 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$
 
BrokenItemException - Exception in akka.actor.mailbox.filebased.filequeue
 
BrokenItemException(long, Throwable) - Constructor for exception akka.actor.mailbox.filebased.filequeue.BrokenItemException
 
BrokenItemException$ - Class in akka.actor.mailbox.filebased.filequeue
 
BrokenItemException$() - Constructor for class akka.actor.mailbox.filebased.filequeue.BrokenItemException$
 
build() - Method in class akka.remote.RemoteProtocol.ActorRefProtocol.Builder
 
build() - Method in class akka.remote.RemoteProtocol.AddressProtocol.Builder
 
build() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
build() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
build() - Method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
build() - Method in class akka.remote.RemoteProtocol.MessageProtocol.Builder
 
build() - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol.Builder
 
build() - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
build() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
build() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
buildPartial() - Method in class akka.remote.RemoteProtocol.ActorRefProtocol.Builder
 
buildPartial() - Method in class akka.remote.RemoteProtocol.AddressProtocol.Builder
 
buildPartial() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
buildPartial() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
buildPartial() - Method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
buildPartial() - Method in class akka.remote.RemoteProtocol.MessageProtocol.Builder
 
buildPartial() - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol.Builder
 
buildPartial() - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
buildPartial() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
buildPartial() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
BundleDelegatingClassLoader - Class in akka.osgi.impl
 
BundleDelegatingClassLoader(org.osgi.framework.Bundle, Option<ClassLoader>) - Constructor for class akka.osgi.impl.BundleDelegatingClassLoader
 
BundleDelegatingClassLoader(org.osgi.framework.Bundle) - Constructor for class akka.osgi.impl.BundleDelegatingClassLoader
 
BundleDelegatingClassLoader$ - Class in akka.osgi.impl
 
BundleDelegatingClassLoader$() - Constructor for class akka.osgi.impl.BundleDelegatingClassLoader$
 
bus() - Method in class akka.event.BusLogging
 
bus() - Method in class akka.event.Logging.InitializeLogger
 
BusLogging - Class in akka.event
 
BusLogging(LoggingBus, String, Class<?>) - Constructor for class akka.event.BusLogging
 
ByteArraySerializer - Class in akka.serialization
This is a special Serializer that Serializes and deserializes byte arrays only, (just returns the byte array unchanged/uncopied)
ByteArraySerializer() - Constructor for class akka.serialization.ByteArraySerializer
 
ByteIterator - Class in akka.util
An iterator over a ByteString.
ByteIterator() - Constructor for class akka.util.ByteIterator
 
ByteIterator$ - Class in akka.util
 
ByteIterator$() - Constructor for class akka.util.ByteIterator$
 
ByteIterator.ByteArrayIterator - Class in akka.util
 
ByteIterator.ByteArrayIterator$ - Class in akka.util
 
ByteIterator.ByteArrayIterator$() - Constructor for class akka.util.ByteIterator.ByteArrayIterator$
 
ByteIterator.MultiByteArrayIterator - Class in akka.util
 
ByteIterator.MultiByteArrayIterator$ - Class in akka.util
 
ByteIterator.MultiByteArrayIterator$() - Constructor for class akka.util.ByteIterator.MultiByteArrayIterator$
 
bytes() - Method in class akka.actor.IO.Chunk
 
bytes() - Method in class akka.actor.IO.Read
 
bytes() - Method in class akka.actor.IO.Write
 
bytes() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
bytesToHuman(long, long) - Method in class akka.actor.mailbox.filebased.filequeue.tools.Util$
 
bytesToHuman(long, long) - Static method in class akka.actor.mailbox.filebased.filequeue.tools.Util
 
bytesToInt(byte[], int) - Method in class akka.util.Convert$
 
bytesToInt(byte[], int) - Static method in class akka.util.Convert
 
bytesToLong(byte[]) - Method in class akka.util.Convert$
 
bytesToLong(byte[]) - Static method in class akka.util.Convert
 
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
 
CallingThreadDispatcher - Class in akka.testkit
 
CallingThreadDispatcher(DispatcherPrerequisites, MailboxType, String) - Constructor for class akka.testkit.CallingThreadDispatcher
 
CallingThreadDispatcher$ - Class in akka.testkit
 
CallingThreadDispatcher$() - Constructor for class akka.testkit.CallingThreadDispatcher$
 
CallingThreadDispatcherConfigurator - Class in akka.testkit
 
CallingThreadDispatcherConfigurator(com.typesafe.config.Config, DispatcherPrerequisites) - Constructor for class akka.testkit.CallingThreadDispatcherConfigurator
 
CallingThreadMailbox - Class in akka.testkit
 
CallingThreadMailbox(akka.actor.Cell, MailboxType) - Constructor for class akka.testkit.CallingThreadMailbox
 
callTimeout() - Method in class akka.cluster.CircuitBreakerSettings
 
callWithCircuitBreaker(Callable<Future<T>>) - Method in class akka.pattern.CircuitBreaker
Java API for CircuitBreaker.withCircuitBreaker(scala.Function0>)
callWithSyncCircuitBreaker(Callable<T>) - Method in class akka.pattern.CircuitBreaker
Java API for CircuitBreaker.withSyncCircuitBreaker(scala.Function0)
Camel - Interface in akka.camel
Camel trait encapsulates the underlying camel machinery.
CamelExtension - Class in akka.camel
This class can be used to get hold of an instance of the Camel class bound to the actor system.
CamelExtension() - Constructor for class akka.camel.CamelExtension
 
CamelExtension$ - Class in akka.camel
This class can be used to get hold of an instance of the Camel class bound to the actor system.
CamelExtension$() - Constructor for class akka.camel.CamelExtension$
 
CamelMessage - Class in akka.camel
An immutable representation of a Camel message.
CamelMessage(Object, Map<String, Object>) - Constructor for class akka.camel.CamelMessage
 
CamelMessage(Object, Map<String, Object>) - Constructor for class akka.camel.CamelMessage
 
CamelMessage$ - Class in akka.camel
Companion object of CamelMessage class.
CamelMessage$() - Constructor for class akka.camel.CamelMessage$
 
CamelPath - Class in akka.camel.internal.component
Converts ActorRefs and actorPaths to URI's that point to the actor through the Camel Actor Component.
CamelPath() - Constructor for class akka.camel.internal.component.CamelPath
 
CamelPath$ - Class in akka.camel.internal.component
Converts ActorRefs and actorPaths to URI's that point to the actor through the Camel Actor Component.
CamelPath$() - Constructor for class akka.camel.internal.component.CamelPath$
 
CamelSettings - Class in akka.camel
Settings for the Camel Extension
canBuildFrom() - Method in class akka.util.ByteString$
 
canBuildFrom() - Static method in class akka.util.ByteString
 
cancel() - Method in interface akka.actor.Cancellable
Cancels this Cancellable Java & Scala API
cancel() - Method in class akka.actor.FSM.Timer
 
cancel(Object) - Method in class akka.transactor.Coordinated
Cancel this Coordinated transaction.
cancel() - Method in interface akka.util.internal.Timeout
Cancels the TimerTask associated with this handle.
Cancellable - Interface in akka.actor
Signifies something that can be cancelled There is no strict guarantee that the implementation is thread-safe, but it should be good practice to make it so.
cancelTimer(String) - Method in interface akka.actor.FSM
Cancel named timer, ensuring that the message is not subsequently delivered (no race).
cancelTimer(String) - Method in class akka.testkit.TestFSMRef
Proxy for FSM.cancelTimer.
capacity() - Method in interface akka.actor.Stash
 
capacity(Set<NodeMetrics>) - Method in class akka.cluster.routing.CapacityMetricsSelector
Remaining capacity for each node.
capacity(Set<NodeMetrics>) - Method in class akka.cluster.routing.CpuMetricsSelector$
 
capacity(Set<NodeMetrics>) - Static method in class akka.cluster.routing.CpuMetricsSelector
 
capacity(Set<NodeMetrics>) - Method in class akka.cluster.routing.HeapMetricsSelector$
 
capacity(Set<NodeMetrics>) - Static method in class akka.cluster.routing.HeapMetricsSelector
 
capacity(Set<NodeMetrics>) - Method in class akka.cluster.routing.MixMetricsSelectorBase
 
capacity(Set<NodeMetrics>) - Method in class akka.cluster.routing.SystemLoadAverageMetricsSelector$
 
capacity(Set<NodeMetrics>) - Static method in class akka.cluster.routing.SystemLoadAverageMetricsSelector
 
capacity() - Method in class akka.dispatch.BoundedDequeBasedMailbox
 
capacity() - Method in class akka.dispatch.BoundedMailbox
 
capacity() - Method in class akka.dispatch.BoundedPriorityMailbox
 
capacity(IndexedSeq<ActorRef>) - Method in class akka.routing.DefaultResizer
Returns the overall desired change in resizer capacity.
CapacityMetricsSelector - Class in akka.cluster.routing
A MetricsSelector producing weights from remaining capacity.
CapacityMetricsSelector() - Constructor for class akka.cluster.routing.CapacityMetricsSelector
 
cause() - Method in class akka.actor.FSM.Failure
 
cause() - Method in class akka.actor.IO.Closed
 
cause() - Method in class akka.actor.IO.Error
 
cause() - Method in class akka.actor.IO.Failure
 
cause() - Method in exception akka.actor.mailbox.filebased.filequeue.BrokenItemException
 
cause() - Method in exception akka.actor.PostRestartException
 
cause() - Method in exception akka.actor.PreRestartException
 
cause() - Method in class akka.actor.Status.Failure
 
cause() - Method in class akka.event.Logging.Error
 
cause() - Method in class akka.remote.RemoteClientError
 
cause() - Method in class akka.remote.RemoteServerError
 
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
 
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$
 
CircuitBreakerCallTimeout() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
CircuitBreakerMaxFailures() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
CircuitBreakerOpenException - Exception in akka.pattern
Exception thrown when Circuit Breaker is open.
CircuitBreakerOpenException(FiniteDuration, String) - Constructor for exception akka.pattern.CircuitBreakerOpenException
 
CircuitBreakerOpenException$ - Class in akka.pattern
 
CircuitBreakerOpenException$() - Constructor for class akka.pattern.CircuitBreakerOpenException$
 
CircuitBreakerResetTimeout() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
CircuitBreakerSettings - Class in akka.cluster
 
CircuitBreakerSettings(int, FiniteDuration, FiniteDuration) - Constructor for class akka.cluster.CircuitBreakerSettings
 
CircuitBreakerSettings$ - Class in akka.cluster
 
CircuitBreakerSettings$() - Constructor for class akka.cluster.CircuitBreakerSettings$
 
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.
cleanUp(ActorRef, MessageQueue) - Method in class akka.actor.mailbox.filebased.FileBasedMessageQueue
 
cleanUp(ActorRef, MessageQueue) - Method in class akka.contrib.mailbox.PeekMailbox
 
cleanUp(ActorRef, MessageQueue) - Method in interface akka.dispatch.MessageQueue
Called when the mailbox this queue belongs to is disposed of.
cleanUp(ActorRef, MessageQueue) - Method in interface akka.dispatch.QueueBasedMessageQueue
 
cleanup() - Method in class akka.dispatch.TaskInvocation
 
cleanUp() - Method in class akka.testkit.CallingThreadMailbox
 
cleanupOverdueNotMemberAnyMore() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
clear() - Method in class akka.remote.RemoteProtocol.ActorRefProtocol.Builder
 
clear() - Method in class akka.remote.RemoteProtocol.AddressProtocol.Builder
 
clear() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
clear() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
clear() - Method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
clear() - Method in class akka.remote.RemoteProtocol.MessageProtocol.Builder
 
clear() - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol.Builder
 
clear() - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
clear() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
clear() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
clear() - Method in class akka.util.BoundedBlockingQueue
 
clear() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
clear() - Method in class akka.util.ByteIterator
 
clear() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
clear() - Method in class akka.util.ByteStringBuilder
 
clear() - Method in class akka.util.Index
Removes all keys and all values
clear() - Method in class akka.util.internal.ConcurrentIdentityHashMap
Removes all of the mappings from this map.
clearCommandType() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
clearConfig() - Method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
clearCookie() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
clearCreator() - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
clearDeploy() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
clearDeploy() - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
clearDispatcher() - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
clearedList() - Method in class akka.util.ByteIterator.MultiByteArrayIterator$
 
clearFromClassCreator() - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
clearHostname() - Method in class akka.remote.RemoteProtocol.AddressProtocol.Builder
 
clearInstruction() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
clearKey() - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol.Builder
 
clearMessage() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
clearMessage() - Method in class akka.remote.RemoteProtocol.MessageProtocol.Builder
 
clearMessage() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
clearMessageManifest() - Method in class akka.remote.RemoteProtocol.MessageProtocol.Builder
 
clearMetadata() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
clearOrigin() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
clearPath() - Method in class akka.remote.RemoteProtocol.ActorRefProtocol.Builder
 
clearPath() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
clearPath() - Method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
clearPort() - Method in class akka.remote.RemoteProtocol.AddressProtocol.Builder
 
clearProps() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
clearRecipient() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
clearRouterConfig() - Method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
clearRouterConfig() - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
clearScope() - Method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
clearSender() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
clearSerializerId() - Method in class akka.remote.RemoteProtocol.MessageProtocol.Builder
 
clearSupervisor() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
clearSystem() - Method in class akka.remote.RemoteProtocol.AddressProtocol.Builder
 
clearValue() - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol.Builder
 
client() - Method in class akka.actor.dsl.Inbox.Get
 
client() - Method in interface akka.actor.dsl.Inbox.Query
 
client() - Method in class akka.actor.dsl.Inbox.Select
 
Client - Class in akka.jmx
A Simple Command-Line JMX Client.
Client() - Constructor for class akka.jmx.Client
Constructor.
client() - Method in exception akka.remote.RemoteClientException
 
Client.CommandParse - Class in akka.jmx
Class that parses commandline arguments.
Client.CommandParse(String) - Constructor for class akka.jmx.Client.CommandParse
 
clientAddress() - Method in class akka.remote.RemoteServerClientClosed
 
clientAddress() - Method in class akka.remote.RemoteServerClientConnected
 
clientAddress() - Method in class akka.remote.RemoteServerClientDisconnected
 
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.cluster.AccrualFailureDetector
 
clone() - Method in class akka.remote.RemoteProtocol.ActorRefProtocol.Builder
 
clone() - Method in class akka.remote.RemoteProtocol.AddressProtocol.Builder
 
clone() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
clone() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
clone() - Method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
clone() - Method in class akka.remote.RemoteProtocol.MessageProtocol.Builder
 
clone() - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol.Builder
 
clone() - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
clone() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
clone() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
clone() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
clone() - Method in class akka.util.ByteIterator
 
clone() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
close() - Method in class akka.actor.DefaultScheduler
 
close() - Method in interface akka.actor.IO.Handle
Sends a request to the IOManager to close the Channel associated with this IO.Handle.
close() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
close() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
Close the queue's journal file.
close() - Method in class akka.agent.Agent
Closes the agents and makes it eligible for garbage collection.
close() - Method in class akka.cluster.JmxMetricsCollector
 
close() - Method in class akka.cluster.SigarMetricsCollector
Releases any native resources associated with this instance.
Closed - Class in akka.zeromq
When the ZeroMQ socket disconnects it sends this message to a listener
Closed() - Constructor for class akka.zeromq.Closed
 
closed() - Method in class akka.zeromq.ZeroMQ$
The message that is sent when an ZeroMQ socket disconnects.
closed() - Static method in class akka.zeromq.ZeroMQ
The message that is sent when an ZeroMQ socket disconnects.
Closed$ - Class in akka.zeromq
When the ZeroMQ socket disconnects it sends this message to a listener
Closed$() - Constructor for class akka.zeromq.Closed$
 
Cluster - Class in akka.cluster
This module is responsible for Gossiping cluster information.
Cluster(ExtendedActorSystem) - Constructor for class akka.cluster.Cluster
 
cluster() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
Cluster$ - Class in akka.cluster
Cluster Extension Id and factory for creating Cluster extension.
Cluster$() - Constructor for class akka.cluster.Cluster$
 
ClusterActorRefProvider - Class in akka.cluster
INTERNAL API The ClusterActorRefProvider will load the Cluster extension, i.e. the cluster will automatically be started when the ClusterActorRefProvider is used.
ClusterActorRefProvider(String, ActorSystem.Settings, EventStream, Scheduler, DynamicAccess) - Constructor for class akka.cluster.ClusterActorRefProvider
 
clusterCore() - Method in class akka.cluster.Cluster
INTERNAL API
ClusterEvent - Class in akka.cluster
Domain events published to the event bus.
ClusterEvent() - Constructor for class akka.cluster.ClusterEvent
 
ClusterEvent$ - Class in akka.cluster
Domain events published to the event bus.
ClusterEvent$() - Constructor for class akka.cluster.ClusterEvent$
 
ClusterEvent.ClusterDomainEvent - Interface in akka.cluster
Marker interface for cluster domain events.
ClusterEvent.ClusterMetricsChanged - Class in akka.cluster
Current snapshot of cluster node metrics.
ClusterEvent.ClusterMetricsChanged(Set<NodeMetrics>) - Constructor for class akka.cluster.ClusterEvent.ClusterMetricsChanged
 
ClusterEvent.ClusterMetricsChanged$ - Class in akka.cluster
 
ClusterEvent.ClusterMetricsChanged$() - Constructor for class akka.cluster.ClusterEvent.ClusterMetricsChanged$
 
ClusterEvent.CurrentClusterState - Class in akka.cluster
Current snapshot state of the cluster.
ClusterEvent.CurrentClusterState(SortedSet<Member>, Set<Member>, Set<Address>, Option<Address>) - Constructor for class akka.cluster.ClusterEvent.CurrentClusterState
 
ClusterEvent.CurrentClusterState$ - Class in akka.cluster
 
ClusterEvent.CurrentClusterState$() - Constructor for class akka.cluster.ClusterEvent.CurrentClusterState$
 
ClusterEvent.InstantClusterState - Class in akka.cluster
Current snapshot state of the cluster.
ClusterEvent.InstantClusterState(SortedSet<Member>) - Constructor for class akka.cluster.ClusterEvent.InstantClusterState
 
ClusterEvent.InstantClusterState$ - Class in akka.cluster
 
ClusterEvent.InstantClusterState$() - Constructor for class akka.cluster.ClusterEvent.InstantClusterState$
 
ClusterEvent.InstantMemberDowned - Class in akka.cluster
Member status changed to Down.
ClusterEvent.InstantMemberDowned(Member) - Constructor for class akka.cluster.ClusterEvent.InstantMemberDowned
 
ClusterEvent.InstantMemberDowned$ - Class in akka.cluster
 
ClusterEvent.InstantMemberDowned$() - Constructor for class akka.cluster.ClusterEvent.InstantMemberDowned$
 
ClusterEvent.InstantMemberEvent - Interface in akka.cluster
Marker interface for membership events published immediately when it happened.
ClusterEvent.InstantMemberExited - Class in akka.cluster
Member status changed to Exiting.
ClusterEvent.InstantMemberExited(Member) - Constructor for class akka.cluster.ClusterEvent.InstantMemberExited
 
ClusterEvent.InstantMemberExited$ - Class in akka.cluster
 
ClusterEvent.InstantMemberExited$() - Constructor for class akka.cluster.ClusterEvent.InstantMemberExited$
 
ClusterEvent.InstantMemberJoined - Class in akka.cluster
A new member joined the cluster.
ClusterEvent.InstantMemberJoined(Member) - Constructor for class akka.cluster.ClusterEvent.InstantMemberJoined
 
ClusterEvent.InstantMemberJoined$ - Class in akka.cluster
 
ClusterEvent.InstantMemberJoined$() - Constructor for class akka.cluster.ClusterEvent.InstantMemberJoined$
 
ClusterEvent.InstantMemberLeft - Class in akka.cluster
Member status changed to Leaving.
ClusterEvent.InstantMemberLeft(Member) - Constructor for class akka.cluster.ClusterEvent.InstantMemberLeft
 
ClusterEvent.InstantMemberLeft$ - Class in akka.cluster
 
ClusterEvent.InstantMemberLeft$() - Constructor for class akka.cluster.ClusterEvent.InstantMemberLeft$
 
ClusterEvent.InstantMemberRemoved - Class in akka.cluster
Member completely removed from the cluster.
ClusterEvent.InstantMemberRemoved(Member) - Constructor for class akka.cluster.ClusterEvent.InstantMemberRemoved
 
ClusterEvent.InstantMemberRemoved$ - Class in akka.cluster
 
ClusterEvent.InstantMemberRemoved$() - Constructor for class akka.cluster.ClusterEvent.InstantMemberRemoved$
 
ClusterEvent.InstantMemberUp - Class in akka.cluster
Member status changed to Up.
ClusterEvent.InstantMemberUp(Member) - Constructor for class akka.cluster.ClusterEvent.InstantMemberUp
 
ClusterEvent.InstantMemberUp$ - Class in akka.cluster
 
ClusterEvent.InstantMemberUp$() - Constructor for class akka.cluster.ClusterEvent.InstantMemberUp$
 
ClusterEvent.LeaderChanged - Class in akka.cluster
Leader of the cluster members changed.
ClusterEvent.LeaderChanged(Option<Address>) - Constructor for class akka.cluster.ClusterEvent.LeaderChanged
 
ClusterEvent.LeaderChanged$ - Class in akka.cluster
 
ClusterEvent.LeaderChanged$() - Constructor for class akka.cluster.ClusterEvent.LeaderChanged$
 
ClusterEvent.MemberDowned - Class in akka.cluster
Member status changed to Down.
ClusterEvent.MemberDowned(Member) - Constructor for class akka.cluster.ClusterEvent.MemberDowned
 
ClusterEvent.MemberDowned$ - Class in akka.cluster
 
ClusterEvent.MemberDowned$() - Constructor for class akka.cluster.ClusterEvent.MemberDowned$
 
ClusterEvent.MemberEvent - Interface in akka.cluster
Marker interface for membership events.
ClusterEvent.MemberExited - Class in akka.cluster
Member status changed to Exiting.
ClusterEvent.MemberExited(Member) - Constructor for class akka.cluster.ClusterEvent.MemberExited
 
ClusterEvent.MemberExited$ - Class in akka.cluster
 
ClusterEvent.MemberExited$() - Constructor for class akka.cluster.ClusterEvent.MemberExited$
 
ClusterEvent.MemberJoined - Class in akka.cluster
A new member joined the cluster.
ClusterEvent.MemberJoined(Member) - Constructor for class akka.cluster.ClusterEvent.MemberJoined
 
ClusterEvent.MemberJoined$ - Class in akka.cluster
 
ClusterEvent.MemberJoined$() - Constructor for class akka.cluster.ClusterEvent.MemberJoined$
 
ClusterEvent.MemberLeft - Class in akka.cluster
Member status changed to Leaving.
ClusterEvent.MemberLeft(Member) - Constructor for class akka.cluster.ClusterEvent.MemberLeft
 
ClusterEvent.MemberLeft$ - Class in akka.cluster
 
ClusterEvent.MemberLeft$() - Constructor for class akka.cluster.ClusterEvent.MemberLeft$
 
ClusterEvent.MemberRemoved - Class in akka.cluster
Member completely removed from the cluster.
ClusterEvent.MemberRemoved(Member) - Constructor for class akka.cluster.ClusterEvent.MemberRemoved
 
ClusterEvent.MemberRemoved$ - Class in akka.cluster
 
ClusterEvent.MemberRemoved$() - Constructor for class akka.cluster.ClusterEvent.MemberRemoved$
 
ClusterEvent.MemberUp - Class in akka.cluster
Member status changed to Up.
ClusterEvent.MemberUp(Member) - Constructor for class akka.cluster.ClusterEvent.MemberUp
 
ClusterEvent.MemberUp$ - Class in akka.cluster
 
ClusterEvent.MemberUp$() - Constructor for class akka.cluster.ClusterEvent.MemberUp$
 
ClusterEvent.UnreachableMember - Class in akka.cluster
A member is considered as unreachable by the failure detector.
ClusterEvent.UnreachableMember(Member) - Constructor for class akka.cluster.ClusterEvent.UnreachableMember
 
ClusterEvent.UnreachableMember$ - Class in akka.cluster
 
ClusterEvent.UnreachableMember$() - Constructor for class akka.cluster.ClusterEvent.UnreachableMember$
 
ClusterMessage - Interface in akka.cluster
Base trait for all cluster messages.
ClusterNodeMBean - Interface in akka.cluster
Interface for the cluster JMX MBean.
ClusterRouterConfig - Class in akka.cluster.routing
RouterConfig implementation for deployment on cluster nodes.
ClusterRouterConfig(RouterConfig, ClusterRouterSettings) - Constructor for class akka.cluster.routing.ClusterRouterConfig
 
ClusterRouterConfig$ - Class in akka.cluster.routing
 
ClusterRouterConfig$() - Constructor for class akka.cluster.routing.ClusterRouterConfig$
 
ClusterRouterSettings - Class in akka.cluster.routing
totalInstances of cluster router must be > 0 maxInstancesPerNode of cluster router must be > 0 maxInstancesPerNode of cluster router must be 1 when routeesPath is defined
ClusterRouterSettings(int, int, boolean) - Constructor for class akka.cluster.routing.ClusterRouterSettings
Java API: Settings for create and deploy of the routees
ClusterRouterSettings(int, String, boolean) - Constructor for class akka.cluster.routing.ClusterRouterSettings
Java API: Settings for lookup of the routees
ClusterRouterSettings$ - Class in akka.cluster.routing
 
ClusterRouterSettings$() - Constructor for class akka.cluster.routing.ClusterRouterSettings$
 
ClusterScope - Class in akka.cluster
 
ClusterScope() - Constructor for class akka.cluster.ClusterScope
 
ClusterScope$ - Class in akka.cluster
Cluster aware scope of a Deploy
ClusterScope$() - Constructor for class akka.cluster.ClusterScope$
 
ClusterSettings - Class in akka.cluster
 
ClusterSettings(com.typesafe.config.Config, String) - Constructor for class akka.cluster.ClusterSettings
 
ClusterSingletonManager - Class in akka.contrib.pattern
Manages a cluster wide singleton actor instance, i.e.
ClusterSingletonManager(Function1<Option<Object>, Props>, String, Object, int, int, FiniteDuration, boolean) - Constructor for class akka.contrib.pattern.ClusterSingletonManager
 
ClusterSingletonManager(String, Object, int, int, FiniteDuration, boolean, ClusterSingletonPropsFactory) - Constructor for class akka.contrib.pattern.ClusterSingletonManager
Full Java API constructor.
ClusterSingletonManager(String, Object, ClusterSingletonPropsFactory) - Constructor for class akka.contrib.pattern.ClusterSingletonManager
Java API constructor with default values.
ClusterSingletonManager$ - Class in akka.contrib.pattern
 
ClusterSingletonManager$() - Constructor for class akka.contrib.pattern.ClusterSingletonManager$
 
ClusterSingletonManager.Data - Interface in akka.contrib.pattern
Internal API public due to the with FSM type parameters
ClusterSingletonManager.State - Interface in akka.contrib.pattern
Internal API public due to the with FSM type parameters
ClusterSingletonManagerIsStuck - Exception in akka.contrib.pattern
Thrown when a consistent state can't be determined within the defined retry limits.
ClusterSingletonManagerIsStuck(String) - Constructor for exception akka.contrib.pattern.ClusterSingletonManagerIsStuck
 
ClusterSingletonPropsFactory - Interface in akka.contrib.pattern
 
ClusterUserAction - Class in akka.cluster
Cluster commands sent by the USER.
ClusterUserAction() - Constructor for class akka.cluster.ClusterUserAction
 
ClusterUserAction$ - Class in akka.cluster
Cluster commands sent by the USER.
ClusterUserAction$() - Constructor for class akka.cluster.ClusterUserAction$
 
ClusterUserAction.Down - Class in akka.cluster
Command to mark node as temporary down.
ClusterUserAction.Down(Address) - Constructor for class akka.cluster.ClusterUserAction.Down
 
ClusterUserAction.Down$ - Class in akka.cluster
 
ClusterUserAction.Down$() - Constructor for class akka.cluster.ClusterUserAction.Down$
 
ClusterUserAction.Join - Class in akka.cluster
Command to join the cluster.
ClusterUserAction.Join(Address) - Constructor for class akka.cluster.ClusterUserAction.Join
 
ClusterUserAction.Join$ - Class in akka.cluster
 
ClusterUserAction.Join$() - Constructor for class akka.cluster.ClusterUserAction.Join$
 
ClusterUserAction.Leave - Class in akka.cluster
Command to leave the cluster.
ClusterUserAction.Leave(Address) - Constructor for class akka.cluster.ClusterUserAction.Leave
 
ClusterUserAction.Leave$ - Class in akka.cluster
 
ClusterUserAction.Leave$() - Constructor for class akka.cluster.ClusterUserAction.Leave$
 
CMD_LINE_ARGS_PATTERN - Static variable in class akka.jmx.Client
Pattern that matches a command name followed by an optional equals and optional comma-delimited list of arguments.
cmp() - Method in class akka.dispatch.BoundedPriorityMailbox
 
cmp() - Method in class akka.dispatch.UnboundedPriorityMailbox
 
COMMANDTYPE_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
committed() - Method in class akka.cluster.StandardMetrics.HeapMemory
 
compact() - Method in class akka.util.ByteString.ByteString1
 
compact() - Method in class akka.util.ByteString.ByteStrings
 
compact() - Method in class akka.util.ByteString
Create a new ByteString with all contents compacted into a single, full byte array.
compact() - Method in class akka.util.CompactByteString
 
CompactByteString - Class in akka.util
A compact ByteString.
CompactByteString() - Constructor for class akka.util.CompactByteString
 
CompactByteString$ - Class in akka.util
 
CompactByteString$() - Constructor for class akka.util.CompactByteString$
 
compare(VectorClock.Timestamp) - Method in class akka.cluster.VectorClock.Timestamp
 
compare(Versioned<T>, Versioned<T>) - Method in class akka.cluster.Versioned$
Returns or 'Ordering' for the two 'Versioned' instances.
compare(Versioned<T>, Versioned<T>) - Method in interface akka.cluster.Versioned
Returns or 'Ordering' for the two 'Versioned' instances.
compare(int, int) - Method in class akka.contrib.pattern.ReliableProxy$
Wrap-around aware comparison of integers: differences limited to 2^31-1 in magnitude will work correctly.
compare(int, int) - Static method in class akka.contrib.pattern.ReliableProxy
Wrap-around aware comparison of integers: differences limited to 2^31-1 in magnitude will work correctly.
compare(Envelope, Envelope) - Method in class akka.dispatch.PriorityGenerator
 
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 only takes address into account.
compareTo(ActorPath) - Method in class akka.actor.ChildActorPath
 
compareTo(ActorPath) - Method in class akka.actor.RootActorPath
 
complete() - Method in class akka.testkit.DebugFilter
 
complete() - Method in class akka.testkit.ErrorFilter
 
complete() - Method in class akka.testkit.EventFilter
 
complete() - Method in class akka.testkit.InfoFilter
 
complete() - Method in class akka.testkit.WarningFilter
 
ConcurrentIdentityHashMap<K,V> - Class in akka.util.internal
An alternative identity-comparing ConcurrentMap which is similar to ConcurrentHashMap.
ConcurrentIdentityHashMap(int, float, int) - Constructor for class akka.util.internal.ConcurrentIdentityHashMap
Creates a new, empty map with the specified initial capacity, load factor and concurrency level.
ConcurrentIdentityHashMap(int, float) - Constructor for class akka.util.internal.ConcurrentIdentityHashMap
Creates a new, empty map with the specified initial capacity and load factor and with the default reference types (weak keys, strong values), and concurrencyLevel (16).
ConcurrentIdentityHashMap(int) - Constructor for class akka.util.internal.ConcurrentIdentityHashMap
Creates a new, empty map with the specified initial capacity, and with default reference types (weak keys, strong values), load factor (0.75) and concurrencyLevel (16).
ConcurrentIdentityHashMap() - Constructor for class akka.util.internal.ConcurrentIdentityHashMap
Creates a new, empty map with a default initial capacity (16), reference types (weak keys, strong values), default load factor (0.75) and concurrencyLevel (16).
ConcurrentIdentityHashMap(Map<? extends K, ? extends V>) - Constructor for class akka.util.internal.ConcurrentIdentityHashMap
Creates a new map with the same mappings as the given map.
ConcurrentMultiMap<K,V> - Class in akka.util
An implementation of a ConcurrentMultiMap Adds/remove is serialized over the specified key Reads are fully concurrent <-- el-cheapo
ConcurrentMultiMap(int, Comparator<V>) - Constructor for class akka.util.ConcurrentMultiMap
 
cond() - Method in class akka.testkit.JavaTestKit.AwaitCond
 
config() - Method in class akka.actor.ActorDSL.Extension
 
config() - Method in class akka.actor.ActorSystem.Settings
The backing Config of this ActorSystem's Settings
config() - Method in class akka.actor.Deploy
 
config() - Method in interface akka.actor.mailbox.DurableMailboxSettings
The extracted config section for this mailbox, which is the “name” section (if that exists), falling back to system defaults.
config() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
config() - Method in class akka.cluster.ClusterSettings
 
config() - Method in class akka.dispatch.MessageDispatcherConfigurator
 
config() - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
config() - Method in class akka.osgi.aries.blueprint.BlueprintActorSystemFactory
 
config() - Method in class akka.remote.RemoteSettings
 
config() - Method in class akka.serialization.Serialization.Settings
 
config() - Method in class akka.testkit.TestKitSettings
 
config() - Method in class akka.transactor.TransactorSettings
 
CONFIG_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.DeployProtocol
 
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
 
configure(FileBasedMailboxSettings) - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
configure(Seq<Option<Function1<ThreadPoolConfigBuilder, ThreadPoolConfigBuilder>>>) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
configure(org.osgi.framework.BundleContext, ActorSystem) - Method in class akka.osgi.ActorSystemActivator
Implement this method to add your own actors to the ActorSystem.
configureExecutor() - Method in class akka.dispatch.MessageDispatcherConfigurator
 
ConfigVersion() - Method in class akka.actor.ActorSystem.Settings
 
confirmRemove(int) - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
confirmRemove(int) - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
confirmRemove(String, int) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
connect(SocketAddress, Seq<IO.SocketOption>, ActorRef) - Method in class akka.actor.IOManager
Create a SocketChannel connecting to an address.
connect(String, int, ActorRef) - Method in class akka.actor.IOManager
Create a SocketChannel connecting to a host and port.
Connect - Class in akka.zeromq
This socket should be a client socket and connect to the specified endpoint
Connect(String) - Constructor for class akka.zeromq.Connect
 
Connect$ - Class in akka.zeromq
 
Connect$() - Constructor for class akka.zeromq.Connect$
 
CONNECT_VALUE - Static variable in enum akka.remote.RemoteProtocol.CommandType
 
Connecting - Class in akka.zeromq
When the ZeroMQ socket connects it sends this message to a listener
Connecting() - Constructor for class akka.zeromq.Connecting
 
connecting() - Method in class akka.zeromq.ZeroMQ$
The message that is sent when an ZeroMQ socket connects.
connecting() - Static method in class akka.zeromq.ZeroMQ
The message that is sent when an ZeroMQ socket connects.
Connecting$ - Class in akka.zeromq
When the ZeroMQ socket connects it sends this message to a listener
Connecting$() - Constructor for class akka.zeromq.Connecting$
 
connectionTime() - Method in class akka.actor.IO.PerformancePreferences
 
ConsistentHash<T> - Class in akka.routing
Consistent Hashing node ring implementation.
ConsistentHash$ - Class in akka.routing
 
ConsistentHash$() - Constructor for class akka.routing.ConsistentHash$
 
ConsistentHashingLike - Interface in akka.routing
The core pieces of the routing logic is located in this trait to be able to extend.
ConsistentHashingRouter - Class in akka.routing
A Router that uses consistent hashing to select a connection based on the sent message.
ConsistentHashingRouter(int, Iterable<String>, Option<Resizer>, String, SupervisorStrategy, int, PartialFunction<Object, Object>) - Constructor for class akka.routing.ConsistentHashingRouter
 
ConsistentHashingRouter(int) - Constructor for class akka.routing.ConsistentHashingRouter
Java API: Constructor that sets nrOfInstances to be created.
ConsistentHashingRouter(Iterable<String>) - Constructor for class akka.routing.ConsistentHashingRouter
Java API: Constructor that sets the routees to be used.
ConsistentHashingRouter(Resizer) - Constructor for class akka.routing.ConsistentHashingRouter
Java API: Constructor that sets the resizer to be used.
ConsistentHashingRouter$ - Class in akka.routing
 
ConsistentHashingRouter$() - Constructor for class akka.routing.ConsistentHashingRouter$
 
ConsistentHashingRouter.ConsistentHashable - Interface in akka.routing
If you don't define the hashMapping when constructing the ConsistentHashingRouter the messages need to implement this interface to define what data to use for the consistent hash key.
ConsistentHashingRouter.ConsistentHashableEnvelope - Class in akka.routing
If you don't define the hashMapping when constructing the ConsistentHashingRouter and messages can't implement ConsistentHashingRouter.ConsistentHashable themselves they can we wrapped by this envelope instead.
ConsistentHashingRouter.ConsistentHashableEnvelope(Object, Object) - Constructor for class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope
 
ConsistentHashingRouter.ConsistentHashableEnvelope$ - Class in akka.routing
 
ConsistentHashingRouter.ConsistentHashableEnvelope$() - Constructor for class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope$
 
ConsistentHashingRouter.ConsistentHashMapper - Interface in akka.routing
JAVA API Mapping from message to the data to use for the consistent hash key.
ConsistentHashingRouter.emptyConsistentHashMapping$ - Class in akka.routing
 
ConsistentHashingRouter.emptyConsistentHashMapping$() - Constructor for class akka.routing.ConsistentHashingRouter.emptyConsistentHashMapping$
 
consistentHashKey() - Method in interface akka.routing.ConsistentHashingRouter.ConsistentHashable
 
consistentHashKey() - Method in class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope
 
Consumer - Interface in akka.camel
Mixed in by Actor implementations that consume message from Camel endpoints.
contains(Object) - Method in class akka.util.BoundedBlockingQueue
 
contains(Object) - Method in class akka.util.internal.ConcurrentIdentityHashMap
Legacy method testing if some key maps into the specified value in this table.
containsAll(Collection<?>) - Method in class akka.util.BoundedBlockingQueue
 
containsKey(Object) - Method in class akka.util.internal.ConcurrentIdentityHashMap
Tests if the specified object is a key in this table.
containsValue(Object) - Method in class akka.util.internal.ConcurrentIdentityHashMap
Returns true if this map maps one or more keys to the specified value.
context() - Method in interface akka.actor.Actor
Stores the context for this actor, including self, and sender.
context() - Method in class akka.actor.TypedActor$
Returns the ActorContext (for a TypedActor) when inside a method call in a TypedActor.
context() - Static method in class akka.actor.TypedActor
Returns the ActorContext (for a TypedActor) when inside a method call in a TypedActor.
context() - Method in interface akka.camel.Camel
Underlying camel context.
context() - Method in class akka.osgi.OsgiActorSystemFactory
 
context() - Method in class akka.routing.RouteeProvider
 
Context - Class in akka.zeromq
Represents an I/O thread pool for ZeroMQ sockets.
Context(int) - Constructor for class akka.zeromq.Context
 
Context$ - Class in akka.zeromq
Companion object for a ZeroMQ I/O thread pool
Context$() - Constructor for class akka.zeromq.Context$
 
contextClassLoader() - Method in class akka.dispatch.MonitorableThreadFactory
 
ContextualTypedActorFactory - Class in akka.actor
ContextualTypedActorFactory allows TypedActors to create children, effectively forming the same Actor Supervision Hierarchies as normal Actors can.
ContextualTypedActorFactory(TypedActorExtension, ActorContext) - Constructor for class akka.actor.ContextualTypedActorFactory
 
ContextualTypedActorFactory$ - Class in akka.actor
 
ContextualTypedActorFactory$() - Constructor for class akka.actor.ContextualTypedActorFactory$
 
Conversions() - Method in class akka.camel.CamelSettings
 
Convert - Class in akka.util
 
Convert() - Constructor for class akka.util.Convert
 
Convert$ - Class in akka.util
 
Convert$() - Constructor for class akka.util.Convert$
 
COOKIE_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
coordinate(Object) - Method in class akka.transactor.Coordinated
Java API: create a new Coordinated object and increment the number of members by one.
coordinate() - Method in interface akka.transactor.Transactor
Override this method to coordinate with other transactors.
coordinate(Object) - Method in class akka.transactor.UntypedTransactor
Override this method to coordinate with other transactors.
Coordinated - Class in akka.transactor
Coordinated is a message wrapper that adds a CommitBarrier for explicitly coordinating transactions across actors or threads.
Coordinated(Object, scala.concurrent.stm.CommitBarrier.Member) - Constructor for class akka.transactor.Coordinated
 
Coordinated(Timeout) - Constructor for class akka.transactor.Coordinated
 
Coordinated$ - Class in akka.transactor
Coordinated transactions across actors.
Coordinated$() - Constructor for class akka.transactor.Coordinated$
 
CoordinatedTimeout() - Method in class akka.transactor.TransactorSettings
 
CoordinatedTransactionException - Exception in akka.transactor
Akka-specific exception for coordinated transactions.
CoordinatedTransactionException(String, Throwable) - Constructor for exception akka.transactor.CoordinatedTransactionException
 
CoordinatedTransactionException(String) - Constructor for exception akka.transactor.CoordinatedTransactionException
 
copy(Address, MemberStatus) - Method in class akka.cluster.Member
 
copyToArray(Object, int, int) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
copyToArray(Object, int, int) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
copyToArray(Object, int, int) - Method in class akka.util.ByteString
 
copyToBuffer(ByteBuffer) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
copyToBuffer(ByteBuffer) - Method in class akka.util.ByteIterator
Copy as many bytes as possible to a ByteBuffer, starting from it's current position.
copyToBuffer(ByteBuffer) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
copyToBuffer(ByteBuffer) - Method in class akka.util.ByteString
Copy as many bytes as possible to a ByteBuffer, starting from it's current position.
corePoolSize() - Method in class akka.dispatch.ThreadPoolConfig
 
count() - Method in class akka.testkit.TestActorRefSpec.Logger
 
countDown() - Method in class akka.testkit.TestLatch
 
Counter - Class in akka.actor.mailbox.filebased.filequeue
 
Counter() - Constructor for class akka.actor.mailbox.filebased.filequeue.Counter
 
counter() - Method in class akka.dispatch.MonitorableThreadFactory
 
counter() - Method in class akka.testkit.TestActorRefSpec$
 
counter() - Static method in class akka.testkit.TestActorRefSpec
 
cpuCombined() - Method in class akka.cluster.SigarMetricsCollector
(SIGAR) Returns the combined CPU sum of User + Sys + Nice + Wait, in percentage.
CpuCombined() - Method in class akka.cluster.StandardMetrics$
 
cpuCombined() - Method in class akka.cluster.StandardMetrics.Cpu
 
CpuCombined() - Static method in class akka.cluster.StandardMetrics
 
CpuMetricsSelector - Class in akka.cluster.routing
MetricsSelector that uses the combined CPU metrics.
CpuMetricsSelector() - Constructor for class akka.cluster.routing.CpuMetricsSelector
 
CpuMetricsSelector$ - Class in akka.cluster.routing
MetricsSelector that uses the combined CPU metrics.
CpuMetricsSelector$() - Constructor for class akka.cluster.routing.CpuMetricsSelector$
 
create() - Method in class akka.actor.ActorSystem$
Creates a new ActorSystem with the name "default", obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
create(String) - Method in class akka.actor.ActorSystem$
Creates a new ActorSystem with the specified name, obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
create(String, com.typesafe.config.Config) - Method in class akka.actor.ActorSystem$
Creates a new ActorSystem with the name "default", and the specified Config, then obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
create(String, com.typesafe.config.Config, ClassLoader) - Method in class akka.actor.ActorSystem$
Creates a new ActorSystem with the name "default", the specified Config, and specified ClassLoader
create() - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the name "default", obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
create(String) - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the specified name, obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
create(String, com.typesafe.config.Config) - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the name "default", and the specified Config, then obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader associated with the ActorSystem class.
create(String, com.typesafe.config.Config, ClassLoader) - Static method in class akka.actor.ActorSystem
Creates a new ActorSystem with the name "default", the specified Config, and specified ClassLoader
create() - Method in class akka.actor.DefaultSupervisorStrategy
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.actor.mailbox.filebased.FileBasedMailboxType
 
create() - Method in class akka.actor.StoppingSupervisorStrategy
 
create() - Method in interface akka.actor.SupervisorStrategyConfigurator
 
create(String, Number, Option<Object>) - Method in class akka.cluster.Metric$
Creates a new Metric instance if the value is valid, otherwise None is returned.
create(String, Try<Number>, Option<Object>) - Method in class akka.cluster.Metric$
Creates a new Metric instance if the Try is successful and the value is valid, otherwise None is returned.
create(String, Number, Option<Object>) - Static method in class akka.cluster.Metric
Creates a new Metric instance if the value is valid, otherwise None is returned.
create(String, Try<Number>, Option<Object>) - Static method in class akka.cluster.Metric
Creates a new Metric instance if the Try is successful and the value is valid, otherwise None is returned.
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.contrib.mailbox.PeekMailboxType
 
create(Object) - Method in interface akka.contrib.pattern.ClusterSingletonPropsFactory
Create the Props from the handOverData sent from previous singleton.
create(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.UnboundedDequeBasedMailbox
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.UnboundedMailbox
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.UnboundedPriorityMailbox
 
create() - Method in interface akka.japi.Creator
This method must return a different instance upon every call.
create() - Method in class akka.osgi.aries.blueprint.BlueprintActorSystemFactory
 
create(Scheduler, int, FiniteDuration, FiniteDuration) - Method in class akka.pattern.CircuitBreaker$
Java API: Create a new CircuitBreaker.
create(Scheduler, int, FiniteDuration, FiniteDuration) - Static method in class akka.pattern.CircuitBreaker
Java API: Create a new CircuitBreaker.
create(Iterable<ActorRef>) - Method in class akka.routing.BroadcastRouter$
 
create(Iterable<ActorRef>) - Static method in class akka.routing.BroadcastRouter
 
create(Iterable<T>, int) - Method in class akka.routing.ConsistentHash$
Java API: Factory method to create a ConsistentHash
create(Iterable<T>, int) - Static method in class akka.routing.ConsistentHash
Java API: Factory method to create a ConsistentHash
create(Iterable<ActorRef>) - Method in class akka.routing.ConsistentHashingRouter$
 
create(Iterable<ActorRef>) - Static method in class akka.routing.ConsistentHashingRouter
 
create(Iterable<ActorRef>) - Method in class akka.routing.RandomRouter$
 
create(Iterable<ActorRef>) - Static method in class akka.routing.RandomRouter
 
create(Iterable<ActorRef>) - Method in class akka.routing.RoundRobinRouter$
 
create(Iterable<ActorRef>) - Static method in class akka.routing.RoundRobinRouter
 
create(Iterable<ActorRef>, FiniteDuration) - Method in class akka.routing.ScatterGatherFirstCompletedRouter$
 
create(Iterable<ActorRef>, FiniteDuration) - Static method in class akka.routing.ScatterGatherFirstCompletedRouter
 
create(Iterable<ActorRef>) - Method in class akka.routing.SmallestMailboxRouter$
 
create(Iterable<ActorRef>) - Static method in class akka.routing.SmallestMailboxRouter
 
create(ActorSystem, Props, String) - Method in class akka.testkit.TestActorRef$
Java API: create a TestActorRef in the given system for the given props
create(ActorSystem, Props, String) - Static method in class akka.testkit.TestActorRef
Java API: create a TestActorRef in the given system for the given props
createActor() - Method in class akka.cluster.routing.ClusterRouterConfig
 
createActor() - Method in class akka.remote.routing.RemoteRouterConfig
 
createActor() - Method in interface akka.routing.RouterConfig
The router "head" actor.
createActorSystem(String) - Method in class akka.osgi.OsgiActorSystemFactory
Creates the ActorSystem, using the name specified
createActorSystem(Option<String>) - Method in class akka.osgi.OsgiActorSystemFactory
Creates the ActorSystem, using the name specified.
createActorSystemBean(org.apache.aries.blueprint.ParserContext, Element, org.apache.aries.blueprint.mutable.MutableBeanMetadata) - Method in class akka.osgi.aries.blueprint.NamespaceHandler
 
createControlEnvelope(RemoteProtocol.RemoteControlProtocol) - Method in class akka.remote.RemoteTransport
Returns a newly created AkkaRemoteProtocol with the given control payload.
createCustomRoute(RouteeProvider) - Method in class akka.routing.CustomRouterConfig
 
createDeployer() - Method in class akka.cluster.ClusterActorRefProvider
Factory method to make it possible to override deployer in subclass Creates a new instance every time
createDeployer() - Method in class akka.remote.RemoteActorRefProvider
Factory method to make it possible to override deployer in subclass Creates a new instance every time
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.camel.CamelExtension$
Creates a new instance of Camel and makes sure it gets stopped when the actor system is shutdown.
createExtension(ExtendedActorSystem) - Static method in class akka.camel.CamelExtension
Creates a new instance of Camel and makes sure it gets stopped when the actor system is shutdown.
createExtension(ExtendedActorSystem) - Method in class akka.cluster.Cluster$
 
createExtension(ExtendedActorSystem) - Static method in class akka.cluster.Cluster
 
createExtension(ExtendedActorSystem) - Method in class akka.contrib.mailbox.PeekMailboxExtension$
 
createExtension(ExtendedActorSystem) - Static method in class akka.contrib.mailbox.PeekMailboxExtension
 
createExtension(ExtendedActorSystem) - Method in class akka.serialization.SerializationExtension$
 
createExtension(ExtendedActorSystem) - Static method in class akka.serialization.SerializationExtension
 
createExtension(ExtendedActorSystem) - Method in class akka.testkit.TestKitExtension$
 
createExtension(ExtendedActorSystem) - Static method in class akka.testkit.TestKitExtension
 
createExtension(ExtendedActorSystem) - Method in class akka.transactor.TransactorExtension$
 
createExtension(ExtendedActorSystem) - Static method in class akka.transactor.TransactorExtension
 
createExtension(ExtendedActorSystem) - Method in class akka.zeromq.ZeroMQExtension$
 
createExtension(ExtendedActorSystem) - Static method in class akka.zeromq.ZeroMQExtension
 
createFactoryBean(org.apache.aries.blueprint.ParserContext, String) - Method in class akka.osgi.aries.blueprint.NamespaceHandler
 
createInstanceFor(Class<?>, Seq<Tuple2<Class<?>, Object>>, ClassTag<T>) - Method in class akka.actor.DynamicAccess
Convenience method which given a Class[_] object and a constructor description will create a new instance of that class.
createInstanceFor(String, Seq<Tuple2<Class<?>, Object>>, ClassTag<T>) - Method in class akka.actor.DynamicAccess
Obtain an object conforming to the type T, which is expected to be instantiated from a class designated by the fully-qualified class name given, where the constructor is selected and invoked according to the args argument.
createInstanceFor(Class<?>, Seq<Tuple2<Class<?>, Object>>, ClassTag<T>) - Method in class akka.actor.ReflectiveDynamicAccess
 
createInstanceFor(String, Seq<Tuple2<Class<?>, Object>>, ClassTag<T>) - Method in class akka.actor.ReflectiveDynamicAccess
 
createMailbox(akka.actor.Cell) - Method in class akka.dispatch.BalancingDispatcher
 
createMailbox(akka.actor.Cell) - Method in class akka.dispatch.Dispatcher
INTERNAL USE ONLY
createMailbox(akka.actor.Cell) - Method in class akka.dispatch.MessageDispatcher
Creates and returns a mailbox for the given actor.
createMailbox(akka.actor.Cell) - Method in class akka.testkit.CallingThreadDispatcher
 
createMailboxTestActor(Props, String) - Method in class akka.actor.mailbox.DurableMailboxSpec
 
createMessageSendEnvelope(RemoteProtocol.RemoteMessageProtocol) - Method in class akka.remote.RemoteTransport
Returns a newly created AkkaRemoteProtocol with the given message payload.
createRemoteMessageProtocolBuilder(ActorRef, Object, Option<ActorRef>) - Method in class akka.remote.RemoteTransport
Returns a new RemoteMessageProtocol containing the serialized representation of the given parameters.
createRoute(RouteeProvider) - Method in interface akka.cluster.routing.AdaptiveLoadBalancingRouterLike
 
createRoute(RouteeProvider) - Method in class akka.cluster.routing.ClusterRouterConfig
 
createRoute(RouteeProvider) - Method in class akka.remote.routing.RemoteRouterConfig
 
createRoute(RouteeProvider) - Method in interface akka.routing.BroadcastLike
 
createRoute(RouteeProvider) - Method in interface akka.routing.ConsistentHashingLike
 
createRoute(RouteeProvider) - Method in class akka.routing.CustomRouterConfig
 
createRoute(RouteeProvider) - Method in class akka.routing.FromConfig
 
createRoute(RouteeProvider) - Method in class akka.routing.NoRouter$
 
createRoute(RouteeProvider) - Static method in class akka.routing.NoRouter
 
createRoute(RouteeProvider) - Method in interface akka.routing.RandomLike
 
createRoute(RouteeProvider) - Method in interface akka.routing.RoundRobinLike
 
createRoute(RouteeProvider) - Method in interface akka.routing.RouterConfig
Implement the routing logic by returning a partial function of partial function from (sender, message) to a set of destinations.
createRoute(RouteeProvider) - Method in interface akka.routing.ScatterGatherFirstCompletedLike
 
createRoute(RouteeProvider) - Method in interface akka.routing.SmallestMailboxLike
 
createRouteeProvider(ActorContext, Props) - Method in class akka.cluster.routing.ClusterRouterConfig
 
createRouteeProvider(ActorContext, Props) - Method in class akka.remote.routing.RemoteRouterConfig
 
createRouteeProvider(ActorContext, Props) - Method in interface akka.routing.RouterConfig
The RouteeProvider responsible for creating or looking up routees.
createRoutees(int) - Method in class akka.remote.routing.RemoteRouteeProvider
 
createRoutees(int) - Method in class akka.routing.RouteeProvider
Creates new routees from specified Props and registers them.
createThreadPoolConfigBuilder(com.typesafe.config.Config, DispatcherPrerequisites) - Method in class akka.dispatch.ThreadPoolExecutorConfigurator
 
createTimeout(TimerTask, long) - Method in class akka.util.internal.HashedWheelTimer
 
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.
CREATOR_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.PropsProtocol
 
Creators - Interface in akka.actor.dsl
 
Creators.Act - Interface in akka.actor.dsl
This trait provides a DSL for writing the inner workings of an actor, e.g.
Creators.ActWithStash - Interface in akka.actor.dsl
Use this trait when defining an Actor with Stash, since just using actor()(new Act with Stash{}) will not be able to see the Stash component due to type erasure.
Crypt - Class in akka.util
 
Crypt() - Constructor for class akka.util.Crypt
 
Crypt$ - Class in akka.util
 
Crypt$() - Constructor for class akka.util.Crypt$
 
ctdLock() - Method in class akka.testkit.CallingThreadMailbox
 
currentAge() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
currentBytes() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
currentDeadline() - Method in class akka.actor.dsl.Inbox.InboxActor
 
currentItems() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
currentMsg() - Method in class akka.actor.dsl.Inbox.InboxActor
 
CurrentRoutees - Class in akka.routing
Sending this message to a router will make it send back its currently used routees.
CurrentRoutees() - Constructor for class akka.routing.CurrentRoutees
 
CurrentRoutees$ - Class in akka.routing
 
CurrentRoutees$() - Constructor for class akka.routing.CurrentRoutees$
 
currentSelect() - Method in class akka.actor.dsl.Inbox.InboxActor
 
currentState() - Method in interface akka.actor.FSM
 
currentState() - Method in class akka.actor.FSM.StopEvent
 
currentSystem() - Method in class akka.serialization.JavaSerializer$
This holds a reference to the current ActorSystem (the surrounding context) during serialization and deserialization.
currentSystem() - Static method in class akka.serialization.JavaSerializer
This holds a reference to the current ActorSystem (the surrounding context) during serialization and deserialization.
currentTransportAddress() - Method in class akka.serialization.Serialization$
This holds a reference to the current transport address to be inserted into local actor refs during serialization.
currentTransportAddress() - Static method in class akka.serialization.Serialization
This holds a reference to the current transport address to be inserted into local actor refs during serialization.
currentXid() - Method in class akka.actor.mailbox.filebased.filequeue.tools.QueueDumper
 
custom(PartialFunction<Logging.LogEvent, Object>, int) - Method in class akka.testkit.EventFilter$
Create a custom event filter.
custom(PartialFunction<Logging.LogEvent, Object>, int) - Static method in class akka.testkit.EventFilter
Create a custom event filter.
CustomEventFilter - Class in akka.testkit
Custom event filter when the others do not fit the bill.
CustomEventFilter(PartialFunction<Logging.LogEvent, Object>, int) - Constructor for class akka.testkit.CustomEventFilter
 
CustomEventFilter$ - Class in akka.testkit
 
CustomEventFilter$() - Constructor for class akka.testkit.CustomEventFilter$
 
CustomRoute - Interface in akka.routing
Java API helper for creating a single-destination routing.
CustomRouterConfig - Class in akka.routing
Java API for a custom router factory.
CustomRouterConfig() - Constructor for class akka.routing.CustomRouterConfig
 

D

daemonic() - Method in class akka.dispatch.MonitorableThreadFactory
 
Daemonicity() - Method in class akka.actor.ActorSystem.Settings
 
data() - Method in class akka.actor.mailbox.filebased.filequeue.QItem
 
dateFormat() - Method in interface akka.event.Logging.StdOutLogger
 
deactivationFutureFor(ActorRef, Timeout, ExecutionContext) - Method in interface akka.camel.Activation
Produces a Future which will be completed when the given endpoint has been deactivated or or if it times out, which will happen after the specified Timeout.
dead() - Method in exception akka.actor.DeathPactException
 
DeadLetter - Class in akka.actor
When a message is sent to an Actor that is terminated before receiving the message, it will be sent as a DeadLetter to the ActorSystem's EventStream
DeadLetter(Object, ActorRef, ActorRef) - Constructor for class akka.actor.DeadLetter
 
DeadLetter$ - Class in akka.actor
 
DeadLetter$() - Constructor for class akka.actor.DeadLetter$
 
deadLetterMailbox() - Method in interface akka.dispatch.DispatcherPrerequisites
 
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.
deadLetters() - Method in class akka.actor.LocalActorRefProvider
 
deadLetters() - Method in class akka.remote.RemoteActorRefProvider
 
deadline() - Method in class akka.actor.dsl.Inbox.Get
 
deadline() - Method in interface akka.actor.dsl.Inbox.Query
 
deadline() - Method in class akka.actor.dsl.Inbox.Select
 
deadlineOrder() - Method in interface akka.actor.dsl.Inbox
 
Deafen - Class in akka.routing
 
Deafen(ActorRef) - Constructor for class akka.routing.Deafen
 
Deafen$ - Class in akka.routing
 
Deafen$() - Constructor for class akka.routing.Deafen$
 
DeathPactException - Exception in akka.actor
A DeathPactException is thrown by an Actor that receives a Terminated(someActor) message that it doesn't handle itself, effectively crashing the Actor and escalating to the supervisor.
DeathPactException$ - Class in akka.actor
 
DeathPactException$() - Constructor for class akka.actor.DeathPactException$
 
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
 
debug(String, String, String, String, int) - Method in class akka.testkit.EventFilter$
Create a filter for Debug events.
debug(String, String, String, String, int) - Static method in class akka.testkit.EventFilter
Create a filter for Debug events.
DebugAutoReceive() - Method in class akka.actor.ActorSystem.Settings
 
debugEvent() - Method in interface akka.actor.FSM
 
debugEvent() - Method in interface akka.actor.LoggingFSM
 
DebugEventStream() - Method in class akka.actor.ActorSystem.Settings
 
DebugFilter - Class in akka.testkit
Filter which matches Debug events, if they satisfy the given criteria: source, if given, applies a filter on the event’s origin message applies a filter on the event’s message (either with String.startsWith or Regex.findFirstIn().isDefined) If you want to match all Debug events, the most efficient is to use Left("").
DebugFilter(Option<String>, Either<String, Regex>, boolean, int) - Constructor for class akka.testkit.DebugFilter
 
DebugFilter(String, String, boolean, boolean, int) - Constructor for class akka.testkit.DebugFilter
Java API: create a DebugFilter
DebugFilter$ - Class in akka.testkit
 
DebugFilter$() - Constructor for class akka.testkit.DebugFilter$
 
debugFormat() - Method in interface akka.event.Logging.StdOutLogger
 
DebugLevel() - Method in class akka.event.Logging$
 
DebugLevel() - Static method in class akka.event.Logging
 
DebugLifecycle() - Method in class akka.actor.ActorSystem.Settings
 
DebugRouterMisconfiguration() - Method in class akka.actor.ActorSystem.Settings
 
DebugUnhandledMessage() - Method in class akka.actor.ActorSystem.Settings
 
decider() - Method in class akka.actor.AllForOneStrategy
 
decider() - Method in class akka.actor.OneForOneStrategy
 
decider() - Method in class akka.actor.SupervisorStrategy
Returns the Decider that is associated with this SupervisorStrategy.
decodeString(String) - Method in class akka.util.ByteString.ByteString1
 
decodeString(String) - Method in class akka.util.ByteString.ByteString1C
 
decodeString(String) - Method in class akka.util.ByteString.ByteStrings
 
decodeString(String) - Method in class akka.util.ByteString
Decodes this ByteString using a charset to produce a String.
decorate(Node, org.osgi.service.blueprint.reflect.ComponentMetadata, org.apache.aries.blueprint.ParserContext) - Method in class akka.osgi.aries.blueprint.NamespaceHandler
 
decr() - Method in class akka.actor.mailbox.filebased.filequeue.Counter
 
decr(long) - Method in class akka.actor.mailbox.filebased.filequeue.Counter
 
defaultAllowCoreThreadTimeout() - Method in class akka.dispatch.ThreadPoolConfig$
 
defaultAllowCoreThreadTimeout() - Static method in class akka.dispatch.ThreadPoolConfig
 
defaultBacklog() - Method in class akka.actor.IOManager.Settings
 
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
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
defaultDispatcher(ActorSystem) - Static method in class akka.dispatch.MessageDispatcher
 
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
 
defaultMaxPoolSize() - Method in class akka.dispatch.ThreadPoolConfig$
 
defaultMaxPoolSize() - Static method in class akka.dispatch.ThreadPoolConfig
 
DefaultPollTimeout() - Method in class akka.zeromq.ZeroMQExtension
 
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(HashedWheelTimer, LoggingAdapter) - 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
 
DefaultTimeout - Interface in akka.testkit
 
DefaultTimeout() - Method in class akka.testkit.TestBarrier$
 
DefaultTimeout() - Static method in class akka.testkit.TestBarrier
 
DefaultTimeout() - Method in class akka.testkit.TestKitSettings
 
DefaultTimeout() - Method in class akka.testkit.TestLatch$
 
DefaultTimeout() - Static method in class akka.testkit.TestLatch
 
DefaultVirtualNodesFactor() - Method in class akka.actor.ActorSystem.Settings
 
delayedStop(Scheduler, Iterable<ActorRef>, FiniteDuration) - Method in class akka.routing.RouteeProvider
Give concurrent messages a chance to be placed in mailbox before sending PoisonPill.
delete(String) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
Deploy - Class in akka.actor
This class represents deployment configuration for a given actor path.
Deploy(String, com.typesafe.config.Config, RouterConfig, Scope) - Constructor for class akka.actor.Deploy
 
Deploy(RouterConfig) - Constructor for class akka.actor.Deploy
Java API to create a Deploy with the given RouterConfig
Deploy(RouterConfig, Scope) - Constructor for class akka.actor.Deploy
Java API to create a Deploy with the given RouterConfig with Scope
Deploy(Scope) - Constructor for class akka.actor.Deploy
Java API to create a Deploy with the given Scope
deploy() - Method in class akka.actor.Props
 
deploy() - Method in class akka.actor.TypedProps
 
Deploy$ - Class in akka.actor
 
Deploy$() - Constructor for class akka.actor.Deploy$
 
DEPLOY_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
DEPLOY_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.PropsProtocol
 
deployer() - Method in interface akka.actor.ActorRefProvider
The Deployer associated with this ActorRefProvider
deployer() - Method in class akka.actor.LocalActorRefProvider
 
deployer() - Method in class akka.remote.RemoteActorRefProvider
 
DequeBasedMessageQueue - Interface in akka.dispatch
DequeBasedMessageQueue refines QueueBasedMessageQueue to be backed by a java.util.Deque
dequeue() - Method in class akka.actor.mailbox.filebased.FileBasedMessageQueue
 
dequeue() - Method in class akka.contrib.mailbox.PeekMailbox
 
dequeue() - Method in interface akka.dispatch.BoundedDequeBasedMessageQueueSemantics
 
dequeue() - Method in interface akka.dispatch.BoundedMessageQueueSemantics
 
dequeue() - Method in interface akka.dispatch.MessageQueue
Try to dequeue the next message from this queue, return null failing that.
dequeue() - Method in interface akka.dispatch.UnboundedDequeBasedMessageQueueSemantics
 
dequeue() - Method in interface akka.dispatch.UnboundedMessageQueueSemantics
 
dequeue() - Method in class akka.testkit.CallingThreadMailbox
 
descendant(Iterable<String>) - Method in interface akka.actor.ActorPath
Java API: Recursively create a descendant’s path by appending all child names.
descendant(Iterable<String>) - Method in class akka.actor.ActorSystem
Java API: Recursively create a descendant’s path by appending all child names.
deserialize(byte[]) - Method in interface akka.actor.mailbox.DurableMessageSerialization
Deserializes an array of Bytes that were serialized using the DurableMessageSerialization.serialize method, into an Envelope.
deserialize(byte[], int, Option<Class<?>>) - 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<?>) - Method in class akka.serialization.Serialization
Deserializes the given array of bytes using the specified type to look up what Serializer should be used.
deserializeActorRef(ActorSystem, RemoteProtocol.ActorRefProtocol) - Method in class akka.remote.serialization.ProtobufSerializer$
Helper to materialize (lookup) an ActorRef from Akka's protobuf representation in the supplied ActorSystem.
deserializeActorRef(ActorSystem, RemoteProtocol.ActorRefProtocol) - Static method in class akka.remote.serialization.ProtobufSerializer
Helper to materialize (lookup) an ActorRef from Akka's protobuf representation in the supplied ActorSystem.
Deserializer - Interface in akka.zeromq
A base trait for message deserializers
Destination - Class in akka.routing
For every message sent to a router, its route determines a set of destinations, where for each recipient a different sender may be specified; typically the sender should match the sender of the original request, but e.g. 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
 
destroy() - Method in class akka.osgi.aries.blueprint.BlueprintActorSystemFactory
 
destroyJournal() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
detach(akka.actor.ActorCell) - Method in class akka.dispatch.MessageDispatcher
Detaches the specified actor instance from this dispatcher
digest(byte[], MessageDigest) - Method in class akka.util.Crypt$
 
digest(byte[], MessageDigest) - Static method in class akka.util.Crypt
 
dilated(Duration) - Method in class akka.testkit.JavaTestKit
 
dilated(Duration, ActorSystem) - Method in class akka.testkit.TestKit$
Java API: Scale timeouts (durations) during tests with the configured 'akka.test.timefactor'.
dilated(Duration, ActorSystem) - Static method in class akka.testkit.TestKit
Java API: Scale timeouts (durations) during tests with the configured 'akka.test.timefactor'.
discardExpired() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
DiscardOldWhenFull() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
discardOldWhenFull() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
discardOldWhenFull() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
dispatch(akka.actor.ActorCell, Envelope) - Method in class akka.dispatch.BalancingDispatcher
 
dispatch(akka.actor.ActorCell, Envelope) - Method in class akka.dispatch.Dispatcher
INTERNAL USE ONLY
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
dispatch(akka.actor.ActorCell, Envelope) - Method in class akka.testkit.CallingThreadDispatcher
 
dispatcher() - Method in interface akka.actor.ActorContext
Returns the dispatcher (MessageDispatcher) that is used for this Actor.
dispatcher() - Method in interface akka.actor.ActorRefFactory
Returns the default MessageDispatcher associated with this ActorRefFactory
dispatcher() - Method in interface akka.actor.ActorRefProvider
 
dispatcher() - Method in class akka.actor.ActorSystem
Default dispatcher as configured.
dispatcher() - Method in class akka.actor.LocalActorRefProvider
 
dispatcher() - Method in class akka.actor.Props
 
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(DispatcherPrerequisites, String, int, Duration, MailboxType, ExecutorServiceFactoryProvider, FiniteDuration) - Constructor for class akka.dispatch.Dispatcher
 
dispatcher() - Method in class akka.dispatch.DispatcherConfigurator
Returns the same dispatcher instance for each invocation
dispatcher() - Method in class akka.dispatch.MessageDispatcherConfigurator
Returns an instance of MessageDispatcher given the configuration.
dispatcher() - Method in class akka.dispatch.PinnedDispatcherConfigurator
Creates new dispatcher for each invocation.
dispatcher() - Method in class akka.remote.RemoteActorRefProvider
 
dispatcher() - Method in class akka.testkit.CallingThreadDispatcherConfigurator
 
DISPATCHER_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.PropsProtocol
 
DispatcherConfigurator - Class in akka.dispatch
Configurator for creating Dispatcher.
DispatcherConfigurator(com.typesafe.config.Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.DispatcherConfigurator
 
DispatcherPrerequisites - Interface in akka.dispatch
DispatcherPrerequisites represents useful contextual pieces when constructing a MessageDispatcher
dispatchers() - Method in class akka.actor.ActorSystem
Helper object for looking up configured dispatchers.
Dispatchers - Class in akka.dispatch
Dispatchers are to be defined in configuration to allow for tuning for different environments.
Dispatchers(ActorSystem.Settings, DispatcherPrerequisites) - Constructor for class akka.dispatch.Dispatchers
 
Dispatchers$ - Class in akka.dispatch
 
Dispatchers$() - Constructor for class akka.dispatch.Dispatchers$
 
dissociate(ActorRef) - Method in interface akka.event.ActorClassification
 
dissociate(ActorRef, ActorRef) - Method in interface akka.event.ActorClassification
 
doAttributeOperation(MBeanServerConnection, ObjectInstance, String, MBeanAttributeInfo[]) - Method in class akka.jmx.Client
 
doBean(MBeanServerConnection, ObjectInstance, String[]) - Method in class akka.jmx.Client
Get attribute or run operation against passed bean instance.
doBeanOperation(MBeanServerConnection, ObjectInstance, String, MBeanOperationInfo[]) - Method in class akka.jmx.Client
 
doBeans(MBeanServerConnection, ObjectName, String[], boolean) - Method in class akka.jmx.Client
 
doMatch(String, Object) - Method in class akka.testkit.EventFilter
internal implementation helper, no guaranteed API
doNothing() - Method in class akka.dispatch.MonitorableThreadFactory$
 
doNothing() - Static method in class akka.dispatch.MonitorableThreadFactory
 
doNothing() - Method in interface akka.transactor.Transactor
Default catch-all for the different Receive methods.
doSubCommand(MBeanServerConnection, ObjectInstance, String) - Method in class akka.jmx.Client
 
down(Address) - Method in class akka.cluster.Cluster
Send command to DOWN the node specified by 'address'.
down(String) - Method in interface akka.cluster.ClusterNodeMBean
Send command to DOWN the node specified by 'address'.
down() - Method in class akka.cluster.MemberStatus$
Java API: retrieve the “down” status singleton
down() - Static method in class akka.cluster.MemberStatus
Java API: retrieve the “down” status singleton
downed() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
drainTo(Collection<? super E>) - Method in class akka.util.BoundedBlockingQueue
 
drainTo(Collection<? super E>, int) - Method in class akka.util.BoundedBlockingQueue
 
drop(int) - Method in class akka.actor.IO$
An Iteratee that ignores the specified number of bytes.
drop(int) - Static method in class akka.actor.IO
An Iteratee that ignores the specified number of bytes.
drop(int) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
drop(int) - Method in class akka.util.ByteIterator
 
drop(int) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
drop(int) - Method in class akka.util.ByteString
 
dropRight(int) - Method in class akka.util.ByteString
 
dropWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
dropWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator
 
dropWhile(Function1<Object, Object>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
dropWhile(Function1<Object, Object>) - Method in class akka.util.ByteString
 
DSLDefaultTimeout() - Method in class akka.actor.ActorDSL.Extension
 
DSLInboxQueueSize() - Method in interface akka.actor.dsl.Inbox.InboxExtension
 
DummyClassForStringSources - Class in akka.event
This is a “marker” class which is inserted as originator class into Logging.LogEvent when the string representation was supplied directly.
DummyClassForStringSources() - Constructor for class akka.event.DummyClassForStringSources
 
dumpConfig() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
dumpConfig(String) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
dumpItem(JournalItem) - Method in class akka.actor.mailbox.filebased.filequeue.tools.QueueDumper
 
dumpStats() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
duplicate() - Method in class akka.util.ByteIterator
 
DurableMailboxSettings - Interface in akka.actor.mailbox
Conventional organization of durable mailbox settings: akka { actor { my-durable-dispatcher { mailbox-type = "my.durable.mailbox" my-durable-mailbox { setting1 = 1 setting2 = 2 } } } } where name=“my-durable-mailbox” in this example.
DurableMailboxSpec - Class in akka.actor.mailbox
Reusable test fixture for durable mailboxes.
DurableMailboxSpec(ActorSystem, String) - Constructor for class akka.actor.mailbox.DurableMailboxSpec
 
DurableMailboxSpec(String, String) - Constructor for class akka.actor.mailbox.DurableMailboxSpec
Subclass must define dispatcher in the supplied config for the specific backend.
DurableMailboxSpec$ - Class in akka.actor.mailbox
 
DurableMailboxSpec$() - Constructor for class akka.actor.mailbox.DurableMailboxSpec$
 
DurableMailboxSpecActorFactory - Class in akka.actor.mailbox
 
DurableMailboxSpecActorFactory() - Constructor for class akka.actor.mailbox.DurableMailboxSpecActorFactory
 
DurableMailboxSpecActorFactory$ - Class in akka.actor.mailbox
 
DurableMailboxSpecActorFactory$() - Constructor for class akka.actor.mailbox.DurableMailboxSpecActorFactory$
 
DurableMailboxSpecActorFactory.AccumulatorActor - Class in akka.actor.mailbox
 
DurableMailboxSpecActorFactory.AccumulatorActor() - Constructor for class akka.actor.mailbox.DurableMailboxSpecActorFactory.AccumulatorActor
 
DurableMailboxSpecActorFactory.MailboxTestActor - Class in akka.actor.mailbox
 
DurableMailboxSpecActorFactory.MailboxTestActor() - Constructor for class akka.actor.mailbox.DurableMailboxSpecActorFactory.MailboxTestActor
 
DurableMessageQueue - Class in akka.actor.mailbox
 
DurableMessageQueue(ActorRef, ExtendedActorSystem) - Constructor for class akka.actor.mailbox.DurableMessageQueue
 
DurableMessageQueueWithSerialization - Class in akka.actor.mailbox
Java API DurableMessageQueue with functionality to serialize and deserialize Envelopes (messages)
DurableMessageQueueWithSerialization(ActorRef, ExtendedActorSystem) - Constructor for class akka.actor.mailbox.DurableMessageQueueWithSerialization
 
DurableMessageSerialization - Interface in akka.actor.mailbox
DurableMessageSerialization can be mixed into a DurableMessageQueue and adds functionality to serialize and deserialize Envelopes (messages)
duration() - Method in class akka.contrib.throttle.Throttler.Rate
 
duration(String) - Static method in class akka.testkit.JavaTestKit
 
duration() - Method in class akka.util.Timeout
 
duration() - Method in class akka.zeromq.PollTimeoutDuration
 
durationInMillis() - Method in class akka.contrib.throttle.Throttler.Rate
The duration in milliseconds.
durationToTimeout(FiniteDuration) - Method in class akka.util.Timeout$
 
durationToTimeout(FiniteDuration) - Static method in class akka.util.Timeout
 
DynamicAccess - Class in akka.actor
The DynamicAccess implementation is the class which is used for loading all configurable parts of an actor system (the ReflectiveDynamicAccess is the default implementation).
DynamicAccess() - Constructor for class akka.actor.DynamicAccess
 
dynamicAccess() - Method in class akka.actor.ExtendedActorSystem
ClassLoader wrapper which is used for reflective accesses internally.
dynamicAccess() - Method in class akka.actor.LocalActorRefProvider
 
dynamicAccess() - Method in interface akka.dispatch.DispatcherPrerequisites
 
dynamicAccess() - Method in class akka.remote.RemoteActorRefProvider
 

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
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
 
elements() - Method in class akka.util.internal.ConcurrentIdentityHashMap
Returns an enumeration of the values in this table.
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.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
 
end() - Method in interface akka.testkit.TestKitBase
 
endpoint() - Method in class akka.zeromq.Bind
 
endpoint() - Method in class akka.zeromq.Connect
 
endpoint() - Method in interface akka.zeromq.SocketConnectOption
 
endpointUri() - Method in interface akka.camel.Consumer
Must return the Camel endpoint URI that the consumer wants to consume messages from.
endpointUri() - Method in class akka.camel.javaapi.UntypedConsumerActor
 
endpointUri() - Method in class akka.camel.javaapi.UntypedProducerActor
 
endpointUri() - Method in interface akka.camel.ProducerSupport
Returns the Camel endpoint URI to produce messages to.
engineGenerateSeed(int) - Method in class akka.remote.security.provider.AES128CounterInetRNG
Unused method Returns the given number of seed bytes.
engineGenerateSeed(int) - Method in class akka.remote.security.provider.AES128CounterSecureRNG
Unused method Returns the given number of seed bytes.
engineGenerateSeed(int) - Method in class akka.remote.security.provider.AES256CounterInetRNG
Unused method Returns the given number of seed bytes.
engineGenerateSeed(int) - Method in class akka.remote.security.provider.AES256CounterSecureRNG
Unused method Returns the given number of seed bytes.
engineNextBytes(byte[]) - Method in class akka.remote.security.provider.AES128CounterInetRNG
Generates a user-specified number of random bytes.
engineNextBytes(byte[]) - Method in class akka.remote.security.provider.AES128CounterSecureRNG
Generates a user-specified number of random bytes.
engineNextBytes(byte[]) - Method in class akka.remote.security.provider.AES256CounterInetRNG
Generates a user-specified number of random bytes.
engineNextBytes(byte[]) - Method in class akka.remote.security.provider.AES256CounterSecureRNG
Generates a user-specified number of random bytes.
engineSetSeed(byte[]) - Method in class akka.remote.security.provider.AES128CounterInetRNG
This is managed internally by AESCounterRNG
engineSetSeed(byte[]) - Method in class akka.remote.security.provider.AES128CounterSecureRNG
This is managed internally by AESCounterRNG
engineSetSeed(byte[]) - Method in class akka.remote.security.provider.AES256CounterInetRNG
This is managed internally by AESCounterRNG
engineSetSeed(byte[]) - Method in class akka.remote.security.provider.AES256CounterSecureRNG
This is managed internally by AESCounterRNG
enqueue(ActorRef, Envelope) - Method in class akka.actor.mailbox.filebased.FileBasedMessageQueue
 
enqueue(ByteString) - Method in class akka.actor.WriteBuffer
 
enqueue(ActorRef, Envelope) - Method in interface akka.dispatch.BoundedDequeBasedMessageQueueSemantics
 
enqueue(ActorRef, Envelope) - Method in interface akka.dispatch.BoundedMessageQueueSemantics
 
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 interface akka.dispatch.UnboundedDequeBasedMessageQueueSemantics
 
enqueue(ActorRef, Envelope) - Method in interface akka.dispatch.UnboundedMessageQueueSemantics
 
enqueue(ActorRef, Envelope) - Method in class akka.testkit.CallingThreadMailbox
 
enqueueFirst(ActorRef, Envelope) - Method in interface akka.dispatch.BoundedDequeBasedMessageQueueSemantics
 
enqueueFirst(ActorRef, Envelope) - Method in interface akka.dispatch.DequeBasedMessageQueue
 
enqueueFirst(ActorRef, Envelope) - Method in interface akka.dispatch.UnboundedDequeBasedMessageQueueSemantics
 
enqueueMessage(Object) - Method in class akka.actor.dsl.Inbox.InboxActor
 
enqueueQuery(Inbox.Query) - Method in class akka.actor.dsl.Inbox.InboxActor
 
entrySet() - Method in class akka.util.internal.ConcurrentIdentityHashMap
Returns a Set view of the mappings contained in this map.
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(Object) - Method in class akka.actor.ChildActorPath
 
equals(Object) - Method in class akka.cluster.Member
 
equals(Object) - Method in class akka.cluster.Metric
 
equals(Object) - Method in class akka.cluster.NodeMetrics
 
erase() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
error(Logging.Error) - Method in interface akka.event.Logging.StdOutLogger
 
error(Throwable, String) - Method in interface akka.event.LoggingAdapter
 
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
 
error(String, String, String, String, int) - Method in class akka.testkit.EventFilter$
Create a filter for Error events which do not have a cause set (i.e. use implicitly supplied Logging.Error.NoCause).
error(String, String, String, String, int) - Static method in class akka.testkit.EventFilter
Create a filter for Error events which do not have a cause set (i.e. use implicitly supplied Logging.Error.NoCause).
ErrorFilter - Class in akka.testkit
Filter which matches Error events, if they satisfy the given criteria: throwable applies an upper bound on the type of exception contained in the Error event source, if given, applies a filter on the event’s origin message applies a filter on the event’s message (either with String.startsWith or Regex.findFirstIn().isDefined); if the message itself does not match, the match is retried with the contained Exception’s message; if both are null, the filter always matches if at the same time the Exception’s stack trace is empty (this catches JVM-omitted “fast-throw” exceptions) If you want to match all Error events, the most efficient is to use Left("").
ErrorFilter(Class<?>, Option<String>, Either<String, Regex>, boolean, int) - Constructor for class akka.testkit.ErrorFilter
 
ErrorFilter(Class<?>, String, String, boolean, boolean, int) - Constructor for class akka.testkit.ErrorFilter
Java API: create an ErrorFilter
ErrorFilter(Class<?>) - Constructor for class akka.testkit.ErrorFilter
Java API: filter only on the given type of exception
ErrorFilter$ - Class in akka.testkit
 
ErrorFilter$() - Constructor for class akka.testkit.ErrorFilter$
 
errorFormat() - Method in interface akka.event.Logging.StdOutLogger
 
errorFormatWithoutCause() - Method in interface akka.event.Logging.StdOutLogger
 
ErrorLevel() - Method in class akka.event.Logging$
Log level in numeric form, used when deciding whether a certain log statement should generate a log event.
ErrorLevel() - Static method in class akka.event.Logging
Log level in numeric form, used when deciding whether a certain log statement should generate a log event.
Escalate() - Method in interface akka.actor.dsl.Creators.Act
 
escalate() - Method in class akka.actor.SupervisorStrategy$
Java API: Returning this directive escalates the failure to the supervisor of the supervisor, by rethrowing the cause of the failure.
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.
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
 
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
EventFilter - Class in akka.testkit
Facilities for selectively filtering out expected events from logging so that you can keep your test run’s console output clean and do not miss real error messages.
EventFilter(int) - Constructor for class akka.testkit.EventFilter
 
EventFilter$ - Class in akka.testkit
Facilities for selectively filtering out expected events from logging so that you can keep your test run’s console output clean and do not miss real error messages.
EventFilter$() - Constructor for class akka.testkit.EventFilter$
 
EventHandlers() - Method in class akka.actor.ActorSystem.Settings
 
EventHandlerStartTimeout() - Method in class akka.actor.ActorSystem.Settings
 
events() - Method in interface akka.actor.LoggingFSM
 
eventStream() - Method in class akka.actor.ActorSystem
Main event bus of this actor system, used for example for logging.
eventStream() - Method in class akka.actor.LocalActorRefProvider
 
eventStream() - Method in interface akka.dispatch.DispatcherPrerequisites
 
eventStream() - Method in class akka.dispatch.TaskInvocation
 
EventStream - Class in akka.event
 
EventStream(boolean) - Constructor for class akka.event.EventStream
 
eventStream() - Method in class akka.remote.RemoteActorRefProvider
 
EventStream$ - Class in akka.event
 
EventStream$() - Constructor for class akka.event.EventStream$
 
EWMA$ - Class in akka.cluster
 
EWMA$() - Constructor for class akka.cluster.EWMA$
 
exceptionHandler() - Method in class akka.dispatch.MonitorableThreadFactory
 
exec() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.MailboxExecutionTask
 
exec() - Method in class akka.testkit.JavaTestKit.EventFilter
 
execute(Runnable) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
execute(Runnable) - Method in class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinPool
 
execute(String[]) - Method in class akka.jmx.Client
Version of execute called from the cmdline.
execute(String, String, String, String, String[]) - Method in class akka.jmx.Client
 
execute(String, String, String, String, String[], boolean) - Method in class akka.jmx.Client
Execute command against remote JMX agent.
executeOneCmd(String, String, String, String, String) - Method in class akka.jmx.Client
 
executeTask(TaskInvocation) - Method in class akka.dispatch.Dispatcher
INTERNAL USE ONLY
executeTask(TaskInvocation) - Method in class akka.dispatch.MessageDispatcher
INTERNAL API
executeTask(TaskInvocation) - Method in class akka.testkit.CallingThreadDispatcher
 
ExecutionContexts - Class in akka.dispatch
ExecutionContexts is the Java API for ExecutionContexts
ExecutionContexts() - Constructor for class akka.dispatch.ExecutionContexts
 
ExecutionContexts$ - Class in akka.dispatch
ExecutionContexts is the Java API for ExecutionContexts
ExecutionContexts$() - Constructor for class akka.dispatch.ExecutionContexts$
 
executor() - Method in interface akka.dispatch.ExecutorServiceDelegate
 
executorService() - Method in class akka.dispatch.Dispatcher
 
ExecutorServiceConfigurator - Class in akka.dispatch
An ExecutorServiceConfigurator is a class that given some prerequisites and a configuration can create instances of ExecutorService
ExecutorServiceConfigurator(com.typesafe.config.Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.ExecutorServiceConfigurator
 
ExecutorServiceDelegate - Interface in akka.dispatch
As the name says
ExecutorServiceFactory - Interface in akka.dispatch
Function0 without the fun stuff (mostly for the sake of the Java API side of things)
ExecutorServiceFactoryProvider - Interface in akka.dispatch
Generic way to specify an ExecutorService to a Dispatcher, create it with the given name if desired
existenceConfirmed() - Method in class akka.actor.Terminated
 
exiting() - Method in class akka.cluster.MemberStatus$
Java API: retrieve the “exiting” status singleton
exiting() - Static method in class akka.cluster.MemberStatus
Java API: retrieve the “exiting” status singleton
expectMsg(T) - Method in interface akka.testkit.TestKitBase
Same as expectMsg(remaining, obj), but correctly treating the timeFactor.
expectMsg(FiniteDuration, T) - Method in interface akka.testkit.TestKitBase
Receive one message from the test actor and assert that it equals the given object.
expectMsg_internal(Duration, T) - Method in interface akka.testkit.TestKitBase
 
expectMsgAllClassOf(Seq<Class<? extends T>>) - Method in interface akka.testkit.TestKitBase
Same as expectMsgAllClassOf(remaining, obj...)
expectMsgAllClassOf(FiniteDuration, Seq<Class<? extends T>>) - Method in interface akka.testkit.TestKitBase
Receive a number of messages from the test actor matching the given number of classes and assert that for each given class one is received which is of that class (equality, not conformance).
expectMsgAllConformingOf(Seq<Class<? extends T>>) - Method in interface akka.testkit.TestKitBase
Same as expectMsgAllConformingOf(remaining, obj...)
expectMsgAllConformingOf(FiniteDuration, Seq<Class<? extends T>>) - Method in interface akka.testkit.TestKitBase
Receive a number of messages from the test actor matching the given number of classes and assert that for each given class one is received which conforms to that class (and vice versa).
expectMsgAllOf(Object...) - Method in class akka.testkit.JavaTestKit
 
expectMsgAllOf(FiniteDuration, Object...) - Method in class akka.testkit.JavaTestKit
 
expectMsgAllOf(Seq<T>) - Method in interface akka.testkit.TestKitBase
Same as expectMsgAllOf(remaining, obj...)
expectMsgAllOf(FiniteDuration, Seq<T>) - Method in interface akka.testkit.TestKitBase
Receive a number of messages from the test actor matching the given number of objects and assert that for each given object one is received which equals it and vice versa.
expectMsgAllOf_internal(FiniteDuration, Seq<T>) - Method in interface akka.testkit.TestKitBase
 
expectMsgAnyClassOf(Class<? extends T>...) - Method in class akka.testkit.JavaTestKit
 
expectMsgAnyClassOf(FiniteDuration, Class<?>...) - Method in class akka.testkit.JavaTestKit
 
expectMsgAnyClassOf(Seq<Class<? extends C>>) - Method in interface akka.testkit.TestKitBase
Same as expectMsgAnyClassOf(remaining, obj...)
expectMsgAnyClassOf(FiniteDuration, Seq<Class<? extends C>>) - Method in interface akka.testkit.TestKitBase
Receive one message from the test actor and assert that it conforms to one of the given classes.
expectMsgAnyClassOf_internal(FiniteDuration, Seq<Class<? extends C>>) - Method in interface akka.testkit.TestKitBase
 
expectMsgAnyOf(Object...) - Method in class akka.testkit.JavaTestKit
 
expectMsgAnyOf(FiniteDuration, Object...) - Method in class akka.testkit.JavaTestKit
 
expectMsgAnyOf(Seq<T>) - Method in interface akka.testkit.TestKitBase
Same as expectMsgAnyOf(remaining, obj...)
expectMsgAnyOf(FiniteDuration, Seq<T>) - Method in interface akka.testkit.TestKitBase
Receive one message from the test actor and assert that it equals one of the given objects.
expectMsgAnyOf_internal(FiniteDuration, Seq<T>) - Method in interface akka.testkit.TestKitBase
 
expectMsgClass(Class<T>) - Method in class akka.testkit.JavaTestKit
 
expectMsgClass(FiniteDuration, Class<T>) - Method in class akka.testkit.JavaTestKit
 
expectMsgClass(Class<C>) - Method in interface akka.testkit.TestKitBase
Same as expectMsgClass(remaining, c), but correctly treating the timeFactor.
expectMsgClass(FiniteDuration, Class<C>) - Method in interface akka.testkit.TestKitBase
Receive one message from the test actor and assert that it conforms to the given class.
expectMsgClass_internal(FiniteDuration, Class<C>) - Method in interface akka.testkit.TestKitBase
 
expectMsgEquals(T) - Method in class akka.testkit.JavaTestKit
 
expectMsgEquals(FiniteDuration, T) - Method in class akka.testkit.JavaTestKit
 
expectMsgPF(Duration, String, PartialFunction<Object, T>) - Method in interface akka.testkit.TestKitBase
Receive one message from the test actor and assert that the given partial function accepts it.
expectMsgType(ClassTag<T>) - Method in interface akka.testkit.TestKitBase
Same as expectMsgType[T](remaining), but correctly treating the timeFactor.
expectMsgType(FiniteDuration, ClassTag<T>) - Method in interface akka.testkit.TestKitBase
Receive one message from the test actor and assert that it conforms to the given type (after erasure).
expectNoMsg() - Method in class akka.testkit.JavaTestKit
 
expectNoMsg(FiniteDuration) - Method in class akka.testkit.JavaTestKit
 
expectNoMsg() - Method in interface akka.testkit.TestKitBase
Same as expectNoMsg(remaining), but correctly treating the timeFactor.
expectNoMsg(FiniteDuration) - Method in interface akka.testkit.TestKitBase
Assert that no message is received for the specified time.
expectNoMsg_internal(FiniteDuration) - Method in interface akka.testkit.TestKitBase
 
expiredQueue() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
expiredQueue() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
expiry() - Method in class akka.actor.mailbox.filebased.filequeue.QItem
 
ExtendedActorSystem - Class in akka.actor
More powerful interface to the actor system’s implementation which is presented to extensions (see Extension).
ExtendedActorSystem() - Constructor for class akka.actor.ExtendedActorSystem
 
extendHash(int, int, int, int) - Method in class akka.routing.MurmurHash$
Incorporates a new value into an existing hash.
extendHash(int, int, int, int) - Static method in class akka.routing.MurmurHash
Incorporates a new value into an existing hash.
extension(ExtensionId<T>) - Method in class akka.actor.ActorSystem
Returns the payload that is associated with the provided extension throws an IllegalStateException if it is not registered.
Extension - Interface in akka.actor
The basic ActorSystem covers all that is needed for locally running actors, using futures and so on.
ExtensionId<T extends Extension> - Interface in akka.actor
Identifies an Extension Lookup of Extensions is done by object identity, so the Id must be the same wherever it's used, otherwise you'll get the same extension loaded multiple times.
ExtensionIdProvider - Interface in akka.actor
To be able to load an ExtensionId from the configuration, a class that implements ExtensionIdProvider must be specified.
ExtensionKey<T extends Extension> - Class in akka.actor
This is a one-stop-shop if all you want is an extension which is constructed with the ExtendedActorSystem as its only constructor argument: object MyExt extends ExtensionKey[Ext] class Ext(system: ExtendedActorSystem) extends MyExt { ... } 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
 
extractCpu(NodeMetrics) - Method in class akka.cluster.StandardMetrics$
Java API to extract Cpu data from nodeMetrics, if the nodeMetrics contains necessary cpu metrics, otherwise it returns null.
extractCpu(NodeMetrics) - Static method in class akka.cluster.StandardMetrics
Java API to extract Cpu data from nodeMetrics, if the nodeMetrics contains necessary cpu metrics, otherwise it returns null.
extractHeapMemory(NodeMetrics) - Method in class akka.cluster.StandardMetrics$
Java API to extract HeapMemory data from nodeMetrics, if the nodeMetrics contains necessary heap metrics, otherwise it returns null.
extractHeapMemory(NodeMetrics) - Static method in class akka.cluster.StandardMetrics
Java API to extract HeapMemory data from nodeMetrics, if the nodeMetrics contains necessary heap metrics, otherwise it returns null.
extractInterfaces(Class<?>) - Method in class akka.actor.TypedProps$
 
extractInterfaces(Class<?>) - Static method in class akka.actor.TypedProps
 
ExtractRoute - Class in akka.testkit
This object can be used to extract the Route out of a RoutedActorRef.
ExtractRoute() - Constructor for class akka.testkit.ExtractRoute
 
ExtractRoute$ - Class in akka.testkit
This object can be used to extract the Route out of a RoutedActorRef.
ExtractRoute$() - Constructor for class akka.testkit.ExtractRoute$
 
extraTime() - Method in interface akka.actor.dsl.Inbox
 

F

f() - Method in class akka.actor.IO.Next
 
f() - Method in class akka.routing.WithListeners
 
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
failureDetector() - Method in class akka.cluster.Cluster
 
FailureDetector - Interface in akka.cluster
Interface for Akka failure detectors.
FailureDetectorAcceptableHeartbeatPause() - Method in class akka.cluster.ClusterSettings
 
FailureDetectorImplementationClass() - Method in class akka.cluster.ClusterSettings
 
FailureDetectorMaxSampleSize() - Method in class akka.cluster.ClusterSettings
 
FailureDetectorMinStdDeviation() - Method in class akka.cluster.ClusterSettings
 
FailureDetectorThreshold() - Method in class akka.cluster.ClusterSettings
 
fallbackClassLoader() - Method in class akka.osgi.OsgiActorSystemFactory
 
fallbackConfig() - Method in class akka.actor.mailbox.DurableMailboxSpec$
 
fallbackConfig() - Static method in class akka.actor.mailbox.DurableMailboxSpec
 
FALSE() - Method in class akka.testkit.TestActor$
 
FALSE() - Static method in class akka.testkit.TestActor
 
FileBasedMailboxSettings - Class in akka.actor.mailbox.filebased
 
FileBasedMailboxSettings(ActorSystem.Settings, com.typesafe.config.Config) - Constructor for class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
FileBasedMailboxType - Class in akka.actor.mailbox.filebased
 
FileBasedMailboxType(ActorSystem.Settings, com.typesafe.config.Config) - Constructor for class akka.actor.mailbox.filebased.FileBasedMailboxType
 
FileBasedMessageQueue - Class in akka.actor.mailbox.filebased
 
FileBasedMessageQueue(ActorRef, ExtendedActorSystem, FileBasedMailboxSettings) - Constructor for class akka.actor.mailbox.filebased.FileBasedMessageQueue
 
FileDescriptor - Class in akka.zeromq
Gets the file descriptor associated with the ZeroMQ socket
FileDescriptor() - Constructor for class akka.zeromq.FileDescriptor
 
fileDescriptor() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its file descriptor configuration.
fileDescriptor() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its file descriptor configuration.
FileDescriptor$ - Class in akka.zeromq
Gets the file descriptor associated with the ZeroMQ socket
FileDescriptor$() - Constructor for class akka.zeromq.FileDescriptor$
 
filenames() - Method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper$
 
filenames() - Static method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper
 
fillArray(int, Function2<byte[], Object, BoxedUnit>) - Method in class akka.util.ByteStringBuilder
 
fillByteBuffer(int, ByteOrder, Function1<ByteBuffer, BoxedUnit>) - Method in class akka.util.ByteStringBuilder
 
fillReadBehind(Function1<QItem, BoxedUnit>) - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
Filter - Class in akka.dispatch
Java API (not recommended): Callback for the Future.filter operation that creates a new Future which will conditionally contain the success of another Future.
Filter() - Constructor for class akka.dispatch.Filter
 
filter(int, int) - Method in class akka.routing.DefaultResizer
This method can be used to smooth the capacity delta by considering the current pressure and current capacity.
filter(Logging.LogEvent) - Method in class akka.testkit.TestEventListener
 
Filter$ - Class in akka.dispatch
Java API (not recommended): Callback for the Future.filter operation that creates a new Future which will conditionally contain the success of another Future.
Filter$() - Constructor for class akka.dispatch.Filter$
 
filterOf(Function<T, Boolean>) - Method in class akka.dispatch.Filter$
 
filterOf(Function<T, Boolean>) - Static method in class akka.dispatch.Filter
 
filters() - Method in class akka.testkit.TestEvent.Mute
 
filters() - Method in class akka.testkit.TestEvent.UnMute
 
filters() - Method in class akka.testkit.TestEventListener
 
finalize() - Method in class akka.actor.dsl.Inbox.Inbox
Overridden finalizer which will try to stop the actor once this Inbox is no longer referenced.
finalizeHash(int) - Method in class akka.routing.MurmurHash$
Once all hashes have been incorporated, this performs a final mixing
finalizeHash(int) - Static method in class akka.routing.MurmurHash
Once all hashes have been incorporated, this performs a final mixing
find(Iterable<Future<T>>, Function<T, Boolean>, ExecutionContext) - Method in class akka.dispatch.Futures$
Returns a Future that will hold the optional result of the first Future with a result that matches the predicate
find(Iterable<Future<T>>, Function<T, Boolean>, ExecutionContext) - Static method in class akka.dispatch.Futures
Returns a Future that will hold the optional result of the first Future with a result that matches the predicate
findAvailableId(org.apache.aries.blueprint.ParserContext) - Method in class akka.osgi.aries.blueprint.NamespaceHandler
 
findClass(String) - Method in class akka.osgi.impl.BundleDelegatingClassLoader
 
findResource(String) - Method in class akka.osgi.impl.BundleDelegatingClassLoader
 
findResources(String) - Method in class akka.osgi.impl.BundleDelegatingClassLoader
 
findSerializerFor(Object) - Method in class akka.serialization.Serialization
Returns the Serializer configured for the given object, returns the NullSerializer if it's null.
findValue(K, Function1<V, Object>) - Method in class akka.util.Index
 
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
firstFrameAsString(String) - Method in class akka.zeromq.ZMQMessage
Convert the bytes in the first frame to a String, using specified charset.
firstFrameAsString() - Method in class akka.zeromq.ZMQMessage
Convert the bytes in the first frame to a String, using "UTF-8" charset.
firstHeartbeatEstimate() - Method in class akka.cluster.AccrualFailureDetector
 
fishForMessage(Duration, String, PartialFunction<Object, Object>) - Method in interface akka.testkit.TestKitBase
Hybrid of expectMsgPF and receiveWhile: receive messages while the partial function matches and returns false.
flatMap(Function1<A, IO.Iteratee<B>>) - Method in class akka.actor.IO.Iteratee
Applies a function to the result of this Iteratee, resulting in a new Iteratee.
flatMap(Function1<A, IO.Iteratee<A>>) - Method in interface akka.actor.IO.IterateeRef
 
flatMap(Function1<A, IO.Iteratee<A>>) - Method in class akka.actor.IO.IterateeRefAsync
 
flatMap(Function1<A, IO.Iteratee<A>>) - Method in class akka.actor.IO.IterateeRefSync
 
flatMap(Function1<T, Agent<B>>) - Method in class akka.agent.Agent
Flatmap this agent to a new agent, applying the function to the internal state.
flatMap(Function<T, Agent<B>>) - Method in class akka.agent.Agent
Java API: Flatmap this agent to a new agent, applying the function to the internal state.
flush() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
flush(String) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
flushAllExpired() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
flushExpired(String) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
fold(B, M, Function2<B, A, IO.Iteratee<B>>) - Method in class akka.actor.IO$
An Iteratee that folds over a Traversable by applying a function that returns an Iteratee.
fold(B, M, Function2<B, A, IO.Iteratee<B>>) - Static method in class akka.actor.IO
An Iteratee that folds over a Traversable by applying a function that returns an Iteratee.
fold(R, Iterable<Future<T>>, Function2<R, T, R>, ExecutionContext) - Method in class akka.dispatch.Futures$
A non-blocking fold over the specified futures, with the start value of the given zero.
fold(R, Iterable<Future<T>>, Function2<R, T, R>, ExecutionContext) - Static method in class akka.dispatch.Futures
A non-blocking fold over the specified futures, with the start value of the given zero.
fold(Function0<T>, Function0<T>) - Method in class akka.util.Switch
Executes the provided callbacks depending on if the switch is either on or off waiting for any pending changes to happen before (locking) Be careful of longrunning or blocking within the provided action as it can lead to deadlocks or bad performance
foldLeft(B, Function2<B, Object, B>) - Method in class akka.util.ByteIterator
 
foreach(Function1<T, U>) - Method in class akka.agent.Agent
Applies the function to the internal state.
foreach(Procedure<T>) - Method in class akka.agent.Agent
Java API: Applies the function to the internal state.
Foreach<T> - Class in akka.dispatch
Callback for the Future.foreach operation that will be invoked if the Future that this callback is registered on becomes completed with a success.
Foreach() - Constructor for class akka.dispatch.Foreach
 
foreach(Function1<Object, U>) - Method in class akka.util.ByteIterator
 
foreach(Function1<Object, U>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
foreach(Function1<Object, U>) - Method in class akka.util.ByteString
 
foreach(Function2<K, V, BoxedUnit>) - Method in class akka.util.Index
Applies the supplied function to all keys and their values
ForkJoinExecutorConfigurator - Class in akka.dispatch
 
ForkJoinExecutorConfigurator(com.typesafe.config.Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator
 
ForkJoinExecutorConfigurator$ - Class in akka.dispatch
 
ForkJoinExecutorConfigurator$() - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator$
 
ForkJoinExecutorConfigurator.AkkaForkJoinPool - Class in akka.dispatch
INTERNAL AKKA USAGE ONLY
ForkJoinExecutorConfigurator.AkkaForkJoinPool(int, ForkJoinPool.ForkJoinWorkerThreadFactory, Thread.UncaughtExceptionHandler) - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinPool
 
ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory - Class in akka.dispatch
 
ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory(ForkJoinPool.ForkJoinWorkerThreadFactory, int) - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory
 
ForkJoinExecutorConfigurator.MailboxExecutionTask - Class in akka.dispatch
INTERNAL AKKA USAGE ONLY
ForkJoinExecutorConfigurator.MailboxExecutionTask(Runnable) - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator.MailboxExecutionTask
 
ForkJoinExecutorConfigurator.MailboxExecutionTask(Mailbox) - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator.MailboxExecutionTask
 
format(String, Seq<Object>) - Method in interface akka.event.LoggingAdapter
 
format(TimeUnit, Duration) - Method in interface akka.testkit.TestKitBase
 
format1(String, Object) - Method in interface akka.event.LoggingAdapter
 
formatCredentials(String, String) - Method in class akka.jmx.Client
 
forMax(Duration) - Method in class akka.actor.FSM.State
Modify state transition descriptor to include a state timeout for the next state.
forward(Object, ActorContext) - Method in class akka.actor.ActorRef
Forwards the message and passes the original sender actor as the sender.
forward(ActorRef) - Method in class akka.testkit.JavaTestKit
 
forward(ActorRef, Object) - Method in class akka.testkit.TestProbe
Forward this message as if in the TestActor's receive method with self.forward.
Frame - Class in akka.zeromq
A single message frame of a zeromq message
Frame(Seq<Object>) - Constructor for class akka.zeromq.Frame
 
Frame(byte[]) - Constructor for class akka.zeromq.Frame
 
Frame(String) - Constructor for class akka.zeromq.Frame
 
Frame$ - Class in akka.zeromq
 
Frame$() - Constructor for class akka.zeromq.Frame$
 
frames() - Method in class akka.zeromq.Send
 
frames() - Method in class akka.zeromq.ZMQMessage
 
from() - Method in class akka.actor.FSM.Transition
 
from(String) - Method in class akka.testkit.JavaTestKit.EventFilter
 
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[], int, int) - Method in class akka.util.ByteString$
Creates a new ByteString by copying length bytes starting at offset from an 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.remote.serialization.ProtobufSerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in class akka.serialization.ByteArraySerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in class akka.serialization.JavaSerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in class akka.serialization.JSerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in class akka.serialization.NullSerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in interface akka.serialization.Serializer
Produces an object from an array of bytes, with an optional type-hint; the class should be loaded using ActorSystem.dynamicAccess.
fromBinary(byte[]) - Method in interface akka.serialization.Serializer
Java API: deserialize without type hint
fromBinary(byte[], Class<?>) - Method in interface akka.serialization.Serializer
Java API: deserialize with type hint
fromBinaryJava(byte[], Class<?>) - Method in class akka.serialization.JSerializer
This method must be implemented, manifest may be null.
fromClass() - Method in class akka.event.LogSource$
 
fromClass() - Method in interface akka.event.LogSource
 
FROMCLASSCREATOR_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.PropsProtocol
 
FromConfig - Class in akka.routing
Java API: Router configuration which has no default, i.e. external configuration is required.
FromConfig(String) - Constructor for class akka.routing.FromConfig
 
FromConfig() - Constructor for class akka.routing.FromConfig
 
FromConfig$ - Class in akka.routing
Router configuration which has no default, i.e. 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
 
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(Timeout) - Method in class akka.agent.Agent
A future to the current value that will be completed after any currently queued updates.
future(Callable<T>, ExecutionContext) - Method in class akka.dispatch.Futures$
Starts an asynchronous computation and returns a Future object with the result of that computation.
future(Callable<T>, ExecutionContext) - Static method in class akka.dispatch.Futures
Starts an asynchronous computation and returns a Future object with the result of that computation.
future() - Method in class akka.pattern.PipeToSupport.PipeableFuture
 
Futures - Class in akka.dispatch
Futures is the Java API for Futures and Promises
Futures() - Constructor for class akka.dispatch.Futures
 
Futures$ - Class in akka.dispatch
Futures is the Java API for Futures and Promises
Futures$() - Constructor for class akka.dispatch.Futures$
 
FutureTimeoutSupport - Interface in akka.pattern
Copyright (C) 2009-2013 Typesafe Inc.

G

gen(Object) - Method in class akka.dispatch.PriorityGenerator
 
generateSecureCookie() - Method in class akka.util.Crypt$
 
generateSecureCookie() - Static method in class akka.util.Crypt
 
generateSeed(int) - Method in class akka.remote.security.provider.InternetSeedGenerator
Generates a seed by trying each of the available strategies in turn until one succeeds.
generation() - Method in interface akka.actor.FSM
 
generation() - Method in class akka.actor.FSM.TimeoutMarker
 
generation() - Method in class akka.actor.FSM.Timer
 
genString(T) - Method in interface akka.event.LogSource
 
genString(T, ActorSystem) - Method in interface akka.event.LogSource
 
get(ActorSystem) - Method in interface akka.actor.ExtensionId
Returns an instance of the extension identified by this ExtensionId instance.
get() - Method in class akka.actor.IO.Iteratee
Passes an akka.actor.IO.EOF to this Iteratee and returns the result if available.
get(K) - Method in class akka.actor.IO.IterateeRef.Map
 
get(ActorSystem) - Method in class akka.actor.TypedActor$
 
get(ActorContext) - Method in class akka.actor.TypedActor$
Returns a contextual TypedActorFactory of this extension, this means that any TypedActors created by this TypedActorExtension will be children to the specified context, this allows for creating hierarchies of TypedActors.
get(ActorSystem) - Static method in class akka.actor.TypedActor
 
get(ActorContext) - Static method in class akka.actor.TypedActor
Returns a contextual TypedActorFactory of this extension, this means that any TypedActors created by this TypedActorExtension will be children to the specified context, this allows for creating hierarchies of TypedActors.
get() - Method in class akka.agent.Agent
Java API: Read the internal state of the agent.
get(ActorSystem) - Method in class akka.camel.CamelExtension$
 
get(ActorSystem) - Static method in class akka.camel.CamelExtension
 
get(ActorSystem) - Method in class akka.cluster.Cluster$
 
get(ActorSystem) - Static method in class akka.cluster.Cluster
 
get() - Method in class akka.japi.Option
 
get() - Method in class akka.japi.Option.Some
 
get(ActorSystem) - Method in class akka.serialization.SerializationExtension$
 
get(ActorSystem) - Static method in class akka.serialization.SerializationExtension
 
get() - Method in class akka.testkit.JavaTestKit.ExpectMsg
 
get() - Method in class akka.testkit.JavaTestKit.ReceiveWhile
 
get(ActorSystem) - Method in class akka.testkit.TestKitExtension$
 
get(ActorSystem) - Static method in class akka.testkit.TestKitExtension
 
get(ActorSystem) - Method in class akka.transactor.TransactorExtension$
 
get(ActorSystem) - Static method in class akka.transactor.TransactorExtension
 
get(Object) - Method in class akka.util.internal.ConcurrentIdentityHashMap
Returns the value to which the specified key is mapped, or null if this map contains no mapping for the key.
get(ActorSystem) - Method in class akka.zeromq.ZeroMQExtension$
 
get(ActorSystem) - Static method in class akka.zeromq.ZeroMQExtension
 
getActivation() - Method in class akka.camel.javaapi.UntypedConsumerActor
Java API: Returns the Activation interface that can be used to wait on activation or de-activation of Camel endpoints.
getActivation() - Method in class akka.camel.javaapi.UntypedProducerActor
''Java API'': Returns the Activation interface that can be used to wait on activation or de-activation of Camel endpoints.
getActor() - Method in exception akka.actor.ActorInitializationException
 
getActor() - Method in class akka.actor.Terminated
 
getActorRefFor(Object) - Method in class akka.actor.ContextualTypedActorFactory
 
getActorRefFor(Object) - Method in class akka.actor.TypedActorExtension
Retrieves the underlying ActorRef for the supplied TypedActor proxy, or null if none found
getActorRefFor(Object) - Method in interface akka.actor.TypedActorFactory
Retrieves the underlying ActorRef for the supplied TypedActor proxy, or null if none found
getActorSystemName(org.osgi.framework.BundleContext) - Method in class akka.osgi.ActorSystemActivator
By default, the ActorSystem name will be set to bundle--ActorSystem.
getAddressTerminated() - Method in class akka.actor.Terminated
 
getArgs() - Method in class akka.jmx.Client.CommandParse
 
getBodyAs(Class<T>, org.apache.camel.CamelContext) - Method in class akka.camel.CamelMessage
Java API: Returns the body of the message converted to the type as given by the clazz parameter.
getByte() - Method in class akka.util.ByteIterator
Get a single Byte from this iterator.
getBytes(byte[], int, int) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
getBytes(byte[]) - Method in class akka.util.ByteIterator
Get a specific number of Bytes from this iterator.
getBytes(byte[], int, int) - Method in class akka.util.ByteIterator
Get a specific number of Bytes from this iterator.
getBytes(byte[], int, int) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
getCallerName(Class<?>) - Method in class akka.testkit.AkkaSpec$
 
getCallerName(Class<?>) - Static method in class akka.testkit.AkkaSpec
 
getCamelContext() - Method in class akka.camel.javaapi.UntypedConsumerActor
Java API: Returns the org.apache.camel.impl.DefaultCamelContext
getCamelContext() - Method in class akka.camel.javaapi.UntypedProducerActor
Returns the CamelContext.
getCause() - Method in class akka.event.Logging.LogEventException
 
getCause() - Method in exception akka.pattern.AskTimeoutException
 
getCause() - Method in class akka.remote.RemoteClientError
 
getCause() - Method in class akka.remote.RemoteServerError
 
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
 
getClient() - Method in exception akka.remote.RemoteClientException
 
getClientAddress() - Method in class akka.remote.RemoteServerClientClosed
 
getClientAddress() - Method in class akka.remote.RemoteServerClientConnected
 
getClientAddress() - Method in class akka.remote.RemoteServerClientDisconnected
 
getClusterStatus() - Method in interface akka.cluster.ClusterNodeMBean
 
getCmd() - Method in class akka.jmx.Client.CommandParse
 
getCommandType() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
getCommandType() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
getCommandType() - Method in interface akka.remote.RemoteProtocol.RemoteControlProtocolOrBuilder
 
getConfig() - Method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
getConfig() - Method in class akka.remote.RemoteProtocol.DeployProtocol
 
getConfig() - Method in interface akka.remote.RemoteProtocol.DeployProtocolOrBuilder
 
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.
getCookie() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
getCookie() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
getCookie() - Method in interface akka.remote.RemoteProtocol.RemoteControlProtocolOrBuilder
 
getCreator() - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
getCreator() - Method in class akka.remote.RemoteProtocol.PropsProtocol
 
getCreator() - Method in interface akka.remote.RemoteProtocol.PropsProtocolOrBuilder
 
getDefaultAddress() - Method in interface akka.actor.ActorRefProvider
Obtain the external address of the default transport.
getDefaultAddress() - Method in class akka.actor.LocalActorRefProvider
 
getDefaultAddress() - Method in class akka.remote.RemoteActorRefProvider
 
getDefaultInstance() - Static method in class akka.remote.RemoteProtocol.ActorRefProtocol
 
getDefaultInstance() - Static method in class akka.remote.RemoteProtocol.AddressProtocol
 
getDefaultInstance() - Static method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
getDefaultInstance() - Static method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
getDefaultInstance() - Static method in class akka.remote.RemoteProtocol.DeployProtocol
 
getDefaultInstance() - Static method in class akka.remote.RemoteProtocol.MessageProtocol
 
getDefaultInstance() - Static method in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
getDefaultInstance() - Static method in class akka.remote.RemoteProtocol.PropsProtocol
 
getDefaultInstance() - Static method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
getDefaultInstance() - Static method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
getDefaultInstanceForType() - Method in class akka.remote.RemoteProtocol.ActorRefProtocol.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.RemoteProtocol.ActorRefProtocol
 
getDefaultInstanceForType() - Method in class akka.remote.RemoteProtocol.AddressProtocol.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.RemoteProtocol.AddressProtocol
 
getDefaultInstanceForType() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
getDefaultInstanceForType() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
getDefaultInstanceForType() - Method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.RemoteProtocol.DeployProtocol
 
getDefaultInstanceForType() - Method in class akka.remote.RemoteProtocol.MessageProtocol.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.RemoteProtocol.MessageProtocol
 
getDefaultInstanceForType() - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
getDefaultInstanceForType() - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.RemoteProtocol.PropsProtocol
 
getDefaultInstanceForType() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
getDefaultInstanceForType() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
getDefaultInstanceForType() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
getDeploy() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
getDeploy() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
getDeploy() - Method in interface akka.remote.RemoteProtocol.DaemonMsgCreateProtocolOrBuilder
 
getDeploy() - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
getDeploy() - Method in class akka.remote.RemoteProtocol.PropsProtocol
 
getDeploy() - Method in interface akka.remote.RemoteProtocol.PropsProtocolOrBuilder
 
getDeployBuilder() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
getDeployBuilder() - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
getDeployOrBuilder() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
getDeployOrBuilder() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
getDeployOrBuilder() - Method in interface akka.remote.RemoteProtocol.DaemonMsgCreateProtocolOrBuilder
 
getDeployOrBuilder() - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
getDeployOrBuilder() - Method in class akka.remote.RemoteProtocol.PropsProtocol
 
getDeployOrBuilder() - Method in interface akka.remote.RemoteProtocol.PropsProtocolOrBuilder
 
getDescriptor() - Static method in class akka.remote.RemoteProtocol.ActorRefProtocol.Builder
 
getDescriptor() - Static method in class akka.remote.RemoteProtocol.ActorRefProtocol
 
getDescriptor() - Static method in class akka.remote.RemoteProtocol.AddressProtocol.Builder
 
getDescriptor() - Static method in class akka.remote.RemoteProtocol.AddressProtocol
 
getDescriptor() - Static method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
getDescriptor() - Static method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
getDescriptor() - Static method in enum akka.remote.RemoteProtocol.CommandType
 
getDescriptor() - Static method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
getDescriptor() - Static method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
getDescriptor() - Static method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
getDescriptor() - Static method in class akka.remote.RemoteProtocol.DeployProtocol
 
getDescriptor() - Static method in class akka.remote.RemoteProtocol
 
getDescriptor() - Static method in class akka.remote.RemoteProtocol.MessageProtocol.Builder
 
getDescriptor() - Static method in class akka.remote.RemoteProtocol.MessageProtocol
 
getDescriptor() - Static method in class akka.remote.RemoteProtocol.MetadataEntryProtocol.Builder
 
getDescriptor() - Static method in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
getDescriptor() - Static method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
getDescriptor() - Static method in class akka.remote.RemoteProtocol.PropsProtocol
 
getDescriptor() - Static method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
getDescriptor() - Static method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
getDescriptor() - Static method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
getDescriptor() - Static method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
getDescriptorForType() - Method in class akka.remote.RemoteProtocol.ActorRefProtocol.Builder
 
getDescriptorForType() - Method in class akka.remote.RemoteProtocol.AddressProtocol.Builder
 
getDescriptorForType() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
getDescriptorForType() - Method in enum akka.remote.RemoteProtocol.CommandType
 
getDescriptorForType() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
getDescriptorForType() - Method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
getDescriptorForType() - Method in class akka.remote.RemoteProtocol.MessageProtocol.Builder
 
getDescriptorForType() - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol.Builder
 
getDescriptorForType() - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
getDescriptorForType() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
getDescriptorForType() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
getDispatcher() - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
getDispatcher() - Method in class akka.remote.RemoteProtocol.PropsProtocol
 
getDispatcher() - Method in interface akka.remote.RemoteProtocol.PropsProtocolOrBuilder
 
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.
getEndpointUri() - Method in class akka.camel.javaapi.UntypedConsumerActor
Java API: Returns the Camel endpoint URI to consume messages from.
getEndpointUri() - Method in class akka.camel.javaapi.UntypedProducerActor
Returns the Camel endpoint URI to produce messages to.
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).
getExternalAddressFor(Address) - Method in class akka.actor.LocalActorRefProvider
 
getExternalAddressFor(Address) - Method in class akka.remote.RemoteActorRefProvider
 
getFeatureInfo(MBeanFeatureInfo[], String) - Method in class akka.jmx.Client
 
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
 
getFromClassCreator() - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
getFromClassCreator() - Method in class akka.remote.RemoteProtocol.PropsProtocol
 
getFromClassCreator() - Method in interface akka.remote.RemoteProtocol.PropsProtocolOrBuilder
 
getHeaderAs(String, Class<T>, org.apache.camel.CamelContext) - Method in class akka.camel.CamelMessage
Java API: Returns the header by given name parameter.
getHeaders(Set<String>) - Method in class akka.camel.CamelMessage
Java API: Returns those headers from this message whose name is contained in names.
getHeaders() - Method in class akka.camel.CamelMessage
Java API: Returns all headers from this message.
getHostname() - Method in class akka.remote.RemoteProtocol.AddressProtocol.Builder
 
getHostname() - Method in class akka.remote.RemoteProtocol.AddressProtocol
 
getHostname() - Method in interface akka.remote.RemoteProtocol.AddressProtocolOrBuilder
 
getInstance() - Method in class akka.actor.Kill$
Java API: get the singleton instance
getInstance() - Static method in class akka.actor.Kill
Java API: get the singleton instance
getInstance() - Method in class akka.actor.LocalScope$
Java API: get the singleton instance
getInstance() - Static method in class akka.actor.LocalScope
Java API: get the singleton instance
getInstance() - Method in class akka.actor.NoScopeGiven$
Java API: get the singleton instance
getInstance() - Static method in class akka.actor.NoScopeGiven
Java API: get the singleton instance
getInstance() - Method in class akka.actor.PoisonPill$
Java API: get the singleton instance
getInstance() - Static method in class akka.actor.PoisonPill
Java API: get the singleton instance
getInstance() - Method in class akka.actor.ReceiveTimeout$
Java API: get the singleton instance
getInstance() - Static method in class akka.actor.ReceiveTimeout
Java API: get the singleton instance
getInstance() - Method in class akka.camel.Ack$
Java API to get the Ack singleton
getInstance() - Static method in class akka.camel.Ack
Java API to get the Ack singleton
getInstance() - Method in class akka.cluster.ClusterScope$
Java API: get the singleton instance
getInstance() - Static method in class akka.cluster.ClusterScope
Java API: get the singleton instance
getInstance() - Method in class akka.cluster.routing.CpuMetricsSelector$
Java API: get the singleton instance
getInstance() - Static method in class akka.cluster.routing.CpuMetricsSelector
Java API: get the singleton instance
getInstance() - Method in class akka.cluster.routing.HeapMetricsSelector$
Java API: get the singleton instance
getInstance() - Static method in class akka.cluster.routing.HeapMetricsSelector
Java API: get the singleton instance
getInstance() - Method in class akka.cluster.routing.MixMetricsSelector$
Java API: get the default singleton instance
getInstance() - Static method in class akka.cluster.routing.MixMetricsSelector
Java API: get the default singleton instance
getInstance() - Method in class akka.cluster.routing.SystemLoadAverageMetricsSelector$
Java API: get the singleton instance
getInstance() - Static method in class akka.cluster.routing.SystemLoadAverageMetricsSelector
Java API: get the singleton instance
getInstance() - Method in class akka.event.Logging.LoggerInitialized$
Java API: get the singleton instance
getInstance() - Method in class akka.event.NoLogging$
Java API to return the reference to NoLogging
getInstance() - Static method in class akka.event.NoLogging
Java API to return the reference to NoLogging
getInstance() - Method in class akka.remote.security.provider.InternetSeedGenerator$
 
getInstance() - Static method in class akka.remote.security.provider.InternetSeedGenerator
 
getInstance() - Method in class akka.routing.CurrentRoutees$
Java API: get the singleton instance
getInstance() - Static method in class akka.routing.CurrentRoutees
Java API: get the singleton instance
getInstance() - Method in class akka.routing.FromConfig$
Java API: get the singleton instance
getInstance() - Static method in class akka.routing.FromConfig
Java API: get the singleton instance
getInstance() - Method in class akka.routing.NoRouter$
Java API: get the singleton instance
getInstance() - Static method in class akka.routing.NoRouter
Java API: get the singleton instance
getInstance() - Method in class akka.zeromq.Closed$
Java API: get the singleton instance
getInstance() - Static method in class akka.zeromq.Closed
Java API: get the singleton instance
getInstance() - Method in class akka.zeromq.Connecting$
Java API: get the singleton instance
getInstance() - Static method in class akka.zeromq.Connecting
Java API: get the singleton instance
getInstruction() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
getInstruction() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
getInstruction() - Method in interface akka.remote.RemoteProtocol.AkkaRemoteProtocolOrBuilder
 
getInstructionBuilder() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
getInstructionOrBuilder() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
getInstructionOrBuilder() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
getInstructionOrBuilder() - Method in interface akka.remote.RemoteProtocol.AkkaRemoteProtocolOrBuilder
 
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
 
getJMXConnector(String, String, String) - Method in class akka.jmx.Client
 
getKey() - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol.Builder
 
getKey() - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
getKey() - Method in interface akka.remote.RemoteProtocol.MetadataEntryProtocolOrBuilder
 
getLastSender() - Method in class akka.testkit.JavaTestKit
 
getLeader() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
Java API: get address of current leader, or null if none
getLeader() - Method in class akka.cluster.ClusterEvent.LeaderChanged
Java API
getLeader() - Method in interface akka.cluster.ClusterNodeMBean
Get the address of the current leader.
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.
getLong(ByteOrder) - Method in class akka.util.ByteIterator
Get a single Long from this iterator.
getLongs(long[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.ByteArrayIterator
 
getLongs(long[], ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Longs from this iterator.
getLongs(long[], int, int, ByteOrder) - Method in class akka.util.ByteIterator
Get a number of Longs from this iterator.
getLongs(long[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
getManagedClasses() - Method in class akka.osgi.aries.blueprint.NamespaceHandler
 
getMembers() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
Java API: get current member list.
getMembers() - Method in class akka.cluster.ClusterEvent.InstantClusterState
Java API: get current member list
getMembers() - Method in interface akka.cluster.ClusterNodeMBean
Comma separated addresses of member nodes, sorted in the cluster ring order.
getMemberStatus() - Method in interface akka.cluster.ClusterNodeMBean
Member status for this node.
getMessage() - Method in class akka.actor.UnhandledMessage
 
getMessage() - Method in exception akka.camel.ActorNotRegisteredException
 
getMessage() - Method in class akka.event.Logging.LogEventException
 
getMessage() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
getMessage() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
getMessage() - Method in interface akka.remote.RemoteProtocol.AkkaRemoteProtocolOrBuilder
 
getMessage() - Method in class akka.remote.RemoteProtocol.MessageProtocol.Builder
 
getMessage() - Method in class akka.remote.RemoteProtocol.MessageProtocol
 
getMessage() - Method in interface akka.remote.RemoteProtocol.MessageProtocolOrBuilder
 
getMessage() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
getMessage() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
getMessage() - Method in interface akka.remote.RemoteProtocol.RemoteMessageProtocolOrBuilder
 
getMessage() - Method in class akka.transactor.Coordinated
Java API: get the message for this Coordinated.
getMessageBuilder() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
getMessageBuilder() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
getMessageManifest() - Method in class akka.remote.RemoteProtocol.MessageProtocol.Builder
 
getMessageManifest() - Method in class akka.remote.RemoteProtocol.MessageProtocol
 
getMessageManifest() - Method in interface akka.remote.RemoteProtocol.MessageProtocolOrBuilder
 
getMessageOrBuilder() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
getMessageOrBuilder() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
getMessageOrBuilder() - Method in interface akka.remote.RemoteProtocol.AkkaRemoteProtocolOrBuilder
 
getMessageOrBuilder() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
getMessageOrBuilder() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
getMessageOrBuilder() - Method in interface akka.remote.RemoteProtocol.RemoteMessageProtocolOrBuilder
 
getMetadata(int) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
getMetadata(int) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
getMetadata(int) - Method in interface akka.remote.RemoteProtocol.RemoteMessageProtocolOrBuilder
 
getMetadataBuilder(int) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
getMetadataBuilderList() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
getMetadataCount() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
getMetadataCount() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
getMetadataCount() - Method in interface akka.remote.RemoteProtocol.RemoteMessageProtocolOrBuilder
 
getMetadataList() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
getMetadataList() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
getMetadataList() - Method in interface akka.remote.RemoteProtocol.RemoteMessageProtocolOrBuilder
 
getMetadataOrBuilder(int) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
getMetadataOrBuilder(int) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
getMetadataOrBuilder(int) - Method in interface akka.remote.RemoteProtocol.RemoteMessageProtocolOrBuilder
 
getMetadataOrBuilderList() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
getMetadataOrBuilderList() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
getMetadataOrBuilderList() - Method in interface akka.remote.RemoteProtocol.RemoteMessageProtocolOrBuilder
 
getMetrics() - Method in class akka.cluster.NodeMetrics
Java API
getNextLeaderChanged() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
getNodeMetrics() - Method in class akka.cluster.ClusterEvent.ClusterMetricsChanged
Java API
getNumber() - Method in enum akka.remote.RemoteProtocol.CommandType
 
getObjectFor(String, ClassTag<T>) - Method in class akka.actor.DynamicAccess
Obtain the Scala “object” instance for the given fully-qualified class name, if there is one.
getObjectFor(String, ClassTag<T>) - Method in class akka.actor.ReflectiveDynamicAccess
 
getObjectName(String) - Method in class akka.jmx.Client
 
getOrigin() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
getOrigin() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
getOrigin() - Method in interface akka.remote.RemoteProtocol.RemoteControlProtocolOrBuilder
 
getOriginBuilder() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
getOriginOrBuilder() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
getOriginOrBuilder() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
getOriginOrBuilder() - Method in interface akka.remote.RemoteProtocol.RemoteControlProtocolOrBuilder
 
getPath() - Method in class akka.remote.RemoteProtocol.ActorRefProtocol.Builder
 
getPath() - Method in class akka.remote.RemoteProtocol.ActorRefProtocol
 
getPath() - Method in interface akka.remote.RemoteProtocol.ActorRefProtocolOrBuilder
 
getPath() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
getPath() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
getPath() - Method in interface akka.remote.RemoteProtocol.DaemonMsgCreateProtocolOrBuilder
 
getPath() - Method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
getPath() - Method in class akka.remote.RemoteProtocol.DeployProtocol
 
getPath() - Method in interface akka.remote.RemoteProtocol.DeployProtocolOrBuilder
 
getPort() - Method in class akka.remote.RemoteProtocol.AddressProtocol.Builder
 
getPort() - Method in class akka.remote.RemoteProtocol.AddressProtocol
 
getPort() - Method in interface akka.remote.RemoteProtocol.AddressProtocolOrBuilder
 
getProducerTemplate() - Method in class akka.camel.javaapi.UntypedConsumerActor
Java API: Returns the org.apache.camel.ProducerTemplate
getProducerTemplate() - Method in class akka.camel.javaapi.UntypedProducerActor
Returns the ProducerTemplate.
getProps() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
getProps() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
getProps() - Method in interface akka.remote.RemoteProtocol.DaemonMsgCreateProtocolOrBuilder
 
getPropsBuilder() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
getPropsOrBuilder() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
getPropsOrBuilder() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
getPropsOrBuilder() - Method in interface akka.remote.RemoteProtocol.DaemonMsgCreateProtocolOrBuilder
 
getRawResult() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.MailboxExecutionTask
 
getRecipient() - Method in class akka.actor.UnhandledMessage
 
getRecipient() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
getRecipient() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
getRecipient() - Method in interface akka.remote.RemoteProtocol.RemoteMessageProtocolOrBuilder
 
getRecipientBuilder() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
getRecipientOrBuilder() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
getRecipientOrBuilder() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
getRecipientOrBuilder() - Method in interface akka.remote.RemoteProtocol.RemoteMessageProtocolOrBuilder
 
getRef() - Method in class akka.testkit.JavaTestKit
 
getRemainingTime() - Method in class akka.testkit.JavaTestKit
 
getRemainingTimeOr(FiniteDuration) - Method in class akka.testkit.JavaTestKit
 
getRemote() - Method in class akka.remote.RemoteClientConnected
 
getRemote() - Method in class akka.remote.RemoteClientDisconnected
 
getRemote() - Method in class akka.remote.RemoteClientShutdown
 
getRemote() - Method in class akka.remote.RemoteClientStarted
 
getRemote() - Method in class akka.remote.RemoteServerClientClosed
 
getRemote() - Method in class akka.remote.RemoteServerClientConnected
 
getRemote() - Method in class akka.remote.RemoteServerClientDisconnected
 
getRemote() - Method in class akka.remote.RemoteServerError
 
getRemote() - Method in class akka.remote.RemoteServerShutdown
 
getRemote() - Method in class akka.remote.RemoteServerStarted
 
getRemoteAddress() - Method in interface akka.remote.RemoteClientLifeCycleEvent
 
getRouteDefinitionHandler() - Method in interface akka.camel.Consumer
Java API: Returns the Mapper function that will be used as a route definition handler for creating custom route to this consumer.
getRoutees() - Method in class akka.routing.RouteeProvider
Java API: All routees of the router
getRouterConfig() - Method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
getRouterConfig() - Method in class akka.remote.RemoteProtocol.DeployProtocol
 
getRouterConfig() - Method in interface akka.remote.RemoteProtocol.DeployProtocolOrBuilder
 
getRouterConfig() - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
getRouterConfig() - Method in class akka.remote.RemoteProtocol.PropsProtocol
 
getRouterConfig() - Method in interface akka.remote.RemoteProtocol.PropsProtocolOrBuilder
 
getSchemaLocation(String) - Method in class akka.osgi.aries.blueprint.NamespaceHandler
 
getScope() - Method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
getScope() - Method in class akka.remote.RemoteProtocol.DeployProtocol
 
getScope() - Method in interface akka.remote.RemoteProtocol.DeployProtocolOrBuilder
 
getSeenBy() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
Java API: get current “seen-by” set.
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.
getSender() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
getSender() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
getSender() - Method in interface akka.remote.RemoteProtocol.RemoteMessageProtocolOrBuilder
 
getSenderBuilder() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
getSenderOrBuilder() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
getSenderOrBuilder() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
getSenderOrBuilder() - Method in interface akka.remote.RemoteProtocol.RemoteMessageProtocolOrBuilder
 
getSerializedSize() - Method in class akka.remote.RemoteProtocol.ActorRefProtocol
 
getSerializedSize() - Method in class akka.remote.RemoteProtocol.AddressProtocol
 
getSerializedSize() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
getSerializedSize() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
getSerializedSize() - Method in class akka.remote.RemoteProtocol.DeployProtocol
 
getSerializedSize() - Method in class akka.remote.RemoteProtocol.MessageProtocol
 
getSerializedSize() - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
getSerializedSize() - Method in class akka.remote.RemoteProtocol.PropsProtocol
 
getSerializedSize() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
getSerializedSize() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
getSerializerId() - Method in class akka.remote.RemoteProtocol.MessageProtocol.Builder
 
getSerializerId() - Method in class akka.remote.RemoteProtocol.MessageProtocol
 
getSerializerId() - Method in interface akka.remote.RemoteProtocol.MessageProtocolOrBuilder
 
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
 
getSupervisor() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
getSupervisor() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
getSupervisor() - Method in interface akka.remote.RemoteProtocol.DaemonMsgCreateProtocolOrBuilder
 
getSupervisorBuilder() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
getSupervisorOrBuilder() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
getSupervisorOrBuilder() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
getSupervisorOrBuilder() - Method in interface akka.remote.RemoteProtocol.DaemonMsgCreateProtocolOrBuilder
 
getSystem() - Method in class akka.remote.RemoteProtocol.AddressProtocol.Builder
 
getSystem() - Method in class akka.remote.RemoteProtocol.AddressProtocol
 
getSystem() - Method in interface akka.remote.RemoteProtocol.AddressProtocolOrBuilder
 
getSystem() - Method in class akka.testkit.JavaTestKit
 
getTask() - Method in interface akka.util.internal.Timeout
Returns the TimerTask which is associated with this handle.
getTimer() - Method in interface akka.util.internal.Timeout
Returns the Timer that created this handle.
getToArray(Object, int, int, int, Function0<A>, Function3<Object, Object, Object, BoxedUnit>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
getUnreachable() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
Java API: get current unreachable set.
getUnreachable() - Method in interface akka.cluster.ClusterNodeMBean
Comma separated addresses of unreachable member nodes.
getValue() - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol.Builder
 
getValue() - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
getValue() - Method in interface akka.remote.RemoteProtocol.MetadataEntryProtocolOrBuilder
 
getValueDescriptor() - Method in enum akka.remote.RemoteProtocol.CommandType
 
GIGABYTE() - Method in class akka.actor.mailbox.filebased.filequeue.tools.Util$
 
GIGABYTE() - Static method in class akka.actor.mailbox.filebased.filequeue.tools.Util
 
global() - Method in class akka.dispatch.ExecutionContexts$
 
global() - Static method in class akka.dispatch.ExecutionContexts
 
GlobalHome() - Method in class akka.actor.ActorSystem$
 
GlobalHome() - Static method in class akka.actor.ActorSystem
 
gossip(Object, ActorRef) - Method in interface akka.routing.Listeners
Sends the supplied message to all current listeners using the provided sender as sender.
GossipDifferentViewProbability() - Method in class akka.cluster.ClusterSettings
 
GossipInterval() - Method in class akka.cluster.ClusterSettings
 
gotoHandingOver(ActorRef, boolean, Option<Object>, Option<ActorRef>) - Method in class akka.contrib.pattern.ClusterSingletonManager
 
gotoLeader(Option<Object>) - Method in class akka.contrib.pattern.ClusterSingletonManager
 
gracefulStop(ActorRef, FiniteDuration, ActorSystem) - 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, ActorSystem) - 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, ActorSystem) - 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(...).
guardian() - Method in class akka.actor.LocalActorRefProvider
 
guardian() - Method in class akka.remote.RemoteActorRefProvider
 
guardianStrategy() - Method in class akka.actor.LocalActorRefProvider
Overridable supervision strategy to be used by the “/user” guardian.

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.
handleTransition(S, S) - Method in interface akka.actor.FSM
 
handOverDone(Option<ActorRef>, Option<Object>) - Method in class akka.contrib.pattern.ClusterSingletonManager
 
hasCommandType() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
hasCommandType() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
hasCommandType() - Method in interface akka.remote.RemoteProtocol.RemoteControlProtocolOrBuilder
 
hasConfig() - Method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
hasConfig() - Method in class akka.remote.RemoteProtocol.DeployProtocol
 
hasConfig() - Method in interface akka.remote.RemoteProtocol.DeployProtocolOrBuilder
 
hasCookie() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
hasCookie() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
hasCookie() - Method in interface akka.remote.RemoteProtocol.RemoteControlProtocolOrBuilder
 
hasCreator() - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
hasCreator() - Method in class akka.remote.RemoteProtocol.PropsProtocol
 
hasCreator() - Method in interface akka.remote.RemoteProtocol.PropsProtocolOrBuilder
 
hasDeploy() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
hasDeploy() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
hasDeploy() - Method in interface akka.remote.RemoteProtocol.DaemonMsgCreateProtocolOrBuilder
 
hasDeploy() - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
hasDeploy() - Method in class akka.remote.RemoteProtocol.PropsProtocol
 
hasDeploy() - Method in interface akka.remote.RemoteProtocol.PropsProtocolOrBuilder
 
hasDispatcher() - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
hasDispatcher() - Method in class akka.remote.RemoteProtocol.PropsProtocol
 
hasDispatcher() - Method in interface akka.remote.RemoteProtocol.PropsProtocolOrBuilder
 
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
hasFromClassCreator() - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
hasFromClassCreator() - Method in class akka.remote.RemoteProtocol.PropsProtocol
 
hasFromClassCreator() - Method in interface akka.remote.RemoteProtocol.PropsProtocolOrBuilder
 
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.ChildActorPath
 
hashCode() - Method in interface akka.actor.IO.Handle
 
hashCode() - Method in class akka.cluster.Member
 
hashCode() - Method in class akka.cluster.Metric
 
hashCode() - Method in class akka.cluster.NodeMetrics
 
HashCode - Class in akka.util
Set of methods which allow easy implementation of hashCode.
HashCode() - Constructor for class akka.util.HashCode
 
HashCode$ - Class in akka.util
Set of methods which allow easy implementation of hashCode.
HashCode$() - Constructor for class akka.util.HashCode$
 
HashedWheelTimer - Class in akka.util.internal
A Timer optimized for approximated I/O timeout scheduling.
HashedWheelTimer(LoggingAdapter, ThreadFactory, Duration, int) - Constructor for class akka.util.internal.HashedWheelTimer
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
 
hasHostname() - Method in class akka.remote.RemoteProtocol.AddressProtocol.Builder
 
hasHostname() - Method in class akka.remote.RemoteProtocol.AddressProtocol
 
hasHostname() - Method in interface akka.remote.RemoteProtocol.AddressProtocolOrBuilder
 
hasInstruction() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
hasInstruction() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
hasInstruction() - Method in interface akka.remote.RemoteProtocol.AkkaRemoteProtocolOrBuilder
 
hasKey() - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol.Builder
 
hasKey() - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
hasKey() - Method in interface akka.remote.RemoteProtocol.MetadataEntryProtocolOrBuilder
 
hasMessage() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
hasMessage() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
hasMessage() - Method in interface akka.remote.RemoteProtocol.AkkaRemoteProtocolOrBuilder
 
hasMessage() - Method in class akka.remote.RemoteProtocol.MessageProtocol.Builder
 
hasMessage() - Method in class akka.remote.RemoteProtocol.MessageProtocol
 
hasMessage() - Method in interface akka.remote.RemoteProtocol.MessageProtocolOrBuilder
 
hasMessage() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
hasMessage() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
hasMessage() - Method in interface akka.remote.RemoteProtocol.RemoteMessageProtocolOrBuilder
 
hasMessageManifest() - Method in class akka.remote.RemoteProtocol.MessageProtocol.Builder
 
hasMessageManifest() - Method in class akka.remote.RemoteProtocol.MessageProtocol
 
hasMessageManifest() - Method in interface akka.remote.RemoteProtocol.MessageProtocolOrBuilder
 
hasMessages() - Method in class akka.actor.mailbox.filebased.FileBasedMessageQueue
 
hasMessages() - Method in interface akka.dispatch.MessageQueue
Indicates whether this queue is non-empty.
hasMessages() - Method in 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.
hasMessages() - Method in class akka.testkit.CallingThreadMailbox
 
hasNext() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
hasNext() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
hasOrigin() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
hasOrigin() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
hasOrigin() - Method in interface akka.remote.RemoteProtocol.RemoteControlProtocolOrBuilder
 
hasPath() - Method in class akka.remote.RemoteProtocol.ActorRefProtocol.Builder
 
hasPath() - Method in class akka.remote.RemoteProtocol.ActorRefProtocol
 
hasPath() - Method in interface akka.remote.RemoteProtocol.ActorRefProtocolOrBuilder
 
hasPath() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
hasPath() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
hasPath() - Method in interface akka.remote.RemoteProtocol.DaemonMsgCreateProtocolOrBuilder
 
hasPath() - Method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
hasPath() - Method in class akka.remote.RemoteProtocol.DeployProtocol
 
hasPath() - Method in interface akka.remote.RemoteProtocol.DeployProtocolOrBuilder
 
hasPort() - Method in class akka.remote.RemoteProtocol.AddressProtocol.Builder
 
hasPort() - Method in class akka.remote.RemoteProtocol.AddressProtocol
 
hasPort() - Method in interface akka.remote.RemoteProtocol.AddressProtocolOrBuilder
 
hasProps() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
hasProps() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
hasProps() - Method in interface akka.remote.RemoteProtocol.DaemonMsgCreateProtocolOrBuilder
 
hasRecipient() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
hasRecipient() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
hasRecipient() - Method in interface akka.remote.RemoteProtocol.RemoteMessageProtocolOrBuilder
 
hasRouterConfig() - Method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
hasRouterConfig() - Method in class akka.remote.RemoteProtocol.DeployProtocol
 
hasRouterConfig() - Method in interface akka.remote.RemoteProtocol.DeployProtocolOrBuilder
 
hasRouterConfig() - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
hasRouterConfig() - Method in class akka.remote.RemoteProtocol.PropsProtocol
 
hasRouterConfig() - Method in interface akka.remote.RemoteProtocol.PropsProtocolOrBuilder
 
hasScope() - Method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
hasScope() - Method in class akka.remote.RemoteProtocol.DeployProtocol
 
hasScope() - Method in interface akka.remote.RemoteProtocol.DeployProtocolOrBuilder
 
hasSender() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
hasSender() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
hasSender() - Method in interface akka.remote.RemoteProtocol.RemoteMessageProtocolOrBuilder
 
hasSerializerId() - Method in class akka.remote.RemoteProtocol.MessageProtocol.Builder
 
hasSerializerId() - Method in class akka.remote.RemoteProtocol.MessageProtocol
 
hasSerializerId() - Method in interface akka.remote.RemoteProtocol.MessageProtocolOrBuilder
 
hasSupervisor() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
hasSupervisor() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
hasSupervisor() - Method in interface akka.remote.RemoteProtocol.DaemonMsgCreateProtocolOrBuilder
 
hasSystem() - Method in class akka.remote.RemoteProtocol.AddressProtocol.Builder
 
hasSystem() - Method in class akka.remote.RemoteProtocol.AddressProtocol
 
hasSystem() - Method in interface akka.remote.RemoteProtocol.AddressProtocolOrBuilder
 
hasValue() - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol.Builder
 
hasValue() - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
hasValue() - Method in interface akka.remote.RemoteProtocol.MetadataEntryProtocolOrBuilder
 
head() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
head() - Method in class akka.util.ByteIterator
 
head() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
head() - Method in class akka.util.ByteString
 
headerAs(String, ClassTag<T>, org.apache.camel.CamelContext) - Method in class akka.camel.CamelMessage
Returns the header by given name parameter in a Try.
headers() - Method in exception akka.camel.AkkaCamelException
 
headers() - Method in class akka.camel.CamelMessage
 
headers(Set<String>) - Method in class akka.camel.CamelMessage
Returns those headers from this message whose name is contained in names.
headersToCopy() - Method in interface akka.camel.ProducerSupport
Returns the names of message headers to copy from a request message to a response message.
headersToCopyDefault() - Method in interface akka.camel.ProducerSupport
CamelMessage headers to copy by default from request message to response-message.
heapCommitted(MemoryUsage) - Method in class akka.cluster.JmxMetricsCollector
(JMX) Returns the current sum of heap memory guaranteed to be available to the JVM from all heap memory pools (in bytes).
heapMax(MemoryUsage) - Method in class akka.cluster.JmxMetricsCollector
(JMX) Returns the maximum amount of memory (in bytes) that can be used for JVM memory management.
HeapMemoryCommitted() - Method in class akka.cluster.StandardMetrics$
 
HeapMemoryCommitted() - Static method in class akka.cluster.StandardMetrics
 
HeapMemoryMax() - Method in class akka.cluster.StandardMetrics$
 
HeapMemoryMax() - Static method in class akka.cluster.StandardMetrics
 
heapMemoryUsage() - Method in class akka.cluster.JmxMetricsCollector
Current heap to be passed in to heapUsed, heapCommitted and heapMax
HeapMemoryUsed() - Method in class akka.cluster.StandardMetrics$
 
HeapMemoryUsed() - Static method in class akka.cluster.StandardMetrics
 
HeapMetricsSelector - Class in akka.cluster.routing
MetricsSelector that uses the heap metrics.
HeapMetricsSelector() - Constructor for class akka.cluster.routing.HeapMetricsSelector
 
HeapMetricsSelector$ - Class in akka.cluster.routing
MetricsSelector that uses the heap metrics.
HeapMetricsSelector$() - Constructor for class akka.cluster.routing.HeapMetricsSelector$
 
heapUsed(MemoryUsage) - Method in class akka.cluster.JmxMetricsCollector
(JMX) Returns the current sum of heap memory used from all heap memory pools (in bytes).
heartbeat(Address) - Method in class akka.cluster.AccrualFailureDetector
Records a heartbeat for a connection.
heartbeat(Address) - Method in interface akka.cluster.FailureDetector
Records a heartbeat for a connection.
HEARTBEAT_VALUE - Static variable in enum akka.remote.RemoteProtocol.CommandType
 
HeartbeatExpectedResponseAfter() - Method in class akka.cluster.ClusterSettings
 
HeartbeatInterval() - Method in class akka.cluster.ClusterSettings
 
HeartbeatRequestDelay() - Method in class akka.cluster.ClusterSettings
 
HeartbeatRequestTimeToLive() - Method in class akka.cluster.ClusterSettings
 
Helpers - Class in akka.util
 
Helpers() - Constructor for class akka.util.Helpers
 
Helpers$ - Class in akka.util
 
Helpers$() - Constructor for class akka.util.Helpers$
 
hex() - Method in class akka.util.Crypt$
 
hex() - Static method in class akka.util.Crypt
 
hexify(byte[]) - Method in class akka.util.Crypt$
 
hexify(byte[]) - Static method in class akka.util.Crypt
 
highestPriorityOf(Member, Member) - Method in class akka.cluster.Member$
Picks the Member with the highest "priority" MemberStatus.
highestPriorityOf(Member, Member) - Static method in class akka.cluster.Member
Picks the Member with the highest "priority" MemberStatus.
HighWatermark - Class in akka.zeromq
The HighWatermark option shall set the high water mark for the specified socket.
HighWatermark(long) - Constructor for class akka.zeromq.HighWatermark
 
HighWatermark$ - Class in akka.zeromq
 
HighWatermark$() - Constructor for class akka.zeromq.HighWatermark$
 
Home() - Method in class akka.actor.ActorSystem.Settings
 
host() - Method in class akka.actor.Address
 
HOSTNAME_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.AddressProtocol
 
hostPort() - Method in class akka.actor.Address
Returns a String representation formatted as: @:

I

i() - Method in class akka.testkit.TestActor.SetIgnore
 
id() - Method in class akka.dispatch.Dispatcher
 
id() - Method in class akka.dispatch.MessageDispatcher
Identifier of this dispatcher, corresponds to the full key of the dispatcher configuration.
Id() - Method in class akka.testkit.CallingThreadDispatcher$
 
Id() - Static method in class akka.testkit.CallingThreadDispatcher
 
id() - Method in class akka.testkit.CallingThreadDispatcher
 
id() - Method in class akka.zeromq.SocketType.ZMQSocketType
 
idCounter() - Method in class akka.osgi.aries.blueprint.NamespaceHandler
 
identifier() - Method in class akka.remote.serialization.ProtobufSerializer
 
identifier() - Method in class akka.serialization.ByteArraySerializer
 
identifier() - Method in class akka.serialization.JavaSerializer
 
identifier() - Method in class akka.serialization.NullSerializer
 
identifier() - Method in interface akka.serialization.Serializer
Completely unique value to identify this implementation of Serializer, used to optimize network traffic Values from 0 to 16 is reserved for Akka internal usage
Identity - Class in akka.zeromq
Sets the identity of the specified socket.
Identity(byte[]) - Constructor for class akka.zeromq.Identity
 
identity() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its identity configuration.
identity() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its identity configuration.
Identity$ - Class in akka.zeromq
Gets the Identity value
Identity$() - Constructor for class akka.zeromq.Identity$
 
identityHashComparator(Comparator<T>) - Method in class akka.util.Helpers$
Create a comparator which will efficiently use System.identityHashCode, unless that happens to be the same for two non-equals objects, in which case the supplied “real” comparator is used; the comparator must be consistent with equals, otherwise it would not be an enhancement over the identityHashCode.
identityHashComparator(Comparator<T>) - Static method in class akka.util.Helpers
Create a comparator which will efficiently use System.identityHashCode, unless that happens to be the same for two non-equals objects, in which case the supplied “real” comparator is used; the comparator must be consistent with equals, otherwise it would not be an enhancement over the identityHashCode.
identityRouteMapper() - Method in interface akka.camel.Consumer
 
idle() - Method in class akka.contrib.pattern.ReliableProxy$
 
idle() - Static method in class akka.contrib.pattern.ReliableProxy
 
ifOff(Function0<BoxedUnit>) - Method in class akka.util.Switch
Executes the provided action and returns if the action was executed or not, if the switch is IMMEDIATELY off (i.e. 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)
ignore(Object) - Method in class akka.testkit.JavaTestKit.IgnoreMsg
 
ignore() - Method in class akka.testkit.TestActor
 
ignoreMsg(PartialFunction<Object, Object>) - Method in interface akka.testkit.TestKitBase
Ignore all messages in the test actor for which the given partial function returns true.
ignoreNoMsg() - Method in class akka.testkit.JavaTestKit
 
ignoreNoMsg() - Method in interface akka.testkit.TestKitBase
Stop ignoring messages in the test actor.
IllegalActorStateException - Exception in akka.actor
IllegalActorStateException is thrown when a core invariant in the Actor implementation has been violated.
IllegalActorStateException$ - Class in akka.actor
 
IllegalActorStateException$() - Constructor for class akka.actor.IllegalActorStateException$
 
ImplicitSender - Interface in akka.testkit
 
InaccessibleQueuePath - Exception in akka.actor.mailbox.filebased.filequeue
 
InaccessibleQueuePath() - Constructor for exception akka.actor.mailbox.filebased.filequeue.InaccessibleQueuePath
 
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.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
 
inboxNr() - Method in interface akka.actor.dsl.Inbox.InboxExtension
 
inboxProps() - Method in interface akka.actor.dsl.Inbox.InboxExtension
 
include(Seq<ActorRef>) - Method in interface akka.transactor.Transactor
Include other actors in this coordinated transaction and send them the same message as received.
include(ActorRef) - Method in class akka.transactor.UntypedTransactor
For including one other actor in this coordinated transaction and sending them the same message as received.
include(ActorRef, Object) - Method in class akka.transactor.UntypedTransactor
For including one other actor in this coordinated transaction and specifying the message to send.
includeManifest() - Method in class akka.remote.serialization.ProtobufSerializer
 
includeManifest() - Method in class akka.serialization.ByteArraySerializer
 
includeManifest() - Method in class akka.serialization.JavaSerializer
 
includeManifest() - Method in class akka.serialization.NullSerializer
 
includeManifest() - Method in interface akka.serialization.Serializer
Returns whether this serializer needs a manifest in the fromBinary method
incr() - Method in class akka.actor.mailbox.filebased.filequeue.Counter
 
incr(long) - Method in class akka.actor.mailbox.filebased.filequeue.Counter
 
Index<K,V> - Class in akka.util
An implementation of a ConcurrentMultiMap Adds/remove is serialized over the specified key Reads are fully concurrent <-- el-cheapo
Index(int, Comparator<V>) - Constructor for class akka.util.Index
 
Index(int, Function2<V, V, Object>) - Constructor for class akka.util.Index
 
indexOf(byte) - Method in class akka.util.ByteIterator
 
indexOf(B) - Method in class akka.util.ByteIterator
 
indexOf(B) - Method in class akka.util.ByteString
 
indexWhere(Function1<Object, Object>) - Method in class akka.util.ByteIterator
 
indexWhere(Function1<Object, Object>) - Method in class akka.util.ByteString
 
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
 
info(String, String, String, String, int) - Method in class akka.testkit.EventFilter$
Create a filter for Info events.
info(String, String, String, String, int) - Static method in class akka.testkit.EventFilter
Create a filter for Info events.
InfoFilter - Class in akka.testkit
Filter which matches Info events, if they satisfy the given criteria: source, if given, applies a filter on the event’s origin message applies a filter on the event’s message (either with String.startsWith or Regex.findFirstIn().isDefined) If you want to match all Info events, the most efficient is to use Left("").
InfoFilter(Option<String>, Either<String, Regex>, boolean, int) - Constructor for class akka.testkit.InfoFilter
 
InfoFilter(String, String, boolean, boolean, int) - Constructor for class akka.testkit.InfoFilter
Java API: create an InfoFilter
InfoFilter$ - Class in akka.testkit
 
InfoFilter$() - Constructor for class akka.testkit.InfoFilter$
 
infoFormat() - Method in interface akka.event.Logging.StdOutLogger
 
InfoLevel() - Method in class akka.event.Logging$
 
InfoLevel() - Static method in class akka.event.Logging
 
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, scheduler, etc.
init(ActorSystemImpl) - Method in class akka.actor.LocalActorRefProvider
 
init(akka.actor.ActorSystemImpl) - Method in class akka.cluster.ClusterActorRefProvider
 
init(akka.actor.ActorSystemImpl) - Method in class akka.remote.RemoteActorRefProvider
 
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.
initialize() - Method in interface akka.actor.mailbox.DurableMailboxSettings
Obtain default extracted mailbox config section from userConfig and system.
inReadBehind() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
inReadBehind() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
instance - Static variable in class akka.util.Unsafe
 
INSTRUCTION_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
intercept(Function0<T>, ActorSystem) - Method in class akka.testkit.EventFilter
Apply this filter while executing the given code block.
interfaces() - Method in class akka.actor.TypedProps
 
internal(T) - Method in class akka.dispatch.Foreach
 
internal(T) - Method in class akka.dispatch.japi.BooleanFunctionBridge
 
internal(T) - Method in class akka.dispatch.japi.CallbackBridge
 
internal(Throwable) - Method in class akka.dispatch.japi.RecoverBridge
 
internal(T) - Method in class akka.dispatch.japi.UnitFunctionBridge
 
internal(Try<T>) - Method in class akka.dispatch.OnComplete
 
internal(Throwable) - Method in class akka.dispatch.OnFailure
 
internal(T) - Method in class akka.dispatch.OnSuccess
 
internal(Throwable) - Method in class akka.dispatch.Recover
 
internalExpectMsgAllClassOf(FiniteDuration, Seq<Class<? extends T>>) - Method in interface akka.testkit.TestKitBase
 
internalExpectMsgAllConformingOf(FiniteDuration, Seq<Class<? extends T>>) - Method in interface akka.testkit.TestKitBase
 
internalGetFieldAccessorTable() - Method in class akka.remote.RemoteProtocol.ActorRefProtocol.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.RemoteProtocol.ActorRefProtocol
 
internalGetFieldAccessorTable() - Method in class akka.remote.RemoteProtocol.AddressProtocol.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.RemoteProtocol.AddressProtocol
 
internalGetFieldAccessorTable() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
internalGetFieldAccessorTable() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
internalGetFieldAccessorTable() - Method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.RemoteProtocol.DeployProtocol
 
internalGetFieldAccessorTable() - Method in class akka.remote.RemoteProtocol.MessageProtocol.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.RemoteProtocol.MessageProtocol
 
internalGetFieldAccessorTable() - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
internalGetFieldAccessorTable() - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.RemoteProtocol.PropsProtocol
 
internalGetFieldAccessorTable() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
internalGetFieldAccessorTable() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
internalGetValueMap() - Static method in enum akka.remote.RemoteProtocol.CommandType
 
InternetSeedGenerator - Class in akka.remote.security.provider
 
InternetSeedGenerator() - Constructor for class akka.remote.security.provider.InternetSeedGenerator
 
InternetSeedGenerator$ - Class in akka.remote.security.provider
Internal API Seed generator that maintains multiple strategies for seed generation and will delegate to the best one available for the current operating environment.
InternetSeedGenerator$() - Constructor for class akka.remote.security.provider.InternetSeedGenerator$
 
intToBytes(int) - Method in class akka.util.Convert$
 
intToBytes(int) - Static method in class akka.util.Convert
 
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.actor
IO messages and iteratees.
IO$() - Constructor for class akka.actor.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.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
 
isAvailable(Address) - Method in class akka.cluster.AccrualFailureDetector
 
isAvailable() - Method in interface akka.cluster.ClusterNodeMBean
Returns true if the node is not unreachable and not Down and not Removed.
isAvailable(Address) - Method in interface akka.cluster.FailureDetector
Returns true if the connection is considered to be up and healthy and returns false otherwise.
isBatchable() - Method in class akka.dispatch.TaskInvocation
 
isCancelled() - Method in interface akka.actor.Cancellable
Returns whether this Cancellable has been cancelled Java & Scala API
isCancelled() - Method in interface akka.util.internal.Timeout
Returns true if and only if the TimerTask associated with this handle has been cancelled.
isClosed() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
isCompact() - Method in class akka.util.ByteString.ByteString1
 
isCompact() - Method in class akka.util.ByteString.ByteStrings
 
isCompact() - Method in class akka.util.ByteString
Check whether this ByteString is compact in memory.
isCompact() - Method in class akka.util.CompactByteString
 
isDebugEnabled() - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
isDebugEnabled() - Method in class akka.event.BusLogging
 
isDebugEnabled() - Method in interface akka.event.LoggingAdapter
 
isDebugEnabled() - Method in class akka.event.NoLogging$
 
isDebugEnabled() - Static method in class akka.event.NoLogging
 
isDefined() - Method in class akka.japi.Option
 
isDefinedAt(Object) - Method in class akka.actor.Actor.emptyBehavior$
 
isDefinedAt(Object) - Method in class akka.actor.FSM.NullFunction$
 
isDefinedAt(T) - Method in class akka.dispatch.japi.CallbackBridge
 
isDefinedAt(Throwable) - Method in class akka.dispatch.japi.RecoverBridge
 
isDefinedAt(Object) - Method in class akka.event.LoggingReceive
 
isDefinedAt(A) - Method in class akka.japi.JavaPartialFunction
 
isDefinedAt(Object) - Method in class akka.routing.ConsistentHashingRouter.emptyConsistentHashMapping$
 
isEmpty() - Method in class akka.actor.WriteBuffer
 
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
 
isEmpty() - Method in class akka.util.internal.ConcurrentIdentityHashMap
Returns true if this map contains no key-value mappings.
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.
isErrorEnabled() - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
isErrorEnabled() - Method in class akka.event.BusLogging
 
isErrorEnabled() - Method in interface akka.event.LoggingAdapter
 
isErrorEnabled() - Method in class akka.event.NoLogging$
 
isErrorEnabled() - Static method in class akka.event.NoLogging
 
isExpired() - Method in interface akka.util.internal.Timeout
Returns true if and only if the TimerTask associated with this handle has been expired.
isFeatureInfo(MBeanFeatureInfo[], String) - Method in class akka.jmx.Client
 
isInfoEnabled() - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
isInfoEnabled() - Method in class akka.event.BusLogging
 
isInfoEnabled() - Method in interface akka.event.LoggingAdapter
 
isInfoEnabled() - Method in class akka.event.NoLogging$
 
isInfoEnabled() - Static method in class akka.event.NoLogging
 
isInitialized() - Method in class akka.remote.RemoteProtocol.ActorRefProtocol.Builder
 
isInitialized() - Method in class akka.remote.RemoteProtocol.ActorRefProtocol
 
isInitialized() - Method in class akka.remote.RemoteProtocol.AddressProtocol.Builder
 
isInitialized() - Method in class akka.remote.RemoteProtocol.AddressProtocol
 
isInitialized() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
isInitialized() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
isInitialized() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
isInitialized() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
isInitialized() - Method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
isInitialized() - Method in class akka.remote.RemoteProtocol.DeployProtocol
 
isInitialized() - Method in class akka.remote.RemoteProtocol.MessageProtocol.Builder
 
isInitialized() - Method in class akka.remote.RemoteProtocol.MessageProtocol
 
isInitialized() - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol.Builder
 
isInitialized() - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
isInitialized() - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
isInitialized() - Method in class akka.remote.RemoteProtocol.PropsProtocol
 
isInitialized() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
isInitialized() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
isInitialized() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
isInitialized() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
isMonitoring(Address) - Method in class akka.cluster.AccrualFailureDetector
 
isMonitoring(Address) - Method in interface akka.cluster.FailureDetector
Returns true if the failure detector has received any heartbeats and started monitoring of the resource.
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
 
isOneway() - Method in class akka.camel.javaapi.UntypedProducerActor
If set to false (default), this producer expects a response message from the Camel endpoint.
isOpen() - Method in class akka.testkit.TestLatch
 
isProcessingMessage(ActorRef) - Method in interface akka.routing.SmallestMailboxLike
Returns true if the actor is currently processing a message.
isReplaying() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
isRouteesPathDefined() - Method in class akka.cluster.routing.ClusterRouterSettings
 
isShutdown() - Method in interface akka.dispatch.ExecutorServiceDelegate
 
isSingleton() - Method in interface akka.cluster.ClusterNodeMBean
Does the cluster consist of only one member?
isSmooth() - Method in class akka.cluster.Metric
 
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 class akka.cluster.Cluster
Returns true if this cluster instance has be shutdown.
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.
isTypedActor(Object) - Method in class akka.actor.ContextualTypedActorFactory
 
isTypedActor(Object) - Method in class akka.actor.TypedActorExtension
Returns wether the supplied AnyRef is a TypedActor proxy or not
isTypedActor(Object) - Method in interface akka.actor.TypedActorFactory
Returns wether the supplied AnyRef is a TypedActor proxy or not
isWarningEnabled() - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
isWarningEnabled() - Method in class akka.event.BusLogging
 
isWarningEnabled() - Method in interface akka.event.LoggingAdapter
 
isWarningEnabled() - Method in class akka.event.NoLogging$
 
isWarningEnabled() - Static method in class akka.event.NoLogging
 
isWindows() - Method in class akka.util.Helpers$
 
isWindows() - Static method in class akka.util.Helpers
 
item() - Method in class akka.actor.mailbox.filebased.filequeue.JournalItem.Add
 
iterator() - Method in class akka.actor.IO.IterateeRef.Map
 
iterator() - Method in class akka.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
 
JavaLogging - Interface in akka.contrib.jul
Makes the Akka Logging API available as the log field, using java.util.logging as the backend.
JavaLoggingAdapter - Interface in akka.contrib.jul
 
JavaLoggingEventHandler - Class in akka.contrib.jul
java.util.logging EventHandler.
JavaLoggingEventHandler() - Constructor for class akka.contrib.jul.JavaLoggingEventHandler
 
JavaPartialFunction<A,B> - Class in akka.japi
Helper for implementing a *pure* partial function: it will possibly be invoked multiple times for a single “application”, because its only abstract method is used for both isDefinedAt() and apply(); the former is mapped to isCheck == true and the latter to isCheck == false for those cases where this is important to know.
JavaPartialFunction() - Constructor for class akka.japi.JavaPartialFunction
 
JavaPartialFunction$ - Class in akka.japi
 
JavaPartialFunction$() - Constructor for class akka.japi.JavaPartialFunction$
 
JavaPartialFunction.NoMatch$ - Exception in akka.japi
 
JavaPartialFunction.NoMatch$() - Constructor for exception akka.japi.JavaPartialFunction.NoMatch$
 
JavaPartialFunction.NoMatchException - Exception in akka.japi
 
JavaPartialFunction.NoMatchException() - Constructor for exception akka.japi.JavaPartialFunction.NoMatchException
 
JavaSerializer - Class in akka.serialization
This Serializer uses standard Java Serialization
JavaSerializer(ExtendedActorSystem) - Constructor for class akka.serialization.JavaSerializer
 
JavaSerializer$ - Class in akka.serialization
 
JavaSerializer$() - Constructor for class akka.serialization.JavaSerializer$
 
JavaTestKit - Class in akka.testkit
Java API for the TestProbe.
JavaTestKit(ActorSystem) - Constructor for class akka.testkit.JavaTestKit
 
JavaTestKit.AwaitCond - Class in akka.testkit
 
JavaTestKit.AwaitCond() - Constructor for class akka.testkit.JavaTestKit.AwaitCond
 
JavaTestKit.AwaitCond(Duration) - Constructor for class akka.testkit.JavaTestKit.AwaitCond
 
JavaTestKit.AwaitCond(Duration, Duration) - Constructor for class akka.testkit.JavaTestKit.AwaitCond
 
JavaTestKit.EventFilter<T> - Class in akka.testkit
 
JavaTestKit.EventFilter(Class<?>) - Constructor for class akka.testkit.JavaTestKit.EventFilter
 
JavaTestKit.ExpectMsg<T> - Class in akka.testkit
 
JavaTestKit.ExpectMsg(String) - Constructor for class akka.testkit.JavaTestKit.ExpectMsg
 
JavaTestKit.ExpectMsg(Duration, String) - Constructor for class akka.testkit.JavaTestKit.ExpectMsg
 
JavaTestKit.IgnoreMsg - Class in akka.testkit
 
JavaTestKit.IgnoreMsg() - Constructor for class akka.testkit.JavaTestKit.IgnoreMsg
 
JavaTestKit.ReceiveWhile<T> - Class in akka.testkit
 
JavaTestKit.ReceiveWhile(Class<T>) - Constructor for class akka.testkit.JavaTestKit.ReceiveWhile
 
JavaTestKit.ReceiveWhile(Class<T>, Duration) - Constructor for class akka.testkit.JavaTestKit.ReceiveWhile
 
JavaTestKit.ReceiveWhile(Class<T>, Duration, int) - Constructor for class akka.testkit.JavaTestKit.ReceiveWhile
 
JavaTestKit.ReceiveWhile(Class<T>, Duration, Duration, int) - Constructor for class akka.testkit.JavaTestKit.ReceiveWhile
 
JavaTestKit.Within - Class in akka.testkit
 
JavaTestKit.Within(FiniteDuration) - Constructor for class akka.testkit.JavaTestKit.Within
 
JavaTestKit.Within(FiniteDuration, FiniteDuration) - Constructor for class akka.testkit.JavaTestKit.Within
 
JmxEnabled() - Method in class akka.cluster.ClusterSettings
 
JmxMetricsCollector - Class in akka.cluster
Loads JVM and system metrics through JMX monitoring beans.
JmxMetricsCollector(Address, double) - Constructor for class akka.cluster.JmxMetricsCollector
 
JmxMetricsCollector(ActorSystem) - Constructor for class akka.cluster.JmxMetricsCollector
This constructor is used when creating an instance from configured FQCN
JmxStatistics() - Method in class akka.camel.CamelSettings
 
join(Address) - Method in class akka.cluster.Cluster
Try to join this cluster node with the node specified by 'address'.
join(String) - Method in interface akka.cluster.ClusterNodeMBean
Try to join this cluster node with the node specified by 'address'.
joining() - Method in class akka.cluster.MemberStatus$
Java API: retrieve the “joining” status singleton
joining() - Static method in class akka.cluster.MemberStatus
Java API: retrieve the “joining” status singleton
Journal - Class in akka.actor.mailbox.filebased.filequeue
Codes for working with the journal file for a PersistentQueue.
Journal(String, Function0<Object>, LoggingAdapter) - Constructor for class akka.actor.mailbox.filebased.filequeue.Journal
 
JournalItem - Interface in akka.actor.mailbox.filebased.filequeue
 
JournalItem$ - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem$() - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem$
 
JournalItem.Add - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.Add(QItem) - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.Add
 
JournalItem.Add$ - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.Add$() - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.Add$
 
JournalItem.ConfirmRemove - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.ConfirmRemove(int) - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.ConfirmRemove
 
JournalItem.ConfirmRemove$ - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.ConfirmRemove$() - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.ConfirmRemove$
 
JournalItem.EndOfFile$ - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.EndOfFile$() - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.EndOfFile$
 
JournalItem.Remove$ - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.Remove$() - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.Remove$
 
JournalItem.RemoveTentative$ - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.RemoveTentative$() - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.RemoveTentative$
 
JournalItem.SavedXid - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.SavedXid(int) - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.SavedXid
 
JournalItem.SavedXid$ - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.SavedXid$() - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.SavedXid$
 
JournalItem.Unremove - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.Unremove(int) - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.Unremove
 
JournalItem.Unremove$ - Class in akka.actor.mailbox.filebased.filequeue
 
JournalItem.Unremove$() - Constructor for class akka.actor.mailbox.filebased.filequeue.JournalItem.Unremove$
 
journalSize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
JSerializer - Class in akka.serialization
Java API for creating a Serializer: make sure to include a constructor which takes exactly one argument of type ExtendedActorSystem, because that is the preferred constructor which will be invoked when reflectively instantiating the JSerializer (also possible with empty constructor).
JSerializer() - Constructor for class akka.serialization.JSerializer
 
JvmExitOnFatalError() - Method in class akka.actor.ActorSystem.Settings
 

K

KeepJournal() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
keepJournal() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
keepJournal() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
keepRunning() - Method in class akka.testkit.TestActor.AutoPilot
 
KEY_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
keys() - Method in class akka.util.Index
Returns the key set.
keys() - Method in class akka.util.internal.ConcurrentIdentityHashMap
Returns an enumeration of the keys in this table.
keySet() - Method in class akka.util.internal.ConcurrentIdentityHashMap
Returns a Set view of the keys contained in this map.
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$
 
KILOBYTE() - Method in class akka.actor.mailbox.filebased.filequeue.tools.Util$
 
KILOBYTE() - Static method in class akka.actor.mailbox.filebased.filequeue.tools.Util
 

L

last() - Method in class akka.util.ByteString
 
lastMessage() - Method in interface akka.testkit.TestKitBase
 
lastSender() - Method in interface akka.testkit.TestKitBase
 
lastSerial() - Method in class akka.contrib.pattern.ReliableProxy.Receiver
 
lastValidPosition() - Method in exception akka.actor.mailbox.filebased.filequeue.BrokenItemException
 
lastWasNoMsg() - Method in interface akka.testkit.TestKitBase
if last assertion was expectNoMsg, disable timing failure upon within() block end.
latency() - Method in class akka.actor.IO.PerformancePreferences
 
latestVersionOf(T, T) - Method in class akka.cluster.Versioned$
Returns the Versioned that have the latest version.
latestVersionOf(T, T) - Method in interface akka.cluster.Versioned
Returns the Versioned that have the latest version.
leader() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
 
leader() - Method in class akka.cluster.ClusterEvent.LeaderChanged
 
LeaderActionsInterval() - Method in class akka.cluster.ClusterSettings
 
leaderChangedBuffer() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
leaderChangedReceived() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
leave(Address) - Method in class akka.cluster.Cluster
Send command to issue state transition to LEAVING for the node specified by 'address'.
leave(String) - Method in interface akka.cluster.ClusterNodeMBean
Send command to issue state transition to LEAVING for the node specified by 'address'.
leaving() - Method in class akka.cluster.MemberStatus$
Java API: retrieve the “leaving” status singleton
leaving() - Static method in class akka.cluster.MemberStatus
Java API: retrieve the “leaving” status singleton
len() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
len() - Method in class akka.util.ByteIterator
 
len() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
length() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
length() - Method in class akka.actor.WriteBuffer
 
length() - Method in class akka.util.ByteIterator.ByteArrayIterator
 
length() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
 
length() - Method in class akka.util.ByteString.ByteString1
 
length() - Method in class akka.util.ByteString.ByteString1C
 
length() - Method in class akka.util.ByteString.ByteStrings
 
length() - Method in class akka.util.ByteStringBuilder
 
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.
lineSeparator() - Method in class akka.util.Crypt$
 
lineSeparator() - Static method in class akka.util.Crypt
 
linger() - Method in class akka.actor.IO.SoLinger
 
Linger - Class in akka.zeromq
Configure this socket to have a linger of the specified value The linger period determines how long pending messages which have yet to be sent to a peer shall linger in memory after a socket is closed, and further affects the termination of the socket's context.
Linger(long) - Constructor for class akka.zeromq.Linger
 
linger() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its linger configuration.
linger() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its linger configuration.
Linger$ - Class in akka.zeromq
Gets the linger option @see akka.zeromq.Linger
Linger$() - Constructor for class akka.zeromq.Linger$
 
linkedBlockingQueue() - Method in class akka.dispatch.ThreadPoolConfig$
 
linkedBlockingQueue(int) - Method in class akka.dispatch.ThreadPoolConfig$
 
linkedBlockingQueue() - Static method in class akka.dispatch.ThreadPoolConfig
 
linkedBlockingQueue(int) - Static method in class akka.dispatch.ThreadPoolConfig
 
listen(SocketAddress, Seq<IO.ServerSocketOption>, ActorRef) - Method in class akka.actor.IOManager
Create a ServerSocketChannel listening on an address.
listen(SocketAddress, ActorRef) - Method in class akka.actor.IOManager
Create a ServerSocketChannel listening on an address.
listen(String, int, Seq<IO.ServerSocketOption>, ActorRef) - Method in class akka.actor.IOManager
Create a ServerSocketChannel listening on a host and port.
Listen - 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
 
Listener - Class in akka.zeromq
An option containing the listener for the socket
Listener(ActorRef) - Constructor for class akka.zeromq.Listener
 
listener() - Method in class akka.zeromq.Listener
 
Listener$ - Class in akka.zeromq
 
Listener$() - Constructor for class akka.zeromq.Listener$
 
listenerManagement() - Method in interface akka.routing.Listeners
Chain this into the receive function.
ListenerMessage - Interface in akka.routing
 
Listeners - Interface in akka.routing
Listeners is a generic trait to implement listening capability on an Actor.
listeners() - Method in interface akka.routing.Listeners
 
listOptions(MBeanServerConnection, ObjectInstance) - Method in class akka.jmx.Client
 
loadClass(String, boolean) - Method in class akka.osgi.impl.BundleDelegatingClassLoader
 
loader() - Method in class akka.actor.TypedProps
 
loadQueues() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
local() - Method in class akka.cluster.routing.ClusterRouterConfig
 
local() - Method in class akka.remote.routing.RemoteRouterConfig
 
LocalActorRefProvider - Class in akka.actor
Local ActorRef provider.
LocalActorRefProvider(String, ActorSystem.Settings, EventStream, Scheduler, DynamicAccess, Deployer) - Constructor for class akka.actor.LocalActorRefProvider
 
LocalActorRefProvider(String, ActorSystem.Settings, EventStream, Scheduler, DynamicAccess) - Constructor for class akka.actor.LocalActorRefProvider
 
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() - Method in class akka.actor.LocalActorRefProvider
 
log() - Method in interface akka.contrib.jul.JavaLogging
 
log(Level, Throwable, String) - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
log(Level, Throwable, String, Class<?>, Object, Logging.LogEvent) - Method in class akka.contrib.jul.JavaLoggingEventHandler
 
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 interface akka.event.slf4j.SLF4JLogging
 
log() - Method in class akka.remote.RemoteActorRefProvider
 
log() - Method in class akka.remote.RemoteTransport
A Logger that can be used to log issues that may occur
log() - Method in class akka.serialization.Serialization
 
log() - Method in class akka.testkit.AkkaSpec
 
log() - Method in class akka.testkit.CallingThreadDispatcher
 
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
 
logger() - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
Logger - Class in akka.event.slf4j
Logger is a factory for obtaining SLF4J-Loggers
Logger() - Constructor for class akka.event.slf4j.Logger
 
Logger$ - Class in akka.event.slf4j
Logger is a factory for obtaining SLF4J-Loggers
Logger$() - Constructor for class akka.event.slf4j.Logger$
 
loggerInitialized() - Method in class akka.event.Logging$
Java API to create a LoggerInitialized message.
loggerInitialized() - Static method in class akka.event.Logging
Java API to create a LoggerInitialized message.
loggers() - Method in interface akka.event.LoggingBus
 
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.EventHandlerException - 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.EventHandlerException() - Constructor for exception akka.event.Logging.EventHandlerException
 
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.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.
loggingExecutionContext() - Method in interface akka.contrib.jul.JavaLoggingAdapter
Override-able option for asynchronous logging
LoggingFSM<S,D> - Interface in akka.actor
Stackable trait for FSM which adds a rolling event log and debug logging capabilities (analogous to LoggingReceive).
LoggingReceive - Class in akka.event
This decorator adds invocation logging to a Receive function.
LoggingReceive(Option<Object>, PartialFunction<Object, BoxedUnit>, ActorContext) - Constructor for class akka.event.LoggingReceive
 
LoggingReceive$ - Class in akka.event
 
LoggingReceive$() - Constructor for class akka.event.LoggingReceive$
 
logInfo(String) - Method in class akka.contrib.pattern.ClusterSingletonManager
 
logInfo(String, Object) - Method in class akka.contrib.pattern.ClusterSingletonManager
 
logInfo(String, Object, Object) - Method in class akka.contrib.pattern.ClusterSingletonManager
 
LogLevel() - Method in class akka.actor.ActorSystem.Settings
 
logLevel() - Method in interface akka.event.LoggingBus
Query currently set log level.
logLevel() - Method in class akka.remote.RemoteClientConnected
 
logLevel() - Method in class akka.remote.RemoteClientDisconnected
 
logLevel() - Method in class akka.remote.RemoteClientError
 
logLevel() - Method in class akka.remote.RemoteClientShutdown
 
logLevel() - Method in class akka.remote.RemoteClientStarted
 
logLevel() - Method in interface akka.remote.RemoteLifeCycleEvent
 
logLevel() - Method in class akka.remote.RemoteServerClientClosed
 
logLevel() - Method in class akka.remote.RemoteServerClientConnected
 
logLevel() - Method in class akka.remote.RemoteServerClientDisconnected
 
logLevel() - Method in class akka.remote.RemoteServerError
 
logLevel() - Method in class akka.remote.RemoteServerShutdown
 
logLevel() - Method in class akka.remote.RemoteServerStarted
 
LogReceive() - Method in class akka.remote.RemoteSettings
 
LogRemoteLifeCycleEvents() - Method in class akka.remote.RemoteSettings
 
logRemoteLifeCycleEvents() - Method in class akka.remote.RemoteTransport
When this method returns true, RemoteLifeCycleEvents will be logged as well as be put onto the eventStream.
LogSend() - Method in class akka.remote.RemoteSettings
 
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$
 
LongRunningTest - Class in akka.testkit
 
LongRunningTest() - Constructor for class akka.testkit.LongRunningTest
 
LongRunningTest$ - Class in akka.testkit
 
LongRunningTest$() - Constructor for class akka.testkit.LongRunningTest$
 
longToBytes(long) - Method in class akka.util.Convert$
 
longToBytes(long) - Static method in class akka.util.Convert
 
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() - Method in class akka.camel.CamelExtension$
 
lookup() - Static method in class akka.camel.CamelExtension
 
lookup() - Method in class akka.cluster.Cluster$
 
lookup() - Static method in class akka.cluster.Cluster
 
lookup() - Method in class akka.contrib.mailbox.PeekMailboxExtension$
 
lookup() - Static method in class akka.contrib.mailbox.PeekMailboxExtension
 
lookup(String) - Method in class akka.dispatch.Dispatchers
Returns a dispatcher as specified in configuration, or if not defined it uses the default dispatcher.
lookup() - Method in class akka.serialization.SerializationExtension$
 
lookup() - Static method in class akka.serialization.SerializationExtension
 
lookup() - Method in class akka.transactor.TransactorExtension$
 
lookup() - Static method in class akka.transactor.TransactorExtension
 
lookup() - Method in class akka.zeromq.ZeroMQExtension$
 
lookup() - Static method in class akka.zeromq.ZeroMQExtension
 
LookupClassification - Interface in akka.event
Maps Subscribers to Classifiers using equality on Classifier to store a Set of Subscribers (hence the need for compareSubscribers) Maps Events to Classifiers through the classify-method (so it knows who to publish to) 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 USE ONLY
lowerBound() - Method in class akka.routing.DefaultResizer
The fewest number of routees the router should ever have.

M

mailbox() - Method in interface akka.actor.Stash
 
mailboxType() - Method in class akka.dispatch.Dispatcher
 
MailboxType - Interface in akka.dispatch
MailboxType is a factory to create MessageQueues for an optionally provided ActorContext.
mailboxType() - Method in class akka.dispatch.MessageDispatcherConfigurator
Returns a factory for the Mailbox given the configuration.
mailboxType() - Method in class akka.testkit.CallingThreadDispatcher
 
mailboxType() - Method in class akka.testkit.CallingThreadMailbox
 
main(String[]) - Method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper$
 
main(String[]) - Static method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper
 
main(String[]) - Static method in class akka.jmx.Client
 
Main - Class in akka.kernel
Main class for running the microkernel.
Main() - Constructor for class akka.kernel.Main
 
main(String[]) - Method in class akka.kernel.Main$
 
main(String[]) - Static method in class akka.kernel.Main
 
Main$ - Class in akka.kernel
Main class for running the microkernel.
Main$() - Constructor for class akka.kernel.Main$
 
major() - Method in class akka.zeromq.ZeroMQVersion
 
makeDecider(Class<?>[]) - 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(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(Class<?>[]) - 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(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
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
 
map(Function1<A, B>) - Method in class akka.actor.IO.Iteratee
Applies a function to transform the result of this Iteratee.
map(Function1<A, A>) - Method in interface akka.actor.IO.IterateeRef
 
map(Function1<A, A>) - Method in class akka.actor.IO.IterateeRefAsync
 
map(Function1<A, A>) - Method in class akka.actor.IO.IterateeRefSync
 
map(Function1<T, B>) - Method in class akka.agent.Agent
Map this agent to a new agent, applying the function to the internal state.
map(Function<T, B>) - Method in class akka.agent.Agent
Java API: Map this agent to a new agent, applying the function to the internal state.
mapBody(Function1<A, B>) - Method in class akka.camel.CamelMessage
Returns a new CamelMessage with a transformed body using a transformer function.
mapBody(Mapper<A, B>) - Method in class akka.camel.CamelMessage
Java API: Returns a new CamelMessage with a transformed body using a transformer function.
mapI(Function1<Object, Object>) - Method in class akka.util.ByteString
map method that will automatically cast Int back into Byte.
Mapper<T,R> - Class in akka.dispatch
Callback for the Future.map and Future.flatMap operations that will be invoked if the Future that this callback is registered on becomes completed with a success.
Mapper() - Constructor for class akka.dispatch.Mapper
 
mappings() - Method in interface akka.event.ActorClassification
 
mapSize() - Method in interface akka.event.ActorClassification
This is a size hint for the number of Classifiers you expect to have (use powers of 2)
mapSize() - Method in interface akka.event.LookupClassification
This is a size hint for the number of Classifiers you expect to have (use powers of 2)
mapSize() - Method in class akka.util.Index
 
mapToConfig(Map<String, Object>) - Method in class akka.testkit.AkkaSpec$
 
mapToConfig(Map<String, Object>) - Static method in class akka.testkit.AkkaSpec
 
Marker() - Method in class akka.contrib.mailbox.PeekMailbox
 
match(Object) - Method in class akka.testkit.JavaTestKit.ExpectMsg
 
match(Object) - Method in class akka.testkit.JavaTestKit.ReceiveWhile
 
matches(akka.event.EventBus.Classifier, akka.event.EventBus.Event) - Method in interface akka.event.ScanningClassification
Returns whether the specified Classifier matches the specified Event
matches(Logging.LogEvent) - Method in class akka.testkit.CustomEventFilter
 
matches(Logging.LogEvent) - Method in class akka.testkit.DebugFilter
 
matches(Logging.LogEvent) - Method in class akka.testkit.ErrorFilter
 
matches(Logging.LogEvent) - Method in class akka.testkit.EventFilter
This method decides whether to filter the event (true) or not (false).
matches(Logging.LogEvent) - Method in class akka.testkit.InfoFilter
 
matches(String) - Method in class akka.testkit.JavaTestKit.EventFilter
 
matches(Logging.LogEvent) - Method in class akka.testkit.WarningFilter
 
max() - Method in class akka.cluster.StandardMetrics.HeapMemory
 
max(VectorClock.Timestamp) - Method in class akka.cluster.VectorClock.Timestamp
 
MaxAge() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
maxAge() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
maxAge() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
maxCapacity() - Method in class akka.util.BoundedBlockingQueue
 
maxFailures() - Method in class akka.cluster.CircuitBreakerSettings
 
MaxGossipMergeRate() - Method in class akka.cluster.ClusterSettings
 
maxInstancesPerNode() - Method in class akka.cluster.routing.ClusterRouterSettings
 
MaxItems() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
maxItems() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
maxItems() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
MaxItemSize() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
maxItemSize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
maxItemSize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
MaxJournalOverflow() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
maxJournalOverflow() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
maxJournalOverflow() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
MaxJournalSize() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
maxJournalSize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
maxJournalSize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
MaxJournalSizeAbsolute() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
maxJournalSizeAbsolute() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
maxJournalSizeAbsolute() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
MaxMemorySize() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
maxMemorySize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
maxMemorySize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
maxMessageSize() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its max message size configuration.
maxMessageSize() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its max message size configuration.
MaxMsgSize - Class in akka.zeromq
Limits the size of the inbound message.
MaxMsgSize(long) - Constructor for class akka.zeromq.MaxMsgSize
 
MaxMsgSize$ - Class in akka.zeromq
 
MaxMsgSize$() - Constructor for class akka.zeromq.MaxMsgSize$
 
maxNrOfRetries() - Method in class akka.actor.AllForOneStrategy
 
maxNrOfRetries() - Method in class akka.actor.OneForOneStrategy
 
maxNrOfRetriesCount() - Method in class akka.actor.ChildRestartStats
 
maxPoolSize() - Method in class akka.dispatch.ThreadPoolConfig
 
maxSampleSize() - Method in class akka.cluster.AccrualFailureDetector
 
MaxSize() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
maxSize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
maxSize() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
md5(String) - Method in class akka.util.Crypt$
 
md5(byte[]) - Method in class akka.util.Crypt$
 
md5(String) - Static method in class akka.util.Crypt
 
md5(byte[]) - Static method in class akka.util.Crypt
 
mdcAkkaSourceAttributeName() - Method in class akka.event.slf4j.Slf4jEventHandler
 
mdcThreadAttributeName() - Method in class akka.event.slf4j.Slf4jEventHandler
 
MEGABYTE() - Method in class akka.actor.mailbox.filebased.filequeue.tools.Util$
 
MEGABYTE() - Static method in class akka.actor.mailbox.filebased.filequeue.tools.Util
 
member() - Method in class akka.cluster.ClusterEvent.InstantMemberDowned
 
member() - Method in interface akka.cluster.ClusterEvent.InstantMemberEvent
 
member() - Method in class akka.cluster.ClusterEvent.InstantMemberExited
 
member() - Method in class akka.cluster.ClusterEvent.InstantMemberJoined
 
member() - Method in class akka.cluster.ClusterEvent.InstantMemberLeft
 
member() - Method in class akka.cluster.ClusterEvent.InstantMemberRemoved
 
member() - Method in class akka.cluster.ClusterEvent.InstantMemberUp
 
member() - Method in class akka.cluster.ClusterEvent.MemberDowned
 
member() - Method in interface akka.cluster.ClusterEvent.MemberEvent
 
member() - Method in class akka.cluster.ClusterEvent.MemberExited
 
member() - Method in class akka.cluster.ClusterEvent.MemberJoined
 
member() - Method in class akka.cluster.ClusterEvent.MemberLeft
 
member() - Method in class akka.cluster.ClusterEvent.MemberRemoved
 
member() - Method in class akka.cluster.ClusterEvent.MemberUp
 
member() - Method in class akka.cluster.ClusterEvent.UnreachableMember
 
Member - Class in akka.cluster
Represents the address and the current status of a cluster member node.
Member(Address, MemberStatus) - Constructor for class akka.cluster.Member
 
Member$ - Class in akka.cluster
Module with factory and ordering methods for Member instances.
Member$() - Constructor for class akka.cluster.Member$
 
members() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
 
members() - Method in class akka.cluster.ClusterEvent.InstantClusterState
 
MemberStatus - Class in akka.cluster
Defines the current status of a cluster member node Can be one of: Joining, Up, Leaving, Exiting and Down.
MemberStatus() - Constructor for class akka.cluster.MemberStatus
 
MemberStatus$ - Class in akka.cluster
 
MemberStatus$() - Constructor for class akka.cluster.MemberStatus$
 
MemberStatus.Down$ - Class in akka.cluster
 
MemberStatus.Down$() - Constructor for class akka.cluster.MemberStatus.Down$
 
MemberStatus.Exiting$ - Class in akka.cluster
 
MemberStatus.Exiting$() - Constructor for class akka.cluster.MemberStatus.Exiting$
 
MemberStatus.Joining$ - Class in akka.cluster
 
MemberStatus.Joining$() - Constructor for class akka.cluster.MemberStatus.Joining$
 
MemberStatus.Leaving$ - Class in akka.cluster
 
MemberStatus.Leaving$() - Constructor for class akka.cluster.MemberStatus.Leaving$
 
MemberStatus.Removed$ - Class in akka.cluster
 
MemberStatus.Removed$() - Constructor for class akka.cluster.MemberStatus.Removed$
 
MemberStatus.Up$ - Class in akka.cluster
 
MemberStatus.Up$() - Constructor for class akka.cluster.MemberStatus.Up$
 
memoryBytes() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
memoryLength() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
merge(NodeMetrics) - Method in class akka.cluster.NodeMetrics
Returns the most recent data.
merge(VectorClock) - Method in class akka.cluster.VectorClock
Merges this VectorClock with another VectorClock.
mergeDeploy(RemoteProtocol.DeployProtocol) - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
mergeDeploy(RemoteProtocol.DeployProtocol) - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.RemoteProtocol.ActorRefProtocol.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.RemoteProtocol.ActorRefProtocol.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.RemoteProtocol.AddressProtocol.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.RemoteProtocol.AddressProtocol.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.RemoteProtocol.MessageProtocol.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.RemoteProtocol.MessageProtocol.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
mergeFrom(com.google.protobuf.Message) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
mergeFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
mergeInstruction(RemoteProtocol.RemoteControlProtocol) - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
mergeMessage(RemoteProtocol.RemoteMessageProtocol) - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
mergeMessage(RemoteProtocol.MessageProtocol) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
mergeOrigin(RemoteProtocol.AddressProtocol) - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
mergeProps(RemoteProtocol.PropsProtocol) - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
mergeRecipient(RemoteProtocol.ActorRefProtocol) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
mergeSender(RemoteProtocol.ActorRefProtocol) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
mergeSupervisor(RemoteProtocol.ActorRefProtocol) - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
message() - Method in exception akka.actor.ActorKilledException
 
message() - Method in class akka.actor.DeadLetter
 
message() - Method in exception akka.actor.IllegalActorStateException
 
message() - Method in exception akka.actor.InvalidActorNameException
 
message() - Method in exception akka.actor.InvalidMessageException
 
message() - Method in class akka.actor.UnhandledMessage
 
message() - Method in class akka.dispatch.Envelope
 
message() - Method in class akka.event.Logging.Debug
 
message() - Method in class akka.event.Logging.Error
 
message() - Method in class akka.event.Logging.Info
 
message() - Method in interface akka.event.Logging.LogEvent
The message, may be any object or null.
message() - Method in class akka.event.Logging.Warning
 
message() - Method in class akka.routing.Broadcast
 
message() - Method in class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope
 
message() - Method in interface akka.routing.RouterEnvelope
 
message() - Method in class akka.testkit.DebugFilter
 
message() - Method in class akka.testkit.ErrorFilter
 
message() - Method in class akka.testkit.EventFilter
 
message() - Method in class akka.testkit.InfoFilter
 
message(String) - Method in class akka.testkit.JavaTestKit.EventFilter
 
message() - Method in class akka.testkit.WarningFilter
 
message() - Method in class akka.transactor.Coordinated
 
message() - Method in class akka.transactor.SendTo
 
MESSAGE_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
MESSAGE_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.MessageProtocol
 
MESSAGE_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
MessageDispatcher - Class in akka.dispatch
 
MessageDispatcher(DispatcherPrerequisites) - Constructor for class akka.dispatch.MessageDispatcher
 
MessageDispatcherConfigurator - Class in akka.dispatch
Base class to be used for hooking in new dispatchers into Dispatchers.
MessageDispatcherConfigurator(com.typesafe.config.Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.MessageDispatcherConfigurator
 
MessageExchangeId() - Method in class akka.camel.CamelMessage$
CamelMessage header to correlate request with response messages.
MessageExchangeId() - Static method in class akka.camel.CamelMessage
CamelMessage header to correlate request with response messages.
MESSAGEMANIFEST_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.MessageProtocol
 
messageOption() - Method in exception akka.actor.PreRestartException
 
messagePredicate() - Method in class akka.actor.dsl.Inbox.InboxActor
 
messageQueue() - Method in class akka.dispatch.BalancingDispatcher
INTERNAL USE ONLY
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.
METADATA_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
method() - Method in class akka.actor.TypedActor.MethodCall
 
Metric - Class in akka.cluster
Metrics key/value.
metric(String) - Method in class akka.cluster.NodeMetrics
 
Metric$ - Class in akka.cluster
Factory for creating valid Metric instances.
Metric$() - Constructor for class akka.cluster.Metric$
 
metrics() - Method in class akka.cluster.JmxMetricsCollector
 
metrics() - Method in class akka.cluster.NodeMetrics
 
metrics() - Method in class akka.cluster.SigarMetricsCollector
 
MetricsCollectorClass() - Method in class akka.cluster.ClusterSettings
 
MetricsEnabled() - Method in class akka.cluster.ClusterSettings
 
MetricsGossipInterval() - Method in class akka.cluster.ClusterSettings
 
MetricsInterval() - Method in class akka.cluster.ClusterSettings
 
MetricsMovingAverageHalfLife() - Method in class akka.cluster.ClusterSettings
 
metricsSelector() - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
 
metricsSelector() - Method in interface akka.cluster.routing.AdaptiveLoadBalancingRouterLike
 
MetricsSelector - Interface in akka.cluster.routing
A MetricsSelector is responsible for producing weights from the node metrics.
MinNrOfMembers() - Method in class akka.cluster.ClusterSettings
 
minor() - Method in class akka.zeromq.ZeroMQVersion
 
minStdDeviation() - Method in class akka.cluster.AccrualFailureDetector
 
MixMetricsSelector - Class in akka.cluster.routing
MetricsSelector that combines other selectors and aggregates their capacity values.
MixMetricsSelector(IndexedSeq<CapacityMetricsSelector>) - Constructor for class akka.cluster.routing.MixMetricsSelector
 
MixMetricsSelector$ - Class in akka.cluster.routing
Singleton instance of the default MixMetricsSelector, which uses [akka.cluster.routing.HeapMetricsSelector], [akka.cluster.routing.CpuMetricsSelector], and [akka.cluster.routing.SystemLoadAverageMetricsSelector]
MixMetricsSelector$() - Constructor for class akka.cluster.routing.MixMetricsSelector$
 
MixMetricsSelectorBase - Class in akka.cluster.routing
Base class for MetricsSelector that combines other selectors and aggregates their capacity.
MixMetricsSelectorBase(IndexedSeq<CapacityMetricsSelector>) - Constructor for class akka.cluster.routing.MixMetricsSelectorBase
 
MixMetricsSelectorBase(Iterable<CapacityMetricsSelector>) - Constructor for class akka.cluster.routing.MixMetricsSelectorBase
Java API: construct a mix-selector from a sequence of selectors
mkChild(Props, String) - Method in class akka.actor.ActorDSL.Extension
 
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.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.IllegalActorStateException$
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.LocalScope$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.DurableMailboxSpec$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.DurableMailboxSpecActorFactory$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.filebased.filequeue.BrokenItemException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.filebased.filequeue.JournalItem$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.filebased.filequeue.QItem$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.filebased.filequeue.tools.QDumper$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.mailbox.filebased.filequeue.tools.Util$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.NoScopeGiven$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.OneForOneStrategy$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.OriginalRestartException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.PoisonPill$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.PostRestartException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.PreRestartException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Props$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.ReceiveTimeout$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.RelativeActorPath$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.RootActorPath$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.StashOverflowException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Status$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.SupervisorStrategy$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.Terminated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.TypedActor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.TypedProps$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.actor.UnhandledMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.agent.Agent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.Ack$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.CamelExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.CamelMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.camel.internal.component.CamelPath$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.AccrualFailureDetector$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.CircuitBreakerSettings$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.Cluster$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterScope$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.ClusterUserAction$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.EWMA$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.Member$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.MemberStatus$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.Metric$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.NodeMetrics$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.AdaptiveLoadBalancingRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.ClusterRouterConfig$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.ClusterRouterSettings$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.CpuMetricsSelector$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.HeapMetricsSelector$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.MixMetricsSelector$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.routing.SystemLoadAverageMetricsSelector$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.StandardMetrics$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.VectorClock$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.cluster.Versioned$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.mailbox.PeekMailboxExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ClusterSingletonManager$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.pattern.ReliableProxy$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.throttle.Throttler$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.contrib.throttle.TimerBasedThrottler$
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.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.MonitorableThreadFactory$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.dispatch.NullMessage$
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.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.event.EventStream$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.Logging$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.LoggingReceive$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.LogSource$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.NoLogging$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.event.slf4j.Logger$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.JavaPartialFunction$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.Option$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.japi.Util$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.kernel.Main$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.osgi.aries.blueprint.NamespaceHandler$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.osgi.impl.BundleDelegatingClassLoader$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.osgi.OsgiActorSystemFactory$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.pattern.CircuitBreaker$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.pattern.CircuitBreakerOpenException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.pattern.Patterns$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteClientConnected$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteClientDisconnected$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteClientError$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteClientException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteClientShutdown$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteClientStarted$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteScope$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteServerClientClosed$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteServerClientConnected$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteServerClientDisconnected$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteServerError$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteServerShutdown$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteServerStarted$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.routing.RemoteRouterConfig$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.security.provider.AkkaProvider$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.security.provider.InternetSeedGenerator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.serialization.ProtobufSerializer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.Broadcast$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.BroadcastRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ConsistentHash$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ConsistentHashingRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.CurrentRoutees$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.Deafen$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.DefaultResizer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.Destination$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.FromConfig$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.Listen$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.MurmurHash$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.NoRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RandomRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RoundRobinRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.RouterRoutees$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.ScatterGatherFirstCompletedRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.SmallestMailboxRouter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.routing.WithListeners$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.serialization.JavaSerializer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.serialization.NullSerializer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.serialization.Serialization$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.serialization.SerializationExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.AkkaSpec$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.CallingThreadDispatcher$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.CustomEventFilter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.DebugFilter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.ErrorFilter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.EventFilter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.ExtractRoute$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.InfoFilter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.LongRunningTest$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestActor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestActorRef$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestActorRefSpec$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestBarrier$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestFSMRef$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestKit$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestKitExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestLatch$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TestProbe$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.TimingTest$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.testkit.WarningFilter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.transactor.Coordinated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.transactor.SendTo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.transactor.TransactorExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.BoxedType$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.ByteIterator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.ByteString$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.CompactByteString$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.Convert$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.Crypt$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.HashCode$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.Helpers$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.Switch$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.util.Timeout$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Affinity$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Backlog$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Bind$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Closed$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Connect$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Connecting$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Context$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.FileDescriptor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Frame$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.HighWatermark$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Identity$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Linger$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Listener$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.MaxMsgSize$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.MulticastHops$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.MulticastLoop$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.PollDispatcher$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.PollTimeoutDuration$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Rate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.ReceiveBufferSize$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.ReceiveHighWatermark$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.ReconnectIVL$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.ReconnectIVLMax$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.RecoveryInterval$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Send$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.SendBufferSize$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.SendHighWatermark$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.SocketType$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Subscribe$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Swap$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.Unsubscribe$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.ZeroMQ$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.ZeroMQExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.ZeroMQVersion$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.zeromq.ZMQMessage$
Static reference to the singleton instance of this Scala object.
MonitorableThreadFactory - Class in akka.dispatch
 
MonitorableThreadFactory(String, boolean, Option<ClassLoader>, Thread.UncaughtExceptionHandler, AtomicLong) - Constructor for class akka.dispatch.MonitorableThreadFactory
 
MonitorableThreadFactory$ - Class in akka.dispatch
 
MonitorableThreadFactory$() - Constructor for class akka.dispatch.MonitorableThreadFactory$
 
MonitoredByNrOfMembers() - Method in class akka.cluster.ClusterSettings
 
msg() - Method in class akka.actor.FSM.Timer
 
msg() - Method in class akka.contrib.pattern.ReliableProxy.Message
 
msg() - Method in interface akka.testkit.TestActor.Message
 
msg() - Method in class akka.testkit.TestActor.NullMessage$
 
msg() - Method in class akka.testkit.TestActor.RealMessage
 
msg() - Method in class akka.testkit.TestActorRefSpec.Logger
 
msgAvailable() - Method in class akka.testkit.JavaTestKit
 
msgAvailable() - Method in interface akka.testkit.TestKitBase
Query queue status.
msgsPer(int, TimeUnit) - Method in class akka.contrib.throttle.Throttler.RateInt
 
msgsPer(FiniteDuration) - Method in class akka.contrib.throttle.Throttler.RateInt
 
msgsPerHour() - Method in class akka.contrib.throttle.Throttler.RateInt
 
msgsPerMinute() - Method in class akka.contrib.throttle.Throttler.RateInt
 
msgsPerSecond() - Method in class akka.contrib.throttle.Throttler.RateInt
 
MulticastHops - Class in akka.zeromq
Sets the time-to-live field in every multicast packet sent from this socket.
MulticastHops(long) - Constructor for class akka.zeromq.MulticastHops
 
multicastHops() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its multicast hops configuration.
multicastHops() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its multicast hops configuration.
MulticastHops$ - Class in akka.zeromq
Gets the MulticastHops
MulticastHops$() - Constructor for class akka.zeromq.MulticastHops$
 
MulticastLoop - Class in akka.zeromq
Controls whether data sent via multicast transports using the specified socket can also be received by the sending host via loop-back.
MulticastLoop(boolean) - Constructor for class akka.zeromq.MulticastLoop
 
multicastLoop() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its multicast loop configuration.
multicastLoop() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its multicast loop configuration.
MulticastLoop$ - Class in akka.zeromq
Gets the MulticastLoop
MulticastLoop$() - Constructor for class akka.zeromq.MulticastLoop$
 
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 interface akka.actor.mailbox.DurableMailboxSettings
Name of this mailbox type for purposes of configuration scoping.
name() - Method in class akka.actor.mailbox.DurableMessageQueue
 
name() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
name() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
name() - Method in class akka.actor.RootActorPath
 
name() - Method in class akka.cluster.Metric
 
name() - Method in class akka.cluster.VectorClock.Node.NodeImpl
 
name() - Method in class akka.dispatch.MonitorableThreadFactory
 
name() - Method in class akka.testkit.CallingThreadDispatcher
 
name() - Method in class akka.zeromq.PollDispatcher
 
NamespaceHandler - Class in akka.osgi.aries.blueprint
Aries Blueprint namespace handler implementation.
NamespaceHandler() - Constructor for class akka.osgi.aries.blueprint.NamespaceHandler
 
NamespaceHandler$ - Class in akka.osgi.aries.blueprint
 
NamespaceHandler$() - Constructor for class akka.osgi.aries.blueprint.NamespaceHandler$
 
newActorCell(akka.actor.ActorSystemImpl, akka.actor.InternalActorRef, Props, akka.actor.InternalActorRef) - Method in class akka.testkit.TestActorRef
 
newBuilder() - Static method in class akka.remote.RemoteProtocol.ActorRefProtocol
 
newBuilder(RemoteProtocol.ActorRefProtocol) - Static method in class akka.remote.RemoteProtocol.ActorRefProtocol
 
newBuilder() - Static method in class akka.remote.RemoteProtocol.AddressProtocol
 
newBuilder(RemoteProtocol.AddressProtocol) - Static method in class akka.remote.RemoteProtocol.AddressProtocol
 
newBuilder() - Static method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
newBuilder(RemoteProtocol.AkkaRemoteProtocol) - Static method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
newBuilder() - Static method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
newBuilder(RemoteProtocol.DaemonMsgCreateProtocol) - Static method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
newBuilder() - Static method in class akka.remote.RemoteProtocol.DeployProtocol
 
newBuilder(RemoteProtocol.DeployProtocol) - Static method in class akka.remote.RemoteProtocol.DeployProtocol
 
newBuilder() - Static method in class akka.remote.RemoteProtocol.MessageProtocol
 
newBuilder(RemoteProtocol.MessageProtocol) - Static method in class akka.remote.RemoteProtocol.MessageProtocol
 
newBuilder() - Static method in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
newBuilder(RemoteProtocol.MetadataEntryProtocol) - Static method in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
newBuilder() - Static method in class akka.remote.RemoteProtocol.PropsProtocol
 
newBuilder(RemoteProtocol.PropsProtocol) - Static method in class akka.remote.RemoteProtocol.PropsProtocol
 
newBuilder() - Static method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
newBuilder(RemoteProtocol.RemoteControlProtocol) - Static method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
newBuilder() - Static method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
newBuilder(RemoteProtocol.RemoteMessageProtocol) - Static method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
newBuilder() - Method in class akka.util.ByteString$
 
newBuilder() - Method in class akka.util.ByteString
 
newBuilderForType() - Method in class akka.remote.RemoteProtocol.ActorRefProtocol
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.RemoteProtocol.ActorRefProtocol
 
newBuilderForType() - Method in class akka.remote.RemoteProtocol.AddressProtocol
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.RemoteProtocol.AddressProtocol
 
newBuilderForType() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
newBuilderForType() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
newBuilderForType() - Method in class akka.remote.RemoteProtocol.DeployProtocol
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.RemoteProtocol.DeployProtocol
 
newBuilderForType() - Method in class akka.remote.RemoteProtocol.MessageProtocol
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.RemoteProtocol.MessageProtocol
 
newBuilderForType() - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
newBuilderForType() - Method in class akka.remote.RemoteProtocol.PropsProtocol
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.RemoteProtocol.PropsProtocol
 
newBuilderForType() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
newBuilderForType() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
newBuilderForType(com.google.protobuf.GeneratedMessage.BuilderParent) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
newDealerSocket(SocketOption[]) - Method in class akka.zeromq.ZeroMQExtension
Java API factory method to create the actor representing the ZeroMQ Dealer socket.
newDealerSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Java API: Factory method to create the Props to build a ZeroMQ Dealer socket actor.
newPubSocket(SocketOption[]) - Method in class akka.zeromq.ZeroMQExtension
Java API factory method to create the actor representing the ZeroMQ Publisher socket.
newPubSocket(Bind) - Method in class akka.zeromq.ZeroMQExtension
Convenience for creating a publisher socket.
newPubSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Java API: Factory method to create the Props to build a ZeroMQ Publisher socket actor.
newPullSocket(SocketOption[]) - Method in class akka.zeromq.ZeroMQExtension
Java API factory method to create the actor representing the ZeroMQ Pull socket.
newPullSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Java API: Factory method to create the Props to build a ZeroMQ Pull socket actor.
newPushSocket(SocketOption[]) - Method in class akka.zeromq.ZeroMQExtension
Java API factory method to create the actor representing the ZeroMQ Push socket.
newPushSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Java API: Factory method to create the Props to build a ZeroMQ Push socket actor.
newReceiver() - Method in interface akka.actor.dsl.Inbox.InboxExtension
 
newRepSocket(SocketOption[]) - Method in class akka.zeromq.ZeroMQExtension
Java API factory method to create the actor representing the ZeroMQ Rep socket.
newRepSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Java API: Factory method to create the Props to build a ZeroMQ Rep socket actor.
newReqSocket(SocketOption[]) - Method in class akka.zeromq.ZeroMQExtension
Java API factory method to create the actor representing the ZeroMQ Req socket.
newReqSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Java API: Factory method to create the Props to build a ZeroMQ Req socket actor.
newRouterSocket(SocketOption[]) - Method in class akka.zeromq.ZeroMQExtension
Java API factory method to create the actor representing the ZeroMQ Router socket.
newRouterSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Java API: Factory method to create the Props to build a ZeroMQ Router socket actor.
newSocket(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Factory method to create the actor representing the ZeroMQ socket.
newSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Factory method to create the Props to build the ZeroMQ socket actor.
NewSocketTimeout() - Method in class akka.zeromq.ZeroMQExtension
 
newSubSocket(SocketOption[]) - Method in class akka.zeromq.ZeroMQExtension
Java API factory method to create the actor representing the ZeroMQ Subscriber socket.
newSubSocket(Connect, Listener, Subscribe) - Method in class akka.zeromq.ZeroMQExtension
Convenience for creating a subscriber socket.
newSubSocketProps(Seq<SocketOption>) - Method in class akka.zeromq.ZeroMQExtension
Java API: Factory method to create the Props to build a ZeroMQ Subscriber socket actor.
newThread(ForkJoinPool) - Method in class akka.dispatch.MonitorableThreadFactory
 
newThread(Runnable) - Method in class akka.dispatch.MonitorableThreadFactory
 
newTimeout(TimerTask, FiniteDuration) - Method in class akka.util.internal.HashedWheelTimer
 
newTimeout(TimerTask, FiniteDuration) - Method in interface akka.util.internal.Timer
Schedules the specified TimerTask for one-time execution after the specified delay.
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
nextSerial() - Method in class akka.contrib.pattern.ReliableProxy
 
nextState() - Method in interface akka.actor.FSM
 
nextStateData() - Method in interface akka.actor.FSM
Return next state data (available in onTransition handlers)
no() - Method in class akka.zeromq.Linger$
 
no() - Static method in class akka.zeromq.Linger
 
noAutoPilot() - Method in class akka.testkit.TestActor.AutoPilot
 
nobody() - Method in interface akka.transactor.Transactor
Empty set of transactors to send to.
nobody() - Method in class akka.transactor.UntypedTransactor
Empty set of transactors to send to.
noCause() - Method in class akka.event.Logging$
Null Object used for errors without cause Throwable
noCause() - Static method in class akka.event.Logging
Null Object used for errors without cause Throwable
node() - Method in class akka.remote.RemoteScope
 
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.
nodeMetrics() - Method in class akka.cluster.ClusterEvent.ClusterMetricsChanged
 
NodeMetrics - Class in akka.cluster
The snapshot of current sampled health metrics for any monitored process.
NodeMetrics(Address, long, Set<Metric>) - Constructor for class akka.cluster.NodeMetrics
 
NodeMetrics$ - Class in akka.cluster
 
NodeMetrics$() - Constructor for class akka.cluster.NodeMetrics$
 
nodes() - Method in class akka.remote.routing.RemoteRouterConfig
 
noIncrement(Object) - Method in class akka.transactor.Coordinated
Create a new Coordinated object but *do not* increment the number of members by one.
NoLogging - Class in akka.event
NoLogging is a LoggingAdapter that does absolutely nothing – no logging at all.
NoLogging() - Constructor for class akka.event.NoLogging
 
NoLogging$ - Class in akka.event
NoLogging is a LoggingAdapter that does absolutely nothing – no logging at all.
NoLogging$() - Constructor for class akka.event.NoLogging$
 
noMatch() - Method in class akka.japi.JavaPartialFunction$
 
noMatch() - Static method in class akka.japi.JavaPartialFunction
 
noMatch() - Method in class akka.testkit.JavaTestKit.ExpectMsg
 
noMatch() - Method in class akka.testkit.JavaTestKit.ReceiveWhile
 
none() - Method in class akka.cluster.Member$
 
none() - Static method in class akka.cluster.Member
 
none() - Method in class akka.japi.Option$
Option factory that creates None
none() - Static method in class akka.japi.Option
Option factory that creates None
normally() - Method in interface akka.transactor.Transactor
Bypass transactionality and behave like a normal actor.
normally(Object) - Method in class akka.transactor.UntypedTransactor
Bypass transactionality and behave like a normal actor.
NoRouter - Class in akka.routing
Routing configuration that indicates no routing; this is also the default value which hence overrides the merge strategy in order to accept values from lower-precedence sources.
NoRouter() - Constructor for class akka.routing.NoRouter
 
NoRouter$ - Class in akka.routing
 
NoRouter$() - Constructor for class akka.routing.NoRouter$
 
NoScopeGiven - Class in akka.actor
This is the default value and as such allows overrides.
NoScopeGiven() - Constructor for class akka.actor.NoScopeGiven
 
NoScopeGiven$ - Class in akka.actor
 
NoScopeGiven$() - Constructor for class akka.actor.NoScopeGiven$
 
noSender() - Method in class akka.actor.Actor$
Default placeholder (null) used for "!"
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.
notEmpty(String) - Method in class akka.jmx.Client
 
notifyDebug(String) - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
notifyDebug(String) - Method in class akka.event.BusLogging
 
notifyDebug(String) - Method in interface akka.event.LoggingAdapter
 
notifyDebug(String) - Method in class akka.event.NoLogging$
 
notifyDebug(String) - Static method in class akka.event.NoLogging
 
notifyError(String) - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
notifyError(Throwable, String) - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
notifyError(String) - Method in class akka.event.BusLogging
 
notifyError(Throwable, String) - Method in class akka.event.BusLogging
 
notifyError(String) - Method in interface akka.event.LoggingAdapter
 
notifyError(Throwable, String) - Method in interface akka.event.LoggingAdapter
 
notifyError(String) - Method in class akka.event.NoLogging$
 
notifyError(Throwable, String) - Method in class akka.event.NoLogging$
 
notifyError(String) - Static method in class akka.event.NoLogging
 
notifyError(Throwable, String) - Static method in class akka.event.NoLogging
 
notifyInfo(String) - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
notifyInfo(String) - Method in class akka.event.BusLogging
 
notifyInfo(String) - Method in interface akka.event.LoggingAdapter
 
notifyInfo(String) - Method in class akka.event.NoLogging$
 
notifyInfo(String) - Static method in class akka.event.NoLogging
 
notifyListeners(RemoteLifeCycleEvent) - Method in class akka.remote.RemoteTransport
Default implementation both publishes the message to the eventStream as well as logs it using the system logger
notifyLog(Logging.LogLevel, String) - Method in interface akka.event.LoggingAdapter
 
notifyWarning(String) - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
notifyWarning(String) - Method in class akka.event.BusLogging
 
notifyWarning(String) - Method in interface akka.event.LoggingAdapter
 
notifyWarning(String) - Method in class akka.event.NoLogging$
 
notifyWarning(String) - Static method in class akka.event.NoLogging
 
now() - Method in class akka.testkit.TestKit$
Obtain current timestamp as Duration for relative measurements (using System.nanoTime).
now() - Static method in class akka.testkit.TestKit
Obtain current timestamp as Duration for relative measurements (using System.nanoTime).
now() - Method in interface akka.testkit.TestKitBase
Obtain current time (System.nanoTime) as Duration.
nrOfInstances() - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
 
nrOfInstances() - Method in interface akka.cluster.routing.AdaptiveLoadBalancingRouterLike
 
nrOfInstances() - Method in interface akka.routing.BroadcastLike
 
nrOfInstances() - Method in class akka.routing.BroadcastRouter
 
nrOfInstances() - Method in interface akka.routing.ConsistentHashingLike
 
nrOfInstances() - Method in class akka.routing.ConsistentHashingRouter
 
nrOfInstances() - Method in interface akka.routing.RandomLike
 
nrOfInstances() - Method in class akka.routing.RandomRouter
 
nrOfInstances() - Method in interface akka.routing.RoundRobinLike
 
nrOfInstances() - Method in class akka.routing.RoundRobinRouter
 
nrOfInstances() - Method in interface akka.routing.ScatterGatherFirstCompletedLike
 
nrOfInstances() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
nrOfInstances() - Method in interface akka.routing.SmallestMailboxLike
 
nrOfInstances() - Method in class akka.routing.SmallestMailboxRouter
 
nullAsBytes() - Method in class akka.serialization.NullSerializer
 
NullMessage - Class in akka.dispatch
This message is sent directly after the Supervise system message in order to form a barrier wrt. the first real message sent by the child, so that e.g.
NullMessage() - Constructor for class akka.dispatch.NullMessage
 
NullMessage$ - Class in akka.dispatch
This message is sent directly after the Supervise system message in order to form a barrier wrt. the first real message sent by the child, so that e.g.
NullMessage$() - Constructor for class akka.dispatch.NullMessage$
 
NullSerializer - Class in akka.serialization
This is a special Serializer that Serializes and deserializes nulls only
NullSerializer() - Constructor for class akka.serialization.NullSerializer
 
NullSerializer$ - Class in akka.serialization
 
NullSerializer$() - Constructor for class akka.serialization.NullSerializer$
 
num() - Method in class akka.actor.mailbox.DurableMailboxSpecActorFactory.AccumulatorActor
 
numberOfCalls() - Method in class akka.contrib.throttle.Throttler.Rate
 
numberOfCalls() - Method in class akka.contrib.throttle.Throttler.RateInt
 
numberOfConnections() - Method in class akka.actor.IO.Backlog
 
NumberOfEndHeartbeats() - Method in class akka.cluster.ClusterSettings
 
numberOfMessages() - Method in class akka.actor.mailbox.filebased.FileBasedMessageQueue
 
numberOfMessages() - Method in interface akka.dispatch.MessageQueue
Should return the current number of messages held in this queue; may always return 0 if no other value is available efficiently.
numberOfMessages() - Method in interface akka.dispatch.QueueBasedMessageQueue
 
numberOfMessages(ActorRef) - Method in interface akka.routing.SmallestMailboxLike
Returns the number of pending messages in the mailbox of the actor.
numberOfMessages() - Method in class akka.testkit.CallingThreadMailbox
 

O

occurrences(int) - Method in class akka.testkit.JavaTestKit.EventFilter
 
offer(E) - Method in class akka.util.BoundedBlockingQueue
 
offer(E, long, TimeUnit) - Method in class akka.util.BoundedBlockingQueue
 
offset() - Method in class akka.actor.mailbox.filebased.filequeue.tools.QueueDumper
 
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
 
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
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, PartialFunction<Throwable, SupervisorStrategy.Directive>) - 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(int, Duration, Class<?>[]) - Constructor for class akka.actor.OneForOneStrategy
 
OneForOneStrategy$ - Class in akka.actor
 
OneForOneStrategy$() - Constructor for class akka.actor.OneForOneStrategy$
 
oneway() - Method in class akka.camel.javaapi.UntypedProducerActor
 
Oneway - Interface in akka.camel
A one-way producer.
oneway() - Method in interface akka.camel.Oneway
 
oneway() - Method in interface akka.camel.ProducerSupport
If set to false (default), this producer expects a response message from the Camel endpoint.
OnFailure - Class in akka.dispatch
Callback for when a Future is completed with a failure SAM (Single Abstract Method) class 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
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.
onReceive(Object) - Method in class akka.camel.javaapi.UntypedProducerActor
Default implementation of UntypedActor.onReceive
onReceive(Object) - Method in class akka.transactor.UntypedTransactor
Implement a general pattern for using coordinated transactions.
onRouteDefinition() - Method in interface akka.camel.Consumer
Returns the route definition handler for creating a custom route to this consumer.
onRouteResponse(Object) - Method in class akka.camel.javaapi.UntypedProducerActor
Called after a response was received from the endpoint specified by endpointUri.
OnSuccess<T> - Class in akka.dispatch
Callback for when a Future is completed successfully SAM (Single Abstract Method) class 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.
onTransformOutgoingMessage(Object) - Method in class akka.camel.javaapi.UntypedProducerActor
Called before the message is sent to the endpoint specified by getEndpointUri.
onTransformResponse(Object) - Method in class akka.camel.javaapi.UntypedProducerActor
Called before the response message is sent to original sender.
onTransition(PartialFunction<Tuple2<S, S>, BoxedUnit>) - Method in interface akka.actor.FSM
Set handler which is called upon each state transition, i.e. not when staying in the same state.
open() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
open() - Method in class akka.testkit.TestLatch
 
openTransactionCount() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
openTransactionIds() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
openTransactions() - Method in class akka.actor.mailbox.filebased.filequeue.tools.QueueDumper
 
operations() - Method in class akka.actor.mailbox.filebased.filequeue.tools.QueueDumper
 
Option<A> - Class in akka.japi
This class represents optional values.
Option() - Constructor for class akka.japi.Option
 
option(A) - Method in class akka.japi.Option$
Option factory that creates None if v is null, Some(v) otherwise.
option(A) - Static method in class akka.japi.Option
Option factory that creates None if v is null, Some(v) otherwise.
Option$ - Class in akka.japi
 
Option$() - Constructor for class akka.japi.Option$
 
Option.Some<A> - Class in akka.japi
Class Some[A] represents existing values of type A.
Option.Some(A) - Constructor for class akka.japi.Option.Some
 
Option.Some$ - Class in akka.japi
 
Option.Some$() - Constructor for class akka.japi.Option.Some$
 
options() - Method in class akka.actor.IO.Accept
 
options() - Method in class akka.actor.IO.Connect
 
options() - Method in class akka.actor.IO.Listen
 
ordering() - Method in class akka.cluster.Member$
Member ordering type class, sorts members by host and port.
ordering() - Static method in class akka.cluster.Member
Member ordering type class, sorts members by host and port.
ORIGIN_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
originalCause() - Method in exception akka.actor.PostRestartException
 
originalCause() - Method in exception akka.actor.PreRestartException
 
originalReceiver() - Method in class akka.remote.RemoteMessage
Returns a String-representation of the ActorPath that this RemoteMessage is destined for
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$
 
originalSender() - Method in class akka.remote.RemoteMessage
Returns an Option with the String representation of the ActorPath of the Actor who is the sender of this message
OsgiActorSystemFactory - Class in akka.osgi
Factory class to create ActorSystem implementations in an OSGi environment.
OsgiActorSystemFactory(org.osgi.framework.BundleContext, Option<ClassLoader>) - Constructor for class akka.osgi.OsgiActorSystemFactory
 
OsgiActorSystemFactory$ - Class in akka.osgi
 
OsgiActorSystemFactory$() - Constructor for class akka.osgi.OsgiActorSystemFactory$
 
otherthread() - Method in class akka.testkit.TestActorRefSpec$
 
otherthread() - Static method in class akka.testkit.TestActorRefSpec
 
overlay(Function0<T>) - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
OverlaySetting<T> - Class in akka.actor.mailbox.filebased.filequeue
 
OverlaySetting(Function0<T>) - Constructor for class akka.actor.mailbox.filebased.filequeue.OverlaySetting
 
owner() - Method in interface akka.actor.IO.Handle
 
owner() - Method in class akka.actor.IO.ServerHandle
 
owner() - Method in class akka.actor.IO.SocketHandle
 
owner() - Method in class akka.actor.mailbox.DurableMessageQueue
 
ownerPath() - Method in class akka.actor.mailbox.DurableMessageQueue
 
ownerPathString() - Method in class akka.actor.mailbox.DurableMessageQueue
 

P

pack() - Method in class akka.actor.mailbox.filebased.filequeue.QItem
 
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.
parse(Element, org.apache.aries.blueprint.ParserContext) - Method in class akka.osgi.aries.blueprint.NamespaceHandler
 
parseActorSystem(Element, org.apache.aries.blueprint.ParserContext) - Method in class akka.osgi.aries.blueprint.NamespaceHandler
 
parseArgs(List<String>) - Method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper$
 
parseArgs(List<String>) - Static method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper
 
parseConfig(Element, org.apache.aries.blueprint.ParserContext, org.apache.aries.blueprint.mutable.MutableBeanMetadata) - Method in class akka.osgi.aries.blueprint.NamespaceHandler
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.RemoteProtocol.ActorRefProtocol
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.ActorRefProtocol
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.RemoteProtocol.AddressProtocol
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.AddressProtocol
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.RemoteProtocol.DeployProtocol
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.DeployProtocol
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.RemoteProtocol.MessageProtocol
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.MessageProtocol
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.RemoteProtocol.PropsProtocol
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.PropsProtocol
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
parseDelimitedFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.RemoteProtocol.ActorRefProtocol
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.ActorRefProtocol
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.ActorRefProtocol
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.ActorRefProtocol
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.RemoteProtocol.ActorRefProtocol
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.ActorRefProtocol
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.RemoteProtocol.AddressProtocol
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.AddressProtocol
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.AddressProtocol
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.AddressProtocol
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.RemoteProtocol.AddressProtocol
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.AddressProtocol
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.RemoteProtocol.DeployProtocol
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.DeployProtocol
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.DeployProtocol
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.DeployProtocol
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.RemoteProtocol.DeployProtocol
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.DeployProtocol
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.RemoteProtocol.MessageProtocol
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.MessageProtocol
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.MessageProtocol
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.MessageProtocol
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.RemoteProtocol.MessageProtocol
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.MessageProtocol
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.RemoteProtocol.PropsProtocol
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.PropsProtocol
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.PropsProtocol
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.PropsProtocol
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.RemoteProtocol.PropsProtocol
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.PropsProtocol
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
parseFrom(com.google.protobuf.ByteString) - Static method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
parseFrom(com.google.protobuf.ByteString, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
parseFrom(byte[], com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
parseFrom(InputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
parseFrom(com.google.protobuf.CodedInputStream) - Static method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
parseFrom(com.google.protobuf.CodedInputStream, com.google.protobuf.ExtensionRegistryLite) - Static method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
parseUserpass(String) - Method in class akka.jmx.Client
Parse a 'login:password' string.
patch() - Method in class akka.zeromq.ZeroMQVersion
 
path() - Method in class akka.actor.ActorRef
Returns the path for this actor (from this actor up to the root actor).
path() - Method in class akka.actor.ActorSelection
 
path() - Method in class akka.actor.Deploy
 
path() - Method in class akka.event.Logging.StandardOutLogger
 
PATH_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.ActorRefProtocol
 
PATH_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
PATH_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.DeployProtocol
 
Patterns - Class in akka.pattern
 
Patterns() - Constructor for class akka.pattern.Patterns
 
Patterns$ - Class in akka.pattern
 
Patterns$() - Constructor for class akka.pattern.Patterns$
 
pauseReads() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
payload() - Method in class akka.remote.RemoteMessage
Returns the message
payload() - Method in class akka.zeromq.Frame
 
payload() - Method in interface akka.zeromq.PubSubOption
 
payload() - Method in class akka.zeromq.Subscribe
 
payload() - Method in class akka.zeromq.Unsubscribe
 
payload(int) - Method in class akka.zeromq.ZMQMessage
 
payloadClass() - Method in class akka.remote.RemoteMessage
 
peek(int) - Method in class akka.actor.IO$
An Iteratee that returns a ByteString of the request length, but does not consume the Input.
peek(int) - Static method in class akka.actor.IO
An Iteratee that returns a ByteString of the request length, but does not consume the Input.
peek() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
Peek at the head item in the queue, if there is one.
peek() - Method in class akka.util.BoundedBlockingQueue
 
PeekMailbox - Class in akka.contrib.mailbox
 
PeekMailbox(ActorRef, ActorSystem, int) - Constructor for class akka.contrib.mailbox.PeekMailbox
 
PeekMailboxExtension - Class in akka.contrib.mailbox
 
PeekMailboxExtension(ExtendedActorSystem) - Constructor for class akka.contrib.mailbox.PeekMailboxExtension
 
PeekMailboxExtension$ - Class in akka.contrib.mailbox
 
PeekMailboxExtension$() - Constructor for class akka.contrib.mailbox.PeekMailboxExtension$
 
PeekMailboxType - Class in akka.contrib.mailbox
configure the mailbox via dispatcher configuration: peek-dispatcher { mailbox-type = "example.PeekMailboxType" }
PeekMailboxType(ActorSystem.Settings, com.typesafe.config.Config) - Constructor for class akka.contrib.mailbox.PeekMailboxType
 
peer(Address) - Method in class akka.contrib.pattern.ClusterSingletonManager
 
PeriodicTasksInitialDelay() - Method in class akka.cluster.ClusterSettings
 
PersistentQueue - Class in akka.actor.mailbox.filebased.filequeue
 
PersistentQueue(String, String, FileBasedMailboxSettings, LoggingAdapter) - Constructor for class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
PersistentQueue$ - Class in akka.actor.mailbox.filebased.filequeue
 
PersistentQueue$() - Constructor for class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
phi(Address) - Method in class akka.cluster.AccrualFailureDetector
The suspicion level of the accrual failure detector.
pickHighestPriority(Set<Member>, Set<Member>) - Method in class akka.cluster.Member$
 
pickHighestPriority(Set<Member>, Set<Member>) - Static method in class akka.cluster.Member
 
pid() - Method in class akka.cluster.SigarMetricsCollector
 
PinnedDispatcher - Class in akka.dispatch
Dedicates a unique thread for each actor passed in as reference.
PinnedDispatcher(DispatcherPrerequisites, akka.actor.ActorCell, String, MailboxType, FiniteDuration, ThreadPoolConfig) - Constructor for class akka.dispatch.PinnedDispatcher
 
PinnedDispatcherConfigurator - Class in akka.dispatch
Configurator for creating PinnedDispatcher.
PinnedDispatcherConfigurator(com.typesafe.config.Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.PinnedDispatcherConfigurator
 
pipe(Future<T>, ExecutionContext) - Method in class akka.pattern.Patterns$
Register an onComplete callback on this Future to send the result to the given 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
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(long, TimeUnit) - Method in class akka.util.BoundedBlockingQueue
 
poll() - Method in class akka.util.BoundedBlockingQueue
 
PollDispatcher - Class in akka.zeromq
An option containing the configuration key for the poller loop dispatcher
PollDispatcher(String) - Constructor for class akka.zeromq.PollDispatcher
 
PollDispatcher$ - Class in akka.zeromq
 
PollDispatcher$() - Constructor for class akka.zeromq.PollDispatcher$
 
poller() - Method in class akka.zeromq.Context
 
PollTimeoutDuration - Class in akka.zeromq
An option containing the duration a poll cycle should wait for a message before it loops
PollTimeoutDuration(FiniteDuration) - Constructor for class akka.zeromq.PollTimeoutDuration
 
PollTimeoutDuration$ - Class in akka.zeromq
 
PollTimeoutDuration$() - Constructor for class akka.zeromq.PollTimeoutDuration$
 
pollTimeUnit() - Method in class akka.zeromq.ZeroMQExtension
 
port() - Method in class akka.actor.Address
 
PORT_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.AddressProtocol
 
pos() - Method in interface akka.actor.LoggingFSM
 
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.Stash
Overridden callback.
postStop() - Method in interface akka.actor.TypedActor.PostStop
User overridable callback.
postStop() - Method in class akka.actor.UntypedActor
User overridable callback.
postStop() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
postStop() - Method in class akka.testkit.TestActor
 
predicate() - Method in class akka.actor.dsl.Inbox.Select
 
PredicateClassifier - Interface in akka.event
Can be mixed into an EventBus to specify that the Classifier type is a Function from Event to Boolean (predicate)
prepend(T) - Method in interface akka.actor.mailbox.filebased.filequeue.Prependable
 
Prependable<T> - Interface in akka.actor.mailbox.filebased.filequeue
 
prerequisites() - Method in class akka.dispatch.Dispatchers
 
prerequisites() - Method in class akka.dispatch.MessageDispatcher
 
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.Stash
Overridden callback.
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 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.
preStart() - Method in interface akka.camel.Consumer
Registers the consumer endpoint.
preStart() - Method in interface akka.camel.ProducerSupport
 
preStart() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
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
 
processors() - Method in class akka.cluster.JmxMetricsCollector
(JMX) Returns the number of available processors Creates a new instance each time.
Processors() - Method in class akka.cluster.StandardMetrics$
 
processors() - Method in class akka.cluster.StandardMetrics.Cpu
 
Processors() - Static method in class akka.cluster.StandardMetrics
 
produce() - Method in interface akka.camel.ProducerSupport
Produces msg to the endpoint specified by endpointUri.
produce(org.apache.camel.Endpoint, org.apache.camel.processor.SendProcessor, Object, org.apache.camel.ExchangePattern) - Method in class akka.camel.ProducerSupport.ProducerChild
Initiates a message exchange of given pattern with the endpoint specified by endpointUri.
Producer - Interface in akka.camel
Mixed in by Actor implementations to produce messages to Camel endpoints.
ProducerSupport - Interface in akka.camel
Support trait for producing messages to Camel endpoints.
ProducerSupport.ProducerChild - Class in akka.camel
 
ProducerSupport.ProducerChild(org.apache.camel.Endpoint, org.apache.camel.processor.SendProcessor) - Constructor for class akka.camel.ProducerSupport.ProducerChild
 
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 ActorRef configuration object, that is immutable, so it is thread safe and fully sharable.
Props(Function0<Actor>, String, RouterConfig, Deploy) - Constructor for class akka.actor.Props
 
Props() - Constructor for class akka.actor.Props
No-args constructor that sets all the default values.
Props(UntypedActorFactory) - Constructor for class akka.actor.Props
Java API: create Props from an UntypedActorFactory
Props(Class<? extends Actor>) - Constructor for class akka.actor.Props
Java API: create Props from a given Class
props(BlockingDeque<TestActor.Message>) - Method in class akka.testkit.TestActor$
 
props(BlockingDeque<TestActor.Message>) - Static method in class akka.testkit.TestActor
 
Props$ - Class in akka.actor
Factory for Props instances.
Props$() - Constructor for class akka.actor.Props$
 
PROPS_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
ProtobufSerializer - Class in akka.remote.serialization
This Serializer serializes com.google.protobuf.Messages
ProtobufSerializer() - Constructor for class akka.remote.serialization.ProtobufSerializer
 
ProtobufSerializer$ - Class in akka.remote.serialization
 
ProtobufSerializer$() - Constructor for class akka.remote.serialization.ProtobufSerializer$
 
protocol() - Method in class akka.actor.Address
 
provider() - Method in interface akka.actor.ActorRefFactory
INTERNAL USE ONLY
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
 
provider() - Method in class akka.remote.RemoteTransport
 
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
 
publishCurrentClusterState() - Method in class akka.cluster.Cluster
Publish current (full) state of the cluster to subscribers, that are subscribing to ClusterEvent.ClusterDomainEvent or ClusterEvent.CurrentClusterState.
PublishStatsInterval() - Method in class akka.cluster.ClusterSettings
 
PubSubOption - Interface in akka.zeromq
A base trait for pubsub options for the ZeroMQ socket
pushTimeOut() - Method in class akka.dispatch.BoundedDequeBasedMailbox
 
pushTimeOut() - Method in interface akka.dispatch.BoundedDequeBasedMessageQueueSemantics
 
pushTimeOut() - Method in class akka.dispatch.BoundedMailbox
 
pushTimeOut() - Method in interface akka.dispatch.BoundedMessageQueueSemantics
 
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
put(K, V) - Method in class akka.util.internal.ConcurrentIdentityHashMap
Maps the specified key to the specified value in this table.
putAll(Map<? extends K, ? extends V>) - Method in class akka.util.internal.ConcurrentIdentityHashMap
Copies all of the mappings from the specified map to this one.
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.
putIfAbsent(K, V) - Method in class akka.util.internal.ConcurrentIdentityHashMap
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.
putLongs(long[], ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Longs from an array to this builder.
putLongs(long[], int, int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Longs from an array to this builder.
putShort(int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a single Short to this builder.
putShorts(short[], ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Shorts from an array to this builder.
putShorts(short[], int, int, ByteOrder) - Method in class akka.util.ByteStringBuilder
Add a number of Shorts from an array to this builder.

Q

QDumper - Class in akka.actor.mailbox.filebased.filequeue.tools
 
QDumper() - Constructor for class akka.actor.mailbox.filebased.filequeue.tools.QDumper
 
QDumper$ - Class in akka.actor.mailbox.filebased.filequeue.tools
 
QDumper$() - Constructor for class akka.actor.mailbox.filebased.filequeue.tools.QDumper$
 
QItem - Class in akka.actor.mailbox.filebased.filequeue
 
QItem(long, long, byte[], int) - Constructor for class akka.actor.mailbox.filebased.filequeue.QItem
 
QItem$ - Class in akka.actor.mailbox.filebased.filequeue
 
QItem$() - Constructor for class akka.actor.mailbox.filebased.filequeue.QItem$
 
queue() - Method in class akka.actor.mailbox.filebased.filequeue.tools.QueueDumper
 
queue() - Method in class akka.contrib.mailbox.PeekMailbox
 
queue() - Method in interface akka.dispatch.BoundedDequeBasedMessageQueueSemantics
 
queue() - Method in interface akka.dispatch.BoundedMessageQueueSemantics
 
queue() - Method in interface akka.dispatch.DequeBasedMessageQueue
 
queue() - Method in interface akka.dispatch.QueueBasedMessageQueue
 
queue() - Method in class akka.testkit.CallingThreadMailbox
 
queue() - Method in interface akka.testkit.TestKitBase
 
QueueBasedMessageQueue - Interface in akka.dispatch
A QueueBasedMessageQueue is a MessageQueue backed by a java.util.Queue
QueueCollection - Class in akka.actor.mailbox.filebased.filequeue
 
QueueCollection(String, FileBasedMailboxSettings, LoggingAdapter) - Constructor for class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
QueueDumper - Class in akka.actor.mailbox.filebased.filequeue.tools
 
QueueDumper(String, LoggingAdapter) - Constructor for class akka.actor.mailbox.filebased.filequeue.tools.QueueDumper
 
queueFactory() - Method in class akka.dispatch.ThreadPoolConfig
 
queueHits() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
queueMisses() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
queueNames() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
QueuePath() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
quiet() - Method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper$
 
quiet() - Static method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper
 

R

rampup(int, int) - Method in class akka.routing.DefaultResizer
Computes a proposed positive (or zero) capacity delta using the configured rampupRate.
rampupRate() - Method in class akka.routing.DefaultResizer
Percentage to increase capacity whenever all routees are busy.
random() - Method in class akka.util.Crypt$
 
random() - Static method in class akka.util.Crypt
 
RandomLike - Interface in akka.routing
The core pieces of the routing logic is located in this trait to be able to extend.
RandomRouter - Class in akka.routing
A Router that randomly selects one of the target connections to send a message to.
RandomRouter(int, Iterable<String>, Option<Resizer>, String, SupervisorStrategy) - Constructor for class akka.routing.RandomRouter
 
RandomRouter(int) - Constructor for class akka.routing.RandomRouter
Java API: Constructor that sets nrOfInstances to be created.
RandomRouter(Iterable<String>) - Constructor for class akka.routing.RandomRouter
Java API: Constructor that sets the routees to be used.
RandomRouter(Resizer) - Constructor for class akka.routing.RandomRouter
Java API: Constructor that sets the resizer to be used.
RandomRouter$ - Class in akka.routing
 
RandomRouter$() - Constructor for class akka.routing.RandomRouter$
 
rate() - Method in class akka.contrib.throttle.Throttler.SetRate
 
rate() - Method in class akka.contrib.throttle.TimerBasedThrottler
 
Rate - Class in akka.zeromq
Sets the maximum send or receive data rate for multicast transports such as pgm using the specified socket.
Rate(long) - Constructor for class akka.zeromq.Rate
 
rate() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its rate configuration.
rate() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its rate configuration.
Rate$ - Class in akka.zeromq
Gets the send or receive rate for the socket
Rate$() - Constructor for class akka.zeromq.Rate$
 
readBufferSize() - Method in class akka.actor.IOManager.Settings
 
readJournalEntry(FileChannel) - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
readView() - Method in class akka.cluster.Cluster
 
ready(Duration, CanAwait) - Method in class akka.testkit.TestLatch
 
reason() - Method in class akka.actor.FSM.StopEvent
 
receive() - Method in interface akka.actor.Actor
This defines the initial actor behavior, it must return a partial function with the actor logic.
receive() - Method in interface akka.actor.dsl.Creators.Act
Default behavior of the actor is empty, use become to change this.
receive(FiniteDuration) - Method in class akka.actor.dsl.Inbox.Inbox
Receive a single message from the internal receiver actor.
receive() - Method in class akka.actor.dsl.Inbox.InboxActor
 
receive() - Method in interface akka.actor.FSM
 
receive() - Method in class akka.actor.IOManagerActor
 
receive() - Method in class akka.actor.mailbox.DurableMailboxSpecActorFactory.AccumulatorActor
 
receive() - Method in class akka.actor.mailbox.DurableMailboxSpecActorFactory.MailboxTestActor
 
receive(String) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
receive() - Method in class akka.actor.UntypedActor
 
receive() - Method in interface akka.camel.Producer
Implementation of Actor.receive.
receive() - Method in class akka.camel.ProducerSupport.ProducerChild
 
receive() - Method in class akka.contrib.jul.JavaLoggingEventHandler
 
receive() - Method in class akka.contrib.pattern.ReliableProxy.Receiver
 
receive() - Method in class akka.event.Logging.DefaultLogger
 
receive() - Method in class akka.event.slf4j.Slf4jEventHandler
 
receive() - Method in interface akka.routing.Router
 
receive() - Method in class akka.testkit.TestActor
 
receive(Object) - Method in class akka.testkit.TestActorRef
Directly inject messages into actor receive behavior.
receive(Object, ActorRef) - Method in class akka.testkit.TestActorRef
Directly inject messages into actor receive behavior.
receive() - Method in class akka.testkit.TestActorRefSpec.Logger
 
receive() - Method in class akka.testkit.TestActorRefSpec.ReceiveTimeoutActor
 
receive() - Method in interface akka.testkit.TestActorRefSpec.TActor
 
receive() - Method in class akka.testkit.TestEventListener
 
receive() - Method in interface akka.transactor.Transactor
Implement a general pattern for using coordinated transactions.
ReceiveBufferSize - Class in akka.zeromq
The ReceiveBufferSize option shall set the underlying kernel receive buffer size for the socket to the specified size in bytes.
ReceiveBufferSize(long) - Constructor for class akka.zeromq.ReceiveBufferSize
 
receiveBufferSize() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its receive bufferSize configuration.
receiveBufferSize() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its receive bufferSize configuration.
ReceiveBufferSize$ - Class in akka.zeromq
Gets the ReceiveBufferSize
ReceiveBufferSize$() - Constructor for class akka.zeromq.ReceiveBufferSize$
 
ReceiveHighWatermark - Class in akka.zeromq
The ReceiveHighWatermark option shall set the high water mark for inbound messages on the specified socket.
ReceiveHighWatermark(long) - Constructor for class akka.zeromq.ReceiveHighWatermark
 
receiveHighWatermark() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its receive high watermark configuration.
receiveHighWatermark() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its receive high watermark configuration.
ReceiveHighWatermark$ - Class in akka.zeromq
Gets the ReceiveHighWatermark
ReceiveHighWatermark$() - Constructor for class akka.zeromq.ReceiveHighWatermark$
 
receiveMessage(RemoteMessage) - Method in class akka.remote.RemoteTransport
Call this method with an inbound RemoteMessage and this will take care of security (see: "useUntrustedMode") as well as making sure that the message ends up at its destination (best effort).
receiveN(int) - Method in interface akka.testkit.TestKitBase
Same as receiveN(n, remaining) but correctly taking into account Duration.timeFactor.
receiveN(int, FiniteDuration) - Method in interface akka.testkit.TestKitBase
Receive N messages in a row before the given deadline.
receiveN_internal(int, Duration) - Method in interface akka.testkit.TestKitBase
 
receiveOne(Duration) - Method in interface akka.testkit.TestKitBase
Receive one message from the internal queue of the TestActor.
receiver() - Method in class akka.actor.dsl.Inbox.Inbox
 
receiver(ActorRef) - Method in class akka.contrib.pattern.ReliableProxy$
 
receiver(ActorRef) - Static method in class akka.contrib.pattern.ReliableProxy
 
receiveT() - Method in class akka.testkit.TestActorRefSpec.ReplyActor
 
receiveT() - Method in class akka.testkit.TestActorRefSpec.SenderActor
 
receiveT() - Method in interface akka.testkit.TestActorRefSpec.TActor
 
receiveT() - Method in class akka.testkit.TestActorRefSpec.WorkerActor
 
receiveTimeout() - Method in interface akka.actor.ActorContext
Gets the current receive timeout.
ReceiveTimeout - Class in akka.actor
 
ReceiveTimeout() - Constructor for class akka.actor.ReceiveTimeout
 
ReceiveTimeout$ - Class in akka.actor
When using ActorContext.setReceiveTimeout, the singleton instance of ReceiveTimeout will be sent to the Actor when there hasn't been any message for that long.
ReceiveTimeout$() - Constructor for class akka.actor.ReceiveTimeout$
 
receiveWhile(Duration, Duration, int, PartialFunction<Object, T>) - Method in interface akka.testkit.TestKitBase
Receive a series of messages until one does not match the given partial function or the idle timeout is met (disabled by default) or the overall maximum duration is elapsed.
recipient() - Method in class akka.actor.DeadLetter
 
recipient() - Method in class akka.actor.UnhandledMessage
 
recipient() - Method in class akka.remote.RemoteMessage
Returns a reference to the Actor that this message is destined for.
recipient() - Method in class akka.routing.Destination
 
RECIPIENT_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
ReconnectIVL - Class in akka.zeromq
Sets the recovery interval for multicast transports using the specified socket.
ReconnectIVL(long) - Constructor for class akka.zeromq.ReconnectIVL
 
reconnectIVL() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its reconnect interval configuration.
reconnectIVL() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its reconnect interval configuration.
ReconnectIVL$ - Class in akka.zeromq
Gets the recover interval @see akka.zeromq.ReconnectIVL
ReconnectIVL$() - Constructor for class akka.zeromq.ReconnectIVL$
 
ReconnectIVLMax - Class in akka.zeromq
The ReconnectIVLMax option shall set the maximum reconnection interval for the specified socket.
ReconnectIVLMax(long) - Constructor for class akka.zeromq.ReconnectIVLMax
 
reconnectIVLMax() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its max reconnect interval configuration.
reconnectIVLMax() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its max reconnect interval configuration.
ReconnectIVLMax$ - Class in akka.zeromq
Gets the max reconnect IVL
ReconnectIVLMax$() - Constructor for class akka.zeromq.ReconnectIVLMax$
 
Recover<T> - Class in akka.dispatch
Callback for the Future.recover operation that conditionally turns failures into successes.
Recover() - Constructor for class akka.dispatch.Recover
 
recover(Throwable) - Method in class akka.dispatch.Recover
This method will be invoked once when/if the Future this recover callback is registered on becomes completed with a failure.
RecoveryInterval - Class in akka.zeromq
Sets the recovery interval for multicast transports using the specified socket.
RecoveryInterval(long) - Constructor for class akka.zeromq.RecoveryInterval
 
recoveryInterval() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its recovery interval configuration.
recoveryInterval() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its recovery interval configuration.
RecoveryInterval$ - Class in akka.zeromq
Gets the RecoveryInterval
RecoveryInterval$() - Constructor for class akka.zeromq.RecoveryInterval$
 
recurseCompositeData(StringBuffer, String, String, CompositeData) - Method in class akka.jmx.Client
 
recurseTabularData(StringBuffer, String, String, TabularData) - Method in class akka.jmx.Client
 
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 interface akka.routing.Router
 
ref() - Method in class akka.testkit.TestActor.UnWatch
 
ref() - Method in class akka.testkit.TestActor.Watch
 
ref() - Method in class akka.testkit.TestProbe
Shorthand to get the testActor.
ReflectiveDynamicAccess - Class in akka.actor
This is the default DynamicAccess implementation used by 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() - Method in interface akka.camel.Consumer
 
register() - Method in interface akka.camel.ProducerSupport
 
register(ActorRef, PeekMailbox) - Method in class akka.contrib.mailbox.PeekMailboxExtension
 
register(akka.actor.ActorCell) - Method in class akka.dispatch.BalancingDispatcher
 
register(akka.actor.ActorCell) - Method in class akka.dispatch.MessageDispatcher
If you override it, you must call it.
register(akka.actor.ActorCell) - Method in class akka.dispatch.PinnedDispatcher
 
register(akka.actor.ActorCell) - Method in class akka.testkit.CallingThreadDispatcher
 
registerAllExtensions(com.google.protobuf.ExtensionRegistry) - Static method in class akka.remote.RemoteProtocol
 
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
registerExtraNames(Map<String, InternalActorRef>) - Method in class akka.actor.LocalActorRefProvider
Higher-level providers (or extensions) might want to register new synthetic top-level paths for doing special stuff.
registerForExecution(Mailbox, boolean, boolean) - Method in class akka.dispatch.Dispatcher
Returns if it was registered INTERNAL USE ONLY
registerForExecution(Mailbox, boolean, boolean) - Method in class akka.dispatch.MessageDispatcher
Suggest to register the provided mailbox for execution INTERNAL API
registerForExecution(akka.dispatch.Mailbox, boolean, boolean) - Method in class akka.testkit.CallingThreadDispatcher
 
registerOnMemberUp(Function0<T>) - Method in class akka.cluster.Cluster
The supplied thunk will be run, once, when current cluster member is Up.
registerOnMemberUp(Runnable) - Method in class akka.cluster.Cluster
Java API: The supplied callback will be run, once, when current cluster member is Up.
registerOnTermination(Function0<T>) - Method in class akka.actor.ActorSystem
Register a block of code (callback) to run after ActorSystem.shutdown has been issued and all actors in this actor system have been stopped.
registerOnTermination(Runnable) - Method in class akka.actor.ActorSystem
Java API: Register a block of code (callback) to run after ActorSystem.shutdown has been issued and all actors in this actor system have been stopped.
registerRoutees(Iterable<ActorRef>) - Method in class akka.routing.RouteeProvider
Adds the routees to the router.
registerRoutees(Iterable<ActorRef>) - Method in class akka.routing.RouteeProvider
Java API: Adds the routees to the router.
registerRouteesFor(Iterable<String>) - Method in class akka.remote.routing.RemoteRouteeProvider
 
registerRouteesFor(Iterable<String>) - Method in class akka.routing.RouteeProvider
Looks up routes with specified paths and registers them.
registerRouteesFor(Iterable<String>) - Method in class akka.routing.RouteeProvider
Java API: Looks up routes with specified paths and registers them.
registerService(org.osgi.framework.BundleContext, ActorSystem) - Method in class akka.osgi.ActorSystemActivator
Register the actor system in the OSGi service registry.
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.
registerTempActor(InternalActorRef, ActorPath) - Method in class akka.actor.LocalActorRefProvider
 
registerTempActor(akka.actor.InternalActorRef, ActorPath) - Method in class akka.remote.RemoteActorRefProvider
 
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$
 
ReliableProxy - Class in akka.contrib.pattern
A ReliableProxy is a means to wrap a remote actor reference in order to obtain certain improved delivery guarantees: - as long as none of the JVMs crashes and the proxy and its remote-deployed peer are not forcefully terminated or restarted, no messages will be lost - messages re-sent due to the first point will not be delivered out-of-order, message ordering is preserved These guarantees are valid for the communication between the two end-points of the reliable “tunnel”, which usually spans an unreliable network.
ReliableProxy(ActorRef, FiniteDuration) - Constructor for class akka.contrib.pattern.ReliableProxy
 
ReliableProxy$ - Class in akka.contrib.pattern
 
ReliableProxy$() - Constructor for class akka.contrib.pattern.ReliableProxy$
 
ReliableProxy.Ack - Class in akka.contrib.pattern
 
ReliableProxy.Ack(int) - Constructor for class akka.contrib.pattern.ReliableProxy.Ack
 
ReliableProxy.Ack$ - Class in akka.contrib.pattern
 
ReliableProxy.Ack$() - Constructor for class akka.contrib.pattern.ReliableProxy.Ack$
 
ReliableProxy.Active$ - Class in akka.contrib.pattern
 
ReliableProxy.Active$() - Constructor for class akka.contrib.pattern.ReliableProxy.Active$
 
ReliableProxy.Idle$ - Class in akka.contrib.pattern
 
ReliableProxy.Idle$() - Constructor for class akka.contrib.pattern.ReliableProxy.Idle$
 
ReliableProxy.Message - Class in akka.contrib.pattern
 
ReliableProxy.Message(Object, ActorRef, int) - Constructor for class akka.contrib.pattern.ReliableProxy.Message
 
ReliableProxy.Message$ - Class in akka.contrib.pattern
 
ReliableProxy.Message$() - Constructor for class akka.contrib.pattern.ReliableProxy.Message$
 
ReliableProxy.Receiver - Class in akka.contrib.pattern
 
ReliableProxy.Receiver(ActorRef) - Constructor for class akka.contrib.pattern.ReliableProxy.Receiver
 
ReliableProxy.State - Interface in akka.contrib.pattern
 
ReliableProxy.Tick$ - Class in akka.contrib.pattern
 
ReliableProxy.Tick$() - Constructor for class akka.contrib.pattern.ReliableProxy.Tick$
 
remaining() - Method in interface akka.testkit.TestKitBase
Obtain time remaining for execution of the innermost enclosing within block or missing that it returns the properly dilated default for this case from settings (key "akka.test.single-expect-default").
remainingCapacity() - Method in class akka.util.BoundedBlockingQueue
 
remainingDuration() - Method in exception akka.pattern.CircuitBreakerOpenException
 
remainingOr(FiniteDuration) - Method in interface akka.testkit.TestKitBase
Obtain time remaining for execution of the innermost enclosing within block or missing that it returns the given duration.
remainingOrDilated(Duration) - Method in interface akka.testkit.TestKitBase
 
remote() - Method in class akka.remote.RemoteClientConnected
 
remote() - Method in class akka.remote.RemoteClientDisconnected
 
remote() - Method in class akka.remote.RemoteClientError
 
remote() - Method in class akka.remote.RemoteClientShutdown
 
remote() - Method in class akka.remote.RemoteClientStarted
 
remote() - Method in class akka.remote.RemoteServerClientClosed
 
remote() - Method in class akka.remote.RemoteServerClientConnected
 
remote() - Method in class akka.remote.RemoteServerClientDisconnected
 
remote() - Method in class akka.remote.RemoteServerError
 
remote() - Method in class akka.remote.RemoteServerShutdown
 
remote() - Method in class akka.remote.RemoteServerStarted
 
RemoteActorRefProvider - Class in akka.remote
Remote ActorRefProvider.
RemoteActorRefProvider(String, ActorSystem.Settings, EventStream, Scheduler, DynamicAccess) - Constructor for class akka.remote.RemoteActorRefProvider
 
remoteAddress() - Method in class akka.remote.RemoteClientConnected
 
remoteAddress() - Method in class akka.remote.RemoteClientDisconnected
 
remoteAddress() - Method in class akka.remote.RemoteClientError
 
remoteAddress() - Method in exception akka.remote.RemoteClientException
 
remoteAddress() - Method in interface akka.remote.RemoteClientLifeCycleEvent
 
remoteAddress() - Method in class akka.remote.RemoteClientShutdown
 
remoteAddress() - Method in class akka.remote.RemoteClientStarted
 
RemoteClientConnected - Class in akka.remote
RemoteClientConnected is published when a RemoteClient's connection is established
RemoteClientConnected(RemoteTransport, Address) - Constructor for class akka.remote.RemoteClientConnected
 
RemoteClientConnected$ - Class in akka.remote
 
RemoteClientConnected$() - Constructor for class akka.remote.RemoteClientConnected$
 
RemoteClientDisconnected - Class in akka.remote
RemoteClientDisconnected is published when a RemoteClient's connection is disconnected
RemoteClientDisconnected(RemoteTransport, Address) - Constructor for class akka.remote.RemoteClientDisconnected
 
RemoteClientDisconnected$ - Class in akka.remote
 
RemoteClientDisconnected$() - Constructor for class akka.remote.RemoteClientDisconnected$
 
RemoteClientError - Class in akka.remote
A RemoteClientError is a general error that is thrown within or from a RemoteClient
RemoteClientError(Throwable, RemoteTransport, Address) - Constructor for class akka.remote.RemoteClientError
 
RemoteClientError$ - Class in akka.remote
 
RemoteClientError$() - Constructor for class akka.remote.RemoteClientError$
 
RemoteClientException - Exception in akka.remote
Thrown for example when trying to send a message using a RemoteClient that is either not started or shut down.
RemoteClientException$ - Class in akka.remote
 
RemoteClientException$() - Constructor for class akka.remote.RemoteClientException$
 
RemoteClientLifeCycleEvent - Interface in akka.remote
Life-cycle events for RemoteClient.
RemoteClientShutdown - Class in akka.remote
RemoteClientShutdown is published when a RemoteClient has shut down
RemoteClientShutdown(RemoteTransport, Address) - Constructor for class akka.remote.RemoteClientShutdown
 
RemoteClientShutdown$ - Class in akka.remote
 
RemoteClientShutdown$() - Constructor for class akka.remote.RemoteClientShutdown$
 
RemoteClientStarted - Class in akka.remote
RemoteClientStarted is published when a RemoteClient has started up
RemoteClientStarted(RemoteTransport, Address) - Constructor for class akka.remote.RemoteClientStarted
 
RemoteClientStarted$ - Class in akka.remote
 
RemoteClientStarted$() - Constructor for class akka.remote.RemoteClientStarted$
 
remoteDaemon() - Method in class akka.remote.RemoteActorRefProvider
 
RemoteLifeCycleEvent - Interface in akka.remote
Remote life-cycle events.
RemoteMessage - Class in akka.remote
RemoteMessage is a wrapper around a message that has come in over the wire, it allows to easily obtain references to the deserialized message, its intended recipient and the sender.
RemoteMessage(RemoteProtocol.RemoteMessageProtocol, ExtendedActorSystem) - Constructor for class akka.remote.RemoteMessage
 
RemoteProtocol - Class in akka.remote
 
RemoteProtocol.ActorRefProtocol - Class in akka.remote
 
RemoteProtocol.ActorRefProtocol.Builder - Class in akka.remote
 
RemoteProtocol.ActorRefProtocolOrBuilder - Interface in akka.remote
 
RemoteProtocol.AddressProtocol - Class in akka.remote
 
RemoteProtocol.AddressProtocol.Builder - Class in akka.remote
 
RemoteProtocol.AddressProtocolOrBuilder - Interface in akka.remote
 
RemoteProtocol.AkkaRemoteProtocol - Class in akka.remote
 
RemoteProtocol.AkkaRemoteProtocol.Builder - Class in akka.remote
 
RemoteProtocol.AkkaRemoteProtocolOrBuilder - Interface in akka.remote
 
RemoteProtocol.CommandType - Enum in akka.remote
 
RemoteProtocol.DaemonMsgCreateProtocol - Class in akka.remote
 
RemoteProtocol.DaemonMsgCreateProtocol.Builder - Class in akka.remote
 
RemoteProtocol.DaemonMsgCreateProtocolOrBuilder - Interface in akka.remote
 
RemoteProtocol.DeployProtocol - Class in akka.remote
 
RemoteProtocol.DeployProtocol.Builder - Class in akka.remote
 
RemoteProtocol.DeployProtocolOrBuilder - Interface in akka.remote
 
RemoteProtocol.MessageProtocol - Class in akka.remote
 
RemoteProtocol.MessageProtocol.Builder - Class in akka.remote
 
RemoteProtocol.MessageProtocolOrBuilder - Interface in akka.remote
 
RemoteProtocol.MetadataEntryProtocol - Class in akka.remote
 
RemoteProtocol.MetadataEntryProtocol.Builder - Class in akka.remote
 
RemoteProtocol.MetadataEntryProtocolOrBuilder - Interface in akka.remote
 
RemoteProtocol.PropsProtocol - Class in akka.remote
 
RemoteProtocol.PropsProtocol.Builder - Class in akka.remote
 
RemoteProtocol.PropsProtocolOrBuilder - Interface in akka.remote
 
RemoteProtocol.RemoteControlProtocol - Class in akka.remote
 
RemoteProtocol.RemoteControlProtocol.Builder - Class in akka.remote
 
RemoteProtocol.RemoteControlProtocolOrBuilder - Interface in akka.remote
 
RemoteProtocol.RemoteMessageProtocol - Class in akka.remote
 
RemoteProtocol.RemoteMessageProtocol.Builder - Class in akka.remote
 
RemoteProtocol.RemoteMessageProtocolOrBuilder - Interface in akka.remote
 
RemoteRouteeProvider - Class in akka.remote.routing
Factory and registry for routees of the router.
RemoteRouteeProvider(Iterable<Address>, ActorContext, Props, Option<Resizer>) - Constructor for class akka.remote.routing.RemoteRouteeProvider
 
RemoteRouterConfig - Class in akka.remote.routing
RouterConfig implementation for remote deployment on defined target nodes.
RemoteRouterConfig(RouterConfig, Iterable<Address>) - Constructor for class akka.remote.routing.RemoteRouterConfig
 
RemoteRouterConfig(RouterConfig, Iterable<Address>) - Constructor for class akka.remote.routing.RemoteRouterConfig
 
RemoteRouterConfig(RouterConfig, Address[]) - Constructor for class akka.remote.routing.RemoteRouterConfig
 
RemoteRouterConfig$ - Class in akka.remote.routing
 
RemoteRouterConfig$() - Constructor for class akka.remote.routing.RemoteRouterConfig$
 
RemoteScope - Class in akka.remote
 
RemoteScope(Address) - Constructor for class akka.remote.RemoteScope
 
RemoteScope$ - Class in akka.remote
 
RemoteScope$() - Constructor for class akka.remote.RemoteScope$
 
RemoteServerClientClosed - Class in akka.remote
RemoteServerClientClosed is published when an inbound RemoteClient is closed
RemoteServerClientClosed(RemoteTransport, Option<Address>) - Constructor for class akka.remote.RemoteServerClientClosed
 
RemoteServerClientClosed$ - Class in akka.remote
 
RemoteServerClientClosed$() - Constructor for class akka.remote.RemoteServerClientClosed$
 
RemoteServerClientConnected - Class in akka.remote
RemoteServerClientConnected is published when an inbound connection has been established
RemoteServerClientConnected(RemoteTransport, Option<Address>) - Constructor for class akka.remote.RemoteServerClientConnected
 
RemoteServerClientConnected$ - Class in akka.remote
 
RemoteServerClientConnected$() - Constructor for class akka.remote.RemoteServerClientConnected$
 
RemoteServerClientDisconnected - Class in akka.remote
RemoteServerClientConnected is published when an inbound connection has been disconnected
RemoteServerClientDisconnected(RemoteTransport, Option<Address>) - Constructor for class akka.remote.RemoteServerClientDisconnected
 
RemoteServerClientDisconnected$ - Class in akka.remote
 
RemoteServerClientDisconnected$() - Constructor for class akka.remote.RemoteServerClientDisconnected$
 
RemoteServerError - Class in akka.remote
A RemoteServerError is a general error that is thrown within or from a RemoteServer
RemoteServerError(Throwable, RemoteTransport) - Constructor for class akka.remote.RemoteServerError
 
RemoteServerError$ - Class in akka.remote
 
RemoteServerError$() - Constructor for class akka.remote.RemoteServerError$
 
RemoteServerLifeCycleEvent - Interface in akka.remote
Life-cycle events for RemoteServer.
RemoteServerShutdown - Class in akka.remote
RemoteServerShutdown is published when a local RemoteServer has shut down
RemoteServerShutdown(RemoteTransport) - Constructor for class akka.remote.RemoteServerShutdown
 
RemoteServerShutdown$ - Class in akka.remote
 
RemoteServerShutdown$() - Constructor for class akka.remote.RemoteServerShutdown$
 
RemoteServerStarted - Class in akka.remote
RemoteServerStarted is published when a local RemoteServer has started up
RemoteServerStarted(RemoteTransport) - Constructor for class akka.remote.RemoteServerStarted
 
RemoteServerStarted$ - Class in akka.remote
 
RemoteServerStarted$() - Constructor for class akka.remote.RemoteServerStarted$
 
remoteSettings() - Method in class akka.remote.RemoteActorRefProvider
 
RemoteSettings - Class in akka.remote
 
RemoteSettings(com.typesafe.config.Config, String) - Constructor for class akka.remote.RemoteSettings
 
RemoteSystemDaemonAckTimeout() - Method in class akka.remote.RemoteSettings
 
RemoteTransport() - Method in class akka.remote.RemoteSettings
 
RemoteTransport - Class in akka.remote
The remote transport is responsible for sending and receiving messages.
RemoteTransport(ExtendedActorSystem, RemoteActorRefProvider) - Constructor for class akka.remote.RemoteTransport
 
RemoteTransportException - Exception in akka.remote
RemoteTransportException represents a general failure within a RemoteTransport, such as inability to start, wrong configuration etc.
RemoteTransportException(String, Throwable) - Constructor for exception akka.remote.RemoteTransportException
 
remove() - Method in class akka.actor.mailbox.filebased.FileBasedMessageQueue
Completely delete the queue.
remove() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
remove(boolean) - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
Remove and return an item from the queue, if there is one.
remove() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
Remove and return an item from the queue, if there is one.
remove(String, int, boolean, boolean, Function1<Option<QItem>, BoxedUnit>) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
Retrieve an item from a queue and pass it to a continuation.
remove(Address) - Method in class akka.cluster.AccrualFailureDetector
Removes the heartbeat management for a connection.
remove(Address) - Method in interface akka.cluster.FailureDetector
Removes the heartbeat management for a connection.
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
remove(Object) - Method in class akka.util.internal.ConcurrentIdentityHashMap
Removes the key (and its corresponding value) from this map.
remove(Object, Object) - Method in class akka.util.internal.ConcurrentIdentityHashMap
removeAll(Collection<?>) - Method in class akka.util.BoundedBlockingQueue
 
removed() - Method in class akka.cluster.MemberStatus$
Java API: retrieve the “removed” status singleton
removed() - Static method in class akka.cluster.MemberStatus
Java API: retrieve the “removed” status singleton
removed() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
removeFilter(EventFilter) - Method in class akka.testkit.TestEventListener
 
removeFromCache(Seq<Tuple2<Object, Set<Object>>>) - Method in interface akka.event.SubchannelClassification
 
removeMetadata(int) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
removeRoutees(int, FiniteDuration) - Method in class akka.routing.RouteeProvider
Remove specified number of routees by unregister them and sending PoisonPill after the specified delay.
removeTentative() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
removeValue(V) - Method in class akka.util.Index
Removes the specified value from all keys
repeat() - Method in class akka.actor.FSM.Timer
 
repeat(IO.Iteratee<T>) - Method in class akka.actor.IO$
An Iteratee that continually repeats an Iteratee.
repeat(IO.Iteratee<T>) - Static method in class akka.actor.IO
An Iteratee that continually repeats an Iteratee.
replace(K, V, V) - Method in class akka.util.internal.ConcurrentIdentityHashMap
replace(K, V) - Method in class akka.util.internal.ConcurrentIdentityHashMap
replay(String, Function1<JournalItem, BoxedUnit>) - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
replayJournal() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
replies() - Method in class akka.actor.FSM.State
 
reply(Object) - Method in class akka.testkit.JavaTestKit
 
reply(Object) - Method in class akka.testkit.TestProbe
Send message to the sender of the last dequeued message.
replying(Object) - Method in class akka.actor.FSM.State
Send reply to sender of the current message, if available.
ReplyTimeout() - Method in class akka.camel.CamelSettings
Configured setting, when endpoint is out-capable (can produce responses) replyTimeout is the maximum time the endpoint can take to send the response before the message exchange fails.
replyTimeout() - Method in interface akka.camel.Consumer
When endpoint is out-capable (can produce responses) replyTimeout is the maximum time the endpoint can take to send the response before the message exchange fails.
replyTo() - Method in class akka.testkit.TestActorRefSpec.ReplyActor
 
reportFailure(Throwable) - Method in class akka.dispatch.MessageDispatcher
 
Request - Interface in akka.zeromq
Marker trait representing request messages for zeromq
requestRestartPermission(Tuple2<Option<Object>, Option<Object>>) - Method in class akka.actor.ChildRestartStats
 
RESCHEDULED() - Static method in class akka.dispatch.MessageDispatcher
 
reset() - Method in class akka.cluster.AccrualFailureDetector
 
reset() - Method in interface akka.cluster.FailureDetector
Removes all connections and starts over.
reset() - Method in class akka.testkit.TestBarrier
 
reset() - Method in class akka.testkit.TestLatch
 
resetStreamCache() - Method in class akka.camel.CamelMessage
Reset StreamCache body.
resetTimeout() - Method in class akka.cluster.CircuitBreakerSettings
 
resize(RouteeProvider) - Method in class akka.routing.DefaultResizer
 
resize(RouteeProvider) - Method in interface akka.routing.Resizer
Decide if the capacity of the router need to be changed.
resizer() - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
 
resizer() - Method in class akka.cluster.routing.ClusterRouterConfig
 
resizer() - Method in class akka.remote.routing.RemoteRouterConfig
 
resizer() - Method in class akka.routing.BroadcastRouter
 
resizer() - Method in class akka.routing.ConsistentHashingRouter
 
resizer() - Method in class akka.routing.RandomRouter
 
Resizer - Interface in akka.routing
Routers with dynamically resizable number of routees is implemented by providing a Resizer implementation in RouterConfig.
resizer() - Method in class akka.routing.RoundRobinRouter
 
resizer() - Method in class akka.routing.RouteeProvider
 
resizer() - Method in interface akka.routing.RouterConfig
Routers with dynamically resizable number of routees return the Resizer to use.
resizer() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
resizer() - Method in class akka.routing.SmallestMailboxRouter
 
resolveClass(ObjectStreamClass) - Method in class akka.util.ClassLoaderObjectInputStream
 
Response - Interface in akka.zeromq
Base trait for the events raised by a ZeroMQ socket actor
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.
restartClientConnection(Address) - Method in class akka.remote.RemoteTransport
Restarts a specific client connected to the supplied remote address, but only if the client is not shut down
restartTimeWindowStartNanos() - Method in class akka.actor.ChildRestartStats
 
result() - Method in class akka.actor.IO.Done
 
result(Duration, CanAwait) - Method in class akka.testkit.TestLatch
 
result() - Method in class akka.util.ByteStringBuilder
 
Resume() - Method in interface akka.actor.dsl.Creators.Act
 
resume() - Method in class akka.actor.SupervisorStrategy$
Java API: Returning this directive resumes message processing for the failed Actor
resume() - Static method in class akka.actor.SupervisorStrategy
Java API: Returning this directive resumes message processing for the failed Actor
resume() - Method in class akka.agent.Agent
Resumes processing of send actions for the agent.
resume(akka.actor.ActorCell) - Method in class akka.dispatch.MessageDispatcher
 
resume(akka.actor.ActorCell) - Method in class akka.testkit.CallingThreadDispatcher
 
resumeChild(ActorRef, Throwable) - Method in class akka.actor.SupervisorStrategy
Resume the previously failed child: do never apply this to a child which is not the currently failing child.
resumeReads() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
retainAll(Collection<?>) - Method in class akka.util.BoundedBlockingQueue
 
ReusableIterator<E> - Interface in akka.util.internal
 
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
 
rewind() - Method in interface akka.util.internal.ReusableIterator
 
roll(int, List<QItem>, Iterable<QItem>) - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
root() - Method in interface akka.actor.ActorPath
Walk up the tree to obtain and return the RootActorPath.
root() - Method in class akka.actor.ChildActorPath
 
root() - Method in class akka.actor.RootActorPath
 
root() - Method in class akka.event.slf4j.Logger$
Returns the SLF4J Root Logger
root() - Static method in class akka.event.slf4j.Logger
Returns the SLF4J Root Logger
RootActorPath - Class in akka.actor
Root of the hierarchy of ActorPaths.
RootActorPath(Address, String) - Constructor for class akka.actor.RootActorPath
 
RootActorPath$ - Class in akka.actor
 
RootActorPath$() - Constructor for class akka.actor.RootActorPath$
 
rootGuardian() - Method in interface akka.actor.ActorRefProvider
Reference to the supervisor of guardian and systemGuardian; this is exposed so that the ActorSystemImpl can use it as lookupRoot, i.e.
rootGuardian() - Method in class akka.actor.LocalActorRefProvider
 
rootGuardian() - Method in class akka.remote.RemoteActorRefProvider
 
rootGuardianStrategy() - Method in class akka.actor.LocalActorRefProvider
Overridable supervision strategy to be used by the “/user” guardian.
rootPath() - Method in interface akka.actor.ActorRefProvider
The root path for all actors within this actor system, not including any remote address information.
rootPath() - Method in class akka.actor.LocalActorRefProvider
 
rootPath() - Method in class akka.remote.RemoteActorRefProvider
 
RoundRobinLike - Interface in akka.routing
The core pieces of the routing logic is located in this trait to be able to extend.
RoundRobinRouter - Class in akka.routing
A Router that uses round-robin to select a connection.
RoundRobinRouter(int, Iterable<String>, Option<Resizer>, String, SupervisorStrategy) - Constructor for class akka.routing.RoundRobinRouter
 
RoundRobinRouter(int) - Constructor for class akka.routing.RoundRobinRouter
Java API: Constructor that sets nrOfInstances to be created.
RoundRobinRouter(Iterable<String>) - Constructor for class akka.routing.RoundRobinRouter
Java API: Constructor that sets the routees to be used.
RoundRobinRouter(Resizer) - Constructor for class akka.routing.RoundRobinRouter
Java API: Constructor that sets the resizer to be used.
RoundRobinRouter$ - Class in akka.routing
 
RoundRobinRouter$() - Constructor for class akka.routing.RoundRobinRouter$
 
routeeProps() - Method in class akka.routing.RouteeProvider
 
RouteeProvider - Class in akka.routing
Factory and registry for routees of the router.
RouteeProvider(ActorContext, Props, Option<Resizer>) - Constructor for class akka.routing.RouteeProvider
 
routees() - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
 
routees() - Method in interface akka.cluster.routing.AdaptiveLoadBalancingRouterLike
 
routees() - Method in interface akka.routing.BroadcastLike
 
routees() - Method in class akka.routing.BroadcastRouter
 
routees() - Method in interface akka.routing.ConsistentHashingLike
 
routees() - Method in class akka.routing.ConsistentHashingRouter
 
routees() - Method in interface akka.routing.RandomLike
 
routees() - Method in class akka.routing.RandomRouter
 
routees() - Method in interface akka.routing.RoundRobinLike
 
routees() - Method in class akka.routing.RoundRobinRouter
 
routees() - Method in class akka.routing.RouteeProvider
All routees of the router
routees() - Method in class akka.routing.RouterRoutees
 
routees() - Method in interface akka.routing.ScatterGatherFirstCompletedLike
 
routees() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
routees() - Method in interface akka.routing.SmallestMailboxLike
 
routees() - Method in class akka.routing.SmallestMailboxRouter
 
routeesPath() - Method in class akka.cluster.routing.ClusterRouterSettings
 
routeesPathElements() - Method in class akka.cluster.routing.ClusterRouterSettings
 
Router - Interface in akka.routing
Base trait for Router actors.
Router.Resize$ - Class in akka.routing
 
Router.Resize$() - Constructor for class akka.routing.Router.Resize$
 
routerConfig() - Method in class akka.actor.Deploy
 
routerConfig() - Method in class akka.actor.Props
 
RouterConfig - Interface in akka.routing
This trait represents a router factory: it produces the actual router actor and creates the routing table (a function which determines the recipients for each message which is to be dispatched).
ROUTERCONFIG_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.DeployProtocol
 
ROUTERCONFIG_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.PropsProtocol
 
routerDispatcher() - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
 
routerDispatcher() - Method in interface akka.cluster.routing.AdaptiveLoadBalancingRouterLike
 
routerDispatcher() - Method in class akka.cluster.routing.ClusterRouterConfig
 
routerDispatcher() - Method in class akka.remote.routing.RemoteRouterConfig
 
routerDispatcher() - Method in class akka.routing.BroadcastRouter
 
routerDispatcher() - Method in class akka.routing.ConsistentHashingRouter
 
routerDispatcher() - Method in class akka.routing.FromConfig
 
routerDispatcher() - Method in class akka.routing.NoRouter$
 
routerDispatcher() - Static method in class akka.routing.NoRouter
 
routerDispatcher() - Method in class akka.routing.RandomRouter
 
routerDispatcher() - Method in class akka.routing.RoundRobinRouter
 
routerDispatcher() - Method in interface akka.routing.RouterConfig
Dispatcher ID to use for running the “head” actor, i.e. 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.
routeResponse(Object) - Method in class akka.camel.javaapi.UntypedProducerActor
 
routeResponse(Object) - Method in interface akka.camel.ProducerSupport
Called after a response was received from the endpoint specified by endpointUri.
routerReceive() - Method in interface akka.routing.Router
 
RouterRoutees - Class in akka.routing
Message used to carry information about what routees the router is currently using.
RouterRoutees(Iterable<ActorRef>) - Constructor for class akka.routing.RouterRoutees
 
RouterRoutees$ - Class in akka.routing
 
RouterRoutees$() - Constructor for class akka.routing.RouterRoutees$
 
run() - Method in class akka.dispatch.TaskInvocation
 
run() - Method in class akka.testkit.JavaTestKit.EventFilter
 
run() - Method in class akka.testkit.JavaTestKit.Within
 
run(ActorRef, Object) - Method in class akka.testkit.TestActor.AutoPilot
 
run(ActorRef, Object) - Method in class akka.testkit.TestActor.KeepRunning$
 
run(ActorRef, Object) - Method in class akka.testkit.TestActor.NoAutoPilot$
 
run(Timeout) - Method in interface akka.util.internal.TimerTask
Executed after the delay specified with Timer#newTimeout(TimerTask, long, java.util.concurrent.TimeUnit) .
runnable() - Method in class akka.dispatch.TaskInvocation
 

S

sameAs(Metric) - Method in class akka.cluster.Metric
Returns true if that is tracking the same metric as this.
sameAs(NodeMetrics) - Method in class akka.cluster.NodeMetrics
Returns true if that address is the same as this
sample() - Method in class akka.cluster.JmxMetricsCollector
Samples and collects new data points.
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, ActorRef, Object, ExecutionContext) - Method in class akka.actor.DefaultScheduler
 
schedule(FiniteDuration, FiniteDuration, Function0<BoxedUnit>, ExecutionContext) - Method in class akka.actor.DefaultScheduler
 
schedule(FiniteDuration, FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.DefaultScheduler
 
schedule(ActorRef, FiniteDuration) - Method in class akka.actor.FSM.Timer
 
schedule(FiniteDuration, FiniteDuration, ActorRef, Object, ExecutionContext) - 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.DefaultScheduler
 
scheduleOnce(FiniteDuration, ActorRef, Object, ExecutionContext) - Method in class akka.actor.DefaultScheduler
 
scheduleOnce(FiniteDuration, Function0<BoxedUnit>, ExecutionContext) - Method in class akka.actor.DefaultScheduler
 
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.
scheduleOnce(FiniteDuration, ActorRef, Object, ExecutionContext) - 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.
scheduler() - Method in interface akka.actor.ActorRefProvider
 
scheduler() - Method in class akka.actor.ActorSystem
Light-weight scheduler for running asynchronous tasks after some deadline in the future.
scheduler() - Method in class akka.actor.LocalActorRefProvider
 
Scheduler - Interface in akka.actor
An Akka scheduler service.
scheduler() - Method in class akka.cluster.Cluster
INTERNAL API
scheduler() - Method in interface akka.dispatch.DispatcherPrerequisites
 
scheduler() - Method in class akka.remote.RemoteActorRefProvider
 
SchedulerTickDuration() - Method in class akka.actor.ActorSystem.Settings
 
SchedulerTickDuration() - Method in class akka.cluster.ClusterSettings
 
SchedulerTicksPerWheel() - Method in class akka.actor.ActorSystem.Settings
 
SchedulerTicksPerWheel() - Method in class akka.cluster.ClusterSettings
 
scheduleTick() - Method in class akka.contrib.pattern.ReliableProxy
 
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.
SCOPE_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.DeployProtocol
 
SEED() - Method in class akka.util.HashCode$
 
SEED() - Static method in class akka.util.HashCode
 
SeedNodes() - Method in class akka.cluster.ClusterSettings
 
SeedNodeTimeout() - Method in class akka.cluster.ClusterSettings
 
seenBy() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
 
select(FiniteDuration, PartialFunction<Object, T>) - Method in class akka.actor.dsl.Inbox.Inbox
Receive a single message for which the given partial function is defined and return the transformed result, using the internal receiver actor.
selectInterval() - Method in class akka.actor.IOManager.Settings
 
SelectionPath - Interface in akka.actor
ActorRefFactory.actorSelection returns a special ref which sends these nested path descriptions whenever using !
selectors() - Method in class akka.cluster.routing.MixMetricsSelector
 
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.

self() - Method in class akka.testkit.CallingThreadMailbox
 
self() - Method in interface akka.testkit.ImplicitSender
 
selfAddress() - Method in class akka.cluster.Cluster
 
selfAddressOption() - Method in class akka.contrib.pattern.ClusterSingletonManager
 
send(Function1<T, T>) - Method in class akka.agent.Agent
Dispatch a function to update the internal state.
send(T) - Method in class akka.agent.Agent
Dispatch a new value for the internal state.
send(Function<T, T>) - Method in class akka.agent.Agent
Java API: Dispatch a function to update the internal state.
send(Object) - Method in class akka.contrib.pattern.ReliableProxy
 
send(Object, Option<ActorRef>, RemoteActorRef) - Method in class akka.remote.RemoteTransport
Sends the given message to the recipient supplying the sender if any
send(ActorRef, Object) - Method in class akka.testkit.JavaTestKit
 
send(ActorRef, Object) - Method in class akka.testkit.TestProbe
Send message to an actor while using the probe's TestActor as the sender.
Send - Class in akka.zeromq
Send a message over the zeromq socket
Send(Seq<Frame>) - Constructor for class akka.zeromq.Send
 
Send$ - Class in akka.zeromq
 
Send$() - Constructor for class akka.zeromq.Send$
 
SendBufferSize - Class in akka.zeromq
The SendBufferSize option shall set the underlying kernel transmit buffer size for the socket to the specified size in bytes.
SendBufferSize(long) - Constructor for class akka.zeromq.SendBufferSize
 
sendBufferSize() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its send buffer size configuration.
sendBufferSize() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its send buffer size configuration.
SendBufferSize$ - Class in akka.zeromq
Gets the SendBufferSize
SendBufferSize$() - Constructor for class akka.zeromq.SendBufferSize$
 
SendCircuitBreakerSettings() - Method in class akka.cluster.ClusterSettings
 
sendCurrentClusterState(ActorRef) - Method in class akka.cluster.Cluster
Publish current (full) state of the cluster to the specified receiver.
sender() - Method in interface akka.actor.Actor
The reference sender Actor of the last received message.
sender() - Method in interface akka.actor.ActorContext
Returns the sender 'ActorRef' of the current message.
sender() - Method in class akka.actor.DeadLetter
 
sender() - Method in class akka.actor.UnhandledMessage
 
sender() - Method in class akka.contrib.pattern.ReliableProxy.Message
 
sender() - Method in class akka.dispatch.Envelope
 
sender() - Method in class akka.remote.RemoteMessage
Returns a reference to the Actor that sent this message, or DeadLetterActorRef if not present or found.
sender() - Method in class akka.routing.Destination
 
sender() - Method in interface akka.testkit.TestActor.Message
 
sender() - Method in class akka.testkit.TestActor.NullMessage$
 
sender() - Method in class akka.testkit.TestActor.RealMessage
 
sender() - Method in class akka.testkit.TestProbe
Get sender of last received message.
SENDER_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
senderFromInbox(Inbox.Inbox) - Method in interface akka.actor.dsl.Inbox
 
SendHighWatermark - Class in akka.zeromq
The SendHighWatermark option shall set the high water mark for outbound messages on the specified socket.
SendHighWatermark(long) - Constructor for class akka.zeromq.SendHighWatermark
 
sendHighWatermark() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its send high watermark configuration.
sendHighWatermark() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its send high watermark configuration.
SendHighWatermark$ - Class in akka.zeromq
Gets the SendHWM
SendHighWatermark$() - Constructor for class akka.zeromq.SendHighWatermark$
 
sendOff(Function1<T, T>, ExecutionContext) - Method in class akka.agent.Agent
Dispatch a function to update the internal state but on its own thread.
sendOff(Function<T, T>, ExecutionContext) - Method in class akka.agent.Agent
Java API: Dispatch a function to update the internal state but on its own thread.
SendTo - Class in akka.transactor
Used for specifying actor refs and messages to send to during coordination.
SendTo(ActorRef, Option<Object>) - Constructor for class akka.transactor.SendTo
 
sendTo(Seq<Tuple2<ActorRef, Object>>) - Method in interface akka.transactor.Transactor
Include other actors in this coordinated transaction and specify the message to send by providing ActorRef -> Message pairs.
sendTo(ActorRef) - Method in class akka.transactor.UntypedTransactor
For including another actor in this coordinated transaction and sending them the same message as received.
sendTo(ActorRef, Object) - Method in class akka.transactor.UntypedTransactor
For including another actor in this coordinated transaction and specifying the message to send.
SendTo$ - Class in akka.transactor
 
SendTo$() - Constructor for class akka.transactor.SendTo$
 
seq(T...) - Static method in class akka.japi.JAPI
 
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).
serial() - Method in class akka.contrib.pattern.ReliableProxy.Ack
 
serial() - Method in class akka.contrib.pattern.ReliableProxy.Message
 
serialization() - Method in class akka.remote.RemoteActorRefProvider
 
Serialization - Class in akka.serialization
Serialization module.
Serialization(ExtendedActorSystem) - Constructor for class akka.serialization.Serialization
 
Serialization$ - Class in akka.serialization
 
Serialization$() - Constructor for class akka.serialization.Serialization$
 
Serialization.Settings - Class in akka.serialization
 
Serialization.Settings(com.typesafe.config.Config) - Constructor for class akka.serialization.Serialization.Settings
 
SerializationBindings() - Method in class akka.serialization.Serialization.Settings
 
SerializationExtension - Class in akka.serialization
SerializationExtension is an Akka Extension to interact with the Serialization that is built into Akka
SerializationExtension() - Constructor for class akka.serialization.SerializationExtension
 
SerializationExtension$ - Class in akka.serialization
SerializationExtension is an Akka Extension to interact with the Serialization that is built into Akka
SerializationExtension$() - Constructor for class akka.serialization.SerializationExtension$
 
serialize(Envelope) - Method in interface akka.actor.mailbox.DurableMessageSerialization
Serializes the given Envelope into an Array of Bytes using an efficient serialization/deserialization strategy
serialize(Object) - Method in class akka.serialization.Serialization
Serializes the given AnyRef/java.lang.Object according to the Serialization configuration to either an Array of Bytes or an Exception if one was thrown.
serializeActorRef(ActorRef) - Method in class akka.remote.serialization.ProtobufSerializer$
Helper to serialize an ActorRef to Akka's protobuf representation.
serializeActorRef(ActorRef) - Static method in class akka.remote.serialization.ProtobufSerializer
Helper to serialize an ActorRef to Akka's protobuf representation.
SerializeAllCreators() - Method in class akka.actor.ActorSystem.Settings
 
SerializeAllMessages() - Method in class akka.actor.ActorSystem.Settings
 
Serializer - Interface in akka.serialization
A Serializer represents a bimap between an object and an array of bytes representing that object.
serializerByIdentity() - Method in class akka.serialization.Serialization
Maps from a Serializer Identity (Int) to a Serializer instance (optimization)
serializerFor(Class<?>) - Method in class akka.serialization.Serialization
Returns the configured Serializer for the given Class.
SERIALIZERID_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.MessageProtocol
 
serializerOf(String) - Method in class akka.serialization.Serialization
 
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
 
set(long) - Method in class akka.actor.mailbox.filebased.filequeue.Counter
 
set(Option<T>) - Method in class akka.actor.mailbox.filebased.filequeue.OverlaySetting
 
setAllowCoreThreadTimeout(boolean) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
setAutoPilot(TestActor.AutoPilot) - Method in class akka.testkit.JavaTestKit
 
setAutoPilot(TestActor.AutoPilot) - Method in interface akka.testkit.TestKitBase
Install an AutoPilot to drive the testActor: the AutoPilot will be run for each received message and can be used to send or forward messages, etc.
setCommandType(RemoteProtocol.CommandType) - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
setConfig(String) - Method in class akka.osgi.aries.blueprint.BlueprintActorSystemFactory
 
setConfig(com.google.protobuf.ByteString) - Method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
setCookie(String) - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
setCorePoolSize(int) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
setCorePoolSizeFromFactor(int, double, int) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
setCreator(com.google.protobuf.ByteString) - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
setDeploy(RemoteProtocol.DeployProtocol) - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
setDeploy(RemoteProtocol.DeployProtocol.Builder) - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
setDeploy(RemoteProtocol.DeployProtocol) - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
setDeploy(RemoteProtocol.DeployProtocol.Builder) - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
setDispatcher(String) - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
setFromClassCreator(String) - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
setHostname(String) - Method in class akka.remote.RemoteProtocol.AddressProtocol.Builder
 
setInstruction(RemoteProtocol.RemoteControlProtocol) - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
setInstruction(RemoteProtocol.RemoteControlProtocol.Builder) - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
setKeepAliveTime(Duration) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
setKeepAliveTimeInMillis(long) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
setKey(String) - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol.Builder
 
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
 
setMessage(RemoteProtocol.RemoteMessageProtocol) - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
setMessage(RemoteProtocol.RemoteMessageProtocol.Builder) - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol.Builder
 
setMessage(com.google.protobuf.ByteString) - Method in class akka.remote.RemoteProtocol.MessageProtocol.Builder
 
setMessage(RemoteProtocol.MessageProtocol) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
setMessage(RemoteProtocol.MessageProtocol.Builder) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
setMessageManifest(com.google.protobuf.ByteString) - Method in class akka.remote.RemoteProtocol.MessageProtocol.Builder
 
setMetadata(int, RemoteProtocol.MetadataEntryProtocol) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
setMetadata(int, RemoteProtocol.MetadataEntryProtocol.Builder) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
setOrigin(RemoteProtocol.AddressProtocol) - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
setOrigin(RemoteProtocol.AddressProtocol.Builder) - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol.Builder
 
setPath(String) - Method in class akka.remote.RemoteProtocol.ActorRefProtocol.Builder
 
setPath(String) - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
setPath(String) - Method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
setPort(int) - Method in class akka.remote.RemoteProtocol.AddressProtocol.Builder
 
setProps(RemoteProtocol.PropsProtocol) - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
setProps(RemoteProtocol.PropsProtocol.Builder) - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
setQueueFactory(Function0<BlockingQueue<Runnable>>) - Method in class akka.dispatch.ThreadPoolConfigBuilder
 
setRawResult(BoxedUnit) - Method in class akka.dispatch.ForkJoinExecutorConfigurator.MailboxExecutionTask
 
setReceiveTimeout(Duration) - Method in interface akka.actor.ActorContext
Defines the inactivity timeout after which the sending of a ReceiveTimeout message is triggered.
setRecipient(RemoteProtocol.ActorRefProtocol) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
setRecipient(RemoteProtocol.ActorRefProtocol.Builder) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
setRouterConfig(com.google.protobuf.ByteString) - Method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
setRouterConfig(com.google.protobuf.ByteString) - Method in class akka.remote.RemoteProtocol.PropsProtocol.Builder
 
setScope(com.google.protobuf.ByteString) - Method in class akka.remote.RemoteProtocol.DeployProtocol.Builder
 
setSender(RemoteProtocol.ActorRefProtocol) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
setSender(RemoteProtocol.ActorRefProtocol.Builder) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol.Builder
 
setSerializerId(int) - Method in class akka.remote.RemoteProtocol.MessageProtocol.Builder
 
setState(S, D, FiniteDuration, Option<FSM.Reason>) - Method in class akka.testkit.TestFSMRef
Change FSM state; any value left out defaults to the current FSM state (timeout defaults to None).
setStateTimeout(S, Option<FiniteDuration>) - Method in interface akka.actor.FSM
Set state timeout explicitly.
setSupervisor(RemoteProtocol.ActorRefProtocol) - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
setSupervisor(RemoteProtocol.ActorRefProtocol.Builder) - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol.Builder
 
setSystem(String) - Method in class akka.remote.RemoteProtocol.AddressProtocol.Builder
 
setTimer(String, Object, FiniteDuration, boolean) - Method in interface akka.actor.FSM
Schedule named timer to deliver message after given delay, possibly repeating.
setTimer(String, Object, FiniteDuration, boolean) - Method in class akka.testkit.TestFSMRef
Proxy for FSM.setTimer.
settings() - Method in interface akka.actor.ActorRefProvider
The Settings associated with this ActorRefProvider
settings() - Method in class akka.actor.ActorSystem
The core settings extracted from the supplied configuration.
settings() - Method in class akka.actor.IOManager
 
settings() - Method in class akka.actor.IOManagerActor
 
settings() - Method in class akka.actor.LocalActorRefProvider
 
settings() - Method in class akka.actor.mailbox.filebased.FileBasedMessageQueue
 
settings() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
settings() - Method in interface akka.camel.Camel
The settings for the CamelExtension
settings() - Method in class akka.cluster.Cluster
 
settings() - Method in class akka.cluster.routing.ClusterRouterConfig
 
settings() - Method in interface akka.dispatch.DispatcherPrerequisites
 
settings() - Method in class akka.dispatch.Dispatchers
 
settings() - Method in class akka.remote.RemoteActorRefProvider
 
settings() - Method in class akka.serialization.Serialization
 
settings() - Method in interface akka.transactor.Transactor
 
setup() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
setUpStdoutLogger(ActorSystem.Settings) - Method in interface akka.event.LoggingBus
 
setValue(com.google.protobuf.ByteString) - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol.Builder
 
sha1(String) - Method in class akka.util.Crypt$
 
sha1(byte[]) - Method in class akka.util.Crypt$
 
sha1(String) - Static method in class akka.util.Crypt
 
sha1(byte[]) - Static method in class akka.util.Crypt
 
shutdown() - Method in class akka.actor.ActorSystem
Stop this actor system.
shutdown() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
Shutdown this queue collection.
shutdown() - Method in class akka.dispatch.Dispatcher
INTERNAL USE ONLY
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
shutdown() - Method in interface akka.kernel.Bootable
Callback run on microkernel shutdown.
shutdown() - Method in class akka.remote.RemoteTransport
Shuts down the remoting
shutdown() - Method in class akka.testkit.CallingThreadDispatcher
 
SHUTDOWN_VALUE - Static variable in enum akka.remote.RemoteProtocol.CommandType
 
shutdownClientConnection(Address) - Method in class akka.remote.RemoteTransport
Shuts down a specific client connected to the supplied remote address returns true if successful
shutdownNow() - Method in interface akka.dispatch.ExecutorServiceDelegate
 
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
shutdownTimeout() - Method in class akka.testkit.CallingThreadDispatcher
 
SigarMetricsCollector - Class in akka.cluster
Loads metrics through Hyperic SIGAR and JMX monitoring beans.
SigarMetricsCollector(Address, double, Object) - Constructor for class akka.cluster.SigarMetricsCollector
 
SigarMetricsCollector(ActorSystem) - Constructor for class akka.cluster.SigarMetricsCollector
This constructor is used when creating an instance from configured FQCN
simpleName(Object) - Method in class akka.event.Logging$
Returns a 'safe' getSimpleName for the provided object's Class
simpleName(Class<?>) - Method in class akka.event.Logging$
Returns a 'safe' getSimpleName for the provided Class
simpleName(Object) - Static method in class akka.event.Logging
Returns a 'safe' getSimpleName for the provided object's Class
simpleName(Class<?>) - Static method in class akka.event.Logging
Returns a 'safe' getSimpleName for the provided Class
SingleExpectDefaultTimeout() - Method in class akka.testkit.TestKitSettings
 
size() - Method in class akka.actor.IO.ReceiveBufferSize
 
size() - Method in class akka.actor.IO.SendBufferSize
 
size() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
size() - Method in class akka.util.BoundedBlockingQueue
 
size() - Method in class akka.util.internal.ConcurrentIdentityHashMap
Returns the number of key-value mappings in this map.
sizeHint(int) - Method in class akka.util.ByteStringBuilder
 
Slf4jEventHandler - Class in akka.event.slf4j
SLF4J Event Handler.
Slf4jEventHandler() - Constructor for class akka.event.slf4j.Slf4jEventHandler
 
SLF4JLogging - Interface in akka.event.slf4j
Base trait for all classes that wants to be able use the SLF4J logging infrastructure.
slice(int, int) - Method in class akka.util.ByteIterator
 
slice(int, int) - Method in class akka.util.ByteString.ByteString1C
 
slice(int, int) - Method in class akka.util.ByteString
 
SmallestMailboxLike - Interface in akka.routing
The core pieces of the routing logic is located in this trait to be able to extend.
SmallestMailboxRouter - Class in akka.routing
A Router that tries to send to the non-suspended routee with fewest messages in mailbox.
SmallestMailboxRouter(int, Iterable<String>, Option<Resizer>, String, SupervisorStrategy) - Constructor for class akka.routing.SmallestMailboxRouter
 
SmallestMailboxRouter(int) - Constructor for class akka.routing.SmallestMailboxRouter
Java API: Constructor that sets nrOfInstances to be created.
SmallestMailboxRouter(Iterable<String>) - Constructor for class akka.routing.SmallestMailboxRouter
Java API: Constructor that sets the routees to be used.
SmallestMailboxRouter(Resizer) - Constructor for class akka.routing.SmallestMailboxRouter
Java API: Constructor that sets the resizer to be used.
SmallestMailboxRouter$ - Class in akka.routing
 
SmallestMailboxRouter$() - Constructor for class akka.routing.SmallestMailboxRouter$
 
smoothValue() - Method in class akka.cluster.Metric
The numerical value of the average, if defined, otherwise the latest value
socket() - Method in class akka.actor.IO.Accept
 
socket() - Method in class akka.actor.IO.Connect
 
socket() - Method in class akka.actor.IO.Connected
 
socket(SocketType.ZMQSocketType) - Method in class akka.zeromq.Context
 
SocketConnectOption - Interface in akka.zeromq
A base trait for connection options for a ZeroMQ socket
SocketMeta - Interface in akka.zeromq
Marker trait representing the base for all meta operations for a socket such as the context, listener, socket type and poller dispatcher
SocketOption - Interface in akka.zeromq
Marker trait representing the base for all socket options
SocketOptionQuery - Interface in akka.zeromq
A marker trait to group option queries together
SocketType - Class in akka.zeromq
The different socket types you can create with zeromq
SocketType() - Constructor for class akka.zeromq.SocketType
 
SocketType$ - Class in akka.zeromq
The different socket types you can create with zeromq
SocketType$() - Constructor for class akka.zeromq.SocketType$
 
SocketType.Dealer$ - Class in akka.zeromq
A dealer socket
SocketType.Dealer$() - Constructor for class akka.zeromq.SocketType.Dealer$
 
SocketType.Pair$ - Class in akka.zeromq
A Pair socket
SocketType.Pair$() - Constructor for class akka.zeromq.SocketType.Pair$
 
SocketType.Pub$ - Class in akka.zeromq
A Publisher socket
SocketType.Pub$() - Constructor for class akka.zeromq.SocketType.Pub$
 
SocketType.Pull$ - Class in akka.zeromq
A pull socket
SocketType.Pull$() - Constructor for class akka.zeromq.SocketType.Pull$
 
SocketType.Push$ - Class in akka.zeromq
A push socket
SocketType.Push$() - Constructor for class akka.zeromq.SocketType.Push$
 
SocketType.Rep$ - Class in akka.zeromq
A reply socket
SocketType.Rep$() - Constructor for class akka.zeromq.SocketType.Rep$
 
SocketType.Req$ - Class in akka.zeromq
A request socket
SocketType.Req$() - Constructor for class akka.zeromq.SocketType.Req$
 
SocketType.Router$ - Class in akka.zeromq
A router socket
SocketType.Router$() - Constructor for class akka.zeromq.SocketType.Router$
 
SocketType.Sub$ - Class in akka.zeromq
A subscriber socket
SocketType.Sub$() - Constructor for class akka.zeromq.SocketType.Sub$
 
SocketType.ZMQSocketType - Class in akka.zeromq
 
SocketType.ZMQSocketType(int) - Constructor for class akka.zeromq.SocketType.ZMQSocketType
 
some(A) - Method in class akka.japi.Option$
Option factory that creates Some
some(A) - Static method in class akka.japi.Option
Option factory that creates Some
source() - Method in class akka.testkit.DebugFilter
 
source() - Method in class akka.testkit.ErrorFilter
 
source() - Method in class akka.testkit.EventFilter
 
source() - Method in class akka.testkit.InfoFilter
 
source() - Method in class akka.testkit.WarningFilter
 
span(Function1<Object, Object>) - Method in class akka.util.ByteIterator
 
span(Function1<Object, Object>) - Method in class akka.util.ByteString
 
spawn(String, Function0<BoxedUnit>) - Method in class akka.testkit.AkkaSpec
 
splitAt(int) - Method in class akka.util.ByteString
 
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
StandardMetrics - Class in akka.cluster
Definitions of the built-in standard metrics.
StandardMetrics() - Constructor for class akka.cluster.StandardMetrics
 
StandardMetrics$ - Class in akka.cluster
Definitions of the built-in standard metrics.
StandardMetrics$() - Constructor for class akka.cluster.StandardMetrics$
 
StandardMetrics.Cpu - Class in akka.cluster
 
StandardMetrics.Cpu(Address, long, Option<Object>, Option<Object>, int) - Constructor for class akka.cluster.StandardMetrics.Cpu
 
StandardMetrics.Cpu$ - Class in akka.cluster
 
StandardMetrics.Cpu$() - Constructor for class akka.cluster.StandardMetrics.Cpu$
 
StandardMetrics.HeapMemory - Class in akka.cluster
The amount of used and committed memory will always be <= max if max is defined.
StandardMetrics.HeapMemory(Address, long, long, long, Option<Object>) - Constructor for class akka.cluster.StandardMetrics.HeapMemory
 
StandardMetrics.HeapMemory$ - Class in akka.cluster
 
StandardMetrics.HeapMemory$() - Constructor for class akka.cluster.StandardMetrics.HeapMemory$
 
StandardOutLogger() - Method in class akka.event.Logging$
 
StandardOutLogger() - Static method in class akka.event.Logging
 
start(org.osgi.framework.BundleContext) - Method in class akka.osgi.ActorSystemActivator
Sets up a new ActorSystem
start() - Method in class akka.remote.RemoteTransport
Start up the transport, i.e. enable incoming connections.
start() - Method in class akka.util.internal.HashedWheelTimer
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.
startReadBehind() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
startStdoutLogger(ActorSystem.Settings) - Method in interface akka.event.LoggingBus
Internal Akka use only
startsWith(String) - Method in class akka.testkit.JavaTestKit.EventFilter
 
startTime() - Method in class akka.actor.ActorSystem
Start-up time in milliseconds since the epoch.
startup() - Method in interface akka.kernel.Bootable
Callback run on microkernel startup.
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.Stash
Adds the current message (the message that the actor received last) to the actor's stash.
StashOverflowException - Exception in akka.actor
Is thrown when the size of the Stash exceeds the capacity of the Stash
StashOverflowException(String, Throwable) - Constructor for exception akka.actor.StashOverflowException
 
StashOverflowException$ - Class in akka.actor
 
StashOverflowException$() - Constructor for class akka.actor.StashOverflowException$
 
state() - Method in class akka.actor.FSM.CurrentState
 
stateData() - Method in class akka.actor.FSM.Event
 
stateData() - Method in class akka.actor.FSM.LogEntry
 
stateData() - Method in class akka.actor.FSM.State
 
stateData() - Method in interface akka.actor.FSM
Return current state data (i.e. object of type D)
stateData() - Method in class akka.actor.FSM.StopEvent
 
stateData() - Method in class akka.testkit.TestFSMRef
Get current state data of this FSM.
stateFunctions() - Method in interface akka.actor.FSM
 
stateName() - Method in class akka.actor.FSM.LogEntry
 
stateName() - Method in class akka.actor.FSM.State
 
stateName() - Method in interface akka.actor.FSM
Return current state name (i.e. object of type S)
stateName() - Method in class akka.testkit.TestFSMRef
Get current state name of this FSM.
states() - Method in interface akka.actor.LoggingFSM
 
StateTimeout() - Method in interface akka.actor.FSM
This case object is received in case of a state timeout.
stateTimeouts() - Method in interface akka.actor.FSM
 
stats(String) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
Status - Class in akka.actor
Classes for passing status back to the sender.
Status() - Constructor for class akka.actor.Status
 
status() - Method in class akka.actor.Status.Success
 
status() - Method in class akka.cluster.Member
 
Status$ - 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.SupervisorStrategy$
Java API: Returning this directive stops the Actor Java API
stop() - Static method in class akka.actor.SupervisorStrategy
Java API: Returning this directive stops the Actor Java API
stop(Object) - Method in interface akka.actor.TypedActorFactory
Stops the underlying ActorRef for the supplied TypedActor proxy, if any, returns whether it could find the find the ActorRef or not
stop(org.osgi.framework.BundleContext) - Method in class akka.osgi.ActorSystemActivator
Shuts down the ActorSystem when the bundle is stopped and, if necessary, unregisters a service registration.
stop() - Method in class akka.util.internal.HashedWheelTimer
 
stop() - Method in interface akka.util.internal.Timer
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
 
StreamingCache() - Method in class akka.camel.CamelSettings
enables or disables streamingCache on the Camel Context
streamMustContain(InputStream, String) - Method in class akka.actor.mailbox.DurableMailboxSpec
 
stringHash(String) - Method in class akka.routing.MurmurHash$
Compute a high-quality hash of a string
stringHash(String) - Static method in class akka.routing.MurmurHash
Compute a high-quality hash of a string
SubchannelClassification - Interface in akka.event
Classification which respects relationships between channels: subscribing to one channel automatically and idempotently subscribes to all sub-channels.
SubchannelEventBus<E,S,C> - Class in akka.event.japi
See documentation for SubchannelClassification E is the Event type S is the Subscriber type C is the Classifier type
SubchannelEventBus() - Constructor for class akka.event.japi.SubchannelEventBus
 
subclassification() - Method in class akka.event.EventStream
 
subclassification() - Method in interface akka.event.SubchannelClassification
 
Subclassification<K> - Interface in akka.util
Typeclass which describes a classification hierarchy.
submit(Callable<T>) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
submit(Runnable, T) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
submit(Runnable) - Method in interface akka.dispatch.ExecutorServiceDelegate
 
subscribe(ActorRef, Class<?>) - Method in class akka.cluster.Cluster
Subscribe to cluster domain events.
subscribe(ActorRef, ActorRef) - Method in interface akka.event.ActorClassification
 
subscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.EventBus
Attempts to register the subscriber to the specified Classifier
subscribe(ActorRef, Class<?>) - Method in class akka.event.EventStream
 
subscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.LookupClassification
 
subscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.ScanningClassification
 
subscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.SubchannelClassification
 
Subscribe - Class in akka.zeromq
The Subscribe option establishes a new message filter on a akka.zeromq.SocketType.Pub socket.
Subscribe(Seq<Object>) - Constructor for class akka.zeromq.Subscribe
 
Subscribe(String) - Constructor for class akka.zeromq.Subscribe
 
Subscribe$ - Class in akka.zeromq
 
Subscribe$() - Constructor for class akka.zeromq.Subscribe$
 
subscribers() - Method in interface akka.event.LookupClassification
 
subscribers() - Method in interface akka.event.ScanningClassification
 
subscriptions() - Method in interface akka.event.SubchannelClassification
 
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.
supervisor() - Method in interface akka.camel.Camel
For internal use only.
SUPERVISOR_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
supervisorStrategy() - Method in interface akka.actor.Actor
User overridable definition the strategy to use for supervising child actors.
supervisorStrategy() - Method in interface akka.actor.dsl.Creators.Act
 
SupervisorStrategy - Class in akka.actor
An Akka SupervisorStrategy is the policy to apply for crashing children.
SupervisorStrategy() - Constructor for class akka.actor.SupervisorStrategy
 
supervisorStrategy() - Method in interface akka.actor.TypedActor.Supervisor
User overridable definition the strategy to use for supervising child actors.
supervisorStrategy() - Method in class akka.actor.UntypedActor
User overridable definition the strategy to use for supervising child actors.
supervisorStrategy() - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
 
supervisorStrategy() - Method in class akka.cluster.routing.ClusterRouterConfig
 
supervisorStrategy() - Method in class akka.contrib.pattern.ReliableProxy
 
supervisorStrategy() - Method in class akka.remote.routing.RemoteRouterConfig
 
supervisorStrategy() - Method in class akka.routing.BroadcastRouter
 
supervisorStrategy() - Method in class akka.routing.ConsistentHashingRouter
 
supervisorStrategy() - Method in class akka.routing.FromConfig
 
supervisorStrategy() - Method in class akka.routing.NoRouter$
 
supervisorStrategy() - Static method in class akka.routing.NoRouter
 
supervisorStrategy() - Method in class akka.routing.RandomRouter
 
supervisorStrategy() - Method in class akka.routing.RoundRobinRouter
 
supervisorStrategy() - Method in interface akka.routing.RouterConfig
SupervisorStrategy for the created Router actor.
supervisorStrategy() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
supervisorStrategy() - Method in class akka.routing.SmallestMailboxRouter
 
SupervisorStrategy$ - Class in akka.actor
 
SupervisorStrategy$() - Constructor for class akka.actor.SupervisorStrategy$
 
SupervisorStrategy.Directive - Interface in akka.actor
 
SupervisorStrategy.Escalate$ - Class in akka.actor
Escalates the failure to the supervisor of the supervisor, by rethrowing the cause of the failure.
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() - Method in class akka.agent.Agent
Suspends processing of send actions for the agent.
suspend(akka.actor.ActorCell) - Method in class akka.dispatch.MessageDispatcher
After the call to this method, the dispatcher mustn't begin any new message processing for the specified reference
suspend(akka.actor.ActorCell) - Method in class akka.testkit.CallingThreadDispatcher
 
suspendSwitch() - Method in class akka.testkit.CallingThreadMailbox
 
Swap - Class in akka.zeromq
The Swap option shall set the disk offload (swap) size for the specified socket.
Swap(long) - Constructor for class akka.zeromq.Swap
 
swap() - Method in class akka.zeromq.ZeroMQ$
The message to ask a ZeroMQ socket for its swap configuration.
swap() - Static method in class akka.zeromq.ZeroMQ
The message to ask a ZeroMQ socket for its swap configuration.
Swap$ - Class in akka.zeromq
Gets the Swap
Swap$() - Constructor for class akka.zeromq.Swap$
 
Switch - Class in akka.util
An atomic switch that can be either on or off
Switch(boolean) - Constructor for class akka.util.Switch
 
Switch$ - Class in akka.util
 
Switch$() - Constructor for class akka.util.Switch$
 
switchOff(Function0<BoxedUnit>) - Method in class akka.util.Switch
Executes the provided action if the lock is on under a lock, so be _very_ careful with longrunning/blocking operations in it Only executes the action if the switch is on, and switches it off immediately after obtaining the lock Will switch it back on if the provided action throws an exception
switchOff() - Method in class akka.util.Switch
Switches the switch off (if on), uses locking
switchOn(Function0<BoxedUnit>) - Method in class akka.util.Switch
Executes the provided action if the lock is off under a lock, so be _very_ careful with longrunning/blocking operations in it Only executes the action if the switch is off, and switches it on immediately after obtaining the lock Will switch it back off if the provided action throws an exception
switchOn() - Method in class akka.util.Switch
Switches the switch on (if off), uses locking
symmetricHash(TraversableOnce<T>, int) - Method in class akka.routing.MurmurHash$
Compute a hash that is symmetric in its arguments--that is, where the order of appearance of elements does not matter.
symmetricHash(TraversableOnce<T>, int) - Static method in class akka.routing.MurmurHash
Compute a hash that is symmetric in its arguments--that is, where the order of appearance of elements does not matter.
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.
syncExecutionContext() - Method in class akka.pattern.CircuitBreaker$
Synchronous execution context to run in caller's thread - used by companion object factory methods
syncExecutionContext() - Static method in class akka.pattern.CircuitBreaker
Synchronous execution context to run in caller's thread - used by companion object factory methods
synchronousQueue(boolean) - Method in class akka.dispatch.ThreadPoolConfig$
 
synchronousQueue(boolean) - Static method in class akka.dispatch.ThreadPoolConfig
 
SyncJournal() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
syncJournal() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue$
 
syncJournal() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
system() - Method in interface akka.actor.ActorContext
The system that the actor belongs to.
system() - Method in class akka.actor.ActorDSL.Extension
 
system() - Method in class akka.actor.Address
 
system() - Method in class akka.actor.mailbox.DurableMessageQueue
 
system() - Method in class akka.actor.TypedActorExtension
 
system() - Method in interface akka.camel.Camel
For internal use only.
system() - Method in class akka.cluster.AccrualFailureDetector
 
system() - Method in class akka.cluster.Cluster
 
system() - Method in class akka.contrib.mailbox.PeekMailboxExtension
 
system() - Method in class akka.osgi.aries.blueprint.BlueprintActorSystemFactory
 
system() - Method in class akka.remote.RemoteTransport
 
system() - Method in class akka.serialization.JavaSerializer
 
system() - Method in class akka.serialization.Serialization
 
system() - Method in class akka.testkit.CallingThreadMailbox
 
system() - Method in class akka.testkit.TestKit
 
system() - Method in interface akka.testkit.TestKitBase
 
SYSTEM_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.AddressProtocol
 
systemDispatch(akka.actor.ActorCell, SystemMessage) - Method in class akka.dispatch.Dispatcher
INTERNAL USE ONLY
systemDispatch(akka.actor.ActorCell, SystemMessage) - Method in class akka.dispatch.MessageDispatcher
Will be called when the dispatcher is to queue an invocation for execution INTERNAL API
systemDispatch(akka.actor.ActorCell, akka.dispatch.SystemMessage) - Method in class akka.testkit.CallingThreadDispatcher
 
systemGuardian() - Method in interface akka.actor.ActorRefProvider
Reference to the supervisor used for all top-level system actors.
systemGuardian() - Method in class akka.actor.ExtendedActorSystem
The top-level supervisor of all system-internal services like logging.
systemGuardian() - Method in class akka.actor.LocalActorRefProvider
 
systemGuardian() - Method in class akka.remote.RemoteActorRefProvider
 
systemGuardianStrategy() - Method in class akka.actor.LocalActorRefProvider
Overridable supervision strategy to be used by the “/user” guardian.
SystemHome() - Method in class akka.actor.ActorSystem$
 
SystemHome() - Static method in class akka.actor.ActorSystem
 
systemImpl() - Method in interface akka.actor.ActorRefFactory
INTERNAL USE ONLY
systemLoadAverage() - Method in class akka.cluster.JmxMetricsCollector
JMX Returns the OS-specific average load on the CPUs in the system, for the past 1 minute.
systemLoadAverage() - Method in class akka.cluster.SigarMetricsCollector
(SIGAR / JMX) Returns the OS-specific average load on the CPUs in the system, for the past 1 minute.
SystemLoadAverage() - Method in class akka.cluster.StandardMetrics$
 
systemLoadAverage() - Method in class akka.cluster.StandardMetrics.Cpu
 
SystemLoadAverage() - Static method in class akka.cluster.StandardMetrics
 
SystemLoadAverageMetricsSelector - Class in akka.cluster.routing
MetricsSelector that uses the system load average metrics.
SystemLoadAverageMetricsSelector() - Constructor for class akka.cluster.routing.SystemLoadAverageMetricsSelector
 
SystemLoadAverageMetricsSelector$ - Class in akka.cluster.routing
MetricsSelector that uses the system load average metrics.
SystemLoadAverageMetricsSelector$() - Constructor for class akka.cluster.routing.SystemLoadAverageMetricsSelector$
 
systemName() - Method in class akka.cluster.ClusterSettings
 
systemName() - Method in class akka.remote.RemoteActorRefProvider
 
systemName() - Method in class akka.remote.RemoteSettings
 
systemSettings() - Method in interface akka.actor.mailbox.DurableMailboxSettings
A reference to the enclosing actor system.
systemSettings() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 

T

t() - Method in class akka.testkit.TestActorRefSpec.WrappedTerminated
 
tail() - Method in class akka.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.ActorSelection
 
target() - Method in class akka.contrib.throttle.Throttler.SetTarget
 
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
 
team() - Method in class akka.dispatch.BalancingDispatcher
INTERNAL USE ONLY
teamWork() - Method in class akka.dispatch.BalancingDispatcher
 
tell(Object) - Method in class akka.actor.ActorRef
Sends the specified message to the sender, i.e. fire-and-forget semantics.
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.
tempContainer() - Method in class akka.actor.LocalActorRefProvider
 
tempContainer() - Method in class akka.remote.RemoteActorRefProvider
 
template() - Method in interface akka.camel.Camel
The Camel ProducerTemplate.
tempPath() - Method in interface akka.actor.ActorRefProvider
Generates and returns a unique actor path below “/temp”.
tempPath() - Method in class akka.actor.LocalActorRefProvider
 
tempPath() - Method in class akka.remote.RemoteActorRefProvider
 
term() - Method in class akka.zeromq.Context
 
terminate(FSM.State<S, D>) - Method in interface akka.actor.FSM
 
Terminated - Class in akka.actor
When Death Watch is used, the watcher will receive a Terminated(watched) message when watched is terminated.
Terminated$ - Class in akka.actor
 
Terminated$() - Constructor for class akka.actor.Terminated$
 
terminateEvent() - Method in interface akka.actor.FSM
 
terminationFuture() - Method in interface akka.actor.ActorRefProvider
This Future is completed upon termination of this ActorRefProvider, which is usually initiated by stopping the guardian via ActorSystem.stop().
terminationFuture() - Method in class akka.actor.LocalActorRefProvider
 
terminationFuture() - Method in class akka.remote.RemoteActorRefProvider
 
terminationPromise() - Method in class akka.actor.LocalActorRefProvider
 
test() - Method in class akka.testkit.CustomEventFilter
 
TestActor - Class in akka.testkit
 
TestActor(BlockingDeque<TestActor.Message>) - Constructor for class akka.testkit.TestActor
 
testActor() - Method in interface akka.testkit.TestKitBase
ActorRef of the test actor.
TestActor$ - Class in akka.testkit
 
TestActor$() - Constructor for class akka.testkit.TestActor$
 
TestActor.AutoPilot - Class in akka.testkit
 
TestActor.AutoPilot() - Constructor for class akka.testkit.TestActor.AutoPilot
 
TestActor.KeepRunning$ - Class in akka.testkit
 
TestActor.KeepRunning$() - Constructor for class akka.testkit.TestActor.KeepRunning$
 
TestActor.Message - Interface in akka.testkit
 
TestActor.NoAutoPilot$ - Class in akka.testkit
 
TestActor.NoAutoPilot$() - Constructor for class akka.testkit.TestActor.NoAutoPilot$
 
TestActor.NullMessage$ - Class in akka.testkit
 
TestActor.NullMessage$() - Constructor for class akka.testkit.TestActor.NullMessage$
 
TestActor.RealMessage - Class in akka.testkit
 
TestActor.RealMessage(Object, ActorRef) - Constructor for class akka.testkit.TestActor.RealMessage
 
TestActor.RealMessage$ - Class in akka.testkit
 
TestActor.RealMessage$() - Constructor for class akka.testkit.TestActor.RealMessage$
 
TestActor.SetAutoPilot - Class in akka.testkit
 
TestActor.SetAutoPilot(TestActor.AutoPilot) - Constructor for class akka.testkit.TestActor.SetAutoPilot
 
TestActor.SetAutoPilot$ - Class in akka.testkit
 
TestActor.SetAutoPilot$() - Constructor for class akka.testkit.TestActor.SetAutoPilot$
 
TestActor.SetIgnore - Class in akka.testkit
 
TestActor.SetIgnore(Option<PartialFunction<Object, Object>>) - Constructor for class akka.testkit.TestActor.SetIgnore
 
TestActor.SetIgnore$ - Class in akka.testkit
 
TestActor.SetIgnore$() - Constructor for class akka.testkit.TestActor.SetIgnore$
 
TestActor.UnWatch - Class in akka.testkit
 
TestActor.UnWatch(ActorRef) - Constructor for class akka.testkit.TestActor.UnWatch
 
TestActor.UnWatch$ - Class in akka.testkit
 
TestActor.UnWatch$() - Constructor for class akka.testkit.TestActor.UnWatch$
 
TestActor.Watch - Class in akka.testkit
 
TestActor.Watch(ActorRef) - Constructor for class akka.testkit.TestActor.Watch
 
TestActor.Watch$ - Class in akka.testkit
 
TestActor.Watch$() - Constructor for class akka.testkit.TestActor.Watch$
 
testActorId() - Method in class akka.testkit.TestKit$
 
testActorId() - Static method in class akka.testkit.TestKit
 
TestActorRef<T extends Actor> - Class in akka.testkit
This special ActorRef is exclusively for use during unit testing in a single-threaded environment.
TestActorRef(akka.actor.ActorSystemImpl, DispatcherPrerequisites, Props, akka.actor.InternalActorRef, String) - Constructor for class akka.testkit.TestActorRef
 
TestActorRef$ - Class in akka.testkit
 
TestActorRef$() - Constructor for class akka.testkit.TestActorRef$
 
TestActorRefSpec - Class in akka.testkit
Forwarding Terminated to non-watching testActor is not possible, and therefore the Terminated message is wrapped.
TestActorRefSpec() - Constructor for class akka.testkit.TestActorRefSpec
 
TestActorRefSpec$ - Class in akka.testkit
Test whether TestActorRef behaves as an ActorRef should, besides its own spec.
TestActorRefSpec$() - Constructor for class akka.testkit.TestActorRefSpec$
 
TestActorRefSpec.Logger - Class in akka.testkit
 
TestActorRefSpec.Logger() - Constructor for class akka.testkit.TestActorRefSpec.Logger
 
TestActorRefSpec.ReceiveTimeoutActor - Class in akka.testkit
 
TestActorRefSpec.ReceiveTimeoutActor(ActorRef) - Constructor for class akka.testkit.TestActorRefSpec.ReceiveTimeoutActor
 
TestActorRefSpec.ReplyActor - Class in akka.testkit
 
TestActorRefSpec.ReplyActor() - Constructor for class akka.testkit.TestActorRefSpec.ReplyActor
 
TestActorRefSpec.SenderActor - Class in akka.testkit
 
TestActorRefSpec.SenderActor(ActorRef) - Constructor for class akka.testkit.TestActorRefSpec.SenderActor
 
TestActorRefSpec.TActor - Interface in akka.testkit
 
TestActorRefSpec.WorkerActor - Class in akka.testkit
 
TestActorRefSpec.WorkerActor() - Constructor for class akka.testkit.TestActorRefSpec.WorkerActor
 
TestActorRefSpec.WrappedTerminated - Class in akka.testkit
Forwarding Terminated to non-watching testActor is not possible, and therefore the Terminated message is wrapped.
TestActorRefSpec.WrappedTerminated(Terminated) - Constructor for class akka.testkit.TestActorRefSpec.WrappedTerminated
 
TestActorRefSpec.WrappedTerminated$ - Class in akka.testkit
 
TestActorRefSpec.WrappedTerminated$() - Constructor for class akka.testkit.TestActorRefSpec.WrappedTerminated$
 
TestBarrier - Class in akka.testkit
 
TestBarrier(int) - Constructor for class akka.testkit.TestBarrier
 
TestBarrier$ - Class in akka.testkit
A cyclic barrier wrapper for use in testing.
TestBarrier$() - Constructor for class akka.testkit.TestBarrier$
 
TestBarrierTimeoutException - Exception in akka.testkit
 
TestBarrierTimeoutException(String) - Constructor for exception akka.testkit.TestBarrierTimeoutException
 
testConf() - Method in class akka.testkit.AkkaSpec$
 
testConf() - Static method in class akka.testkit.AkkaSpec
 
TestEvent - Interface in akka.testkit
Implementation helpers of the EventFilter facilities: send Mute to the TestEventListener to install a filter, and UnMute to deinstall it.
TestEvent$ - Class in akka.testkit
Implementation helpers of the EventFilter facilities: send Mute to the TestEventFilter to install a filter, and UnMute to deinstall it.
TestEvent$() - Constructor for class akka.testkit.TestEvent$
 
TestEvent.Mute - Class in akka.testkit
 
TestEvent.Mute(Seq<EventFilter>) - Constructor for class akka.testkit.TestEvent.Mute
 
TestEvent.Mute(Iterable<EventFilter>) - Constructor for class akka.testkit.TestEvent.Mute
Java API: create a Mute command from a list of filters
TestEvent.Mute$ - Class in akka.testkit
 
TestEvent.Mute$() - Constructor for class akka.testkit.TestEvent.Mute$
 
TestEvent.UnMute - Class in akka.testkit
 
TestEvent.UnMute(Seq<EventFilter>) - Constructor for class akka.testkit.TestEvent.UnMute
 
TestEvent.UnMute(Iterable<EventFilter>) - Constructor for class akka.testkit.TestEvent.UnMute
Java API: create an UnMute command from a list of filters
TestEvent.UnMute$ - Class in akka.testkit
Java API: create a Mute command from a list of filters
TestEvent.UnMute$() - Constructor for class akka.testkit.TestEvent.UnMute$
 
TestEventFilterLeeway() - Method in class akka.testkit.TestKitSettings
 
TestEventListener - Class in akka.testkit
EventListener for running tests, which allows selectively filtering out expected messages.
TestEventListener() - Constructor for class akka.testkit.TestEventListener
 
TestFSMRef<S,D,T extends Actor> - Class in akka.testkit
This is a specialised form of the TestActorRef with support for querying and setting the state of a FSM.
TestFSMRef(akka.actor.ActorSystemImpl, DispatcherPrerequisites, Props, akka.actor.InternalActorRef, String, Predef.$less$colon$less<T, FSM<S, D>>) - Constructor for class akka.testkit.TestFSMRef
 
TestFSMRef$ - Class in akka.testkit
 
TestFSMRef$() - Constructor for class akka.testkit.TestFSMRef$
 
TestFSMRefSpec - Class in akka.testkit
 
TestFSMRefSpec() - Constructor for class akka.testkit.TestFSMRefSpec
 
TestKit - Class in akka.testkit
Test kit for testing actors.
TestKit(ActorSystem) - Constructor for class akka.testkit.TestKit
 
TestKit$ - Class in akka.testkit
 
TestKit$() - Constructor for class akka.testkit.TestKit$
 
TestKitBase - Interface in akka.testkit
Implementation trait behind the TestKit class: you may use this if inheriting from a concrete class is not possible.
TestKitExtension - Class in akka.testkit
 
TestKitExtension() - Constructor for class akka.testkit.TestKitExtension
 
TestKitExtension$ - Class in akka.testkit
 
TestKitExtension$() - Constructor for class akka.testkit.TestKitExtension$
 
testKitSettings() - Method in interface akka.testkit.TestKitBase
 
TestKitSettings - Class in akka.testkit
 
TestKitSettings(com.typesafe.config.Config) - Constructor for class akka.testkit.TestKitSettings
 
TestLatch - Class in akka.testkit
 
TestLatch(int, ActorSystem) - Constructor for class akka.testkit.TestLatch
 
TestLatch$ - Class in akka.testkit
A count down latch wrapper for use in testing.
TestLatch$() - Constructor for class akka.testkit.TestLatch$
 
TestProbe - Class in akka.testkit
TestKit-based probe which allows sending, reception and reply.
TestProbe(ActorSystem) - Constructor for class akka.testkit.TestProbe
 
TestProbe$ - Class in akka.testkit
 
TestProbe$() - Constructor for class akka.testkit.TestProbe$
 
TestProbeSpec - Class in akka.testkit
 
TestProbeSpec() - Constructor for class akka.testkit.TestProbeSpec
 
TestTimeFactor() - Method in class akka.testkit.TestKitSettings
 
TestTimeSpec - Class in akka.testkit
 
TestTimeSpec() - Constructor for class akka.testkit.TestTimeSpec
 
theOneWhoWalksTheBubblesOfSpaceTime() - Method in class akka.actor.LocalActorRefProvider
Top-level anchor for the supervision hierarchy of this actor system.
theStash() - Method in interface akka.actor.Stash
 
thread() - Method in interface akka.event.Logging.LogEvent
The thread that created this log event
thread() - Method in class akka.testkit.TestActorRefSpec$
 
thread() - Static method in class akka.testkit.TestActorRefSpec
 
threadFactory() - Method in class akka.actor.ExtendedActorSystem
A ThreadFactory that can be used if the transport needs to create any Threads
threadFactory() - Method in interface akka.dispatch.DispatcherPrerequisites
 
threadFactory() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory
 
threadFactory() - Method in class akka.dispatch.ThreadPoolConfig.ThreadPoolExecutorServiceFactory
 
ThreadPoolConfig - Class in akka.dispatch
A small configuration DSL to create ThreadPoolExecutors that can be provided as an ExecutorServiceFactoryProvider to Dispatcher
ThreadPoolConfig(boolean, int, int, Duration, Function0<BlockingQueue<Runnable>>, RejectedExecutionHandler) - Constructor for class akka.dispatch.ThreadPoolConfig
 
threadPoolConfig() - Method in class akka.dispatch.ThreadPoolExecutorConfigurator
 
ThreadPoolConfig$ - Class in akka.dispatch
 
ThreadPoolConfig$() - Constructor for class akka.dispatch.ThreadPoolConfig$
 
ThreadPoolConfig.ThreadPoolExecutorServiceFactory - Class in akka.dispatch
 
ThreadPoolConfig.ThreadPoolExecutorServiceFactory(ThreadFactory) - Constructor for class akka.dispatch.ThreadPoolConfig.ThreadPoolExecutorServiceFactory
 
ThreadPoolConfigBuilder - Class in akka.dispatch
A DSL to configure and create a MessageDispatcher with a ThreadPoolExecutor
ThreadPoolConfigBuilder(ThreadPoolConfig) - Constructor for class akka.dispatch.ThreadPoolConfigBuilder
 
ThreadPoolConfigBuilder$ - Class in akka.dispatch
 
ThreadPoolConfigBuilder$() - Constructor for class akka.dispatch.ThreadPoolConfigBuilder$
 
ThreadPoolExecutorConfigurator - Class in akka.dispatch
 
ThreadPoolExecutorConfigurator(com.typesafe.config.Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.ThreadPoolExecutorConfigurator
 
threadTimeout() - Method in class akka.dispatch.ThreadPoolConfig
 
threshold() - Method in class akka.cluster.AccrualFailureDetector
 
Throttler - Interface in akka.contrib.throttle
Marker trait for throttlers.
Throttler$ - Class in akka.contrib.throttle
Message types understood by Throttler's.
Throttler$() - Constructor for class akka.contrib.throttle.Throttler$
 
Throttler.Rate - Class in akka.contrib.throttle
A rate used for throttling.
Throttler.Rate(int, FiniteDuration) - Constructor for class akka.contrib.throttle.Throttler.Rate
 
Throttler.Rate$ - Class in akka.contrib.throttle
 
Throttler.Rate$() - Constructor for class akka.contrib.throttle.Throttler.Rate$
 
Throttler.RateInt - Class in akka.contrib.throttle
Helper for some syntactic sugar.
Throttler.RateInt(int) - Constructor for class akka.contrib.throttle.Throttler.RateInt
 
Throttler.RateInt$ - Class in akka.contrib.throttle
 
Throttler.RateInt$() - Constructor for class akka.contrib.throttle.Throttler.RateInt$
 
Throttler.SetRate - Class in akka.contrib.throttle
Set the rate of a Throttler.
Throttler.SetRate(Throttler.Rate) - Constructor for class akka.contrib.throttle.Throttler.SetRate
 
Throttler.SetRate$ - Class in akka.contrib.throttle
 
Throttler.SetRate$() - Constructor for class akka.contrib.throttle.Throttler.SetRate$
 
Throttler.SetTarget - Class in akka.contrib.throttle
Set the target of a Throttler.
Throttler.SetTarget(Option<ActorRef>) - Constructor for class akka.contrib.throttle.Throttler.SetTarget
 
Throttler.SetTarget$ - Class in akka.contrib.throttle
 
Throttler.SetTarget$() - Constructor for class akka.contrib.throttle.Throttler.SetTarget$
 
throughput() - Method in class akka.dispatch.Dispatcher
 
throughput() - Method in class akka.dispatch.MessageDispatcher
INTERNAL API
throughput() - Method in class akka.testkit.CallingThreadDispatcher
 
throughputDeadlineTime() - Method in class akka.dispatch.Dispatcher
 
throughputDeadlineTime() - Method in class akka.dispatch.MessageDispatcher
INTERNAL API
throughputDeadlineTime() - Method in class akka.testkit.CallingThreadDispatcher
 
throwable() - Method in class akka.testkit.ErrorFilter
 
time() - Method in class akka.cluster.VectorClock.Timestamp
 
timeout() - Method in class akka.actor.FSM.State
 
timeout() - Method in class akka.actor.IO.SoTimeout
 
timeout() - Method in class akka.actor.TypedProps
 
timeout() - Method in interface akka.testkit.DefaultTimeout
 
Timeout - Interface in akka.util.internal
A handle associated with a TimerTask that is returned by a Timer.
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
Schedules TimerTasks for one-time future execution in a background thread.
TimerBasedThrottler - Class in akka.contrib.throttle
A Throttler that uses a timer to control the message delivery rate.
TimerBasedThrottler(Throttler.Rate) - Constructor for class akka.contrib.throttle.TimerBasedThrottler
 
TimerBasedThrottler$ - Class in akka.contrib.throttle
Implementation-specific internals.
TimerBasedThrottler$() - Constructor for class akka.contrib.throttle.TimerBasedThrottler$
 
timerGen() - Method in interface akka.actor.FSM
 
timers() - Method in interface akka.actor.FSM
 
TimerTask - Interface in akka.util.internal
A task which is executed after the delay specified with Timer#newTimeout(TimerTask, long, java.util.concurrent.TimeUnit) .
timestamp() - Method in class akka.cluster.NodeMetrics
 
timestamp() - Method in class akka.cluster.StandardMetrics.Cpu
 
timestamp() - Method in class akka.cluster.StandardMetrics.HeapMemory
 
timestamp() - Method in class akka.cluster.VectorClock
 
timestamp() - Method in interface akka.event.Logging.StdOutLogger
 
TimingTest - Class in akka.testkit
 
TimingTest() - Constructor for class akka.testkit.TimingTest
 
TimingTest$ - Class in akka.testkit
 
TimingTest$() - Constructor for class akka.testkit.TimingTest$
 
to() - Method in class akka.actor.FSM.Transition
 
to(ActorRef) - Method in class akka.camel.ActorRouteDefinition
Sends the message to an ActorRef endpoint.
to(ActorRef, boolean, Duration) - Method in class akka.camel.ActorRouteDefinition
Sends the message to an ActorRef endpoint
to(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(ClassTag<B>) - Method in class akka.util.ByteString
 
toBinary(Object) - Method in class akka.remote.serialization.ProtobufSerializer
 
toBinary(Object) - Method in class akka.serialization.ByteArraySerializer
 
toBinary(Object) - Method in class akka.serialization.JavaSerializer
 
toBinary(Object) - Method in class akka.serialization.NullSerializer
 
toBinary(Object) - Method in interface akka.serialization.Serializer
Serializes the given object into an Array of Byte
toBuilder() - Method in class akka.remote.RemoteProtocol.ActorRefProtocol
 
toBuilder() - Method in class akka.remote.RemoteProtocol.AddressProtocol
 
toBuilder() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
toBuilder() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
toBuilder() - Method in class akka.remote.RemoteProtocol.DeployProtocol
 
toBuilder() - Method in class akka.remote.RemoteProtocol.MessageProtocol
 
toBuilder() - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
toBuilder() - Method in class akka.remote.RemoteProtocol.PropsProtocol
 
toBuilder() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
toBuilder() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
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
 
toList() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
toRemoteActorRefProtocol(ActorRef) - Method in class akka.remote.RemoteTransport
Serializes the ActorRef instance into a Protocol Buffers (protobuf) Message.
toScala(ActorSelection) - Method in class akka.actor.ActorSelection$
 
toScala(ActorSelection) - Static method in class akka.actor.ActorSelection
 
toSeq() - Method in class akka.util.ByteIterator
 
toString() - Method in class akka.actor.ActorRef
 
toString() - Method in class akka.actor.ActorSystem.Settings
Returns the String representation of the Config that this Settings is backed by
toString() - Method in class akka.actor.Address
Returns the canonical String representation of this Address formatted as: ://@:
toString() - Method in class akka.actor.ChildActorPath
 
toString() - Method in class akka.actor.mailbox.filebased.filequeue.Counter
 
toString() - Method in class akka.actor.RootActorPath
 
toString() - Method in exception akka.AkkaException
 
toString() - Method in class akka.camel.CamelMessage
 
toString() - Method in class akka.cluster.Member
 
toString() - Method in class akka.cluster.VectorClock.Node.NodeImpl
 
toString() - Method in class akka.cluster.VectorClock.Timestamp
 
toString() - Method in class akka.cluster.VectorClock
 
toString() - Method in class akka.dispatch.Dispatcher
 
toString() - Method in class akka.event.Logging.StandardOutLogger
 
toString() - Method in class akka.osgi.impl.BundleDelegatingClassLoader
 
toString() - Method in class akka.remote.RemoteClientConnected
 
toString() - Method in class akka.remote.RemoteClientDisconnected
 
toString() - Method in class akka.remote.RemoteClientError
 
toString() - Method in class akka.remote.RemoteClientShutdown
 
toString() - Method in class akka.remote.RemoteClientStarted
 
toString() - Method in class akka.remote.RemoteMessage
Returns a String representation of this RemoteMessage, intended for debugging purposes.
toString() - Method in class akka.remote.RemoteServerClientClosed
 
toString() - Method in class akka.remote.RemoteServerClientConnected
 
toString() - Method in class akka.remote.RemoteServerClientDisconnected
 
toString() - Method in class akka.remote.RemoteServerError
 
toString() - Method in class akka.remote.RemoteServerShutdown
 
toString() - Method in class akka.remote.RemoteServerStarted
 
toString() - Method in class akka.remote.RemoteTransport
Returns this RemoteTransports Address' textual representation
toString() - Method in class akka.testkit.TestActorRef
 
toString() - Method in class akka.zeromq.ZeroMQVersion
 
toStringWithAddress(Address) - Method in interface akka.actor.ActorPath
Generate String representation, replacing the Address in the RootActor Path with the given one unless this path’s address includes host and port information.
toStringWithAddress(Address) - Method in class akka.actor.ChildActorPath
 
toStringWithAddress(Address) - Method in class akka.actor.RootActorPath
 
total2pf(Function2<S, S, BoxedUnit>) - Method in interface akka.actor.FSM
Convenience wrapper for using a total function instead of a partial function literal.
totalAdded() - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
totalDiscarded() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
totalExpired() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
totalInstances() - Method in class akka.cluster.routing.ClusterRouterSettings
 
totalItems() - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
 
toUri(ActorRef) - Method in class akka.camel.internal.component.CamelPath$
Converts the actorRef to a Camel URI (string) which can be used in custom routes.
toUri(ActorRef, boolean, Duration) - Method in class akka.camel.internal.component.CamelPath$
Converts the actorRef to a Camel URI (string) which can be used in custom routes.
toUri(ActorRef) - Static method in class akka.camel.internal.component.CamelPath
Converts the actorRef to a Camel URI (string) which can be used in custom routes.
toUri(ActorRef, boolean, Duration) - Static method in class akka.camel.internal.component.CamelPath
Converts the actorRef to a Camel URI (string) which can be used in custom routes.
Transactor - Interface in akka.transactor
An actor with built-in support for coordinated transactions.
TransactorExtension - Class in akka.transactor
TransactorExtension is an Akka Extension to hold settings for transactors.
TransactorExtension() - Constructor for class akka.transactor.TransactorExtension
 
TransactorExtension$ - Class in akka.transactor
TransactorExtension is an Akka Extension to hold settings for transactors.
TransactorExtension$() - Constructor for class akka.transactor.TransactorExtension$
 
TransactorSettings - Class in akka.transactor
 
TransactorSettings(com.typesafe.config.Config) - Constructor for class akka.transactor.TransactorSettings
 
transcend(boolean, Function0<BoxedUnit>) - Method in class akka.util.Switch
 
transform(PartialFunction<FSM.Event, FSM.State<S, D>>) - Method in interface akka.actor.FSM
 
transformOutgoingMessage(Object) - Method in class akka.camel.javaapi.UntypedProducerActor
 
transformOutgoingMessage(Object) - Method in interface akka.camel.ProducerSupport
Called before the message is sent to the endpoint specified by endpointUri.
transformResponse(Object) - Method in class akka.camel.javaapi.UntypedProducerActor
 
transformResponse(Object) - Method in interface akka.camel.ProducerSupport
Called before the response message is sent to the original sender.
transitionEvent() - Method in interface akka.actor.FSM
 
transport() - Method in class akka.remote.RemoteActorRefProvider
 
traverse(M, Function1<A, IO.Iteratee<B>>, CanBuildFrom<M, B, M>) - Method in class akka.actor.IO$
An Iteratee that applies an Iteratee to each element of a Traversable and finally returning a single Iteratee containing a Traversable of the results.
traverse(M, Function1<A, IO.Iteratee<B>>, CanBuildFrom<M, B, M>) - Static method in class akka.actor.IO
An Iteratee that applies an Iteratee to each element of a Traversable and finally returning a single Iteratee containing a Traversable of the results.
traverse(Iterable<A>, Function<A, Future<B>>, ExecutionContext) - Method in class akka.dispatch.Futures$
Transforms a JIterable[A] into a Future[JIterable[B} using the provided Function A ⇒ Future[B].
traverse(Iterable<A>, Function<A, Future<B>>, ExecutionContext) - Static method in class akka.dispatch.Futures
Transforms a JIterable[A] into a Future[JIterable[B} using the provided Function A ⇒ Future[B].
tries() - Method in class akka.contrib.mailbox.PeekMailbox
 
tryCompareTo(V, Function1<V, PartiallyOrdered<V>>) - Method in class akka.cluster.VectorClock
For the 'PartiallyOrdered' trait, to allow natural comparisons using <, > and ==.
tunnel() - Method in class akka.contrib.pattern.ReliableProxy
 
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

uid() - Method in class akka.actor.ChildRestartStats
 
unapply(ActorInitializationException) - Method in class akka.actor.ActorInitializationException$
 
unapply(ActorInitializationException) - Static method in exception akka.actor.ActorInitializationException
 
unapply(String) - Method in class akka.actor.ActorPathExtractor$
 
unapply(String) - Static method in class akka.actor.ActorPathExtractor
 
unapply(String) - Method in class akka.actor.AddressFromURIString$
 
unapply(URI) - Method in class akka.actor.AddressFromURIString$
 
unapply(String) - Static method in class akka.actor.AddressFromURIString
 
unapply(URI) - Static method in class akka.actor.AddressFromURIString
 
unapply(Tuple2<S, S>) - Method in class akka.actor.FSM.$minus$greater$
 
unapply(PostRestartException) - Method in class akka.actor.OriginalRestartException$
 
unapply(PostRestartException) - Static method in class akka.actor.OriginalRestartException
 
unapply(String) - Method in class akka.actor.RelativeActorPath$
 
unapply(String) - Static method in class akka.actor.RelativeActorPath
 
unapply(Object) - Method in class akka.cluster.Member$
 
unapply(Object) - Static method in class akka.cluster.Member
 
unapply(NodeMetrics) - Method in class akka.cluster.StandardMetrics.Cpu$
Given a NodeMetrics it returns the Cpu data if the nodeMetrics contains necessary cpu metrics.
unapply(NodeMetrics) - Method in class akka.cluster.StandardMetrics.HeapMemory$
Given a NodeMetrics it returns the HeapMemory data if the nodeMetrics contains necessary heap metrics.
unapply(FromConfig) - Method in class akka.routing.FromConfig$
 
unapply(FromConfig) - Static method in class akka.routing.FromConfig
 
unapply(Coordinated) - Method in class akka.transactor.Coordinated$
 
unapply(Coordinated) - Static method in class akka.transactor.Coordinated
 
unbatchedExecute(Runnable) - Method in class akka.dispatch.MessageDispatcher
 
unbecome() - Method in interface akka.actor.ActorContext
Reverts the Actor behavior to the previous one in the hotswap stack.
unbecome() - Method in interface akka.actor.dsl.Creators.Act
Pop the active behavior from the behavior stack of this actor.
UnboundedDequeBasedMailbox - Class in akka.dispatch
UnboundedDequeBasedMailbox is an unbounded MailboxType, backed by a Deque.
UnboundedDequeBasedMailbox() - Constructor for class akka.dispatch.UnboundedDequeBasedMailbox
 
UnboundedDequeBasedMailbox(ActorSystem.Settings, com.typesafe.config.Config) - Constructor for class akka.dispatch.UnboundedDequeBasedMailbox
 
UnboundedDequeBasedMailbox$ - Class in akka.dispatch
 
UnboundedDequeBasedMailbox$() - Constructor for class akka.dispatch.UnboundedDequeBasedMailbox$
 
UnboundedDequeBasedMessageQueueSemantics - Interface in akka.dispatch
UnboundedDequeBasedMessageQueueSemantics adds unbounded semantics to a DequeBasedMessageQueue, i.e. a non-blocking enqueue and dequeue.
UnboundedMailbox - Class in akka.dispatch
UnboundedMailbox is the default unbounded MailboxType used by Akka Actors.
UnboundedMailbox() - Constructor for class akka.dispatch.UnboundedMailbox
 
UnboundedMailbox(ActorSystem.Settings, com.typesafe.config.Config) - Constructor for class akka.dispatch.UnboundedMailbox
 
UnboundedMailbox$ - Class in akka.dispatch
 
UnboundedMailbox$() - Constructor for class akka.dispatch.UnboundedMailbox$
 
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 priorization of its contents.
UnboundedPriorityMailbox(Comparator<Envelope>, int) - Constructor for class akka.dispatch.UnboundedPriorityMailbox
 
UnboundedPriorityMailbox(Comparator<Envelope>) - Constructor for class akka.dispatch.UnboundedPriorityMailbox
 
underlyingActor() - Method in class akka.testkit.TestActorRef
Retrieve reference to the underlying actor, where the static type matches the factory used inside the constructor.
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(())
unpack(byte[]) - Method in class akka.actor.mailbox.filebased.filequeue.QItem$
 
unpack(byte[]) - Static method in class akka.actor.mailbox.filebased.filequeue.QItem
 
unpackOldAdd(byte[]) - Method in class akka.actor.mailbox.filebased.filequeue.QItem$
 
unpackOldAdd(byte[]) - Static method in class akka.actor.mailbox.filebased.filequeue.QItem
 
unreachable() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
 
UnreachableNodesReaperInterval() - Method in class akka.cluster.ClusterSettings
 
unregister(ActorRef) - Method in class akka.contrib.mailbox.PeekMailboxExtension
 
unregister(akka.actor.ActorCell) - Method in class akka.dispatch.BalancingDispatcher
 
unregister(akka.actor.ActorCell) - Method in class akka.dispatch.MessageDispatcher
If you override it, you must call it.
unregister(akka.actor.ActorCell) - Method in class akka.dispatch.PinnedDispatcher
 
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.
unregisterTempActor(ActorPath) - Method in class akka.actor.LocalActorRefProvider
 
unregisterTempActor(ActorPath) - Method in class akka.remote.RemoteActorRefProvider
 
unremove(int) - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
unremove(int) - Method in class akka.actor.mailbox.filebased.filequeue.PersistentQueue
Return a transactionally-removed item to the queue.
unremove(String, int) - Method in class akka.actor.mailbox.filebased.filequeue.QueueCollection
 
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.Stash
Prepends all messages in the stash to the mailbox, and then clears the stash.
unsubscribe(ActorRef) - Method in class akka.cluster.Cluster
Unsubscribe to all cluster domain events.
unsubscribe(ActorRef, Class<?>) - Method in class akka.cluster.Cluster
Unsubscribe to a specific type of cluster domain events, matching previous subscribe registration.
unsubscribe(ActorRef, ActorRef) - Method in interface akka.event.ActorClassification
 
unsubscribe(ActorRef) - Method in interface akka.event.ActorClassification
 
unsubscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.EventBus
Attempts to deregister the subscriber from the specified Classifier
unsubscribe(akka.event.EventBus.Subscriber) - Method in interface akka.event.EventBus
Attempts to deregister the subscriber from all Classifiers it may be subscribed to
unsubscribe(ActorRef, Class<?>) - Method in class akka.event.EventStream
 
unsubscribe(ActorRef) - Method in class akka.event.EventStream
 
unsubscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.LookupClassification
 
unsubscribe(akka.event.EventBus.Subscriber) - Method in interface akka.event.LookupClassification
 
unsubscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.ScanningClassification
 
unsubscribe(akka.event.EventBus.Subscriber) - Method in interface akka.event.ScanningClassification
 
unsubscribe(akka.event.EventBus.Subscriber, akka.event.EventBus.Classifier) - Method in interface akka.event.SubchannelClassification
 
unsubscribe(akka.event.EventBus.Subscriber) - Method in interface akka.event.SubchannelClassification
 
Unsubscribe - Class in akka.zeromq
The Unsubscribe option shall remove an existing message filter on a akka.zeromq.SocketType.Sub socket.
Unsubscribe(Seq<Object>) - Constructor for class akka.zeromq.Unsubscribe
 
Unsubscribe(String) - Constructor for class akka.zeromq.Unsubscribe
 
Unsubscribe$ - Class in akka.zeromq
 
Unsubscribe$() - Constructor for class akka.zeromq.Unsubscribe$
 
UntrustedMode() - Method in class akka.remote.RemoteSettings
 
UntypedActor - Class in akka.actor
Actor base trait that should be extended by or mixed to create an Actor with the semantics of the 'Actor Model': http://en.wikipedia.org/wiki/Actor_model 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
 
UntypedConsumerActor - Class in akka.camel.javaapi
Subclass this abstract class to create an MDB-style untyped consumer actor.
UntypedConsumerActor() - Constructor for class akka.camel.javaapi.UntypedConsumerActor
 
UntypedProducerActor - Class in akka.camel.javaapi
Subclass this abstract class to create an untyped producer actor.
UntypedProducerActor() - Constructor for class akka.camel.javaapi.UntypedProducerActor
 
UntypedTransactor - Class in akka.transactor
An UntypedActor version of transactor for using from Java.
UntypedTransactor() - Constructor for class akka.transactor.UntypedTransactor
 
unwatch(ActorRef) - Method in interface akka.actor.ActorContext
Unregisters this actor as Monitor for the provided ActorRef.
unwatch(ActorRef) - Method in class akka.testkit.JavaTestKit
 
unwatch(ActorRef) - Method in class akka.testkit.TestActorRef
Deregisters this actor from being a death monitor of the provided ActorRef This means that this actor will not get a Terminated()-message when the provided actor is permanently terminated.
unwatch(ActorRef) - Method in interface akka.testkit.TestKitBase
Have the testActor stop watching someone (i.e.
up() - Method in class akka.cluster.MemberStatus$
Java API: retrieve the “up” status singleton
up() - Static method in class akka.cluster.MemberStatus
Java API: retrieve the “up” status singleton
update(T) - Method in class akka.agent.Agent
Dispatch a new value for the internal state.
updateSource(LogRecord) - Method in interface akka.contrib.jul.JavaLoggingAdapter
 
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.
usage() - Method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper$
 
usage() - Static method in class akka.actor.mailbox.filebased.filequeue.tools.QDumper
 
usage() - Static method in class akka.jmx.Client
 
usage(int, String) - Static method in class akka.jmx.Client
 
useActorOnNode(ActorPath, Props, Deploy, ActorRef) - Method in class akka.cluster.ClusterActorRefProvider
This method is overridden here to keep track of remote deployed actors to be able to clean up corresponding child references.
useActorOnNode(ActorPath, Props, Deploy, ActorRef) - Method in class akka.remote.RemoteActorRefProvider
Using (checking out) actor on a specific node.
used() - Method in class akka.cluster.StandardMetrics.HeapMemory
 
UseDispatcher() - Method in class akka.cluster.ClusterSettings
 
userConfig() - Method in interface akka.actor.mailbox.DurableMailboxSettings
A reference to the config section which the user specified for this mailbox’s dispatcher.
userConfig() - Method in class akka.actor.mailbox.filebased.FileBasedMailboxSettings
 
useUntrustedMode() - Method in class akka.remote.RemoteTransport
When this method returns true, some functionality will be turned off for security purposes.
using(D) - Method in class akka.actor.FSM.State
Modify state transition descriptor with new state data.
using(PartialFunction<FSM.State<S, D>, FSM.State<S, D>>) - Method in class akka.actor.FSM.TransformHelper
 
utf8String() - Method in class akka.util.ByteString
Decodes this ByteString as a UTF-8 encoded String.
Util - Class in akka.actor.mailbox.filebased.filequeue.tools
 
Util() - Constructor for class akka.actor.mailbox.filebased.filequeue.tools.Util
 
Util - Class in akka.japi
This class hold common utilities for Java
Util() - Constructor for class akka.japi.Util
 
Util$ - Class in akka.actor.mailbox.filebased.filequeue.tools
 
Util$() - Constructor for class akka.actor.mailbox.filebased.filequeue.tools.Util$
 
Util$ - Class in akka.japi
This class hold common utilities for Java
Util$() - Constructor for class akka.japi.Util$
 
uuid() - Method in interface akka.actor.IO.Handle
 
uuid() - Method in class akka.actor.IO.ServerHandle
 
uuid() - Method in class akka.actor.IO.SocketHandle
 
uuid() - Method in exception akka.AkkaException
 

V

v() - Method in class akka.japi.Option.Some
 
validate(ThreadFactory) - Method in class akka.dispatch.ForkJoinExecutorConfigurator
 
value() - Method in class akka.actor.IO.IterateeRefSync
Returns the current value of this IterateeRefSync
value() - Method in class akka.cluster.Metric
 
value() - Method in class akka.zeromq.Affinity
 
value() - Method in class akka.zeromq.Backlog
 
value() - Method in class akka.zeromq.HighWatermark
 
value() - Method in class akka.zeromq.Identity
 
value() - Method in class akka.zeromq.Linger
 
value() - Method in class akka.zeromq.MaxMsgSize
 
value() - Method in class akka.zeromq.MulticastHops
 
value() - Method in class akka.zeromq.MulticastLoop
 
value() - Method in class akka.zeromq.Rate
 
value() - Method in class akka.zeromq.ReceiveBufferSize
 
value() - Method in class akka.zeromq.ReceiveHighWatermark
 
value() - Method in class akka.zeromq.ReconnectIVL
 
value() - Method in class akka.zeromq.ReconnectIVLMax
 
value() - Method in class akka.zeromq.RecoveryInterval
 
value() - Method in class akka.zeromq.SendBufferSize
 
value() - Method in class akka.zeromq.SendHighWatermark
 
value() - Method in class akka.zeromq.Swap
 
VALUE_FIELD_NUMBER - Static variable in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
valueComparator() - Method in class akka.util.Index
 
valueIterator(K) - Method in class akka.util.Index
Returns an Iterator of V containing the values for the supplied key, or an empty iterator if the key doesn't exist
valueOf(String) - Static method in enum akka.remote.RemoteProtocol.CommandType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum akka.remote.RemoteProtocol.CommandType
 
valueOf(com.google.protobuf.Descriptors.EnumValueDescriptor) - Static method in enum akka.remote.RemoteProtocol.CommandType
 
values() - Static method in enum akka.remote.RemoteProtocol.CommandType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class akka.util.Index
Returns the union of all value sets.
values() - Method in class akka.util.internal.ConcurrentIdentityHashMap
Returns a Collection view of the values contained in this map.
VectorClock - Class in akka.cluster
Representation of a Vector-based clock (counting clock), inspired by Lamport logical clocks.
VectorClock(VectorClock.Timestamp, Map<VectorClock.Node, VectorClock.Timestamp>) - Constructor for class akka.cluster.VectorClock
 
VectorClock$ - Class in akka.cluster
VectorClock module with helper classes and methods.
VectorClock$() - Constructor for class akka.cluster.VectorClock$
 
VectorClock.Node - Interface in akka.cluster
Hash representation of a versioned node name.
VectorClock.Node$ - Class in akka.cluster
 
VectorClock.Node$() - Constructor for class akka.cluster.VectorClock.Node$
 
VectorClock.Node.NodeImpl - Class in akka.cluster
 
VectorClock.Node.NodeImpl(String) - Constructor for class akka.cluster.VectorClock.Node.NodeImpl
 
VectorClock.Node.NodeImpl$ - Class in akka.cluster
 
VectorClock.Node.NodeImpl$() - Constructor for class akka.cluster.VectorClock.Node.NodeImpl$
 
VectorClock.Timestamp - Class in akka.cluster
Timestamp representation a unique 'Ordered' timestamp.
VectorClock.Timestamp$ - Class in akka.cluster
 
VectorClock.Timestamp$() - Constructor for class akka.cluster.VectorClock.Timestamp$
 
VectorClockException - Exception in akka.cluster
 
VectorClockException(String) - Constructor for exception akka.cluster.VectorClockException
 
verifyConfig() - Method in class akka.routing.FromConfig
 
verifyConfig() - 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
 
version() - Method in interface akka.cluster.Versioned
 
version() - Method in class akka.zeromq.ZeroMQExtension
The version of the ZeroMQ library
Versioned<T> - Interface in akka.cluster
Trait to be extended by classes that wants to be versioned using a VectorClock.
Versioned$ - Class in akka.cluster
Utility methods for comparing Versioned instances.
Versioned$() - Constructor for class akka.cluster.Versioned$
 
Versioned.After$ - Class in akka.cluster
 
Versioned.After$() - Constructor for class akka.cluster.Versioned.After$
 
Versioned.Before$ - Class in akka.cluster
 
Versioned.Before$() - Constructor for class akka.cluster.Versioned.Before$
 
Versioned.Concurrent$ - Class in akka.cluster
 
Versioned.Concurrent$() - Constructor for class akka.cluster.Versioned.Concurrent$
 
Versioned.Ordering - Interface in akka.cluster
The result of comparing two Versioned objects.
versions() - Method in class akka.cluster.VectorClock
 
virtualNodesFactor() - Method in class akka.routing.ConsistentHash
 
virtualNodesFactor() - Method in interface akka.routing.ConsistentHashingLike
 
virtualNodesFactor() - Method in class akka.routing.ConsistentHashingRouter
 

W

walk() - Method in class akka.actor.mailbox.filebased.filequeue.Journal
 
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
 
warning(String, String, String, String, int) - Method in class akka.testkit.EventFilter$
Create a filter for Warning events.
warning(String, String, String, String, int) - Static method in class akka.testkit.EventFilter
Create a filter for Warning events.
WarningFilter - Class in akka.testkit
Filter which matches Warning events, if they satisfy the given criteria: source, if given, applies a filter on the event’s origin message applies a filter on the event’s message (either with String.startsWith or Regex.findFirstIn().isDefined) If you want to match all Warning events, the most efficient is to use Left("").
WarningFilter(Option<String>, Either<String, Regex>, boolean, int) - Constructor for class akka.testkit.WarningFilter
 
WarningFilter(String, String, boolean, boolean, int) - Constructor for class akka.testkit.WarningFilter
Java API: create a WarningFilter
WarningFilter$ - Class in akka.testkit
 
WarningFilter$() - Constructor for class akka.testkit.WarningFilter$
 
warningFormat() - Method in interface akka.event.Logging.StdOutLogger
 
WarningLevel() - Method in class akka.event.Logging$
 
WarningLevel() - Static method in class akka.event.Logging
 
watch(ActorRef) - Method in interface akka.actor.ActorContext
Registers this actor as a Monitor for the provided ActorRef.
watch(ActorRef) - Method in class akka.testkit.JavaTestKit
 
watch(ActorRef) - Method in class akka.testkit.TestActorRef
Registers this actor to be a death monitor of the provided ActorRef This means that this actor will get a Terminated()-message when the provided actor is permanently terminated.
watch(ActorRef) - Method in interface akka.testkit.TestKitBase
Have the testActor watch someone (i.e.
weights(Map<Address, Object>) - Method in class akka.cluster.routing.CapacityMetricsSelector
Converts the capacity values to weights.
weights(Set<NodeMetrics>) - Method in class akka.cluster.routing.CapacityMetricsSelector
The weights per address, based on the capacity produced by the nodeMetrics.
weights(Set<NodeMetrics>) - Method in interface akka.cluster.routing.MetricsSelector
The weights per address, based on the the nodeMetrics.
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
 
withBody(T) - Method in class akka.camel.CamelMessage
Java API: Returns a new CamelMessage with a new body, while keeping the same headers.
withBodyAs(ClassTag<T>, org.apache.camel.CamelContext) - Method in class akka.camel.CamelMessage
Creates a CamelMessage with current body converted to type T.
withBodyAs(Class<T>, org.apache.camel.CamelContext) - Method in class akka.camel.CamelMessage
Java API: Creates a CamelMessage with current body converted to type clazz.
withCircuitBreaker(Function0<Future<T>>) - Method in class akka.pattern.CircuitBreaker
Wraps invocations of asynchronous calls that need to be protected
withClient(ActorRef) - Method in class akka.actor.dsl.Inbox.Get
 
withClient(ActorRef) - Method in interface akka.actor.dsl.Inbox.Query
 
withClient(ActorRef) - Method in class akka.actor.dsl.Inbox.Select
 
withCreator(Function0<Actor>) - Method in class akka.actor.Props
Scala API: Returns a new Props with the specified creator set.
withCreator(Creator<Actor>) - Method in class akka.actor.Props
Java API: Returns a new Props with the specified creator set.
withCreator(Class<? extends Actor>) - Method in class akka.actor.Props
Java API: Returns a new Props with the specified creator set.
withDeploy(Deploy) - Method in class akka.actor.Props
Returns a new Props with the specified deployment configuration.
withDeploy(Deploy) - Method in class akka.actor.TypedProps
Returns a new TypedProps with the specified deployment configuration.
withDispatcher(String) - Method in class akka.actor.Props
Returns a new Props with the specified dispatcher set.
withDispatcher(String) - Method in class akka.actor.TypedProps
Returns a new TypedProps with the specified dispatcher set.
withDispatcher(String) - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.BroadcastRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.ConsistentHashingRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.RandomRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.RoundRobinRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.ScatterGatherFirstCompletedRouter
Java API for setting routerDispatcher
withDispatcher(String) - Method in class akka.routing.SmallestMailboxRouter
Java API for setting routerDispatcher
withFallback(Deploy) - Method in class akka.actor.Deploy
Do a merge between this and the other Deploy, where values from “this” take precedence.
withFallback(Scope) - Method in class akka.actor.LocalScope$
 
withFallback(Scope) - Static method in class akka.actor.LocalScope
 
withFallback(Scope) - Method in class akka.actor.NoScopeGiven$
 
withFallback(Scope) - Static method in class akka.actor.NoScopeGiven
 
withFallback(Scope) - Method in interface akka.actor.Scope
When merging Deploy instances using withFallback() on the left one, this is propagated to “merging” scopes in the same way.
withFallback(Scope) - Method in class akka.cluster.ClusterScope$
 
withFallback(Scope) - Static method in class akka.cluster.ClusterScope
 
withFallback(RouterConfig) - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
Uses the resizer 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.cluster.routing.ClusterRouterConfig
 
withFallback(Scope) - Method in class akka.remote.RemoteScope
 
withFallback(RouterConfig) - Method in class akka.remote.routing.RemoteRouterConfig
 
withFallback(RouterConfig) - Method in class akka.routing.BroadcastRouter
Uses the resizer 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 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 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 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 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 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.
withHeaders(Map<String, A>) - Method in class akka.camel.CamelMessage
Java API: Creates a new CamelMessage with given headers.
within() - Method in interface akka.routing.ScatterGatherFirstCompletedLike
 
within() - Method in class akka.routing.ScatterGatherFirstCompletedRouter
 
within(FiniteDuration, FiniteDuration, Function0<T>) - Method in interface akka.testkit.TestKitBase
Execute code block while bounding its execution time between min and max.
within(FiniteDuration, Function0<T>) - Method in interface akka.testkit.TestKitBase
Same as calling within(0 seconds, max)(f).
withInterface(Class<? super T>) - Method in class akka.actor.TypedProps
Returns a new TypedProps that has the specified interface, or if the interface class is not an interface, all the interfaces it implements, appended in the sequence of interfaces.
withinTimeRange() - Method in class akka.actor.AllForOneStrategy
 
withinTimeRange() - Method in class akka.actor.OneForOneStrategy
 
WithListeners - Class in akka.routing
 
WithListeners(Function1<ActorRef, BoxedUnit>) - Constructor for class akka.routing.WithListeners
 
WithListeners$ - Class in akka.routing
 
WithListeners$() - Constructor for class akka.routing.WithListeners$
 
withLoader(ClassLoader) - Method in class akka.actor.TypedProps
Java API: return a new TypedProps that will use the specified ClassLoader to create its proxy class in If loader is null, it will use the bootstrap classloader.
withLoader(Option<ClassLoader>) - Method in class akka.actor.TypedProps
Scala API: return a new TypedProps that will use the specified ClassLoader to create its proxy class in If loader is null, it will use the bootstrap classloader.
withMdc(String, String, Function0<BoxedUnit>) - Method in class akka.event.slf4j.Slf4jEventHandler
 
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.
withRouter(RouterConfig) - Method in class akka.actor.Props
Returns a new Props with the specified router config set.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.cluster.routing.AdaptiveLoadBalancingRouter
Java API for setting the supervisor strategy to be used for the “head” Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.BroadcastRouter
Java API for setting the supervisor strategy to be used for the “head” Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.ConsistentHashingRouter
Java API for setting the supervisor strategy to be used for the “head” Router actor.
withSupervisorStrategy(SupervisorStrategy) - Method in class akka.routing.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.
withVirtualNodesFactor(int) - Method in class akka.routing.ConsistentHashingRouter
Java API for setting the number of virtual nodes per node, used in akka.routing.ConsistantHash
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
 
WriteBuffer - Class in akka.actor
 
WriteBuffer(int) - Constructor for class akka.actor.WriteBuffer
 
writeObject(ObjectOutputStream) - Method in interface akka.actor.ActorContext
ActorContexts shouldn't be Serializable
writeReplace() - Method in class akka.remote.RemoteProtocol.ActorRefProtocol
 
writeReplace() - Method in class akka.remote.RemoteProtocol.AddressProtocol
 
writeReplace() - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
writeReplace() - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
writeReplace() - Method in class akka.remote.RemoteProtocol.DeployProtocol
 
writeReplace() - Method in class akka.remote.RemoteProtocol.MessageProtocol
 
writeReplace() - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
writeReplace() - Method in class akka.remote.RemoteProtocol.PropsProtocol
 
writeReplace() - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
writeReplace() - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.RemoteProtocol.ActorRefProtocol
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.RemoteProtocol.AddressProtocol
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.RemoteProtocol.AkkaRemoteProtocol
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.RemoteProtocol.DaemonMsgCreateProtocol
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.RemoteProtocol.DeployProtocol
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.RemoteProtocol.MessageProtocol
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.RemoteProtocol.MetadataEntryProtocol
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.RemoteProtocol.PropsProtocol
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.RemoteProtocol.RemoteControlProtocol
 
writeTo(com.google.protobuf.CodedOutputStream) - Method in class akka.remote.RemoteProtocol.RemoteMessageProtocol
 

X

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

Z

zero() - Method in class akka.cluster.VectorClock.Timestamp$
 
zero() - Method in class akka.util.Timeout$
A timeout with zero duration, will cause most requests to always timeout.
zero() - Static method in class akka.util.Timeout
A timeout with zero duration, will cause most requests to always timeout.
ZeroMQ - Class in akka.zeromq
Java API for akka.zeromq
ZeroMQ() - Constructor for class akka.zeromq.ZeroMQ
 
ZeroMQ$ - Class in akka.zeromq
Java API for akka.zeromq
ZeroMQ$() - Constructor for class akka.zeromq.ZeroMQ$
 
ZeroMQExtension - Class in akka.zeromq
The extension for the ZeroMQ module
ZeroMQExtension(ActorSystem) - Constructor for class akka.zeromq.ZeroMQExtension
 
ZeroMQExtension$ - Class in akka.zeromq
The ExtensionId and ExtensionIdProvider for the ZeroMQ module
ZeroMQExtension$() - Constructor for class akka.zeromq.ZeroMQExtension$
 
ZeroMQVersion - Class in akka.zeromq
A Model to represent a version of the zeromq library
ZeroMQVersion(int, int, int) - Constructor for class akka.zeromq.ZeroMQVersion
 
ZeroMQVersion$ - Class in akka.zeromq
 
ZeroMQVersion$() - Constructor for class akka.zeromq.ZeroMQVersion$
 
ZMQMessage - Class in akka.zeromq
A message received over the zeromq socket
ZMQMessage(Seq<Frame>) - Constructor for class akka.zeromq.ZMQMessage
 
ZMQMessage(Frame) - Constructor for class akka.zeromq.ZMQMessage
 
ZMQMessage(Frame, Frame) - Constructor for class akka.zeromq.ZMQMessage
 
ZMQMessage(Frame[]) - Constructor for class akka.zeromq.ZMQMessage
 
ZMQMessage$ - Class in akka.zeromq
Convert the bytes in the first frame to a String, using "UTF-8" charset.
ZMQMessage$() - Constructor for class akka.zeromq.ZMQMessage$
 
ZMQMessageDeserializer - Class in akka.zeromq
 
ZMQMessageDeserializer() - Constructor for class akka.zeromq.ZMQMessageDeserializer
 

_

_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 X Z _