All Classes Interface Summary Class Summary Enum Summary Exception Summary Annotation Types Summary
Class |
Description |
AAAARecord |
|
AAAARecord$ |
INTERNAL API
|
AbruptIOTerminationException |
This exception signals that a stream has been completed by an onError signal
while there was still IO operations in progress.
|
AbruptIOTerminationException$ |
|
AbruptStageTerminationException |
Signal that the operator was abruptly terminated, usually seen as a call to postStop of the GraphStageLogic without
any of the handler callbacks seeing completion or failure from upstream or cancellation from downstream.
|
AbruptTerminationException |
This exception signals that an actor implementing a Reactive Streams Subscriber, Publisher or Processor
has been terminated without being notified by an onError, onComplete or cancel signal.
|
AbruptTerminationException$ |
|
AbstractActor |
Returns this AbstractActor's ActorContext
The ActorContext is not thread safe so do not expose it outside of the
AbstractActor.
|
AbstractActor.ActorContext |
The ActorRef representing this actor
|
AbstractActor.Receive |
|
AbstractActor$ |
Defines which messages the Actor can handle, along with the implementation of
how the messages should be processed.
|
AbstractActorPublisher<T> |
Deprecated.
|
AbstractActorPublisher$ |
Deprecated.
|
AbstractActorPublisherWithStash<T> |
Deprecated.
|
AbstractActorPublisherWithUnboundedStash<T> |
Deprecated.
|
AbstractActorPublisherWithUnrestrictedStash<T> |
Deprecated.
|
AbstractActorSubscriber |
Deprecated.
|
AbstractActorSubscriber$ |
Deprecated.
|
AbstractActorWithStash |
Java API: compatible with lambda expressions
|
AbstractActorWithTimers |
Start and cancel timers via the enclosed TimerScheduler .
|
AbstractActorWithUnboundedStash |
Java API: compatible with lambda expressions
|
AbstractActorWithUnrestrictedStash |
Java API: compatible with lambda expressions
|
AbstractBehavior<T> |
Implement this to define how messages and signals are processed.
|
AbstractBehavior<T> |
Implement this method to process an incoming message and return the next behavior.
|
AbstractBoundedNodeQueue<T> |
Lock-free bounded non-blocking multiple-producer single-consumer queue based on the works of:
Andriy Plokhotnuyk (https://github.com/plokhotnyuk)
- https://github.com/plokhotnyuk/actors/blob/2e65abb7ce4cbfcb1b29c98ee99303d6ced6b01f/src/test/scala/akka/dispatch/Mailboxes.scala
(Apache V2: https://github.com/plokhotnyuk/actors/blob/master/LICENSE)
Dmitriy Vyukov's non-intrusive MPSC queue:
- http://www.1024cores.net/home/lock-free-algorithms/queues/non-intrusive-mpsc-node-based-queue
(Simplified BSD)
|
AbstractBoundedNodeQueue.Node<T> |
|
AbstractDeltaReplicatedData<A extends AbstractDeltaReplicatedData<A,B>,B extends ReplicatedDelta> |
|
AbstractEventsByPersistenceIdPublisher |
INTERNAL API
|
AbstractEventsByTagPublisher |
INTERNAL API
|
AbstractExtensionId<T extends Extension> |
Java API for ExtensionId
|
AbstractExtensionSetup<T extends Extension> |
Scala 2.11 API: Each extension typically provide a concrete ExtensionSetup that can be used in
ActorSystemSetup when starting the ActorSystem to replace the default
implementation of the extension.
|
AbstractFSM<S,D> |
Returns this AbstractActor's ActorContext
The ActorContext is not thread safe so do not expose it outside of the
AbstractActor.
|
AbstractFSM$ |
A partial function value which does not match anything and can be used to
“reset” whenUnhandled and onTermination handlers.
|
AbstractFSMWithStash<S,D> |
Java API: compatible with lambda expressions
|
AbstractGraphStageWithMaterializedValue<S extends Shape,M> |
Java API: A GraphStage represents a reusable graph stream processing operator.
|
AbstractInHandler |
Java API: callbacks for an input port where termination logic is predefined
(completing when upstream completes, failing when upstream fails).
|
AbstractInOutHandler |
Java API: callback combination for output and input ports where termination logic is predefined
(completing when upstream completes, failing when upstream fails, completing when downstream cancels).
|
AbstractLogger |
If arg is an Array it will be expanded into replacement arguments, which is useful when
there are more than four arguments.
|
AbstractLoggingActor |
Java API: compatible with lambda expressions
|
AbstractLoggingFSM<S,D> |
Java API: compatible with lambda expressions
|
AbstractNodeQueue<T> |
Lock-free MPSC linked queue implementation based on Dmitriy Vyukov's non-intrusive MPSC queue:
http://www.1024cores.net/home/lock-free-algorithms/queues/non-intrusive-mpsc-node-based-queue
This queue could be wait-free (i.e.
|
AbstractNodeQueue.Node<T> |
|
AbstractOutHandler |
Java API: callbacks for an output port where termination logic is predefined
(completing when downstream cancels).
|
AbstractPersistentActor |
Recovery handler that receives persisted events during recovery.
|
AbstractPersistentActorLike |
Recovery handler that receives persisted events during recovery.
|
AbstractPersistentActorWithAtLeastOnceDelivery |
Java API: Send the message created by the deliveryIdToMessage function to
the destination actor.
|
AbstractPersistentActorWithTimers |
|
AbstractPersistentFSM<S extends PersistentFSM.FSMState,D,E> |
Adapter from Java 8 Functional Interface to Scala Function
param: action - Java 8 lambda expression defining the action
|
AbstractPersistentFSMBase<S,D,E> |
Returns this AbstractActor's ActorContext
The ActorContext is not thread safe so do not expose it outside of the
AbstractActor.
|
AbstractPersistentFSMBase$ |
A partial function value which does not match anything and can be used to
“reset” whenUnhandled and onTermination handlers.
|
AbstractPersistentLoggingFSM<S extends PersistentFSM.FSMState,D,E> |
Java API: compatible with lambda expressions
|
AbstractProps |
INTERNAL API
|
AbstractReplicatedData<A extends AbstractReplicatedData<A>> |
|
AbstractScheduler |
An Akka scheduler service.
|
AbstractSchedulerBase |
The maximum supported task frequency of this scheduler, i.e.
|
AbstractSerializationSupport |
Java API
|
AbstractServiceKey |
Type-safe down-cast
|
AbstractShape |
Provide the list of all input ports of this shape.
|
AbstractSupervisor<O,I,Thr extends java.lang.Throwable> |
INTERNAL API
|
AbstractTransportAdapter |
INTERNAL API
|
AbstractTransportAdapterHandle |
INTERNAL API
|
Ack |
Java API to get the Ack singleton
|
Ack |
Class representing an acknowledgement with selective negative acknowledgements.
|
Ack$ |
Java API to get the Ack singleton
|
Ack$ |
|
AckedReceiveBuffer<T extends HasSequenceNumber> |
Puts a sequenced message in the receive buffer returning a new buffer.
|
AckedReceiveBuffer$ |
|
AckedSendBuffer<T extends HasSequenceNumber> |
Processes an incoming acknowledgement and returns a new buffer with only unacknowledged elements remaining.
|
AckedSendBuffer$ |
|
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.
|
ActivationProtocol |
Super class of all activation messages.
|
ActivationProtocol.ActivationMessage |
|
ActivationProtocol.ActivationMessage$ |
|
ActivationProtocol.EndpointActivated |
|
ActivationProtocol.EndpointActivated$ |
|
ActivationProtocol.EndpointDeActivated |
|
ActivationProtocol.EndpointDeActivated$ |
|
ActivationProtocol.EndpointFailedToActivate |
|
ActivationProtocol.EndpointFailedToActivate$ |
|
ActivationProtocol.EndpointFailedToDeActivate |
|
ActivationProtocol.EndpointFailedToDeActivate$ |
|
ActivationProtocol$ |
Super class of all activation messages.
|
ActivationTracker |
A state machine that keeps track of the endpoint activation status of an actor.
|
Actor |
Scala API: Stores the context for this actor, including self, and sender.
|
Actor.emptyBehavior$ |
emptyBehavior is a Receive-expression that matches no messages at all, ever.
|
Actor.ignoringBehavior$ |
|
Actor$ |
Type alias representing a Receive-expression for Akka Actors.
|
ActorActivationException |
INTERNAL API
Thrown by the registrars to indicate that the actor could not be activated.
|
ActorAdapter<T> |
Failures from failed children, that were stopped through untyped supervision, this is what allows us to pass
child exception in Terminated for direct children.
|
ActorAdapter.TypedActorFailedException |
|
ActorAdapter.TypedActorFailedException$ |
|
ActorAdapter$ |
Thrown to indicate that a Behavior has failed so that the parent gets
the cause and can fill in the cause in the ChildFailed signal
Wrapped to avoid it being logged as the typed supervision will already
have logged it.
|
ActorAttributes |
INTERNAL API
Resolves the dispatcher's name with a fallback to the default blocking IO dispatcher.
|
ActorAttributes.Dispatcher |
|
ActorAttributes.Dispatcher$ |
|
ActorAttributes.SupervisionStrategy |
|
ActorAttributes.SupervisionStrategy$ |
|
ActorAttributes$ |
INTERNAL API
Resolves the dispatcher's name with a fallback to the default blocking IO dispatcher.
|
ActorCell |
Everything in here is completely Akka PRIVATE.
|
ActorCell$ |
Everything in here is completely Akka PRIVATE.
|
ActorClassificationUnsubscriber |
INTERNAL API
|
ActorClassificationUnsubscriber.Register |
|
ActorClassificationUnsubscriber.Register$ |
|
ActorClassificationUnsubscriber.Unregister |
|
ActorClassificationUnsubscriber.Unregister$ |
|
ActorClassificationUnsubscriber$ |
INTERNAL API
|
ActorClassifier |
Can be mixed into an EventBus to specify that the Classifier type is ActorRef
|
ActorComponent |
|
ActorContext |
The ActorRef representing this actor
|
ActorContext<T> |
Get the scaladsl of this ActorContext .
|
ActorContext<T> |
Get the javadsl of this ActorContext .
|
ActorContextAdapter<T> |
Made accessible to allow stash to deal with unhandled messages as though they were interpreted by
the adapter itself, even though the unstashing occurs inside the behavior stack.
|
ActorContextAdapter$ |
|
ActorContextImpl<T> |
INTERNAL API: Needed to make Scala 2.12 compiler happy if spawnMessageAdapter is overloaded for scaladsl/javadsl.
|
ActorDeActivationException |
INTERNAL API
Thrown by registrars to indicate that the actor could not be de-activated.
|
ActorDSL |
Deprecated.
|
ActorDSL.Extension |
|
ActorDSL.Extension$ |
|
ActorDSL$ |
Deprecated.
|
ActorEndpoint |
The ActorEndpoint only supports receiving messages from Camel.
|
ActorEndpointConfig |
INTERNAL API
Configures the ActorEndpoint .
|
ActorEndpointPath |
INTERNAL API
An endpoint to an ActorRef
param: actorPath the String representation of the path to the actor
|
ActorEndpointPath$ |
|
ActorEventBus |
Represents an EventBus where the Subscriber type is ActorRef
|
ActorFlow |
Use the ask pattern to send a request-reply message to the target ref actor.
|
ActorFlow |
Use the ask pattern to send a request-reply message to the target ref actor.
|
ActorFlow$ |
Use the ask pattern to send a request-reply message to the target ref actor.
|
ActorFlow$ |
Use the ask pattern to send a request-reply message to the target ref actor.
|
ActorGraphInterpreter |
INTERNAL API
|
ActorGraphInterpreter.ActorOutputBoundary |
|
ActorGraphInterpreter.BatchingActorInputBoundary |
|
ActorGraphInterpreter.BoundaryEvent |
|
ActorGraphInterpreter.Cancel |
|
ActorGraphInterpreter.Cancel$ |
|
ActorGraphInterpreter.OutputBoundaryPublisher |
|
ActorGraphInterpreter.RequestMore |
|
ActorGraphInterpreter.RequestMore$ |
|
ActorGraphInterpreter.Resume$ |
|
ActorGraphInterpreter.SimpleBoundaryEvent |
|
ActorGraphInterpreter.Snapshot$ |
|
ActorGraphInterpreter.SubscribePending |
|
ActorGraphInterpreter.SubscribePending$ |
|
ActorGraphInterpreter$ |
INTERNAL API
|
ActorIdentity |
Java API: ActorRef of the actor replying to the request or
null if no actor matched the request.
|
ActorIdentity$ |
|
ActorInitializationException |
An ActorInitializationException is thrown when the initialization logic for an Actor fails.
|
ActorInitializationException$ |
|
ActorInterruptedException |
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 |
ActorKilledException is thrown when an Actor receives the Kill message
|
ActorKilledException$ |
|
ActorLogging |
Scala API: Mix in ActorLogging into your Actor to easily obtain a reference to a logger,
which is available under the name "log".
|
ActorMaterializer |
Shuts down this materializer and all the operators that have been materialized through this materializer.
|
ActorMaterializer |
Creates an ActorMaterializer which will execute every step of a transformation
pipeline within its own Actor .
|
ActorMaterializer$ |
Scala API: Creates an ActorMaterializer that can materialize stream blueprints as running streams.
|
ActorMaterializer$ |
Creates an ActorMaterializer which will execute every step of a transformation
pipeline within its own Actor .
|
ActorMaterializerFactory |
Creates an ActorMaterializer which will execute every step of a transformation
pipeline within its own Actor .
|
ActorMaterializerFactory$ |
Creates an ActorMaterializer which will execute every step of a transformation
pipeline within its own Actor .
|
ActorMaterializerHelper |
INTERNAL API
|
ActorMaterializerHelper$ |
INTERNAL API
|
ActorMaterializerSettings |
Each asynchronous piece of a materialized stream topology is executed by one Actor
that manages an input buffer for all inlets of its shape.
|
ActorMaterializerSettings$ |
|
ActorNotFound |
|
ActorNotFound$ |
|
ActorNotRegisteredException |
Thrown to indicate that the actor referenced by an endpoint URI cannot be
found in the actor system.
|
ActorPath |
The Address under which this path can be reached; walks up the tree to
the RootActorPath.
|
ActorPath$ |
Parse string as actor path; throws java.net.MalformedURLException if unable to do so.
|
ActorPathExtractor |
Given an ActorPath it returns the Address and the path elements if the path is well-formed
|
ActorPathExtractor$ |
Given an ActorPath it returns the Address and the path elements if the path is well-formed
|
ActorPaths |
Parse string as actor path; throws java.net.MalformedURLException if unable to do so.
|
ActorPaths$ |
Parse string as actor path; throws java.net.MalformedURLException if unable to do so.
|
ActorProcessor<I,O> |
INTERNAL API
|
ActorProcessor$ |
INTERNAL API
|
ActorProcessorImpl |
|
ActorProducer |
Processes the exchange.
|
ActorPublisher<T> |
Deprecated.
|
ActorPublisher<T> |
INTERNAL API
|
ActorPublisher.Internal$ |
INTERNAL API
|
ActorPublisher.Internal$.LifecycleState |
|
ActorPublisher.NormalShutdownException |
|
ActorPublisher$ |
Deprecated.
|
ActorPublisher$ |
INTERNAL API
|
ActorPublisherImpl<T> |
INTERNAL API
|
ActorPublisherImpl$ |
|
ActorPublisherMessage |
INTERNAL API
|
ActorPublisherMessage.Cancel |
|
ActorPublisherMessage.Cancel$ |
|
ActorPublisherMessage.Request |
|
ActorPublisherMessage.Request$ |
|
ActorPublisherMessage.SubscriptionTimeoutExceeded |
|
ActorPublisherMessage.SubscriptionTimeoutExceeded$ |
This message is delivered to the ActorPublisher actor in order to signal the exceeding of an subscription timeout.
|
ActorPublisherMessage$ |
This message is delivered to the ActorPublisher actor when the stream subscriber requests
more elements.
|
ActorPublisherSource<Out> |
INTERNAL API
Creates and wraps an actor into Publisher from the given props ,
which should be Props for an ActorPublisher .
|
ActorPublisherState |
INTERNAL API
|
ActorPublisherState.State |
|
ActorPublisherState.State$ |
|
ActorPublisherState$ |
INTERNAL API
Some state must survive restarts.
|
ActorPublisherSubscription<T> |
INTERNAL API
|
ActorRef |
Returns the path for this actor (from this actor up to the root actor).
|
ActorRef<T> |
Send a message to the Actor referenced by this ActorRef using *at-most-once*
messaging semantics.
|
ActorRef.ActorRefOps<T> |
|
ActorRef.ActorRefOps$ |
|
ActorRef$ |
|
ActorRef$ |
Send a message to the Actor referenced by this ActorRef using *at-most-once*
messaging semantics.
|
ActorRefAdapter<T> |
INTERNAL API
|
ActorRefAdapter$ |
|
ActorRefBackpressureSinkStage<In> |
INTERNAL API
|
ActorRefBackpressureSource<T> |
INTERNAL API
|
ActorRefBackpressureSource.ActorRefStage |
|
ActorRefBackpressureSource$ |
|
ActorRefFactory |
INTERNAL API
|
ActorRefFactoryAdapter |
INTERNAL API
|
ActorRefFactoryAdapter$ |
INTERNAL API
|
ActorRefImpl<T> |
Comparison takes path and the unique id of the actor cell into account.
|
ActorRefProvider |
Reference to the supervisor of guardian and systemGuardian; this is
exposed so that the ActorSystemImpl can use it as lookupRoot, i.e.
|
ActorRefResolveCache |
INTERNAL API
|
ActorRefResolveCacheWithAddress |
INTERNAL API
|
ActorRefResolver |
Generate full String representation including the uid for the actor cell
instance as URI fragment, replacing the Address in the RootActor Path
with the local one unless this path’s address includes host and port
information.
|
ActorRefResolver$ |
|
ActorRefResolverImpl |
INTERNAL API
|
ActorRefResolverSetup |
|
ActorRefResolverSetup$ |
|
ActorRefResolveThreadLocalCache |
INTERNAL API
|
ActorRefResolveThreadLocalCache$ |
INTERNAL API: Thread local cache per actor system
|
ActorRefRoutee |
|
ActorRefRoutee$ |
|
ActorRefScope |
All ActorRefs have a scope which describes where they live.
|
ActorRefSink<In> |
INTERNAL API
|
ActorRefSinkActor |
INTERNAL API
|
ActorRefSinkActor$ |
INTERNAL API
|
ActorRefSource<T> |
INTERNAL API
|
ActorRefSource.ActorRefStage |
|
ActorRefSource$ |
|
ActorRefWithCell |
Common trait of all actor refs which actually have a Cell, most notably
LocalActorRef and RepointableActorRef.
|
ActorRouteDefinition<T extends org.apache.camel.model.ProcessorDefinition<T>> |
Sends the message to an ActorRef endpoint.
|
ActorSelection |
Sends the specified message to this ActorSelection, i.e.
|
ActorSelection$ |
Construct an ActorSelection from the given string representing a path
relative to the given target.
|
ActorSelectionMessage |
INTERNAL API
ActorRefFactory.actorSelection returns a ActorSelection which sends these
nested path descriptions whenever using ! on them, the idea being that the
message is delivered by traversing the various actor paths involved.
|
ActorSelectionMessage$ |
|
ActorSelectionRoutee |
|
ActorSelectionRoutee$ |
|
ActorSink |
Sends the elements of the stream to the given ActorRef .
|
ActorSink |
Sends the elements of the stream to the given ActorRef .
|
ActorSink$ |
Sends the elements of the stream to the given ActorRef .
|
ActorSink$ |
Sends the elements of the stream to the given ActorRef .
|
ActorSource |
Creates a Source that is materialized as an ActorRef .
|
ActorSource |
Creates a Source that is materialized as an ActorRef .
|
ActorSource$ |
Creates a Source that is materialized as an ActorRef .
|
ActorSource$ |
Creates a Source that is materialized as an ActorRef .
|
ActorSubscriber |
Deprecated.
|
ActorSubscriber.OnSubscribe |
INTERNAL API
|
ActorSubscriber.OnSubscribe$ |
|
ActorSubscriber$ |
Deprecated.
|
ActorSubscriberImpl<T> |
INTERNAL API
|
ActorSubscriberMessage |
INTERNAL API
|
ActorSubscriberMessage.OnComplete$ |
|
ActorSubscriberMessage.OnError |
|
ActorSubscriberMessage.OnError$ |
|
ActorSubscriberMessage.OnNext |
|
ActorSubscriberMessage.OnNext$ |
|
ActorSubscriberMessage$ |
Java API: get the singleton instance of the OnComplete message
|
ActorSubscriberSink<In> |
INTERNAL API
Creates and wraps an actor into Subscriber from the given props ,
which should be Props for an ActorSubscriber .
|
ActorSubscriberState |
INTERNAL API
|
ActorSubscriberState.State |
|
ActorSubscriberState.State$ |
|
ActorSubscriberState$ |
INTERNAL API
Some state must survive restarts.
|
ActorSubscription<T> |
INTERNAL API
|
ActorSubscriptionWithCursor<T> |
INTERNAL API
|
ActorSystem |
The name of this actor system, used to distinguish multiple ones within
the same JVM & class loader.
|
ActorSystem<T> |
The name of this actor system, used to distinguish multiple ones within
the same JVM & class loader.
|
ActorSystem.Settings |
The backing Config of this ActorSystem's Settings
|
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.
|
ActorSystem$ |
Scala API: Create an ActorSystem
|
ActorSystemActivator |
Implement this method to add your own actors to the ActorSystem.
|
ActorSystemAdapter<T> |
INTERNAL API.
|
ActorSystemAdapter.AdapterExtension |
|
ActorSystemAdapter.AdapterExtension$ |
|
ActorSystemAdapter.LoadTypedExtensions |
|
ActorSystemAdapter.LoadTypedExtensions$ |
|
ActorSystemAdapter$ |
An untyped extension to load configured typed extensions.
|
ActorSystemImpl |
This is an extension point: by overriding this method, subclasses can
control all reflection activities of an actor system.
|
ActorSystemSetup |
Java API: Extract a concrete Setup of type T if it is defined in the settings.
|
ActorSystemSetup$ |
|
ActorSystemStub |
INTERNAL API
|
ActorSystemTerminating |
INTERNAL API
|
ActorSystemTerminating$ |
|
ActorSystemTerminatingAck |
INTERNAL API
|
ActorSystemTerminatingAck$ |
|
ActorTestKit |
|
ActorTestKit |
Spawn the given behavior.
|
ActorTestKit$ |
Create a testkit named from the class that is calling this method.
|
ActorTestKit$ |
Create a testkit named from the class that is calling this method.
|
ActorTestKitBase |
Use a custom config for the actor system.
|
ActorTestKitBase$ |
|
ActorTestKitGuardian |
INTERNAL API
|
ActorTestKitGuardian.Ack$ |
|
ActorTestKitGuardian.ActorStopped<T> |
|
ActorTestKitGuardian.ActorStopped$ |
|
ActorTestKitGuardian.SpawnActor<T> |
|
ActorTestKitGuardian.SpawnActor$ |
|
ActorTestKitGuardian.SpawnActorAnonymous<T> |
|
ActorTestKitGuardian.SpawnActorAnonymous$ |
|
ActorTestKitGuardian.StopActor<T> |
|
ActorTestKitGuardian.StopActor$ |
|
ActorTestKitGuardian.TestKitCommand |
|
ActorTestKitGuardian$ |
INTERNAL API
|
ActorTransportAdapter |
|
ActorTransportAdapter.AssociateUnderlying |
|
ActorTransportAdapter.AssociateUnderlying$ |
|
ActorTransportAdapter.DisassociateUnderlying |
|
ActorTransportAdapter.DisassociateUnderlying$ |
|
ActorTransportAdapter.ListenerRegistered |
|
ActorTransportAdapter.ListenerRegistered$ |
|
ActorTransportAdapter.ListenUnderlying |
|
ActorTransportAdapter.ListenUnderlying$ |
|
ActorTransportAdapter.TransportOperation |
|
ActorTransportAdapter$ |
|
ActorTransportAdapterManager |
|
AdaptedClusterSingletonImpl |
INTERNAL API:
|
Adapter |
Spawn the given behavior as a child of the user actor in an untyped ActorSystem.
|
Adapter$ |
Spawn the given behavior as a child of the user actor in an untyped ActorSystem.
|
AdapterClusterImpl |
INTERNAL API:
|
AdapterClusterImpl.SeenState |
|
AdapterClusterImpl$ |
INTERNAL API:
|
AdapterExtension |
Internal API
|
AdapterExtension$ |
Internal API
|
AdaptiveLoadBalancingGroup |
Java API
param: metricsSelector decides what probability to use for selecting a routee, based
on remaining capacity as indicated by the node metrics
param: routeesPaths string representation of the actor paths of the routees, messages are
sent with ActorSelection to these paths
|
AdaptiveLoadBalancingGroup$ |
|
AdaptiveLoadBalancingMetricsListener |
INTERNAL API
Subscribe to ClusterMetricsEvent s and update routing logic depending on the events.
|
AdaptiveLoadBalancingPool |
Java API
param: metricsSelector decides what probability to use for selecting a routee, based
on remaining capacity as indicated by the node metrics
param: nr initial number of routees in the pool
|
AdaptiveLoadBalancingPool$ |
|
AdaptiveLoadBalancingRoutingLogic |
Load balancing of messages to cluster nodes based on cluster metric data.
|
AdaptiveLoadBalancingRoutingLogic$ |
|
AdaptMessage<U,T> |
INTERNAL API: Wrapping of messages that should be adapted by the included
function.
|
AdaptMessage$ |
|
AdaptWithRegisteredMessageAdapter<U> |
INTERNAL API: Wrapping of messages that should be adapted by
adapters registered with ActorContext.messageAdapter .
|
AdaptWithRegisteredMessageAdapter$ |
|
Address |
Returns true if this Address is only defined locally.
|
Address$ |
Constructs a new Address with the specified protocol and system name
|
AddressFromURIString |
Try to construct an Address from the given String or throw a java.net.MalformedURLException.
|
AddressFromURIString$ |
Try to construct an Address from the given String or throw a java.net.MalformedURLException.
|
AddressReply |
|
AddressReply$ |
|
AddressTerminated |
INTERNAL API
|
AddressTerminated$ |
|
AddressTerminatedTopic |
INTERNAL API
|
AddressTerminatedTopic$ |
INTERNAL API
|
AddressUidExtension |
|
AddressUidExtension$ |
Extension that holds a uid that is assigned as a random Long or Int depending
on which version of remoting that is used.
|
AddressUrlEncoder |
INTERNAL API
|
AddressUrlEncoder$ |
INTERNAL API
|
AddRoutee |
Add a routee by sending this message to the router.
|
AddRoutee$ |
|
AdjustPoolSize |
Increase or decrease the number of routees in a Pool .
|
AdjustPoolSize$ |
|
AeronErrorLog |
Application to print out errors recorded in the command-and-control (cnc) file is maintained by
media driver in shared memory.
|
AeronSink |
INTERNAL API
param: channel eg.
|
AeronSink.GaveUpMessageException |
|
AeronSink.PublicationClosedException |
|
AeronSink$ |
INTERNAL API
|
AeronSource |
INTERNAL API
param: channel eg.
|
AeronSource.AeronLifecycle |
|
AeronSource.Fragments |
|
AeronSource.MessageHandler |
|
AeronSource$ |
INTERNAL API
|
AffinityPool |
Each worker should go through that method while terminating.
|
AffinityPool$ |
|
AffinityPoolConfigurator |
INTERNAL API
|
Agent<T> |
Deprecated.
|
Agent$ |
Deprecated.
|
AggregateServiceDiscovery |
Each discovery method is given the resolveTimeout rather than reducing it each time between methods.
|
AggregateServiceDiscovery$ |
INTERNAL API
|
AggregateServiceDiscoverySettings |
INTERNAL API
|
Aggregator |
Deprecated.
|
AkkaCamelException |
An exception indicating that the exchange to the camel endpoint failed.
|
AkkaClusterTypedSerializer |
INTERNAL API
|
AkkaException |
Akka base Exception.
|
AkkaLoggerBridge |
|
AkkaLoggerFactory |
|
AkkaPduCodec |
|
AkkaPduCodec.AkkaPdu |
|
AkkaPduCodec.Associate |
|
AkkaPduCodec.Associate$ |
|
AkkaPduCodec.Disassociate |
|
AkkaPduCodec.Disassociate$ |
|
AkkaPduCodec.Heartbeat$ |
|
AkkaPduCodec.Message |
|
AkkaPduCodec.Message$ |
|
AkkaPduCodec.Payload |
|
AkkaPduCodec.Payload$ |
|
AkkaPduCodec$ |
Trait that represents decoded Akka PDUs (Protocol Data Units)
|
AkkaPduProtobufCodec |
INTERNAL API
|
AkkaPduProtobufCodec$ |
INTERNAL API
|
AkkaProtocolException |
|
AkkaProtocolHandle |
|
AkkaProtocolManager |
|
AkkaProtocolSettings |
|
AkkaProtocolTransport |
Implementation of the Akka protocol as a Transport that wraps an underlying Transport instance.
|
AkkaProtocolTransport.AssociateUnderlyingRefuseUid |
|
AkkaProtocolTransport.AssociateUnderlyingRefuseUid$ |
|
AkkaProtocolTransport$ |
|
AkkaSSLConfig |
Can be used to modify the underlying config, most typically used to change a few values in the default config
|
AkkaSSLConfig$ |
|
AkkaVersion |
Check that the version of Akka is a specific patch version or higher and throw an UnsupportedAkkaVersion
exception if the version requirement is not fulfilled.
|
AkkaVersion$ |
Check that the version of Akka is a specific patch version or higher and throw an UnsupportedAkkaVersion
exception if the version requirement is not fulfilled.
|
AllAtOnceEntityRecoveryStrategy |
|
AllDeadLetters |
Subscribe to this class to be notified about all DeadLetters (also the suppressed ones).
|
AllForOneStrategy |
Java API
|
AllForOneStrategy$ |
|
AllPersistenceIdsPublisher |
INTERNAL API
|
AllPersistenceIdsPublisher$ |
INTERNAL API
|
Always |
INTERNAL API
|
Always$ |
INTERNAL API
|
AmorphousShape |
This type of Shape can express any number of inputs and outputs at the
expense of forgetting about their specific types.
|
AmorphousShape$ |
|
ApiMayChange |
Marks APIs that are meant to evolve towards becoming stable APIs, but are not stable APIs yet.
|
AppendTraversal |
INTERNAL API
|
AppendTraversal$ |
|
ARecord |
|
ARecord$ |
INTERNAL API
|
ArgsReflectConstructor |
INTERNAL API
|
ArteryAeronUdpTransport |
INTERNAL API
|
ArteryControlFormats |
|
ArteryControlFormats.Address |
Protobuf type Address
|
ArteryControlFormats.Address.Builder |
Protobuf type Address
|
ArteryControlFormats.AddressOrBuilder |
|
ArteryControlFormats.ArteryHeartbeatRsp |
Protobuf type ArteryHeartbeatRsp
|
ArteryControlFormats.ArteryHeartbeatRsp.Builder |
Protobuf type ArteryHeartbeatRsp
|
ArteryControlFormats.ArteryHeartbeatRspOrBuilder |
|
ArteryControlFormats.CompressionTableAdvertisement |
Protobuf type CompressionTableAdvertisement
|
ArteryControlFormats.CompressionTableAdvertisement.Builder |
Protobuf type CompressionTableAdvertisement
|
ArteryControlFormats.CompressionTableAdvertisementAck |
Protobuf type CompressionTableAdvertisementAck
|
ArteryControlFormats.CompressionTableAdvertisementAck.Builder |
Protobuf type CompressionTableAdvertisementAck
|
ArteryControlFormats.CompressionTableAdvertisementAckOrBuilder |
|
ArteryControlFormats.CompressionTableAdvertisementOrBuilder |
|
ArteryControlFormats.HandshakeReq |
Protobuf type HandshakeReq
|
ArteryControlFormats.HandshakeReq.Builder |
Protobuf type HandshakeReq
|
ArteryControlFormats.HandshakeReqOrBuilder |
|
ArteryControlFormats.MessageWithAddress |
Protobuf type MessageWithAddress
|
ArteryControlFormats.MessageWithAddress.Builder |
Protobuf type MessageWithAddress
|
ArteryControlFormats.MessageWithAddressOrBuilder |
|
ArteryControlFormats.Quarantined |
Protobuf type Quarantined
|
ArteryControlFormats.Quarantined.Builder |
Protobuf type Quarantined
|
ArteryControlFormats.QuarantinedOrBuilder |
|
ArteryControlFormats.SystemMessageDeliveryAck |
Protobuf type SystemMessageDeliveryAck
|
ArteryControlFormats.SystemMessageDeliveryAck.Builder |
Protobuf type SystemMessageDeliveryAck
|
ArteryControlFormats.SystemMessageDeliveryAckOrBuilder |
|
ArteryControlFormats.SystemMessageEnvelope |
Protobuf type SystemMessageEnvelope
|
ArteryControlFormats.SystemMessageEnvelope.Builder |
Protobuf type SystemMessageEnvelope
|
ArteryControlFormats.SystemMessageEnvelopeOrBuilder |
|
ArteryControlFormats.UniqueAddress |
Protobuf type UniqueAddress
|
ArteryControlFormats.UniqueAddress.Builder |
Protobuf type UniqueAddress
|
ArteryControlFormats.UniqueAddressOrBuilder |
|
ArteryMessage |
INTERNAL API: marker trait for protobuf-serializable artery messages
|
ArteryMessageSerializer |
INTERNAL API
|
ArteryMessageSerializer$ |
INTERNAL API
|
ArterySettings |
Used version of the header format for outbound messages.
|
ArterySettings.AeronUpd$ |
|
ArterySettings.Compression |
INTERNAL API
|
ArterySettings.Compression$ |
|
ArterySettings.Tcp$ |
|
ArterySettings.TlsTcp$ |
|
ArterySettings.Transport |
|
ArterySettings$ |
INTERNAL API
|
ArteryTcpTransport |
INTERNAL API
|
ArteryTcpTransport$ |
INTERNAL API
|
ArteryTransport |
Compression tables must be created once, such that inbound lane restarts don't cause dropping of the tables.
|
ArteryTransport.AeronTerminated |
|
ArteryTransport.InboundStreamMatValues<LifeCycle> |
|
ArteryTransport.InboundStreamMatValues$ |
|
ArteryTransport.ShutdownSignal$ |
|
ArteryTransport.ShuttingDown$ |
|
ArteryTransport$ |
INTERNAL API
|
AskableActorRef |
|
AskableActorRef$ |
INTERNAL API
|
AskableActorSelection |
INTERNAL API: for binary compatibility
|
AskableActorSelection$ |
|
AskeableWithCircuitBreakerActor |
Deprecated.
|
AskeableWithCircuitBreakerActor$ |
Deprecated.
|
AskeableWithCircuitBreakerActorSelection |
Deprecated.
|
AskeableWithCircuitBreakerActorSelection$ |
Deprecated.
|
AskPattern |
The ask-pattern implements the initiator side of a request–reply protocol.
|
AskPattern |
See ask
|
AskPattern.Askable<T> |
|
AskPattern.Askable$ |
|
AskPattern$ |
The ask-pattern implements the initiator side of a request–reply protocol.
|
AskPattern$ |
See ask
|
AskPromiseRef |
|
AskPromiseRef$ |
|
AskSupport |
Import this implicit conversion to gain ? and ask methods on
ActorRef , which will defer to the
ask(actorRef, message)(timeout) method defined here.
|
AskTimeoutException |
This is what is used to complete a Future that is returned from an ask/? call,
when it times out.
|
AsPublisher |
|
AssociatedEvent |
|
AssociatedEvent$ |
|
Association |
Holds reference to shared state of Association - *access only via helper methods*
|
Association.DisabledQueueWrapper$ |
|
Association.LazyQueueWrapper |
|
Association.LazyQueueWrapper$ |
|
Association.OutboundStreamMatValues |
|
Association.OutboundStreamMatValues$ |
|
Association.OutboundStreamStopIdleSignal$ |
|
Association.OutboundStreamStopQuarantinedSignal$ |
|
Association.QueueWrapper |
|
Association.QueueWrapperImpl |
|
Association.QueueWrapperImpl$ |
|
Association.RemovedQueueWrapper$ |
|
Association.StopSignal |
|
Association$ |
INTERNAL API
|
AssociationErrorEvent |
|
AssociationErrorEvent$ |
|
AssociationEvent |
|
AssociationHandle |
Address of the local endpoint.
|
AssociationHandle.ActorHandleEventListener |
|
AssociationHandle.ActorHandleEventListener$ |
|
AssociationHandle.Disassociated |
|
AssociationHandle.Disassociated$ |
|
AssociationHandle.DisassociateInfo |
|
AssociationHandle.HandleEvent |
|
AssociationHandle.HandleEventListener |
|
AssociationHandle.InboundPayload |
|
AssociationHandle.InboundPayload$ |
|
AssociationHandle.Quarantined$ |
|
AssociationHandle.Shutdown$ |
|
AssociationHandle.Unknown$ |
|
AssociationHandle$ |
Trait for events that the registered listener for an AssociationHandle might receive.
|
AssociationProblem |
INTERNAL API
|
AssociationRegistry |
|
AssociationRegistry |
Resets the state of the registry.
|
AssociationRegistry$ |
Resets the state of the registry.
|
AssociationState |
Full outbound address with UID for this association.
|
AssociationState.QuarantinedTimestamp |
|
AssociationState.QuarantinedTimestamp$ |
|
AssociationState$ |
INTERNAL API
|
AsyncCallback<T> |
Dispatch an asynchronous notification.
|
AsyncDnsCache |
Gets any IPv4 and IPv6 cached entries.
|
AsyncDnsManager |
Ctr expected by the DnsExt for all DnsMangers
|
AsyncDnsManager.GetCache$ |
|
AsyncDnsManager$ |
INTERNAL API
|
AsyncDnsProvider |
INTERNAL API
|
AsyncDnsResolver |
INTERNAL API
|
AsyncDnsResolver.ResolveFailedException |
|
AsyncDnsResolver.ResolveFailedException$ |
|
AsyncDnsResolver$ |
INTERNAL API
|
AsyncRecovery |
Plugin API: asynchronously replays persistent messages.
|
AsyncRecovery |
Java API: asynchronous message replay and sequence number recovery interface.
|
AsyncReplayTimeoutException |
Thrown if replay inactivity exceeds a specified timeout.
|
AsyncSerializer |
Serializes the given object into an Array of Byte
|
AsyncSerializerWithStringManifest |
Scala API: Async serializer with string manifest that delegates synchronous calls to the asynchronous calls
and blocks.
|
AsyncSerializerWithStringManifestCS |
|
AsyncWriteJournal |
Plugin API: asynchronously writes a batch (Seq ) of persistent messages to the
journal.
|
AsyncWriteJournal |
Java API: abstract journal, optimized for asynchronous, non-blocking writes.
|
AsyncWriteJournal.Desequenced |
|
AsyncWriteJournal.Desequenced$ |
|
AsyncWriteJournal.Resequencer |
|
AsyncWriteJournal$ |
INTERNAL API.
|
AsyncWriteProxy |
INTERNAL API.
|
AsyncWriteProxy.InitTimeout$ |
|
AsyncWriteProxy.SetStore |
|
AsyncWriteProxy.SetStore$ |
|
AsyncWriteProxy$ |
INTERNAL API.
|
AsyncWriteTarget |
INTERNAL API.
|
AsyncWriteTarget.DeleteMessagesTo |
|
AsyncWriteTarget.DeleteMessagesTo$ |
|
AsyncWriteTarget.ReplayFailure |
|
AsyncWriteTarget.ReplayFailure$ |
|
AsyncWriteTarget.ReplayMessages |
|
AsyncWriteTarget.ReplayMessages$ |
|
AsyncWriteTarget.ReplaySuccess |
|
AsyncWriteTarget.ReplaySuccess$ |
|
AsyncWriteTarget.WriteMessages |
|
AsyncWriteTarget.WriteMessages$ |
|
AsyncWriteTarget$ |
INTERNAL API.
|
AtLeastOnceDelivery |
Scala API: Send the message created by the deliveryIdToMessage function to
the destination actor.
|
AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot |
|
AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot$ |
|
AtLeastOnceDelivery.Internal$ |
|
AtLeastOnceDelivery.MaxUnconfirmedMessagesExceededException |
|
AtLeastOnceDelivery.UnconfirmedDelivery |
|
AtLeastOnceDelivery.UnconfirmedDelivery$ |
|
AtLeastOnceDelivery.UnconfirmedWarning |
|
AtLeastOnceDelivery.UnconfirmedWarning$ |
|
AtLeastOnceDelivery$ |
Snapshot of current AtLeastOnceDelivery state.
|
AtLeastOnceDeliveryLike |
Interval between redelivery attempts.
|
AtomicTraversalBuilder |
INTERNAL API
|
AtomicTraversalBuilder$ |
|
AtomicWrite |
|
AtomicWrite$ |
|
Attributes |
Note that this must only be used during traversal building and not during materialization
as it will then always return true because of the defaults from the ActorMaterializerSettings
INTERNAL API
|
Attributes.AsyncBoundary$ |
|
Attributes.Attribute |
|
Attributes.CancellationStrategy |
|
Attributes.CancellationStrategy$ |
|
Attributes.CancellationStrategy$.AfterDelay |
|
Attributes.CancellationStrategy$.AfterDelay$ |
|
Attributes.CancellationStrategy$.CompleteStage$ |
|
Attributes.CancellationStrategy$.FailStage$ |
|
Attributes.CancellationStrategy$.Strategy |
|
Attributes.InputBuffer |
|
Attributes.InputBuffer$ |
|
Attributes.LogLevels |
|
Attributes.LogLevels$ |
|
Attributes.MandatoryAttribute |
|
Attributes.Name |
|
Attributes.Name$ |
|
Attributes$ |
Cancellation strategies provide a way to configure the behavior of a stage when cancelStage is called.
|
AutoDown |
INTERNAL API
|
AutoDown.UnreachableTimeout |
|
AutoDown.UnreachableTimeout$ |
|
AutoDown$ |
INTERNAL API
|
AutoDownBase |
INTERNAL API
|
AutoDowning |
Used when no custom provider is configured and 'auto-down-unreachable-after' is enabled.
|
AutoReceivedMessage |
INTERNAL API
|
AutoReset |
|
AutoReset$ |
|
AwaitActivation |
INTERNAL API
A request message to the ActivationTracker for the status of activation.
|
AwaitActivation$ |
|
AwaitDeActivation |
INTERNAL API
A request message to the ActivationTracker for the status of de-activation.
|
AwaitDeActivation$ |
|
Backoff |
Deprecated.
|
Backoff$ |
Deprecated.
|
BackoffOnFailureOptions |
Predicate evaluated for each message, if it returns true and the supervised actor is
stopped then the supervisor will stop its self.
|
BackoffOnFailureOptionsImpl<T> |
|
BackoffOnFailureOptionsImpl$ |
|
BackoffOnRestartSupervisor |
INTERNAL API
|
BackoffOnStopOptions |
Returns a new BackoffOptions with a default SupervisorStrategy.stoppingStrategy .
|
BackoffOnStopOptionsImpl<T> |
|
BackoffOnStopOptionsImpl$ |
|
BackoffOnStopSupervisor |
INTERNAL API
|
BackoffOptions |
Deprecated.
|
BackoffOptionsImpl |
Returns the props to create the back-off supervisor.
|
BackoffOptionsImpl$ |
|
BackoffOpts |
Back-off options for creating a back-off supervisor actor that expects a child actor to restart on failure.
|
BackoffOpts$ |
Back-off options for creating a back-off supervisor actor that expects a child actor to restart on failure.
|
BackoffReset |
|
BackoffSupervisor |
INTERNAL API
|
BackoffSupervisor.CurrentChild |
Java API: The ActorRef of the current child, if any
|
BackoffSupervisor.CurrentChild$ |
|
BackoffSupervisor.GetCurrentChild$ |
Send this message to the BackoffSupervisor and it will reply with
BackoffSupervisor.CurrentChild containing the ActorRef of the current child, if any.
|
BackoffSupervisor.GetRestartCount$ |
|
BackoffSupervisor.Reset$ |
|
BackoffSupervisor.ResetRestartCount |
|
BackoffSupervisor.ResetRestartCount$ |
|
BackoffSupervisor.RestartCount |
|
BackoffSupervisor.RestartCount$ |
|
BackoffSupervisor.StartChild$ |
|
BackoffSupervisor$ |
Props for creating a BackoffSupervisor actor.
|
BackoffSupervisorStrategy |
Scala API: The back-off algorithm is reset if the actor does not crash within the
specified resetBackoffAfter .
|
BackoffType |
|
Balance |
Create a new Balance operator with the specified input type, eagerCancel is false .
|
Balance<T> |
Fan-out the stream to several streams.
|
Balance$ |
Create a new Balance operator with the specified input type, eagerCancel is false .
|
Balance$ |
Create a new Balance with the specified number of output ports.
|
BalancingDispatcher |
Deprecated.
|
BalancingDispatcherConfigurator |
Returns the same dispatcher instance for each invocation
|
BalancingDispatcherConfigurator$ |
INTERNAL API
|
BalancingPool |
Java API
param: nr initial number of routees in the pool
|
BalancingPool$ |
|
BalancingPoolDeploy |
INTERNAL API
Can't be in the BalancingPool companion for binary compatibility reasons.
|
BalancingPoolDeploy$ |
INTERNAL API
Can't be in the BalancingPool companion for binary compatibility reasons.
|
BalancingRoutingLogic |
INTERNAL API
Selects the first routee, balancing will be done by the dispatcher.
|
BalancingRoutingLogic$ |
INTERNAL API
|
BarrierCoordinator |
This barrier coordinator gets informed of players connecting (NodeInfo),
players being deliberately removed (RemoveClient) or failing (ClientDisconnected)
by the controller.
|
BarrierCoordinator.BarrierEmpty |
|
BarrierCoordinator.BarrierEmpty$ |
|
BarrierCoordinator.BarrierTimeout |
|
BarrierCoordinator.BarrierTimeout$ |
|
BarrierCoordinator.ClientLost |
|
BarrierCoordinator.ClientLost$ |
|
BarrierCoordinator.Data |
|
BarrierCoordinator.Data$ |
|
BarrierCoordinator.DuplicateNode |
|
BarrierCoordinator.DuplicateNode$ |
|
BarrierCoordinator.FailedBarrier |
|
BarrierCoordinator.FailedBarrier$ |
|
BarrierCoordinator.Idle$ |
|
BarrierCoordinator.Printer |
|
BarrierCoordinator.RemoveClient |
|
BarrierCoordinator.RemoveClient$ |
|
BarrierCoordinator.State |
|
BarrierCoordinator.Waiting$ |
|
BarrierCoordinator.WrongBarrier |
|
BarrierCoordinator.WrongBarrier$ |
|
BarrierCoordinator$ |
INTERNAL API.
|
BarrierResult |
|
BarrierResult$ |
|
BaseSerializer |
Actor system which is required by most serializer implementations.
|
BaseSerializer$ |
Configuration namespace of serialization identifiers in the reference.conf .
|
Batch<In,Out> |
INTERNAL API
|
Batch$ |
|
Batchable |
All Batchables are automatically batched when submitted to a BatchingExecutor
|
BatchingExecutor |
Override this to define which runnables will be batched.
|
BatchingInputBuffer |
INTERNAL API
|
Behavior<T> |
Narrow the type of this Behavior, which is always a safe operation.
|
Behavior.BehaviorDecorators<T> |
|
Behavior.BehaviorDecorators$ |
|
Behavior.DeferredBehavior<T> |
INTERNAL API
Not placed in internal.BehaviorImpl because Behavior is sealed.
|
Behavior.DeferredBehavior$ |
|
Behavior.EmptyBehavior$ |
INTERNAL API.
|
Behavior.FailedBehavior |
|
Behavior.IgnoreBehavior$ |
|
Behavior.SameBehavior$ |
|
Behavior.StoppedBehavior<T> |
|
Behavior.StoppedBehavior$ |
|
Behavior.UnhandledBehavior$ |
|
Behavior$ |
Widen the wrapped Behavior by placing a funnel in front of it: the supplied
PartialFunction decides which message to pull in (those that it is defined
at) and may transform the incoming message to place them into the wrapped
Behavior’s type hierarchy.
|
BehaviorBuilder<T> |
Build a Behavior from the current state of the builder
|
BehaviorBuilder.Case<BT,MT> |
INTERNAL API
|
BehaviorBuilder.Case$ |
|
BehaviorBuilder$ |
INTERNAL API
|
BehaviorImpl |
|
BehaviorImpl.ContextAs<T> |
|
BehaviorImpl.ContextAs$ |
|
BehaviorImpl.OrElseBehavior<T> |
|
BehaviorImpl.ReceiveBehavior<T> |
|
BehaviorImpl.ReceiveBehavior$ |
|
BehaviorImpl.ReceiveMessageBehavior<T> |
|
BehaviorImpl.ReceiveMessageBehavior$ |
|
BehaviorImpl$ |
Similar to ReceiveBehavior however onMessage does not accept context.
|
BehaviorInterceptor<O,I> |
Allows for applying the interceptor only to certain message types.
|
BehaviorInterceptor.PreStartTarget<T> |
|
BehaviorInterceptor.ReceiveTarget<T> |
|
BehaviorInterceptor.SignalTarget<T> |
|
BehaviorInterceptor$ |
Abstraction of passing the on further in the behavior stack in BehaviorInterceptor#preStart .
|
Behaviors |
setup is a factory for a behavior.
|
Behaviors |
setup is a factory for a behavior.
|
Behaviors.Receive<T> |
Behavior that exposes additional fluent DSL methods to further change the message or
signal reception behavior.
|
Behaviors.ReceiveImpl<T> |
|
Behaviors.ReceiveMessageImpl<T> |
|
Behaviors.Supervise<T> |
Specify the SupervisorStrategy to be invoked when the wrapped behavior throws.
|
Behaviors.Supervise<T> |
Specify the SupervisorStrategy to be invoked when the wrapped behavior throws.
|
Behaviors.Supervise$ |
|
Behaviors$ |
setup is a factory for a behavior.
|
Behaviors$ |
setup is a factory for a behavior.
|
BehaviorSetup<C,E,S> |
catchAndLog=true should be used for "unknown" signals in the phases before Running
to avoid restart loops if restart supervision is used.
|
BehaviorSetup.NoSnapshot$ |
|
BehaviorSetup.SnapshotAfterPersist |
|
BehaviorSetup.SnapshotWithoutRetention$ |
|
BehaviorSetup.SnapshotWithRetention$ |
|
BehaviorSetup$ |
INTERNAL API
|
BehaviorTags |
INTERNAL API
|
BehaviorTags$ |
INTERNAL API
|
BehaviorTestKit<T> |
Requests the oldest Effect or akka.actor.testkit.typed.javadsl.Effects.noEffects if no effects
have taken place.
|
BehaviorTestKit<T> |
|
BehaviorTestKit$ |
JAVA API
|
BehaviorTestKit$ |
|
BehaviorTestKitImpl<T> |
INTERNAL API
|
BidiFlow<I1,O1,I2,O2,Mat> |
Add the given BidiFlow as the next step in a bidirectional transformation
pipeline.
|
BidiFlow<I1,O1,I2,O2,Mat> |
Add the given BidiFlow as the next step in a bidirectional transformation
pipeline.
|
BidiFlow$ |
A graph with the shape of a BidiFlow logically is a BidiFlow, this method makes
it so also in type.
|
BidiFlow$ |
A graph with the shape of a flow logically is a flow, this method makes
it so also in type.
|
BidiShape<In1,Out1,In2,Out2> |
Java API for creating from a pair of unidirectional flows.
|
BidiShape$ |
Java API
|
BindFailedException |
|
BindFailedException$ |
Deprecated.
|
BooleanSerializer |
INTERNAL API: only public by configuration
|
BootstrapSetup |
|
BootstrapSetup$ |
Scala API: Construct a bootstrap settings with default values.
|
BoundAddressesExtension |
Returns a mapping from a protocol to a set of bound addresses.
|
BoundAddressesExtension$ |
Extension provides access to bound addresses.
|
BoundedBlockingQueue<E> |
BoundedBlockingQueue wraps any Queue and turns the result into a BlockingQueue with a limited capacity.
|
BoundedBuffer<T> |
INTERNAL API
|
BoundedControlAwareMailbox |
BoundedControlAwareMailbox is a bounded MailboxType, that maintains two queues
to allow messages that extend ControlMessage to be delivered with priority.
|
BoundedControlAwareMailbox.MessageQueue |
|
BoundedControlAwareMailbox$ |
|
BoundedControlAwareMessageQueueSemantics |
|
BoundedDequeBasedMailbox |
BoundedDequeBasedMailbox is an bounded MailboxType, backed by a Deque.
|
BoundedDequeBasedMailbox.MessageQueue |
|
BoundedDequeBasedMailbox$ |
|
BoundedDequeBasedMessageQueue |
BoundedMessageQueueSemantics adds bounded semantics to a DequeBasedMessageQueue,
i.e.
|
BoundedDequeBasedMessageQueueSemantics |
|
BoundedMailbox |
BoundedMailbox is the default bounded MailboxType used by Akka Actors.
|
BoundedMailbox.MessageQueue |
|
BoundedMailbox$ |
|
BoundedMessageQueueSemantics |
BoundedMessageQueueSemantics adds bounded semantics to a QueueBasedMessageQueue,
i.e.
|
BoundedNodeMessageQueue |
Lock-free bounded non-blocking multiple-producer single-consumer queue.
|
BoundedPriorityMailbox |
BoundedPriorityMailbox is a bounded mailbox that allows for prioritization of its contents.
|
BoundedPriorityMailbox.MessageQueue |
|
BoundedPriorityMailbox$ |
|
BoundedQueueBasedMessageQueue |
|
BoundedStablePriorityMailbox |
BoundedStablePriorityMailbox is a bounded mailbox that allows for prioritization of its contents.
|
BoundedStablePriorityMailbox.MessageQueue |
|
BoundedStablePriorityMailbox$ |
|
BoxedType |
|
BoxedType$ |
|
Broadcast |
Used to broadcast a message to all routees in a router; only the
contained message will be forwarded, i.e.
|
Broadcast |
Create a new Broadcast operator with the specified input type.
|
Broadcast<T> |
Fan-out the stream to several streams emitting each incoming upstream element to all downstream consumers.
|
Broadcast$ |
|
Broadcast$ |
Create a new Broadcast operator with the specified input type.
|
Broadcast$ |
Create a new Broadcast with the specified number of output ports.
|
BroadcastGroup |
Java API
param: routeePaths string representation of the actor paths of the routees, messages are
sent with ActorSelection to these paths
|
BroadcastGroup$ |
|
BroadcastHub |
Creates a Sink that receives elements from its upstream producer and broadcasts them to a dynamic set
of consumers.
|
BroadcastHub<T> |
INTERNAL API
|
BroadcastHub.ConsumerEvent |
|
BroadcastHub.HubEvent |
|
BroadcastHub.HubState |
|
BroadcastHub$ |
Creates a Sink that receives elements from its upstream producer and broadcasts them to a dynamic set
of consumers.
|
BroadcastHub$ |
Creates a Sink that receives elements from its upstream producer and broadcasts them to a dynamic set
of consumers.
|
BroadcastPool |
Java API
param: nr initial number of routees in the pool
|
BroadcastPool$ |
|
BroadcastRoutingLogic |
Broadcasts a message to all its routees.
|
BroadcastRoutingLogic$ |
|
Buffer<T> |
INTERNAL API
|
Buffer<T> |
INTERNAL API
|
Buffer$ |
|
Buffer$ |
|
BufferOverflowException |
INTERNAL API
|
BufferOverflowException$ |
|
BufferPool |
|
BuilderKey |
INTERNAL API
|
BuiltBehavior<T> |
The concrete behavior
|
BuiltReceive<T> |
|
BundleDelegatingClassLoader |
|
BundleDelegatingClassLoader$ |
|
BusLogging |
|
ByteArraySerializer |
This is a special Serializer that Serializes and deserializes byte arrays only,
(just returns the byte array unchanged/uncopied)
|
ByteBufferSerializer |
Serializes the given object into the ByteBuffer .
|
ByteFlag |
INTERNAL API
|
ByteFlag$ |
INTERNAL API
|
ByteIterator |
Get a single Byte from this iterator.
|
ByteIterator.ByteArrayIterator |
|
ByteIterator.ByteArrayIterator$ |
|
ByteIterator.MultiByteArrayIterator |
|
ByteIterator.MultiByteArrayIterator$ |
|
ByteIterator$ |
For performance sensitive code, call take() directly on ByteString (it's optimised there)
|
ByteString |
Java API: copy this ByteString into a fresh byte array
|
ByteString.ByteString1 |
|
ByteString.ByteString1$ |
|
ByteString.ByteString1C |
|
ByteString.ByteString1C$ |
|
ByteString.ByteStrings |
|
ByteString.ByteStrings$ |
|
ByteString.Companion |
|
ByteString.Companion$ |
|
ByteString$ |
Creates a new ByteString by copying a byte array.
|
ByteStringBuilder |
Java API: append a ByteString to this builder.
|
ByteStringParser<T> |
doParse() is the main driver for the parser.
|
ByteStringParser.ByteReader |
|
ByteStringParser.FinishedParser$ |
|
ByteStringParser.ParseResult<T> |
param: result - parser can return some element for downstream or return None if no element was generated in this step
and parsing should immediately continue with the next step.
|
ByteStringParser.ParseResult$ |
|
ByteStringParser.ParseStep<T> |
|
ByteStringParser.ParsingException |
|
ByteStringParser$ |
param: result - parser can return some element for downstream or return None if no element was generated in this step
and parsing should immediately continue with the next step.
|
ByteStringSerializer |
|
CachePolicy |
|
CachePolicy.Forever$ |
|
CachePolicy.Never$ |
|
CachePolicy.Ttl |
|
CachePolicy.Ttl$ |
|
CachePolicy.Ttl$.TtlIsOrdered$ |
|
CachePolicy$ |
|
CacheStatistics |
INTERNAL API
|
CacheStatistics$ |
|
CachingConfig |
INTERNAL API
|
CachingConfig.PathEntry |
|
CachingConfig.StringPathEntry |
|
CachingConfig.StringPathEntry$ |
|
CachingConfig.ValuePathEntry |
|
CachingConfig.ValuePathEntry$ |
|
CachingConfig$ |
INTERNAL API
|
CachingPartialFunction<A,B> |
Deprecated.
|
CachingPartialFunction<A,B> |
INTERNAL API
|
Callback<State> |
INTERNAL API
|
CallingThreadDispatcher |
Dispatcher which runs invocations on the current thread only.
|
CallingThreadDispatcher$ |
|
CallingThreadDispatcherConfigurator |
|
CallingThreadDispatcherQueues |
|
CallingThreadDispatcherQueues$ |
|
CallingThreadMailbox |
This is only a marker to be put in the messageQueue’s stead to make error
messages pertaining to violated mailbox type requirements less cryptic.
|
Camel |
Underlying camel context.
|
CamelExchangeAdapter |
Returns the exchange id
|
CamelExtension |
Creates a new instance of Camel and makes sure it gets stopped when the actor system is shutdown.
|
CamelExtension$ |
Creates a new instance of Camel and makes sure it gets stopped when the actor system is shutdown.
|
CamelMessage |
Deprecated.
|
CamelMessage$ |
Deprecated.
|
CamelPath |
Converts the actorRef to a Camel URI (string) which can be used in custom routes.
|
CamelPath$ |
Converts the actorRef to a Camel URI (string) which can be used in custom routes.
|
CamelSettings |
Configured setting for how long the actor should wait for activation before it fails.
|
CamelSupervisor |
INTERNAL API
Top level supervisor for internal Camel actors
|
CamelSupervisor.AddWatch |
|
CamelSupervisor.AddWatch$ |
|
CamelSupervisor.CamelProducerObjects |
|
CamelSupervisor.CamelProducerObjects$ |
|
CamelSupervisor.CamelSupervisorMessage |
|
CamelSupervisor.DeRegister |
|
CamelSupervisor.DeRegister$ |
|
CamelSupervisor.Register |
|
CamelSupervisor.Register$ |
|
CamelSupervisor$ |
INTERNAL API
Registers a consumer or a producer.
|
CamelSupport |
INTERNAL API
Returns a Camel trait which provides access to the CamelExtension.
|
Cancel<T> |
INTERNAL API
|
Cancel$ |
|
Cancellable |
Cancels this Cancellable and returns true if that was successful.
|
Cancellable$ |
Returns true if and only if this Cancellable has been successfully cancelled
|
CancelledSubscription |
INTERNAL API
This is only a legal subscription when it is immediately followed by
a termination signal (onComplete, onError).
|
CancelledSubscription$ |
INTERNAL API
This is only a legal subscription when it is immediately followed by
a termination signal (onComplete, onError).
|
CancellingSubscriber<T> |
INTERNAL API
|
CancelSink |
INTERNAL API
A sink that immediately cancels its upstream upon materialization.
|
CapabilityFlag |
|
CapabilityFlag$ |
Java DSL
|
CapabilityFlags |
Java DSL
|
CapacityMetricsSelector |
Remaining capacity for each node.
|
CapturedLogEvent |
Constructor for Java API
|
CapturedLogEvent$ |
Helper method to convert OptionVal to Option
|
CaseStatement<F,P,T> |
|
CaseStatement$ |
|
ccompatUsedUntil213 |
INTERNAL API
|
Cell |
The “self” reference which this Cell is attached to.
|
ChannelLocalActor |
INTERNAL API
|
ChannelLocalActor$ |
INTERNAL API
|
ChannelRegistration |
Explicitly cancel the registration and close the underlying channel.
|
ChannelRegistry |
Registers the given channel with the selector, creates a ChannelRegistration instance for it
and dispatches it back to the channelActor calling this register
|
ChildActorPath |
INTERNAL API
|
ChildFailed |
Java API
|
ChildFailed$ |
Java API: The actor that was watched and got terminated
|
ChildNameReserved |
INTERNAL API
|
ChildNameReserved$ |
INTERNAL API
|
Children |
|
Children$ |
|
ChildrenContainer |
INTERNAL API
|
ChildrenContainer.ChildrenIterable |
|
ChildrenContainer.ChildRestartsIterable |
|
ChildrenContainer.Creation |
|
ChildrenContainer.Creation$ |
|
ChildrenContainer.EmptyChildrenContainer |
|
ChildrenContainer.EmptyChildrenContainer$ |
|
ChildrenContainer.NormalChildrenContainer |
|
ChildrenContainer.NormalChildrenContainer$ |
|
ChildrenContainer.Recreation |
|
ChildrenContainer.Recreation$ |
|
ChildrenContainer.SuspendReason |
|
ChildrenContainer.TerminatedChildrenContainer$ |
|
ChildrenContainer.TerminatingChildrenContainer |
|
ChildrenContainer.TerminatingChildrenContainer$ |
|
ChildrenContainer.Termination$ |
|
ChildrenContainer.UserRequest$ |
|
ChildrenContainer.WaitingForChildren |
|
ChildrenContainer$ |
This is the empty container, shared among all leaf actors.
|
ChildRestartStats |
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$ |
|
ChildStats |
INTERNAL API
|
CircuitBreaker |
The resetTimeout will be increased exponentially for each failed attempt to close the circuit.
|
CircuitBreaker.State |
Add a listener function which is invoked on state entry
|
CircuitBreaker$ |
Create a new CircuitBreaker.
|
CircuitBreakerAwareFuture |
Deprecated.
|
CircuitBreakerAwareFuture$ |
Deprecated.
|
CircuitBreakerOpenException |
Exception thrown when Circuit Breaker is open.
|
CircuitBreakerOpenException$ |
|
CircuitBreakerProxy |
Deprecated.
|
CircuitBreakerProxy.CircuitBreakerCommand |
|
CircuitBreakerProxy.CircuitBreakerEvent |
|
CircuitBreakerProxy.CircuitBreakerInternalEvents$ |
|
CircuitBreakerProxy.CircuitBreakerInternalEvents$.CircuitBreakerInternalEvent |
|
CircuitBreakerProxy.CircuitBreakerPropsBuilder |
|
CircuitBreakerProxy.CircuitBreakerPropsBuilder$ |
|
CircuitBreakerProxy.CircuitBreakerResponse |
|
CircuitBreakerProxy.CircuitBreakerState |
|
CircuitBreakerProxy.CircuitBreakerStateData |
|
CircuitBreakerProxy.CircuitBreakerStateData$ |
|
CircuitBreakerProxy.CircuitClosed |
|
CircuitBreakerProxy.CircuitClosed$ |
|
CircuitBreakerProxy.CircuitHalfOpen |
|
CircuitBreakerProxy.CircuitHalfOpen$ |
|
CircuitBreakerProxy.CircuitOpen |
|
CircuitBreakerProxy.CircuitOpen$ |
|
CircuitBreakerProxy.CircuitOpenFailure |
|
CircuitBreakerProxy.CircuitOpenFailure$ |
|
CircuitBreakerProxy.Closed$ |
|
CircuitBreakerProxy.HalfOpen$ |
|
CircuitBreakerProxy.Open$ |
|
CircuitBreakerProxy.Passthrough |
|
CircuitBreakerProxy.Passthrough$ |
|
CircuitBreakerProxy.TellOnly |
|
CircuitBreakerProxy.TellOnly$ |
|
CircuitBreakerProxy$ |
Deprecated.
|
ClassicActorContextProvider |
INTERNAL API
|
ClassicActorSystemProvider |
Allows access to the classic akka.actor.ActorSystem even for akka.actor.typed.ActorSystem[_] s.
|
ClassLoaderObjectInputStream |
ClassLoaderObjectInputStream tries to utilize the provided ClassLoader to load Classes and falls
back to ObjectInputStreams resolver.
|
Client |
INTERNAL API.
|
Client |
The client is usually the side that consumes the service provided by its
interlocutor.
|
Client$ |
INTERNAL API.
|
Client$ |
|
ClientFSM |
This is the controlling entity on the Player
side: in a first step it registers itself with a symbolic name and its remote
address at the Controller , then waits for the
Done message which signals that all other expected test participants have
done the same.
|
ClientFSM.AwaitDone$ |
|
ClientFSM.Connected |
|
ClientFSM.Connected$ |
|
ClientFSM.Connecting$ |
|
ClientFSM.ConnectionFailure |
|
ClientFSM.ConnectionFailure$ |
|
ClientFSM.Data |
|
ClientFSM.Data$ |
|
ClientFSM.Disconnected$ |
|
ClientFSM.Failed$ |
|
ClientFSM.State |
|
ClientFSM$ |
INTERNAL API.
|
ClientHandler |
INTERNAL API
|
ClientOp |
|
ClosedShape |
This Shape is used for graphs that have neither open inputs nor open
outputs.
|
ClosedShape$ |
Java API: obtain ClosedShape instance
|
Cluster |
The address including a uid of this cluster member.
|
Cluster |
Details about this cluster node itself
|
Cluster$ |
INTERNAL API
|
Cluster$ |
Java API
|
ClusterActorRefProvider |
Factory method to make it possible to override deployer in subclass
Creates a new instance every time
|
ClusterClient |
This actor is intended to be used on an external node that is not member
of the cluster.
|
ClusterClient.Internal$ |
|
ClusterClient.Publish |
|
ClusterClient.Publish$ |
|
ClusterClient.Send |
Convenience constructor with localAffinity false
|
ClusterClient.Send$ |
|
ClusterClient.SendToAll |
|
ClusterClient.SendToAll$ |
|
ClusterClient$ |
Scala API: Factory method for ClusterClient Props .
|
ClusterClientInteraction |
Declares a super type for all events emitted by the ClusterReceptionist .
|
ClusterClientMessage |
Marker trait for remote messages with special serializer.
|
ClusterClientMessages |
|
ClusterClientMessages.Contacts |
Protobuf type Contacts
|
ClusterClientMessages.Contacts.Builder |
Protobuf type Contacts
|
ClusterClientMessages.ContactsOrBuilder |
|
ClusterClientMessageSerializer |
INTERNAL API: Serializer of ClusterClient messages.
|
ClusterClientReceptionist |
Returns true if this member is not tagged with the role configured for the
receptionist.
|
ClusterClientReceptionist$ |
|
ClusterClients |
Java API
|
ClusterClients$ |
|
ClusterClientSettings |
For binary/source compatibility
|
ClusterClientSettings$ |
Create settings from the default configuration
akka.cluster.client .
|
ClusterClientUnreachable |
Emitted to the Akka event stream when a cluster client was previously connected
but then not seen for some time.
|
ClusterClientUnreachable$ |
|
ClusterClientUp |
Emitted to the Akka event stream when a cluster client has interacted with
a receptionist.
|
ClusterClientUp$ |
|
ClusterCommand |
Not intended for user extension.
|
ClusterCoreDaemon |
Looks up and returns the remote cluster command connection for the specific address.
|
ClusterCoreDaemon.ReceiveGossipType |
The types of gossip actions that receive gossip has performed.
|
ClusterCoreDaemon$ |
INTERNAL API.
|
ClusterCoreSupervisor |
INTERNAL API.
|
ClusterDaemon |
INTERNAL API.
|
ClusterDeployer |
INTERNAL API
|
ClusterDomainEventPublisher |
The current snapshot state corresponding to latest gossip
to mimic what you would have seen if you were listening to the events.
|
ClusterEvent |
|
ClusterEvent.ClusterDomainEvent |
Marker interface for cluster domain events.
|
ClusterEvent.ClusterShuttingDown$ |
|
ClusterEvent.CurrentClusterState |
|
ClusterEvent.CurrentClusterState$ |
|
ClusterEvent.CurrentInternalStats |
|
ClusterEvent.CurrentInternalStats$ |
|
ClusterEvent.DataCenterReachabilityEvent |
|
ClusterEvent.InitialStateAsEvents$ |
|
ClusterEvent.InitialStateAsSnapshot$ |
|
ClusterEvent.LeaderChanged |
|
ClusterEvent.LeaderChanged$ |
|
ClusterEvent.MemberDowned |
|
ClusterEvent.MemberDowned$ |
|
ClusterEvent.MemberEvent |
|
ClusterEvent.MemberExited |
|
ClusterEvent.MemberExited$ |
|
ClusterEvent.MemberJoined |
|
ClusterEvent.MemberJoined$ |
|
ClusterEvent.MemberLeft |
|
ClusterEvent.MemberLeft$ |
|
ClusterEvent.MemberRemoved |
|
ClusterEvent.MemberRemoved$ |
|
ClusterEvent.MemberUp |
|
ClusterEvent.MemberUp$ |
|
ClusterEvent.MemberWeaklyUp |
|
ClusterEvent.MemberWeaklyUp$ |
|
ClusterEvent.ReachabilityChanged |
|
ClusterEvent.ReachabilityChanged$ |
|
ClusterEvent.ReachabilityEvent |
|
ClusterEvent.ReachableDataCenter |
|
ClusterEvent.ReachableDataCenter$ |
|
ClusterEvent.ReachableMember |
|
ClusterEvent.ReachableMember$ |
|
ClusterEvent.RoleLeaderChanged |
|
ClusterEvent.RoleLeaderChanged$ |
|
ClusterEvent.SeenChanged |
|
ClusterEvent.SeenChanged$ |
|
ClusterEvent.SubscriptionInitialStateMode |
|
ClusterEvent.UnreachableDataCenter |
|
ClusterEvent.UnreachableDataCenter$ |
|
ClusterEvent.UnreachableMember |
|
ClusterEvent.UnreachableMember$ |
|
ClusterEvent$ |
|
ClusterHeartbeatReceiver |
INTERNAL API.
|
ClusterHeartbeatReceiver$ |
INTERNAL API: Utilities to obtain ClusterHeartbeatReceiver paths
|
ClusterHeartbeatSender |
Looks up and returns the remote cluster heartbeat connection for the specific address.
|
ClusterHeartbeatSender.ExpectedFirstHeartbeat |
|
ClusterHeartbeatSender.ExpectedFirstHeartbeat$ |
|
ClusterHeartbeatSender.Heartbeat |
|
ClusterHeartbeatSender.Heartbeat$ |
|
ClusterHeartbeatSender.HeartbeatRsp |
|
ClusterHeartbeatSender.HeartbeatRsp$ |
|
ClusterHeartbeatSender.HeartbeatTick$ |
|
ClusterHeartbeatSender$ |
Sent at regular intervals for failure detection.
|
ClusterHeartbeatSenderState |
|
ClusterHeartbeatSenderState$ |
|
ClusterJmx |
Creates the cluster JMX MBean and registers it in the MBean server.
|
ClusterMessage |
Base trait for all cluster messages.
|
ClusterMessages |
|
ClusterMessages |
|
ClusterMessages.Address |
Protobuf type Address
|
ClusterMessages.Address.Builder |
Protobuf type Address
|
ClusterMessages.AddressOrBuilder |
|
ClusterMessages.ClusterRouterPool |
Protobuf type ClusterRouterPool
|
ClusterMessages.ClusterRouterPool.Builder |
Protobuf type ClusterRouterPool
|
ClusterMessages.ClusterRouterPoolOrBuilder |
|
ClusterMessages.ClusterRouterPoolSettings |
Protobuf type ClusterRouterPoolSettings
|
ClusterMessages.ClusterRouterPoolSettings.Builder |
Protobuf type ClusterRouterPoolSettings
|
ClusterMessages.ClusterRouterPoolSettingsOrBuilder |
|
ClusterMessages.CompatibleConfig |
Protobuf type CompatibleConfig
|
ClusterMessages.CompatibleConfig.Builder |
Protobuf type CompatibleConfig
|
ClusterMessages.CompatibleConfigOrBuilder |
|
ClusterMessages.ConfigCheck |
Protobuf type ConfigCheck
|
ClusterMessages.ConfigCheck.Builder |
Protobuf type ConfigCheck
|
ClusterMessages.ConfigCheck.Type |
Protobuf enum ConfigCheck.Type
|
ClusterMessages.ConfigCheckOrBuilder |
|
ClusterMessages.Empty |
Protobuf type Empty
|
ClusterMessages.Empty.Builder |
Protobuf type Empty
|
ClusterMessages.EmptyOrBuilder |
|
ClusterMessages.Gossip |
Protobuf type Gossip
|
ClusterMessages.Gossip.Builder |
Protobuf type Gossip
|
ClusterMessages.GossipEnvelope |
Protobuf type GossipEnvelope
|
ClusterMessages.GossipEnvelope.Builder |
Protobuf type GossipEnvelope
|
ClusterMessages.GossipEnvelopeOrBuilder |
|
ClusterMessages.GossipOrBuilder |
|
ClusterMessages.GossipOverview |
Protobuf type GossipOverview
|
ClusterMessages.GossipOverview.Builder |
Protobuf type GossipOverview
|
ClusterMessages.GossipOverviewOrBuilder |
|
ClusterMessages.GossipStatus |
Protobuf type GossipStatus
|
ClusterMessages.GossipStatus.Builder |
Protobuf type GossipStatus
|
ClusterMessages.GossipStatusOrBuilder |
|
ClusterMessages.Heartbeat |
Protobuf type Heartbeat
|
ClusterMessages.Heartbeat.Builder |
Protobuf type Heartbeat
|
ClusterMessages.HeartbeatOrBuilder |
|
ClusterMessages.HeartBeatResponse |
Protobuf type HeartBeatResponse
|
ClusterMessages.HeartBeatResponse.Builder |
Protobuf type HeartBeatResponse
|
ClusterMessages.HeartBeatResponseOrBuilder |
|
ClusterMessages.IncompatibleConfig |
Protobuf type IncompatibleConfig
|
ClusterMessages.IncompatibleConfig.Builder |
Protobuf type IncompatibleConfig
|
ClusterMessages.IncompatibleConfigOrBuilder |
|
ClusterMessages.InitJoin |
Protobuf type InitJoin
|
ClusterMessages.InitJoin.Builder |
Protobuf type InitJoin
|
ClusterMessages.InitJoinAck |
Protobuf type InitJoinAck
|
ClusterMessages.InitJoinAck.Builder |
Protobuf type InitJoinAck
|
ClusterMessages.InitJoinAckOrBuilder |
|
ClusterMessages.InitJoinOrBuilder |
|
ClusterMessages.Join |
Protobuf type Join
|
ClusterMessages.Join.Builder |
Protobuf type Join
|
ClusterMessages.JoinOrBuilder |
|
ClusterMessages.Member |
Protobuf type Member
|
ClusterMessages.Member.Builder |
Protobuf type Member
|
ClusterMessages.MemberOrBuilder |
|
ClusterMessages.MemberStatus |
Protobuf enum MemberStatus
|
ClusterMessages.ObserverReachability |
Protobuf type ObserverReachability
|
ClusterMessages.ObserverReachability.Builder |
Protobuf type ObserverReachability
|
ClusterMessages.ObserverReachabilityOrBuilder |
|
ClusterMessages.Pool |
Protobuf type Pool
|
ClusterMessages.Pool.Builder |
Protobuf type Pool
|
ClusterMessages.PoolOrBuilder |
|
ClusterMessages.ReachabilityStatus |
Protobuf enum ReachabilityStatus
|
ClusterMessages.ReceptionistEntry |
Protobuf type akka.cluster.typed.ReceptionistEntry
|
ClusterMessages.ReceptionistEntry.Builder |
Protobuf type akka.cluster.typed.ReceptionistEntry
|
ClusterMessages.ReceptionistEntryOrBuilder |
|
ClusterMessages.SubjectReachability |
Protobuf type SubjectReachability
|
ClusterMessages.SubjectReachability.Builder |
Protobuf type SubjectReachability
|
ClusterMessages.SubjectReachabilityOrBuilder |
|
ClusterMessages.Tombstone |
Protobuf type Tombstone
|
ClusterMessages.Tombstone.Builder |
Protobuf type Tombstone
|
ClusterMessages.TombstoneOrBuilder |
|
ClusterMessages.UncheckedConfig |
Protobuf type UncheckedConfig
|
ClusterMessages.UncheckedConfig.Builder |
Protobuf type UncheckedConfig
|
ClusterMessages.UncheckedConfigOrBuilder |
|
ClusterMessages.UniqueAddress |
Protobuf type UniqueAddress
|
ClusterMessages.UniqueAddress.Builder |
Protobuf type UniqueAddress
|
ClusterMessages.UniqueAddressOrBuilder |
|
ClusterMessages.VectorClock |
Protobuf type VectorClock
|
ClusterMessages.VectorClock.Builder |
Protobuf type VectorClock
|
ClusterMessages.VectorClock.Version |
Protobuf type VectorClock.Version
|
ClusterMessages.VectorClock.Version.Builder |
Protobuf type VectorClock.Version
|
ClusterMessages.VectorClock.VersionOrBuilder |
|
ClusterMessages.VectorClockOrBuilder |
|
ClusterMessages.Welcome |
Protobuf type Welcome
|
ClusterMessages.Welcome.Builder |
Protobuf type Welcome
|
ClusterMessages.WelcomeOrBuilder |
|
ClusterMessageSerializer |
Protobuf serializer of cluster messages.
|
ClusterMessageSerializer$ |
INTERNAL API
|
ClusterMetricsChanged |
Java API
|
ClusterMetricsChanged$ |
|
ClusterMetricsCollector |
The node ring gossipped that contains only members that are Up.
|
ClusterMetricsCollector.GossipTick$ |
|
ClusterMetricsCollector.MetricsTick$ |
|
ClusterMetricsCollector$ |
INTERNAL API.
|
ClusterMetricsEvent |
Local cluster metrics extension events.
|
ClusterMetricsExtension |
Metrics extension configuration.
|
ClusterMetricsExtension$ |
Cluster metrics extension provider.
|
ClusterMetricsMessage |
INTERNAL API.
|
ClusterMetricsMessages |
|
ClusterMetricsMessages.AdaptiveLoadBalancingPool |
Protobuf type AdaptiveLoadBalancingPool
|
ClusterMetricsMessages.AdaptiveLoadBalancingPool.Builder |
Protobuf type AdaptiveLoadBalancingPool
|
ClusterMetricsMessages.AdaptiveLoadBalancingPoolOrBuilder |
|
ClusterMetricsMessages.Address |
Protobuf type Address
|
ClusterMetricsMessages.Address.Builder |
Protobuf type Address
|
ClusterMetricsMessages.AddressOrBuilder |
|
ClusterMetricsMessages.MetricsGossip |
Protobuf type MetricsGossip
|
ClusterMetricsMessages.MetricsGossip.Builder |
Protobuf type MetricsGossip
|
ClusterMetricsMessages.MetricsGossipEnvelope |
Protobuf type MetricsGossipEnvelope
|
ClusterMetricsMessages.MetricsGossipEnvelope.Builder |
Protobuf type MetricsGossipEnvelope
|
ClusterMetricsMessages.MetricsGossipEnvelopeOrBuilder |
|
ClusterMetricsMessages.MetricsGossipOrBuilder |
|
ClusterMetricsMessages.MetricsSelector |
Protobuf type MetricsSelector
|
ClusterMetricsMessages.MetricsSelector.Builder |
Protobuf type MetricsSelector
|
ClusterMetricsMessages.MetricsSelectorOrBuilder |
|
ClusterMetricsMessages.MixMetricsSelector |
Protobuf type MixMetricsSelector
|
ClusterMetricsMessages.MixMetricsSelector.Builder |
Protobuf type MixMetricsSelector
|
ClusterMetricsMessages.MixMetricsSelectorOrBuilder |
|
ClusterMetricsMessages.NodeMetrics |
Protobuf type NodeMetrics
|
ClusterMetricsMessages.NodeMetrics.Builder |
Protobuf type NodeMetrics
|
ClusterMetricsMessages.NodeMetrics.EWMA |
Protobuf type NodeMetrics.EWMA
|
ClusterMetricsMessages.NodeMetrics.EWMA.Builder |
Protobuf type NodeMetrics.EWMA
|
ClusterMetricsMessages.NodeMetrics.EWMAOrBuilder |
|
ClusterMetricsMessages.NodeMetrics.Metric |
Protobuf type NodeMetrics.Metric
|
ClusterMetricsMessages.NodeMetrics.Metric.Builder |
Protobuf type NodeMetrics.Metric
|
ClusterMetricsMessages.NodeMetrics.MetricOrBuilder |
|
ClusterMetricsMessages.NodeMetrics.Number |
Protobuf type NodeMetrics.Number
|
ClusterMetricsMessages.NodeMetrics.Number.Builder |
Protobuf type NodeMetrics.Number
|
ClusterMetricsMessages.NodeMetrics.NumberOrBuilder |
|
ClusterMetricsMessages.NodeMetrics.NumberType |
Protobuf enum NodeMetrics.NumberType
|
ClusterMetricsMessages.NodeMetricsOrBuilder |
|
ClusterMetricsSettings |
Metrics extension settings.
|
ClusterMetricsSettings$ |
|
ClusterMetricsStrategy |
|
ClusterMetricsStrategy$ |
SupervisorStrategy Decider which allows to survive intermittent Sigar native method calls failures.
|
ClusterMetricsSupervisor |
INTERNAL API.
|
ClusterNodeMBean |
Member status for this node.
|
ClusterReadView |
Current state
|
ClusterReceptionist |
|
ClusterReceptionist |
INTERNAL API
|
ClusterReceptionist.Entry |
|
ClusterReceptionist.Entry$ |
|
ClusterReceptionist.Internal$ |
Replies are tunneled via this actor, child of the receptionist, to avoid
inbound connections from other cluster nodes to the client.
|
ClusterReceptionist.InternalCommand |
|
ClusterReceptionist.Setup |
|
ClusterReceptionist$ |
Scala API: Factory method for ClusterReceptionist Props .
|
ClusterReceptionist$ |
param: registry The last seen state from the replicator - only updated when we get an update from th replicator
param: subscriptions Locally subscriptions, not replicated
|
ClusterReceptionistConfigCompatChecker |
INTERNAL API
|
ClusterReceptionistSettings |
param: role Start the receptionist on members tagged with this role.
|
ClusterReceptionistSettings |
|
ClusterReceptionistSettings$ |
Create settings from the default configuration
akka.cluster.client.receptionist .
|
ClusterReceptionistSettings$ |
Internal API
|
ClusterRemoteWatcher |
When a cluster node is added this class takes over the
responsibility for watchees on that node already handled
by super RemoteWatcher.
|
ClusterRemoteWatcher$ |
Factory method for ClusterRemoteWatcher Props .
|
ClusterRouterActor |
Fills in self address for local ActorRef
|
ClusterRouterConfigBase |
INTERNAL API
|
ClusterRouterGroup |
INTERNAL API
|
ClusterRouterGroup$ |
|
ClusterRouterGroupActor |
Adds routees based on totalInstances and maxInstancesPerNode settings
|
ClusterRouterGroupSettings |
|
ClusterRouterGroupSettings$ |
|
ClusterRouterPool |
INTERNAL API
|
ClusterRouterPool$ |
|
ClusterRouterPoolActor |
Adds routees based on totalInstances and maxInstancesPerNode settings
|
ClusterRouterPoolSettings |
|
ClusterRouterPoolSettings$ |
|
ClusterRouterSettingsBase |
INTERNAL API
|
ClusterRouterSettingsBase$ |
For backwards compatibility reasons, nr-of-instances
has the same purpose as max-total-nr-of-instances for cluster
aware routers and nr-of-instances (if defined by user) takes
precedence over max-total-nr-of-instances.
|
ClusterScope |
|
ClusterScope$ |
Java API: get the singleton instance
|
ClusterSettings |
Is in fact always a FiniteDuration but needs to stay Duration for binary compatibility
|
ClusterSettings$ |
INTERNAL API.
|
ClusterSetup |
Can be used in ActorSystemSetup when starting the ActorSystem
to replace the default implementation of the Cluster extension.
|
ClusterSetup$ |
|
ClusterSharding |
Scala API: Register a named entity type by defining the Props of the entity actor
and functions to extract entity and shard identifier from messages.
|
ClusterSharding |
Initialize sharding for the given entity factory settings.
|
ClusterSharding |
Initialize sharding for the given entity factory settings.
|
ClusterSharding.Passivate<M> |
|
ClusterSharding.Passivate<M> |
|
ClusterSharding.Passivate$ |
|
ClusterSharding.Passivate$ |
|
ClusterSharding.ShardCommand |
When an entity is created an ActorRef[ShardCommand] is passed to the
factory method.
|
ClusterSharding.ShardCommand |
When an entity is created an ActorRef[ShardCommand] is passed to the
factory method.
|
ClusterSharding$ |
This extension provides sharding functionality of actors in a cluster.
|
ClusterSharding$ |
When an entity is created an ActorRef[ShardCommand] is passed to the
factory method.
|
ClusterSharding$ |
When an entity is created an ActorRef[ShardCommand] is passed to the
factory method.
|
ClusterShardingGuardian |
INTERNAL API.
|
ClusterShardingGuardian.Start |
|
ClusterShardingGuardian.Start$ |
|
ClusterShardingGuardian.Started |
|
ClusterShardingGuardian.Started$ |
|
ClusterShardingGuardian.StartProxy |
|
ClusterShardingGuardian.StartProxy$ |
|
ClusterShardingGuardian$ |
INTERNAL API.
|
ClusterShardingImpl |
INTERNAL API
|
ClusterShardingMessages |
|
ClusterShardingMessages.ActorRefMessage |
Protobuf type ActorRefMessage
|
ClusterShardingMessages.ActorRefMessage.Builder |
Protobuf type ActorRefMessage
|
ClusterShardingMessages.ActorRefMessageOrBuilder |
|
ClusterShardingMessages.Address |
Protobuf type Address
|
ClusterShardingMessages.Address.Builder |
Protobuf type Address
|
ClusterShardingMessages.AddressOrBuilder |
|
ClusterShardingMessages.ClusterShardingStats |
Protobuf type ClusterShardingStats
|
ClusterShardingMessages.ClusterShardingStats.Builder |
Protobuf type ClusterShardingStats
|
ClusterShardingMessages.ClusterShardingStatsEntry |
Protobuf type ClusterShardingStatsEntry
|
ClusterShardingMessages.ClusterShardingStatsEntry.Builder |
Protobuf type ClusterShardingStatsEntry
|
ClusterShardingMessages.ClusterShardingStatsEntryOrBuilder |
|
ClusterShardingMessages.ClusterShardingStatsOrBuilder |
|
ClusterShardingMessages.CoordinatorState |
Protobuf type CoordinatorState
|
ClusterShardingMessages.CoordinatorState.Builder |
Protobuf type CoordinatorState
|
ClusterShardingMessages.CoordinatorState.ShardEntry |
Protobuf type CoordinatorState.ShardEntry
|
ClusterShardingMessages.CoordinatorState.ShardEntry.Builder |
Protobuf type CoordinatorState.ShardEntry
|
ClusterShardingMessages.CoordinatorState.ShardEntryOrBuilder |
|
ClusterShardingMessages.CoordinatorStateOrBuilder |
|
ClusterShardingMessages.CurrentRegions |
Protobuf type CurrentRegions
|
ClusterShardingMessages.CurrentRegions.Builder |
Protobuf type CurrentRegions
|
ClusterShardingMessages.CurrentRegionsOrBuilder |
|
ClusterShardingMessages.EntityStarted |
Protobuf type EntityStarted
|
ClusterShardingMessages.EntityStarted.Builder |
Protobuf type EntityStarted
|
ClusterShardingMessages.EntityStartedOrBuilder |
|
ClusterShardingMessages.EntityState |
Protobuf type EntityState
|
ClusterShardingMessages.EntityState.Builder |
Protobuf type EntityState
|
ClusterShardingMessages.EntityStateOrBuilder |
|
ClusterShardingMessages.EntityStopped |
Protobuf type EntityStopped
|
ClusterShardingMessages.EntityStopped.Builder |
Protobuf type EntityStopped
|
ClusterShardingMessages.EntityStoppedOrBuilder |
|
ClusterShardingMessages.GetClusterShardingStats |
Protobuf type GetClusterShardingStats
|
ClusterShardingMessages.GetClusterShardingStats.Builder |
Protobuf type GetClusterShardingStats
|
ClusterShardingMessages.GetClusterShardingStatsOrBuilder |
|
ClusterShardingMessages.MapFieldEntry |
Protobuf type MapFieldEntry
|
ClusterShardingMessages.MapFieldEntry.Builder |
Protobuf type MapFieldEntry
|
ClusterShardingMessages.MapFieldEntryOrBuilder |
|
ClusterShardingMessages.ShardHome |
Protobuf type ShardHome
|
ClusterShardingMessages.ShardHome.Builder |
Protobuf type ShardHome
|
ClusterShardingMessages.ShardHomeAllocated |
Protobuf type ShardHomeAllocated
|
ClusterShardingMessages.ShardHomeAllocated.Builder |
Protobuf type ShardHomeAllocated
|
ClusterShardingMessages.ShardHomeAllocatedOrBuilder |
|
ClusterShardingMessages.ShardHomeOrBuilder |
|
ClusterShardingMessages.ShardIdMessage |
Protobuf type ShardIdMessage
|
ClusterShardingMessages.ShardIdMessage.Builder |
Protobuf type ShardIdMessage
|
ClusterShardingMessages.ShardIdMessageOrBuilder |
|
ClusterShardingMessages.ShardRegionStats |
Protobuf type ShardRegionStats
|
ClusterShardingMessages.ShardRegionStats.Builder |
Protobuf type ShardRegionStats
|
ClusterShardingMessages.ShardRegionStatsOrBuilder |
|
ClusterShardingMessages.ShardStats |
Protobuf type ShardStats
|
ClusterShardingMessages.ShardStats.Builder |
Protobuf type ShardStats
|
ClusterShardingMessages.ShardStatsOrBuilder |
|
ClusterShardingMessages.StartEntity |
Protobuf type StartEntity
|
ClusterShardingMessages.StartEntity.Builder |
Protobuf type StartEntity
|
ClusterShardingMessages.StartEntityAck |
Protobuf type StartEntityAck
|
ClusterShardingMessages.StartEntityAck.Builder |
Protobuf type StartEntityAck
|
ClusterShardingMessages.StartEntityAckOrBuilder |
|
ClusterShardingMessages.StartEntityOrBuilder |
|
ClusterShardingMessageSerializer |
INTERNAL API: Protobuf serializer of ClusterSharding messages.
|
ClusterShardingQuery |
Protocol for querying sharding state e.g.
|
ClusterShardingSerializable |
Marker trait for remote messages and persistent events/snapshots with special serializer.
|
ClusterShardingSettings |
If true, this node should run the shard region, otherwise just a shard proxy should started on this node.
|
ClusterShardingSettings |
INTERNAL API
If true, this node should run the shard region, otherwise just a shard proxy should started on this node.
|
ClusterShardingSettings.StateStoreMode |
|
ClusterShardingSettings.StateStoreMode$ |
|
ClusterShardingSettings.StateStoreModeDData$ |
|
ClusterShardingSettings.StateStoreModePersistence$ |
|
ClusterShardingSettings.TuningParameters |
|
ClusterShardingSettings.TuningParameters |
|
ClusterShardingSettings$ |
Create settings from the default configuration
akka.cluster.sharding .
|
ClusterShardingSettings$ |
Scala API: Creates new cluster sharding settings object
|
ClusterShardingSetup |
|
ClusterShardingSetup$ |
|
ClusterSingleton |
Start if needed and provide a proxy to a named singleton
|
ClusterSingleton$ |
Java API:
|
ClusterSingletonImpl |
INTERNAL API:
|
ClusterSingletonImpl$ |
INTERNAL API:
|
ClusterSingletonManager |
Manages singleton actor instance among all cluster nodes or a group
of nodes tagged with a specific role.
|
ClusterSingletonManager.Data |
|
ClusterSingletonManager.Internal$ |
|
ClusterSingletonManager.State |
INTERNAL API
public due to the with FSM type parameters
|
ClusterSingletonManager$ |
Scala API: Factory method for ClusterSingletonManager Props .
|
ClusterSingletonManagerIsStuck |
Thrown when a consistent state can't be determined within the
defined retry limits.
|
ClusterSingletonManagerSettings |
param: singletonName The actor name of the child singleton actor.
|
ClusterSingletonManagerSettings |
param: singletonName The actor name of the child singleton actor.
|
ClusterSingletonManagerSettings$ |
Create settings from the default configuration
akka.cluster.singleton .
|
ClusterSingletonManagerSettings$ |
Create settings from the default configuration
akka.cluster.singleton .
|
ClusterSingletonMessage |
Marker trait for remote messages with special serializer.
|
ClusterSingletonMessageSerializer |
INTERNAL API: Serializer of ClusterSingleton messages.
|
ClusterSingletonProxy |
Discard old singleton ActorRef and send a periodic message to self to identify the singleton.
|
ClusterSingletonProxy$ |
Scala API: Factory method for ClusterSingletonProxy Props .
|
ClusterSingletonProxySettings |
|
ClusterSingletonProxySettings$ |
Create settings from the default configuration
akka.cluster.singleton-proxy .
|
ClusterSingletonSettings |
INTERNAL API:
|
ClusterSingletonSettings$ |
Java API
|
ClusterSingletonSetup |
|
ClusterSingletonSetup$ |
|
ClusterStateSubscription |
Messages for subscribing to changes in the cluster state
|
ClusterUserAction |
Command to initiate join another node (represented by address ).
|
ClusterUserAction.Down |
|
ClusterUserAction.Down$ |
|
ClusterUserAction.JoinTo |
|
ClusterUserAction.JoinTo$ |
|
ClusterUserAction.Leave |
|
ClusterUserAction.Leave$ |
|
ClusterUserAction$ |
Command to initiate join another node (represented by address ).
|
CNameRecord |
INTERNAL API
|
CNameRecord$ |
INTERNAL API
|
Collect<In,Out> |
|
Collect$ |
|
CollectionControlMessage |
Runtime collection management commands.
|
Collections |
INTERNAL API
|
Collections.EmptyImmutableSeq$ |
|
Collections.PartialImmutableValuesIterable<From,To> |
|
Collections$ |
INTERNAL API
|
CollectionStartMessage |
Java API
|
CollectionStartMessage$ |
Java API
|
CollectionStopMessage |
Java API
|
CollectionStopMessage$ |
Java API
|
CollectorState<T,R> |
INTERNAL API
|
CommandHandler<Command,Event,State> |
FunctionalInterface for reacting on commands
|
CommandHandlerBuilder<Command,Event,State> |
Use this method to define command handlers that are selected when the passed predicate holds true.
|
CommandHandlerBuilder$ |
|
CommandHandlerBuilderByState<Command,Event,S extends State,State> |
Matches any command which the given predicate returns true for.
|
CommandHandlerBuilderByState$ |
param: stateClass The handlers defined by this builder are used when the state is an instance of the stateClass
|
CommandHandlerWithReply<Command,Event,State> |
FunctionalInterface for reacting on commands
|
CommandHandlerWithReplyBuilder<Command,Event,State> |
Use this method to define command handlers that are selected when the passed predicate holds true.
|
CommandHandlerWithReplyBuilder$ |
|
CommandHandlerWithReplyBuilderByState<Command,Event,S extends State,State> |
Matches any command which the given predicate returns true for.
|
CommandHandlerWithReplyBuilderByState$ |
param: stateClass The handlers defined by this builder are used when the state is an instance of the stateClass
|
CommandOp |
|
CommonHandlers |
INTERNAL API
|
CompactByteString |
A compact ByteString.
|
CompactByteString$ |
Creates a new CompactByteString by copying a byte array.
|
CompactionSegmentManagement |
INTERNAL API.
|
CompactionSegmentManagement$ |
|
CompatImpl |
INTERNAL API
|
CompatImpl$ |
INTERNAL API
|
Completed |
INTERNAL API
|
Completed$ |
INTERNAL API
|
CompletedTraversalBuilder |
INTERNAL API
|
CompletedTraversalBuilder$ |
|
CompletionStrategy |
|
CompletionStrategy.Draining$ |
|
CompletionStrategy.Immediately$ |
|
CompletionStrategy$ |
INTERNAL API
|
Compose |
INTERNAL API
|
Compose$ |
|
ComposedStoppingBehavior<T> |
INTERNAL API
|
CompositeEffect<Event,State> |
|
CompositeEffect$ |
INTERNAL API
|
CompositeTraversalBuilder |
|
CompositeTraversalBuilder$ |
|
Compression |
Creates a Flow that decompresses gzip-compressed stream of data.
|
Compression |
Creates a flow that gzip-compresses a stream of ByteStrings.
|
Compression$ |
Creates a Flow that decompresses gzip-compressed stream of data.
|
Compression$ |
Creates a flow that gzip-compresses a stream of ByteStrings.
|
CompressionProtocol |
INTERNAL API
|
CompressionProtocol.ActorRefCompressionAdvertisement |
|
CompressionProtocol.ActorRefCompressionAdvertisement$ |
|
CompressionProtocol.ActorRefCompressionAdvertisementAck |
|
CompressionProtocol.ActorRefCompressionAdvertisementAck$ |
|
CompressionProtocol.ClassManifestCompressionAdvertisement |
|
CompressionProtocol.ClassManifestCompressionAdvertisement$ |
|
CompressionProtocol.ClassManifestCompressionAdvertisementAck |
|
CompressionProtocol.ClassManifestCompressionAdvertisementAck$ |
|
CompressionProtocol.CompressionAckMessage |
|
CompressionProtocol.CompressionAdvertisement<T> |
|
CompressionProtocol.CompressionMessage |
|
CompressionProtocol.Events$ |
|
CompressionProtocol.Events$.Event |
|
CompressionProtocol$ |
INTERNAL API
|
CompressionTable<T> |
INTERNAL API: Versioned compression table to be advertised between systems
|
CompressionTable$ |
INTERNAL API
|
CompressionUtils |
Creates a flow from a compressor constructor.
|
CompressionUtils$ |
Creates a flow from a compressor constructor.
|
Compressor |
Compresses the given input and returns compressed data.
|
Concat |
|
Concat |
Create a new anonymous Concat operator with the specified input types.
|
Concat<T> |
Takes multiple streams and outputs one stream formed from the input streams
by first emitting all of the elements from the first stream and then emitting
all of the elements from the second stream, etc.
|
Concat$ |
An optimizatzion to remove cheaply recognizable patterns of redundancy, for example PushNotUsed immediately
followed by a Pop.
|
Concat$ |
Create a new anonymous Concat operator with the specified input types.
|
Concat$ |
Create a new Concat .
|
ConcurrentMultiMap<K,V> |
An implementation of a ConcurrentMultiMap
Adds/remove is serialized over the specified key
Reads are fully concurrent <-- el-cheapo
|
Conductor |
Start the Controller , which in turn will
bind to a TCP port as specified in the akka.testconductor.port config
property, where 0 denotes automatic allocation.
|
ConductorHandler |
This handler is installed at the end of the controller’s netty pipeline.
|
ConfigServiceDiscovery |
INTERNAL API
|
ConfigServicesParser |
INTERNAL API
|
ConfigServicesParser$ |
INTERNAL API
|
ConfigSSLEngineProvider |
Subclass may override to customize loading of KeyStore
|
ConfigSSLEngineProvider |
Subclass may override to customize loading of KeyStore
|
ConfigurationException |
This exception is thrown when Akka detects a problem with the provided configuration
|
ConfigValidation |
INTERNAL API
|
ConfirmedClientOp |
|
ConnectionException |
|
ConnectionSnapshot |
Not for user extension
|
ConnectionSnapshot.Closed$ |
|
ConnectionSnapshot.ConnectionState |
|
ConnectionSnapshot.ShouldPull$ |
|
ConnectionSnapshot.ShouldPush$ |
|
ConnectionSnapshot$ |
|
ConnectionSnapshotImpl |
INTERNAL API
|
ConnectionSnapshotImpl$ |
|
ConnectionSourceStage |
INTERNAL API
|
ConnectionSourceStage$ |
|
ConsistentHash<T> |
Adds a node to the node ring.
|
ConsistentHash$ |
Java API: Factory method to create a ConsistentHash
|
ConsistentHashingGroup |
Java API
param: routeePaths string representation of the actor paths of the routees, messages are
sent with ActorSelection to these paths
|
ConsistentHashingGroup$ |
|
ConsistentHashingPool |
Java API
param: nr initial number of routees in the pool
|
ConsistentHashingPool$ |
|
ConsistentHashingRouter |
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.ConsistentHashable |
|
ConsistentHashingRouter.ConsistentHashableEnvelope |
|
ConsistentHashingRouter.ConsistentHashableEnvelope$ |
|
ConsistentHashingRouter.ConsistentHashMapper |
|
ConsistentHashingRouter.emptyConsistentHashMapping$ |
|
ConsistentHashingRouter$ |
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.
|
ConsistentHashingRoutingLogic |
|
ConsistentHashingRoutingLogic$ |
Address to use for the selfAddress parameter
|
ConsistentRoutee |
INTERNAL API
Important to use ActorRef with full address, with host and port, in the hash ring,
so that same ring is produced on different nodes.
|
ConsistentRoutee$ |
|
ConstantFun |
Deprecated.
|
ConstantFun |
INTERNAL API
|
ConstantFun$ |
Deprecated.
|
ConstantFun$ |
INTERNAL API
|
ConstantRateEntityRecoveryStrategy |
|
Consumer |
Deprecated.
|
Consumer$ |
Deprecated.
|
ConsumerActorRouteBuilder |
INTERNAL API
Builder of a route to a target which can be an actor.
|
ConsumerConfig |
INTERNAL API
Captures the configuration of the Consumer.
|
ConsumerConfig$ |
|
ConsumerRegistrar |
INTERNAL API
Registers Consumers.
|
ContactPointAdded |
Emitted to a subscriber when contact points have been
received by the ClusterClient and a new one has been added.
|
ContactPointAdded$ |
|
ContactPointChange |
Declares a super type for all events emitted by the ClusterClient
in relation to contact points being added or removed.
|
ContactPointRemoved |
Emitted to a subscriber when contact points have been
received by the ClusterClient and a new one has been added.
|
ContactPointRemoved$ |
|
ContactPoints |
Java API
|
ContactPoints$ |
|
ContainerFormats |
|
ContainerFormats.ActorIdentity |
Protobuf type ActorIdentity
|
ContainerFormats.ActorIdentity.Builder |
Protobuf type ActorIdentity
|
ContainerFormats.ActorIdentityOrBuilder |
|
ContainerFormats.ActorInitializationException |
Protobuf type ActorInitializationException
|
ContainerFormats.ActorInitializationException.Builder |
Protobuf type ActorInitializationException
|
ContainerFormats.ActorInitializationExceptionOrBuilder |
|
ContainerFormats.ActorRef |
Protobuf type ActorRef
|
ContainerFormats.ActorRef.Builder |
Protobuf type ActorRef
|
ContainerFormats.ActorRefOrBuilder |
|
ContainerFormats.Identify |
Protobuf type Identify
|
ContainerFormats.Identify.Builder |
Protobuf type Identify
|
ContainerFormats.IdentifyOrBuilder |
|
ContainerFormats.Option |
Protobuf type Option
|
ContainerFormats.Option.Builder |
Protobuf type Option
|
ContainerFormats.OptionOrBuilder |
|
ContainerFormats.PatternType |
Protobuf enum PatternType
|
ContainerFormats.Payload |
Protobuf type Payload
|
ContainerFormats.Payload.Builder |
Protobuf type Payload
|
ContainerFormats.PayloadOrBuilder |
|
ContainerFormats.Selection |
Protobuf type Selection
|
ContainerFormats.Selection.Builder |
Protobuf type Selection
|
ContainerFormats.SelectionEnvelope |
Protobuf type SelectionEnvelope
|
ContainerFormats.SelectionEnvelope.Builder |
Protobuf type SelectionEnvelope
|
ContainerFormats.SelectionEnvelopeOrBuilder |
|
ContainerFormats.SelectionOrBuilder |
|
ContainerFormats.StackTraceElement |
Protobuf type StackTraceElement
|
ContainerFormats.StackTraceElement.Builder |
Protobuf type StackTraceElement
|
ContainerFormats.StackTraceElementOrBuilder |
|
ContainerFormats.Throwable |
Protobuf type Throwable
|
ContainerFormats.Throwable.Builder |
Protobuf type Throwable
|
ContainerFormats.ThrowableNotSerializable |
Protobuf type ThrowableNotSerializable
|
ContainerFormats.ThrowableNotSerializable.Builder |
Protobuf type ThrowableNotSerializable
|
ContainerFormats.ThrowableNotSerializableOrBuilder |
|
ContainerFormats.ThrowableOrBuilder |
|
ContainerFormats.WatcherHeartbeatResponse |
Protobuf type WatcherHeartbeatResponse
|
ContainerFormats.WatcherHeartbeatResponse.Builder |
Protobuf type WatcherHeartbeatResponse
|
ContainerFormats.WatcherHeartbeatResponseOrBuilder |
|
ContextProvider |
Retrieve or create a Camel Context for the given actor system
Called once per actor system
|
ContextualTypedActorFactory |
ContextualTypedActorFactory allows TypedActors to create children, effectively forming the same Actor Supervision Hierarchies
as normal Actors can.
|
ContextualTypedActorFactory$ |
|
ControlAwareMessageQueueSemantics |
ControlAwareMessageQueue handles messages that extend ControlMessage with priority.
|
ControlledExecutor |
INTERNAL API
|
Controller |
This controls test execution by managing barriers (delegated to
BarrierCoordinator , its child) and allowing
network and other failures to be injected at the test nodes.
|
Controller.ClientDisconnected |
|
Controller.ClientDisconnected$ |
|
Controller.ClientDisconnectedException |
|
Controller.CreateServerFSM |
|
Controller.CreateServerFSM$ |
|
Controller.GetNodes$ |
|
Controller.GetSockAddr$ |
|
Controller.NodeInfo |
|
Controller.NodeInfo$ |
|
Controller$ |
INTERNAL API.
|
ControlMessage |
Messages that extend this trait will be handled with priority by control aware mailboxes.
|
ControlMessage |
INTERNAL API
Marker trait for control messages that can be sent via the system message sub-channel
but don't need full reliable delivery.
|
CoordinatedShutdown |
INTERNAL API
|
CoordinatedShutdown.ClusterDowningReason$ |
Scala API: The shutdown was initiated by Cluster downing.
|
CoordinatedShutdown.ClusterJoinUnsuccessfulReason$ |
Scala API: The shutdown was initiated by a failure to join a seed node.
|
CoordinatedShutdown.ClusterLeavingReason$ |
Scala API: The shutdown was initiated by Cluster leaving.
|
CoordinatedShutdown.IncompatibleConfigurationDetectedReason$ |
Scala API: The shutdown was initiated by a configuration clash within the existing cluster and the joining node
|
CoordinatedShutdown.JvmExitReason$ |
Scala API: The shutdown was initiated by a JVM shutdown hook, e.g.
|
CoordinatedShutdown.Phase |
INTERNAL API
|
CoordinatedShutdown.Phase$ |
|
CoordinatedShutdown.Reason |
Reason for the shutdown, which can be used by tasks in case they need to do
different things depending on what caused the shutdown.
|
CoordinatedShutdown.UnknownReason$ |
|
CoordinatedShutdown$ |
The first pre-defined phase that applications can add tasks to.
|
CoordinatedShutdownLeave |
INTERNAL API
|
CoordinatedShutdownLeave.LeaveReq$ |
|
CoordinatedShutdownLeave$ |
INTERNAL API
|
CountMinSketch |
INTERNAL API: Count-Min Sketch datastructure.
|
CoupledTerminationBidi<I,O> |
INTERNAL API
|
CoupledTerminationFlow |
Similar to Flow.fromSinkAndSource however couples the termination of these two operators.
|
CoupledTerminationFlow |
Similar to Flow.fromSinkAndSource however couples the termination of these two operators.
|
CoupledTerminationFlow$ |
Similar to Flow.fromSinkAndSource however couples the termination of these two operators.
|
CoupledTerminationFlow$ |
Similar to Flow.fromSinkAndSource however couples the termination of these two operators.
|
CpuMetricsSelector |
Java API: get the singleton instance
|
CpuMetricsSelector$ |
Java API: get the singleton instance
|
Create |
INTERNAL API
|
Create |
INTERNAL API
|
Create$ |
|
Create$ |
|
Creator<T> |
This method must return a different instance upon every call.
|
Creator<T> |
This method must return a different instance upon every call.
|
CreatorConsumer |
INTERNAL API
|
CreatorFunctionConsumer |
INTERNAL API
|
Creators |
This trait provides a DSL for writing the inner workings of an actor, e.g.
|
Creators.Act |
|
Creators.ActWithStash |
|
CrossDcHeartbeatingState |
Decides if self node should become active and monitor other nodes with heartbeats.
|
CrossDcHeartbeatingState$ |
Sorted by age
|
CrossDcHeartbeatSender |
Looks up and returns the remote cluster heartbeat connection for the specific address.
|
CrossDcHeartbeatSender.InspectionCommand |
|
CrossDcHeartbeatSender.MonitoringActive |
|
CrossDcHeartbeatSender.MonitoringActive$ |
|
CrossDcHeartbeatSender.MonitoringDormant |
|
CrossDcHeartbeatSender.MonitoringDormant$ |
|
CrossDcHeartbeatSender.MonitoringStateReport |
|
CrossDcHeartbeatSender.ReportStatus |
|
CrossDcHeartbeatSender.ReportStatus$ |
|
CrossDcHeartbeatSender.StatusReport |
|
CrossDcHeartbeatSender$ |
INTERNAL API
|
CurrentEventsByPersistenceIdPublisher |
INTERNAL API
|
CurrentEventsByPersistenceIdQuery |
|
CurrentEventsByPersistenceIdQuery |
|
CurrentEventsByTagPublisher |
INTERNAL API
|
CurrentEventsByTagQuery |
|
CurrentEventsByTagQuery |
|
CurrentPersistenceIdsQuery |
|
CurrentPersistenceIdsQuery |
|
CustomEventFilter |
Custom event filter when the others do not fit the bill.
|
CustomEventFilter$ |
|
CustomRouterConfig |
INTERNAL API
|
DaemonMsg |
INTERNAL API
|
DaemonMsgCreate |
INTERNAL API
|
DaemonMsgCreate$ |
|
DaemonMsgCreateSerializer |
Serializes Akka's internal DaemonMsgCreate using protobuf
for the core structure of DaemonMsgCreate, Props and Deploy.
|
DDataShard |
If the message is for the same entity as we are waiting for the update it will be added to
its messageBuffer, which will be sent after the update has completed.
|
DDataShardCoordinator |
Singleton coordinator (with state based on ddata) that decides where to allocate shards.
|
DeadLetter |
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$ |
|
DeadLetterActorRef |
Internal implementation of the dead letter destination: will publish any
received message to the eventStream, wrapped as DeadLetter .
|
DeadLetterActorRef.SerializedDeadLetterActorRef |
|
DeadLetterActorRef$ |
|
DeadLetterListener |
|
DeadLettersFilter |
|
DeadLettersFilter$ |
|
DeadLetterSuppression |
Use with caution: Messages extending this trait will not be logged by the default dead-letters listener.
|
DeadlineFailureDetector |
Constructor that reads parameters from config.
|
Deafen |
|
Deafen$ |
|
DeathPactException |
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 |
Java API
|
DeathPactException$ |
|
DeathPactException$ |
|
DeathWatch |
This map holds a None for actors for which we send a Terminated notification on termination,
Some(message) for actors for which we send a custom termination message.
|
DeathWatchNotification |
INTERNAL API
|
DeathWatchNotification |
|
DeathWatchNotification$ |
|
DeathWatchNotification$ |
|
DebugFilter |
Java API: create a DebugFilter
|
DebugFilter$ |
|
DebugRef<T> |
INTERNAL API
|
DeciderBuilder |
|
Decoder |
INTERNAL API
|
Decoder.InboundCompressionAccess |
|
Decoder.InboundCompressionAccessImpl |
|
Decoder$ |
Materialized value of Encoder which allows safely calling into the operator to interfact with compression tables.
|
DecompressionTable<T> |
Writes complete table as String (heavy operation)
|
DecompressionTable$ |
INTERNAL API
|
DefaultCamel |
Starts camel and underlying camel context and template.
|
DefaultContextProvider |
Default implementation of ContextProvider
Provides a new DefaultCamelContext per actor system
|
DefaultDispatcherPrerequisites |
INTERNAL API
|
DefaultDispatcherPrerequisites$ |
|
DefaultExecutorServiceConfigurator |
|
DefaultFailureDetectorRegistry<A> |
INTERNAL API
Get the underlying FailureDetector for a resource.
|
DefaultInputTransferStates |
INTERNAL API
|
DefaultLoggingFilter |
|
DefaultMessageDispatcher |
INTERNAL API
|
DefaultOptimalSizeExploringResizer |
INTERNAL API
|
DefaultOptimalSizeExploringResizer$ |
|
DefaultOSGiLogger |
Behavior of the logger that waits for its LogService
|
DefaultOutputTransferStates |
INTERNAL API
|
DefaultResizer |
|
DefaultResizer$ |
Creates a new DefaultResizer from the given configuration
|
DefaultServiceKey<T> |
This is the only actual concrete service key type
|
DefaultServiceKey$ |
|
DefaultSigarProvider |
|
DefaultSigarProvider$ |
|
DefaultSSLEngineConfigurator |
|
DefaultSupervisorStrategy |
|
DefaultSystemMessageQueue |
INTERNAL API
|
DefaultTimeout |
|
DeflateCompressor |
INTERNAL API
|
DeflateCompressor$ |
INTERNAL API
|
DeflateDecompressor |
INTERNAL API
|
DeflateDecompressorBase |
INTERNAL API
|
DeflateDecompressorBase$ |
INTERNAL API
|
Delay<T> |
INTERNAL API
|
DelayOverflowStrategy |
INTERNAL API
|
DelayOverflowStrategy$ |
If the buffer is full when a new element is available this strategy send next element downstream without waiting
|
DeleteEventsCompleted |
Java API
|
DeleteEventsCompleted$ |
|
DeleteEventsFailed |
Java API
|
DeleteEventsFailed$ |
|
DeleteMessagesFailure |
|
DeleteMessagesFailure$ |
|
DeleteMessagesSuccess |
|
DeleteMessagesSuccess$ |
|
DeleteSnapshotFailure |
|
DeleteSnapshotFailure$ |
|
DeleteSnapshotsCompleted |
Java API
|
DeleteSnapshotsCompleted$ |
|
DeleteSnapshotsFailed |
Java API
|
DeleteSnapshotsFailed$ |
|
DeleteSnapshotsFailure |
|
DeleteSnapshotsFailure$ |
|
DeleteSnapshotsSuccess |
Sent to a PersistentActor after successful deletion of specified range of snapshots.
|
DeleteSnapshotsSuccess$ |
|
DeleteSnapshotSuccess |
|
DeleteSnapshotSuccess$ |
|
DeletionTarget |
Not for user extension
|
DeletionTarget.Criteria |
|
DeletionTarget.Criteria$ |
|
DeletionTarget.Individual |
|
DeletionTarget.Individual$ |
|
DeletionTarget$ |
Java API
|
DeliveryBuffer<T> |
INTERNAL API
|
DeltaPropagationSelector |
INTERNAL API: Used by the Replicator actor.
|
DeltaReplicatedData |
The type of the delta.
|
Deploy |
|
Deploy$ |
|
Deployer |
Factory method for creating RouterConfig
param: routerType the configured name of the router, or FQCN
param: key the full configuration key of the deployment section
param: config the user defined config of the deployment, without defaults
param: deployment the deployment config, with defaults
|
DequeBasedMessageQueue |
|
DequeBasedMessageQueueSemantics |
DequeBasedMessageQueue refines QueueBasedMessageQueue to be backed by a java.util.Deque.
|
Deserializer |
INTERNAL API
|
DiagnosticActorLogging |
Scala API: Mix in DiagnosticActorLogging into your Actor to easily obtain a reference to a logger with MDC support,
which is available under the name "log".
|
DiagnosticLoggingAdapter |
|
DiagnosticMarkerBusLoggingAdapter |
Message template with 4 replacement arguments.
|
DirectByteBufferPool |
INTERNAL API
|
DirectByteBufferPool$ |
DirectByteBuffers are garbage collected by using a phantom reference and a
reference queue.
|
DisabledJavaSerializer |
This Serializer is used when akka.actor.java-serialization = off
|
DisabledJavaSerializer.JavaSerializationException |
|
DisabledJavaSerializer$ |
|
DisabledRetentionCriteria |
INTERNAL API
|
DisabledRetentionCriteria$ |
INTERNAL API
|
DisassociatedEvent |
|
DisassociatedEvent$ |
|
DiscardConfigurator |
|
DiscardToDeadLetterStrategy |
Java API: get the singleton instance
|
DiscardToDeadLetterStrategy$ |
Java API: get the singleton instance
|
Disconnect |
|
Disconnect$ |
|
DisconnectMsg |
|
DisconnectMsg$ |
|
Discovery |
|
Discovery$ |
INTERNAL API
|
Dispatch |
Initialize this cell, i.e.
|
Dispatcher |
At first glance this var does not seem to be updated anywhere, but in
fact it is, via the esUpdater AtomicReferenceFieldUpdater below.
|
DispatcherConfigurator |
Returns the same dispatcher instance for each invocation
|
DispatcherDefault |
INTERNAL API
|
DispatcherDefault$ |
Retrieve an instance for this configuration node with empty next reference.
|
DispatcherFromConfig |
Look up an executor definition in the ActorSystem configuration.
|
DispatcherFromConfig$ |
|
DispatcherPrerequisites |
DispatcherPrerequisites represents useful contextual pieces when constructing a MessageDispatcher
|
Dispatchers |
An ActorSystem looks up all its thread pools via a Dispatchers instance.
|
Dispatchers |
The one and only default dispatcher.
|
Dispatchers$ |
The id of the default dispatcher, also the full key of the
configuration of the default dispatcher.
|
Dispatchers$ |
The id of the default dispatcher, also the full key of the
configuration of the default dispatcher.
|
DispatcherSelector |
Not for user extension.
|
DispatcherSelector$ |
Scala API:
Run the actor on the default ActorSystem executor.
|
DistributedData |
|
DistributedData |
|
DistributedData |
|
DistributedData$ |
|
DistributedData$ |
|
DistributedData$ |
|
DistributedDataImpl |
INTERNAL API
|
DistributedDataSetup |
|
DistributedDataSetup$ |
|
DistributedPubSub |
Returns true if this member is not tagged with the role configured for the
mediator.
|
DistributedPubSub$ |
Gossip to peer nodes.
|
DistributedPubSubMediator |
Gossip to peer nodes.
|
DistributedPubSubMediator.Count$ |
|
DistributedPubSubMediator.CountSubscribers |
|
DistributedPubSubMediator.CountSubscribers$ |
|
DistributedPubSubMediator.CurrentTopics |
Java API
|
DistributedPubSubMediator.CurrentTopics$ |
|
DistributedPubSubMediator.GetTopics |
|
DistributedPubSubMediator.GetTopics$ |
|
DistributedPubSubMediator.Internal$ |
|
DistributedPubSubMediator.Internal$.ChildActorTerminationProtocol |
|
DistributedPubSubMediator.Internal$.TopicLike |
|
DistributedPubSubMediator.Publish |
|
DistributedPubSubMediator.Publish$ |
|
DistributedPubSubMediator.Put |
|
DistributedPubSubMediator.Put$ |
|
DistributedPubSubMediator.Remove |
|
DistributedPubSubMediator.Remove$ |
|
DistributedPubSubMediator.Send |
|
DistributedPubSubMediator.Send$ |
|
DistributedPubSubMediator.SendToAll |
|
DistributedPubSubMediator.SendToAll$ |
|
DistributedPubSubMediator.Subscribe |
|
DistributedPubSubMediator.Subscribe$ |
|
DistributedPubSubMediator.SubscribeAck |
|
DistributedPubSubMediator.SubscribeAck$ |
|
DistributedPubSubMediator.Unsubscribe |
|
DistributedPubSubMediator.Unsubscribe$ |
|
DistributedPubSubMediator.UnsubscribeAck |
|
DistributedPubSubMediator.UnsubscribeAck$ |
|
DistributedPubSubMediator$ |
Scala API: Factory method for DistributedPubSubMediator Props .
|
DistributedPubSubMessage |
Marker trait for remote messages with special serializer.
|
DistributedPubSubMessages |
|
DistributedPubSubMessages.Address |
Protobuf type Address
|
DistributedPubSubMessages.Address.Builder |
Protobuf type Address
|
DistributedPubSubMessages.AddressOrBuilder |
|
DistributedPubSubMessages.Delta |
Protobuf type Delta
|
DistributedPubSubMessages.Delta.Bucket |
Protobuf type Delta.Bucket
|
DistributedPubSubMessages.Delta.Bucket.Builder |
Protobuf type Delta.Bucket
|
DistributedPubSubMessages.Delta.BucketOrBuilder |
|
DistributedPubSubMessages.Delta.Builder |
Protobuf type Delta
|
DistributedPubSubMessages.Delta.Entry |
Protobuf type Delta.Entry
|
DistributedPubSubMessages.Delta.Entry.Builder |
Protobuf type Delta.Entry
|
DistributedPubSubMessages.Delta.EntryOrBuilder |
|
DistributedPubSubMessages.DeltaOrBuilder |
|
DistributedPubSubMessages.Payload |
Protobuf type Payload
|
DistributedPubSubMessages.Payload.Builder |
Protobuf type Payload
|
DistributedPubSubMessages.PayloadOrBuilder |
|
DistributedPubSubMessages.Publish |
Protobuf type Publish
|
DistributedPubSubMessages.Publish.Builder |
Protobuf type Publish
|
DistributedPubSubMessages.PublishOrBuilder |
|
DistributedPubSubMessages.Send |
Protobuf type Send
|
DistributedPubSubMessages.Send.Builder |
Protobuf type Send
|
DistributedPubSubMessages.SendOrBuilder |
|
DistributedPubSubMessages.SendToAll |
Protobuf type SendToAll
|
DistributedPubSubMessages.SendToAll.Builder |
Protobuf type SendToAll
|
DistributedPubSubMessages.SendToAllOrBuilder |
|
DistributedPubSubMessages.SendToOneSubscriber |
Protobuf type SendToOneSubscriber
|
DistributedPubSubMessages.SendToOneSubscriber.Builder |
Protobuf type SendToOneSubscriber
|
DistributedPubSubMessages.SendToOneSubscriberOrBuilder |
|
DistributedPubSubMessages.Status |
Protobuf type Status
|
DistributedPubSubMessages.Status.Builder |
Protobuf type Status
|
DistributedPubSubMessages.Status.Version |
Protobuf type Status.Version
|
DistributedPubSubMessages.Status.Version.Builder |
Protobuf type Status.Version
|
DistributedPubSubMessages.Status.VersionOrBuilder |
|
DistributedPubSubMessages.StatusOrBuilder |
|
DistributedPubSubMessageSerializer |
INTERNAL API: Protobuf serializer of DistributedPubSubMediator messages.
|
DistributedPubSubSettings |
param: role Start the mediator on members tagged with this role.
|
DistributedPubSubSettings$ |
Create settings from the default configuration
akka.cluster.pub-sub .
|
Dns |
Lookup if a DNS resolved is cached.
|
Dns.Command |
|
Dns.Resolve |
|
Dns.Resolve$ |
|
Dns.Resolved |
|
Dns.Resolved$ |
|
Dns$ |
Lookup if a DNS resolved is cached.
|
DnsClient |
Silent to allow map update syntax
|
DnsClient.Answer |
|
DnsClient.Answer$ |
|
DnsClient.DnsQuestion |
|
DnsClient.DropRequest |
|
DnsClient.DropRequest$ |
|
DnsClient.Question4 |
|
DnsClient.Question4$ |
|
DnsClient.Question6 |
|
DnsClient.Question6$ |
|
DnsClient.SrvQuestion |
|
DnsClient.SrvQuestion$ |
|
DnsClient$ |
INTERNAL API
|
DnsExt |
INTERNAL API
|
DnsProtocol |
Java API
|
DnsProtocol.Ip |
|
DnsProtocol.Ip$ |
|
DnsProtocol.RequestType |
|
DnsProtocol.Resolve |
|
DnsProtocol.Resolve$ |
|
DnsProtocol.Resolved |
Java API
|
DnsProtocol.Resolved$ |
|
DnsProtocol.Srv$ |
|
DnsProtocol$ |
Java API
|
DnsProvider |
|
DnsServiceDiscovery |
INTERNAL API
|
DnsServiceDiscovery$ |
INTERNAL API
|
DnsSettings |
INTERNAL API
|
DnsSettings$ |
INTERNAL API
|
DomainName |
INTERNAL API
|
DomainName$ |
INTERNAL API
|
Done |
Typically used together with Future to signal completion
but there is no actual value completed.
|
Done |
|
Done$ |
Java API: the singleton instance
|
Done$ |
|
DoNotInherit |
Marks APIs that are designed under an closed-world assumption for and are NOT meant to be
extended by user-code.
|
Down |
Send command to DOWN the node specified by 'address'.
|
Down$ |
|
DowningProvider |
Time margin after which shards or singletons that belonged to a downed/removed
partition are created in surviving partition.
|
DowningProvider$ |
param: fqcn Fully qualified class name of the implementation to be loaded.
|
Drop<T> |
INTERNAL API
|
Drop$ |
|
Dropped |
Java API
|
Dropped$ |
|
DropWhile<T> |
INTERNAL API
|
DropWhile$ |
|
DropWithin<T> |
INTERNAL API
|
DummyClassForStringSources |
|
DuplicateHandshakeReq |
INTERNAL API: The HandshakeReq message must be passed in each inbound lane to
ensure that it arrives before any application message.
|
DurableStore |
Request to store an entry.
|
DurableStore.DurableDataEnvelope |
|
DurableStore.LoadAll$ |
|
DurableStore.LoadAllCompleted$ |
|
DurableStore.LoadData |
|
DurableStore.LoadData$ |
|
DurableStore.LoadFailed |
|
DurableStore.Store |
|
DurableStore.Store$ |
|
DurableStore.StoreReply |
|
DurableStore.StoreReply$ |
|
DurableStore$ |
Request to store an entry.
|
DurationTypeConverter |
INTERNAL API
Converts Strings to Duration
|
DurationTypeConverter$ |
INTERNAL API
Converts Strings to Duration
|
DynamicAccess |
Convenience method which given a Class[_] object and a constructor description
will create a new instance of that class.
|
EagerClose |
|
EagerClose$ |
|
EarliestFirstSystemMessageList |
Indicates if the list is empty or not.
|
EarliestFirstSystemMessageList |
Indicates if the list is empty or not.
|
EarliestFirstSystemMessageList$ |
|
EarliestFirstSystemMessageList$ |
|
Effect |
|
Effect |
An executable piece of code that takes no parameters and doesn't return any value.
|
Effect |
An executable piece of code that takes no parameters and doesn't return any value.
|
Effect<Event,State> |
A command handler returns an Effect directive that defines what event or events to persist.
|
Effect<Event,State> |
A command handler returns an Effect directive that defines what event or events to persist.
|
Effect.MessageAdapter<A,T> |
|
Effect.MessageAdapter$ |
|
Effect.NoEffects |
|
Effect.NoEffects$ |
|
Effect.ReceiveTimeoutCancelled |
|
Effect.ReceiveTimeoutCancelled$ |
|
Effect.ReceiveTimeoutSet<T> |
|
Effect.ReceiveTimeoutSet$ |
|
Effect.Scheduled<U> |
|
Effect.Scheduled$ |
|
Effect.Spawned<T> |
|
Effect.Spawned$ |
|
Effect.SpawnedAdapter<T> |
|
Effect.SpawnedAdapter$ |
|
Effect.SpawnedAnonymous<T> |
|
Effect.SpawnedAnonymous$ |
|
Effect.SpawnedAnonymousAdapter<T> |
|
Effect.SpawnedAnonymousAdapter$ |
|
Effect.Stopped |
|
Effect.Stopped$ |
|
Effect.Unwatched<T> |
|
Effect.Unwatched$ |
|
Effect.Watched<T> |
|
Effect.Watched$ |
|
Effect$ |
The behavior spawned a named child with the given behavior (and optionally specific props)
|
Effect$ |
Persist a single event
|
EffectBuilder<Event,State> |
Run the given callback.
|
EffectBuilder<Event,State> |
Run the given callback.
|
EffectFactories<Event,State> |
Persist a single event
|
EffectFactories$ |
INTERNAL API: see class EffectFactories
|
EffectfulActorContext<T> |
INTERNAL API
|
EffectImpl<Event,State> |
INTERNAL API
|
Effects |
The behavior spawned a named child with the given behavior with no specific props
|
Effects |
The behavior spawned a named child with the given behavior with no specific props
|
Effects$ |
The behavior spawned a named child with the given behavior with no specific props
|
Effects$ |
The behavior spawned a named child with the given behavior with no specific props
|
EmptyEventSeq |
|
EmptyEventSeq$ |
|
EmptyLocalActorRef |
This special dead letter reference has a name: it is that which is returned
by a local look-up which is unsuccessful.
|
EmptyProps |
The empty configuration node, used as a terminator for the internally linked
list of each Props.
|
EmptyProps$ |
The empty configuration node, used as a terminator for the internally linked
list of each Props.
|
EmptyPublisher |
INTERNAL API
|
EmptyPublisher$ |
INTERNAL API
|
EmptySource |
INTERNAL API
|
EmptySource$ |
INTERNAL API
|
EmptyTraversal |
INTERNAL API
|
EmptyTraversal$ |
INTERNAL API
|
Encoder |
External call from ChangeOutboundCompression materialized value
|
Encoder.OutboundCompressionAccess |
|
Encoder$ |
INTERNAL API
|
EndpointActor |
INTERNAL API
|
EndpointAssociationException |
INTERNAL API
|
EndpointDisassociatedException |
INTERNAL API
|
EndpointException |
INTERNAL API
|
EndpointManager |
INTERNAL API
|
EndpointManager.EndpointPolicy |
|
EndpointManager.EndpointRegistry |
|
EndpointManager.Gated |
|
EndpointManager.Gated$ |
|
EndpointManager.Link |
|
EndpointManager.Link$ |
|
EndpointManager.Listen |
|
EndpointManager.Listen$ |
|
EndpointManager.ListensFailure |
|
EndpointManager.ListensFailure$ |
|
EndpointManager.ListensResult |
|
EndpointManager.ListensResult$ |
|
EndpointManager.ManagementCommand |
|
EndpointManager.ManagementCommand$ |
|
EndpointManager.ManagementCommandAck |
|
EndpointManager.ManagementCommandAck$ |
|
EndpointManager.Pass |
|
EndpointManager.Pass$ |
|
EndpointManager.Prune$ |
|
EndpointManager.Quarantine |
|
EndpointManager.Quarantine$ |
|
EndpointManager.Quarantined |
|
EndpointManager.Quarantined$ |
|
EndpointManager.RemotingCommand |
|
EndpointManager.ResendState |
|
EndpointManager.ResendState$ |
|
EndpointManager.Send |
|
EndpointManager.Send$ |
|
EndpointManager.ShutdownAndFlush$ |
|
EndpointManager.StartupFinished$ |
|
EndpointManager$ |
Indicates that the policy does not contain an active endpoint, but it is a tombstone of a previous failure
|
EndpointReader |
INTERNAL API
|
EndpointReader$ |
INTERNAL API
|
EndpointWriter |
INTERNAL API
|
EndpointWriter.AckIdleCheckTimer$ |
|
EndpointWriter.BackoffTimer$ |
|
EndpointWriter.FlushAndStop$ |
|
EndpointWriter.Handle |
|
EndpointWriter.Handle$ |
|
EndpointWriter.OutboundAck |
|
EndpointWriter.OutboundAck$ |
|
EndpointWriter.StoppedReading |
|
EndpointWriter.StoppedReading$ |
|
EndpointWriter.StopReading |
|
EndpointWriter.StopReading$ |
|
EndpointWriter.TakeOver |
This message signals that the current association maintained by the local EndpointWriter and EndpointReader is
to be overridden by a new inbound association.
|
EndpointWriter.TakeOver$ |
|
EndpointWriter.TookOver |
|
EndpointWriter.TookOver$ |
|
EndpointWriter$ |
This message signals that the current association maintained by the local EndpointWriter and EndpointReader is
to be overridden by a new inbound association.
|
EnterBarrier |
|
EnterBarrier$ |
|
EnterIsland |
INTERNAL API
|
EnterIsland$ |
|
Entity<M,E> |
Props of the entity actors, such as dispatcher settings.
|
Entity<M,E> |
Props of the entity actors, such as dispatcher settings.
|
Entity$ |
Defines how the entity should be created.
|
Entity$ |
Defines how the entity should be created.
|
EntityContext<M> |
Parameter to Entity.of
|
EntityContext |
Parameter to Entity.apply
|
EntityFactory<M> |
|
EntityRecoveryStrategy |
|
EntityRecoveryStrategy$ |
If the message is for the same entity as we are waiting for the update it will be added to
its messageBuffer, which will be sent after the update has completed.
|
EntityRef<M> |
Send a message to the entity referenced by this EntityRef using *at-most-once*
messaging semantics.
|
EntityRef<M> |
Send a message to the entity referenced by this EntityRef using *at-most-once*
messaging semantics.
|
EntityRefImpl<M> |
Similar to akka.actor.typed.scaladsl.AskPattern.PromiseRef but for an `EntityRef` target.
|
EntityTypeKey<T> |
Name of the entity type.
|
EntityTypeKey<T> |
Name of the entity type.
|
EntityTypeKey$ |
Creates an EntityTypeKey .
|
EntityTypeKey$ |
Creates an EntityTypeKey .
|
EntityTypeKeyImpl<T> |
|
EntityTypeKeyImpl$ |
Default separator character used for concatenating EntityTypeKey with entityId to construct unique persistenceId.
|
Envelope |
|
Envelope$ |
|
EnvelopeBuffer |
INTERNAL API
|
EnvelopeBuffer$ |
INTERNAL API
|
EnvelopeBufferPool |
INTERNAL API
|
ErrorFilter |
Java API: create an ErrorFilter
|
ErrorFilter$ |
|
ErrorMessages |
INTERNAL API
|
ErrorMessages$ |
INTERNAL API
|
ErrorPublisher |
INTERNAL API
|
ErrorPublisher$ |
|
EventAdapter |
|
EventAdapter<E,P> |
Type of the event to persist
|
EventAdapters |
Finds the "most specific" matching adapter for the given class (i.e.
|
EventAdapters.CombinedReadEventAdapter |
INTERNAL API
|
EventAdapters.CombinedReadEventAdapter$ |
|
EventAdapters$ |
INTERNAL API
|
EventBus |
Attempts to register the subscriber to the specified Classifier
|
EventBus<E,S,C> |
Attempts to register the subscriber to the specified Classifier
|
EventClock |
INTERNAL API
|
EventClockImpl |
INTERNAL API
|
EventEnvelope |
Event wrapper adding meta data for the events in the result stream of
EventsByTagQuery query, or similar queries.
|
EventEnvelope$ |
|
EventFilter |
This method decides whether to filter the event (true ) or not
(false ).
|
EventFilter |
|
EventFilter$ |
Create a filter for Error events.
|
EventHandler<State,Event> |
FunctionalInterface for reacting on events having been persisted
|
EventHandlerBuilder<State,Event> |
Use this method to define event handlers that are selected when the passed predicate holds true.
|
EventHandlerBuilder$ |
|
EventHandlerBuilderByState<S extends State,State,Event> |
Match any event which is an instance of E or a subtype of E .
|
EventHandlerBuilderByState$ |
param: stateClass The handlers defined by this builder are used when the state is an instance of the stateClass
|
EventPublisher |
INTERNAL API
|
EventRejectedException |
Thrown if a journal rejects an event e.g.
|
EventsByPersistenceIdPublisher |
INTERNAL API
|
EventsByPersistenceIdPublisher.Continue$ |
INTERNAL API
|
EventsByPersistenceIdPublisher$ |
INTERNAL API
|
EventsByPersistenceIdQuery |
Query events for a specific PersistentActor identified by persistenceId .
|
EventsByPersistenceIdQuery |
Query events for a specific PersistentActor identified by persistenceId .
|
EventsByTagPublisher |
INTERNAL API
|
EventsByTagPublisher.Continue$ |
INTERNAL API
|
EventsByTagPublisher$ |
INTERNAL API
|
EventsByTagQuery |
Query events that have a specific tag.
|
EventsByTagQuery |
Query events that have a specific tag.
|
EventSeq |
Convert a event from its journal model to the applications domain model.
|
EventSeq$ |
Java API
|
EventSink |
INTERNAL API
|
Eventsourced |
Returns persistenceId .
|
Eventsourced.AsyncHandlerInvocation |
|
Eventsourced.AsyncHandlerInvocation$ |
|
Eventsourced.PendingHandlerInvocation |
INTERNAL API
|
Eventsourced.RecoveryTick |
|
Eventsourced.RecoveryTick$ |
|
Eventsourced.StashingHandlerInvocation |
|
Eventsourced.StashingHandlerInvocation$ |
|
Eventsourced.State |
|
Eventsourced$ |
INTERNAL API
|
EventSourcedBehavior<Command,Event,State> |
Factory of effects.
|
EventSourcedBehavior<Command,Event,State> |
Allows the event sourced behavior to react on signals.
|
EventSourcedBehavior.CommandHandler$ |
Convenience for simple commands that don't need the state and context.
|
EventSourcedBehavior$ |
Type alias for the command handler function that defines how to act on commands.
|
EventSourcedBehaviorImpl<Command,Event,State> |
|
EventSourcedBehaviorImpl.WriterIdentity |
|
EventSourcedBehaviorImpl.WriterIdentity$ |
|
EventSourcedBehaviorImpl$ |
|
EventSourcedBehaviorWithEnforcedReplies<Command,Event,State> |
Implement by handling incoming commands and return an Effect() to persist or signal other effects
of the command handling such as stopping the behavior or others.
|
EventSourcedEntity<Command,Event,State> |
Any Behavior can be used as a sharded entity actor, but the combination of sharding and persistent
actors is very common and therefore this PersistentEntity class is provided as convenience.
|
EventSourcedEntity |
Create a Behavior for a persistent actor that is used with Cluster Sharding.
|
EventSourcedEntity$ |
Create a Behavior for a persistent actor that is used with Cluster Sharding.
|
EventSourcedSettings |
|
EventSourcedSettings$ |
INTERNAL API
|
EventSourcedSignal |
Supertype for all Akka Persistence Typed specific signals
|
EventsSeq<E> |
|
EventsSeq$ |
|
EventStream |
|
EventStreamUnsubscriber |
INTERNAL API
|
EventStreamUnsubscriber.Register |
|
EventStreamUnsubscriber.Register$ |
|
EventStreamUnsubscriber.UnregisterIfNoMoreSubscribedChannels |
|
EventStreamUnsubscriber.UnregisterIfNoMoreSubscribedChannels$ |
|
EventStreamUnsubscriber$ |
INTERNAL API
|
EWMA |
Calculates the exponentially weighted moving average for a given monitored data set.
|
EWMA$ |
math.log(2)
|
ExecutionContexts |
Returns a new ExecutionContextExecutor which will delegate execution to the underlying Executor,
and which will use the default error reporter.
|
ExecutionContexts.sameThreadExecutionContext$ |
WARNING: Not A General Purpose ExecutionContext!
|
ExecutionContexts$ |
Returns a new ExecutionContextExecutor which will delegate execution to the underlying Executor,
and which will use the default error reporter.
|
ExecutorServiceConfigurator |
An ExecutorServiceConfigurator is a class that given some prerequisites and a configuration can create instances of ExecutorService
|
ExecutorServiceDelegate |
As the name says
|
ExecutorServiceFactory |
|
ExecutorServiceFactoryProvider |
|
ExitIsland |
INTERNAL API
|
ExitIsland$ |
INTERNAL API
|
Expand<In,Out> |
INTERNAL API
|
ExpectingReply<ReplyMessage> |
Commands may implement this trait to facilitate sending reply messages via Effect.thenReply .
|
ExplicitAskSupport |
Import this implicit conversion to gain ? and ask methods on
ActorRef , which will defer to the
ask(actorRef, askSender => message)(timeout) method defined here.
|
ExplicitlyAskableActorRef |
INTERNAL API: for binary compatibility
|
ExplicitlyAskableActorRef$ |
|
ExplicitlyAskableActorSelection |
INTERNAL API: for binary compatibility
|
ExplicitlyAskableActorSelection$ |
|
ExplicitlyTriggeredScheduler |
Advance the clock by the specified duration, executing all outstanding jobs on the calling thread before returning.
|
ExposedPublisher |
INTERNAL API
|
ExposedPublisher$ |
|
ExposedPublisherReceive |
INTERNAL API
|
ExtendedActorMaterializer |
INTERNAL API
|
ExtendedActorSystem |
The ActorRefProvider is the only entity which creates all actor references within this actor system.
|
ExtendedBackoffOptions<T extends ExtendedBackoffOptions<T>> |
Returns a new BackoffOptions with automatic back-off reset.
|
ExtensibleBehavior<T> |
Process an incoming message and return the next behavior.
|
Extension |
The basic ActorSystem covers all that is needed for locally running actors,
using futures and so on.
|
Extension |
Marker trait/interface for extensions.
|
ExtensionId<T extends Extension> |
Returns an instance of the extension identified by this ExtensionId instance.
|
ExtensionId<T extends Extension> |
Create the extension, will be invoked at most one time per actor system where the extension is registered.
|
ExtensionIdProvider |
Returns the canonical ExtensionId for this Extension
|
ExtensionKey<T extends Extension> |
Deprecated.
|
Extensions |
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
|
ExtensionSetup<T extends Extension> |
Each extension typically provide a concrete ExtensionSetup that can be used in
ActorSystemSetup when starting the ActorSystem to replace the default
implementation of the extension.
|
ExtensionsImpl |
INTERNAL API
|
ExtractorAdapter<E,M> |
INTERNAL API
Extracts entityId and unwraps ShardingEnvelope and StartEntity messages.
|
FailBarrier |
|
FailBarrier$ |
|
Failed |
INTERNAL API
|
Failed$ |
|
FailedSource<T> |
INTERNAL API
|
FailureDetector |
Returns true if the resource is considered to be up and healthy and returns false otherwise.
|
FailureDetector.Clock |
|
FailureDetector$ |
Abstraction of a clock that returns time in milliseconds.
|
FailureDetectorLoader |
|
FailureDetectorLoader$ |
|
FailureDetectorRegistry<A> |
Returns true if the resource is considered to be up and healthy and returns false otherwise.
|
FailureInjectorException |
|
FailureInjectorException$ |
|
FailureInjectorHandle |
INTERNAL API
|
FailureInjectorHandle$ |
|
FailureInjectorProvider |
|
FailureInjectorTransportAdapter |
INTERNAL API
|
FailureInjectorTransportAdapter.All |
Deprecated.
|
FailureInjectorTransportAdapter.All$ |
Deprecated.
|
FailureInjectorTransportAdapter.Drop |
|
FailureInjectorTransportAdapter.Drop$ |
|
FailureInjectorTransportAdapter.FailureInjectorCommand |
|
FailureInjectorTransportAdapter.GremlinMode |
|
FailureInjectorTransportAdapter.One |
|
FailureInjectorTransportAdapter.One$ |
|
FailureInjectorTransportAdapter.PassThru$ |
|
FailureInjectorTransportAdapter$ |
Java API: get the singleton instance
|
FailureResult |
INTERNAL API
|
FailureResult$ |
|
FairDistributionHashCache |
INTERNAL API
|
FanIn |
INTERNAL API
|
FanIn.InputBunch |
|
FanIn.OnComplete |
|
FanIn.OnComplete$ |
|
FanIn.OnError |
|
FanIn.OnError$ |
|
FanIn.OnNext |
|
FanIn.OnNext$ |
|
FanIn.OnSubscribe |
|
FanIn.OnSubscribe$ |
|
FanIn.SubInput<T> |
|
FanIn.SubInput$ |
|
FanIn$ |
INTERNAL API
|
FanInShape<O> |
Not meant for overriding outside of Akka.
|
FanInShape.Init<O> |
|
FanInShape.Name<O> |
|
FanInShape.Name$ |
|
FanInShape.Ports<O> |
|
FanInShape.Ports$ |
|
FanInShape$ |
|
FanInShape10<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,O> |
|
FanInShape11<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,O> |
|
FanInShape12<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,O> |
|
FanInShape13<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,O> |
|
FanInShape14<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,O> |
|
FanInShape15<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,O> |
|
FanInShape16<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,O> |
|
FanInShape17<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,O> |
|
FanInShape18<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,O> |
|
FanInShape19<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,O> |
|
FanInShape1N<T0,T1,O> |
Deprecated.
|
FanInShape2<T0,T1,O> |
|
FanInShape20<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,O> |
|
FanInShape21<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,O> |
|
FanInShape22<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,O> |
|
FanInShape3<T0,T1,T2,O> |
|
FanInShape4<T0,T1,T2,T3,O> |
|
FanInShape5<T0,T1,T2,T3,T4,O> |
|
FanInShape6<T0,T1,T2,T3,T4,T5,O> |
|
FanInShape7<T0,T1,T2,T3,T4,T5,T6,O> |
|
FanInShape8<T0,T1,T2,T3,T4,T5,T6,T7,O> |
|
FanInShape9<T0,T1,T2,T3,T4,T5,T6,T7,T8,O> |
|
FanOut |
INTERNAL API
|
FanOut.ExposedPublishers |
|
FanOut.ExposedPublishers$ |
|
FanOut.FanoutOutputs |
|
FanOut.OutputBunch |
|
FanOut.SubstreamCancel |
|
FanOut.SubstreamCancel$ |
|
FanOut.SubstreamRequestMore |
|
FanOut.SubstreamRequestMore$ |
|
FanOut.SubstreamSubscribePending |
|
FanOut.SubstreamSubscribePending$ |
|
FanOut.SubstreamSubscription |
|
FanOut$ |
Will only transfer an element when all marked outputs
have demand, and will complete as soon as any of the marked
outputs have canceled.
|
FanoutOutputs |
INTERNAL API
|
FanoutProcessorImpl |
INTERNAL API
|
FanoutProcessorImpl$ |
INTERNAL API
|
FanoutPublisherSink<In> |
INTERNAL API
|
FanOutShape<I> |
Not meant for overriding outside of Akka.
|
FanOutShape.Init<I> |
|
FanOutShape.Name<I> |
|
FanOutShape.Name$ |
|
FanOutShape.Ports<I> |
|
FanOutShape.Ports$ |
|
FanOutShape$ |
|
FanOutShape10<I,O0,O1,O2,O3,O4,O5,O6,O7,O8,O9> |
|
FanOutShape11<I,O0,O1,O2,O3,O4,O5,O6,O7,O8,O9,O10> |
|
FanOutShape12<I,O0,O1,O2,O3,O4,O5,O6,O7,O8,O9,O10,O11> |
|
FanOutShape13<I,O0,O1,O2,O3,O4,O5,O6,O7,O8,O9,O10,O11,O12> |
|
FanOutShape14<I,O0,O1,O2,O3,O4,O5,O6,O7,O8,O9,O10,O11,O12,O13> |
|
FanOutShape15<I,O0,O1,O2,O3,O4,O5,O6,O7,O8,O9,O10,O11,O12,O13,O14> |
|
FanOutShape16<I,O0,O1,O2,O3,O4,O5,O6,O7,O8,O9,O10,O11,O12,O13,O14,O15> |
|
FanOutShape17<I,O0,O1,O2,O3,O4,O5,O6,O7,O8,O9,O10,O11,O12,O13,O14,O15,O16> |
|
FanOutShape18<I,O0,O1,O2,O3,O4,O5,O6,O7,O8,O9,O10,O11,O12,O13,O14,O15,O16,O17> |
|
FanOutShape19<I,O0,O1,O2,O3,O4,O5,O6,O7,O8,O9,O10,O11,O12,O13,O14,O15,O16,O17,O18> |
|
FanOutShape2<I,O0,O1> |
|
FanOutShape20<I,O0,O1,O2,O3,O4,O5,O6,O7,O8,O9,O10,O11,O12,O13,O14,O15,O16,O17,O18,O19> |
|
FanOutShape21<I,O0,O1,O2,O3,O4,O5,O6,O7,O8,O9,O10,O11,O12,O13,O14,O15,O16,O17,O18,O19,O20> |
|
FanOutShape22<I,O0,O1,O2,O3,O4,O5,O6,O7,O8,O9,O10,O11,O12,O13,O14,O15,O16,O17,O18,O19,O20,O21> |
|
FanOutShape3<I,O0,O1,O2> |
|
FanOutShape4<I,O0,O1,O2,O3> |
|
FanOutShape5<I,O0,O1,O2,O3,O4> |
|
FanOutShape6<I,O0,O1,O2,O3,O4,O5> |
|
FanOutShape7<I,O0,O1,O2,O3,O4,O5,O6> |
|
FanOutShape8<I,O0,O1,O2,O3,O4,O5,O6,O7> |
|
FanOutShape9<I,O0,O1,O2,O3,O4,O5,O6,O7,O8> |
|
FastMerge |
INTERNAL API: should be called from "updating" methods, and `resetDelta`
|
FaultHandling |
Do re-create the actor in response to a failure.
|
FI |
Class that encapsulates Functional Interfaces used for creating partial functions.
|
FI.Apply<I,R> |
Functional interface for an application.
|
FI.Apply2<I1,I2,R> |
Functional interface for an application.
|
FI.TypedPredicate<T> |
Functional interface for a predicate.
|
FI.TypedPredicate2<T,U> |
Functional interface for a predicate.
|
FI.UnitApply<I> |
Functional interface for an application.
|
FI.UnitApply2<I1,I2> |
Functional interface for an application.
|
FI.UnitApply3<I1,I2,I3> |
Functional interface for an application.
|
FI.UnitApply4<I1,I2,I3,I4> |
Functional interface for an application.
|
FI.UnitApplyVoid |
Functional interface for an application.
|
FileIO |
Creates a Sink that writes incoming ByteString elements to the given file.
|
FileIO |
Creates a Source from a files contents.
|
FileIO$ |
Creates a Sink that writes incoming ByteString elements to the given file.
|
FileIO$ |
Creates a Source from a files contents.
|
FileSink |
INTERNAL API
Creates simple synchronous Sink which writes all incoming elements to the given file
(creating it before hand if necessary).
|
FileSource |
BLOCKING I/O READ
|
FileSource$ |
INTERNAL API
|
FileSubscriber |
INTERNAL API
|
FileSubscriber$ |
INTERNAL API
|
Filter |
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<T> |
INTERNAL API
|
Filter$ |
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$ |
|
FirstCollectorState<T,R> |
INTERNAL API
|
FirstReducerState<T,R> |
INTERNAL API
|
FirstSeedNodeProcess |
INTERNAL API.
|
FishingOutcome |
Not for user extension.
|
FishingOutcome.Complete$ |
|
FishingOutcome.Continue$ |
|
FishingOutcome.ContinueAndIgnore$ |
|
FishingOutcome.ContinueOutcome |
|
FishingOutcome.Fail |
|
FishingOutcome.Fail$ |
|
FishingOutcome$ |
|
FishingOutcomes |
Consume this message and continue with the next
|
FishingOutcomes |
Complete fishing and return all messages up until this
|
FishingOutcomes$ |
Consume this message and continue with the next
|
FishingOutcomes$ |
Complete fishing and return all messages up until this
|
FixedSizeBuffer |
INTERNAL API
|
FixedSizeBuffer.ModuloFixedSizeBuffer<T> |
|
FixedSizeBuffer.PowerOfTwoFixedSizeBuffer<T> |
|
FixedSizeBuffer$ |
INTERNAL API
|
FixedSizePartitionHub<T> |
INTERNAL API
|
FixedSizePartitionQueue |
INTERNAL API
|
Flag |
|
Flag$ |
Flag that is initialized to false .
|
FlagKey |
|
FlagKey$ |
|
FlattenMerge<T,M> |
INTERNAL API
|
FlightRecorder |
INTERNAL API
|
FlightRecorder$ |
|
FlightRecorderDump |
Internal API
|
FlightRecorderDump$ |
Internal API
|
FlightRecorderEvents |
INTERNAL API
|
FlightRecorderEvents$ |
INTERNAL API
|
FlightRecorderReader |
Internal API
|
FlightRecorderReader.Empty$ |
|
FlightRecorderReader.Entry |
|
FlightRecorderReader.Live$ |
|
FlightRecorderReader.LogState |
|
FlightRecorderReader.SectionParameters |
|
FlightRecorderReader.SectionParameters$ |
|
FlightRecorderReader.Snapshot$ |
|
FlightRecorderReader$ |
Internal API
|
FlightRecorderStatus |
INTERNAL API
|
FlightRecordingSupport |
Delete flight the recorder file if it exists
|
Flow<In,Out,Mat> |
Converts this Flow to its Scala DSL counterpart
|
Flow<In,Out,Mat> |
Connect this Flow to a Sink , concatenating the processing steps of both.
|
Flow$ |
Create a `Flow` which can process elements of type `T`.
|
Flow$ |
Creates a Flow from a Reactive Streams Processor
|
FlowMonitor<T> |
Used to monitor the state of a stream
|
FlowMonitorState |
Stream was created, but no events have passed through it
|
FlowMonitorState.Failed |
Stream failed
|
FlowMonitorState.Failed$ |
|
FlowMonitorState.Finished$ |
Stream completed successfully
|
FlowMonitorState.Initialized$ |
|
FlowMonitorState.Received<U> |
Stream processed a message
|
FlowMonitorState.Received$ |
|
FlowMonitorState.StreamState<U> |
|
FlowMonitorState$ |
Stream was created, but no events have passed through it
|
FlowNames |
INTERNAL API
|
FlowNames$ |
INTERNAL API
|
FlowOps<Out,Mat> |
Transform this Flow by appending the given processing steps.
|
FlowOpsMat<Out,Mat> |
Transform this Flow by appending the given processing steps.
|
FlowShape<I,O> |
A Flow Shape has exactly one input and one output, it looks from the
outside like a pipe (but it can be a complex topology of streams within of
course).
|
FlowShape$ |
Java API
|
FlowWithContext<In,CtxIn,Out,CtxOut,Mat> |
Transform this flow by the regular flow.
|
FlowWithContext<In,CtxIn,Out,CtxOut,Mat> |
Context-preserving variant of akka.stream.scaladsl.Flow.withAttributes .
|
FlowWithContext$ |
Creates a FlowWithContext from a regular flow that operates on Pair elements.
|
FlowWithContext$ |
Creates an "empty" FlowWithContext that passes elements through with their context unchanged.
|
FlowWithContextOps<Out,Ctx,Mat> |
Transform this flow by the regular flow.
|
FlushOnShutdown |
INTERNAL API
|
FlushOnShutdown.Timeout$ |
|
FlushOnShutdown$ |
INTERNAL API
|
Fold<In,Out> |
INTERNAL API
|
Fold$ |
|
FoldAsync<In,Out> |
INTERNAL API
|
Foreach<T> |
This method will be invoked once when/if a Future that this callback is registered on
becomes successfully completed
|
ForkJoinExecutorConfigurator |
INTERNAL AKKA USAGE ONLY
|
ForkJoinExecutorConfigurator.AkkaForkJoinPool |
|
ForkJoinExecutorConfigurator.AkkaForkJoinTask |
|
ForkJoinExecutorConfigurator$ |
INTERNAL AKKA USAGE ONLY
|
ForkJoinPool |
|
ForkJoinPool.ForkJoinWorkerThreadFactory |
|
ForkJoinPool.ManagedBlocker |
Interface for extending managed parallelism for tasks running
in ForkJoinPool s.
|
ForkJoinTask<V> |
Abstract base class for tasks that run within a ForkJoinPool .
|
ForkJoinWorkerThread |
|
ForwardWire |
|
ForwardWire$ |
|
Framing |
Creates a Flow that handles decoding a stream of unstructured byte chunks into a stream of frames where the
incoming chunk stream uses a specific byte-sequence to mark frame boundaries.
|
Framing |
Creates a Flow that handles decoding a stream of unstructured byte chunks into a stream of frames where the
incoming chunk stream uses a specific byte-sequence to mark frame boundaries.
|
Framing.FramingException |
|
Framing$ |
Creates a Flow that handles decoding a stream of unstructured byte chunks into a stream of frames where the
incoming chunk stream uses a specific byte-sequence to mark frame boundaries.
|
Framing$ |
Creates a Flow that handles decoding a stream of unstructured byte chunks into a stream of frames where the
incoming chunk stream uses a specific byte-sequence to mark frame boundaries.
|
FramingTruncation |
Determines mode in which [[Framing]] operates.
|
FromConfig |
INTERNAL API
|
FromConfig$ |
Java API: get the singleton instance
|
FSM<S,D> |
This extractor is just convenience for matching a (S, S) pair, including a
reminder what the new state is.
|
FSM.$minus$greater$ |
|
FSM.CurrentState<S> |
|
FSM.CurrentState$ |
|
FSM.Event<D> |
|
FSM.Event$ |
|
FSM.Failure |
|
FSM.Failure$ |
|
FSM.LogEntry<S,D> |
Log Entry of the LoggingFSM , can be obtained by calling getLog .
|
FSM.LogEntry$ |
|
FSM.Normal$ |
|
FSM.NullFunction$ |
|
FSM.Reason |
|
FSM.Shutdown$ |
|
FSM.SilentState<S,D> |
INTERNAL API
|
FSM.State<S,D> |
|
FSM.State$ |
|
FSM.StateTimeout$ |
|
FSM.StopEvent<S,D> |
|
FSM.StopEvent$ |
|
FSM.SubscribeTransitionCallBack |
|
FSM.SubscribeTransitionCallBack$ |
|
FSM.Timer |
|
FSM.Timer$ |
|
FSM.TransformHelper |
|
FSM.Transition<S> |
|
FSM.Transition$ |
|
FSM.UnsubscribeTransitionCallBack |
|
FSM.UnsubscribeTransitionCallBack$ |
|
FSM$ |
A partial function value which does not match anything and can be used to
“reset” whenUnhandled and onTermination handlers.
|
FSMStateFunctionBuilder<S,D> |
|
FSMStateFunctionBuilder<S,D,E> |
|
FSMStopBuilder<S,D> |
|
FSMStopBuilder<S,D> |
|
FSMTransitionHandlerBuilder<S> |
|
Function<T,R> |
A Function interface.
|
Function<T,R> |
A Function interface.
|
Function10<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,R> |
A Function interface.
|
Function11<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,R> |
A Function interface.
|
Function12<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,R> |
A Function interface.
|
Function13<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,R> |
A Function interface.
|
Function14<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,R> |
A Function interface.
|
Function15<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,R> |
A Function interface.
|
Function16<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,R> |
A Function interface.
|
Function17<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,R> |
A Function interface.
|
Function18<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,R> |
A Function interface.
|
Function19<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,R> |
A Function interface.
|
Function2<T1,T2,R> |
A Function interface.
|
Function2<T1,T2,R> |
A Function interface.
|
Function20<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,R> |
A Function interface.
|
Function21<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,R> |
A Function interface.
|
Function22<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,R> |
A Function interface.
|
Function3<T1,T2,T3,R> |
A Function interface.
|
Function4<T1,T2,T3,T4,R> |
A Function interface.
|
Function5<T1,T2,T3,T4,T5,R> |
A Function interface.
|
Function6<T1,T2,T3,T4,T5,T6,R> |
A Function interface.
|
Function7<T1,T2,T3,T4,T5,T6,T7,R> |
A Function interface.
|
Function8<T1,T2,T3,T4,T5,T6,T7,T8,R> |
A Function interface.
|
Function9<T1,T2,T3,T4,T5,T6,T7,T8,T9,R> |
A Function interface.
|
FunctionRef |
Have this FunctionRef watch the given Actor.
|
FunctionRef<T> |
INTERNAL API
|
Future |
INTERNAL API
|
Future$ |
INTERNAL API
|
FutureRef<T> |
ActorRef associated with this FutureRef.
|
FutureRef$ |
Wraps an ActorRef and a Future into a FutureRef.
|
FutureRefImpl<T> |
|
Futures |
Starts an asynchronous computation and returns a Future object with the result of that computation.
|
Futures$ |
Starts an asynchronous computation and returns a Future object with the result of that computation.
|
FutureTimeoutSupport |
Returns a Future that will be completed with the success or failure of the provided value
after the specified duration.
|
GCounter |
|
GCounter$ |
Java API
|
GCounterKey |
|
GCounterKey$ |
|
GenericGraph<S extends Shape,Mat> |
INTERNAL API
|
GenericGraphWithChangedAttributes<S extends Shape,Mat> |
INTERNAL API
|
GetAddress |
|
GetAddress$ |
|
GetClusterClients |
Java API: get the singleton instance
|
GetClusterClients$ |
Java API: get the singleton instance
|
GetContactPoints |
Java API: get the singleton instance
|
GetContactPoints$ |
Java API: get the singleton instance
|
GetCurrentState |
|
GetCurrentState$ |
|
GetRoutees |
Sending this message to a router will make it send back its currently used routees.
|
GetRoutees$ |
Java API: get the singleton instance
|
GetShardRegionState |
Java API
|
GetShardRegionState$ |
|
Gossip |
|
Gossip$ |
INTERNAL API
|
GossipEnvelope |
INTERNAL API
Envelope adding a sender and receiver address to the gossip.
|
GossipEnvelope$ |
|
GossipOverview |
INTERNAL API
Represents the overview of the cluster, holds the cluster convergence table and set with unreachable nodes.
|
GossipOverview$ |
|
GossipStats |
INTERNAL API
|
GossipStats$ |
|
GossipStatus |
INTERNAL API
When there are no known changes to the node ring a GossipStatus
initiates a gossip chat between two members.
|
GossipStatus$ |
|
GossipTargetSelector |
Select n random nodes to gossip to (used to quickly inform the rest of the cluster when leaving for example)
|
GracefulShutdownQuarantinedEvent |
The uniqueAddress was quarantined but it was due to normal shutdown or cluster leaving/exiting.
|
GracefulShutdownQuarantinedEvent$ |
|
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.
|
Graph<S extends Shape,M> |
Type-level accessor for the shape parameter of this graph.
|
GraphApply |
Creates a new Graph by passing a GraphDSL.Builder to the given create function.
|
GraphCreate |
Creates a new Graph of the given Shape by passing a GraphDSL.Builder to the given create function.
|
GraphDelegate<S extends Shape,Mat> |
INTERNAL API
|
GraphDSL |
|
GraphDSL.Builder<Mat> |
Import a graph into this module, performing a deep copy, discarding its
materialized value and returning the copied Ports that are now to be
connected.
|
GraphDSL$ |
|
GraphDSL$ |
Creates a new Graph by importing the given graph list graphs and passing their Shape s
along with the GraphDSL.Builder to the given create function.
|
GraphInterpreter |
INTERNAL API
|
GraphInterpreter.Connection |
INERNAL API
|
GraphInterpreter.DownstreamBoundaryStageLogic<T> |
|
GraphInterpreter.Empty$ |
Marker object that indicates that a port holds no element since it was already grabbed.
|
GraphInterpreter.Failed |
|
GraphInterpreter.Failed$ |
|
GraphInterpreter.UpstreamBoundaryStageLogic<T> |
|
GraphInterpreter$ |
Compile time constant, enable it for debug logging to the console.
|
GraphInterpreterShell |
param: promise Will be completed upon processing the event, or failed if processing the event throws
if the event isn't ever processed the promise (the operator stops) is failed elsewhere
|
GraphStage<S extends Shape> |
A GraphStage represents a reusable graph stream processing operator.
|
GraphStageIsland |
INTERNAL API
|
GraphStageLogic |
INTERNAL API
|
GraphStageLogic.ConditionalTerminateInput |
|
GraphStageLogic.ConditionalTerminateOutput |
|
GraphStageLogic.EagerTerminateInput$ |
|
GraphStageLogic.EagerTerminateOutput$ |
|
GraphStageLogic.IgnoreTerminateInput$ |
|
GraphStageLogic.IgnoreTerminateOutput$ |
|
GraphStageLogic.StageActor |
|
GraphStageLogic.StageActorRef$ |
|
GraphStageLogic.StageActorRefNotInitializedException |
|
GraphStageLogic.StageActorRefNotInitializedException$ |
|
GraphStageLogic.TotallyIgnorantInput$ |
|
GraphStageLogic$ |
Input handler that terminates the operator upon receiving completion.
|
GraphStageLogicWithLogging |
|
GraphStageMessages |
Sent to the probe when the operator callback threw an exception
param: operation The operation that failed
|
GraphStageMessages.DownstreamFinish$ |
|
GraphStageMessages.Failure |
|
GraphStageMessages.Failure$ |
|
GraphStageMessages.Pull$ |
|
GraphStageMessages.Push$ |
|
GraphStageMessages.StageFailure |
|
GraphStageMessages.StageFailure$ |
|
GraphStageMessages.StageMessage |
|
GraphStageMessages.UpstreamFinish$ |
|
GraphStageMessages$ |
Sent to the probe when the operator callback threw an exception
param: operation The operation that failed
|
GraphStageModule<S extends Shape,M> |
INTERNAL API
|
GraphStageModule$ |
|
GraphStages |
INTERNAL API
|
GraphStages.Detacher<T> |
INTERNAL API
|
GraphStages.FutureFlattenSource<T,M> |
|
GraphStages.FutureSource<T> |
|
GraphStages.IgnoreSink$ |
|
GraphStages.SimpleLinearGraphStage<T> |
|
GraphStages.SingleSource<T> |
|
GraphStages.TickSource<T> |
|
GraphStages$ |
INTERNAL API
|
GraphStageTag |
INTERNAL API
|
GraphStageTag$ |
INTERNAL API
|
GraphStageWithMaterializedValue<S extends Shape,M> |
Grants access to the materializer before preStart of the graph stage logic is invoked.
|
Group |
Props for a group router based on the settings defined by
this instance.
|
GroupBase |
Java API: Base class for custom router Group
|
GroupBy<T,K> |
INTERNAL API
|
GroupBy$ |
|
Grouped<T> |
INTERNAL API
|
Grouped$ |
|
GroupedWeightedWithin<T> |
INTERNAL API
|
GroupedWeightedWithin$ |
|
GroupRouter<T> |
Route messages by randomly selecting the routee from the available routees.
|
GroupRouter<T> |
Route messages by randomly selecting the routee from the available routees.
|
GroupRouterBuilder<T> |
Provides builder style configuration options for group routers while still being a behavior that can be spawned
|
GroupRouterBuilder$ |
|
GroupRouterImpl<T> |
INTERNAL API
|
GSet<A> |
|
GSet$ |
Java API
|
GSetKey<A> |
|
GSetKey$ |
|
GuardianStartupBehavior<T> |
INTERNAL API
|
GuardianStartupBehavior.Start$ |
|
GuardianStartupBehavior$ |
INTERNAL API
|
GzipCompressor |
INTERNAL API
|
GzipCompressor$ |
|
GzipDecompressor |
Reading the header bytes
|
GzipDecompressor$ |
INTERNAL API
|
HandleBackoff |
INTERNAL API
|
HandshakeInfo |
|
HandshakeInfo$ |
|
HashCode |
Set of methods which allow easy implementation of hashCode .
|
HashCode$ |
Set of methods which allow easy implementation of hashCode .
|
HashCodeMessageExtractor<M> |
Default message extractor type, using envelopes to identify what entity a message is for
and the hashcode of the entityId to decide which shard an entity belongs to.
|
HashCodeNoEnvelopeMessageExtractor<M> |
Default message extractor type, using a property of the message to identify what entity a message is for
and the hashcode of the entityId to decide which shard an entity belongs to.
|
HasSequenceNumber |
Sequence number of the message
|
HasSequenceNumber$ |
|
HeaderBuilder |
Retrive the compressed ActorRef by the compressionId carried by this header.
|
HeaderBuilder$ |
INTERNAL API
|
HeaderBuilderImpl |
Note that Serialization.currentTransportInformation must be set when calling this method,
because it's using Serialization.serializedActorPath
|
HeadOptionStage<T> |
INTERNAL API
|
HeapMetricsSelector |
Java API: get the singleton instance
|
HeapMetricsSelector$ |
Java API: get the singleton instance
|
HeartbeatHistory |
|
HeartbeatHistory$ |
Create an empty HeartbeatHistory, without any history.
|
HeartbeatMessage |
Failure detector heartbeat messages are marked with this trait.
|
HeartbeatNodeRing |
Receivers for selfAddress .
|
HeartbeatNodeRing$ |
|
Hello |
First message of connection sets names straight.
|
Hello$ |
|
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.
|
Helpers.ConfigOps |
|
Helpers.ConfigOps$ |
|
Helpers.Requiring<A> |
Check that a condition is true.
|
Helpers.Requiring$ |
|
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.
|
HideImpl |
INTERNAL API
|
HopelessAssociation |
INTERNAL API
|
HopelessAssociation$ |
|
Identify |
A message all Actors will understand, that when processed will reply with
ActorIdentity containing the ActorRef .
|
Identify$ |
|
IdentityEventAdapter |
No-op model adapter which passes through the incoming events as-is.
|
IdentityEventAdapter$ |
No-op model adapter which passes through the incoming events as-is.
|
IdentityEventAdapters |
Sort so that subtypes always precede their supertypes, but without
obeying any order between unrelated subtypes (insert sort).
|
IdentityEventAdapters$ |
Sort so that subtypes always precede their supertypes, but without
obeying any order between unrelated subtypes (insert sort).
|
IgnoreBoth |
|
IgnoreBoth$ |
|
IgnoreCancel |
|
IgnoreCancel$ |
|
IgnoreComplete |
|
IgnoreComplete$ |
|
IgnoreEventSink |
INTERNAL API
|
IgnoreEventSink$ |
INTERNAL API
|
IllegalActorStateException |
IllegalActorStateException is thrown when a core invariant in the Actor implementation has been violated.
|
IllegalActorStateException$ |
|
ImmutableIntMap |
Worst case O(log n) , allocation free.
|
ImmutableIntMap$ |
INTERNAL API
|
ImmutableLongMap<A> |
Worst case O(log n) , allocation free.
|
ImmutableLongMap$ |
INTERNAL API
|
Implicits |
Deprecated.
|
Implicits |
Provides time measurement utilities on Stream elements.
|
Implicits.TimedFlowDsl<I,O,Mat> |
|
Implicits.TimedFlowDsl$ |
|
Implicits.TimedSourceDsl<I,Mat> |
|
Implicits.TimedSourceDsl$ |
|
Implicits$ |
Deprecated.
|
Implicits$ |
Provides time measurement utilities on Stream elements.
|
ImplicitSender |
|
InboundActorRefCompression |
INTERNAL API
Dedicated per remote system inbound compression table.
|
InboundCompression<T> |
Override and specialize if needed, for default compression logic delegate to 3-param overload
|
InboundCompression.Tables<T> |
|
InboundCompression.Tables$ |
|
InboundCompression$ |
Encapsulates the various compression tables that Inbound Compression uses.
|
InboundCompressions |
Triggers compression advertisement via control message.
|
InboundCompressionsImpl |
Send compression table advertisement over control stream.
|
InboundCompressionsImpl$ |
|
InboundContext |
The local inbound address.
|
InboundControlJunction |
INTERNAL API
|
InboundControlJunction.Attach |
|
InboundControlJunction.Attach$ |
|
InboundControlJunction.CallbackMessage |
|
InboundControlJunction.ControlMessageObserver |
|
InboundControlJunction.ControlMessageSubject |
|
InboundControlJunction.Dettach |
|
InboundControlJunction.Dettach$ |
|
InboundControlJunction$ |
Observer subject for inbound control messages.
|
InboundEnvelope |
INTERNAL API
|
InboundEnvelope$ |
Only used in tests
|
InboundHandshake |
INTERNAL API
|
InboundManifestCompression |
INTERNAL API
|
InboundMessageDispatcher |
INTERNAL API
|
InboundQuarantineCheck |
INTERNAL API
|
InboundTestStage |
INTERNAL API
|
Inbox |
Create a new actor which will internally queue up messages it gets so that
they can be interrogated with the akka.actor.dsl.Inbox!.Inbox!.receive
and akka.actor.dsl.Inbox!.Inbox!.select methods.
|
Inbox |
Receive the next message from this Inbox.
|
Inbox.InboxExtension |
|
Inbox.Query |
|
Inbox$ |
INTERNAL API
|
Inbox$ |
Create a new Inbox within the given system.
|
Inbox$Inbox |
Receive a single message from the internal receiver actor.
|
IncomingConnectionStage |
INTERNAL API
|
Index<K,V> |
Associates the value of type V with the key of type K
|
IndirectActorProducer |
This factory method must produce a fresh actor instance upon each
invocation.
|
IndirectActorProducer$ |
This method is used by Props to determine the type of actor which will
be created.
|
Inet |
SocketOption is a package of data (from the user) and associated
behavior (how to apply that to a channel).
|
Inet.AbstractSocketOption |
|
Inet.AbstractSocketOptionV2 |
|
Inet.DatagramChannelCreator |
|
Inet.DatagramChannelCreator$ |
|
Inet.SO$ |
|
Inet.SocketOption |
|
Inet.SocketOptionV2 |
|
Inet.SoForwarders |
|
Inet.SoJavaFactories |
|
Inet$ |
SocketOption is a package of data (from the user) and associated
behavior (how to apply that to a channel).
|
InetAddressDnsProvider |
|
InetAddressDnsResolver |
Respects the settings that can be set on the Java runtime via parameters.
|
InfoFilter |
Java API: create an InfoFilter
|
InfoFilter$ |
|
InHandler |
Called when the input port has a new element available.
|
Inlet<T> |
INTERNAL API.
|
Inlet$ |
Scala API
|
InmemJournal |
INTERNAL API.
|
InmemMessages |
INTERNAL API.
|
InPort |
INTERNAL API
|
Inputs |
INTERNAL API
|
InputStreamAdapter |
INTERNAL API
InputStreamAdapter that interacts with InputStreamSinkStage
|
InputStreamPublisher |
INTERNAL API
|
InputStreamPublisher$ |
INTERNAL API
|
InputStreamSinkStage |
INTERNAL API
|
InputStreamSinkStage.AdapterToStageMessage |
|
InputStreamSinkStage.Close$ |
|
InputStreamSinkStage.Data |
|
InputStreamSinkStage.Data$ |
|
InputStreamSinkStage.Failed |
|
InputStreamSinkStage.Failed$ |
|
InputStreamSinkStage.Finished$ |
|
InputStreamSinkStage.Initialized$ |
|
InputStreamSinkStage.ReadElementAcknowledgement$ |
|
InputStreamSinkStage.StageWithCallback |
|
InputStreamSinkStage.StreamToAdapterMessage |
|
InputStreamSinkStage$ |
|
InputStreamSource |
INTERNAL API
Source backed by the given input stream.
|
InterceptorImpl<O,I> |
Provides the impl of any behavior that could nest another behavior
|
InterceptorImpl$ |
Provides the impl of any behavior that could nest another behavior
|
Interleave<T> |
Interleave represents deterministic merge which takes N elements per input stream,
in-order of inputs, emits them downstream and then cycles/"wraps-around" the inputs.
|
Interleave$ |
Create a new Interleave with the specified number of input ports and given size of elements
to take from each input.
|
InternalActorRef |
Get a reference to the actor ref provider which created this ref.
|
InternalApi |
Marks APIs that are considered internal to Akka and may change at any point in time without any
warning.
|
InternalClusterAction |
Command to join the cluster.
|
InternalClusterAction.AddOnMemberRemovedListener |
|
InternalClusterAction.AddOnMemberRemovedListener$ |
|
InternalClusterAction.AddOnMemberUpListener |
|
InternalClusterAction.AddOnMemberUpListener$ |
|
InternalClusterAction.CompatibleConfig |
|
InternalClusterAction.CompatibleConfig$ |
|
InternalClusterAction.ConfigCheck |
|
InternalClusterAction.ConfigCheckUnsupportedByJoiningNode$ |
|
InternalClusterAction.ExitingCompleted$ |
|
InternalClusterAction.ExitingConfirmed |
|
InternalClusterAction.ExitingConfirmed$ |
|
InternalClusterAction.GetClusterCoreRef$ |
|
InternalClusterAction.GossipSpeedupTick$ |
|
InternalClusterAction.GossipTick$ |
|
InternalClusterAction.IncompatibleConfig$ |
|
InternalClusterAction.InitJoin |
|
InternalClusterAction.InitJoin$ |
|
InternalClusterAction.InitJoinAck |
|
InternalClusterAction.InitJoinAck$ |
|
InternalClusterAction.InitJoinNack |
|
InternalClusterAction.InitJoinNack$ |
|
InternalClusterAction.Join |
|
InternalClusterAction.Join$ |
|
InternalClusterAction.JoinSeedNode$ |
|
InternalClusterAction.JoinSeedNodes |
|
InternalClusterAction.JoinSeedNodes$ |
|
InternalClusterAction.LeaderActionsTick$ |
|
InternalClusterAction.PublishChanges |
|
InternalClusterAction.PublishChanges$ |
|
InternalClusterAction.PublishEvent |
|
InternalClusterAction.PublishEvent$ |
|
InternalClusterAction.PublishMessage |
|
InternalClusterAction.PublishStatsTick$ |
|
InternalClusterAction.ReapUnreachableTick$ |
|
InternalClusterAction.SendCurrentClusterState |
|
InternalClusterAction.SendCurrentClusterState$ |
|
InternalClusterAction.SendGossipTo |
|
InternalClusterAction.SendGossipTo$ |
|
InternalClusterAction.Subscribe |
|
InternalClusterAction.Subscribe$ |
|
InternalClusterAction.SubscriptionMessage |
|
InternalClusterAction.Tick |
|
InternalClusterAction.UncheckedConfig$ |
|
InternalClusterAction.Unsubscribe |
|
InternalClusterAction.Unsubscribe$ |
|
InternalClusterAction.Welcome |
|
InternalClusterAction.Welcome$ |
|
InternalClusterAction$ |
Command to join the cluster.
|
InternalMessage |
A marker trait for internal messages.
|
InternalProtocol |
Protocol used internally by the eventsourced behaviors.
|
InternalProtocol.IncomingCommand<C> |
|
InternalProtocol.IncomingCommand$ |
|
InternalProtocol.JournalResponse |
|
InternalProtocol.JournalResponse$ |
|
InternalProtocol.RecoveryPermitGranted$ |
|
InternalProtocol.RecoveryTickEvent |
|
InternalProtocol.RecoveryTickEvent$ |
|
InternalProtocol.SnapshotterResponse |
|
InternalProtocol.SnapshotterResponse$ |
|
InternalProtocol$ |
|
InternalRecipientRef<T> |
Get a reference to the actor ref provider which created this ref.
|
InternalStableApi |
Marks internal members that shouldn't be changed without considering possible usage outside of
the Akka core modules.
|
InterpreterSnapshot |
A snapshot of one interpreter - contains a set of logics running in the same underlying actor.
|
Intersperse<T> |
INTERNAL API
|
Intersperse$ |
|
IntSerializer |
|
Invalid |
Java API: get the singleton instance
|
Invalid$ |
|
InvalidActorNameException |
An InvalidActorNameException is thrown when you try to convert something, usually a String, to an Actor name
which doesn't validate.
|
InvalidActorNameException$ |
|
InvalidAssociation |
INTERNAL API
|
InvalidAssociation$ |
|
InvalidMessageException |
InvalidMessageException is thrown when an invalid message is sent to an Actor;
Currently only null is an invalid message.
|
InvalidMessageException$ |
|
InvalidPartnerActorException |
Stream refs establish a connection between a local and remote actor, representing the origin and remote sides
of a stream.
|
InvalidPartnerActorException$ |
|
InvalidSequenceNumberException |
|
InvalidSequenceNumberException$ |
|
IO |
Scala API: obtain a reference to the manager actor for the given IO extension,
for example Tcp or Udp .
|
IO.Extension |
|
IO$ |
Scala API: obtain a reference to the manager actor for the given IO extension,
for example Tcp or Udp .
|
IOResult |
Java API: Numeric value depending on context, for example IO operations performed or bytes processed.
|
IOResult$ |
JAVA API: Creates successful IOResult
|
IOSettings |
Java API
|
IOSettings$ |
Java API
|
IpVersionSelector |
Load the default resolver
|
IpVersionSelector$ |
Load the default resolver
|
IslandTag |
INTERNAL API
|
IslandTracking |
|
japi |
This class contains bridge classes between Scala and Java.
|
JAPI |
|
japi.BooleanFunctionBridge<T> |
Deprecated.
|
japi.CallbackBridge<T> |
Deprecated.
|
japi.RecoverBridge<T> |
Deprecated.
|
japi.UnitFunctionBridge<T> |
Deprecated.
|
japi$ |
This class contains bridge classes between Scala and Java.
|
JavaDurationConverters |
INTERNAL API
|
JavaDurationConverters.JavaDurationOps |
|
JavaDurationConverters.JavaDurationOps$ |
|
JavaDurationConverters.ScalaDurationOps |
|
JavaDurationConverters.ScalaDurationOps$ |
|
JavaDurationConverters$ |
INTERNAL API
|
JavaJournalPerfSpec |
JAVA API
|
JavaJournalSpec |
JAVA API
|
JavaLogger |
Deprecated.
|
JavaLogger |
java.util.logging logger.
|
JavaLogging |
Deprecated.
|
JavaLogging |
Base trait for all classes that wants to be able use the JUL logging infrastructure.
|
JavaLoggingAdapter |
Deprecated.
|
JavaLoggingFilter |
LoggingFilter that uses the log level defined in the JUL
backend configuration to filter log events before publishing
the log events to the eventStream .
|
JavaPartialFunction<A,B> |
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.NoMatch$ |
|
JavaPartialFunction.NoMatchException |
|
JavaPartialFunction$ |
This method must return a different instance upon every call.
|
JavaSerializable |
Marker trait for test messages that will use JavaSerializer.
|
JavaSerializer |
This Serializer uses standard Java Serialization
|
JavaSerializer.CurrentSystem |
Java API: invoke the callable with the current system being set to the given value for this thread.
|
JavaSerializer$ |
This holds a reference to the current ActorSystem (the surrounding context)
during serialization and deserialization.
|
JavaSnapshotStoreSpec |
JAVA API
|
JavaStreamSource<T,S extends java.util.stream.BaseStream<T,S>> |
INTERNAL API
|
JavaTestKit |
Deprecated.
|
JavaVersion |
INTERNAL API
|
JavaVersion$ |
INTERNAL API
|
JmxMetricsCollector |
This constructor is used when creating an instance from configured FQCN
|
Join |
Try to join this cluster node with the node specified by 'address'.
|
Join$ |
Java API
|
JoinConfigCompatCheckCluster |
INTERNAL API
|
JoinConfigCompatChecker |
The configuration keys that are required for this checker
|
JoinConfigCompatChecker$ |
Checks that all requiredKeys are available in toCheck Config.
|
JoinConfigCompatCheckerClusterSharding |
INTERNAL API
|
JoinConfigCompatCheckSharding |
INTERNAL API
|
JoinSeedNodeProcess |
INTERNAL API.
|
JoinSeedNodes |
Java API: Join the specified seed nodes without defining them in config.
|
JoinSeedNodes$ |
|
JournalCapabilityFlags |
When true enables tests which check if the Journal properly rejects
writes of objects which are not java.lang.Serializable .
|
JournalFailureException |
INTERNAL API
|
JournalInteractions<C,E,S> |
Intended to be used in .onSignal(returnPermitOnStop) by behaviors
|
JournalPerfSpec |
Executes a block of code multiple times (no warm-up)
|
JournalPerfSpec.BenchActor |
|
JournalPerfSpec.Cmd |
|
JournalPerfSpec.Cmd$ |
|
JournalPerfSpec.ResetCounter$ |
|
JournalPerfSpec$ |
|
JournalProtocol |
Marker trait shared by internal journal messages.
|
JournalProtocol.DeleteMessagesTo |
|
JournalProtocol.DeleteMessagesTo$ |
|
JournalProtocol.LoopMessageSuccess |
|
JournalProtocol.LoopMessageSuccess$ |
|
JournalProtocol.Message |
|
JournalProtocol.RecoverySuccess |
|
JournalProtocol.RecoverySuccess$ |
|
JournalProtocol.ReplayedMessage |
|
JournalProtocol.ReplayedMessage$ |
|
JournalProtocol.ReplayMessages |
|
JournalProtocol.ReplayMessages$ |
|
JournalProtocol.ReplayMessagesFailure |
|
JournalProtocol.ReplayMessagesFailure$ |
|
JournalProtocol.Request |
|
JournalProtocol.Response |
|
JournalProtocol.WriteMessageFailure |
|
JournalProtocol.WriteMessageFailure$ |
|
JournalProtocol.WriteMessageRejected |
|
JournalProtocol.WriteMessageRejected$ |
|
JournalProtocol.WriteMessages |
|
JournalProtocol.WriteMessages$ |
|
JournalProtocol.WriteMessagesFailed |
|
JournalProtocol.WriteMessagesFailed$ |
|
JournalProtocol.WriteMessagesSuccessful$ |
|
JournalProtocol.WriteMessageSuccess |
|
JournalProtocol.WriteMessageSuccess$ |
|
JournalProtocol$ |
Marker trait shared by internal journal messages.
|
JournalSpec |
Overridable hook that is called before populating the journal for the next
test case.
|
JournalSpec$ |
|
JSerializer |
This method must be implemented, manifest may be null.
|
JsonFraming |
Returns a Flow that implements a "brace counting" based framing operator for emitting valid JSON chunks.
|
JsonFraming |
Returns a Flow that implements a "brace counting" based framing operator for emitting valid JSON chunks.
|
JsonFraming$ |
Returns a Flow that implements a "brace counting" based framing operator for emitting valid JSON chunks.
|
JsonFraming$ |
Returns a Flow that implements a "brace counting" based framing operator for emitting valid JSON chunks.
|
JsonObjectParser |
|
JsonObjectParser$ |
|
Keep |
|
Keep |
Convenience functions for often-encountered purposes like keeping only the
left (first) or only the right (second) of two input values.
|
Keep$ |
|
Keep$ |
Convenience functions for often-encountered purposes like keeping only the
left (first) or only the right (second) of two input values.
|
Key<T extends ReplicatedData> |
|
Key |
LevelDB key.
|
Key$ |
|
Key$ |
|
Kill |
Java API: get the singleton instance
|
Kill$ |
Java API: get the singleton instance
|
KillSwitch |
|
KillSwitches |
Creates a new SharedKillSwitch with the given name that can be used to control the completion of multiple
streams from the outside simultaneously.
|
KillSwitches.KillableGraphStageLogic |
|
KillSwitches.UniqueBidiKillSwitchStage$ |
|
KillSwitches.UniqueKillSwitchStage$ |
|
KillSwitches$ |
Creates a new SharedKillSwitch with the given name that can be used to control the completion of multiple
streams from the outside simultaneously.
|
LatestFirstSystemMessageList |
Indicates if the list is empty or not.
|
LatestFirstSystemMessageList |
Indicates if the list is empty or not.
|
LatestFirstSystemMessageList$ |
|
LatestFirstSystemMessageList$ |
|
LazyFlow<I,O,M> |
INTERNAL API
|
LazySink<T,M> |
INTERNAL API
|
LazySource<T,M> |
INTERNAL API
|
LazySource$ |
INTERNAL API
|
Lease |
Try to acquire the lease.
|
Lease |
Try to acquire the lease.
|
LeaseAdapter |
INTERNAL API
|
LeaseException |
|
LeaseProvider |
The configuration define at configPath must have a property lease-class that defines
the fully qualified class name of the Lease implementation.
|
LeaseProvider |
The configuration define at configPath must have a property lease-class that defines
the fully qualified class name of the Lease implementation.
|
LeaseProvider$ |
|
LeaseProvider$ |
|
LeaseSettings |
|
LeaseSettings$ |
|
LeaseTimeoutException |
|
LeaseUsageSettings |
|
Leave |
Send command to issue state transition to LEAVING for the node specified by 'address'.
|
Leave$ |
Java API
|
LeveldbCompaction |
INTERNAL API.
|
LeveldbCompaction.TryCompactLeveldb |
|
LeveldbCompaction.TryCompactLeveldb$ |
|
LeveldbCompaction$ |
|
LeveldbIdMapping |
Get the mapped numeric id for the specified persistent actor id .
|
LeveldbJournal |
INTERNAL API.
|
LeveldbJournal.CurrentPersistenceIds |
|
LeveldbJournal.CurrentPersistenceIds$ |
|
LeveldbJournal.EventAppended |
|
LeveldbJournal.EventAppended$ |
|
LeveldbJournal.PersistenceIdAdded |
|
LeveldbJournal.PersistenceIdAdded$ |
|
LeveldbJournal.ReplayedTaggedMessage |
|
LeveldbJournal.ReplayedTaggedMessage$ |
|
LeveldbJournal.ReplayTaggedMessages |
|
LeveldbJournal.ReplayTaggedMessages$ |
|
LeveldbJournal.SubscribeAllPersistenceIds$ |
|
LeveldbJournal.SubscribePersistenceId |
|
LeveldbJournal.SubscribePersistenceId$ |
|
LeveldbJournal.SubscribeTag |
|
LeveldbJournal.SubscribeTag$ |
|
LeveldbJournal.SubscriptionCommand |
|
LeveldbJournal.TaggedEventAppended |
|
LeveldbJournal.TaggedEventAppended$ |
|
LeveldbJournal$ |
Subscribe the sender to changes (appended events) for a specific persistenceId .
|
LeveldbReadJournal |
persistenceIds is used for retrieving all persistenceIds of all
persistent actors.
|
LeveldbReadJournal |
persistenceIds is used for retrieving all persistenceIds of all
persistent actors.
|
LeveldbReadJournal$ |
|
LeveldbReadJournal$ |
|
LeveldbReadJournalProvider |
|
LeveldbRecovery |
INTERNAL API.
|
LeveldbStore |
INTERNAL API.
|
LeveldbStore$ |
|
LightArrayRevolverScheduler |
Clock implementation is replaceable (for testing); the implementation must
return a monotonically increasing series of Long nanoseconds.
|
LightArrayRevolverScheduler.TaskHolder |
|
LightArrayRevolverScheduler.TimerTask |
|
LightArrayRevolverScheduler$ |
INTERNAL API
|
LimitWeighted<T> |
INTERNAL API
|
LimitWeighted$ |
|
LinearTraversalBuilder |
|
LinearTraversalBuilder$ |
Create a traversal builder specialized for linear graphs.
|
LineNumbers |
Scala API: Obtain line number information for the class defining the given object.
|
LineNumbers.NoSourceInfo$ |
|
LineNumbers.Result |
|
LineNumbers.SourceFile |
|
LineNumbers.SourceFile$ |
|
LineNumbers.SourceFileLines |
|
LineNumbers.SourceFileLines$ |
|
LineNumbers.UnknownSourceFormat |
|
LineNumbers.UnknownSourceFormat$ |
|
LineNumbers$ |
Scala API: Obtain line number information for the class defining the given object.
|
LinkedTransferQueue<E> |
|
Listen |
|
Listen$ |
|
ListenerMessage |
|
Listeners |
Chain this into the receive function.
|
LiveEventsByPersistenceIdPublisher |
INTERNAL API
|
LiveEventsByTagPublisher |
INTERNAL API
|
LmdbDurableStore |
|
LmdbDurableStore$ |
Wrapper class for serialization of a data value.
|
LoadMetrics |
INTERNAL API
|
LocalActorRef |
INTERNAL API: Is the actor terminated?
If this method returns true, it will never return false again, but if it
returns false, you cannot be sure if it's alive still (race condition)
|
LocalActorRefProvider |
Top-level anchor for the supervision hierarchy of this actor system.
|
LocalActorRefProvider$ |
System guardian
|
LocalReceptionist |
INTERNAL API
|
LocalReceptionist.InternalCommand |
|
LocalReceptionist.RegisteredActorTerminated<T> |
|
LocalReceptionist.RegisteredActorTerminated$ |
|
LocalReceptionist.SubscriberTerminated<T> |
|
LocalReceptionist.SubscriberTerminated$ |
|
LocalReceptionist$ |
INTERNAL API
|
LocalRef |
Refs which are statically known to be local inherit from this Scope
|
LocalScope |
When merging Deploy instances using
withFallback()
on
the left one, this is propagated to “merging” scopes in the same way.
|
LocalScope$ |
Java API: get the singleton instance
|
LocalSnapshotStore |
Only by persistenceId and sequenceNr, timestamp is informational - accommodates for 2.13.x series files
|
Log<T> |
INTERNAL API
|
Log$ |
Must be located here to be visible for implicit resolution, when Materializer is passed to Logging
More specific LogSource than fromString , which would add the ActorSystem name in addition to the supervision to the log source.
|
Logger |
Whether error logging is enabled on the actor system level, may not represent the setting all the way to the
logger implementation, but when it does it allows avoiding unnecessary resource usage for log entries that
will not actually end up in any logger output.
|
Logger |
param: logger - which logger
|
Logger |
param: logger - which logger
|
Logger$ |
param: logger - which logger
|
Logger$ |
param: logger - which logger
|
LoggerAdapterImpl |
INTERNAL API
|
LoggerClass |
Try to extract a logger class from the call stack, if not possible the provided default is used
|
LoggerClass$ |
Try to extract a logger class from the call stack, if not possible the provided default is used
|
LoggerMailbox |
INTERNAL API
|
LoggerMailboxType |
INTERNAL API
|
LoggerMessageQueueSemantics |
|
Logging |
|
Logging.Debug |
|
Logging.Debug$ |
|
Logging.Debug2 |
|
Logging.Debug3 |
|
Logging.DefaultLogger |
|
Logging.Error |
|
Logging.Error$ |
|
Logging.Error$.NoCause$ |
|
Logging.Error2 |
|
Logging.Error2$ |
|
Logging.Error3 |
|
Logging.Info |
|
Logging.Info$ |
|
Logging.Info2 |
|
Logging.Info3 |
|
Logging.InitializeLogger |
|
Logging.InitializeLogger$ |
|
Logging.LogEvent |
|
Logging.LogEvent$ |
|
Logging.LogEventException |
|
Logging.LogEventWithCause |
|
Logging.LogEventWithMarker |
|
Logging.LogExt |
|
Logging.LogExt$ |
|
Logging.LoggerException |
|
Logging.LoggerInitializationException |
|
Logging.LoggerInitialized |
|
Logging.LoggerInitialized$ |
|
Logging.LogLevel |
|
Logging.LogLevel$ |
|
Logging.SerializedStandardOutLogger |
|
Logging.StandardOutLogger |
|
Logging.StdOutLogger |
|
Logging.StdOutLogger$ |
|
Logging.Warning |
|
Logging.Warning$ |
|
Logging.Warning2 |
|
Logging.Warning3 |
|
Logging.Warning4 |
|
Logging$ |
|
LoggingAdapter |
|
LoggingBus |
Query currently set log level.
|
LoggingFilter |
|
LoggingFilterWithMarker |
|
LoggingFilterWithMarker$ |
|
LoggingFilterWithMarkerWrapper |
|
LoggingFSM<S,D> |
Retrieve current rolling log in oldest-first order.
|
LoggingPersistentFSM<S,D,E> |
Retrieve current rolling log in oldest-first order.
|
LoggingReceive |
This decorator adds invocation logging to a Receive function.
|
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.
|
LogicSnapshot |
Not for user extension
|
LogicSnapshotImpl |
INTERNAL API
|
LogicSnapshotImpl$ |
|
LogMarker |
A log marker is an additional metadata tag supported by some logging backends to identify "special" log events.
|
LogMarker |
Java API
|
LogMarker$ |
INTERNAL API
|
LogMarker$ |
The Marker is internally transferred via MDC using using this key
|
LogMessagesInterceptor<T> |
Log all messages for this decorated ReceiveTarget[T] to logger before receiving it ourselves.
|
LogMessagesInterceptor$ |
|
LogOptions |
User control whether messages are logged or not.
|
LogOptions.LogOptionsImpl |
|
LogOptions.LogOptionsImpl$ |
|
LogOptions$ |
INTERNAL API
|
LogSource<T> |
|
LogSource$ |
|
LongSerializer |
|
Lookup |
Which port for a service e.g.
|
Lookup$ |
Create a service Lookup with only a serviceName.
|
LookupClassification |
This is a size hint for the number of Classifiers you expect to have (use powers of 2)
|
LookupEventBus<E,S,C> |
This is a size hint for the number of Classifiers you expect to have (use powers of 2)
|
LruBoundedCache<K,V> |
INTERNAL API
|
LWWMap<A,B> |
Scala API: All entries of the map.
|
LWWMap.LWWMapTag$ |
|
LWWMap$ |
INTERNAL API
|
LWWMapKey<A,B> |
|
LWWMapKey$ |
INTERNAL API
|
LWWRegister<A> |
Java API
|
LWWRegister.Clock<A> |
|
LWWRegister$ |
param: currentTimestamp the current timestamp value of the LWWRegister
param: value the register value to set and associate with the returned timestamp
|
LWWRegisterKey<A> |
|
LWWRegisterKey$ |
INTERNAL API
|
Mailbox |
Try to enqueue the message to this queue, or throw an exception.
|
Mailbox$ |
INTERNAL API
|
Mailboxes |
Returns a mailbox type as specified in configuration, based on the id, or if not defined None.
|
Mailboxes$ |
|
MailboxType |
MailboxType is a factory to create MessageQueues for an optionally
provided ActorContext.
|
Main |
param: args one argument: the class of the application supervisor actor
|
Main.Terminator |
|
Main$ |
param: args one argument: the class of the application supervisor actor
|
ManagedActorClassification |
The unsubscriber takes care of unsubscribing actors, which have terminated.
|
ManagedActorEventBus<E> |
This is a size hint for the number of Classifiers you expect to have (use powers of 2)
|
ManifestInfo |
Versions of artifacts from known vendors.
|
ManifestInfo.Version |
Comparable version information
|
ManifestInfo$ |
Comparable version information
|
ManualReset |
|
ManualReset$ |
|
ManualTime |
Advance the clock by the specified duration, executing all outstanding jobs on the calling thread before returning.
|
ManualTime |
Advance the clock by the specified duration, executing all outstanding jobs on the calling thread before returning.
|
ManualTime$ |
Config that needs to be in place for the actor system to use the manual
|
ManualTime$ |
Config needed to use the ExplicitlyTriggeredScheduler
|
ManyVersionVector |
INTERNAL API
|
ManyVersionVector$ |
|
Map<In,Out> |
INTERNAL API
|
Map$ |
|
MapAsync<In,Out> |
|
MapAsync.Holder<T> |
|
MapAsync$ |
INTERNAL API
|
MapAsyncUnordered<In,Out> |
INTERNAL API
|
MapAsyncUnordered$ |
|
MapError<T> |
Maps error with the provided function if it is defined for an error or, otherwise, passes it on unchanged.
|
MapError$ |
|
Mapper<T,R> |
Override this method to perform the map operation, by default delegates to "checkedApply"
which by default throws an UnsupportedOperationException.
|
MarkerLoggingAdapter |
Log message at error level, including the exception that caused the error.
|
Match<I,R> |
Version of PartialFunction that can be built during runtime from Java.
|
MaterializationContext |
Context parameter to the create methods of sources and sinks.
|
MaterializationContext$ |
|
MaterializationException |
This exception or subtypes thereof should be used to signal materialization
failures.
|
MaterializationException$ |
|
MaterializeAtomic |
INTERNAL API
|
MaterializeAtomic$ |
|
MaterializedValueOp |
INTERNAL API
|
Materializer |
The namePrefix shall be used for deriving the names of processing
entities that are created during materialization.
|
Materializer$ |
Implicitly provides the system wide materializer from a classic or typed ActorSystem
|
MaterializerLoggingProvider |
SPI intended only to be extended by custom Materializer implementations,
that also want to provide operators they materialize with specialized LoggingAdapter instances.
|
MaterializerState |
Dump stream snapshots of all streams of the given materializer.
|
MaterializerState$ |
Dump stream snapshots of all streams of the given materializer.
|
MaxInFlightRequestStrategy |
Concrete subclass must implement this method to define how many
messages that are currently in progress or queued.
|
MaybeSource |
INTERNAL API
|
MaybeSource$ |
INTERNAL API
|
MayVerb |
Configurable number of frames to be shown when a MAY test fails (is canceled).
|
MayVerb.StringMayWrapperForVerb |
Block of tests which MAY pass, and if not should be ignored.
|
MayVerb.TestCanceledByFailure |
|
MayVerb.TestCanceledByFailure$ |
|
MayVerb$ |
Implicitly converts an object of type String to a StringMayWrapper ,
to enable may methods to be invokable on that object.
|
MDC |
INTERNAL API
|
MDC$ |
INTERNAL API
|
Member |
Java API
|
Member$ |
INTERNAL API
Create a new member with status Joining.
|
MembershipState |
|
MembershipState$ |
INTERNAL API
|
MemberStatus |
Defines the current status of a cluster member node
|
MemberStatus.Down$ |
|
MemberStatus.Exiting$ |
|
MemberStatus.Joining$ |
|
MemberStatus.Leaving$ |
|
MemberStatus.Removed$ |
|
MemberStatus.Up$ |
|
MemberStatus.WeaklyUp$ |
|
MemberStatus$ |
Java API: retrieve the “joining” status singleton
|
Merge |
Create a new Merge operator with the specified output type.
|
Merge<T> |
Merge several streams, taking elements as they arrive from input streams
(picking randomly when several have elements ready).
|
Merge$ |
Create a new Merge operator with the specified output type.
|
Merge$ |
Create a new Merge with the specified number of input ports.
|
MergeHub |
Creates a Source that emits elements merged from a dynamic set of producers.
|
MergeHub<T> |
INTERNAL API
|
MergeHub.Event |
|
MergeHub.ProducerFailed |
|
MergeHub$ |
Creates a Source that emits elements merged from a dynamic set of producers.
|
MergeHub$ |
Creates a Source that emits elements merged from a dynamic set of producers.
|
MergeLatest |
Create a new MergeLatest with the specified number of input ports.
|
MergeLatest<T,M> |
Create a new MergeLatest with the specified number of input ports.
|
MergeLatest$ |
Create a new MergeLatest with the specified number of input ports.
|
MergeLatest$ |
Create a new MergeLatest with the specified number of input ports.
|
MergePreferred |
Create a new MergePreferred operator with the specified output type.
|
MergePreferred<T> |
Merge several streams, taking elements as they arrive from input streams
(picking from preferred when several have elements ready).
|
MergePreferred.MergePreferredShape<T> |
|
MergePreferred$ |
Create a new MergePreferred operator with the specified output type.
|
MergePreferred$ |
Create a new MergePreferred with the specified number of secondary input ports.
|
MergePrioritized |
Create a new MergePrioritized operator with the specified output type.
|
MergePrioritized<T> |
Merge several streams, taking elements as they arrive from input streams
(picking from prioritized once when several have elements ready).
|
MergePrioritized$ |
Create a new MergePrioritized operator with the specified output type.
|
MergePrioritized$ |
Create a new MergePrioritized with specified number of input ports.
|
MergeSorted<T> |
Merge two pre-sorted streams such that the resulting stream is sorted.
|
Message |
INTERNAL API
|
Message |
Marker trait for all protobuf-serializable messages in akka.persistence .
|
Message$ |
INTERNAL API
|
MessageBuffer |
Check if the message buffer is empty.
|
MessageBuffer$ |
Create an empty message buffer.
|
MessageBufferMap<I> |
Check if the buffer map is empty.
|
MessageContainerSerializer |
|
MessageDispatcher |
Creates and returns a mailbox for the given actor.
|
MessageDispatcher |
INTERNAL API
|
MessageDispatcher$ |
INTERNAL API
|
MessageDispatcherConfigurator |
Returns an instance of MessageDispatcher given the configuration.
|
MessageFlags |
INTERNAL API
|
MessageFlags$ |
INTERNAL API
|
MessageFormats |
|
MessageFormats.AtLeastOnceDeliverySnapshot |
Protobuf type AtLeastOnceDeliverySnapshot
|
MessageFormats.AtLeastOnceDeliverySnapshot.Builder |
Protobuf type AtLeastOnceDeliverySnapshot
|
MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery |
Protobuf type AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
|
MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder |
Protobuf type AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
|
MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder |
|
MessageFormats.AtLeastOnceDeliverySnapshotOrBuilder |
|
MessageFormats.AtomicWrite |
Protobuf type AtomicWrite
|
MessageFormats.AtomicWrite.Builder |
Protobuf type AtomicWrite
|
MessageFormats.AtomicWriteOrBuilder |
|
MessageFormats.PersistentFSMSnapshot |
Protobuf type PersistentFSMSnapshot
|
MessageFormats.PersistentFSMSnapshot.Builder |
Protobuf type PersistentFSMSnapshot
|
MessageFormats.PersistentFSMSnapshotOrBuilder |
|
MessageFormats.PersistentMessage |
Protobuf type PersistentMessage
|
MessageFormats.PersistentMessage.Builder |
Protobuf type PersistentMessage
|
MessageFormats.PersistentMessageOrBuilder |
|
MessageFormats.PersistentPayload |
Protobuf type PersistentPayload
|
MessageFormats.PersistentPayload.Builder |
Protobuf type PersistentPayload
|
MessageFormats.PersistentPayloadOrBuilder |
|
MessageFormats.PersistentStateChangeEvent |
Protobuf type PersistentStateChangeEvent
|
MessageFormats.PersistentStateChangeEvent.Builder |
Protobuf type PersistentStateChangeEvent
|
MessageFormats.PersistentStateChangeEventOrBuilder |
|
MessageQueue |
Try to enqueue the message to this queue, or throw an exception.
|
MessageResult |
INTERNAL API
|
MessageResult$ |
|
MessageSerializer |
|
MessageSerializer |
Serializes persistent messages.
|
MessageSerializer |
Uses Akka Serialization for the specified ActorSystem to transform the given MessageProtocol to a message
|
MessageSerializer.SerializationException |
|
MessageSerializer$ |
Uses Akka Serialization for the specified ActorSystem to transform the given MessageProtocol to a message
|
Metric |
Updates the data point, and if defined, updates the data stream (average).
|
Metric$ |
Creates a new Metric instance if the value is valid, otherwise None
is returned.
|
MetricNumericConverter |
An defined value is neither negative nor NaN/Infinite:
JMX system load average and max heap can be 'undefined' for certain OS, in which case a -1 is returned
SIGAR combined CPU can occasionally return a NaN or Infinite (known bug)
|
MetricsCollector |
Samples and collects new data points.
|
MetricsCollector$ |
Try to create collector instance in the order of priority.
|
MetricsGossip |
|
MetricsGossip$ |
INTERNAL API
|
MetricsGossipEnvelope |
INTERNAL API.
|
MetricsGossipEnvelope$ |
|
MetricsSelector |
The weights per address, based on the nodeMetrics.
|
MetricsSelector$ |
Java API: construct a mix-selector from a sequence of selectors
|
MinimalActorRef |
Trait for ActorRef implementations where all methods contain default stubs.
|
MiscMessageSerializer |
|
MiscMessageSerializer |
|
MixMetricsSelector |
|
MixMetricsSelector$ |
Java API: get the default singleton instance
|
MixMetricsSelectorBase |
Java API: construct a mix-selector from a sequence of selectors
|
MonitorableThreadFactory |
|
MonitorableThreadFactory.AkkaForkJoinWorkerThread |
|
MonitorableThreadFactory$ |
|
MonitorInterceptor<T> |
Fire off any incoming message to another actor before receiving it ourselves.
|
MonitorInterceptor$ |
|
MsgDecoder |
|
MsgEncoder |
|
MultiNodeConfig |
Register a common base config for all test participants, if so desired.
|
MultiNodeSpec |
Constructor for using arbitrary logic to create the actor system used in
the multi node spec (the Config passed to the creator must be used in
the created actor system for the multi node tests to work)
|
MultiNodeSpec$ |
Number of nodes node taking part in this test.
|
MultiNodeSpecCallbacks |
Call this before the start of the test run.
|
MultipleConsumerSemantics |
This is a marker trait for message queues which support multiple consumers,
as is required by the BalancingDispatcher.
|
MurmurHash |
The first 23 magic integers from the first stream are stored here
|
MurmurHash$ |
The first 23 magic integers from the first stream are stored here
|
MutableCollectorState<T,R> |
INTERNAL API
|
MutableReducerState<T,R> |
INTERNAL API
|
NanoTimeTokenBucket |
Default implementation of TokenBucket that uses System.nanoTime as the time source.
|
NettyClientHelpers |
INTERNAL API
|
NettyFutureBridge |
|
NettyFutureBridge$ |
|
NettyHelpers |
INTERNAL API
|
NettyServerHelpers |
INTERNAL API
|
NettySSLSupport |
Construct a SSLHandler which can be inserted into a Netty server/client pipeline
|
NettySSLSupport$ |
Construct a SSLHandler which can be inserted into a Netty server/client pipeline
|
NettyTransport |
INTERNAL API
|
NettyTransport$ |
INTERNAL API
|
NettyTransportException |
|
NettyTransportExceptionNoStack |
|
NettyTransportSettings |
|
NettyTransportSettings.Mode |
|
NettyTransportSettings.Tcp$ |
|
NettyTransportSettings.Udp$ |
|
NettyTransportSettings$ |
|
NetworkOp |
|
NoArgsReflectConstructor |
INTERNAL API
|
Nobody |
This is an internal look-up failure token, not useful for anything else.
|
Nobody$ |
This is an internal look-up failure token, not useful for anything else.
|
NodeMessageQueue |
Called when the mailbox this queue belongs to is disposed of.
|
NodeMetrics |
Returns the most recent data.
|
NodeMetrics$ |
|
NoDowning |
Default downing provider used when no provider is configured and 'auto-down-unreachable-after'
is not enabled.
|
NoInboundCompressions |
INTERNAL API
|
NoInboundCompressions$ |
INTERNAL API
|
NoLogging |
Java API to return the reference to NoLogging
|
NoLogging$ |
Java API to return the reference to NoLogging
|
NoMarkerLogging |
Java API to return the reference to NoLogging
|
NoMarkerLogging$ |
Java API to return the reference to NoLogging
|
NoMaterializer |
INTERNAL API
|
NoMaterializer$ |
INTERNAL API
|
NoMessage |
INTERNAL API
|
NoMessage |
INTERNAL API
|
NoMessage$ |
INTERNAL API
|
NoMessage$ |
INTERNAL API
|
NonBlockingBoundedMailbox |
NonBlockingBoundedMailbox is a high-performance, multiple-producer single-consumer, bounded MailboxType,
Noteworthy is that it discards overflow as DeadLetters.
|
NonBlockingBoundedMailbox$ |
|
NonPersistentRepr |
INTERNAL API
Message which can be resequenced by the Journal, but will not be persisted.
|
NonPersistentRepr$ |
|
NoOffset |
Java API:
|
NoOffset$ |
Java API:
|
NoOpEventAdapter<E> |
INTERNAL API
|
NoOpEventAdapter$ |
INTERNAL API
|
NoopReadEventAdapter |
INTERNAL API
|
NoopReadEventAdapter$ |
|
NoopWriteEventAdapter |
INTERNAL API
|
NoopWriteEventAdapter$ |
|
NoReplyEffectImpl<State> |
INTERNAL API
|
NoRoutee |
Routee that doesn't send the message to any routee.
|
NoRoutee$ |
Routee that doesn't send the message to any routee.
|
NoRouter |
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$ |
INTERNAL API
|
NoScopeGiven |
This is the default value and as such allows overrides.
|
NoScopeGiven$ |
Java API: get the singleton instance
|
NoSerializationVerificationNeeded |
Marker trait to signal that this class should not be verified for serializability.
|
NoSnapshotStore |
Used as default snapshot-store in case no other store was configured.
|
NotInfluenceReceiveTimeout |
Marker trait to indicate that a message should not reset the receive timeout.
|
NotInitialized |
INTERNAL API
|
NotInitialized$ |
INTERNAL API
|
NotUsed |
This type is used in generic type signatures wherever the actual value is of no importance.
|
NotUsed$ |
Java API: the singleton instance
|
NotWhitelistedClassRemoteDeploymentAttemptException |
INTERNAL API
|
NullSerializer |
This is a special Serializer that Serializes and deserializes nulls only
|
NullSerializer$ |
This method must be implemented, manifest may be null.
|
ObjectPool<A> |
INTERNAL API
|
Offset |
|
Offset$ |
|
OnComplete<T> |
This method will be invoked once when/if a Future that this callback is registered on
becomes completed with a failure or a success.
|
OneByOneRequestStrategy |
Java API: get the singleton instance
|
OneByOneRequestStrategy$ |
Java API: get the singleton instance
|
OneForOneStrategy |
Java API
|
OneForOneStrategy$ |
|
OneVersionVector |
INTERNAL API
|
OneVersionVector$ |
|
Oneway |
Deprecated.
|
OnFailure |
This method will be invoked once when/if a Future that this callback is registered on
becomes completed with a failure
|
OnlyCauseStackTrace |
Mix in this trait to suppress the StackTrace for the instance of the exception but not the cause,
scala.util.control.NoStackTrace suppresses all the StackTraces.
|
OnMemberStatusChangedListener |
INTERNAL API
|
OnSuccess<T> |
This method will be invoked once when/if a Future that this callback is registered on
becomes successfully completed
|
OpCode |
INTERNAL API
|
OpCode$ |
INTERNAL API
|
OpenCircuitException |
Deprecated.
|
OpenCircuitException$ |
Deprecated.
|
OptimalSizeExploringResizer |
Report the messageCount as well as current routees so that the
it can collect metrics.
|
OptimalSizeExploringResizer.ResizeRecord |
|
OptimalSizeExploringResizer.ResizeRecord$ |
|
OptimalSizeExploringResizer.UnderUtilizationStreak |
INTERNAL API
|
OptimalSizeExploringResizer.UnderUtilizationStreak$ |
|
OptimalSizeExploringResizer$ |
INTERNAL API
|
Option<A> |
Returns a if this is some(a) or defaultValue if
this is none .
|
Option.Some<A> |
Class Some[A] represents existing values of type
A .
|
Option.Some$ |
|
Option$ |
Option factory that creates Some
|
OptionalTests |
|
OptionVal<A> |
|
OptionVal.Some$ |
|
OptionVal$ |
Represents non-existent values, null values.
|
OrElse<T> |
Takes two streams and passes the first through, the secondary stream is only passed
through if the primary stream completes without passing any elements through.
|
OrElse$ |
|
OriginalRestartException |
This is an extractor for retrieving the original cause (i.e.
|
OriginalRestartException$ |
This is an extractor for retrieving the original cause (i.e.
|
ORMap<A,B extends ReplicatedData> |
|
ORMap.AtomicDeltaOp<A,B extends ReplicatedData> |
|
ORMap.DeltaGroup<A,B extends ReplicatedData> |
|
ORMap.DeltaGroup$ |
|
ORMap.DeltaOp |
|
ORMap.PutDeltaOp<A,B extends ReplicatedData> |
|
ORMap.PutDeltaOp$ |
|
ORMap.RemoveDeltaOp<A,B extends ReplicatedData> |
|
ORMap.RemoveDeltaOp$ |
|
ORMap.RemoveKeyDeltaOp<A,B extends ReplicatedData> |
|
ORMap.RemoveKeyDeltaOp$ |
|
ORMap.UpdateDeltaOp<A,B extends ReplicatedData> |
|
ORMap.UpdateDeltaOp$ |
|
ORMap.VanillaORMapTag$ |
|
ORMap.ZeroTag |
|
ORMap$ |
Java API
|
ORMapKey<A,B extends ReplicatedData> |
|
ORMapKey$ |
|
ORMultiMap<A,B> |
Scala API: All entries of a multimap where keys are strings and values are sets.
|
ORMultiMap.ORMultiMapTag$ |
|
ORMultiMap.ORMultiMapWithValueDeltasTag$ |
|
ORMultiMap$ |
INTERNAL API
|
ORMultiMapKey<A,B> |
|
ORMultiMapKey$ |
INTERNAL API
|
ORSet<A> |
|
ORSet.AddDeltaOp<A> |
|
ORSet.AddDeltaOp$ |
|
ORSet.AtomicDeltaOp<A> |
|
ORSet.DeltaGroup<A> |
|
ORSet.DeltaGroup$ |
|
ORSet.DeltaOp |
|
ORSet.FullStateDeltaOp<A> |
|
ORSet.FullStateDeltaOp$ |
|
ORSet.RemoveDeltaOp<A> |
|
ORSet.RemoveDeltaOp$ |
|
ORSet$ |
Java API
|
ORSetKey<A> |
|
ORSetKey$ |
|
OsgiActorSystemFactory |
|
OsgiActorSystemFactory$ |
Class loader of akka-actor bundle.
|
OtherMessageComparator |
|
OtherMessageComparator$ |
|
OutboundContext |
The local inbound address.
|
OutboundControlJunction |
INTERNAL API
|
OutboundControlJunction.OutboundControlIngress |
|
OutboundControlJunction$ |
INTERNAL API
|
OutboundEnvelope |
INTERNAL API
|
OutboundEnvelope$ |
INTERNAL API
|
OutboundHandshake |
INTERNAL API
|
OutboundHandshake.HandshakeReq |
|
OutboundHandshake.HandshakeReq$ |
|
OutboundHandshake.HandshakeRsp |
|
OutboundHandshake.HandshakeRsp$ |
|
OutboundHandshake.HandshakeState |
|
OutboundHandshake.HandshakeTimeoutException |
|
OutboundHandshake$ |
Stream is failed with this exception if the handshake is not completed
within the handshake timeout.
|
OutboundTestStage |
INTERNAL API
|
OutgoingConnectionStage |
INTERNAL API
|
OutgoingConnectionStage$ |
|
OutHandler |
Called when the output port has received a pull, and therefore ready to emit an element, i.e.
|
Outlet<T> |
INTERNAL API.
|
Outlet$ |
Scala API
|
OutOfBuffersException |
INTERNAL API
|
OutPort |
INTERNAL API
|
Outputs |
INTERNAL API
|
OutputStreamAdapter |
|
OutputStreamSink |
INTERNAL API
Creates simple synchronous Sink which writes all incoming elements to the output stream.
|
OutputStreamSourceStage |
|
OutputStreamSourceStage.AdapterToStageMessage |
|
OutputStreamSourceStage.Close$ |
|
OutputStreamSourceStage.Send |
|
OutputStreamSourceStage.Send$ |
|
OutputStreamSourceStage$ |
|
OutputStreamSubscriber |
INTERNAL API
|
OutputStreamSubscriber$ |
INTERNAL API
|
OverflowStrategies |
INTERNAL API
|
OverflowStrategies.Backpressure |
|
OverflowStrategies.Backpressure$ |
|
OverflowStrategies.DropBuffer |
|
OverflowStrategies.DropBuffer$ |
|
OverflowStrategies.DropHead |
|
OverflowStrategies.DropHead$ |
|
OverflowStrategies.DropNew |
|
OverflowStrategies.DropNew$ |
|
OverflowStrategies.DropTail |
|
OverflowStrategies.DropTail$ |
|
OverflowStrategies.EmitEarly$ |
|
OverflowStrategies.Fail |
|
OverflowStrategies.Fail$ |
|
OverflowStrategies$ |
INTERNAL API
|
OverflowStrategy |
INTERNAL API
|
OverflowStrategy$ |
If the buffer is full when a new element arrives, drops the oldest element from the buffer to make space for
the new element.
|
OversizedPayloadException |
INTERNAL API
|
Pair<A,B> |
Java API
Represents a pair (tuple) of two elements.
|
Pair$ |
|
Partition |
Create a new Partition operator with the specified input type, eagerCancel is false .
|
Partition<T> |
Sets eagerCancel to false .
|
Partition.PartitionOutOfBoundsException |
|
Partition.PartitionOutOfBoundsException$ |
|
Partition$ |
Create a new Partition operator with the specified input type, eagerCancel is false .
|
Partition$ |
Create a new Partition operator with the specified input type.
|
PartitionHub |
Creates a Sink that receives elements from its upstream producer and routes them to a dynamic set
of consumers.
|
PartitionHub<T> |
INTERNAL API
|
PartitionHub.ConsumerInfo |
Sequence of all identifiers of current consumers.
|
PartitionHub.ConsumerInfo |
Sequence of all identifiers of current consumers.
|
PartitionHub.Internal$ |
|
PartitionHub.Internal$.ConsumerEvent |
|
PartitionHub.Internal$.HubEvent |
|
PartitionHub.Internal$.HubState |
|
PartitionHub.Internal$.PartitionQueue |
|
PartitionHub$ |
Creates a Sink that receives elements from its upstream producer and routes them to a dynamic set
of consumers.
|
PartitionHub$ |
INTERNAL API
|
PathUtils |
Address ordering type class, sorts addresses by protocol, name, host and port.
|
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.
|
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.
|
PatternsCS |
Deprecated.
|
PatternsCS$ |
Deprecated.
|
PduCodecException |
INTERNAL API
|
PeekMailbox |
Deprecated.
|
PeekMailboxExtension |
Deprecated.
|
PeekMailboxExtension$ |
Deprecated.
|
PeekMailboxType |
Deprecated.
|
PerfFlamesSupport |
Runs perf-java-flames script on given node (JVM process).
|
PerGroupingBuffer |
|
PeriodicCacheCleanup |
|
Persist<Event,State> |
INTERNAL API
|
Persist$ |
|
PersistAll<Event,State> |
INTERNAL API
|
PersistAll$ |
|
Persistence |
INTERNAL API: When starting many persistent actors at the same time the journal
its data store is protected from being overloaded by limiting number
of recoveries that can be in progress at the same time.
|
Persistence.PluginHolder |
INTERNAL API.
|
Persistence.PluginHolder$ |
|
Persistence$ |
Java API.
|
PersistenceId |
Unique identifier in the backend data store (journal and snapshot store) of the
persistent actor.
|
PersistenceId$ |
|
PersistenceIdentity |
Id of the persistent entity for which messages should be replayed.
|
PersistenceIdsQuery |
Query all PersistentActor identifiers, i.e.
|
PersistenceIdsQuery |
Query all PersistentActor identifiers, i.e.
|
PersistencePlugin<ScalaDsl,JavaDsl,T> |
Check for default or missing identity.
|
PersistencePlugin.PluginHolder<ScalaDsl,JavaDsl> |
|
PersistencePlugin.PluginHolder$ |
|
PersistencePlugin$ |
INTERNAL API
|
PersistencePluginProxy |
|
PersistencePluginProxy.PluginType |
|
PersistencePluginProxy.TargetLocation |
|
PersistencePluginProxy.TargetLocation$ |
|
PersistencePluginProxy$ |
|
PersistencePluginProxyExtension |
|
PersistencePluginProxyExtension$ |
|
PersistencePluginProxyExtensionImpl |
PersistencePluginProxyExtensionImpl is an Extension that enables initialization of the PersistencePluginProxy
via configuration, without requiring any code changes or the creation of any actors.
|
PersistenceQuery |
Scala API: Returns the ReadJournal specified by the given
read journal configuration entry.
|
PersistenceQuery$ |
Java API.
|
PersistenceRecovery |
Called when the persistent actor is started for the first time.
|
PersistenceSettings |
INTERNAL API.
|
PersistenceStash |
The returned StashOverflowStrategy object determines how to handle the message failed to stash
when the internal Stash capacity exceeded.
|
PersistentActor |
Asynchronously persists event .
|
PersistentEnvelope |
INTERNAL API
|
PersistentFSM<S extends PersistentFSM.FSMState,D,E> |
Enables to pass a ClassTag of a domain event base type from the implementing class
|
PersistentFSM.$minus$greater$ |
|
PersistentFSM.CurrentState<S> |
|
PersistentFSM.CurrentState$ |
|
PersistentFSM.Event<D> |
|
PersistentFSM.Event$ |
|
PersistentFSM.Failure |
|
PersistentFSM.Failure$ |
|
PersistentFSM.FSMState |
|
PersistentFSM.LogEntry<S,D> |
Log Entry of the LoggingFSM , can be obtained by calling getLog .
|
PersistentFSM.LogEntry$ |
|
PersistentFSM.Normal$ |
|
PersistentFSM.NullFunction$ |
|
PersistentFSM.PersistentFsmEvent |
Base persistent event class
|
PersistentFSM.PersistentFSMSnapshot<D> |
|
PersistentFSM.PersistentFSMSnapshot$ |
|
PersistentFSM.Reason |
|
PersistentFSM.Shutdown$ |
|
PersistentFSM.State<S,D,E> |
|
PersistentFSM.State$ |
|
PersistentFSM.StateChangeEvent |
|
PersistentFSM.StateChangeEvent$ |
|
PersistentFSM.StateTimeout$ |
|
PersistentFSM.StopEvent<S,D> |
|
PersistentFSM.StopEvent$ |
|
PersistentFSM.SubscribeTransitionCallBack |
|
PersistentFSM.SubscribeTransitionCallBack$ |
|
PersistentFSM.TimeoutMarker |
|
PersistentFSM.TimeoutMarker$ |
|
PersistentFSM.Timer |
|
PersistentFSM.Timer$ |
|
PersistentFSM.Transition<S> |
|
PersistentFSM.Transition$ |
|
PersistentFSM.UnsubscribeTransitionCallBack |
|
PersistentFSM.UnsubscribeTransitionCallBack$ |
|
PersistentFSM$ |
Used by forMax to signal "cancel stateTimeout"
|
PersistentFSMBase<S,D,E> |
This extractor is just convenience for matching a (S, S) pair, including a
reminder what the new state is.
|
PersistentFSMBase.TransformHelper |
|
PersistentImpl |
INTERNAL API.
|
PersistentImpl$ |
|
PersistentRepr |
This persistent message's payload.
|
PersistentRepr$ |
Plugin API: value of an undefined persistenceId or manifest.
|
PersistentShard |
INTERNAL API
|
PersistentShardCoordinator |
Singleton coordinator that decides where to allocate shards.
|
PersistNothing |
INTERNAL API
|
PersistNothing$ |
INTERNAL API
|
PFBuilder<I,R> |
A builder for PartialFunction .
|
Phase<M> |
INTERNAL API
|
PhasedFusingActorMaterializer |
|
PhasedFusingActorMaterializer$ |
INTERNAL API
|
PhaseIsland<M> |
INTERNAL API
|
PhiAccrualFailureDetector |
Constructor without eventStream to support backwards compatibility
|
PinnedDispatcher |
Dedicates a unique thread for each actor passed in as reference.
|
PinnedDispatcherConfigurator |
Creates new dispatcher for each invocation.
|
PipeToSupport |
Import this implicit conversion to gain the pipeTo method on Future :
|
PipeToSupport.PipeableCompletionStage<T> |
|
PipeToSupport.PipeableFuture<T> |
|
Player |
Connect to the conductor on the given port (the host is taken from setting
akka.testconductor.host ).
|
Player.Waiter |
|
Player$ |
|
PlayerHandler |
This handler only forwards messages received from the conductor to the ClientFSM .
|
PluginProvider<T,ScalaDsl,JavaDsl> |
INTERNAL API
|
PluginSpec |
|
PNCounter |
Scala API: Current total value of the counter.
|
PNCounter$ |
Java API
|
PNCounterKey |
|
PNCounterKey$ |
Internal API
|
PNCounterMap<A> |
Scala API
|
PNCounterMap.PNCounterMapTag$ |
|
PNCounterMap$ |
INTERNAL API
|
PNCounterMapKey<A> |
|
PNCounterMapKey$ |
INTERNAL API
|
PoisonPill |
|
PoisonPill |
INTERNAL API
|
PoisonPill$ |
Java API: get the singleton instance
|
PoisonPill$ |
INTERNAL API
|
PoisonPillInterceptor<M> |
INTERNAL API
|
Pool |
Initial number of routee instances
|
Pool$ |
INTERNAL API
|
PoolBase |
Java API: Base class for custom router Pool
|
PoolOverrideUnsetConfig<T extends Pool> |
INTERNAL API
|
PoolRouter<T> |
Route messages by randomly selecting the routee from the available routees.
|
PoolRouter<T> |
Route messages by randomly selecting the routee from the available routees.
|
PoolRouterBuilder<T> |
INTERNAL API
|
PoolRouterBuilder$ |
|
PoolRouterImpl<T> |
INTERNAL API
|
Pop |
INTERNAL API
|
Pop$ |
INTERNAL API
|
PopAttributes |
INTERNAL API
|
PopAttributes$ |
INTERNAL API
|
PossiblyHarmful |
Marker trait to indicate that a message might be potentially harmful,
this is used to block messages coming in over remoting.
|
PostRestartException |
A PostRestartException is thrown when constructor or postRestart() method
fails during a restart attempt.
|
PostRestartException$ |
|
PostStop |
Lifecycle signal that is fired after this actor and all its child actors
(transitively) have terminated.
|
PostStop$ |
Lifecycle signal that is fired after this actor and all its child actors
(transitively) have terminated.
|
Predicate<T> |
Java API: Defines a criteria and determines whether the parameter meets this criteria.
|
Predicate<T> |
Java API: Defines a criteria and determines whether the parameter meets this criteria.
|
PredicateClassifier |
Can be mixed into an EventBus to specify that the Classifier type is a Function from Event to Boolean (predicate)
|
PrefixAndTail<T> |
INTERNAL API
|
PreRestart |
Lifecycle signal that is fired upon restart of the Actor before replacing
the behavior with the fresh one (i.e.
|
PreRestart$ |
|
PreRestartException |
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$ |
|
PrettyByteString |
INTERNAL API: ByteString pretty printer, based on Johanes Rudolph's implementation from:
https://github.com/jrudolph/akka/commit/c889dddf37c8635c365a79a391eb18a709f36773#diff-947cbf07996eeb823cb9850cc2e81126R19
|
PrettyByteString.asPretty |
|
PrettyByteString$ |
INTERNAL API: ByteString pretty printer, based on Johanes Rudolph's implementation from:
https://github.com/jrudolph/akka/commit/c889dddf37c8635c365a79a391eb18a709f36773#diff-947cbf07996eeb823cb9850cc2e81126R19
|
PrettyDuration |
JAVA API
Selects most appropriate TimeUnit for given duration and formats it accordingly, with 4 digits precision
|
PrettyDuration.PrettyPrintableDuration |
Selects most appropriate TimeUnit for given duration and formats it accordingly, with 4 digits precision
|
PrettyDuration.PrettyPrintableDuration$ |
|
PrettyDuration$ |
JAVA API
Selects most appropriate TimeUnit for given duration and formats it accordingly, with 4 digits precision
|
PriorityGenerator |
A PriorityGenerator is a convenience API to create a Comparator that orders the messages of a
PriorityDispatcher
|
PriorityGenerator$ |
Creates a PriorityGenerator that uses the supplied function as priority generator
|
PriorityMessage |
INTERNAL API
Messages marked with this trait will be sent before other messages when buffering is active.
|
PriorityQueueStabilizer<E> |
PriorityQueueStabilizer wraps a priority queue so that it respects FIFO for elements of equal priority.
|
PriorityQueueStabilizer.WrappedElement<E> |
|
PriorityQueueStabilizer.WrappedElementComparator<E> |
|
PriorityQueueStabilizer$ |
|
Procedure<T> |
A Procedure is like a Function, but it doesn't produce a return value.
|
Procedure<T> |
A Procedure is like a Function, but it doesn't produce a return value.
|
Procedure10<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10> |
A Consumer interface.
|
Procedure11<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11> |
A Consumer interface.
|
Procedure12<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12> |
A Consumer interface.
|
Procedure13<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13> |
A Consumer interface.
|
Procedure14<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14> |
A Consumer interface.
|
Procedure15<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15> |
A Consumer interface.
|
Procedure16<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16> |
A Consumer interface.
|
Procedure17<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17> |
A Consumer interface.
|
Procedure18<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18> |
A Consumer interface.
|
Procedure19<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19> |
A Consumer interface.
|
Procedure2<T1,T2> |
A Consumer interface.
|
Procedure20<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20> |
A Consumer interface.
|
Procedure21<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21> |
A Consumer interface.
|
Procedure22<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22> |
A Consumer interface.
|
Procedure3<T1,T2,T3> |
A Consumer interface.
|
Procedure4<T1,T2,T3,T4> |
A Consumer interface.
|
Procedure5<T1,T2,T3,T4,T5> |
A Consumer interface.
|
Procedure6<T1,T2,T3,T4,T5,T6> |
A Consumer interface.
|
Procedure7<T1,T2,T3,T4,T5,T6,T7> |
A Consumer interface.
|
Procedure8<T1,T2,T3,T4,T5,T6,T7,T8> |
A Consumer interface.
|
Procedure9<T1,T2,T3,T4,T5,T6,T7,T8,T9> |
A Consumer interface.
|
ProcessorModule<In,Out,Mat> |
INTERNAL API
|
ProcessorModule$ |
|
ProcessorModuleIslandTag |
INTERNAL API
|
ProcessorModuleIslandTag$ |
INTERNAL API
|
ProcessorModulePhase |
INTERNAL API
|
Producer |
Deprecated.
|
ProducerRegistrar |
INTERNAL API
Registers Producers.
|
ProducerSupport |
CamelMessage headers to copy by default from request message to response-message.
|
ProducesMessageQueue<T extends MessageQueue> |
|
ProducesPushTimeoutSemanticsMailbox |
INTERNAL API
Used to determine mailbox factories which create BoundedMessageQueueSemantics
mailboxes, and thus should be validated that the pushTimeOut is greater than 0.
|
PromiseActorRef |
As an optimization for the common (local) case we only register this PromiseActorRef
with the provider when the path member is actually queried, which happens during
serialization (but also during a simple call to toString , equals or hashCode !).
|
PromiseActorRef$ |
INTERNAL API
|
PromiseRef<T> |
ActorRef associated with this PromiseRef.
|
PromiseRef$ |
Wraps an ActorRef and a Promise into a PromiseRef.
|
PromiseRefImpl<T> |
Constructs a new PromiseRef which will be completed with the first message sent to it.
|
Props |
|
Props |
Reference to the tail of this Props list.
|
Props.EmptyActor |
INTERNAL API
|
Props$ |
The defaultCreator, simply throws an UnsupportedOperationException when applied, which is used when creating a Props
|
Props$ |
Empty props instance, should seldom be needed in user code but can be useful as a default props where
custom configuration of an actor is possible.
|
PropsAdapter |
INTERNAL API
|
PropsAdapter |
|
PropsAdapter$ |
INTERNAL API
|
PropsAdapter$ |
|
ProtobufDecoder |
INTERNAL API.
|
ProtobufEncoder |
INTERNAL API.
|
ProtobufSerializer |
Using the serialization-bindings as source for the whitelist.
|
ProtobufSerializer$ |
Helper to serialize an ActorRef to Akka's
protobuf representation.
|
Protocol |
INTERNAL API.
|
Protocol.Message |
|
Protocol$ |
INTERNAL API.
|
ProtocolStateActor |
|
ProtocolStateActor.AssociatedWaitHandler |
|
ProtocolStateActor.AssociatedWaitHandler$ |
|
ProtocolStateActor.AssociationState |
|
ProtocolStateActor.Closed$ |
|
ProtocolStateActor.ForbiddenUidReason$ |
|
ProtocolStateActor.Handle |
|
ProtocolStateActor.Handle$ |
|
ProtocolStateActor.HandleListenerRegistered |
|
ProtocolStateActor.HandleListenerRegistered$ |
|
ProtocolStateActor.HandshakeTimer$ |
|
ProtocolStateActor.HeartbeatTimer$ |
|
ProtocolStateActor.InboundUnassociated |
|
ProtocolStateActor.InboundUnassociated$ |
|
ProtocolStateActor.InitialProtocolStateData |
|
ProtocolStateActor.ListenerReady |
|
ProtocolStateActor.ListenerReady$ |
|
ProtocolStateActor.Open$ |
|
ProtocolStateActor.OutboundUnassociated |
|
ProtocolStateActor.OutboundUnassociated$ |
|
ProtocolStateActor.OutboundUnderlyingAssociated |
|
ProtocolStateActor.OutboundUnderlyingAssociated$ |
|
ProtocolStateActor.ProtocolStateData |
|
ProtocolStateActor.TimeoutReason |
|
ProtocolStateActor.TimeoutReason$ |
|
ProtocolStateActor.WaitHandshake$ |
|
ProtocolStateActor$ |
|
ProviderSelection |
|
ProviderSelection.Cluster$ |
|
ProviderSelection.Local$ |
|
ProviderSelection.Remote$ |
|
ProviderSelection$ |
|
PruningState |
INTERNAL API
|
PruningState.PruningInitialized |
|
PruningState.PruningInitialized$ |
|
PruningState.PruningPerformed |
|
PruningState.PruningPerformed$ |
|
PruningState$ |
INTERNAL API
|
PublisherSink<In> |
INTERNAL API
Holds the downstream-most Publisher interface of the materialized flow.
|
PublisherSource<Out> |
INTERNAL API
Construct a transformation starting with given publisher.
|
Pump |
INTERNAL API
|
PushAttributes |
INTERNAL API
|
PushAttributes$ |
|
PushNotUsed |
INTERNAL API
|
PushNotUsed$ |
INTERNAL API
|
Quarantined |
INTERNAL API
|
Quarantined$ |
|
QuarantinedEvent |
|
QuarantinedEvent$ |
|
Question |
INTERNAL API
|
Question$ |
INTERNAL API
|
QueueBasedMessageQueue |
A QueueBasedMessageQueue is a MessageQueue backed by a java.util.Queue.
|
QueueOfferResult |
|
QueueOfferResult.Dropped$ |
Type is used to indicate that stream is dropped an element
|
QueueOfferResult.Enqueued$ |
|
QueueOfferResult.Failure |
Type is used to indicate that stream is failed before or during call to the stream
param: cause - exception that stream failed with
|
QueueOfferResult.Failure$ |
|
QueueOfferResult.QueueClosed$ |
|
QueueOfferResult$ |
Type is used to indicate that stream is successfully enqueued an element
|
QueueSelector |
Must be deterministic—return the same value for the same input.
|
QueueSelectorFactory |
|
QueueSink<T> |
INTERNAL API
|
QueueSink.Cancel$ |
|
QueueSink.Output<T> |
|
QueueSink.Pull<T> |
|
QueueSink.Pull$ |
|
QueueSink$ |
INTERNAL API
|
QueueSource<T> |
INTERNAL API
|
QueueSource.Completion$ |
|
QueueSource.Failure |
|
QueueSource.Failure$ |
|
QueueSource.Input<T> |
|
QueueSource.Offer<T> |
|
QueueSource.Offer$ |
|
QueueSource$ |
INTERNAL API
|
RandomGroup |
Java API
param: routeePaths string representation of the actor paths of the routees, messages are
sent with ActorSelection to these paths
|
RandomGroup$ |
|
RandomPool |
Java API
param: nr initial number of routees in the pool
|
RandomPool$ |
|
RandomRoutingLogic |
Randomly selects one of the target routees to send a message to
|
RandomRoutingLogic$ |
|
RARP |
INTERNAL API
|
RARP$ |
INTERNAL API
|
RateExceededException |
Exception that is thrown when rated controlled by stream is exceeded
|
Reachability |
|
Reachability.ReachabilityStatus |
|
Reachability.Reachable$ |
|
Reachability.Record |
|
Reachability.Record$ |
|
Reachability.Terminated$ |
|
Reachability.Unreachable$ |
|
Reachability$ |
INTERNAL API
|
ReactiveStreamsCompliance |
INTERNAL API
|
ReactiveStreamsCompliance.SignalThrewException |
|
ReactiveStreamsCompliance.SpecViolation |
|
ReactiveStreamsCompliance$ |
INTERNAL API
|
ReadAggregator |
INTERNAL API
|
ReadAggregator$ |
INTERNAL API
|
ReadEventAdapter |
Convert a event from its journal model to the applications domain model.
|
ReadJournal |
API for reading persistent events and information derived
from stored persistent events.
|
ReadJournal |
API for reading persistent events and information derived
from stored persistent events.
|
ReadJournalProvider |
The ReadJournal implementation for the Scala API.
|
ReadWriteAggregator |
INTERNAL API
|
ReadWriteAggregator.SendToSecondary$ |
|
ReadWriteAggregator$ |
INTERNAL API
|
Receive<T> |
Process an incoming message and return the next behavior.
|
ReceiveBuilder<T> |
Add a new case to the message handling.
|
ReceiveBuilder |
|
ReceiveBuilder.Case<BT,MT> |
INTERNAL API
|
ReceiveBuilder.Case$ |
|
ReceiveBuilder$ |
Create a new mutable receive builder
|
ReceivePipeline |
Deprecated.
|
ReceivePipeline.Delegation |
|
ReceivePipeline.HandledCompletely$ |
|
ReceivePipeline.HandlerResult |
|
ReceivePipeline.Inner |
|
ReceivePipeline.Inner$ |
|
ReceivePipeline.InnerAndAfter |
|
ReceivePipeline.InnerAndAfter$ |
|
ReceivePipeline$ |
Deprecated.
|
ReceiveTimeout |
|
ReceiveTimeout |
|
ReceiveTimeout$ |
|
ReceiveTimeout$ |
Java API: get the singleton instance
|
Receptionist |
This class is not intended for user extension other than for test purposes (e.g.
|
Receptionist.Command |
The set of commands accepted by a Receptionist.
|
Receptionist.Find$ |
Scala API:
|
Receptionist.Listing |
Scala API
|
Receptionist.Listing$ |
|
Receptionist.Register$ |
|
Receptionist.Registered |
Scala API
|
Receptionist.Registered$ |
|
Receptionist.Subscribe$ |
Scala API:
|
Receptionist$ |
The set of commands accepted by a Receptionist.
|
ReceptionistBehaviorProvider |
Marker interface to use with dynamic access
|
ReceptionistImpl |
INTERNAL API
|
ReceptionistMessages |
Internal API
|
ReceptionistMessages.Find<T> |
|
ReceptionistMessages.Find$ |
|
ReceptionistMessages.Listing<T> |
|
ReceptionistMessages.Listing$ |
|
ReceptionistMessages.Register<T> |
|
ReceptionistMessages.Register$ |
|
ReceptionistMessages.Registered<T> |
|
ReceptionistMessages.Registered$ |
|
ReceptionistMessages.Subscribe<T> |
|
ReceptionistMessages.Subscribe$ |
|
ReceptionistMessages$ |
Internal API
|
ReceptionistSetup |
|
ReceptionistSetup$ |
Java API: Sent by the receptionist, available here for easier testing
|
RecipientRef<T> |
Send a message to the destination referenced by this RecipientRef using *at-most-once*
messaging semantics.
|
RecipientRef.RecipientRefOps<T> |
|
RecipientRef.RecipientRefOps$ |
|
RecipientRef$ |
Send a message to the destination referenced by this RecipientRef using *at-most-once*
messaging semantics.
|
RecordClass |
|
RecordClass$ |
|
RecordClassSerializer |
INTERNAL API
|
RecordClassSerializer$ |
INTERNAL API
|
RecordType |
DNS Record Type
|
RecordType$ |
array for fast lookups by id
wasteful, but we get trivial indexing into it for lookup
|
RecordTypeSerializer |
INTERNAL API
|
RecordTypeSerializer$ |
INTERNAL API
|
Recover<T> |
This method will be invoked once when/if the Future this recover callback is registered on
becomes completed with a failure.
|
Recover<T> |
INTERNAL API
|
Recover$ |
|
RecoverWith<T,M> |
|
RecoverWith$ |
INTERNAL API
|
Recovery |
|
Recovery$ |
Java API
|
RecoveryCompleted |
|
RecoveryCompleted |
|
RecoveryCompleted$ |
Java API: get the singleton instance
|
RecoveryCompleted$ |
|
RecoveryFailed |
Java API
|
RecoveryFailed$ |
|
RecoveryPermitter |
INTERNAL API: When starting many persistent actors at the same time the journal
its data store is protected from being overloaded by limiting number
of recoveries that can be in progress at the same time.
|
RecoveryPermitter.Protocol |
|
RecoveryPermitter.RecoveryPermitGranted$ |
|
RecoveryPermitter.Reply |
|
RecoveryPermitter.Request |
|
RecoveryPermitter.RequestRecoveryPermit$ |
|
RecoveryPermitter.ReturnRecoveryPermit$ |
|
RecoveryPermitter$ |
INTERNAL API
|
RecoveryTimedOut |
|
Recreate |
INTERNAL API
|
Recreate$ |
|
RecursiveAction |
|
RecursiveTask<V> |
|
Reduce<T> |
INTERNAL API
|
ReducerState<T,R> |
INTERNAL API
|
ReentrantGuard |
|
Reflect |
This optionally holds a function which looks N levels above itself
on the call stack and returns the Class[_] object for the code
executing in that stack frame.
|
Reflect$ |
This optionally holds a function which looks N levels above itself
on the call stack and returns the Class[_] object for the code
executing in that stack frame.
|
ReflectiveDynamicAccess |
|
Registry |
INTERNAL API
Registry for Camel Consumers and Producers.
|
RejectAdditionalSubscribers |
INTERNAL API
|
RejectAdditionalSubscribers$ |
INTERNAL API
|
RejectionHandler |
|
RejectionHandlerFactory |
|
RelativeActorPath |
Extractor for so-called “relative actor paths” as in “relative URI”, not in
“relative to some actor”.
|
RelativeActorPath$ |
Extractor for so-called “relative actor paths” as in “relative URI”, not in
“relative to some actor”.
|
ReliableDeliverySupervisor |
INTERNAL API
|
ReliableDeliverySupervisor.AttemptSysMsgRedelivery$ |
|
ReliableDeliverySupervisor.GotUid |
|
ReliableDeliverySupervisor.GotUid$ |
|
ReliableDeliverySupervisor.Idle$ |
|
ReliableDeliverySupervisor.IsIdle$ |
|
ReliableDeliverySupervisor.TooLongIdle$ |
|
ReliableDeliverySupervisor.Ungate$ |
|
ReliableDeliverySupervisor$ |
INTERNAL API
|
ReliableProxy |
Deprecated.
|
ReliableProxy.Active$ |
|
ReliableProxy.Connecting$ |
|
ReliableProxy.Idle$ |
|
ReliableProxy.Message |
|
ReliableProxy.Message$ |
|
ReliableProxy.ProxyTerminated |
|
ReliableProxy.ProxyTerminated$ |
|
ReliableProxy.Receiver |
|
ReliableProxy.State |
|
ReliableProxy.TargetChanged |
|
ReliableProxy.TargetChanged$ |
|
ReliableProxy.Unsent |
|
ReliableProxy.Unsent$ |
|
ReliableProxy$ |
Deprecated.
|
ReliableProxyDebugLogging |
INTERNAL API
|
RememberEntityStarter |
INTERNAL API: Actor responsible for starting entities when rememberEntities is enabled
|
RememberEntityStarter$ |
Will call onLeaseAcquired when completed, also when lease isn't used
|
RememberingShard |
INTERNAL API: Common things for PersistentShard and DDataShard
|
RemoteActorRef |
Determine if a watch/unwatch message must be handled by the remoteWatcher actor, or sent to this remote ref
|
RemoteActorRefProvider |
Factory method to make it possible to override deployer in subclass
Creates a new instance every time
|
RemoteActorRefProvider.Finished$ |
|
RemoteActorRefProvider.Idle$ |
|
RemoteActorRefProvider.TerminatorState |
|
RemoteActorRefProvider.Uninitialized$ |
|
RemoteActorRefProvider.WaitDaemonShutdown$ |
|
RemoteActorRefProvider.WaitTransportShutdown$ |
|
RemoteActorRefProvider$ |
INTERNAL API
|
RemoteConnection |
INTERNAL API.
|
RemoteConnection$ |
INTERNAL API.
|
RemoteDeployer |
INTERNAL API
|
RemoteDeploymentWatcher |
INTERNAL API
|
RemoteDeploymentWatcher.WatchRemote |
|
RemoteDeploymentWatcher.WatchRemote$ |
|
RemoteDeploymentWatcher$ |
INTERNAL API
|
RemoteInstrument |
Instrument identifier.
|
RemoteInstruments |
INTERNAL API
|
RemoteInstruments$ |
INTERNAL API
|
RemoteMetrics |
Logging of the size of different message types.
|
RemoteMetricsExtension |
INTERNAL API
Extension that keeps track of remote metrics, such
as max size of different message types.
|
RemoteMetricsExtension$ |
INTERNAL API
Extension that keeps track of remote metrics, such
as max size of different message types.
|
RemoteMetricsOff |
INTERNAL API
|
RemoteMetricsOn |
INTERNAL API
|
RemoteRef |
Marks a remote system as out of sync and prevents reconnects until the quarantine timeout elapses.
|
RemoteRouterConfig |
RouterConfig implementation for remote deployment on defined
target nodes.
|
RemoteRouterConfig$ |
|
RemoteScope |
|
RemoteScope$ |
|
RemoteSettings |
|
RemoteStreamRefActorTerminatedException |
|
RemoteStreamRefActorTerminatedException$ |
|
RemoteSystemDaemon |
Find the longest matching path which we know about and return that ref
(or ask that ref to continue searching if elements are left).
|
RemoteTransport |
Shuts down the remoting
|
RemoteTransportException |
RemoteTransportException represents a general failure within a RemoteTransport,
such as inability to start, wrong configuration etc.
|
RemoteTransportExceptionNoStackTrace |
|
RemoteWatcher |
To ensure that we receive heartbeat messages from the right actor system
incarnation we send Watch again for the first HeartbeatRsp (containing
the system UID) and if HeartbeatRsp contains a new system UID.
|
RemoteWatcher.ArteryHeartbeat$ |
|
RemoteWatcher.ArteryHeartbeatRsp |
|
RemoteWatcher.ArteryHeartbeatRsp$ |
|
RemoteWatcher.ExpectedFirstHeartbeat |
|
RemoteWatcher.ExpectedFirstHeartbeat$ |
|
RemoteWatcher.Heartbeat$ |
|
RemoteWatcher.HeartbeatRsp |
|
RemoteWatcher.HeartbeatRsp$ |
|
RemoteWatcher.HeartbeatTick$ |
|
RemoteWatcher.ReapUnreachableTick$ |
|
RemoteWatcher.Stats |
|
RemoteWatcher.Stats$ |
|
RemoteWatcher.UnwatchRemote |
|
RemoteWatcher.UnwatchRemote$ |
|
RemoteWatcher.WatchRemote |
|
RemoteWatcher.WatchRemote$ |
|
RemoteWatcher$ |
Factory method for RemoteWatcher Props .
|
Remoting |
INTERNAL API
|
Remoting.RegisterTransportActor |
|
Remoting.RegisterTransportActor$ |
|
Remoting.TransportSupervisor |
|
Remoting$ |
INTERNAL API
|
RemotingErrorEvent |
|
RemotingErrorEvent$ |
|
RemotingLifecycleEvent |
|
RemotingListenEvent |
|
RemotingListenEvent$ |
|
RemotingShutdownEvent |
|
RemotingShutdownEvent$ |
|
Remove |
|
Remove$ |
|
RemovedNodePruning |
The nodes that have changed the state for this data
and would need pruning when such node is no longer part
of the cluster.
|
RemoveInternalClusterShardingData |
|
RemoveInternalClusterShardingData.RemoveOnePersistenceId |
|
RemoveInternalClusterShardingData.RemoveOnePersistenceId$ |
INTERNAL API
|
RemoveInternalClusterShardingData.RemoveOnePersistenceId$.Removals |
|
RemoveInternalClusterShardingData.RemoveOnePersistenceId$.Removals$ |
|
RemoveInternalClusterShardingData.RemoveOnePersistenceId$.Result |
|
RemoveInternalClusterShardingData.RemoveOnePersistenceId$.Result$ |
|
RemoveInternalClusterShardingData$ |
|
RemoveRoutee |
Remove a specific routee by sending this message to the router.
|
RemoveRoutee$ |
|
ReplayFilter |
INTERNAL API
|
ReplayFilter.Disabled$ |
|
ReplayFilter.Fail$ |
|
ReplayFilter.Mode |
|
ReplayFilter.RepairByDiscardOld$ |
|
ReplayFilter.Warn$ |
|
ReplayFilter$ |
INTERNAL API
|
ReplayingEvents<C,E,S> |
Called whenever a message replay fails.
|
ReplayingEvents.ReplayingState<State> |
|
ReplayingEvents.ReplayingState$ |
|
ReplayingEvents$ |
INTERNAL API
|
ReplayingSnapshot<C,E,S> |
Called whenever a message replay fails.
|
ReplayingSnapshot$ |
INTERNAL API
|
ReplayMediator |
|
ReplicatedData |
The type of the concrete implementation, e.g.
|
ReplicatedDataMessages |
|
ReplicatedDataMessages.Flag |
Protobuf type akka.cluster.ddata.Flag
|
ReplicatedDataMessages.Flag.Builder |
Protobuf type akka.cluster.ddata.Flag
|
ReplicatedDataMessages.FlagOrBuilder |
|
ReplicatedDataMessages.GCounter |
Protobuf type akka.cluster.ddata.GCounter
|
ReplicatedDataMessages.GCounter.Builder |
Protobuf type akka.cluster.ddata.GCounter
|
ReplicatedDataMessages.GCounter.Entry |
Protobuf type akka.cluster.ddata.GCounter.Entry
|
ReplicatedDataMessages.GCounter.Entry.Builder |
Protobuf type akka.cluster.ddata.GCounter.Entry
|
ReplicatedDataMessages.GCounter.EntryOrBuilder |
|
ReplicatedDataMessages.GCounterOrBuilder |
|
ReplicatedDataMessages.GSet |
Protobuf type akka.cluster.ddata.GSet
|
ReplicatedDataMessages.GSet.Builder |
Protobuf type akka.cluster.ddata.GSet
|
ReplicatedDataMessages.GSetOrBuilder |
|
ReplicatedDataMessages.LWWMap |
Protobuf type akka.cluster.ddata.LWWMap
|
ReplicatedDataMessages.LWWMap.Builder |
Protobuf type akka.cluster.ddata.LWWMap
|
ReplicatedDataMessages.LWWMap.Entry |
Protobuf type akka.cluster.ddata.LWWMap.Entry
|
ReplicatedDataMessages.LWWMap.Entry.Builder |
Protobuf type akka.cluster.ddata.LWWMap.Entry
|
ReplicatedDataMessages.LWWMap.EntryOrBuilder |
|
ReplicatedDataMessages.LWWMapOrBuilder |
|
ReplicatedDataMessages.LWWRegister |
Protobuf type akka.cluster.ddata.LWWRegister
|
ReplicatedDataMessages.LWWRegister.Builder |
Protobuf type akka.cluster.ddata.LWWRegister
|
ReplicatedDataMessages.LWWRegisterOrBuilder |
|
ReplicatedDataMessages.ORMap |
Protobuf type akka.cluster.ddata.ORMap
|
ReplicatedDataMessages.ORMap.Builder |
Protobuf type akka.cluster.ddata.ORMap
|
ReplicatedDataMessages.ORMap.Entry |
Protobuf type akka.cluster.ddata.ORMap.Entry
|
ReplicatedDataMessages.ORMap.Entry.Builder |
Protobuf type akka.cluster.ddata.ORMap.Entry
|
ReplicatedDataMessages.ORMap.EntryOrBuilder |
|
ReplicatedDataMessages.ORMapDeltaGroup |
Protobuf type akka.cluster.ddata.ORMapDeltaGroup
|
ReplicatedDataMessages.ORMapDeltaGroup.Builder |
Protobuf type akka.cluster.ddata.ORMapDeltaGroup
|
ReplicatedDataMessages.ORMapDeltaGroup.Entry |
Protobuf type akka.cluster.ddata.ORMapDeltaGroup.Entry
|
ReplicatedDataMessages.ORMapDeltaGroup.Entry.Builder |
Protobuf type akka.cluster.ddata.ORMapDeltaGroup.Entry
|
ReplicatedDataMessages.ORMapDeltaGroup.EntryOrBuilder |
|
ReplicatedDataMessages.ORMapDeltaGroup.MapEntry |
Protobuf type akka.cluster.ddata.ORMapDeltaGroup.MapEntry
|
ReplicatedDataMessages.ORMapDeltaGroup.MapEntry.Builder |
Protobuf type akka.cluster.ddata.ORMapDeltaGroup.MapEntry
|
ReplicatedDataMessages.ORMapDeltaGroup.MapEntryOrBuilder |
|
ReplicatedDataMessages.ORMapDeltaGroupOrBuilder |
|
ReplicatedDataMessages.ORMapDeltaOp |
Protobuf enum akka.cluster.ddata.ORMapDeltaOp
|
ReplicatedDataMessages.ORMapOrBuilder |
|
ReplicatedDataMessages.ORMultiMap |
Protobuf type akka.cluster.ddata.ORMultiMap
|
ReplicatedDataMessages.ORMultiMap.Builder |
Protobuf type akka.cluster.ddata.ORMultiMap
|
ReplicatedDataMessages.ORMultiMap.Entry |
Protobuf type akka.cluster.ddata.ORMultiMap.Entry
|
ReplicatedDataMessages.ORMultiMap.Entry.Builder |
Protobuf type akka.cluster.ddata.ORMultiMap.Entry
|
ReplicatedDataMessages.ORMultiMap.EntryOrBuilder |
|
ReplicatedDataMessages.ORMultiMapOrBuilder |
|
ReplicatedDataMessages.ORSet |
Protobuf type akka.cluster.ddata.ORSet
|
ReplicatedDataMessages.ORSet.Builder |
Protobuf type akka.cluster.ddata.ORSet
|
ReplicatedDataMessages.ORSetDeltaGroup |
Protobuf type akka.cluster.ddata.ORSetDeltaGroup
|
ReplicatedDataMessages.ORSetDeltaGroup.Builder |
Protobuf type akka.cluster.ddata.ORSetDeltaGroup
|
ReplicatedDataMessages.ORSetDeltaGroup.Entry |
Protobuf type akka.cluster.ddata.ORSetDeltaGroup.Entry
|
ReplicatedDataMessages.ORSetDeltaGroup.Entry.Builder |
Protobuf type akka.cluster.ddata.ORSetDeltaGroup.Entry
|
ReplicatedDataMessages.ORSetDeltaGroup.EntryOrBuilder |
|
ReplicatedDataMessages.ORSetDeltaGroupOrBuilder |
|
ReplicatedDataMessages.ORSetDeltaOp |
Protobuf enum akka.cluster.ddata.ORSetDeltaOp
|
ReplicatedDataMessages.ORSetOrBuilder |
|
ReplicatedDataMessages.PNCounter |
Protobuf type akka.cluster.ddata.PNCounter
|
ReplicatedDataMessages.PNCounter.Builder |
Protobuf type akka.cluster.ddata.PNCounter
|
ReplicatedDataMessages.PNCounterMap |
Protobuf type akka.cluster.ddata.PNCounterMap
|
ReplicatedDataMessages.PNCounterMap.Builder |
Protobuf type akka.cluster.ddata.PNCounterMap
|
ReplicatedDataMessages.PNCounterMap.Entry |
Protobuf type akka.cluster.ddata.PNCounterMap.Entry
|
ReplicatedDataMessages.PNCounterMap.Entry.Builder |
Protobuf type akka.cluster.ddata.PNCounterMap.Entry
|
ReplicatedDataMessages.PNCounterMap.EntryOrBuilder |
|
ReplicatedDataMessages.PNCounterMapOrBuilder |
|
ReplicatedDataMessages.PNCounterOrBuilder |
|
ReplicatedDataSerialization |
|
ReplicatedDataSerializer |
Protobuf serializer of ReplicatedData.
|
ReplicatedDataSerializer.KeyComparator<A extends akka.protobuf.GeneratedMessage> |
|
ReplicatedDataSerializer.LWWMapEntry$ |
|
ReplicatedDataSerializer.LWWMapEntryComparator$ |
|
ReplicatedDataSerializer.ORMapDeltaGroupEntry$ |
|
ReplicatedDataSerializer.ORMapEntry$ |
|
ReplicatedDataSerializer.ORMapEntryComparator$ |
|
ReplicatedDataSerializer.ORMultiMapEntry$ |
|
ReplicatedDataSerializer.ORMultiMapEntryComparator$ |
|
ReplicatedDataSerializer.PNCounterMapEntry$ |
|
ReplicatedDataSerializer.PNCounterMapEntryComparator$ |
|
ReplicatedDataSerializer.ProtoMapEntryReader<Entry extends akka.protobuf.GeneratedMessage,A extends akka.protobuf.GeneratedMessage> |
|
ReplicatedDataSerializer.ProtoMapEntryWriter<Entry extends akka.protobuf.GeneratedMessage,EntryBuilder extends akka.protobuf.GeneratedMessage.Builder<EntryBuilder>,Value extends akka.protobuf.GeneratedMessage> |
|
ReplicatedDataSerializer$ |
Get the key from the entry.
|
ReplicatedDelta |
The empty full state.
|
ReplicatedDeltaSize |
Some complex deltas grow in size for each update and above a configured
threshold such deltas are discarded and sent as full state instead.
|
Replicator |
A replicated in-memory data store supporting low latency and high availability
requirements.
|
Replicator |
The Behavior for the Replicator actor.
|
Replicator |
The Behavior for the Replicator actor.
|
Replicator.Changed<A extends ReplicatedData> |
|
Replicator.Changed<A extends ReplicatedData> |
|
Replicator.Changed$ |
|
Replicator.Changed$ |
|
Replicator.Changed$ |
|
Replicator.Command<A extends ReplicatedData> |
|
Replicator.Command |
|
Replicator.Command |
|
Replicator.DataDeleted<A extends ReplicatedData> |
|
Replicator.DataDeleted<A extends ReplicatedData> |
|
Replicator.DataDeleted$ |
|
Replicator.DataDeleted$ |
|
Replicator.Delete<A extends ReplicatedData> |
|
Replicator.Delete<A extends ReplicatedData> |
|
Replicator.Delete<A extends ReplicatedData> |
|
Replicator.Delete$ |
|
Replicator.Delete$ |
|
Replicator.Delete$ |
Convenience for ask .
|
Replicator.Deleted<A extends ReplicatedData> |
|
Replicator.Deleted$ |
|
Replicator.DeleteResponse<A extends ReplicatedData> |
|
Replicator.DeleteResponse<A extends ReplicatedData> |
|
Replicator.DeleteSuccess<A extends ReplicatedData> |
|
Replicator.DeleteSuccess<A extends ReplicatedData> |
|
Replicator.DeleteSuccess$ |
|
Replicator.DeleteSuccess$ |
|
Replicator.FlushChanges$ |
|
Replicator.FlushChanges$ |
|
Replicator.FlushChanges$ |
Notify subscribers of changes now, otherwise they will be notified periodically
with the configured notify-subscribers-interval .
|
Replicator.Get<A extends ReplicatedData> |
|
Replicator.Get<A extends ReplicatedData> |
Send this message to the local Replicator to retrieve a data value for the
given key .
|
Replicator.Get<A extends ReplicatedData> |
|
Replicator.Get$ |
|
Replicator.Get$ |
|
Replicator.Get$ |
|
Replicator.GetFailure<A extends ReplicatedData> |
|
Replicator.GetFailure<A extends ReplicatedData> |
|
Replicator.GetFailure$ |
|
Replicator.GetFailure$ |
|
Replicator.GetKeyIds$ |
INTERNAL API
|
Replicator.GetKeyIdsResult |
|
Replicator.GetKeyIdsResult$ |
|
Replicator.GetReplicaCount |
|
Replicator.GetReplicaCount |
|
Replicator.GetReplicaCount$ |
|
Replicator.GetReplicaCount$ |
|
Replicator.GetReplicaCount$ |
Convenience for ask .
|
Replicator.GetResponse<A extends ReplicatedData> |
|
Replicator.GetResponse<A extends ReplicatedData> |
|
Replicator.GetSuccess<A extends ReplicatedData> |
|
Replicator.GetSuccess<A extends ReplicatedData> |
|
Replicator.GetSuccess$ |
|
Replicator.GetSuccess$ |
|
Replicator.GetSuccess$ |
|
Replicator.Internal$ |
|
Replicator.Internal$.DestinationSystemUid |
|
Replicator.Internal$.SendingSystemUid |
|
Replicator.ModifyFailure<A extends ReplicatedData> |
|
Replicator.ModifyFailure<A extends ReplicatedData> |
|
Replicator.ModifyFailure$ |
|
Replicator.ModifyFailure$ |
|
Replicator.NotFound<A extends ReplicatedData> |
|
Replicator.NotFound<A extends ReplicatedData> |
|
Replicator.NotFound$ |
|
Replicator.NotFound$ |
|
Replicator.ReadAll |
|
Replicator.ReadAll |
|
Replicator.ReadAll$ |
|
Replicator.ReadAll$ |
|
Replicator.ReadConsistency |
|
Replicator.ReadConsistency |
|
Replicator.ReadFrom |
|
Replicator.ReadFrom |
|
Replicator.ReadFrom$ |
|
Replicator.ReadFrom$ |
|
Replicator.ReadLocal$ |
|
Replicator.ReadLocal$ |
|
Replicator.ReadMajority |
|
Replicator.ReadMajority |
|
Replicator.ReadMajority$ |
|
Replicator.ReadMajority$ |
|
Replicator.ReplicaCount |
Current number of replicas.
|
Replicator.ReplicaCount |
|
Replicator.ReplicaCount$ |
|
Replicator.ReplicaCount$ |
|
Replicator.ReplicationDeleteFailure<A extends ReplicatedData> |
|
Replicator.ReplicationDeleteFailure<A extends ReplicatedData> |
|
Replicator.ReplicationDeleteFailure$ |
|
Replicator.ReplicationDeleteFailure$ |
|
Replicator.ReplicatorMessage |
|
Replicator.StoreFailure<A extends ReplicatedData> |
|
Replicator.StoreFailure<A extends ReplicatedData> |
|
Replicator.StoreFailure$ |
|
Replicator.StoreFailure$ |
|
Replicator.Subscribe<A extends ReplicatedData> |
|
Replicator.Subscribe<A extends ReplicatedData> |
|
Replicator.Subscribe<A extends ReplicatedData> |
Register a subscriber that will be notified with a Changed message
when the value of the given key is changed.
|
Replicator.Subscribe$ |
|
Replicator.Subscribe$ |
|
Replicator.Subscribe$ |
|
Replicator.Unsubscribe<A extends ReplicatedData> |
|
Replicator.Unsubscribe<A extends ReplicatedData> |
|
Replicator.Unsubscribe<A extends ReplicatedData> |
|
Replicator.Unsubscribe$ |
|
Replicator.Unsubscribe$ |
|
Replicator.Unsubscribe$ |
|
Replicator.Update<A extends ReplicatedData> |
|
Replicator.Update<A extends ReplicatedData> |
|
Replicator.Update<A extends ReplicatedData> |
|
Replicator.Update$ |
|
Replicator.Update$ |
|
Replicator.Update$ |
Modify value of local Replicator and replicate with given writeConsistency .
|
Replicator.UpdateFailure<A extends ReplicatedData> |
|
Replicator.UpdateFailure<A extends ReplicatedData> |
|
Replicator.UpdateResponse<A extends ReplicatedData> |
|
Replicator.UpdateResponse<A extends ReplicatedData> |
|
Replicator.UpdateSuccess<A extends ReplicatedData> |
|
Replicator.UpdateSuccess<A extends ReplicatedData> |
|
Replicator.UpdateSuccess$ |
|
Replicator.UpdateSuccess$ |
|
Replicator.UpdateTimeout<A extends ReplicatedData> |
|
Replicator.UpdateTimeout<A extends ReplicatedData> |
|
Replicator.UpdateTimeout$ |
|
Replicator.UpdateTimeout$ |
|
Replicator.WriteAll |
|
Replicator.WriteAll |
|
Replicator.WriteAll$ |
|
Replicator.WriteAll$ |
|
Replicator.WriteConsistency |
|
Replicator.WriteConsistency |
|
Replicator.WriteLocal$ |
|
Replicator.WriteLocal$ |
|
Replicator.WriteMajority |
|
Replicator.WriteMajority |
|
Replicator.WriteMajority$ |
|
Replicator.WriteMajority$ |
|
Replicator.WriteTo |
|
Replicator.WriteTo |
|
Replicator.WriteTo$ |
|
Replicator.WriteTo$ |
|
Replicator$ |
|
Replicator$ |
The Behavior for the Replicator actor.
|
Replicator$ |
The Behavior for the Replicator actor.
|
ReplicatorBehavior |
INTERNAL API
|
ReplicatorBehavior$ |
INTERNAL API
|
ReplicatorMessages |
|
ReplicatorMessages.Address |
Protobuf type akka.cluster.ddata.Address
|
ReplicatorMessages.Address.Builder |
Protobuf type akka.cluster.ddata.Address
|
ReplicatorMessages.AddressOrBuilder |
|
ReplicatorMessages.Changed |
Protobuf type akka.cluster.ddata.Changed
|
ReplicatorMessages.Changed.Builder |
Protobuf type akka.cluster.ddata.Changed
|
ReplicatorMessages.ChangedOrBuilder |
|
ReplicatorMessages.DataEnvelope |
Protobuf type akka.cluster.ddata.DataEnvelope
|
ReplicatorMessages.DataEnvelope.Builder |
Protobuf type akka.cluster.ddata.DataEnvelope
|
ReplicatorMessages.DataEnvelope.PruningEntry |
Protobuf type akka.cluster.ddata.DataEnvelope.PruningEntry
|
ReplicatorMessages.DataEnvelope.PruningEntry.Builder |
Protobuf type akka.cluster.ddata.DataEnvelope.PruningEntry
|
ReplicatorMessages.DataEnvelope.PruningEntryOrBuilder |
|
ReplicatorMessages.DataEnvelopeOrBuilder |
|
ReplicatorMessages.DeltaPropagation |
Protobuf type akka.cluster.ddata.DeltaPropagation
|
ReplicatorMessages.DeltaPropagation.Builder |
Protobuf type akka.cluster.ddata.DeltaPropagation
|
ReplicatorMessages.DeltaPropagation.Entry |
Protobuf type akka.cluster.ddata.DeltaPropagation.Entry
|
ReplicatorMessages.DeltaPropagation.Entry.Builder |
Protobuf type akka.cluster.ddata.DeltaPropagation.Entry
|
ReplicatorMessages.DeltaPropagation.EntryOrBuilder |
|
ReplicatorMessages.DeltaPropagationOrBuilder |
|
ReplicatorMessages.DurableDataEnvelope |
Protobuf type akka.cluster.ddata.DurableDataEnvelope
|
ReplicatorMessages.DurableDataEnvelope.Builder |
Protobuf type akka.cluster.ddata.DurableDataEnvelope
|
ReplicatorMessages.DurableDataEnvelopeOrBuilder |
|
ReplicatorMessages.Empty |
Protobuf type akka.cluster.ddata.Empty
|
ReplicatorMessages.Empty.Builder |
Protobuf type akka.cluster.ddata.Empty
|
ReplicatorMessages.EmptyOrBuilder |
|
ReplicatorMessages.Get |
Protobuf type akka.cluster.ddata.Get
|
ReplicatorMessages.Get.Builder |
Protobuf type akka.cluster.ddata.Get
|
ReplicatorMessages.GetFailure |
Protobuf type akka.cluster.ddata.GetFailure
|
ReplicatorMessages.GetFailure.Builder |
Protobuf type akka.cluster.ddata.GetFailure
|
ReplicatorMessages.GetFailureOrBuilder |
|
ReplicatorMessages.GetOrBuilder |
|
ReplicatorMessages.GetSuccess |
Protobuf type akka.cluster.ddata.GetSuccess
|
ReplicatorMessages.GetSuccess.Builder |
Protobuf type akka.cluster.ddata.GetSuccess
|
ReplicatorMessages.GetSuccessOrBuilder |
|
ReplicatorMessages.Gossip |
Protobuf type akka.cluster.ddata.Gossip
|
ReplicatorMessages.Gossip.Builder |
Protobuf type akka.cluster.ddata.Gossip
|
ReplicatorMessages.Gossip.Entry |
Protobuf type akka.cluster.ddata.Gossip.Entry
|
ReplicatorMessages.Gossip.Entry.Builder |
Protobuf type akka.cluster.ddata.Gossip.Entry
|
ReplicatorMessages.Gossip.EntryOrBuilder |
|
ReplicatorMessages.GossipOrBuilder |
|
ReplicatorMessages.NotFound |
Protobuf type akka.cluster.ddata.NotFound
|
ReplicatorMessages.NotFound.Builder |
Protobuf type akka.cluster.ddata.NotFound
|
ReplicatorMessages.NotFoundOrBuilder |
|
ReplicatorMessages.OtherMessage |
Protobuf type akka.cluster.ddata.OtherMessage
|
ReplicatorMessages.OtherMessage.Builder |
Protobuf type akka.cluster.ddata.OtherMessage
|
ReplicatorMessages.OtherMessageOrBuilder |
|
ReplicatorMessages.Read |
Protobuf type akka.cluster.ddata.Read
|
ReplicatorMessages.Read.Builder |
Protobuf type akka.cluster.ddata.Read
|
ReplicatorMessages.ReadOrBuilder |
|
ReplicatorMessages.ReadResult |
Protobuf type akka.cluster.ddata.ReadResult
|
ReplicatorMessages.ReadResult.Builder |
Protobuf type akka.cluster.ddata.ReadResult
|
ReplicatorMessages.ReadResultOrBuilder |
|
ReplicatorMessages.Status |
Protobuf type akka.cluster.ddata.Status
|
ReplicatorMessages.Status.Builder |
Protobuf type akka.cluster.ddata.Status
|
ReplicatorMessages.Status.Entry |
Protobuf type akka.cluster.ddata.Status.Entry
|
ReplicatorMessages.Status.Entry.Builder |
Protobuf type akka.cluster.ddata.Status.Entry
|
ReplicatorMessages.Status.EntryOrBuilder |
|
ReplicatorMessages.StatusOrBuilder |
|
ReplicatorMessages.StringGSet |
Protobuf type akka.cluster.ddata.StringGSet
|
ReplicatorMessages.StringGSet.Builder |
Protobuf type akka.cluster.ddata.StringGSet
|
ReplicatorMessages.StringGSetOrBuilder |
|
ReplicatorMessages.Subscribe |
Protobuf type akka.cluster.ddata.Subscribe
|
ReplicatorMessages.Subscribe.Builder |
Protobuf type akka.cluster.ddata.Subscribe
|
ReplicatorMessages.SubscribeOrBuilder |
|
ReplicatorMessages.UniqueAddress |
Protobuf type akka.cluster.ddata.UniqueAddress
|
ReplicatorMessages.UniqueAddress.Builder |
Protobuf type akka.cluster.ddata.UniqueAddress
|
ReplicatorMessages.UniqueAddressOrBuilder |
|
ReplicatorMessages.Unsubscribe |
Protobuf type akka.cluster.ddata.Unsubscribe
|
ReplicatorMessages.Unsubscribe.Builder |
Protobuf type akka.cluster.ddata.Unsubscribe
|
ReplicatorMessages.UnsubscribeOrBuilder |
|
ReplicatorMessages.VersionVector |
Protobuf type akka.cluster.ddata.VersionVector
|
ReplicatorMessages.VersionVector.Builder |
Protobuf type akka.cluster.ddata.VersionVector
|
ReplicatorMessages.VersionVector.Entry |
Protobuf type akka.cluster.ddata.VersionVector.Entry
|
ReplicatorMessages.VersionVector.Entry.Builder |
Protobuf type akka.cluster.ddata.VersionVector.Entry
|
ReplicatorMessages.VersionVector.EntryOrBuilder |
|
ReplicatorMessages.VersionVectorOrBuilder |
|
ReplicatorMessages.Write |
Protobuf type akka.cluster.ddata.Write
|
ReplicatorMessages.Write.Builder |
Protobuf type akka.cluster.ddata.Write
|
ReplicatorMessages.WriteOrBuilder |
|
ReplicatorMessageSerializer |
Protobuf serializer of ReplicatorMessage messages.
|
ReplicatorMessageSerializer.SmallCache<A,B> |
|
ReplicatorMessageSerializer$ |
A cache that is designed for a small number (<= 32) of
entries.
|
ReplicatorSettings |
INTERNAL API
|
ReplicatorSettings |
Create settings from the default configuration
akka.cluster.distributed-data .
|
ReplicatorSettings |
Create settings from the default configuration
akka.cluster.distributed-data .
|
ReplicatorSettings$ |
Create settings from the default configuration
akka.cluster.distributed-data .
|
ReplicatorSettings$ |
Create settings from the default configuration
akka.cluster.distributed-data .
|
ReplicatorSettings$ |
Create settings from the default configuration
akka.cluster.distributed-data .
|
Reply |
INTERNAL API: Marker trait for reply messages
|
ReplyEffect<Event,State> |
Unstash the commands that were stashed with EffectFactories.stash .
|
ReplyEffect<Event,State> |
Unstash the commands that were stashed with Effect.stash .
|
ReplyEffectImpl<ReplyMessage,State> |
INTERNAL API
|
ReplyToStrategy |
Reply to sender with predefined response, and discard the received message silently.
|
ReplyToStrategy$ |
|
RepointableActorRef |
Initialize: make a dummy cell which holds just a mailbox, then tell our
supervisor that we exist so that he can create the real Cell in
handleSupervise().
|
RepointableRef |
RepointableActorRef (and potentially others) may change their locality at
runtime, meaning that isLocal might not be stable.
|
RequestingRecoveryPermit<C,E,S> |
|
RequestingRecoveryPermit$ |
INTERNAL API
|
RequestMore<T> |
INTERNAL API
|
RequestMore$ |
|
RequestStrategy |
Invoked by the ActorSubscriber after each incoming message to
determine how many more elements to request from the stream.
|
RequiresCausalDeliveryOfDeltas |
Marker that specifies that the deltas must be applied in causal order.
|
RequiresMessageQueue<T> |
Trait to signal that an Actor requires a certain type of message queue semantics.
|
ResendBufferCapacityReachedException |
|
ResendUnfulfillableException |
|
ResizableMultiReaderRingBuffer<T> |
The number of elements currently in the buffer.
|
ResizableMultiReaderRingBuffer.Cursor |
|
ResizableMultiReaderRingBuffer.Cursors |
|
ResizableMultiReaderRingBuffer.NothingToReadException$ |
|
ResizableMultiReaderRingBuffer$ |
INTERNAL API
|
ResizablePoolActor |
INTERNAL API
|
ResizablePoolActor.Resize$ |
|
ResizablePoolActor$ |
INTERNAL API
|
ResizablePoolCell |
This approach is chosen for binary compatibility
|
Resizer |
Is it time for resizing.
|
Resizer$ |
Decide if the capacity of the router need to be changed.
|
ResizerInitializationException |
|
ResolvConf |
|
ResolvConf$ |
|
ResolvConfParser |
Does a partial parse according to https://linux.die.net/man/5/resolver.
|
ResolvConfParser$ |
Does a partial parse according to https://linux.die.net/man/5/resolver.
|
ResourceRecord |
|
ResourceRecord$ |
INTERNAL API
|
ResponseCode |
INTERNAL API
|
ResponseCode$ |
INTERNAL API
|
RestartCounter |
Current number of restarts.
|
RestartCounter.State |
|
RestartCounter.State$ |
|
RestartCounter$ |
INTERNAL API
|
RestartFlow |
Wrap the given Flow with a Flow that will restart it when it fails or complete using an exponential
backoff.
|
RestartFlow |
Wrap the given Flow with a Flow that will restart it when it fails or complete using an exponential
backoff.
|
RestartFlow$ |
Wrap the given Flow with a Flow that will restart it when it fails or complete using an exponential
backoff.
|
RestartFlow$ |
Wrap the given Flow with a Flow that will restart it when it fails or complete using an exponential
backoff.
|
RestartImpliesFailure |
|
RestartImpliesFailure$ |
|
RestartSink |
Wrap the given Sink with a Sink that will restart it when it fails or complete using an exponential
backoff.
|
RestartSink |
Wrap the given Sink with a Sink that will restart it when it fails or complete using an exponential
backoff.
|
RestartSink$ |
Wrap the given Sink with a Sink that will restart it when it fails or complete using an exponential
backoff.
|
RestartSink$ |
Wrap the given Sink with a Sink that will restart it when it fails or complete using an exponential
backoff.
|
RestartSource |
Wrap the given Source with a Source that will restart it when it fails or complete using an exponential
backoff.
|
RestartSource |
Wrap the given Source with a Source that will restart it when it fails or complete using an exponential
backoff.
|
RestartSource$ |
Wrap the given Source with a Source that will restart it when it fails or complete using an exponential
backoff.
|
RestartSource$ |
Wrap the given Source with a Source that will restart it when it fails or complete using an exponential
backoff.
|
RestartSupervisor<O,T,Thr extends java.lang.Throwable> |
Calculates an exponential back off delay.
|
RestartSupervisor.ResetRestartCount |
|
RestartSupervisor.ResetRestartCount$ |
|
RestartSupervisor.ScheduledRestart |
|
RestartSupervisor.ScheduledRestart$ |
|
RestartSupervisor$ |
Calculates an exponential back off delay.
|
RestartSupervisorStrategy |
Scala API: Restart with a limit of number of restart retries.
|
RestartWithBackoffFlow<In,Out> |
Wrap the given Flow with a Flow that will restart it when it fails using an exponential
backoff.
|
RestartWithBackoffFlow.Delay |
|
RestartWithBackoffFlow.Delay$ |
|
RestartWithBackoffFlow$ |
Temporary attribute that can override the time a RestartWithBackoffFlow waits
for a failure before cancelling.
|
RestartWithBackoffLogic<S extends Shape> |
param: out The permanent outlet
|
RestartWithBackoffSink<T> |
Wrap the given Sink with a Sink that will restart it when it fails or complete using an exponential
backoff.
|
RestartWithBackoffSource<T> |
Wrap the given Source with a Source that will restart it when it fails using an exponential backoff.
|
Resume |
INTERNAL API
|
Resume$ |
|
ResumeSupervisor<T,Thr extends java.lang.Throwable> |
|
RetentionCriteria |
Criteria for retention/deletion of snapshots and events.
|
RetentionCriteria |
Criteria for retention/deletion of snapshots and events.
|
RetentionCriteria$ |
Snapshots are not saved and deleted automatically, events are not deleted.
|
RetentionCriteria$ |
Snapshots are not saved and deleted automatically, events are not deleted.
|
RetrySupport |
Given a function from Unit to Future, returns an internally retrying Future
The first attempt will be made immediately, each subsequent attempt will be made after 'delay'
A scheduler (eg context.system.scheduler) must be provided to delay each retry
If attempts are exhausted the returned future is simply the result of invoking attempt.
|
RetrySupport$ |
Given a function from Unit to Future, returns an internally retrying Future
The first attempt will be made immediately, each subsequent attempt will be made after 'delay'
A scheduler (eg context.system.scheduler) must be provided to delay each retry
If attempts are exhausted the returned future is simply the result of invoking attempt.
|
ReusableInboundEnvelope |
INTERNAL API
|
ReusableInboundEnvelope$ |
INTERNAL API
|
ReusableOutboundEnvelope |
INTERNAL API
|
ReusableOutboundEnvelope$ |
INTERNAL API
|
Role |
INTERNAL API.
|
RoleName |
|
RoleName$ |
|
RollingEventLogSection |
INTERNAL API
|
RollingEventLogSection$ |
INTERNAL API
|
RootActorPath |
INTERNAL API
|
RootActorPath$ |
|
RoundRobinGroup |
Java API
param: routeePaths string representation of the actor paths of the routees, messages are
sent with ActorSelection to these paths
|
RoundRobinGroup$ |
|
RoundRobinPool |
Java API
param: nr initial number of routees in the pool
|
RoundRobinPool$ |
|
RoundRobinRoutingLogic |
Uses round-robin to select a routee.
|
RoundRobinRoutingLogic$ |
|
RoutedActorCell |
Add routees to the Router .
|
RoutedActorCell.RouterActorCreator |
|
RoutedActorCell$ |
INTERNAL API
|
RoutedActorRef |
INTERNAL API
|
Routee |
Abstraction of a destination for messages routed via a Router .
|
Routees |
Java API
|
Routees$ |
|
Router |
Java API
|
Router$ |
|
RouterActor |
INTERNAL API
|
RouterConfig |
Create the actual router, responsible for routing messages to routees.
|
RouterEnvelope |
Only the contained message will be forwarded to the
destination, i.e.
|
RouterManagementMesssage |
INTERNAL API
|
RouterPoolActor |
INTERNAL API
|
Routers |
A router that will keep track of the available routees registered to the Receptionist
and route over those by random selection.
|
Routers |
A router that will keep track of the available routees registered to the Receptionist
and route over those by random selection.
|
Routers$ |
A router that will keep track of the available routees registered to the Receptionist
and route over those by random selection.
|
Routers$ |
A router that will keep track of the available routees registered to the Receptionist
and route over those by random selection.
|
RoutingLogic<T> |
Invoked an initial time before selectRoutee is ever called and then every time the set of available
routees changes.
|
RoutingLogic |
Pick the destination for a given message.
|
RoutingLogics |
INTERNAL API
|
RoutingLogics.RandomLogic<T> |
|
RoutingLogics.RoundRobinLogic<T> |
|
RoutingLogics$ |
INTERNAL API
|
RunnableGraph<Mat> |
Run this flow and return the materialized values of the flow.
|
RunnableGraph<Mat> |
|
RunnableGraph$ |
A graph with a closed shape is logically a runnable graph, this method makes
it so also in type.
|
RunnableGraph$ |
A graph with a closed shape is logically a runnable graph, this method makes
it so also in type.
|
Running<C,E,S> |
INTERNAL API
|
Running |
|
Running.RunningState<State> |
|
Running.RunningState$ |
|
Running.WithSeqNrAccessible |
|
Running$ |
INTERNAL API
|
Running$ |
|
RunningInterpreter |
Each of the materialized graph stage logics running inside the interpreter
|
RunningInterpreterImpl |
INTERNAL API
|
RunningInterpreterImpl$ |
|
RuntimePluginConfig |
Additional configuration of the journal plugin servicing this persistent actor.
|
SaneRejectedExecutionHandler |
The RejectedExecutionHandler used by Akka, it improves on CallerRunsPolicy
by throwing a RejectedExecutionException if the executor isShutdown.
|
SavedIslandData |
|
SavedIslandData$ |
|
SaveSnapshotFailure |
|
SaveSnapshotFailure$ |
|
SaveSnapshotSuccess |
|
SaveSnapshotSuccess$ |
|
ScalaActorRef |
Sends a one-way asynchronous message.
|
ScalaActorSelection |
Contains the Scala API (!-method) for ActorSelections) which provides automatic tracking of the sender,
as per the usual implicit ActorRef pattern.
|
ScalaSessionAPI |
The underlying SSLSession .
|
ScalaSessionAPI$ |
Constructs a ScalaSessionAPI instance from an SSLSession
|
ScalaTestWithActorTestKit |
Use a custom config for the actor system.
|
Scan<In,Out> |
INTERNAL API
|
Scan$ |
|
ScanAsync<In,Out> |
INTERNAL API
|
ScanAsync$ |
|
ScanningClassification |
Provides a total ordering of Classifiers (think java.util.Comparator.compare)
|
ScanningEventBus<E,S,C> |
Provides a total ordering of Classifiers (think java.util.Comparator.compare)
|
ScatterGatherFirstCompletedGroup |
Java API
param: routeePaths string representation of the actor paths of the routees, messages are
sent with ActorSelection to these paths
param: within expecting at least one reply within this duration, otherwise
it will reply with AskTimeoutException in a Status.Failure
|
ScatterGatherFirstCompletedGroup$ |
|
ScatterGatherFirstCompletedPool |
Java API
param: nr initial number of routees in the pool
param: within expecting at least one reply within this duration, otherwise
it will reply with AskTimeoutException in a Status.Failure
|
ScatterGatherFirstCompletedPool$ |
|
ScatterGatherFirstCompletedRoutees |
INTERNAL API
|
ScatterGatherFirstCompletedRoutees$ |
|
ScatterGatherFirstCompletedRoutingLogic |
Broadcasts the message to all routees, and replies with the first response.
|
ScatterGatherFirstCompletedRoutingLogic$ |
|
Scheduler |
Schedules a message to be sent repeatedly with an initial delay and
frequency.
|
SchedulerException |
This exception is thrown by Scheduler.schedule* when scheduling is not
possible, e.g.
|
SchedulerException$ |
|
SchemeAugmenter |
|
Scope |
When merging Deploy instances using
withFallback()
on
the left one, this is propagated to “merging” scopes in the same way.
|
SecureRandomFactory |
INTERNAL API
|
SecureRandomFactory$ |
INTERNAL API
|
SeedSize |
INTERNAL API
From AESCounterRNG API docs:
Valid values are 16 (128 bits), 24 (192 bits) and 32 (256 bits).
|
SeedSize$ |
INTERNAL API
From AESCounterRNG API docs:
Valid values are 16 (128 bits), 24 (192 bits) and 32 (256 bits).
|
SegmentInfo |
|
SegmentInfo$ |
|
SelectChildName |
INTERNAL API
|
SelectChildName$ |
|
SelectChildPattern |
INTERNAL API
|
SelectChildPattern$ |
|
SelectedSnapshot |
|
SelectedSnapshot$ |
Java API, Plugin API.
|
SelectionHandler |
Special supervisor strategy for parents of TCP connection and listener actors.
|
SelectionHandler.ChannelAcceptable$ |
|
SelectionHandler.ChannelConnectable$ |
|
SelectionHandler.ChannelReadable$ |
|
SelectionHandler.ChannelWritable$ |
|
SelectionHandler.HasFailureMessage |
|
SelectionHandler.Retry |
|
SelectionHandler.Retry$ |
|
SelectionHandler.SelectorBasedManager |
|
SelectionHandler.WorkerForCommand |
|
SelectionHandler.WorkerForCommand$ |
|
SelectionHandler$ |
Special supervisor strategy for parents of TCP connection and listener actors.
|
SelectionHandlerSettings |
|
SelectionPathElement |
INTERNAL API
|
SelectParent |
INTERNAL API
|
SelectParent$ |
INTERNAL API
|
SelfRemoved |
Subscribe to this node being removed from the cluster.
|
SelfRemoved$ |
|
SelfUniqueAddress |
Cluster non-specific (typed vs untyped) wrapper for UniqueAddress .
|
SelfUniqueAddress$ |
|
SelfUp |
Subscribe to this node being up, after sending this event the subscription is automatically
cancelled.
|
SelfUp$ |
|
SendQueue<T> |
INTERNAL API
|
SendQueue.ProducerApi<T> |
|
SendQueue.QueueValue<T> |
|
SendQueue.WakeupSignal |
|
SendQueue$ |
INTERNAL API
|
SeqActorName |
INTERNAL API
As discussed in https://github.com/akka/akka/issues/16613
|
SeqActorName$ |
INTERNAL API
|
SeqActorNameImpl |
INTERNAL API
|
SeqNo |
|
SeqNo$ |
|
SeqStage<T,That> |
INTERNAL API
|
Sequence |
Corresponds to an ordered sequence number for the events.
|
Sequence$ |
|
Serialization |
INTERNAL API
|
Serialization.Information |
Serialization information needed for serializing local actor refs,
or if serializer library e.g.
|
Serialization.Information$ |
|
Serialization.Settings |
|
Serialization$ |
Tuple that represents mapping from Class to Serializer
|
SerializationCheckFailedException |
|
SerializationCheckFailedException$ |
|
SerializationExtension |
SerializationExtension is an Akka Extension to interact with the Serialization
that is built into Akka
|
SerializationExtension$ |
SerializationExtension is an Akka Extension to interact with the Serialization
that is built into Akka
|
SerializationFormatCache |
INTERNAL API
|
SerializationSetup |
Setup for the serialization subsystem, constructor is *Internal API*, use factories in SerializationSetup()
|
SerializationSetup$ |
Scala API: Programmatic definition of serializers
param: createSerializers create pairs of serializer and the set of classes it should be used for
|
SerializationSupport |
Some useful serialization helper methods.
|
SerializedActorRef |
Memento pattern for serializing ActorRefs transparently
INTERNAL API
|
SerializedActorRef<T> |
|
SerializedActorRef$ |
INTERNAL API
|
SerializedActorRef$ |
INTERNAL API
|
SerializedNobody |
INTERNAL API
|
SerializedSuspendableExecutionContext |
Resumes execution of tasks until suspend is called,
if it isn't currently suspended, it is a no-op.
|
SerializedSuspendableExecutionContext$ |
|
Serializer |
Completely unique value to identify this implementation of Serializer, used to optimize network traffic.
|
SerializerDetails |
|
SerializerDetails$ |
Scala API: factory for details about one programmatically setup serializer
|
Serializers |
Java API: deserialize with type hint
|
Serializers$ |
Java API: deserialize with type hint
|
SerializerWithStringManifest |
Completely unique value to identify this implementation of Serializer, used to optimize network traffic.
|
Server |
INTERNAL API.
|
Server |
The server is usually the side the provides the service to its interlocutor.
|
Server$ |
INTERNAL API.
|
Server$ |
|
ServerFSM |
The server part of each client connection is represented by a ServerFSM.
|
ServerFSM.Initial$ |
|
ServerFSM.Ready$ |
|
ServerFSM.State |
|
ServerFSM$ |
INTERNAL API.
|
ServerHandler |
INTERNAL API
|
ServerOp |
|
ServiceDiscovery |
Scala API: Perform lookup using underlying discovery implementation.
|
ServiceDiscovery.Resolved |
|
ServiceDiscovery.Resolved$ |
|
ServiceDiscovery.ResolvedTarget |
|
ServiceDiscovery.ResolvedTarget$ |
|
ServiceDiscovery$ |
Result of a successful resolve request
|
ServiceKey<T> |
Scala API: Provides a type safe pattern match for listings
|
ServiceKey$ |
Scala API: Creates a service key.
|
ServiceKeySerializer |
Internal API
|
ServiceRegistry |
INTERNAL API
|
ServiceRegistry$ |
INTERNAL API
|
Settings |
Returns the String representation of the Config that this Settings is backed by
|
Setup |
|
SetupFlowStage<T,U,M> |
Internal Api
|
SetupSinkStage<T,M> |
Internal Api
|
SetupSourceStage<T,M> |
Internal Api
|
SetupStage |
|
SetupStage$ |
|
SeveralRoutees |
Java API
|
SeveralRoutees$ |
|
Shape |
Scala API: get a list of all input ports
|
Shape$ |
inlets and outlets can be Vector or List so this method
checks the size of 1 in an optimized way.
|
Shard |
Will call onLeaseAcquired when completed, also when lease isn't used
|
Shard.CurrentShardState |
|
Shard.CurrentShardState$ |
|
Shard.EntityStarted |
|
Shard.EntityStarted$ |
|
Shard.EntityStopped |
|
Shard.EntityStopped$ |
|
Shard.GetCurrentShardState$ |
|
Shard.GetShardStats$ |
|
Shard.LeaseAcquireResult |
|
Shard.LeaseAcquireResult$ |
|
Shard.LeaseLost |
|
Shard.LeaseLost$ |
|
Shard.LeaseRetry$ |
|
Shard.PassivateIdleTick$ |
|
Shard.RestartEntities |
|
Shard.RestartEntities$ |
|
Shard.RestartEntity |
|
Shard.RestartEntity$ |
|
Shard.ShardCommand |
|
Shard.ShardQuery |
|
Shard.ShardStats |
|
Shard.ShardStats$ |
|
Shard.State |
|
Shard.State$ |
|
Shard.StateChange |
|
Shard$ |
A Shard command
|
ShardCommandActor |
INTERNAL API
|
ShardCommandActor$ |
INTERNAL API
|
ShardCoordinator |
|
ShardCoordinator.AbstractShardAllocationStrategy |
|
ShardCoordinator.Internal$ |
|
ShardCoordinator.Internal$.CoordinatorCommand |
|
ShardCoordinator.Internal$.CoordinatorMessage |
|
ShardCoordinator.Internal$.DomainEvent |
|
ShardCoordinator.LeastShardAllocationStrategy |
|
ShardCoordinator.RebalanceWorker |
|
ShardCoordinator.ShardAllocationStrategy |
Invoked when the location of a new shard is to be decided.
|
ShardCoordinator$ |
|
ShardedServiceRegistry |
|
ShardedServiceRegistry$ |
INTERNAL API
|
ShardingEnvelope<M> |
Default envelope type that may be used with Cluster Sharding.
|
ShardingEnvelope$ |
|
ShardingMessageExtractor<E,M> |
Extract the entity id from an incoming message .
|
ShardingMessageExtractor$ |
Scala API:
|
ShardingMessages |
|
ShardingMessages.ShardingEnvelope |
Protobuf type akka.cluster.sharding.typed.ShardingEnvelope
|
ShardingMessages.ShardingEnvelope.Builder |
Protobuf type akka.cluster.sharding.typed.ShardingEnvelope
|
ShardingMessages.ShardingEnvelopeOrBuilder |
|
ShardingSerializer |
INTERNAL API
|
ShardingState |
INTERNAL API
|
ShardingState$ |
INTERNAL API
|
ShardRegion |
When leaving the coordinator singleton is started rather quickly on next
oldest node and therefore it is good to send the GracefulShutdownReq to
the likely locations of the coordinator.
|
ShardRegion.ClusterShardingStats |
|
ShardRegion.ClusterShardingStats$ |
|
ShardRegion.CurrentRegions |
Java API
|
ShardRegion.CurrentRegions$ |
|
ShardRegion.CurrentShardRegionState |
Java API:
|
ShardRegion.CurrentShardRegionState$ |
|
ShardRegion.GetClusterShardingStats |
|
ShardRegion.GetClusterShardingStats$ |
|
ShardRegion.GetCurrentRegions$ |
|
ShardRegion.GetShardRegionState$ |
|
ShardRegion.GetShardRegionStats$ |
|
ShardRegion.GracefulShutdown$ |
|
ShardRegion.HandOffStopper |
|
ShardRegion.HashCodeMessageExtractor |
|
ShardRegion.HashCodeMessageExtractor$ |
|
ShardRegion.MessageExtractor |
Extract the entity id from an incoming message .
|
ShardRegion.Passivate |
|
ShardRegion.Passivate$ |
|
ShardRegion.ShardInitialized |
|
ShardRegion.ShardInitialized$ |
|
ShardRegion.ShardRegionCommand |
|
ShardRegion.ShardRegionQuery |
|
ShardRegion.ShardRegionStats |
Java API
|
ShardRegion.ShardRegionStats$ |
|
ShardRegion.ShardState |
|
ShardRegion.ShardState$ |
|
ShardRegion.StartEntity |
|
ShardRegion.StartEntity$ |
|
ShardRegion.StartEntityAck |
|
ShardRegion.StartEntityAck$ |
|
ShardRegion$ |
|
SharedKillSwitch |
After calling SharedKillSwitch.shutdown() all materialized, running instances of all Graph s provided by the
SharedKillSwitch will complete their downstreams and cancel their upstreams (unless if finished or failed already in which
case the command is ignored).
|
SharedLeveldbJournal |
INTERNAL API.
|
SharedLeveldbJournal$ |
Sets the shared LevelDB store for the given actor system .
|
SharedLeveldbStore |
A LevelDB store that can be shared by multiple actor systems.
|
SharedTestState |
Enable blackholing between given address in given direction
|
ShutDown |
|
ShutDown$ |
|
ShutDownAssociation |
INTERNAL API
|
ShutDownAssociation$ |
|
SideEffect<State> |
A SideEffect is an side effect that can be chained after a main effect.
|
SideEffect$ |
INTERNAL API
|
SigarMetricsCollector |
This constructor is used when creating an instance from configured FQCN
|
SigarProvider |
Library extract location.
|
SigarProvider$ |
Release underlying sigar proxy resources.
|
Signal |
System signals are notifications that are generated by the system and
delivered to the Actor behavior in a reliable fashion (i.e.
|
SignalHandler<State> |
INTERNAL API
|
SignalHandler$ |
|
SignalHandlerBuilder<State> |
If the behavior recieves a signal of type T , callback is invoked with the signal instance as input.
|
SignalHandlerBuilder$ |
INTERNAL API
|
SimpleDnsCache |
|
SimpleDnsCache.Cache<K,V> |
|
SimpleDnsCache.ExpiryEntry<K> |
|
SimpleDnsCache$ |
INTERNAL API
|
SimpleDnsManager |
|
SimpleDnsManager$ |
|
SimpleOutputs |
INTERNAL API
|
SimpleSupervisor<T,Thr extends java.lang.Throwable> |
For cases where O == I for BehaviorInterceptor.
|
SingleConsumerOnlyUnboundedMailbox |
SingleConsumerOnlyUnboundedMailbox is a high-performance, multiple producer—single consumer, unbounded MailboxType,
with the drawback that you can't have multiple consumers,
which rules out using it with BalancingPool (BalancingDispatcher) for instance.
|
SingleConsumerOnlyUnboundedMailbox$ |
|
SingleEventSeq |
Java API
|
SingleEventSeq$ |
|
SingletonActor<M> |
Props of the singleton actor, such as dispatcher settings.
|
SingletonActor$ |
param: name Unique name for the singleton
param: behavior Behavior for the singleton
|
Sink<In,Mat> |
Converts this Sink to its Scala DSL counterpart.
|
Sink<In,Mat> |
Transform this Sink by applying a function to each *incoming* upstream element before
it is passed to the Sink
|
Sink$ |
A Sink that will invoke the given function for every received element, giving it its previous
output (or the given zero value) and the element as input.
|
Sink$ |
INTERNAL API
|
SinkholeSubscriber<T> |
INTERNAL API
|
SinkModule<In,Mat> |
Create the Subscriber or VirtualPublisher that consumes the incoming
stream, plus the materialized value.
|
SinkModuleIslandTag |
INTERNAL API
|
SinkModuleIslandTag$ |
INTERNAL API
|
SinkModulePhase |
INTERNAL API
|
SinkQueue<T> |
Method pulls elements from stream and returns future that:
- fails if stream is failed
- completes with None in case if stream is completed
- completes with Some(element) in case next element is available from stream.
|
SinkQueue<T> |
Method pulls elements from stream and returns future that:
- fails if stream is failed
- completes with None in case if stream is completed
- completes with Some(element) in case next element is available from stream.
|
SinkQueueAdapter<T> |
INTERNAL API
|
SinkQueueWithCancel<T> |
Cancel the stream.
|
SinkQueueWithCancel<T> |
Cancel the stream.
|
SinkRef<In> |
Scala API: Get Sink underlying to this source ref.
|
SinkRef$ |
Implicitly converts a SinkRef to a Sink .
|
SinkRefImpl<In> |
INTERNAL API: Implementation class, not intended to be touched directly by end-users
|
SinkRefImpl$ |
|
SinkRefStageImpl<In> |
INTERNAL API: Actual operator implementation backing SinkRef s.
|
SinkShape<T> |
A Sink Shape has exactly one input and no outputs, it models a data sink.
|
SinkShape$ |
Java API
|
Slf4jLogger |
Override this method to provide a differently formatted timestamp
param: timestamp a "currentTimeMillis"-obtained timestamp
|
SLF4JLogging |
Base trait for all classes that wants to be able use the SLF4J logging infrastructure.
|
Slf4jLoggingFilter |
LoggingFilter that uses the log level defined in the SLF4J
backend configuration (e.g.
|
Slf4jLogMarker |
Wraps Marker
|
Slf4jLogMarker$ |
Java API
|
Sliding<T> |
INTERNAL API
|
Sliding$ |
|
SmallestMailboxPool |
Java API
param: nr initial number of routees in the pool
|
SmallestMailboxPool$ |
|
SmallestMailboxRoutingLogic |
Returns true if the actor is currently processing a message.
|
SmallestMailboxRoutingLogic$ |
|
Snapshot |
Wrapper for snapshot data .
|
Snapshot$ |
|
SnapshotAfter |
Function that takes lastSequenceNr as the param, and returns whether the passed
sequence number should trigger auto snapshot or not
|
SnapshotAfter$ |
SnapshotAfter Extension Id and factory for creating SnapshotAfter extension
|
SnapshotCompleted |
Java API
|
SnapshotCompleted$ |
|
SnapshotCountRetentionCriteria |
Delete events after saving snapshot via {@link RetentionCriteria.snapshotEvery()}.
|
SnapshotCountRetentionCriteria |
Delete events after saving snapshot via {@link RetentionCriteria.snapshotEvery()}.
|
SnapshotCountRetentionCriteriaImpl |
INTERNAL API
|
SnapshotCountRetentionCriteriaImpl$ |
|
SnapshotFailed |
Java API
|
SnapshotFailed$ |
|
SnapshotInProgress |
|
SnapshotInProgress$ |
|
SnapshotInteractions<C,E,S> |
Instructs the snapshot store to load the specified snapshot and send it via an SnapshotOffer
to the running PersistentActor .
|
SnapshotMetadata |
Snapshot metadata.
|
SnapshotMetadata |
Snapshot metadata.
|
SnapshotMetadata$ |
|
SnapshotMetadata$ |
param: persistenceId id of persistent actor from which the snapshot was taken.
|
SnapshotOffer |
|
SnapshotOffer$ |
|
SnapshotProtocol |
Marker trait shared by internal snapshot messages.
|
SnapshotProtocol.DeleteSnapshot |
|
SnapshotProtocol.DeleteSnapshot$ |
|
SnapshotProtocol.DeleteSnapshots |
|
SnapshotProtocol.DeleteSnapshots$ |
|
SnapshotProtocol.LoadSnapshot |
|
SnapshotProtocol.LoadSnapshot$ |
|
SnapshotProtocol.LoadSnapshotFailed |
|
SnapshotProtocol.LoadSnapshotFailed$ |
|
SnapshotProtocol.LoadSnapshotResult |
|
SnapshotProtocol.LoadSnapshotResult$ |
|
SnapshotProtocol.Message |
|
SnapshotProtocol.Request |
|
SnapshotProtocol.Response |
|
SnapshotProtocol.SaveSnapshot |
|
SnapshotProtocol.SaveSnapshot$ |
|
SnapshotProtocol$ |
Marker trait shared by internal snapshot messages.
|
SnapshotSelectionCriteria |
INTERNAL API.
|
SnapshotSelectionCriteria |
upper bound for a selected snapshot's sequence number
|
SnapshotSelectionCriteria$ |
The latest saved snapshot.
|
SnapshotSelectionCriteria$ |
The latest saved snapshot.
|
SnapshotSerializer |
|
SnapshotStore |
Java API: abstract snapshot store.
|
SnapshotStore |
Documents intent that the sender() is expected to be the PersistentActor
|
SnapshotStoreCapabilityFlags |
When true enables tests which check if the snapshot store properly serialize and
deserialize snapshots.
|
SnapshotStoreSpec |
The limit defines a number of bytes persistence plugin can support to store the snapshot.
|
SnapshotStoreSpec$ |
|
Snapshotter |
Snapshot store plugin actor.
|
SocketUtil |
|
SocketUtil.Both$ |
|
SocketUtil.Protocol |
|
SocketUtil.Tcp$ |
|
SocketUtil.Udp$ |
|
SocketUtil$ |
|
SoftShutdown |
INTERNAL API
|
Source<Out,Mat> |
Converts this Java DSL element to its Scala DSL counterpart.
|
Source<Out,Mat> |
Connect this Source to a Sink ,
concatenating the processing steps of both.
|
Source$ |
Create a Source with no elements, i.e.
|
Source$ |
INTERNAL API
|
SourceModule<Out,Mat> |
INTERNAL API
|
SourceModuleIslandTag |
INTERNAL API
|
SourceModuleIslandTag$ |
INTERNAL API
|
SourceModulePhase |
INTERNAL API
|
SourceQueue<T> |
Method offers next element to a stream and returns future that:
- completes with Enqueued if element is consumed by a stream
- completes with Dropped when stream dropped offered element
- completes with QueueClosed when stream is completed during future is active
- completes with Failure(f) when failure to enqueue element from upstream
- fails when stream is completed
|
SourceQueue<T> |
Method offers next element to a stream and returns future that:
- completes with Enqueued if element is consumed by a stream
- completes with Dropped when stream dropped offered element
- completes with QueueClosed when stream is completed during future is active
- completes with Failure(f) when failure to enqueue element from upstream
- fails when stream is completed
|
SourceQueueAdapter<T> |
INTERNAL API
|
SourceQueueWithComplete<T> |
Complete the stream normally.
|
SourceQueueWithComplete<T> |
Complete the stream normally.
|
SourceRef<T> |
Scala API: Get Source underlying to this source ref.
|
SourceRef$ |
Implicitly converts a SourceRef to a Source.
|
SourceRefImpl<T> |
INTERNAL API: Implementation class, not intended to be touched directly by end-users
|
SourceRefImpl$ |
|
SourceRefStageImpl<Out> |
|
SourceShape<T> |
A Source Shape has exactly one output and no inputs, it models a source
of data.
|
SourceShape$ |
Java API
|
SourceWithContext<Out,Ctx,Mat> |
Transform this flow by the regular flow.
|
SourceWithContext<Out,Ctx,Mat> |
Context-preserving variant of akka.stream.scaladsl.Source.withAttributes .
|
SourceWithContext$ |
Creates a SourceWithContext from a regular flow that operates on Pair elements.
|
SourceWithContext$ |
Creates a SourceWithContext from a regular source that operates on a tuple of (data, context) elements.
|
SpawnProtocol |
A message protocol for actors that support spawning a child actor when receiving a SpawnProtocol#Spawn
message and sending back the ActorRef of the child actor.
|
SpawnProtocol.Spawn<T> |
|
SpawnProtocol.Spawn$ |
|
SpawnProtocol$ |
Special factory to make using Spawn with ask easier
|
Split<T> |
INTERNAL API
|
Split.SplitAfter$ |
|
Split.SplitBefore$ |
|
Split.SplitDecision |
|
Split$ |
Splits before the current element.
|
SRVRecord |
INTERNAL API
|
SRVRecord$ |
INTERNAL API
|
SSLEngineConfigurator |
Gives the chance to configure the SSLContext before it is going to be used.
|
SSLEngineProvider |
Verification that will be called after every successful handshake
to verify additional session information.
|
SSLEngineProvider |
|
SSLEngineProviderSetup |
Setup for defining a SSLEngineProvider that is passed in when ActorSystem
is created rather than creating one from configured class name.
|
SSLEngineProviderSetup$ |
Scala API: factory for defining a SSLEngineProvider that is passed in when ActorSystem
is created rather than creating one from configured class name.
|
SSLSettings |
INTERNAL API
|
SslTransportException |
Verification that will be called after every successful handshake
to verify additional session information.
|
StablePriorityBlockingQueue<E> |
StablePriorityBlockingQueue is a blocking priority queue that preserves order for elements of equal priority.
|
StablePriorityQueue<E> |
StablePriorityQueue is a priority queue that preserves order for elements of equal priority.
|
StageLogging |
Override to customise reported log source
|
Stages |
INTERNAL API
|
Stages.DefaultAttributes$ |
|
Stages$ |
INTERNAL API
|
StandardMetrics |
Sum of User + Sys + Nice + Wait.
|
StandardMetrics.Cpu |
param: address Address of the node the metrics are gathered at
param: timestamp the time of sampling, in milliseconds since midnight, January 1, 1970 UTC
param: systemLoadAverage OS-specific average load on the CPUs in the system, for the past 1 minute,
The system is possibly nearing a bottleneck if the system load average is nearing number of cpus/cores.
|
StandardMetrics.Cpu$ |
|
StandardMetrics.HeapMemory |
The amount of used and committed memory will always be <= max if max is defined.
|
StandardMetrics.HeapMemory$ |
Given a NodeMetrics it returns the HeapMemory data if the nodeMetrics contains
necessary heap metrics.
|
StandardMetrics$ |
Sum of User + Sys + Nice + Wait.
|
StartEntity |
Returns ShardingEnvelope which can be sent via Cluster Sharding in order to wake up the
specified (by entityId ) Sharded Entity, ''without'' delivering a real message to it.
|
StartEntity |
Returns ShardingEnvelope which can be sent via Cluster Sharding in order to wake up the
specified (by entityId ) Sharded Entity, ''without'' delivering a real message to it.
|
StartEntity$ |
Returns ShardingEnvelope which can be sent via Cluster Sharding in order to wake up the
specified (by entityId ) Sharded Entity, ''without'' delivering a real message to it.
|
StartEntity$ |
Returns ShardingEnvelope which can be sent via Cluster Sharding in order to wake up the
specified (by entityId ) Sharded Entity, ''without'' delivering a real message to it.
|
Stash |
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 |
INTERNAL API
|
Stash$ |
INTERNAL API
|
StashBuffer<T> |
Check if the message buffer is empty.
|
StashBuffer<T> |
Check if the message buffer is empty.
|
StashBuffer$ |
Create an empty message buffer.
|
StashBuffer$ |
Create an empty message buffer.
|
StashBufferImpl<T> |
INTERNAL API
|
StashBufferImpl$ |
INTERNAL API
|
StashFactory |
INTERNAL API.
|
StashManagement<C,E,S> |
Stash a command to the internal stash buffer, which is used while waiting for persist to be completed.
|
StashOverflowException |
Is thrown when the size of the Stash exceeds the capacity of the Stash
|
StashOverflowException |
Is thrown when the size of the stash exceeds the capacity of the stash buffer.
|
StashOverflowException |
Is thrown when the size of the stash exceeds the capacity of the stash buffer.
|
StashOverflowException$ |
|
StashOverflowStrategy |
This defines how to handle the current received message which failed to stash, when the size of
Stash exceeding the capacity of Stash.
|
StashOverflowStrategy |
INTERNAL API
|
StashOverflowStrategy.Drop$ |
|
StashOverflowStrategy.Fail$ |
|
StashOverflowStrategy$ |
INTERNAL API
|
StashOverflowStrategyConfigurator |
Implement this interface in order to configure the stashOverflowStrategy for
the internal stash of persistent actor.
|
StashState |
INTERNAL API: stash buffer state in order to survive restart of internal behavior
|
StashSupport |
|
StashWhenFailed |
INTERNAL API
|
StashWhenWaitingForChildren |
INTERNAL API
|
StatefulMapConcat<In,Out> |
INTERNAL API
|
Status |
This class/message type is preferably used to indicate success of some operation performed.
|
Status.Failure |
|
Status.Failure$ |
|
Status.Success |
|
Status.Success$ |
|
Status$ |
This class/message type is preferably used to indicate success of some operation performed.
|
Status$Status |
|
Stop |
INTERNAL API
|
Stop$ |
INTERNAL API
|
StopChild |
Internal Akka use only, used in implementation of system.stop(child).
|
StopChild$ |
|
StopImpliesFailure |
|
StopImpliesFailure$ |
|
StoppingSupervisorStrategy |
|
StopSupervisor<T,Thr extends java.lang.Throwable> |
|
StreamConverters |
Sink which writes incoming ByteString s to an OutputStream created by the given function.
|
StreamConverters |
Creates a Source from an InputStream created by the given function.
|
StreamConverters$ |
Sink which writes incoming ByteString s to an OutputStream created by the given function.
|
StreamConverters$ |
Creates a Source from an InputStream created by the given function.
|
StreamDetachedException |
This exception signals that materialized value is already detached from stream.
|
StreamLayout |
This is the only extension point for the sealed type hierarchy: composition
(i.e.
|
StreamLayout.AtomicModule<S extends Shape,M> |
This is the only extension point for the sealed type hierarchy: composition
(i.e.
|
StreamLayout$ |
This is the only extension point for the sealed type hierarchy: composition
(i.e.
|
StreamLimitReachedException |
|
StreamRefAttributes |
Attributes specific to stream refs.
|
StreamRefAttributes.StreamRefAttribute |
|
StreamRefAttributes.SubscriptionTimeout |
|
StreamRefAttributes.SubscriptionTimeout$ |
|
StreamRefAttributes$ |
Attributes specific to stream refs.
|
StreamRefMessages |
|
StreamRefMessages.ActorRef |
Protobuf type ActorRef
|
StreamRefMessages.ActorRef.Builder |
Protobuf type ActorRef
|
StreamRefMessages.ActorRefOrBuilder |
|
StreamRefMessages.CumulativeDemand |
Protobuf type CumulativeDemand
|
StreamRefMessages.CumulativeDemand.Builder |
Protobuf type CumulativeDemand
|
StreamRefMessages.CumulativeDemandOrBuilder |
|
StreamRefMessages.OnSubscribeHandshake |
Protobuf type OnSubscribeHandshake
|
StreamRefMessages.OnSubscribeHandshake.Builder |
Protobuf type OnSubscribeHandshake
|
StreamRefMessages.OnSubscribeHandshakeOrBuilder |
|
StreamRefMessages.Payload |
Protobuf type Payload
|
StreamRefMessages.Payload.Builder |
Protobuf type Payload
|
StreamRefMessages.PayloadOrBuilder |
|
StreamRefMessages.RemoteStreamCompleted |
Protobuf type RemoteStreamCompleted
|
StreamRefMessages.RemoteStreamCompleted.Builder |
Protobuf type RemoteStreamCompleted
|
StreamRefMessages.RemoteStreamCompletedOrBuilder |
|
StreamRefMessages.RemoteStreamFailure |
Protobuf type RemoteStreamFailure
|
StreamRefMessages.RemoteStreamFailure.Builder |
Protobuf type RemoteStreamFailure
|
StreamRefMessages.RemoteStreamFailureOrBuilder |
|
StreamRefMessages.SequencedOnNext |
Protobuf type SequencedOnNext
|
StreamRefMessages.SequencedOnNext.Builder |
Protobuf type SequencedOnNext
|
StreamRefMessages.SequencedOnNextOrBuilder |
|
StreamRefMessages.SinkRef |
Protobuf type SinkRef
|
StreamRefMessages.SinkRef.Builder |
Protobuf type SinkRef
|
StreamRefMessages.SinkRefOrBuilder |
|
StreamRefMessages.SourceRef |
Protobuf type SourceRef
|
StreamRefMessages.SourceRef.Builder |
Protobuf type SourceRef
|
StreamRefMessages.SourceRefOrBuilder |
|
StreamRefResolver |
Generate full String representation of the SourceRef .
|
StreamRefResolver$ |
Java API
|
StreamRefResolverImpl |
INTERNAL API
|
StreamRefs |
A local Sink which materializes a SourceRef which can be used by other streams (including remote ones),
to consume data from this local stream, as if they were attached in the spot of the local Sink directly.
|
StreamRefs |
A local Sink which materializes a SourceRef which can be used by other streams (including remote ones),
to consume data from this local stream, as if they were attached directly in place of the local Sink.
|
StreamRefs$ |
A local Sink which materializes a SourceRef which can be used by other streams (including remote ones),
to consume data from this local stream, as if they were attached in the spot of the local Sink directly.
|
StreamRefs$ |
A local Sink which materializes a SourceRef which can be used by other streams (including remote ones),
to consume data from this local stream, as if they were attached directly in place of the local Sink.
|
StreamRefSerializer |
INTERNAL API
|
StreamRefSettings |
|
StreamRefSettings$ |
Java API
|
StreamRefSettingsImpl |
INTERNAL API
|
StreamRefSettingsImpl$ |
|
StreamRefsMaster |
INTERNAL API
|
StreamRefsMaster$ |
INTERNAL API
|
StreamRefsProtocol |
INTERNAL API
|
StreamRefsProtocol.CumulativeDemand |
|
StreamRefsProtocol.CumulativeDemand$ |
|
StreamRefsProtocol.OnSubscribeHandshake |
|
StreamRefsProtocol.OnSubscribeHandshake$ |
|
StreamRefsProtocol.RemoteStreamCompleted |
|
StreamRefsProtocol.RemoteStreamCompleted$ |
|
StreamRefsProtocol.RemoteStreamFailure |
|
StreamRefsProtocol.RemoteStreamFailure$ |
|
StreamRefsProtocol.SequencedOnNext<T> |
|
StreamRefsProtocol.SequencedOnNext$ |
|
StreamRefsProtocol$ |
Sequenced Subscriber#onNext equivalent.
|
StreamRefSubscriptionTimeoutException |
|
StreamRefSubscriptionTimeoutException$ |
|
StreamSnapshot |
Running interpreters
|
StreamSnapshotImpl |
INTERNAL API
|
StreamSnapshotImpl$ |
|
StreamSubscriptionTimeoutSettings |
|
StreamSubscriptionTimeoutSettings$ |
Create settings from individual values (Java).
|
StreamSubscriptionTimeoutSupport |
Default settings for subscription timeouts.
|
StreamSubscriptionTimeoutSupport.CancelingSubscriber$ |
|
StreamSubscriptionTimeoutSupport.NoopSubscriptionTimeout$ |
|
StreamSubscriptionTimeoutSupport$ |
A subscriber who calls cancel directly from onSubscribe and ignores all other callbacks.
|
StreamSubscriptionTimeoutTerminationMode |
This mode describes what shall happen when the subscription timeout expires for
substream Publishers created by operations like prefixAndTail .
|
StreamSubscriptionTimeoutTerminationMode.CancelTermination$ |
|
StreamSubscriptionTimeoutTerminationMode.NoopTermination$ |
|
StreamSubscriptionTimeoutTerminationMode.WarnTermination$ |
|
StreamSubscriptionTimeoutTerminationMode$ |
Do not do anything when timeout expires.
|
StreamSupervisor |
INTERNAL API
|
StreamSupervisor.AddFunctionRef |
|
StreamSupervisor.AddFunctionRef$ |
|
StreamSupervisor.Children |
|
StreamSupervisor.Children$ |
|
StreamSupervisor.ChildrenSnapshots |
|
StreamSupervisor.ChildrenSnapshots$ |
|
StreamSupervisor.GetChildren$ |
|
StreamSupervisor.GetChildrenSnapshots$ |
|
StreamSupervisor.Materialize |
|
StreamSupervisor.Materialize$ |
|
StreamSupervisor.RemoveFunctionRef |
|
StreamSupervisor.RemoveFunctionRef$ |
|
StreamSupervisor.StopChildren$ |
|
StreamSupervisor.StoppedChildren$ |
|
StreamSupervisor$ |
Testing purpose
|
StreamTcpException |
|
StreamTestKit |
Assert that there are no stages running under a given materializer.
|
StreamTestKit |
Asserts that after the given code block is ran, no stages are left over
that were created by the given materializer.
|
StreamTestKit |
INTERNAL API
|
StreamTestKit.CompletedSubscription<T> |
|
StreamTestKit.CompletedSubscription$ |
|
StreamTestKit.FailedSubscription<T> |
|
StreamTestKit.FailedSubscription$ |
|
StreamTestKit.ProbeSink<T> |
|
StreamTestKit.ProbeSource<T> |
|
StreamTestKit.PublisherProbeSubscription<I> |
|
StreamTestKit.PublisherProbeSubscription$ |
|
StreamTestKit$ |
Assert that there are no stages running under a given materializer.
|
StreamTestKit$ |
Asserts that after the given code block is ran, no stages are left over
that were created by the given materializer.
|
StreamTestKit$ |
INTERNAL API
|
StringSerializer |
|
StubbedActorContext<T> |
INTERNAL API
|
StubbedLogger |
INTERNAL API
|
StubbedLoggerWithMdc |
|
SubchannelClassification |
The logic to form sub-class hierarchy
|
SubchannelEventBus<E,S,C> |
The logic to form sub-class hierarchy
|
Subclassification<K> |
True if and only if x and y are of the same class.
|
SubclassifiedIndex<K,V> |
Add key to this index which inherits its value set from the most specific
super-class which is known.
|
SubclassifiedIndex.Nonroot<K,V> |
|
SubclassifiedIndex$ |
True if and only if x is a subclass of y; equal classes must be considered sub-classes!
|
SubFlow<In,Out,Mat> |
Converts this Flow to its Scala DSL counterpart
|
SubFlow<Out,Mat,F,C> |
Attach a Sink to each sub-flow, closing the overall Graph that is being
constructed.
|
SubFlow$ |
Upcast a stream of elements to a stream of supertypes of that element.
|
SubFlowImpl<In,Out,Mat,F,C> |
INTERNAL API
|
SubFlowImpl.MergeBack<In,F> |
|
SubFlowImpl$ |
INTERNAL API
|
SubFusingActorMaterializerImpl |
This materializer replaces the default phase with one that will fuse operators into an existing interpreter (via registerShell ),
rather than start a new actor for each of them.
|
SubReceive |
INTERNAL API
|
Subscribe<A extends ClusterEvent.ClusterDomainEvent> |
Subscribe to cluster state changes.
|
Subscribe$ |
Java API
|
SubscribeClusterClients |
|
SubscribeClusterClients$ |
Java API: get the singleton instance
|
SubscribeContactPoints |
|
SubscribeContactPoints$ |
Java API: get the singleton instance
|
SubscribePending |
INTERNAL API
|
SubscribePending$ |
INTERNAL API
|
SubscriberManagement<T> |
called when we are ready to consume more elements from our upstream
MUST NOT call pushToDownstream
|
SubscriberManagement.Completed$ |
|
SubscriberManagement.EndOfStream |
|
SubscriberManagement.ErrorCompleted |
|
SubscriberManagement.ErrorCompleted$ |
|
SubscriberManagement.NotReached$ |
|
SubscriberManagement$ |
INTERNAL API
|
SubscriberSink<In> |
INTERNAL API
Attaches a subscriber to this stream.
|
SubscriberSource<Out> |
INTERNAL API
Holds a Subscriber representing the input side of the flow.
|
SubscriptionTimeoutException |
INTERNAL API
|
SubscriptionWithCancelException |
Not for user extension
|
SubscriptionWithCancelException.NoMoreElementsNeeded$ |
|
SubscriptionWithCancelException.NonFailureCancellation |
|
SubscriptionWithCancelException.StageWasCompleted$ |
|
SubscriptionWithCancelException$ |
Not for user extension
|
SubscriptionWithCursor<T> |
Do not increment directly, use `moreRequested(Long)` instead (it provides overflow protection)!
|
SubSink<T> |
INTERNAL API
|
SubSink.Cancel$ |
|
SubSink.CancelScheduledBeforeMaterialization$ |
|
SubSink.Command |
|
SubSink.CommandScheduledBeforeMaterialization |
|
SubSink.RequestOne$ |
|
SubSink.RequestOneScheduledBeforeMaterialization$ |
|
SubSink.State |
|
SubSink.Uninitialized$ |
|
SubSink$ |
Not yet materialized and no command has been scheduled
|
SubSource<T> |
INTERNAL API
|
SubSource<Out,Mat> |
Converts this Flow to its Scala DSL counterpart
|
SubSource$ |
* Upcast a stream of elements to a stream of supertypes of that element.
|
SubstreamCancelStrategies |
INTERNAL API
|
SubstreamCancelStrategies.Drain$ |
|
SubstreamCancelStrategies.Propagate$ |
|
SubstreamCancelStrategies$ |
INTERNAL API
|
SubstreamCancelStrategy |
Represents a strategy that decides how to deal with substream events.
|
SubstreamCancelStrategy$ |
Cancel the stream of streams if any substream is cancelled.
|
Supervise |
INTERNAL API
|
Supervise$ |
|
SupervisedGraphStageLogic |
INTERNAL API
|
Supervision |
Scala API: The stream will be completed with failure if application code for processing an element
throws an exception.
|
Supervision.Directive |
|
Supervision.Restart$ |
Scala API: The element is dropped and the stream continues after restarting the operator
if application code for processing an element throws an exception.
|
Supervision.Resume$ |
Scala API: The element is dropped and the stream continues if application code for processing
an element throws an exception.
|
Supervision.Stop$ |
|
Supervision$ |
Scala API: The stream will be completed with failure if application code for processing an element
throws an exception.
|
Supervisor |
INTERNAL API
|
Supervisor$ |
INTERNAL API
|
SupervisorStrategy |
Returns the Decider that is associated with this SupervisorStrategy.
|
SupervisorStrategy |
INTERNAL API
|
SupervisorStrategy.Backoff |
|
SupervisorStrategy.Backoff$ |
|
SupervisorStrategy.Directive |
|
SupervisorStrategy.Escalate$ |
|
SupervisorStrategy.Restart |
|
SupervisorStrategy.Restart$ |
|
SupervisorStrategy.Restart$ |
|
SupervisorStrategy.RestartOrBackoff |
|
SupervisorStrategy.Resume |
INTERNAL API
|
SupervisorStrategy.Resume$ |
|
SupervisorStrategy.Resume$ |
|
SupervisorStrategy.Stop |
|
SupervisorStrategy.Stop$ |
|
SupervisorStrategy.Stop$ |
|
SupervisorStrategy$ |
Resumes message processing for the failed Actor
|
SupervisorStrategy$ |
Resume means keeping the same state as before the exception was
thrown and is thus less safe than restart .
|
SupervisorStrategyConfigurator |
Implement this interface in order to configure the supervisorStrategy for
the top-level guardian actor (/user ).
|
SupervisorStrategyLowPriorityImplicits |
Implicit conversion from Seq of Cause-Directive pairs to a Decider .
|
SuppressedDeadLetter |
Similar to DeadLetter with the slight twist of NOT being logged by the default dead letters listener.
|
SuppressedDeadLetter$ |
|
Suspend |
INTERNAL API
|
Suspend$ |
|
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
|
Switch$ |
|
SynchronizedEventSink |
INTERNAL API
|
SystemGuardian |
For the purpose of orderly shutdown it's possible
to register interest in the termination of systemGuardian
and receive a notification TerminationHook
before systemGuardian is stopped.
|
SystemGuardian.RegisterTerminationHook$ |
|
SystemGuardian.TerminationHook$ |
|
SystemGuardian.TerminationHookDone$ |
|
SystemGuardian$ |
For the purpose of orderly shutdown it's possible
to register interest in the termination of systemGuardian
and receive a notification TerminationHook
before systemGuardian is stopped.
|
SystemLoadAverageMetricsSelector |
Java API: get the singleton instance
|
SystemLoadAverageMetricsSelector$ |
Java API: get the singleton instance
|
SystemMaterializer |
|
SystemMaterializer$ |
The system materializer is a default materializer to use for most cases running streams, it is a single instance
per actor system that is tied to the lifecycle of that system.
|
SystemMessage |
System messages are handled specially: they form their own queue within
each actor’s mailbox.
|
SystemMessage |
System messages are handled specially: they form their own queue within
each actor’s mailbox.
|
SystemMessageAcker |
INTERNAL API
|
SystemMessageAcker$ |
INTERNAL API
|
SystemMessageDelivery |
INTERNAL API
|
SystemMessageDelivery.Ack |
|
SystemMessageDelivery.Ack$ |
|
SystemMessageDelivery.AckedDeliveryMessage |
|
SystemMessageDelivery.ClearSystemMessageDelivery |
|
SystemMessageDelivery.ClearSystemMessageDelivery$ |
|
SystemMessageDelivery.GaveUpSystemMessageException |
|
SystemMessageDelivery.Nack |
|
SystemMessageDelivery.Nack$ |
|
SystemMessageDelivery.SystemMessageEnvelope |
|
SystemMessageDelivery.SystemMessageEnvelope$ |
|
SystemMessageDelivery$ |
Sent when an incarnation of an Association is quarantined.
|
SystemMessageFormats |
|
SystemMessageFormats.DeathWatchNotificationData |
Protobuf type DeathWatchNotificationData
|
SystemMessageFormats.DeathWatchNotificationData.Builder |
Protobuf type DeathWatchNotificationData
|
SystemMessageFormats.DeathWatchNotificationDataOrBuilder |
|
SystemMessageFormats.FailedData |
Protobuf type FailedData
|
SystemMessageFormats.FailedData.Builder |
Protobuf type FailedData
|
SystemMessageFormats.FailedDataOrBuilder |
|
SystemMessageFormats.SuperviseData |
Protobuf type SuperviseData
|
SystemMessageFormats.SuperviseData.Builder |
Protobuf type SuperviseData
|
SystemMessageFormats.SuperviseDataOrBuilder |
|
SystemMessageFormats.SystemMessage |
Protobuf type SystemMessage
|
SystemMessageFormats.SystemMessage.Builder |
Protobuf type SystemMessage
|
SystemMessageFormats.SystemMessage.Type |
Protobuf enum SystemMessage.Type
|
SystemMessageFormats.SystemMessageOrBuilder |
|
SystemMessageFormats.WatchData |
Protobuf type WatchData
|
SystemMessageFormats.WatchData.Builder |
Protobuf type WatchData
|
SystemMessageFormats.WatchDataOrBuilder |
|
SystemMessageList |
INTERNAL API
|
SystemMessageList |
INTERNAL API
|
SystemMessageList$ |
INTERNAL API
|
SystemMessageList$ |
INTERNAL API
|
SystemMessageQueue |
Enqueue a new system message, e.g.
|
SystemMessageSerializer |
|
Tagged |
Java API
|
Tagged$ |
|
TailChoppingGroup |
Java API
param: routeePaths string representation of the actor paths of the routees, messages are
sent with ActorSelection to these paths
param: within expecting at least one reply within this duration, otherwise
it will reply with AskTimeoutException in a Status.Failure
param: interval duration after which next routee will be picked
|
TailChoppingGroup$ |
|
TailChoppingPool |
Java API
param: nr initial number of routees in the pool
param: within expecting at least one reply within this duration, otherwise
it will reply with AskTimeoutException in a Status.Failure
param: interval duration after which next routee will be picked
|
TailChoppingPool$ |
|
TailChoppingRoutees |
INTERNAL API
|
TailChoppingRoutees$ |
|
TailChoppingRoutingLogic |
As each message is sent to the router, the routees are randomly ordered.
|
TailChoppingRoutingLogic$ |
|
Take<T> |
INTERNAL API
|
Take$ |
|
TakeLastStage<T> |
INTERNAL API
|
TakeWhile<T> |
INTERNAL API
|
TakeWhile$ |
|
TakeWithin<T> |
INTERNAL API
|
TargetRefNotInitializedYetException |
Java API: Get javadsl.Source underlying to this source ref.
|
TargetRefNotInitializedYetException$ |
|
TaskInvocation |
|
TaskInvocation$ |
|
TaskRunner |
INTERNAL API
|
TaskRunner.Add |
|
TaskRunner.Add$ |
|
TaskRunner.Command |
|
TaskRunner.CommandQueue |
|
TaskRunner.Remove |
|
TaskRunner.Remove$ |
|
TaskRunner.Shutdown$ |
|
TaskRunner$ |
A specialized collection with allocation free add, remove and iterate of
elements.
|
Tcp |
Java API: retrieve the Tcp extension for the given system.
|
Tcp |
Creates a Tcp.ServerBinding instance which represents a prospective TCP server binding on the given endpoint .
|
Tcp |
Creates a Tcp.ServerBinding instance which represents a prospective TCP server binding on the given endpoint .
|
Tcp.Abort$ |
|
Tcp.Aborted$ |
|
Tcp.Bind |
|
Tcp.Bind$ |
|
Tcp.Bound |
|
Tcp.Bound$ |
|
Tcp.Close$ |
|
Tcp.CloseCommand |
|
Tcp.Closed$ |
|
Tcp.Command |
|
Tcp.CommandFailed |
|
Tcp.CommandFailed$ |
|
Tcp.CompoundWrite |
|
Tcp.CompoundWrite$ |
|
Tcp.ConfirmedClose$ |
|
Tcp.ConfirmedClosed$ |
|
Tcp.Connect |
|
Tcp.Connect$ |
|
Tcp.Connected |
|
Tcp.Connected$ |
|
Tcp.ConnectionClosed |
|
Tcp.ErrorClosed |
|
Tcp.ErrorClosed$ |
|
Tcp.Event |
|
Tcp.IncomingConnection |
|
Tcp.IncomingConnection |
|
Tcp.IncomingConnection$ |
|
Tcp.Message |
|
Tcp.NoAck |
|
Tcp.NoAck$ |
|
Tcp.OutgoingConnection |
|
Tcp.OutgoingConnection |
|
Tcp.OutgoingConnection$ |
|
Tcp.PeerClosed$ |
|
Tcp.Received |
|
Tcp.Received$ |
|
Tcp.Register |
|
Tcp.Register$ |
|
Tcp.ResumeAccepting |
|
Tcp.ResumeAccepting$ |
|
Tcp.ResumeReading$ |
|
Tcp.ResumeWriting$ |
|
Tcp.ServerBinding |
|
Tcp.ServerBinding |
|
Tcp.ServerBinding$ |
|
Tcp.SimpleWriteCommand |
|
Tcp.SO$ |
|
Tcp.SuspendReading$ |
|
Tcp.Unbind$ |
|
Tcp.Unbound |
|
Tcp.Unbound$ |
|
Tcp.Write |
|
Tcp.Write$ |
|
Tcp.WriteCommand |
|
Tcp.WriteCommand$ |
|
Tcp.WriteFile |
Deprecated.
|
Tcp.WriteFile$ |
Deprecated.
|
Tcp.WritePath |
|
Tcp.WritePath$ |
|
Tcp.WritingResumed |
|
Tcp.WritingResumed$ |
|
Tcp$ |
Java API: retrieve the Tcp extension for the given system.
|
Tcp$ |
Represents a prospective TCP server binding.
|
Tcp$ |
Represents a successful TCP server binding.
|
TcpAssociationHandle |
INTERNAL API
|
TcpClientHandler |
INTERNAL API
|
TcpConnection |
connection established, waiting for registration from user handler
|
TcpConnection.AllRead$ |
|
TcpConnection.CloseInformation |
|
TcpConnection.CloseInformation$ |
|
TcpConnection.ConnectionInfo |
|
TcpConnection.ConnectionInfo$ |
|
TcpConnection.EmptyPendingWrite$ |
|
TcpConnection.EndOfStream$ |
|
TcpConnection.MoreDataWaiting$ |
|
TcpConnection.PendingWrite |
|
TcpConnection.ReadResult |
|
TcpConnection.Unregistered$ |
|
TcpConnection.UpdatePendingWriteAndThen |
|
TcpConnection.UpdatePendingWriteAndThen$ |
|
TcpConnection.WriteFileFailed |
|
TcpConnection.WriteFileFailed$ |
|
TcpConnection$ |
Used to transport information to the postStop method to notify
interested party about a connection close.
|
TcpConnectionStage |
Fail stage and report to localAddressPromise if still possible
|
TcpConnectionStage.Inbound |
|
TcpConnectionStage.Inbound$ |
|
TcpConnectionStage.Outbound |
|
TcpConnectionStage.Outbound$ |
|
TcpConnectionStage.TcpRole |
|
TcpConnectionStage.TcpStreamLogic |
|
TcpConnectionStage.WriteAck$ |
|
TcpConnectionStage$ |
Fail stage and report to localAddressPromise if still possible
|
TcpDnsClient |
INTERNAL API
|
TcpDnsClient$ |
|
TcpExt |
|
TcpFraming |
INTERNAL API
|
TcpFraming$ |
The first 4 bytes of a new connection must be these 0x64 0x75 0x75 0x64 (AKKA).
|
TcpHandlers |
INTERNAL API
|
TcpIdleTimeout |
INTERNAL API
|
TcpIdleTimeout$ |
INTERNAL API
|
TcpIdleTimeoutException |
Creates a Tcp.ServerBinding instance which represents a prospective TCP server binding on the given endpoint
handling the incoming connections through TLS and then run using the provided Flow.
|
TcpIncomingConnection |
An actor handling the connection state machine for an incoming, already connected
SocketChannel.
|
TcpListener |
INTERNAL API
|
TcpListener.FailedRegisterIncoming |
|
TcpListener.FailedRegisterIncoming$ |
|
TcpListener.RegisterIncoming |
|
TcpListener.RegisterIncoming$ |
|
TcpListener$ |
INTERNAL API
|
TcpManager |
INTERNAL API
|
TcpMessage |
The Connect message is sent to the TCP manager actor, which is obtained via
TcpExt.getManager() .
|
TcpMessage$ |
The Connect message is sent to the TCP manager actor, which is obtained via
TcpExt.getManager() .
|
TcpOutgoingConnection |
An actor handling the connection state machine for an outgoing connection
to be established.
|
TcpOutgoingConnection$ |
|
TcpServerHandler |
INTERNAL API
|
TcpSO |
|
TcpSO$ |
|
Terminate |
INTERNAL API
|
Terminate |
INTERNAL API
|
Terminate |
|
Terminate$ |
|
Terminate$ |
|
Terminate$ |
|
Terminated |
When Death Watch is used, the watcher will receive a Terminated(watched)
message when watched is terminated.
|
Terminated |
Java API: The actor that was watched and got terminated
|
Terminated$ |
|
Terminated$ |
|
TerminateMsg |
|
TerminateMsg$ |
|
TerminationSignal |
After calling KillSwitch#abort() the linked Graph s of FlowShape are failed.
|
TestActor |
INTERNAL API
|
TestActor.AutoPilot |
|
TestActor.DelegatingSupervisorStrategy |
INTERNAL API
|
TestActor.KeepRunning$ |
|
TestActor.Message |
|
TestActor.NoAutoPilot$ |
|
TestActor.NullMessage$ |
|
TestActor.RealMessage |
|
TestActor.RealMessage$ |
|
TestActor.SetAutoPilot |
|
TestActor.SetAutoPilot$ |
|
TestActor.SetIgnore |
|
TestActor.SetIgnore$ |
|
TestActor.Spawn |
|
TestActor.Spawn$ |
|
TestActor.UnWatch |
|
TestActor.UnWatch$ |
|
TestActor.Watch |
|
TestActor.Watch$ |
|
TestActor$ |
INTERNAL API
|
TestActorRef<T extends Actor> |
Directly inject messages into actor receive behavior.
|
TestActorRef$ |
Java API: create a TestActorRef in the given system for the given props,
with the given supervisor and name.
|
TestActors |
EchoActor sends back received messages (unmodified).
|
TestActors.BlackholeActor |
|
TestActors.EchoActor |
|
TestActors.ForwardActor |
|
TestActors$ |
EchoActor sends back received messages (unmodified).
|
TestAssociationHandle |
|
TestAssociationHandle$ |
|
TestBarrier |
|
TestBarrier$ |
A cyclic barrier wrapper for use in testing.
|
TestBarrierTimeoutException |
|
TestConductor |
Java API: retrieve the TestConductor extension for the given system.
|
TestConductor$ |
Java API: retrieve the TestConductor extension for the given system.
|
TestConductorExt |
Remote transport used by the actor ref provider.
|
TestConductorPipelineFactory |
INTERNAL API.
|
TestConductorProtocol |
|
TestConductorProtocol.Address |
Protobuf type Address
|
TestConductorProtocol.Address.Builder |
Protobuf type Address
|
TestConductorProtocol.AddressOrBuilder |
|
TestConductorProtocol.AddressRequest |
Protobuf type AddressRequest
|
TestConductorProtocol.AddressRequest.Builder |
Protobuf type AddressRequest
|
TestConductorProtocol.AddressRequestOrBuilder |
|
TestConductorProtocol.BarrierOp |
Protobuf enum BarrierOp
|
TestConductorProtocol.Direction |
Protobuf enum Direction
|
TestConductorProtocol.EnterBarrier |
Protobuf type EnterBarrier
|
TestConductorProtocol.EnterBarrier.Builder |
Protobuf type EnterBarrier
|
TestConductorProtocol.EnterBarrierOrBuilder |
|
TestConductorProtocol.FailType |
Protobuf enum FailType
|
TestConductorProtocol.Hello |
Protobuf type Hello
|
TestConductorProtocol.Hello.Builder |
Protobuf type Hello
|
TestConductorProtocol.HelloOrBuilder |
|
TestConductorProtocol.InjectFailure |
Protobuf type InjectFailure
|
TestConductorProtocol.InjectFailure.Builder |
Protobuf type InjectFailure
|
TestConductorProtocol.InjectFailureOrBuilder |
|
TestConductorProtocol.Wrapper |
Protobuf type Wrapper
|
TestConductorProtocol.Wrapper.Builder |
Protobuf type Wrapper
|
TestConductorProtocol.WrapperOrBuilder |
|
TestEvent |
Implementation helpers of the EventFilter facilities: send Mute
to the TestEventListener to install a filter, and UnMute to
uninstall it.
|
TestEvent.Mute |
|
TestEvent.Mute$ |
|
TestEvent.UnMute |
|
TestEvent.UnMute$ |
|
TestEvent$ |
Java API: create a Mute command from a list of filters
|
TestEventListener |
EventListener for running tests, which allows selectively filtering out
expected messages.
|
TestException |
A predefined exception that can be used in tests.
|
TestException$ |
|
TestFSMRef<S,D,T extends Actor> |
Get current state name of this FSM.
|
TestFSMRef$ |
|
TestInbox<T> |
The actor ref of the inbox
|
TestInbox<T> |
The actor ref of the inbox
|
TestInbox$ |
|
TestInbox$ |
|
TestInboxImpl<T> |
INTERNAL API
|
TestKit |
All the Java APIs are delegated to TestProbe
|
TestKit |
Test kit for testing actors.
|
TestKit$ |
Shut down an actor system and wait for termination.
|
TestKit$ |
Await until the given condition evaluates to true or the timeout
expires, whichever comes first.
|
TestKitBase |
Defines the testActor name.
|
TestKitExtension |
|
TestKitExtension$ |
|
TestKitJunitResource |
Use a custom config for the actor system.
|
TestKitSettings |
dilated with `TestTimeFactor`
|
TestKitSettings |
|
TestKitSettings$ |
Reads configuration settings from akka.actor.testkit.typed section.
|
TestKitUtils |
Sanitize the name to be used as valid actor system name by
replacing invalid characters.
|
TestKitUtils$ |
Sanitize the name to be used as valid actor system name by
replacing invalid characters.
|
TestLatch |
|
TestLatch$ |
A count down latch wrapper for use in testing.
|
TestManagementCommands |
INTERNAL API
|
TestManagementCommands.FailInboundStreamOnce |
|
TestManagementCommands.FailInboundStreamOnce$ |
|
TestManagementCommands$ |
INTERNAL API
|
TestMessageSerializer |
This Serializer uses standard Java Serialization and is useful for tests where ad-hoc messages are created and sent
between actor systems.
|
TestPayload |
|
TestPayload$ |
|
TestProbe<M> |
ActorRef for this TestProbe
|
TestProbe<M> |
ActorRef for this TestProbe
|
TestProbe |
Shorthand to get the testActor.
|
TestProbe$ |
Fail fishing with a custom error message
|
TestProbe$ |
Fail fishing with a custom error message
|
TestProbe$ |
Send message to the sender of the last dequeued message.
|
TestProbeImpl<M> |
if last assertion was expectNoMessage, disable timing failure upon within()
block end.
|
TestProbeImpl$ |
|
TestPublisher |
Publisher that signals complete to subscribers, after handing a void subscription.
|
TestPublisher.CancelSubscription |
|
TestPublisher.CancelSubscription$ |
|
TestPublisher.ManualProbe<I> |
Subscribes a given Subscriber to this probe publisher.
|
TestPublisher.ManualProbe$ |
|
TestPublisher.Probe<T> |
|
TestPublisher.PublisherEvent |
|
TestPublisher.RequestMore |
|
TestPublisher.RequestMore$ |
|
TestPublisher.Subscribe |
|
TestPublisher.Subscribe$ |
|
TestPublisher.SubscriptionDone$ |
|
TestPublisher$ |
Publisher that signals complete to subscribers, after handing a void subscription.
|
TestSerializer |
|
TestSink |
|
TestSink |
|
TestSink$ |
|
TestSink$ |
|
TestSinkStage<T,M> |
Creates a sink out of the stageUnderTest that will inform the probe
of operator events and callbacks by sending it the various messages found under
GraphStageMessages .
|
TestSinkStage$ |
Creates a sink out of the stageUnderTest that will inform the probe
of operator events and callbacks by sending it the various messages found under
GraphStageMessages .
|
TestSource |
|
TestSource |
|
TestSource$ |
|
TestSource$ |
|
TestSourceStage<T,M> |
Creates a source out of the stageUnderTest that will inform the probe
of operator events and callbacks by sending it the various messages found under
GraphStageMessages .
|
TestSourceStage$ |
Creates a source out of the stageUnderTest that will inform the probe
of operator events and callbacks by sending it the various messages found under
GraphStageMessages .
|
TestState |
INTERNAL API
|
TestState$ |
|
TestSubscriber |
Probe that implements Subscriber interface.
|
TestSubscriber.ManualProbe<I> |
Expect and return a Subscription .
|
TestSubscriber.OnComplete$ |
|
TestSubscriber.OnError |
|
TestSubscriber.OnError$ |
|
TestSubscriber.OnNext<I> |
|
TestSubscriber.OnNext$ |
|
TestSubscriber.OnSubscribe |
|
TestSubscriber.OnSubscribe$ |
|
TestSubscriber.Probe<T> |
|
TestSubscriber.SubscriberEvent |
|
TestSubscriber$ |
Probe that implements Subscriber interface.
|
TestTransport |
|
TestTransport.Activity |
|
TestTransport.AssociateAttempt |
|
TestTransport.AssociateAttempt$ |
|
TestTransport.AssociationRegistry |
|
TestTransport.DisassociateAttempt |
|
TestTransport.DisassociateAttempt$ |
|
TestTransport.ListenAttempt |
|
TestTransport.ListenAttempt$ |
|
TestTransport.ShutdownAttempt |
|
TestTransport.ShutdownAttempt$ |
|
TestTransport.SwitchableLoggedBehavior<A,B> |
Changes the current behavior to the provided one.
|
TestTransport.WriteAttempt |
|
TestTransport.WriteAttempt$ |
|
TestTransport$ |
Test utility to make behavior of functions that return some Future[B] controllable from tests.
|
ThisActorSystemQuarantinedEvent |
|
ThisActorSystemQuarantinedEvent$ |
|
ThreadLocalRandom |
A random number generator isolated to the current thread.
|
ThreadPoolConfig |
|
ThreadPoolConfig$ |
|
ThreadPoolConfigBuilder |
A DSL to configure and create a MessageDispatcher with a ThreadPoolExecutor
|
ThreadPoolConfigBuilder$ |
|
ThreadPoolExecutorConfigurator |
Returns an instance of MessageDispatcher given the configuration.
|
Throttle |
|
Throttle<T> |
INTERNAL API
|
Throttle$ |
|
Throttle$ |
INTERNAL API
|
ThrottledAssociation |
INTERNAL API
|
ThrottledAssociation.Dequeue$ |
|
ThrottledAssociation.ExposedHandle |
|
ThrottledAssociation.ExposedHandle$ |
|
ThrottledAssociation.FailWith |
|
ThrottledAssociation.FailWith$ |
|
ThrottledAssociation.ThrottlerData |
|
ThrottledAssociation.ThrottlerState |
|
ThrottledAssociation.Throttling$ |
|
ThrottledAssociation.Uninitialized$ |
|
ThrottledAssociation.WaitExposedHandle$ |
|
ThrottledAssociation.WaitMode$ |
|
ThrottledAssociation.WaitModeAndUpstreamListener$ |
|
ThrottledAssociation.WaitOrigin$ |
|
ThrottledAssociation.WaitUpstreamListener$ |
|
ThrottledAssociation$ |
INTERNAL API
|
ThrottleMode |
Represents a mode that decides how to deal exceed rate for Throttle operator
|
ThrottleMode.Enforcing$ |
|
ThrottleMode.Shaping$ |
|
ThrottleMode$ |
Tells throttle to make pauses before emitting messages to meet throttle rate
|
ThrottleMsg |
|
ThrottleMsg$ |
|
Throttler |
Deprecated.
|
Throttler.Rate |
|
Throttler.Rate$ |
|
Throttler.RateInt |
|
Throttler.RateInt$ |
|
Throttler.SetRate |
|
Throttler.SetRate$ |
|
Throttler.SetTarget |
|
Throttler.SetTarget$ |
|
Throttler$ |
Deprecated.
|
ThrottlerHandle |
INTERNAL API
|
ThrottlerHandle$ |
|
ThrottlerManager |
INTERNAL API
|
ThrottlerManager.AssociateResult |
|
ThrottlerManager.AssociateResult$ |
|
ThrottlerManager.Checkin |
|
ThrottlerManager.Checkin$ |
|
ThrottlerManager.Handle |
|
ThrottlerManager.Handle$ |
|
ThrottlerManager.Listener |
|
ThrottlerManager.Listener$ |
|
ThrottlerManager.ListenerAndMode |
|
ThrottlerManager.ListenerAndMode$ |
|
ThrottlerManager$ |
INTERNAL API
|
ThrottlerProvider |
|
ThrottlerTransportAdapter |
Java API: get the ThrottleMode.Unthrottled instance
|
ThrottlerTransportAdapter.Blackhole$ |
|
ThrottlerTransportAdapter.Direction |
|
ThrottlerTransportAdapter.Direction$ |
|
ThrottlerTransportAdapter.Direction$.Both$ |
|
ThrottlerTransportAdapter.Direction$.Receive$ |
|
ThrottlerTransportAdapter.Direction$.Send$ |
|
ThrottlerTransportAdapter.ForceDisassociate |
|
ThrottlerTransportAdapter.ForceDisassociate$ |
|
ThrottlerTransportAdapter.ForceDisassociateAck$ |
|
ThrottlerTransportAdapter.ForceDisassociateExplicitly |
|
ThrottlerTransportAdapter.ForceDisassociateExplicitly$ |
|
ThrottlerTransportAdapter.SetThrottle |
|
ThrottlerTransportAdapter.SetThrottle$ |
|
ThrottlerTransportAdapter.SetThrottleAck$ |
|
ThrottlerTransportAdapter.ThrottleMode |
|
ThrottlerTransportAdapter.TokenBucket |
|
ThrottlerTransportAdapter.TokenBucket$ |
|
ThrottlerTransportAdapter.Unthrottled$ |
|
ThrottlerTransportAdapter$ |
Java API: get the singleton instance
|
ThrowableNotSerializableException |
Use as replacement for an original exception when it can't be serialized or deserialized.
|
Throwables |
Returns true if the provided Throwable is to be considered non-fatal,
or false if it is to be considered fatal
|
Throwables$ |
Returns true if the provided Throwable is to be considered non-fatal,
or false if it is to be considered fatal
|
ThrowableSupport |
INTERNAL API
|
ThrowExceptionConfigurator |
|
ThrowOnOverflowRejectionHandler |
INTERNAL API
|
ThrowOverflowExceptionStrategy |
Java API: get the singleton instance
|
ThrowOverflowExceptionStrategy$ |
Java API: get the singleton instance
|
TimeBasedUUID |
Corresponds to an ordered unique identifier of the events.
|
TimeBasedUUID$ |
|
Timed |
Deprecated.
|
Timed.StartTimed<T> |
|
Timed.StopTimed<T> |
|
Timed.TimedFlowContext |
|
Timed.TimedInterval<T> |
|
Timed$ |
Deprecated.
|
TimedIntervalBetweenOps |
Measures rolling interval between immediately subsequent matching(o: O) elements.
|
TimedOps |
INTERNAL API
|
Timeout |
Construct a Timeout from the given time unit and factor.
|
Timeout$ |
A timeout with zero duration, will cause most requests to always timeout.
|
TimeoutSettings |
Java API
|
TimeoutSettings$ |
|
TimerBasedThrottler |
Deprecated.
|
TimerBasedThrottler.Active$ |
|
TimerBasedThrottler.Data |
|
TimerBasedThrottler.Data$ |
|
TimerBasedThrottler.Idle$ |
|
TimerBasedThrottler.Message |
|
TimerBasedThrottler.Message$ |
|
TimerBasedThrottler.State |
|
TimerBasedThrottler.Tick$ |
|
TimerBasedThrottler$ |
Deprecated.
|
TimerGraphStageLogic |
Will be called when the scheduled timer is triggered.
|
TimerGraphStageLogicWithLogging |
|
TimerKeys |
INTERNAL API
|
TimerKeys.DropWithinTimerKey$ |
|
TimerKeys.GroupedWithinTimerKey$ |
|
TimerKeys.TakeWithinTimerKey$ |
|
TimerKeys$ |
INTERNAL API
|
TimerMessages |
|
TimerMessages.Scheduled |
|
TimerMessages.Scheduled$ |
|
TimerMessages.Timer |
|
TimerMessages.Timer$ |
|
TimerMessages$ |
|
Timers |
Start and cancel timers via the enclosed TimerScheduler .
|
Timers |
Given a timeout computes how often the check should be run without causing
excessive load or losing timeout precision.
|
Timers.BackpressureTimeout<T> |
|
Timers.Completion<T> |
|
Timers.DelayInitial<T> |
|
Timers.GraphStageLogicTimer$ |
|
Timers.Idle<T> |
|
Timers.IdleInject<I,O> |
|
Timers.IdleTimeoutBidi<I,O> |
|
Timers.Initial<T> |
|
Timers$ |
Given a timeout computes how often the check should be run without causing
excessive load or losing timeout precision.
|
TimerScheduler |
Start a periodic timer that will send msg to the self actor at
a fixed interval .
|
TimerScheduler<T> |
Start a periodic timer that will send msg to the self actor at
a fixed interval .
|
TimerScheduler<T> |
Start a periodic timer that will send msg to the self actor at
a fixed interval .
|
TimerSchedulerImpl |
INTERNAL API
|
TimerSchedulerImpl<T> |
INTERNAL API
|
TimerSchedulerImpl.InfluenceReceiveTimeoutTimerMsg |
|
TimerSchedulerImpl.InfluenceReceiveTimeoutTimerMsg$ |
|
TimerSchedulerImpl.NotInfluenceReceiveTimeoutTimerMsg |
|
TimerSchedulerImpl.NotInfluenceReceiveTimeoutTimerMsg$ |
|
TimerSchedulerImpl.Timer |
|
TimerSchedulerImpl.Timer<T> |
|
TimerSchedulerImpl.Timer$ |
|
TimerSchedulerImpl.Timer$ |
|
TimerSchedulerImpl.TimerMsg |
|
TimerSchedulerImpl.TimerMsg |
|
TimerSchedulerImpl$ |
INTERNAL API
|
TimerSchedulerImpl$ |
INTERNAL API
|
TLS |
Create a StreamTls BidiFlow in client mode.
|
TLS |
|
TLS$ |
Create a StreamTls BidiFlow in client mode.
|
TLS$ |
|
TLSActor |
The SSLEngine needs bite-sized chunks of data but we get arbitrary ByteString
from both the UserIn and the TransportIn ports.
|
TLSActor$ |
INTERNAL API.
|
TLSClientAuth |
An SSLEngine can either demand, allow or ignore its peer’s authentication
(via certificates), where Need will fail the handshake if the peer does
not provide valid credentials, Want allows the peer to send credentials
and verifies them if provided, and None disables peer certificate
verification.
|
TLSClientAuth.Need$ |
|
TLSClientAuth.None$ |
|
TLSClientAuth.Want$ |
|
TLSClientAuth$ |
|
TLSClosing |
All streams in Akka are unidirectional: while in a complex flow graph data
may flow in multiple directions these individual flows are independent from
each other.
|
TLSClosing$ |
|
TlsModule |
INTERNAL API.
|
TlsModule$ |
INTERNAL API.
|
TlsModuleIslandTag |
INTERNAL API
|
TlsModuleIslandTag$ |
INTERNAL API
|
TlsModulePhase |
INTERNAL API
|
TLSPlacebo |
|
TLSPlacebo |
This object holds simple wrapping BidiFlow implementations that can
be used instead of TLS when no encryption is desired.
|
TLSPlacebo$ |
|
TLSPlacebo$ |
This object holds simple wrapping BidiFlow implementations that can
be used instead of TLS when no encryption is desired.
|
TLSProtocol |
This is the supertype of all messages that the SslTls operator emits on the
plaintext side.
|
TLSProtocol.NegotiateNewSession |
|
TLSProtocol.NegotiateNewSession$ |
|
TLSProtocol.SendBytes |
Send the given ByteString across the encrypted session to the
peer.
|
TLSProtocol.SendBytes$ |
|
TLSProtocol.SessionBytes |
|
TLSProtocol.SessionBytes$ |
|
TLSProtocol.SessionTruncated |
|
TLSProtocol.SessionTruncated$ |
|
TLSProtocol.SslTlsInbound |
|
TLSProtocol.SslTlsOutbound |
|
TLSProtocol$ |
This is the supertype of all messages that the SslTls operator emits on the
plaintext side.
|
TLSRole |
Java API: obtain the Server singleton value.
|
TLSRole$ |
Java API: obtain the Client singleton value.
|
TlsUtils |
INTERNAL API
|
TlsUtils$ |
INTERNAL API
|
ToClient |
|
ToClient$ |
|
TokenBucket |
This method must be called before the token bucket can be used.
|
TooManySubstreamsOpenException |
This exception signals that the maximum number of substreams declared has been exceeded.
|
TopHeavyHitters<T> |
Iterates over the current heavy hitters, order is not of significance.
|
TopHeavyHitters.HashCodeVal |
|
TopHeavyHitters.HashCodeVal$ |
|
TopHeavyHitters$ |
Value class to avoid mixing up count and hashCode in APIs.
|
ToServer |
|
ToServer$ |
|
TransferPhase |
INTERNAL API
|
TransferPhase$ |
|
TransferQueue<E> |
A BlockingQueue in which producers may wait for consumers
to receive elements.
|
TransferState |
INTERNAL API
|
Transform |
INTERNAL API
|
Transform$ |
|
Transport |
Returns a string that will be used as the scheme part of the URLs corresponding to this transport
|
Transport.ActorAssociationEventListener |
|
Transport.ActorAssociationEventListener$ |
|
Transport.AssociationEvent |
|
Transport.AssociationEventListener |
|
Transport.InboundAssociation |
|
Transport.InboundAssociation$ |
|
Transport.InvalidAssociationException |
|
Transport.InvalidAssociationException$ |
|
Transport$ |
Indicates that the association setup request is invalid, and it is impossible to recover (malformed IP address,
hostname, etc.).
|
TransportAdapterProvider |
Create the transport adapter that wraps an underlying transport.
|
TransportAdapters |
Create the transport adapter that wraps an underlying transport.
|
TransportAdaptersExtension |
|
TransportAdaptersExtension$ |
|
TraversableOnceExtensionMethods<A> |
Get a Builder for the collection.
|
TraversableOnceExtensionMethods$ |
|
Traversal |
Concatenates two traversals building a new Traversal which traverses both.
|
TraversalBuilder |
Adds a module to the builder.
|
TraversalBuilder$ |
INTERNAL API
|
TraversalBuildStep |
INTERNAL API
|
TryNative |
INTERNAL API
|
TryNative$ |
INTERNAL API
|
Tuple10<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10> |
|
Tuple10$ |
Used to create tuples with 10 elements in Java.
|
Tuple11<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11> |
|
Tuple11$ |
Used to create tuples with 11 elements in Java.
|
Tuple12<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12> |
|
Tuple12$ |
Used to create tuples with 12 elements in Java.
|
Tuple13<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13> |
|
Tuple13$ |
Used to create tuples with 13 elements in Java.
|
Tuple14<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14> |
|
Tuple14$ |
Used to create tuples with 14 elements in Java.
|
Tuple15<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15> |
|
Tuple15$ |
Used to create tuples with 15 elements in Java.
|
Tuple16<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16> |
|
Tuple16$ |
Used to create tuples with 16 elements in Java.
|
Tuple17<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17> |
|
Tuple17$ |
Used to create tuples with 17 elements in Java.
|
Tuple18<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18> |
|
Tuple18$ |
Used to create tuples with 18 elements in Java.
|
Tuple19<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19> |
|
Tuple19$ |
Used to create tuples with 19 elements in Java.
|
Tuple20<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20> |
|
Tuple20$ |
Used to create tuples with 20 elements in Java.
|
Tuple21<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21> |
|
Tuple21$ |
Used to create tuples with 21 elements in Java.
|
Tuple22<T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22> |
|
Tuple22$ |
Used to create tuples with 22 elements in Java.
|
Tuple3<T1,T2,T3> |
|
Tuple3$ |
Used to create tuples with 3 elements in Java.
|
Tuple4<T1,T2,T3,T4> |
|
Tuple4$ |
Used to create tuples with 4 elements in Java.
|
Tuple5<T1,T2,T3,T4,T5> |
|
Tuple5$ |
Used to create tuples with 5 elements in Java.
|
Tuple6<T1,T2,T3,T4,T5,T6> |
|
Tuple6$ |
Used to create tuples with 6 elements in Java.
|
Tuple7<T1,T2,T3,T4,T5,T6,T7> |
|
Tuple7$ |
Used to create tuples with 7 elements in Java.
|
Tuple8<T1,T2,T3,T4,T5,T6,T7,T8> |
|
Tuple8$ |
Used to create tuples with 8 elements in Java.
|
Tuple9<T1,T2,T3,T4,T5,T6,T7,T8,T9> |
|
Tuple9$ |
Used to create tuples with 9 elements in Java.
|
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.
|
TypedActor.MethodCall |
Invokes the Method on the supplied instance
|
TypedActor.MethodCall$ |
|
TypedActor.PostRestart |
|
TypedActor.PostStop |
|
TypedActor.PreRestart |
|
TypedActor.PreStart |
|
TypedActor.Receiver |
|
TypedActor.SerializedMethodCall |
|
TypedActor.SerializedMethodCall$ |
|
TypedActor.SerializedTypedActorInvocationHandler |
|
TypedActor.SerializedTypedActorInvocationHandler$ |
|
TypedActor.Supervisor |
|
TypedActor.TypedActorInvocationHandler |
|
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.
|
TypedActorContext<T> |
Get the javadsl of this ActorContext .
|
TypedActorExtension |
Default timeout for typed actor methods with non-void return type
|
TypedActorFactory |
Underlying dependency is to be able to create normal Actors
|
TypedCreatorFunctionConsumer |
INTERNAL API
|
TypedMultiMap<T,K> |
Return the set of keys which are mapped to non-empty value sets.
|
TypedMultiMap$ |
Obtain the empty map for the given key type and key–value type function.
|
TypedProps<T> |
|
TypedProps$ |
|
Udp |
Java API: retrieve the Udp extension for the given system.
|
Udp.Bind |
|
Udp.Bind$ |
|
Udp.Bound |
|
Udp.Bound$ |
|
Udp.Command |
|
Udp.CommandFailed |
|
Udp.CommandFailed$ |
|
Udp.Event |
|
Udp.Message |
|
Udp.NoAck |
|
Udp.NoAck$ |
|
Udp.Received |
|
Udp.Received$ |
|
Udp.ResumeReading$ |
|
Udp.Send |
|
Udp.Send$ |
|
Udp.SimpleSender |
|
Udp.SimpleSender$ |
|
Udp.SimpleSenderReady |
|
Udp.SimpleSenderReady$ |
|
Udp.SO$ |
|
Udp.SuspendReading$ |
|
Udp.UdpSettings |
|
Udp.Unbind$ |
|
Udp.Unbound |
|
Udp.Unbound$ |
|
Udp$ |
Java API: retrieve the Udp extension for the given system.
|
UdpAssociationHandle |
INTERNAL API
|
UdpClientHandler |
Deprecated.
|
UdpConnected |
Java API: retrieve the UdpConnected extension for the given system.
|
UdpConnected.Command |
|
UdpConnected.CommandFailed |
|
UdpConnected.CommandFailed$ |
|
UdpConnected.Connect |
|
UdpConnected.Connect$ |
|
UdpConnected.Connected |
|
UdpConnected.Connected$ |
|
UdpConnected.Disconnect$ |
|
UdpConnected.Disconnected |
|
UdpConnected.Disconnected$ |
|
UdpConnected.Event |
|
UdpConnected.Message |
|
UdpConnected.NoAck |
|
UdpConnected.NoAck$ |
|
UdpConnected.Received |
|
UdpConnected.Received$ |
|
UdpConnected.ResumeReading$ |
|
UdpConnected.Send |
|
UdpConnected.Send$ |
|
UdpConnected.SuspendReading$ |
|
UdpConnected$ |
Java API: retrieve the UdpConnected extension for the given system.
|
UdpConnectedExt |
Java API: retrieve the UDP manager actor’s reference.
|
UdpConnectedManager |
INTERNAL API
|
UdpConnectedMessage |
Send this message to the UdpExt.manager() in order to bind to a local
port (optionally with the chosen localAddress ) and create a UDP socket
which is restricted to sending to and receiving from the given remoteAddress .
|
UdpConnectedMessage$ |
Send this message to the UdpExt.manager() in order to bind to a local
port (optionally with the chosen localAddress ) and create a UDP socket
which is restricted to sending to and receiving from the given remoteAddress .
|
UdpConnection |
INTERNAL API
|
UdpExt |
Java API: retrieve the UDP manager actor’s reference.
|
UdpHandlers |
Deprecated.
|
UdpListener |
INTERNAL API
|
UdpManager |
INTERNAL API
|
UdpMessage |
Each Udp.Send can optionally request a positive acknowledgment to be sent
to the commanding actor.
|
UdpMessage$ |
Each Udp.Send can optionally request a positive acknowledgment to be sent
to the commanding actor.
|
UdpSender |
INTERNAL API
|
UdpServerHandler |
Deprecated.
|
UdpSO |
|
UdpSO$ |
|
UnboundedControlAwareMailbox |
UnboundedControlAwareMailbox is an unbounded MailboxType, that maintains two queues
to allow messages that extend ControlMessage to be delivered with priority.
|
UnboundedControlAwareMailbox.MessageQueue |
|
UnboundedControlAwareMailbox$ |
|
UnboundedControlAwareMessageQueueSemantics |
|
UnboundedDequeBasedMailbox |
UnboundedDequeBasedMailbox is an unbounded MailboxType, backed by a Deque.
|
UnboundedDequeBasedMailbox.MessageQueue |
|
UnboundedDequeBasedMailbox$ |
|
UnboundedDequeBasedMessageQueue |
UnboundedDequeBasedMessageQueueSemantics adds unbounded semantics to a DequeBasedMessageQueue,
i.e.
|
UnboundedDequeBasedMessageQueueSemantics |
|
UnboundedMailbox |
UnboundedMailbox is the default unbounded MailboxType used by Akka Actors.
|
UnboundedMailbox.MessageQueue |
|
UnboundedMailbox$ |
|
UnboundedMessageQueueSemantics |
UnboundedMessageQueueSemantics adds unbounded semantics to a QueueBasedMessageQueue,
i.e.
|
UnboundedPriorityMailbox |
UnboundedPriorityMailbox is an unbounded mailbox that allows for prioritization of its contents.
|
UnboundedPriorityMailbox.MessageQueue |
|
UnboundedPriorityMailbox$ |
|
UnboundedQueueBasedMessageQueue |
|
UnboundedStablePriorityMailbox |
UnboundedStablePriorityMailbox is an unbounded mailbox that allows for prioritization of its contents.
|
UnboundedStablePriorityMailbox.MessageQueue |
|
UnboundedStablePriorityMailbox$ |
|
UnboundedStash |
The UnboundedStash trait is a version of Stash that enforces an unbounded stash for you actor.
|
UnconfirmedClientOp |
|
UndefinedUidActorRef |
Starts subscription to AddressTerminated if not already subscribing and the
block adds a non-local ref to watching or watchedBy.
|
Unfold<S,E> |
INTERNAL API
|
UnfoldAsync<S,E> |
INTERNAL API
|
UnfoldResourceSource<T,S> |
INTERNAL API
|
UnfoldResourceSourceAsync<T,S> |
INTERNAL API
|
Unhandled |
INTERNAL API
|
Unhandled$ |
INTERNAL API
|
UnhandledMessage |
This message is published to the EventStream whenever an Actor receives a message it doesn't understand
|
UnhandledMessage$ |
|
UniformFanInShape<T,O> |
|
UniformFanInShape$ |
|
UniformFanOutShape<I,O> |
|
UniformFanOutShape$ |
|
UninitializedInterpreter |
A stream interpreter that was not yet initialized when the snapshot was taken
|
UninitializedInterpreterImpl |
INTERNAL API
|
UninitializedInterpreterImpl$ |
|
UniqueAddress |
|
UniqueAddress |
|
UniqueAddress$ |
INTERNAL API
|
UniqueAddress$ |
|
UniqueKillSwitch |
|
UnitCaseStatement<F,P> |
|
UnitMatch<I> |
Version of PartialFunction that can be built during runtime from Java.
|
UnitPFBuilder<I> |
A builder for PartialFunction .
|
UnknownCompressedIdException |
INTERNAL API
|
UnknownRecord |
INTERNAL API
|
UnknownRecord$ |
INTERNAL API
|
UnregisteringLogService |
Message sent when LogService is unregistered.
|
UnregisteringLogService$ |
Message sent when LogService is unregistered.
|
UnrestrictedStash |
Overridden callback.
|
Unsafe |
INTERNAL API
|
UnstartedCell |
Method for looking up a single child beneath this actor.
|
UnstashAll |
INTERNAL API
|
UnstashAll$ |
INTERNAL API
|
UnstashException<T> |
|
UnstashException$ |
INTERNAL API
|
Unsubscribe<T> |
|
Unsubscribe$ |
|
UnsubscribeClusterClients |
Java API: get the singleton instance
|
UnsubscribeClusterClients$ |
Java API: get the singleton instance
|
UnsubscribeContactPoints |
Java API: get the singleton instance
|
UnsubscribeContactPoints$ |
Java API: get the singleton instance
|
UnsupportedAkkaVersion |
|
UntypedAbstractActor |
To be implemented by concrete UntypedAbstractActor, this defines the behavior of the
actor.
|
UntypedActor |
Deprecated.
|
UntypedActorContext |
Deprecated.
|
UntypedActorPublisher<T> |
Deprecated.
|
UntypedActorPublisher$ |
Deprecated.
|
UntypedActorSubscriber |
Deprecated.
|
UntypedActorSubscriber$ |
Deprecated.
|
UntypedActorWithStash |
Deprecated.
|
UntypedActorWithUnboundedStash |
Deprecated.
|
UntypedActorWithUnrestrictedStash |
Deprecated.
|
UntypedConsumerActor |
Java API: Returns the Camel endpoint URI to consume messages from.
|
UntypedPersistentActor |
Deprecated.
|
UntypedPersistentActorWithAtLeastOnceDelivery |
Deprecated.
|
UntypedProducerActor |
Called before the message is sent to the endpoint specified by getEndpointUri .
|
unused |
Marker for explicit or implicit parameter known to be unused, yet
still necessary from a binary compatibility perspective
or other reason.
|
Unwatch |
INTERNAL API
|
Unwatch |
INTERNAL API
|
Unwatch$ |
|
Unwatch$ |
|
Unzip |
INTERNAL API
|
Unzip |
Creates a new Unzip operator with the specified output types.
|
Unzip<A,B> |
Takes a stream of pair elements and splits each pair to two output streams.
|
Unzip$ |
INTERNAL API
|
Unzip$ |
Creates a new Unzip operator with the specified output types.
|
Unzip$ |
Create a new Unzip .
|
UnzipWith |
Create a new UnzipWith vertex with the specified input type and unzipping-function f .
|
UnzipWith |
Transforms each element of input stream into multiple streams using a splitter function.
|
UnzipWith$ |
Create a new UnzipWith vertex with the specified input type and unzipping-function f .
|
UnzipWith$ |
Transforms each element of input stream into multiple streams using a splitter function.
|
UnzipWith10<In,A1,A2,A3,A4,A5,A6,A7,A8,A9,A10> |
`UnzipWith` specialized for 10 outputs
|
UnzipWith11<In,A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11> |
`UnzipWith` specialized for 11 outputs
|
UnzipWith12<In,A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12> |
`UnzipWith` specialized for 12 outputs
|
UnzipWith13<In,A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13> |
`UnzipWith` specialized for 13 outputs
|
UnzipWith14<In,A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14> |
`UnzipWith` specialized for 14 outputs
|
UnzipWith15<In,A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15> |
`UnzipWith` specialized for 15 outputs
|
UnzipWith16<In,A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16> |
`UnzipWith` specialized for 16 outputs
|
UnzipWith17<In,A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16,A17> |
`UnzipWith` specialized for 17 outputs
|
UnzipWith18<In,A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16,A17,A18> |
`UnzipWith` specialized for 18 outputs
|
UnzipWith19<In,A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16,A17,A18,A19> |
`UnzipWith` specialized for 19 outputs
|
UnzipWith2<In,A1,A2> |
`UnzipWith` specialized for 2 outputs
|
UnzipWith20<In,A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16,A17,A18,A19,A20> |
`UnzipWith` specialized for 20 outputs
|
UnzipWith21<In,A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16,A17,A18,A19,A20,A21> |
`UnzipWith` specialized for 21 outputs
|
UnzipWith22<In,A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16,A17,A18,A19,A20,A21,A22> |
`UnzipWith` specialized for 22 outputs
|
UnzipWith3<In,A1,A2,A3> |
`UnzipWith` specialized for 3 outputs
|
UnzipWith4<In,A1,A2,A3,A4> |
`UnzipWith` specialized for 4 outputs
|
UnzipWith5<In,A1,A2,A3,A4,A5> |
`UnzipWith` specialized for 5 outputs
|
UnzipWith6<In,A1,A2,A3,A4,A5,A6> |
`UnzipWith` specialized for 6 outputs
|
UnzipWith7<In,A1,A2,A3,A4,A5,A6,A7> |
`UnzipWith` specialized for 7 outputs
|
UnzipWith8<In,A1,A2,A3,A4,A5,A6,A7,A8> |
`UnzipWith` specialized for 8 outputs
|
UnzipWith9<In,A1,A2,A3,A4,A5,A6,A7,A8,A9> |
`UnzipWith` specialized for 9 outputs
|
UnzipWithApply |
Create a new UnzipWith specialized for 2 outputs.
|
UnzipWithApply.UnzipWithCreator<In,Out,T> |
|
UnzipWithApply.UnzipWithCreator10<In,A1,A2,A3,A4,A5,A6,A7,A8,A9,A10> |
|
UnzipWithApply.UnzipWithCreator11<In,A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11> |
|
UnzipWithApply.UnzipWithCreator12<In,A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12> |
|
UnzipWithApply.UnzipWithCreator13<In,A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13> |
|
UnzipWithApply.UnzipWithCreator14<In,A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14> |
|
UnzipWithApply.UnzipWithCreator15<In,A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15> |
|
UnzipWithApply.UnzipWithCreator16<In,A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16> |
|
UnzipWithApply.UnzipWithCreator17<In,A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16,A17> |
|
UnzipWithApply.UnzipWithCreator18<In,A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16,A17,A18> |
|
UnzipWithApply.UnzipWithCreator19<In,A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16,A17,A18,A19> |
|
UnzipWithApply.UnzipWithCreator2<In,A1,A2> |
|
UnzipWithApply.UnzipWithCreator20<In,A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16,A17,A18,A19,A20> |
|
UnzipWithApply.UnzipWithCreator21<In,A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16,A17,A18,A19,A20,A21> |
|
UnzipWithApply.UnzipWithCreator22<In,A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16,A17,A18,A19,A20,A21,A22> |
|
UnzipWithApply.UnzipWithCreator3<In,A1,A2,A3> |
|
UnzipWithApply.UnzipWithCreator4<In,A1,A2,A3,A4> |
|
UnzipWithApply.UnzipWithCreator5<In,A1,A2,A3,A4,A5> |
|
UnzipWithApply.UnzipWithCreator6<In,A1,A2,A3,A4,A5,A6> |
|
UnzipWithApply.UnzipWithCreator7<In,A1,A2,A3,A4,A5,A6,A7> |
|
UnzipWithApply.UnzipWithCreator8<In,A1,A2,A3,A4,A5,A6,A7,A8> |
|
UnzipWithApply.UnzipWithCreator9<In,A1,A2,A3,A4,A5,A6,A7,A8,A9> |
|
UnzipWithApply.UnzipWithCreatorObject10$ |
|
UnzipWithApply.UnzipWithCreatorObject11$ |
|
UnzipWithApply.UnzipWithCreatorObject12$ |
|
UnzipWithApply.UnzipWithCreatorObject13$ |
|
UnzipWithApply.UnzipWithCreatorObject14$ |
|
UnzipWithApply.UnzipWithCreatorObject15$ |
|
UnzipWithApply.UnzipWithCreatorObject16$ |
|
UnzipWithApply.UnzipWithCreatorObject17$ |
|
UnzipWithApply.UnzipWithCreatorObject18$ |
|
UnzipWithApply.UnzipWithCreatorObject19$ |
|
UnzipWithApply.UnzipWithCreatorObject2$ |
|
UnzipWithApply.UnzipWithCreatorObject20$ |
|
UnzipWithApply.UnzipWithCreatorObject21$ |
|
UnzipWithApply.UnzipWithCreatorObject22$ |
|
UnzipWithApply.UnzipWithCreatorObject3$ |
|
UnzipWithApply.UnzipWithCreatorObject4$ |
|
UnzipWithApply.UnzipWithCreatorObject5$ |
|
UnzipWithApply.UnzipWithCreatorObject6$ |
|
UnzipWithApply.UnzipWithCreatorObject7$ |
|
UnzipWithApply.UnzipWithCreatorObject8$ |
|
UnzipWithApply.UnzipWithCreatorObject9$ |
|
UnzipWithApply$ |
|
Util |
Returns a ClassTag describing the provided Class.
|
Util$ |
Returns a ClassTag describing the provided Class.
|
Valid |
Java API: get the singleton instance
|
Valid$ |
Java API: get the singleton instance
|
VectorClock |
|
VectorClock.After$ |
|
VectorClock.Before$ |
|
VectorClock.Concurrent$ |
|
VectorClock.Node$ |
|
VectorClock.Ordering |
|
VectorClock.Same$ |
|
VectorClock.Timestamp$ |
|
VectorClock$ |
Hash representation of a versioned node name.
|
VectorClockStats |
INTERNAL API
|
VectorClockStats$ |
|
Version |
|
Version$ |
|
VersionVector |
Increment the version for the node passed as argument.
|
VersionVector.After$ |
|
VersionVector.Before$ |
|
VersionVector.Concurrent$ |
|
VersionVector.Ordering |
|
VersionVector.Same$ |
|
VersionVector.Timestamp$ |
INTERNAL API
|
VersionVector$ |
INTERNAL API
|
VirtualPathContainer |
|
VirtualProcessor<T> |
INTERNAL API
|
VirtualProcessor.Both |
|
VirtualProcessor.Both$ |
|
VirtualProcessor.Establishing |
|
VirtualProcessor.Establishing$ |
|
VirtualProcessor.HasActualSubscriber |
|
VirtualProcessor.Inert$ |
|
VirtualProcessor.WrappedSubscription$.SubscriptionState |
|
VirtualProcessor$ |
INTERNAL API
|
VirtualPublisher<T> |
INTERNAL API
|
WaitingForUpstreamSubscription |
INTERNAL API
|
WaitingForUpstreamSubscription$ |
|
WarningFilter |
Java API: create a WarningFilter
|
WarningFilter$ |
|
Watch |
INTERNAL API
|
Watch |
INTERNAL API
|
Watch<T> |
|
Watch$ |
|
Watch$ |
|
Watch$ |
|
WatchedActorTerminatedException |
Used as failure exception by an ask operator if the target actor terminates.
|
WatermarkRequestStrategy |
|
WatermarkRequestStrategy$ |
|
WeightedRoutees |
Pick the routee matching a value, from 1 to total.
|
WidenedInterceptor<O,I> |
|
WidenedInterceptor$ |
INTERNAL API
|
WildcardIndex<T> |
|
WildcardIndex$ |
|
WildcardTree<T> |
|
WildcardTree$ |
|
WireFormats |
|
WireFormats.AckAndEnvelopeContainer |
Protobuf type AckAndEnvelopeContainer
|
WireFormats.AckAndEnvelopeContainer.Builder |
Protobuf type AckAndEnvelopeContainer
|
WireFormats.AckAndEnvelopeContainerOrBuilder |
|
WireFormats.AcknowledgementInfo |
Protobuf type AcknowledgementInfo
|
WireFormats.AcknowledgementInfo.Builder |
Protobuf type AcknowledgementInfo
|
WireFormats.AcknowledgementInfoOrBuilder |
|
WireFormats.ActorRefData |
Protobuf type ActorRefData
|
WireFormats.ActorRefData.Builder |
Protobuf type ActorRefData
|
WireFormats.ActorRefDataOrBuilder |
|
WireFormats.AddressData |
Protobuf type AddressData
|
WireFormats.AddressData.Builder |
Protobuf type AddressData
|
WireFormats.AddressDataOrBuilder |
|
WireFormats.AkkaControlMessage |
Protobuf type AkkaControlMessage
|
WireFormats.AkkaControlMessage.Builder |
Protobuf type AkkaControlMessage
|
WireFormats.AkkaControlMessageOrBuilder |
|
WireFormats.AkkaHandshakeInfo |
Protobuf type AkkaHandshakeInfo
|
WireFormats.AkkaHandshakeInfo.Builder |
Protobuf type AkkaHandshakeInfo
|
WireFormats.AkkaHandshakeInfoOrBuilder |
|
WireFormats.AkkaProtocolMessage |
Protobuf type AkkaProtocolMessage
|
WireFormats.AkkaProtocolMessage.Builder |
Protobuf type AkkaProtocolMessage
|
WireFormats.AkkaProtocolMessageOrBuilder |
|
WireFormats.CommandType |
Protobuf enum CommandType
|
WireFormats.DaemonMsgCreateData |
Protobuf type DaemonMsgCreateData
|
WireFormats.DaemonMsgCreateData.Builder |
Protobuf type DaemonMsgCreateData
|
WireFormats.DaemonMsgCreateDataOrBuilder |
|
WireFormats.DefaultResizer |
Protobuf type DefaultResizer
|
WireFormats.DefaultResizer.Builder |
Protobuf type DefaultResizer
|
WireFormats.DefaultResizerOrBuilder |
|
WireFormats.DeployData |
Protobuf type DeployData
|
WireFormats.DeployData.Builder |
Protobuf type DeployData
|
WireFormats.DeployDataOrBuilder |
|
WireFormats.FiniteDuration |
Protobuf type FiniteDuration
|
WireFormats.FiniteDuration.Builder |
Protobuf type FiniteDuration
|
WireFormats.FiniteDurationOrBuilder |
|
WireFormats.FromConfig |
Protobuf type FromConfig
|
WireFormats.FromConfig.Builder |
Protobuf type FromConfig
|
WireFormats.FromConfigOrBuilder |
|
WireFormats.GenericRoutingPool |
Protobuf type GenericRoutingPool
|
WireFormats.GenericRoutingPool.Builder |
Protobuf type GenericRoutingPool
|
WireFormats.GenericRoutingPoolOrBuilder |
|
WireFormats.PropsData |
Protobuf type PropsData
|
WireFormats.PropsData.Builder |
Protobuf type PropsData
|
WireFormats.PropsDataOrBuilder |
|
WireFormats.RemoteEnvelope |
Protobuf type RemoteEnvelope
|
WireFormats.RemoteEnvelope.Builder |
Protobuf type RemoteEnvelope
|
WireFormats.RemoteEnvelopeOrBuilder |
|
WireFormats.RemoteRouterConfig |
Protobuf type RemoteRouterConfig
|
WireFormats.RemoteRouterConfig.Builder |
Protobuf type RemoteRouterConfig
|
WireFormats.RemoteRouterConfigOrBuilder |
|
WireFormats.RemoteScope |
Protobuf type RemoteScope
|
WireFormats.RemoteScope.Builder |
Protobuf type RemoteScope
|
WireFormats.RemoteScopeOrBuilder |
|
WireFormats.ScatterGatherPool |
Protobuf type ScatterGatherPool
|
WireFormats.ScatterGatherPool.Builder |
Protobuf type ScatterGatherPool
|
WireFormats.ScatterGatherPoolOrBuilder |
|
WireFormats.SerializedMessage |
Protobuf type SerializedMessage
|
WireFormats.SerializedMessage.Builder |
Protobuf type SerializedMessage
|
WireFormats.SerializedMessageOrBuilder |
|
WireFormats.TailChoppingPool |
Protobuf type TailChoppingPool
|
WireFormats.TailChoppingPool.Builder |
Protobuf type TailChoppingPool
|
WireFormats.TailChoppingPoolOrBuilder |
|
WireFormats.TimeUnit |
Protobuf enum TimeUnit
|
WireTap<T> |
Fan-out the stream to two output streams - a 'main' and a 'tap' one.
|
WireTap$ |
|
WithListeners |
|
WithListeners$ |
|
WithMdcBehaviorInterceptor<T> |
Support for Mapped Dagnostic Context for logging
|
WithMdcBehaviorInterceptor$ |
INTERNAL API
|
WithUdpSend |
INTERNAL API
|
WorkList<T> |
Deprecated.
|
WorkList.Entry<T> |
Singly linked list entry implementation for WorkList.
|
WorkList$ |
Deprecated.
|
WrappedPayloadSupport |
INTERNAL API
|
WriteAggregator |
INTERNAL API
|
WriteAggregator$ |
INTERNAL API
|
WriteEventAdapter |
Return the manifest (type hint) that will be provided in the fromJournal method.
|
WriteJournalBase |
INTERNAL API
|
ZeroRequestStrategy |
Java API: get the singleton instance
|
ZeroRequestStrategy$ |
Java API: get the singleton instance
|
Zip |
Create a new Zip operator with the specified input types and zipping-function
which creates akka.japi.Pair s.
|
Zip<A,B> |
Combine the elements of 2 streams into a stream of tuples.
|
Zip$ |
Create a new Zip operator with the specified input types and zipping-function
which creates akka.japi.Pair s.
|
Zip$ |
Create a new Zip .
|
ZipLatest |
Create a new ZipLatest operator with the specified input types and zipping-function
which creates akka.japi.Pair s.
|
ZipLatest<A,B> |
Combine the elements of 2 streams into a stream of tuples, picking always the latest element of each.
|
ZipLatest$ |
Create a new ZipLatest operator with the specified input types and zipping-function
which creates akka.japi.Pair s.
|
ZipLatest$ |
Create a new ZipLatest .
|
ZipLatestWith |
Create a new ZipLatestWith vertex with the specified input types and zipping-function f .
|
ZipLatestWith |
Combine the elements of multiple streams into a stream of combined elements using a combiner function,
picking always the latest of the elements of each source.
|
ZipLatestWith$ |
Create a new ZipLatestWith vertex with the specified input types and zipping-function f .
|
ZipLatestWith$ |
Combine the elements of multiple streams into a stream of combined elements using a combiner function,
picking always the latest of the elements of each source.
|
ZipLatestWith10<A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,O> |
`ZipLatestWith` specialized for 10 inputs
|
ZipLatestWith11<A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,O> |
`ZipLatestWith` specialized for 11 inputs
|
ZipLatestWith12<A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,O> |
`ZipLatestWith` specialized for 12 inputs
|
ZipLatestWith13<A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,O> |
`ZipLatestWith` specialized for 13 inputs
|
ZipLatestWith14<A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,O> |
`ZipLatestWith` specialized for 14 inputs
|
ZipLatestWith15<A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,O> |
`ZipLatestWith` specialized for 15 inputs
|
ZipLatestWith16<A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16,O> |
`ZipLatestWith` specialized for 16 inputs
|
ZipLatestWith17<A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16,A17,O> |
`ZipLatestWith` specialized for 17 inputs
|
ZipLatestWith18<A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16,A17,A18,O> |
`ZipLatestWith` specialized for 18 inputs
|
ZipLatestWith19<A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16,A17,A18,A19,O> |
`ZipLatestWith` specialized for 19 inputs
|
ZipLatestWith2<A1,A2,O> |
`ZipLatestWith` specialized for 2 inputs
|
ZipLatestWith20<A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16,A17,A18,A19,A20,O> |
`ZipLatestWith` specialized for 20 inputs
|
ZipLatestWith21<A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16,A17,A18,A19,A20,A21,O> |
`ZipLatestWith` specialized for 21 inputs
|
ZipLatestWith22<A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16,A17,A18,A19,A20,A21,A22,O> |
`ZipLatestWith` specialized for 22 inputs
|
ZipLatestWith3<A1,A2,A3,O> |
`ZipLatestWith` specialized for 3 inputs
|
ZipLatestWith4<A1,A2,A3,A4,O> |
`ZipLatestWith` specialized for 4 inputs
|
ZipLatestWith5<A1,A2,A3,A4,A5,O> |
`ZipLatestWith` specialized for 5 inputs
|
ZipLatestWith6<A1,A2,A3,A4,A5,A6,O> |
`ZipLatestWith` specialized for 6 inputs
|
ZipLatestWith7<A1,A2,A3,A4,A5,A6,A7,O> |
`ZipLatestWith` specialized for 7 inputs
|
ZipLatestWith8<A1,A2,A3,A4,A5,A6,A7,A8,O> |
`ZipLatestWith` specialized for 8 inputs
|
ZipLatestWith9<A1,A2,A3,A4,A5,A6,A7,A8,A9,O> |
`ZipLatestWith` specialized for 9 inputs
|
ZipLatestWithApply |
Create a new ZipLatestWith specialized for 2 inputs.
|
ZipN |
Combine the elements of multiple streams into a stream of lists.
|
ZipN<A> |
Combine the elements of multiple streams into a stream of sequences.
|
ZipN$ |
Combine the elements of multiple streams into a stream of lists.
|
ZipN$ |
Create a new ZipN .
|
ZipWith |
Create a new ZipWith vertex with the specified input types and zipping-function f .
|
ZipWith |
Combine the elements of multiple streams into a stream of combined elements using a combiner function.
|
ZipWith$ |
Create a new ZipWith vertex with the specified input types and zipping-function f .
|
ZipWith$ |
Combine the elements of multiple streams into a stream of combined elements using a combiner function.
|
ZipWith10<A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,O> |
`ZipWith` specialized for 10 inputs
|
ZipWith11<A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,O> |
`ZipWith` specialized for 11 inputs
|
ZipWith12<A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,O> |
`ZipWith` specialized for 12 inputs
|
ZipWith13<A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,O> |
`ZipWith` specialized for 13 inputs
|
ZipWith14<A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,O> |
`ZipWith` specialized for 14 inputs
|
ZipWith15<A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,O> |
`ZipWith` specialized for 15 inputs
|
ZipWith16<A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16,O> |
`ZipWith` specialized for 16 inputs
|
ZipWith17<A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16,A17,O> |
`ZipWith` specialized for 17 inputs
|
ZipWith18<A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16,A17,A18,O> |
`ZipWith` specialized for 18 inputs
|
ZipWith19<A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16,A17,A18,A19,O> |
`ZipWith` specialized for 19 inputs
|
ZipWith2<A1,A2,O> |
`ZipWith` specialized for 2 inputs
|
ZipWith20<A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16,A17,A18,A19,A20,O> |
`ZipWith` specialized for 20 inputs
|
ZipWith21<A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16,A17,A18,A19,A20,A21,O> |
`ZipWith` specialized for 21 inputs
|
ZipWith22<A1,A2,A3,A4,A5,A6,A7,A8,A9,A10,A11,A12,A13,A14,A15,A16,A17,A18,A19,A20,A21,A22,O> |
`ZipWith` specialized for 22 inputs
|
ZipWith3<A1,A2,A3,O> |
`ZipWith` specialized for 3 inputs
|
ZipWith4<A1,A2,A3,A4,O> |
`ZipWith` specialized for 4 inputs
|
ZipWith5<A1,A2,A3,A4,A5,O> |
`ZipWith` specialized for 5 inputs
|
ZipWith6<A1,A2,A3,A4,A5,A6,O> |
`ZipWith` specialized for 6 inputs
|
ZipWith7<A1,A2,A3,A4,A5,A6,A7,O> |
`ZipWith` specialized for 7 inputs
|
ZipWith8<A1,A2,A3,A4,A5,A6,A7,A8,O> |
`ZipWith` specialized for 8 inputs
|
ZipWith9<A1,A2,A3,A4,A5,A6,A7,A8,A9,O> |
`ZipWith` specialized for 9 inputs
|
ZipWithApply |
Create a new ZipWith specialized for 2 inputs.
|
ZipWithN |
Combine the elements of multiple streams into a stream of lists using a combiner function.
|
ZipWithN<A,O> |
Combine the elements of multiple streams into a stream of sequences using a combiner function.
|
ZipWithN$ |
Combine the elements of multiple streams into a stream of lists using a combiner function.
|
ZipWithN$ |
Create a new ZipWithN .
|