All Classes Interface Summary Class Summary Enum Summary Exception Summary Annotation Types Summary
Class |
Description |
AAAARecord |
|
AAAARecord$ |
INTERNAL API
|
AbruptIOTerminationException |
Deprecated.
|
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.
|
AbruptStreamTerminationException |
A base exception for abrupt stream termination.
|
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 |
Java API: compatible with lambda expressions
|
AbstractActor.ActorContext |
The actor context - the view of the actor cell from the actor.
|
AbstractActor.Receive |
Defines which messages the Actor can handle, along with the implementation of
how the messages should be processed.
|
AbstractActor$ |
Java API: compatible with lambda expressions
|
AbstractActorWithStash |
Java API: compatible with lambda expressions
|
AbstractActorWithTimers |
|
AbstractActorWithUnboundedStash |
Java API: compatible with lambda expressions
|
AbstractActorWithUnrestrictedStash |
Java API: compatible with lambda expressions
|
AbstractBehavior<T> |
|
AbstractBehavior<T> |
|
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:
- https://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> |
|
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> |
Java API: compatible with lambda expressions
|
AbstractFSM$ |
Java API: compatible with lambda expressions
|
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).
|
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:
https://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> |
|
AbstractOnMessageBehavior<T> |
|
AbstractOutHandler |
Java API: callbacks for an output port where termination logic is predefined
(completing when downstream cancels).
|
AbstractPersistentActor |
Java API: an persistent actor - can be used to implement command or Event Sourcing.
|
AbstractPersistentActorLike |
INTERNAL API
|
AbstractPersistentActorWithAtLeastOnceDelivery |
Java API: compatible with lambda expressions
|
AbstractPersistentActorWithTimers |
|
AbstractProps |
Java API: Factory for Props instances.
|
AbstractReplicatedData<A extends AbstractReplicatedData<A>> |
|
AbstractScheduler |
An Akka scheduler service.
|
AbstractSchedulerBase |
|
AbstractSerializationSupport |
Java API
|
AbstractShape |
Java API for creating custom Shape types.
|
AbstractSupervisor<I,Thr extends java.lang.Throwable> |
INTERNAL API
|
ActiveEntities$ |
INTERNAL API
|
Actor |
|
Actor.emptyBehavior$ |
emptyBehavior is a Receive-expression that matches no messages at all, ever.
|
Actor.ignoringBehavior$ |
ignoringBehavior is a Receive-expression that consumes and ignores all messages.
|
Actor$ |
|
ActorAdapter$ |
INTERNAL API
|
ActorAttributes |
|
ActorAttributes.DebugLogging |
Enables additional low level troubleshooting logging at DEBUG log level
|
ActorAttributes.DebugLogging$ |
|
ActorAttributes.Dispatcher |
Configures the dispatcher to be used by streams.
|
ActorAttributes.Dispatcher$ |
|
ActorAttributes.FuzzingMode |
Test utility: fuzzing mode means that GraphStage events are not processed
in FIFO order within a fused subgraph, but randomized.
|
ActorAttributes.FuzzingMode$ |
|
ActorAttributes.MaxFixedBufferSize |
Configure the maximum buffer size for which a FixedSizeBuffer will be preallocated.
|
ActorAttributes.MaxFixedBufferSize$ |
|
ActorAttributes.OutputBurstLimit |
Maximum number of elements emitted in batch if downstream signals large demand.
|
ActorAttributes.OutputBurstLimit$ |
|
ActorAttributes.StreamSubscriptionTimeout |
Defines a timeout for stream subscription and what action to take when that hits.
|
ActorAttributes.StreamSubscriptionTimeout$ |
|
ActorAttributes.SupervisionStrategy |
|
ActorAttributes.SupervisionStrategy$ |
|
ActorAttributes.SyncProcessingLimit |
Limit for number of messages that can be processed synchronously in stream to substream communication.
|
ActorAttributes.SyncProcessingLimit$ |
|
ActorAttributes$ |
|
ActorCell$ |
INTERNAL API
|
ActorClassificationUnsubscriber$ |
INTERNAL API
|
ActorClassifier |
Can be mixed into an EventBus to specify that the Classifier type is ActorRef
|
ActorContext |
The actor context - the view of the actor cell from the actor.
|
ActorContext<T> |
An Actor is given by the combination of a Behavior and a context in
which this behavior is executed.
|
ActorContext<T> |
An Actor is given by the combination of a Behavior and a context in
which this behavior is executed.
|
ActorContextAdapter$ |
|
ActorContextImpl<T> |
INTERNAL API
|
ActorContextImpl.LoggingContext |
|
ActorContextImpl.LoggingContext$ |
|
ActorContextImpl$ |
INTERNAL API
|
ActorEventBus |
Represents an EventBus where the Subscriber type is ActorRef
|
ActorFlightRecorder |
INTERNAL API
|
ActorFlightRecorder$ |
INTERNAL API
|
ActorFlow |
Collection of Flows aimed at integrating with typed Actors.
|
ActorFlow |
Collection of Flows aimed at integrating with typed Actors.
|
ActorFlow$ |
Collection of Flows aimed at integrating with typed Actors.
|
ActorFlow$ |
Collection of Flows aimed at integrating with typed Actors.
|
ActorIdentity |
|
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".
|
ActorLogMarker |
This is public with the purpose to document the used markers and properties of log events.
|
ActorLogMarker$ |
This is public with the purpose to document the used markers and properties of log events.
|
ActorMaterializer |
Deprecated.
|
ActorMaterializer$ |
|
ActorMaterializerHelper |
INTERNAL API
|
ActorMaterializerHelper$ |
INTERNAL API
|
ActorMaterializerSettings |
|
ActorMaterializerSettings$ |
|
ActorMdc |
INTERNAL API
|
ActorMdc$ |
INTERNAL API
|
ActorNotFound |
|
ActorNotFound$ |
|
ActorPath |
Actor path is a unique path to an actor that shows the creation path
up through the actor tree to the root actor.
|
ActorPath$ |
|
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 |
Java API
|
ActorPaths$ |
Java API
|
ActorRef |
Immutable and serializable handle to an actor, which may or may not reside
on the local host or inside the same ActorSystem .
|
ActorRef<T> |
An ActorRef is the identity or address of an Actor instance.
|
ActorRef.ActorRefOps<T> |
|
ActorRef.ActorRefOps$ |
|
ActorRef$ |
|
ActorRef$ |
|
ActorRefAdapter$ |
|
ActorRefDeserializer$ |
INTERNAL API
|
ActorRefFactory |
Interface implemented by ActorSystem and ActorContext, the only two places
from which you can get fresh actors.
|
ActorRefFactoryAdapter |
INTERNAL API
|
ActorRefFactoryAdapter$ |
INTERNAL API
|
ActorRefImpl<T> |
Every ActorRef is also an ActorRefImpl, but these two methods shall be
completely hidden from client code.
|
ActorRefModule |
INTERNAL API: Adds support for serializing and deserializing ActorRef .
|
ActorRefProvider |
Interface for all ActorRef providers to implement.
|
ActorRefResolver |
Serialization and deserialization of ActorRef .
|
ActorRefResolver$ |
|
ActorRefResolverSetup |
|
ActorRefResolverSetup$ |
|
ActorRefResolveThreadLocalCache$ |
INTERNAL API: Thread local cache per actor system
|
ActorRefRoutee |
|
ActorRefRoutee$ |
|
ActorRefScope |
All ActorRefs have a scope which describes where they live.
|
ActorRefSerializer$ |
INTERNAL API
|
ActorSelection |
An ActorSelection is a logical view of a section of an ActorSystem's tree of Actors,
allowing for broadcasting of messages to that section.
|
ActorSelection$ |
An ActorSelection is a logical view of a section of an ActorSystem's tree of Actors,
allowing for broadcasting of messages to that section.
|
ActorSelectionMessage$ |
|
ActorSelectionRoutee |
|
ActorSelectionRoutee$ |
|
ActorSink |
Collection of Sinks aimed at integrating with typed Actors.
|
ActorSink |
Collection of Sinks aimed at integrating with typed Actors.
|
ActorSink$ |
Collection of Sinks aimed at integrating with typed Actors.
|
ActorSink$ |
Collection of Sinks aimed at integrating with typed Actors.
|
ActorSource |
Collection of Sources aimed at integrating with typed Actors.
|
ActorSource |
Collection of Sources aimed at integrating with typed Actors.
|
ActorSource$ |
Collection of Sources aimed at integrating with typed Actors.
|
ActorSource$ |
Collection of Sources aimed at integrating with typed Actors.
|
ActorSystem |
An actor system is a hierarchical group of actors which share common
configuration, e.g.
|
ActorSystem<T> |
An ActorSystem is home to a hierarchy of Actors.
|
ActorSystem.Settings |
Settings are the overall ActorSystem Settings which also provides a convenient access to the Config object.
|
ActorSystem.Settings$ |
INTERNAL API
|
ActorSystem$ |
|
ActorSystem$ |
|
ActorSystemAccess |
INTERNAL API
|
ActorSystemAccess$ |
INTERNAL API
|
ActorSystemAdapter$ |
|
ActorSystemSetup |
A set of setup settings for programmatic configuration of the actor system.
|
ActorSystemSetup$ |
|
ActorSystemStub$ |
|
ActorSystemTerminating$ |
|
ActorSystemTerminatingAck$ |
|
ActorTags |
Actor tags are used to logically group actors.
|
ActorTags$ |
|
ActorTestKit |
Java API: Test kit for asynchronous testing of typed actors.
|
ActorTestKit |
Testkit for asynchronous testing of typed actors, meant for mixing into the test class.
|
ActorTestKit$ |
|
ActorTestKit$ |
|
ActorTestKitBase |
A base class for the ActorTestKit , making it possible to have testing framework (e.g.
|
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
|
ActorWithLogClass$ |
|
Adapter |
Adapters between typed and classic actors and actor systems.
|
Adapter$ |
Adapters between typed and classic actors and actor systems.
|
AdapterClusterImpl$ |
INTERNAL API:
|
AdapterExtension$ |
Internal API
|
AdaptiveLoadBalancingGroup |
A router group that performs load balancing of messages to cluster nodes based on
cluster metric data.
|
AdaptiveLoadBalancingGroup$ |
|
AdaptiveLoadBalancingPool |
A router pool that performs load balancing of messages to cluster nodes based on
cluster metric data.
|
AdaptiveLoadBalancingPool$ |
|
AdaptiveLoadBalancingRoutingLogic |
Load balancing of messages to cluster nodes based on cluster metric data.
|
AdaptiveLoadBalancingRoutingLogic$ |
|
AdaptMessage$ |
|
AdaptWithRegisteredMessageAdapter$ |
|
Address |
The address specifies the physical location under which an Actor can be
reached.
|
Address$ |
|
AddressDeserializer$ |
INTERNAL API
|
AddressFromURIString |
This object serves as extractor for Scala and as address parser for Java.
|
AddressFromURIString$ |
This object serves as extractor for Scala and as address parser for Java.
|
AddressModule |
INTERNAL API: Adds support for serializing and deserializing Address .
|
AddressReply$ |
|
AddressSerializer$ |
INTERNAL API
|
AddressTerminated$ |
|
AddressTerminatedTopic$ |
INTERNAL API
|
AddressUidExtension |
Deprecated.
|
AddressUidExtension$ |
Deprecated.
|
AddRoutee |
Add a routee by sending this message to the router.
|
AddRoutee$ |
|
AdjustPoolSize |
Increase or decrease the number of routees in a Pool .
|
AdjustPoolSize$ |
|
AdmissionFilter$ |
INTERNAL API
|
AdmissionOptimizer$ |
INTERNAL API
|
AeronErrorLog |
INTERNAL API
|
AeronSink$ |
INTERNAL API
|
AeronSinkDelegateToTaskRunner |
INTERNAL API
|
AeronSinkEnvelopeGrabbed |
INTERNAL API
|
AeronSinkEnvelopeOffered |
INTERNAL API
|
AeronSinkGaveUpEnvelope |
INTERNAL API
|
AeronSinkPublicationClosed |
INTERNAL API
|
AeronSinkPublicationClosedUnexpectedly |
INTERNAL API
|
AeronSinkReturnFromTaskRunner |
INTERNAL API
|
AeronSinkStarted |
INTERNAL API
|
AeronSinkStopped |
INTERNAL API
|
AeronSinkTaskRunnerRemoved |
INTERNAL API
|
AeronSource$ |
INTERNAL API
|
AeronSourceDelegateToTaskRunner |
INTERNAL API
|
AeronSourceReceived |
INTERNAL API
|
AeronSourceReturnFromTaskRunner |
INTERNAL API
|
AeronSourceStarted |
INTERNAL API
|
AeronSourceStopped |
INTERNAL API
|
AffinityPool$ |
|
AggregateServiceDiscovery$ |
INTERNAL API
|
AggregateServiceDiscoverySettings |
INTERNAL API
|
AkkaException |
Akka base Exception.
|
AkkaJacksonModule |
Complete module with support for all custom serializers.
|
AkkaJacksonModule$ |
|
AkkaJacksonSerializationFeature |
Provides auto-registration of user classes marked with the built in marker types.
|
AkkaSerializationDeserializer |
|
AkkaSerializationSerializer |
|
AkkaStreamJacksonModule |
|
AkkaStreamJacksonModule$ |
|
AkkaTypedJacksonModule |
|
AkkaTypedJacksonModule$ |
|
AkkaVersion |
|
AkkaVersion$ |
|
AllDeadLetters |
Subscribe to this class to be notified about all DeadLetter (also the suppressed ones)
and Dropped .
|
AllForOneStrategy |
Applies the fault handling Directive (Resume, Restart, Stop) specified in the Decider
to all children when one fails, as opposed to OneForOneStrategy that applies
it only to the child actor that failed.
|
AllForOneStrategy$ |
|
AlwaysAdmissionFilter |
INTERNAL API
|
AlwaysAdmissionFilter$ |
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.
|
ARecord |
|
ARecord$ |
INTERNAL API
|
ArteryControlFormats |
|
ArteryControlFormats.Address |
Defines a remote address.
|
ArteryControlFormats.Address.Builder |
Defines a remote address.
|
ArteryControlFormats.AddressOrBuilder |
|
ArteryControlFormats.ArteryHeartbeatRsp |
RemoteWatcher.ArteryHeartbeat is empty array
RemoteWatcher.ArteryHeartbeatRsp
|
ArteryControlFormats.ArteryHeartbeatRsp.Builder |
RemoteWatcher.ArteryHeartbeat is empty array
RemoteWatcher.ArteryHeartbeatRsp
|
ArteryControlFormats.ArteryHeartbeatRspOrBuilder |
|
ArteryControlFormats.CompressionTableAdvertisement |
CompressionProtocol.ActorRefCompressionAdvertisement
CompressionProtocol.ClassManifestCompressionAdvertisement
|
ArteryControlFormats.CompressionTableAdvertisement.Builder |
CompressionProtocol.ActorRefCompressionAdvertisement
CompressionProtocol.ClassManifestCompressionAdvertisement
|
ArteryControlFormats.CompressionTableAdvertisementAck |
CompressionProtocol.ActorRefCompressionAdvertisementAck
CompressionProtocol.ClassManifestCompressionAdvertisementAck
|
ArteryControlFormats.CompressionTableAdvertisementAck.Builder |
CompressionProtocol.ActorRefCompressionAdvertisementAck
CompressionProtocol.ClassManifestCompressionAdvertisementAck
|
ArteryControlFormats.CompressionTableAdvertisementAckOrBuilder |
|
ArteryControlFormats.CompressionTableAdvertisementOrBuilder |
|
ArteryControlFormats.FlushAck |
Protobuf type FlushAck
|
ArteryControlFormats.FlushAck.Builder |
Protobuf type FlushAck
|
ArteryControlFormats.FlushAckOrBuilder |
|
ArteryControlFormats.HandshakeReq |
Protobuf type HandshakeReq
|
ArteryControlFormats.HandshakeReq.Builder |
Protobuf type HandshakeReq
|
ArteryControlFormats.HandshakeReqOrBuilder |
|
ArteryControlFormats.MessageWithAddress |
Generic message declaration that is used for all types of message that (currently) have a single
address field.
|
ArteryControlFormats.MessageWithAddress.Builder |
Generic message declaration that is used for all types of message that (currently) have a single
address field.
|
ArteryControlFormats.MessageWithAddressOrBuilder |
|
ArteryControlFormats.Quarantined |
Protobuf type Quarantined
|
ArteryControlFormats.Quarantined.Builder |
Protobuf type Quarantined
|
ArteryControlFormats.QuarantinedOrBuilder |
|
ArteryControlFormats.SystemMessageDeliveryAck |
SystemMessageDelivery.Ack
SystemMessageDelivery.Nack
|
ArteryControlFormats.SystemMessageDeliveryAck.Builder |
SystemMessageDelivery.Ack
SystemMessageDelivery.Nack
|
ArteryControlFormats.SystemMessageDeliveryAckOrBuilder |
|
ArteryControlFormats.SystemMessageEnvelope |
SystemMessageDelivery.SystemMessageEnvelope
|
ArteryControlFormats.SystemMessageEnvelope.Builder |
SystemMessageDelivery.SystemMessageEnvelope
|
ArteryControlFormats.SystemMessageEnvelopeOrBuilder |
|
ArteryControlFormats.UniqueAddress |
Defines a remote address with uid.
|
ArteryControlFormats.UniqueAddress.Builder |
Defines a remote address with uid.
|
ArteryControlFormats.UniqueAddressOrBuilder |
|
ArteryMessage |
INTERNAL API: marker trait for protobuf-serializable artery messages
|
ArteryMessageSerializer$ |
INTERNAL API
|
ArterySettings$ |
INTERNAL API
|
ArteryTcpTransport$ |
INTERNAL API
|
ArteryTransport$ |
INTERNAL API
|
AskableActorRef |
|
AskableActorRef$ |
|
AskableActorSelection |
|
AskableActorSelection$ |
|
AskPattern |
The ask-pattern implements the initiator side of a request–reply protocol.
|
AskPattern |
The ask-pattern implements the initiator side of a request–reply protocol.
|
AskPattern.Askable<Req> |
|
AskPattern.Askable$ |
|
AskPattern$ |
The ask-pattern implements the initiator side of a request–reply protocol.
|
AskPattern$ |
The ask-pattern implements the initiator side of a request–reply protocol.
|
AskPromiseRef$ |
|
AskSupport |
This object contains implementation details of the “ask” pattern.
|
AskTimeoutException |
This is what is used to complete a Future that is returned from an ask/? call,
when it times out.
|
AsPublisher |
|
Association$ |
INTERNAL API
|
AssociationState$ |
INTERNAL API
|
AsyncCallback<T> |
|
AsyncDnsManager$ |
INTERNAL API
|
AsyncDnsResolver$ |
INTERNAL API
|
AsyncEffect$ |
|
AsyncRecovery |
Asynchronous message replay and sequence number recovery interface.
|
AsyncRecovery |
Java API: asynchronous message replay and sequence number recovery interface.
|
AsyncReplay |
A plugin may implement this trait as an optimization.
|
AsyncReplayTimeoutException |
Thrown if replay inactivity exceeds a specified timeout.
|
AsyncSerializer |
Serializer that supports async serialization.
|
AsyncSerializerWithStringManifest |
Scala API: Async serializer with string manifest that delegates synchronous calls to the asynchronous calls
and blocks.
|
AsyncSerializerWithStringManifestCS |
Java API: Async serializer with string manifest that delegates synchronous calls to the asynchronous calls
and blocks.
|
AsyncWriteJournal |
Abstract journal, optimized for asynchronous, non-blocking writes.
|
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: Mix-in this trait with your PersistentActor to send messages with at-least-once
delivery semantics to destinations.
|
AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot |
Snapshot of current AtLeastOnceDelivery state.
|
AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot$ |
|
AtLeastOnceDelivery.Internal$ |
INTERNAL API
|
AtLeastOnceDelivery.MaxUnconfirmedMessagesExceededException |
|
AtLeastOnceDelivery.UnconfirmedDelivery |
Information about a message that has not been confirmed.
|
AtLeastOnceDelivery.UnconfirmedDelivery$ |
|
AtLeastOnceDelivery.UnconfirmedWarning |
|
AtLeastOnceDelivery.UnconfirmedWarning$ |
|
AtLeastOnceDelivery$ |
|
AtLeastOnceDeliveryLike |
|
AtomicWrite |
|
AtomicWrite$ |
|
Attributes |
Holds attributes which can be used to alter Flow / Flow
or GraphDSL / GraphDSL materialization.
|
Attributes.AsyncBoundary$ |
|
Attributes.Attribute |
|
Attributes.CancellationStrategy |
Cancellation strategies provide a way to configure the behavior of a stage when cancelStage is called.
|
Attributes.CancellationStrategy$ |
|
Attributes.CancellationStrategy$.AfterDelay |
Strategy that allows to delay any action when cancelStage is invoked.
|
Attributes.CancellationStrategy$.AfterDelay$ |
|
Attributes.CancellationStrategy$.CompleteStage$ |
Strategy that treats cancelStage the same as completeStage , i.e.
|
Attributes.CancellationStrategy$.FailStage$ |
Strategy that treats cancelStage the same as failStage , i.e.
|
Attributes.CancellationStrategy$.PropagateFailure$ |
Strategy that treats cancelStage in different ways depending on the cause that was given to the cancellation.
|
Attributes.CancellationStrategy$.Strategy |
Not for user extension
|
Attributes.InputBuffer |
Each asynchronous piece of a materialized stream topology is executed by one Actor
that manages an input buffer for all inlets of its shape.
|
Attributes.InputBuffer$ |
|
Attributes.LogLevels |
|
Attributes.LogLevels$ |
|
Attributes.MandatoryAttribute |
Attributes that are always present (is defined with default values by the materializer)
|
Attributes.Name |
|
Attributes.Name$ |
|
Attributes.NestedMaterializationCancellationPolicy |
Nested materialization cancellation strategy provides a way to configure the cancellation behavior of stages that materialize a nested flow.
|
Attributes.NestedMaterializationCancellationPolicy$ |
|
Attributes.SourceLocation |
Attribute that contains the source location of for example a lambda passed to an operator, useful for example
for debugging.
|
Attributes.SourceLocation$ |
|
Attributes$ |
|
AutoReceivedMessage |
INTERNAL API
|
AutoReset$ |
|
BackoffOnFailureOptions |
|
BackoffOnFailureOptionsImpl<T> |
|
BackoffOnFailureOptionsImpl$ |
|
BackoffOnStopOptions |
|
BackoffOnStopOptionsImpl<T> |
|
BackoffOnStopOptionsImpl$ |
|
BackoffOpts |
Backoff options allow to specify a number of properties for backoff supervisors.
|
BackoffOpts$ |
Backoff options allow to specify a number of properties for backoff supervisors.
|
BackoffReset |
|
BackoffSupervisor |
|
BackoffSupervisor.CurrentChild |
Send this message to the BackoffSupervisor and it will reply with
BackoffSupervisor.CurrentChild containing 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$ |
Send this message to the BackoffSupervisor and it will reset the back-off.
|
BackoffSupervisor.ResetRestartCount$ |
|
BackoffSupervisor.RestartCount |
|
BackoffSupervisor.RestartCount$ |
|
BackoffSupervisor.StartChild$ |
INTERNAL API
|
BackoffSupervisor$ |
|
BackoffSupervisorStrategy |
Not for user extension
|
BackpressureTimeoutException |
|
Balance |
Fan-out the stream to several streams.
|
Balance<T> |
Fan-out the stream to several streams.
|
Balance$ |
Fan-out the stream to several streams.
|
Balance$ |
|
BalancingDispatcherConfigurator |
Configurator for creating BalancingDispatcher .
|
BalancingDispatcherConfigurator$ |
INTERNAL API
|
BalancingPool |
A router pool that will try to redistribute work from busy routees to idle routees.
|
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
|
BarrierCoordinator$ |
INTERNAL API.
|
BarrierResult$ |
|
Base62 |
Base62 encoder/decoder.
|
Base62.Base62EncodingException |
|
Base62$ |
Base62 encoder/decoder.
|
BaseSerializer |
Base serializer trait with serialization identifiers configuration contract,
when globally unique serialization identifier is configured in the reference.conf .
|
BaseSerializer$ |
|
Batchable |
INTERNAL API
|
BatchingExecutor |
INTERNAL API
|
Behavior<T> |
The behavior of an actor defines how it reacts to the messages that it
receives.
|
Behavior.BehaviorDecorators<Inner> |
|
Behavior.BehaviorDecorators$ |
|
Behavior$ |
|
BehaviorBuilder<T> |
Immutable builder used for creating a Behavior by 'chaining' message and signal handlers.
|
BehaviorBuilder.Case$ |
|
BehaviorBuilder$ |
|
BehaviorImpl |
INTERNAL API
|
BehaviorImpl.ContextAs<T> |
|
BehaviorImpl.ContextAs$ |
|
BehaviorImpl.DeferredBehavior<T> |
|
BehaviorImpl.DeferredBehavior$ |
|
BehaviorImpl.FailedBehavior |
|
BehaviorImpl.ReceiveBehavior<T> |
|
BehaviorImpl.ReceiveBehavior$ |
|
BehaviorImpl.ReceiveMessageBehavior<T> |
|
BehaviorImpl.ReceiveMessageBehavior$ |
|
BehaviorImpl.SameBehavior$ |
|
BehaviorImpl.UnhandledBehavior$ |
|
BehaviorImpl$ |
INTERNAL API
|
BehaviorInterceptor<Outer,Inner> |
A behavior interceptor allows for intercepting message and signal reception and perform arbitrary logic -
transform, filter, send to a side channel etc.
|
BehaviorInterceptor.PreStartTarget<T> |
|
BehaviorInterceptor.ReceiveTarget<T> |
|
BehaviorInterceptor.SignalTarget<T> |
|
BehaviorInterceptor$ |
|
Behaviors |
|
Behaviors |
|
Behaviors.Receive<T> |
Behavior that exposes additional fluent DSL methods to further change the message or
signal reception behavior.
|
Behaviors.Supervise<T> |
|
Behaviors.Supervise<T> |
|
Behaviors.Supervise$ |
|
Behaviors$ |
|
Behaviors$ |
|
BehaviorSetup$ |
INTERNAL API
|
BehaviorSignalInterceptor<Inner> |
A behavior interceptor allows for intercepting signals reception and perform arbitrary logic -
transform, filter, send to a side channel etc.
|
BehaviorTags |
INTERNAL API
|
BehaviorTags$ |
INTERNAL API
|
BehaviorTestKit<T> |
|
BehaviorTestKit<T> |
|
BehaviorTestKit$ |
|
BehaviorTestKit$ |
|
BehaviorTestKitImpl$ |
|
BidiFlow<I1,O1,I2,O2,Mat> |
|
BidiFlow<I1,O1,I2,O2,Mat> |
|
BidiFlow$ |
|
BidiFlow$ |
|
BidiShape<In1,Out1,In2,Out2> |
A bidirectional flow of elements that consequently has two inputs and two
outputs, arranged like this:
|
BidiShape$ |
|
BindFailedException |
|
BindFailedException$ |
Deprecated.
|
Blackhole |
|
Blackhole$ |
|
BootstrapSetup |
|
BootstrapSetup$ |
|
BoundAddressesExtension |
|
BoundAddressesExtension$ |
Extension provides access to bound addresses.
|
BoundedBlockingQueue<E> |
BoundedBlockingQueue wraps any Queue and turns the result into a BlockingQueue with a limited capacity.
|
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 |
|
BoundedSourceQueue<T> |
A queue of the given size that gives immediate feedback whether an element could be enqueued or not.
|
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 |
Fan-out the stream to several streams.
|
Broadcast<T> |
Fan-out the stream to several streams emitting each incoming upstream element to all downstream consumers.
|
Broadcast$ |
|
Broadcast$ |
Fan-out the stream to several streams.
|
Broadcast$ |
|
BroadcastGroup |
A router group that broadcasts a message to all its routees.
|
BroadcastGroup$ |
|
BroadcastHub |
A BroadcastHub is a special streaming hub that is able to broadcast streamed elements to a dynamic set of consumers.
|
BroadcastHub$ |
A BroadcastHub is a special streaming hub that is able to broadcast streamed elements to a dynamic set of consumers.
|
BroadcastHub$ |
A BroadcastHub is a special streaming hub that is able to broadcast streamed elements to a dynamic set of consumers.
|
BroadcastPool |
A router pool that broadcasts a message to all its routees.
|
BroadcastPool$ |
|
BroadcastRoutingLogic |
Broadcasts a message to all its routees.
|
BroadcastRoutingLogic$ |
|
Buffer<T> |
INTERNAL API
|
BufferOverflowException |
|
BufferOverflowException$ |
|
BufferPool |
|
BuiltBehavior<T> |
The concrete behavior
|
BuiltReceive<T> |
|
BusLogging |
|
ByteArraySerializer |
This is a special Serializer that Serializes and deserializes byte arrays only,
(just returns the byte array unchanged/uncopied)
|
ByteBufferSerializer |
Serializer between an object and a ByteBuffer representing that object.
|
ByteFlag$ |
INTERNAL API
|
ByteIterator |
An iterator over a ByteString.
|
ByteIterator.ByteArrayIterator |
|
ByteIterator.ByteArrayIterator$ |
|
ByteIterator.MultiByteArrayIterator |
|
ByteIterator.MultiByteArrayIterator$ |
|
ByteIterator$ |
|
ByteString |
A rope-like immutable data structure containing bytes.
|
ByteString.ByteString1 |
An unfragmented ByteString.
|
ByteString.ByteString1$ |
INTERNAL API: ByteString backed by exactly one array, with start / end markers
|
ByteString.ByteString1C |
A compact (unsliced) and unfragmented ByteString, implementation of ByteString1C.
|
ByteString.ByteString1C$ |
|
ByteString.ByteStrings |
A ByteString with 2 or more fragments.
|
ByteString.ByteStrings$ |
|
ByteString.Companion |
|
ByteString.Companion$ |
|
ByteString$ |
|
ByteStringBuilder |
A mutable builder for efficiently creating a ByteString .
|
ByteStringSerializer |
Deprecated.
|
ByteStringUtils |
INTERNAL API
|
ByteStringUtils$ |
INTERNAL API
|
CachedProps$ |
|
CachePolicy |
|
CachePolicy.Forever$ |
|
CachePolicy.Never$ |
|
CachePolicy.Ttl |
|
CachePolicy.Ttl$ |
|
CachePolicy.Ttl$.TtlIsOrdered$ |
|
CachePolicy$ |
|
CacheStatistics$ |
|
CachingConfig$ |
INTERNAL API
|
CallingThreadDispatcher |
Dispatcher which runs invocations on the current thread only.
|
CallingThreadDispatcher$ |
|
CallingThreadDispatcherConfigurator |
|
CallingThreadDispatcherQueues$ |
|
CallingThreadMailbox |
|
Cancellable |
Signifies something that can be cancelled
There is no strict guarantee that the implementation is thread-safe,
but it should be good practice to make it so.
|
Cancellable$ |
|
CapabilityFlag |
|
CapabilityFlag$ |
|
CapabilityFlags |
|
CapacityMetricsSelector |
A MetricsSelector producing weights from remaining capacity.
|
CapturedLogEvent |
|
CapturedLogEvent$ |
|
CapturingAppender$ |
INTERNAL API
|
CaseStatement$ |
|
CatchupOrFirehose$ |
INTERNAL API
|
CborSerializable |
Predefined marker trait for serialization with Jackson CBOR.
|
Cell |
INTERNAL API
|
ChangeEventHandler<Command,State,ChangeEvent> |
API May Change: Implement this interface and use it in DurableStateBehavior#withChangeEventHandler
to store additional change event when the state is updated.
|
ChangeEventHandler<Command,State,ChangeEvent> |
|
ChangeEventHandler$ |
INTERNAL API
|
ChangeEventHandler$ |
API May Change
|
ChangeNumberOfProcesses |
Tell the sharded daemon process to rescale to the given number of processes.
|
ChangeNumberOfProcesses$ |
|
ChannelRegistration |
Implementations of this interface are sent as actor messages back to a channel actor as
a result of it having called register on the ChannelRegistry .
|
ChannelRegistry |
Interface behind which we hide our selector management logic from the connection actors
|
ChildActorPath |
Not for user instantiation
|
ChildFailed |
Child has failed due an uncaught exception
|
ChildFailed$ |
|
ChildNameReserved |
INTERNAL API
|
ChildNameReserved$ |
INTERNAL API
|
Children |
INTERNAL API
|
Children$ |
INTERNAL API
|
ChildrenContainer |
INTERNAL API
|
ChildrenContainer.ChildrenIterable |
|
ChildrenContainer.ChildRestartsIterable |
|
ChildrenContainer.Creation |
|
ChildrenContainer.Creation$ |
|
ChildrenContainer.EmptyChildrenContainer |
|
ChildrenContainer.EmptyChildrenContainer$ |
This is the empty container, shared among all leaf actors.
|
ChildrenContainer.NormalChildrenContainer |
Normal children container: we do have at least one child, but none of our
children are currently terminating (which is the time period between
calling context.stop(child) and processing the ChildTerminated() system
message).
|
ChildrenContainer.NormalChildrenContainer$ |
|
ChildrenContainer.Recreation |
|
ChildrenContainer.Recreation$ |
|
ChildrenContainer.SuspendReason |
|
ChildrenContainer.TerminatedChildrenContainer$ |
This is the empty container which is installed after the last child has
terminated while stopping; it is necessary to distinguish from the normal
empty state while calling handleChildTerminated() for the last time.
|
ChildrenContainer.TerminatingChildrenContainer |
Waiting state: there are outstanding termination requests (i.e.
|
ChildrenContainer.TerminatingChildrenContainer$ |
|
ChildrenContainer.Termination$ |
|
ChildrenContainer.UserRequest$ |
|
ChildrenContainer.WaitingForChildren |
|
ChildrenContainer$ |
INTERNAL API
|
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
|
ChunkedMessage$ |
|
CircuitBreaker |
Provides circuit breaker functionality for stability when working with "dangerous" operations, e.g.
|
CircuitBreaker.State |
Internal state abstraction
|
CircuitBreaker$ |
Companion object providing factory methods for Circuit Breaker which runs callbacks in caller's thread
|
CircuitBreakerNoopTelemetry |
INTERNAL API
|
CircuitBreakerNoopTelemetry$ |
INTERNAL API
|
CircuitBreakerOpenException |
Exception thrown when Circuit Breaker is open.
|
CircuitBreakerOpenException$ |
|
CircuitBreakersRegistry |
A CircuitBreakersPanel is a central point collecting all circuit breakers in Akka.
|
CircuitBreakersRegistry$ |
Companion object providing factory methods for Circuit Breaker which runs callbacks in caller's thread
|
CircuitBreakerTelemetry |
Service Provider Interface (SPI) for collecting metrics from Circuit Breaker.
|
CircuitBreakerTelemetryProvider |
INTERNAL API
|
CircuitBreakerTelemetryProvider$ |
INTERNAL API
|
ClassicActorContextProvider |
Glue API introduced to allow minimal user effort integration between classic and typed for example for streams.
|
ClassicActorSystemProvider |
Glue API introduced to allow minimal user effort integration between classic and typed for example for streams.
|
ClassLoaderObjectInputStream |
ClassLoaderObjectInputStream tries to utilize the provided ClassLoader to load Classes and falls
back to ObjectInputStreams resolver.
|
ClearOps |
|
ClearPreservingSeqNums |
|
Client |
INTERNAL API.
|
Client |
The client is usually the side that consumes the service provided by its
interlocutor.
|
Client$ |
INTERNAL API.
|
Client$ |
|
ClientFSM$ |
INTERNAL API.
|
ClientOp |
|
ClientTimeoutException |
|
Clock |
INTERNAL API
|
Clock$ |
INTERNAL API
|
ClosedShape |
This Shape is used for graphs that have neither open inputs nor open
outputs.
|
ClosedShape$ |
|
Cluster |
This module is responsible cluster membership information.
|
Cluster |
This class is not intended for user extension other than for test purposes (e.g.
|
Cluster$ |
Cluster Extension Id and factory for creating Cluster extension.
|
Cluster$ |
Akka Typed Cluster API entry point
|
ClusterCommand |
Not intended for user extension.
|
ClusterCoreDaemon$ |
INTERNAL API.
|
ClusterEvent |
Domain events published to the event bus.
|
ClusterEvent.ClusterDomainEvent |
Marker interface for cluster domain events.
|
ClusterEvent.ClusterShuttingDown$ |
|
ClusterEvent.CurrentClusterState |
|
ClusterEvent.CurrentClusterState$ |
|
ClusterEvent.CurrentInternalStats$ |
|
ClusterEvent.DataCenterReachabilityEvent |
Deprecated.
|
ClusterEvent.InitialStateAsEvents$ |
When using this subscription mode the events corresponding
to the current state will be sent to the subscriber to mimic what you would
have seen if you were listening to the events when they occurred in the past.
|
ClusterEvent.InitialStateAsSnapshot$ |
|
ClusterEvent.LeaderChanged |
Leader of the cluster data center of this node changed.
|
ClusterEvent.LeaderChanged$ |
|
ClusterEvent.MemberDowned |
Member status changed to MemberStatus.Down and will be removed
when all members have seen the Down status.
|
ClusterEvent.MemberDowned$ |
|
ClusterEvent.MemberEvent |
Marker interface for membership events.
|
ClusterEvent.MemberExited |
Member status changed to MemberStatus.Exiting and will be removed
when all members have seen the Exiting status.
|
ClusterEvent.MemberExited$ |
|
ClusterEvent.MemberJoined |
Member status changed to Joining.
|
ClusterEvent.MemberJoined$ |
|
ClusterEvent.MemberLeft |
Member status changed to Leaving.
|
ClusterEvent.MemberLeft$ |
|
ClusterEvent.MemberPreparingForShutdown |
|
ClusterEvent.MemberPreparingForShutdown$ |
|
ClusterEvent.MemberReadyForShutdown |
|
ClusterEvent.MemberReadyForShutdown$ |
|
ClusterEvent.MemberRemoved |
Member completely removed from the cluster.
|
ClusterEvent.MemberRemoved$ |
|
ClusterEvent.MemberTombstonesChanged$ |
|
ClusterEvent.MemberUp |
Member status changed to Up.
|
ClusterEvent.MemberUp$ |
|
ClusterEvent.MemberWeaklyUp |
Member status changed to WeaklyUp.
|
ClusterEvent.MemberWeaklyUp$ |
|
ClusterEvent.ReachabilityChanged$ |
|
ClusterEvent.ReachabilityEvent |
|
ClusterEvent.ReachableDataCenter |
Deprecated.
|
ClusterEvent.ReachableDataCenter$ |
|
ClusterEvent.ReachableMember |
A member is considered as reachable by the failure detector
after having been unreachable.
|
ClusterEvent.ReachableMember$ |
|
ClusterEvent.RoleLeaderChanged |
First member (leader) of the members within a role set (in the same data center as this node,
if data centers are used) changed.
|
ClusterEvent.RoleLeaderChanged$ |
|
ClusterEvent.SeenChanged$ |
|
ClusterEvent.SubscriptionInitialStateMode |
|
ClusterEvent.UnreachableDataCenter |
Deprecated.
|
ClusterEvent.UnreachableDataCenter$ |
|
ClusterEvent.UnreachableMember |
A member is considered as unreachable by the failure detector.
|
ClusterEvent.UnreachableMember$ |
|
ClusterEvent$ |
Domain events published to the event bus.
|
ClusterHeartbeatReceiver$ |
INTERNAL API: Utilities to obtain ClusterHeartbeatReceiver paths
|
ClusterHeartbeatSender$ |
INTERNAL API
|
ClusterHeartbeatSenderState$ |
|
ClusterLogClass |
INTERNAL API
|
ClusterLogClass$ |
INTERNAL API
|
ClusterLogMarker |
This is public with the purpose to document the used markers and properties of log events.
|
ClusterLogMarker.Properties$ |
INTERNAL API
|
ClusterLogMarker$ |
This is public with the purpose to document the used markers and properties of log events.
|
ClusterMessage |
Base trait for all cluster messages.
|
ClusterMessages |
|
ClusterMessages |
|
ClusterMessages.Address |
Defines a remote address.
|
ClusterMessages.Address.Builder |
Defines a remote 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.ConfigCheck |
Protobuf type ConfigCheck
|
ClusterMessages.ConfigCheck.Builder |
Protobuf type ConfigCheck
|
ClusterMessages.ConfigCheck.Type |
Protobuf enum ConfigCheck.Type
|
ClusterMessages.ConfigCheckOrBuilder |
|
ClusterMessages.Empty |
An empty message
|
ClusterMessages.Empty.Builder |
An empty message
|
ClusterMessages.EmptyOrBuilder |
|
ClusterMessages.Gossip |
Gossip
|
ClusterMessages.Gossip.Builder |
Gossip
|
ClusterMessages.GossipEnvelope |
Gossip Envelope
|
ClusterMessages.GossipEnvelope.Builder |
Gossip Envelope
|
ClusterMessages.GossipEnvelopeOrBuilder |
|
ClusterMessages.GossipOrBuilder |
|
ClusterMessages.GossipOverview |
Gossip Overview
|
ClusterMessages.GossipOverview.Builder |
Gossip Overview
|
ClusterMessages.GossipOverviewOrBuilder |
|
ClusterMessages.GossipStatus |
Gossip Status
|
ClusterMessages.GossipStatus.Builder |
Gossip Status
|
ClusterMessages.GossipStatusOrBuilder |
|
ClusterMessages.Heartbeat |
Prior to version 2.5.24
Heartbeat sends an Address
Version 2.5.24 can deserialize this message but does not send it.
|
ClusterMessages.Heartbeat.Builder |
Prior to version 2.5.24
Heartbeat sends an Address
Version 2.5.24 can deserialize this message but does not send it.
|
ClusterMessages.HeartbeatOrBuilder |
|
ClusterMessages.HeartBeatResponse |
Prior to version 2.5.24
HeartbeatRsp Sends an UniqueAddress
Version 2.5.24 can deserialize this message but does not send it.
|
ClusterMessages.HeartBeatResponse.Builder |
Prior to version 2.5.24
HeartbeatRsp Sends an UniqueAddress
Version 2.5.24 can deserialize this message but does not send it.
|
ClusterMessages.HeartBeatResponseOrBuilder |
|
ClusterMessages.InitJoin |
InitJoin
|
ClusterMessages.InitJoin.Builder |
InitJoin
|
ClusterMessages.InitJoinAck |
InitJoinAck
|
ClusterMessages.InitJoinAck.Builder |
InitJoinAck
|
ClusterMessages.InitJoinAckOrBuilder |
|
ClusterMessages.InitJoinOrBuilder |
|
ClusterMessages.Join |
Join
|
ClusterMessages.Join.Builder |
Join
|
ClusterMessages.JoinOrBuilder |
|
ClusterMessages.Member |
Member
|
ClusterMessages.Member.Builder |
Member
|
ClusterMessages.MemberOrBuilder |
|
ClusterMessages.MemberStatus |
Member Status
|
ClusterMessages.ObserverReachability |
Reachability
|
ClusterMessages.ObserverReachability.Builder |
Reachability
|
ClusterMessages.ObserverReachabilityOrBuilder |
|
ClusterMessages.Pool |
Protobuf type Pool
|
ClusterMessages.Pool.Builder |
Protobuf type Pool
|
ClusterMessages.PoolOrBuilder |
|
ClusterMessages.PubSubMessagePublished |
Protobuf type akka.cluster.typed.PubSubMessagePublished
|
ClusterMessages.PubSubMessagePublished.Builder |
Protobuf type akka.cluster.typed.PubSubMessagePublished
|
ClusterMessages.PubSubMessagePublishedOrBuilder |
|
ClusterMessages.ReachabilityStatus |
Reachability status
|
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.UniqueAddress |
Defines a remote address with uid.
|
ClusterMessages.UniqueAddress.Builder |
Defines a remote address with uid.
|
ClusterMessages.UniqueAddressOrBuilder |
|
ClusterMessages.VectorClock |
Vector Clock
|
ClusterMessages.VectorClock.Builder |
Vector Clock
|
ClusterMessages.VectorClock.Version |
Protobuf type VectorClock.Version
|
ClusterMessages.VectorClock.Version.Builder |
Protobuf type VectorClock.Version
|
ClusterMessages.VectorClock.VersionOrBuilder |
|
ClusterMessages.VectorClockOrBuilder |
|
ClusterMessages.Welcome |
Welcome, reply to Join
|
ClusterMessages.Welcome.Builder |
Welcome, reply to Join
|
ClusterMessages.WelcomeOrBuilder |
|
ClusterMessageSerializer |
Protobuf serializer of cluster messages.
|
ClusterMessageSerializer$ |
INTERNAL API
|
ClusterMetricsChanged |
Current snapshot of cluster node metrics.
|
ClusterMetricsChanged$ |
|
ClusterMetricsCollector$ |
INTERNAL API.
|
ClusterMetricsEvent |
Local cluster metrics extension events.
|
ClusterMetricsExtension |
Cluster metrics extension.
|
ClusterMetricsExtension$ |
Cluster metrics extension provider.
|
ClusterMetricsMessage |
INTERNAL API.
|
ClusterMetricsMessages |
|
ClusterMetricsMessages.AdaptiveLoadBalancingPool |
Protobuf type AdaptiveLoadBalancingPool
|
ClusterMetricsMessages.AdaptiveLoadBalancingPool.Builder |
Protobuf type AdaptiveLoadBalancingPool
|
ClusterMetricsMessages.AdaptiveLoadBalancingPoolOrBuilder |
|
ClusterMetricsMessages.Address |
Defines a remote address.
|
ClusterMetricsMessages.Address.Builder |
Defines a remote address.
|
ClusterMetricsMessages.AddressOrBuilder |
|
ClusterMetricsMessages.MetricsGossip |
Metrics Gossip
|
ClusterMetricsMessages.MetricsGossip.Builder |
Metrics Gossip
|
ClusterMetricsMessages.MetricsGossipEnvelope |
Metrics Gossip Envelope
|
ClusterMetricsMessages.MetricsGossipEnvelope.Builder |
Metrics Gossip Envelope
|
ClusterMetricsMessages.MetricsGossipEnvelopeOrBuilder |
|
ClusterMetricsMessages.MetricsGossipOrBuilder |
|
ClusterMetricsMessages.MetricsSelector |
couldn't figure out how to import Payload
|
ClusterMetricsMessages.MetricsSelector.Builder |
couldn't figure out how to import Payload
|
ClusterMetricsMessages.MetricsSelectorOrBuilder |
|
ClusterMetricsMessages.MixMetricsSelector |
Protobuf type MixMetricsSelector
|
ClusterMetricsMessages.MixMetricsSelector.Builder |
Protobuf type MixMetricsSelector
|
ClusterMetricsMessages.MixMetricsSelectorOrBuilder |
|
ClusterMetricsMessages.NodeMetrics |
Node Metrics
|
ClusterMetricsMessages.NodeMetrics.Builder |
Node Metrics
|
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 |
Default ClusterMetricsSupervisor strategy:
A configurable OneForOneStrategy with restart-on-throwable decider.
|
ClusterMetricsStrategy$ |
Provide custom metrics strategy resources.
|
ClusterNodeMBean |
Interface for the cluster JMX MBean.
|
ClusterReadView$ |
INTERNAL API
|
ClusterReceptionist$ |
INTERNAL API
|
ClusterReceptionistProtocol |
INTERNAL API
|
ClusterReceptionistProtocol$ |
INTERNAL API
|
ClusterReceptionistSettings$ |
Internal API
|
ClusterRemoteWatcher$ |
INTERNAL API
|
ClusterRouterActor |
INTERNAL API
The router actor, subscribes to cluster events and
adjusts the routees.
|
ClusterRouterConfigBase |
INTERNAL API
|
ClusterRouterGroup |
RouterConfig implementation for deployment on cluster nodes.
|
ClusterRouterGroup$ |
|
ClusterRouterGroupSettings |
totalInstances of cluster router must be > 0
|
ClusterRouterGroupSettings$ |
|
ClusterRouterPool |
RouterConfig implementation for deployment on cluster nodes.
|
ClusterRouterPool$ |
|
ClusterRouterPoolSettings |
totalInstances of cluster router must be > 0
maxInstancesPerNode of cluster router must be > 0
maxInstancesPerNode of cluster router must be 1 when routeesPath is defined
|
ClusterRouterPoolSettings$ |
|
ClusterRouterSettingsBase |
INTERNAL API
|
ClusterRouterSettingsBase$ |
INTERNAL API
|
ClusterScope |
|
ClusterScope$ |
Cluster aware scope of a Deploy
|
ClusterSettings |
|
ClusterSettings$ |
|
ClusterSetup |
Can be used in ActorSystemSetup when starting the ActorSystem
to replace the default implementation of the Cluster extension.
|
ClusterSetup$ |
|
ClusterShardAllocationMixin |
INTERNAL API
|
ClusterShardAllocationMixin.RegionEntry |
|
ClusterShardAllocationMixin.RegionEntry$ |
|
ClusterShardAllocationMixin.ShardSuitabilityOrdering |
|
ClusterShardAllocationMixin.ShardSuitabilityOrdering$ |
|
ClusterShardAllocationMixin$ |
INTERNAL API
|
ClusterSharding |
|
ClusterSharding |
This extension provides sharding functionality of actors in a cluster.
|
ClusterSharding |
This extension provides sharding functionality of actors in a cluster.
|
ClusterSharding.Passivate<M> |
The entity can request passivation by sending the ClusterSharding.Passivate message
to the ActorRef[ShardCommand] that was passed in to the factory method
when creating the entity.
|
ClusterSharding.Passivate<M> |
The entity can request passivation by sending the ClusterSharding.Passivate message
to the ActorRef[ShardCommand] that was passed in to the factory method
when creating the entity.
|
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$ |
|
ClusterSharding$ |
|
ClusterShardingGuardian$ |
INTERNAL API.
|
ClusterShardingHealthCheck |
INTERNAL API (ctr)
|
ClusterShardingHealthCheck$ |
|
ClusterShardingHealthCheckSettings |
|
ClusterShardingHealthCheckSettings$ |
Internal API
|
ClusterShardingMessages |
|
ClusterShardingMessages.ActorRefMessage |
Protobuf type ActorRefMessage
|
ClusterShardingMessages.ActorRefMessage.Builder |
Protobuf type ActorRefMessage
|
ClusterShardingMessages.ActorRefMessageOrBuilder |
|
ClusterShardingMessages.Address |
Defines a remote address.
|
ClusterShardingMessages.Address.Builder |
Defines a remote 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.CurrentShardRegionState |
Protobuf type CurrentShardRegionState
|
ClusterShardingMessages.CurrentShardRegionState.Builder |
Protobuf type CurrentShardRegionState
|
ClusterShardingMessages.CurrentShardRegionStateOrBuilder |
|
ClusterShardingMessages.CurrentShardState |
Protobuf type CurrentShardState
|
ClusterShardingMessages.CurrentShardState.Builder |
Protobuf type CurrentShardState
|
ClusterShardingMessages.CurrentShardStateOrBuilder |
|
ClusterShardingMessages.EntitiesStarted |
Protobuf type EntitiesStarted
|
ClusterShardingMessages.EntitiesStarted.Builder |
Protobuf type EntitiesStarted
|
ClusterShardingMessages.EntitiesStartedOrBuilder |
|
ClusterShardingMessages.EntitiesStopped |
Protobuf type EntitiesStopped
|
ClusterShardingMessages.EntitiesStopped.Builder |
Protobuf type EntitiesStopped
|
ClusterShardingMessages.EntitiesStoppedOrBuilder |
|
ClusterShardingMessages.EntityStarted |
not written anymore but kept for backwards compatibility
|
ClusterShardingMessages.EntityStarted.Builder |
not written anymore but kept for backwards compatibility
|
ClusterShardingMessages.EntityStartedOrBuilder |
|
ClusterShardingMessages.EntityState |
Protobuf type EntityState
|
ClusterShardingMessages.EntityState.Builder |
Protobuf type EntityState
|
ClusterShardingMessages.EntityStateOrBuilder |
|
ClusterShardingMessages.EntityStopped |
not written anymore but kept for backwards compatibility
|
ClusterShardingMessages.EntityStopped.Builder |
not written anymore but kept for backwards compatibility
|
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.RememberedShardState |
Protobuf type RememberedShardState
|
ClusterShardingMessages.RememberedShardState.Builder |
Protobuf type RememberedShardState
|
ClusterShardingMessages.RememberedShardStateOrBuilder |
|
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.ShardHomes |
Protobuf type ShardHomes
|
ClusterShardingMessages.ShardHomes.Builder |
Protobuf type ShardHomes
|
ClusterShardingMessages.ShardHomesEntry |
only used nested in ShardHomes
|
ClusterShardingMessages.ShardHomesEntry.Builder |
only used nested in ShardHomes
|
ClusterShardingMessages.ShardHomesEntryOrBuilder |
|
ClusterShardingMessages.ShardHomesOrBuilder |
|
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.ShardState |
Protobuf type ShardState
|
ClusterShardingMessages.ShardState.Builder |
Protobuf type ShardState
|
ClusterShardingMessages.ShardStateOrBuilder |
|
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 |
|
ClusterShardingMessages.StopShards |
Protobuf type StopShards
|
ClusterShardingMessages.StopShards.Builder |
Protobuf type StopShards
|
ClusterShardingMessages.StopShardsOrBuilder |
|
ClusterShardingQuery |
Protocol for querying sharding state e.g.
|
ClusterShardingSerializable |
Marker trait for remote messages and persistent events/snapshots with special serializer.
|
ClusterShardingSettings |
param: role specifies that this entity type requires cluster nodes with a specific role.
|
ClusterShardingSettings |
param: numberOfShards number of shards used by the default HashCodeMessageExtractor
param: role Specifies that this entity type requires cluster nodes with a specific role.
|
ClusterShardingSettings.CompositePassivationStrategy$ |
INTERNAL API
|
ClusterShardingSettings.CompositePassivationStrategy$.AdmissionFilter |
|
ClusterShardingSettings.CompositePassivationStrategy$.AdmissionFilter$ |
|
ClusterShardingSettings.CompositePassivationStrategy$.AdmissionOptimizer |
|
ClusterShardingSettings.CompositePassivationStrategy$.AdmissionOptimizer$ |
|
ClusterShardingSettings.CompositePassivationStrategy$.AlwaysAdmissionFilter$ |
|
ClusterShardingSettings.CompositePassivationStrategy$.FrequencySketchAdmissionFilter |
|
ClusterShardingSettings.CompositePassivationStrategy$.FrequencySketchAdmissionFilter$ |
|
ClusterShardingSettings.CompositePassivationStrategy$.HillClimbingAdmissionOptimizer |
|
ClusterShardingSettings.CompositePassivationStrategy$.HillClimbingAdmissionOptimizer$ |
|
ClusterShardingSettings.CompositePassivationStrategy$.NoAdmissionOptimizer$ |
|
ClusterShardingSettings.IdlePassivationStrategy$ |
INTERNAL API
|
ClusterShardingSettings.LeastFrequentlyUsedPassivationStrategy$ |
INTERNAL API
|
ClusterShardingSettings.LeastRecentlyUsedPassivationStrategy$ |
INTERNAL API
|
ClusterShardingSettings.MostRecentlyUsedPassivationStrategy$ |
|
ClusterShardingSettings.NoPassivationStrategy$ |
INTERNAL API
|
ClusterShardingSettings.PassivationStrategy |
INTERNAL API
|
ClusterShardingSettings.PassivationStrategy$ |
INTERNAL API
Determine the passivation strategy to use from settings.
|
ClusterShardingSettings.PassivationStrategySettings |
API MAY CHANGE: Settings for passivation strategies may change after additional testing and feedback.
|
ClusterShardingSettings.PassivationStrategySettings |
API MAY CHANGE: Settings for passivation strategies may change after additional testing and feedback.
|
ClusterShardingSettings.PassivationStrategySettings$ |
API MAY CHANGE: Settings for passivation strategies may change after additional testing and feedback.
|
ClusterShardingSettings.PassivationStrategySettings$ |
API MAY CHANGE: Settings for passivation strategies may change after additional testing and feedback.
|
ClusterShardingSettings.PassivationStrategySettings$.AdmissionSettings |
|
ClusterShardingSettings.PassivationStrategySettings$.AdmissionSettings |
|
ClusterShardingSettings.PassivationStrategySettings$.AdmissionSettings$ |
|
ClusterShardingSettings.PassivationStrategySettings$.AdmissionSettings$ |
|
ClusterShardingSettings.PassivationStrategySettings$.AdmissionSettings$.FilterSettings |
|
ClusterShardingSettings.PassivationStrategySettings$.AdmissionSettings$.FilterSettings |
|
ClusterShardingSettings.PassivationStrategySettings$.AdmissionSettings$.FilterSettings$ |
|
ClusterShardingSettings.PassivationStrategySettings$.AdmissionSettings$.FilterSettings$ |
|
ClusterShardingSettings.PassivationStrategySettings$.AdmissionSettings$.FrequencySketchSettings |
|
ClusterShardingSettings.PassivationStrategySettings$.AdmissionSettings$.FrequencySketchSettings |
|
ClusterShardingSettings.PassivationStrategySettings$.AdmissionSettings$.FrequencySketchSettings$ |
|
ClusterShardingSettings.PassivationStrategySettings$.AdmissionSettings$.FrequencySketchSettings$ |
|
ClusterShardingSettings.PassivationStrategySettings$.AdmissionSettings$.HillClimbingSettings |
|
ClusterShardingSettings.PassivationStrategySettings$.AdmissionSettings$.HillClimbingSettings |
|
ClusterShardingSettings.PassivationStrategySettings$.AdmissionSettings$.HillClimbingSettings$ |
|
ClusterShardingSettings.PassivationStrategySettings$.AdmissionSettings$.HillClimbingSettings$ |
|
ClusterShardingSettings.PassivationStrategySettings$.AdmissionSettings$.OptimizerSettings |
|
ClusterShardingSettings.PassivationStrategySettings$.AdmissionSettings$.OptimizerSettings |
|
ClusterShardingSettings.PassivationStrategySettings$.AdmissionSettings$.OptimizerSettings$ |
|
ClusterShardingSettings.PassivationStrategySettings$.AdmissionSettings$.OptimizerSettings$ |
|
ClusterShardingSettings.PassivationStrategySettings$.AdmissionSettings$.WindowSettings |
|
ClusterShardingSettings.PassivationStrategySettings$.AdmissionSettings$.WindowSettings |
|
ClusterShardingSettings.PassivationStrategySettings$.AdmissionSettings$.WindowSettings$ |
|
ClusterShardingSettings.PassivationStrategySettings$.AdmissionSettings$.WindowSettings$ |
|
ClusterShardingSettings.PassivationStrategySettings$.IdleSettings |
|
ClusterShardingSettings.PassivationStrategySettings$.IdleSettings |
|
ClusterShardingSettings.PassivationStrategySettings$.IdleSettings$ |
|
ClusterShardingSettings.PassivationStrategySettings$.IdleSettings$ |
|
ClusterShardingSettings.PassivationStrategySettings$.LeastFrequentlyUsedSettings |
|
ClusterShardingSettings.PassivationStrategySettings$.LeastFrequentlyUsedSettings |
|
ClusterShardingSettings.PassivationStrategySettings$.LeastFrequentlyUsedSettings$ |
|
ClusterShardingSettings.PassivationStrategySettings$.LeastFrequentlyUsedSettings$ |
|
ClusterShardingSettings.PassivationStrategySettings$.LeastRecentlyUsedSettings |
|
ClusterShardingSettings.PassivationStrategySettings$.LeastRecentlyUsedSettings |
|
ClusterShardingSettings.PassivationStrategySettings$.LeastRecentlyUsedSettings$ |
|
ClusterShardingSettings.PassivationStrategySettings$.LeastRecentlyUsedSettings$ |
|
ClusterShardingSettings.PassivationStrategySettings$.LeastRecentlyUsedSettings$.SegmentedSettings |
|
ClusterShardingSettings.PassivationStrategySettings$.LeastRecentlyUsedSettings$.SegmentedSettings |
|
ClusterShardingSettings.PassivationStrategySettings$.LeastRecentlyUsedSettings$.SegmentedSettings$ |
|
ClusterShardingSettings.PassivationStrategySettings$.LeastRecentlyUsedSettings$.SegmentedSettings$ |
|
ClusterShardingSettings.PassivationStrategySettings$.MostRecentlyUsedSettings |
|
ClusterShardingSettings.PassivationStrategySettings$.MostRecentlyUsedSettings |
|
ClusterShardingSettings.PassivationStrategySettings$.MostRecentlyUsedSettings$ |
|
ClusterShardingSettings.PassivationStrategySettings$.MostRecentlyUsedSettings$ |
|
ClusterShardingSettings.PassivationStrategySettings$.PolicySettings |
|
ClusterShardingSettings.PassivationStrategySettings$.PolicySettings |
|
ClusterShardingSettings.PassivationStrategySettings$.PolicySettings$ |
|
ClusterShardingSettings.PassivationStrategySettings$.PolicySettings$ |
|
ClusterShardingSettings.RememberEntitiesStoreMode |
|
ClusterShardingSettings.RememberEntitiesStoreMode$ |
|
ClusterShardingSettings.RememberEntitiesStoreModeDData$ |
|
ClusterShardingSettings.RememberEntitiesStoreModeEventSourced$ |
|
ClusterShardingSettings.StateStoreMode |
|
ClusterShardingSettings.StateStoreMode$ |
|
ClusterShardingSettings.StateStoreModeDData$ |
|
ClusterShardingSettings.StateStoreModePersistence$ |
|
ClusterShardingSettings.TuningParameters |
|
ClusterShardingSettings.TuningParameters |
|
ClusterShardingSettings$ |
|
ClusterShardingSettings$ |
|
ClusterShardingSetup |
|
ClusterShardingSetup$ |
|
ClusterShardingTypedSerializable |
INTERNAL API
|
ClusterSingleton |
This class is not intended for user extension other than for test purposes (e.g.
|
ClusterSingleton$ |
|
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 |
INTERNAL API
public due to the with FSM type parameters
|
ClusterSingletonManager.Internal$ |
INTERNAL API
|
ClusterSingletonManager.State |
INTERNAL API
public due to the with FSM type parameters
|
ClusterSingletonManager$ |
|
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$ |
|
ClusterSingletonManagerSettings$ |
|
ClusterSingletonMessage |
Marker trait for remote messages with special serializer.
|
ClusterSingletonProxy |
The ClusterSingletonProxy works together with the ClusterSingletonManager to provide a
distributed proxy to the singleton actor.
|
ClusterSingletonProxy$ |
|
ClusterSingletonProxySettings |
|
ClusterSingletonProxySettings$ |
|
ClusterSingletonSettings |
|
ClusterSingletonSettings$ |
|
ClusterSingletonSetup |
|
ClusterSingletonSetup$ |
|
ClusterStateSubscription |
Messages for subscribing to changes in the cluster state
|
ClusterUserAction |
INTERNAL API
Cluster commands sent by the USER via
Cluster extension
or JMX.
|
ClusterUserAction.Down |
Command to mark node as temporary down.
|
ClusterUserAction.Down$ |
|
ClusterUserAction.JoinTo |
Command to initiate join another node (represented by address ).
|
ClusterUserAction.JoinTo$ |
|
ClusterUserAction.Leave |
Command to leave the cluster.
|
ClusterUserAction.Leave$ |
|
ClusterUserAction.PrepareForShutdown$ |
Command to mark all nodes as shutting down
|
ClusterUserAction.SetAppVersion |
Command to set the appVersion after system startup but before joining.
|
ClusterUserAction.SetAppVersion$ |
|
ClusterUserAction.SetAppVersionLater$ |
The appVersion is defined after system startup but before joining.
|
ClusterUserAction$ |
INTERNAL API
Cluster commands sent by the USER via
Cluster extension
or JMX.
|
CNameRecord |
|
CNameRecord$ |
|
CollectionControlMessage |
Runtime collection management commands.
|
Collections |
INTERNAL API
|
Collections.EmptyImmutableSeq$ |
|
Collections.PartialImmutableValuesIterable<From,To> |
|
Collections$ |
INTERNAL API
|
CollectionStartMessage |
Command for ClusterMetricsSupervisor to start metrics collection.
|
CollectionStartMessage$ |
Command for ClusterMetricsSupervisor to start metrics collection.
|
CollectionStopMessage |
Command for ClusterMetricsSupervisor to stop metrics collection.
|
CollectionStopMessage$ |
Command for ClusterMetricsSupervisor to stop metrics collection.
|
CommandHandler<Command,Event,State> |
FunctionalInterface for reacting on commands
|
CommandHandler<Command,State> |
FunctionalInterface for reacting on commands
|
CommandHandlerBuilder<Command,Event,State> |
|
CommandHandlerBuilder<Command,State> |
|
CommandHandlerBuilder$ |
|
CommandHandlerBuilder$ |
|
CommandHandlerBuilderByState<Command,Event,S extends State,State> |
|
CommandHandlerBuilderByState<Command,S extends State,State> |
|
CommandHandlerBuilderByState$ |
|
CommandHandlerBuilderByState$ |
|
CommandHandlerWithReply<Command,Event,State> |
FunctionalInterface for reacting on commands
|
CommandHandlerWithReply<Command,State> |
FunctionalInterface for reacting on commands
|
CommandHandlerWithReplyBuilder<Command,Event,State> |
|
CommandHandlerWithReplyBuilder<Command,State> |
|
CommandHandlerWithReplyBuilder$ |
|
CommandHandlerWithReplyBuilder$ |
|
CommandHandlerWithReplyBuilderByState<Command,Event,S extends State,State> |
|
CommandHandlerWithReplyBuilderByState<Command,S extends State,State> |
|
CommandHandlerWithReplyBuilderByState$ |
|
CommandHandlerWithReplyBuilderByState$ |
|
CommandOp |
|
CommonTestKitOps<S,P> |
|
CompactByteString |
A compact ByteString.
|
CompactByteString$ |
|
CompactionSegmentManagement |
INTERNAL API.
|
CompactionSegmentManagement$ |
|
CompletionStrategy |
|
CompletionStrategy.Draining$ |
INTERNAL API
|
CompletionStrategy.Immediately$ |
INTERNAL API
|
CompletionStrategy$ |
|
CompletionTimeoutException |
|
CompositeEffect$ |
INTERNAL API
|
CompositeEffect$ |
INTERNAL API
|
Compression |
|
Compression |
|
Compression |
|
Compression.Algoritm |
|
Compression.GZip |
|
Compression.GZip$ |
|
Compression.LZ4 |
|
Compression.LZ4$ |
|
Compression.Off$ |
|
Compression$ |
|
Compression$ |
|
Compression$ |
|
CompressionActorRefAdvertisement |
INTERNAL API
|
CompressionClassManifestAdvertisement |
INTERNAL API
|
CompressionProtocol |
INTERNAL API
|
CompressionProtocol.ActorRefCompressionAdvertisement$ |
|
CompressionProtocol.ActorRefCompressionAdvertisementAck$ |
|
CompressionProtocol.ClassManifestCompressionAdvertisement$ |
|
CompressionProtocol.ClassManifestCompressionAdvertisementAck$ |
|
CompressionProtocol.CompressionAckMessage |
INTERNAL API
|
CompressionProtocol.CompressionAdvertisement<T> |
INTERNAL API
|
CompressionProtocol.CompressionMessage |
INTERNAL API
|
CompressionProtocol.Events$ |
INTERNAL API
|
CompressionProtocol.Events$.Event |
INTERNAL API
|
CompressionProtocol$ |
INTERNAL API
|
CompressionTable$ |
INTERNAL API
|
Concat |
Takes two streams and outputs an output stream formed from the two input streams
by consuming one stream first emitting all of its elements, then consuming the
second stream emitting all of its elements.
|
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$ |
Takes two streams and outputs an output stream formed from the two input streams
by consuming one stream first emitting all of its elements, then consuming the
second stream emitting all of its elements.
|
Concat$ |
|
ConcurrentAsyncCallbackState |
INTERNAL API
|
ConcurrentAsyncCallbackState.Event<E> |
|
ConcurrentAsyncCallbackState.Event$ |
|
ConcurrentAsyncCallbackState.Initialized$ |
|
ConcurrentAsyncCallbackState.Pending<E> |
|
ConcurrentAsyncCallbackState.Pending$ |
|
ConcurrentAsyncCallbackState.State<E> |
|
ConcurrentAsyncCallbackState$ |
INTERNAL API
|
ConcurrentMultiMap<K,V> |
An implementation of a ConcurrentMultiMap
Adds/remove is serialized over the specified key
Reads are fully concurrent <-- el-cheapo
|
Conductor |
The conductor is the one orchestrating the test: it governs the
Controller ’s port to which all
Player s connect, it issues commands to their
akka.remote.testconductor.NetworkFailureInjector and provides support
for barriers using the BarrierCoordinator .
|
ConfigServicesParser |
INTERNAL API
|
ConfigServicesParser$ |
INTERNAL API
|
ConfigSSLEngineProvider |
Config in akka.remote.artery.ssl.config-ssl-engine
|
ConfigurationException |
This exception is thrown when Akka detects a problem with the provided configuration
|
ConfigValidation |
|
ConfirmedClientOp |
|
ConnectionException |
|
ConnectionSnapshot |
Not for user extension
|
ConnectionSnapshot.Closed$ |
|
ConnectionSnapshot.ConnectionState |
Not for user extension
|
ConnectionSnapshot.ShouldPull$ |
|
ConnectionSnapshot.ShouldPush$ |
|
ConnectionSnapshot$ |
|
ConnectionSnapshotImpl$ |
|
ConsistentHash<T> |
Consistent Hashing node ring implementation.
|
ConsistentHash$ |
|
ConsistentHashingGroup |
A router group that uses consistent hashing to select a routee based on the
sent message.
|
ConsistentHashingGroup$ |
|
ConsistentHashingPool |
A router pool that uses consistent hashing to select a routee based on the
sent message.
|
ConsistentHashingPool$ |
|
ConsistentHashingRouter |
|
ConsistentHashingRouter.ConsistentHashable |
If you don't define the hashMapping when
constructing the ConsistentHashingRouter
the messages need to implement this interface to define what
data to use for the consistent hash key.
|
ConsistentHashingRouter.ConsistentHashableEnvelope |
|
ConsistentHashingRouter.ConsistentHashableEnvelope$ |
|
ConsistentHashingRouter.ConsistentHashMapper |
JAVA API
Mapping from message to the data to use for the consistent hash key.
|
ConsistentHashingRouter.emptyConsistentHashMapping$ |
|
ConsistentHashingRouter$ |
|
ConsistentHashingRoutingLogic |
|
ConsistentHashingRoutingLogic$ |
|
ConsistentHashingShardAllocationStrategy |
|
ConsistentHashingShardAllocationStrategy$ |
|
ConsistentRoutee$ |
|
ConstantFun |
INTERNAL API
|
ConstantFun$ |
INTERNAL API
|
ConsumerController |
|
ConsumerController.Command<A> |
|
ConsumerController.Confirmed |
|
ConsumerController.Confirmed$ |
When the message has been processed the consumer is supposed to send Confirmed back
to the ConsumerController via the confirmTo in the ConsumerController.Delivery message.
|
ConsumerController.DeliverThenStop<A> |
|
ConsumerController.DeliverThenStop$ |
|
ConsumerController.Delivery<A> |
Received messages from the producer are wrapped in Delivery when sent to the consumer.
|
ConsumerController.Delivery$ |
|
ConsumerController.RegisterToProducerController<A> |
Register the ConsumerController to the given producerController .
|
ConsumerController.RegisterToProducerController$ |
|
ConsumerController.SequencedMessage<A> |
|
ConsumerController.SequencedMessage$ |
|
ConsumerController.Settings |
|
ConsumerController.Settings$ |
|
ConsumerController.Start<A> |
Initial message from the consumer actor.
|
ConsumerController.Start$ |
|
ConsumerController$ |
|
ConsumerControllerImpl<A> |
|
ConsumerControllerImpl.InternalCommand |
|
ConsumerControllerImpl.UnsealedInternalCommand |
For commands defined in public ConsumerController
|
ConsumerControllerImpl$ |
INTERNAL API
|
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.StatusReplyErrorMessage |
ReplyWith pattern message(s)
|
ContainerFormats.StatusReplyErrorMessage.Builder |
ReplyWith pattern message(s)
|
ContainerFormats.StatusReplyErrorMessageOrBuilder |
|
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 |
|
ControlAwareMessageQueueSemantics |
ControlAwareMessageQueue handles messages that extend ControlMessage with priority.
|
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 |
|
CoordinatedShutdown.ActorSystemTerminateReason$ |
|
CoordinatedShutdown.ClusterDowningReason$ |
|
CoordinatedShutdown.ClusterJoinUnsuccessfulReason$ |
|
CoordinatedShutdown.ClusterLeavingReason$ |
|
CoordinatedShutdown.IncompatibleConfigurationDetectedReason$ |
|
CoordinatedShutdown.JvmExitReason$ |
|
CoordinatedShutdown.Phase$ |
|
CoordinatedShutdown.PhaseDefinition |
|
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$ |
|
CoordinatedShutdownLeave$ |
INTERNAL API
|
CoordinatedShutdownTerminationWatcher$ |
INTERNAL API
|
Counter |
|
Counter.Updated |
|
Counter.Updated$ |
|
Counter$ |
|
CountMinSketch |
INTERNAL API: Count-Min Sketch datastructure.
|
CpuMetricsSelector |
MetricsSelector that uses the combined CPU time metrics and stolen CPU time metrics.
|
CpuMetricsSelector$ |
MetricsSelector that uses the combined CPU time metrics and stolen CPU time metrics.
|
Create$ |
|
Create$ |
|
Creator<T> |
A constructor/factory, takes no parameters but creates a new value of type T every call.
|
Creator<T> |
A constructor/factory, takes no parameters but creates a new value of type T every call.
|
CrossDcHeartbeatingState$ |
INTERNAL API
|
CrossDcHeartbeatSender$ |
INTERNAL API
|
CurrentEventsByPersistenceIdQuery |
A plugin may optionally support this query by implementing this interface.
|
CurrentEventsByPersistenceIdQuery |
A plugin may optionally support this query by implementing this trait.
|
CurrentEventsByPersistenceIdStartingFromSnapshotQuery |
A plugin may optionally support this query by implementing this trait.
|
CurrentEventsByPersistenceIdStartingFromSnapshotQuery |
A plugin may optionally support this query by implementing this trait.
|
CurrentEventsByPersistenceIdTypedQuery |
A plugin may optionally support this query by implementing this trait.
|
CurrentEventsByPersistenceIdTypedQuery |
A plugin may optionally support this query by implementing this trait.
|
CurrentEventsBySliceQuery |
A plugin may optionally support this query by implementing this trait.
|
CurrentEventsBySliceQuery |
A plugin may optionally support this query by implementing this trait.
|
CurrentEventsBySliceStartingFromSnapshotsQuery |
A plugin may optionally support this query by implementing this trait.
|
CurrentEventsBySliceStartingFromSnapshotsQuery |
A plugin may optionally support this query by implementing this trait.
|
CurrentEventsByTagQuery |
A plugin may optionally support this query by implementing this interface.
|
CurrentEventsByTagQuery |
A plugin may optionally support this query by implementing this trait.
|
CurrentPersistenceIdsQuery |
A plugin may optionally support this query by implementing this interface.
|
CurrentPersistenceIdsQuery |
A plugin may optionally support this query by implementing this trait.
|
CurrentTime |
INTERNAL API
|
CurrentTime$ |
INTERNAL API
|
CustomEventFilter |
Custom event filter when the others do not fit the bill.
|
CustomEventFilter$ |
|
CustomRouterConfig |
If a custom router implementation is not a Group nor
a Pool it may extend this base class.
|
DaemonMsg |
INTERNAL API
|
DaemonMsgCreate$ |
|
DDataRememberEntitiesCoordinatorStore$ |
INTERNAL API
|
DDataRememberEntitiesShardStore$ |
INTERNAL API
|
DDataShardCoordinator$ |
INTERNAL API
|
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$ |
|
DeadLetterListener |
|
DeadLettersFilter |
|
DeadLettersFilter$ |
|
DeadLetterSuppression |
Use with caution: Messages extending this trait will not be logged by the default dead-letters listener.
|
DeadlineFailureDetector |
Implementation of failure detector using an absolute timeout of missing heartbeats
to trigger unavailability.
|
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 |
Exception that an actor fails with if it does not handle a Terminated message.
|
DeathPactException$ |
|
DeathPactException$ |
|
DeathWatch |
INTERNAL API
|
DeathWatchNotification$ |
|
DeathWatchNotification$ |
|
DebugFilter |
Filter which matches Debug events, if they satisfy the given criteria:
source , if given, applies a filter on the event’s origin
message applies a filter on the event’s message (either with String.startsWith or Regex.findFirstIn().isDefined)
If you want to match all Debug events, the most efficient is to use Left("") .
|
DebugFilter$ |
|
DeciderBuilder |
|
Decoder$ |
INTERNAL API
|
DecompressionTable$ |
INTERNAL API
|
DefaultDispatcherPrerequisites$ |
|
DefaultExecutorServiceConfigurator |
|
DefaultFailureDetectorRegistry<A> |
|
DefaultLoggingFilter |
|
DefaultOptimalSizeExploringResizer |
This resizer resizes the pool to an optimal size that provides
the most message throughput.
|
DefaultOptimalSizeExploringResizer$ |
|
DefaultRecovery |
INTERNAL API
|
DefaultRecovery$ |
INTERNAL API
|
DefaultResizer |
|
DefaultResizer$ |
|
DefaultServiceKey<T> |
This is the only actual concrete service key type
|
DefaultServiceKey$ |
|
DefaultSigarProvider |
|
DefaultSigarProvider$ |
|
DefaultSupervisorStrategy |
|
DefaultSystemMessageQueue |
INTERNAL API
|
DefaultTimeout |
|
DelayOverflowStrategy |
Represents a strategy that decides how to deal with a buffer of time based operator
that is full but is about to receive a new element.
|
DelayOverflowStrategy$ |
|
DelayStrategy<T> |
Allows to manage delay and can be stateful to compute delay for any sequence of elements,
all elements go through nextDelay() updating state and returning delay for each element
|
DelayStrategy<T> |
Allows to manage delay.
|
DelayStrategy$ |
|
DelayStrategy$ |
|
Delete$ |
|
DeletedDurableState<A> |
param: persistenceId The persistence id of the origin entity.
|
DeletedDurableState$ |
|
DeleteEvents |
Delete events in the journal up to toSeqNumber operation.
|
DeleteEvents$ |
|
DeleteEventsCompleted |
|
DeleteEventsCompleted$ |
|
DeleteEventsFailed |
|
DeleteEventsFailed$ |
|
DeleteMessagesFailure |
|
DeleteMessagesFailure$ |
|
DeleteMessagesSuccess |
|
DeleteMessagesSuccess$ |
|
DeleteSnapshot |
INTERNAL API
|
DeleteSnapshotByMeta |
Delete particular snapshot from storage by its metadata.
|
DeleteSnapshotByMeta$ |
|
DeleteSnapshotFailure |
|
DeleteSnapshotFailure$ |
|
DeleteSnapshotsByCriteria |
Delete snapshots from storage by criteria.
|
DeleteSnapshotsByCriteria$ |
|
DeleteSnapshotsCompleted |
|
DeleteSnapshotsCompleted$ |
|
DeleteSnapshotsFailed |
|
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$ |
|
DeliveryConsumerChangedProducer |
INTERNAL API
|
DeliveryConsumerCreated |
INTERNAL API
|
DeliveryConsumerDuplicate |
INTERNAL API
|
DeliveryConsumerMissing |
INTERNAL API
|
DeliveryConsumerReceived |
INTERNAL API
|
DeliveryConsumerReceivedPreviousInProgress |
INTERNAL API
|
DeliveryConsumerReceivedResend |
INTERNAL API
|
DeliveryConsumerSentRequest |
INTERNAL API
|
DeliveryConsumerStarted |
INTERNAL API
|
DeliveryConsumerStashFull |
INTERNAL API
|
DeliveryProducerCreated |
INTERNAL API
|
DeliveryProducerReceived |
INTERNAL API
|
DeliveryProducerReceivedRequest |
INTERNAL API
|
DeliveryProducerReceivedResend |
INTERNAL API
|
DeliveryProducerRequestNext |
INTERNAL API
|
DeliveryProducerResentFirst |
INTERNAL API
|
DeliveryProducerResentFirstUnconfirmed |
INTERNAL API
|
DeliveryProducerResentUnconfirmed |
INTERNAL API
|
DeliveryProducerSent |
INTERNAL API
|
DeliveryProducerStarted |
INTERNAL API
|
DeliveryProducerWaitingForRequest |
INTERNAL API
|
DeliverySerializable |
INTERNAL API
|
DeltaPropagationSelector |
INTERNAL API: Used by the Replicator actor.
|
DeltaReplicatedData |
|
Deploy |
|
Deploy$ |
|
DequeBasedMessageQueue |
|
DequeBasedMessageQueueSemantics |
DequeBasedMessageQueue refines QueueBasedMessageQueue to be backed by a java.util.Deque.
|
DERPrivateKeyLoader |
|
DERPrivateKeyLoader$ |
|
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 |
|
DirectByteBufferPool$ |
INTERNAL API
|
Direction |
|
Direction.Both$ |
|
Direction.Receive$ |
|
Direction.Send$ |
|
Direction$ |
|
DisabledEntityPassivationStrategy |
INTERNAL API: No-op passivation strategy for when automatic passivation is disabled.
|
DisabledEntityPassivationStrategy$ |
INTERNAL API: No-op passivation strategy for when automatic passivation is disabled.
|
DisabledJavaSerializer |
This Serializer is used when akka.actor.java-serialization = off
|
DisabledJavaSerializer.JavaSerializationException |
|
DisabledJavaSerializer$ |
|
DisabledRecovery |
INTERNAL API
|
DisabledRecovery$ |
INTERNAL API
|
DisabledRetentionCriteria |
INTERNAL API
|
DisabledRetentionCriteria$ |
INTERNAL API
|
DiscardConfigurator |
|
DiscardToDeadLetterStrategy |
|
DiscardToDeadLetterStrategy$ |
|
Disconnect$ |
|
DisconnectMsg$ |
|
Discovery |
|
Discovery$ |
|
Dispatch |
INTERNAL API
|
Dispatcher |
The event-based Dispatcher binds a set of Actors to a thread pool backed up by a
BlockingQueue .
|
DispatcherConfigurator |
|
DispatcherPrerequisites |
DispatcherPrerequisites represents useful contextual pieces when constructing a MessageDispatcher
|
Dispatchers |
An ActorSystem looks up all its thread pools via a Dispatchers instance.
|
Dispatchers |
Dispatchers are to be defined in configuration to allow for tuning
for different environments.
|
Dispatchers$ |
|
Dispatchers$ |
|
DispatcherSelector |
Not for user extension.
|
DispatcherSelector$ |
Factories for DispatcherSelector s which describe which thread pool shall be used to run
the actor to which this configuration is applied.
|
DistributedData |
Akka extension for convenient configuration and use of the
Replicator .
|
DistributedData |
Akka extension for convenient configuration and use of the
Replicator .
|
DistributedData |
Akka extension for convenient configuration and use of the
Replicator .
|
DistributedData$ |
|
DistributedData$ |
|
DistributedData$ |
|
DistributedDataSetup |
|
DistributedDataSetup$ |
|
DistributedPubSub |
|
DistributedPubSub$ |
|
DistributedPubSubMediator |
This actor manages a registry of actor references and replicates
the entries to peer actors among all cluster nodes or a group of nodes
tagged with a specific role.
|
DistributedPubSubMediator.Count |
|
DistributedPubSubMediator.Count$ |
Scala API: Send this message to the mediator and it will reply with an Int of
the number of subscribers.
|
DistributedPubSubMediator.CountSubscribers |
|
DistributedPubSubMediator.CountSubscribers$ |
|
DistributedPubSubMediator.CurrentTopics |
Reply to GetTopics .
|
DistributedPubSubMediator.CurrentTopics$ |
|
DistributedPubSubMediator.GetTopics |
|
DistributedPubSubMediator.GetTopics$ |
|
DistributedPubSubMediator.Internal$ |
INTERNAL API
|
DistributedPubSubMediator.Internal$.ChildActorTerminationProtocol |
Messages used to encode protocol to make sure that we do not send Subscribe/Unsubscribe message to
child (mediator -> topic, topic -> group) during a period of transition.
|
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$ |
|
DistributedPubSubMessage |
Marker trait for remote messages with special serializer.
|
DistributedPubSubMessages |
|
DistributedPubSubMessages.Address |
Defines a remote address.
|
DistributedPubSubMessages.Address.Builder |
Defines a remote 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 |
Publish normally local.
|
DistributedPubSubMessages.Publish.Builder |
Publish normally local.
|
DistributedPubSubMessages.PublishOrBuilder |
|
DistributedPubSubMessages.Send |
Send normally local.
|
DistributedPubSubMessages.Send.Builder |
Send normally local.
|
DistributedPubSubMessages.SendOrBuilder |
|
DistributedPubSubMessages.SendToAll |
SendToAll normally local.
|
DistributedPubSubMessages.SendToAll.Builder |
SendToAll normally local.
|
DistributedPubSubMessages.SendToAllOrBuilder |
|
DistributedPubSubMessages.SendToOneSubscriber |
Send a message to only one subscriber of a group.
|
DistributedPubSubMessages.SendToOneSubscriber.Builder |
Send a message to only one subscriber of a group.
|
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 |
|
DistributedPubSubSettings |
param: role Start the mediator on members tagged with this role.
|
DistributedPubSubSettings$ |
|
Dns |
Not for user extension.
|
Dns.Command |
|
Dns.Resolve |
Deprecated.
|
Dns.Resolve$ |
|
Dns.Resolved |
Deprecated.
|
Dns.Resolved$ |
Deprecated.
|
Dns$ |
|
DnsClient$ |
INTERNAL API
|
DnsExt |
|
DnsProtocol |
|
DnsProtocol.Ip |
|
DnsProtocol.Ip$ |
|
DnsProtocol.RequestType |
|
DnsProtocol.Resolve |
|
DnsProtocol.Resolve$ |
|
DnsProtocol.Resolved |
param: name of the record
param: records resource records for the query
param: additionalRecords records that relate to the query but are not strictly answers
|
DnsProtocol.Resolved$ |
|
DnsProtocol.Srv$ |
|
DnsProtocol$ |
|
DnsProvider |
Deprecated.
|
DnsServiceDiscovery$ |
INTERNAL API
|
DnsSettings$ |
|
DomainName |
INTERNAL API
|
DomainName$ |
INTERNAL API
|
Done |
Typically used together with Future to signal completion
but there is no actual value completed.
|
Done$ |
|
Done$ |
|
DoNotInherit |
Marks APIs that are designed under a 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 |
API for plugins that will handle downing of cluster nodes.
|
DowningProvider$ |
INTERNAL API
|
DowningStrategy$ |
INTERNAL API
|
Dropped |
Envelope that is published on the eventStream wrapped in DeadLetter for every message that is
dropped due to overfull queues or routers with no routees.
|
Dropped$ |
|
DummyClassForStringSources |
|
DurableProducerQueue |
Actor message protocol for storing and confirming reliable delivery of messages.
|
DurableProducerQueue.Cleanup$ |
|
DurableProducerQueue.Command<A> |
|
DurableProducerQueue.Confirmed$ |
|
DurableProducerQueue.Event |
INTERNAL API
|
DurableProducerQueue.LoadState<A> |
Request that is used at startup to retrieve the unconfirmed messages and current sequence number.
|
DurableProducerQueue.LoadState$ |
|
DurableProducerQueue.MessageSent<A> |
The fact (event) that a message has been sent.
|
DurableProducerQueue.MessageSent$ |
|
DurableProducerQueue.State<A> |
|
DurableProducerQueue.State$ |
|
DurableProducerQueue.StoreMessageConfirmed<A> |
Store the fact that a message has been confirmed to be delivered and processed.
|
DurableProducerQueue.StoreMessageConfirmed$ |
|
DurableProducerQueue.StoreMessageSent<A> |
Store the fact that a message is to be sent.
|
DurableProducerQueue.StoreMessageSent$ |
|
DurableProducerQueue.StoreMessageSentAck |
|
DurableProducerQueue.StoreMessageSentAck$ |
|
DurableProducerQueue$ |
Actor message protocol for storing and confirming reliable delivery of messages.
|
DurableStateBehavior<Command,State> |
A Behavior for a persistent actor with durable storage of its state.
|
DurableStateBehavior<Command,State> |
Further customization of the DurableStateBehavior can be done with the methods defined here.
|
DurableStateBehavior.CommandHandler$ |
The CommandHandler defines how to act on commands.
|
DurableStateBehavior$ |
API May Change
|
DurableStateBehaviorEnsemble |
INTERNAL API
|
DurableStateBehaviorImpl$ |
|
DurableStateBehaviorInstrumentation |
INTERNAL API: Instrumentation SPI for DurableStateBehavior.
|
DurableStateBehaviorInstrumentation$ |
INTERNAL API
|
DurableStateBehaviorInstrumentationProvider |
INTERNAL API
|
DurableStateBehaviorInstrumentationProvider$ |
INTERNAL API
|
DurableStateBehaviorWithEnforcedReplies<Command,State> |
|
DurableStateChange<A> |
The DurableStateStoreQuery stream elements for DurableStateStoreQuery .
|
DurableStateOnCommandBehavior<Command,State> |
A Behavior for a persistent actor with durable storage of its state for projects built with Java 17 or newer where message handling can be done
* using switch pattern match.
|
DurableStateOnCommandWithReplyBehavior<Command,State> |
A Behavior for a persistent actor with durable storage of its state for projects built with Java 17 or newer where message handling can be done
* using switch pattern match.
|
DurableStateSettings$ |
INTERNAL API
|
DurableStateSignal |
Supertype for all DurableStateBehavior specific signals
|
DurableStateStore<A> |
API for reading durable state objects with payload A .
|
DurableStateStore<A> |
API for reading durable state objects with payload A .
|
DurableStateStoreBySliceQuery<A> |
Query API for reading durable state objects.
|
DurableStateStoreBySliceQuery<A> |
Query API for reading durable state objects.
|
DurableStateStoreInteractions<C,S> |
INTERNAL API
|
DurableStateStorePagedPersistenceIdsQuery<A> |
A DurableStateStore may optionally support this query by implementing this trait.
|
DurableStateStorePagedPersistenceIdsQuery<A> |
A DurableStateStore may optionally support this query by implementing this trait.
|
DurableStateStoreProvider |
A durable state store plugin must implement a class that implements this trait.
|
DurableStateStoreQuery<A> |
Query API for reading durable state objects.
|
DurableStateStoreQuery<A> |
Query API for reading durable state objects.
|
DurableStateStoreRegistry |
|
DurableStateStoreRegistry$ |
Persistence extension for queries.
|
DurableStateUpdateStore<A> |
API for updating durable state objects.
|
DurableStateUpdateStore<A> |
API for updating durable state objects.
|
DurableStateUpdateWithChangeEventStore<A> |
API May Change: API for updating durable state objects and storing additional change event.
|
DurableStateUpdateWithChangeEventStore<A> |
API May Change: API for updating durable state objects and storing additional change event.
|
DurableStore |
An actor implementing the durable store for the Distributed Data Replicator
has to implement the protocol with the messages defined here.
|
DurableStore.DurableDataEnvelope |
Wrapper class for serialization of a data value.
|
DurableStore.Expire |
Request to expire (remove) entries.
|
DurableStore.Expire$ |
|
DurableStore.LoadAll$ |
Request to load all entries.
|
DurableStore.LoadAllCompleted$ |
|
DurableStore.LoadData |
|
DurableStore.LoadData$ |
|
DurableStore.LoadFailed |
|
DurableStore.Store |
Request to store an entry.
|
DurableStore.Store$ |
|
DurableStore.StoreReply |
|
DurableStore.StoreReply$ |
|
DurableStore$ |
An actor implementing the durable store for the Distributed Data Replicator
has to implement the protocol with the messages defined here.
|
DynamicAccess |
The DynamicAccess implementation is the class which is used for
loading all configurable parts of an actor system (the
ReflectiveDynamicAccess is the default implementation).
|
EagerClose |
|
EagerClose$ |
|
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<State> |
A command handler returns an Effect directive that defines what state to persist.
|
Effect<State> |
A command handler returns an Effect directive that defines what state to persist.
|
Effect.AskInitiated<Req,Res,T> |
The behavior initiated an ask via its context.
|
Effect.AskInitiated$ |
|
Effect.MessageAdapter<A,T> |
The behavior create a message adapter for the messages of type clazz
|
Effect.MessageAdapter$ |
|
Effect.NoEffects |
Used for NoEffects expectations by type
|
Effect.NoEffects$ |
Used to represent an empty list of effects - in other words, the behavior didn't do anything observable
|
Effect.ReceiveTimeoutCancelled |
|
Effect.ReceiveTimeoutCancelled$ |
|
Effect.ReceiveTimeoutSet<T> |
The behavior set a new receive timeout, with message as timeout notification
|
Effect.ReceiveTimeoutSet$ |
|
Effect.Scheduled<U> |
The behavior used context.scheduleOnce to schedule message to be sent to target after delay
FIXME what about events scheduled through the scheduler?
|
Effect.Scheduled$ |
|
Effect.Spawned<T> |
The behavior spawned a named child with the given behavior (and optionally specific props)
|
Effect.Spawned$ |
|
Effect.SpawnedAdapter$ |
INTERNAL API
Spawning adapters is private[akka]
|
Effect.SpawnedAnonymous<T> |
The behavior spawned an anonymous child with the given behavior (and optionally specific props)
|
Effect.SpawnedAnonymous$ |
|
Effect.SpawnedAnonymousAdapter$ |
INTERNAL API
|
Effect.Stopped |
The behavior stopped childName
|
Effect.Stopped$ |
|
Effect.TimerCancelled |
|
Effect.TimerCancelled$ |
|
Effect.TimerScheduled<U> |
|
Effect.TimerScheduled$ |
|
Effect.TimerScheduled$.FixedDelayMode$ |
|
Effect.TimerScheduled$.FixedDelayModeWithInitialDelay |
|
Effect.TimerScheduled$.FixedDelayModeWithInitialDelay$ |
|
Effect.TimerScheduled$.FixedRateMode$ |
|
Effect.TimerScheduled$.FixedRateModeWithInitialDelay |
|
Effect.TimerScheduled$.FixedRateModeWithInitialDelay$ |
|
Effect.TimerScheduled$.SingleMode$ |
|
Effect.TimerScheduled$.TimerMode |
|
Effect.Unwatched<T> |
The behavior stopped watching other , through context.unwatch(other)
|
Effect.Unwatched$ |
|
Effect.Watched<T> |
The behavior started watching other , through context.watch(other)
|
Effect.Watched$ |
|
Effect.WatchedWith<U,T> |
The behavior started watching other , through context.watchWith(other, message)
|
Effect.WatchedWith$ |
|
Effect$ |
|
Effect$ |
Factory methods for creating Effect directives - how an event sourced actor reacts on a command.
|
Effect$ |
Factory methods for creating Effect directives - how a DurableStateBehavior reacts on a command.
|
EffectBuilder<Event,State> |
A command handler returns an Effect directive that defines what event or events to persist.
|
EffectBuilder<Event,State> |
A command handler returns an Effect directive that defines what event or events to persist.
|
EffectBuilder<State> |
A command handler returns an Effect directive that defines what state to persist.
|
EffectBuilder<State> |
A command handler returns an Effect directive that defines what state to persist.
|
EffectFactories<Event,State> |
Factory methods for creating Effect directives - how an event sourced actor reacts on a command.
|
EffectFactories<State> |
Factory methods for creating Effect directives - how a DurableStateBehavior reacts on a command.
|
EffectFactories$ |
INTERNAL API: see class EffectFactories
|
EffectFactories$ |
INTERNAL API: see class EffectFactories
|
Effects |
Factories for behavior effects for BehaviorTestKit , each effect has a suitable equals and can be used to compare
actual effects to expected ones.
|
Effects |
Factories for behavior effects for BehaviorTestKit , each effect has a suitable equals and can be used to compare
actual effects to expected ones.
|
Effects$ |
Factories for behavior effects for BehaviorTestKit , each effect has a suitable equals and can be used to compare
actual effects to expected ones.
|
Effects$ |
Factories for behavior effects for BehaviorTestKit , each effect has a suitable equals and can be used to compare
actual effects to expected ones.
|
EmptyDurableStateBehaviorInstrumentation |
INTERNAL API
|
EmptyDurableStateBehaviorInstrumentation$ |
INTERNAL API
|
EmptyEventSeq |
|
EmptyEventSeq |
INTERNAL API
|
EmptyEventSeq$ |
|
EmptyEventSeq$ |
INTERNAL API
|
EmptyEventSourcedBehaviorInstrumentation |
INTERNAL API
|
EmptyEventSourcedBehaviorInstrumentation$ |
INTERNAL API
|
EmptyEventsourcedInstrumentation |
INTERNAL API
|
EmptyEventsourcedInstrumentation$ |
INTERNAL API
|
EmptyRecoveryPermitterInstrumentation |
INTERNAL API
|
EmptyRecoveryPermitterInstrumentation$ |
INTERNAL API
|
Encoder$ |
INTERNAL API
|
EnterBarrier$ |
|
Entity<M,E> |
Defines how the entity should be created.
|
Entity<M,E> |
Defines how the entity should be created.
|
Entity$ |
|
Entity$ |
|
EntityContext<M> |
Parameter to createBehavior function in Entity.of .
|
EntityContext<M> |
Parameter to createBehavior function in Entity.apply .
|
EntityFactory<M> |
|
EntityPassivationStrategy$ |
INTERNAL API
|
EntityRef<M> |
A reference to an sharded Entity, which allows ActorRef -like usage.
|
EntityRef<M> |
A reference to an sharded Entity, which allows ActorRef -like usage.
|
EntityRefImpl$ |
|
EntityTypeKey<T> |
The key of an entity type, the name must be unique.
|
EntityTypeKey<T> |
The key of an entity type, the name must be unique.
|
EntityTypeKey$ |
|
EntityTypeKey$ |
|
EntityTypeKeyImpl$ |
|
Envelope |
|
Envelope$ |
|
EnvelopeBuffer$ |
INTERNAL API
|
ErrorFilter |
Filter which matches Error events, if they satisfy the given criteria:
throwable applies an upper bound on the type of exception contained in the Error event
source , if given, applies a filter on the event’s origin
message applies a filter on the event’s message (either
with String.startsWith or Regex.findFirstIn().isDefined); if the message
itself does not match, the match is retried with the contained Exception’s
message; if both are null , the filter always matches if at
the same time the Exception’s stack trace is empty (this catches
JVM-omitted “fast-throw” exceptions)
If you want to match all Error events, the most efficient is to use Left("") .
|
ErrorFilter$ |
|
ErrorMessages |
INTERNAL API
|
ErrorMessages$ |
INTERNAL API
|
EstimatedSize |
INTERNAL API: Rough estimate in bytes of some serialized data elements.
|
EstimatedSize$ |
INTERNAL API: Rough estimate in bytes of some serialized data elements.
|
EventAdapter |
|
EventAdapter<E,P> |
Facility to convert from and to specialised data models, as may be required by specialized persistence Journals.
|
EventAdapters |
EventAdapters serves as a per-journal collection of bound event adapters.
|
EventAdapters.CombinedReadEventAdapter$ |
|
EventAdapters$ |
INTERNAL API
|
EventBus |
Represents the base type for EventBuses
Internally has an Event type, a Classifier type and a Subscriber type
|
EventBus<E,S,C> |
Java API: See documentation for EventBus
E is the Event type
S is the Subscriber type
C is the Classifier type
|
EventEnvelope |
Event wrapper adding meta data for the events in the result stream of
EventsByTagQuery query, or similar queries.
|
EventEnvelope<Event> |
Event wrapper adding meta data for the events in the result stream of
EventsBySliceQuery query, or similar queries.
|
EventEnvelope$ |
|
EventEnvelope$ |
|
EventFilter |
Facilities for selectively filtering out expected events from logging so
that you can keep your test run’s console output clean and do not miss real
error messages.
|
EventFilter |
|
EventFilter$ |
Facilities for selectively filtering out expected events from logging so
that you can keep your test run’s console output clean and do not miss real
error messages.
|
EventHandler<State,Event> |
FunctionalInterface for reacting on events having been persisted
|
EventHandlerBuilder<State,Event> |
|
EventHandlerBuilder$ |
|
EventHandlerBuilderByState<S extends State,State,Event> |
|
EventHandlerBuilderByState$ |
|
EventRejectedException |
Thrown if a journal rejects an event e.g.
|
EventsByPersistenceIdQuery |
A plugin may optionally support this query by implementing this interface.
|
EventsByPersistenceIdQuery |
A plugin may optionally support this query by implementing this trait.
|
EventsByPersistenceIdStage$ |
INTERNAL API
|
EventsByPersistenceIdStartingFromSnapshotQuery |
A plugin may optionally support this query by implementing this trait.
|
EventsByPersistenceIdStartingFromSnapshotQuery |
A plugin may optionally support this query by implementing this trait.
|
EventsByPersistenceIdTypedQuery |
A plugin may optionally support this query by implementing this trait.
|
EventsByPersistenceIdTypedQuery |
A plugin may optionally support this query by implementing this trait.
|
EventsBySliceFirehose$ |
INTERNAL API
|
EventsBySliceFirehoseQuery |
This wrapper of EventsBySliceQuery gives better scalability when many consumers retrieve the
same events, for example many Projections of the same entity type.
|
EventsBySliceFirehoseQuery |
This wrapper of EventsBySliceQuery gives better scalability when many consumers retrieve the
same events, for example many Projections of the same entity type.
|
EventsBySliceFirehoseQuery$ |
|
EventsBySliceFirehoseQuery$ |
|
EventsBySliceFirehoseReadJournalProvider |
|
EventsBySliceQuery |
A plugin may optionally support this query by implementing this trait.
|
EventsBySliceQuery |
A plugin may optionally support this query by implementing this trait.
|
EventsBySliceStartingFromSnapshotsQuery |
A plugin may optionally support this query by implementing this trait.
|
EventsBySliceStartingFromSnapshotsQuery |
A plugin may optionally support this query by implementing this trait.
|
EventsByTagQuery |
A plugin may optionally support this query by implementing this interface.
|
EventsByTagQuery |
A plugin may optionally support this query by implementing this trait.
|
EventsByTagStage$ |
INTERNAL API
|
EventSeq |
|
EventSeq<A> |
|
EventSeq$ |
|
EventSeq$ |
|
Eventsourced |
INTERNAL API.
|
Eventsourced.AsyncHandlerInvocation |
INTERNAL API: does not force the actor to stash commands; Originates from either `persistAsync` or `defer` calls
|
Eventsourced.AsyncHandlerInvocation$ |
|
Eventsourced.PendingHandlerInvocation |
INTERNAL API
|
Eventsourced.RecoveryTick |
INTERNAL API: message used to detect that recovery timed out
|
Eventsourced.RecoveryTick$ |
|
Eventsourced.StashingHandlerInvocation |
INTERNAL API: forces actor to stash incoming commands until all these invocations are handled
|
Eventsourced.StashingHandlerInvocation$ |
|
Eventsourced.State |
|
Eventsourced$ |
INTERNAL API
|
EventSourcedBehavior<Command,Event,State> |
|
EventSourcedBehavior<Command,Event,State> |
Further customization of the EventSourcedBehavior can be done with the methods defined here.
|
EventSourcedBehavior.CommandHandler$ |
The CommandHandler defines how to act on commands.
|
EventSourcedBehavior$ |
|
EventSourcedBehaviorEnsemble |
INTERNAL API
|
EventSourcedBehaviorImpl$ |
|
EventSourcedBehaviorInstrumentation |
INTERNAL API: Instrumentation SPI for EventSourcedBehavior.
|
EventSourcedBehaviorInstrumentation$ |
INTERNAL API
|
EventSourcedBehaviorInstrumentationProvider |
INTERNAL API
|
EventSourcedBehaviorInstrumentationProvider$ |
INTERNAL API
|
EventSourcedBehaviorTestKit<Command,Event,State> |
|
EventSourcedBehaviorTestKit<Command,Event,State> |
|
EventSourcedBehaviorTestKit.CommandResult<Command,Event,State> |
The result of running a command.
|
EventSourcedBehaviorTestKit.CommandResult<Command,Event,State> |
The result of running a command.
|
EventSourcedBehaviorTestKit.CommandResultWithReply<Command,Event,State,Reply> |
The result of running a command with a ActorRef replyTo , i.e.
|
EventSourcedBehaviorTestKit.CommandResultWithReply<Command,Event,State,Reply> |
The result of running a command with a replyTo: ActorRef[R] , i.e.
|
EventSourcedBehaviorTestKit.RestartResult<State> |
The result of restarting the behavior.
|
EventSourcedBehaviorTestKit.RestartResult<State> |
The result of restarting the behavior.
|
EventSourcedBehaviorTestKit.SerializationSettings |
Customization of which serialization checks that are performed.
|
EventSourcedBehaviorTestKit.SerializationSettings |
Customization of which serialization checks that are performed.
|
EventSourcedBehaviorTestKit.SerializationSettings$ |
|
EventSourcedBehaviorTestKit$ |
|
EventSourcedBehaviorTestKit$ |
|
EventSourcedBehaviorTestKitImpl$ |
INTERNAL API
|
EventSourcedBehaviorWithEnforcedReplies<Command,Event,State> |
|
EventsourcedEnsemble |
INTERNAL API
|
EventsourcedInstrumentation |
INTERNAL API: Instrumentation SPI for PersistentActor.
|
EventsourcedInstrumentation$ |
INTERNAL API
|
EventsourcedInstrumentationProvider |
INTERNAL API
|
EventsourcedInstrumentationProvider$ |
INTERNAL API
|
EventSourcedOnCommandBehavior<Command,Event,State> |
Event sourced behavior for projects built with Java 17 or newer where message handling can be done
using switch pattern match.
|
EventSourcedOnCommandWithReplyBehavior<Command,Event,State> |
Event sourced behavior for projects built with Java 17 or newer where message handling can be done
using switch pattern match.
|
EventSourcedProducerQueue<A> |
INTERNAL API
|
EventSourcedProducerQueue.Settings |
|
EventSourcedProducerQueue.Settings$ |
|
EventSourcedProducerQueue$ |
DurableProducerQueue that can be used with ProducerController
for reliable delivery of messages.
|
EventSourcedRememberEntitiesCoordinatorStore$ |
INTERNAL API
|
EventSourcedRememberEntitiesShardStore$ |
INTERNAL API
|
EventSourcedSettings$ |
INTERNAL API
|
EventSourcedSignal |
Supertype for all Akka Persistence Typed specific signals
|
EventsSeq<E> |
|
EventsSeq$ |
|
EventsSeq$ |
|
EventStorage |
INTERNAL API
|
EventStorage.JournalPolicies$ |
|
EventStorage$ |
|
EventStream |
|
EventStream |
An Akka EventStream is a pub-sub stream of events both system and user generated,
where subscribers are ActorRefs and the channels are Classes and Events are any java.lang.Object.
|
EventStream.Command |
The set of commands accepted by the akka.actor.typed.ActorSystem.eventStream .
|
EventStream.Publish<E> |
Publish an event of type E by sending this command to
the akka.actor.typed.ActorSystem.eventStream .
|
EventStream.Publish$ |
|
EventStream.Subscribe<E> |
Subscribe a typed actor to listen for types and subtypes of E
by sending this command to the akka.actor.typed.ActorSystem.eventStream .
|
EventStream.Subscribe$ |
|
EventStream.Unsubscribe<E> |
Unsubscribe all subscriptions created by this actor from the event stream
by sending this command to the akka.actor.typed.ActorSystem.eventStream .
|
EventStream.Unsubscribe$ |
|
EventStream$ |
|
EventStreamAdapter |
INTERNAL API
Encapsulates the akka.actor.ActorSystem.eventStream in a Behavior
|
EventStreamAdapter$ |
INTERNAL API
Encapsulates the akka.actor.ActorSystem.eventStream in a Behavior
|
EventStreamExtension$ |
|
EventStreamUnsubscriber$ |
INTERNAL API
|
EventTimestampQuery |
EventsBySliceQuery that is using a timestamp based offset should also implement this query.
|
EventTimestampQuery |
EventsBySliceQuery that is using a timestamp based offset should also implement this query.
|
EventWriter |
INTERNAL API
|
EventWriter.AskMaxSeqNrReason |
|
EventWriter.Command |
|
EventWriter.EventWriterSettings |
|
EventWriter.EventWriterSettings$ |
|
EventWriter.Write |
|
EventWriter.Write$ |
|
EventWriter.WriteAck |
|
EventWriter.WriteAck$ |
|
EventWriter$ |
INTERNAL API
|
EventWriterExtension$ |
INTERNAL API
|
EWMA |
The exponentially weighted moving average (EWMA) approach captures short-term
movements in volatility for a conditional volatility forecasting model.
|
EWMA$ |
|
ExecutionContexts |
ExecutionContexts is the Java API for ExecutionContexts
|
ExecutionContexts$ |
ExecutionContexts is the Java API for ExecutionContexts
|
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 |
|
ExpectedFailure |
|
ExpectedFailure$ |
|
ExpectedRejection |
|
ExpectedRejection$ |
|
ExpectOps<U> |
|
ExplicitAskSupport |
This object contains implementation details of the “ask” pattern,
which can be combined with "replyTo" pattern.
|
ExplicitlyAskableActorRef |
|
ExplicitlyAskableActorRef$ |
|
ExplicitlyAskableActorSelection |
|
ExplicitlyAskableActorSelection$ |
|
ExplicitlyTriggeredScheduler |
For testing: scheduler that does not look at the clock, but must be
progressed manually by calling timePasses .
|
ExtendedActorSystem |
More powerful interface to the actor system’s implementation which is presented to extensions (see Extension ).
|
ExtendedBackoffOptions<T extends ExtendedBackoffOptions<T>> |
Not for user extension
|
ExtensibleBehavior<T> |
Extension point for implementing custom behaviors in addition to the existing
set of behaviors available through the DSLs in Behaviors and Behaviors
|
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> |
Identifies an Extension
Lookup of Extensions is done by object identity, so the Id must be the same wherever it's used,
otherwise you'll get the same extension loaded multiple times.
|
ExtensionId<T extends Extension> |
Identifier and factory for an extension.
|
ExtensionIdProvider |
To be able to load an ExtensionId from the configuration,
a class that implements ExtensionIdProvider must be specified.
|
Extensions |
API for registering and looking up extensions.
|
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
|
ExternalShardAllocation |
|
ExternalShardAllocation$ |
|
ExternalShardAllocationClient |
Not for user extension
|
ExternalShardAllocationClient |
Not for user extension
|
ExternalShardAllocationStrategy |
|
ExternalShardAllocationStrategy.GetShardLocation$ |
|
ExternalShardAllocationStrategy.GetShardLocationResponse$ |
|
ExternalShardAllocationStrategy.GetShardLocations$ |
|
ExternalShardAllocationStrategy.GetShardLocationsResponse$ |
|
ExternalShardAllocationStrategy.ShardLocation |
|
ExternalShardAllocationStrategy.ShardLocation$ |
|
ExternalShardAllocationStrategy$ |
|
FailBarrier$ |
|
Failed$ |
|
FailureDetector |
A failure detector must be a thread-safe mutable construct that registers heartbeat events of a resource and is able to
decide the availability of that monitored resource.
|
FailureDetector.Clock |
Abstraction of a clock that returns time in milliseconds.
|
FailureDetector$ |
|
FailureDetectorLoader |
INTERNAL API
|
FailureDetectorLoader$ |
INTERNAL API
|
FailureDetectorRegistry<A> |
Interface for a registry of Akka failure detectors.
|
FanInShape<O> |
|
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> |
|
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> |
|
FanOutShape<I> |
|
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> |
|
FastFrequencySketch$ |
INTERNAL API
|
FastMerge |
INTERNAL API
|
FaultHandling |
|
FaultHandling.FailedInfo |
|
FaultHandling$ |
INTERNAL API
|
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 |
Java API: Factories to create sinks and sources from files
|
FileIO |
Factories to create sinks and sources from files
|
FileIO$ |
Java API: Factories to create sinks and sources from files
|
FileIO$ |
Factories to create sinks and sources from files
|
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$ |
Java API (not recommended):
Callback for the Future.filter operation that creates a new Future which will
conditionally contain the success of another Future.
|
FilteredPayload |
In some use cases with projections and events by slice filtered events needs to be stored in the journal
to keep the sequence numbers for a given persistence id gap free.
|
FilteredPayload$ |
In some use cases with projections and events by slice filtered events needs to be stored in the journal
to keep the sequence numbers for a given persistence id gap free.
|
FiniteDurationDeserializer$ |
INTERNAL API
|
FiniteDurationModule |
INTERNAL API: Adds support for serializing and deserializing FiniteDuration .
|
FiniteDurationSerializer$ |
INTERNAL API
|
FishingOutcome |
Not for user extension.
|
FishingOutcome.Complete$ |
|
FishingOutcome.Continue$ |
|
FishingOutcome.ContinueAndIgnore$ |
|
FishingOutcome.ContinueOutcome |
|
FishingOutcome.Fail |
|
FishingOutcome.Fail$ |
|
FishingOutcome$ |
|
FishingOutcomes |
|
FishingOutcomes |
|
FishingOutcomes$ |
|
FishingOutcomes$ |
|
Flag |
|
Flag$ |
|
FlagKey |
|
FlagKey$ |
|
Flow<In,Out,Mat> |
A Flow is a set of stream processing steps that has one open input and one open output.
|
Flow<In,Out,Mat> |
A Flow is a set of stream processing steps that has one open input and one open output.
|
Flow$ |
|
Flow$ |
|
FlowMonitor<T> |
Used to monitor the state of a stream
|
FlowMonitorState |
|
FlowMonitorState.Failed |
Stream failed
|
FlowMonitorState.Failed$ |
|
FlowMonitorState.Finished$ |
Stream completed successfully
|
FlowMonitorState.Initialized$ |
Stream was created, but no events have passed through it
|
FlowMonitorState.Received<U> |
Stream processed a message
|
FlowMonitorState.Received$ |
|
FlowMonitorState.StreamState<U> |
|
FlowMonitorState$ |
|
FlowOps<Out,Mat> |
Scala API: Operations offered by Sources and Flows with a free output side: the DSL flows left-to-right only.
|
FlowOpsMat<Out,Mat> |
INTERNAL API: this trait will be changed in binary-incompatible ways for classes that are derived from it!
Do not implement this interface outside the Akka code base!
|
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$ |
|
FlowWithContext<In,CtxIn,Out,CtxOut,Mat> |
A flow that provides operations which automatically propagate the context of an element.
|
FlowWithContext<In,CtxIn,Out,CtxOut,Mat> |
A flow that provides operations which automatically propagate the context of an element.
|
FlowWithContext$ |
|
FlowWithContext$ |
|
FlowWithContextOps<Out,Ctx,Mat> |
|
Flush |
INTERNAL API
|
Flush$ |
INTERNAL API
|
FlushAck$ |
|
FlushBeforeDeathWatchNotification$ |
INTERNAL API
|
FlushOnShutdown$ |
INTERNAL API
|
ForceDisassociate |
Management Command to force disassociation of an address.
|
ForceDisassociate$ |
|
ForceDisassociateAck |
|
ForceDisassociateAck$ |
|
Foreach<T> |
Callback for the Future.foreach operation that will be invoked if the Future that this callback
is registered on becomes completed with a success.
|
ForkJoinExecutorConfigurator |
|
ForkJoinExecutorConfigurator.AkkaForkJoinPool |
INTERNAL AKKA USAGE ONLY
|
ForkJoinExecutorConfigurator.AkkaForkJoinTask |
INTERNAL AKKA USAGE ONLY
|
ForkJoinExecutorConfigurator$ |
|
ForwardDeathLetters |
|
ForwardDeathLetters$ |
|
ForwardTo$ |
|
Framing |
|
Framing |
|
Framing.FramingException |
|
Framing$ |
|
Framing$ |
|
FramingTruncation |
Determines mode in which [[Framing]] operates.
|
FrequencyList$ |
INTERNAL API
|
FrequencySketch$ |
INTERNAL API
|
FrequencySketchAdmissionFilter$ |
INTERNAL API
|
FrequencySketchUtil |
INTERNAL API
|
FrequencySketchUtil$ |
INTERNAL API
|
FromConfig |
Java API: Wraps a Props to mark the actor as externally configurable to be used with a router.
|
FromConfig$ |
Wraps a Props to mark the actor as externally configurable to be used with a router.
|
FSM<S,D> |
Finite State Machine actor trait.
|
FSM.$minus$greater$ |
This extractor is just convenience for matching a (S, S) pair, including a
reminder what the new state is.
|
FSM.CurrentState<S> |
|
FSM.CurrentState$ |
|
FSM.Event<D> |
All messages sent to the FSM will be wrapped inside an
Event , which allows pattern matching to extract both state and data.
|
FSM.Event$ |
|
FSM.Failure |
Signifies that the FSM is shutting itself down because of
an error, e.g.
|
FSM.Failure$ |
|
FSM.FixedDelayMode$ |
INTERNAL API
|
FSM.FixedRateMode$ |
INTERNAL API
|
FSM.LogEntry<S,D> |
Log Entry of the LoggingFSM , can be obtained by calling getLog .
|
FSM.LogEntry$ |
|
FSM.Normal$ |
Default reason if calling stop() .
|
FSM.NullFunction$ |
A partial function value which does not match anything and can be used to
“reset” whenUnhandled and onTermination handlers.
|
FSM.Reason |
Reason why this FSM is shutting down.
|
FSM.Shutdown$ |
Reason given when someone was calling system.stop(fsm) from outside;
also applies to Stop supervision directive.
|
FSM.SilentState<S,D> |
INTERNAL API
Using a subclass for binary compatibility reasons
|
FSM.SingleMode$ |
INTERNAL API
|
FSM.State<S,D> |
|
FSM.State$ |
This captures all of the managed state of the FSM : the state
name, the state data, possibly custom timeout, stop reason and replies
accumulated while processing the last message.
|
FSM.StateTimeout$ |
This case object is received in case of a state timeout.
|
FSM.StopEvent<S,D> |
Case class representing the state of the FSM within the
onTermination block.
|
FSM.StopEvent$ |
|
FSM.SubscribeTransitionCallBack |
|
FSM.SubscribeTransitionCallBack$ |
|
FSM.Timer |
INTERNAL API
|
FSM.Timer$ |
|
FSM.TimerMode |
INTERNAL API
|
FSM.TransformHelper |
|
FSM.Transition<S> |
|
FSM.Transition$ |
|
FSM.UnsubscribeTransitionCallBack |
|
FSM.UnsubscribeTransitionCallBack$ |
|
FSM$ |
|
FSMStateFunctionBuilder<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$ |
INTERNAL API
|
FutureRef<T> |
A combination of a Future and an ActorRef associated with it, which points
to an actor performing a task which will eventually resolve the Future.
|
FutureRef$ |
|
Futures |
Futures is the Java API for Futures and Promises
|
Futures$ |
Futures is the Java API for Futures and Promises
|
FutureTimeoutSupport |
|
GCounter |
|
GCounter$ |
|
GCounterKey |
|
GCounterKey$ |
|
GetAddress$ |
|
GetClusterShardingStats |
Query the statistics about the currently running sharded entities in the
entire cluster.
|
GetClusterShardingStats$ |
|
GetCurrentState |
|
GetCurrentState$ |
|
GetNumberOfProcesses |
Query the sharded daemon process for the current scale
|
GetNumberOfProcesses$ |
|
GetObjectResult<A> |
|
GetObjectResult<A> |
|
GetObjectResult$ |
|
GetObjectResult$ |
|
GetRoutees |
Sending this message to a router will make it send back its currently used routees.
|
GetRoutees$ |
|
GetShardRegionState |
Query the ShardRegion state for the given entity type key.
|
GetShardRegionState$ |
|
Gossip$ |
INTERNAL API
|
GossipEnvelope$ |
|
GossipOverview$ |
|
GossipStats$ |
|
GossipStatus$ |
|
GracefulShutdownQuarantinedEvent |
|
GracefulShutdownQuarantinedEvent$ |
|
GracefulStopSupport |
|
Graph<S extends Shape,M> |
Not intended to be directly extended by user classes
|
Graph.GraphMapMatVal<S extends Shape,M> |
Scala API, see https://github.com/akka/akka/issues/28501 for discussion why this can't be an instance method on class Graph.
|
Graph$ |
|
GraphApply |
|
GraphDSL |
|
GraphDSL.Builder<Mat> |
|
GraphDSL$ |
|
GraphDSL$ |
|
GraphStage<S extends Shape> |
A GraphStage represents a reusable graph stream processing operator.
|
GraphStageLogic |
Represents the processing logic behind a GraphStage .
|
GraphStageLogic.ConditionalTerminateInput |
Input handler that terminates the state upon receiving completion if the
given condition holds at that time.
|
GraphStageLogic.ConditionalTerminateOutput |
Output handler that terminates the state upon receiving completion if the
given condition holds at that time.
|
GraphStageLogic.EagerTerminateInput$ |
Input handler that terminates the operator upon receiving completion.
|
GraphStageLogic.EagerTerminateOutput$ |
Output handler that terminates the operator upon cancellation.
|
GraphStageLogic.IgnoreTerminateInput$ |
Input handler that does not terminate the operator upon receiving completion.
|
GraphStageLogic.IgnoreTerminateOutput$ |
Output handler that does not terminate the operator upon cancellation.
|
GraphStageLogic.StageActor |
Minimal actor to work with other actors and watch them in a synchronous ways
|
GraphStageLogic.StageActorRef$ |
|
GraphStageLogic.StageActorRefNotInitializedException |
|
GraphStageLogic.StageActorRefNotInitializedException$ |
|
GraphStageLogic.TotallyIgnorantInput$ |
Input handler that does not terminate the operator upon receiving completion
nor failure.
|
GraphStageLogic$ |
|
GraphStageLogicWithLogging |
|
GraphStageMessages |
Messages emitted after the corresponding stageUnderTest methods has been invoked.
|
GraphStageMessages.DownstreamFinish$ |
|
GraphStageMessages.Failure |
|
GraphStageMessages.Failure$ |
|
GraphStageMessages.Pull$ |
|
GraphStageMessages.Push$ |
|
GraphStageMessages.StageFailure |
Sent to the probe when the operator callback threw an exception
param: operation The operation that failed
|
GraphStageMessages.StageFailure$ |
|
GraphStageMessages.StageMessage |
|
GraphStageMessages.UpstreamFinish$ |
|
GraphStageMessages$ |
Messages emitted after the corresponding stageUnderTest methods has been invoked.
|
GraphStageWithMaterializedValue<S extends Shape,M> |
Scala API: A GraphStage represents a reusable graph stream processing operator.
|
Group |
RouterConfig for router actor with routee actors that are created external to the
router and the router sends messages to the specified path using actor selection,
without watching for termination.
|
GroupBase |
Java API: Base class for custom router Group
|
GroupRouter<T> |
Provides builder style configuration options for group routers
|
GroupRouter<T> |
Provides builder style configuration options for group routers
|
GroupRouterBuilder$ |
|
GroupRouterHelper |
INTERNAL API
|
GroupRouterHelper$ |
INTERNAL API
|
GSet<A> |
|
GSet$ |
|
GSetKey<A> |
|
GSetKey$ |
|
GuardianStartupBehavior |
INTERNAL API
|
GuardianStartupBehavior.Start$ |
|
GuardianStartupBehavior$ |
INTERNAL API
|
HandleBackoff |
INTERNAL API
|
HandlingWhileStopped |
|
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.
|
HasStorage<P,R> |
Abstract persistent storage for tests.
|
HeaderBuilder |
INTERNAL API
|
HeaderBuilder$ |
INTERNAL API
|
HeapMetricsSelector |
MetricsSelector that uses the heap metrics.
|
HeapMetricsSelector$ |
MetricsSelector that uses the heap metrics.
|
HeartbeatHistory$ |
|
HeartbeatMessage |
Failure detector heartbeat messages are marked with this trait.
|
HeartbeatNodeRing$ |
|
Hello$ |
|
Helpers |
|
Helpers.ConfigOps$ |
|
Helpers.Requiring<A> |
Implicit class providing requiring methods.
|
Helpers.Requiring$ |
|
Helpers$ |
|
HideImpl |
INTERNAL API
|
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 |
|
IdentityEventAdapters$ |
|
IgnoreActorRef$ |
INTERNAL API
|
IgnoreBoth |
|
IgnoreBoth$ |
|
IgnoreCancel |
|
IgnoreCancel$ |
|
IgnoreComplete |
|
IgnoreComplete$ |
|
IllegalActorStateException |
IllegalActorStateException is thrown when a core invariant in the Actor implementation has been violated.
|
IllegalActorStateException$ |
|
ImmutableIntMap$ |
INTERNAL API
|
ImmutableLongMap$ |
INTERNAL API
|
ImplicitSender |
|
InboundCompression$ |
INTERNAL API
|
InboundCompressions |
INTERNAL API
Decompress and cause compression advertisements.
|
InboundContext |
INTERNAL API
Inbound API that is used by the stream operators.
|
InboundControlJunction$ |
INTERNAL API
|
InboundEnvelope |
INTERNAL API
|
InboundEnvelope$ |
INTERNAL API
|
Index<K,V> |
An implementation of a ConcurrentMultiMap
Adds/remove is serialized over the specified key
Reads are fully concurrent <-- el-cheapo
|
IndirectActorProducer |
This interface defines a class of actor creation strategies deviating from
the usual default of just reflectively instantiating the Actor
subclass.
|
IndirectActorProducer$ |
|
Inet |
|
Inet.AbstractSocketOption |
Java API: AbstractSocketOption is a package of data (from the user) and associated
behavior (how to apply that to a channel).
|
Inet.AbstractSocketOptionV2 |
Java API
|
Inet.DatagramChannelCreator |
DatagramChannel creation behavior.
|
Inet.DatagramChannelCreator$ |
|
Inet.SO$ |
|
Inet.SocketOption |
SocketOption is a package of data (from the user) and associated
behavior (how to apply that to a channel).
|
Inet.SocketOptionV2 |
|
Inet.SoForwarders |
|
Inet.SoJavaFactories |
|
Inet$ |
|
InetAddressDnsProvider |
INTERNAL API
|
InetAddressDnsResolver |
INTERNAL API
|
InfoFilter |
Filter which matches Info events, if they satisfy the given criteria:
source , if given, applies a filter on the event’s origin
message applies a filter on the event’s message (either with String.startsWith or Regex.findFirstIn().isDefined)
If you want to match all Info events, the most efficient is to use Left("") .
|
InfoFilter$ |
|
InHandler |
Collection of callbacks for an input port of a GraphStage
|
InitialGroupRouterImpl<T> |
INTERNAL API
|
InitialTimeoutException |
|
Inlet<T> |
|
Inlet$ |
An Inlet is a typed input to a Shape.
|
InmemJournal$ |
The InmemJournal publishes writes and deletes to the eventStream , which tests may use to
verify that expected events have been persisted or deleted.
|
InmemMessages |
INTERNAL API.
|
InMemStorage<K,R> |
INTERNAL API
|
InMemStorageExtension |
INTERNAL API
|
InMemStorageExtension$ |
INTERNAL API
|
InPort |
An input port of a StreamLayout.Module.
|
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$ |
|
InternalActorRef$ |
INTERNAL API
|
InternalApi |
Marks APIs that are considered internal to Akka and may change at any point in time without any
warning.
|
InternalClusterAction |
INTERNAL API
|
InternalClusterAction.AddOnMemberRemovedListener |
|
InternalClusterAction.AddOnMemberRemovedListener$ |
|
InternalClusterAction.AddOnMemberUpListener |
Command to ClusterDaemon to create a
OnMemberStatusChangedListener .
|
InternalClusterAction.AddOnMemberUpListener$ |
|
InternalClusterAction.CompatibleConfig |
|
InternalClusterAction.CompatibleConfig$ |
|
InternalClusterAction.ConfigCheck |
|
InternalClusterAction.ConfigCheckUnsupportedByJoiningNode$ |
Node with version 2.5.9 or earlier is joining.
|
InternalClusterAction.ExitingCompleted$ |
|
InternalClusterAction.ExitingConfirmed |
|
InternalClusterAction.ExitingConfirmed$ |
|
InternalClusterAction.GetClusterCoreRef$ |
|
InternalClusterAction.GossipSpeedupTick$ |
|
InternalClusterAction.GossipTick$ |
|
InternalClusterAction.IncompatibleConfig$ |
|
InternalClusterAction.InitJoin |
see JoinSeedNode
|
InternalClusterAction.InitJoin$ |
|
InternalClusterAction.InitJoinAck |
see JoinSeedNode
|
InternalClusterAction.InitJoinAck$ |
|
InternalClusterAction.InitJoinNack |
see JoinSeedNode
|
InternalClusterAction.InitJoinNack$ |
|
InternalClusterAction.Join |
Command to join the cluster.
|
InternalClusterAction.Join$ |
|
InternalClusterAction.JoinSeedNode$ |
Start message of the process to join one of the seed nodes.
|
InternalClusterAction.JoinSeedNodes |
Command to initiate the process to join the specified
seed nodes.
|
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 |
Marker interface for periodic tick messages
|
InternalClusterAction.UncheckedConfig$ |
|
InternalClusterAction.Unsubscribe |
|
InternalClusterAction.Unsubscribe$ |
|
InternalClusterAction.Welcome |
Reply to Join
|
InternalClusterAction.Welcome$ |
|
InternalClusterAction$ |
INTERNAL API
|
InternalMessage |
A marker trait for internal messages.
|
InternalProtocol |
Protocol used internally by the eventsourced behaviors.
|
InternalProtocol |
Protocol used internally by the DurableStateBehavior.
|
InternalProtocol.AsyncEffectCompleted<C,E,S> |
|
InternalProtocol.AsyncEffectCompleted$ |
|
InternalProtocol.AsyncReplicationInterceptCompleted |
|
InternalProtocol.AsyncReplicationInterceptCompleted$ |
|
InternalProtocol.ContinueUnstash$ |
|
InternalProtocol.ContinueUnstash$ |
|
InternalProtocol.DeleteFailure |
|
InternalProtocol.DeleteFailure$ |
|
InternalProtocol.DeleteSuccess$ |
|
InternalProtocol.GetFailure |
|
InternalProtocol.GetFailure$ |
|
InternalProtocol.GetSuccess<S> |
|
InternalProtocol.GetSuccess$ |
|
InternalProtocol.IncomingCommand<C> |
|
InternalProtocol.IncomingCommand<C> |
|
InternalProtocol.IncomingCommand$ |
|
InternalProtocol.IncomingCommand$ |
|
InternalProtocol.JournalResponse |
|
InternalProtocol.JournalResponse$ |
|
InternalProtocol.RecoveryPermitGranted$ |
|
InternalProtocol.RecoveryPermitGranted$ |
|
InternalProtocol.RecoveryTickEvent |
|
InternalProtocol.RecoveryTickEvent$ |
|
InternalProtocol.RecoveryTimeout$ |
|
InternalProtocol.ReplicatedEventEnvelope<E> |
|
InternalProtocol.ReplicatedEventEnvelope$ |
|
InternalProtocol.SnapshotterResponse |
|
InternalProtocol.SnapshotterResponse$ |
|
InternalProtocol.UpsertFailure |
|
InternalProtocol.UpsertFailure$ |
|
InternalProtocol.UpsertSuccess$ |
|
InternalProtocol$ |
|
InternalProtocol$ |
|
InternalRecipientRef<T> |
INTERNAL API
|
InternalReprSupport<R> |
INTERNAL API
|
InternalStableApi |
Marks APIs that are considered internal to Akka and should not be accessed by user code but that
are used across Akka project boundaries and therefore 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.
|
IntSerializer |
Deprecated.
|
Invalid |
|
Invalid$ |
|
InvalidActorNameException |
An InvalidActorNameException is thrown when you try to convert something, usually a String, to an Actor name
which doesn't validate.
|
InvalidActorNameException$ |
|
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 |
Entry point to Akka’s IO layer.
|
IO.Extension |
|
IO$ |
Entry point to Akka’s IO layer.
|
IOOperationIncompleteException |
This exception signals that a stream has been completed or has an error while
there was still IO operations in progress
|
IOResult |
Holds a result of an IO operation.
|
IOResult$ |
|
IOSettings |
|
IOSettings$ |
|
IpVersionSelector |
INTERNAL API
|
IpVersionSelector$ |
INTERNAL API
|
JacksonMigration |
Data migration of old formats to current format can
be implemented in a concrete subclass and configured to
be used by the JacksonSerializer for a changed class.
|
JacksonModule |
INTERNAL API
|
JacksonModule.DeserializerResolverByClass |
|
JacksonModule.SerializerResolverByClass |
|
JacksonModule$ |
INTERNAL API
|
JacksonObjectMapperFactory |
Used with JacksonObjectMapperProviderSetup for defining a JacksonObjectMapperProvider that can be
passed in when ActorSystem is created rather than creating one from configured class name.
|
JacksonObjectMapperProvider |
Registry of shared ObjectMapper instances, each with it's unique bindingName .
|
JacksonObjectMapperProvider$ |
|
JacksonObjectMapperProviderSetup |
Setup for defining a JacksonObjectMapperProvider that can be passed in when ActorSystem
is created rather than creating one from configured class name.
|
JacksonObjectMapperProviderSetup$ |
|
JacksonSerializer$ |
INTERNAL API
|
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.
|
JavaFlowSupport |
For use only with `JDK 9+`.
|
JavaFlowSupport |
For use only with JDK 9+ .
|
JavaFlowSupport.Flow |
{@link akka.stream.javadsl.Flow]] factories operating with java.util.concurrent.Flow.* interfaces.
|
JavaFlowSupport.Flow$ |
Flow factories operating with java.util.concurrent.Flow.* interfaces.
|
JavaFlowSupport.Sink |
Sink factories operating with java.util.concurrent.Flow.*
interfaces.
|
JavaFlowSupport.Sink$ |
Sink factories operating with java.util.concurrent.Flow.* interfaces.
|
JavaFlowSupport.Source |
{@link akka.stream.javadsl.Flow]] factories operating with java.util.concurrent.Flow.* interfaces.
|
JavaFlowSupport.Source$ |
Source factories operating with java.util.concurrent.Flow.* interfaces.
|
JavaFlowSupport$ |
For use only with JDK 9+ .
|
JavaJournalPerfSpec |
JAVA API
|
JavaJournalSpec |
JAVA API
|
JavaLogger |
Deprecated.
|
JavaLogging |
Deprecated.
|
JavaLoggingFilter |
Deprecated.
|
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$ |
|
JavaSerializable |
|
JavaSerializer |
This Serializer uses standard Java Serialization
|
JavaSerializer.CurrentSystem |
|
JavaSerializer$ |
|
JavaSnapshotStoreSpec |
JAVA API
|
JavaVersion |
INTERNAL API
|
JavaVersion$ |
INTERNAL API
|
JFREventUtils |
INTERNAL API
|
JFREventUtils$ |
INTERNAL API
|
JmxMetricsCollector |
Loads JVM and system metrics through JMX monitoring beans.
|
Join |
Try to join this cluster node with the node specified by 'address'.
|
Join$ |
|
JoinConfigCompatCheckCluster |
INTERNAL API
|
JoinConfigCompatCheckCluster$ |
INTERNAL API
|
JoinConfigCompatChecker |
|
JoinConfigCompatChecker$ |
|
JoinConfigCompatCheckSharding |
INTERNAL API
|
JoinSeedNodes |
Scala API: Join the specified seed nodes without defining them in config.
|
JoinSeedNodes$ |
|
JournalCapabilityFlags |
|
JournalInteractions<C,E,S> |
INTERNAL API
|
JournalInteractions.EventToPersist |
|
JournalInteractions.EventToPersist$ |
|
JournalInteractions$ |
INTERNAL API
|
JournalOperation |
INTERNAL API
|
JournalPerfSpec |
This spec measures execution times of the basic operations that an PersistentActor provides,
using the provided Journal (plugin).
|
JournalPerfSpec.BenchActor |
|
JournalPerfSpec.Cmd |
|
JournalPerfSpec.Cmd$ |
|
JournalPerfSpec.ResetCounter$ |
|
JournalPerfSpec$ |
|
JournalProtocol |
INTERNAL API.
|
JournalProtocol.DeleteMessagesTo |
Request to delete all persistent messages with sequence numbers up to toSequenceNr
(inclusive).
|
JournalProtocol.DeleteMessagesTo$ |
|
JournalProtocol.LoopMessageSuccess |
|
JournalProtocol.LoopMessageSuccess$ |
|
JournalProtocol.Message |
Marker trait shared by internal journal messages.
|
JournalProtocol.RecoverySuccess |
|
JournalProtocol.RecoverySuccess$ |
|
JournalProtocol.ReplayedMessage |
|
JournalProtocol.ReplayedMessage$ |
|
JournalProtocol.ReplayMessages |
Request to replay messages to persistentActor .
|
JournalProtocol.ReplayMessages$ |
|
JournalProtocol.ReplayMessagesFailure |
|
JournalProtocol.ReplayMessagesFailure$ |
|
JournalProtocol.Request |
Internal journal command.
|
JournalProtocol.Response |
Internal journal acknowledgement.
|
JournalProtocol.WriteMessageFailure |
|
JournalProtocol.WriteMessageFailure$ |
|
JournalProtocol.WriteMessageRejected |
|
JournalProtocol.WriteMessageRejected$ |
|
JournalProtocol.WriteMessages |
|
JournalProtocol.WriteMessages$ |
|
JournalProtocol.WriteMessagesFailed |
|
JournalProtocol.WriteMessagesFailed$ |
|
JournalProtocol.WriteMessagesSuccessful$ |
|
JournalProtocol.WriteMessageSuccess |
|
JournalProtocol.WriteMessageSuccess$ |
|
JournalProtocol$ |
INTERNAL API.
|
JournalSpec |
This spec aims to verify custom akka-persistence Journal implementations.
|
JournalSpec$ |
|
JSerializer |
Java API for creating a Serializer: make sure to include a constructor which
takes exactly one argument of type ExtendedActorSystem , because
that is the preferred constructor which will be invoked when reflectively instantiating
the JSerializer (also possible with empty constructor).
|
JsonFraming |
Provides JSON framing operators that can separate valid JSON objects from incoming ByteString objects.
|
JsonFraming |
Provides JSON framing operators that can separate valid JSON objects from incoming ByteString objects.
|
JsonFraming.PartialObjectException |
Thrown if upstream completes with a partial object in the buffer.
|
JsonFraming.PartialObjectException$ |
|
JsonFraming$ |
Provides JSON framing operators that can separate valid JSON objects from incoming ByteString objects.
|
JsonFraming$ |
Provides JSON framing operators that can separate valid JSON objects from incoming ByteString objects.
|
JsonSerializable |
Predefined marker trait for serialization with Jackson JSON.
|
JVMShutdownHooks |
|
JVMShutdownHooks$ |
|
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.
|
KeepOldestSettings$ |
|
Key<T extends ReplicatedData> |
|
Key.UnspecificKey |
|
Key.UnspecificKey$ |
|
Key$ |
|
Key$ |
|
Kill |
|
Kill$ |
A message all Actors will understand, that when processed will make the Actor throw an ActorKilledException,
which will trigger supervision.
|
KillSwitch |
|
KillSwitches |
Creates shared or single kill switches which can be used to control completion of graphs from the outside.
|
KillSwitches.KillableGraphStageLogic |
|
KillSwitches.UniqueBidiKillSwitchStage$ |
|
KillSwitches.UniqueKillSwitchStage$ |
|
KillSwitches$ |
Creates shared or single kill switches which can be used to control completion of graphs from the outside.
|
LatestFirstSystemMessageList$ |
|
LatestFirstSystemMessageList$ |
|
Lease |
|
Lease |
|
LeaseException |
|
LeaseMajoritySettings$ |
|
LeaseProvider |
|
LeaseProvider |
|
LeaseProvider$ |
|
LeaseProvider$ |
|
LeaseSettings |
|
LeaseSettings$ |
|
LeaseTimeoutException |
|
LeaseUsageSettings |
|
LeaseUsageSettings$ |
Note that if you define a custom lease name and have several Cluster Singletons or Cluster Sharding
entity types each one must have a unique lease name.
|
LeastShardAllocationStrategy$ |
INTERNAL API
|
Leave |
Send command to issue state transition to LEAVING for the node specified by 'address'.
|
Leave$ |
|
LeveldbCompaction |
INTERNAL API.
|
LeveldbCompaction.TryCompactLeveldb |
|
LeveldbCompaction.TryCompactLeveldb$ |
|
LeveldbCompaction$ |
|
LeveldbIdMapping |
INTERNAL API.
|
LeveldbJournal$ |
INTERNAL API.
|
LeveldbReadJournal |
Deprecated.
|
LeveldbReadJournal |
Deprecated.
|
LeveldbReadJournal$ |
|
LeveldbReadJournal$ |
|
LeveldbReadJournalProvider |
Deprecated.
|
LeveldbRecovery |
INTERNAL API.
|
LeveldbStore |
INTERNAL API.
|
LeveldbStore$ |
|
LicenseKeySupplier |
INTERNAL API: Supplies an Akka license key.
|
LicenseKeySupplier$ |
INTERNAL API
|
LightArrayRevolverScheduler |
This scheduler implementation is based on a revolving wheel of buckets,
like Netty’s HashedWheelTimer, which it advances at a fixed tick rate and
dispatches tasks it finds in the current bucket to their respective
ExecutionContexts.
|
LightArrayRevolverScheduler.TaskHolder |
INTERNAL API
|
LightArrayRevolverScheduler.TimerTask |
INTERNAL API
|
LightArrayRevolverScheduler$ |
|
LineNumbers |
This is a minimized byte-code parser that concentrates exclusively on line
numbers and source file extraction.
|
LineNumbers.NoSourceInfo$ |
|
LineNumbers.Result |
|
LineNumbers.SourceFile |
|
LineNumbers.SourceFile$ |
|
LineNumbers.SourceFileLines |
|
LineNumbers.SourceFileLines$ |
|
LineNumbers.UnknownSourceFormat |
|
LineNumbers.UnknownSourceFormat$ |
|
LineNumbers$ |
This is a minimized byte-code parser that concentrates exclusively on line
numbers and source file extraction.
|
Listen |
|
Listen$ |
|
ListenerMessage |
|
Listeners |
Listeners is a generic trait to implement listening capability on an Actor.
|
LmdbDurableStore |
|
LmdbDurableStore$ |
|
LoadEventQuery |
EventsBySliceQuery that is using a timestamp based offset should also implement this query.
|
LoadEventQuery |
EventsBySliceQuery that is using a timestamp based offset should also implement this query.
|
LoadMetrics |
INTERNAL API
|
LocalActorRefProvider$ |
|
LocalReceptionist$ |
INTERNAL API
|
LocalRef |
Refs which are statically known to be local inherit from this Scope
|
LocalScope |
|
LocalScope$ |
The Local Scope is the default one, which is assumed on all deployments
which do not set a different scope.
|
LogbackUtil |
INTERNAL API
|
LogbackUtil$ |
INTERNAL API
|
LogCapturing |
JUnit TestRule to make log lines appear only when the test failed.
|
LogCapturing |
Mixin this trait to a ScalaTest test to make log lines appear only when the test failed.
|
Logger |
Deprecated.
|
Logger |
Logger is a factory for obtaining SLF4J-Loggers
|
Logger$ |
Deprecated.
|
Logger$ |
Logger is a factory for obtaining SLF4J-Loggers
|
LoggerClass |
INTERNAL API
|
LoggerClass$ |
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.LoggerException |
Artificial exception injected into Error events if no Throwable is
supplied; used for getting a stack dump of error locations.
|
Logging.LoggerInitializationException |
|
Logging.LoggerInitialized |
|
Logging.LoggerInitialized$ |
|
Logging.LogLevel |
|
Logging.LogLevel$ |
|
Logging.StandardOutLogger |
|
Logging.StdOutLogger |
|
Logging.StdOutLogger$ |
|
Logging.Warning |
|
Logging.Warning$ |
|
Logging.Warning2 |
|
Logging.Warning3 |
|
Logging.Warning4 |
|
Logging$ |
|
LoggingAdapter |
|
LoggingBus |
This trait brings log level handling to the EventStream: it reads the log
levels for the initial logging (StandardOutLogger) and the loggers & level
for after-init logging, possibly keeping the StandardOutLogger enabled if
it is part of the configured loggers.
|
LoggingEvent |
|
LoggingEvent$ |
|
LoggingFilter |
|
LoggingFilterWithMarker |
|
LoggingFilterWithMarker$ |
|
LoggingFilterWithMarkerWrapper |
|
LoggingFSM<S,D> |
Stackable trait for FSM which adds a rolling event log and
debug logging capabilities (analogous to LoggingReceive ).
|
LoggingReceive |
This decorator adds invocation logging to a Receive function.
|
LoggingReceive$ |
|
LoggingTestKit |
Facilities for verifying logs.
|
LoggingTestKit |
Facilities for verifying logs.
|
LoggingTestKit$ |
Facilities for selectively matching log messages.
|
LoggingTestKit$ |
Facilities for selectively matching expected events from logging.
|
LoggingTestKitImpl$ |
INTERNAL API
|
LogicSnapshot |
Not for user extension
|
LogicSnapshotImpl$ |
|
LogMarker |
DO NOT INHERIT: Class is open only for use by akka-slf4j
|
LogMarker.Properties$ |
INTERNAL API
|
LogMarker$ |
|
LogMessagesInterceptor$ |
INTERNAL API
|
LogOptions |
Logging options when using Behaviors.logMessages .
|
LogOptions.LogOptionsImpl$ |
|
LogOptions$ |
Factories for log options
|
LogSource<T> |
|
LogSource$ |
|
LongSerializer |
Deprecated.
|
Lookup |
A service lookup.
|
Lookup$ |
|
LookupClassification |
Maps Subscribers to Classifiers using equality on Classifier to store a Set of Subscribers (hence the need for compareSubscribers)
Maps Events to Classifiers through the classify-method (so it knows who to publish to)
|
LookupEventBus<E,S,C> |
Java API: See documentation for LookupClassification
E is the Event type
S is the Subscriber type
C is the Classifier type
|
LWWMap<A,B> |
|
LWWMap.LWWMapTag$ |
INTERNAL API
|
LWWMap$ |
|
LWWMapKey<A,B> |
|
LWWMapKey$ |
|
LWWRegister<A> |
Implements a 'Last Writer Wins Register' CRDT, also called a 'LWW-Register'.
|
LWWRegister.Clock<A> |
|
LWWRegister$ |
|
LWWRegisterKey<A> |
|
LWWRegisterKey$ |
|
LwwTime |
Utility class for comparing timestamp replica
identifier when implementing last-writer wins.
|
LwwTime$ |
|
Mailbox$ |
INTERNAL API
|
Mailboxes$ |
|
MailboxSelector |
Not for user extension.
|
MailboxSelector$ |
|
MailboxType |
MailboxType is a factory to create MessageQueues for an optionally
provided ActorContext.
|
ManagedActorClassification |
Maps ActorRefs to ActorRefs to form an EventBus where ActorRefs can listen to other ActorRefs.
|
ManagedActorEventBus<E> |
Java API: See documentation for ManagedActorClassification
An EventBus where the Subscribers are ActorRefs and the Classifier is ActorRef
Means that ActorRefs "listen" to other ActorRefs
E is the Event type
|
ManifestInfo |
Utility that extracts ManifestInfo#Version information from META-INF/MANIFEST.MF in jar files on the classpath.
|
ManifestInfo.Version |
Comparable version information
|
ManifestInfo$ |
Akka extension that extracts ManifestInfo.Version information from META-INF/MANIFEST.MF in jar files
on the classpath of the ClassLoader of the ActorSystem .
|
ManualReset |
|
ManualReset$ |
|
ManualTime |
|
ManualTime |
|
ManualTime$ |
Manual time allows you to do async tests while controlling the scheduler of the system.
|
ManualTime$ |
Manual time allows you to do async tests while controlling the scheduler of the system.
|
ManyVersionVector |
|
ManyVersionVector$ |
|
ManyVersionVector$ |
|
Mapper<T,R> |
Callback for the Future.map and Future.flatMap operations that will be invoked
if the Future that this callback is registered on becomes completed with a success.
|
MarkerLoggingAdapter |
|
Match<I,R> |
Version of PartialFunction that can be built during runtime from Java.
|
MaterializationContext$ |
|
MaterializationException |
This exception or subtypes thereof should be used to signal materialization
failures.
|
MaterializationException$ |
|
Materializer |
The Materializer is the component responsible for turning a stream blueprint into a running stream.
|
Materializer$ |
|
MaterializerLoggingProvider |
Not for user extension
|
MaterializerState |
Debug utility to dump the running streams of a materializers in a structure describing the graph layout
and "waits-on" relationships.
|
MaterializerState$ |
Debug utility to dump the running streams of a materializers in a structure describing the graph layout
and "waits-on" relationships.
|
MayVerb |
|
MayVerb.StringMayWrapperForVerb |
|
MayVerb.TestCanceledByFailure |
|
MayVerb.TestCanceledByFailure$ |
|
MayVerb$ |
|
Member |
Represents the address, current status, and roles of a cluster member node.
|
Member$ |
Module with factory and ordering methods for Member instances.
|
MembershipState$ |
INTERNAL API
|
MemberStatus |
Defines the current status of a cluster member node
|
MemberStatus.Down$ |
|
MemberStatus.Exiting$ |
|
MemberStatus.Joining$ |
|
MemberStatus.Leaving$ |
|
MemberStatus.PreparingForShutdown$ |
|
MemberStatus.ReadyForShutdown$ |
|
MemberStatus.Removed$ |
|
MemberStatus.Up$ |
|
MemberStatus.WeaklyUp$ |
|
MemberStatus$ |
|
Merge |
Merge several streams, taking elements as they arrive from input streams
(picking randomly when several have elements ready).
|
Merge<T> |
Merge several streams, taking elements as they arrive from input streams
(picking randomly when several have elements ready).
|
Merge$ |
Merge several streams, taking elements as they arrive from input streams
(picking randomly when several have elements ready).
|
Merge$ |
|
MergeHub |
A MergeHub is a special streaming hub that is able to collect streamed elements from a dynamic set of
producers.
|
MergeHub.DrainingControl |
A DrainingControl object is created during the materialization of a MergeHub and allows to initiate the draining
and eventual completion of the Hub from the outside.
|
MergeHub$ |
A MergeHub is a special streaming hub that is able to collect streamed elements from a dynamic set of
producers.
|
MergeHub$ |
A MergeHub is a special streaming hub that is able to collect streamed elements from a dynamic set of
producers.
|
MergeLatest |
MergeLatest joins elements from N input streams into stream of lists of size N.
|
MergeLatest<T,M> |
|
MergeLatest$ |
MergeLatest joins elements from N input streams into stream of lists of size N.
|
MergeLatest$ |
MergeLatest joins elements from N input streams into stream of lists of size N.
|
MergePreferred |
Merge several streams, taking elements as they arrive from input streams
(picking from preferred when several have elements ready).
|
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$ |
Merge several streams, taking elements as they arrive from input streams
(picking from preferred when several have elements ready).
|
MergePreferred$ |
|
MergePrioritized |
Merge several streams, taking elements as they arrive from input streams
(picking from prioritized once when several have elements ready).
|
MergePrioritized<T> |
Merge several streams, taking elements as they arrive from input streams
(picking from prioritized once when several have elements ready).
|
MergePrioritized$ |
Merge several streams, taking elements as they arrive from input streams
(picking from prioritized once when several have elements ready).
|
MergePrioritized$ |
|
MergeSequence |
Takes multiple streams whose elements in aggregate have a defined linear
sequence with difference 1, starting at 0, and outputs a single stream
containing these elements, in order.
|
MergeSequence<T> |
Takes multiple streams whose elements in aggregate have a defined linear
sequence with difference 1, starting at 0, and outputs a single stream
containing these elements, in order.
|
MergeSequence$ |
Takes multiple streams whose elements in aggregate have a defined linear
sequence with difference 1, starting at 0, and outputs a single stream
containing these elements, in order.
|
MergeSequence$ |
|
MergeSorted<T> |
Merge two pre-sorted streams such that the resulting stream is sorted.
|
Message |
Marker trait for all protobuf-serializable messages in akka.persistence .
|
Message$ |
INTERNAL API
|
MessageAdaptionFailure |
Signal passed to the actor when a message adapter has thrown an exception adapting an incoming message.
|
MessageAdaptionFailure$ |
|
MessageBuffer |
A non thread safe mutable message buffer that can be used to buffer messages inside actors.
|
MessageBuffer$ |
|
MessageBufferMap<I> |
A non thread safe mutable message buffer map that can be used to buffer messages inside actors.
|
MessageContainerSerializer |
|
MessageDispatcher |
|
MessageDispatcher$ |
INTERNAL API
|
MessageDispatcherConfigurator |
Base class to be used for hooking in new dispatchers into Dispatchers.
|
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 |
no longer created but needs to stay for reading persistent FSM events and snapshots
|
MessageFormats.PersistentStateChangeEvent.Builder |
no longer created but needs to stay for reading persistent FSM events and snapshots
|
MessageFormats.PersistentStateChangeEventOrBuilder |
|
MessageQueue |
A MessageQueue is one of the core components in forming an Akka Mailbox.
|
MessageSerializer |
|
MessageSerializer |
|
MessageSerializer |
INTERNAL API
|
MessageSerializer.SerializationException |
|
MessageSerializer$ |
INTERNAL API
|
Metric |
Metrics key/value.
|
Metric$ |
Factory for creating valid Metric instances.
|
MetricNumericConverter |
INTERNAL API
|
MetricsCollector |
Metrics sampler.
|
MetricsCollector$ |
INTERNAL API
|
MetricsGossip$ |
INTERNAL API
|
MetricsGossipEnvelope$ |
|
MetricsSelector |
A MetricsSelector is responsible for producing weights from the node metrics.
|
MetricsSelector$ |
|
MinimalActorRef |
Trait for ActorRef implementations where all methods contain default stubs.
|
MiscMessageSerializer |
|
MixMetricsSelector |
|
MixMetricsSelector$ |
Singleton instance of the default MixMetricsSelector, which uses [akka.cluster.routing.HeapMetricsSelector],
[akka.cluster.routing.CpuMetricsSelector], and [akka.cluster.routing.SystemLoadAverageMetricsSelector]
|
MixMetricsSelectorBase |
Base class for MetricsSelector that combines other selectors and aggregates their capacity.
|
MonitorableThreadFactory |
|
MonitorableThreadFactory$ |
|
MonitorInterceptor$ |
|
MultiNodeConfig |
Configure the role names and participants of the test, including configuration settings.
|
MultiNodeSpec |
Note: To be able to run tests with everything ignored or excluded by tags
you must not use testconductor , or helper methods that use testconductor ,
from the constructor of your test class.
|
MultiNodeSpec$ |
|
MultiNodeSpecCallbacks |
Use this to hook MultiNodeSpec into your test framework lifecycle, either by having your test extend MultiNodeSpec
and call these methods or by creating a trait that calls them and then mixing that trait with your test together
with MultiNodeSpec.
|
MultipleConsumerSemantics |
This is a marker trait for message queues which support multiple consumers,
as is required by the BalancingDispatcher.
|
Murmur2 |
INTERNAL API
|
Murmur2$ |
INTERNAL API
|
Murmur2MessageExtractor<M> |
The murmur2 message extractor uses the same algorithm as the default kafka partitioner
allowing kafka partitions to be mapped to shards.
|
Murmur2NoEnvelopeMessageExtractor<M> |
|
MurmurHash |
An object designed to generate well-distributed non-cryptographic
hashes.
|
MurmurHash$ |
An object designed to generate well-distributed non-cryptographic
hashes.
|
NanoTimeTokenBucket |
Default implementation of TokenBucket that uses System.nanoTime as the time source.
|
NativeImageUtils |
INTERNAL API
|
NativeImageUtils.Condition |
|
NativeImageUtils.Condition$ |
|
NativeImageUtils.ReflectConfigEntry |
|
NativeImageUtils.ReflectConfigEntry$ |
|
NativeImageUtils.ReflectField |
|
NativeImageUtils.ReflectField$ |
|
NativeImageUtils.ReflectMethod |
|
NativeImageUtils.ReflectMethod$ |
|
NativeImageUtils$ |
INTERNAL API
|
NetworkOp |
|
NeverMaterializedException |
|
NoActiveEntities |
INTERNAL API
|
NoActiveEntities$ |
INTERNAL API
|
NoAdmissionOptimizer |
INTERNAL API
|
NoAdmissionOptimizer$ |
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 |
|
NodeMetrics |
The snapshot of current sampled health metrics for any monitored process.
|
NodeMetrics$ |
|
NoDowning |
Default downing provider used when no provider is configured.
|
NoInboundCompressions |
INTERNAL API
|
NoInboundCompressions$ |
INTERNAL API
|
NoLogging |
NoLogging is a LoggingAdapter that does absolutely nothing – no logging at all.
|
NoLogging$ |
NoLogging is a LoggingAdapter that does absolutely nothing – no logging at all.
|
NoMarkerLogging |
NoLogging is a MarkerLoggingAdapter that does absolutely nothing – no logging at all.
|
NoMarkerLogging$ |
NoLogging is a MarkerLoggingAdapter that does absolutely nothing – no logging at all.
|
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$ |
|
NoOffset |
Used when retrieving all events.
|
NoOffset$ |
Used when retrieving all events.
|
NoOpEventAdapter$ |
INTERNAL API
|
NoopReadEventAdapter$ |
|
NoopSessionVerifier |
This verifier approves all sessions.
|
NoopSessionVerifier$ |
This verifier approves all sessions.
|
NoOpSnapshotAdapter$ |
INTERNAL API
|
NoOpSnapshotAdapter$ |
INTERNAL API
|
NoopWriteEventAdapter$ |
|
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$ |
|
NoScopeGiven |
This is the default value and as such allows overrides.
|
NoScopeGiven$ |
|
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.
|
NotAllowedClassRemoteDeploymentAttemptException |
INTERNAL API
|
NotInfluenceReceiveTimeout |
Marker trait to indicate that a message should not reset the receive timeout.
|
NotUsed |
This type is used in generic type signatures wherever the actual value is of no importance.
|
NotUsed$ |
|
NullSerializer |
This is a special Serializer that Serializes and deserializes nulls only
|
NullSerializer$ |
|
NumberOfProcesses |
|
Offset |
|
Offset$ |
|
OnComplete<T> |
Callback for when a Future is completed with either failure or a success
SAM (Single Abstract Method) class
|
OneForOneStrategy |
Applies the fault handling Directive (Resume, Restart, Stop) specified in the Decider
to the child actor that failed, as opposed to AllForOneStrategy that applies
it to all children.
|
OneForOneStrategy$ |
|
OneVersionVector |
|
OneVersionVector$ |
|
OneVersionVector$ |
|
OnFailure |
Callback for when a Future is completed with a failure
SAM (Single Abstract Method) class
|
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.
|
OnSuccess<T> |
Callback for when a Future is completed successfully
SAM (Single Abstract Method) class
|
OpCode |
INTERNAL API
|
OpCode$ |
INTERNAL API
|
OpCrdt<Operation> |
|
OptimalSizeExploringResizer |
|
OptimalSizeExploringResizer.ResizeRecord |
INTERNAL API
|
OptimalSizeExploringResizer.ResizeRecord$ |
|
OptimalSizeExploringResizer.UnderUtilizationStreak |
INTERNAL API
|
OptimalSizeExploringResizer.UnderUtilizationStreak$ |
|
OptimalSizeExploringResizer$ |
|
Option<A> |
This class represents optional values.
|
Option.Some<A> |
Class Some[A] represents existing values of type
A .
|
Option.Some$ |
|
Option$ |
|
OptionalTests |
|
OptionVal$ |
INTERNAL API
|
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.DeltaGroup$ |
|
ORMap.DeltaOp |
|
ORMap.PutDeltaOp$ |
|
ORMap.RemoveDeltaOp$ |
|
ORMap.RemoveKeyDeltaOp$ |
|
ORMap.UpdateDeltaOp$ |
|
ORMap.VanillaORMapTag$ |
|
ORMap.ZeroTag |
|
ORMap$ |
|
ORMapKey<A,B extends ReplicatedData> |
|
ORMapKey$ |
|
ORMultiMap |