- abort() - Method in class akka.actor.ActorSystemImpl
-
This kind of shutdown attempts to bring the system down and release its
resources more forcefully than plain shutdown.
- abort() - Method in class akka.io.TcpConnection
-
- abort() - Method in class akka.io.TcpMessage$
-
An abort operation will not flush pending writes and will issue a TCP ABORT
command to the O/S kernel which should result in a TCP_RST packet being sent
to the peer.
- abort() - Static method in class akka.io.TcpMessage
-
An abort operation will not flush pending writes and will issue a TCP ABORT
command to the O/S kernel which should result in a TCP_RST packet being sent
to the peer.
- abort(RoleName, RoleName) - Method in interface akka.remote.testconductor.Conductor
-
Tell the remote support to TCP_RESET the connection to the given remote
peer.
- abort() - Method in class akka.remote.testconductor.Disconnect
-
- abort() - Method in class akka.remote.testconductor.DisconnectMsg
-
- Abort$() - Constructor for class akka.io.Tcp.Abort$
-
- Abort_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.FailType
-
Abort = 3;
- Aborted$() - Constructor for class akka.io.Tcp.Aborted$
-
- aborting() - Method in class akka.actor.ActorSystemImpl
-
- AbstractActor - Class in akka.actor
-
Java API: compatible with lambda expressions
- AbstractActor() - Constructor for class akka.actor.AbstractActor
-
- AbstractActor$ - Class in akka.actor
-
Java API: compatible with lambda expressions
- AbstractActor$() - Constructor for class akka.actor.AbstractActor$
-
- AbstractActorContext - Interface in akka.actor
-
AbstractActorContext is the AbstractActor equivalent of ActorContext,
containing the Java API
- AbstractActorWithStash - Class in akka.actor
-
Java API: compatible with lambda expressions
- AbstractActorWithStash() - Constructor for class akka.actor.AbstractActorWithStash
-
- AbstractActorWithUnboundedStash - Class in akka.actor
-
Java API: compatible with lambda expressions
- AbstractActorWithUnboundedStash() - Constructor for class akka.actor.AbstractActorWithUnboundedStash
-
- AbstractActorWithUnrestrictedStash - Class in akka.actor
-
Java API: compatible with lambda expressions
- AbstractActorWithUnrestrictedStash() - Constructor for class akka.actor.AbstractActorWithUnrestrictedStash
-
- AbstractBatch() - Constructor for class akka.dispatch.BatchingExecutor.AbstractBatch
-
- AbstractBoundedNodeQueue<T> - Class in akka.dispatch
-
Lock-free bounded non-blocking multiple-producer multiple-consumer queue based on the works of:
Andriy Plokhotnuyk (https://github.com/plokhotnyuk)
- https://github.com/plokhotnyuk/actors/blob/2e65abb7ce4cbfcb1b29c98ee99303d6ced6b01f/src/test/scala/akka/dispatch/Mailboxes.scala
(Apache V2: https://github.com/plokhotnyuk/actors/blob/master/LICENSE)
Dmitriy Vyukov's non-intrusive MPSC queue:
- http://www.1024cores.net/home/lock-free-algorithms/queues/non-intrusive-mpsc-node-based-queue
(Simplified BSD)
- AbstractBoundedNodeQueue(int) - Constructor for class akka.dispatch.AbstractBoundedNodeQueue
-
- AbstractBoundedNodeQueue.Node<T> - Class in akka.dispatch
-
- AbstractExtensionId<T extends Extension> - Class in akka.actor
-
Java API for ExtensionId
- AbstractExtensionId() - Constructor for class akka.actor.AbstractExtensionId
-
- AbstractFSM<S,D> - Class in akka.actor
-
Java API: compatible with lambda expressions
- AbstractFSM() - Constructor for class akka.actor.AbstractFSM
-
- AbstractFSM$ - Class in akka.actor
-
Java API: compatible with lambda expressions
- AbstractFSM$() - Constructor for class akka.actor.AbstractFSM$
-
- AbstractLoggingActor - Class in akka.actor
-
Java API: compatible with lambda expressions
- AbstractLoggingActor() - Constructor for class akka.actor.AbstractLoggingActor
-
- AbstractLoggingFSM<S,D> - Class in akka.actor
-
Java API: compatible with lambda expressions
- AbstractLoggingFSM() - Constructor for class akka.actor.AbstractLoggingFSM
-
- AbstractNodeQueue<T> - Class in akka.dispatch
-
Lock-free MPSC linked queue implementation based on Dmitriy Vyukov's non-intrusive MPSC queue:
http://www.1024cores.net/home/lock-free-algorithms/queues/non-intrusive-mpsc-node-based-queue
- AbstractNodeQueue() - Constructor for class akka.dispatch.AbstractNodeQueue
-
- AbstractNodeQueue.Node<T> - Class in akka.dispatch
-
- AbstractPersistentActor - Class in akka.persistence
-
Java API: an persistent actor - can be used to implement command or event sourcing.
- AbstractPersistentActor() - Constructor for class akka.persistence.AbstractPersistentActor
-
- AbstractPersistentActorWithAtLeastOnceDelivery - Class in akka.persistence
-
Java API compatible with lambda expressions
- AbstractPersistentActorWithAtLeastOnceDelivery() - Constructor for class akka.persistence.AbstractPersistentActorWithAtLeastOnceDelivery
-
- AbstractPersistentView - Class in akka.persistence
-
Java API: compatible with lambda expressions (to be used with
ReceiveBuilder
)
- AbstractPersistentView() - Constructor for class akka.persistence.AbstractPersistentView
-
- AbstractScheduler - Class in akka.actor
-
An Akka scheduler service.
- AbstractScheduler() - Constructor for class akka.actor.AbstractScheduler
-
- AbstractSchedulerBase - Class in akka.actor
-
- AbstractSchedulerBase() - Constructor for class akka.actor.AbstractSchedulerBase
-
- AbstractShardAllocationStrategy() - Constructor for class akka.cluster.sharding.ShardCoordinator.AbstractShardAllocationStrategy
-
- AbstractSocketOption() - Constructor for class akka.io.Inet.AbstractSocketOption
-
- AbstractSocketOptionV2() - Constructor for class akka.io.Inet.AbstractSocketOptionV2
-
- AbstractTransportAdapter - Class in akka.remote.transport
-
An adapter that wraps a transport and provides interception
- AbstractTransportAdapter(Transport, ExecutionContext) - Constructor for class akka.remote.transport.AbstractTransportAdapter
-
- AbstractTransportAdapterHandle - Class in akka.remote.transport
-
- AbstractTransportAdapterHandle(Address, Address, AssociationHandle, String) - Constructor for class akka.remote.transport.AbstractTransportAdapterHandle
-
- AbstractTransportAdapterHandle(AssociationHandle, String) - Constructor for class akka.remote.transport.AbstractTransportAdapterHandle
-
- acceptableHeartbeatPause() - Method in class akka.remote.DeadlineFailureDetector
-
- acceptableHeartbeatPause() - Method in class akka.remote.PhiAccrualFailureDetector
-
- acceptAllPending(ChannelRegistration, int) - Method in class akka.io.TcpListener
-
- accepting() - Method in class akka.remote.EndpointManager
-
- acceptLimit() - Method in class akka.io.TcpListener
-
- Ack - Class in akka.camel
-
Positive acknowledgement message (used for application-acknowledged message receipts).
- Ack() - Constructor for class akka.camel.Ack
-
- ack() - Method in class akka.cluster.pubsub.DistributedPubSubMediator.Internal$.Subscribed
-
- ack() - Method in class akka.cluster.pubsub.DistributedPubSubMediator.Internal$.Unsubscribed
-
- ack() - Method in class akka.contrib.mailbox.PeekMailbox
-
- ack(ActorContext) - Method in class akka.contrib.mailbox.PeekMailboxExtension$
-
- ack(ActorContext) - Method in class akka.contrib.mailbox.PeekMailboxExtension
-
- ack() - Method in class akka.io.Tcp.SimpleWriteCommand
-
The acknowledgment token associated with this write command.
- ack() - Method in class akka.io.Tcp.Write
-
- ack() - Method in class akka.io.Tcp.WriteFile
-
- ack() - Method in class akka.io.Udp.Send
-
- ack() - Method in class akka.io.UdpConnected.Send
-
- Ack - Class in akka.remote
-
Class representing an acknowledgement with selective negative acknowledgements.
- Ack(SeqNo, Set<SeqNo>) - Constructor for class akka.remote.Ack
-
- ack() - Method in class akka.remote.EndpointWriter.OutboundAck
-
- Ack$ - Class in akka.camel
-
Positive acknowledgement message (used for application-acknowledged message receipts).
- Ack$() - Constructor for class akka.camel.Ack$
-
- Ack$ - Class in akka.remote
-
- Ack$() - Constructor for class akka.remote.Ack$
-
- ACK_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AckAndEnvelopeContainer
-
- ackDeadline() - Method in class akka.remote.EndpointWriter
-
- AckedReceiveBuffer<T extends HasSequenceNumber> - Class in akka.remote
-
Implements an immutable receive buffer that buffers incoming messages until they can be safely delivered.
- AckedReceiveBuffer(SeqNo, SeqNo, SortedSet<T>, Ordering<T>) - Constructor for class akka.remote.AckedReceiveBuffer
-
- ackedReceiveBuffer() - Method in class akka.remote.EndpointReader
-
- AckedReceiveBuffer$ - Class in akka.remote
-
- AckedReceiveBuffer$() - Constructor for class akka.remote.AckedReceiveBuffer$
-
- AckedSendBuffer<T extends HasSequenceNumber> - Class in akka.remote
-
Implements an immutable resend buffer that buffers messages until they have been acknowledged.
- AckedSendBuffer(int, IndexedSeq<T>, IndexedSeq<T>, SeqNo) - Constructor for class akka.remote.AckedSendBuffer
-
- AckedSendBuffer$ - Class in akka.remote
-
- AckedSendBuffer$() - Constructor for class akka.remote.AckedSendBuffer$
-
- AckIdleCheckTimer$() - Constructor for class akka.remote.EndpointWriter.AckIdleCheckTimer$
-
- ackIdleTimer() - Method in class akka.remote.EndpointWriter
-
- acknowledge(Ack) - Method in class akka.remote.AckedSendBuffer
-
Processes an incoming acknowledgement and returns a new buffer with only unacknowledged elements remaining.
- acquire() - Method in interface akka.io.BufferPool
-
- acquire() - Method in class akka.io.DirectByteBufferPool
-
- activated(List<ActorRef>) - Method in class akka.camel.internal.ActivationTracker.ActivationStateMachine
-
Activated state.
- Activation - Interface in akka.camel
-
Activation trait that can be used to wait on activation or de-activation of Camel endpoints.
- activationFutureFor(ActorRef, Timeout, ExecutionContext) - Method in interface akka.camel.Activation
-
Produces a Future with the specified endpoint that will be completed when the endpoint has been activated,
or if it times out, which will happen after the specified Timeout.
- activationFutureFor(ActorRef, Timeout, ExecutionContext) - Method in class akka.camel.internal.DefaultCamel
-
Produces a Future with the specified endpoint that will be completed when the endpoint has been activated,
or if it times out, which will happen after the specified Timeout.
- ActivationMessage(ActorRef) - Constructor for class akka.camel.internal.ActivationProtocol.ActivationMessage
-
- ActivationMessage$() - Constructor for class akka.camel.internal.ActivationProtocol.ActivationMessage$
-
- ActivationProtocol - Class in akka.camel.internal
-
- ActivationProtocol() - Constructor for class akka.camel.internal.ActivationProtocol
-
- ActivationProtocol$ - Class in akka.camel.internal
-
- ActivationProtocol$() - Constructor for class akka.camel.internal.ActivationProtocol$
-
- ActivationProtocol.ActivationMessage - Class in akka.camel.internal
-
Super class of all activation messages.
- ActivationProtocol.ActivationMessage$ - Class in akka.camel.internal
-
INTERNAL API
companion object of ActivationMessage
- ActivationProtocol.EndpointActivated - Class in akka.camel.internal
-
INTERNAL API
Event message indicating that a single endpoint has been activated.
- ActivationProtocol.EndpointActivated$ - Class in akka.camel.internal
-
- ActivationProtocol.EndpointDeActivated - Class in akka.camel.internal
-
INTERNAL API
Event message indicating that a single endpoint was de-activated.
- ActivationProtocol.EndpointDeActivated$ - Class in akka.camel.internal
-
- ActivationProtocol.EndpointFailedToActivate - Class in akka.camel.internal
-
INTERNAL API
Event message indicating that a single endpoint failed to activate.
- ActivationProtocol.EndpointFailedToActivate$ - Class in akka.camel.internal
-
- ActivationProtocol.EndpointFailedToDeActivate - Class in akka.camel.internal
-
INTERNAL API
Event message indicating that a single endpoint failed to de-activate.
- ActivationProtocol.EndpointFailedToDeActivate$ - Class in akka.camel.internal
-
- activations() - Method in class akka.camel.internal.ActivationTracker
-
- ActivationStateMachine() - Constructor for class akka.camel.internal.ActivationTracker.ActivationStateMachine
-
- ActivationTimeout() - Method in class akka.camel.CamelSettings
-
Configured setting for how long the actor should wait for activation before it fails.
- activationTimeout() - Method in interface akka.camel.Consumer
-
How long the actor should wait for activation before it fails.
- activationTimeout() - Method in class akka.camel.ConsumerConfig
-
- ActivationTracker - Class in akka.camel.internal
-
INTERNAL API
An actor that tracks activation and de-activation of endpoints.
- ActivationTracker() - Constructor for class akka.camel.internal.ActivationTracker
-
- ActivationTracker.ActivationStateMachine - Class in akka.camel.internal
-
A state machine that keeps track of the endpoint activation status of an actor.
- active(ActorRef) - Method in class akka.cluster.client.ClusterClient
-
- active() - Method in class akka.cluster.ClusterHeartbeatSender
-
- active() - Method in class akka.contrib.pattern.ReliableProxy$
-
- active() - Static method in class akka.contrib.pattern.ReliableProxy
-
- Active$() - Constructor for class akka.contrib.pattern.ReliableProxy.Active$
-
- Active$() - Constructor for class akka.contrib.throttle.TimerBasedThrottler.Active$
-
- activeReceivers() - Method in class akka.cluster.ClusterHeartbeatSenderState
-
- Actor - Interface in akka.actor
-
- actor() - Method in class akka.actor.ActorCell
-
- actor(Function0<T>, ClassTag<T>, ActorRefFactory) - Method in interface akka.actor.dsl.Creators
-
Create an actor from the given thunk which must produce an
Actor
.
- actor(String, Function0<T>, ClassTag<T>, ActorRefFactory) - Method in interface akka.actor.dsl.Creators
-
Create an actor from the given thunk which must produce an
Actor
.
- actor(ActorRefFactory, String, Function0<T>, ClassTag<T>) - Method in interface akka.actor.dsl.Creators
-
Create an actor from the given thunk which must produce an
Actor
.
- actor(ActorRefFactory, Function0<T>, ClassTag<T>) - Method in interface akka.actor.dsl.Creators
-
Create an actor with an automatically generated name from the given thunk
which must produce an
Actor
.
- actor() - Method in exception akka.actor.PostRestartException
-
- actor() - Method in exception akka.actor.PreRestartException
-
- actor() - Method in class akka.actor.Terminated
-
- actor() - Method in class akka.actor.TypedActor.SerializedTypedActorInvocationHandler
-
- actor() - Method in class akka.actor.TypedActor.TypedActorInvocationHandler
-
- actor() - Method in class akka.camel.internal.ActivationProtocol.ActivationMessage
-
- actor() - Method in class akka.contrib.pattern.ReliableProxy.ProxyTerminated
-
- actor() - Method in class akka.dispatch.Mailbox
-
- actor() - Method in class akka.dispatch.sysmsg.DeathWatchNotification
-
- actor() - Method in class akka.event.ActorClassificationUnsubscriber.Register
-
- actor() - Method in class akka.event.ActorClassificationUnsubscriber.Unregister
-
- actor() - Method in class akka.event.EventStreamUnsubscriber.Register
-
- actor() - Method in class akka.event.EventStreamUnsubscriber.UnregisterIfNoMoreSubscribedChannels
-
- actor() - Method in class akka.persistence.Persistence.PluginHolder
-
- actor() - Method in class akka.remote.RemoteDeploymentWatcher.WatchRemote
-
- actor() - Method in class akka.remote.transport.AssociationHandle.ActorHandleEventListener
-
- actor() - Method in class akka.remote.transport.Transport.ActorAssociationEventListener
-
- Actor$ - Class in akka.actor
-
- Actor$() - Constructor for class akka.actor.Actor$
-
- Actor.emptyBehavior$ - Class in akka.actor
-
emptyBehavior is a Receive-expression that matches no messages at all, ever.
- Actor.ignoringBehavior$ - Class in akka.actor
-
ignoringBehavior is a Receive-expression that consumes and ignores all messages.
- ActorActivationException - Exception in akka.camel.internal
-
INTERNAL API
Thrown by the registrars to indicate that the actor could not be activated.
- ActorActivationException(ActorRef, Throwable) - Constructor for exception akka.camel.internal.ActorActivationException
-
- ActorAdapter<T> - Class in akka.typed
-
INTERNAL API.
- ActorAdapter(Function0<Behavior<T>>) - Constructor for class akka.typed.ActorAdapter
-
- ActorAssociationEventListener(ActorRef) - Constructor for class akka.remote.transport.Transport.ActorAssociationEventListener
-
- ActorAssociationEventListener$() - Constructor for class akka.remote.transport.Transport.ActorAssociationEventListener$
-
- ActorCell - Class in akka.actor
-
Everything in here is completely Akka PRIVATE.
- ActorCell(ActorSystemImpl, InternalActorRef, Props, MessageDispatcher, InternalActorRef) - Constructor for class akka.actor.ActorCell
-
- actorCell() - Method in interface akka.actor.StashSupport
-
- ActorCell$ - Class in akka.actor
-
Everything in here is completely Akka PRIVATE.
- ActorCell$() - Constructor for class akka.actor.ActorCell$
-
- actorClass() - Method in class akka.actor.ArgsReflectConstructor
-
- actorClass() - Method in class akka.actor.CreatorConsumer
-
- actorClass() - Method in class akka.actor.CreatorFunctionConsumer
-
- actorClass() - Method in interface akka.actor.IndirectActorProducer
-
This method is used by
Props
to determine the type of actor which will
be created.
- actorClass() - Method in class akka.actor.NoArgsReflectConstructor
-
- actorClass() - Method in class akka.actor.Props
-
Obtain an upper-bound approximation of the actor class which is going to
be created by these Props.
- actorClass() - Method in class akka.actor.TypedCreatorFunctionConsumer
-
- actorClass() - Method in interface akka.io.DnsProvider
-
- actorClass() - Method in class akka.io.InetAddressDnsProvider
-
- actorClass() - Method in class akka.routing.RoutedActorCell.RouterActorCreator
-
- ActorClassification - Interface in akka.event
-
Maps ActorRefs to ActorRefs to form an EventBus where ActorRefs can listen to other ActorRefs
- ActorClassificationUnsubscriber - Class in akka.event
-
INTERNAL API
- ActorClassificationUnsubscriber(ManagedActorClassification, boolean) - Constructor for class akka.event.ActorClassificationUnsubscriber
-
- ActorClassificationUnsubscriber$ - Class in akka.event
-
INTERNAL API
- ActorClassificationUnsubscriber$() - Constructor for class akka.event.ActorClassificationUnsubscriber$
-
- ActorClassificationUnsubscriber.Register - Class in akka.event
-
- ActorClassificationUnsubscriber.Register$ - Class in akka.event
-
- ActorClassificationUnsubscriber.Unregister - Class in akka.event
-
- ActorClassificationUnsubscriber.Unregister$ - Class in akka.event
-
- ActorClassifier - Interface in akka.event
-
Can be mixed into an EventBus to specify that the Classifier type is ActorRef
- ActorComponent - Class in akka.camel.internal.component
-
- ActorComponent(Camel, ActorSystem) - Constructor for class akka.camel.internal.component.ActorComponent
-
- ActorContext - Interface in akka.actor
-
The actor context - the view of the actor cell from the actor.
- actorContext() - Method in class akka.actor.LocalActorRef
-
- ActorContext<T> - Interface in akka.typed
-
An Actor is given by the combination of a
Behavior
and a context in
which this behavior is executed.
- ActorContextAdapter<T> - Class in akka.typed
-
INTERNAL API.
- ActorContextAdapter(ActorContext) - Constructor for class akka.typed.ActorContextAdapter
-
- ActorContextOps(ActorContext) - Constructor for class akka.typed.Ops.ActorContextOps
-
- ActorContextOps$() - Constructor for class akka.typed.Ops.ActorContextOps$
-
- ActorDeActivationException - Exception in akka.camel.internal
-
INTERNAL API
Thrown by registrars to indicate that the actor could not be de-activated.
- ActorDeActivationException(ActorRef, Throwable) - Constructor for exception akka.camel.internal.ActorDeActivationException
-
- ActorDSL - Class in akka.actor
-
This object contains elements which make writing actors and related code
more concise, e.g.
- ActorDSL() - Constructor for class akka.actor.ActorDSL
-
- ActorDSL$ - Class in akka.actor
-
This object contains elements which make writing actors and related code
more concise, e.g.
- ActorDSL$() - Constructor for class akka.actor.ActorDSL$
-
- ActorDSL.Extension - Class in akka.actor
-
- ActorDSL.Extension$ - Class in akka.actor
-
- ActorEndpoint - Class in akka.camel.internal.component
-
INTERNAL API
Does what an endpoint does, creates consumers and producers for the component.
- ActorEndpoint(String, ActorComponent, ActorEndpointPath, Camel) - Constructor for class akka.camel.internal.component.ActorEndpoint
-
- ActorEndpointConfig - Interface in akka.camel.internal.component
-
INTERNAL API
Configures the ActorEndpoint
.
- ActorEndpointPath - Class in akka.camel.internal.component
-
INTERNAL API
An endpoint to an
ActorRef
param: actorPath the String representation of the path to the actor
- ActorEndpointPath$ - Class in akka.camel.internal.component
-
INTERNAL API
Companion of ActorEndpointPath
- ActorEndpointPath$() - Constructor for class akka.camel.internal.component.ActorEndpointPath$
-
- ActorEventBus - Interface in akka.event
-
Represents an EventBus where the Subscriber type is ActorRef
- ActorEventBus<E> - Class in akka.event.japi
-
Java API: See documentation for
ActorClassification
An EventBus where the Subscribers are ActorRefs and the Classifier is ActorRef
Means that ActorRefs "listen" to other ActorRefs
E is the Event type
- ActorEventBus() - Constructor for class akka.event.japi.ActorEventBus
-
- actorFactory() - Method in class akka.actor.ContextualTypedActorFactory
-
- actorFactory() - Method in class akka.actor.TypedActorExtension
-
- actorFactory() - Method in interface akka.actor.TypedActorFactory
-
Underlying dependency is to be able to create normal Actors
- actorFor(ActorPath) - Method in interface akka.actor.ActorRefFactory
-
INTERNAL API
- actorFor(String) - Method in interface akka.actor.ActorRefFactory
-
INTERNAL API
- actorFor(Iterable<String>) - Method in interface akka.actor.ActorRefFactory
-
INTERNAL API
- actorFor(Iterable<String>) - Method in interface akka.actor.ActorRefFactory
-
INTERNAL API
- actorFor(ActorPath) - Method in interface akka.actor.ActorRefProvider
-
INTERNAL API
- actorFor(InternalActorRef, String) - Method in interface akka.actor.ActorRefProvider
-
INTERNAL API
- actorFor(InternalActorRef, Iterable<String>) - Method in interface akka.actor.ActorRefProvider
-
INTERNAL API
- actorFor(InternalActorRef, String) - Method in class akka.actor.LocalActorRefProvider
-
- actorFor(ActorPath) - Method in class akka.actor.LocalActorRefProvider
-
- actorFor(InternalActorRef, Iterable<String>) - Method in class akka.actor.LocalActorRefProvider
-
- actorFor(ActorPath) - Method in class akka.remote.RemoteActorRefProvider
-
- actorFor(InternalActorRef, String) - Method in class akka.remote.RemoteActorRefProvider
-
- actorFor(InternalActorRef, Iterable<String>) - Method in class akka.remote.RemoteActorRefProvider
-
- ActorHandleEventListener(ActorRef) - Constructor for class akka.remote.transport.AssociationHandle.ActorHandleEventListener
-
- ActorHandleEventListener$() - Constructor for class akka.remote.transport.AssociationHandle.ActorHandleEventListener$
-
- ActorIdentity - Class in akka.actor
-
- ActorIdentity(Object, Option<ActorRef>) - Constructor for class akka.actor.ActorIdentity
-
- ActorIdentity$ - Class in akka.actor
-
- ActorIdentity$() - Constructor for class akka.actor.ActorIdentity$
-
- ActorInitializationException - Exception in akka.actor
-
An ActorInitializationException is thrown when the the initialization logic for an Actor fails.
- ActorInitializationException(ActorRef, String, Throwable) - Constructor for exception akka.actor.ActorInitializationException
-
- ActorInitializationException$ - Class in akka.actor
-
- ActorInitializationException$() - Constructor for class akka.actor.ActorInitializationException$
-
- actorInstanceId() - Method in class akka.persistence.JournalProtocol.LoopMessageSuccess
-
- actorInstanceId() - Method in class akka.persistence.JournalProtocol.WriteMessageFailure
-
- actorInstanceId() - Method in class akka.persistence.JournalProtocol.WriteMessages
-
- actorInstanceId() - Method in class akka.persistence.JournalProtocol.WriteMessageSuccess
-
- actorInstanceId() - Method in class akka.persistence.PluginSpec
-
- ActorInterruptedException - Exception in akka.actor
-
When an InterruptedException is thrown inside an Actor, it is wrapped as an ActorInterruptedException as to
avoid cascading interrupts to other threads than the originally interrupted one.
- ActorInterruptedException(Throwable) - Constructor for exception akka.actor.ActorInterruptedException
-
- ActorKilledException - Exception in akka.actor
-
ActorKilledException is thrown when an Actor receives the
Kill
message
- ActorKilledException(String) - Constructor for exception akka.actor.ActorKilledException
-
- ActorKilledException$ - Class in akka.actor
-
- ActorKilledException$() - Constructor for class akka.actor.ActorKilledException$
-
- ActorLogging - Interface in akka.actor
-
Scala API: Mix in ActorLogging into your Actor to easily obtain a reference to a logger,
which is available under the name "log".
- ActorNotFound - Exception in akka.actor
-
- ActorNotFound(ActorSelection) - Constructor for exception akka.actor.ActorNotFound
-
- ActorNotFound$ - Class in akka.actor
-
- ActorNotFound$() - Constructor for class akka.actor.ActorNotFound$
-
- ActorNotRegisteredException - Exception in akka.camel
-
Thrown to indicate that the actor referenced by an endpoint URI cannot be
found in the actor system.
- ActorNotRegisteredException(String) - Constructor for exception akka.camel.ActorNotRegisteredException
-
- actorOf(Props) - Method in interface akka.actor.ActorRefFactory
-
Create new actor as child of this context and give it an automatically
generated name (currently similar to base64-encoded integer count,
reversed and with “$” prepended, may change in the future).
- actorOf(Props, String) - Method in interface akka.actor.ActorRefFactory
-
Create new actor as child of this context with the given name, which must
not be null, empty or start with “$”.
- actorOf(ActorSystemImpl, Props, InternalActorRef, ActorPath, boolean, Option<Deploy>, boolean, boolean) - Method in interface akka.actor.ActorRefProvider
-
Actor factory with create-only semantics: will create an actor as
described by props with the given supervisor and path (may be different
in case of remote supervision).
- actorOf(Props, String) - Method in class akka.actor.ActorSystemImpl
-
- actorOf(Props) - Method in class akka.actor.ActorSystemImpl
-
- actorOf(Props) - Method in interface akka.actor.dungeon.Children
-
- actorOf(Props, String) - Method in interface akka.actor.dungeon.Children
-
- actorOf(ActorSystemImpl, Props, InternalActorRef, ActorPath, boolean, Option<Deploy>, boolean, boolean) - Method in class akka.actor.LocalActorRefProvider
-
- actorOf(ActorSystemImpl, Props, InternalActorRef, ActorPath, boolean, Option<Deploy>, boolean, boolean) - Method in class akka.remote.RemoteActorRefProvider
-
- actorOf(Props) - Method in interface akka.typed.ActorContext
-
Create an untyped child Actor from the given
Props
under a randomly chosen name.
- actorOf(Props, String) - Method in interface akka.typed.ActorContext
-
Create an untyped child Actor from the given
Props
and with the given name.
- actorOf(Props) - Method in class akka.typed.ActorContextAdapter
-
- actorOf(Props, String) - Method in class akka.typed.ActorContextAdapter
-
- actorOf(Props) - Method in class akka.typed.EffectfulActorContext
-
- actorOf(Props, String) - Method in class akka.typed.EffectfulActorContext
-
- actorOf(Props) - Method in class akka.typed.StubbedActorContext
-
- actorOf(Props, String) - Method in class akka.typed.StubbedActorContext
-
- ActorPath - Class in akka.actor
-
Actor path is a unique path to an actor that shows the creation path
up through the actor tree to the root actor.
- ActorPath() - Constructor for class akka.actor.ActorPath
-
- actorPath() - Method in class akka.camel.internal.component.ActorEndpointPath
-
- ActorPath$ - Class in akka.actor
-
- ActorPath$() - Constructor for class akka.actor.ActorPath$
-
- ActorPathExtractor - Class in akka.actor
-
Given an ActorPath it returns the Address and the path elements if the path is well-formed
- ActorPathExtractor() - Constructor for class akka.actor.ActorPathExtractor
-
- ActorPathExtractor$ - Class in akka.actor
-
Given an ActorPath it returns the Address and the path elements if the path is well-formed
- ActorPathExtractor$() - Constructor for class akka.actor.ActorPathExtractor$
-
- ActorProducer - Class in akka.camel.internal.component
-
Sends the in-message of an exchange to an untyped actor, identified by an
ActorEndpoint
- ActorProducer(ActorEndpoint, Camel) - Constructor for class akka.camel.internal.component.ActorProducer
-
- actorProps() - Method in class akka.actor.TypedProps
-
Returns the akka.actor.Props representation of this TypedProps
- ActorRef - Class in akka.actor
-
Immutable and serializable handle to an actor, which may or may not reside
on the local host or inside the same
ActorSystem
.
- ActorRef() - Constructor for class akka.actor.ActorRef
-
- actorRef() - Method in class akka.actor.FSM.SubscribeTransitionCallBack
-
- actorRef() - Method in class akka.actor.FSM.UnsubscribeTransitionCallBack
-
- actorRef() - Method in class akka.camel.internal.ActivationProtocol.EndpointActivated
-
- actorRef() - Method in class akka.camel.internal.ActivationProtocol.EndpointDeActivated
-
- actorRef() - Method in class akka.camel.internal.ActivationProtocol.EndpointFailedToActivate
-
- actorRef() - Method in class akka.camel.internal.ActivationProtocol.EndpointFailedToDeActivate
-
- actorRef() - Method in exception akka.camel.internal.ActorActivationException
-
- actorRef() - Method in exception akka.camel.internal.ActorDeActivationException
-
- actorRef() - Method in class akka.camel.internal.CamelSupervisor.AddWatch
-
- actorRef() - Method in class akka.camel.internal.CamelSupervisor.DeRegister
-
- actorRef() - Method in class akka.camel.internal.CamelSupervisor.Register
-
- actorRef() - Method in class akka.pattern.AskableActorRef
-
- ActorRef<T> - Class in akka.typed
-
An ActorRef is the identity or address of an Actor instance.
- ActorRef() - Constructor for class akka.typed.ActorRef
-
- ActorRef$ - Class in akka.actor
-
- ActorRef$() - Constructor for class akka.actor.ActorRef$
-
- ActorRef$ - Class in akka.typed
-
- ActorRef$() - Constructor for class akka.typed.ActorRef$
-
- actorRefAdapter(ActorRef) - Method in class akka.typed.Ops$
-
- actorRefAdapter(ActorRef) - Static method in class akka.typed.Ops
-
- ActorRefFactory - Interface in akka.actor
-
Interface implemented by ActorSystem and ActorContext, the only two places
from which you can get fresh actors.
- ActorRefProvider - Interface in akka.actor
-
Interface for all ActorRef providers to implement.
- ActorRefRoutee - Class in akka.routing
-
- ActorRefRoutee(ActorRef) - Constructor for class akka.routing.ActorRefRoutee
-
- ActorRefRoutee$ - Class in akka.routing
-
- ActorRefRoutee$() - Constructor for class akka.routing.ActorRefRoutee$
-
- ActorRefScope - Interface in akka.actor
-
All ActorRefs have a scope which describes where they live.
- ActorRefWithCell - Class in akka.actor
-
Common trait of all actor refs which actually have a Cell, most notably
LocalActorRef and RepointableActorRef.
- ActorRefWithCell() - Constructor for class akka.actor.ActorRefWithCell
-
- ActorRouteDefinition<T extends org.apache.camel.model.ProcessorDefinition<T>> - Class in akka.camel
-
Wraps a ProcessorDefinition
.
- ActorRouteDefinition(ProcessorDefinition<T>) - Constructor for class akka.camel.ActorRouteDefinition
-
- actors() - Method in class akka.dispatch.MessageDispatcher$
-
- actors() - Static method in class akka.dispatch.MessageDispatcher
-
- actorSel() - Method in class akka.pattern.AskableActorSelection
-
- actorSelection(String) - Method in interface akka.actor.ActorRefFactory
-
Construct an
ActorSelection
from the given path, which is
parsed for wildcards (these are replaced by regular expressions
internally).
- actorSelection(ActorPath) - Method in interface akka.actor.ActorRefFactory
-
Construct an
ActorSelection
from the given path, which is
parsed for wildcards (these are replaced by regular expressions
internally).
- ActorSelection - Class in akka.actor
-
An ActorSelection is a logical view of a section of an ActorSystem's tree of Actors,
allowing for broadcasting of messages to that section.
- ActorSelection() - Constructor for class akka.actor.ActorSelection
-
- ActorSelection$ - Class in akka.actor
-
An ActorSelection is a logical view of a section of an ActorSystem's tree of Actors,
allowing for broadcasting of messages to that section.
- ActorSelection$() - Constructor for class akka.actor.ActorSelection$
-
- ActorSelectionMessage - Class in akka.actor
-
INTERNAL API
ActorRefFactory.actorSelection returns a ActorSelection which sends these
nested path descriptions whenever using ! on them, the idea being that the
message is delivered by traversing the various actor paths involved.
- ActorSelectionMessage(Object, Iterable<SelectionPathElement>, boolean) - Constructor for class akka.actor.ActorSelectionMessage
-
- ActorSelectionMessage$ - Class in akka.actor
-
- ActorSelectionMessage$() - Constructor for class akka.actor.ActorSelectionMessage$
-
- ActorSelectionRoutee - Class in akka.routing
-
- ActorSelectionRoutee(ActorSelection) - Constructor for class akka.routing.ActorSelectionRoutee
-
- ActorSelectionRoutee$ - Class in akka.routing
-
- ActorSelectionRoutee$() - Constructor for class akka.routing.ActorSelectionRoutee$
-
- ActorSystem - Class in akka.actor
-
An actor system is a hierarchical group of actors which share common
configuration, e.g.
- ActorSystem() - Constructor for class akka.actor.ActorSystem
-
- ActorSystem<T> - Class in akka.typed
-
An ActorSystem is home to a hierarchy of Actors.
- ActorSystem(String) - Constructor for class akka.typed.ActorSystem
-
- ActorSystem$ - Class in akka.actor
-
- ActorSystem$() - Constructor for class akka.actor.ActorSystem$
-
- ActorSystem$ - Class in akka.typed
-
- ActorSystem$() - Constructor for class akka.typed.ActorSystem$
-
- ActorSystem.Settings - Class in akka.actor
-
Settings are the overall ActorSystem Settings which also provides a convenient access to the Config object.
- ActorSystemActivator - Class in akka.osgi
-
Abstract bundle activator implementation to bootstrap and configure an actor system in an
OSGi environment.
- ActorSystemActivator() - Constructor for class akka.osgi.ActorSystemActivator
-
- actorSystemConfig(BundleContext) - Method in class akka.osgi.OsgiActorSystemFactory
-
Strategy method to create the Config for the ActorSystem
ensuring that the default/reference configuration is loaded from the akka-actor bundle.
- ActorSystemImpl - Class in akka.actor
-
- ActorSystemImpl(String, Config, ClassLoader, Option<ExecutionContext>, Option<Props>) - Constructor for class akka.actor.ActorSystemImpl
-
- ActorSystemImpl.TerminationCallbacks<T> - Class in akka.actor
-
- actorSystemName(Option<String>) - Method in class akka.osgi.OsgiActorSystemFactory
-
Determine the name for the
ActorSystem
Returns a default value of
bundle-<bundle id>-ActorSystem
is no name is being specified
- ActorSystemOps(ActorSystem) - Constructor for class akka.typed.Ops.ActorSystemOps
-
- ActorSystemOps$() - Constructor for class akka.typed.Ops.ActorSystemOps$
-
- ActorTransportAdapter - Class in akka.remote.transport
-
- ActorTransportAdapter(Transport, ActorSystem) - Constructor for class akka.remote.transport.ActorTransportAdapter
-
- ActorTransportAdapter$ - Class in akka.remote.transport
-
- ActorTransportAdapter$() - Constructor for class akka.remote.transport.ActorTransportAdapter$
-
- ActorTransportAdapter.AssociateUnderlying - Class in akka.remote.transport
-
- ActorTransportAdapter.AssociateUnderlying$ - Class in akka.remote.transport
-
- ActorTransportAdapter.DisassociateUnderlying - Class in akka.remote.transport
-
- ActorTransportAdapter.DisassociateUnderlying$ - Class in akka.remote.transport
-
- ActorTransportAdapter.ListenerRegistered - Class in akka.remote.transport
-
- ActorTransportAdapter.ListenerRegistered$ - Class in akka.remote.transport
-
- ActorTransportAdapter.ListenUnderlying - Class in akka.remote.transport
-
- ActorTransportAdapter.ListenUnderlying$ - Class in akka.remote.transport
-
- ActorTransportAdapter.TransportOperation - Interface in akka.remote.transport
-
- ActorTransportAdapterManager - Class in akka.remote.transport
-
- ActorTransportAdapterManager() - Constructor for class akka.remote.transport.ActorTransportAdapterManager
-
- actorVar() - Method in class akka.actor.TypedActor.TypedActorInvocationHandler
-
- Adapters() - Method in class akka.remote.RemoteSettings
-
- adaptiveBackoffNanos() - Method in class akka.remote.EndpointWriter
-
- AdaptiveLoadBalancingGroup - Class in akka.cluster.metrics
-
A router group that performs load balancing of messages to cluster nodes based on
cluster metric data.
- AdaptiveLoadBalancingGroup(MetricsSelector, Iterable<String>, String) - Constructor for class akka.cluster.metrics.AdaptiveLoadBalancingGroup
-
- AdaptiveLoadBalancingGroup(Config, DynamicAccess) - Constructor for class akka.cluster.metrics.AdaptiveLoadBalancingGroup
-
- AdaptiveLoadBalancingGroup(MetricsSelector, Iterable<String>) - Constructor for class akka.cluster.metrics.AdaptiveLoadBalancingGroup
-
Java API
- AdaptiveLoadBalancingGroup - Class in akka.cluster.routing
-
A router group that performs load balancing of messages to cluster nodes based on
cluster metric data.
- AdaptiveLoadBalancingGroup(MetricsSelector, Iterable<String>, String) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingGroup
-
- AdaptiveLoadBalancingGroup(Config, DynamicAccess) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingGroup
-
- AdaptiveLoadBalancingGroup(MetricsSelector, Iterable<String>) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingGroup
-
Java API
- AdaptiveLoadBalancingGroup$ - Class in akka.cluster.metrics
-
- AdaptiveLoadBalancingGroup$() - Constructor for class akka.cluster.metrics.AdaptiveLoadBalancingGroup$
-
- AdaptiveLoadBalancingGroup$ - Class in akka.cluster.routing
-
- AdaptiveLoadBalancingGroup$() - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingGroup$
-
- AdaptiveLoadBalancingMetricsListener - Class in akka.cluster.metrics
-
INTERNAL API
Subscribe to
ClusterMetricsEvent
s and update routing logic depending on the events.
- AdaptiveLoadBalancingMetricsListener(AdaptiveLoadBalancingRoutingLogic) - Constructor for class akka.cluster.metrics.AdaptiveLoadBalancingMetricsListener
-
- AdaptiveLoadBalancingMetricsListener - Class in akka.cluster.routing
-
INTERNAL API
subscribe to ClusterMetricsChanged and update routing logic
- AdaptiveLoadBalancingMetricsListener(AdaptiveLoadBalancingRoutingLogic) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingMetricsListener
-
- AdaptiveLoadBalancingPool - Class in akka.cluster.metrics
-
A router pool that performs load balancing of messages to cluster nodes based on
cluster metric data.
- AdaptiveLoadBalancingPool(MetricsSelector, int, SupervisorStrategy, String, boolean) - Constructor for class akka.cluster.metrics.AdaptiveLoadBalancingPool
-
- AdaptiveLoadBalancingPool(Config, DynamicAccess) - Constructor for class akka.cluster.metrics.AdaptiveLoadBalancingPool
-
- AdaptiveLoadBalancingPool(MetricsSelector, int) - Constructor for class akka.cluster.metrics.AdaptiveLoadBalancingPool
-
Java API
- AdaptiveLoadBalancingPool - Class in akka.cluster.routing
-
A router pool that performs load balancing of messages to cluster nodes based on
cluster metric data.
- AdaptiveLoadBalancingPool(MetricsSelector, int, SupervisorStrategy, String, boolean) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingPool
-
- AdaptiveLoadBalancingPool(Config, DynamicAccess) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingPool
-
- AdaptiveLoadBalancingPool(MetricsSelector, int) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingPool
-
Java API
- AdaptiveLoadBalancingPool$ - Class in akka.cluster.metrics
-
- AdaptiveLoadBalancingPool$() - Constructor for class akka.cluster.metrics.AdaptiveLoadBalancingPool$
-
- AdaptiveLoadBalancingPool$ - Class in akka.cluster.routing
-
- AdaptiveLoadBalancingPool$() - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingPool$
-
- AdaptiveLoadBalancingRoutingLogic - Class in akka.cluster.metrics
-
Load balancing of messages to cluster nodes based on cluster metric data.
- AdaptiveLoadBalancingRoutingLogic(ActorSystem, MetricsSelector) - Constructor for class akka.cluster.metrics.AdaptiveLoadBalancingRoutingLogic
-
- AdaptiveLoadBalancingRoutingLogic - Class in akka.cluster.routing
-
Load balancing of messages to cluster nodes based on cluster metric data.
- AdaptiveLoadBalancingRoutingLogic(ActorSystem, MetricsSelector) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingRoutingLogic
-
- AdaptiveLoadBalancingRoutingLogic$ - Class in akka.cluster.metrics
-
- AdaptiveLoadBalancingRoutingLogic$() - Constructor for class akka.cluster.metrics.AdaptiveLoadBalancingRoutingLogic$
-
- AdaptiveLoadBalancingRoutingLogic$ - Class in akka.cluster.routing
-
- AdaptiveLoadBalancingRoutingLogic$() - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingRoutingLogic$
-
- add(Runnable) - Method in class akka.actor.ActorSystemImpl.TerminationCallbacks
-
Adds a Runnable that will be executed on ActorSystem termination.
- add(String, ChildRestartStats) - Method in interface akka.actor.dungeon.ChildrenContainer
-
- add(String, ChildRestartStats) - Method in interface akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer
-
- add(String, ChildRestartStats) - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
-
- add(String, ChildRestartStats) - Method in class akka.actor.dungeon.ChildrenContainer.TerminatedChildrenContainer$
-
- add(String, ChildRestartStats) - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
-
- add(Member) - Method in class akka.cluster.singleton.ClusterSingletonProxy
-
Adds new member if it has the right role.
- add(T, boolean) - Method in class akka.contrib.pattern.WorkList
-
Appends an entry to the work list.
- add(T) - Method in class akka.dispatch.AbstractBoundedNodeQueue
-
- add(T) - Method in class akka.dispatch.AbstractNodeQueue
-
- add(ActorRef, ActorRef) - Method in class akka.event.ManagedActorClassification.ManagedActorClassificationMappings
-
- add(PersistentRepr) - Method in interface akka.persistence.journal.inmem.InmemMessages
-
- add(T) - Method in class akka.routing.ConsistentHash
-
Java API: Adds a node to the node ring.
- addAll(WorkList<T>) - Method in class akka.contrib.pattern.WorkList
-
Appends another WorkList to this WorkList.
- addAllAddresses(ClusterMetricsMessages.Address) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- addAllAddresses(int, ClusterMetricsMessages.Address) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- addAllAddresses(ClusterMetricsMessages.Address.Builder) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- addAllAddresses(int, ClusterMetricsMessages.Address.Builder) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- addAllAddresses(ClusterMessages.UniqueAddress) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .UniqueAddress allAddresses = 1;
- addAllAddresses(int, ClusterMessages.UniqueAddress) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .UniqueAddress allAddresses = 1;
- addAllAddresses(ClusterMessages.UniqueAddress.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .UniqueAddress allAddresses = 1;
- addAllAddresses(int, ClusterMessages.UniqueAddress.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .UniqueAddress allAddresses = 1;
- addAllAddresses(ClusterMessages.Address) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- addAllAddresses(int, ClusterMessages.Address) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- addAllAddresses(ClusterMessages.Address.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- addAllAddresses(int, ClusterMessages.Address.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- addAllAddressesBuilder() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- addAllAddressesBuilder(int) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- addAllAddressesBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .UniqueAddress allAddresses = 1;
- addAllAddressesBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .UniqueAddress allAddresses = 1;
- addAllAddressesBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- addAllAddressesBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- addAllAllAddresses(Iterable<? extends ClusterMetricsMessages.Address>) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- addAllAllAddresses(Iterable<? extends ClusterMessages.UniqueAddress>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .UniqueAddress allAddresses = 1;
- addAllAllAddresses(Iterable<? extends ClusterMessages.Address>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- addAllAllHashes(Iterable<String>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated string allHashes = 3;
- addAllAllHashes(Iterable<String>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
repeated string allHashes = 2;
- addAllAllMetricNames(Iterable<String>) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated string allMetricNames = 2;
- addAllAllMetricNames(Iterable<String>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated string allMetricNames = 2;
- addAllAllRoles(Iterable<String>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated string allRoles = 2;
- addAllArgs(Iterable<? extends ByteString>) - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated bytes args = 4;
- addAllBuckets(Iterable<? extends DistributedPubSubMessages.Delta.Bucket>) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Builder
-
repeated .Delta.Bucket buckets = 1;
- addAllClasses(Iterable<String>) - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated string classes = 5;
- addAllContent(Iterable<? extends DistributedPubSubMessages.Delta.Entry>) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
repeated .Delta.Entry content = 3;
- addAllHashes(String) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated string allHashes = 3;
- addAllHashes(String) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
repeated string allHashes = 2;
- addAllHashesBytes(ByteString) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated string allHashes = 3;
- addAllHashesBytes(ByteString) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
repeated string allHashes = 2;
- addAllMembers(Iterable<? extends ClusterMessages.Member>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .Member members = 4;
- addAllMetricNames(String) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated string allMetricNames = 2;
- addAllMetricNames(String) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated string allMetricNames = 2;
- addAllMetricNamesBytes(ByteString) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated string allMetricNames = 2;
- addAllMetricNamesBytes(ByteString) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated string allMetricNames = 2;
- addAllMetrics(Iterable<? extends ClusterMetricsMessages.NodeMetrics.Metric>) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- addAllMetrics(Iterable<? extends ClusterMessages.NodeMetrics.Metric>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- addAllNacks(Iterable<? extends Long>) - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
-
repeated fixed64 nacks = 2;
- addAllNodeMetrics(Iterable<? extends ClusterMetricsMessages.NodeMetrics>) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- addAllNodeMetrics(Iterable<? extends ClusterMessages.NodeMetrics>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- addAllObserverReachability(Iterable<? extends ClusterMessages.ObserverReachability>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated .ObserverReachability observerReachability = 2;
- addAllPattern(Iterable<? extends ContainerFormats.Selection>) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
repeated .Selection pattern = 3;
- addAllRoles(String) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated string allRoles = 2;
- addAllRoles(Iterable<String>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
-
repeated string roles = 2;
- addAllRolesBytes(ByteString) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated string allRoles = 2;
- addAllRolesIndexes(Iterable<? extends Integer>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
repeated int32 rolesIndexes = 4 [packed = true];
- addAllSeen(Iterable<? extends Integer>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated int32 seen = 1;
- addAllSubjectReachability(Iterable<? extends ClusterMessages.SubjectReachability>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
repeated .SubjectReachability subjectReachability = 2;
- addAllUnconfirmedDeliveries(Iterable<? extends MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery>) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- addAllVersions(Iterable<? extends ClusterMessages.VectorClock.Version>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
repeated .VectorClock.Version versions = 2;
- addAllVersions(Iterable<? extends DistributedPubSubMessages.Status.Version>) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
repeated .Status.Version versions = 1;
- addArgs(ByteString) - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated bytes args = 4;
- addBuckets(DistributedPubSubMessages.Delta.Bucket) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Builder
-
repeated .Delta.Bucket buckets = 1;
- addBuckets(int, DistributedPubSubMessages.Delta.Bucket) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Builder
-
repeated .Delta.Bucket buckets = 1;
- addBuckets(DistributedPubSubMessages.Delta.Bucket.Builder) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Builder
-
repeated .Delta.Bucket buckets = 1;
- addBuckets(int, DistributedPubSubMessages.Delta.Bucket.Builder) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Builder
-
repeated .Delta.Bucket buckets = 1;
- addBucketsBuilder() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Builder
-
repeated .Delta.Bucket buckets = 1;
- addBucketsBuilder(int) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Builder
-
repeated .Delta.Bucket buckets = 1;
- addBuffer() - Method in interface akka.contrib.pattern.Aggregator
-
- addChild(String, InternalActorRef) - Method in class akka.actor.VirtualPathContainer
-
- addClasses(String) - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated string classes = 5;
- addClassesBytes(ByteString) - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated string classes = 5;
- addContent(DistributedPubSubMessages.Delta.Entry) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
repeated .Delta.Entry content = 3;
- addContent(int, DistributedPubSubMessages.Delta.Entry) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
repeated .Delta.Entry content = 3;
- addContent(DistributedPubSubMessages.Delta.Entry.Builder) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
repeated .Delta.Entry content = 3;
- addContent(int, DistributedPubSubMessages.Delta.Entry.Builder) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
repeated .Delta.Entry content = 3;
- addContentBuilder() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
repeated .Delta.Entry content = 3;
- addContentBuilder(int) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
repeated .Delta.Entry content = 3;
- addedSchemeIdentifier() - Method in class akka.remote.transport.AbstractTransportAdapterHandle
-
- addedSchemeIdentifier() - Method in class akka.remote.transport.AkkaProtocolTransport
-
- addedSchemeIdentifier() - Method in class akka.remote.transport.FailureInjectorTransportAdapter
-
- addedSchemeIdentifier() - Method in interface akka.remote.transport.SchemeAugmenter
-
- addedSchemeIdentifier() - Method in class akka.remote.transport.ThrottlerTransportAdapter
-
- addFilter(EventFilter) - Method in class akka.testkit.TestEventListener
-
- addKey(K) - Method in class akka.util.SubclassifiedIndex
-
Add key to this index which inherits its value set from the most specific
super-class which is known.
- addLogger(ActorSystemImpl, Class<? extends Actor>, Logging.LogLevel, String) - Method in interface akka.event.LoggingBus
-
INTERNAL API
- AddLoggingReceive() - Method in class akka.actor.ActorSystem.Settings
-
- addLogServiceListener(BundleContext, ActorSystem) - Method in class akka.osgi.ActorSystemActivator
-
Adds a LogService Listener that will advertise the ActorSystem on LogService registration and unregistration
- addMember(Member) - Method in class akka.cluster.ClusterHeartbeatSender
-
- addMember(UniqueAddress) - Method in class akka.cluster.ClusterHeartbeatSenderState
-
- addMember(Member) - Method in class akka.cluster.ClusterMetricsCollector
-
Adds a member to the node ring.
- addMember(Member) - Method in class akka.cluster.metrics.ClusterMetricsCollector
-
Adds a member to the node ring.
- addMember(Member) - Method in interface akka.cluster.routing.ClusterRouterActor
-
- addMembers(ClusterMessages.Member) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .Member members = 4;
- addMembers(int, ClusterMessages.Member) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .Member members = 4;
- addMembers(ClusterMessages.Member.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .Member members = 4;
- addMembers(int, ClusterMessages.Member.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .Member members = 4;
- addMembersBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .Member members = 4;
- addMembersBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .Member members = 4;
- addMetrics(ClusterMetricsMessages.NodeMetrics.Metric) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- addMetrics(int, ClusterMetricsMessages.NodeMetrics.Metric) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- addMetrics(ClusterMetricsMessages.NodeMetrics.Metric.Builder) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- addMetrics(int, ClusterMetricsMessages.NodeMetrics.Metric.Builder) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- addMetrics(ClusterMessages.NodeMetrics.Metric) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- addMetrics(int, ClusterMessages.NodeMetrics.Metric) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- addMetrics(ClusterMessages.NodeMetrics.Metric.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- addMetrics(int, ClusterMessages.NodeMetrics.Metric.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- addMetricsBuilder() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- addMetricsBuilder(int) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- addMetricsBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- addMetricsBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- addNacks(long) - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
-
repeated fixed64 nacks = 2;
- addNode(AbstractBoundedNodeQueue.Node<T>) - Method in class akka.dispatch.AbstractBoundedNodeQueue
-
- addNode(AbstractNodeQueue.Node<T>) - Method in class akka.dispatch.AbstractNodeQueue
-
- addNodeMetrics(ClusterMetricsMessages.NodeMetrics) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- addNodeMetrics(int, ClusterMetricsMessages.NodeMetrics) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- addNodeMetrics(ClusterMetricsMessages.NodeMetrics.Builder) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- addNodeMetrics(int, ClusterMetricsMessages.NodeMetrics.Builder) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- addNodeMetrics(ClusterMessages.NodeMetrics) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- addNodeMetrics(int, ClusterMessages.NodeMetrics) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- addNodeMetrics(ClusterMessages.NodeMetrics.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- addNodeMetrics(int, ClusterMessages.NodeMetrics.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- addNodeMetricsBuilder() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- addNodeMetricsBuilder(int) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- addNodeMetricsBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- addNodeMetricsBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- addObserverReachability(ClusterMessages.ObserverReachability) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated .ObserverReachability observerReachability = 2;
- addObserverReachability(int, ClusterMessages.ObserverReachability) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated .ObserverReachability observerReachability = 2;
- addObserverReachability(ClusterMessages.ObserverReachability.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated .ObserverReachability observerReachability = 2;
- addObserverReachability(int, ClusterMessages.ObserverReachability.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated .ObserverReachability observerReachability = 2;
- addObserverReachabilityBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated .ObserverReachability observerReachability = 2;
- addObserverReachabilityBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated .ObserverReachability observerReachability = 2;
- AddOnMemberRemovedListener(Runnable) - Constructor for class akka.cluster.InternalClusterAction.AddOnMemberRemovedListener
-
- AddOnMemberRemovedListener$() - Constructor for class akka.cluster.InternalClusterAction.AddOnMemberRemovedListener$
-
- AddOnMemberUpListener(Runnable) - Constructor for class akka.cluster.InternalClusterAction.AddOnMemberUpListener
-
- AddOnMemberUpListener$() - Constructor for class akka.cluster.InternalClusterAction.AddOnMemberUpListener$
-
- addPattern(ContainerFormats.Selection) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
repeated .Selection pattern = 3;
- addPattern(int, ContainerFormats.Selection) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
repeated .Selection pattern = 3;
- addPattern(ContainerFormats.Selection.Builder) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
repeated .Selection pattern = 3;
- addPattern(int, ContainerFormats.Selection.Builder) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
repeated .Selection pattern = 3;
- addPatternBuilder() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
repeated .Selection pattern = 3;
- addPatternBuilder(int) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
repeated .Selection pattern = 3;
- addr() - Method in class akka.io.Dns.Resolved
-
- addr() - Method in class akka.remote.testconductor.AddressReply
-
- addr() - Method in class akka.remote.testconductor.Controller.NodeInfo
-
- addr() - Method in class akka.remote.testconductor.Hello
-
- ADDR_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
-
- ADDR_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Wrapper
-
- addRemoved(Address) - Method in class akka.cluster.singleton.ClusterSingletonManager
-
- address() - Method in class akka.actor.ActorPath
-
The Address under which this path can be reached; walks up the tree to
the RootActorPath.
- Address - Class in akka.actor
-
The address specifies the physical location under which an Actor can be
reached.
- Address(String, String) - Constructor for class akka.actor.Address
-
- Address(String, String, String, int) - Constructor for class akka.actor.Address
-
- address() - Method in class akka.actor.AddressTerminated
-
- address() - Method in class akka.actor.ChildActorPath
-
- address() - Method in class akka.actor.RootActorPath
-
- address() - Method in class akka.cluster.ClusterUserAction.Down
-
- address() - Method in class akka.cluster.ClusterUserAction.JoinTo
-
- address() - Method in class akka.cluster.ClusterUserAction.Leave
-
- address() - Method in class akka.cluster.InternalClusterAction.InitJoinAck
-
- address() - Method in class akka.cluster.InternalClusterAction.InitJoinNack
-
- address() - Method in class akka.cluster.InternalClusterAction.SendGossipTo
-
- address() - Method in class akka.cluster.Member
-
INTERNAL API
- address() - Method in class akka.cluster.metrics.NodeMetrics
-
- address() - Method in class akka.cluster.metrics.StandardMetrics.Cpu
-
- address() - Method in class akka.cluster.metrics.StandardMetrics.HeapMemory
-
- address() - Method in class akka.cluster.NodeMetrics
-
- address() - Method in class akka.cluster.StandardMetrics.Cpu
-
- address() - Method in class akka.cluster.StandardMetrics.HeapMemory
-
- address() - Method in class akka.cluster.UniqueAddress
-
- address() - Method in class akka.remote.QuarantinedEvent
-
- address() - Method in class akka.remote.testconductor.TestConductorExt
-
Transport address of this Netty-like remote transport.
- address() - Method in class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociate
-
- address() - Method in class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociateExplicitly
-
- address() - Method in class akka.remote.transport.ThrottlerTransportAdapter.SetThrottle
-
- address() - Method in class akka.serialization.Serialization.Information
-
- address() - Method in class akka.typed.patterns.Receptionist.Register
-
- address() - Method in class akka.typed.patterns.Receptionist.Registered
-
- Address$ - Class in akka.actor
-
- Address$() - Constructor for class akka.actor.Address$
-
- address2proto(Address) - Method in class akka.remote.testconductor.MsgEncoder
-
- address2scala(TestConductorProtocol.Address) - Method in class akka.remote.testconductor.MsgDecoder
-
- ADDRESS_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
-
- ADDRESS_FIELD_NUMBER - Static variable in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version
-
- ADDRESS_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Hello
-
- ADDRESS_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
-
- addressChaosTable() - Method in class akka.remote.transport.FailureInjectorTransportAdapter
-
- addresses() - Method in class akka.remote.RemoteTransport
-
Address to be used in RootActorPath of refs generated for this transport.
- addresses() - Method in class akka.remote.Remoting
-
- addresses() - Method in class akka.typed.patterns.Receptionist.Listing
-
- addressesPromise() - Method in class akka.remote.EndpointManager.Listen
-
- addressesPromise() - Method in class akka.remote.EndpointManager.ListensFailure
-
- addressesPromise() - Method in class akka.remote.EndpointManager.ListensResult
-
- addressFromSocketAddress(SocketAddress, String, String, Option<String>, Option<Object>) - Method in class akka.remote.transport.netty.NettyTransport$
-
- addressFromSocketAddress(SocketAddress, String, String, Option<String>) - Method in class akka.remote.transport.netty.NettyTransport$
-
- addressFromSocketAddress(SocketAddress, String, String, Option<String>, Option<Object>) - Static method in class akka.remote.transport.netty.NettyTransport
-
- addressFromSocketAddress(SocketAddress, String, String, Option<String>) - Static method in class akka.remote.transport.netty.NettyTransport
-
- AddressFromURIString - Class in akka.actor
-
This object serves as extractor for Scala and as address parser for Java.
- AddressFromURIString() - Constructor for class akka.actor.AddressFromURIString
-
- AddressFromURIString$ - Class in akka.actor
-
This object serves as extractor for Scala and as address parser for Java.
- AddressFromURIString$() - Constructor for class akka.actor.AddressFromURIString$
-
- ADDRESSINDEX_FIELD_NUMBER - Static variable in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics
-
- ADDRESSINDEX_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Member
-
- ADDRESSINDEX_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
-
- ADDRESSINDEX_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
-
- ADDRESSINDEX_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
-
- addressOrdering() - Method in class akka.cluster.Member$
-
Address
ordering type class, sorts addresses by host and port.
- addressOrdering() - Static method in class akka.cluster.Member
-
Address
ordering type class, sorts addresses by host and port.
- AddressReply - Class in akka.remote.testconductor
-
- AddressReply(RoleName, Address) - Constructor for class akka.remote.testconductor.AddressReply
-
- AddressReply$ - Class in akka.remote.testconductor
-
- AddressReply$() - Constructor for class akka.remote.testconductor.AddressReply$
-
- AddressTerminated - Class in akka.actor
-
INTERNAL API
- AddressTerminated(Address) - Constructor for class akka.actor.AddressTerminated
-
- addressTerminated(Address) - Method in interface akka.actor.dungeon.DeathWatch
-
- addressTerminated() - Method in class akka.actor.Terminated
-
- addressTerminated() - Method in class akka.dispatch.sysmsg.DeathWatchNotification
-
- AddressTerminated$ - Class in akka.actor
-
- AddressTerminated$() - Constructor for class akka.actor.AddressTerminated$
-
- AddressTerminatedTopic - Class in akka.event
-
INTERNAL API
- AddressTerminatedTopic() - Constructor for class akka.event.AddressTerminatedTopic
-
- AddressTerminatedTopic$ - Class in akka.event
-
INTERNAL API
- AddressTerminatedTopic$() - Constructor for class akka.event.AddressTerminatedTopic$
-
- addressToSocketAddress(Address) - Method in class akka.remote.transport.netty.NettyTransport
-
- addressUid() - Method in class akka.remote.AddressUidExtension
-
- addressUid() - Method in class akka.remote.RemoteWatcher.HeartbeatRsp
-
- AddressUidExtension - Class in akka.remote
-
- AddressUidExtension(ExtendedActorSystem) - Constructor for class akka.remote.AddressUidExtension
-
- AddressUidExtension$ - Class in akka.remote
-
Extension that holds a uid that is assigned as a random Int
.
- AddressUidExtension$() - Constructor for class akka.remote.AddressUidExtension$
-
- addressUids() - Method in class akka.remote.RemoteWatcher
-
- AddressUrlEncoder - Class in akka.remote
-
INTERNAL API
- AddressUrlEncoder() - Constructor for class akka.remote.AddressUrlEncoder
-
- AddressUrlEncoder$ - Class in akka.remote
-
INTERNAL API
- AddressUrlEncoder$() - Constructor for class akka.remote.AddressUrlEncoder$
-
- addrInterest() - Method in class akka.remote.testconductor.Controller
-
- addRoles(String) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
-
repeated string roles = 2;
- addRolesBytes(ByteString) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
-
repeated string roles = 2;
- addRolesIndexes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
repeated int32 rolesIndexes = 4 [packed = true];
- addrOption() - Method in class akka.io.Dns.Resolved
-
- AddRoutee - Class in akka.routing
-
Add a routee by sending this message to the router.
- AddRoutee(Routee) - Constructor for class akka.routing.AddRoutee
-
- addRoutee(Routee) - Method in class akka.routing.RoutedActorCell
-
- addRoutee(Routee) - Method in class akka.routing.Router
-
Create a new instance with one more routee and the same
RoutingLogic
.
- addRoutee(ActorRef) - Method in class akka.routing.Router
-
- addRoutee(ActorSelection) - Method in class akka.routing.Router
-
- AddRoutee$ - Class in akka.routing
-
- AddRoutee$() - Constructor for class akka.routing.AddRoutee$
-
- addRoutees() - Method in interface akka.cluster.routing.ClusterRouterActor
-
Adds routees based on settings
- addRoutees() - Method in class akka.cluster.routing.ClusterRouterGroupActor
-
Adds routees based on totalInstances and maxInstancesPerNode settings
- addRoutees() - Method in class akka.cluster.routing.ClusterRouterPoolActor
-
Adds routees based on totalInstances and maxInstancesPerNode settings
- addRoutees(Iterable<Routee>) - Method in class akka.routing.RoutedActorCell
-
Add routees to the Router
.
- addSeen(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated int32 seen = 1;
- addSelf(String) - Method in interface akka.contrib.pattern.ReliableProxyDebugLogging
-
- addSubjectReachability(ClusterMessages.SubjectReachability) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
repeated .SubjectReachability subjectReachability = 2;
- addSubjectReachability(int, ClusterMessages.SubjectReachability) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
repeated .SubjectReachability subjectReachability = 2;
- addSubjectReachability(ClusterMessages.SubjectReachability.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
repeated .SubjectReachability subjectReachability = 2;
- addSubjectReachability(int, ClusterMessages.SubjectReachability.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
repeated .SubjectReachability subjectReachability = 2;
- addSubjectReachabilityBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
repeated .SubjectReachability subjectReachability = 2;
- addSubjectReachabilityBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
repeated .SubjectReachability subjectReachability = 2;
- addToCache(Seq<Tuple2<Object, Set<Object>>>) - Method in interface akka.event.SubchannelClassification
-
- addToMessageBatch(PersistentRepr, WriteBatch) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
-
- addUnconfirmedDeliveries(MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- addUnconfirmedDeliveries(int, MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- addUnconfirmedDeliveries(MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- addUnconfirmedDeliveries(int, MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- addUnconfirmedDeliveriesBuilder() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- addUnconfirmedDeliveriesBuilder(int) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- addValue(K, V) - Method in class akka.util.SubclassifiedIndex
-
Add value to all keys which are subclasses of the given key.
- addVersions(ClusterMessages.VectorClock.Version) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
repeated .VectorClock.Version versions = 2;
- addVersions(int, ClusterMessages.VectorClock.Version) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
repeated .VectorClock.Version versions = 2;
- addVersions(ClusterMessages.VectorClock.Version.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
repeated .VectorClock.Version versions = 2;
- addVersions(int, ClusterMessages.VectorClock.Version.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
repeated .VectorClock.Version versions = 2;
- addVersions(DistributedPubSubMessages.Status.Version) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
repeated .Status.Version versions = 1;
- addVersions(int, DistributedPubSubMessages.Status.Version) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
repeated .Status.Version versions = 1;
- addVersions(DistributedPubSubMessages.Status.Version.Builder) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
repeated .Status.Version versions = 1;
- addVersions(int, DistributedPubSubMessages.Status.Version.Builder) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
repeated .Status.Version versions = 1;
- addVersionsBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
repeated .VectorClock.Version versions = 2;
- addVersionsBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
repeated .VectorClock.Version versions = 2;
- addVersionsBuilder() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
repeated .Status.Version versions = 1;
- addVersionsBuilder(int) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
repeated .Status.Version versions = 1;
- AddWatch(ActorRef) - Constructor for class akka.camel.internal.CamelSupervisor.AddWatch
-
- addWatch(InternalActorRef, InternalActorRef) - Method in class akka.remote.RemoteWatcher
-
- AddWatch$() - Constructor for class akka.camel.internal.CamelSupervisor.AddWatch$
-
- addWatcher(ActorRef, ActorRef) - Method in interface akka.actor.dungeon.DeathWatch
-
- adjustAdaptiveBackup() - Method in class akka.remote.EndpointWriter
-
- adjustedGossipDifferentViewProbability() - Method in class akka.cluster.ClusterCoreDaemon
-
For large clusters we should avoid shooting down individual
nodes.
- AdjustPoolSize - Class in akka.routing
-
Increase or decrease the number of routees in a
Pool
.
- AdjustPoolSize(int) - Constructor for class akka.routing.AdjustPoolSize
-
- AdjustPoolSize$ - Class in akka.routing
-
- AdjustPoolSize$() - Constructor for class akka.routing.AdjustPoolSize$
-
- advance() - Method in interface akka.actor.LoggingFSM
-
- AES128CounterInetRNG - Class in akka.remote.security.provider
-
INTERNAL API
This class is a wrapper around the 128-bit AESCounterRNG algorithm provided by http://maths.uncommons.org/
It uses the default seed generator which uses one of the following 3 random seed sources:
Depending on availability: random.org, /dev/random, and SecureRandom (provided by Java)
The only method used by netty ssl is engineNextBytes(bytes)
- AES128CounterInetRNG() - Constructor for class akka.remote.security.provider.AES128CounterInetRNG
-
- AES128CounterSecureRNG - Class in akka.remote.security.provider
-
INTERNAL API
This class is a wrapper around the 128-bit AESCounterRNG algorithm provided by http://maths.uncommons.org/
The only method used by netty ssl is engineNextBytes(bytes)
This RNG is good to use to prevent startup delay when you don't have Internet access to random.org
- AES128CounterSecureRNG() - Constructor for class akka.remote.security.provider.AES128CounterSecureRNG
-
- AES256CounterInetRNG - Class in akka.remote.security.provider
-
INTERNAL API
This class is a wrapper around the 256-bit AESCounterRNG algorithm provided by http://maths.uncommons.org/
It uses the default seed generator which uses one of the following 3 random seed sources:
Depending on availability: random.org, /dev/random, and SecureRandom (provided by Java)
The only method used by netty ssl is engineNextBytes(bytes)
- AES256CounterInetRNG() - Constructor for class akka.remote.security.provider.AES256CounterInetRNG
-
- AES256CounterSecureRNG - Class in akka.remote.security.provider
-
INTERNAL API
This class is a wrapper around the 256-bit AESCounterRNG algorithm provided by http://maths.uncommons.org/
The only method used by netty ssl is engineNextBytes(bytes)
This RNG is good to use to prevent startup delay when you don't have Internet access to random.org
- AES256CounterSecureRNG() - Constructor for class akka.remote.security.provider.AES256CounterSecureRNG
-
- after(FiniteDuration, Scheduler, Function0<Future<T>>, ExecutionContext) - Method in interface akka.pattern.FutureTimeoutSupport
-
Returns a Future
that will be completed with the success or failure of the provided value
after the specified duration.
- after(FiniteDuration, Scheduler, ExecutionContext, Callable<Future<T>>) - Method in class akka.pattern.Patterns$
-
Returns a Future
that will be completed with the success or failure of the provided Callable
after the specified duration.
- after(FiniteDuration, Scheduler, ExecutionContext, Future<T>) - Method in class akka.pattern.Patterns$
-
Returns a Future
that will be completed with the success or failure of the provided value
after the specified duration.
- after(FiniteDuration, Scheduler, ExecutionContext, Callable<Future<T>>) - Static method in class akka.pattern.Patterns
-
Returns a Future
that will be completed with the success or failure of the provided Callable
after the specified duration.
- after(FiniteDuration, Scheduler, ExecutionContext, Future<T>) - Static method in class akka.pattern.Patterns
-
Returns a Future
that will be completed with the success or failure of the provided value
after the specified duration.
- After$() - Constructor for class akka.cluster.VectorClock.After$
-
- afterAll() - Method in class akka.persistence.PluginSpec
-
- afterBind(DatagramSocket) - Method in interface akka.io.Inet.SocketOptionV2
-
Action to be taken for this option after connect returned (i.e.
- afterBind(ServerSocket) - Method in interface akka.io.Inet.SocketOptionV2
-
Action to be taken for this option after connect returned (i.e.
- afterConnect(Socket) - Method in class akka.io.Inet.SO$.SendBufferSize
-
- afterConnect(Socket) - Method in class akka.io.Inet.SO$.TrafficClass
-
- afterConnect(Socket) - Method in interface akka.io.Inet.SocketOption
-
Action to be taken for this option after connect returned (i.e.
- afterConnect(DatagramSocket) - Method in interface akka.io.Inet.SocketOptionV2
-
Action to be taken for this option after connect returned (i.e.
- afterConnect(Socket) - Method in class akka.io.Tcp.SO$.KeepAlive
-
- afterConnect(Socket) - Method in class akka.io.Tcp.SO$.OOBInline
-
- afterConnect(Socket) - Method in class akka.io.Tcp.SO$.TcpNoDelay
-
- afterTermination() - Method in class akka.remote.testkit.MultiNodeSpec
-
Override this method to do something when the whole test is terminating.
- Agent<T> - Class in akka.agent
-
The Agent class was inspired by agents in Clojure.
- Agent() - Constructor for class akka.agent.Agent
-
- Agent$ - Class in akka.agent
-
- Agent$() - Constructor for class akka.agent.Agent$
-
- ageOrdering() - Method in class akka.cluster.sharding.ShardRegion
-
- ageOrdering() - Method in class akka.cluster.singleton.ClusterSingletonProxy
-
- Aggregator - Interface in akka.contrib.pattern
-
The aggregator is to be mixed into an actor for the aggregator behavior.
- akka - package akka
-
- akka.actor - package akka.actor
-
- akka.actor.dsl - package akka.actor.dsl
-
- akka.actor.dungeon - package akka.actor.dungeon
-
- akka.agent - package akka.agent
-
- akka.camel - package akka.camel
-
- akka.camel.internal - package akka.camel.internal
-
- akka.camel.internal.component - package akka.camel.internal.component
-
- akka.camel.javaapi - package akka.camel.javaapi
-
- akka.cluster - package akka.cluster
-
- akka.cluster.client - package akka.cluster.client
-
- akka.cluster.metrics - package akka.cluster.metrics
-
- akka.cluster.metrics.protobuf - package akka.cluster.metrics.protobuf
-
- akka.cluster.metrics.protobuf.msg - package akka.cluster.metrics.protobuf.msg
-
- akka.cluster.protobuf - package akka.cluster.protobuf
-
- akka.cluster.protobuf.msg - package akka.cluster.protobuf.msg
-
- akka.cluster.pubsub - package akka.cluster.pubsub
-
- akka.cluster.pubsub.protobuf - package akka.cluster.pubsub.protobuf
-
- akka.cluster.pubsub.protobuf.msg - package akka.cluster.pubsub.protobuf.msg
-
- akka.cluster.routing - package akka.cluster.routing
-
- akka.cluster.sharding - package akka.cluster.sharding
-
- akka.cluster.singleton - package akka.cluster.singleton
-
- akka.contrib.jul - package akka.contrib.jul
-
- akka.contrib.mailbox - package akka.contrib.mailbox
-
- akka.contrib.pattern - package akka.contrib.pattern
-
- akka.contrib.throttle - package akka.contrib.throttle
-
- akka.dispatch - package akka.dispatch
-
- akka.dispatch.sysmsg - package akka.dispatch.sysmsg
-
- akka.event - package akka.event
-
- akka.event.japi - package akka.event.japi
-
- akka.event.slf4j - package akka.event.slf4j
-
- akka.io - package akka.io
-
- akka.japi - package akka.japi
-
- akka.japi.function - package akka.japi.function
-
- akka.japi.pf - package akka.japi.pf
-
- akka.kernel - package akka.kernel
-
- akka.osgi - package akka.osgi
-
- akka.pattern - package akka.pattern
-
- akka.persistence - package akka.persistence
-
- akka.persistence.japi.journal - package akka.persistence.japi.journal
-
- akka.persistence.japi.snapshot - package akka.persistence.japi.snapshot
-
- akka.persistence.journal - package akka.persistence.journal
-
- akka.persistence.journal.inmem - package akka.persistence.journal.inmem
-
- akka.persistence.journal.japi - package akka.persistence.journal.japi
-
- akka.persistence.journal.leveldb - package akka.persistence.journal.leveldb
-
- akka.persistence.serialization - package akka.persistence.serialization
-
- akka.persistence.snapshot - package akka.persistence.snapshot
-
- akka.persistence.snapshot.japi - package akka.persistence.snapshot.japi
-
- akka.persistence.snapshot.local - package akka.persistence.snapshot.local
-
- akka.remote - package akka.remote
-
- akka.remote.routing - package akka.remote.routing
-
- akka.remote.security.provider - package akka.remote.security.provider
-
- akka.remote.serialization - package akka.remote.serialization
-
- akka.remote.testconductor - package akka.remote.testconductor
-
- akka.remote.testkit - package akka.remote.testkit
-
- akka.remote.transport - package akka.remote.transport
-
- akka.remote.transport.netty - package akka.remote.transport.netty
-
- akka.routing - package akka.routing
-
- akka.serialization - package akka.serialization
-
- akka.testkit - package akka.testkit
-
- akka.typed - package akka.typed
-
- akka.typed.patterns - package akka.typed.patterns
-
- akka.util - package akka.util
-
- akkaActorClassLoader() - Method in class akka.osgi.OsgiActorSystemFactory$
-
Class loader of akka-actor bundle.
- akkaActorClassLoader() - Static method in class akka.osgi.OsgiActorSystemFactory
-
Class loader of akka-actor bundle.
- AkkaCamelException - Exception in akka.camel
-
An exception indicating that the exchange to the camel endpoint failed.
- AkkaCamelException(Throwable, Map<String, Object>) - Constructor for exception akka.camel.AkkaCamelException
-
- AkkaCamelException(Throwable) - Constructor for exception akka.camel.AkkaCamelException
-
- AkkaException - Exception in akka
-
Akka base Exception.
- AkkaException(String, Throwable) - Constructor for exception akka.AkkaException
-
- AkkaException(String) - Constructor for exception akka.AkkaException
-
- AkkaForkJoinPool(int, ForkJoinPool.ForkJoinWorkerThreadFactory, Thread.UncaughtExceptionHandler, boolean) - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinPool
-
- AkkaForkJoinPool(int, ForkJoinPool.ForkJoinWorkerThreadFactory, Thread.UncaughtExceptionHandler) - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinPool
-
- AkkaForkJoinTask(Runnable) - Constructor for class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinTask
-
- AkkaForkJoinWorkerThread(ForkJoinPool) - Constructor for class akka.dispatch.MonitorableThreadFactory.AkkaForkJoinWorkerThread
-
- AkkaOverhead() - Method in class akka.remote.transport.AkkaProtocolTransport$
-
- AkkaOverhead() - Static method in class akka.remote.transport.AkkaProtocolTransport
-
- AkkaPduCodec - Interface in akka.remote.transport
-
INTERNAL API
- AkkaPduCodec$ - Class in akka.remote.transport
-
INTERNAL API
- AkkaPduCodec$() - Constructor for class akka.remote.transport.AkkaPduCodec$
-
- AkkaPduCodec.AkkaPdu - Interface in akka.remote.transport
-
Trait that represents decoded Akka PDUs (Protocol Data Units)
- AkkaPduCodec.Associate - Class in akka.remote.transport
-
- AkkaPduCodec.Associate$ - Class in akka.remote.transport
-
- AkkaPduCodec.Disassociate - Class in akka.remote.transport
-
- AkkaPduCodec.Disassociate$ - Class in akka.remote.transport
-
- AkkaPduCodec.Heartbeat$ - Class in akka.remote.transport
-
- AkkaPduCodec.Message - Class in akka.remote.transport
-
- AkkaPduCodec.Message$ - Class in akka.remote.transport
-
- AkkaPduCodec.Payload - Class in akka.remote.transport
-
- AkkaPduCodec.Payload$ - Class in akka.remote.transport
-
- AkkaPduProtobufCodec - Class in akka.remote.transport
-
INTERNAL API
- AkkaPduProtobufCodec() - Constructor for class akka.remote.transport.AkkaPduProtobufCodec
-
- AkkaPduProtobufCodec$ - Class in akka.remote.transport
-
INTERNAL API
- AkkaPduProtobufCodec$() - Constructor for class akka.remote.transport.AkkaPduProtobufCodec$
-
- AkkaProtocolException - Exception in akka.remote.transport
-
- AkkaProtocolException(String, Throwable) - Constructor for exception akka.remote.transport.AkkaProtocolException
-
- AkkaProtocolException(String) - Constructor for exception akka.remote.transport.AkkaProtocolException
-
- AkkaProtocolHandle - Class in akka.remote.transport
-
- AkkaProtocolHandle(Address, Address, Promise<AssociationHandle.HandleEventListener>, AssociationHandle, HandshakeInfo, ActorRef, AkkaPduCodec) - Constructor for class akka.remote.transport.AkkaProtocolHandle
-
- AkkaProtocolManager - Class in akka.remote.transport
-
- AkkaProtocolManager(Transport, AkkaProtocolSettings) - Constructor for class akka.remote.transport.AkkaProtocolManager
-
- AkkaProtocolSettings - Class in akka.remote.transport
-
- AkkaProtocolSettings(Config) - Constructor for class akka.remote.transport.AkkaProtocolSettings
-
- AkkaProtocolTransport - Class in akka.remote.transport
-
Implementation of the Akka protocol as a Transport that wraps an underlying Transport instance.
- AkkaProtocolTransport(Transport, ActorSystem, AkkaProtocolSettings, AkkaPduCodec) - Constructor for class akka.remote.transport.AkkaProtocolTransport
-
- AkkaProtocolTransport$ - Class in akka.remote.transport
-
- AkkaProtocolTransport$() - Constructor for class akka.remote.transport.AkkaProtocolTransport$
-
- AkkaProtocolTransport.AssociateUnderlyingRefuseUid - Class in akka.remote.transport
-
- AkkaProtocolTransport.AssociateUnderlyingRefuseUid$ - Class in akka.remote.transport
-
- AkkaProvider - Class in akka.remote.security.provider
-
A provider that for AES128CounterRNGFast, a cryptographically secure random number generator through SecureRandom
- AkkaProvider() - Constructor for class akka.remote.security.provider.AkkaProvider
-
- AkkaProvider$ - Class in akka.remote.security.provider
-
A provider that for AES128CounterRNGFast, a cryptographically secure random number generator through SecureRandom
- AkkaProvider$() - Constructor for class akka.remote.security.provider.AkkaProvider$
-
- AkkaScheme() - Method in class akka.remote.transport.AkkaProtocolTransport$
-
- AkkaScheme() - Static method in class akka.remote.transport.AkkaProtocolTransport
-
- All(FailureInjectorTransportAdapter.GremlinMode) - Constructor for class akka.remote.transport.FailureInjectorTransportAdapter.All
-
- All$() - Constructor for class akka.remote.transport.FailureInjectorTransportAdapter.All$
-
- ALLADDRESSES_FIELD_NUMBER - Static variable in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip
-
- ALLADDRESSES_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
- ALLADDRESSES_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
-
- allButSelf() - Method in class akka.cluster.pubsub.DistributedPubSubMediator.SendToAll
-
- ALLBUTSELF_FIELD_NUMBER - Static variable in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll
-
- AllDeadLetters - Interface in akka.actor
-
Subscribe to this class to be notified about all DeadLetters (also the supressed ones).
- allEndpoints() - Method in class akka.remote.EndpointManager.EndpointRegistry
-
- AllForOneStrategy - Class in akka.actor
-
Applies the fault handling
Directive
(Resume, Restart, Stop) specified in the
Decider
to all children when one fails, as opposed to
OneForOneStrategy
that applies
it only to the child actor that failed.
- AllForOneStrategy(int, Duration, boolean, PartialFunction<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.AllForOneStrategy
-
- AllForOneStrategy(int, Duration, Function<Throwable, SupervisorStrategy.Directive>, boolean) - Constructor for class akka.actor.AllForOneStrategy
-
Java API
- AllForOneStrategy(int, Duration, Function<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.AllForOneStrategy
-
Java API
- AllForOneStrategy(int, Duration, Iterable<Class<? extends Throwable>>) - Constructor for class akka.actor.AllForOneStrategy
-
Java API
- AllForOneStrategy(int, Duration, PartialFunction<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.AllForOneStrategy
-
Java API: compatible with lambda expressions
This is an EXPERIMENTAL feature and is subject to change until it has received more real world testing.
- AllForOneStrategy(boolean, PartialFunction<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.AllForOneStrategy
-
Java API: compatible with lambda expressions
This is an EXPERIMENTAL feature and is subject to change until it has received more real world testing.
- AllForOneStrategy(PartialFunction<Throwable, SupervisorStrategy.Directive>) - Constructor for class akka.actor.AllForOneStrategy
-
Java API: compatible with lambda expressions
This is an EXPERIMENTAL feature and is subject to change until it has received more real world testing.
- AllForOneStrategy() - Method in interface akka.actor.dsl.Creators.Act
-
- AllForOneStrategy$ - Class in akka.actor
-
- AllForOneStrategy$() - Constructor for class akka.actor.AllForOneStrategy$
-
- ALLHASHES_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
- ALLHASHES_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
-
- AllLogLevels() - Method in class akka.event.Logging$
-
- AllLogLevels() - Static method in class akka.event.Logging
-
- ALLMETRICNAMES_FIELD_NUMBER - Static variable in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip
-
- ALLMETRICNAMES_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
-
- allObservers() - Method in class akka.cluster.Reachability
-
- allocateShard(ActorRef, String, Map<ActorRef, IndexedSeq<String>>) - Method in class akka.cluster.sharding.ShardCoordinator.AbstractShardAllocationStrategy
-
- allocateShard(ActorRef, String, Map<ActorRef, IndexedSeq<String>>) - Method in class akka.cluster.sharding.ShardCoordinator.AbstractShardAllocationStrategy
-
Invoked when the location of a new shard is to be decided.
- allocateShard(ActorRef, String, Map<ActorRef, IndexedSeq<String>>) - Method in class akka.cluster.sharding.ShardCoordinator.LeastShardAllocationStrategy
-
- allocateShard(ActorRef, String, Map<ActorRef, IndexedSeq<String>>) - Method in interface akka.cluster.sharding.ShardCoordinator.ShardAllocationStrategy
-
Invoked when the location of a new shard is to be decided.
- allocateShardHomes() - Method in class akka.cluster.sharding.ShardCoordinator
-
- AllocateShardResult(String, Option<ActorRef>, ActorRef) - Constructor for class akka.cluster.sharding.ShardCoordinator.Internal$.AllocateShardResult
-
- allocationStrategy() - Method in class akka.cluster.sharding.ClusterShardingGuardian.Start
-
- allowCorePoolTimeout() - Method in class akka.dispatch.ThreadPoolConfig
-
- allowedTransitions() - Method in class akka.cluster.MemberStatus$
-
INTERNAL API
- allowedTransitions() - Static method in class akka.cluster.MemberStatus
-
INTERNAL API
- allowLocalRoutees() - Method in class akka.cluster.routing.ClusterRouterGroupSettings
-
- allowLocalRoutees() - Method in class akka.cluster.routing.ClusterRouterPoolSettings
-
- allowLocalRoutees() - Method in interface akka.cluster.routing.ClusterRouterSettingsBase
-
- AllRead$() - Constructor for class akka.io.TcpConnection.AllRead$
-
- allRoles() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
-
All node roles in the cluster
- allRoles() - Method in class akka.cluster.Gossip
-
- ALLROLES_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
- allUnreachable() - Method in class akka.cluster.Reachability
-
Doesn't include terminated
- allUnreachableFrom(UniqueAddress) - Method in class akka.cluster.Reachability
-
Doesn't include terminated
- allUnreachableOrTerminated() - Method in class akka.cluster.Reachability
-
- alpha(FiniteDuration, FiniteDuration) - Method in class akka.cluster.EWMA$
-
Calculate the alpha (decay factor) used in
EWMA
from specified half-life and interval between observations.
- alpha() - Method in class akka.cluster.EWMA
-
- alpha(FiniteDuration, FiniteDuration) - Method in class akka.cluster.metrics.EWMA$
-
Calculate the alpha (decay factor) used in
EWMA
from specified half-life and interval between observations.
- alpha() - Method in class akka.cluster.metrics.EWMA
-
- ALPHA_FIELD_NUMBER - Static variable in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA
-
- ALPHA_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
-
- alter(T) - Method in class akka.agent.Agent
-
Dispatch an update to the internal state, and return a Future where
that new state can be obtained.
- alter(Function1<T, T>) - Method in class akka.agent.Agent
-
Dispatch a function to update the internal state, and return a Future where
that new state can be obtained.
- alterOff(Function1<T, T>, ExecutionContext) - Method in class akka.agent.Agent
-
Dispatch a function to update the internal state but on its own thread,
and return a Future where that new state can be obtained.
- amendConfig(Config) - Method in class akka.dispatch.BalancingDispatcherConfigurator$
-
- amendConfig(Config) - Static method in class akka.dispatch.BalancingDispatcherConfigurator
-
- anchor() - Method in class akka.actor.ActorSelection
-
- anchorPath() - Method in class akka.actor.ActorSelection
-
- And(Behavior<T>, Behavior<T>) - Constructor for class akka.typed.ScalaDSL.And
-
- And$() - Constructor for class akka.typed.ScalaDSL.And$
-
- anyEvent(FI.Apply2<Object, D, FSM.State<S, D>>) - Method in class akka.japi.pf.FSMStateFunctionBuilder
-
Add a case statement that matches on any type of event.
- ap() - Method in class akka.testkit.TestActor.SetAutoPilot
-
- apiCommand() - Method in class akka.io.SelectionHandler.WorkerForCommand
-
- append(Tcp.WriteCommand) - Method in class akka.io.Tcp.SimpleWriteCommand
-
Java API: appends this command with another WriteCommand
to form a CompoundWrite
.
- append(ByteString) - Method in class akka.util.ByteStringBuilder
-
Java API: append a ByteString to this builder.
- apply(Object) - Method in class akka.actor.Actor.emptyBehavior$
-
- apply(Object) - Method in class akka.actor.Actor.ignoringBehavior$
-
- apply(ActorRef, String, Throwable) - Method in class akka.actor.ActorInitializationException$
-
- apply(String) - Method in class akka.actor.ActorInitializationException$
-
- apply(ActorRef, String, Throwable) - Static method in exception akka.actor.ActorInitializationException
-
- apply(String) - Static method in exception akka.actor.ActorInitializationException
-
- apply(ActorRef, String) - Method in class akka.actor.ActorSelection$
-
Construct an ActorSelection from the given string representing a path
relative to the given target.
- apply(ActorRef, Iterable<String>) - Method in class akka.actor.ActorSelection$
-
Construct an ActorSelection from the given string representing a path
relative to the given target.
- apply(ActorRef, String) - Static method in class akka.actor.ActorSelection
-
Construct an ActorSelection from the given string representing a path
relative to the given target.
- apply(ActorRef, Iterable<String>) - Static method in class akka.actor.ActorSelection
-
Construct an ActorSelection from the given string representing a path
relative to the given target.
- apply() - Method in class akka.actor.ActorSystem$
-
Creates a new ActorSystem with the name "default",
obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader,
then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader
associated with the ActorSystem class.
- apply(String) - Method in class akka.actor.ActorSystem$
-
Creates a new ActorSystem with the specified name,
obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader,
then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader
associated with the ActorSystem class.
- apply(String, Config) - Method in class akka.actor.ActorSystem$
-
Creates a new ActorSystem with the specified name, and the specified Config, then
obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader,
then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader
associated with the ActorSystem class.
- apply(String, Config, ClassLoader) - Method in class akka.actor.ActorSystem$
-
Creates a new ActorSystem with the specified name, the specified Config, and specified ClassLoader
- apply(String, Option<Config>, Option<ClassLoader>, Option<ExecutionContext>) - Method in class akka.actor.ActorSystem$
-
Creates a new ActorSystem with the specified name,
the specified ClassLoader if given, otherwise obtains the current ClassLoader by first inspecting the current
threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then
falls back to the ClassLoader associated with the ActorSystem class.
- apply() - Static method in class akka.actor.ActorSystem
-
Creates a new ActorSystem with the name "default",
obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader,
then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader
associated with the ActorSystem class.
- apply(String) - Static method in class akka.actor.ActorSystem
-
Creates a new ActorSystem with the specified name,
obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader,
then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader
associated with the ActorSystem class.
- apply(String, Config) - Static method in class akka.actor.ActorSystem
-
Creates a new ActorSystem with the specified name, and the specified Config, then
obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader,
then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader
associated with the ActorSystem class.
- apply(String, Config, ClassLoader) - Static method in class akka.actor.ActorSystem
-
Creates a new ActorSystem with the specified name, the specified Config, and specified ClassLoader
- apply(String, Option<Config>, Option<ClassLoader>, Option<ExecutionContext>) - Static method in class akka.actor.ActorSystem
-
Creates a new ActorSystem with the specified name,
the specified ClassLoader if given, otherwise obtains the current ClassLoader by first inspecting the current
threads' getContextClassLoader, then tries to walk the stack to find the callers class loader, then
falls back to the ClassLoader associated with the ActorSystem class.
- apply(String, String) - Method in class akka.actor.Address$
-
Constructs a new Address with the specified protocol and system name
- apply(String, String, String, int) - Method in class akka.actor.Address$
-
Constructs a new Address with the specified protocol, system name, host and port
- apply(String, String) - Static method in class akka.actor.Address
-
Constructs a new Address with the specified protocol and system name
- apply(String, String, String, int) - Static method in class akka.actor.Address
-
Constructs a new Address with the specified protocol, system name, host and port
- apply(String) - Method in class akka.actor.AddressFromURIString$
-
Try to construct an Address from the given String or throw a java.net.MalformedURLException.
- apply(String) - Static method in class akka.actor.AddressFromURIString
-
Try to construct an Address from the given String or throw a java.net.MalformedURLException.
- apply(ChildStats) - Method in class akka.actor.dungeon.ChildrenContainer.ChildrenIterable
-
- apply(ChildStats) - Method in class akka.actor.dungeon.ChildrenContainer.ChildRestartsIterable
-
- apply(TreeMap<String, ChildStats>) - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer$
-
- apply(ActorSystem) - Method in interface akka.actor.ExtensionId
-
Returns an instance of the extension identified by this ExtensionId instance.
- apply(Object) - Method in class akka.actor.FSM.NullFunction$
-
- apply(Class<?>, Seq<Object>) - Method in class akka.actor.IndirectActorProducer$
-
- apply(ClassTag<T>) - Method in class akka.actor.Props$
-
- apply(Function0<T>, ClassTag<T>) - Method in class akka.actor.Props$
-
- apply(Class<?>, Seq<Object>) - Method in class akka.actor.Props$
-
- apply(ClassTag<T>) - Static method in class akka.actor.Props
-
- apply(Function0<T>, ClassTag<T>) - Static method in class akka.actor.Props
-
- apply(Class<?>, Seq<Object>) - Static method in class akka.actor.Props
-
- apply(ActorRef) - Method in class akka.actor.SerializedActorRef$
-
- apply(ActorRef) - Static method in class akka.actor.SerializedActorRef
-
- apply(ActorContext) - Method in class akka.actor.TypedActor$
-
Returns a contextual TypedActorFactory of this extension, this means that any TypedActors created by this TypedActorExtension
will be children to the specified context, this allows for creating hierarchies of TypedActors.
- apply(ActorContext) - Static method in class akka.actor.TypedActor
-
Returns a contextual TypedActorFactory of this extension, this means that any TypedActors created by this TypedActorExtension
will be children to the specified context, this allows for creating hierarchies of TypedActors.
- apply(Object) - Method in class akka.actor.TypedActor.MethodCall
-
Invokes the Method on the supplied instance
- apply(Class<T>) - Method in class akka.actor.TypedProps$
-
Uses the supplied class as the factory for the TypedActor implementation,
proxying all the interfaces it implements.
- apply(Class<? super T>, Class<T>) - Method in class akka.actor.TypedProps$
-
Uses the supplied class as the factory for the TypedActor implementation,
and that has the specified interface,
or if the interface class is not an interface, all the interfaces it implements,
appended in the sequence of interfaces.
- apply(Class<? super T>, Function0<T>) - Method in class akka.actor.TypedProps$
-
Uses the supplied thunk as the factory for the TypedActor implementation,
and that has the specified interface,
or if the interface class is not an interface, all the interfaces it implements,
appended in the sequence of interfaces.
- apply(ClassTag<T>) - Method in class akka.actor.TypedProps$
-
Uses the supplied class as the factory for the TypedActor implementation,
proxying all the interfaces it implements.
- apply(Seq<Class<?>>, Function0<T>) - Method in class akka.actor.TypedProps$
-
INTERNAL API
- apply(Class<T>) - Static method in class akka.actor.TypedProps
-
Uses the supplied class as the factory for the TypedActor implementation,
proxying all the interfaces it implements.
- apply(Class<? super T>, Class<T>) - Static method in class akka.actor.TypedProps
-
Uses the supplied class as the factory for the TypedActor implementation,
and that has the specified interface,
or if the interface class is not an interface, all the interfaces it implements,
appended in the sequence of interfaces.
- apply(Class<? super T>, Function0<T>) - Static method in class akka.actor.TypedProps
-
Uses the supplied thunk as the factory for the TypedActor implementation,
and that has the specified interface,
or if the interface class is not an interface, all the interfaces it implements,
appended in the sequence of interfaces.
- apply(ClassTag<T>) - Static method in class akka.actor.TypedProps
-
Uses the supplied class as the factory for the TypedActor implementation,
proxying all the interfaces it implements.
- apply(Seq<Class<?>>, Function0<T>) - Static method in class akka.actor.TypedProps
-
INTERNAL API
- apply(T, ExecutionContext) - Method in class akka.agent.Agent$
-
Factory method for creating an Agent.
- apply() - Method in class akka.agent.Agent
-
Read the internal state of the agent.
- apply(FiniteDuration, FiniteDuration, boolean, Function1<RouteDefinition, ProcessorDefinition<?>>) - Method in class akka.camel.ConsumerConfig$
-
- apply(FiniteDuration, FiniteDuration, boolean, Function1<RouteDefinition, ProcessorDefinition<?>>) - Static method in class akka.camel.ConsumerConfig
-
- apply(ActorRef) - Method in class akka.camel.internal.component.ActorEndpointPath$
-
- apply(ActorRef) - Static method in class akka.camel.internal.component.ActorEndpointPath
-
- apply(ActorSystem) - Method in class akka.cluster.client.ClusterClientSettings$
-
Create settings from the default configuration
akka.cluster.client
.
- apply(Config) - Method in class akka.cluster.client.ClusterClientSettings$
-
Create settings from a configuration with the same layout as
the default configuration akka.cluster.client
.
- apply(ActorSystem) - Static method in class akka.cluster.client.ClusterClientSettings
-
Create settings from the default configuration
akka.cluster.client
.
- apply(Config) - Static method in class akka.cluster.client.ClusterClientSettings
-
Create settings from a configuration with the same layout as
the default configuration akka.cluster.client
.
- apply(ActorSystem) - Method in class akka.cluster.client.ClusterReceptionistSettings$
-
Create settings from the default configuration
akka.cluster.client.receptionist
.
- apply(Config) - Method in class akka.cluster.client.ClusterReceptionistSettings$
-
Create settings from a configuration with the same layout as
the default configuration akka.cluster.client.receptionist
.
- apply(ActorSystem) - Static method in class akka.cluster.client.ClusterReceptionistSettings
-
Create settings from the default configuration
akka.cluster.client.receptionist
.
- apply(Config) - Static method in class akka.cluster.client.ClusterReceptionistSettings
-
Create settings from a configuration with the same layout as
the default configuration akka.cluster.client.receptionist
.
- apply(SortedSet<Member>) - Method in class akka.cluster.Gossip$
-
- apply(SortedSet<Member>) - Static method in class akka.cluster.Gossip
-
- apply(UniqueAddress, UniqueAddress, Gossip) - Method in class akka.cluster.GossipEnvelope$
-
- apply(UniqueAddress, UniqueAddress, Deadline, Function0<Gossip>) - Method in class akka.cluster.GossipEnvelope$
-
- apply(UniqueAddress, UniqueAddress, Gossip) - Static method in class akka.cluster.GossipEnvelope
-
- apply(UniqueAddress, UniqueAddress, Deadline, Function0<Gossip>) - Static method in class akka.cluster.GossipEnvelope
-
- apply(UniqueAddress, Set<String>) - Method in class akka.cluster.Member$
-
INTERNAL API
Create a new member with status Joining.
- apply(UniqueAddress, Set<String>) - Static method in class akka.cluster.Member
-
INTERNAL API
Create a new member with status Joining.
- apply(ActorSystem) - Method in class akka.cluster.metrics.MetricsCollector$
-
Try to create collector instance in the order of priority.
- apply(Function0<T>) - Method in class akka.cluster.metrics.TryNative$
-
- apply(Function0<T>) - Static method in class akka.cluster.metrics.TryNative
-
- apply(int) - Method in class akka.cluster.metrics.WeightedRoutees
-
Pick the routee matching a value, from 1 to total.
- apply(ExtendedActorSystem, ClusterSettings) - Method in class akka.cluster.MetricsCollector$
-
- apply(String, Object) - Method in class akka.cluster.pubsub.DistributedPubSubMediator.Publish$
-
- apply(String, ActorRef) - Method in class akka.cluster.pubsub.DistributedPubSubMediator.Subscribe$
-
- apply(String, ActorRef) - Method in class akka.cluster.pubsub.DistributedPubSubMediator.Unsubscribe$
-
- apply(ActorSystem) - Method in class akka.cluster.pubsub.DistributedPubSubSettings$
-
Create settings from the default configuration
akka.cluster.pub-sub
.
- apply(Config) - Method in class akka.cluster.pubsub.DistributedPubSubSettings$
-
Create settings from a configuration with the same layout as
the default configuration akka.cluster.pub-sub
.
- apply(ActorSystem) - Static method in class akka.cluster.pubsub.DistributedPubSubSettings
-
Create settings from the default configuration
akka.cluster.pub-sub
.
- apply(Config) - Static method in class akka.cluster.pubsub.DistributedPubSubSettings
-
Create settings from a configuration with the same layout as
the default configuration akka.cluster.pub-sub
.
- apply(IndexedSeq<Reachability.Record>, Map<UniqueAddress, Object>) - Method in class akka.cluster.Reachability$
-
- apply(IndexedSeq<Reachability.Record>, Map<UniqueAddress, Object>) - Static method in class akka.cluster.Reachability
-
- apply(int) - Method in class akka.cluster.routing.WeightedRoutees
-
Pick the routee matching a value, from 1 to total.
- apply(ActorSystem) - Method in class akka.cluster.singleton.ClusterSingletonManagerSettings$
-
Create settings from the default configuration
akka.cluster.singleton
.
- apply(Config) - Method in class akka.cluster.singleton.ClusterSingletonManagerSettings$
-
Create settings from a configuration with the same layout as
the default configuration akka.cluster.singleton
.
- apply(ActorSystem) - Static method in class akka.cluster.singleton.ClusterSingletonManagerSettings
-
Create settings from the default configuration
akka.cluster.singleton
.
- apply(Config) - Static method in class akka.cluster.singleton.ClusterSingletonManagerSettings
-
Create settings from a configuration with the same layout as
the default configuration akka.cluster.singleton
.
- apply(ActorSystem) - Method in class akka.cluster.singleton.ClusterSingletonProxySettings$
-
Create settings from the default configuration
akka.cluster.singleton-proxy
.
- apply(Config) - Method in class akka.cluster.singleton.ClusterSingletonProxySettings$
-
Create settings from a configuration with the same layout as
the default configuration akka.cluster.singleton-proxy
.
- apply(ActorSystem) - Static method in class akka.cluster.singleton.ClusterSingletonProxySettings
-
Create settings from the default configuration
akka.cluster.singleton-proxy
.
- apply(Config) - Static method in class akka.cluster.singleton.ClusterSingletonProxySettings
-
Create settings from a configuration with the same layout as
the default configuration akka.cluster.singleton-proxy
.
- apply(String) - Method in class akka.cluster.VectorClock.Node$
-
- apply(Object, ActorRef, ActorSystem) - Method in class akka.dispatch.Envelope$
-
- apply(Object, ActorRef, ActorSystem) - Static method in class akka.dispatch.Envelope
-
- apply(T) - Method in class akka.dispatch.japi.BooleanFunctionBridge
-
- apply(T) - Method in class akka.dispatch.japi.CallbackBridge
-
- apply(Throwable) - Method in class akka.dispatch.japi.RecoverBridge
-
- apply(T) - Method in class akka.dispatch.japi.UnitFunctionBridge
-
- apply(T) - Method in class akka.dispatch.Mapper
-
Override this method to perform the map operation, by default delegates to "checkedApply"
which by default throws an UnsupportedOperationException.
- apply(Function1<Object, Object>) - Method in class akka.dispatch.PriorityGenerator$
-
Creates a PriorityGenerator that uses the supplied function as priority generator
- apply(Function1<Object, Object>) - Static method in class akka.dispatch.PriorityGenerator
-
Creates a PriorityGenerator that uses the supplied function as priority generator
- apply(ActorSystem, T, LogSource<T>) - Method in class akka.event.Logging$
-
Obtain LoggingAdapter for the given actor system and source object.
- apply(LoggingBus, T, LogSource<T>) - Method in class akka.event.Logging$
-
Obtain LoggingAdapter for the given logging bus and source object.
- apply(Actor) - Method in class akka.event.Logging$
-
Obtain LoggingAdapter with MDC support for the given actor.
- apply(ActorSystem, T, LogSource<T>) - Static method in class akka.event.Logging
-
Obtain LoggingAdapter for the given actor system and source object.
- apply(LoggingBus, T, LogSource<T>) - Static method in class akka.event.Logging
-
Obtain LoggingAdapter for the given logging bus and source object.
- apply(Actor) - Static method in class akka.event.Logging
-
Obtain LoggingAdapter with MDC support for the given actor.
- apply(String, Class<?>, Object, Map<String, Object>) - Method in class akka.event.Logging.Debug$
-
- apply(String, Class<?>, Object) - Method in class akka.event.Logging.Error$
-
- apply(Throwable, String, Class<?>, Object, Map<String, Object>) - Method in class akka.event.Logging.Error$
-
- apply(String, Class<?>, Object, Map<String, Object>) - Method in class akka.event.Logging.Error$
-
- apply(String, Class<?>, Object, Map<String, Object>) - Method in class akka.event.Logging.Info$
-
- apply(String, Class<?>, Object, Map<String, Object>) - Method in class akka.event.Logging.Warning$
-
- apply(PartialFunction<Object, BoxedUnit>, ActorContext) - Method in class akka.event.LoggingReceive$
-
Wrap a Receive partial function in a logging enclosure, which sends a
debug message to the event bus each time before a message is matched.
- apply(Object) - Method in class akka.event.LoggingReceive
-
- apply(T, LogSource<T>) - Method in class akka.event.LogSource$
-
Convenience converter access: given an implicit LogSource
, generate the
string representation and originating class.
- apply(T, ActorSystem, LogSource<T>) - Method in class akka.event.LogSource$
-
Convenience converter access: given an implicit
LogSource
and
ActorSystem
, generate the string representation and
originating class.
- apply(String) - Method in class akka.event.slf4j.Logger$
-
- apply(Class<?>, String) - Method in class akka.event.slf4j.Logger$
-
- apply(String) - Static method in class akka.event.slf4j.Logger
-
- apply(Class<?>, String) - Static method in class akka.event.slf4j.Logger
-
- apply(String, Iterable<InetAddress>) - Method in class akka.io.Dns.Resolved$
-
- apply() - Method in class akka.io.Inet.DatagramChannelCreator$
-
- apply(ExtensionId<T>, ActorSystem) - Method in class akka.io.IO$
-
Scala API: obtain a reference to the manager actor for the given IO extension,
for example
Tcp
or
Udp
.
- apply(ExtensionId<T>, ActorSystem) - Static method in class akka.io.IO
-
Scala API: obtain a reference to the manager actor for the given IO extension,
for example
Tcp
or
Udp
.
- apply(ByteString) - Method in class akka.io.Tcp.Write$
-
Create a new unacknowledged Write command with the given data.
- apply(Iterable<Tcp.WriteCommand>) - Method in class akka.io.Tcp.WriteCommand$
-
Combines the given number of write commands into one atomic WriteCommand
.
- apply(ByteString, InetSocketAddress) - Method in class akka.io.Udp.Send$
-
- apply(ByteString) - Method in class akka.io.UdpConnected.Send$
-
- apply() - Method in interface akka.japi.Effect
-
- apply(T) - Method in interface akka.japi.Function
-
- apply() - Method in interface akka.japi.function.Effect
-
- apply(T) - Method in interface akka.japi.function.Function
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Method in interface akka.japi.function.Function10
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Method in interface akka.japi.function.Function11
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Method in interface akka.japi.function.Function12
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Method in interface akka.japi.function.Function13
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Method in interface akka.japi.function.Function14
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Method in interface akka.japi.function.Function15
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Method in interface akka.japi.function.Function16
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Method in interface akka.japi.function.Function17
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Method in interface akka.japi.function.Function18
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Method in interface akka.japi.function.Function19
-
- apply(T1, T2) - Method in interface akka.japi.function.Function2
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Method in interface akka.japi.function.Function20
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Method in interface akka.japi.function.Function21
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Method in interface akka.japi.function.Function22
-
- apply(T1, T2, T3) - Method in interface akka.japi.function.Function3
-
- apply(T1, T2, T3, T4) - Method in interface akka.japi.function.Function4
-
- apply(T1, T2, T3, T4, T5) - Method in interface akka.japi.function.Function5
-
- apply(T1, T2, T3, T4, T5, T6) - Method in interface akka.japi.function.Function6
-
- apply(T1, T2, T3, T4, T5, T6, T7) - Method in interface akka.japi.function.Function7
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8) - Method in interface akka.japi.function.Function8
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in interface akka.japi.function.Function9
-
- apply(T) - Method in interface akka.japi.function.Procedure
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Method in interface akka.japi.function.Procedure10
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Method in interface akka.japi.function.Procedure11
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Method in interface akka.japi.function.Procedure12
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Method in interface akka.japi.function.Procedure13
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Method in interface akka.japi.function.Procedure14
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Method in interface akka.japi.function.Procedure15
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Method in interface akka.japi.function.Procedure16
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Method in interface akka.japi.function.Procedure17
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Method in interface akka.japi.function.Procedure18
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Method in interface akka.japi.function.Procedure19
-
- apply(T1, T2) - Method in interface akka.japi.function.Procedure2
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Method in interface akka.japi.function.Procedure20
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Method in interface akka.japi.function.Procedure21
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Method in interface akka.japi.function.Procedure22
-
- apply(T1, T2, T3) - Method in interface akka.japi.function.Procedure3
-
- apply(T1, T2, T3, T4) - Method in interface akka.japi.function.Procedure4
-
- apply(T1, T2, T3, T4, T5) - Method in interface akka.japi.function.Procedure5
-
- apply(T1, T2, T3, T4, T5, T6) - Method in interface akka.japi.function.Procedure6
-
- apply(T1, T2, T3, T4, T5, T6, T7) - Method in interface akka.japi.function.Procedure7
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8) - Method in interface akka.japi.function.Procedure8
-
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in interface akka.japi.function.Procedure9
-
- apply(T1, T2) - Method in interface akka.japi.Function2
-
- apply(A, boolean) - Method in class akka.japi.JavaPartialFunction
-
- apply(A) - Method in class akka.japi.JavaPartialFunction
-
- apply(F) - Method in class akka.japi.pf.CaseStatement
-
- apply(I) - Method in interface akka.japi.pf.FI.Apply
-
The application to perform.
- apply(I1, I2) - Method in interface akka.japi.pf.FI.Apply2
-
The application to perform.
- apply(I) - Method in interface akka.japi.pf.FI.UnitApply
-
The application to perform.
- apply(I1, I2) - Method in interface akka.japi.pf.FI.UnitApply2
-
The application to perform.
- apply(I1, I2, I3) - Method in interface akka.japi.pf.FI.UnitApply3
-
The application to perform.
- apply() - Method in interface akka.japi.pf.FI.UnitApplyVoid
-
The application to perform.
- apply(F) - Method in class akka.japi.pf.UnitCaseStatement
-
- apply(T) - Method in interface akka.japi.Procedure
-
- apply(BundleContext) - Method in class akka.osgi.BundleDelegatingClassLoader$
-
- apply(BundleContext, Option<ClassLoader>) - Method in class akka.osgi.BundleDelegatingClassLoader$
-
- apply(BundleContext) - Static method in class akka.osgi.BundleDelegatingClassLoader
-
- apply(BundleContext, Option<ClassLoader>) - Static method in class akka.osgi.BundleDelegatingClassLoader
-
- apply(BundleContext, Config) - Method in class akka.osgi.OsgiActorSystemFactory$
-
- apply(BundleContext, Config) - Static method in class akka.osgi.OsgiActorSystemFactory
-
- apply(Scheduler, int, FiniteDuration, FiniteDuration) - Method in class akka.pattern.CircuitBreaker$
-
Create a new CircuitBreaker.
- apply(Scheduler, int, FiniteDuration, FiniteDuration) - Static method in class akka.pattern.CircuitBreaker
-
Create a new CircuitBreaker.
- apply(ActorRefProvider, Timeout, Object, String, ActorRef) - Method in class akka.pattern.PromiseActorRef$
-
- apply(ActorRefProvider, Timeout, String) - Method in class akka.pattern.PromiseActorRef$
-
- apply(ActorRefProvider, Timeout, Object, String, ActorRef) - Static method in class akka.pattern.PromiseActorRef
-
- apply(ActorRefProvider, Timeout, String) - Static method in class akka.pattern.PromiseActorRef
-
- apply(Object, long, String, boolean, ActorRef) - Method in class akka.persistence.PersistentRepr$
-
Plugin API.
- apply(Address) - Method in class akka.remote.AddressUrlEncoder$
-
- apply(Address) - Static method in class akka.remote.AddressUrlEncoder
-
- apply(String, Config, ActorContext) - Method in class akka.remote.FailureDetectorLoader$
-
- apply(String, Config, ActorContext) - Static method in class akka.remote.FailureDetectorLoader
-
- apply(int) - Method in class akka.remote.HeartbeatHistory$
-
Create an empty HeartbeatHistory, without any history.
- apply(int) - Static method in class akka.remote.HeartbeatHistory
-
Create an empty HeartbeatHistory, without any history.
- apply(Role, InetSocketAddress, int, ChannelUpstreamHandler) - Method in class akka.remote.testconductor.RemoteConnection$
-
- apply(Role, InetSocketAddress, int, ChannelUpstreamHandler) - Static method in class akka.remote.testconductor.RemoteConnection
-
- apply(ActorContext) - Method in class akka.remote.testconductor.TestConductor$
-
- apply(ActorContext) - Static method in class akka.remote.testconductor.TestConductor
-
- apply(ChannelFuture) - Method in class akka.remote.transport.netty.NettyFutureBridge$
-
- apply(ChannelGroupFuture) - Method in class akka.remote.transport.netty.NettyFutureBridge$
-
- apply(ChannelFuture) - Static method in class akka.remote.transport.netty.NettyFutureBridge
-
- apply(ChannelGroupFuture) - Static method in class akka.remote.transport.netty.NettyFutureBridge
-
- apply(SSLSettings, LoggingAdapter, boolean) - Method in class akka.remote.transport.netty.NettySSLSupport$
-
Construct a SSLHandler which can be inserted into a Netty server/client pipeline
- apply(SSLSettings, LoggingAdapter, boolean) - Static method in class akka.remote.transport.netty.NettySSLSupport
-
Construct a SSLHandler which can be inserted into a Netty server/client pipeline
- apply(A) - Method in class akka.remote.transport.TestTransport.SwitchableLoggedBehavior
-
Applies the current behavior, and invokes the callback.
- apply() - Method in class akka.routing.BalancingRoutingLogic$
-
- apply() - Static method in class akka.routing.BalancingRoutingLogic
-
- apply() - Method in class akka.routing.BroadcastRoutingLogic$
-
- apply() - Static method in class akka.routing.BroadcastRoutingLogic
-
- apply(Iterable<T>, int, ClassTag<T>) - Method in class akka.routing.ConsistentHash$
-
- apply(Iterable<T>, int, ClassTag<T>) - Static method in class akka.routing.ConsistentHash
-
- apply(Object) - Method in class akka.routing.ConsistentHashingRouter.emptyConsistentHashMapping$
-
- apply(Config) - Method in class akka.routing.DefaultResizer$
-
Creates a new DefaultResizer from the given configuration
- apply(Config) - Static method in class akka.routing.DefaultResizer
-
Creates a new DefaultResizer from the given configuration
- apply(Option<Resizer>, SupervisorStrategy, String) - Method in class akka.routing.FromConfig$
-
- apply(Option<Resizer>, SupervisorStrategy, String) - Static method in class akka.routing.FromConfig
-
- apply() - Method in class akka.routing.RandomRoutingLogic$
-
- apply() - Static method in class akka.routing.RandomRoutingLogic
-
- apply() - Method in class akka.routing.RoundRobinRoutingLogic$
-
- apply() - Static method in class akka.routing.RoundRobinRoutingLogic
-
- apply() - Method in class akka.routing.SmallestMailboxRoutingLogic$
-
- apply() - Static method in class akka.routing.SmallestMailboxRoutingLogic
-
- apply(A) - Method in class akka.testkit.CachingPartialFunction
-
- apply(ClassTag<T>) - Method in class akka.testkit.DeadLettersFilter$
-
- apply(ClassTag<T>) - Static method in class akka.testkit.DeadLettersFilter
-
- apply(String, String, String, String, int, ClassTag<A>) - Method in class akka.testkit.EventFilter$
-
Create a filter for Error events.
- apply(Logging.LogEvent) - Method in class akka.testkit.EventFilter
-
- apply(Function0<T>, ClassTag<T>, ActorSystem) - Method in class akka.testkit.TestActorRef$
-
- apply(Function0<T>, String, ClassTag<T>, ActorSystem) - Method in class akka.testkit.TestActorRef$
-
- apply(Props, ActorSystem) - Method in class akka.testkit.TestActorRef$
-
- apply(Props, String, ActorSystem) - Method in class akka.testkit.TestActorRef$
-
- apply(Props, ActorRef, String, ActorSystem) - Method in class akka.testkit.TestActorRef$
-
- apply(ClassTag<T>, ActorSystem) - Method in class akka.testkit.TestActorRef$
-
- apply(String, ClassTag<T>, ActorSystem) - Method in class akka.testkit.TestActorRef$
-
- apply(Function0<T>, ClassTag<T>, ActorSystem) - Static method in class akka.testkit.TestActorRef
-
- apply(Function0<T>, String, ClassTag<T>, ActorSystem) - Static method in class akka.testkit.TestActorRef
-
- apply(Props, ActorSystem) - Static method in class akka.testkit.TestActorRef
-
- apply(Props, String, ActorSystem) - Static method in class akka.testkit.TestActorRef
-
- apply(Props, ActorRef, String, ActorSystem) - Static method in class akka.testkit.TestActorRef
-
- apply(ClassTag<T>, ActorSystem) - Static method in class akka.testkit.TestActorRef
-
- apply(String, ClassTag<T>, ActorSystem) - Static method in class akka.testkit.TestActorRef
-
- apply(int) - Method in class akka.testkit.TestBarrier$
-
- apply(int) - Static method in class akka.testkit.TestBarrier
-
- apply(EventFilter, Seq<EventFilter>) - Method in class akka.testkit.TestEvent.Mute$
-
- apply(EventFilter, Seq<EventFilter>) - Method in class akka.testkit.TestEvent.UnMute$
-
- apply(Function0<T>, ClassTag<T>, Predef.$less$colon$less<T, FSM<S, D>>, ActorSystem) - Method in class akka.testkit.TestFSMRef$
-
- apply(Function0<T>, String, ClassTag<T>, Predef.$less$colon$less<T, FSM<S, D>>, ActorSystem) - Method in class akka.testkit.TestFSMRef$
-
- apply(Function0<T>, ClassTag<T>, Predef.$less$colon$less<T, FSM<S, D>>, ActorSystem) - Static method in class akka.testkit.TestFSMRef
-
- apply(Function0<T>, String, ClassTag<T>, Predef.$less$colon$less<T, FSM<S, D>>, ActorSystem) - Static method in class akka.testkit.TestFSMRef
-
- apply(int, ActorSystem) - Method in class akka.testkit.TestLatch$
-
- apply(int, ActorSystem) - Static method in class akka.testkit.TestLatch
-
- apply(ActorSystem) - Method in class akka.testkit.TestProbe$
-
- apply(String, ActorSystem) - Method in class akka.testkit.TestProbe$
-
- apply(ActorSystem) - Static method in class akka.testkit.TestProbe
-
- apply(String, ActorSystem) - Static method in class akka.testkit.TestProbe
-
- apply(ActorRef) - Method in class akka.typed.ActorRef$
-
Construct a typed ActorRef from an untyped one and a protocol definition
(i.e.
- apply(ActorRef) - Static method in class akka.typed.ActorRef
-
Construct a typed ActorRef from an untyped one and a protocol definition
(i.e.
- apply(String, Props<T>, Option<Config>, Option<ClassLoader>, Option<ExecutionContext>) - Method in class akka.typed.ActorSystem$
-
- apply(ActorSystem) - Method in class akka.typed.ActorSystem$
-
- apply(String, Props<T>, Option<Config>, Option<ClassLoader>, Option<ExecutionContext>) - Static method in class akka.typed.ActorSystem
-
- apply(ActorSystem) - Static method in class akka.typed.ActorSystem
-
- apply(Function0<Behavior<T>>) - Method in class akka.typed.Props$
-
Create a Props instance from a block of code that creates a
Behavior
.
- apply(Props) - Method in class akka.typed.Props$
-
INTERNAL API.
- apply(Function0<Behavior<T>>) - Static method in class akka.typed.Props
-
Create a Props instance from a block of code that creates a
Behavior
.
- apply(Props) - Static method in class akka.typed.Props
-
INTERNAL API.
- apply(Function2<ActorContext<T>, StepWise.StartWith<T>, StepWise.Steps<T, ?>>) - Method in class akka.typed.StepWise$
-
- apply(Function2<ActorContext<T>, StepWise.StartWith<T>, StepWise.Steps<T, ?>>) - Static method in class akka.typed.StepWise
-
- apply(Function0<U>) - Method in class akka.typed.StepWise.StartWith
-
- apply(Function1<U, V>) - Method in class akka.typed.StepWise.Steps
-
- apply(Class<?>) - Method in class akka.util.BoxedType$
-
- apply(Class<?>) - Static method in class akka.util.BoxedType
-
- apply(byte[]) - Method in class akka.util.ByteIterator.ByteArrayIterator$
-
- apply(byte[], int, int) - Method in class akka.util.ByteIterator.ByteArrayIterator$
-
- apply(LinearSeq<ByteIterator.ByteArrayIterator>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator$
-
- apply(byte[]) - Method in class akka.util.ByteString$
-
Creates a new ByteString by copying a byte array.
- apply(Seq<Object>) - Method in class akka.util.ByteString$
-
Creates a new ByteString by copying bytes.
- apply(Seq<T>, Integral<T>) - Method in class akka.util.ByteString$
-
Creates a new ByteString by converting from integral numbers to bytes.
- apply(ByteBuffer) - Method in class akka.util.ByteString$
-
Creates a new ByteString by copying bytes from a ByteBuffer.
- apply(String) - Method in class akka.util.ByteString$
-
Creates a new ByteString by encoding a String as UTF-8.
- apply(String, String) - Method in class akka.util.ByteString$
-
Creates a new ByteString by encoding a String with a charset.
- apply(int) - Method in class akka.util.ByteString
-
- apply(byte[]) - Method in class akka.util.ByteString.ByteString1$
-
- apply(byte[], int, int) - Method in class akka.util.ByteString.ByteString1$
-
- apply(int) - Method in class akka.util.ByteString.ByteString1
-
- apply(byte[]) - Method in class akka.util.ByteString.ByteString1C$
-
- apply(int) - Method in class akka.util.ByteString.ByteString1C
-
- apply(Vector<ByteString.ByteString1>) - Method in class akka.util.ByteString.ByteStrings$
-
- apply(Vector<ByteString.ByteString1>, int) - Method in class akka.util.ByteString.ByteStrings$
-
- apply(ByteString.ByteString1, ByteString.ByteString1) - Method in class akka.util.ByteString.ByteStrings$
-
- apply(ByteString.ByteString1, ByteString.ByteStrings) - Method in class akka.util.ByteString.ByteStrings$
-
- apply(ByteString.ByteStrings, ByteString.ByteString1) - Method in class akka.util.ByteString.ByteStrings$
-
- apply(ByteString.ByteStrings, ByteString.ByteStrings) - Method in class akka.util.ByteString.ByteStrings$
-
- apply(int) - Method in class akka.util.ByteString.ByteStrings
-
- apply(byte) - Method in class akka.util.ByteString.Companion$
-
- apply(int) - Method in class akka.util.Collections.EmptyImmutableSeq$
-
- apply(From) - Method in class akka.util.Collections.PartialImmutableValuesIterable
-
- apply(byte[]) - Method in class akka.util.CompactByteString$
-
Creates a new CompactByteString by copying a byte array.
- apply(Seq<Object>) - Method in class akka.util.CompactByteString$
-
Creates a new CompactByteString by copying bytes.
- apply(Seq<T>, Integral<T>) - Method in class akka.util.CompactByteString$
-
Creates a new CompactByteString by converting from integral numbers to bytes.
- apply(ByteBuffer) - Method in class akka.util.CompactByteString$
-
Creates a new CompactByteString by copying bytes from a ByteBuffer.
- apply(String) - Method in class akka.util.CompactByteString$
-
Creates a new CompactByteString by encoding a String as UTF-8.
- apply(String, String) - Method in class akka.util.CompactByteString$
-
Creates a new CompactByteString by encoding a String with a charset.
- apply(byte[]) - Static method in class akka.util.CompactByteString
-
Creates a new CompactByteString by copying a byte array.
- apply(Seq<Object>) - Static method in class akka.util.CompactByteString
-
Creates a new CompactByteString by copying bytes.
- apply(Seq<T>, Integral<T>) - Static method in class akka.util.CompactByteString
-
Creates a new CompactByteString by converting from integral numbers to bytes.
- apply(ByteBuffer) - Static method in class akka.util.CompactByteString
-
Creates a new CompactByteString by copying bytes from a ByteBuffer.
- apply(String) - Static method in class akka.util.CompactByteString
-
Creates a new CompactByteString by encoding a String as UTF-8.
- apply(String, String) - Static method in class akka.util.CompactByteString
-
Creates a new CompactByteString by encoding a String with a charset.
- apply(Object) - Method in class akka.util.LineNumbers$
-
Scala API: Obtain line number information for the class defining the given object.
- apply(Object) - Static method in class akka.util.LineNumbers
-
Scala API: Obtain line number information for the class defining the given object.
- apply(int, ExecutionContext) - Method in class akka.util.SerializedSuspendableExecutionContext$
-
- apply(int, ExecutionContext) - Static method in class akka.util.SerializedSuspendableExecutionContext
-
- apply(long, TimeUnit) - Method in class akka.util.Timeout$
-
Construct a Timeout from the given time unit and factor.
- apply(long, TimeUnit) - Static method in class akka.util.Timeout
-
Construct a Timeout from the given time unit and factor.
- apply() - Method in class akka.util.WildcardTree$
-
- apply() - Static method in class akka.util.WildcardTree
-
- applyOrElse(A1, Function1<A1, B1>) - Method in class akka.japi.JavaPartialFunction
-
- applyState(FSM.State<S, D>) - Method in interface akka.actor.FSM
-
- applyUserRouteCustomization(RouteDefinition) - Method in class akka.camel.internal.ConsumerActorRouteBuilder
-
- args() - Method in class akka.actor.Props
-
- ARGS_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.PropsData
-
- ArgsReflectConstructor - Class in akka.actor
-
INTERNAL API
- ArgsReflectConstructor(Class<? extends Actor>, Seq<Object>) - Constructor for class akka.actor.ArgsReflectConstructor
-
- aroundCache() - Method in interface akka.contrib.pattern.ReceivePipeline
-
- aroundPostRestart(Throwable) - Method in interface akka.actor.Actor
-
Can be overridden to intercept calls to postRestart
.
- aroundPostStop() - Method in interface akka.actor.Actor
-
Can be overridden to intercept calls to postStop
.
- aroundPostStop() - Method in interface akka.persistence.AtLeastOnceDelivery
-
INTERNAL API
- aroundPostStop() - Method in interface akka.persistence.Eventsourced
-
INTERNAL API.
- aroundPreRestart(Throwable, Option<Object>) - Method in interface akka.actor.Actor
-
Can be overridden to intercept calls to preRestart
.
- aroundPreRestart(Throwable, Option<Object>) - Method in interface akka.persistence.AtLeastOnceDelivery
-
INTERNAL API
- aroundPreRestart(Throwable, Option<Object>) - Method in interface akka.persistence.Eventsourced
-
INTERNAL API.
- aroundPreStart() - Method in interface akka.actor.Actor
-
Can be overridden to intercept calls to preStart
.
- aroundPreStart() - Method in interface akka.persistence.Eventsourced
-
INTERNAL API.
- aroundPreStart() - Method in interface akka.persistence.PersistentView
-
INTERNAL API.
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.actor.Actor
-
INTERNAL API.
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.actor.DiagnosticActorLogging
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.contrib.pattern.ReceivePipeline
-
INTERNAL API.
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.persistence.AtLeastOnceDelivery
-
INTERNAL API
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.persistence.Eventsourced
-
INTERNAL API.
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.persistence.PersistentView
-
INTERNAL API.
- ARRAY_OF_BYTE_ARRAY() - Method in class akka.remote.serialization.ProtobufSerializer
-
- arrayBlockingQueue(int, boolean) - Method in class akka.dispatch.ThreadPoolConfig$
-
- arrayBlockingQueue(int, boolean) - Static method in class akka.dispatch.ThreadPoolConfig
-
- arrayHash(Object) - Method in class akka.routing.MurmurHash$
-
Compute a high-quality hash of an array
- arrayHash(Object) - Static method in class akka.routing.MurmurHash
-
Compute a high-quality hash of an array
- arrived() - Method in class akka.remote.testconductor.BarrierCoordinator.Data
-
- asByteBuffer() - Method in class akka.util.ByteString
-
Returns a read-only ByteBuffer that directly wraps this ByteString
if it is not fragmented.
- asByteBuffer() - Method in class akka.util.ByteString.ByteString1
-
- asByteBuffer() - Method in class akka.util.ByteString.ByteString1C
-
- asByteBuffer() - Method in class akka.util.ByteString.ByteStrings
-
- asByteBuffers() - Method in class akka.util.ByteString
-
Scala API: Returns an immutable Iterable of read-only ByteBuffers that directly wraps this ByteStrings
all fragments.
- asByteBuffers() - Method in class akka.util.ByteString.ByteString1
-
- asByteBuffers() - Method in class akka.util.ByteString.ByteString1C
-
- asByteBuffers() - Method in class akka.util.ByteString.ByteStrings
-
- asInputStream() - Method in class akka.util.ByteIterator
-
Directly wraps this ByteIterator in an InputStream without copying.
- asInputStream() - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- asInputStream() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- asInt() - Method in class akka.event.Logging.LogLevel
-
- ask(Object, Timeout) - Method in class akka.pattern.AskableActorRef
-
- ask(Object, Timeout, ActorRef) - Method in class akka.pattern.AskableActorRef
-
- ask(Object, Timeout) - Method in class akka.pattern.AskableActorSelection
-
- ask(Object, Timeout, ActorRef) - Method in class akka.pattern.AskableActorSelection
-
- ask(ActorRef) - Method in interface akka.pattern.AskSupport
-
Import this implicit conversion to gain
?
and
ask
methods on
ActorRef
, which will defer to the
ask(actorRef, message)(timeout)
method defined here.
- ask(ActorRef, Object, Timeout) - Method in interface akka.pattern.AskSupport
-
Sends a message asynchronously and returns a Future
holding the eventual reply message; this means that the target actor
needs to send the result to the sender
reference provided.
- ask(ActorRef, Object, ActorRef, Timeout) - Method in interface akka.pattern.AskSupport
-
- ask(ActorSelection) - Method in interface akka.pattern.AskSupport
-
Import this implicit conversion to gain
?
and
ask
methods on
ActorSelection
, which will defer to the
ask(actorSelection, message)(timeout)
method defined here.
- ask(ActorSelection, Object, Timeout) - Method in interface akka.pattern.AskSupport
-
Sends a message asynchronously and returns a Future
holding the eventual reply message; this means that the target actor
needs to send the result to the sender
reference provided.
- ask(ActorSelection, Object, ActorRef, Timeout) - Method in interface akka.pattern.AskSupport
-
- ask(ActorRef, Object, Timeout) - Method in class akka.pattern.Patterns$
-
Java API for akka.pattern.ask
:
Sends a message asynchronously and returns a Future
holding the eventual reply message; this means that the target actor
needs to send the result to the sender
reference provided.
- ask(ActorRef, Object, long) - Method in class akka.pattern.Patterns$
-
Java API for akka.pattern.ask
:
Sends a message asynchronously and returns a Future
holding the eventual reply message; this means that the target actor
needs to send the result to the sender
reference provided.
- ask(ActorSelection, Object, Timeout) - Method in class akka.pattern.Patterns$
-
Java API for akka.pattern.ask
:
Sends a message asynchronously and returns a
Future
holding the eventual reply message; this means that the target
ActorSelection
needs to send the result to the
sender
reference provided.
- ask(ActorSelection, Object, long) - Method in class akka.pattern.Patterns$
-
Java API for akka.pattern.ask
:
Sends a message asynchronously and returns a
Future
holding the eventual reply message; this means that the target
ActorSelection
needs to send the result to the
sender
reference provided.
- ask(ActorRef, Object, Timeout) - Static method in class akka.pattern.Patterns
-
Java API for akka.pattern.ask
:
Sends a message asynchronously and returns a Future
holding the eventual reply message; this means that the target actor
needs to send the result to the sender
reference provided.
- ask(ActorRef, Object, long) - Static method in class akka.pattern.Patterns
-
Java API for akka.pattern.ask
:
Sends a message asynchronously and returns a Future
holding the eventual reply message; this means that the target actor
needs to send the result to the sender
reference provided.
- ask(ActorSelection, Object, Timeout) - Static method in class akka.pattern.Patterns
-
Java API for akka.pattern.ask
:
Sends a message asynchronously and returns a
Future
holding the eventual reply message; this means that the target
ActorSelection
needs to send the result to the
sender
reference provided.
- ask(ActorSelection, Object, long) - Static method in class akka.pattern.Patterns
-
Java API for akka.pattern.ask
:
Sends a message asynchronously and returns a
Future
holding the eventual reply message; this means that the target
ActorSelection
needs to send the result to the
sender
reference provided.
- ask(ActorRef<T>, Timeout, Function1<ActorRef<U>, T>) - Method in class akka.typed.AskPattern$
-
- ask(ActorRef<T>, Timeout, Function1<ActorRef<U>, T>) - Static method in class akka.typed.AskPattern
-
- Askable(ActorRef<T>) - Constructor for class akka.typed.AskPattern.Askable
-
- Askable$() - Constructor for class akka.typed.AskPattern.Askable$
-
- AskableActorRef - Class in akka.pattern
-
- AskableActorRef(ActorRef) - Constructor for class akka.pattern.AskableActorRef
-
- AskableActorRef$ - Class in akka.pattern
-
- AskableActorRef$() - Constructor for class akka.pattern.AskableActorRef$
-
- AskableActorSelection - Class in akka.pattern
-
- AskableActorSelection(ActorSelection) - Constructor for class akka.pattern.AskableActorSelection
-
- AskableActorSelection$ - Class in akka.pattern
-
- AskableActorSelection$() - Constructor for class akka.pattern.AskableActorSelection$
-
- AskPattern - Class in akka.typed
-
The ask-pattern implements the initiator side of a request–reply protocol.
- AskPattern() - Constructor for class akka.typed.AskPattern
-
- AskPattern$ - Class in akka.typed
-
The ask-pattern implements the initiator side of a request–reply protocol.
- AskPattern$() - Constructor for class akka.typed.AskPattern$
-
- AskPattern.Askable<T> - Class in akka.typed
-
- AskPattern.Askable$ - Class in akka.typed
-
- AskSupport - Interface in akka.pattern
-
This object contains implementation details of the “ask” pattern.
- AskTimeout() - Method in class akka.remote.transport.ActorTransportAdapter$
-
- AskTimeout() - Static method in class akka.remote.transport.ActorTransportAdapter
-
- AskTimeoutException - Exception in akka.pattern
-
This is what is used to complete a Future that is returned from an ask/? call,
when it times out.
- AskTimeoutException(String, Throwable) - Constructor for exception akka.pattern.AskTimeoutException
-
- AskTimeoutException(String) - Constructor for exception akka.pattern.AskTimeoutException
-
- asOutputStream() - Method in class akka.util.ByteStringBuilder
-
Directly wraps this ByteStringBuilder in an OutputStream.
- asScala() - Method in class akka.japi.Option
-
- asScala() - Method in class akka.japi.Option.Some
-
- assertDone(Duration) - Method in class akka.testkit.EventFilter
-
Assert that this filter has matched as often as requested by its
occurrences
parameter specifies.
- associate(ActorRef, ActorRef) - Method in interface akka.event.ActorClassification
-
- associate(ActorRef, ActorRef) - Method in interface akka.event.ManagedActorClassification
-
- associate(Address) - Method in class akka.remote.transport.AbstractTransportAdapter
-
- Associate(HandshakeInfo) - Constructor for class akka.remote.transport.AkkaPduCodec.Associate
-
- associate(Address, Option<Object>) - Method in class akka.remote.transport.AkkaProtocolTransport
-
- associate(Address) - Method in class akka.remote.transport.netty.NettyTransport
-
- associate(Address) - Method in class akka.remote.transport.TestTransport
-
- associate(Address) - Method in interface akka.remote.transport.Transport
-
Asynchronously opens a logical duplex link between two Transport Entities over a network.
- Associate$() - Constructor for class akka.remote.transport.AkkaPduCodec.Associate$
-
- ASSOCIATE_VALUE - Static variable in enum akka.remote.WireFormats.CommandType
-
ASSOCIATE = 1;
- AssociateAttempt(Address, Address) - Constructor for class akka.remote.transport.TestTransport.AssociateAttempt
-
- AssociateAttempt$() - Constructor for class akka.remote.transport.TestTransport.AssociateAttempt$
-
- associateBehavior() - Method in class akka.remote.transport.TestTransport
-
- AssociatedEvent - Class in akka.remote
-
- AssociatedEvent(Address, Address, boolean) - Constructor for class akka.remote.AssociatedEvent
-
- AssociatedEvent$ - Class in akka.remote
-
- AssociatedEvent$() - Constructor for class akka.remote.AssociatedEvent$
-
- AssociatedWaitHandler(Future<AssociationHandle.HandleEventListener>, AssociationHandle, Queue<ByteString>) - Constructor for class akka.remote.transport.ProtocolStateActor.AssociatedWaitHandler
-
- AssociatedWaitHandler$() - Constructor for class akka.remote.transport.ProtocolStateActor.AssociatedWaitHandler$
-
- AssociateResult(AssociationHandle, Promise<AssociationHandle>) - Constructor for class akka.remote.transport.ThrottlerManager.AssociateResult
-
- AssociateResult$() - Constructor for class akka.remote.transport.ThrottlerManager.AssociateResult$
-
- AssociateUnderlying(Address, Promise<AssociationHandle>) - Constructor for class akka.remote.transport.ActorTransportAdapter.AssociateUnderlying
-
- AssociateUnderlying$() - Constructor for class akka.remote.transport.ActorTransportAdapter.AssociateUnderlying$
-
- AssociateUnderlyingRefuseUid(Address, Promise<AssociationHandle>, Option<Object>) - Constructor for class akka.remote.transport.AkkaProtocolTransport.AssociateUnderlyingRefuseUid
-
- AssociateUnderlyingRefuseUid$() - Constructor for class akka.remote.transport.AkkaProtocolTransport.AssociateUnderlyingRefuseUid$
-
- association() - Method in class akka.remote.transport.Transport.InboundAssociation
-
- AssociationErrorEvent - Class in akka.remote
-
- AssociationErrorEvent(Throwable, Address, Address, boolean, Logging.LogLevel) - Constructor for class akka.remote.AssociationErrorEvent
-
- AssociationErrorEvent$ - Class in akka.remote
-
- AssociationErrorEvent$() - Constructor for class akka.remote.AssociationErrorEvent$
-
- AssociationEvent - Interface in akka.remote
-
- AssociationHandle - Interface in akka.remote.transport
-
An SPI layer for abstracting over logical links (associations) created by a
Transport
.
- AssociationHandle$ - Class in akka.remote.transport
-
- AssociationHandle$() - Constructor for class akka.remote.transport.AssociationHandle$
-
- AssociationHandle.ActorHandleEventListener - Class in akka.remote.transport
-
Class to convert ordinary
ActorRef
instances to a HandleEventListener.
- AssociationHandle.ActorHandleEventListener$ - Class in akka.remote.transport
-
- AssociationHandle.Disassociated - Class in akka.remote.transport
-
Message sent to the listener registered to an association
- AssociationHandle.Disassociated$ - Class in akka.remote.transport
-
- AssociationHandle.DisassociateInfo - Interface in akka.remote.transport
-
Supertype of possible disassociation reasons
- AssociationHandle.HandleEvent - Interface in akka.remote.transport
-
Trait for events that the registered listener for an
AssociationHandle
might receive.
- AssociationHandle.HandleEventListener - Interface in akka.remote.transport
-
An interface that needs to be implemented by the user of an
AssociationHandle
to listen to association events.
- AssociationHandle.InboundPayload - Class in akka.remote.transport
-
- AssociationHandle.InboundPayload$ - Class in akka.remote.transport
-
- AssociationHandle.Quarantined$ - Class in akka.remote.transport
-
- AssociationHandle.Shutdown$ - Class in akka.remote.transport
-
- AssociationHandle.Unknown$ - Class in akka.remote.transport
-
- associationHandler() - Method in class akka.remote.transport.ThrottledAssociation
-
- associationListener() - Method in class akka.remote.transport.ActorTransportAdapterManager
-
- associationListener() - Method in class akka.remote.transport.ProtocolStateActor.InboundUnassociated
-
- AssociationProblem - Interface in akka.remote
-
INTERNAL API
- AssociationRegistry - Class in akka.remote.transport
-
- AssociationRegistry() - Constructor for class akka.remote.transport.AssociationRegistry
-
- AssociationRegistry() - Constructor for class akka.remote.transport.TestTransport.AssociationRegistry
-
- AssociationRegistry$ - Class in akka.remote.transport
-
- AssociationRegistry$() - Constructor for class akka.remote.transport.AssociationRegistry$
-
- async() - Method in class akka.dispatch.sysmsg.Supervise
-
- asyncDeleteMessagesTo(String, long, boolean) - Method in interface akka.persistence.journal.AsyncWriteJournal
-
Plugin API: asynchronously deletes all persistent messages up to toSequenceNr
(inclusive).
- asyncDeleteMessagesTo(String, long, boolean) - Method in interface akka.persistence.journal.AsyncWriteProxy
-
- asyncDeleteMessagesTo(String, long, boolean) - Method in class akka.persistence.journal.japi.AsyncWriteJournal
-
- AsyncHandlerInvocation(Object, Function1<Object, BoxedUnit>) - Constructor for class akka.persistence.Eventsourced.AsyncHandlerInvocation
-
- AsyncHandlerInvocation$() - Constructor for class akka.persistence.Eventsourced.AsyncHandlerInvocation$
-
- asyncMode() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory
-
- asyncReadHighestSequenceNr(String, long) - Method in interface akka.persistence.journal.AsyncRecovery
-
Plugin API: asynchronously reads the highest stored sequence number for the
given persistenceId
.
- asyncReadHighestSequenceNr(String, long) - Method in interface akka.persistence.journal.AsyncWriteProxy
-
- asyncReadHighestSequenceNr(String, long) - Method in class akka.persistence.journal.japi.AsyncRecovery
-
- asyncReadHighestSequenceNr(String, long) - Method in interface akka.persistence.journal.leveldb.LeveldbRecovery
-
- AsyncRecovery - Interface in akka.persistence.journal
-
Asynchronous message replay and sequence number recovery interface.
- AsyncRecovery - Class in akka.persistence.journal.japi
-
Java API: asynchronous message replay and sequence number recovery interface.
- AsyncRecovery() - Constructor for class akka.persistence.journal.japi.AsyncRecovery
-
- asyncReplayMessages(String, long, long, long, Function1<PersistentRepr, BoxedUnit>) - Method in interface akka.persistence.journal.AsyncRecovery
-
Plugin API: asynchronously replays persistent messages.
- asyncReplayMessages(String, long, long, long, Function1<PersistentRepr, BoxedUnit>) - Method in interface akka.persistence.journal.AsyncWriteProxy
-
- asyncReplayMessages(String, long, long, long, Function1<PersistentRepr, BoxedUnit>) - Method in class akka.persistence.journal.japi.AsyncRecovery
-
- asyncReplayMessages(String, long, long, long, Function1<PersistentRepr, BoxedUnit>) - Method in interface akka.persistence.journal.leveldb.LeveldbRecovery
-
- AsyncReplayTimeoutException - Exception in akka.persistence.journal
-
Thrown if replay inactivity exceeds a specified timeout.
- AsyncReplayTimeoutException(String) - Constructor for exception akka.persistence.journal.AsyncReplayTimeoutException
-
- AsyncWriteJournal - Interface in akka.persistence.journal
-
Abstract journal, optimized for asynchronous, non-blocking writes.
- AsyncWriteJournal - Class in akka.persistence.journal.japi
-
Java API: abstract journal, optimized for asynchronous, non-blocking writes.
- AsyncWriteJournal() - Constructor for class akka.persistence.journal.japi.AsyncWriteJournal
-
- AsyncWriteJournal$ - Class in akka.persistence.journal
-
INTERNAL API.
- AsyncWriteJournal$() - Constructor for class akka.persistence.journal.AsyncWriteJournal$
-
- AsyncWriteJournal.Desequenced - Class in akka.persistence.journal
-
- AsyncWriteJournal.Desequenced$ - Class in akka.persistence.journal
-
- AsyncWriteJournal.Resequencer - Class in akka.persistence.journal
-
- asyncWriteMessages(Seq<PersistentRepr>) - Method in interface akka.persistence.journal.AsyncWriteJournal
-
Plugin API: asynchronously writes a batch of persistent messages to the journal.
- asyncWriteMessages(Seq<PersistentRepr>) - Method in interface akka.persistence.journal.AsyncWriteProxy
-
- asyncWriteMessages(Seq<PersistentRepr>) - Method in class akka.persistence.journal.japi.AsyncWriteJournal
-
- AsyncWriteProxy - Interface in akka.persistence.journal
-
INTERNAL API.
- AsyncWriteProxy$ - Class in akka.persistence.journal
-
INTERNAL API.
- AsyncWriteProxy$() - Constructor for class akka.persistence.journal.AsyncWriteProxy$
-
- AsyncWriteProxy.SetStore - Class in akka.persistence.journal
-
- AsyncWriteProxy.SetStore$ - Class in akka.persistence.journal
-
- AsyncWriteTarget - Class in akka.persistence.journal
-
INTERNAL API.
- AsyncWriteTarget() - Constructor for class akka.persistence.journal.AsyncWriteTarget
-
- AsyncWriteTarget$ - Class in akka.persistence.journal
-
INTERNAL API.
- AsyncWriteTarget$() - Constructor for class akka.persistence.journal.AsyncWriteTarget$
-
- AsyncWriteTarget.DeleteMessagesTo - Class in akka.persistence.journal
-
- AsyncWriteTarget.DeleteMessagesTo$ - Class in akka.persistence.journal
-
- AsyncWriteTarget.ReadHighestSequenceNr - Class in akka.persistence.journal
-
- AsyncWriteTarget.ReadHighestSequenceNr$ - Class in akka.persistence.journal
-
- AsyncWriteTarget.ReplayFailure - Class in akka.persistence.journal
-
- AsyncWriteTarget.ReplayFailure$ - Class in akka.persistence.journal
-
- AsyncWriteTarget.ReplayMessages - Class in akka.persistence.journal
-
- AsyncWriteTarget.ReplayMessages$ - Class in akka.persistence.journal
-
- AsyncWriteTarget.ReplaySuccess$ - Class in akka.persistence.journal
-
- AsyncWriteTarget.WriteMessages - Class in akka.persistence.journal
-
- AsyncWriteTarget.WriteMessages$ - Class in akka.persistence.journal
-
- atFullThrottle() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinPool
-
- atFullThrottle() - Method in interface akka.dispatch.LoadMetrics
-
- atKey(String) - Method in class akka.dispatch.CachingConfig
-
- AtLeastOnceDelivery - Interface in akka.persistence
-
Mix-in this trait with your PersistentActor
to send messages with at-least-once
delivery semantics to destinations.
- atLeastOnceDelivery() - Method in class akka.persistence.PersistenceSettings
-
- atLeastOnceDelivery() - Constructor for class akka.persistence.PersistenceSettings.atLeastOnceDelivery
-
- AtLeastOnceDelivery$ - Class in akka.persistence
-
- AtLeastOnceDelivery$() - Constructor for class akka.persistence.AtLeastOnceDelivery$
-
- AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot - Class in akka.persistence
-
Snapshot of current AtLeastOnceDelivery
state.
- AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot$ - Class in akka.persistence
-
- AtLeastOnceDelivery.Internal$ - Class in akka.persistence
-
- AtLeastOnceDelivery.Internal$.Delivery - Class in akka.persistence
-
- AtLeastOnceDelivery.Internal$.RedeliveryTick - Class in akka.persistence
-
- AtLeastOnceDelivery.MaxUnconfirmedMessagesExceededException - Exception in akka.persistence
-
- AtLeastOnceDelivery.UnconfirmedDelivery - Class in akka.persistence
-
Information about a message that has not been confirmed.
- AtLeastOnceDelivery.UnconfirmedDelivery$ - Class in akka.persistence
-
- AtLeastOnceDelivery.UnconfirmedWarning - Class in akka.persistence
-
- AtLeastOnceDelivery.UnconfirmedWarning$ - Class in akka.persistence
-
- AtLeastOnceDeliverySnapshot(long, Seq<AtLeastOnceDelivery.UnconfirmedDelivery>) - Constructor for class akka.persistence.AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot
-
- atLeastOnceDeliverySnapshot(MessageFormats.AtLeastOnceDeliverySnapshot) - Method in class akka.persistence.serialization.MessageSerializer
-
- AtLeastOnceDeliverySnapshot$() - Constructor for class akka.persistence.AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot$
-
- atLeastOnceDeliverySnapshotBuilder(AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot) - Method in class akka.persistence.serialization.MessageSerializer
-
- AtLeastOnceDeliverySnapshotClass() - Method in class akka.persistence.serialization.MessageSerializer
-
- atPath(String) - Method in class akka.dispatch.CachingConfig
-
- atStartup() - Method in class akka.remote.testkit.MultiNodeSpec
-
Override this method to do something when the whole test is starting up.
- attach(ActorCell) - Method in class akka.dispatch.MessageDispatcher
-
Attaches the specified actor instance to this dispatcher, which includes
scheduling it to run for the first time (Create() is expected to have
been enqueued by the ActorCell upon mailbox creation).
- attach() - Method in class akka.util.SerializedSuspendableExecutionContext
-
- attachChild(Props, boolean) - Method in interface akka.actor.dungeon.Children
-
- attachChild(Props, String, boolean) - Method in interface akka.actor.dungeon.Children
-
- attachConductor(TestConductorExt) - Method in class akka.remote.testkit.MultiNodeSpec
-
- attempt() - Method in class akka.persistence.AtLeastOnceDelivery.Internal$.Delivery
-
- attemptedReconnects() - Method in class akka.contrib.pattern.ReliableProxy
-
- AttemptSysMsgRedelivery$() - Constructor for class akka.remote.ReliableDeliverySupervisor.AttemptSysMsgRedelivery$
-
- augmentScheme(String) - Method in interface akka.remote.transport.SchemeAugmenter
-
- augmentScheme(Address) - Method in interface akka.remote.transport.SchemeAugmenter
-
- AutoAck() - Method in class akka.camel.CamelSettings
-
Configured setting which determines whether one-way communications between an endpoint and this consumer actor
should be auto-acknowledged or application-acknowledged.
- autoAck() - Method in interface akka.camel.Consumer
-
Determines whether one-way communications between an endpoint and this consumer actor
should be auto-acknowledged or application-acknowledged.
- autoAck() - Method in class akka.camel.ConsumerConfig
-
- autoAck() - Method in interface akka.camel.internal.component.ActorEndpointConfig
-
- AutoDown - Class in akka.cluster
-
INTERNAL API
- AutoDown(FiniteDuration) - Constructor for class akka.cluster.AutoDown
-
- AutoDown$ - Class in akka.cluster
-
INTERNAL API
- AutoDown$() - Constructor for class akka.cluster.AutoDown$
-
- AutoDown.UnreachableTimeout - Class in akka.cluster
-
- AutoDown.UnreachableTimeout$ - Class in akka.cluster
-
- AutoDownBase - Class in akka.cluster
-
INTERNAL API
- AutoDownBase(FiniteDuration) - Constructor for class akka.cluster.AutoDownBase
-
- AutoDownUnreachableAfter() - Method in class akka.cluster.ClusterSettings
-
- autopilot() - Method in class akka.testkit.TestActor
-
- AutoPilot() - Constructor for class akka.testkit.TestActor.AutoPilot
-
- AutoReceivedMessage - Interface in akka.actor
-
INTERNAL API
- autoReceiveMessage(Envelope) - Method in class akka.actor.ActorCell
-
- autoResendTimer() - Method in class akka.remote.ReliableDeliverySupervisor
-
- autoUpdate() - Method in class akka.persistence.PersistenceSettings.view
-
- autoUpdate() - Method in interface akka.persistence.PersistentView
-
If true
, this view automatically updates itself with an interval specified by autoUpdateInterval
.
- autoUpdateInterval() - Method in class akka.persistence.PersistenceSettings.view
-
- autoUpdateInterval() - Method in interface akka.persistence.PersistentView
-
The interval for automated updates.
- autoUpdateReplayMax() - Method in class akka.persistence.PersistenceSettings.view
-
- autoUpdateReplayMax() - Method in interface akka.persistence.PersistentView
-
The maximum number of messages to replay per update.
- availableNodes() - Method in interface akka.cluster.routing.ClusterRouterActor
-
- availableTokens() - Method in class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket
-
- average() - Method in class akka.cluster.Metric
-
- average() - Method in class akka.cluster.metrics.Metric
-
- await() - Method in class akka.persistence.Update
-
- await() - Method in class akka.remote.testkit.MultiNodeSpec.AwaitHelper
-
- await(ActorSystem) - Method in class akka.testkit.TestBarrier
-
- await(FiniteDuration, ActorSystem) - Method in class akka.testkit.TestBarrier
-
- AwaitActivation - Class in akka.camel.internal
-
INTERNAL API
A request message to the ActivationTracker for the status of activation.
- AwaitActivation(ActorRef) - Constructor for class akka.camel.internal.AwaitActivation
-
- AwaitActivation$ - Class in akka.camel.internal
-
- AwaitActivation$() - Constructor for class akka.camel.internal.AwaitActivation$
-
- AwaitAssert() - Constructor for class akka.testkit.JavaTestKit.AwaitAssert
-
- AwaitAssert(Duration) - Constructor for class akka.testkit.JavaTestKit.AwaitAssert
-
- AwaitAssert(Duration, Duration) - Constructor for class akka.testkit.JavaTestKit.AwaitAssert
-
- awaitAssert(Function0<Object>, Duration, Duration) - Method in interface akka.testkit.TestKitBase
-
Await until the given assert does not throw an exception or the timeout
expires, whichever comes first.
- AwaitCond() - Constructor for class akka.testkit.JavaTestKit.AwaitCond
-
- AwaitCond(Duration) - Constructor for class akka.testkit.JavaTestKit.AwaitCond
-
- AwaitCond(Duration, Duration) - Constructor for class akka.testkit.JavaTestKit.AwaitCond
-
- AwaitCond(Duration, Duration, String) - Constructor for class akka.testkit.JavaTestKit.AwaitCond
-
- awaitCond(Function0<Object>, Duration, Duration, boolean) - Method in class akka.testkit.TestKit$
-
Await until the given condition evaluates to true
or the timeout
expires, whichever comes first.
- awaitCond(Function0<Object>, Duration, Duration, boolean) - Static method in class akka.testkit.TestKit
-
Await until the given condition evaluates to true
or the timeout
expires, whichever comes first.
- awaitCond(Function0<Object>, Duration, Duration, String) - Method in interface akka.testkit.TestKitBase
-
Await until the given condition evaluates to true
or the timeout
expires, whichever comes first.
- AwaitDeActivation - Class in akka.camel.internal
-
INTERNAL API
A request message to the ActivationTracker for the status of de-activation.
- AwaitDeActivation(ActorRef) - Constructor for class akka.camel.internal.AwaitDeActivation
-
- AwaitDeActivation$ - Class in akka.camel.internal
-
- AwaitDeActivation$() - Constructor for class akka.camel.internal.AwaitDeActivation$
-
- awaitDone(Duration) - Method in class akka.testkit.EventFilter
-
- AwaitDone$() - Constructor for class akka.remote.testconductor.ClientFSM.AwaitDone$
-
- awaitDurationMillis() - Method in class akka.persistence.journal.JournalPerfSpec
-
Override in order to customize timeouts used for expectMsg, in order to tune the awaits to your journal's perf
- awaitHelper(Awaitable<T>) - Method in class akka.remote.testkit.MultiNodeSpec
-
Enrich .await()
onto all Awaitables, using remaining duration from the innermost
enclosing within
block or QueryTimeout.
- AwaitHelper(Awaitable<T>) - Constructor for class akka.remote.testkit.MultiNodeSpec.AwaitHelper
-
- awaitTermination(Duration) - Method in class akka.actor.ActorSystem
-
Block current thread until the system has been shutdown, or the specified
timeout has elapsed.
- awaitTermination() - Method in class akka.actor.ActorSystem
-
Block current thread until the system has been shutdown.
- awaitTermination(Duration) - Method in class akka.actor.ActorSystemImpl
-
- awaitTermination() - Method in class akka.actor.ActorSystemImpl
-
- awaitTermination(long, TimeUnit) - Method in interface akka.dispatch.ExecutorServiceDelegate
-
- c() - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
-
- c() - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
-
- cache() - Method in interface akka.event.SubchannelClassification
-
- cache() - Method in class akka.io.DnsExt
-
- cache() - Method in interface akka.io.DnsProvider
-
- cache() - Method in class akka.io.InetAddressDnsProvider
-
- cache() - Method in class akka.testkit.CachingPartialFunction
-
- cached(String, ActorSystem) - Method in class akka.io.Dns$
-
- cached(String) - Method in class akka.io.Dns
-
- cached(String) - Method in class akka.io.SimpleDnsCache
-
- CachingConfig - Class in akka.dispatch
-
INTERNAL API
- CachingConfig(Config) - Constructor for class akka.dispatch.CachingConfig
-
- cachingConfig() - Method in class akka.dispatch.Dispatchers
-
- CachingConfig$ - Class in akka.dispatch
-
INTERNAL API
- CachingConfig$() - Constructor for class akka.dispatch.CachingConfig$
-
- CachingConfig.PathEntry - Interface in akka.dispatch
-
- CachingConfig.StringPathEntry - Class in akka.dispatch
-
- CachingConfig.StringPathEntry$ - Class in akka.dispatch
-
- CachingConfig.ValuePathEntry - Class in akka.dispatch
-
- CachingConfig.ValuePathEntry$ - Class in akka.dispatch
-
- CachingPartialFunction<A,B> - Class in akka.testkit
-
INTERNAL API
- CachingPartialFunction() - Constructor for class akka.testkit.CachingPartialFunction
-
- callback() - Method in class akka.cluster.InternalClusterAction.AddOnMemberRemovedListener
-
- callback() - Method in class akka.cluster.InternalClusterAction.AddOnMemberUpListener
-
- CallbackBridge() - Constructor for class akka.dispatch.japi.CallbackBridge
-
- CallingThreadDispatcher - Class in akka.testkit
-
Dispatcher which runs invocations on the current thread only.
- CallingThreadDispatcher(MessageDispatcherConfigurator) - Constructor for class akka.testkit.CallingThreadDispatcher
-
- CallingThreadDispatcher$ - Class in akka.testkit
-
- CallingThreadDispatcher$() - Constructor for class akka.testkit.CallingThreadDispatcher$
-
- CallingThreadDispatcherConfigurator - Class in akka.testkit
-
- CallingThreadDispatcherConfigurator(Config, DispatcherPrerequisites) - Constructor for class akka.testkit.CallingThreadDispatcherConfigurator
-
- CallingThreadDispatcherQueues - Class in akka.testkit
-
- CallingThreadDispatcherQueues() - Constructor for class akka.testkit.CallingThreadDispatcherQueues
-
- CallingThreadDispatcherQueues$ - Class in akka.testkit
-
- CallingThreadDispatcherQueues$() - Constructor for class akka.testkit.CallingThreadDispatcherQueues$
-
- CallingThreadMailbox - Class in akka.testkit
-
- CallingThreadMailbox(Cell, MailboxType) - Constructor for class akka.testkit.CallingThreadMailbox
-
- callsLeftInThisPeriod() - Method in class akka.contrib.throttle.TimerBasedThrottler.Data
-
- callWithCircuitBreaker(Callable<Future<T>>) - Method in class akka.pattern.CircuitBreaker
-
- callWithSyncCircuitBreaker(Callable<T>) - Method in class akka.pattern.CircuitBreaker
-
- Camel - Interface in akka.camel
-
Camel trait encapsulates the underlying camel machinery.
- camel() - Method in interface akka.camel.CamelSupport
-
INTERNAL API
Returns a
Camel
trait which provides access to the CamelExtension.
- camel() - Method in class akka.camel.internal.component.ActorEndpoint
-
- camel() - Method in interface akka.camel.internal.component.ActorEndpointConfig
-
- camelContext() - Method in interface akka.camel.CamelSupport
-
Returns the CamelContext.
- CamelExchangeAdapter - Class in akka.camel.internal
-
- CamelExchangeAdapter(Exchange) - Constructor for class akka.camel.internal.CamelExchangeAdapter
-
- CamelExtension - Class in akka.camel
-
This class can be used to get hold of an instance of the Camel class bound to the actor system.
- CamelExtension() - Constructor for class akka.camel.CamelExtension
-
- CamelExtension$ - Class in akka.camel
-
This class can be used to get hold of an instance of the Camel class bound to the actor system.
- CamelExtension$() - Constructor for class akka.camel.CamelExtension$
-
- CamelMessage - Class in akka.camel
-
An immutable representation of a Camel message.
- CamelMessage(Object, Map<String, Object>) - Constructor for class akka.camel.CamelMessage
-
- CamelMessage(Object, Map<String, Object>) - Constructor for class akka.camel.CamelMessage
-
- CamelMessage$ - Class in akka.camel
-
Companion object of CamelMessage class.
- CamelMessage$() - Constructor for class akka.camel.CamelMessage$
-
- CamelPath - Class in akka.camel.internal.component
-
Converts ActorRefs and actorPaths to URI's that point to the actor through the Camel Actor Component.
- CamelPath() - Constructor for class akka.camel.internal.component.CamelPath
-
- CamelPath$ - Class in akka.camel.internal.component
-
Converts ActorRefs and actorPaths to URI's that point to the actor through the Camel Actor Component.
- CamelPath$() - Constructor for class akka.camel.internal.component.CamelPath$
-
- CamelProducerObjects(Endpoint, SendProcessor) - Constructor for class akka.camel.internal.CamelSupervisor.CamelProducerObjects
-
- CamelProducerObjects$() - Constructor for class akka.camel.internal.CamelSupervisor.CamelProducerObjects$
-
- CamelSettings - Class in akka.camel
-
Settings for the Camel Extension
param: config the config
- CamelSettings(Config, DynamicAccess) - Constructor for class akka.camel.CamelSettings
-
- CamelSupervisor - Class in akka.camel.internal
-
INTERNAL API
Top level supervisor for internal Camel actors
- CamelSupervisor() - Constructor for class akka.camel.internal.CamelSupervisor
-
- CamelSupervisor$ - Class in akka.camel.internal
-
INTERNAL API
Messages for the camel supervisor, registrations and de-registrations.
- CamelSupervisor$() - Constructor for class akka.camel.internal.CamelSupervisor$
-
- CamelSupervisor.AddWatch - Class in akka.camel.internal
-
INTERNAL API
Adds a watch for the actor
- CamelSupervisor.AddWatch$ - Class in akka.camel.internal
-
- CamelSupervisor.CamelProducerObjects - Class in akka.camel.internal
-
INTERNAL API
Provides a Producer with the required camel objects to function.
- CamelSupervisor.CamelProducerObjects$ - Class in akka.camel.internal
-
- CamelSupervisor.CamelSupervisorMessage - Interface in akka.camel.internal
-
- CamelSupervisor.DeRegister - Class in akka.camel.internal
-
INTERNAL API
De-registers a producer or a consumer.
- CamelSupervisor.DeRegister$ - Class in akka.camel.internal
-
- CamelSupervisor.Register - Class in akka.camel.internal
-
INTERNAL API
Registers a consumer or a producer.
- CamelSupervisor.Register$ - Class in akka.camel.internal
-
- CamelSupport - Interface in akka.camel
-
- canBeScheduledForExecution(boolean, boolean) - Method in class akka.dispatch.Mailbox
-
- canBuildFrom() - Method in class akka.util.ByteString$
-
- canBuildFrom() - Static method in class akka.util.ByteString
-
- cancel() - Method in interface akka.actor.Cancellable
-
Cancels this Cancellable and returns true if that was successful.
- cancel() - Method in class akka.actor.FSM.Timer
-
- cancel() - Method in class akka.actor.LightArrayRevolverScheduler.TaskHolder
-
- Cancellable - Interface in akka.actor
-
Signifies something that can be cancelled
There is no strict guarantee that the implementation is thread-safe,
but it should be good practice to make it so.
- cancelReceiveTimeout() - Method in interface akka.actor.dungeon.ReceiveTimeout
-
- cancelTimer(String) - Method in interface akka.actor.FSM
-
- cancelTimer() - Method in class akka.cluster.singleton.ClusterSingletonProxy
-
- cancelTimer(String) - Method in class akka.testkit.TestFSMRef
-
- canonicalize(Object) - Method in class akka.camel.CamelMessage$
-
Creates a canonical form of the given message msg
.
- canonicalize(Object) - Static method in class akka.camel.CamelMessage
-
Creates a canonical form of the given message msg
.
- canonicalize(ActorContext<T>, Behavior<T>, Behavior<T>) - Method in class akka.typed.Behavior$
-
Given a possibly special behavior (same or unhandled) and a
“current” behavior (which defines the meaning of encountering a Same
behavior) this method unwraps the behavior such that the innermost behavior
is returned, i.e.
- canonicalize(ActorContext<T>, Behavior<T>, Behavior<T>) - Static method in class akka.typed.Behavior
-
Given a possibly special behavior (same or unhandled) and a
“current” behavior (which defines the meaning of encountering a Same
behavior) this method unwraps the behavior such that the innermost behavior
is returned, i.e.
- capacity() - Method in interface akka.actor.StashSupport
-
- capacity(Set<NodeMetrics>) - Method in class akka.cluster.metrics.CapacityMetricsSelector
-
Remaining capacity for each node.
- capacity(Set<NodeMetrics>) - Method in class akka.cluster.metrics.CpuMetricsSelector$
-
- capacity(Set<NodeMetrics>) - Static method in class akka.cluster.metrics.CpuMetricsSelector
-
- capacity(Set<NodeMetrics>) - Method in class akka.cluster.metrics.HeapMetricsSelector$
-
- capacity(Set<NodeMetrics>) - Static method in class akka.cluster.metrics.HeapMetricsSelector
-
- capacity(Set<NodeMetrics>) - Method in class akka.cluster.metrics.MixMetricsSelectorBase
-
- capacity(Set<NodeMetrics>) - Method in class akka.cluster.metrics.SystemLoadAverageMetricsSelector$
-
- capacity(Set<NodeMetrics>) - Static method in class akka.cluster.metrics.SystemLoadAverageMetricsSelector
-
- capacity(Set<NodeMetrics>) - Method in class akka.cluster.routing.CapacityMetricsSelector
-
Remaining capacity for each node.
- capacity(Set<NodeMetrics>) - Method in class akka.cluster.routing.CpuMetricsSelector$
-
- capacity(Set<NodeMetrics>) - Static method in class akka.cluster.routing.CpuMetricsSelector
-
- capacity(Set<NodeMetrics>) - Method in class akka.cluster.routing.HeapMetricsSelector$
-
- capacity(Set<NodeMetrics>) - Static method in class akka.cluster.routing.HeapMetricsSelector
-
- capacity(Set<NodeMetrics>) - Method in class akka.cluster.routing.MixMetricsSelectorBase
-
- capacity(Set<NodeMetrics>) - Method in class akka.cluster.routing.SystemLoadAverageMetricsSelector$
-
- capacity(Set<NodeMetrics>) - Static method in class akka.cluster.routing.SystemLoadAverageMetricsSelector
-
- capacity() - Method in class akka.dispatch.AbstractBoundedNodeQueue
-
- capacity() - Method in class akka.dispatch.BoundedControlAwareMailbox
-
- capacity() - Method in class akka.dispatch.BoundedControlAwareMailbox.MessageQueue
-
- capacity() - Method in class akka.dispatch.BoundedDequeBasedMailbox
-
- capacity() - Method in class akka.dispatch.BoundedMailbox
-
- capacity() - Method in class akka.dispatch.BoundedPriorityMailbox
-
- capacity() - Method in class akka.dispatch.BoundedStablePriorityMailbox
-
- capacity() - Method in class akka.dispatch.NonBlockingBoundedMailbox
-
- capacity() - Method in class akka.remote.AckedSendBuffer
-
- capacity() - Method in class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket
-
- capacity(IndexedSeq<Routee>) - Method in class akka.routing.DefaultResizer
-
Returns the overall desired change in resizer capacity.
- CapacityMetricsSelector - Class in akka.cluster.metrics
-
A MetricsSelector producing weights from remaining capacity.
- CapacityMetricsSelector() - Constructor for class akka.cluster.metrics.CapacityMetricsSelector
-
- CapacityMetricsSelector - Class in akka.cluster.routing
-
A MetricsSelector producing weights from remaining capacity.
- CapacityMetricsSelector() - Constructor for class akka.cluster.routing.CapacityMetricsSelector
-
- CaseStatement<F,P,T> - Class in akka.japi.pf
-
- CaseStatement(FI.Predicate, FI.Apply<P, T>) - Constructor for class akka.japi.pf.CaseStatement
-
- CaseStatement$ - Class in akka.japi.pf
-
- CaseStatement$() - Constructor for class akka.japi.pf.CaseStatement$
-
- cause() - Method in class akka.actor.dungeon.ChildrenContainer.Recreation
-
- cause() - Method in class akka.actor.FSM.Failure
-
- cause() - Method in exception akka.actor.PostRestartException
-
- cause() - Method in exception akka.actor.PreRestartException
-
- cause() - Method in class akka.actor.Status.Failure
-
- cause() - Method in class akka.camel.FailureResult
-
- cause() - Method in class akka.camel.internal.ActivationProtocol.EndpointFailedToActivate
-
- cause() - Method in class akka.camel.internal.ActivationProtocol.EndpointFailedToDeActivate
-
- cause() - Method in class akka.dispatch.sysmsg.Failed
-
- cause() - Method in class akka.dispatch.sysmsg.Recreate
-
- cause() - Method in class akka.event.Logging.Error
-
- cause() - Method in class akka.io.Tcp.ErrorClosed
-
- cause() - Method in class akka.persistence.journal.AsyncWriteTarget.ReplayFailure
-
- cause() - Method in class akka.persistence.JournalProtocol.DeleteMessagesFailure
-
- cause() - Method in class akka.persistence.JournalProtocol.ReadHighestSequenceNrFailure
-
- cause() - Method in class akka.persistence.JournalProtocol.ReplayMessagesFailure
-
- cause() - Method in class akka.persistence.JournalProtocol.WriteMessageFailure
-
- cause() - Method in class akka.persistence.JournalProtocol.WriteMessagesFailed
-
- cause() - Method in class akka.persistence.PersistenceFailure
-
- cause() - Method in class akka.persistence.RecoveryFailure
-
- cause() - Method in class akka.persistence.SaveSnapshotFailure
-
- cause() - Method in class akka.remote.AssociationErrorEvent
-
- cause() - Method in class akka.remote.EndpointManager.ListensFailure
-
- cause() - Method in exception akka.remote.HopelessAssociation
-
- cause() - Method in exception akka.remote.InvalidAssociation
-
- cause() - Method in class akka.remote.RemotingErrorEvent
-
- cause() - Method in exception akka.remote.ShutDownAssociation
-
- cause() - Method in exception akka.remote.transport.Transport.InvalidAssociationException
-
- cause() - Method in class akka.typed.Failed
-
- causedByFailure() - Method in class akka.dispatch.sysmsg.Resume
-
- Cell - Interface in akka.actor
-
INTERNAL API
- cell() - Method in class akka.routing.RouterActor
-
- change() - Method in class akka.routing.AdjustPoolSize
-
- changeMembers(SortedSet<Member>) - Method in class akka.cluster.sharding.ShardRegion
-
- changeState(Eventsourced.State) - Method in interface akka.persistence.Eventsourced
-
- changeState(PersistentView.State) - Method in interface akka.persistence.PersistentView
-
- channel() - Method in class akka.io.TcpConnection
-
- channel() - Method in class akka.io.TcpListener
-
- channel() - Method in class akka.io.TcpListener.FailedRegisterIncoming
-
- channel() - Method in class akka.io.TcpListener.RegisterIncoming
-
- channel() - Method in class akka.io.UdpConnection
-
- channel() - Method in class akka.io.UdpListener
-
- channel() - Method in class akka.io.UdpSender
-
- channel() - Method in interface akka.io.WithUdpSend
-
- channel() - Method in class akka.remote.testconductor.ClientFSM.Connected
-
- channel() - Method in class akka.remote.testconductor.ClientFSM.Data
-
- channel() - Method in class akka.remote.testconductor.Controller.CreateServerFSM
-
- channel() - Method in class akka.remote.testconductor.ServerFSM
-
- ChannelAcceptable$() - Constructor for class akka.io.SelectionHandler.ChannelAcceptable$
-
- channelBound(ChannelHandlerContext, ChannelStateEvent) - Method in class akka.remote.testconductor.PlayerHandler
-
- channelClosed(ChannelHandlerContext, ChannelStateEvent) - Method in class akka.remote.testconductor.PlayerHandler
-
- ChannelConnectable$() - Constructor for class akka.io.SelectionHandler.ChannelConnectable$
-
- channelConnected(ChannelHandlerContext, ChannelStateEvent) - Method in class akka.remote.testconductor.ConductorHandler
-
- channelConnected(ChannelHandlerContext, ChannelStateEvent) - Method in class akka.remote.testconductor.PlayerHandler
-
- channelConnected(ChannelHandlerContext, ChannelStateEvent) - Method in interface akka.remote.transport.netty.NettyClientHelpers
-
- channelConnected(ChannelHandlerContext, ChannelStateEvent) - Method in interface akka.remote.transport.netty.NettyServerHelpers
-
- channelDisconnected(ChannelHandlerContext, ChannelStateEvent) - Method in class akka.remote.testconductor.ConductorHandler
-
- channelDisconnected(ChannelHandlerContext, ChannelStateEvent) - Method in class akka.remote.testconductor.PlayerHandler
-
- channelDisconnected(ChannelHandlerContext, ChannelStateEvent) - Method in interface akka.remote.transport.netty.NettyClientHelpers
-
- channelDisconnected(ChannelHandlerContext, ChannelStateEvent) - Method in interface akka.remote.transport.netty.NettyServerHelpers
-
- channelGroup() - Method in class akka.remote.transport.netty.NettyTransport
-
- ChannelLocalActor - Class in akka.remote.transport.netty
-
INTERNAL API
- ChannelLocalActor() - Constructor for class akka.remote.transport.netty.ChannelLocalActor
-
- ChannelLocalActor$ - Class in akka.remote.transport.netty
-
INTERNAL API
- ChannelLocalActor$() - Constructor for class akka.remote.transport.netty.ChannelLocalActor$
-
- channelOpen(ChannelHandlerContext, ChannelStateEvent) - Method in class akka.remote.testconductor.PlayerHandler
-
- channelOpen(ChannelHandlerContext, ChannelStateEvent) - Method in interface akka.remote.transport.netty.NettyClientHelpers
-
- channelOpen(ChannelHandlerContext, ChannelStateEvent) - Method in interface akka.remote.transport.netty.NettyServerHelpers
-
- ChannelReadable$() - Constructor for class akka.io.SelectionHandler.ChannelReadable$
-
- ChannelRegistration - Interface in akka.io
-
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 in akka.io
-
Interface behind which we hide our selector management logic from the connection actors
- channelUnbound(ChannelHandlerContext, ChannelStateEvent) - Method in class akka.remote.testconductor.PlayerHandler
-
- ChannelWritable$() - Constructor for class akka.io.SelectionHandler.ChannelWritable$
-
- chaosMode(Address) - Method in class akka.remote.transport.FailureInjectorTransportAdapter
-
- check() - Method in class akka.testkit.JavaTestKit.AwaitAssert
-
- checkedApply(T) - Method in class akka.dispatch.Mapper
-
Override this method if you need to throw checked exceptions
- Checkin(Address, ThrottlerHandle) - Constructor for class akka.remote.transport.ThrottlerManager.Checkin
-
- Checkin$() - Constructor for class akka.remote.transport.ThrottlerManager.Checkin$
-
- checkMissingAndUnexpected(Seq<Object>, Seq<Object>, String, String) - Method in interface akka.testkit.TestKitBase
-
- checkName(String) - Method in interface akka.actor.dungeon.Children
-
- checkReceiveTimeout() - Method in interface akka.actor.dungeon.ReceiveTimeout
-
- checkValid(Config, Seq<String>) - Method in class akka.dispatch.CachingConfig
-
- checkValid(Config, String[]) - Method in class akka.dispatch.CachingConfig
-
- child(String) - Method in interface akka.actor.ActorContext
-
Get the child with the given name if it exists.
- child(String) - Method in class akka.actor.ActorPath
-
Java API: Create a new child actor path.
- child(String) - Method in class akka.actor.ActorSystem
-
Java API: Create a new child actor path.
- child() - Method in class akka.actor.ChildRestartStats
-
- child(String) - Method in interface akka.actor.dungeon.Children
-
- child() - Method in class akka.actor.StopChild
-
- child() - Method in class akka.dispatch.sysmsg.Failed
-
- child() - Method in class akka.dispatch.sysmsg.Supervise
-
- child(String) - Method in interface akka.typed.ActorContext
-
The named child Actor if it is alive.
- child(String) - Method in class akka.typed.ActorContextAdapter
-
- child() - Method in class akka.typed.Failed
-
- child(String) - Method in class akka.typed.StubbedActorContext
-
- CHILD_NAME_VALUE - Static variable in enum akka.remote.ContainerFormats.PatternType
-
CHILD_NAME = 1;
- CHILD_PATTERN_VALUE - Static variable in enum akka.remote.ContainerFormats.PatternType
-
CHILD_PATTERN = 2;
- ChildActorPath - Class in akka.actor
-
- ChildActorPath(ActorPath, String, int) - Constructor for class akka.actor.ChildActorPath
-
- ChildActorPath(ActorPath, String) - Constructor for class akka.actor.ChildActorPath
-
- childName() - Method in class akka.typed.Effect.Spawned
-
- childName() - Method in class akka.typed.Effect.Stopped
-
- ChildNameReserved - Class in akka.actor
-
INTERNAL API
- ChildNameReserved() - Constructor for class akka.actor.ChildNameReserved
-
- ChildNameReserved$ - Class in akka.actor
-
INTERNAL API
- ChildNameReserved$() - Constructor for class akka.actor.ChildNameReserved$
-
- childProps() - Method in class akka.io.SelectionHandler.WorkerForCommand
-
- children() - Method in interface akka.actor.ActorContext
-
Returns all supervised children; this method returns a view (i.e.
- children() - Method in class akka.actor.ActorRefWithCell
-
- Children - Interface in akka.actor.dungeon
-
- children() - Method in interface akka.actor.dungeon.Children
-
- children() - Method in interface akka.actor.dungeon.ChildrenContainer
-
- children() - Method in interface akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer
-
- children() - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
-
- children() - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
-
- children() - Method in class akka.actor.LocalActorRef
-
- children() - Method in class akka.actor.RepointableActorRef
-
- children() - Method in interface akka.typed.ActorContext
-
The list of child Actors created by this Actor during its lifetime that
are still alive, in no particular order.
- children() - Method in class akka.typed.ActorContextAdapter
-
- children() - Method in class akka.typed.StubbedActorContext
-
- children() - Method in class akka.util.WildcardTree
-
- ChildrenContainer - Interface in akka.actor.dungeon
-
INTERNAL API
- ChildrenContainer$ - Class in akka.actor.dungeon
-
INTERNAL API
- ChildrenContainer$() - Constructor for class akka.actor.dungeon.ChildrenContainer$
-
- ChildrenContainer.ChildrenIterable - Class in akka.actor.dungeon
-
- ChildrenContainer.ChildRestartsIterable - Class in akka.actor.dungeon
-
- ChildrenContainer.Creation - Class in akka.actor.dungeon
-
- ChildrenContainer.Creation$ - Class in akka.actor.dungeon
-
- ChildrenContainer.EmptyChildrenContainer - Interface in akka.actor.dungeon
-
- ChildrenContainer.EmptyChildrenContainer$ - Class in akka.actor.dungeon
-
This is the empty container, shared among all leaf actors.
- ChildrenContainer.NormalChildrenContainer - Class in akka.actor.dungeon
-
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$ - Class in akka.actor.dungeon
-
- ChildrenContainer.Recreation - Class in akka.actor.dungeon
-
- ChildrenContainer.Recreation$ - Class in akka.actor.dungeon
-
- ChildrenContainer.SuspendReason - Interface in akka.actor.dungeon
-
- ChildrenContainer.TerminatedChildrenContainer$ - Class in akka.actor.dungeon
-
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 - Class in akka.actor.dungeon
-
Waiting state: there are outstanding termination requests (i.e.
- ChildrenContainer.TerminatingChildrenContainer$ - Class in akka.actor.dungeon
-
- ChildrenContainer.Termination$ - Class in akka.actor.dungeon
-
- ChildrenContainer.UserRequest$ - Class in akka.actor.dungeon
-
- ChildrenContainer.WaitingForChildren - Interface in akka.actor.dungeon
-
- ChildrenIterable(MapLike<?, ChildStats, ?>) - Constructor for class akka.actor.dungeon.ChildrenContainer.ChildrenIterable
-
- childrenRefs() - Method in interface akka.actor.Cell
-
All children of this actor, including only reserved-names.
- childrenRefs() - Method in interface akka.actor.dungeon.Children
-
- childrenRefs() - Method in class akka.actor.UnstartedCell
-
- ChildRestartsIterable(MapLike<?, ChildStats, ?>) - Constructor for class akka.actor.dungeon.ChildrenContainer.ChildRestartsIterable
-
- ChildRestartStats - Class in akka.actor
-
ChildRestartStats is the statistics kept by every parent Actor for every child Actor
and is used for SupervisorStrategies to know how to deal with problems that occur for the children.
- ChildRestartStats(ActorRef, int, long) - Constructor for class akka.actor.ChildRestartStats
-
- ChildRestartStats$ - Class in akka.actor
-
- ChildRestartStats$() - Constructor for class akka.actor.ChildRestartStats$
-
- ChildStats - Interface in akka.actor
-
INTERNAL API
- CircuitBreaker - Class in akka.pattern
-
Provides circuit breaker functionality to provide stability when working with "dangerous" operations, e.g.
- CircuitBreaker(Scheduler, int, FiniteDuration, FiniteDuration, ExecutionContext) - Constructor for class akka.pattern.CircuitBreaker
-
- CircuitBreaker(ExecutionContext, Scheduler, int, FiniteDuration, FiniteDuration) - Constructor for class akka.pattern.CircuitBreaker
-
- CircuitBreaker$ - Class in akka.pattern
-
Companion object providing factory methods for Circuit Breaker which runs callbacks in caller's thread
- CircuitBreaker$() - Constructor for class akka.pattern.CircuitBreaker$
-
- CircuitBreakerOpenException - Exception in akka.pattern
-
Exception thrown when Circuit Breaker is open.
- CircuitBreakerOpenException(FiniteDuration, String) - Constructor for exception akka.pattern.CircuitBreakerOpenException
-
- CircuitBreakerOpenException$ - Class in akka.pattern
-
- CircuitBreakerOpenException$() - Constructor for class akka.pattern.CircuitBreakerOpenException$
-
- CLASSES_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.PropsData
-
- classFor(Logging.LogLevel) - Method in class akka.event.Logging$
-
Returns the event class associated with the given LogLevel
- classFor(Logging.LogLevel) - Static method in class akka.event.Logging
-
Returns the event class associated with the given LogLevel
- classify(ActorClassification) - Method in interface akka.event.ActorClassification
-
Returns the Classifier associated with the specified Event
- classify(Object) - Method in class akka.event.EventStream
-
- classify(E) - Method in class akka.event.japi.ActorEventBus
-
Returns the Classifier associated with the given Event
- classify(E) - Method in class akka.event.japi.LookupEventBus
-
Returns the Classifier associated with the given Event
- classify(E) - Method in class akka.event.japi.ManagedActorEventBus
-
Returns the Classifier associated with the given Event
- classify(E) - Method in class akka.event.japi.SubchannelEventBus
-
Returns the Classifier associated with the given Event
- classify(LookupClassification) - Method in interface akka.event.LookupClassification
-
Returns the Classifier associated with the given Event
- classify(ManagedActorClassification) - Method in interface akka.event.ManagedActorClassification
-
Returns the Classifier associated with the specified Event
- classify(SubchannelClassification) - Method in interface akka.event.SubchannelClassification
-
Returns the Classifier associated with the given Event
- classLoader() - Method in class akka.actor.DynamicAccess
-
This is the class loader to be used in those special cases where the
other factory method are not applicable (e.g.
- classLoader() - Method in class akka.actor.ReflectiveDynamicAccess
-
- ClassLoaderObjectInputStream - Class in akka.util
-
ClassLoaderObjectInputStream tries to utilize the provided ClassLoader to load Classes and falls
back to ObjectInputStreams resolver.
- ClassLoaderObjectInputStream(ClassLoader, InputStream) - Constructor for class akka.util.ClassLoaderObjectInputStream
-
- classTag(Class<T>) - Method in class akka.japi.Util$
-
Returns a ClassTag describing the provided Class.
- classTag(Class<T>) - Static method in class akka.japi.Util
-
Returns a ClassTag describing the provided Class.
- clazz(Object) - Method in class akka.actor.ActorCell
-
- clazz() - Method in class akka.actor.Props
-
- CLAZZ_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.PropsData
-
- cleanUp(ActorRef, MessageQueue) - Method in class akka.contrib.mailbox.PeekMailbox
-
- cleanUp(ActorRef, MessageQueue) - Method in class akka.dispatch.BoundedNodeMessageQueue
-
- cleanUp() - Method in class akka.dispatch.Mailbox
-
Overridable callback to clean up the mailbox,
called when an actor is unregistered.
- cleanUp(ActorRef, MessageQueue) - Method in interface akka.dispatch.MessageQueue
-
Called when the mailbox this queue belongs to is disposed of.
- cleanUp(ActorRef, MessageQueue) - Method in class akka.dispatch.NodeMessageQueue
-
- cleanUp(ActorRef, MessageQueue) - Method in interface akka.dispatch.QueueBasedMessageQueue
-
- cleanup() - Method in class akka.dispatch.TaskInvocation
-
- cleanup() - Method in interface akka.io.PeriodicCacheCleanup
-
- cleanup() - Method in class akka.io.SimpleDnsCache
-
- cleanUp() - Method in class akka.testkit.CallingThreadMailbox
-
- cleanupOverdueNotMemberAnyMore() - Method in class akka.cluster.singleton.ClusterSingletonManager
-
- clear() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
- clear() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
- clear() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
- clear() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
- clear() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA.Builder
-
- clear() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
- clear() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number.Builder
-
- clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
- clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty.Builder
-
- clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
- clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
- clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
- clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
- clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
-
- clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
- clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
- clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
- clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
- clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
-
- clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
- clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
-
- clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
- clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
-
- clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
-
- clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
- clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
-
- clear() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
-
- clear() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
- clear() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
- clear() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Builder
-
- clear() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
- clear() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload.Builder
-
- clear() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish.Builder
-
- clear() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
- clear() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
-
- clear() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
- clear() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
-
- clear() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
- clear() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
- clear() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
- clear() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
-
- clear() - Method in class akka.remote.ContainerFormats.Selection.Builder
-
- clear() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
- clear() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
- clear() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
-
- clear() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
-
- clear() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
-
- clear() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
- clear() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
- clear() - Method in class akka.remote.transport.AssociationRegistry$
-
- clear() - Static method in class akka.remote.transport.AssociationRegistry
-
- clear() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
- clear() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
-
- clear() - Method in class akka.remote.WireFormats.ActorRefData.Builder
-
- clear() - Method in class akka.remote.WireFormats.AddressData.Builder
-
- clear() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
-
- clear() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
- clear() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
-
- clear() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
- clear() - Method in class akka.remote.WireFormats.DeployData.Builder
-
- clear() - Method in class akka.remote.WireFormats.PropsData.Builder
-
- clear() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
- clear() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
-
- clear() - Method in class akka.util.BoundedBlockingQueue
-
- clear() - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- clear() - Method in class akka.util.ByteIterator
-
- clear() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- clear() - Method in class akka.util.ByteStringBuilder
-
- clear() - Method in class akka.util.Index
-
Removes all keys and all values
- clearAck() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
optional .AcknowledgementInfo ack = 1;
- clearActorCellFields(ActorCell) - Method in class akka.actor.ActorCell
-
- clearActorFields(Actor) - Method in class akka.actor.ActorCell
-
- clearAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
-
optional .Address addr = 2;
- clearAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .AddressRequest addr = 5;
- clearAddress() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
-
required .Address address = 1;
- clearAddress() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
-
required .Address address = 1;
- clearAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
-
required .Address address = 2;
- clearAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
optional .Address address = 3;
- clearAddressIndex() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
required int32 addressIndex = 1;
- clearAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
required int32 addressIndex = 1;
- clearAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
required int32 addressIndex = 1;
- clearAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
required int32 addressIndex = 1;
- clearAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
-
required int32 addressIndex = 1;
- clearAllAddresses() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- clearAllAddresses() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .UniqueAddress allAddresses = 1;
- clearAllAddresses() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- clearAllButSelf() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
-
required bool allButSelf = 2;
- clearAllHashes() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated string allHashes = 3;
- clearAllHashes() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
repeated string allHashes = 2;
- clearAllMetricNames() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated string allMetricNames = 2;
- clearAllMetricNames() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated string allMetricNames = 2;
- clearAllRoles() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated string allRoles = 2;
- clearAlpha() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA.Builder
-
required double alpha = 2;
- clearAlpha() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
-
required double alpha = 2;
- clearArgs() - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated bytes args = 4;
- clearBarrier() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .EnterBarrier barrier = 2;
- clearBuckets() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Builder
-
repeated .Delta.Bucket buckets = 1;
- clearClasses() - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated string classes = 5;
- clearClazz() - Method in class akka.remote.WireFormats.PropsData.Builder
-
required string clazz = 3;
- clearCommandType() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
-
required .CommandType commandType = 1;
- clearConfig() - Method in class akka.remote.WireFormats.DeployData.Builder
-
optional bytes config = 2;
- clearContent() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
repeated .Delta.Entry content = 3;
- clearCookie() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
optional string cookie = 3;
- clearCumulativeAck() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
-
required fixed64 cumulativeAck = 1;
- clearCurrentDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
required int64 currentDeliveryId = 1;
- clearDeleted() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional bool deleted = 4;
- clearDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
required int64 deliveryId = 1;
- clearDeploy() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required .DeployData deploy = 2;
- clearDeploy() - Method in class akka.remote.WireFormats.PropsData.Builder
-
required .DeployData deploy = 2;
- clearDestination() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
required string destination = 2;
- clearDirection() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
optional .Direction direction = 2;
- clearDispatcher() - Method in class akka.remote.WireFormats.DeployData.Builder
-
optional string dispatcher = 5;
- clearDone() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional string done = 4;
- clearedList() - Method in class akka.util.ByteIterator.MultiByteArrayIterator$
-
- clearEnclosedMessage() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload.Builder
-
required bytes enclosedMessage = 1;
- clearEnclosedMessage() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
required bytes enclosedMessage = 1;
- clearEnvelope() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
optional .RemoteEnvelope envelope = 2;
- clearEwma() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
optional .NodeMetrics.EWMA ewma = 3;
- clearEwma() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
optional .NodeMetrics.EWMA ewma = 3;
- clearExitValue() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
optional int32 exitValue = 7;
- clearFailed() - Method in interface akka.actor.dungeon.FaultHandling
-
- clearFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
required .FailType failure = 1;
- clearFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .InjectFailure failure = 3;
- clearFrom() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
required .Address from = 1;
- clearFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
required .UniqueAddress from = 1;
- clearFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
required .UniqueAddress from = 1;
- clearFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
required .Address from = 1;
- clearFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
-
required .UniqueAddress from = 1;
- clearGossip() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
required .MetricsGossip gossip = 2;
- clearGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
required .MetricsGossip gossip = 2;
- clearGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
-
required .Gossip gossip = 2;
- clearHandshakeInfo() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
-
optional .AkkaHandshakeInfo handshakeInfo = 2;
- clearHashIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
-
required int32 hashIndex = 1;
- clearHello() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .Hello hello = 1;
- clearHost() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
required string host = 3;
- clearHostname() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
required string hostname = 2;
- clearHostname() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
required string hostname = 2;
- clearHostname() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
required string hostname = 2;
- clearHostname() - Method in class akka.remote.WireFormats.AddressData.Builder
-
required string hostname = 2;
- clearInstruction() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
-
optional .AkkaControlMessage instruction = 2;
- clearKey() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
required string key = 1;
- clearLocalAffinity() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
required bool localAffinity = 2;
- clearLog() - Method in class akka.remote.transport.TestTransport.AssociationRegistry
-
Clears the activity log.
- clearMatcher() - Method in class akka.remote.ContainerFormats.Selection.Builder
-
optional string matcher = 2;
- clearMDC() - Method in interface akka.event.DiagnosticLoggingAdapter
-
Clear all entries in the MDC
- clearMembers() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .Member members = 4;
- clearMessage() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
required .SerializedMessage message = 2;
- clearMessage() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
-
required bytes message = 1;
- clearMessageManifest() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload.Builder
-
optional bytes messageManifest = 4;
- clearMessageManifest() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
optional bytes messageManifest = 4;
- clearMessageManifest() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
-
optional bytes messageManifest = 3;
- clearMetrics() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- clearMetrics() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- clearNacks() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
-
repeated fixed64 nacks = 2;
- clearName() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
-
required string name = 1;
- clearName() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
-
required string name = 1;
- clearNameIndex() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
required int32 nameIndex = 1;
- clearNameIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
required int32 nameIndex = 1;
- clearNode() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
-
required .UniqueAddress node = 1;
- clearNode() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
-
required string node = 1;
- clearNodeMetrics() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- clearNodeMetrics() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- clearNumber() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
required .NodeMetrics.Number number = 2;
- clearNumber() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
required .NodeMetrics.Number number = 2;
- clearObserverReachability() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated .ObserverReachability observerReachability = 2;
- clearOp() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
-
required .BarrierOp op = 2;
- clearOrigin() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
required .AddressData origin = 1;
- clearOverview() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
required .GossipOverview overview = 5;
- clearOwner() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
required .Address owner = 1;
- clearPath() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
required string path = 1;
- clearPath() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
-
required string path = 1;
- clearPath() - Method in class akka.remote.WireFormats.ActorRefData.Builder
-
required string path = 1;
- clearPath() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required string path = 3;
- clearPath() - Method in class akka.remote.WireFormats.DeployData.Builder
-
required string path = 1;
- clearPattern() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
repeated .Selection pattern = 3;
- clearPayload() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish.Builder
-
required .Payload payload = 3;
- clearPayload() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
required .Payload payload = 3;
- clearPayload() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
-
required .Payload payload = 3;
- clearPayload() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
required .PersistentPayload payload = 3;
- clearPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional .PersistentPayload payload = 1;
- clearPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
-
required bytes payload = 2;
- clearPayload() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
-
optional bytes payload = 1;
- clearPayloadManifest() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
-
optional bytes payloadManifest = 3;
- clearPersistenceId() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional string persistenceId = 3;
- clearPort() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
required uint32 port = 3;
- clearPort() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
required uint32 port = 3;
- clearPort() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
required uint32 port = 3;
- clearPort() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
required int32 port = 4;
- clearPort() - Method in class akka.remote.WireFormats.AddressData.Builder
-
required uint32 port = 3;
- clearProps() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required .PropsData props = 1;
- clearProtocol() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
optional string protocol = 4;
- clearProtocol() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
optional string protocol = 4;
- clearProtocol() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
optional string protocol = 4;
- clearProtocol() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
required string protocol = 1;
- clearProtocol() - Method in class akka.remote.WireFormats.AddressData.Builder
-
optional string protocol = 4;
- clearRateMBit() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
optional float rateMBit = 6;
- clearRecipient() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
required .ActorRefData recipient = 1;
- clearRef() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
optional string ref = 3;
- clearReply() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
required bool reply = 3;
- clearReply() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
required bool reply = 3;
- clearRoles() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
-
repeated string roles = 2;
- clearRolesIndexes() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
repeated int32 rolesIndexes = 4 [packed = true];
- clearRouterConfig() - Method in class akka.remote.WireFormats.DeployData.Builder
-
optional bytes routerConfig = 3;
- clearScope() - Method in class akka.remote.WireFormats.DeployData.Builder
-
optional bytes scope = 4;
- clearSeen() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated int32 seen = 1;
- clearSender() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional string sender = 11;
- clearSender() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
optional .ActorRefData sender = 4;
- clearSeq() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
optional fixed64 seq = 5;
- clearSequenceNr() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional int64 sequenceNr = 2;
- clearSerialized() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number.Builder
-
optional bytes serialized = 4;
- clearSerialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
-
optional bytes serialized = 4;
- clearSerializedGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
required bytes serializedGossip = 3;
- clearSerializerId() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload.Builder
-
required int32 serializerId = 2;
- clearSerializerId() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
-
required int32 serializerId = 1;
- clearSerializerId() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
required int32 serializerId = 2;
- clearSerializerId() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
-
required int32 serializerId = 2;
- clearStash() - Method in interface akka.actor.StashSupport
-
INTERNAL API.
- clearState() - Method in class akka.cluster.ClusterDomainEventPublisher
-
- clearStatus() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
required .MemberStatus status = 3;
- clearStatus() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
-
required .ReachabilityStatus status = 3;
- clearSubjectReachability() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
repeated .SubjectReachability subjectReachability = 2;
- clearSupervisor() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required .ActorRefData supervisor = 4;
- clearSystem() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
required string system = 1;
- clearSystem() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
required string system = 1;
- clearSystem() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
required string system = 1;
- clearSystem() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
required string system = 2;
- clearSystem() - Method in class akka.remote.WireFormats.AddressData.Builder
-
required string system = 1;
- clearTimeout() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
-
optional int64 timeout = 3;
- clearTimestamp() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
required int64 timestamp = 2;
- clearTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
required int64 timestamp = 2;
- clearTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
optional int64 timestamp = 1;
- clearTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
-
required int64 timestamp = 2;
- clearTimestamp() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
-
required int64 timestamp = 2;
- clearTo() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
required .UniqueAddress to = 2;
- clearTopic() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish.Builder
-
required string topic = 1;
- clearType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number.Builder
-
required .NodeMetrics.NumberType type = 1;
- clearType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
-
required .NodeMetrics.NumberType type = 1;
- clearType() - Method in class akka.remote.ContainerFormats.Selection.Builder
-
required .PatternType type = 1;
- clearUid() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
-
required uint32 uid = 2;
- clearUid() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
required fixed64 uid = 2;
- clearUnconfirmedDeliveries() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- clearUpNumber() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
required int32 upNumber = 2;
- clearValue() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA.Builder
-
required double value = 1;
- clearValue() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
-
required double value = 1;
- clearValue32() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number.Builder
-
optional uint32 value32 = 2;
- clearValue32() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
-
optional uint32 value32 = 2;
- clearValue64() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number.Builder
-
optional uint64 value64 = 3;
- clearValue64() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
-
optional uint64 value64 = 3;
- clearVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
required .VectorClock version = 6;
- clearVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
required .VectorClock version = 3;
- clearVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
required int64 version = 4;
- clearVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
-
required int64 version = 4;
- clearVersion() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
required int64 version = 2;
- clearVersion() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
required int64 version = 2;
- clearVersions() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
repeated .VectorClock.Version versions = 2;
- clearVersions() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
repeated .Status.Version versions = 1;
- clearWildcardFanOut() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
optional bool wildcardFanOut = 5;
- client() - Method in class akka.actor.dsl.Inbox.Get
-
- client() - Method in interface akka.actor.dsl.Inbox.Query
-
- client() - Method in class akka.actor.dsl.Inbox.Select
-
- client() - Method in exception akka.remote.testconductor.BarrierCoordinator.ClientLost
-
- client() - Method in exception akka.remote.testconductor.BarrierCoordinator.WrongBarrier
-
- Client - Class in akka.remote.testconductor
-
INTERNAL API.
- Client() - Constructor for class akka.remote.testconductor.Client
-
- client() - Method in interface akka.remote.testconductor.Player
-
- Client$ - Class in akka.remote.testconductor
-
INTERNAL API.
- Client$() - Constructor for class akka.remote.testconductor.Client$
-
- ClientDisconnected(RoleName) - Constructor for class akka.remote.testconductor.Controller.ClientDisconnected
-
- ClientDisconnected$() - Constructor for class akka.remote.testconductor.Controller.ClientDisconnected$
-
- ClientDisconnectedException(String) - Constructor for exception akka.remote.testconductor.Controller.ClientDisconnectedException
-
- ClientFSM - Class in akka.remote.testconductor
-
This is the controlling entity on the
Player
side: in a first step it registers itself with a symbolic name and its remote
address at the
Controller
, then waits for the
Done
message which signals that all other expected test participants have
done the same.
- ClientFSM(RoleName, InetSocketAddress) - Constructor for class akka.remote.testconductor.ClientFSM
-
- ClientFSM$ - Class in akka.remote.testconductor
-
INTERNAL API.
- ClientFSM$() - Constructor for class akka.remote.testconductor.ClientFSM$
-
- ClientFSM.AwaitDone$ - Class in akka.remote.testconductor
-
- ClientFSM.Connected - Class in akka.remote.testconductor
-
- ClientFSM.Connected$ - Class in akka.remote.testconductor
-
- ClientFSM.Connecting$ - Class in akka.remote.testconductor
-
- ClientFSM.ConnectionFailure - Exception in akka.remote.testconductor
-
- ClientFSM.ConnectionFailure$ - Class in akka.remote.testconductor
-
- ClientFSM.Data - Class in akka.remote.testconductor
-
- ClientFSM.Data$ - Class in akka.remote.testconductor
-
- ClientFSM.Disconnected$ - Class in akka.remote.testconductor
-
- ClientFSM.Failed$ - Class in akka.remote.testconductor
-
- ClientFSM.State - Interface in akka.remote.testconductor
-
- ClientHandler - Class in akka.remote.transport.netty
-
INTERNAL API
- ClientHandler(NettyTransport, Address) - Constructor for class akka.remote.transport.netty.ClientHandler
-
- ClientLost(BarrierCoordinator.Data, RoleName) - Constructor for exception akka.remote.testconductor.BarrierCoordinator.ClientLost
-
- ClientLost$() - Constructor for class akka.remote.testconductor.BarrierCoordinator.ClientLost$
-
- ClientOp - Interface in akka.remote.testconductor
-
- clientPredicate() - Method in class akka.actor.dsl.Inbox.InboxActor
-
- ClientReconnects() - Method in class akka.remote.testconductor.TestConductorExt.Settings
-
- ClientResponseTunnel(ActorRef, FiniteDuration) - Constructor for class akka.cluster.client.ClusterReceptionist.Internal$.ClientResponseTunnel
-
- clients() - Method in class akka.actor.dsl.Inbox.InboxActor
-
- clients() - Method in class akka.remote.testconductor.BarrierCoordinator.Data
-
- clients() - Method in class akka.remote.testconductor.ConductorHandler
-
- clientsByTimeout() - Method in class akka.actor.dsl.Inbox.InboxActor
-
- ClientSocketWorkerPoolSize() - Method in class akka.remote.testconductor.TestConductorExt.Settings
-
- ClientSocketWorkerPoolSize() - Method in class akka.remote.transport.netty.NettyTransportSettings
-
- clock() - Method in class akka.actor.LightArrayRevolverScheduler
-
Clock implementation is replaceable (for testing); the implementation must
return a monotonically increasing series of Long nanoseconds.
- clock() - Method in class akka.io.SimpleDnsCache
-
- Clock() - Constructor for class akka.remote.FailureDetector.Clock
-
- clone() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
- clone() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
- clone() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
- clone() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
- clone() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA.Builder
-
- clone() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
- clone() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number.Builder
-
- clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
- clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty.Builder
-
- clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
- clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
- clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
- clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
- clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
-
- clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
- clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
- clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
- clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
- clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
-
- clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
- clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
-
- clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
- clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
-
- clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
-
- clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
- clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
-
- clone() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
-
- clone() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
- clone() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
- clone() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Builder
-
- clone() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
- clone() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload.Builder
-
- clone() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish.Builder
-
- clone() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
- clone() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
-
- clone() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
- clone() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
-
- clone() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
- clone() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
- clone() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
- clone() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
-
- clone() - Method in class akka.remote.ContainerFormats.Selection.Builder
-
- clone() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
- clone() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
- clone() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
-
- clone() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
-
- clone() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
-
- clone() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
- clone() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
- clone() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
- clone() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
-
- clone() - Method in class akka.remote.WireFormats.ActorRefData.Builder
-
- clone() - Method in class akka.remote.WireFormats.AddressData.Builder
-
- clone() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
-
- clone() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
- clone() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
-
- clone() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
- clone() - Method in class akka.remote.WireFormats.DeployData.Builder
-
- clone() - Method in class akka.remote.WireFormats.PropsData.Builder
-
- clone() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
- clone() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
-
- clone() - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- clone() - Method in class akka.util.ByteIterator
-
- clone() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- close() - Method in class akka.actor.LightArrayRevolverScheduler
-
- close() - Method in class akka.cluster.ClusterReadView
-
Unsubscribe to cluster events.
- close() - Method in class akka.cluster.JmxMetricsCollector
-
- close() - Method in class akka.cluster.metrics.JmxMetricsCollector
-
- close() - Method in class akka.cluster.metrics.SigarMetricsCollector
-
Releases any native resources associated with this instance.
- close(SigarProxy) - Method in class akka.cluster.metrics.SigarProvider$
-
Release underlying sigar proxy resources.
- close() - Method in class akka.cluster.SigarMetricsCollector
-
Releases any native resources associated with this instance.
- close() - Method in class akka.io.TcpMessage$
-
A normal close operation will first flush pending writes and then close the
socket.
- close() - Static method in class akka.io.TcpMessage
-
A normal close operation will first flush pending writes and then close the
socket.
- Close$() - Constructor for class akka.io.Tcp.Close$
-
- Closed() - Method in class akka.dispatch.Mailbox$
-
- Closed() - Static method in class akka.dispatch.Mailbox
-
- Closed$() - Constructor for class akka.io.Tcp.Closed$
-
- Closed$() - Constructor for class akka.remote.transport.ProtocolStateActor.Closed$
-
- closedEvent() - Method in class akka.io.TcpConnection.CloseInformation
-
- closedMessage() - Method in class akka.io.TcpConnection
-
- CloseInformation(Set<ActorRef>, Tcp.Event) - Constructor for class akka.io.TcpConnection.CloseInformation
-
- CloseInformation$() - Constructor for class akka.io.TcpConnection.CloseInformation$
-
- closeReason() - Method in class akka.io.TcpConnection
-
- closing(TcpConnection.ConnectionInfo, Option<ActorRef>) - Method in class akka.io.TcpConnection
-
connection is closed on our side and we're waiting from confirmation from the other side
- closingWithPendingWrite(TcpConnection.ConnectionInfo, Option<ActorRef>, Tcp.ConnectionClosed) - Method in class akka.io.TcpConnection
-
connection is closing but a write has to be finished first
- cluster() - Method in class akka.cluster.AutoDown
-
- cluster() - Method in class akka.cluster.client.ClusterReceptionist
-
- Cluster - Class in akka.cluster
-
This module is responsible cluster membership information.
- Cluster(ExtendedActorSystem) - Constructor for class akka.cluster.Cluster
-
- cluster() - Method in class akka.cluster.ClusterCoreDaemon
-
- cluster() - Method in class akka.cluster.ClusterHeartbeatSender
-
- cluster() - Method in class akka.cluster.ClusterMetricsCollector
-
- cluster() - Method in class akka.cluster.ClusterRemoteWatcher
-
- cluster() - Method in class akka.cluster.FirstSeedNodeProcess
-
- cluster() - Method in class akka.cluster.metrics.ClusterMetricsCollector
-
- cluster() - Method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- cluster() - Method in class akka.cluster.routing.AdaptiveLoadBalancingMetricsListener
-
- cluster() - Method in interface akka.cluster.routing.ClusterRouterActor
-
- cluster() - Method in class akka.cluster.sharding.ClusterShardingGuardian
-
- cluster() - Method in class akka.cluster.sharding.ShardRegion
-
- cluster() - Method in class akka.cluster.singleton.ClusterSingletonManager
-
- cluster() - Method in class akka.cluster.singleton.ClusterSingletonProxy
-
- Cluster$ - Class in akka.cluster
-
Cluster Extension Id and factory for creating Cluster extension.
- Cluster$() - Constructor for class akka.cluster.Cluster$
-
- Cluster.InfoLogger$ - Class in akka.cluster
-
INTERNAL API
- ClusterActorRefProvider - Class in akka.cluster
-
INTERNAL API
- ClusterActorRefProvider(String, ActorSystem.Settings, EventStream, DynamicAccess) - Constructor for class akka.cluster.ClusterActorRefProvider
-
- ClusterClient - Class in akka.cluster.client
-
This actor is intended to be used on an external node that is not member
of the cluster.
- ClusterClient(ClusterClientSettings) - Constructor for class akka.cluster.client.ClusterClient
-
- ClusterClient$ - Class in akka.cluster.client
-
- ClusterClient$() - Constructor for class akka.cluster.client.ClusterClient$
-
- ClusterClient.Internal$ - Class in akka.cluster.client
-
INTERNAL API
- ClusterClient.Internal$.RefreshContactsTick - Class in akka.cluster.client
-
- ClusterClient.Publish - Class in akka.cluster.client
-
- ClusterClient.Publish$ - Class in akka.cluster.client
-
- ClusterClient.Send - Class in akka.cluster.client
-
- ClusterClient.Send$ - Class in akka.cluster.client
-
- ClusterClient.SendToAll - Class in akka.cluster.client
-
- ClusterClient.SendToAll$ - Class in akka.cluster.client
-
- ClusterClientReceptionist - Class in akka.cluster.client
-
- ClusterClientReceptionist(ExtendedActorSystem) - Constructor for class akka.cluster.client.ClusterClientReceptionist
-
- ClusterClientReceptionist$ - Class in akka.cluster.client
-
- ClusterClientReceptionist$() - Constructor for class akka.cluster.client.ClusterClientReceptionist$
-
- ClusterClientSettings - Class in akka.cluster.client
-
param: initialContacts Actor paths of the ClusterReceptionist
actors on
the servers (cluster nodes) that the client will try to contact initially.
- ClusterClientSettings(Set<ActorPath>, FiniteDuration, FiniteDuration) - Constructor for class akka.cluster.client.ClusterClientSettings
-
- ClusterClientSettings$ - Class in akka.cluster.client
-
- ClusterClientSettings$() - Constructor for class akka.cluster.client.ClusterClientSettings$
-
- clusterCore() - Method in class akka.cluster.Cluster
-
INTERNAL API
- ClusterCoreDaemon - Class in akka.cluster
-
INTERNAL API.
- ClusterCoreDaemon(ActorRef) - Constructor for class akka.cluster.ClusterCoreDaemon
-
- ClusterCoreDaemon.Ignored - Class in akka.cluster
-
- ClusterCoreDaemon.Merge - Class in akka.cluster
-
- ClusterCoreDaemon.Newer - Class in akka.cluster
-
- ClusterCoreDaemon.Older - Class in akka.cluster
-
- ClusterCoreDaemon.ReceiveGossipType - Interface in akka.cluster
-
The types of gossip actions that receive gossip has performed.
- ClusterCoreDaemon.Same - Class in akka.cluster
-
- ClusterCoreSupervisor - Class in akka.cluster
-
INTERNAL API.
- ClusterCoreSupervisor() - Constructor for class akka.cluster.ClusterCoreSupervisor
-
- ClusterDaemon - Class in akka.cluster
-
INTERNAL API.
- ClusterDaemon(ClusterSettings) - Constructor for class akka.cluster.ClusterDaemon
-
- ClusterDeployer - Class in akka.cluster
-
INTERNAL API
- ClusterDeployer(ActorSystem.Settings, DynamicAccess) - Constructor for class akka.cluster.ClusterDeployer
-
- ClusterDomainEventPublisher - Class in akka.cluster
-
INTERNAL API.
- ClusterDomainEventPublisher() - Constructor for class akka.cluster.ClusterDomainEventPublisher
-
- ClusterEvent - Class in akka.cluster
-
Domain events published to the event bus.
- ClusterEvent() - Constructor for class akka.cluster.ClusterEvent
-
- ClusterEvent$ - Class in akka.cluster
-
Domain events published to the event bus.
- ClusterEvent$() - Constructor for class akka.cluster.ClusterEvent$
-
- ClusterEvent.ClusterDomainEvent - Interface in akka.cluster
-
Marker interface for cluster domain events.
- ClusterEvent.ClusterMetricsChanged - Class in akka.cluster
-
Current snapshot of cluster node metrics.
- ClusterEvent.ClusterMetricsChanged$ - Class in akka.cluster
-
- ClusterEvent.ClusterShuttingDown$ - Class in akka.cluster
-
- ClusterEvent.CurrentClusterState - Class in akka.cluster
-
Current snapshot state of the cluster.
- ClusterEvent.CurrentClusterState$ - Class in akka.cluster
-
- ClusterEvent.CurrentInternalStats - Class in akka.cluster
-
INTERNAL API
- ClusterEvent.CurrentInternalStats$ - Class in akka.cluster
-
- ClusterEvent.InitialStateAsEvents$ - Class in akka.cluster
-
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$ - Class in akka.cluster
-
- ClusterEvent.LeaderChanged - Class in akka.cluster
-
Leader of the cluster members changed.
- ClusterEvent.LeaderChanged$ - Class in akka.cluster
-
- ClusterEvent.MemberEvent - Interface in akka.cluster
-
Marker interface for membership events.
- ClusterEvent.MemberExited - Class in akka.cluster
-
Member status changed to MemberStatus.Exiting
and will be removed
when all members have seen the Exiting
status.
- ClusterEvent.MemberExited$ - Class in akka.cluster
-
- ClusterEvent.MemberRemoved - Class in akka.cluster
-
Member completely removed from the cluster.
- ClusterEvent.MemberRemoved$ - Class in akka.cluster
-
- ClusterEvent.MemberUp - Class in akka.cluster
-
Member status changed to Up.
- ClusterEvent.MemberUp$ - Class in akka.cluster
-
- ClusterEvent.ReachabilityChanged - Class in akka.cluster
-
INTERNAL API
- ClusterEvent.ReachabilityChanged$ - Class in akka.cluster
-
- ClusterEvent.ReachabilityEvent - Interface in akka.cluster
-
- ClusterEvent.ReachableMember - Class in akka.cluster
-
A member is considered as reachable by the failure detector
after having been unreachable.
- ClusterEvent.ReachableMember$ - Class in akka.cluster
-
- ClusterEvent.RoleLeaderChanged - Class in akka.cluster
-
First member (leader) of the members within a role set changed.
- ClusterEvent.RoleLeaderChanged$ - Class in akka.cluster
-
- ClusterEvent.SeenChanged - Class in akka.cluster
-
INTERNAL API
The nodes that have seen current version of the Gossip.
- ClusterEvent.SeenChanged$ - Class in akka.cluster
-
- ClusterEvent.SubscriptionInitialStateMode - Class in akka.cluster
-
- ClusterEvent.UnreachableMember - Class in akka.cluster
-
A member is considered as unreachable by the failure detector.
- ClusterEvent.UnreachableMember$ - Class in akka.cluster
-
- ClusterHeartbeatReceiver - Class in akka.cluster
-
INTERNAL API.
- ClusterHeartbeatReceiver() - Constructor for class akka.cluster.ClusterHeartbeatReceiver
-
- ClusterHeartbeatSender - Class in akka.cluster
-
- ClusterHeartbeatSender() - Constructor for class akka.cluster.ClusterHeartbeatSender
-
- ClusterHeartbeatSender$ - Class in akka.cluster
-
INTERNAL API
- ClusterHeartbeatSender$() - Constructor for class akka.cluster.ClusterHeartbeatSender$
-
- ClusterHeartbeatSender.ExpectedFirstHeartbeat - Class in akka.cluster
-
- ClusterHeartbeatSender.ExpectedFirstHeartbeat$ - Class in akka.cluster
-
- ClusterHeartbeatSender.Heartbeat - Class in akka.cluster
-
Sent at regular intervals for failure detection.
- ClusterHeartbeatSender.Heartbeat$ - Class in akka.cluster
-
- ClusterHeartbeatSender.HeartbeatRsp - Class in akka.cluster
-
- ClusterHeartbeatSender.HeartbeatRsp$ - Class in akka.cluster
-
- ClusterHeartbeatSender.HeartbeatTick$ - Class in akka.cluster
-
- ClusterHeartbeatSenderState - Class in akka.cluster
-
- ClusterHeartbeatSenderState(HeartbeatNodeRing, Set<UniqueAddress>, FailureDetectorRegistry<Address>) - Constructor for class akka.cluster.ClusterHeartbeatSenderState
-
- ClusterHeartbeatSenderState$ - Class in akka.cluster
-
- ClusterHeartbeatSenderState$() - Constructor for class akka.cluster.ClusterHeartbeatSenderState$
-
- ClusterJmx - Class in akka.cluster
-
INTERNAL API
- ClusterJmx(Cluster, LoggingAdapter) - Constructor for class akka.cluster.ClusterJmx
-
- ClusterMessage - Interface in akka.cluster
-
Base trait for all cluster messages.
- ClusterMessages - Class in akka.cluster.protobuf.msg
-
- ClusterMessages.Address - Class in akka.cluster.protobuf.msg
-
Protobuf type Address
- ClusterMessages.Address.Builder - Class in akka.cluster.protobuf.msg
-
Protobuf type Address
- ClusterMessages.AddressOrBuilder - Interface in akka.cluster.protobuf.msg
-
- ClusterMessages.Empty - Class in akka.cluster.protobuf.msg
-
Protobuf type Empty
- ClusterMessages.Empty.Builder - Class in akka.cluster.protobuf.msg
-
Protobuf type Empty
- ClusterMessages.EmptyOrBuilder - Interface in akka.cluster.protobuf.msg
-
- ClusterMessages.Gossip - Class in akka.cluster.protobuf.msg
-
Protobuf type Gossip
- ClusterMessages.Gossip.Builder - Class in akka.cluster.protobuf.msg
-
Protobuf type Gossip
- ClusterMessages.GossipEnvelope - Class in akka.cluster.protobuf.msg
-
Protobuf type GossipEnvelope
- ClusterMessages.GossipEnvelope.Builder - Class in akka.cluster.protobuf.msg
-
Protobuf type GossipEnvelope
- ClusterMessages.GossipEnvelopeOrBuilder - Interface in akka.cluster.protobuf.msg
-
- ClusterMessages.GossipOrBuilder - Interface in akka.cluster.protobuf.msg
-
- ClusterMessages.GossipOverview - Class in akka.cluster.protobuf.msg
-
Protobuf type GossipOverview
- ClusterMessages.GossipOverview.Builder - Class in akka.cluster.protobuf.msg
-
Protobuf type GossipOverview
- ClusterMessages.GossipOverviewOrBuilder - Interface in akka.cluster.protobuf.msg
-
- ClusterMessages.GossipStatus - Class in akka.cluster.protobuf.msg
-
Protobuf type GossipStatus
- ClusterMessages.GossipStatus.Builder - Class in akka.cluster.protobuf.msg
-
Protobuf type GossipStatus
- ClusterMessages.GossipStatusOrBuilder - Interface in akka.cluster.protobuf.msg
-
- ClusterMessages.Join - Class in akka.cluster.protobuf.msg
-
Protobuf type Join
- ClusterMessages.Join.Builder - Class in akka.cluster.protobuf.msg
-
Protobuf type Join
- ClusterMessages.JoinOrBuilder - Interface in akka.cluster.protobuf.msg
-
- ClusterMessages.Member - Class in akka.cluster.protobuf.msg
-
Protobuf type Member
- ClusterMessages.Member.Builder - Class in akka.cluster.protobuf.msg
-
Protobuf type Member
- ClusterMessages.MemberOrBuilder - Interface in akka.cluster.protobuf.msg
-
- ClusterMessages.MemberStatus - Enum in akka.cluster.protobuf.msg
-
Protobuf enum MemberStatus
- ClusterMessages.MetricsGossip - Class in akka.cluster.protobuf.msg
-
Protobuf type MetricsGossip
- ClusterMessages.MetricsGossip.Builder - Class in akka.cluster.protobuf.msg
-
Protobuf type MetricsGossip
- ClusterMessages.MetricsGossipEnvelope - Class in akka.cluster.protobuf.msg
-
Protobuf type MetricsGossipEnvelope
- ClusterMessages.MetricsGossipEnvelope.Builder - Class in akka.cluster.protobuf.msg
-
Protobuf type MetricsGossipEnvelope
- ClusterMessages.MetricsGossipEnvelopeOrBuilder - Interface in akka.cluster.protobuf.msg
-
- ClusterMessages.MetricsGossipOrBuilder - Interface in akka.cluster.protobuf.msg
-
- ClusterMessages.NodeMetrics - Class in akka.cluster.protobuf.msg
-
Protobuf type NodeMetrics
- ClusterMessages.NodeMetrics.Builder - Class in akka.cluster.protobuf.msg
-
Protobuf type NodeMetrics
- ClusterMessages.NodeMetrics.EWMA - Class in akka.cluster.protobuf.msg
-
Protobuf type NodeMetrics.EWMA
- ClusterMessages.NodeMetrics.EWMA.Builder - Class in akka.cluster.protobuf.msg
-
Protobuf type NodeMetrics.EWMA
- ClusterMessages.NodeMetrics.EWMAOrBuilder - Interface in akka.cluster.protobuf.msg
-
- ClusterMessages.NodeMetrics.Metric - Class in akka.cluster.protobuf.msg
-
Protobuf type NodeMetrics.Metric
- ClusterMessages.NodeMetrics.Metric.Builder - Class in akka.cluster.protobuf.msg
-
Protobuf type NodeMetrics.Metric
- ClusterMessages.NodeMetrics.MetricOrBuilder - Interface in akka.cluster.protobuf.msg
-
- ClusterMessages.NodeMetrics.Number - Class in akka.cluster.protobuf.msg
-
Protobuf type NodeMetrics.Number
- ClusterMessages.NodeMetrics.Number.Builder - Class in akka.cluster.protobuf.msg
-
Protobuf type NodeMetrics.Number
- ClusterMessages.NodeMetrics.NumberOrBuilder - Interface in akka.cluster.protobuf.msg
-
- ClusterMessages.NodeMetrics.NumberType - Enum in akka.cluster.protobuf.msg
-
Protobuf enum NodeMetrics.NumberType
- ClusterMessages.NodeMetricsOrBuilder - Interface in akka.cluster.protobuf.msg
-
- ClusterMessages.ObserverReachability - Class in akka.cluster.protobuf.msg
-
Protobuf type ObserverReachability
- ClusterMessages.ObserverReachability.Builder - Class in akka.cluster.protobuf.msg
-
Protobuf type ObserverReachability
- ClusterMessages.ObserverReachabilityOrBuilder - Interface in akka.cluster.protobuf.msg
-
- ClusterMessages.ReachabilityStatus - Enum in akka.cluster.protobuf.msg
-
Protobuf enum ReachabilityStatus
- ClusterMessages.SubjectReachability - Class in akka.cluster.protobuf.msg
-
Protobuf type SubjectReachability
- ClusterMessages.SubjectReachability.Builder - Class in akka.cluster.protobuf.msg
-
Protobuf type SubjectReachability
- ClusterMessages.SubjectReachabilityOrBuilder - Interface in akka.cluster.protobuf.msg
-
- ClusterMessages.UniqueAddress - Class in akka.cluster.protobuf.msg
-
Protobuf type UniqueAddress
- ClusterMessages.UniqueAddress.Builder - Class in akka.cluster.protobuf.msg
-
Protobuf type UniqueAddress
- ClusterMessages.UniqueAddressOrBuilder - Interface in akka.cluster.protobuf.msg
-
- ClusterMessages.VectorClock - Class in akka.cluster.protobuf.msg
-
Protobuf type VectorClock
- ClusterMessages.VectorClock.Builder - Class in akka.cluster.protobuf.msg
-
Protobuf type VectorClock
- ClusterMessages.VectorClock.Version - Class in akka.cluster.protobuf.msg
-
Protobuf type VectorClock.Version
- ClusterMessages.VectorClock.Version.Builder - Class in akka.cluster.protobuf.msg
-
Protobuf type VectorClock.Version
- ClusterMessages.VectorClock.VersionOrBuilder - Interface in akka.cluster.protobuf.msg
-
- ClusterMessages.VectorClockOrBuilder - Interface in akka.cluster.protobuf.msg
-
- ClusterMessages.Welcome - Class in akka.cluster.protobuf.msg
-
Protobuf type Welcome
- ClusterMessages.Welcome.Builder - Class in akka.cluster.protobuf.msg
-
Protobuf type Welcome
- ClusterMessages.WelcomeOrBuilder - Interface in akka.cluster.protobuf.msg
-
- ClusterMessageSerializer - Class in akka.cluster.protobuf
-
Protobuf serializer of cluster messages.
- ClusterMessageSerializer(ExtendedActorSystem) - Constructor for class akka.cluster.protobuf.ClusterMessageSerializer
-
- ClusterMessageSerializer() - Constructor for class akka.cluster.protobuf.ClusterMessageSerializer
-
- clusterMetrics() - Method in class akka.cluster.ClusterReadView
-
Current cluster metrics.
- ClusterMetricsChanged(Set<NodeMetrics>) - Constructor for class akka.cluster.ClusterEvent.ClusterMetricsChanged
-
- ClusterMetricsChanged - Class in akka.cluster.metrics
-
Current snapshot of cluster node metrics.
- ClusterMetricsChanged(Set<NodeMetrics>) - Constructor for class akka.cluster.metrics.ClusterMetricsChanged
-
- ClusterMetricsChanged$() - Constructor for class akka.cluster.ClusterEvent.ClusterMetricsChanged$
-
- ClusterMetricsChanged$ - Class in akka.cluster.metrics
-
- ClusterMetricsChanged$() - Constructor for class akka.cluster.metrics.ClusterMetricsChanged$
-
- ClusterMetricsCollector - Class in akka.cluster
-
INTERNAL API.
- ClusterMetricsCollector(ActorRef) - Constructor for class akka.cluster.ClusterMetricsCollector
-
- ClusterMetricsCollector - Class in akka.cluster.metrics
-
INTERNAL API.
- ClusterMetricsCollector() - Constructor for class akka.cluster.metrics.ClusterMetricsCollector
-
- ClusterMetricsEvent - Interface in akka.cluster.metrics
-
Local cluster metrics extension events.
- ClusterMetricsExtension - Class in akka.cluster.metrics
-
Cluster metrics extension.
- ClusterMetricsExtension(ExtendedActorSystem) - Constructor for class akka.cluster.metrics.ClusterMetricsExtension
-
- ClusterMetricsExtension$ - Class in akka.cluster.metrics
-
Cluster metrics extension provider.
- ClusterMetricsExtension$() - Constructor for class akka.cluster.metrics.ClusterMetricsExtension$
-
- ClusterMetricsMessage - Interface in akka.cluster.metrics
-
INTERNAL API.
- ClusterMetricsMessages - Class in akka.cluster.metrics.protobuf.msg
-
- ClusterMetricsMessages.Address - Class in akka.cluster.metrics.protobuf.msg
-
Protobuf type Address
- ClusterMetricsMessages.Address.Builder - Class in akka.cluster.metrics.protobuf.msg
-
Protobuf type Address
- ClusterMetricsMessages.AddressOrBuilder - Interface in akka.cluster.metrics.protobuf.msg
-
- ClusterMetricsMessages.MetricsGossip - Class in akka.cluster.metrics.protobuf.msg
-
Protobuf type MetricsGossip
- ClusterMetricsMessages.MetricsGossip.Builder - Class in akka.cluster.metrics.protobuf.msg
-
Protobuf type MetricsGossip
- ClusterMetricsMessages.MetricsGossipEnvelope - Class in akka.cluster.metrics.protobuf.msg
-
Protobuf type MetricsGossipEnvelope
- ClusterMetricsMessages.MetricsGossipEnvelope.Builder - Class in akka.cluster.metrics.protobuf.msg
-
Protobuf type MetricsGossipEnvelope
- ClusterMetricsMessages.MetricsGossipEnvelopeOrBuilder - Interface in akka.cluster.metrics.protobuf.msg
-
- ClusterMetricsMessages.MetricsGossipOrBuilder - Interface in akka.cluster.metrics.protobuf.msg
-
- ClusterMetricsMessages.NodeMetrics - Class in akka.cluster.metrics.protobuf.msg
-
Protobuf type NodeMetrics
- ClusterMetricsMessages.NodeMetrics.Builder - Class in akka.cluster.metrics.protobuf.msg
-
Protobuf type NodeMetrics
- ClusterMetricsMessages.NodeMetrics.EWMA - Class in akka.cluster.metrics.protobuf.msg
-
Protobuf type NodeMetrics.EWMA
- ClusterMetricsMessages.NodeMetrics.EWMA.Builder - Class in akka.cluster.metrics.protobuf.msg
-
Protobuf type NodeMetrics.EWMA
- ClusterMetricsMessages.NodeMetrics.EWMAOrBuilder - Interface in akka.cluster.metrics.protobuf.msg
-
- ClusterMetricsMessages.NodeMetrics.Metric - Class in akka.cluster.metrics.protobuf.msg
-
Protobuf type NodeMetrics.Metric
- ClusterMetricsMessages.NodeMetrics.Metric.Builder - Class in akka.cluster.metrics.protobuf.msg
-
Protobuf type NodeMetrics.Metric
- ClusterMetricsMessages.NodeMetrics.MetricOrBuilder - Interface in akka.cluster.metrics.protobuf.msg
-
- ClusterMetricsMessages.NodeMetrics.Number - Class in akka.cluster.metrics.protobuf.msg
-
Protobuf type NodeMetrics.Number
- ClusterMetricsMessages.NodeMetrics.Number.Builder - Class in akka.cluster.metrics.protobuf.msg
-
Protobuf type NodeMetrics.Number
- ClusterMetricsMessages.NodeMetrics.NumberOrBuilder - Interface in akka.cluster.metrics.protobuf.msg
-
- ClusterMetricsMessages.NodeMetrics.NumberType - Enum in akka.cluster.metrics.protobuf.msg
-
Protobuf enum NodeMetrics.NumberType
- ClusterMetricsMessages.NodeMetricsOrBuilder - Interface in akka.cluster.metrics.protobuf.msg
-
- ClusterMetricsSettings - Class in akka.cluster.metrics
-
Metrics extension settings.
- ClusterMetricsSettings(Config) - Constructor for class akka.cluster.metrics.ClusterMetricsSettings
-
- ClusterMetricsSettings$ - Class in akka.cluster.metrics
-
- ClusterMetricsSettings$() - Constructor for class akka.cluster.metrics.ClusterMetricsSettings$
-
- ClusterMetricsStrategy - Class in akka.cluster.metrics
-
- ClusterMetricsStrategy(Config) - Constructor for class akka.cluster.metrics.ClusterMetricsStrategy
-
- ClusterMetricsStrategy$ - Class in akka.cluster.metrics
-
Provide custom metrics strategy resources.
- ClusterMetricsStrategy$() - Constructor for class akka.cluster.metrics.ClusterMetricsStrategy$
-
- ClusterMetricsSupervisor - Class in akka.cluster.metrics
-
INTERNAL API.
- ClusterMetricsSupervisor() - Constructor for class akka.cluster.metrics.ClusterMetricsSupervisor
-
- ClusterNodeMBean - Interface in akka.cluster
-
Interface for the cluster JMX MBean.
- clusterNodes() - Method in class akka.cluster.ClusterRemoteWatcher
-
- ClusterReadView - Class in akka.cluster
-
INTERNAL API
- ClusterReadView(Cluster) - Constructor for class akka.cluster.ClusterReadView
-
- clusterReceive() - Method in interface akka.cluster.routing.ClusterRouterActor
-
- ClusterReceptionist - Class in akka.cluster.client
-
- ClusterReceptionist(ActorRef, ClusterReceptionistSettings) - Constructor for class akka.cluster.client.ClusterReceptionist
-
- ClusterReceptionist$ - Class in akka.cluster.client
-
- ClusterReceptionist$() - Constructor for class akka.cluster.client.ClusterReceptionist$
-
- ClusterReceptionist.Internal$ - Class in akka.cluster.client
-
INTERNAL API
- ClusterReceptionist.Internal$.ClientResponseTunnel - Class in akka.cluster.client
-
Replies are tunneled via this actor, child of the receptionist, to avoid
inbound connections from other cluster nodes to the client.
- ClusterReceptionist.Internal$.Contacts - Class in akka.cluster.client
-
- ClusterReceptionist.Internal$.GetContacts - Class in akka.cluster.client
-
- ClusterReceptionist.Internal$.Ping - Class in akka.cluster.client
-
- ClusterReceptionistSettings - Class in akka.cluster.client
-
param: role Start the receptionist on members tagged with this role.
- ClusterReceptionistSettings(Option<String>, int, FiniteDuration) - Constructor for class akka.cluster.client.ClusterReceptionistSettings
-
- ClusterReceptionistSettings$ - Class in akka.cluster.client
-
- ClusterReceptionistSettings$() - Constructor for class akka.cluster.client.ClusterReceptionistSettings$
-
- ClusterRemoteWatcher - Class in akka.cluster
-
INTERNAL API
- ClusterRemoteWatcher(FailureDetectorRegistry<Address>, FiniteDuration, FiniteDuration, FiniteDuration) - Constructor for class akka.cluster.ClusterRemoteWatcher
-
- ClusterRemoteWatcher$ - Class in akka.cluster
-
INTERNAL API
- ClusterRemoteWatcher$() - Constructor for class akka.cluster.ClusterRemoteWatcher$
-
- ClusterRouterActor - Interface in akka.cluster.routing
-
INTERNAL API
The router actor, subscribes to cluster events and
adjusts the routees.
- ClusterRouterConfigBase - Interface in akka.cluster.routing
-
INTERNAL API
- ClusterRouterGroup - Class in akka.cluster.routing
-
RouterConfig
implementation for deployment on cluster nodes.
- ClusterRouterGroup(Group, ClusterRouterGroupSettings) - Constructor for class akka.cluster.routing.ClusterRouterGroup
-
- ClusterRouterGroup$ - Class in akka.cluster.routing
-
- ClusterRouterGroup$() - Constructor for class akka.cluster.routing.ClusterRouterGroup$
-
- ClusterRouterGroupActor - Class in akka.cluster.routing
-
INTERNAL API
- ClusterRouterGroupActor(ClusterRouterGroupSettings) - Constructor for class akka.cluster.routing.ClusterRouterGroupActor
-
- ClusterRouterGroupSettings - Class in akka.cluster.routing
-
- ClusterRouterGroupSettings(int, Seq<String>, boolean, Option<String>) - Constructor for class akka.cluster.routing.ClusterRouterGroupSettings
-
- ClusterRouterGroupSettings(int, Iterable<String>, boolean, String) - Constructor for class akka.cluster.routing.ClusterRouterGroupSettings
-
Java API
- ClusterRouterGroupSettings$ - Class in akka.cluster.routing
-
- ClusterRouterGroupSettings$() - Constructor for class akka.cluster.routing.ClusterRouterGroupSettings$
-
- ClusterRouterPool - Class in akka.cluster.routing
-
RouterConfig
implementation for deployment on cluster nodes.
- ClusterRouterPool(Pool, ClusterRouterPoolSettings) - Constructor for class akka.cluster.routing.ClusterRouterPool
-
- ClusterRouterPool$ - Class in akka.cluster.routing
-
- ClusterRouterPool$() - Constructor for class akka.cluster.routing.ClusterRouterPool$
-
- ClusterRouterPoolActor - Class in akka.cluster.routing
-
INTERNAL API
- ClusterRouterPoolActor(SupervisorStrategy, ClusterRouterPoolSettings) - Constructor for class akka.cluster.routing.ClusterRouterPoolActor
-
- ClusterRouterPoolSettings - Class in akka.cluster.routing
-
- ClusterRouterPoolSettings(int, int, boolean, Option<String>) - Constructor for class akka.cluster.routing.ClusterRouterPoolSettings
-
- ClusterRouterPoolSettings(int, int, boolean, String) - Constructor for class akka.cluster.routing.ClusterRouterPoolSettings
-
Java API
- ClusterRouterPoolSettings$ - Class in akka.cluster.routing
-
- ClusterRouterPoolSettings$() - Constructor for class akka.cluster.routing.ClusterRouterPoolSettings$
-
- ClusterRouterSettingsBase - Interface in akka.cluster.routing
-
INTERNAL API
- ClusterRouterSettingsBase$ - Class in akka.cluster.routing
-
INTERNAL API
- ClusterRouterSettingsBase$() - Constructor for class akka.cluster.routing.ClusterRouterSettingsBase$
-
- ClusterScope - Class in akka.cluster
-
- ClusterScope() - Constructor for class akka.cluster.ClusterScope
-
- ClusterScope$ - Class in akka.cluster
-
Cluster aware scope of a
Deploy
- ClusterScope$() - Constructor for class akka.cluster.ClusterScope$
-
- ClusterSettings - Class in akka.cluster
-
- ClusterSettings(Config, String) - Constructor for class akka.cluster.ClusterSettings
-
- ClusterSharding - Class in akka.cluster.sharding
-
- ClusterSharding(ExtendedActorSystem) - Constructor for class akka.cluster.sharding.ClusterSharding
-
- ClusterSharding$ - Class in akka.cluster.sharding
-
This extension provides sharding functionality of actors in a cluster.
- ClusterSharding$() - Constructor for class akka.cluster.sharding.ClusterSharding$
-
- ClusterSharding.Settings$ - Class in akka.cluster.sharding
-
INTERNAL API
- ClusterShardingGuardian - Class in akka.cluster.sharding
-
INTERNAL API.
- ClusterShardingGuardian() - Constructor for class akka.cluster.sharding.ClusterShardingGuardian
-
- ClusterShardingGuardian$ - Class in akka.cluster.sharding
-
INTERNAL API.
- ClusterShardingGuardian$() - Constructor for class akka.cluster.sharding.ClusterShardingGuardian$
-
- ClusterShardingGuardian.Start - Class in akka.cluster.sharding
-
- ClusterShardingGuardian.Start$ - Class in akka.cluster.sharding
-
- ClusterShardingGuardian.Started - Class in akka.cluster.sharding
-
- ClusterShardingGuardian.Started$ - Class in akka.cluster.sharding
-
- ClusterShuttingDown$() - Constructor for class akka.cluster.ClusterEvent.ClusterShuttingDown$
-
- ClusterSingletonManager - Class in akka.cluster.singleton
-
Manages singleton actor instance among all cluster nodes or a group
of nodes tagged with a specific role.
- ClusterSingletonManager(Props, Object, ClusterSingletonManagerSettings) - Constructor for class akka.cluster.singleton.ClusterSingletonManager
-
- ClusterSingletonManager$ - Class in akka.cluster.singleton
-
- ClusterSingletonManager$() - Constructor for class akka.cluster.singleton.ClusterSingletonManager$
-
- ClusterSingletonManager.Data - Interface in akka.cluster.singleton
-
INTERNAL API
public due to the with FSM
type parameters
- ClusterSingletonManager.State - Interface in akka.cluster.singleton
-
INTERNAL API
public due to the with FSM
type parameters
- ClusterSingletonManagerIsStuck - Exception in akka.cluster.singleton
-
Thrown when a consistent state can't be determined within the
defined retry limits.
- ClusterSingletonManagerIsStuck(String) - Constructor for exception akka.cluster.singleton.ClusterSingletonManagerIsStuck
-
- ClusterSingletonManagerSettings - Class in akka.cluster.singleton
-
param: singletonName The actor name of the child singleton actor.
- ClusterSingletonManagerSettings(String, Option<String>, int, int, FiniteDuration) - Constructor for class akka.cluster.singleton.ClusterSingletonManagerSettings
-
- ClusterSingletonManagerSettings$ - Class in akka.cluster.singleton
-
- ClusterSingletonManagerSettings$() - Constructor for class akka.cluster.singleton.ClusterSingletonManagerSettings$
-
- ClusterSingletonProxy - Class in akka.cluster.singleton
-
The
ClusterSingletonProxy
works together with the
ClusterSingletonManager
to provide a
distributed proxy to the singleton actor.
- ClusterSingletonProxy(String, ClusterSingletonProxySettings) - Constructor for class akka.cluster.singleton.ClusterSingletonProxy
-
- ClusterSingletonProxy$ - Class in akka.cluster.singleton
-
- ClusterSingletonProxy$() - Constructor for class akka.cluster.singleton.ClusterSingletonProxy$
-
- ClusterSingletonProxySettings - Class in akka.cluster.singleton
-
param: role The role of the cluster nodes where the singleton can be deployed.
- ClusterSingletonProxySettings(Option<String>, FiniteDuration) - Constructor for class akka.cluster.singleton.ClusterSingletonProxySettings
-
- ClusterSingletonProxySettings$ - Class in akka.cluster.singleton
-
- ClusterSingletonProxySettings$() - Constructor for class akka.cluster.singleton.ClusterSingletonProxySettings$
-
- ClusterUserAction - Class in akka.cluster
-
INTERNAL API
Cluster commands sent by the USER via
Cluster
extension
or JMX.
- ClusterUserAction() - Constructor for class akka.cluster.ClusterUserAction
-
- ClusterUserAction$ - Class in akka.cluster
-
INTERNAL API
Cluster commands sent by the USER via
Cluster
extension
or JMX.
- ClusterUserAction$() - Constructor for class akka.cluster.ClusterUserAction$
-
- ClusterUserAction.Down - Class in akka.cluster
-
Command to mark node as temporary down.
- ClusterUserAction.Down$ - Class in akka.cluster
-
- ClusterUserAction.JoinTo - Class in akka.cluster
-
Command to initiate join another node (represented by address
).
- ClusterUserAction.JoinTo$ - Class in akka.cluster
-
- ClusterUserAction.Leave - Class in akka.cluster
-
Command to leave the cluster.
- ClusterUserAction.Leave$ - Class in akka.cluster
-
- cmd() - Method in class akka.io.Tcp.CommandFailed
-
- cmd() - Method in class akka.io.Udp.CommandFailed
-
- cmd() - Method in class akka.io.UdpConnected.CommandFailed
-
- Cmd(String, int) - Constructor for class akka.persistence.journal.JournalPerfSpec.Cmd
-
- cmd() - Method in class akka.remote.EndpointManager.ManagementCommand
-
- Cmd$() - Constructor for class akka.persistence.journal.JournalPerfSpec.Cmd$
-
- cmp() - Method in class akka.dispatch.BoundedPriorityMailbox
-
- cmp() - Method in class akka.dispatch.BoundedStablePriorityMailbox
-
- cmp() - Method in class akka.dispatch.UnboundedPriorityMailbox
-
- cmp() - Method in class akka.dispatch.UnboundedStablePriorityMailbox
-
- cmp() - Method in class akka.util.PriorityQueueStabilizer.WrappedElementComparator
-
- codec() - Method in class akka.remote.EndpointActor
-
- codec() - Method in class akka.remote.ReliableDeliverySupervisor
-
- collect() - Method in class akka.cluster.ClusterMetricsCollector
-
Samples the latest metrics for the node, updates metrics statistics in
MetricsGossip
, and publishes the change to the event bus.
- collectDelta(Map<Address, Object>) - Method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- CollectionControlMessage - Class in akka.cluster.metrics
-
Runtime collection management commands.
- CollectionControlMessage() - Constructor for class akka.cluster.metrics.CollectionControlMessage
-
- Collections - Class in akka.util
-
INTERNAL API
- Collections() - Constructor for class akka.util.Collections
-
- Collections$ - Class in akka.util
-
INTERNAL API
- Collections$() - Constructor for class akka.util.Collections$
-
- Collections.EmptyImmutableSeq$ - Class in akka.util
-
- Collections.PartialImmutableValuesIterable<From,To> - Class in akka.util
-
- CollectionStartMessage - Class in akka.cluster.metrics
-
- CollectionStartMessage() - Constructor for class akka.cluster.metrics.CollectionStartMessage
-
- CollectionStartMessage$ - Class in akka.cluster.metrics
-
- CollectionStartMessage$() - Constructor for class akka.cluster.metrics.CollectionStartMessage$
-
- CollectionStopMessage - Class in akka.cluster.metrics
-
- CollectionStopMessage() - Constructor for class akka.cluster.metrics.CollectionStopMessage
-
- CollectionStopMessage$ - Class in akka.cluster.metrics
-
- CollectionStopMessage$() - Constructor for class akka.cluster.metrics.CollectionStopMessage$
-
- collector() - Method in class akka.cluster.ClusterMetricsCollector
-
The metrics collector that samples data on the node.
- collector() - Method in class akka.cluster.metrics.ClusterMetricsCollector
-
The metrics collector that samples data on the node.
- CollectorEnabled() - Method in class akka.cluster.metrics.ClusterMetricsSettings
-
- CollectorFallback() - Method in class akka.cluster.metrics.ClusterMetricsSettings
-
- CollectorGossipInterval() - Method in class akka.cluster.metrics.ClusterMetricsSettings
-
- collectorInstance() - Method in class akka.cluster.metrics.ClusterMetricsSupervisor
-
- CollectorMovingAverageHalfLife() - Method in class akka.cluster.metrics.ClusterMetricsSettings
-
- collectorName() - Method in class akka.cluster.metrics.ClusterMetricsSupervisor
-
- CollectorProvider() - Method in class akka.cluster.metrics.ClusterMetricsSettings
-
- CollectorSampleInterval() - Method in class akka.cluster.metrics.ClusterMetricsSettings
-
- command() - Method in class akka.io.SelectionHandler.Retry
-
- CommandAckTimeout() - Method in class akka.remote.RemoteSettings
-
- commander() - Method in class akka.io.SelectionHandler.WorkerForCommand
-
- commander() - Method in class akka.io.TcpConnection.EmptyPendingWrite$
-
- commander() - Method in class akka.io.TcpConnection.PendingBufferWrite
-
- commander() - Method in class akka.io.TcpConnection.PendingWrite
-
- commander() - Method in class akka.io.TcpConnection.PendingWriteFile
-
- CommandFailed(Tcp.Command) - Constructor for class akka.io.Tcp.CommandFailed
-
- CommandFailed(Udp.Command) - Constructor for class akka.io.Udp.CommandFailed
-
- CommandFailed(UdpConnected.Command) - Constructor for class akka.io.UdpConnected.CommandFailed
-
- CommandFailed$() - Constructor for class akka.io.Tcp.CommandFailed$
-
- CommandFailed$() - Constructor for class akka.io.Udp.CommandFailed$
-
- CommandFailed$() - Constructor for class akka.io.UdpConnected.CommandFailed$
-
- CommandOp - Interface in akka.remote.testconductor
-
- COMMANDTYPE_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AkkaControlMessage
-
- committed() - Method in class akka.cluster.metrics.StandardMetrics.HeapMemory
-
- committed() - Method in class akka.cluster.StandardMetrics.HeapMemory
-
- common() - Method in class akka.persistence.Eventsourced.ProcessingState
-
- commonConfig(Config) - Method in class akka.remote.testkit.MultiNodeConfig
-
Register a common base config for all test participants, if so desired.
- CommonHandlers - Interface in akka.remote.transport.netty
-
INTERNAL API
- compact() - Method in class akka.util.ByteString.ByteString1
-
- compact() - Method in class akka.util.ByteString.ByteStrings
-
- compact() - Method in class akka.util.ByteString
-
Create a new ByteString with all contents compacted into a single,
full byte array.
- compact() - Method in class akka.util.CompactByteString
-
- CompactByteString - Class in akka.util
-
A compact ByteString.
- CompactByteString() - Constructor for class akka.util.CompactByteString
-
- CompactByteString$ - Class in akka.util
-
- CompactByteString$() - Constructor for class akka.util.CompactByteString$
-
- Companion$() - Constructor for class akka.util.ByteString.Companion$
-
- compare(UniqueAddress) - Method in class akka.cluster.UniqueAddress
-
- compare(int, int) - Method in class akka.contrib.pattern.ReliableProxy$
-
Wrap-around aware comparison of integers: differences limited to 2**31-1
in magnitude will work correctly.
- compare(int, int) - Static method in class akka.contrib.pattern.ReliableProxy
-
Wrap-around aware comparison of integers: differences limited to 2**31-1
in magnitude will work correctly.
- compare(Envelope, Envelope) - Method in class akka.dispatch.PriorityGenerator
-
- compare(SeqNo) - Method in class akka.remote.SeqNo
-
- compare(ByteString, ByteString) - Method in class akka.util.ByteString.ByteStrings$
-
- compare(PriorityQueueStabilizer.WrappedElement<E>, PriorityQueueStabilizer.WrappedElement<E>) - Method in class akka.util.PriorityQueueStabilizer.WrappedElementComparator
-
- compareClassifiers(C, C) - Method in class akka.event.japi.ScanningEventBus
-
Provides a total ordering of Classifiers (think java.util.Comparator.compare)
- compareClassifiers(ScanningClassification, ScanningClassification) - Method in interface akka.event.ScanningClassification
-
Provides a total ordering of Classifiers (think java.util.Comparator.compare)
- compareIdentityHash(Object, Object) - Method in class akka.util.Helpers$
-
- compareIdentityHash(Object, Object) - Static method in class akka.util.Helpers
-
- compareSubscribers(ActorRef, ActorRef) - Method in interface akka.event.ActorEventBus
-
- compareSubscribers(S, S) - Method in class akka.event.japi.LookupEventBus
-
Provides a total ordering of Subscribers (think java.util.Comparator.compare)
- compareSubscribers(S, S) - Method in class akka.event.japi.ScanningEventBus
-
Provides a total ordering of Subscribers (think java.util.Comparator.compare)
- compareSubscribers(LookupClassification, LookupClassification) - Method in interface akka.event.LookupClassification
-
Provides a total ordering of Subscribers (think java.util.Comparator.compare)
- compareSubscribers(ScanningClassification, ScanningClassification) - Method in interface akka.event.ScanningClassification
-
Provides a total ordering of Subscribers (think java.util.Comparator.compare)
- compareTo(ActorRef) - Method in class akka.actor.ActorRef
-
Comparison takes path and the unique id of the actor cell into account.
- compareTo(ActorPath) - Method in class akka.actor.ChildActorPath
-
- compareTo(ActorPath) - Method in class akka.actor.RootActorPath
-
- compareTo(VectorClock) - Method in class akka.cluster.VectorClock
-
Compare two vector clocks.
- compareTo(ActorRef<?>) - Method in class akka.typed.ActorRef
-
- complete() - Method in class akka.testkit.DebugFilter
-
- complete() - Method in class akka.testkit.ErrorFilter
-
- complete() - Method in class akka.testkit.EventFilter
-
- complete() - Method in class akka.testkit.InfoFilter
-
- complete() - Method in class akka.testkit.WarningFilter
-
- completeConnect(ChannelRegistration, ActorRef, Traversable<Inet.SocketOption>) - Method in class akka.io.TcpConnection
-
used in subclasses to start the common machinery above once a channel is connected
- CompoundWrite(Tcp.SimpleWriteCommand, Tcp.WriteCommand) - Constructor for class akka.io.Tcp.CompoundWrite
-
- CompoundWrite$() - Constructor for class akka.io.Tcp.CompoundWrite$
-
- compress(MessageLite) - Method in class akka.cluster.metrics.protobuf.MessageSerializer
-
- compress(MessageLite) - Method in class akka.cluster.protobuf.ClusterMessageSerializer
-
- compress(MessageLite) - Method in class akka.cluster.pubsub.protobuf.DistributedPubSubMessageSerializer
-
- concat(ByteString) - Method in class akka.util.ByteString
-
Java API: efficiently concatenate another ByteString.
- Concurrent$() - Constructor for class akka.cluster.VectorClock.Concurrent$
-
- ConcurrentMultiMap<K,V> - Class in akka.util
-
An implementation of a ConcurrentMultiMap
Adds/remove is serialized over the specified key
Reads are fully concurrent <-- el-cheapo
- ConcurrentMultiMap(int, Comparator<V>) - Constructor for class akka.util.ConcurrentMultiMap
-
- cond() - Method in class akka.testkit.JavaTestKit.AwaitCond
-
- Conductor - Interface in akka.remote.testconductor
-
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
.
- ConductorHandler - Class in akka.remote.testconductor
-
This handler is installed at the end of the controller’s netty pipeline.
- ConductorHandler(Timeout, ActorRef, LoggingAdapter) - Constructor for class akka.remote.testconductor.ConductorHandler
-
- config() - Method in class akka.actor.ActorDSL.Extension
-
- config() - Method in class akka.actor.ActorSystem.Settings
-
The backing Config of this ActorSystem's Settings
- config() - Method in class akka.actor.Deploy
-
- config() - Method in class akka.camel.internal.CamelSupervisor.Register
-
- config() - Method in class akka.cluster.ClusterSettings
-
- config() - Method in class akka.cluster.metrics.ClusterMetricsSettings
-
- config() - Method in class akka.cluster.sharding.ClusterSharding.Settings$
-
- config() - Method in interface akka.dispatch.CachingConfig.PathEntry
-
- config() - Method in class akka.dispatch.CachingConfig.StringPathEntry
-
- config() - Method in class akka.dispatch.CachingConfig.ValuePathEntry
-
- config(String) - Method in class akka.dispatch.Dispatchers
-
INTERNAL API
- config(String, Config) - Method in class akka.dispatch.Dispatchers
-
INTERNAL API
- config() - Method in class akka.dispatch.MessageDispatcherConfigurator
-
- config() - Method in class akka.dispatch.ThreadPoolConfigBuilder
-
- config() - Method in class akka.persistence.journal.JournalSpec$
-
- config() - Static method in class akka.persistence.journal.JournalSpec
-
- config() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
-
- config() - Method in class akka.persistence.PluginSpec
-
- config() - Method in class akka.persistence.snapshot.SnapshotStoreSpec$
-
- config() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- config() - Method in class akka.remote.RemoteSettings
-
- config() - Method in class akka.remote.testconductor.TestConductorExt.Settings
-
- config() - Method in class akka.remote.testkit.MultiNodeConfig
-
- config() - Method in class akka.serialization.Serialization.Settings
-
- config() - Method in class akka.testkit.TestKitSettings
-
- config() - Method in class akka.util.Helpers.ConfigOps
-
- CONFIG_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DeployData
-
- ConfigOps(Config) - Constructor for class akka.util.Helpers.ConfigOps
-
- ConfigOps$() - Constructor for class akka.util.Helpers.ConfigOps$
-
- configPath() - Method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- configPath() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
-
- configPath() - Method in class akka.persistence.journal.leveldb.SharedLeveldbStore
-
- ConfigurationException - Exception in akka
-
This exception is thrown when Akka detects a problem with the provided configuration
- ConfigurationException(String, Throwable) - Constructor for exception akka.ConfigurationException
-
- ConfigurationException(String) - Constructor for exception akka.ConfigurationException
-
- configurator() - Method in class akka.dispatch.MessageDispatcher
-
- configure() - Method in class akka.camel.internal.ConsumerActorRouteBuilder
-
- configure(Seq<Option<Function1<ThreadPoolConfigBuilder, ThreadPoolConfigBuilder>>>) - Method in class akka.dispatch.ThreadPoolConfigBuilder
-
- configure(BundleContext, ActorSystem) - Method in class akka.osgi.ActorSystemActivator
-
Implement this method to add your own actors to the ActorSystem.
- configureDispatcher(Props) - Method in class akka.remote.RARP
-
- configureDispatcher(Props) - Method in class akka.remote.RemoteSettings
-
- configureExecutor() - Method in class akka.dispatch.MessageDispatcherConfigurator
-
- ConfigVersion() - Method in class akka.actor.ActorSystem.Settings
-
- confirmDelivery(long) - Method in interface akka.persistence.AtLeastOnceDelivery
-
Call this method when a message has been confirmed by the destination,
or to abort re-sending.
- ConfirmedClientOp - Interface in akka.remote.testconductor
-
- confirmedClose() - Method in class akka.io.TcpMessage$
-
A confirmed close operation will flush pending writes and half-close the
connection, waiting for the peer to close the other half.
- confirmedClose() - Static method in class akka.io.TcpMessage
-
A confirmed close operation will flush pending writes and half-close the
connection, waiting for the peer to close the other half.
- ConfirmedClose$() - Constructor for class akka.io.Tcp.ConfirmedClose$
-
- ConfirmedClosed$() - Constructor for class akka.io.Tcp.ConfirmedClosed$
-
- Connect(InetSocketAddress, Option<InetSocketAddress>, Traversable<Inet.SocketOption>, Option<FiniteDuration>, boolean) - Constructor for class akka.io.Tcp.Connect
-
- connect(InetSocketAddress, InetSocketAddress, Iterable<Inet.SocketOption>, FiniteDuration, boolean) - Method in class akka.io.TcpMessage$
-
The Connect message is sent to the TCP manager actor, which is obtained via
TcpExt.getManager()
.
- connect(InetSocketAddress) - Method in class akka.io.TcpMessage$
-
Connect to the given remoteAddress
without binding to a local address and without
specifying options.
- connect(InetSocketAddress, InetSocketAddress, Iterable<Inet.SocketOption>, FiniteDuration, boolean) - Static method in class akka.io.TcpMessage
-
The Connect message is sent to the TCP manager actor, which is obtained via
TcpExt.getManager()
.
- connect(InetSocketAddress) - Static method in class akka.io.TcpMessage
-
Connect to the given remoteAddress
without binding to a local address and without
specifying options.
- Connect(ActorRef, InetSocketAddress, Option<InetSocketAddress>, Traversable<Inet.SocketOption>) - Constructor for class akka.io.UdpConnected.Connect
-
- connect(ActorRef, InetSocketAddress, InetSocketAddress, Iterable<Inet.SocketOption>) - Method in class akka.io.UdpConnectedMessage$
-
Send this message to the
UdpExt.manager()
in order to bind to a local
port (optionally with the chosen
localAddress
) and create a UDP socket
which is restricted to sending to and receiving from the given
remoteAddress
.
- connect(ActorRef, InetSocketAddress, Iterable<Inet.SocketOption>) - Method in class akka.io.UdpConnectedMessage$
-
Connect without specifying the localAddress
.
- connect(ActorRef, InetSocketAddress) - Method in class akka.io.UdpConnectedMessage$
-
Connect without specifying the localAddress
or options
.
- connect(ActorRef, InetSocketAddress, InetSocketAddress, Iterable<Inet.SocketOption>) - Static method in class akka.io.UdpConnectedMessage
-
Send this message to the
UdpExt.manager()
in order to bind to a local
port (optionally with the chosen
localAddress
) and create a UDP socket
which is restricted to sending to and receiving from the given
remoteAddress
.
- connect(ActorRef, InetSocketAddress, Iterable<Inet.SocketOption>) - Static method in class akka.io.UdpConnectedMessage
-
Connect without specifying the localAddress
.
- connect(ActorRef, InetSocketAddress) - Static method in class akka.io.UdpConnectedMessage
-
Connect without specifying the localAddress
or options
.
- Connect$() - Constructor for class akka.io.Tcp.Connect$
-
- Connect$() - Constructor for class akka.io.UdpConnected.Connect$
-
- Connected(InetSocketAddress, InetSocketAddress) - Constructor for class akka.io.Tcp.Connected
-
- connected(TcpConnection.ConnectionInfo) - Method in class akka.io.TcpConnection
-
normal connected state
- connected(ChannelRegistration) - Method in class akka.io.UdpConnection
-
- Connected(Channel) - Constructor for class akka.remote.testconductor.ClientFSM.Connected
-
- Connected$() - Constructor for class akka.io.Tcp.Connected$
-
- Connected$() - Constructor for class akka.io.UdpConnected.Connected$
-
- Connected$() - Constructor for class akka.remote.testconductor.ClientFSM.Connected$
-
- connecting(ChannelRegistration, int) - Method in class akka.io.TcpOutgoingConnection
-
- Connecting$() - Constructor for class akka.contrib.pattern.ReliableProxy.Connecting$
-
- Connecting$() - Constructor for class akka.remote.testconductor.ClientFSM.Connecting$
-
- connection() - Method in class akka.remote.testconductor.Controller
-
- ConnectionFailure(String) - Constructor for exception akka.remote.testconductor.ClientFSM.ConnectionFailure
-
- ConnectionFailure$() - Constructor for class akka.remote.testconductor.ClientFSM.ConnectionFailure$
-
- ConnectionInfo(ChannelRegistration, ActorRef, boolean, boolean) - Constructor for class akka.io.TcpConnection.ConnectionInfo
-
- ConnectionInfo$() - Constructor for class akka.io.TcpConnection.ConnectionInfo$
-
- connectionSupervisorStrategy() - Method in class akka.io.SelectionHandler$
-
Special supervisor strategy for parents of TCP connection and listener actors.
- connectionSupervisorStrategy() - Static method in class akka.io.SelectionHandler
-
Special supervisor strategy for parents of TCP connection and listener actors.
- ConnectionTimeout() - Method in class akka.remote.transport.netty.NettyTransportSettings
-
- ConnectTimeout() - Method in class akka.remote.testconductor.TestConductorExt.Settings
-
- consistentHash() - Method in class akka.cluster.client.ClusterReceptionist
-
- ConsistentHash<T> - Class in akka.routing
-
Consistent Hashing node ring implementation.
- ConsistentHash$ - Class in akka.routing
-
- ConsistentHash$() - Constructor for class akka.routing.ConsistentHash$
-
- ConsistentHashableEnvelope(Object, Object) - Constructor for class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope
-
- ConsistentHashableEnvelope$() - Constructor for class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope$
-
- ConsistentHashingGroup - Class in akka.routing
-
A router group that uses consistent hashing to select a routee based on the
sent message.
- ConsistentHashingGroup(Iterable<String>, int, PartialFunction<Object, Object>, String) - Constructor for class akka.routing.ConsistentHashingGroup
-
- ConsistentHashingGroup(Config) - Constructor for class akka.routing.ConsistentHashingGroup
-
- ConsistentHashingGroup(Iterable<String>) - Constructor for class akka.routing.ConsistentHashingGroup
-
Java API
- ConsistentHashingGroup$ - Class in akka.routing
-
- ConsistentHashingGroup$() - Constructor for class akka.routing.ConsistentHashingGroup$
-
- ConsistentHashingPool - Class in akka.routing
-
A router pool that uses consistent hashing to select a routee based on the
sent message.
- ConsistentHashingPool(int, Option<Resizer>, int, PartialFunction<Object, Object>, SupervisorStrategy, String, boolean) - Constructor for class akka.routing.ConsistentHashingPool
-
- ConsistentHashingPool(Config) - Constructor for class akka.routing.ConsistentHashingPool
-
- ConsistentHashingPool(int) - Constructor for class akka.routing.ConsistentHashingPool
-
Java API
- ConsistentHashingPool$ - Class in akka.routing
-
- ConsistentHashingPool$() - Constructor for class akka.routing.ConsistentHashingPool$
-
- ConsistentHashingRouter - Class in akka.routing
-
- ConsistentHashingRouter() - Constructor for class akka.routing.ConsistentHashingRouter
-
- ConsistentHashingRouter$ - Class in akka.routing
-
- ConsistentHashingRouter$() - Constructor for class akka.routing.ConsistentHashingRouter$
-
- ConsistentHashingRouter.ConsistentHashable - Interface in akka.routing
-
If you don't define the
hashMapping
when
constructing the
ConsistentHashingRouter
the messages need to implement this interface to define what
data to use for the consistent hash key.
- ConsistentHashingRouter.ConsistentHashableEnvelope - Class in akka.routing
-
- ConsistentHashingRouter.ConsistentHashableEnvelope$ - Class in akka.routing
-
- ConsistentHashingRouter.ConsistentHashMapper - Interface in akka.routing
-
JAVA API
Mapping from message to the data to use for the consistent hash key.
- ConsistentHashingRouter.emptyConsistentHashMapping$ - Class in akka.routing
-
- ConsistentHashingRoutingLogic - Class in akka.routing
-
- ConsistentHashingRoutingLogic(ActorSystem, int, PartialFunction<Object, Object>) - Constructor for class akka.routing.ConsistentHashingRoutingLogic
-
- ConsistentHashingRoutingLogic(ActorSystem) - Constructor for class akka.routing.ConsistentHashingRoutingLogic
-
Java API
- ConsistentHashingRoutingLogic$ - Class in akka.routing
-
- ConsistentHashingRoutingLogic$() - Constructor for class akka.routing.ConsistentHashingRoutingLogic$
-
- consistentHashKey() - Method in class akka.io.Dns.Resolve
-
- consistentHashKey() - Method in interface akka.routing.ConsistentHashingRouter.ConsistentHashable
-
- consistentHashKey() - Method in class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope
-
- ConsistentRoutee - Class in akka.routing
-
INTERNAL API
Important to use ActorRef with full address, with host and port, in the hash ring,
so that same ring is produced on different nodes.
- ConsistentRoutee(Routee, Address) - Constructor for class akka.routing.ConsistentRoutee
-
- ConsistentRoutee$ - Class in akka.routing
-
- ConsistentRoutee$() - Constructor for class akka.routing.ConsistentRoutee$
-
- constructAssociate(HandshakeInfo) - Method in interface akka.remote.transport.AkkaPduCodec
-
- constructAssociate(HandshakeInfo) - Method in class akka.remote.transport.AkkaPduProtobufCodec$
-
- constructAssociate(HandshakeInfo) - Static method in class akka.remote.transport.AkkaPduProtobufCodec
-
- constructDisassociate(AssociationHandle.DisassociateInfo) - Method in interface akka.remote.transport.AkkaPduCodec
-
- constructDisassociate(AssociationHandle.DisassociateInfo) - Method in class akka.remote.transport.AkkaPduProtobufCodec$
-
- constructDisassociate(AssociationHandle.DisassociateInfo) - Static method in class akka.remote.transport.AkkaPduProtobufCodec
-
- constructHeartbeat() - Method in interface akka.remote.transport.AkkaPduCodec
-
- constructHeartbeat() - Method in class akka.remote.transport.AkkaPduProtobufCodec$
-
- constructHeartbeat() - Static method in class akka.remote.transport.AkkaPduProtobufCodec
-
- constructMessage(Address, ActorRef, WireFormats.SerializedMessage, Option<ActorRef>, Option<SeqNo>, Option<Ack>) - Method in interface akka.remote.transport.AkkaPduCodec
-
- constructMessage(Address, ActorRef, WireFormats.SerializedMessage, Option<ActorRef>, Option<SeqNo>, Option<Ack>) - Method in class akka.remote.transport.AkkaPduProtobufCodec$
-
- constructMessage(Address, ActorRef, WireFormats.SerializedMessage, Option<ActorRef>, Option<SeqNo>, Option<Ack>) - Static method in class akka.remote.transport.AkkaPduProtobufCodec
-
- constructPayload(ByteString) - Method in interface akka.remote.transport.AkkaPduCodec
-
- constructPayload(ByteString) - Method in class akka.remote.transport.AkkaPduProtobufCodec$
-
- constructPayload(ByteString) - Static method in class akka.remote.transport.AkkaPduProtobufCodec
-
- constructPureAck(Ack) - Method in interface akka.remote.transport.AkkaPduCodec
-
- constructPureAck(Ack) - Method in class akka.remote.transport.AkkaPduProtobufCodec$
-
- constructPureAck(Ack) - Static method in class akka.remote.transport.AkkaPduProtobufCodec
-
- Consumer - Interface in akka.camel
-
Mixed in by Actor implementations that consume message from Camel endpoints.
- Consumer$ - Class in akka.camel
-
Internal use only.
- Consumer$() - Constructor for class akka.camel.Consumer$
-
- ConsumerActorRouteBuilder - Class in akka.camel.internal
-
INTERNAL API
Builder of a route to a target which can be an actor.
- ConsumerActorRouteBuilder(String, ActorRef, ConsumerConfig, CamelSettings) - Constructor for class akka.camel.internal.ConsumerActorRouteBuilder
-
- ConsumerConfig - Class in akka.camel
-
INTERNAL API
Captures the configuration of the Consumer.
- ConsumerConfig(FiniteDuration, FiniteDuration, boolean, Function1<RouteDefinition, ProcessorDefinition<?>>) - Constructor for class akka.camel.ConsumerConfig
-
- ConsumerConfig$ - Class in akka.camel
-
- ConsumerConfig$() - Constructor for class akka.camel.ConsumerConfig$
-
- ConsumerRegistrar - Class in akka.camel.internal
-
INTERNAL API
Registers Consumers.
- ConsumerRegistrar(ActorRef) - Constructor for class akka.camel.internal.ConsumerRegistrar
-
- contactPoints() - Method in class akka.cluster.client.ClusterReceptionist.Internal$.Contacts
-
- contacts() - Method in class akka.cluster.client.ClusterClient
-
- Contacts(IndexedSeq<ActorSelection>) - Constructor for class akka.cluster.client.ClusterReceptionist.Internal$.Contacts
-
- ContainerFormats - Class in akka.remote
-
- ContainerFormats.PatternType - Enum in akka.remote
-
Protobuf enum PatternType
- ContainerFormats.Selection - Class in akka.remote
-
Protobuf type Selection
- ContainerFormats.Selection.Builder - Class in akka.remote
-
Protobuf type Selection
- ContainerFormats.SelectionEnvelope - Class in akka.remote
-
Protobuf type SelectionEnvelope
- ContainerFormats.SelectionEnvelope.Builder - Class in akka.remote
-
Protobuf type SelectionEnvelope
- ContainerFormats.SelectionEnvelopeOrBuilder - Interface in akka.remote
-
- ContainerFormats.SelectionOrBuilder - Interface in akka.remote
-
- contains(Object) - Method in class akka.util.BoundedBlockingQueue
-
- containsAll(Collection<?>) - Method in class akka.util.BoundedBlockingQueue
-
- content() - Method in class akka.cluster.pubsub.DistributedPubSubMediator.Internal$.Bucket
-
- CONTENT_FIELD_NUMBER - Static variable in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
-
- context() - Method in interface akka.actor.Actor
-
Stores the context for this actor, including self, and sender.
- context() - Method in interface akka.actor.StashSupport
-
INTERNAL API.
- context() - Method in class akka.actor.TypedActor$
-
Returns the ActorContext (for a TypedActor) when inside a method call in a TypedActor.
- context() - Static method in class akka.actor.TypedActor
-
Returns the ActorContext (for a TypedActor) when inside a method call in a TypedActor.
- context() - Method in interface akka.camel.Camel
-
Underlying camel context.
- context() - Method in class akka.camel.internal.DefaultCamel
-
- context() - Method in class akka.osgi.OsgiActorSystemFactory
-
- context() - Method in class akka.routing.TailChoppingRoutingLogic
-
- context() - Method in class akka.util.SerializedSuspendableExecutionContext
-
- ContextAware(Function1<ActorContext<T>, Behavior<T>>) - Method in class akka.typed.ScalaDSL$
-
A behavior decorator that extracts the
ActorContext
while receiving the
the first signal or message and uses that to construct the real behavior
(which will then also receive that signal or message).
- ContextAware(Function1<ActorContext<T>, Behavior<T>>) - Static method in class akka.typed.ScalaDSL
-
A behavior decorator that extracts the
ActorContext
while receiving the
the first signal or message and uses that to construct the real behavior
(which will then also receive that signal or message).
- contextClassLoader() - Method in class akka.dispatch.MonitorableThreadFactory
-
- ContextProvider() - Method in class akka.camel.CamelSettings
-
Configured setting, determine the class used to load/retrive the instance of the Camel Context
- ContextProvider - Interface in akka.camel
-
Implement this interface in order to inject a specific CamelContext in a system
An instance of this class must be instantiable using a no-arg constructor.
- contextStack() - Method in class akka.actor.ActorCell$
-
- contextStack() - Static method in class akka.actor.ActorCell
-
- ContextualTypedActorFactory - Class in akka.actor
-
ContextualTypedActorFactory allows TypedActors to create children, effectively forming the same Actor Supervision Hierarchies
as normal Actors can.
- ContextualTypedActorFactory(TypedActorExtension, ActorContext) - Constructor for class akka.actor.ContextualTypedActorFactory
-
- ContextualTypedActorFactory$ - Class in akka.actor
-
- ContextualTypedActorFactory$() - Constructor for class akka.actor.ContextualTypedActorFactory$
-
- continueGetShardHome(String, ActorRef, ActorRef) - Method in class akka.cluster.sharding.ShardCoordinator
-
- continueRebalance(Set<String>) - Method in class akka.cluster.sharding.ShardCoordinator
-
- ControlAwareMessageQueueSemantics - Interface in akka.dispatch
-
ControlAwareMessageQueue handles messages that extend
ControlMessage
with priority.
- controller() - Method in interface akka.remote.testconductor.Conductor
-
- Controller - Class in akka.remote.testconductor
-
This controls test execution by managing barriers (delegated to
BarrierCoordinator
, its child) and allowing
network and other failures to be injected at the test nodes.
- Controller(int, InetSocketAddress) - Constructor for class akka.remote.testconductor.Controller
-
- controller() - Method in class akka.remote.testconductor.ServerFSM
-
- Controller$ - Class in akka.remote.testconductor
-
INTERNAL API.
- Controller$() - Constructor for class akka.remote.testconductor.Controller$
-
- Controller.ClientDisconnected - Class in akka.remote.testconductor
-
- Controller.ClientDisconnected$ - Class in akka.remote.testconductor
-
- Controller.ClientDisconnectedException - Exception in akka.remote.testconductor
-
- Controller.CreateServerFSM - Class in akka.remote.testconductor
-
- Controller.CreateServerFSM$ - Class in akka.remote.testconductor
-
- Controller.GetNodes$ - Class in akka.remote.testconductor
-
- Controller.GetSockAddr$ - Class in akka.remote.testconductor
-
- Controller.NodeInfo - Class in akka.remote.testconductor
-
- Controller.NodeInfo$ - Class in akka.remote.testconductor
-
- ControlMessage - Interface in akka.dispatch
-
Messages that extend this trait will be handled with priority by control aware mailboxes.
- controlQueue() - Method in class akka.dispatch.BoundedControlAwareMailbox.MessageQueue
-
- controlQueue() - Method in interface akka.dispatch.ControlAwareMessageQueueSemantics
-
- controlQueue() - Method in class akka.dispatch.UnboundedControlAwareMailbox.MessageQueue
-
- convergence() - Method in class akka.cluster.ClusterEvent.SeenChanged
-
- convergence(UniqueAddress) - Method in class akka.cluster.Gossip
-
Checks if we have a cluster convergence.
- convergenceSkipUnreachableWithMemberStatus() - Method in class akka.cluster.Gossip$
-
- convergenceSkipUnreachableWithMemberStatus() - Static method in class akka.cluster.Gossip
-
- Conversions() - Method in class akka.camel.CamelSettings
-
- convertNumber(Object) - Method in interface akka.cluster.MetricNumericConverter
-
May involve rounding or truncation.
- convertNumber(Object) - Method in interface akka.cluster.metrics.MetricNumericConverter
-
May involve rounding or truncation.
- convertTo(Class<T>, Exchange, Object) - Method in class akka.camel.internal.component.DurationTypeConverter$
-
- convertTo(Class<T>, Exchange, Object) - Static method in class akka.camel.internal.component.DurationTypeConverter
-
- cookie() - Method in class akka.remote.transport.HandshakeInfo
-
- COOKIE_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AkkaHandshakeInfo
-
- coordinator() - Method in class akka.cluster.sharding.ShardCoordinator.Internal$.RegisterAck
-
- coordinator() - Method in class akka.cluster.sharding.ShardRegion
-
- CoordinatorFailureBackoff() - Method in class akka.cluster.sharding.ClusterSharding.Settings$
-
- coordinatorSelection() - Method in class akka.cluster.sharding.ShardRegion
-
- copy(S, D, Option<FiniteDuration>, Option<FSM.Reason>, List<Object>) - Method in class akka.actor.FSM.SilentState
-
- copy(S, D, Option<FiniteDuration>, Option<FSM.Reason>, List<Object>) - Method in class akka.actor.FSM.State
-
- copy(MemberStatus) - Method in class akka.cluster.Member
-
- copyContent(CamelMessage, Message) - Method in class akka.camel.CamelMessage$
-
INTERNAL API
copies the content of this CamelMessage to an Apache Camel Message.
- copyContent(CamelMessage, Message) - Static method in class akka.camel.CamelMessage
-
INTERNAL API
copies the content of this CamelMessage to an Apache Camel Message.
- copyToArray(Object, int, int) - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- copyToArray(Object, int, int) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- copyToArray(Object, int, int) - Method in class akka.util.ByteString
-
- copyToBuffer(ByteBuffer) - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- copyToBuffer(ByteBuffer) - Method in class akka.util.ByteIterator
-
Copy as many bytes as possible to a ByteBuffer, starting from it's
current position.
- copyToBuffer(ByteBuffer) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- copyToBuffer(ByteBuffer) - Method in class akka.util.ByteString
-
Copy as many bytes as possible to a ByteBuffer, starting from it's
current position.
- copyUp(int) - Method in class akka.cluster.Member
-
- coreDaemon() - Method in class akka.cluster.ClusterCoreSupervisor
-
- corePoolSize() - Method in class akka.dispatch.ThreadPoolConfig
-
- coreSupervisor() - Method in class akka.cluster.ClusterDaemon
-
- correlationId() - Method in class akka.actor.ActorIdentity
-
- count - Variable in class akka.dispatch.AbstractBoundedNodeQueue.Node
-
- count() - Method in class akka.dispatch.AbstractNodeQueue
-
- count() - Method in class akka.event.DeadLetterListener
-
- count() - Method in class akka.io.Tcp.WriteFile
-
- Count$() - Constructor for class akka.cluster.pubsub.DistributedPubSubMediator.Count$
-
- countDown() - Method in class akka.testkit.TestLatch
-
- counter() - Method in class akka.dispatch.MonitorableThreadFactory
-
- counter() - Method in class akka.persistence.journal.JournalPerfSpec.BenchActor
-
- counterFromBytes(byte[]) - Method in class akka.persistence.journal.leveldb.Key$
-
- counterFromBytes(byte[]) - Static method in class akka.persistence.journal.leveldb.Key
-
- counterKey(int) - Method in class akka.persistence.journal.leveldb.Key$
-
- counterKey(int) - Static method in class akka.persistence.journal.leveldb.Key
-
- counterToBytes(long) - Method in class akka.persistence.journal.leveldb.Key$
-
- counterToBytes(long) - Static method in class akka.persistence.journal.leveldb.Key
-
- counts(int, int) - Method in class akka.remote.RemoteWatcher.Stats$
-
- Cpu(Address, long, Option<Object>, Option<Object>, Option<Object>, int) - Constructor for class akka.cluster.metrics.StandardMetrics.Cpu
-
- Cpu(Address, long, Option<Object>, Option<Object>, int) - Constructor for class akka.cluster.StandardMetrics.Cpu
-
- Cpu$() - Constructor for class akka.cluster.metrics.StandardMetrics.Cpu$
-
- Cpu$() - Constructor for class akka.cluster.StandardMetrics.Cpu$
-
- cpuCombined(CpuPerc) - Method in class akka.cluster.metrics.SigarMetricsCollector
-
(SIGAR) Returns the combined CPU sum of User + Sys + Nice + Wait, in percentage.
- CpuCombined() - Method in class akka.cluster.metrics.StandardMetrics$
-
Sum of User + Sys + Nice + Wait.
- cpuCombined() - Method in class akka.cluster.metrics.StandardMetrics.Cpu
-
- CpuCombined() - Static method in class akka.cluster.metrics.StandardMetrics
-
Sum of User + Sys + Nice + Wait.
- cpuCombined() - Method in class akka.cluster.SigarMetricsCollector
-
(SIGAR) Returns the combined CPU sum of User + Sys + Nice + Wait, in percentage.
- CpuCombined() - Method in class akka.cluster.StandardMetrics$
-
- cpuCombined() - Method in class akka.cluster.StandardMetrics.Cpu
-
- CpuCombined() - Static method in class akka.cluster.StandardMetrics
-
- cpuIdle(CpuPerc) - Method in class akka.cluster.metrics.SigarMetricsCollector
-
(SIGAR) Returns the idle CPU time.
- CpuIdle() - Method in class akka.cluster.metrics.StandardMetrics$
-
Amount of CPU time left after combined and stolen are removed.
- CpuIdle() - Static method in class akka.cluster.metrics.StandardMetrics
-
Amount of CPU time left after combined and stolen are removed.
- CpuMetricsSelector - Class in akka.cluster.metrics
-
MetricsSelector that uses the combined CPU time metrics and stolen CPU time metrics.
- CpuMetricsSelector() - Constructor for class akka.cluster.metrics.CpuMetricsSelector
-
- CpuMetricsSelector - Class in akka.cluster.routing
-
MetricsSelector that uses the combined CPU metrics.
- CpuMetricsSelector() - Constructor for class akka.cluster.routing.CpuMetricsSelector
-
- CpuMetricsSelector$ - Class in akka.cluster.metrics
-
MetricsSelector that uses the combined CPU time metrics and stolen CPU time metrics.
- CpuMetricsSelector$() - Constructor for class akka.cluster.metrics.CpuMetricsSelector$
-
- CpuMetricsSelector$ - Class in akka.cluster.routing
-
MetricsSelector that uses the combined CPU metrics.
- CpuMetricsSelector$() - Constructor for class akka.cluster.routing.CpuMetricsSelector$
-
- cpuStolen(CpuPerc) - Method in class akka.cluster.metrics.SigarMetricsCollector
-
(SIGAR) Returns the stolen CPU time.
- CpuStolen() - Method in class akka.cluster.metrics.StandardMetrics$
-
The amount of CPU 'stolen' from this virtual machine by the hypervisor for other tasks (such as running another virtual machine).
- cpuStolen() - Method in class akka.cluster.metrics.StandardMetrics.Cpu
-
- CpuStolen() - Static method in class akka.cluster.metrics.StandardMetrics
-
The amount of CPU 'stolen' from this virtual machine by the hypervisor for other tasks (such as running another virtual machine).
- create(Option<ActorInitializationException>) - Method in class akka.actor.ActorCell
-
- create() - Method in class akka.actor.ActorSystem$
-
Creates a new ActorSystem with the name "default",
obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader,
then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader
associated with the ActorSystem class.
- create(String) - Method in class akka.actor.ActorSystem$
-
Creates a new ActorSystem with the specified name,
obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader,
then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader
associated with the ActorSystem class.
- create(String, Config) - Method in class akka.actor.ActorSystem$
-
Creates a new ActorSystem with the specified name, and the specified Config, then
obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader,
then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader
associated with the ActorSystem class.
- create(String, Config, ClassLoader) - Method in class akka.actor.ActorSystem$
-
Creates a new ActorSystem with the specified name, the specified Config, and specified ClassLoader
- create(String, Config, ClassLoader, ExecutionContext) - Method in class akka.actor.ActorSystem$
-
Creates a new ActorSystem with the specified name, the specified Config, the specified ClassLoader,
and the specified ExecutionContext.
- create() - Static method in class akka.actor.ActorSystem
-
Creates a new ActorSystem with the name "default",
obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader,
then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader
associated with the ActorSystem class.
- create(String) - Static method in class akka.actor.ActorSystem
-
Creates a new ActorSystem with the specified name,
obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader,
then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader
associated with the ActorSystem class.
- create(String, Config) - Static method in class akka.actor.ActorSystem
-
Creates a new ActorSystem with the specified name, and the specified Config, then
obtains the current ClassLoader by first inspecting the current threads' getContextClassLoader,
then tries to walk the stack to find the callers class loader, then falls back to the ClassLoader
associated with the ActorSystem class.
- create(String, Config, ClassLoader) - Static method in class akka.actor.ActorSystem
-
Creates a new ActorSystem with the specified name, the specified Config, and specified ClassLoader
- create(String, Config, ClassLoader, ExecutionContext) - Static method in class akka.actor.ActorSystem
-
Creates a new ActorSystem with the specified name, the specified Config, the specified ClassLoader,
and the specified ExecutionContext.
- create() - Method in class akka.actor.DefaultSupervisorStrategy
-
- create(ActorSystem) - Method in class akka.actor.Inbox$
-
Create a new Inbox within the given system.
- create(ActorSystem) - Static method in class akka.actor.Inbox
-
Create a new Inbox within the given system.
- create(Class<?>, Object...) - Method in class akka.actor.Props$
-
Java API: create a Props given a class and its constructor arguments.
- create(Class<?>, Seq<Object>) - Method in class akka.actor.Props$
-
- create(Creator<T>) - Method in class akka.actor.Props$
-
Create new Props from the given
Creator
.
- create(Class<T>, Creator<T>) - Method in class akka.actor.Props$
-
Create new Props from the given
Creator
with the type set to the given actorClass.
- create(Class<?>, Object...) - Static method in class akka.actor.Props
-
Java API: create a Props given a class and its constructor arguments.
- create(Class<?>, Seq<Object>) - Static method in class akka.actor.Props
-
- create(Creator<T>) - Static method in class akka.actor.Props
-
Create new Props from the given
Creator
.
- create(Class<T>, Creator<T>) - Static method in class akka.actor.Props
-
Create new Props from the given
Creator
with the type set to the given actorClass.
- create() - Method in class akka.actor.StoppingSupervisorStrategy
-
- create() - Method in interface akka.actor.SupervisorStrategyConfigurator
-
- create(T, ExecutionContext) - Method in class akka.agent.Agent$
-
Java API: Factory method for creating an Agent.
- create(T, ExecutionContext) - Static method in class akka.agent.Agent
-
Java API: Factory method for creating an Agent.
- create(ActorSystem) - Method in class akka.cluster.client.ClusterClientSettings$
-
Java API: Create settings from the default configuration
akka.cluster.client
.
- create(Config) - Method in class akka.cluster.client.ClusterClientSettings$
-
Java API: Create settings from a configuration with the same layout as
the default configuration akka.cluster.client
.
- create(ActorSystem) - Static method in class akka.cluster.client.ClusterClientSettings
-
Java API: Create settings from the default configuration
akka.cluster.client
.
- create(Config) - Static method in class akka.cluster.client.ClusterClientSettings
-
Java API: Create settings from a configuration with the same layout as
the default configuration akka.cluster.client
.
- create(ActorSystem) - Method in class akka.cluster.client.ClusterReceptionistSettings$
-
Java API: Create settings from the default configuration
akka.cluster.client.receptionist
.
- create(Config) - Method in class akka.cluster.client.ClusterReceptionistSettings$
-
Java API: Create settings from a configuration with the same layout as
the default configuration akka.cluster.client.receptionist
.
- create(ActorSystem) - Static method in class akka.cluster.client.ClusterReceptionistSettings
-
Java API: Create settings from the default configuration
akka.cluster.client.receptionist
.
- create(Config) - Static method in class akka.cluster.client.ClusterReceptionistSettings
-
Java API: Create settings from a configuration with the same layout as
the default configuration akka.cluster.client.receptionist
.
- create(String, Number, Option<Object>) - Method in class akka.cluster.Metric$
-
Creates a new Metric instance if the value is valid, otherwise None
is returned.
- create(String, Try<Number>, Option<Object>) - Method in class akka.cluster.Metric$
-
Creates a new Metric instance if the Try is successful and the value is valid,
otherwise None is returned.
- create(String, Number, Option<Object>) - Static method in class akka.cluster.Metric
-
Creates a new Metric instance if the value is valid, otherwise None
is returned.
- create(String, Try<Number>, Option<Object>) - Static method in class akka.cluster.Metric
-
Creates a new Metric instance if the Try is successful and the value is valid,
otherwise None is returned.
- create(String, Number, Option<Object>) - Method in class akka.cluster.metrics.Metric$
-
Creates a new Metric instance if the value is valid, otherwise None
is returned.
- create(String, Try<Number>, Option<Object>) - Method in class akka.cluster.metrics.Metric$
-
Creates a new Metric instance if the Try is successful and the value is valid,
otherwise None is returned.
- create(String, Number, Option<Object>) - Static method in class akka.cluster.metrics.Metric
-
Creates a new Metric instance if the value is valid, otherwise None
is returned.
- create(String, Try<Number>, Option<Object>) - Static method in class akka.cluster.metrics.Metric
-
Creates a new Metric instance if the Try is successful and the value is valid,
otherwise None is returned.
- create(ActorSystem) - Method in class akka.cluster.pubsub.DistributedPubSubSettings$
-
Java API: Create settings from the default configuration
akka.cluster.pub-sub
.
- create(Config) - Method in class akka.cluster.pubsub.DistributedPubSubSettings$
-
Java API: Create settings from a configuration with the same layout as
the default configuration akka.cluster.pub-sub
.
- create(ActorSystem) - Static method in class akka.cluster.pubsub.DistributedPubSubSettings
-
Java API: Create settings from the default configuration
akka.cluster.pub-sub
.
- create(Config) - Static method in class akka.cluster.pubsub.DistributedPubSubSettings
-
Java API: Create settings from a configuration with the same layout as
the default configuration akka.cluster.pub-sub
.
- create(Seq<Reachability.Record>, Map<UniqueAddress, Object>) - Method in class akka.cluster.Reachability$
-
- create(Seq<Reachability.Record>, Map<UniqueAddress, Object>) - Static method in class akka.cluster.Reachability
-
- create(ActorSystem) - Method in class akka.cluster.singleton.ClusterSingletonManagerSettings$
-
Java API: Create settings from the default configuration
akka.cluster.singleton
.
- create(Config) - Method in class akka.cluster.singleton.ClusterSingletonManagerSettings$
-
Java API: Create settings from a configuration with the same layout as
the default configuration akka.cluster.singleton
.
- create(ActorSystem) - Static method in class akka.cluster.singleton.ClusterSingletonManagerSettings
-
Java API: Create settings from the default configuration
akka.cluster.singleton
.
- create(Config) - Static method in class akka.cluster.singleton.ClusterSingletonManagerSettings
-
Java API: Create settings from a configuration with the same layout as
the default configuration akka.cluster.singleton
.
- create(ActorSystem) - Method in class akka.cluster.singleton.ClusterSingletonProxySettings$
-
Java API: Create settings from the default configuration
akka.cluster.singleton-proxy
.
- create(Config) - Method in class akka.cluster.singleton.ClusterSingletonProxySettings$
-
Java API: Create settings from a configuration with the same layout as
the default configuration akka.cluster.singleton-proxy
.
- create(ActorSystem) - Static method in class akka.cluster.singleton.ClusterSingletonProxySettings
-
Java API: Create settings from the default configuration
akka.cluster.singleton-proxy
.
- create(Config) - Static method in class akka.cluster.singleton.ClusterSingletonProxySettings
-
Java API: Create settings from a configuration with the same layout as
the default configuration akka.cluster.singleton-proxy
.
- create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.contrib.mailbox.PeekMailboxType
-
- create(MailboxType) - Method in class akka.dispatch.BalancingDispatcherConfigurator
-
- create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.BoundedControlAwareMailbox
-
- create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.BoundedDequeBasedMailbox
-
- create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.BoundedMailbox
-
- create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.BoundedPriorityMailbox
-
- create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.BoundedStablePriorityMailbox
-
- create(Option<ActorRef>, Option<ActorSystem>) - Method in interface akka.dispatch.MailboxType
-
- create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.NonBlockingBoundedMailbox
-
- create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.SingleConsumerOnlyUnboundedMailbox
-
- Create - Class in akka.dispatch.sysmsg
-
INTERNAL API
- Create(Option<ActorInitializationException>) - Constructor for class akka.dispatch.sysmsg.Create
-
- create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.UnboundedControlAwareMailbox
-
- create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.UnboundedDequeBasedMailbox
-
- create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.UnboundedMailbox
-
- create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.UnboundedPriorityMailbox
-
- create(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.dispatch.UnboundedStablePriorityMailbox
-
- create(PartialFunction<Object, BoxedUnit>, ActorContext) - Method in class akka.event.LoggingReceive$
-
Java API: compatible with lambda expressions
This is an EXPERIMENTAL feature and is subject to change until it has received more real world testing.
- create(PartialFunction<Object, BoxedUnit>, ActorContext) - Static method in class akka.event.LoggingReceive
-
Java API: compatible with lambda expressions
This is an EXPERIMENTAL feature and is subject to change until it has received more real world testing.
- create() - Method in class akka.io.Inet.DatagramChannelCreator
-
Open and return new DatagramChannel.
- create(Iterable<Tcp.WriteCommand>) - Method in class akka.io.Tcp.WriteCommand$
-
Java API: combines the given number of write commands into one atomic WriteCommand
.
- create() - Method in interface akka.japi.Creator
-
This method must return a different instance upon every call.
- create() - Method in interface akka.japi.function.Creator
-
This method must return a different instance upon every call.
- create(PFBuilder<F, T>) - Static method in class akka.japi.pf.Match
-
Create a
Match
from the builder.
- create(UnitPFBuilder<F>) - Static method in class akka.japi.pf.UnitMatch
-
- create(Scheduler, int, FiniteDuration, FiniteDuration) - Method in class akka.pattern.CircuitBreaker$
-
Java API: Create a new CircuitBreaker.
- create(Scheduler, int, FiniteDuration, FiniteDuration) - Static method in class akka.pattern.CircuitBreaker
-
Java API: Create a new CircuitBreaker.
- create() - Method in class akka.persistence.PersistentRepr$
-
Java API, Plugin API.
- create() - Method in class akka.persistence.Recover$
-
Java API.
- create(long) - Method in class akka.persistence.Recover$
-
Java API.
- create(SnapshotSelectionCriteria) - Method in class akka.persistence.Recover$
-
Java API.
- create(SnapshotSelectionCriteria, long) - Method in class akka.persistence.Recover$
-
Java API.
- create(SnapshotSelectionCriteria, long, long) - Method in class akka.persistence.Recover$
-
Java API.
- create() - Static method in class akka.persistence.Recover
-
Java API.
- create(long) - Static method in class akka.persistence.Recover
-
Java API.
- create(SnapshotSelectionCriteria) - Static method in class akka.persistence.Recover
-
Java API.
- create(SnapshotSelectionCriteria, long) - Static method in class akka.persistence.Recover
-
Java API.
- create(SnapshotSelectionCriteria, long, long) - Static method in class akka.persistence.Recover
-
Java API.
- create(SnapshotMetadata, Object) - Method in class akka.persistence.SelectedSnapshot$
-
Java API, Plugin API.
- create(SnapshotMetadata, Object) - Static method in class akka.persistence.SelectedSnapshot
-
Java API, Plugin API.
- create(long, long) - Method in class akka.persistence.SnapshotSelectionCriteria$
-
Java API.
- create(long, long) - Static method in class akka.persistence.SnapshotSelectionCriteria
-
Java API.
- create() - Method in class akka.persistence.Update$
-
Java API.
- create(boolean) - Method in class akka.persistence.Update$
-
Java API.
- create(boolean, long) - Method in class akka.persistence.Update$
-
Java API.
- create() - Static method in class akka.persistence.Update
-
Java API.
- create(boolean) - Static method in class akka.persistence.Update
-
Java API.
- create(boolean, long) - Static method in class akka.persistence.Update
-
Java API.
- create(Transport, ExtendedActorSystem) - Method in class akka.remote.transport.FailureInjectorProvider
-
- create(Transport, ExtendedActorSystem) - Method in class akka.remote.transport.ThrottlerProvider
-
- create(Transport, ExtendedActorSystem) - Method in interface akka.remote.transport.TransportAdapterProvider
-
Create the transport adapter that wraps an underlying transport.
- create(Iterable<T>, int) - Method in class akka.routing.ConsistentHash$
-
Java API: Factory method to create a ConsistentHash
- create(Iterable<T>, int) - Static method in class akka.routing.ConsistentHash
-
Java API: Factory method to create a ConsistentHash
- create(ActorSystem, Props, String) - Method in class akka.testkit.TestActorRef$
-
Java API: create a TestActorRef in the given system for the given props,
with the given name.
- create(ActorSystem, Props) - Method in class akka.testkit.TestActorRef$
-
Java API: create a TestActorRef in the given system for the given props,
with a random name.
- create(ActorSystem, Props, String) - Static method in class akka.testkit.TestActorRef
-
Java API: create a TestActorRef in the given system for the given props,
with the given name.
- create(ActorSystem, Props) - Static method in class akka.testkit.TestActorRef
-
Java API: create a TestActorRef in the given system for the given props,
with a random name.
- Create$ - Class in akka.dispatch.sysmsg
-
- Create$() - Constructor for class akka.dispatch.sysmsg.Create$
-
- createActorRefProxy(TypedProps<T>, AtomicReference<R>, Function0<ActorRef>) - Method in class akka.actor.TypedActorExtension
-
INTERNAL API
- createActorSystem(String) - Method in class akka.osgi.OsgiActorSystemFactory
-
- createActorSystem(Option<String>) - Method in class akka.osgi.OsgiActorSystemFactory
-
- createConsumer(Processor) - Method in class akka.camel.internal.component.ActorEndpoint
-
The ActorEndpoint only supports receiving messages from Camel.
- createDeployer() - Method in class akka.cluster.ClusterActorRefProvider
-
Factory method to make it possible to override deployer in subclass
Creates a new instance every time
- createDeployer() - Method in class akka.remote.RemoteActorRefProvider
-
Factory method to make it possible to override deployer in subclass
Creates a new instance every time
- createDynamicAccess() - Method in class akka.actor.ActorSystemImpl
-
This is an extension point: by overriding this method, subclasses can
control all reflection activities of an actor system.
- createEndpoint(String, String, Map<String, Object>) - Method in class akka.camel.internal.component.ActorComponent
-
- createEWMA(double, Option<Object>) - Method in class akka.cluster.metrics.Metric$
-
- createEWMA(double, Option<Object>) - Static method in class akka.cluster.metrics.Metric
-
- createExecutorService() - Method in interface akka.dispatch.ExecutorServiceFactory
-
- createExecutorService() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.ForkJoinExecutorServiceFactory
-
- createExecutorService() - Method in class akka.dispatch.ThreadPoolConfig.ThreadPoolExecutorServiceFactory
-
- createExecutorServiceFactory(String, ThreadFactory) - Method in class akka.dispatch.DefaultExecutorServiceConfigurator
-
- createExecutorServiceFactory(String, ThreadFactory) - Method in interface akka.dispatch.ExecutorServiceFactoryProvider
-
- createExecutorServiceFactory(String, ThreadFactory) - Method in class akka.dispatch.ForkJoinExecutorConfigurator
-
- createExecutorServiceFactory(String, ThreadFactory) - Method in class akka.dispatch.ThreadPoolConfig
-
- createExecutorServiceFactory(String, ThreadFactory) - Method in class akka.dispatch.ThreadPoolExecutorConfigurator
-
- createExtension(ExtendedActorSystem) - Method in class akka.actor.ActorDSL.Extension$
-
- createExtension(ExtendedActorSystem) - Method in interface akka.actor.ExtensionId
-
Is used by Akka to instantiate the Extension identified by this ExtensionId,
internal use only.
- createExtension(ExtendedActorSystem) - Method in class akka.actor.ExtensionKey
-
- createExtension(ExtendedActorSystem) - Method in class akka.actor.TypedActor$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.actor.TypedActor
-
- createExtension(ExtendedActorSystem) - Method in class akka.camel.CamelExtension$
-
Creates a new instance of Camel and makes sure it gets stopped when the actor system is shutdown.
- createExtension(ExtendedActorSystem) - Static method in class akka.camel.CamelExtension
-
Creates a new instance of Camel and makes sure it gets stopped when the actor system is shutdown.
- createExtension(ExtendedActorSystem) - Method in class akka.cluster.client.ClusterClientReceptionist$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.cluster.client.ClusterClientReceptionist
-
- createExtension(ExtendedActorSystem) - Method in class akka.cluster.Cluster$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.cluster.Cluster
-
- createExtension(ExtendedActorSystem) - Method in class akka.cluster.metrics.ClusterMetricsExtension$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.cluster.metrics.ClusterMetricsExtension
-
- createExtension(ExtendedActorSystem) - Method in class akka.cluster.pubsub.DistributedPubSub$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.cluster.pubsub.DistributedPubSub
-
- createExtension(ExtendedActorSystem) - Method in class akka.cluster.sharding.ClusterSharding$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.cluster.sharding.ClusterSharding
-
- createExtension(ExtendedActorSystem) - Method in class akka.contrib.mailbox.PeekMailboxExtension$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.contrib.mailbox.PeekMailboxExtension
-
- createExtension(ExtendedActorSystem) - Method in class akka.event.AddressTerminatedTopic$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.event.AddressTerminatedTopic
-
- createExtension(ExtendedActorSystem) - Method in class akka.io.Dns$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.io.Dns
-
- createExtension(ExtendedActorSystem) - Method in class akka.io.Tcp$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.io.Tcp
-
- createExtension(ExtendedActorSystem) - Method in class akka.io.Udp$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.io.Udp
-
- createExtension(ExtendedActorSystem) - Method in class akka.io.UdpConnected$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.io.UdpConnected
-
- createExtension(ExtendedActorSystem) - Method in class akka.persistence.Persistence$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.persistence.Persistence
-
- createExtension(ExtendedActorSystem) - Method in class akka.remote.AddressUidExtension$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.remote.AddressUidExtension
-
- createExtension(ExtendedActorSystem) - Method in class akka.remote.BoundAddressesExtension$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.remote.BoundAddressesExtension
-
- createExtension(ExtendedActorSystem) - Method in class akka.remote.RARP$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.remote.RARP
-
- createExtension(ExtendedActorSystem) - Method in class akka.remote.RemoteMetricsExtension$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.remote.RemoteMetricsExtension
-
- createExtension(ExtendedActorSystem) - Method in class akka.remote.testconductor.TestConductor$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.remote.testconductor.TestConductor
-
- createExtension(ExtendedActorSystem) - Method in class akka.remote.transport.TransportAdaptersExtension$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.remote.transport.TransportAdaptersExtension
-
- createExtension(ExtendedActorSystem) - Method in class akka.serialization.SerializationExtension$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.serialization.SerializationExtension
-
- createExtension(ExtendedActorSystem) - Method in class akka.testkit.CallingThreadDispatcherQueues$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.testkit.CallingThreadDispatcherQueues
-
- createExtension(ExtendedActorSystem) - Method in class akka.testkit.TestKitExtension$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.testkit.TestKitExtension
-
- createHandle(Channel, Address, Address) - Method in interface akka.remote.transport.netty.CommonHandlers
-
- createHandle(Channel, Address, Address) - Method in interface akka.remote.transport.netty.TcpHandlers
-
- createHandle(Channel, Address, Address) - Method in interface akka.remote.transport.netty.UdpHandlers
-
- createIdentifyId(int) - Method in class akka.cluster.singleton.ClusterSingletonProxy
-
- createInstanceFor(Class<?>, Seq<Tuple2<Class<?>, Object>>, ClassTag<T>) - Method in class akka.actor.DynamicAccess
-
Convenience method which given a Class[_]
object and a constructor description
will create a new instance of that class.
- createInstanceFor(String, Seq<Tuple2<Class<?>, Object>>, ClassTag<T>) - Method in class akka.actor.DynamicAccess
-
Obtain an object conforming to the type T, which is expected to be
instantiated from a class designated by the fully-qualified class name
given, where the constructor is selected and invoked according to the
args
argument.
- createInstanceFor(Class<?>, Seq<Tuple2<Class<?>, Object>>, ClassTag<T>) - Method in class akka.actor.ReflectiveDynamicAccess
-
- createInstanceFor(String, Seq<Tuple2<Class<?>, Object>>, ClassTag<T>) - Method in class akka.actor.ReflectiveDynamicAccess
-
- createMailbox(Cell, MailboxType) - Method in class akka.dispatch.BalancingDispatcher
-
- createMailbox(Cell, MailboxType) - Method in class akka.dispatch.Dispatcher
-
INTERNAL API
- createMailbox(Cell, MailboxType) - Method in class akka.dispatch.MessageDispatcher
-
Creates and returns a mailbox for the given actor.
- createMailbox(Cell, MailboxType) - Method in class akka.testkit.CallingThreadDispatcher
-
- createMBean() - Method in class akka.cluster.ClusterJmx
-
Creates the cluster JMX MBean and registers it in the MBean server.
- createProducer() - Method in class akka.camel.internal.component.ActorEndpoint
-
Creates a new producer which is used send messages into the endpoint.
- createRemoteDeploymentWatcher(ActorSystemImpl) - Method in class akka.remote.RemoteActorRefProvider
-
- createRemoteWatcher(ActorSystemImpl) - Method in class akka.cluster.ClusterActorRefProvider
-
- createRemoteWatcher(ActorSystemImpl) - Method in class akka.remote.RemoteActorRefProvider
-
- createRemoteWatcherFailureDetector(ExtendedActorSystem) - Method in class akka.remote.RemoteActorRefProvider
-
- createRouter(ActorSystem) - Method in class akka.cluster.metrics.AdaptiveLoadBalancingGroup
-
- createRouter(ActorSystem) - Method in class akka.cluster.metrics.AdaptiveLoadBalancingPool
-
- createRouter(ActorSystem) - Method in class akka.cluster.routing.AdaptiveLoadBalancingGroup
-
- createRouter(ActorSystem) - Method in class akka.cluster.routing.AdaptiveLoadBalancingPool
-
- createRouter(ActorSystem) - Method in interface akka.cluster.routing.ClusterRouterConfigBase
-
- createRouter(ActorSystem) - Method in class akka.remote.routing.RemoteRouterConfig
-
- createRouter(ActorSystem) - Method in class akka.routing.BalancingPool
-
- createRouter(ActorSystem) - Method in class akka.routing.BroadcastGroup
-
- createRouter(ActorSystem) - Method in class akka.routing.BroadcastPool
-
- createRouter(ActorSystem) - Method in class akka.routing.ConsistentHashingGroup
-
- createRouter(ActorSystem) - Method in class akka.routing.ConsistentHashingPool
-
- createRouter(ActorSystem) - Method in class akka.routing.FromConfig
-
- createRouter(ActorSystem) - Method in class akka.routing.NoRouter$
-
- createRouter(ActorSystem) - Static method in class akka.routing.NoRouter
-
- createRouter(ActorSystem) - Method in class akka.routing.RandomGroup
-
- createRouter(ActorSystem) - Method in class akka.routing.RandomPool
-
- createRouter(ActorSystem) - Method in class akka.routing.RoundRobinGroup
-
- createRouter(ActorSystem) - Method in class akka.routing.RoundRobinPool
-
- createRouter(ActorSystem) - Method in interface akka.routing.RouterConfig
-
Create the actual router, responsible for routing messages to routees.
- createRouter(ActorSystem) - Method in class akka.routing.ScatterGatherFirstCompletedGroup
-
- createRouter(ActorSystem) - Method in class akka.routing.ScatterGatherFirstCompletedPool
-
- createRouter(ActorSystem) - Method in class akka.routing.SmallestMailboxPool
-
- createRouter(ActorSystem) - Method in class akka.routing.TailChoppingGroup
-
- createRouter(ActorSystem) - Method in class akka.routing.TailChoppingPool
-
- createRouterActor() - Method in class akka.cluster.routing.ClusterRouterGroup
-
INTERNAL API
- createRouterActor() - Method in class akka.cluster.routing.ClusterRouterPool
-
INTERNAL API
- createRouterActor() - Method in class akka.remote.routing.RemoteRouterConfig
-
- createRouterActor() - Method in class akka.routing.CustomRouterConfig
-
INTERNAL API
- createRouterActor() - Method in class akka.routing.FromConfig
-
INTERNAL API
- createRouterActor() - Method in interface akka.routing.Group
-
INTERNAL API
- createRouterActor() - Method in class akka.routing.NoRouter$
-
INTERNAL API
- createRouterActor() - Static method in class akka.routing.NoRouter
-
INTERNAL API
- createRouterActor() - Method in interface akka.routing.Pool
-
INTERNAL API
- createRouterActor() - Method in interface akka.routing.RouterConfig
-
INTERNAL API
The router "head" actor.
- createRouterConfig(String, String, Config, Config) - Method in class akka.actor.Deployer
-
Factory method for creating RouterConfig
- createScheduler() - Method in class akka.actor.ActorSystemImpl
-
Create the scheduler service.
- CreateServerFSM(Channel) - Constructor for class akka.remote.testconductor.Controller.CreateServerFSM
-
- CreateServerFSM$() - Constructor for class akka.remote.testconductor.Controller.CreateServerFSM$
-
- createSigarInstance() - Method in interface akka.cluster.metrics.SigarProvider
-
Create sigar instance with 2-phase sigar library loading.
- createStash(ActorContext, ActorRef) - Method in interface akka.actor.StashFactory
-
- createThreadPoolConfigBuilder(Config, DispatcherPrerequisites) - Method in class akka.dispatch.ThreadPoolExecutorConfigurator
-
- createTimeout() - Method in class akka.remote.testconductor.ConductorHandler
-
- createTunnel(ActorRef) - Method in class akka.contrib.pattern.ReliableProxy
-
- Creation() - Constructor for class akka.actor.dungeon.ChildrenContainer.Creation
-
- Creation$() - Constructor for class akka.actor.dungeon.ChildrenContainer.Creation$
-
- CreationTimeout() - Method in class akka.actor.ActorSystem.Settings
-
- creator() - Method in class akka.actor.TypedProps
-
- Creator<T> - Interface in akka.japi
-
A constructor/factory, takes no parameters but creates a new value of type T every call.
- Creator<T> - Interface in akka.japi.function
-
A constructor/factory, takes no parameters but creates a new value of type T every call.
- creator() - Method in class akka.typed.Props
-
- CreatorConsumer - Class in akka.actor
-
INTERNAL API
- CreatorConsumer(Class<? extends Actor>, Creator<Actor>) - Constructor for class akka.actor.CreatorConsumer
-
- CreatorConsumerClass() - Method in class akka.actor.IndirectActorProducer$
-
- CreatorFunctionConsumer - Class in akka.actor
-
INTERNAL API
- CreatorFunctionConsumer(Function0<Actor>) - Constructor for class akka.actor.CreatorFunctionConsumer
-
- CreatorFunctionConsumerClass() - Method in class akka.actor.IndirectActorProducer$
-
- Creators - Interface in akka.actor.dsl
-
- Creators.Act - Interface in akka.actor.dsl
-
This trait provides a DSL for writing the inner workings of an actor, e.g.
- Creators.ActWithStash - Interface in akka.actor.dsl
-
Use this trait when defining an
Actor
with
Stash
,
since just using
actor()(new Act with Stash{})
will not be able to see the
Stash component due to type erasure.
- criteria() - Method in class akka.persistence.SnapshotProtocol.DeleteSnapshots
-
- criteria() - Method in class akka.persistence.SnapshotProtocol.LoadSnapshot
-
- Crypt - Class in akka.util
-
- Crypt() - Constructor for class akka.util.Crypt
-
- Crypt$ - Class in akka.util
-
- Crypt$() - Constructor for class akka.util.Crypt$
-
- ctdLock() - Method in class akka.testkit.CallingThreadMailbox
-
- ctx() - Method in class akka.typed.ActorAdapter
-
- ctx() - Method in class akka.typed.Ops.ActorContextOps
-
- ctx() - Method in class akka.typed.ScalaDSL.Msg
-
- ctx() - Method in class akka.typed.ScalaDSL.Sig
-
- cumulativeAck() - Method in class akka.remote.Ack
-
- cumulativeAck() - Method in class akka.remote.AckedReceiveBuffer
-
- CUMULATIVEACK_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AcknowledgementInfo
-
- currentBehavior() - Method in class akka.typed.EffectfulActorContext
-
- CurrentClusterState(SortedSet<Member>, Set<Member>, Set<Address>, Option<Address>, Map<String, Option<Address>>) - Constructor for class akka.cluster.ClusterEvent.CurrentClusterState
-
- CurrentClusterState$() - Constructor for class akka.cluster.ClusterEvent.CurrentClusterState$
-
- currentDeadline() - Method in class akka.actor.dsl.Inbox.InboxActor
-
- currentDeliveryId() - Method in class akka.persistence.AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot
-
- CURRENTDELIVERYID_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
-
- currentFailureCount() - Method in class akka.pattern.CircuitBreaker
-
Retrieves current failure count.
- currentHandle() - Method in class akka.remote.ReliableDeliverySupervisor
-
- CurrentInternalStats(GossipStats, VectorClockStats) - Constructor for class akka.cluster.ClusterEvent.CurrentInternalStats
-
- CurrentInternalStats$() - Constructor for class akka.cluster.ClusterEvent.CurrentInternalStats$
-
- currentMessage() - Method in class akka.actor.ActorCell
-
- currentMsg() - Method in class akka.actor.dsl.Inbox.InboxActor
-
- currentSelect() - Method in class akka.actor.dsl.Inbox.InboxActor
-
- currentSerial() - Method in class akka.contrib.pattern.ReliableProxy
-
- currentState() - Method in interface akka.actor.FSM
-
- CurrentState(ActorRef, S) - Constructor for class akka.actor.FSM.CurrentState
-
- currentState() - Method in class akka.actor.FSM.StopEvent
-
- currentState() - Method in interface akka.persistence.Eventsourced
-
- currentState() - Method in interface akka.persistence.PersistentView
-
- CurrentState$() - Constructor for class akka.actor.FSM.CurrentState$
-
- currentStatus() - Method in class akka.dispatch.Mailbox
-
- currentSystem() - Method in class akka.serialization.JavaSerializer$
-
This holds a reference to the current ActorSystem (the surrounding context)
during serialization and deserialization.
- currentSystem() - Static method in class akka.serialization.JavaSerializer
-
This holds a reference to the current ActorSystem (the surrounding context)
during serialization and deserialization.
- CurrentSystem() - Constructor for class akka.serialization.JavaSerializer.CurrentSystem
-
- currentTarget() - Method in class akka.contrib.pattern.ReliableProxy
-
- currentTimeMillisToUTCString(long) - Method in class akka.util.Helpers$
-
Converts a "currentTimeMillis"-obtained timestamp accordingly:
- currentTimeMillisToUTCString(long) - Static method in class akka.util.Helpers
-
Converts a "currentTimeMillis"-obtained timestamp accordingly:
- CurrentTopics(Set<String>) - Constructor for class akka.cluster.pubsub.DistributedPubSubMediator.CurrentTopics
-
- CurrentTopics$() - Constructor for class akka.cluster.pubsub.DistributedPubSubMediator.CurrentTopics$
-
- currentTransportInformation() - Method in class akka.serialization.Serialization$
-
This holds a reference to the current transport serialization information used for
serializing local actor refs.
- currentTransportInformation() - Static method in class akka.serialization.Serialization
-
This holds a reference to the current transport serialization information used for
serializing local actor refs.
- custom(PartialFunction<Logging.LogEvent, Object>, int) - Method in class akka.testkit.EventFilter$
-
Create a custom event filter.
- custom(PartialFunction<Logging.LogEvent, Object>, int) - Static method in class akka.testkit.EventFilter
-
Create a custom event filter.
- CustomEventFilter - Class in akka.testkit
-
Custom event filter when the others do not fit the bill.
- CustomEventFilter(PartialFunction<Logging.LogEvent, Object>, int) - Constructor for class akka.testkit.CustomEventFilter
-
- CustomEventFilter$ - Class in akka.testkit
-
- CustomEventFilter$() - Constructor for class akka.testkit.CustomEventFilter$
-
- CustomRouterConfig - Class in akka.routing
-
If a custom router implementation is not a
Group
nor
a
Pool
it may extend this base class.
- CustomRouterConfig() - Constructor for class akka.routing.CustomRouterConfig
-
- g() - Method in class akka.cluster.GossipEnvelope
-
- Gated(Deadline) - Constructor for class akka.remote.EndpointManager.Gated
-
- gated() - Method in class akka.remote.ReliableDeliverySupervisor
-
- Gated$() - Constructor for class akka.remote.EndpointManager.Gated$
-
- gatherFromAllOtherQueues(CallingThreadMailbox, MessageQueue) - Method in class akka.testkit.CallingThreadDispatcherQueues
-
- gen(Object) - Method in class akka.dispatch.PriorityGenerator
-
- generateSecureCookie() - Method in class akka.util.Crypt$
-
- generateSecureCookie() - Static method in class akka.util.Crypt
-
- generateSeed(int) - Method in class akka.remote.security.provider.InternetSeedGenerator
-
Generates a seed by trying each of the available strategies in
turn until one succeeds.
- generation() - Method in interface akka.actor.FSM
-
- generation() - Method in class akka.actor.FSM.TimeoutMarker
-
- generation() - Method in class akka.actor.FSM.Timer
-
- generation() - Method in class akka.remote.testconductor.Controller
-
- genString(T) - Method in interface akka.event.LogSource
-
- genString(T, ActorSystem) - Method in interface akka.event.LogSource
-
- get(ActorSystem) - Method in class akka.actor.ActorDSL.Extension$
-
Java API: retrieve the ActorDSL extension for the given system.
- Get(Deadline, ActorRef) - Constructor for class akka.actor.dsl.Inbox.Get
-
- get(ActorSystem) - Method in interface akka.actor.ExtensionId
-
Returns an instance of the extension identified by this ExtensionId instance.
- get(ActorSystem) - Method in class akka.actor.TypedActor$
-
- get(ActorContext) - Method in class akka.actor.TypedActor$
-
Returns a contextual TypedActorFactory of this extension, this means that any TypedActors created by this TypedActorExtension
will be children to the specified context, this allows for creating hierarchies of TypedActors.
- get(ActorSystem) - Static method in class akka.actor.TypedActor
-
- get(ActorContext) - Static method in class akka.actor.TypedActor
-
Returns a contextual TypedActorFactory of this extension, this means that any TypedActors created by this TypedActorExtension
will be children to the specified context, this allows for creating hierarchies of TypedActors.
- get() - Method in class akka.agent.Agent
-
Java API: Read the internal state of the agent.
- get(ActorSystem) - Method in class akka.camel.CamelExtension$
-
- get(ActorSystem) - Static method in class akka.camel.CamelExtension
-
- get(ActorSystem) - Method in class akka.cluster.client.ClusterClientReceptionist$
-
- get(ActorSystem) - Static method in class akka.cluster.client.ClusterClientReceptionist
-
- get(ActorSystem) - Method in class akka.cluster.Cluster$
-
- get(ActorSystem) - Static method in class akka.cluster.Cluster
-
- get(ActorSystem) - Method in class akka.cluster.metrics.ClusterMetricsExtension$
-
- get(ActorSystem) - Static method in class akka.cluster.metrics.ClusterMetricsExtension
-
- get(ActorSystem) - Method in class akka.cluster.pubsub.DistributedPubSub$
-
- get(ActorSystem) - Static method in class akka.cluster.pubsub.DistributedPubSub
-
- get(ActorSystem) - Method in class akka.cluster.sharding.ClusterSharding$
-
- get(ActorSystem) - Static method in class akka.cluster.sharding.ClusterSharding
-
- get(ActorSystem) - Method in class akka.event.AddressTerminatedTopic$
-
- get(ActorSystem) - Static method in class akka.event.AddressTerminatedTopic
-
- get(ActorRef) - Method in class akka.event.ManagedActorClassification.ManagedActorClassificationMappings
-
- get(ActorSystem) - Method in class akka.io.Dns$
-
Java API: retrieve the Udp extension for the given system.
- get(ActorSystem) - Static method in class akka.io.Dns
-
Java API: retrieve the Udp extension for the given system.
- get(ActorSystem) - Method in class akka.io.Tcp$
-
Java API: retrieve the Tcp extension for the given system.
- get(ActorSystem) - Static method in class akka.io.Tcp
-
Java API: retrieve the Tcp extension for the given system.
- get(ActorSystem) - Method in class akka.io.Udp$
-
Java API: retrieve the Udp extension for the given system.
- get(ActorSystem) - Static method in class akka.io.Udp
-
Java API: retrieve the Udp extension for the given system.
- get(ActorSystem) - Method in class akka.io.UdpConnected$
-
Java API: retrieve the UdpConnected extension for the given system.
- get(ActorSystem) - Static method in class akka.io.UdpConnected
-
Java API: retrieve the UdpConnected extension for the given system.
- get() - Method in class akka.japi.Option
-
- get() - Method in class akka.japi.Option.Some
-
- get(ActorSystem) - Method in class akka.persistence.Persistence$
-
Java API.
- get(ActorSystem) - Static method in class akka.persistence.Persistence
-
Java API.
- get(ActorSystem) - Method in class akka.remote.AddressUidExtension$
-
- get(ActorSystem) - Static method in class akka.remote.AddressUidExtension
-
- get(ActorSystem) - Method in class akka.remote.BoundAddressesExtension$
-
- get(ActorSystem) - Static method in class akka.remote.BoundAddressesExtension
-
- get(ActorSystem) - Method in class akka.remote.RemoteMetricsExtension$
-
- get(ActorSystem) - Static method in class akka.remote.RemoteMetricsExtension
-
- get(ActorSystem) - Method in class akka.remote.testconductor.TestConductor$
-
Java API: retrieve the TestConductor extension for the given system.
- get(ActorSystem) - Static method in class akka.remote.testconductor.TestConductor
-
Java API: retrieve the TestConductor extension for the given system.
- get(String) - Method in class akka.remote.transport.AssociationRegistry$
-
- get(String) - Static method in class akka.remote.transport.AssociationRegistry
-
- get(ActorSystem) - Method in class akka.remote.transport.TransportAdaptersExtension$
-
- get(ActorSystem) - Static method in class akka.remote.transport.TransportAdaptersExtension
-
- get(ActorSystem) - Method in class akka.serialization.SerializationExtension$
-
- get(ActorSystem) - Static method in class akka.serialization.SerializationExtension
-
- get() - Method in class akka.testkit.JavaTestKit.ExpectMsg
-
- get() - Method in class akka.testkit.JavaTestKit.ReceiveWhile
-
- get(ActorSystem) - Method in class akka.testkit.TestKitExtension$
-
- get(ActorSystem) - Static method in class akka.testkit.TestKitExtension
-
- get(T) - Method in class akka.util.TypedMultiMap
-
Obtain all mappings for the given key.
- Get$() - Constructor for class akka.actor.dsl.Inbox.Get$
-
- getAck() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
optional .AcknowledgementInfo ack = 1;
- getAck() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
-
optional .AcknowledgementInfo ack = 1;
- getAck() - Method in interface akka.remote.WireFormats.AckAndEnvelopeContainerOrBuilder
-
optional .AcknowledgementInfo ack = 1;
- getAckBuilder() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
optional .AcknowledgementInfo ack = 1;
- getAckOrBuilder() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
optional .AcknowledgementInfo ack = 1;
- getAckOrBuilder() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
-
optional .AcknowledgementInfo ack = 1;
- getAckOrBuilder() - Method in interface akka.remote.WireFormats.AckAndEnvelopeContainerOrBuilder
-
optional .AcknowledgementInfo ack = 1;
- getActivation() - Method in class akka.camel.javaapi.UntypedConsumerActor
-
Java API: Returns the
Activation
interface
that can be used to wait on activation or de-activation of Camel endpoints.
- getActivation() - Method in class akka.camel.javaapi.UntypedProducerActor
-
''Java API'': Returns the
Activation
interface
that can be used to wait on activation or de-activation of Camel endpoints.
- getActor() - Method in exception akka.actor.ActorInitializationException
-
- getActor() - Method in class akka.actor.Terminated
-
- getActorRefFor(Object) - Method in class akka.actor.ContextualTypedActorFactory
-
- getActorRefFor(Object) - Method in class akka.actor.TypedActorExtension
-
Retrieves the underlying ActorRef for the supplied TypedActor proxy, or null if none found
- getActorRefFor(Object) - Method in interface akka.actor.TypedActorFactory
-
Retrieves the underlying ActorRef for the supplied TypedActor proxy, or null if none found
- getActorSystemConfiguration(BundleContext) - Method in class akka.osgi.ActorSystemActivator
-
Override this method to define a configuration for your
ActorSystem
instance.
- getActorSystemName(BundleContext) - Method in class akka.osgi.ActorSystemActivator
-
By default, the
ActorSystem
name will be set to
bundle-<bundle id>-ActorSystem
.
- getAdapterProvider(String) - Method in class akka.remote.transport.TransportAdapters
-
- getAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
-
optional .Address addr = 2;
- getAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
-
optional .Address addr = 2;
- getAddr() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressRequestOrBuilder
-
optional .Address addr = 2;
- getAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .AddressRequest addr = 5;
- getAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
-
optional .AddressRequest addr = 5;
- getAddr() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
-
optional .AddressRequest addr = 5;
- getAddrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
-
optional .Address addr = 2;
- getAddrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .AddressRequest addr = 5;
- getAddress() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
-
required .Address address = 1;
- getAddress() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
-
required .Address address = 1;
- getAddress() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.UniqueAddressOrBuilder
-
required .Address address = 1;
- getAddress() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
-
required .Address address = 1;
- getAddress() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version
-
required .Address address = 1;
- getAddress() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.VersionOrBuilder
-
required .Address address = 1;
- GetAddress - Class in akka.remote.testconductor
-
- GetAddress(RoleName) - Constructor for class akka.remote.testconductor.GetAddress
-
- getAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
-
required .Address address = 2;
- getAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
-
required .Address address = 2;
- getAddress() - Method in interface akka.remote.testconductor.TestConductorProtocol.HelloOrBuilder
-
required .Address address = 2;
- getAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
optional .Address address = 3;
- getAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
-
optional .Address address = 3;
- getAddress() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
-
optional .Address address = 3;
- GetAddress$ - Class in akka.remote.testconductor
-
- GetAddress$() - Constructor for class akka.remote.testconductor.GetAddress$
-
- getAddressBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
-
required .Address address = 1;
- getAddressBuilder() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
-
required .Address address = 1;
- getAddressBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
-
required .Address address = 2;
- getAddressBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
optional .Address address = 3;
- getAddressFor(RoleName) - Method in interface akka.remote.testconductor.Player
-
Query remote transport address of named node.
- getAddressIndex() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
required int32 addressIndex = 1;
- getAddressIndex() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics
-
required int32 addressIndex = 1;
- getAddressIndex() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetricsOrBuilder
-
required int32 addressIndex = 1;
- getAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
required int32 addressIndex = 1;
- getAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
-
required int32 addressIndex = 1;
- getAddressIndex() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MemberOrBuilder
-
required int32 addressIndex = 1;
- getAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
required int32 addressIndex = 1;
- getAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
-
required int32 addressIndex = 1;
- getAddressIndex() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetricsOrBuilder
-
required int32 addressIndex = 1;
- getAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
required int32 addressIndex = 1;
- getAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
-
required int32 addressIndex = 1;
- getAddressIndex() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.ObserverReachabilityOrBuilder
-
required int32 addressIndex = 1;
- getAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
-
required int32 addressIndex = 1;
- getAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
-
required int32 addressIndex = 1;
- getAddressIndex() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.SubjectReachabilityOrBuilder
-
required int32 addressIndex = 1;
- getAddressOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
-
required .Address address = 1;
- getAddressOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
-
required .Address address = 1;
- getAddressOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.UniqueAddressOrBuilder
-
required .Address address = 1;
- getAddressOrBuilder() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
-
required .Address address = 1;
- getAddressOrBuilder() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version
-
required .Address address = 1;
- getAddressOrBuilder() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.VersionOrBuilder
-
required .Address address = 1;
- getAddressOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
-
required .Address address = 2;
- getAddressOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
-
required .Address address = 2;
- getAddressOrBuilder() - Method in interface akka.remote.testconductor.TestConductorProtocol.HelloOrBuilder
-
required .Address address = 2;
- getAddressOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
optional .Address address = 3;
- getAddressOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
-
optional .Address address = 3;
- getAddressOrBuilder() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
-
optional .Address address = 3;
- getAddressTerminated() - Method in class akka.actor.Terminated
-
- getAddrOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
-
optional .Address addr = 2;
- getAddrOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
-
optional .Address addr = 2;
- getAddrOrBuilder() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressRequestOrBuilder
-
optional .Address addr = 2;
- getAddrOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .AddressRequest addr = 5;
- getAddrOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
-
optional .AddressRequest addr = 5;
- getAddrOrBuilder() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
-
optional .AddressRequest addr = 5;
- getAddrString(Channel) - Method in class akka.remote.testconductor.RemoteConnection$
-
- getAddrString(Channel) - Static method in class akka.remote.testconductor.RemoteConnection
-
- GetAll(FiniteDuration, ActorRef<Receiver.GetAllResult<T>>) - Constructor for class akka.typed.patterns.Receiver.GetAll
-
- GetAll$() - Constructor for class akka.typed.patterns.Receiver.GetAll$
-
- getAllAddresses(int) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- getAllAddresses(int) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip
-
repeated .Address allAddresses = 1;
- getAllAddresses(int) - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipOrBuilder
-
repeated .Address allAddresses = 1;
- getAllAddresses(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .UniqueAddress allAddresses = 1;
- getAllAddresses(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
repeated .UniqueAddress allAddresses = 1;
- getAllAddresses(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
-
repeated .UniqueAddress allAddresses = 1;
- getAllAddresses(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- getAllAddresses(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
-
repeated .Address allAddresses = 1;
- getAllAddresses(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
-
repeated .Address allAddresses = 1;
- getAllAddressesBuilder(int) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- getAllAddressesBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .UniqueAddress allAddresses = 1;
- getAllAddressesBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- getAllAddressesBuilderList() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- getAllAddressesBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .UniqueAddress allAddresses = 1;
- getAllAddressesBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- getAllAddressesCount() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- getAllAddressesCount() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip
-
repeated .Address allAddresses = 1;
- getAllAddressesCount() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipOrBuilder
-
repeated .Address allAddresses = 1;
- getAllAddressesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .UniqueAddress allAddresses = 1;
- getAllAddressesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
repeated .UniqueAddress allAddresses = 1;
- getAllAddressesCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
-
repeated .UniqueAddress allAddresses = 1;
- getAllAddressesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- getAllAddressesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
-
repeated .Address allAddresses = 1;
- getAllAddressesCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
-
repeated .Address allAddresses = 1;
- getAllAddressesList() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- getAllAddressesList() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip
-
repeated .Address allAddresses = 1;
- getAllAddressesList() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipOrBuilder
-
repeated .Address allAddresses = 1;
- getAllAddressesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .UniqueAddress allAddresses = 1;
- getAllAddressesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
repeated .UniqueAddress allAddresses = 1;
- getAllAddressesList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
-
repeated .UniqueAddress allAddresses = 1;
- getAllAddressesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- getAllAddressesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
-
repeated .Address allAddresses = 1;
- getAllAddressesList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
-
repeated .Address allAddresses = 1;
- getAllAddressesOrBuilder(int) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- getAllAddressesOrBuilder(int) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip
-
repeated .Address allAddresses = 1;
- getAllAddressesOrBuilder(int) - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipOrBuilder
-
repeated .Address allAddresses = 1;
- getAllAddressesOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .UniqueAddress allAddresses = 1;
- getAllAddressesOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
repeated .UniqueAddress allAddresses = 1;
- getAllAddressesOrBuilder(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
-
repeated .UniqueAddress allAddresses = 1;
- getAllAddressesOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- getAllAddressesOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
-
repeated .Address allAddresses = 1;
- getAllAddressesOrBuilder(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
-
repeated .Address allAddresses = 1;
- getAllAddressesOrBuilderList() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- getAllAddressesOrBuilderList() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip
-
repeated .Address allAddresses = 1;
- getAllAddressesOrBuilderList() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipOrBuilder
-
repeated .Address allAddresses = 1;
- getAllAddressesOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .UniqueAddress allAddresses = 1;
- getAllAddressesOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
repeated .UniqueAddress allAddresses = 1;
- getAllAddressesOrBuilderList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
-
repeated .UniqueAddress allAddresses = 1;
- getAllAddressesOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- getAllAddressesOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
-
repeated .Address allAddresses = 1;
- getAllAddressesOrBuilderList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
-
repeated .Address allAddresses = 1;
- getAllButSelf() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
-
required bool allButSelf = 2;
- getAllButSelf() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll
-
required bool allButSelf = 2;
- getAllButSelf() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAllOrBuilder
-
required bool allButSelf = 2;
- getAllChildStats() - Method in interface akka.actor.dungeon.Children
-
- getAllEffects() - Method in class akka.typed.EffectfulActorContext
-
- getAllHashes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated string allHashes = 3;
- getAllHashes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
repeated string allHashes = 3;
- getAllHashes(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
-
repeated string allHashes = 3;
- getAllHashes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
repeated string allHashes = 2;
- getAllHashes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
-
repeated string allHashes = 2;
- getAllHashes(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipStatusOrBuilder
-
repeated string allHashes = 2;
- getAllHashesBytes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated string allHashes = 3;
- getAllHashesBytes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
repeated string allHashes = 3;
- getAllHashesBytes(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
-
repeated string allHashes = 3;
- getAllHashesBytes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
repeated string allHashes = 2;
- getAllHashesBytes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
-
repeated string allHashes = 2;
- getAllHashesBytes(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipStatusOrBuilder
-
repeated string allHashes = 2;
- getAllHashesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated string allHashes = 3;
- getAllHashesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
repeated string allHashes = 3;
- getAllHashesCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
-
repeated string allHashes = 3;
- getAllHashesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
repeated string allHashes = 2;
- getAllHashesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
-
repeated string allHashes = 2;
- getAllHashesCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipStatusOrBuilder
-
repeated string allHashes = 2;
- getAllHashesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated string allHashes = 3;
- getAllHashesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
repeated string allHashes = 3;
- getAllHashesList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
-
repeated string allHashes = 3;
- getAllHashesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
repeated string allHashes = 2;
- getAllHashesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
-
repeated string allHashes = 2;
- getAllHashesList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipStatusOrBuilder
-
repeated string allHashes = 2;
- getAllMetricNames(int) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated string allMetricNames = 2;
- getAllMetricNames(int) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip
-
repeated string allMetricNames = 2;
- getAllMetricNames(int) - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipOrBuilder
-
repeated string allMetricNames = 2;
- getAllMetricNames(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated string allMetricNames = 2;
- getAllMetricNames(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
-
repeated string allMetricNames = 2;
- getAllMetricNames(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
-
repeated string allMetricNames = 2;
- getAllMetricNamesBytes(int) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated string allMetricNames = 2;
- getAllMetricNamesBytes(int) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip
-
repeated string allMetricNames = 2;
- getAllMetricNamesBytes(int) - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipOrBuilder
-
repeated string allMetricNames = 2;
- getAllMetricNamesBytes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated string allMetricNames = 2;
- getAllMetricNamesBytes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
-
repeated string allMetricNames = 2;
- getAllMetricNamesBytes(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
-
repeated string allMetricNames = 2;
- getAllMetricNamesCount() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated string allMetricNames = 2;
- getAllMetricNamesCount() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip
-
repeated string allMetricNames = 2;
- getAllMetricNamesCount() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipOrBuilder
-
repeated string allMetricNames = 2;
- getAllMetricNamesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated string allMetricNames = 2;
- getAllMetricNamesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
-
repeated string allMetricNames = 2;
- getAllMetricNamesCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
-
repeated string allMetricNames = 2;
- getAllMetricNamesList() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated string allMetricNames = 2;
- getAllMetricNamesList() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip
-
repeated string allMetricNames = 2;
- getAllMetricNamesList() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipOrBuilder
-
repeated string allMetricNames = 2;
- getAllMetricNamesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated string allMetricNames = 2;
- getAllMetricNamesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
-
repeated string allMetricNames = 2;
- getAllMetricNamesList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
-
repeated string allMetricNames = 2;
- GetAllResult(ActorRef<Receiver.Command<T>>, Seq<T>) - Constructor for class akka.typed.patterns.Receiver.GetAllResult
-
- GetAllResult$() - Constructor for class akka.typed.patterns.Receiver.GetAllResult$
-
- getAllRoles() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
-
Java API: All node roles in the cluster
- getAllRoles(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated string allRoles = 2;
- getAllRoles(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
repeated string allRoles = 2;
- getAllRoles(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
-
repeated string allRoles = 2;
- getAllRolesBytes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated string allRoles = 2;
- getAllRolesBytes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
repeated string allRoles = 2;
- getAllRolesBytes(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
-
repeated string allRoles = 2;
- getAllRolesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated string allRoles = 2;
- getAllRolesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
repeated string allRoles = 2;
- getAllRolesCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
-
repeated string allRoles = 2;
- getAllRolesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated string allRoles = 2;
- getAllRolesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
repeated string allRoles = 2;
- getAllRolesList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
-
repeated string allRoles = 2;
- getAlpha() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA.Builder
-
required double alpha = 2;
- getAlpha() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA
-
required double alpha = 2;
- getAlpha() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMAOrBuilder
-
required double alpha = 2;
- getAlpha() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
-
required double alpha = 2;
- getAlpha() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
-
required double alpha = 2;
- getAlpha() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMAOrBuilder
-
required double alpha = 2;
- getAnyRef(String) - Method in class akka.dispatch.CachingConfig
-
- getAnyRefList(String) - Method in class akka.dispatch.CachingConfig
-
- getArgs(int) - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated bytes args = 4;
- getArgs(int) - Method in class akka.remote.WireFormats.PropsData
-
repeated bytes args = 4;
- getArgs(int) - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
-
repeated bytes args = 4;
- getArgsCount() - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated bytes args = 4;
- getArgsCount() - Method in class akka.remote.WireFormats.PropsData
-
repeated bytes args = 4;
- getArgsCount() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
-
repeated bytes args = 4;
- getArgsList() - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated bytes args = 4;
- getArgsList() - Method in class akka.remote.WireFormats.PropsData
-
repeated bytes args = 4;
- getArgsList() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
-
repeated bytes args = 4;
- getAutoAck() - Method in interface akka.camel.internal.component.ActorEndpointConfig
-
- getBarrier() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .EnterBarrier barrier = 2;
- getBarrier() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
-
optional .EnterBarrier barrier = 2;
- getBarrier() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
-
optional .EnterBarrier barrier = 2;
- getBarrierBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .EnterBarrier barrier = 2;
- getBarrierOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .EnterBarrier barrier = 2;
- getBarrierOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
-
optional .EnterBarrier barrier = 2;
- getBarrierOrBuilder() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
-
optional .EnterBarrier barrier = 2;
- getBodyAs(Class<T>, CamelContext) - Method in class akka.camel.CamelMessage
-
Java API: Returns the body of the message converted to the type as given by the clazz
parameter.
- getBoolean(String) - Method in class akka.dispatch.CachingConfig
-
- getBooleanList(String) - Method in class akka.dispatch.CachingConfig
-
- getBuckets(int) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Builder
-
repeated .Delta.Bucket buckets = 1;
- getBuckets(int) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta
-
repeated .Delta.Bucket buckets = 1;
- getBuckets(int) - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.DeltaOrBuilder
-
repeated .Delta.Bucket buckets = 1;
- getBucketsBuilder(int) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Builder
-
repeated .Delta.Bucket buckets = 1;
- getBucketsBuilderList() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Builder
-
repeated .Delta.Bucket buckets = 1;
- getBucketsCount() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Builder
-
repeated .Delta.Bucket buckets = 1;
- getBucketsCount() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta
-
repeated .Delta.Bucket buckets = 1;
- getBucketsCount() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.DeltaOrBuilder
-
repeated .Delta.Bucket buckets = 1;
- getBucketsList() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Builder
-
repeated .Delta.Bucket buckets = 1;
- getBucketsList() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta
-
repeated .Delta.Bucket buckets = 1;
- getBucketsList() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.DeltaOrBuilder
-
repeated .Delta.Bucket buckets = 1;
- getBucketsOrBuilder(int) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Builder
-
repeated .Delta.Bucket buckets = 1;
- getBucketsOrBuilder(int) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta
-
repeated .Delta.Bucket buckets = 1;
- getBucketsOrBuilder(int) - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.DeltaOrBuilder
-
repeated .Delta.Bucket buckets = 1;
- getBucketsOrBuilderList() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Builder
-
repeated .Delta.Bucket buckets = 1;
- getBucketsOrBuilderList() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta
-
repeated .Delta.Bucket buckets = 1;
- getBucketsOrBuilderList() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.DeltaOrBuilder
-
repeated .Delta.Bucket buckets = 1;
- getByName(String) - Method in interface akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer
-
- getByName(String) - Method in interface akka.actor.dungeon.ChildrenContainer
-
- getByName(String) - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
-
- getByName(String) - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
-
- getByRef(ActorRef) - Method in interface akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer
-
- getByRef(ActorRef) - Method in interface akka.actor.dungeon.ChildrenContainer
-
- getByRef(ActorRef) - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
-
- getByRef(ActorRef) - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
-
- getByte() - Method in class akka.util.ByteIterator
-
Get a single Byte from this iterator.
- getByteBuffers() - Method in class akka.util.ByteString
-
Java API: Returns an Iterable of read-only ByteBuffers that directly wraps this ByteStrings
all fragments.
- getBytes(String) - Method in class akka.dispatch.CachingConfig
-
- getBytes(byte[], int, int) - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- getBytes(byte[]) - Method in class akka.util.ByteIterator
-
Get a specific number of Bytes from this iterator.
- getBytes(byte[], int, int) - Method in class akka.util.ByteIterator
-
Get a specific number of Bytes from this iterator.
- getBytes(int) - Method in class akka.util.ByteIterator
-
Get a specific number of Bytes from this iterator.
- getBytes(byte[], int, int) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- getBytesList(String) - Method in class akka.dispatch.CachingConfig
-
- getByteString(int) - Method in class akka.util.ByteIterator
-
Get a ByteString with specific number of Bytes from this iterator.
- getCallerClass() - Method in class akka.util.Reflect$
-
This optionally holds a function which looks N levels above itself
on the call stack and returns the Class[_]
object for the code
executing in that stack frame.
- getCallerClass() - Static method in class akka.util.Reflect
-
This optionally holds a function which looks N levels above itself
on the call stack and returns the Class[_]
object for the code
executing in that stack frame.
- getCamelContext() - Method in class akka.camel.javaapi.UntypedConsumerActor
-
Java API: Returns the DefaultCamelContext
- getCamelContext() - Method in class akka.camel.javaapi.UntypedProducerActor
-
Returns the CamelContext
.
- getCause() - Method in class akka.event.Logging.LogEventException
-
- getCause() - Method in exception akka.pattern.AskTimeoutException
-
- getCause() - Method in class akka.remote.AssociationErrorEvent
-
- getCause() - Method in class akka.remote.RemotingErrorEvent
-
- getChild(String) - Method in interface akka.actor.AbstractActorContext
-
Returns a reference to the named child or null if no child with
that name exists.
- getChild(String) - Method in interface akka.actor.dungeon.Children
-
- getChild(Iterator<String>) - Method in class akka.actor.InternalActorRef
-
Obtain ActorRef by possibly traversing the actor tree or looking it up at
some provider-specific location.
- getChild(Iterator<String>) - Method in class akka.actor.LocalActorRef
-
- getChild(Iterator<String>) - Method in interface akka.actor.MinimalActorRef
-
- getChild(Iterator<String>) - Method in class akka.actor.RepointableActorRef
-
- getChild(String) - Method in interface akka.actor.UntypedActorContext
-
Returns a reference to the named child or null if no child with
that name exists.
- getChild(String) - Method in class akka.actor.VirtualPathContainer
-
- getChild(Iterator<String>) - Method in class akka.actor.VirtualPathContainer
-
- getChild(Iterator<String>) - Method in class akka.remote.RemoteActorRef
-
- getChild(Iterator<String>) - Method in class akka.remote.RemoteSystemDaemon
-
Find the longest matching path which we know about and return that ref
(or ask that ref to continue searching if elements are left).
- getChildByName(String) - Method in interface akka.actor.Cell
-
Get the stats for the named child, if that exists.
- getChildByName(String) - Method in interface akka.actor.dungeon.Children
-
- getChildByName(String) - Method in class akka.actor.UnstartedCell
-
- getChildByRef(ActorRef) - Method in interface akka.actor.dungeon.Children
-
- getChildren() - Method in interface akka.actor.AbstractActorContext
-
Returns an unmodifiable Java Collection containing the linked actors,
please note that the backing map is thread-safe but not immutable
- getChildren() - Method in interface akka.actor.dungeon.Children
-
- getChildren() - Method in interface akka.actor.UntypedActorContext
-
Returns an unmodifiable Java Collection containing the linked actors,
please note that the backing map is thread-safe but not immutable
- getClasses(int) - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated string classes = 5;
- getClasses(int) - Method in class akka.remote.WireFormats.PropsData
-
repeated string classes = 5;
- getClasses(int) - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
-
repeated string classes = 5;
- getClassesBytes(int) - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated string classes = 5;
- getClassesBytes(int) - Method in class akka.remote.WireFormats.PropsData
-
repeated string classes = 5;
- getClassesBytes(int) - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
-
repeated string classes = 5;
- getClassesCount() - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated string classes = 5;
- getClassesCount() - Method in class akka.remote.WireFormats.PropsData
-
repeated string classes = 5;
- getClassesCount() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
-
repeated string classes = 5;
- getClassesList() - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated string classes = 5;
- getClassesList() - Method in class akka.remote.WireFormats.PropsData
-
repeated string classes = 5;
- getClassesList() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
-
repeated string classes = 5;
- getClassFor(String, ClassTag<T>) - Method in class akka.actor.DynamicAccess
-
Obtain a Class[_]
object loaded with the right class loader (i.e.
- getClassFor(String, ClassTag<T>) - Method in class akka.actor.ReflectiveDynamicAccess
-
- getClazz(T) - Method in interface akka.event.LogSource
-
- getClazz() - Method in class akka.remote.WireFormats.PropsData.Builder
-
required string clazz = 3;
- getClazz() - Method in class akka.remote.WireFormats.PropsData
-
required string clazz = 3;
- getClazz() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
-
required string clazz = 3;
- getClazzBytes() - Method in class akka.remote.WireFormats.PropsData.Builder
-
required string clazz = 3;
- getClazzBytes() - Method in class akka.remote.WireFormats.PropsData
-
required string clazz = 3;
- getClazzBytes() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
-
required string clazz = 3;
- GetClusterCoreRef$() - Constructor for class akka.cluster.InternalClusterAction.GetClusterCoreRef$
-
- getClusterShuttingDownInstance() - Method in class akka.cluster.ClusterEvent$
-
Java API: get the singleton instance of ClusterShuttingDown
event
- getClusterShuttingDownInstance() - Static method in class akka.cluster.ClusterEvent
-
Java API: get the singleton instance of ClusterShuttingDown
event
- getClusterStatus() - Method in interface akka.cluster.ClusterNodeMBean
-
- getCommandType() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
-
required .CommandType commandType = 1;
- getCommandType() - Method in class akka.remote.WireFormats.AkkaControlMessage
-
required .CommandType commandType = 1;
- getCommandType() - Method in interface akka.remote.WireFormats.AkkaControlMessageOrBuilder
-
required .CommandType commandType = 1;
- getConfig(String) - Method in class akka.dispatch.CachingConfig
-
- getConfig() - Method in class akka.remote.WireFormats.DeployData.Builder
-
optional bytes config = 2;
- getConfig() - Method in class akka.remote.WireFormats.DeployData
-
optional bytes config = 2;
- getConfig() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
-
optional bytes config = 2;
- getConfigList(String) - Method in class akka.dispatch.CachingConfig
-
- GetContacts() - Constructor for class akka.cluster.client.ClusterReceptionist.Internal$.GetContacts
-
- getContent(int) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
repeated .Delta.Entry content = 3;
- getContent(int) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
-
repeated .Delta.Entry content = 3;
- getContent(int) - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.BucketOrBuilder
-
repeated .Delta.Entry content = 3;
- getContentBuilder(int) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
repeated .Delta.Entry content = 3;
- getContentBuilderList() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
repeated .Delta.Entry content = 3;
- getContentCount() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
repeated .Delta.Entry content = 3;
- getContentCount() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
-
repeated .Delta.Entry content = 3;
- getContentCount() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.BucketOrBuilder
-
repeated .Delta.Entry content = 3;
- getContentList() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
repeated .Delta.Entry content = 3;
- getContentList() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
-
repeated .Delta.Entry content = 3;
- getContentList() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.BucketOrBuilder
-
repeated .Delta.Entry content = 3;
- getContentOrBuilder(int) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
repeated .Delta.Entry content = 3;
- getContentOrBuilder(int) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
-
repeated .Delta.Entry content = 3;
- getContentOrBuilder(int) - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.BucketOrBuilder
-
repeated .Delta.Entry content = 3;
- getContentOrBuilderList() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
repeated .Delta.Entry content = 3;
- getContentOrBuilderList() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
-
repeated .Delta.Entry content = 3;
- getContentOrBuilderList() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.BucketOrBuilder
-
repeated .Delta.Entry content = 3;
- getContext() - Method in class akka.actor.AbstractActor
-
Returns this AbstractActor's AbstractActorContext
The AbstractActorContext is not thread safe so do not expose it outside of the
AbstractActor.
- getContext() - Method in class akka.actor.UntypedActor
-
Returns this UntypedActor's UntypedActorContext
The UntypedActorContext is not thread safe so do not expose it outside of the
UntypedActor.
- getContext(ExtendedActorSystem) - Method in interface akka.camel.ContextProvider
-
Retrieve or create a Camel Context for the given actor system
Called once per actor system
- getContext(ExtendedActorSystem) - Method in class akka.camel.DefaultContextProvider
-
- getCookie() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
optional string cookie = 3;
- getCookie() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
-
optional string cookie = 3;
- getCookie() - Method in interface akka.remote.WireFormats.AkkaHandshakeInfoOrBuilder
-
optional string cookie = 3;
- getCookieBytes() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
optional string cookie = 3;
- getCookieBytes() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
-
optional string cookie = 3;
- getCookieBytes() - Method in interface akka.remote.WireFormats.AkkaHandshakeInfoOrBuilder
-
optional string cookie = 3;
- getCumulativeAck() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
-
required fixed64 cumulativeAck = 1;
- getCumulativeAck() - Method in class akka.remote.WireFormats.AcknowledgementInfo
-
required fixed64 cumulativeAck = 1;
- getCumulativeAck() - Method in interface akka.remote.WireFormats.AcknowledgementInfoOrBuilder
-
required fixed64 cumulativeAck = 1;
- getCurrentDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
required int64 currentDeliveryId = 1;
- getCurrentDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
-
required int64 currentDeliveryId = 1;
- getCurrentDeliveryId() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshotOrBuilder
-
required int64 currentDeliveryId = 1;
- getCurrentTopics() - Method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- getDeadline(Option<FiniteDuration>) - Method in class akka.remote.testconductor.BarrierCoordinator
-
- getDecision() - Method in class akka.typed.Failed
-
- getDefaultAddress() - Method in interface akka.actor.ActorRefProvider
-
Obtain the external address of the default transport.
- getDefaultAddress() - Method in class akka.actor.LocalActorRefProvider
-
- getDefaultAddress() - Method in class akka.remote.RemoteActorRefProvider
-
- getDefaultInstance() - Static method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address
-
- getDefaultInstance() - Static method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip
-
- getDefaultInstance() - Static method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope
-
- getDefaultInstance() - Static method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA
-
- getDefaultInstance() - Static method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics
-
- getDefaultInstance() - Static method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric
-
- getDefaultInstance() - Static method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number
-
- getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Address
-
- getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
-
- getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
- getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
-
- getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
-
- getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
-
- getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Join
-
- getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Member
-
- getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
-
- getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
-
- getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
-
- getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
-
- getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
-
- getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
-
- getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
-
- getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
-
- getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
-
- getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
-
- getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
-
- getDefaultInstance() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
-
- getDefaultInstance() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address
-
- getDefaultInstance() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
-
- getDefaultInstance() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry
-
- getDefaultInstance() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta
-
- getDefaultInstance() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload
-
- getDefaultInstance() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish
-
- getDefaultInstance() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send
-
- getDefaultInstance() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll
-
- getDefaultInstance() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status
-
- getDefaultInstance() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version
-
- getDefaultInstance() - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
-
- getDefaultInstance() - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
-
- getDefaultInstance() - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
- getDefaultInstance() - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
-
- getDefaultInstance() - Static method in class akka.remote.ContainerFormats.Selection
-
- getDefaultInstance() - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
-
- getDefaultInstance() - Static method in class akka.remote.testconductor.TestConductorProtocol.Address
-
- getDefaultInstance() - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
-
- getDefaultInstance() - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
-
- getDefaultInstance() - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello
-
- getDefaultInstance() - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
-
- getDefaultInstance() - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
-
- getDefaultInstance() - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
-
- getDefaultInstance() - Static method in class akka.remote.WireFormats.AcknowledgementInfo
-
- getDefaultInstance() - Static method in class akka.remote.WireFormats.ActorRefData
-
- getDefaultInstance() - Static method in class akka.remote.WireFormats.AddressData
-
- getDefaultInstance() - Static method in class akka.remote.WireFormats.AkkaControlMessage
-
- getDefaultInstance() - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
-
- getDefaultInstance() - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
-
- getDefaultInstance() - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
-
- getDefaultInstance() - Static method in class akka.remote.WireFormats.DeployData
-
- getDefaultInstance() - Static method in class akka.remote.WireFormats.PropsData
-
- getDefaultInstance() - Static method in class akka.remote.WireFormats.RemoteEnvelope
-
- getDefaultInstance() - Static method in class akka.remote.WireFormats.SerializedMessage
-
- getDefaultInstanceForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address
-
- getDefaultInstanceForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip
-
- getDefaultInstanceForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope
-
- getDefaultInstanceForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA
-
- getDefaultInstanceForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics
-
- getDefaultInstanceForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric
-
- getDefaultInstanceForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
-
- getDefaultInstanceForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address
-
- getDefaultInstanceForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
-
- getDefaultInstanceForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry
-
- getDefaultInstanceForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta
-
- getDefaultInstanceForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload
-
- getDefaultInstanceForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish
-
- getDefaultInstanceForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send
-
- getDefaultInstanceForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll
-
- getDefaultInstanceForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status
-
- getDefaultInstanceForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version
-
- getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
- getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
-
- getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
- getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
-
- getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
- getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
- getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
-
- getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
-
- getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.Selection.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.Selection
-
- getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
-
- getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
-
- getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
-
- getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
-
- getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
-
- getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
-
- getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
-
- getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
-
- getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AcknowledgementInfo
-
- getDefaultInstanceForType() - Method in class akka.remote.WireFormats.ActorRefData.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.WireFormats.ActorRefData
-
- getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AddressData.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AddressData
-
- getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AkkaControlMessage
-
- getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
-
- getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
-
- getDefaultInstanceForType() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
-
- getDefaultInstanceForType() - Method in class akka.remote.WireFormats.DeployData.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.WireFormats.DeployData
-
- getDefaultInstanceForType() - Method in class akka.remote.WireFormats.PropsData.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.WireFormats.PropsData
-
- getDefaultInstanceForType() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.WireFormats.RemoteEnvelope
-
- getDefaultInstanceForType() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.WireFormats.SerializedMessage
-
- getDeleted() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional bool deleted = 4;
- getDeleted() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
optional bool deleted = 4;
- getDeleted() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
-
optional bool deleted = 4;
- getDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
required int64 deliveryId = 1;
- getDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
-
required int64 deliveryId = 1;
- getDeliveryId() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder
-
required int64 deliveryId = 1;
- getDeliverySnapshot() - Method in interface akka.persistence.AtLeastOnceDelivery
-
Full state of the AtLeastOnceDelivery
.
- getDeploy() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required .DeployData deploy = 2;
- getDeploy() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
-
required .DeployData deploy = 2;
- getDeploy() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
-
required .DeployData deploy = 2;
- getDeploy() - Method in class akka.remote.WireFormats.PropsData.Builder
-
required .DeployData deploy = 2;
- getDeploy() - Method in class akka.remote.WireFormats.PropsData
-
required .DeployData deploy = 2;
- getDeploy() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
-
required .DeployData deploy = 2;
- getDeployBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required .DeployData deploy = 2;
- getDeployBuilder() - Method in class akka.remote.WireFormats.PropsData.Builder
-
required .DeployData deploy = 2;
- getDeployOrBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required .DeployData deploy = 2;
- getDeployOrBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
-
required .DeployData deploy = 2;
- getDeployOrBuilder() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
-
required .DeployData deploy = 2;
- getDeployOrBuilder() - Method in class akka.remote.WireFormats.PropsData.Builder
-
required .DeployData deploy = 2;
- getDeployOrBuilder() - Method in class akka.remote.WireFormats.PropsData
-
required .DeployData deploy = 2;
- getDeployOrBuilder() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
-
required .DeployData deploy = 2;
- getDescriptor() - Static method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
- getDescriptor() - Static method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address
-
- getDescriptor() - Static method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages
-
- getDescriptor() - Static method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
- getDescriptor() - Static method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip
-
- getDescriptor() - Static method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
- getDescriptor() - Static method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope
-
- getDescriptor() - Static method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
- getDescriptor() - Static method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA.Builder
-
- getDescriptor() - Static method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA
-
- getDescriptor() - Static method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics
-
- getDescriptor() - Static method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
- getDescriptor() - Static method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric
-
- getDescriptor() - Static method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number.Builder
-
- getDescriptor() - Static method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number
-
- getDescriptor() - Static method in enum akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.NumberType
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Address
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Empty.Builder
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Join
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Member
-
- getDescriptor() - Static method in enum akka.cluster.protobuf.msg.ClusterMessages.MemberStatus
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
-
- getDescriptor() - Static method in enum akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberType
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
-
- getDescriptor() - Static method in enum akka.cluster.protobuf.msg.ClusterMessages.ReachabilityStatus
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
-
- getDescriptor() - Static method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
-
- getDescriptor() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
- getDescriptor() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address
-
- getDescriptor() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
- getDescriptor() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
-
- getDescriptor() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Builder
-
- getDescriptor() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
- getDescriptor() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry
-
- getDescriptor() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta
-
- getDescriptor() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages
-
- getDescriptor() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload.Builder
-
- getDescriptor() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload
-
- getDescriptor() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish.Builder
-
- getDescriptor() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish
-
- getDescriptor() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
- getDescriptor() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send
-
- getDescriptor() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
-
- getDescriptor() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll
-
- getDescriptor() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
- getDescriptor() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status
-
- getDescriptor() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
-
- getDescriptor() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version
-
- getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
- getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
-
- getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
- getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
-
- getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats
-
- getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
- getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
- getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
-
- getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
-
- getDescriptor() - Static method in class akka.remote.ContainerFormats
-
- getDescriptor() - Static method in enum akka.remote.ContainerFormats.PatternType
-
- getDescriptor() - Static method in class akka.remote.ContainerFormats.Selection.Builder
-
- getDescriptor() - Static method in class akka.remote.ContainerFormats.Selection
-
- getDescriptor() - Static method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
- getDescriptor() - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
-
- getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
- getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.Address
-
- getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
-
- getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
-
- getDescriptor() - Static method in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
-
- getDescriptor() - Static method in enum akka.remote.testconductor.TestConductorProtocol.Direction
-
- getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
-
- getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
-
- getDescriptor() - Static method in enum akka.remote.testconductor.TestConductorProtocol.FailType
-
- getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol
-
- getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
-
- getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.Hello
-
- getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
- getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
-
- getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
- getDescriptor() - Static method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
-
- getDescriptor() - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
- getDescriptor() - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
-
- getDescriptor() - Static method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
-
- getDescriptor() - Static method in class akka.remote.WireFormats.AcknowledgementInfo
-
- getDescriptor() - Static method in class akka.remote.WireFormats.ActorRefData.Builder
-
- getDescriptor() - Static method in class akka.remote.WireFormats.ActorRefData
-
- getDescriptor() - Static method in class akka.remote.WireFormats.AddressData.Builder
-
- getDescriptor() - Static method in class akka.remote.WireFormats.AddressData
-
- getDescriptor() - Static method in class akka.remote.WireFormats.AkkaControlMessage.Builder
-
- getDescriptor() - Static method in class akka.remote.WireFormats.AkkaControlMessage
-
- getDescriptor() - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
- getDescriptor() - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
-
- getDescriptor() - Static method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
-
- getDescriptor() - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
-
- getDescriptor() - Static method in enum akka.remote.WireFormats.CommandType
-
- getDescriptor() - Static method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
- getDescriptor() - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
-
- getDescriptor() - Static method in class akka.remote.WireFormats.DeployData.Builder
-
- getDescriptor() - Static method in class akka.remote.WireFormats.DeployData
-
- getDescriptor() - Static method in class akka.remote.WireFormats
-
- getDescriptor() - Static method in class akka.remote.WireFormats.PropsData.Builder
-
- getDescriptor() - Static method in class akka.remote.WireFormats.PropsData
-
- getDescriptor() - Static method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
- getDescriptor() - Static method in class akka.remote.WireFormats.RemoteEnvelope
-
- getDescriptor() - Static method in class akka.remote.WireFormats.SerializedMessage.Builder
-
- getDescriptor() - Static method in class akka.remote.WireFormats.SerializedMessage
-
- getDescriptorForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
- getDescriptorForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
- getDescriptorForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
- getDescriptorForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
- getDescriptorForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA.Builder
-
- getDescriptorForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
- getDescriptorForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number.Builder
-
- getDescriptorForType() - Method in enum akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.NumberType
-
- getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
- getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty.Builder
-
- getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
- getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
- getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
- getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
- getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
-
- getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
- getDescriptorForType() - Method in enum akka.cluster.protobuf.msg.ClusterMessages.MemberStatus
-
- getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
- getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
- getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
- getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
-
- getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
- getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
-
- getDescriptorForType() - Method in enum akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberType
-
- getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
- getDescriptorForType() - Method in enum akka.cluster.protobuf.msg.ClusterMessages.ReachabilityStatus
-
- getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
-
- getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
-
- getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
- getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
-
- getDescriptorForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
-
- getDescriptorForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
- getDescriptorForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
- getDescriptorForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Builder
-
- getDescriptorForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
- getDescriptorForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload.Builder
-
- getDescriptorForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish.Builder
-
- getDescriptorForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
- getDescriptorForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
-
- getDescriptorForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
- getDescriptorForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
-
- getDescriptorForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
- getDescriptorForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
- getDescriptorForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
- getDescriptorForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
-
- getDescriptorForType() - Method in enum akka.remote.ContainerFormats.PatternType
-
- getDescriptorForType() - Method in class akka.remote.ContainerFormats.Selection.Builder
-
- getDescriptorForType() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
- getDescriptorForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
- getDescriptorForType() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
-
- getDescriptorForType() - Method in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
-
- getDescriptorForType() - Method in enum akka.remote.testconductor.TestConductorProtocol.Direction
-
- getDescriptorForType() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
-
- getDescriptorForType() - Method in enum akka.remote.testconductor.TestConductorProtocol.FailType
-
- getDescriptorForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
-
- getDescriptorForType() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
- getDescriptorForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
- getDescriptorForType() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
- getDescriptorForType() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
-
- getDescriptorForType() - Method in class akka.remote.WireFormats.ActorRefData.Builder
-
- getDescriptorForType() - Method in class akka.remote.WireFormats.AddressData.Builder
-
- getDescriptorForType() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
-
- getDescriptorForType() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
- getDescriptorForType() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
-
- getDescriptorForType() - Method in enum akka.remote.WireFormats.CommandType
-
- getDescriptorForType() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
- getDescriptorForType() - Method in class akka.remote.WireFormats.DeployData.Builder
-
- getDescriptorForType() - Method in class akka.remote.WireFormats.PropsData.Builder
-
- getDescriptorForType() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
- getDescriptorForType() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
-
- getDestination() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
required string destination = 2;
- getDestination() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
-
required string destination = 2;
- getDestination() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder
-
required string destination = 2;
- getDestinationBytes() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
required string destination = 2;
- getDestinationBytes() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
-
required string destination = 2;
- getDestinationBytes() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder
-
required string destination = 2;
- getDirection() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
optional .Direction direction = 2;
- getDirection() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
-
optional .Direction direction = 2;
- getDirection() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
-
optional .Direction direction = 2;
- getDispatcher() - Method in class akka.remote.WireFormats.DeployData.Builder
-
optional string dispatcher = 5;
- getDispatcher() - Method in class akka.remote.WireFormats.DeployData
-
optional string dispatcher = 5;
- getDispatcher() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
-
optional string dispatcher = 5;
- getDispatcherBytes() - Method in class akka.remote.WireFormats.DeployData.Builder
-
optional string dispatcher = 5;
- getDispatcherBytes() - Method in class akka.remote.WireFormats.DeployData
-
optional string dispatcher = 5;
- getDispatcherBytes() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
-
optional string dispatcher = 5;
- getDone() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional string done = 4;
- getDone() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
-
optional string done = 4;
- getDone() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
-
optional string done = 4;
- getDoneBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional string done = 4;
- getDoneBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
-
optional string done = 4;
- getDoneBytes() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
-
optional string done = 4;
- getDouble(String) - Method in class akka.dispatch.CachingConfig
-
- getDouble(ByteOrder) - Method in class akka.util.ByteIterator
-
- getDoubleList(String) - Method in class akka.dispatch.CachingConfig
-
- getDoubles(double[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- getDoubles(double[], ByteOrder) - Method in class akka.util.ByteIterator
-
Get a number of Doubles from this iterator.
- getDoubles(double[], int, int, ByteOrder) - Method in class akka.util.ByteIterator
-
Get a number of Doubles from this iterator.
- getDoubles(double[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- getDuration(String, TimeUnit) - Method in class akka.dispatch.CachingConfig
-
- getDuration(String) - Method in class akka.dispatch.CachingConfig
-
- getDurationList(String, TimeUnit) - Method in class akka.dispatch.CachingConfig
-
- getDurationList(String) - Method in class akka.dispatch.CachingConfig
-
- getEffect() - Method in class akka.typed.EffectfulActorContext
-
- getElements() - Method in class akka.actor.ActorPath
-
Java API: Sequence of names for this path from root to this.
- getEnclosedMessage() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload.Builder
-
required bytes enclosedMessage = 1;
- getEnclosedMessage() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload
-
required bytes enclosedMessage = 1;
- getEnclosedMessage() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.PayloadOrBuilder
-
required bytes enclosedMessage = 1;
- getEnclosedMessage() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
required bytes enclosedMessage = 1;
- getEnclosedMessage() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
-
required bytes enclosedMessage = 1;
- getEnclosedMessage() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
-
required bytes enclosedMessage = 1;
- getEndpointUri() - Method in class akka.camel.javaapi.UntypedConsumerActor
-
Java API: Returns the Camel endpoint URI to consume messages from.
- getEndpointUri() - Method in class akka.camel.javaapi.UntypedProducerActor
-
Returns the Camel endpoint URI to produce messages to.
- getEntry(String) - Method in class akka.cluster.sharding.Shard
-
- getEnvelope() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
optional .RemoteEnvelope envelope = 2;
- getEnvelope() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
-
optional .RemoteEnvelope envelope = 2;
- getEnvelope() - Method in interface akka.remote.WireFormats.AckAndEnvelopeContainerOrBuilder
-
optional .RemoteEnvelope envelope = 2;
- getEnvelopeBuilder() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
optional .RemoteEnvelope envelope = 2;
- getEnvelopeOrBuilder() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
optional .RemoteEnvelope envelope = 2;
- getEnvelopeOrBuilder() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
-
optional .RemoteEnvelope envelope = 2;
- getEnvelopeOrBuilder() - Method in interface akka.remote.WireFormats.AckAndEnvelopeContainerOrBuilder
-
optional .RemoteEnvelope envelope = 2;
- getErrorCause() - Method in interface akka.io.Tcp.ConnectionClosed
-
If isErrorClosed
returns true, then the error condition can be
retrieved by this method.
- getErrorCause() - Method in class akka.io.Tcp.ErrorClosed
-
- getEwma() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
optional .NodeMetrics.EWMA ewma = 3;
- getEwma() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric
-
optional .NodeMetrics.EWMA ewma = 3;
- getEwma() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.MetricOrBuilder
-
optional .NodeMetrics.EWMA ewma = 3;
- getEwma() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
optional .NodeMetrics.EWMA ewma = 3;
- getEwma() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
-
optional .NodeMetrics.EWMA ewma = 3;
- getEwma() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.MetricOrBuilder
-
optional .NodeMetrics.EWMA ewma = 3;
- getEwmaBuilder() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
optional .NodeMetrics.EWMA ewma = 3;
- getEwmaBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
optional .NodeMetrics.EWMA ewma = 3;
- getEwmaOrBuilder() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
optional .NodeMetrics.EWMA ewma = 3;
- getEwmaOrBuilder() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric
-
optional .NodeMetrics.EWMA ewma = 3;
- getEwmaOrBuilder() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.MetricOrBuilder
-
optional .NodeMetrics.EWMA ewma = 3;
- getEwmaOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
optional .NodeMetrics.EWMA ewma = 3;
- getEwmaOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
-
optional .NodeMetrics.EWMA ewma = 3;
- getEwmaOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.MetricOrBuilder
-
optional .NodeMetrics.EWMA ewma = 3;
- getExchangeId() - Method in class akka.camel.internal.CamelExchangeAdapter
-
Returns the exchange id
- getExistenceConfirmed() - Method in class akka.actor.Terminated
-
- getExitValue() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
optional int32 exitValue = 7;
- getExitValue() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
-
optional int32 exitValue = 7;
- getExitValue() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
-
optional int32 exitValue = 7;
- getExternalAddressFor(Address) - Method in interface akka.actor.ActorRefProvider
-
Obtain the address which is to be used within sender references when
sending to the given other address or none if the other address cannot be
reached from this system (i.e.
- getExternalAddressFor(Address) - Method in class akka.actor.LocalActorRefProvider
-
- getExternalAddressFor(Address) - Method in class akka.remote.RemoteActorRefProvider
-
- getFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
required .FailType failure = 1;
- getFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
-
required .FailType failure = 1;
- getFailure() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
-
required .FailType failure = 1;
- getFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .InjectFailure failure = 3;
- getFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
-
optional .InjectFailure failure = 3;
- getFailure() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
-
optional .InjectFailure failure = 3;
- getFailureBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .InjectFailure failure = 3;
- getFailureOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .InjectFailure failure = 3;
- getFailureOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
-
optional .InjectFailure failure = 3;
- getFailureOrBuilder() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
-
optional .InjectFailure failure = 3;
- getFloat(ByteOrder) - Method in class akka.util.ByteIterator
-
- getFloats(float[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- getFloats(float[], ByteOrder) - Method in class akka.util.ByteIterator
-
Get a number of Floats from this iterator.
- getFloats(float[], int, int, ByteOrder) - Method in class akka.util.ByteIterator
-
Get a number of Floats from this iterator.
- getFloats(float[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- getFrom() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
required .Address from = 1;
- getFrom() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope
-
required .Address from = 1;
- getFrom() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelopeOrBuilder
-
required .Address from = 1;
- getFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
required .UniqueAddress from = 1;
- getFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
-
required .UniqueAddress from = 1;
- getFrom() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelopeOrBuilder
-
required .UniqueAddress from = 1;
- getFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
required .UniqueAddress from = 1;
- getFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
-
required .UniqueAddress from = 1;
- getFrom() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipStatusOrBuilder
-
required .UniqueAddress from = 1;
- getFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
required .Address from = 1;
- getFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
-
required .Address from = 1;
- getFrom() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelopeOrBuilder
-
required .Address from = 1;
- getFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
-
required .UniqueAddress from = 1;
- getFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
-
required .UniqueAddress from = 1;
- getFrom() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.WelcomeOrBuilder
-
required .UniqueAddress from = 1;
- getFromBuilder() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
required .Address from = 1;
- getFromBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
required .UniqueAddress from = 1;
- getFromBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
required .UniqueAddress from = 1;
- getFromBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
required .Address from = 1;
- getFromBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
-
required .UniqueAddress from = 1;
- getFromOrBuilder() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
required .Address from = 1;
- getFromOrBuilder() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope
-
required .Address from = 1;
- getFromOrBuilder() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelopeOrBuilder
-
required .Address from = 1;
- getFromOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
required .UniqueAddress from = 1;
- getFromOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
-
required .UniqueAddress from = 1;
- getFromOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelopeOrBuilder
-
required .UniqueAddress from = 1;
- getFromOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
required .UniqueAddress from = 1;
- getFromOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
-
required .UniqueAddress from = 1;
- getFromOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipStatusOrBuilder
-
required .UniqueAddress from = 1;
- getFromOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
required .Address from = 1;
- getFromOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
-
required .Address from = 1;
- getFromOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelopeOrBuilder
-
required .Address from = 1;
- getFromOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
-
required .UniqueAddress from = 1;
- getFromOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
-
required .UniqueAddress from = 1;
- getFromOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.WelcomeOrBuilder
-
required .UniqueAddress from = 1;
- getGossip() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
required .MetricsGossip gossip = 2;
- getGossip() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope
-
required .MetricsGossip gossip = 2;
- getGossip() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelopeOrBuilder
-
required .MetricsGossip gossip = 2;
- getGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
required .MetricsGossip gossip = 2;
- getGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
-
required .MetricsGossip gossip = 2;
- getGossip() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelopeOrBuilder
-
required .MetricsGossip gossip = 2;
- getGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
-
required .Gossip gossip = 2;
- getGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
-
required .Gossip gossip = 2;
- getGossip() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.WelcomeOrBuilder
-
required .Gossip gossip = 2;
- getGossipBuilder() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
required .MetricsGossip gossip = 2;
- getGossipBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
required .MetricsGossip gossip = 2;
- getGossipBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
-
required .Gossip gossip = 2;
- getGossipOrBuilder() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
required .MetricsGossip gossip = 2;
- getGossipOrBuilder() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope
-
required .MetricsGossip gossip = 2;
- getGossipOrBuilder() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelopeOrBuilder
-
required .MetricsGossip gossip = 2;
- getGossipOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
required .MetricsGossip gossip = 2;
- getGossipOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
-
required .MetricsGossip gossip = 2;
- getGossipOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelopeOrBuilder
-
required .MetricsGossip gossip = 2;
- getGossipOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
-
required .Gossip gossip = 2;
- getGossipOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
-
required .Gossip gossip = 2;
- getGossipOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.WelcomeOrBuilder
-
required .Gossip gossip = 2;
- getHandshakeInfo() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
-
optional .AkkaHandshakeInfo handshakeInfo = 2;
- getHandshakeInfo() - Method in class akka.remote.WireFormats.AkkaControlMessage
-
optional .AkkaHandshakeInfo handshakeInfo = 2;
- getHandshakeInfo() - Method in interface akka.remote.WireFormats.AkkaControlMessageOrBuilder
-
optional .AkkaHandshakeInfo handshakeInfo = 2;
- getHandshakeInfoBuilder() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
-
optional .AkkaHandshakeInfo handshakeInfo = 2;
- getHandshakeInfoOrBuilder() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
-
optional .AkkaHandshakeInfo handshakeInfo = 2;
- getHandshakeInfoOrBuilder() - Method in class akka.remote.WireFormats.AkkaControlMessage
-
optional .AkkaHandshakeInfo handshakeInfo = 2;
- getHandshakeInfoOrBuilder() - Method in interface akka.remote.WireFormats.AkkaControlMessageOrBuilder
-
optional .AkkaHandshakeInfo handshakeInfo = 2;
- getHashIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
-
required int32 hashIndex = 1;
- getHashIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
-
required int32 hashIndex = 1;
- getHashIndex() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.VectorClock.VersionOrBuilder
-
required int32 hashIndex = 1;
- getHeaderAs(String, Class<T>, CamelContext) - Method in class akka.camel.CamelMessage
-
Java API: Returns the header by given name
parameter.
- getHeaders(Set<String>) - Method in class akka.camel.CamelMessage
-
Java API: Returns those headers from this message whose name is contained in names
.
- getHeaders() - Method in class akka.camel.CamelMessage
-
Java API: Returns all headers from this message.
- getHello() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .Hello hello = 1;
- getHello() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
-
optional .Hello hello = 1;
- getHello() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
-
optional .Hello hello = 1;
- getHelloBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .Hello hello = 1;
- getHelloOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .Hello hello = 1;
- getHelloOrBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
-
optional .Hello hello = 1;
- getHelloOrBuilder() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
-
optional .Hello hello = 1;
- getHost() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
required string host = 3;
- getHost() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
-
required string host = 3;
- getHost() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
-
required string host = 3;
- getHostBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
required string host = 3;
- getHostBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
-
required string host = 3;
- getHostBytes() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
-
required string host = 3;
- getHostname() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
required string hostname = 2;
- getHostname() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address
-
required string hostname = 2;
- getHostname() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.AddressOrBuilder
-
required string hostname = 2;
- getHostname() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
required string hostname = 2;
- getHostname() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
-
required string hostname = 2;
- getHostname() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.AddressOrBuilder
-
required string hostname = 2;
- getHostname() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
required string hostname = 2;
- getHostname() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address
-
required string hostname = 2;
- getHostname() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.AddressOrBuilder
-
required string hostname = 2;
- getHostname() - Method in class akka.remote.WireFormats.AddressData.Builder
-
required string hostname = 2;
- getHostname() - Method in class akka.remote.WireFormats.AddressData
-
required string hostname = 2;
- getHostname() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
-
required string hostname = 2;
- getHostnameBytes() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
required string hostname = 2;
- getHostnameBytes() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address
-
required string hostname = 2;
- getHostnameBytes() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.AddressOrBuilder
-
required string hostname = 2;
- getHostnameBytes() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
required string hostname = 2;
- getHostnameBytes() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
-
required string hostname = 2;
- getHostnameBytes() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.AddressOrBuilder
-
required string hostname = 2;
- getHostnameBytes() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
required string hostname = 2;
- getHostnameBytes() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address
-
required string hostname = 2;
- getHostnameBytes() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.AddressOrBuilder
-
required string hostname = 2;
- getHostnameBytes() - Method in class akka.remote.WireFormats.AddressData.Builder
-
required string hostname = 2;
- getHostnameBytes() - Method in class akka.remote.WireFormats.AddressData
-
required string hostname = 2;
- getHostnameBytes() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
-
required string hostname = 2;
- getInbox(String) - Method in class akka.typed.StubbedActorContext
-
- getInstance() - Method in class akka.actor.Kill$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.actor.Kill
-
Java API: get the singleton instance
- getInstance() - Method in class akka.actor.LocalScope$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.actor.LocalScope
-
Java API: get the singleton instance
- getInstance() - Method in class akka.actor.NoScopeGiven$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.actor.NoScopeGiven
-
Java API: get the singleton instance
- getInstance() - Method in class akka.actor.PoisonPill$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.actor.PoisonPill
-
Java API: get the singleton instance
- getInstance() - Method in class akka.actor.ReceiveTimeout$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.actor.ReceiveTimeout
-
Java API: get the singleton instance
- getInstance() - Method in class akka.camel.Ack$
-
Java API to get the Ack singleton
- getInstance() - Static method in class akka.camel.Ack
-
Java API to get the Ack singleton
- getInstance() - Method in class akka.cluster.ClusterScope$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.cluster.ClusterScope
-
Java API: get the singleton instance
- getInstance() - Method in class akka.cluster.metrics.CollectionStartMessage$
-
Java API
- getInstance() - Static method in class akka.cluster.metrics.CollectionStartMessage
-
Java API
- getInstance() - Method in class akka.cluster.metrics.CollectionStopMessage$
-
Java API
- getInstance() - Static method in class akka.cluster.metrics.CollectionStopMessage
-
Java API
- getInstance() - Method in class akka.cluster.metrics.CpuMetricsSelector$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.cluster.metrics.CpuMetricsSelector
-
Java API: get the singleton instance
- getInstance() - Method in class akka.cluster.metrics.HeapMetricsSelector$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.cluster.metrics.HeapMetricsSelector
-
Java API: get the singleton instance
- getInstance() - Method in class akka.cluster.metrics.MixMetricsSelector$
-
Java API: get the default singleton instance
- getInstance() - Static method in class akka.cluster.metrics.MixMetricsSelector
-
Java API: get the default singleton instance
- getInstance() - Method in class akka.cluster.metrics.SystemLoadAverageMetricsSelector$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.cluster.metrics.SystemLoadAverageMetricsSelector
-
Java API: get the singleton instance
- getInstance() - Method in class akka.cluster.routing.CpuMetricsSelector$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.cluster.routing.CpuMetricsSelector
-
Java API: get the singleton instance
- getInstance() - Method in class akka.cluster.routing.HeapMetricsSelector$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.cluster.routing.HeapMetricsSelector
-
Java API: get the singleton instance
- getInstance() - Method in class akka.cluster.routing.MixMetricsSelector$
-
Java API: get the default singleton instance
- getInstance() - Static method in class akka.cluster.routing.MixMetricsSelector
-
Java API: get the default singleton instance
- getInstance() - Method in class akka.cluster.routing.SystemLoadAverageMetricsSelector$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.cluster.routing.SystemLoadAverageMetricsSelector
-
Java API: get the singleton instance
- getInstance() - Method in class akka.event.Logging.LoggerInitialized$
-
Java API: get the singleton instance
- getInstance() - Method in class akka.event.NoLogging$
-
Java API to return the reference to NoLogging
- getInstance() - Static method in class akka.event.NoLogging
-
Java API to return the reference to NoLogging
- getInstance() - Method in class akka.persistence.RecoveryCompleted$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.persistence.RecoveryCompleted
-
Java API: get the singleton instance
- getInstance() - Method in class akka.remote.security.provider.InternetSeedGenerator$
-
- getInstance() - Static method in class akka.remote.security.provider.InternetSeedGenerator
-
- getInstance() - Method in class akka.remote.testconductor.Done$
-
- getInstance() - Static method in class akka.remote.testconductor.Done
-
- getInstance() - Method in class akka.remote.transport.FailureInjectorTransportAdapter.PassThru$
-
Java API: get the singleton instance
- getInstance() - Method in class akka.remote.transport.ThrottlerTransportAdapter.Blackhole$
-
Java API: get the singleton instance
- getInstance() - Method in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Both$
-
Java API: get the singleton instance
- getInstance() - Method in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Receive$
-
Java API: get the singleton instance
- getInstance() - Method in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Send$
-
Java API: get the singleton instance
- getInstance() - Method in class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociateAck$
-
Java API: get the singleton instance
- getInstance() - Method in class akka.remote.transport.ThrottlerTransportAdapter.SetThrottleAck$
-
Java API: get the singleton instance
- getInstance() - Method in class akka.remote.transport.ThrottlerTransportAdapter.Unthrottled$
-
Java API: get the singleton instance
- getInstance() - Method in class akka.routing.FromConfig$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.routing.FromConfig
-
Java API: get the singleton instance
- getInstance() - Method in class akka.routing.GetRoutees$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.routing.GetRoutees
-
Java API: get the singleton instance
- getInstance() - Method in class akka.routing.NoRouter$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.routing.NoRouter
-
Java API: get the singleton instance
- getInstruction() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
-
optional .AkkaControlMessage instruction = 2;
- getInstruction() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
-
optional .AkkaControlMessage instruction = 2;
- getInstruction() - Method in interface akka.remote.WireFormats.AkkaProtocolMessageOrBuilder
-
optional .AkkaControlMessage instruction = 2;
- getInstructionBuilder() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
-
optional .AkkaControlMessage instruction = 2;
- getInstructionOrBuilder() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
-
optional .AkkaControlMessage instruction = 2;
- getInstructionOrBuilder() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
-
optional .AkkaControlMessage instruction = 2;
- getInstructionOrBuilder() - Method in interface akka.remote.WireFormats.AkkaProtocolMessageOrBuilder
-
optional .AkkaControlMessage instruction = 2;
- getInt(String) - Method in class akka.dispatch.CachingConfig
-
- getInt(ByteOrder) - Method in class akka.util.ByteIterator
-
Get a single Int from this iterator.
- getIntList(String) - Method in class akka.dispatch.CachingConfig
-
- getInts(int[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- getInts(int[], ByteOrder) - Method in class akka.util.ByteIterator
-
Get a number of Ints from this iterator.
- getInts(int[], int, int, ByteOrder) - Method in class akka.util.ByteIterator
-
Get a number of Ints from this iterator.
- getInts(int[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- getIsNull(String) - Method in class akka.dispatch.CachingConfig
-
- getKey() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
required string key = 1;
- getKey() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry
-
required string key = 1;
- getKey() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.EntryOrBuilder
-
required string key = 1;
- getKeyBytes() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
required string key = 1;
- getKeyBytes() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry
-
required string key = 1;
- getKeyBytes() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.EntryOrBuilder
-
required string key = 1;
- getLastSender() - Method in class akka.testkit.JavaTestKit
-
- getLeader() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
-
Java API: get address of current leader, or null if none
- getLeader() - Method in class akka.cluster.ClusterEvent.LeaderChanged
-
Java API
- getLeader() - Method in class akka.cluster.ClusterEvent.RoleLeaderChanged
-
Java API
- getLeader() - Method in interface akka.cluster.ClusterNodeMBean
-
Get the address of the current leader.
- getList(String) - Method in class akka.dispatch.CachingConfig
-
- getListenAddresses() - Method in class akka.remote.RemotingListenEvent
-
- getLocalAddress() - Method in interface akka.remote.AssociationEvent
-
- getLocalAffinity() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
required bool localAffinity = 2;
- getLocalAffinity() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send
-
required bool localAffinity = 2;
- getLocalAffinity() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendOrBuilder
-
required bool localAffinity = 2;
- getLog() - Method in interface akka.actor.LoggingFSM
-
Retrieve current rolling log in oldest-first order.
- getLogger(ActorSystem, Object) - Method in class akka.event.Logging$
-
Obtain LoggingAdapter for the given actor system and source object.
- getLogger(LoggingBus, Object) - Method in class akka.event.Logging$
-
Obtain LoggingAdapter for the given logging bus and source object.
- getLogger(UntypedActor) - Method in class akka.event.Logging$
-
Obtain LoggingAdapter with MDC support for the given actor.
- getLogger(ActorSystem, Object) - Static method in class akka.event.Logging
-
Obtain LoggingAdapter for the given actor system and source object.
- getLogger(LoggingBus, Object) - Static method in class akka.event.Logging
-
Obtain LoggingAdapter for the given logging bus and source object.
- getLogger(UntypedActor) - Static method in class akka.event.Logging
-
Obtain LoggingAdapter with MDC support for the given actor.
- getLong(String) - Method in class akka.dispatch.CachingConfig
-
- getLong(ByteOrder) - Method in class akka.util.ByteIterator
-
Get a single Long from this iterator.
- getLongList(String) - Method in class akka.dispatch.CachingConfig
-
- getLongPart(int, ByteOrder) - Method in class akka.util.ByteIterator
-
Get a Long from this iterator where only the least significant n
bytes were encoded.
- getLongs(long[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- getLongs(long[], ByteOrder) - Method in class akka.util.ByteIterator
-
Get a number of Longs from this iterator.
- getLongs(long[], int, int, ByteOrder) - Method in class akka.util.ByteIterator
-
Get a number of Longs from this iterator.
- getLongs(long[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- getMailboxRequirement(Config) - Method in class akka.dispatch.Mailboxes
-
- getMailboxType(Props, Config) - Method in class akka.dispatch.Mailboxes
-
Finds out the mailbox type for an actor based on configuration, props and requirements.
- getManager() - Method in class akka.io.TcpExt
-
Java API: retrieve a reference to the manager actor.
- getManager() - Method in class akka.io.UdpConnectedExt
-
Java API: retrieve the UDP manager actor’s reference.
- getManager() - Method in class akka.io.UdpExt
-
Java API: retrieve the UDP manager actor’s reference.
- getMatcher() - Method in class akka.remote.ContainerFormats.Selection.Builder
-
optional string matcher = 2;
- getMatcher() - Method in class akka.remote.ContainerFormats.Selection
-
optional string matcher = 2;
- getMatcher() - Method in interface akka.remote.ContainerFormats.SelectionOrBuilder
-
optional string matcher = 2;
- getMatcherBytes() - Method in class akka.remote.ContainerFormats.Selection.Builder
-
optional string matcher = 2;
- getMatcherBytes() - Method in class akka.remote.ContainerFormats.Selection
-
optional string matcher = 2;
- getMatcherBytes() - Method in interface akka.remote.ContainerFormats.SelectionOrBuilder
-
optional string matcher = 2;
- getMDC() - Method in interface akka.event.DiagnosticLoggingAdapter
-
Java API:
Mapped Diagnostic Context for application defined values
which can be used in PatternLayout when akka.event.slf4j.Slf4jLogger
is configured.
- getMDC() - Method in interface akka.event.Logging.LogEvent
-
Java API: Retrieve the contents of the MDC.
- getMembers() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
-
Java API: get current member list.
- getMembers() - Method in interface akka.cluster.ClusterNodeMBean
-
Comma separated addresses of member nodes, sorted in the cluster ring order.
- getMembers(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .Member members = 4;
- getMembers(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
repeated .Member members = 4;
- getMembers(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
-
repeated .Member members = 4;
- getMembersBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .Member members = 4;
- getMembersBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .Member members = 4;
- getMembersCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .Member members = 4;
- getMembersCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
repeated .Member members = 4;
- getMembersCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
-
repeated .Member members = 4;
- getMembersList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .Member members = 4;
- getMembersList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
repeated .Member members = 4;
- getMembersList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
-
repeated .Member members = 4;
- getMembersOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .Member members = 4;
- getMembersOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
repeated .Member members = 4;
- getMembersOrBuilder(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
-
repeated .Member members = 4;
- getMembersOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .Member members = 4;
- getMembersOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
repeated .Member members = 4;
- getMembersOrBuilderList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
-
repeated .Member members = 4;
- getMemberStatus() - Method in interface akka.cluster.ClusterNodeMBean
-
Member status for this node.
- getMemorySize(String) - Method in class akka.dispatch.CachingConfig
-
- getMemorySizeList(String) - Method in class akka.dispatch.CachingConfig
-
- getMessage() - Method in class akka.actor.UnhandledMessage
-
- getMessage() - Method in exception akka.camel.ActorNotRegisteredException
-
- getMessage() - Method in class akka.event.Logging.LogEventException
-
- getMessage() - Method in class akka.persistence.AtLeastOnceDelivery.UnconfirmedDelivery
-
Java API
- getMessage() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
required .SerializedMessage message = 2;
- getMessage() - Method in class akka.remote.WireFormats.RemoteEnvelope
-
required .SerializedMessage message = 2;
- getMessage() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
-
required .SerializedMessage message = 2;
- getMessage() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
-
required bytes message = 1;
- getMessage() - Method in class akka.remote.WireFormats.SerializedMessage
-
required bytes message = 1;
- getMessage() - Method in interface akka.remote.WireFormats.SerializedMessageOrBuilder
-
required bytes message = 1;
- getMessageBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
required .SerializedMessage message = 2;
- getMessageManifest() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload.Builder
-
optional bytes messageManifest = 4;
- getMessageManifest() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload
-
optional bytes messageManifest = 4;
- getMessageManifest() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.PayloadOrBuilder
-
optional bytes messageManifest = 4;
- getMessageManifest() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
optional bytes messageManifest = 4;
- getMessageManifest() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
-
optional bytes messageManifest = 4;
- getMessageManifest() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
-
optional bytes messageManifest = 4;
- getMessageManifest() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
-
optional bytes messageManifest = 3;
- getMessageManifest() - Method in class akka.remote.WireFormats.SerializedMessage
-
optional bytes messageManifest = 3;
- getMessageManifest() - Method in interface akka.remote.WireFormats.SerializedMessageOrBuilder
-
optional bytes messageManifest = 3;
- getMessageOrBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
required .SerializedMessage message = 2;
- getMessageOrBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope
-
required .SerializedMessage message = 2;
- getMessageOrBuilder() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
-
required .SerializedMessage message = 2;
- getMetrics() - Method in class akka.cluster.metrics.NodeMetrics
-
Java API
- getMetrics(int) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetrics(int) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetrics(int) - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetricsOrBuilder
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetrics() - Method in class akka.cluster.NodeMetrics
-
Java API
- getMetrics(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetrics(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetrics(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetricsOrBuilder
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsBuilder(int) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsBuilderList() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsCount() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsCount() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsCount() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetricsOrBuilder
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetricsOrBuilder
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsList() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsList() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsList() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetricsOrBuilder
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetricsOrBuilder
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsOrBuilder(int) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsOrBuilder(int) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsOrBuilder(int) - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetricsOrBuilder
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsOrBuilder(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetricsOrBuilder
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsOrBuilderList() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsOrBuilderList() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsOrBuilderList() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetricsOrBuilder
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
-
repeated .NodeMetrics.Metric metrics = 3;
- getMetricsOrBuilderList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetricsOrBuilder
-
repeated .NodeMetrics.Metric metrics = 3;
- getMillisDuration(String) - Method in class akka.util.Helpers.ConfigOps
-
- getMilliseconds(String) - Method in class akka.dispatch.CachingConfig
-
- getMillisecondsList(String) - Method in class akka.dispatch.CachingConfig
-
- getNacks(int) - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
-
repeated fixed64 nacks = 2;
- getNacks(int) - Method in class akka.remote.WireFormats.AcknowledgementInfo
-
repeated fixed64 nacks = 2;
- getNacks(int) - Method in interface akka.remote.WireFormats.AcknowledgementInfoOrBuilder
-
repeated fixed64 nacks = 2;
- getNacksCount() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
-
repeated fixed64 nacks = 2;
- getNacksCount() - Method in class akka.remote.WireFormats.AcknowledgementInfo
-
repeated fixed64 nacks = 2;
- getNacksCount() - Method in interface akka.remote.WireFormats.AcknowledgementInfoOrBuilder
-
repeated fixed64 nacks = 2;
- getNacksList() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
-
repeated fixed64 nacks = 2;
- getNacksList() - Method in class akka.remote.WireFormats.AcknowledgementInfo
-
repeated fixed64 nacks = 2;
- getNacksList() - Method in interface akka.remote.WireFormats.AcknowledgementInfoOrBuilder
-
repeated fixed64 nacks = 2;
- getName() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
-
required string name = 1;
- getName() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
-
required string name = 1;
- getName() - Method in interface akka.remote.testconductor.TestConductorProtocol.EnterBarrierOrBuilder
-
required string name = 1;
- getName() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
-
required string name = 1;
- getName() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
-
required string name = 1;
- getName() - Method in interface akka.remote.testconductor.TestConductorProtocol.HelloOrBuilder
-
required string name = 1;
- getNameBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
-
required string name = 1;
- getNameBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
-
required string name = 1;
- getNameBytes() - Method in interface akka.remote.testconductor.TestConductorProtocol.EnterBarrierOrBuilder
-
required string name = 1;
- getNameBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
-
required string name = 1;
- getNameBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
-
required string name = 1;
- getNameBytes() - Method in interface akka.remote.testconductor.TestConductorProtocol.HelloOrBuilder
-
required string name = 1;
- getNameIndex() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
required int32 nameIndex = 1;
- getNameIndex() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric
-
required int32 nameIndex = 1;
- getNameIndex() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.MetricOrBuilder
-
required int32 nameIndex = 1;
- getNameIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
required int32 nameIndex = 1;
- getNameIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
-
required int32 nameIndex = 1;
- getNameIndex() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.MetricOrBuilder
-
required int32 nameIndex = 1;
- getNanosDuration(String) - Method in class akka.util.Helpers.ConfigOps
-
- getNanoseconds(String) - Method in class akka.dispatch.CachingConfig
-
- getNanosecondsList(String) - Method in class akka.dispatch.CachingConfig
-
- getNextOldestChanged() - Method in class akka.cluster.singleton.ClusterSingletonManager
-
- getNode() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
-
required .UniqueAddress node = 1;
- getNode() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
-
required .UniqueAddress node = 1;
- getNode() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.JoinOrBuilder
-
required .UniqueAddress node = 1;
- getNode() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
-
required string node = 1;
- getNode() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
-
required string node = 1;
- getNode() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressRequestOrBuilder
-
required string node = 1;
- getNodeBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
-
required .UniqueAddress node = 1;
- getNodeBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
-
required string node = 1;
- getNodeBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
-
required string node = 1;
- getNodeBytes() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressRequestOrBuilder
-
required string node = 1;
- getNodeMetrics() - Method in class akka.cluster.ClusterEvent.ClusterMetricsChanged
-
Java API
- getNodeMetrics() - Method in class akka.cluster.metrics.ClusterMetricsChanged
-
Java API
- getNodeMetrics(int) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetrics(int) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetrics(int) - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipOrBuilder
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetrics(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetrics(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetrics(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsBuilder(int) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsBuilderList() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsCount() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsCount() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsCount() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipOrBuilder
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsList() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsList() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsList() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipOrBuilder
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsOrBuilder(int) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsOrBuilder(int) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsOrBuilder(int) - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipOrBuilder
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsOrBuilder(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsOrBuilderList() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsOrBuilderList() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsOrBuilderList() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipOrBuilder
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeMetricsOrBuilderList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipOrBuilder
-
repeated .NodeMetrics nodeMetrics = 3;
- getNodeOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
-
required .UniqueAddress node = 1;
- getNodeOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
-
required .UniqueAddress node = 1;
- getNodeOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.JoinOrBuilder
-
required .UniqueAddress node = 1;
- getNodes() - Method in interface akka.remote.testconductor.Conductor
-
Obtain the list of remote host names currently registered.
- GetNodes$() - Constructor for class akka.remote.testconductor.Controller.GetNodes$
-
- getNumber() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
required .NodeMetrics.Number number = 2;
- getNumber() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric
-
required .NodeMetrics.Number number = 2;
- getNumber() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.MetricOrBuilder
-
required .NodeMetrics.Number number = 2;
- getNumber() - Method in enum akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.NumberType
-
- getNumber() - Method in enum akka.cluster.protobuf.msg.ClusterMessages.MemberStatus
-
- getNumber() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
required .NodeMetrics.Number number = 2;
- getNumber() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
-
required .NodeMetrics.Number number = 2;
- getNumber() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.MetricOrBuilder
-
required .NodeMetrics.Number number = 2;
- getNumber() - Method in enum akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberType
-
- getNumber() - Method in enum akka.cluster.protobuf.msg.ClusterMessages.ReachabilityStatus
-
- getNumber(String) - Method in class akka.dispatch.CachingConfig
-
- getNumber() - Method in enum akka.remote.ContainerFormats.PatternType
-
- getNumber() - Method in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
-
- getNumber() - Method in enum akka.remote.testconductor.TestConductorProtocol.Direction
-
- getNumber() - Method in enum akka.remote.testconductor.TestConductorProtocol.FailType
-
- getNumber() - Method in enum akka.remote.WireFormats.CommandType
-
- getNumberBuilder() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
required .NodeMetrics.Number number = 2;
- getNumberBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
required .NodeMetrics.Number number = 2;
- getNumberList(String) - Method in class akka.dispatch.CachingConfig
-
- getNumberOrBuilder() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
required .NodeMetrics.Number number = 2;
- getNumberOrBuilder() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric
-
required .NodeMetrics.Number number = 2;
- getNumberOrBuilder() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.MetricOrBuilder
-
required .NodeMetrics.Number number = 2;
- getNumberOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
required .NodeMetrics.Number number = 2;
- getNumberOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
-
required .NodeMetrics.Number number = 2;
- getNumberOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.MetricOrBuilder
-
required .NodeMetrics.Number number = 2;
- getObject(String) - Method in class akka.dispatch.CachingConfig
-
- getObjectFor(String, ClassTag<T>) - Method in class akka.actor.DynamicAccess
-
Obtain the Scala “object” instance for the given fully-qualified class name, if there is one.
- getObjectFor(String, ClassTag<T>) - Method in class akka.actor.ReflectiveDynamicAccess
-
- getObjectList(String) - Method in class akka.dispatch.CachingConfig
-
- getObserverReachability(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated .ObserverReachability observerReachability = 2;
- getObserverReachability(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
-
repeated .ObserverReachability observerReachability = 2;
- getObserverReachability(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOverviewOrBuilder
-
repeated .ObserverReachability observerReachability = 2;
- getObserverReachabilityBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated .ObserverReachability observerReachability = 2;
- getObserverReachabilityBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated .ObserverReachability observerReachability = 2;
- getObserverReachabilityCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated .ObserverReachability observerReachability = 2;
- getObserverReachabilityCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
-
repeated .ObserverReachability observerReachability = 2;
- getObserverReachabilityCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOverviewOrBuilder
-
repeated .ObserverReachability observerReachability = 2;
- getObserverReachabilityList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated .ObserverReachability observerReachability = 2;
- getObserverReachabilityList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
-
repeated .ObserverReachability observerReachability = 2;
- getObserverReachabilityList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOverviewOrBuilder
-
repeated .ObserverReachability observerReachability = 2;
- getObserverReachabilityOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated .ObserverReachability observerReachability = 2;
- getObserverReachabilityOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
-
repeated .ObserverReachability observerReachability = 2;
- getObserverReachabilityOrBuilder(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOverviewOrBuilder
-
repeated .ObserverReachability observerReachability = 2;
- getObserverReachabilityOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated .ObserverReachability observerReachability = 2;
- getObserverReachabilityOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
-
repeated .ObserverReachability observerReachability = 2;
- getObserverReachabilityOrBuilderList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOverviewOrBuilder
-
repeated .ObserverReachability observerReachability = 2;
- GetOne(FiniteDuration, ActorRef<Receiver.GetOneResult<T>>) - Constructor for class akka.typed.patterns.Receiver.GetOne
-
- GetOne$() - Constructor for class akka.typed.patterns.Receiver.GetOne$
-
- GetOneResult(ActorRef<Receiver.Command<T>>, Option<T>) - Constructor for class akka.typed.patterns.Receiver.GetOneResult
-
- GetOneResult$() - Constructor for class akka.typed.patterns.Receiver.GetOneResult$
-
- getOp() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
-
required .BarrierOp op = 2;
- getOp() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
-
required .BarrierOp op = 2;
- getOp() - Method in interface akka.remote.testconductor.TestConductorProtocol.EnterBarrierOrBuilder
-
required .BarrierOp op = 2;
- getOrElse(B) - Method in class akka.japi.Option
-
Returns a
if this is some(a)
or defaultValue
if
this is none
.
- getOrElse(B) - Method in class akka.japi.Option.Some
-
- getOrigin() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
required .AddressData origin = 1;
- getOrigin() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
-
required .AddressData origin = 1;
- getOrigin() - Method in interface akka.remote.WireFormats.AkkaHandshakeInfoOrBuilder
-
required .AddressData origin = 1;
- getOriginBuilder() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
required .AddressData origin = 1;
- getOriginOrBuilder() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
required .AddressData origin = 1;
- getOriginOrBuilder() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
-
required .AddressData origin = 1;
- getOriginOrBuilder() - Method in interface akka.remote.WireFormats.AkkaHandshakeInfoOrBuilder
-
required .AddressData origin = 1;
- getOverview() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
required .GossipOverview overview = 5;
- getOverview() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
required .GossipOverview overview = 5;
- getOverview() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
-
required .GossipOverview overview = 5;
- getOverviewBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
required .GossipOverview overview = 5;
- getOverviewOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
required .GossipOverview overview = 5;
- getOverviewOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
required .GossipOverview overview = 5;
- getOverviewOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
-
required .GossipOverview overview = 5;
- getOwner() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
required .Address owner = 1;
- getOwner() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
-
required .Address owner = 1;
- getOwner() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.BucketOrBuilder
-
required .Address owner = 1;
- getOwnerBuilder() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
required .Address owner = 1;
- getOwnerOrBuilder() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
required .Address owner = 1;
- getOwnerOrBuilder() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
-
required .Address owner = 1;
- getOwnerOrBuilder() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.BucketOrBuilder
-
required .Address owner = 1;
- getParent() - Method in class akka.actor.InternalActorRef
-
Obtain parent of this ref; used by getChild for ".." paths.
- getParent() - Method in class akka.actor.LocalActorRef
-
- getParent() - Method in interface akka.actor.MinimalActorRef
-
- getParent() - Method in class akka.actor.RepointableActorRef
-
- getParent() - Method in class akka.actor.VirtualPathContainer
-
- getParent() - Method in class akka.pattern.PromiseActorRef
-
- getParent() - Method in class akka.remote.RemoteActorRef
-
- getParserForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address
-
- getParserForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip
-
- getParserForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope
-
- getParserForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA
-
- getParserForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics
-
- getParserForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric
-
- getParserForType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number
-
- getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
-
- getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
-
- getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
- getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
-
- getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
-
- getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
-
- getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
-
- getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
-
- getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
-
- getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
-
- getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
-
- getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
-
- getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
-
- getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
-
- getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
-
- getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
-
- getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
-
- getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
-
- getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
-
- getParserForType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
-
- getParserForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address
-
- getParserForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
-
- getParserForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry
-
- getParserForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta
-
- getParserForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload
-
- getParserForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish
-
- getParserForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send
-
- getParserForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll
-
- getParserForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status
-
- getParserForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version
-
- getParserForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
-
- getParserForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
-
- getParserForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
- getParserForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
-
- getParserForType() - Method in class akka.remote.ContainerFormats.Selection
-
- getParserForType() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
-
- getParserForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
-
- getParserForType() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
-
- getParserForType() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
-
- getParserForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
-
- getParserForType() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
-
- getParserForType() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
-
- getParserForType() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
-
- getParserForType() - Method in class akka.remote.WireFormats.AcknowledgementInfo
-
- getParserForType() - Method in class akka.remote.WireFormats.ActorRefData
-
- getParserForType() - Method in class akka.remote.WireFormats.AddressData
-
- getParserForType() - Method in class akka.remote.WireFormats.AkkaControlMessage
-
- getParserForType() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
-
- getParserForType() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
-
- getParserForType() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
-
- getParserForType() - Method in class akka.remote.WireFormats.DeployData
-
- getParserForType() - Method in class akka.remote.WireFormats.PropsData
-
- getParserForType() - Method in class akka.remote.WireFormats.RemoteEnvelope
-
- getParserForType() - Method in class akka.remote.WireFormats.SerializedMessage
-
- getPath() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
required string path = 1;
- getPath() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send
-
required string path = 1;
- getPath() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendOrBuilder
-
required string path = 1;
- getPath() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
-
required string path = 1;
- getPath() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll
-
required string path = 1;
- getPath() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAllOrBuilder
-
required string path = 1;
- getPath() - Method in class akka.remote.WireFormats.ActorRefData.Builder
-
required string path = 1;
- getPath() - Method in class akka.remote.WireFormats.ActorRefData
-
required string path = 1;
- getPath() - Method in interface akka.remote.WireFormats.ActorRefDataOrBuilder
-
required string path = 1;
- getPath() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required string path = 3;
- getPath() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
-
required string path = 3;
- getPath() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
-
required string path = 3;
- getPath() - Method in class akka.remote.WireFormats.DeployData.Builder
-
required string path = 1;
- getPath() - Method in class akka.remote.WireFormats.DeployData
-
required string path = 1;
- getPath() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
-
required string path = 1;
- getPathBytes() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
required string path = 1;
- getPathBytes() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send
-
required string path = 1;
- getPathBytes() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendOrBuilder
-
required string path = 1;
- getPathBytes() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
-
required string path = 1;
- getPathBytes() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll
-
required string path = 1;
- getPathBytes() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAllOrBuilder
-
required string path = 1;
- getPathBytes() - Method in class akka.remote.WireFormats.ActorRefData.Builder
-
required string path = 1;
- getPathBytes() - Method in class akka.remote.WireFormats.ActorRefData
-
required string path = 1;
- getPathBytes() - Method in interface akka.remote.WireFormats.ActorRefDataOrBuilder
-
required string path = 1;
- getPathBytes() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required string path = 3;
- getPathBytes() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
-
required string path = 3;
- getPathBytes() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
-
required string path = 3;
- getPathBytes() - Method in class akka.remote.WireFormats.DeployData.Builder
-
required string path = 1;
- getPathBytes() - Method in class akka.remote.WireFormats.DeployData
-
required string path = 1;
- getPathBytes() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
-
required string path = 1;
- getPaths() - Method in class akka.routing.GroupBase
-
- getPattern(int) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
repeated .Selection pattern = 3;
- getPattern(int) - Method in class akka.remote.ContainerFormats.SelectionEnvelope
-
repeated .Selection pattern = 3;
- getPattern(int) - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
-
repeated .Selection pattern = 3;
- getPatternBuilder(int) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
repeated .Selection pattern = 3;
- getPatternBuilderList() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
repeated .Selection pattern = 3;
- getPatternCount() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
repeated .Selection pattern = 3;
- getPatternCount() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
-
repeated .Selection pattern = 3;
- getPatternCount() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
-
repeated .Selection pattern = 3;
- getPatternList() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
repeated .Selection pattern = 3;
- getPatternList() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
-
repeated .Selection pattern = 3;
- getPatternList() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
-
repeated .Selection pattern = 3;
- getPatternOrBuilder(int) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
repeated .Selection pattern = 3;
- getPatternOrBuilder(int) - Method in class akka.remote.ContainerFormats.SelectionEnvelope
-
repeated .Selection pattern = 3;
- getPatternOrBuilder(int) - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
-
repeated .Selection pattern = 3;
- getPatternOrBuilderList() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
repeated .Selection pattern = 3;
- getPatternOrBuilderList() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
-
repeated .Selection pattern = 3;
- getPatternOrBuilderList() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
-
repeated .Selection pattern = 3;
- getPayload() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish.Builder
-
required .Payload payload = 3;
- getPayload() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish
-
required .Payload payload = 3;
- getPayload() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.PublishOrBuilder
-
required .Payload payload = 3;
- getPayload() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
required .Payload payload = 3;
- getPayload() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send
-
required .Payload payload = 3;
- getPayload() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendOrBuilder
-
required .Payload payload = 3;
- getPayload() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
-
required .Payload payload = 3;
- getPayload() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll
-
required .Payload payload = 3;
- getPayload() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAllOrBuilder
-
required .Payload payload = 3;
- getPayload() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
required .PersistentPayload payload = 3;
- getPayload() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
-
required .PersistentPayload payload = 3;
- getPayload() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder
-
required .PersistentPayload payload = 3;
- getPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional .PersistentPayload payload = 1;
- getPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
optional .PersistentPayload payload = 1;
- getPayload() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
-
optional .PersistentPayload payload = 1;
- getPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
-
required bytes payload = 2;
- getPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
-
required bytes payload = 2;
- getPayload() - Method in interface akka.persistence.serialization.MessageFormats.PersistentPayloadOrBuilder
-
required bytes payload = 2;
- getPayload() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
-
optional bytes payload = 1;
- getPayload() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
-
optional bytes payload = 1;
- getPayload() - Method in interface akka.remote.WireFormats.AkkaProtocolMessageOrBuilder
-
optional bytes payload = 1;
- getPayloadBuilder() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish.Builder
-
required .Payload payload = 3;
- getPayloadBuilder() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
required .Payload payload = 3;
- getPayloadBuilder() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
-
required .Payload payload = 3;
- getPayloadBuilder() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
required .PersistentPayload payload = 3;
- getPayloadBuilder() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional .PersistentPayload payload = 1;
- getPayloadManifest() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
-
optional bytes payloadManifest = 3;
- getPayloadManifest() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
-
optional bytes payloadManifest = 3;
- getPayloadManifest() - Method in interface akka.persistence.serialization.MessageFormats.PersistentPayloadOrBuilder
-
optional bytes payloadManifest = 3;
- getPayloadOrBuilder() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish.Builder
-
required .Payload payload = 3;
- getPayloadOrBuilder() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish
-
required .Payload payload = 3;
- getPayloadOrBuilder() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.PublishOrBuilder
-
required .Payload payload = 3;
- getPayloadOrBuilder() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
required .Payload payload = 3;
- getPayloadOrBuilder() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send
-
required .Payload payload = 3;
- getPayloadOrBuilder() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendOrBuilder
-
required .Payload payload = 3;
- getPayloadOrBuilder() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
-
required .Payload payload = 3;
- getPayloadOrBuilder() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll
-
required .Payload payload = 3;
- getPayloadOrBuilder() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAllOrBuilder
-
required .Payload payload = 3;
- getPayloadOrBuilder() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
required .PersistentPayload payload = 3;
- getPayloadOrBuilder() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
-
required .PersistentPayload payload = 3;
- getPayloadOrBuilder() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder
-
required .PersistentPayload payload = 3;
- getPayloadOrBuilder() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional .PersistentPayload payload = 1;
- getPayloadOrBuilder() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
optional .PersistentPayload payload = 1;
- getPayloadOrBuilder() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
-
optional .PersistentPayload payload = 1;
- getPersistenceId() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional string persistenceId = 3;
- getPersistenceId() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
optional string persistenceId = 3;
- getPersistenceId() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
-
optional string persistenceId = 3;
- getPersistenceIdBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional string persistenceId = 3;
- getPersistenceIdBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
optional string persistenceId = 3;
- getPersistenceIdBytes() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
-
optional string persistenceId = 3;
- getPipeline() - Method in class akka.remote.testconductor.TestConductorPipelineFactory
-
- getPort() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
required uint32 port = 3;
- getPort() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address
-
required uint32 port = 3;
- getPort() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.AddressOrBuilder
-
required uint32 port = 3;
- getPort() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
required uint32 port = 3;
- getPort() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
-
required uint32 port = 3;
- getPort() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.AddressOrBuilder
-
required uint32 port = 3;
- getPort() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
required uint32 port = 3;
- getPort() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address
-
required uint32 port = 3;
- getPort() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.AddressOrBuilder
-
required uint32 port = 3;
- getPort() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
required int32 port = 4;
- getPort() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
-
required int32 port = 4;
- getPort() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
-
required int32 port = 4;
- getPort() - Method in class akka.remote.WireFormats.AddressData.Builder
-
required uint32 port = 3;
- getPort() - Method in class akka.remote.WireFormats.AddressData
-
required uint32 port = 3;
- getPort() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
-
required uint32 port = 3;
- getProducedMessageQueueType(MailboxType) - Method in class akka.dispatch.Mailboxes
-
- getProducerTemplate() - Method in class akka.camel.javaapi.UntypedConsumerActor
-
Java API: Returns the ProducerTemplate
- getProducerTemplate() - Method in class akka.camel.javaapi.UntypedProducerActor
-
Returns the ProducerTemplate
.
- getProps() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required .PropsData props = 1;
- getProps() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
-
required .PropsData props = 1;
- getProps() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
-
required .PropsData props = 1;
- getPropsBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required .PropsData props = 1;
- getPropsOrBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required .PropsData props = 1;
- getPropsOrBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
-
required .PropsData props = 1;
- getPropsOrBuilder() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
-
required .PropsData props = 1;
- getProtocol() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
optional string protocol = 4;
- getProtocol() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address
-
optional string protocol = 4;
- getProtocol() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.AddressOrBuilder
-
optional string protocol = 4;
- getProtocol() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
optional string protocol = 4;
- getProtocol() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
-
optional string protocol = 4;
- getProtocol() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.AddressOrBuilder
-
optional string protocol = 4;
- getProtocol() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
optional string protocol = 4;
- getProtocol() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address
-
optional string protocol = 4;
- getProtocol() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.AddressOrBuilder
-
optional string protocol = 4;
- getProtocol() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
required string protocol = 1;
- getProtocol() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
-
required string protocol = 1;
- getProtocol() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
-
required string protocol = 1;
- getProtocol() - Method in class akka.remote.WireFormats.AddressData.Builder
-
optional string protocol = 4;
- getProtocol() - Method in class akka.remote.WireFormats.AddressData
-
optional string protocol = 4;
- getProtocol() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
-
optional string protocol = 4;
- getProtocolBytes() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
optional string protocol = 4;
- getProtocolBytes() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address
-
optional string protocol = 4;
- getProtocolBytes() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.AddressOrBuilder
-
optional string protocol = 4;
- getProtocolBytes() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
optional string protocol = 4;
- getProtocolBytes() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
-
optional string protocol = 4;
- getProtocolBytes() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.AddressOrBuilder
-
optional string protocol = 4;
- getProtocolBytes() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
optional string protocol = 4;
- getProtocolBytes() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address
-
optional string protocol = 4;
- getProtocolBytes() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.AddressOrBuilder
-
optional string protocol = 4;
- getProtocolBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
required string protocol = 1;
- getProtocolBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
-
required string protocol = 1;
- getProtocolBytes() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
-
required string protocol = 1;
- getProtocolBytes() - Method in class akka.remote.WireFormats.AddressData.Builder
-
optional string protocol = 4;
- getProtocolBytes() - Method in class akka.remote.WireFormats.AddressData
-
optional string protocol = 4;
- getProtocolBytes() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
-
optional string protocol = 4;
- getRateMBit() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
optional float rateMBit = 6;
- getRateMBit() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
-
optional float rateMBit = 6;
- getRateMBit() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
-
optional float rateMBit = 6;
- getRawResult() - Method in class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinTask
-
- getRawResult() - Method in class akka.dispatch.Mailbox
-
- getRecipient() - Method in class akka.actor.UnhandledMessage
-
- getRecipient() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
required .ActorRefData recipient = 1;
- getRecipient() - Method in class akka.remote.WireFormats.RemoteEnvelope
-
required .ActorRefData recipient = 1;
- getRecipient() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
-
required .ActorRefData recipient = 1;
- getRecipientBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
required .ActorRefData recipient = 1;
- getRecipientOrBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
required .ActorRefData recipient = 1;
- getRecipientOrBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope
-
required .ActorRefData recipient = 1;
- getRecipientOrBuilder() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
-
required .ActorRefData recipient = 1;
- getRef() - Method in class akka.actor.ActorIdentity
-
Java API: ActorRef
of the actor replying to the request or
null if no actor matched the request.
- getRef() - Method in class akka.actor.dsl.Inbox.Inbox
-
- getRef() - Method in class akka.actor.Inbox
-
Obtain a reference to the internal actor, which can then for example be
registered with the event stream or whatever else you may want to do with
an
ActorRef
.
- getRef() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
optional string ref = 3;
- getRef() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry
-
optional string ref = 3;
- getRef() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.EntryOrBuilder
-
optional string ref = 3;
- getRef() - Method in class akka.testkit.JavaTestKit
-
Shorthand to get the testActor.
- getRefBytes() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
optional string ref = 3;
- getRefBytes() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry
-
optional string ref = 3;
- getRefBytes() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.EntryOrBuilder
-
optional string ref = 3;
- getRemainingTime() - Method in class akka.testkit.JavaTestKit
-
- getRemainingTimeOr(FiniteDuration) - Method in class akka.testkit.JavaTestKit
-
- getRemoteAddress() - Method in interface akka.remote.AssociationEvent
-
- getRemoteReadHandlerFor(TestAssociationHandle) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
-
Returns the event handler corresponding to the remote endpoint of the given local handle.
- getReply() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
required bool reply = 3;
- getReply() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope
-
required bool reply = 3;
- getReply() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelopeOrBuilder
-
required bool reply = 3;
- getReply() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
required bool reply = 3;
- getReply() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
-
required bool reply = 3;
- getReply() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelopeOrBuilder
-
required bool reply = 3;
- getReplyTimeout() - Method in interface akka.camel.internal.component.ActorEndpointConfig
-
- getRequiredType(Class<? extends Actor>) - Method in class akka.dispatch.Mailboxes
-
Return the required message queue type for this class if any.
- getResolver() - Method in class akka.io.DnsExt
-
- getRoleLeader(String) - Method in class akka.cluster.ClusterEvent.CurrentClusterState
-
Java API: get address of current leader within the role set,
or null if no node with that role
- getRoles() - Method in class akka.cluster.Member
-
Java API
- getRoles(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
-
repeated string roles = 2;
- getRoles(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
-
repeated string roles = 2;
- getRoles(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.JoinOrBuilder
-
repeated string roles = 2;
- getRolesBytes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
-
repeated string roles = 2;
- getRolesBytes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
-
repeated string roles = 2;
- getRolesBytes(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.JoinOrBuilder
-
repeated string roles = 2;
- getRolesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
-
repeated string roles = 2;
- getRolesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
-
repeated string roles = 2;
- getRolesCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.JoinOrBuilder
-
repeated string roles = 2;
- getRolesIndexes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
repeated int32 rolesIndexes = 4 [packed = true];
- getRolesIndexes(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
-
repeated int32 rolesIndexes = 4 [packed = true];
- getRolesIndexes(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MemberOrBuilder
-
repeated int32 rolesIndexes = 4 [packed = true];
- getRolesIndexesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
repeated int32 rolesIndexes = 4 [packed = true];
- getRolesIndexesCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
-
repeated int32 rolesIndexes = 4 [packed = true];
- getRolesIndexesCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MemberOrBuilder
-
repeated int32 rolesIndexes = 4 [packed = true];
- getRolesIndexesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
repeated int32 rolesIndexes = 4 [packed = true];
- getRolesIndexesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
-
repeated int32 rolesIndexes = 4 [packed = true];
- getRolesIndexesList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MemberOrBuilder
-
repeated int32 rolesIndexes = 4 [packed = true];
- getRolesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
-
repeated string roles = 2;
- getRolesList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
-
repeated string roles = 2;
- getRolesList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.JoinOrBuilder
-
repeated string roles = 2;
- getRouteDefinitionHandler() - Method in interface akka.camel.Consumer
-
Java API: Returns the
Mapper
function that will be used as a route definition handler
for creating custom route to this consumer.
- GetRoutees - Class in akka.routing
-
Sending this message to a router will make it send back its currently used routees.
- GetRoutees() - Constructor for class akka.routing.GetRoutees
-
- getRoutees() - Method in class akka.routing.Routees
-
Java API
- getRoutees() - Method in class akka.routing.SeveralRoutees
-
Java API
- GetRoutees$ - Class in akka.routing
-
- GetRoutees$() - Constructor for class akka.routing.GetRoutees$
-
- getRouterConfig() - Method in class akka.remote.WireFormats.DeployData.Builder
-
optional bytes routerConfig = 3;
- getRouterConfig() - Method in class akka.remote.WireFormats.DeployData
-
optional bytes routerConfig = 3;
- getRouterConfig() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
-
optional bytes routerConfig = 3;
- getScope() - Method in class akka.remote.WireFormats.DeployData.Builder
-
optional bytes scope = 4;
- getScope() - Method in class akka.remote.WireFormats.DeployData
-
optional bytes scope = 4;
- getScope() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
-
optional bytes scope = 4;
- getSeen(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated int32 seen = 1;
- getSeen(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
-
repeated int32 seen = 1;
- getSeen(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOverviewOrBuilder
-
repeated int32 seen = 1;
- getSeenBy() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
-
Java API: get current “seen-by” set.
- getSeenCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated int32 seen = 1;
- getSeenCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
-
repeated int32 seen = 1;
- getSeenCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOverviewOrBuilder
-
repeated int32 seen = 1;
- getSeenList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated int32 seen = 1;
- getSeenList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
-
repeated int32 seen = 1;
- getSeenList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOverviewOrBuilder
-
repeated int32 seen = 1;
- getSelf() - Method in class akka.actor.UntypedActor
-
Returns the ActorRef for this actor.
- getSelfRoles() - Method in class akka.cluster.Cluster
-
Java API: roles that this member has
- getSender() - Method in class akka.actor.UnhandledMessage
-
- getSender() - Method in class akka.actor.UntypedActor
-
The reference sender Actor of the currently processed message.
- getSender() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional string sender = 11;
- getSender() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
optional string sender = 11;
- getSender() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
-
optional string sender = 11;
- getSender() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
optional .ActorRefData sender = 4;
- getSender() - Method in class akka.remote.WireFormats.RemoteEnvelope
-
optional .ActorRefData sender = 4;
- getSender() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
-
optional .ActorRefData sender = 4;
- getSenderBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
optional .ActorRefData sender = 4;
- getSenderBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional string sender = 11;
- getSenderBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
optional string sender = 11;
- getSenderBytes() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
-
optional string sender = 11;
- getSenderOrBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
optional .ActorRefData sender = 4;
- getSenderOrBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope
-
optional .ActorRefData sender = 4;
- getSenderOrBuilder() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
-
optional .ActorRefData sender = 4;
- getSeq() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
optional fixed64 seq = 5;
- getSeq() - Method in class akka.remote.WireFormats.RemoteEnvelope
-
optional fixed64 seq = 5;
- getSeq() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
-
optional fixed64 seq = 5;
- getSequenceNr() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional int64 sequenceNr = 2;
- getSequenceNr() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
optional int64 sequenceNr = 2;
- getSequenceNr() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
-
optional int64 sequenceNr = 2;
- getSerialized() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number.Builder
-
optional bytes serialized = 4;
- getSerialized() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number
-
optional bytes serialized = 4;
- getSerialized() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.NumberOrBuilder
-
optional bytes serialized = 4;
- getSerialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
-
optional bytes serialized = 4;
- getSerialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
-
optional bytes serialized = 4;
- getSerialized() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberOrBuilder
-
optional bytes serialized = 4;
- getSerializedGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
required bytes serializedGossip = 3;
- getSerializedGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
-
required bytes serializedGossip = 3;
- getSerializedGossip() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelopeOrBuilder
-
required bytes serializedGossip = 3;
- getSerializedSize() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address
-
- getSerializedSize() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip
-
- getSerializedSize() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope
-
- getSerializedSize() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA
-
- getSerializedSize() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics
-
- getSerializedSize() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric
-
- getSerializedSize() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number
-
- getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
-
- getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
-
- getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
- getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
-
- getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
-
- getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
-
- getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
-
- getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
-
- getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
-
- getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
-
- getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
-
- getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
-
- getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
-
- getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
-
- getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
-
- getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
-
- getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
-
- getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
-
- getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
-
- getSerializedSize() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
-
- getSerializedSize() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address
-
- getSerializedSize() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
-
- getSerializedSize() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry
-
- getSerializedSize() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta
-
- getSerializedSize() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload
-
- getSerializedSize() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish
-
- getSerializedSize() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send
-
- getSerializedSize() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll
-
- getSerializedSize() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status
-
- getSerializedSize() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version
-
- getSerializedSize() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
-
- getSerializedSize() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
-
- getSerializedSize() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
- getSerializedSize() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
-
- getSerializedSize() - Method in class akka.remote.ContainerFormats.Selection
-
- getSerializedSize() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
-
- getSerializedSize() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
-
- getSerializedSize() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
-
- getSerializedSize() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
-
- getSerializedSize() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
-
- getSerializedSize() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
-
- getSerializedSize() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
-
- getSerializedSize() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
-
- getSerializedSize() - Method in class akka.remote.WireFormats.AcknowledgementInfo
-
- getSerializedSize() - Method in class akka.remote.WireFormats.ActorRefData
-
- getSerializedSize() - Method in class akka.remote.WireFormats.AddressData
-
- getSerializedSize() - Method in class akka.remote.WireFormats.AkkaControlMessage
-
- getSerializedSize() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
-
- getSerializedSize() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
-
- getSerializedSize() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
-
- getSerializedSize() - Method in class akka.remote.WireFormats.DeployData
-
- getSerializedSize() - Method in class akka.remote.WireFormats.PropsData
-
- getSerializedSize() - Method in class akka.remote.WireFormats.RemoteEnvelope
-
- getSerializedSize() - Method in class akka.remote.WireFormats.SerializedMessage
-
- getSerializerId() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload.Builder
-
required int32 serializerId = 2;
- getSerializerId() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload
-
required int32 serializerId = 2;
- getSerializerId() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.PayloadOrBuilder
-
required int32 serializerId = 2;
- getSerializerId() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
-
required int32 serializerId = 1;
- getSerializerId() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
-
required int32 serializerId = 1;
- getSerializerId() - Method in interface akka.persistence.serialization.MessageFormats.PersistentPayloadOrBuilder
-
required int32 serializerId = 1;
- getSerializerId() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
required int32 serializerId = 2;
- getSerializerId() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
-
required int32 serializerId = 2;
- getSerializerId() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
-
required int32 serializerId = 2;
- getSerializerId() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
-
required int32 serializerId = 2;
- getSerializerId() - Method in class akka.remote.WireFormats.SerializedMessage
-
required int32 serializerId = 2;
- getSerializerId() - Method in interface akka.remote.WireFormats.SerializedMessageOrBuilder
-
required int32 serializerId = 2;
- getShard(String) - Method in class akka.cluster.sharding.ShardRegion
-
- GetShardHome(String) - Constructor for class akka.cluster.sharding.ShardCoordinator.Internal$.GetShardHome
-
- getShardHomeSender() - Method in class akka.cluster.sharding.ShardCoordinator.Internal$.AllocateShardResult
-
- getShort(ByteOrder) - Method in class akka.util.ByteIterator
-
Get a single Short from this iterator.
- getShorts(short[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- getShorts(short[], ByteOrder) - Method in class akka.util.ByteIterator
-
Get a number of Shorts from this iterator.
- getShorts(short[], int, int, ByteOrder) - Method in class akka.util.ByteIterator
-
Get a number of Shorts from this iterator.
- getShorts(short[], int, int, ByteOrder) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- getShutdownTimeout() - Method in class akka.actor.LightArrayRevolverScheduler
-
Overridable for tests
- getSingleChild(String) - Method in class akka.actor.ActorRefWithCell
-
- getSingleChild(String) - Method in interface akka.actor.Cell
-
Method for looking up a single child beneath this actor.
- getSingleChild(String) - Method in interface akka.actor.dungeon.Children
-
- getSingleChild(String) - Method in class akka.actor.LocalActorRef
-
Method for looking up a single child beneath this actor.
- getSingleChild(String) - Method in class akka.actor.RepointableActorRef
-
Method for looking up a single child beneath this actor.
- getSingleChild(String) - Method in class akka.actor.UnstartedCell
-
- GetSockAddr$() - Constructor for class akka.remote.testconductor.Controller.GetSockAddr$
-
- getStatus() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
required .MemberStatus status = 3;
- getStatus() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
-
required .MemberStatus status = 3;
- getStatus() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MemberOrBuilder
-
required .MemberStatus status = 3;
- getStatus() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
-
required .ReachabilityStatus status = 3;
- getStatus() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
-
required .ReachabilityStatus status = 3;
- getStatus() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.SubjectReachabilityOrBuilder
-
required .ReachabilityStatus status = 3;
- getString(String) - Method in class akka.dispatch.CachingConfig
-
- getStringList(String) - Method in class akka.dispatch.CachingConfig
-
- getSubjectReachability(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
repeated .SubjectReachability subjectReachability = 2;
- getSubjectReachability(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
-
repeated .SubjectReachability subjectReachability = 2;
- getSubjectReachability(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.ObserverReachabilityOrBuilder
-
repeated .SubjectReachability subjectReachability = 2;
- getSubjectReachabilityBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
repeated .SubjectReachability subjectReachability = 2;
- getSubjectReachabilityBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
repeated .SubjectReachability subjectReachability = 2;
- getSubjectReachabilityCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
repeated .SubjectReachability subjectReachability = 2;
- getSubjectReachabilityCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
-
repeated .SubjectReachability subjectReachability = 2;
- getSubjectReachabilityCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.ObserverReachabilityOrBuilder
-
repeated .SubjectReachability subjectReachability = 2;
- getSubjectReachabilityList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
repeated .SubjectReachability subjectReachability = 2;
- getSubjectReachabilityList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
-
repeated .SubjectReachability subjectReachability = 2;
- getSubjectReachabilityList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.ObserverReachabilityOrBuilder
-
repeated .SubjectReachability subjectReachability = 2;
- getSubjectReachabilityOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
repeated .SubjectReachability subjectReachability = 2;
- getSubjectReachabilityOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
-
repeated .SubjectReachability subjectReachability = 2;
- getSubjectReachabilityOrBuilder(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.ObserverReachabilityOrBuilder
-
repeated .SubjectReachability subjectReachability = 2;
- getSubjectReachabilityOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
repeated .SubjectReachability subjectReachability = 2;
- getSubjectReachabilityOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
-
repeated .SubjectReachability subjectReachability = 2;
- getSubjectReachabilityOrBuilderList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.ObserverReachabilityOrBuilder
-
repeated .SubjectReachability subjectReachability = 2;
- getSupervisor() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required .ActorRefData supervisor = 4;
- getSupervisor() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
-
required .ActorRefData supervisor = 4;
- getSupervisor() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
-
required .ActorRefData supervisor = 4;
- getSupervisorBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required .ActorRefData supervisor = 4;
- getSupervisorOrBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required .ActorRefData supervisor = 4;
- getSupervisorOrBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
-
required .ActorRefData supervisor = 4;
- getSupervisorOrBuilder() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
-
required .ActorRefData supervisor = 4;
- getSystem() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
required string system = 1;
- getSystem() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address
-
required string system = 1;
- getSystem() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.AddressOrBuilder
-
required string system = 1;
- getSystem() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
required string system = 1;
- getSystem() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
-
required string system = 1;
- getSystem() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.AddressOrBuilder
-
required string system = 1;
- getSystem() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
required string system = 1;
- getSystem() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address
-
required string system = 1;
- getSystem() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.AddressOrBuilder
-
required string system = 1;
- getSystem() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
required string system = 2;
- getSystem() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
-
required string system = 2;
- getSystem() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
-
required string system = 2;
- getSystem() - Method in class akka.remote.WireFormats.AddressData.Builder
-
required string system = 1;
- getSystem() - Method in class akka.remote.WireFormats.AddressData
-
required string system = 1;
- getSystem() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
-
required string system = 1;
- getSystem() - Method in class akka.testkit.JavaTestKit
-
- getSystemBytes() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
required string system = 1;
- getSystemBytes() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address
-
required string system = 1;
- getSystemBytes() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.AddressOrBuilder
-
required string system = 1;
- getSystemBytes() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
required string system = 1;
- getSystemBytes() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
-
required string system = 1;
- getSystemBytes() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.AddressOrBuilder
-
required string system = 1;
- getSystemBytes() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
required string system = 1;
- getSystemBytes() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address
-
required string system = 1;
- getSystemBytes() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.AddressOrBuilder
-
required string system = 1;
- getSystemBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
required string system = 2;
- getSystemBytes() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
-
required string system = 2;
- getSystemBytes() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
-
required string system = 2;
- getSystemBytes() - Method in class akka.remote.WireFormats.AddressData.Builder
-
required string system = 1;
- getSystemBytes() - Method in class akka.remote.WireFormats.AddressData
-
required string system = 1;
- getSystemBytes() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
-
required string system = 1;
- getTestActor() - Method in class akka.testkit.JavaTestKit
-
ActorRef of the test actor.
- getTimeout() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
-
optional int64 timeout = 3;
- getTimeout() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
-
optional int64 timeout = 3;
- getTimeout() - Method in interface akka.remote.testconductor.TestConductorProtocol.EnterBarrierOrBuilder
-
optional int64 timeout = 3;
- getTimestamp() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
required int64 timestamp = 2;
- getTimestamp() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics
-
required int64 timestamp = 2;
- getTimestamp() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetricsOrBuilder
-
required int64 timestamp = 2;
- getTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
required int64 timestamp = 2;
- getTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
-
required int64 timestamp = 2;
- getTimestamp() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetricsOrBuilder
-
required int64 timestamp = 2;
- getTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
optional int64 timestamp = 1;
- getTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
-
optional int64 timestamp = 1;
- getTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
-
required int64 timestamp = 2;
- getTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
-
required int64 timestamp = 2;
- getTimestamp() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.VectorClock.VersionOrBuilder
-
required int64 timestamp = 2;
- getTimestamp() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.VectorClockOrBuilder
-
optional int64 timestamp = 1;
- getTimestamp() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
-
required int64 timestamp = 2;
- getTimestamp() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version
-
required int64 timestamp = 2;
- getTimestamp() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.VersionOrBuilder
-
required int64 timestamp = 2;
- getTo() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
required .UniqueAddress to = 2;
- getTo() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
-
required .UniqueAddress to = 2;
- getTo() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelopeOrBuilder
-
required .UniqueAddress to = 2;
- getToArray(Object, int, int, int, Function0<A>, Function3<Object, Object, Object, BoxedUnit>) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- getToBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
required .UniqueAddress to = 2;
- getToOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
required .UniqueAddress to = 2;
- getToOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
-
required .UniqueAddress to = 2;
- getToOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelopeOrBuilder
-
required .UniqueAddress to = 2;
- getTopic() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish.Builder
-
required string topic = 1;
- getTopic() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish
-
required string topic = 1;
- getTopic() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.PublishOrBuilder
-
required string topic = 1;
- getTopicBytes() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish.Builder
-
required string topic = 1;
- getTopicBytes() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish
-
required string topic = 1;
- getTopicBytes() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.PublishOrBuilder
-
required string topic = 1;
- getTopics() - Method in class akka.cluster.pubsub.DistributedPubSubMediator.CurrentTopics
-
Java API
- GetTopics() - Constructor for class akka.cluster.pubsub.DistributedPubSubMediator.GetTopics
-
- GetTopics$() - Constructor for class akka.cluster.pubsub.DistributedPubSubMediator.GetTopics$
-
- getTopicsInstance() - Method in class akka.cluster.pubsub.DistributedPubSubMediator$
-
Java API
- getTopicsInstance() - Static method in class akka.cluster.pubsub.DistributedPubSubMediator
-
Java API
- getType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number.Builder
-
required .NodeMetrics.NumberType type = 1;
- getType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number
-
required .NodeMetrics.NumberType type = 1;
- getType() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.NumberOrBuilder
-
required .NodeMetrics.NumberType type = 1;
- getType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
-
required .NodeMetrics.NumberType type = 1;
- getType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
-
required .NodeMetrics.NumberType type = 1;
- getType() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberOrBuilder
-
required .NodeMetrics.NumberType type = 1;
- getType() - Method in class akka.remote.ContainerFormats.Selection.Builder
-
required .PatternType type = 1;
- getType() - Method in class akka.remote.ContainerFormats.Selection
-
required .PatternType type = 1;
- getType() - Method in interface akka.remote.ContainerFormats.SelectionOrBuilder
-
required .PatternType type = 1;
- getUid() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
-
required uint32 uid = 2;
- getUid() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
-
required uint32 uid = 2;
- getUid() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.UniqueAddressOrBuilder
-
required uint32 uid = 2;
- getUid() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
required fixed64 uid = 2;
- getUid() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
-
required fixed64 uid = 2;
- getUid() - Method in interface akka.remote.WireFormats.AkkaHandshakeInfoOrBuilder
-
required fixed64 uid = 2;
- getUnconfirmedDeliveries() - Method in class akka.persistence.AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot
-
Java API
- getUnconfirmedDeliveries() - Method in class akka.persistence.AtLeastOnceDelivery.UnconfirmedWarning
-
Java API
- getUnconfirmedDeliveries(int) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- getUnconfirmedDeliveries(int) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- getUnconfirmedDeliveries(int) - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshotOrBuilder
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- getUnconfirmedDeliveriesBuilder(int) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- getUnconfirmedDeliveriesBuilderList() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- getUnconfirmedDeliveriesCount() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- getUnconfirmedDeliveriesCount() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- getUnconfirmedDeliveriesCount() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshotOrBuilder
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- getUnconfirmedDeliveriesList() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- getUnconfirmedDeliveriesList() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- getUnconfirmedDeliveriesList() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshotOrBuilder
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- getUnconfirmedDeliveriesOrBuilder(int) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- getUnconfirmedDeliveriesOrBuilder(int) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- getUnconfirmedDeliveriesOrBuilder(int) - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshotOrBuilder
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- getUnconfirmedDeliveriesOrBuilderList() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- getUnconfirmedDeliveriesOrBuilderList() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- getUnconfirmedDeliveriesOrBuilderList() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshotOrBuilder
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- getUnknownFields() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address
-
- getUnknownFields() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip
-
- getUnknownFields() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope
-
- getUnknownFields() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA
-
- getUnknownFields() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics
-
- getUnknownFields() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric
-
- getUnknownFields() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number
-
- getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
-
- getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty
-
- getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
- getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
-
- getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
-
- getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
-
- getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
-
- getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
-
- getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip
-
- getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
-
- getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
-
- getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
-
- getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
-
- getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
-
- getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
-
- getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
-
- getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
-
- getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
-
- getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
-
- getUnknownFields() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
-
- getUnknownFields() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address
-
- getUnknownFields() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
-
- getUnknownFields() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry
-
- getUnknownFields() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta
-
- getUnknownFields() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload
-
- getUnknownFields() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish
-
- getUnknownFields() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send
-
- getUnknownFields() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll
-
- getUnknownFields() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status
-
- getUnknownFields() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version
-
- getUnknownFields() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
-
- getUnknownFields() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
-
- getUnknownFields() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
- getUnknownFields() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
-
- getUnknownFields() - Method in class akka.remote.ContainerFormats.Selection
-
- getUnknownFields() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
-
- getUnknownFields() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
-
- getUnknownFields() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
-
- getUnknownFields() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
-
- getUnknownFields() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
-
- getUnknownFields() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
-
- getUnknownFields() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
-
- getUnknownFields() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
-
- getUnknownFields() - Method in class akka.remote.WireFormats.AcknowledgementInfo
-
- getUnknownFields() - Method in class akka.remote.WireFormats.ActorRefData
-
- getUnknownFields() - Method in class akka.remote.WireFormats.AddressData
-
- getUnknownFields() - Method in class akka.remote.WireFormats.AkkaControlMessage
-
- getUnknownFields() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
-
- getUnknownFields() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
-
- getUnknownFields() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
-
- getUnknownFields() - Method in class akka.remote.WireFormats.DeployData
-
- getUnknownFields() - Method in class akka.remote.WireFormats.PropsData
-
- getUnknownFields() - Method in class akka.remote.WireFormats.RemoteEnvelope
-
- getUnknownFields() - Method in class akka.remote.WireFormats.SerializedMessage
-
- getUnreachable() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
-
Java API: get current unreachable set.
- getUnreachable() - Method in interface akka.cluster.ClusterNodeMBean
-
Comma separated addresses of unreachable member nodes.
- getUpNumber() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
required int32 upNumber = 2;
- getUpNumber() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
-
required int32 upNumber = 2;
- getUpNumber() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MemberOrBuilder
-
required int32 upNumber = 2;
- getValue() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA.Builder
-
required double value = 1;
- getValue() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA
-
required double value = 1;
- getValue() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMAOrBuilder
-
required double value = 1;
- getValue() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
-
required double value = 1;
- getValue() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
-
required double value = 1;
- getValue() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMAOrBuilder
-
required double value = 1;
- getValue(String) - Method in class akka.dispatch.CachingConfig
-
- getValue32() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number.Builder
-
optional uint32 value32 = 2;
- getValue32() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number
-
optional uint32 value32 = 2;
- getValue32() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.NumberOrBuilder
-
optional uint32 value32 = 2;
- getValue32() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
-
optional uint32 value32 = 2;
- getValue32() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
-
optional uint32 value32 = 2;
- getValue32() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberOrBuilder
-
optional uint32 value32 = 2;
- getValue64() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number.Builder
-
optional uint64 value64 = 3;
- getValue64() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number
-
optional uint64 value64 = 3;
- getValue64() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.NumberOrBuilder
-
optional uint64 value64 = 3;
- getValue64() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
-
optional uint64 value64 = 3;
- getValue64() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
-
optional uint64 value64 = 3;
- getValue64() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberOrBuilder
-
optional uint64 value64 = 3;
- getValueDescriptor() - Method in enum akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.NumberType
-
- getValueDescriptor() - Method in enum akka.cluster.protobuf.msg.ClusterMessages.MemberStatus
-
- getValueDescriptor() - Method in enum akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberType
-
- getValueDescriptor() - Method in enum akka.cluster.protobuf.msg.ClusterMessages.ReachabilityStatus
-
- getValueDescriptor() - Method in enum akka.remote.ContainerFormats.PatternType
-
- getValueDescriptor() - Method in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
-
- getValueDescriptor() - Method in enum akka.remote.testconductor.TestConductorProtocol.Direction
-
- getValueDescriptor() - Method in enum akka.remote.testconductor.TestConductorProtocol.FailType
-
- getValueDescriptor() - Method in enum akka.remote.WireFormats.CommandType
-
- getVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
required .VectorClock version = 6;
- getVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
required .VectorClock version = 6;
- getVersion() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
-
required .VectorClock version = 6;
- getVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
required .VectorClock version = 3;
- getVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
-
required .VectorClock version = 3;
- getVersion() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipStatusOrBuilder
-
required .VectorClock version = 3;
- getVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
required int64 version = 4;
- getVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
-
required int64 version = 4;
- getVersion() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.ObserverReachabilityOrBuilder
-
required int64 version = 4;
- getVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
-
required int64 version = 4;
- getVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
-
required int64 version = 4;
- getVersion() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.SubjectReachabilityOrBuilder
-
required int64 version = 4;
- getVersion() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
required int64 version = 2;
- getVersion() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
-
required int64 version = 2;
- getVersion() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.BucketOrBuilder
-
required int64 version = 2;
- getVersion() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
required int64 version = 2;
- getVersion() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry
-
required int64 version = 2;
- getVersion() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.EntryOrBuilder
-
required int64 version = 2;
- getVersionBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
required .VectorClock version = 6;
- getVersionBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
required .VectorClock version = 3;
- getVersionOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
required .VectorClock version = 6;
- getVersionOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
required .VectorClock version = 6;
- getVersionOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
-
required .VectorClock version = 6;
- getVersionOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
required .VectorClock version = 3;
- getVersionOrBuilder() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
-
required .VectorClock version = 3;
- getVersionOrBuilder() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipStatusOrBuilder
-
required .VectorClock version = 3;
- getVersions(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
repeated .VectorClock.Version versions = 2;
- getVersions(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
-
repeated .VectorClock.Version versions = 2;
- getVersions(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.VectorClockOrBuilder
-
repeated .VectorClock.Version versions = 2;
- getVersions(int) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
repeated .Status.Version versions = 1;
- getVersions(int) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status
-
repeated .Status.Version versions = 1;
- getVersions(int) - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.StatusOrBuilder
-
repeated .Status.Version versions = 1;
- getVersionsBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
repeated .VectorClock.Version versions = 2;
- getVersionsBuilder(int) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
repeated .Status.Version versions = 1;
- getVersionsBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
repeated .VectorClock.Version versions = 2;
- getVersionsBuilderList() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
repeated .Status.Version versions = 1;
- getVersionsCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
repeated .VectorClock.Version versions = 2;
- getVersionsCount() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
-
repeated .VectorClock.Version versions = 2;
- getVersionsCount() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.VectorClockOrBuilder
-
repeated .VectorClock.Version versions = 2;
- getVersionsCount() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
repeated .Status.Version versions = 1;
- getVersionsCount() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status
-
repeated .Status.Version versions = 1;
- getVersionsCount() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.StatusOrBuilder
-
repeated .Status.Version versions = 1;
- getVersionsList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
repeated .VectorClock.Version versions = 2;
- getVersionsList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
-
repeated .VectorClock.Version versions = 2;
- getVersionsList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.VectorClockOrBuilder
-
repeated .VectorClock.Version versions = 2;
- getVersionsList() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
repeated .Status.Version versions = 1;
- getVersionsList() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status
-
repeated .Status.Version versions = 1;
- getVersionsList() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.StatusOrBuilder
-
repeated .Status.Version versions = 1;
- getVersionsOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
repeated .VectorClock.Version versions = 2;
- getVersionsOrBuilder(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
-
repeated .VectorClock.Version versions = 2;
- getVersionsOrBuilder(int) - Method in interface akka.cluster.protobuf.msg.ClusterMessages.VectorClockOrBuilder
-
repeated .VectorClock.Version versions = 2;
- getVersionsOrBuilder(int) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
repeated .Status.Version versions = 1;
- getVersionsOrBuilder(int) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status
-
repeated .Status.Version versions = 1;
- getVersionsOrBuilder(int) - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.StatusOrBuilder
-
repeated .Status.Version versions = 1;
- getVersionsOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
repeated .VectorClock.Version versions = 2;
- getVersionsOrBuilderList() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
-
repeated .VectorClock.Version versions = 2;
- getVersionsOrBuilderList() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.VectorClockOrBuilder
-
repeated .VectorClock.Version versions = 2;
- getVersionsOrBuilderList() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
repeated .Status.Version versions = 1;
- getVersionsOrBuilderList() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status
-
repeated .Status.Version versions = 1;
- getVersionsOrBuilderList() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.StatusOrBuilder
-
repeated .Status.Version versions = 1;
- getWildcardFanOut() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
optional bool wildcardFanOut = 5;
- getWildcardFanOut() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
-
optional bool wildcardFanOut = 5;
- getWildcardFanOut() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
-
optional bool wildcardFanOut = 5;
- global() - Method in class akka.dispatch.ExecutionContexts$
-
- global() - Static method in class akka.dispatch.ExecutionContexts
-
- GlobalHome() - Method in class akka.actor.ActorSystem$
-
- GlobalHome() - Static method in class akka.actor.ActorSystem
-
- gossip() - Method in class akka.cluster.ClusterCoreDaemon
-
Initiates a new round of gossip.
- gossip() - Method in class akka.cluster.ClusterMetricsCollector
-
Gossip to peer nodes.
- Gossip - Class in akka.cluster
-
- Gossip(SortedSet<Member>, GossipOverview, VectorClock) - Constructor for class akka.cluster.Gossip
-
- gossip() - Method in class akka.cluster.GossipEnvelope
-
- gossip() - Method in class akka.cluster.InternalClusterAction.Welcome
-
- gossip() - Method in class akka.cluster.metrics.ClusterMetricsCollector
-
Gossip to peer nodes.
- gossip() - Method in class akka.cluster.metrics.MetricsGossipEnvelope
-
- gossip() - Method in class akka.cluster.MetricsGossipEnvelope
-
- gossip() - Method in class akka.cluster.pubsub.DistributedPubSubMediator
-
Gossip to peer nodes.
- gossip(Object, ActorRef) - Method in interface akka.routing.Listeners
-
Sends the supplied message to all current listeners using the provided sender() as sender.
- Gossip$ - Class in akka.cluster
-
INTERNAL API
- Gossip$() - Constructor for class akka.cluster.Gossip$
-
- GOSSIP_FIELD_NUMBER - Static variable in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope
-
- GOSSIP_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
-
- GOSSIP_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
-
- GossipDifferentViewProbability() - Method in class akka.cluster.ClusterSettings
-
- GossipEnvelope - Class in akka.cluster
-
INTERNAL API
Envelope adding a sender and receiver address to the gossip.
- GossipEnvelope$ - Class in akka.cluster
-
- GossipEnvelope$() - Constructor for class akka.cluster.GossipEnvelope$
-
- GossipInterval() - Method in class akka.cluster.ClusterSettings
-
- gossipInterval() - Method in class akka.cluster.pubsub.DistributedPubSubSettings
-
- GossipOverview - Class in akka.cluster
-
INTERNAL API
Represents the overview of the cluster, holds the cluster convergence table and set with unreachable nodes.
- GossipOverview(Set<UniqueAddress>, Reachability) - Constructor for class akka.cluster.GossipOverview
-
- GossipOverview$ - Class in akka.cluster
-
- GossipOverview$() - Constructor for class akka.cluster.GossipOverview$
-
- gossipSpeedupTick() - Method in class akka.cluster.ClusterCoreDaemon
-
- GossipSpeedupTick$() - Constructor for class akka.cluster.InternalClusterAction.GossipSpeedupTick$
-
- gossipStats() - Method in class akka.cluster.ClusterCoreDaemon
-
- gossipStats() - Method in class akka.cluster.ClusterEvent.CurrentInternalStats
-
- GossipStats - Class in akka.cluster
-
INTERNAL API
- GossipStats(long, long, long, long, long) - Constructor for class akka.cluster.GossipStats
-
- GossipStats$ - Class in akka.cluster
-
- GossipStats$() - Constructor for class akka.cluster.GossipStats$
-
- GossipStatus - Class in akka.cluster
-
INTERNAL API
When there are no known changes to the node ring a GossipStatus
initiates a gossip chat between two members.
- GossipStatus(UniqueAddress, VectorClock) - Constructor for class akka.cluster.GossipStatus
-
- GossipStatus$ - Class in akka.cluster
-
- GossipStatus$() - Constructor for class akka.cluster.GossipStatus$
-
- gossipStatusTo(UniqueAddress, ActorRef) - Method in class akka.cluster.ClusterCoreDaemon
-
- gossipStatusTo(UniqueAddress) - Method in class akka.cluster.ClusterCoreDaemon
-
- gossipTask() - Method in class akka.cluster.ClusterCoreDaemon
-
- gossipTask() - Method in class akka.cluster.ClusterMetricsCollector
-
Start periodic gossip to random nodes in cluster
- gossipTask() - Method in class akka.cluster.metrics.ClusterMetricsCollector
-
Start periodic gossip to random nodes in cluster
- gossipTask() - Method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- gossipTick() - Method in class akka.cluster.ClusterCoreDaemon
-
- GossipTick() - Constructor for class akka.cluster.pubsub.DistributedPubSubMediator.Internal$.GossipTick
-
- GossipTick$() - Constructor for class akka.cluster.InternalClusterAction.GossipTick$
-
- GossipTimeToLive() - Method in class akka.cluster.ClusterSettings
-
- gossipTo(UniqueAddress) - Method in class akka.cluster.ClusterCoreDaemon
-
Gossips latest gossip to a node.
- gossipTo(UniqueAddress, ActorRef) - Method in class akka.cluster.ClusterCoreDaemon
-
- gossipTo(Address) - Method in class akka.cluster.ClusterMetricsCollector
-
- gossipTo(Address) - Method in class akka.cluster.metrics.ClusterMetricsCollector
-
- gossipTo(Address) - Method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- goTo(S) - Method in class akka.actor.AbstractFSM
-
Produce transition to other state.
- gotoHandingOver(ActorRef, boolean, Option<ActorRef>) - Method in class akka.cluster.singleton.ClusterSingletonManager
-
- gotoOldest() - Method in class akka.cluster.singleton.ClusterSingletonManager
-
- GotUid(int, Address) - Constructor for class akka.remote.ReliableDeliverySupervisor.GotUid
-
- GotUid$() - Constructor for class akka.remote.ReliableDeliverySupervisor.GotUid$
-
- gracefulClose(Channel, ExecutionContext) - Method in class akka.remote.transport.netty.NettyTransport$
-
- gracefulClose(Channel, ExecutionContext) - Static method in class akka.remote.transport.netty.NettyTransport
-
- gracefulStop(ActorRef, FiniteDuration, Object) - Method in interface akka.pattern.GracefulStopSupport
-
Returns a Future
that will be completed with success (value true
) when
existing messages of the target actor has been processed and the actor has been
terminated.
- gracefulStop(ActorRef, FiniteDuration) - Method in class akka.pattern.Patterns$
-
Returns a Future
that will be completed with success (value true
) when
existing messages of the target actor has been processed and the actor has been
terminated.
- gracefulStop(ActorRef, FiniteDuration, Object) - Method in class akka.pattern.Patterns$
-
Returns a Future
that will be completed with success (value true
) when
existing messages of the target actor has been processed and the actor has been
terminated.
- gracefulStop(ActorRef, FiniteDuration) - Static method in class akka.pattern.Patterns
-
Returns a Future
that will be completed with success (value true
) when
existing messages of the target actor has been processed and the actor has been
terminated.
- gracefulStop(ActorRef, FiniteDuration, Object) - Static method in class akka.pattern.Patterns
-
Returns a Future
that will be completed with success (value true
) when
existing messages of the target actor has been processed and the actor has been
terminated.
- GracefulStopSupport - Interface in akka.pattern
-
- Group(FiniteDuration, RoutingLogic) - Constructor for class akka.cluster.pubsub.DistributedPubSubMediator.Internal$.Group
-
- group() - Method in class akka.cluster.pubsub.DistributedPubSubMediator.Subscribe
-
- group() - Method in class akka.cluster.pubsub.DistributedPubSubMediator.Unsubscribe
-
- group() - Method in class akka.cluster.routing.ClusterRouterGroupActor
-
- Group - Interface in akka.routing
-
RouterConfig
for router actor with routee actors that are created external to the
router and the router sends messages to the specified path using actor selection,
without watching for termination.
- GroupBase - Class in akka.routing
-
Java API: Base class for custom router
Group
- GroupBase() - Constructor for class akka.routing.GroupBase
-
- guard() - Method in interface akka.event.LoggingBus
-
- guardian() - Method in class akka.actor.ActorCell
-
- guardian() - Method in interface akka.actor.ActorRefFactory
-
Father of all children created by this interface.
- guardian() - Method in interface akka.actor.ActorRefProvider
-
Reference to the supervisor used for all top-level user actors.
- guardian() - Method in class akka.actor.ActorSystemImpl
-
- guardian() - Method in class akka.actor.ExtendedActorSystem
-
The top-level supervisor of all actors created using system.actorOf(...).
- guardian() - Method in class akka.actor.LocalActorRefProvider
-
- guardian() - Method in class akka.remote.RemoteActorRefProvider
-
- GuardianName() - Method in class akka.cluster.sharding.ClusterSharding.Settings$
-
- guardianProps() - Method in class akka.actor.ActorSystemImpl
-
- guardianStrategy() - Method in class akka.actor.LocalActorRefProvider
-
Overridable supervision strategy to be used by the “/user” guardian.
- handingOff() - Method in class akka.cluster.sharding.ShardRegion
-
- handle() - Method in class akka.remote.EndpointWriter
-
- Handle(AkkaProtocolHandle) - Constructor for class akka.remote.EndpointWriter.Handle
-
- handle() - Method in class akka.remote.EndpointWriter.Handle
-
- handle() - Method in class akka.remote.EndpointWriter.TakeOver
-
- handle() - Method in class akka.remote.EndpointWriter.TookOver
-
- Handle(AssociationHandle) - Constructor for class akka.remote.transport.ProtocolStateActor.Handle
-
- handle() - Method in class akka.remote.transport.ProtocolStateActor.Handle
-
- handle() - Method in class akka.remote.transport.ThrottledAssociation.ExposedHandle
-
- handle() - Method in class akka.remote.transport.ThrottlerManager.AssociateResult
-
- handle() - Method in class akka.remote.transport.ThrottlerManager.Checkin
-
- Handle(ThrottlerHandle) - Constructor for class akka.remote.transport.ThrottlerManager.Handle
-
- handle() - Method in class akka.remote.transport.ThrottlerManager.Handle
-
- Handle$() - Constructor for class akka.remote.EndpointWriter.Handle$
-
- Handle$() - Constructor for class akka.remote.transport.ProtocolStateActor.Handle$
-
- Handle$() - Constructor for class akka.remote.transport.ThrottlerManager.Handle$
-
- handleBarrier(BarrierCoordinator.Data) - Method in class akka.remote.testconductor.BarrierCoordinator
-
- handleChildTerminated(ActorContext, ActorRef, Iterable<ActorRef>) - Method in class akka.actor.AllForOneStrategy
-
- handleChildTerminated(ActorRef) - Method in interface akka.actor.dungeon.FaultHandling
-
- handleChildTerminated(ActorContext, ActorRef, Iterable<ActorRef>) - Method in class akka.actor.OneForOneStrategy
-
- handleChildTerminated(ActorContext, ActorRef, Iterable<ActorRef>) - Method in class akka.actor.SupervisorStrategy
-
This method is called after the child has been removed from the set of children.
- handleClose(TcpConnection.ConnectionInfo, Option<ActorRef>, Tcp.ConnectionClosed) - Method in class akka.io.TcpConnection
-
- handleError(ActorRef, IOException) - Method in class akka.io.TcpConnection
-
- handleEvent() - Method in interface akka.actor.FSM
-
- handleEventDefault() - Method in interface akka.actor.FSM
-
- handleException() - Method in interface akka.actor.dungeon.Dispatch
-
- handleFailure(Failed) - Method in interface akka.actor.dungeon.FaultHandling
-
- handleFailure(ActorContext, ActorRef, Throwable, ChildRestartStats, Iterable<ChildRestartStats>) - Method in class akka.actor.SupervisorStrategy
-
This is the main entry point: in case of a child’s failure, this method
must try to handle the failure by resuming, restarting or stopping the
child (and returning true
), or it returns false
to escalate the
failure, which will lead to this actor re-throwing the exception which
caused the failure.
- handleInboundAssociation(Transport.InboundAssociation, boolean) - Method in class akka.remote.EndpointManager
-
- handleInitial(ClusterEvent.CurrentClusterState) - Method in class akka.cluster.singleton.ClusterSingletonProxy
-
- handleInvokeFailure(Iterable<ActorRef>, Throwable) - Method in interface akka.actor.dungeon.FaultHandling
-
- handleListener() - Method in class akka.remote.transport.ProtocolStateActor.AssociatedWaitHandler
-
- HandleListenerRegistered(AssociationHandle.HandleEventListener) - Constructor for class akka.remote.transport.ProtocolStateActor.HandleListenerRegistered
-
- HandleListenerRegistered$() - Constructor for class akka.remote.transport.ProtocolStateActor.HandleListenerRegistered$
-
- handleMessage(Object) - Method in interface akka.contrib.pattern.Aggregator
-
Handles messages and matches against the expect list.
- handleNonFatalOrInterruptedException(Function1<Throwable, BoxedUnit>) - Method in interface akka.actor.dungeon.FaultHandling
-
- handler() - Method in class akka.io.Tcp.Bind
-
- handler() - Method in class akka.io.Tcp.Register
-
- handler() - Method in class akka.io.TcpConnection.ConnectionInfo
-
- handler() - Method in class akka.io.Udp.Bind
-
- handler() - Method in class akka.io.UdpConnected.Connect
-
- handler() - Method in class akka.persistence.Eventsourced.AsyncHandlerInvocation
-
- handler() - Method in interface akka.persistence.Eventsourced.PendingHandlerInvocation
-
- handler() - Method in class akka.persistence.Eventsourced.StashingHandlerInvocation
-
- handler() - Method in class akka.remote.testconductor.ClientFSM
-
- handleStashedInbound(ActorRef, boolean) - Method in class akka.remote.EndpointManager
-
- handleSupervise(ActorRef, boolean) - Method in class akka.actor.ActorCell
-
- handleTransition(S, S) - Method in interface akka.actor.FSM
-
- handleWriteMessages(TcpConnection.ConnectionInfo) - Method in class akka.io.TcpConnection
-
- handOff(ActorRef) - Method in class akka.cluster.sharding.Shard
-
- HandOff(String) - Constructor for class akka.cluster.sharding.ShardCoordinator.Internal$.HandOff
-
- handoff() - Method in class akka.remote.EndpointWriter
-
- handOffStopper() - Method in class akka.cluster.sharding.Shard
-
- HandOffStopper(String, ActorRef, Set<ActorRef>) - Constructor for class akka.cluster.sharding.ShardRegion.HandOffStopper
-
- handOffStopperProps(String, ActorRef, Set<ActorRef>) - Method in class akka.cluster.sharding.ShardRegion$
-
- handOffStopperProps(String, ActorRef, Set<ActorRef>) - Static method in class akka.cluster.sharding.ShardRegion
-
- HandOffTimeout() - Method in class akka.cluster.sharding.ClusterSharding.Settings$
-
- handOverDone(Option<ActorRef>) - Method in class akka.cluster.singleton.ClusterSingletonManager
-
- handshakeInfo() - Method in class akka.remote.transport.AkkaProtocolHandle
-
- HandshakeInfo - Class in akka.remote.transport
-
- HandshakeInfo(Address, int, Option<String>) - Constructor for class akka.remote.transport.HandshakeInfo
-
- HandshakeInfo$ - Class in akka.remote.transport
-
- HandshakeInfo$() - Constructor for class akka.remote.transport.HandshakeInfo$
-
- HANDSHAKEINFO_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AkkaControlMessage
-
- hasAck() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
optional .AcknowledgementInfo ack = 1;
- hasAck() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
-
optional .AcknowledgementInfo ack = 1;
- hasAck() - Method in interface akka.remote.WireFormats.AckAndEnvelopeContainerOrBuilder
-
optional .AcknowledgementInfo ack = 1;
- hasAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
-
optional .Address addr = 2;
- hasAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
-
optional .Address addr = 2;
- hasAddr() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressRequestOrBuilder
-
optional .Address addr = 2;
- hasAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .AddressRequest addr = 5;
- hasAddr() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
-
optional .AddressRequest addr = 5;
- hasAddr() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
-
optional .AddressRequest addr = 5;
- hasAddress() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
-
required .Address address = 1;
- hasAddress() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
-
required .Address address = 1;
- hasAddress() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.UniqueAddressOrBuilder
-
required .Address address = 1;
- hasAddress() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
-
required .Address address = 1;
- hasAddress() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version
-
required .Address address = 1;
- hasAddress() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.VersionOrBuilder
-
required .Address address = 1;
- hasAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
-
required .Address address = 2;
- hasAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
-
required .Address address = 2;
- hasAddress() - Method in interface akka.remote.testconductor.TestConductorProtocol.HelloOrBuilder
-
required .Address address = 2;
- hasAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
optional .Address address = 3;
- hasAddress() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
-
optional .Address address = 3;
- hasAddress() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
-
optional .Address address = 3;
- hasAddressIndex() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
required int32 addressIndex = 1;
- hasAddressIndex() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics
-
required int32 addressIndex = 1;
- hasAddressIndex() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetricsOrBuilder
-
required int32 addressIndex = 1;
- hasAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
required int32 addressIndex = 1;
- hasAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
-
required int32 addressIndex = 1;
- hasAddressIndex() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MemberOrBuilder
-
required int32 addressIndex = 1;
- hasAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
required int32 addressIndex = 1;
- hasAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
-
required int32 addressIndex = 1;
- hasAddressIndex() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetricsOrBuilder
-
required int32 addressIndex = 1;
- hasAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
required int32 addressIndex = 1;
- hasAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
-
required int32 addressIndex = 1;
- hasAddressIndex() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.ObserverReachabilityOrBuilder
-
required int32 addressIndex = 1;
- hasAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
-
required int32 addressIndex = 1;
- hasAddressIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
-
required int32 addressIndex = 1;
- hasAddressIndex() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.SubjectReachabilityOrBuilder
-
required int32 addressIndex = 1;
- hasAllButSelf() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
-
required bool allButSelf = 2;
- hasAllButSelf() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll
-
required bool allButSelf = 2;
- hasAllButSelf() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAllOrBuilder
-
required bool allButSelf = 2;
- hasAlpha() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA.Builder
-
required double alpha = 2;
- hasAlpha() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA
-
required double alpha = 2;
- hasAlpha() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMAOrBuilder
-
required double alpha = 2;
- hasAlpha() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
-
required double alpha = 2;
- hasAlpha() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
-
required double alpha = 2;
- hasAlpha() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMAOrBuilder
-
required double alpha = 2;
- hasBarrier() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .EnterBarrier barrier = 2;
- hasBarrier() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
-
optional .EnterBarrier barrier = 2;
- hasBarrier() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
-
optional .EnterBarrier barrier = 2;
- hasChildren() - Method in class akka.actor.VirtualPathContainer
-
- hasClazz() - Method in class akka.remote.WireFormats.PropsData.Builder
-
required string clazz = 3;
- hasClazz() - Method in class akka.remote.WireFormats.PropsData
-
required string clazz = 3;
- hasClazz() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
-
required string clazz = 3;
- hasCommandType() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
-
required .CommandType commandType = 1;
- hasCommandType() - Method in class akka.remote.WireFormats.AkkaControlMessage
-
required .CommandType commandType = 1;
- hasCommandType() - Method in interface akka.remote.WireFormats.AkkaControlMessageOrBuilder
-
required .CommandType commandType = 1;
- hasConfig() - Method in class akka.remote.WireFormats.DeployData.Builder
-
optional bytes config = 2;
- hasConfig() - Method in class akka.remote.WireFormats.DeployData
-
optional bytes config = 2;
- hasConfig() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
-
optional bytes config = 2;
- hasCookie() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
optional string cookie = 3;
- hasCookie() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
-
optional string cookie = 3;
- hasCookie() - Method in interface akka.remote.WireFormats.AkkaHandshakeInfoOrBuilder
-
optional string cookie = 3;
- hasCumulativeAck() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
-
required fixed64 cumulativeAck = 1;
- hasCumulativeAck() - Method in class akka.remote.WireFormats.AcknowledgementInfo
-
required fixed64 cumulativeAck = 1;
- hasCumulativeAck() - Method in interface akka.remote.WireFormats.AcknowledgementInfoOrBuilder
-
required fixed64 cumulativeAck = 1;
- hasCurrentDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
required int64 currentDeliveryId = 1;
- hasCurrentDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
-
required int64 currentDeliveryId = 1;
- hasCurrentDeliveryId() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshotOrBuilder
-
required int64 currentDeliveryId = 1;
- hasDeleted() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional bool deleted = 4;
- hasDeleted() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
optional bool deleted = 4;
- hasDeleted() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
-
optional bool deleted = 4;
- hasDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
required int64 deliveryId = 1;
- hasDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
-
required int64 deliveryId = 1;
- hasDeliveryId() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder
-
required int64 deliveryId = 1;
- hasDeploy() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required .DeployData deploy = 2;
- hasDeploy() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
-
required .DeployData deploy = 2;
- hasDeploy() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
-
required .DeployData deploy = 2;
- hasDeploy() - Method in class akka.remote.WireFormats.PropsData.Builder
-
required .DeployData deploy = 2;
- hasDeploy() - Method in class akka.remote.WireFormats.PropsData
-
required .DeployData deploy = 2;
- hasDeploy() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
-
required .DeployData deploy = 2;
- hasDestination() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
required string destination = 2;
- hasDestination() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
-
required string destination = 2;
- hasDestination() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder
-
required string destination = 2;
- hasDirection() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
optional .Direction direction = 2;
- hasDirection() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
-
optional .Direction direction = 2;
- hasDirection() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
-
optional .Direction direction = 2;
- hasDispatcher(String) - Method in class akka.dispatch.Dispatchers
-
Checks that the configuration provides a section for the given dispatcher.
- hasDispatcher() - Method in class akka.remote.WireFormats.DeployData.Builder
-
optional string dispatcher = 5;
- hasDispatcher() - Method in class akka.remote.WireFormats.DeployData
-
optional string dispatcher = 5;
- hasDispatcher() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
-
optional string dispatcher = 5;
- hasDone() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional string done = 4;
- hasDone() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
-
optional string done = 4;
- hasDone() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
-
optional string done = 4;
- hasEffects() - Method in class akka.typed.EffectfulActorContext
-
- hasEnclosedMessage() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload.Builder
-
required bytes enclosedMessage = 1;
- hasEnclosedMessage() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload
-
required bytes enclosedMessage = 1;
- hasEnclosedMessage() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.PayloadOrBuilder
-
required bytes enclosedMessage = 1;
- hasEnclosedMessage() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
required bytes enclosedMessage = 1;
- hasEnclosedMessage() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
-
required bytes enclosedMessage = 1;
- hasEnclosedMessage() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
-
required bytes enclosedMessage = 1;
- hasEnvelope() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
optional .RemoteEnvelope envelope = 2;
- hasEnvelope() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
-
optional .RemoteEnvelope envelope = 2;
- hasEnvelope() - Method in interface akka.remote.WireFormats.AckAndEnvelopeContainerOrBuilder
-
optional .RemoteEnvelope envelope = 2;
- hasEwma() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
optional .NodeMetrics.EWMA ewma = 3;
- hasEwma() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric
-
optional .NodeMetrics.EWMA ewma = 3;
- hasEwma() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.MetricOrBuilder
-
optional .NodeMetrics.EWMA ewma = 3;
- hasEwma() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
optional .NodeMetrics.EWMA ewma = 3;
- hasEwma() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
-
optional .NodeMetrics.EWMA ewma = 3;
- hasEwma() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.MetricOrBuilder
-
optional .NodeMetrics.EWMA ewma = 3;
- hasExitValue() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
optional int32 exitValue = 7;
- hasExitValue() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
-
optional int32 exitValue = 7;
- hasExitValue() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
-
optional int32 exitValue = 7;
- hasExtension(ExtensionId<? extends Extension>) - Method in class akka.actor.ActorSystem
-
Returns whether the specified extension is already registered, this method can potentially block, waiting for the initialization
of the payload, if is in the process of registration from another Thread of execution
- hasExtension(ExtensionId<? extends Extension>) - Method in class akka.actor.ActorSystemImpl
-
- hasFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
required .FailType failure = 1;
- hasFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
-
required .FailType failure = 1;
- hasFailure() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
-
required .FailType failure = 1;
- hasFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .InjectFailure failure = 3;
- hasFailure() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
-
optional .InjectFailure failure = 3;
- hasFailure() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
-
optional .InjectFailure failure = 3;
- hasFrom() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
required .Address from = 1;
- hasFrom() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope
-
required .Address from = 1;
- hasFrom() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelopeOrBuilder
-
required .Address from = 1;
- hasFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
required .UniqueAddress from = 1;
- hasFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
-
required .UniqueAddress from = 1;
- hasFrom() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelopeOrBuilder
-
required .UniqueAddress from = 1;
- hasFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
required .UniqueAddress from = 1;
- hasFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
-
required .UniqueAddress from = 1;
- hasFrom() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipStatusOrBuilder
-
required .UniqueAddress from = 1;
- hasFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
required .Address from = 1;
- hasFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
-
required .Address from = 1;
- hasFrom() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelopeOrBuilder
-
required .Address from = 1;
- hasFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
-
required .UniqueAddress from = 1;
- hasFrom() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
-
required .UniqueAddress from = 1;
- hasFrom() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.WelcomeOrBuilder
-
required .UniqueAddress from = 1;
- hasGlobalScope() - Method in class akka.actor.Address
-
Returns true if this Address is usable globally.
- hasGossip() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
required .MetricsGossip gossip = 2;
- hasGossip() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope
-
required .MetricsGossip gossip = 2;
- hasGossip() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelopeOrBuilder
-
required .MetricsGossip gossip = 2;
- hasGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
required .MetricsGossip gossip = 2;
- hasGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
-
required .MetricsGossip gossip = 2;
- hasGossip() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelopeOrBuilder
-
required .MetricsGossip gossip = 2;
- hasGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
-
required .Gossip gossip = 2;
- hasGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome
-
required .Gossip gossip = 2;
- hasGossip() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.WelcomeOrBuilder
-
required .Gossip gossip = 2;
- hash(int, Object) - Method in class akka.util.HashCode$
-
- hash(int, boolean) - Method in class akka.util.HashCode$
-
- hash(int, char) - Method in class akka.util.HashCode$
-
- hash(int, int) - Method in class akka.util.HashCode$
-
- hash(int, long) - Method in class akka.util.HashCode$
-
- hash(int, float) - Method in class akka.util.HashCode$
-
- hash(int, double) - Method in class akka.util.HashCode$
-
- hash(int, Object) - Static method in class akka.util.HashCode
-
- hash(int, boolean) - Static method in class akka.util.HashCode
-
- hash(int, char) - Static method in class akka.util.HashCode
-
- hash(int, int) - Static method in class akka.util.HashCode
-
- hash(int, long) - Static method in class akka.util.HashCode
-
- hash(int, float) - Static method in class akka.util.HashCode
-
- hash(int, double) - Static method in class akka.util.HashCode
-
- hasHandshakeInfo() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
-
optional .AkkaHandshakeInfo handshakeInfo = 2;
- hasHandshakeInfo() - Method in class akka.remote.WireFormats.AkkaControlMessage
-
optional .AkkaHandshakeInfo handshakeInfo = 2;
- hasHandshakeInfo() - Method in interface akka.remote.WireFormats.AkkaControlMessageOrBuilder
-
optional .AkkaHandshakeInfo handshakeInfo = 2;
- hasHashIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
-
required int32 hashIndex = 1;
- hasHashIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
-
required int32 hashIndex = 1;
- hasHashIndex() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.VectorClock.VersionOrBuilder
-
required int32 hashIndex = 1;
- hashCode() - Method in class akka.actor.ActorRef
-
- hashCode() - Method in class akka.actor.ActorSelection
-
- hashCode() - Method in class akka.actor.Address
-
- hashCode() - Method in class akka.actor.ChildActorPath
-
- hashCode() - Method in interface akka.actor.ExtensionId
-
- hashCode() - Method in class akka.cluster.Member
-
- hashCode() - Method in class akka.cluster.Metric
-
- hashCode() - Method in class akka.cluster.metrics.Metric
-
- hashCode() - Method in class akka.cluster.metrics.NodeMetrics
-
- hashCode() - Method in class akka.cluster.NodeMetrics
-
- hashCode() - Method in class akka.cluster.Reachability
-
- hashCode() - Method in class akka.cluster.UniqueAddress
-
- hashCode() - Method in class akka.typed.ActorRef
-
- HashCode - Class in akka.util
-
Set of methods which allow easy implementation of hashCode
.
- HashCode() - Constructor for class akka.util.HashCode
-
- hashCode() - Method in class akka.util.TypedMultiMap
-
- HashCode$ - Class in akka.util
-
Set of methods which allow easy implementation of hashCode
.
- HashCode$() - Constructor for class akka.util.HashCode$
-
- hasHello() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .Hello hello = 1;
- hasHello() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper
-
optional .Hello hello = 1;
- hasHello() - Method in interface akka.remote.testconductor.TestConductorProtocol.WrapperOrBuilder
-
optional .Hello hello = 1;
- HASHINDEX_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
-
- hashKey() - Method in class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope
-
- hashKey(Object) - Method in interface akka.routing.ConsistentHashingRouter.ConsistentHashMapper
-
- hashMapping() - Method in class akka.routing.ConsistentHashingGroup
-
- hashMapping() - Method in class akka.routing.ConsistentHashingPool
-
- hashMapping() - Method in class akka.routing.ConsistentHashingRoutingLogic
-
- hashMappingAdapter(ConsistentHashingRouter.ConsistentHashMapper) - Method in class akka.routing.ConsistentHashingRouter$
-
INTERNAL API
- hashMappingAdapter(ConsistentHashingRouter.ConsistentHashMapper) - Static method in class akka.routing.ConsistentHashingRouter
-
INTERNAL API
- hasHost() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
required string host = 3;
- hasHost() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
-
required string host = 3;
- hasHost() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
-
required string host = 3;
- hasHostname() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
required string hostname = 2;
- hasHostname() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address
-
required string hostname = 2;
- hasHostname() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.AddressOrBuilder
-
required string hostname = 2;
- hasHostname() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
required string hostname = 2;
- hasHostname() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
-
required string hostname = 2;
- hasHostname() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.AddressOrBuilder
-
required string hostname = 2;
- hasHostname() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
required string hostname = 2;
- hasHostname() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address
-
required string hostname = 2;
- hasHostname() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.AddressOrBuilder
-
required string hostname = 2;
- hasHostname() - Method in class akka.remote.WireFormats.AddressData.Builder
-
required string hostname = 2;
- hasHostname() - Method in class akka.remote.WireFormats.AddressData
-
required string hostname = 2;
- hasHostname() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
-
required string hostname = 2;
- hasInstruction() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
-
optional .AkkaControlMessage instruction = 2;
- hasInstruction() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
-
optional .AkkaControlMessage instruction = 2;
- hasInstruction() - Method in interface akka.remote.WireFormats.AkkaProtocolMessageOrBuilder
-
optional .AkkaControlMessage instruction = 2;
- hasKey() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
required string key = 1;
- hasKey() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry
-
required string key = 1;
- hasKey() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.EntryOrBuilder
-
required string key = 1;
- hasLocalAffinity() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
required bool localAffinity = 2;
- hasLocalAffinity() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send
-
required bool localAffinity = 2;
- hasLocalAffinity() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendOrBuilder
-
required bool localAffinity = 2;
- hasLocalScope() - Method in class akka.actor.Address
-
Returns true if this Address is only defined locally.
- hasMatcher() - Method in class akka.remote.ContainerFormats.Selection.Builder
-
optional string matcher = 2;
- hasMatcher() - Method in class akka.remote.ContainerFormats.Selection
-
optional string matcher = 2;
- hasMatcher() - Method in interface akka.remote.ContainerFormats.SelectionOrBuilder
-
optional string matcher = 2;
- hasMember(UniqueAddress) - Method in class akka.cluster.Gossip
-
- hasMessage() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
required .SerializedMessage message = 2;
- hasMessage() - Method in class akka.remote.WireFormats.RemoteEnvelope
-
required .SerializedMessage message = 2;
- hasMessage() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
-
required .SerializedMessage message = 2;
- hasMessage() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
-
required bytes message = 1;
- hasMessage() - Method in class akka.remote.WireFormats.SerializedMessage
-
required bytes message = 1;
- hasMessage() - Method in interface akka.remote.WireFormats.SerializedMessageOrBuilder
-
required bytes message = 1;
- hasMessageManifest() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload.Builder
-
optional bytes messageManifest = 4;
- hasMessageManifest() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload
-
optional bytes messageManifest = 4;
- hasMessageManifest() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.PayloadOrBuilder
-
optional bytes messageManifest = 4;
- hasMessageManifest() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
optional bytes messageManifest = 4;
- hasMessageManifest() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
-
optional bytes messageManifest = 4;
- hasMessageManifest() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
-
optional bytes messageManifest = 4;
- hasMessageManifest() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
-
optional bytes messageManifest = 3;
- hasMessageManifest() - Method in class akka.remote.WireFormats.SerializedMessage
-
optional bytes messageManifest = 3;
- hasMessageManifest() - Method in interface akka.remote.WireFormats.SerializedMessageOrBuilder
-
optional bytes messageManifest = 3;
- hasMessages() - Method in interface akka.actor.Cell
-
If the actor isLocal, returns whether "user messages" are currently queued,
“false” otherwise.
- hasMessages() - Method in interface akka.actor.dungeon.Dispatch
-
- hasMessages() - Method in class akka.actor.UnstartedCell
-
- hasMessages() - Method in class akka.dispatch.BoundedControlAwareMailbox.MessageQueue
-
- hasMessages() - Method in class akka.dispatch.BoundedNodeMessageQueue
-
- hasMessages() - Method in interface akka.dispatch.ControlAwareMessageQueueSemantics
-
- hasMessages() - Method in class akka.dispatch.Mailbox
-
Indicates whether this queue is non-empty.
- hasMessages() - Method in interface akka.dispatch.MessageQueue
-
Indicates whether this queue is non-empty.
- hasMessages() - Method in class akka.dispatch.NodeMessageQueue
-
- hasMessages() - Method in interface akka.dispatch.QueueBasedMessageQueue
-
- hasMessages(Routee) - Method in class akka.routing.SmallestMailboxRoutingLogic
-
Returns true if the actor currently has any pending messages
in the mailbox, i.e.
- hasMessages() - Method in class akka.testkit.CallingThreadMailbox
-
- hasMessages() - Method in class akka.typed.Inbox.SyncInbox
-
- hasName() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
-
required string name = 1;
- hasName() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
-
required string name = 1;
- hasName() - Method in interface akka.remote.testconductor.TestConductorProtocol.EnterBarrierOrBuilder
-
required string name = 1;
- hasName() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
-
required string name = 1;
- hasName() - Method in class akka.remote.testconductor.TestConductorProtocol.Hello
-
required string name = 1;
- hasName() - Method in interface akka.remote.testconductor.TestConductorProtocol.HelloOrBuilder
-
required string name = 1;
- hasNameIndex() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
required int32 nameIndex = 1;
- hasNameIndex() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric
-
required int32 nameIndex = 1;
- hasNameIndex() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.MetricOrBuilder
-
required int32 nameIndex = 1;
- hasNameIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
required int32 nameIndex = 1;
- hasNameIndex() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
-
required int32 nameIndex = 1;
- hasNameIndex() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.MetricOrBuilder
-
required int32 nameIndex = 1;
- hasNecessaryClusterRole(Option<String>) - Method in class akka.cluster.sharding.ClusterSharding.Settings$
-
- hasNext() - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- hasNext() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- hasNode() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
-
required .UniqueAddress node = 1;
- hasNode() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join
-
required .UniqueAddress node = 1;
- hasNode() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.JoinOrBuilder
-
required .UniqueAddress node = 1;
- hasNode() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
-
required string node = 1;
- hasNode() - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest
-
required string node = 1;
- hasNode() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressRequestOrBuilder
-
required string node = 1;
- hasNumber() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
required .NodeMetrics.Number number = 2;
- hasNumber() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric
-
required .NodeMetrics.Number number = 2;
- hasNumber() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.MetricOrBuilder
-
required .NodeMetrics.Number number = 2;
- hasNumber() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
required .NodeMetrics.Number number = 2;
- hasNumber() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric
-
required .NodeMetrics.Number number = 2;
- hasNumber() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.MetricOrBuilder
-
required .NodeMetrics.Number number = 2;
- hasOp() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
-
required .BarrierOp op = 2;
- hasOp() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
-
required .BarrierOp op = 2;
- hasOp() - Method in interface akka.remote.testconductor.TestConductorProtocol.EnterBarrierOrBuilder
-
required .BarrierOp op = 2;
- hasOrigin() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
required .AddressData origin = 1;
- hasOrigin() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
-
required .AddressData origin = 1;
- hasOrigin() - Method in interface akka.remote.WireFormats.AkkaHandshakeInfoOrBuilder
-
required .AddressData origin = 1;
- hasOverview() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
required .GossipOverview overview = 5;
- hasOverview() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
required .GossipOverview overview = 5;
- hasOverview() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
-
required .GossipOverview overview = 5;
- hasOwner() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
required .Address owner = 1;
- hasOwner() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
-
required .Address owner = 1;
- hasOwner() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.BucketOrBuilder
-
required .Address owner = 1;
- hasPath() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
required string path = 1;
- hasPath() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send
-
required string path = 1;
- hasPath() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendOrBuilder
-
required string path = 1;
- hasPath() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
-
required string path = 1;
- hasPath() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll
-
required string path = 1;
- hasPath() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAllOrBuilder
-
required string path = 1;
- hasPath(String) - Method in class akka.dispatch.CachingConfig
-
- hasPath() - Method in class akka.remote.WireFormats.ActorRefData.Builder
-
required string path = 1;
- hasPath() - Method in class akka.remote.WireFormats.ActorRefData
-
required string path = 1;
- hasPath() - Method in interface akka.remote.WireFormats.ActorRefDataOrBuilder
-
required string path = 1;
- hasPath() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required string path = 3;
- hasPath() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
-
required string path = 3;
- hasPath() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
-
required string path = 3;
- hasPath() - Method in class akka.remote.WireFormats.DeployData.Builder
-
required string path = 1;
- hasPath() - Method in class akka.remote.WireFormats.DeployData
-
required string path = 1;
- hasPath() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
-
required string path = 1;
- hasPathOrNull(String) - Method in class akka.dispatch.CachingConfig
-
- hasPayload() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish.Builder
-
required .Payload payload = 3;
- hasPayload() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish
-
required .Payload payload = 3;
- hasPayload() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.PublishOrBuilder
-
required .Payload payload = 3;
- hasPayload() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
required .Payload payload = 3;
- hasPayload() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send
-
required .Payload payload = 3;
- hasPayload() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendOrBuilder
-
required .Payload payload = 3;
- hasPayload() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
-
required .Payload payload = 3;
- hasPayload() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll
-
required .Payload payload = 3;
- hasPayload() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAllOrBuilder
-
required .Payload payload = 3;
- hasPayload() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
required .PersistentPayload payload = 3;
- hasPayload() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
-
required .PersistentPayload payload = 3;
- hasPayload() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder
-
required .PersistentPayload payload = 3;
- hasPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional .PersistentPayload payload = 1;
- hasPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
optional .PersistentPayload payload = 1;
- hasPayload() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
-
optional .PersistentPayload payload = 1;
- hasPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
-
required bytes payload = 2;
- hasPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
-
required bytes payload = 2;
- hasPayload() - Method in interface akka.persistence.serialization.MessageFormats.PersistentPayloadOrBuilder
-
required bytes payload = 2;
- hasPayload() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
-
optional bytes payload = 1;
- hasPayload() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
-
optional bytes payload = 1;
- hasPayload() - Method in interface akka.remote.WireFormats.AkkaProtocolMessageOrBuilder
-
optional bytes payload = 1;
- hasPayloadManifest() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
-
optional bytes payloadManifest = 3;
- hasPayloadManifest() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
-
optional bytes payloadManifest = 3;
- hasPayloadManifest() - Method in interface akka.persistence.serialization.MessageFormats.PersistentPayloadOrBuilder
-
optional bytes payloadManifest = 3;
- hasPersistenceId() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional string persistenceId = 3;
- hasPersistenceId() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
optional string persistenceId = 3;
- hasPersistenceId() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
-
optional string persistenceId = 3;
- hasPort() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
required uint32 port = 3;
- hasPort() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address
-
required uint32 port = 3;
- hasPort() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.AddressOrBuilder
-
required uint32 port = 3;
- hasPort() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
required uint32 port = 3;
- hasPort() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
-
required uint32 port = 3;
- hasPort() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.AddressOrBuilder
-
required uint32 port = 3;
- hasPort() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
required uint32 port = 3;
- hasPort() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address
-
required uint32 port = 3;
- hasPort() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.AddressOrBuilder
-
required uint32 port = 3;
- hasPort() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
required int32 port = 4;
- hasPort() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
-
required int32 port = 4;
- hasPort() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
-
required int32 port = 4;
- hasPort() - Method in class akka.remote.WireFormats.AddressData.Builder
-
required uint32 port = 3;
- hasPort() - Method in class akka.remote.WireFormats.AddressData
-
required uint32 port = 3;
- hasPort() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
-
required uint32 port = 3;
- hasProps() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required .PropsData props = 1;
- hasProps() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
-
required .PropsData props = 1;
- hasProps() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
-
required .PropsData props = 1;
- hasProtocol() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
optional string protocol = 4;
- hasProtocol() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address
-
optional string protocol = 4;
- hasProtocol() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.AddressOrBuilder
-
optional string protocol = 4;
- hasProtocol() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
optional string protocol = 4;
- hasProtocol() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
-
optional string protocol = 4;
- hasProtocol() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.AddressOrBuilder
-
optional string protocol = 4;
- hasProtocol() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
optional string protocol = 4;
- hasProtocol() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address
-
optional string protocol = 4;
- hasProtocol() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.AddressOrBuilder
-
optional string protocol = 4;
- hasProtocol() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
required string protocol = 1;
- hasProtocol() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
-
required string protocol = 1;
- hasProtocol() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
-
required string protocol = 1;
- hasProtocol() - Method in class akka.remote.WireFormats.AddressData.Builder
-
optional string protocol = 4;
- hasProtocol() - Method in class akka.remote.WireFormats.AddressData
-
optional string protocol = 4;
- hasProtocol() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
-
optional string protocol = 4;
- hasRateMBit() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
optional float rateMBit = 6;
- hasRateMBit() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure
-
optional float rateMBit = 6;
- hasRateMBit() - Method in interface akka.remote.testconductor.TestConductorProtocol.InjectFailureOrBuilder
-
optional float rateMBit = 6;
- hasRecipient() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
required .ActorRefData recipient = 1;
- hasRecipient() - Method in class akka.remote.WireFormats.RemoteEnvelope
-
required .ActorRefData recipient = 1;
- hasRecipient() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
-
required .ActorRefData recipient = 1;
- hasRef() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
optional string ref = 3;
- hasRef() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry
-
optional string ref = 3;
- hasRef() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.EntryOrBuilder
-
optional string ref = 3;
- hasReply() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
required bool reply = 3;
- hasReply() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope
-
required bool reply = 3;
- hasReply() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelopeOrBuilder
-
required bool reply = 3;
- hasReply() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
required bool reply = 3;
- hasReply() - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope
-
required bool reply = 3;
- hasReply() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelopeOrBuilder
-
required bool reply = 3;
- hasRequiredType(Class<? extends Actor>) - Method in class akka.dispatch.Mailboxes
-
Check if this class can have a required message queue type.
- hasRole(String) - Method in class akka.cluster.Member
-
- hasRouterConfig() - Method in class akka.remote.WireFormats.DeployData.Builder
-
optional bytes routerConfig = 3;
- hasRouterConfig() - Method in class akka.remote.WireFormats.DeployData
-
optional bytes routerConfig = 3;
- hasRouterConfig() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
-
optional bytes routerConfig = 3;
- hasScope() - Method in class akka.remote.WireFormats.DeployData.Builder
-
optional bytes scope = 4;
- hasScope() - Method in class akka.remote.WireFormats.DeployData
-
optional bytes scope = 4;
- hasScope() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
-
optional bytes scope = 4;
- hasSender() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional string sender = 11;
- hasSender() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
optional string sender = 11;
- hasSender() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
-
optional string sender = 11;
- hasSender() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
optional .ActorRefData sender = 4;
- hasSender() - Method in class akka.remote.WireFormats.RemoteEnvelope
-
optional .ActorRefData sender = 4;
- hasSender() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
-
optional .ActorRefData sender = 4;
- hasSeq() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
optional fixed64 seq = 5;
- hasSeq() - Method in class akka.remote.WireFormats.RemoteEnvelope
-
optional fixed64 seq = 5;
- hasSeq() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
-
optional fixed64 seq = 5;
- hasSequenceNr() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional int64 sequenceNr = 2;
- hasSequenceNr() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
optional int64 sequenceNr = 2;
- hasSequenceNr() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
-
optional int64 sequenceNr = 2;
- HasSequenceNumber - Interface in akka.remote
-
- HasSequenceNumber$ - Class in akka.remote
-
- HasSequenceNumber$() - Constructor for class akka.remote.HasSequenceNumber$
-
- hasSerialized() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number.Builder
-
optional bytes serialized = 4;
- hasSerialized() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number
-
optional bytes serialized = 4;
- hasSerialized() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.NumberOrBuilder
-
optional bytes serialized = 4;
- hasSerialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
-
optional bytes serialized = 4;
- hasSerialized() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
-
optional bytes serialized = 4;
- hasSerialized() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberOrBuilder
-
optional bytes serialized = 4;
- hasSerializedGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
required bytes serializedGossip = 3;
- hasSerializedGossip() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
-
required bytes serializedGossip = 3;
- hasSerializedGossip() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelopeOrBuilder
-
required bytes serializedGossip = 3;
- hasSerializerId() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload.Builder
-
required int32 serializerId = 2;
- hasSerializerId() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload
-
required int32 serializerId = 2;
- hasSerializerId() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.PayloadOrBuilder
-
required int32 serializerId = 2;
- hasSerializerId() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
-
required int32 serializerId = 1;
- hasSerializerId() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
-
required int32 serializerId = 1;
- hasSerializerId() - Method in interface akka.persistence.serialization.MessageFormats.PersistentPayloadOrBuilder
-
required int32 serializerId = 1;
- hasSerializerId() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
required int32 serializerId = 2;
- hasSerializerId() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
-
required int32 serializerId = 2;
- hasSerializerId() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
-
required int32 serializerId = 2;
- hasSerializerId() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
-
required int32 serializerId = 2;
- hasSerializerId() - Method in class akka.remote.WireFormats.SerializedMessage
-
required int32 serializerId = 2;
- hasSerializerId() - Method in interface akka.remote.WireFormats.SerializedMessageOrBuilder
-
required int32 serializerId = 2;
- hasStatus() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
required .MemberStatus status = 3;
- hasStatus() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
-
required .MemberStatus status = 3;
- hasStatus() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MemberOrBuilder
-
required .MemberStatus status = 3;
- hasStatus() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
-
required .ReachabilityStatus status = 3;
- hasStatus() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
-
required .ReachabilityStatus status = 3;
- hasStatus() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.SubjectReachabilityOrBuilder
-
required .ReachabilityStatus status = 3;
- hasSubscriptions(SubchannelClassification) - Method in interface akka.event.SubchannelClassification
-
INTERNAL API
Expensive call! Avoid calling directly from event bus subscribe / unsubscribe.
- hasSupervisor() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required .ActorRefData supervisor = 4;
- hasSupervisor() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
-
required .ActorRefData supervisor = 4;
- hasSupervisor() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
-
required .ActorRefData supervisor = 4;
- hasSystem() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
required string system = 1;
- hasSystem() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address
-
required string system = 1;
- hasSystem() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.AddressOrBuilder
-
required string system = 1;
- hasSystem() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
required string system = 1;
- hasSystem() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address
-
required string system = 1;
- hasSystem() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.AddressOrBuilder
-
required string system = 1;
- hasSystem() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
required string system = 1;
- hasSystem() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address
-
required string system = 1;
- hasSystem() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.AddressOrBuilder
-
required string system = 1;
- hasSystem() - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
required string system = 2;
- hasSystem() - Method in class akka.remote.testconductor.TestConductorProtocol.Address
-
required string system = 2;
- hasSystem() - Method in interface akka.remote.testconductor.TestConductorProtocol.AddressOrBuilder
-
required string system = 2;
- hasSystem() - Method in class akka.remote.WireFormats.AddressData.Builder
-
required string system = 1;
- hasSystem() - Method in class akka.remote.WireFormats.AddressData
-
required string system = 1;
- hasSystem() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
-
required string system = 1;
- hasSystemMessages() - Method in interface akka.dispatch.DefaultSystemMessageQueue
-
- hasSystemMessages() - Method in interface akka.dispatch.SystemMessageQueue
-
- hasTimeout() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
-
optional int64 timeout = 3;
- hasTimeout() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier
-
optional int64 timeout = 3;
- hasTimeout() - Method in interface akka.remote.testconductor.TestConductorProtocol.EnterBarrierOrBuilder
-
optional int64 timeout = 3;
- hasTimestamp() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
required int64 timestamp = 2;
- hasTimestamp() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics
-
required int64 timestamp = 2;
- hasTimestamp() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetricsOrBuilder
-
required int64 timestamp = 2;
- hasTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
required int64 timestamp = 2;
- hasTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
-
required int64 timestamp = 2;
- hasTimestamp() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetricsOrBuilder
-
required int64 timestamp = 2;
- hasTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
optional int64 timestamp = 1;
- hasTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock
-
optional int64 timestamp = 1;
- hasTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
-
required int64 timestamp = 2;
- hasTimestamp() - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version
-
required int64 timestamp = 2;
- hasTimestamp() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.VectorClock.VersionOrBuilder
-
required int64 timestamp = 2;
- hasTimestamp() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.VectorClockOrBuilder
-
optional int64 timestamp = 1;
- hasTimestamp() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
-
required int64 timestamp = 2;
- hasTimestamp() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version
-
required int64 timestamp = 2;
- hasTimestamp() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.VersionOrBuilder
-
required int64 timestamp = 2;
- hasTo() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
required .UniqueAddress to = 2;
- hasTo() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
-
required .UniqueAddress to = 2;
- hasTo() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelopeOrBuilder
-
required .UniqueAddress to = 2;
- hasTopic() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish.Builder
-
required string topic = 1;
- hasTopic() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish
-
required string topic = 1;
- hasTopic() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.PublishOrBuilder
-
required string topic = 1;
- hasType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number.Builder
-
required .NodeMetrics.NumberType type = 1;
- hasType() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number
-
required .NodeMetrics.NumberType type = 1;
- hasType() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.NumberOrBuilder
-
required .NodeMetrics.NumberType type = 1;
- hasType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
-
required .NodeMetrics.NumberType type = 1;
- hasType() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
-
required .NodeMetrics.NumberType type = 1;
- hasType() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberOrBuilder
-
required .NodeMetrics.NumberType type = 1;
- hasType() - Method in class akka.remote.ContainerFormats.Selection.Builder
-
required .PatternType type = 1;
- hasType() - Method in class akka.remote.ContainerFormats.Selection
-
required .PatternType type = 1;
- hasType() - Method in interface akka.remote.ContainerFormats.SelectionOrBuilder
-
required .PatternType type = 1;
- hasUid() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
-
required uint32 uid = 2;
- hasUid() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
-
required uint32 uid = 2;
- hasUid() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.UniqueAddressOrBuilder
-
required uint32 uid = 2;
- hasUid() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
required fixed64 uid = 2;
- hasUid() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
-
required fixed64 uid = 2;
- hasUid() - Method in interface akka.remote.WireFormats.AkkaHandshakeInfoOrBuilder
-
required fixed64 uid = 2;
- hasUpNumber() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
required int32 upNumber = 2;
- hasUpNumber() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member
-
required int32 upNumber = 2;
- hasUpNumber() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.MemberOrBuilder
-
required int32 upNumber = 2;
- hasValue() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA.Builder
-
required double value = 1;
- hasValue() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA
-
required double value = 1;
- hasValue() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMAOrBuilder
-
required double value = 1;
- hasValue() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
-
required double value = 1;
- hasValue() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA
-
required double value = 1;
- hasValue() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMAOrBuilder
-
required double value = 1;
- hasValue32() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number.Builder
-
optional uint32 value32 = 2;
- hasValue32() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number
-
optional uint32 value32 = 2;
- hasValue32() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.NumberOrBuilder
-
optional uint32 value32 = 2;
- hasValue32() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
-
optional uint32 value32 = 2;
- hasValue32() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
-
optional uint32 value32 = 2;
- hasValue32() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberOrBuilder
-
optional uint32 value32 = 2;
- hasValue64() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number.Builder
-
optional uint64 value64 = 3;
- hasValue64() - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number
-
optional uint64 value64 = 3;
- hasValue64() - Method in interface akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.NumberOrBuilder
-
optional uint64 value64 = 3;
- hasValue64() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
-
optional uint64 value64 = 3;
- hasValue64() - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
-
optional uint64 value64 = 3;
- hasValue64() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberOrBuilder
-
optional uint64 value64 = 3;
- hasVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
required .VectorClock version = 6;
- hasVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
required .VectorClock version = 6;
- hasVersion() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipOrBuilder
-
required .VectorClock version = 6;
- hasVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
required .VectorClock version = 3;
- hasVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus
-
required .VectorClock version = 3;
- hasVersion() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.GossipStatusOrBuilder
-
required .VectorClock version = 3;
- hasVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
required int64 version = 4;
- hasVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
-
required int64 version = 4;
- hasVersion() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.ObserverReachabilityOrBuilder
-
required int64 version = 4;
- hasVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
-
required int64 version = 4;
- hasVersion() - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
-
required int64 version = 4;
- hasVersion() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.SubjectReachabilityOrBuilder
-
required int64 version = 4;
- hasVersion() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
required int64 version = 2;
- hasVersion() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket
-
required int64 version = 2;
- hasVersion() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.BucketOrBuilder
-
required int64 version = 2;
- hasVersion() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
required int64 version = 2;
- hasVersion() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry
-
required int64 version = 2;
- hasVersion() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.EntryOrBuilder
-
required int64 version = 2;
- hasWildcardFanOut() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
optional bool wildcardFanOut = 5;
- hasWildcardFanOut() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
-
optional bool wildcardFanOut = 5;
- hasWildcardFanOut() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
-
optional bool wildcardFanOut = 5;
- hasWritableEndpointFor(Address) - Method in class akka.remote.EndpointManager.EndpointRegistry
-
- hasWritePending() - Method in interface akka.io.WithUdpSend
-
- head() - Method in class akka.contrib.pattern.WorkList
-
- head() - Method in class akka.dispatch.sysmsg.EarliestFirstSystemMessageList
-
- head() - Method in class akka.dispatch.sysmsg.LatestFirstSystemMessageList
-
- head() - Method in class akka.io.Tcp.CompoundWrite
-
- head() - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- head() - Method in class akka.util.ByteIterator
-
- head() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- head() - Method in class akka.util.ByteString
-
- headerAs(String, ClassTag<T>, CamelContext) - Method in class akka.camel.CamelMessage
-
Returns the header by given name
parameter in a Try
.
- headers() - Method in exception akka.camel.AkkaCamelException
-
- headers() - Method in class akka.camel.CamelMessage
-
- headers(Set<String>) - Method in class akka.camel.CamelMessage
-
Returns those headers from this message whose name is contained in names
.
- headers() - Method in class akka.camel.FailureResult
-
- headersToCopy() - Method in interface akka.camel.ProducerSupport
-
Returns the names of message headers to copy from a request message to a response message.
- headersToCopyDefault() - Method in interface akka.camel.ProducerSupport
-
CamelMessage headers to copy by default from request message to response-message.
- heapCommitted(MemoryUsage) - Method in class akka.cluster.JmxMetricsCollector
-
(JMX) Returns the current sum of heap memory guaranteed to be available to the JVM
from all heap memory pools (in bytes).
- heapCommitted(MemoryUsage) - Method in class akka.cluster.metrics.JmxMetricsCollector
-
(JMX) Returns the current sum of heap memory guaranteed to be available to the JVM
from all heap memory pools (in bytes).
- heapMax(MemoryUsage) - Method in class akka.cluster.JmxMetricsCollector
-
(JMX) Returns the maximum amount of memory (in bytes) that can be used
for JVM memory management.
- heapMax(MemoryUsage) - Method in class akka.cluster.metrics.JmxMetricsCollector
-
(JMX) Returns the maximum amount of memory (in bytes) that can be used
for JVM memory management.
- HeapMemory(Address, long, long, long, Option<Object>) - Constructor for class akka.cluster.metrics.StandardMetrics.HeapMemory
-
- HeapMemory(Address, long, long, long, Option<Object>) - Constructor for class akka.cluster.StandardMetrics.HeapMemory
-
- HeapMemory$() - Constructor for class akka.cluster.metrics.StandardMetrics.HeapMemory$
-
- HeapMemory$() - Constructor for class akka.cluster.StandardMetrics.HeapMemory$
-
- HeapMemoryCommitted() - Method in class akka.cluster.metrics.StandardMetrics$
-
- HeapMemoryCommitted() - Static method in class akka.cluster.metrics.StandardMetrics
-
- HeapMemoryCommitted() - Method in class akka.cluster.StandardMetrics$
-
- HeapMemoryCommitted() - Static method in class akka.cluster.StandardMetrics
-
- HeapMemoryMax() - Method in class akka.cluster.metrics.StandardMetrics$
-
- HeapMemoryMax() - Static method in class akka.cluster.metrics.StandardMetrics
-
- HeapMemoryMax() - Method in class akka.cluster.StandardMetrics$
-
- HeapMemoryMax() - Static method in class akka.cluster.StandardMetrics
-
- heapMemoryUsage() - Method in class akka.cluster.JmxMetricsCollector
-
Current heap to be passed in to heapUsed, heapCommitted and heapMax
- heapMemoryUsage() - Method in class akka.cluster.metrics.JmxMetricsCollector
-
Current heap to be passed in to heapUsed, heapCommitted and heapMax
- HeapMemoryUsed() - Method in class akka.cluster.metrics.StandardMetrics$
-
- HeapMemoryUsed() - Static method in class akka.cluster.metrics.StandardMetrics
-
- HeapMemoryUsed() - Method in class akka.cluster.StandardMetrics$
-
- HeapMemoryUsed() - Static method in class akka.cluster.StandardMetrics
-
- HeapMetricsSelector - Class in akka.cluster.metrics
-
MetricsSelector that uses the heap metrics.
- HeapMetricsSelector() - Constructor for class akka.cluster.metrics.HeapMetricsSelector
-
- HeapMetricsSelector - Class in akka.cluster.routing
-
MetricsSelector that uses the heap metrics.
- HeapMetricsSelector() - Constructor for class akka.cluster.routing.HeapMetricsSelector
-
- HeapMetricsSelector$ - Class in akka.cluster.metrics
-
MetricsSelector that uses the heap metrics.
- HeapMetricsSelector$() - Constructor for class akka.cluster.metrics.HeapMetricsSelector$
-
- HeapMetricsSelector$ - Class in akka.cluster.routing
-
MetricsSelector that uses the heap metrics.
- HeapMetricsSelector$() - Constructor for class akka.cluster.routing.HeapMetricsSelector$
-
- heapUsed(MemoryUsage) - Method in class akka.cluster.JmxMetricsCollector
-
(JMX) Returns the current sum of heap memory used from all heap memory pools (in bytes).
- heapUsed(MemoryUsage) - Method in class akka.cluster.metrics.JmxMetricsCollector
-
(JMX) Returns the current sum of heap memory used from all heap memory pools (in bytes).
- heartbeat() - Method in class akka.cluster.ClusterHeartbeatSender
-
- Heartbeat(Address) - Constructor for class akka.cluster.ClusterHeartbeatSender.Heartbeat
-
- heartbeat() - Method in class akka.remote.DeadlineFailureDetector
-
- heartbeat(A) - Method in class akka.remote.DefaultFailureDetectorRegistry
-
- heartbeat() - Method in interface akka.remote.FailureDetector
-
Notifies the FailureDetector that a heartbeat arrived from the monitored resource.
- heartbeat(A) - Method in interface akka.remote.FailureDetectorRegistry
-
Records a heartbeat for a resource.
- heartbeat() - Method in class akka.remote.PhiAccrualFailureDetector
-
- Heartbeat$() - Constructor for class akka.cluster.ClusterHeartbeatSender.Heartbeat$
-
- Heartbeat$() - Constructor for class akka.remote.RemoteWatcher.Heartbeat$
-
- Heartbeat$() - Constructor for class akka.remote.transport.AkkaPduCodec.Heartbeat$
-
- HEARTBEAT_VALUE - Static variable in enum akka.remote.WireFormats.CommandType
-
HEARTBEAT = 3;
- HeartbeatExpectedResponseAfter() - Method in class akka.cluster.ClusterSettings
-
- HeartbeatHistory - Class in akka.remote
-
- HeartbeatHistory$ - Class in akka.remote
-
- HeartbeatHistory$() - Constructor for class akka.remote.HeartbeatHistory$
-
- HeartbeatInterval() - Method in class akka.cluster.ClusterSettings
-
- HeartbeatNodeRing - Class in akka.cluster
-
INTERNAL API
- HeartbeatNodeRing(UniqueAddress, Set<UniqueAddress>, Set<UniqueAddress>, int) - Constructor for class akka.cluster.HeartbeatNodeRing
-
- HeartbeatNodeRing$ - Class in akka.cluster
-
- HeartbeatNodeRing$() - Constructor for class akka.cluster.HeartbeatNodeRing$
-
- heartbeatReceiver(Address) - Method in class akka.cluster.ClusterHeartbeatSender
-
Looks up and returns the remote cluster heartbeat connection for the specific address.
- heartbeatRsp(UniqueAddress) - Method in class akka.cluster.ClusterHeartbeatSender
-
- HeartbeatRsp(UniqueAddress) - Constructor for class akka.cluster.ClusterHeartbeatSender.HeartbeatRsp
-
- heartbeatRsp(UniqueAddress) - Method in class akka.cluster.ClusterHeartbeatSenderState
-
- HeartbeatRsp(int) - Constructor for class akka.remote.RemoteWatcher.HeartbeatRsp
-
- HeartbeatRsp$() - Constructor for class akka.cluster.ClusterHeartbeatSender.HeartbeatRsp$
-
- HeartbeatRsp$() - Constructor for class akka.remote.RemoteWatcher.HeartbeatRsp$
-
- heartbeatTask() - Method in class akka.cluster.ClusterHeartbeatSender
-
- heartbeatTask() - Method in class akka.remote.RemoteWatcher
-
- HeartbeatTick$() - Constructor for class akka.cluster.ClusterHeartbeatSender.HeartbeatTick$
-
- HeartbeatTick$() - Constructor for class akka.remote.RemoteWatcher.HeartbeatTick$
-
- HeartbeatTimer$() - Constructor for class akka.remote.transport.ProtocolStateActor.HeartbeatTimer$
-
- Hello - Class in akka.remote.testconductor
-
First message of connection sets names straight.
- Hello(String, Address) - Constructor for class akka.remote.testconductor.Hello
-
- Hello$ - Class in akka.remote.testconductor
-
- Hello$() - Constructor for class akka.remote.testconductor.Hello$
-
- HELLO_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Wrapper
-
- Helpers - Class in akka.util
-
- Helpers() - Constructor for class akka.util.Helpers
-
- Helpers$ - Class in akka.util
-
- Helpers$() - Constructor for class akka.util.Helpers$
-
- Helpers.ConfigOps - Class in akka.util
-
INTERNAL API
- Helpers.ConfigOps$ - Class in akka.util
-
- Helpers.Requiring<A> - Class in akka.util
-
Implicit class providing requiring
methods.
- Helpers.Requiring$ - Class in akka.util
-
- hex() - Method in class akka.util.Crypt$
-
- hex() - Static method in class akka.util.Crypt
-
- hexify(byte[]) - Method in class akka.util.Crypt$
-
- hexify(byte[]) - Static method in class akka.util.Crypt
-
- highestPriorityOf(Member, Member) - Method in class akka.cluster.Member$
-
Picks the Member with the highest "priority" MemberStatus.
- highestPriorityOf(Member, Member) - Static method in class akka.cluster.Member
-
Picks the Member with the highest "priority" MemberStatus.
- highestSequenceNr(String) - Method in interface akka.persistence.journal.inmem.InmemMessages
-
- highestSequenceNr() - Method in class akka.persistence.JournalProtocol.ReadHighestSequenceNrSuccess
-
- Home() - Method in class akka.actor.ActorSystem.Settings
-
- HopelessAssociation - Exception in akka.remote
-
INTERNAL API
- HopelessAssociation(Address, Address, Option<Object>, Throwable) - Constructor for exception akka.remote.HopelessAssociation
-
- HopelessAssociation$ - Class in akka.remote
-
- HopelessAssociation$() - Constructor for class akka.remote.HopelessAssociation$
-
- host() - Method in class akka.actor.Address
-
- HOST_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Address
-
- Hostname() - Method in class akka.remote.transport.netty.NettyTransportSettings
-
- HOSTNAME_FIELD_NUMBER - Static variable in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address
-
- HOSTNAME_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Address
-
- HOSTNAME_FIELD_NUMBER - Static variable in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address
-
- HOSTNAME_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AddressData
-
- hostPort() - Method in class akka.actor.Address
-
Returns a String representation formatted as:
- HostShard(String) - Constructor for class akka.cluster.sharding.ShardCoordinator.Internal$.HostShard
-
- mailbox() - Method in class akka.actor.Deploy
-
- mailbox() - Method in interface akka.actor.dungeon.Dispatch
-
- mailbox() - Method in class akka.actor.Props
-
Convenience method for extracting the mailbox information from the
contained
Deploy
instance.
- mailbox() - Method in interface akka.actor.StashSupport
-
INTERNAL API.
- Mailbox - Class in akka.dispatch
-
Mailbox and InternalMailbox is separated in two classes because ActorCell is needed for implementation,
but can't be exposed to user defined mailbox subclasses.
- Mailbox(MessageQueue) - Constructor for class akka.dispatch.Mailbox
-
- Mailbox$ - Class in akka.dispatch
-
INTERNAL API
- Mailbox$() - Constructor for class akka.dispatch.Mailbox$
-
- mailboxes() - Method in class akka.actor.ActorSystem
-
Helper object for looking up configured mailbox types.
- mailboxes() - Method in class akka.actor.ActorSystemImpl
-
- mailboxes() - Method in class akka.dispatch.DefaultDispatcherPrerequisites
-
- mailboxes() - Method in interface akka.dispatch.DispatcherPrerequisites
-
- Mailboxes - Class in akka.dispatch
-
- Mailboxes(ActorSystem.Settings, EventStream, DynamicAccess, ActorRef) - Constructor for class akka.dispatch.Mailboxes
-
- mailboxes() - Method in class akka.dispatch.MessageDispatcher
-
- Mailboxes$ - Class in akka.dispatch
-
- Mailboxes$() - Constructor for class akka.dispatch.Mailboxes$
-
- mailboxType() - Method in class akka.actor.RepointableActorRef
-
- MailboxType - Interface in akka.dispatch
-
MailboxType is a factory to create MessageQueues for an optionally
provided ActorContext.
- mailboxType() - Method in class akka.testkit.CallingThreadMailbox
-
- Main - Class in akka.kernel
-
Main class for running the microkernel.
- Main() - Constructor for class akka.kernel.Main
-
- main(String[]) - Method in class akka.kernel.Main$
-
- main(String[]) - Static method in class akka.kernel.Main
-
- Main - Class in akka
-
Main class to start an
ActorSystem
with one
top level application supervisor actor.
- Main() - Constructor for class akka.Main
-
- main(String[]) - Method in class akka.Main$
-
- main(String[]) - Static method in class akka.Main
-
- Main$ - Class in akka.kernel
-
Main class for running the microkernel.
- Main$() - Constructor for class akka.kernel.Main$
-
- Main$ - Class in akka
-
Main class to start an
ActorSystem
with one
top level application supervisor actor.
- Main$() - Constructor for class akka.Main$
-
- Main.Terminator - Class in akka
-
- maintainAddressTerminatedSubscription(ActorRef, Function0<T>) - Method in interface akka.actor.dungeon.DeathWatch
-
Starts subscription to AddressTerminated if not already subscribing and the
block adds a non-local ref to watching or watchedBy.
- makeChild(ActorCell, Props, String, boolean, boolean) - Method in interface akka.actor.dungeon.Children
-
- makeDecider(Seq<Class<? extends Throwable>>) - Method in class akka.actor.SupervisorStrategy$
-
Decider builder which just checks whether one of
the given Throwables matches the cause and restarts, otherwise escalates.
- makeDecider(Iterable<Class<? extends Throwable>>) - Method in class akka.actor.SupervisorStrategy$
-
Decider builder which just checks whether one of
the given Throwables matches the cause and restarts, otherwise escalates.
- makeDecider(Iterable<Tuple2<Class<? extends Throwable>, SupervisorStrategy.Directive>>) - Method in class akka.actor.SupervisorStrategy$
-
Decider builder for Iterables of cause-directive pairs, e.g.
- makeDecider(Function<Throwable, SupervisorStrategy.Directive>) - Method in class akka.actor.SupervisorStrategy$
-
Converts a Java Decider into a Scala Decider
- makeDecider(Seq<Class<? extends Throwable>>) - Static method in class akka.actor.SupervisorStrategy
-
Decider builder which just checks whether one of
the given Throwables matches the cause and restarts, otherwise escalates.
- makeDecider(Iterable<Class<? extends Throwable>>) - Static method in class akka.actor.SupervisorStrategy
-
Decider builder which just checks whether one of
the given Throwables matches the cause and restarts, otherwise escalates.
- makeDecider(Iterable<Tuple2<Class<? extends Throwable>, SupervisorStrategy.Directive>>) - Static method in class akka.actor.SupervisorStrategy
-
Decider builder for Iterables of cause-directive pairs, e.g.
- makeDecider(Function<Throwable, SupervisorStrategy.Directive>) - Static method in class akka.actor.SupervisorStrategy
-
Converts a Java Decider into a Scala Decider
- makePattern(String) - Method in class akka.util.Helpers$
-
- makePattern(String) - Static method in class akka.util.Helpers
-
- makeTransition(FSM.State<S, D>) - Method in interface akka.actor.FSM
-
- ManagedActorClassification - Interface in akka.event
-
Maps ActorRefs to ActorRefs to form an EventBus where ActorRefs can listen to other ActorRefs.
- ManagedActorClassification.ManagedActorClassificationMappings - Class in akka.event
-
- ManagedActorClassificationMappings(int, Map<ActorRef, TreeSet<ActorRef>>) - Constructor for class akka.event.ManagedActorClassification.ManagedActorClassificationMappings
-
- ManagedActorEventBus<E> - Class in akka.event.japi
-
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
- ManagedActorEventBus(ActorSystem) - Constructor for class akka.event.japi.ManagedActorEventBus
-
- management(ActorContext<Object>, Signal) - Method in class akka.typed.Behavior.emptyBehavior$
-
- management(ActorContext<Object>, Signal) - Method in class akka.typed.Behavior.ignoreBehavior$
-
- management(ActorContext<T>, Signal) - Method in class akka.typed.Behavior
-
Process an incoming
Signal
and return the next behavior.
- management(ActorContext<Nothing$>, Signal) - Method in class akka.typed.Behavior.sameBehavior$
-
- management(ActorContext<Nothing$>, Signal) - Method in class akka.typed.Behavior.stoppedBehavior$
-
- management(ActorContext<Nothing$>, Signal) - Method in class akka.typed.Behavior.unhandledBehavior$
-
- management(ActorContext<T>, Signal) - Method in class akka.typed.ScalaDSL.And
-
- management(ActorContext<T>, Signal) - Method in class akka.typed.ScalaDSL.Full
-
- management(ActorContext<T>, Signal) - Method in class akka.typed.ScalaDSL.FullTotal
-
- management(ActorContext<T>, Signal) - Method in class akka.typed.ScalaDSL.Or
-
- management(ActorContext<T>, Signal) - Method in class akka.typed.ScalaDSL.Partial
-
- management(ActorContext<T>, Signal) - Method in class akka.typed.ScalaDSL.Static
-
- management(ActorContext<T>, Signal) - Method in class akka.typed.ScalaDSL.SynchronousSelf
-
- management(ActorContext<T>, Signal) - Method in class akka.typed.ScalaDSL.Tap
-
- management(ActorContext<T>, Signal) - Method in class akka.typed.ScalaDSL.Total
-
- management(ActorContext<U>, Signal) - Method in class akka.typed.ScalaDSL.Widened
-
- ManagementCommand(Object) - Constructor for class akka.remote.EndpointManager.ManagementCommand
-
- managementCommand(Object) - Method in class akka.remote.RemoteTransport
-
Sends a management command to the underlying transport stack.
- managementCommand(Object) - Method in class akka.remote.Remoting
-
- managementCommand(Object) - Method in class akka.remote.transport.AkkaProtocolTransport
-
- managementCommand(Object) - Method in class akka.remote.transport.FailureInjectorTransportAdapter
-
- managementCommand(Object) - Method in class akka.remote.transport.ThrottlerTransportAdapter
-
- managementCommand(Object) - Method in interface akka.remote.transport.Transport
-
This method allows upper layers to send management commands to the transport.
- ManagementCommand$() - Constructor for class akka.remote.EndpointManager.ManagementCommand$
-
- ManagementCommandAck(boolean) - Constructor for class akka.remote.EndpointManager.ManagementCommandAck
-
- ManagementCommandAck$() - Constructor for class akka.remote.EndpointManager.ManagementCommandAck$
-
- ManagementDispatcher() - Method in class akka.io.TcpExt.Settings
-
- ManagementDispatcher() - Method in class akka.io.Udp.UdpSettings
-
- manager() - Method in class akka.io.DnsExt
-
- manager() - Method in interface akka.io.IO.Extension
-
- manager() - Method in class akka.io.TcpExt
-
- manager() - Method in class akka.io.UdpConnectedExt
-
- manager() - Method in class akka.io.UdpExt
-
- manager() - Method in class akka.remote.transport.ActorTransportAdapter
-
- manager() - Method in class akka.remote.transport.ThrottledAssociation
-
- managerClass() - Method in interface akka.io.DnsProvider
-
- managerClass() - Method in class akka.io.InetAddressDnsProvider
-
- managerName() - Method in class akka.remote.transport.ActorTransportAdapter
-
- managerName() - Method in class akka.remote.transport.AkkaProtocolTransport
-
- managerName() - Method in class akka.remote.transport.ThrottlerTransportAdapter
-
- managerProps() - Method in class akka.remote.transport.ActorTransportAdapter
-
- managerProps() - Method in class akka.remote.transport.AkkaProtocolTransport
-
- managerProps() - Method in class akka.remote.transport.ThrottlerTransportAdapter
-
- manifest() - Method in class akka.persistence.serialization.SnapshotHeader
-
- map(Function1<T, B>) - Method in class akka.agent.Agent
-
Map this agent to a new agent, applying the function to the internal state.
- mapBody(Function1<A, B>) - Method in class akka.camel.CamelMessage
-
Returns a new CamelMessage with a transformed body using a transformer
function.
- mapBody(Mapper<A, B>) - Method in class akka.camel.CamelMessage
-
Java API: Returns a new CamelMessage with a transformed body using a transformer
function.
- mapI(Function1<Object, Object>) - Method in class akka.util.ByteString
-
map method that will automatically cast Int back into Byte.
- Mapper<T,R> - Class in akka.dispatch
-
Callback for the Future.map and Future.flatMap operations that will be invoked
if the Future that this callback is registered on becomes completed with a success.
- Mapper() - Constructor for class akka.dispatch.Mapper
-
- mappingId() - Method in class akka.persistence.journal.leveldb.Key
-
- mappingKey(int) - Method in class akka.persistence.journal.leveldb.Key$
-
- mappingKey(int) - Static method in class akka.persistence.journal.leveldb.Key
-
- mappings() - Method in interface akka.event.ActorClassification
-
- mappings() - Method in interface akka.event.ManagedActorClassification
-
- mapSize() - Method in interface akka.event.ActorClassification
-
This is a size hint for the number of Classifiers you expect to have (use powers of 2)
- mapSize() - Method in class akka.event.japi.ActorEventBus
-
This is a size hint for the number of Classifiers you expect to have (use powers of 2)
- mapSize() - Method in class akka.event.japi.LookupEventBus
-
This is a size hint for the number of Classifiers you expect to have (use powers of 2)
- mapSize() - Method in class akka.event.japi.ManagedActorEventBus
-
This is a size hint for the number of Classifiers you expect to have (use powers of 2)
- mapSize() - Method in interface akka.event.LookupClassification
-
This is a size hint for the number of Classifiers you expect to have (use powers of 2)
- mapSize() - Method in interface akka.event.ManagedActorClassification
-
This is a size hint for the number of Classifiers you expect to have (use powers of 2)
- mapSize() - Method in class akka.util.Index
-
- markAsFailed(ActorRef, Deadline) - Method in class akka.remote.EndpointManager.EndpointRegistry
-
Marking an endpoint as failed means that we will not try to connect to the remote system within
the gated period but it is ok for the remote system to try to connect to us.
- markAsQuarantined(Address, int, Deadline) - Method in class akka.remote.EndpointManager.EndpointRegistry
-
- Marker() - Method in class akka.contrib.mailbox.PeekMailbox
-
- match(Class<P>, FI.Apply<P, SupervisorStrategy.Directive>) - Static method in class akka.japi.pf.DeciderBuilder
-
Return a new
PFBuilder
with a case statement added.
- match(Class<P>, FI.TypedPredicate<P>, FI.Apply<P, SupervisorStrategy.Directive>) - Static method in class akka.japi.pf.DeciderBuilder
-
Return a new
PFBuilder
with a case statement added.
- Match<I,R> - Class in akka.japi.pf
-
Version of PartialFunction
that can be built during
runtime from Java.
- match(Class<? extends P>, FI.Apply<? extends P, T>) - Static method in class akka.japi.pf.Match
-
Convenience function to create a
PFBuilder
with the first
case statement added.
- match(Class<? extends P>, FI.TypedPredicate<? extends P>, FI.Apply<? extends P, T>) - Static method in class akka.japi.pf.Match
-
Convenience function to create a
PFBuilder
with the first
case statement added.
- match(I) - Method in class akka.japi.pf.Match
-
Convenience function to make the Java code more readable.
- match(Class<? extends P>, FI.Apply<? extends P, R>) - Method in class akka.japi.pf.PFBuilder
-
Add a new case statement to this builder.
- match(Class<? extends P>, FI.TypedPredicate<? extends P>, FI.Apply<? extends P, R>) - Method in class akka.japi.pf.PFBuilder
-
Add a new case statement to this builder.
- match(Class<? extends P>, FI.UnitApply<? extends P>) - Static method in class akka.japi.pf.ReceiveBuilder
-
- match(Class<? extends P>, FI.TypedPredicate<? extends P>, FI.UnitApply<? extends P>) - Static method in class akka.japi.pf.ReceiveBuilder
-
- match(Class<? extends P>, FI.UnitApply<? extends P>) - Static method in class akka.japi.pf.UnitMatch
-
Convenience function to create a
UnitPFBuilder
with the first
case statement added.
- match(Class<? extends P>, FI.TypedPredicate<? extends P>, FI.UnitApply<? extends P>) - Static method in class akka.japi.pf.UnitMatch
-
Convenience function to create a
UnitPFBuilder
with the first
case statement added.
- match(I) - Method in class akka.japi.pf.UnitMatch
-
Convenience function to make the Java code more readable.
- match(Class<? extends P>, FI.UnitApply<? extends P>) - Method in class akka.japi.pf.UnitPFBuilder
-
Add a new case statement to this builder.
- match(Class<? extends P>, FI.TypedPredicate<? extends P>, FI.UnitApply<? extends P>) - Method in class akka.japi.pf.UnitPFBuilder
-
Add a new case statement to this builder.
- match(A) - Method in class akka.testkit.CachingPartialFunction
-
- match(Object) - Method in class akka.testkit.JavaTestKit.ExpectMsg
-
- match(Object) - Method in class akka.testkit.JavaTestKit.ReceiveWhile
-
- matchAny(FI.Apply<Object, SupervisorStrategy.Directive>) - Static method in class akka.japi.pf.DeciderBuilder
-
Return a new
PFBuilder
with a case statement added.
- matchAny(FI.Apply<Object, T>) - Static method in class akka.japi.pf.Match
-
Convenience function to create a
PFBuilder
with the first
case statement added.
- matchAny(FI.Apply<Object, R>) - Method in class akka.japi.pf.PFBuilder
-
Add a new case statement to this builder, that matches any argument.
- matchAny(FI.UnitApply<Object>) - Static method in class akka.japi.pf.ReceiveBuilder
-
- matchAny(FI.UnitApply<Object>) - Static method in class akka.japi.pf.UnitMatch
-
Convenience function to create a
UnitPFBuilder
with the first
case statement added.
- matchAny(FI.UnitApply<Object>) - Method in class akka.japi.pf.UnitPFBuilder
-
Add a new case statement to this builder, that matches any argument.
- matchAnyEvent(FI.Apply2<Object, D, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
-
- matchData(Class<DT>, FI.UnitApply<DT>) - Method in class akka.actor.AbstractFSM
-
- matchData(Class<DT>, FI.TypedPredicate<DT>, FI.UnitApply<DT>) - Method in class akka.actor.AbstractFSM
-
- matchEquals(P, FI.Apply<P, T>) - Static method in class akka.japi.pf.Match
-
Convenience function to create a
PFBuilder
with the first
case statement added.
- matchEquals(P, FI.Apply<P, R>) - Method in class akka.japi.pf.PFBuilder
-
Add a new case statement to this builder.
- matchEquals(P, FI.UnitApply<P>) - Static method in class akka.japi.pf.ReceiveBuilder
-
- matchEquals(P, FI.TypedPredicate<P>, FI.UnitApply<P>) - Static method in class akka.japi.pf.ReceiveBuilder
-
- matchEquals(P, FI.UnitApply<P>) - Static method in class akka.japi.pf.UnitMatch
-
Convenience function to create a
UnitPFBuilder
with the first
case statement added.
- matchEquals(P, FI.TypedPredicate<P>, FI.UnitApply<P>) - Static method in class akka.japi.pf.UnitMatch
-
Convenience function to create a
UnitPFBuilder
with the first
case statement added.
- matchEquals(P, FI.UnitApply<P>) - Method in class akka.japi.pf.UnitPFBuilder
-
Add a new case statement to this builder.
- matchEquals(P, FI.TypedPredicate<P>, FI.UnitApply<P>) - Method in class akka.japi.pf.UnitPFBuilder
-
Add a new case statement to this builder.
- matcher() - Method in class akka.typed.ScalaDSL.Widened
-
- MATCHER_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.Selection
-
- matches(C, E) - Method in class akka.event.japi.ScanningEventBus
-
Returns whether the specified Classifier matches the specified Event
- matches(ScanningClassification, ScanningClassification) - Method in interface akka.event.ScanningClassification
-
Returns whether the specified Classifier matches the specified Event
- matches(SnapshotMetadata) - Method in class akka.persistence.SnapshotSelectionCriteria
-
INTERNAL API.
- matches(Logging.LogEvent) - Method in class akka.testkit.CustomEventFilter
-
- matches(Logging.LogEvent) - Method in class akka.testkit.DeadLettersFilter
-
- matches(Logging.LogEvent) - Method in class akka.testkit.DebugFilter
-
- matches(Logging.LogEvent) - Method in class akka.testkit.ErrorFilter
-
- matches(Logging.LogEvent) - Method in class akka.testkit.EventFilter
-
This method decides whether to filter the event (true
) or not
(false
).
- matches(Logging.LogEvent) - Method in class akka.testkit.InfoFilter
-
- matches(String) - Method in class akka.testkit.JavaTestKit.EventFilter
-
- matches(Logging.LogEvent) - Method in class akka.testkit.WarningFilter
-
- matchEvent(Class<ET>, Class<DT>, FI.TypedPredicate2<ET, DT>, FI.Apply2<ET, DT, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
-
- matchEvent(Class<ET>, Class<DT>, FI.Apply2<ET, DT, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
-
- matchEvent(Class<ET>, FI.TypedPredicate2<ET, D>, FI.Apply2<ET, D, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
-
- matchEvent(Class<ET>, FI.Apply2<ET, D, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
-
- matchEvent(FI.TypedPredicate2<Object, D>, FI.Apply2<Object, D, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
-
- matchEvent(List<Object>, Class<DT>, FI.Apply2<Object, DT, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
-
- matchEvent(List<Object>, FI.Apply2<Object, D, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
-
- matchEventEquals(E, Class<DT>, FI.Apply2<E, DT, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
-
- matchEventEquals(E, FI.Apply2<E, D, FSM.State<S, D>>) - Method in class akka.actor.AbstractFSM
-
- matchingRole(Member) - Method in class akka.cluster.client.ClusterReceptionist
-
- matchingRole(Member) - Method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- matchingRole(Member) - Method in class akka.cluster.sharding.ShardRegion
-
- matchingRole(Member) - Method in class akka.cluster.singleton.ClusterSingletonProxy
-
- matchState(S, S, FI.UnitApplyVoid) - Method in class akka.actor.AbstractFSM
-
- matchState(S, S, FI.UnitApply2<S, S>) - Method in class akka.actor.AbstractFSM
-
- matchStop(FSM.Reason, FI.UnitApply2<S, D>) - Method in class akka.actor.AbstractFSM
-
- matchStop(Class<RT>, FI.UnitApply3<RT, S, D>) - Method in class akka.actor.AbstractFSM
-
- matchStop(Class<RT>, FI.TypedPredicate<RT>, FI.UnitApply3<RT, S, D>) - Method in class akka.actor.AbstractFSM
-
- max() - Method in class akka.cluster.metrics.StandardMetrics.HeapMemory
-
- max() - Method in class akka.cluster.StandardMetrics.HeapMemory
-
- max() - Method in class akka.persistence.journal.AsyncWriteTarget.ReplayMessages
-
- max() - Method in class akka.persistence.JournalProtocol.ReplayMessages
-
- maxCapacity() - Method in class akka.util.BoundedBlockingQueue
-
- MaxChannels() - Method in class akka.io.SelectionHandlerSettings
-
- MaxChannelsPerSelector() - Method in class akka.io.SelectionHandlerSettings
-
- MaxChannelsPerSelector() - Method in class akka.io.TcpExt.Settings
-
- MaxChannelsPerSelector() - Method in class akka.io.Udp.UdpSettings
-
- maxCount() - Method in class akka.event.DeadLetterListener
-
- maxDeletionBatchSize() - Method in class akka.persistence.PersistenceSettings.journal
-
- maxDeltaElements() - Method in class akka.cluster.pubsub.DistributedPubSubSettings
-
- MaxDirectBufferPoolSize() - Method in class akka.io.TcpExt.Settings
-
- MaxDirectBufferPoolSize() - Method in class akka.io.Udp.UdpSettings
-
- MaxFrameSize() - Method in class akka.remote.transport.netty.NettyTransportSettings
-
- maxFrequency() - Method in class akka.actor.AbstractScheduler
-
The maximum supported task frequency of this scheduler, i.e.
- maxFrequency() - Method in class akka.actor.LightArrayRevolverScheduler
-
- maxFrequency() - Method in interface akka.actor.Scheduler
-
The maximum supported task frequency of this scheduler, i.e.
- maxHandOverRetries() - Method in class akka.cluster.singleton.ClusterSingletonManagerSettings
-
- maximumOverhead() - Method in class akka.remote.transport.AbstractTransportAdapter
-
- maximumOverhead() - Method in class akka.remote.transport.AkkaProtocolTransport
-
- maximumOverhead() - Method in class akka.remote.transport.FailureInjectorTransportAdapter
-
- maximumOverhead() - Method in class akka.remote.transport.ThrottlerTransportAdapter
-
- maximumPayloadBytes() - Method in class akka.remote.transport.AbstractTransportAdapter
-
- maximumPayloadBytes() - Method in class akka.remote.transport.netty.NettyTransport
-
- maximumPayloadBytes() - Method in class akka.remote.transport.TestTransport
-
- maximumPayloadBytes() - Method in interface akka.remote.transport.Transport
-
Defines the maximum size of payload this transport is able to deliver.
- maxInstancesPerNode() - Method in class akka.cluster.routing.ClusterRouterPoolSettings
-
- maxMessageBatchSize() - Method in interface akka.persistence.Eventsourced
-
- maxMessageBatchSize() - Method in class akka.persistence.PersistenceSettings.journal
-
- maxNodes() - Method in class akka.remote.testkit.MultiNodeSpec$
-
Number of nodes node taking part in this test.
- maxNodes() - Static method in class akka.remote.testkit.MultiNodeSpec
-
Number of nodes node taking part in this test.
- maxNrOfRetries() - Method in class akka.actor.AllForOneStrategy
-
- maxNrOfRetries() - Method in class akka.actor.OneForOneStrategy
-
- maxNrOfRetriesCount() - Method in class akka.actor.ChildRestartStats
-
- maxNrOfRetriesOption(int) - Method in class akka.actor.SupervisorStrategy$
-
- maxNrOfRetriesOption(int) - Static method in class akka.actor.SupervisorStrategy
-
- maxPoolSize() - Method in class akka.dispatch.ThreadPoolConfig
-
- maxResendRate() - Method in class akka.remote.ReliableDeliverySupervisor
-
- maxSampleSize() - Method in class akka.remote.HeartbeatHistory
-
- maxSampleSize() - Method in class akka.remote.PhiAccrualFailureDetector
-
- maxSeq() - Method in class akka.remote.AckedSendBuffer
-
- maxSequenceNr() - Method in class akka.persistence.SnapshotSelectionCriteria
-
- maxTakeOverRetries() - Method in class akka.cluster.singleton.ClusterSingletonManagerSettings
-
- maxTimestamp() - Method in class akka.persistence.SnapshotSelectionCriteria
-
- maxUnconfirmedMessages() - Method in interface akka.persistence.AtLeastOnceDelivery
-
Maximum number of unconfirmed messages that this actor is allowed to hold in memory.
- maxUnconfirmedMessages() - Method in class akka.persistence.PersistenceSettings.atLeastOnceDelivery
-
- MaxUnconfirmedMessagesExceededException(String) - Constructor for exception akka.persistence.AtLeastOnceDelivery.MaxUnconfirmedMessagesExceededException
-
- maxWriteCount() - Method in class akka.remote.EndpointWriter
-
- md5(String) - Method in class akka.util.Crypt$
-
- md5(byte[]) - Method in class akka.util.Crypt$
-
- md5(String) - Static method in class akka.util.Crypt
-
- md5(byte[]) - Static method in class akka.util.Crypt
-
- mdc(Object) - Method in interface akka.actor.DiagnosticActorLogging
-
- mdc() - Method in interface akka.event.DiagnosticLoggingAdapter
-
Scala API:
Mapped Diagnostic Context for application defined values
which can be used in PatternLayout when akka.event.slf4j.Slf4jLogger
is configured.
- mdc(Map<String, Object>) - Method in interface akka.event.DiagnosticLoggingAdapter
-
Scala API:
Sets the values to be added to the MDC (Mapped Diagnostic Context) before the log is appended.
- mdc() - Method in class akka.event.Logging.Debug2
-
- mdc() - Method in class akka.event.Logging.Error2
-
- mdc() - Method in class akka.event.Logging.Info2
-
- mdc() - Method in interface akka.event.Logging.LogEvent
-
Extra values for adding to MDC
- mdc() - Method in class akka.event.Logging.Warning2
-
- mdc() - Method in interface akka.event.LoggingAdapter
-
- mdcActorSystemAttributeName() - Method in class akka.event.slf4j.Slf4jLogger
-
- mdcAkkaSourceAttributeName() - Method in class akka.event.slf4j.Slf4jLogger
-
- mdcAkkaTimestamp() - Method in class akka.event.slf4j.Slf4jLogger
-
- mdcThreadAttributeName() - Method in class akka.event.slf4j.Slf4jLogger
-
- mean() - Method in class akka.remote.HeartbeatHistory
-
- measure(Function1<Duration, String>, Function0<BoxedUnit>) - Method in class akka.persistence.journal.JournalPerfSpec
-
Executes a block of code multiple times (no warmup)
- measurementIterations() - Method in class akka.persistence.journal.JournalPerfSpec
-
Number of measurement iterations each test will be run.
- mediator() - Method in class akka.cluster.pubsub.DistributedPubSub
-
- MediatorRouterEnvelope(Object) - Constructor for class akka.cluster.pubsub.DistributedPubSubMediator.Internal$.MediatorRouterEnvelope
-
- member() - Method in interface akka.cluster.ClusterEvent.MemberEvent
-
- member() - Method in class akka.cluster.ClusterEvent.MemberExited
-
- member() - Method in class akka.cluster.ClusterEvent.MemberRemoved
-
- member() - Method in class akka.cluster.ClusterEvent.MemberUp
-
- member() - Method in class akka.cluster.ClusterEvent.ReachableMember
-
- member() - Method in class akka.cluster.ClusterEvent.UnreachableMember
-
- member(UniqueAddress) - Method in class akka.cluster.Gossip
-
- Member - Class in akka.cluster
-
Represents the address, current status, and roles of a cluster member node.
- Member(UniqueAddress, int, MemberStatus, Set<String>) - Constructor for class akka.cluster.Member
-
- Member$ - Class in akka.cluster
-
Module with factory and ordering methods for Member instances.
- Member$() - Constructor for class akka.cluster.Member$
-
- MemberExited(Member) - Constructor for class akka.cluster.ClusterEvent.MemberExited
-
- MemberExited$() - Constructor for class akka.cluster.ClusterEvent.MemberExited$
-
- MemberRemoved(Member, MemberStatus) - Constructor for class akka.cluster.ClusterEvent.MemberRemoved
-
- MemberRemoved$() - Constructor for class akka.cluster.ClusterEvent.MemberRemoved$
-
- members() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
-
- members() - Method in class akka.cluster.ClusterReadView
-
Current cluster members, sorted by address.
- members() - Method in class akka.cluster.Gossip
-
- MEMBERS_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Gossip
-
- membersByAge() - Method in class akka.cluster.sharding.ShardRegion
-
- membersByAge() - Method in class akka.cluster.singleton.ClusterSingletonProxy
-
- MemberStatus - Class in akka.cluster
-
Defines the current status of a cluster member node
- MemberStatus() - Constructor for class akka.cluster.MemberStatus
-
- MemberStatus$ - Class in akka.cluster
-
- MemberStatus$() - Constructor for class akka.cluster.MemberStatus$
-
- MemberStatus.Down$ - Class in akka.cluster
-
- MemberStatus.Exiting$ - Class in akka.cluster
-
- MemberStatus.Joining$ - Class in akka.cluster
-
- MemberStatus.Leaving$ - Class in akka.cluster
-
- MemberStatus.Removed$ - Class in akka.cluster
-
- MemberStatus.Up$ - Class in akka.cluster
-
- MemberUp(Member) - Constructor for class akka.cluster.ClusterEvent.MemberUp
-
- MemberUp$() - Constructor for class akka.cluster.ClusterEvent.MemberUp$
-
- Merge() - Method in class akka.cluster.ClusterCoreDaemon
-
- Merge() - Constructor for class akka.cluster.ClusterCoreDaemon.Merge
-
- merge(Gossip) - Method in class akka.cluster.Gossip
-
Merges two Gossip instances including membership tables, and the VectorClock histories.
- merge(MetricsGossip) - Method in class akka.cluster.metrics.MetricsGossip
-
Adds new remote
NodeMetrics
and merges existing from a remote gossip.
- merge(NodeMetrics) - Method in class akka.cluster.metrics.NodeMetrics
-
Returns the most recent data.
- merge(MetricsGossip) - Method in class akka.cluster.MetricsGossip
-
Adds new remote
NodeMetrics
and merges existing from a remote gossip.
- merge(NodeMetrics) - Method in class akka.cluster.NodeMetrics
-
Returns the most recent data.
- merge(Set<UniqueAddress>, Reachability) - Method in class akka.cluster.Reachability
-
- merge(VectorClock) - Method in class akka.cluster.VectorClock
-
Merges this VectorClock with another VectorClock.
- mergeAck(WireFormats.AcknowledgementInfo) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
optional .AcknowledgementInfo ack = 1;
- mergeAddr(TestConductorProtocol.Address) - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
-
optional .Address addr = 2;
- mergeAddr(TestConductorProtocol.AddressRequest) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .AddressRequest addr = 5;
- mergeAddress(ClusterMessages.Address) - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
-
required .Address address = 1;
- mergeAddress(DistributedPubSubMessages.Address) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
-
required .Address address = 1;
- mergeAddress(TestConductorProtocol.Address) - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
-
required .Address address = 2;
- mergeAddress(TestConductorProtocol.Address) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
optional .Address address = 3;
- mergeBarrier(TestConductorProtocol.EnterBarrier) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .EnterBarrier barrier = 2;
- mergeCount() - Method in class akka.cluster.GossipStats
-
- mergeDeploy(WireFormats.DeployData) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required .DeployData deploy = 2;
- mergeDeploy(WireFormats.DeployData) - Method in class akka.remote.WireFormats.PropsData.Builder
-
required .DeployData deploy = 2;
- mergeEnvelope(WireFormats.RemoteEnvelope) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
optional .RemoteEnvelope envelope = 2;
- mergeEwma(ClusterMetricsMessages.NodeMetrics.EWMA) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
optional .NodeMetrics.EWMA ewma = 3;
- mergeEwma(ClusterMessages.NodeMetrics.EWMA) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
optional .NodeMetrics.EWMA ewma = 3;
- mergeFailure(TestConductorProtocol.InjectFailure) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .InjectFailure failure = 3;
- mergeFrom(Message) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
- mergeFrom(ClusterMetricsMessages.Address) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
- mergeFrom(ClusterMetricsMessages.MetricsGossip) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
- mergeFrom(ClusterMetricsMessages.MetricsGossipEnvelope) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
- mergeFrom(ClusterMetricsMessages.Address) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
required .Address from = 1;
- mergeFrom(Message) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
- mergeFrom(ClusterMetricsMessages.NodeMetrics) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA.Builder
-
- mergeFrom(ClusterMetricsMessages.NodeMetrics.EWMA) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
- mergeFrom(ClusterMetricsMessages.NodeMetrics.Metric) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number.Builder
-
- mergeFrom(ClusterMetricsMessages.NodeMetrics.Number) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
- mergeFrom(ClusterMessages.Address) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty.Builder
-
- mergeFrom(ClusterMessages.Empty) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Empty.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
- mergeFrom(ClusterMessages.Gossip) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
- mergeFrom(ClusterMessages.GossipEnvelope) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
- mergeFrom(ClusterMessages.UniqueAddress) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
required .UniqueAddress from = 1;
- mergeFrom(Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
- mergeFrom(ClusterMessages.GossipOverview) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
- mergeFrom(ClusterMessages.GossipStatus) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
- mergeFrom(ClusterMessages.UniqueAddress) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
required .UniqueAddress from = 1;
- mergeFrom(Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
-
- mergeFrom(ClusterMessages.Join) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
- mergeFrom(ClusterMessages.Member) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
- mergeFrom(ClusterMessages.MetricsGossip) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
- mergeFrom(ClusterMessages.MetricsGossipEnvelope) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
- mergeFrom(ClusterMessages.Address) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
required .Address from = 1;
- mergeFrom(Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
- mergeFrom(ClusterMessages.NodeMetrics) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
-
- mergeFrom(ClusterMessages.NodeMetrics.EWMA) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
- mergeFrom(ClusterMessages.NodeMetrics.Metric) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
-
- mergeFrom(ClusterMessages.NodeMetrics.Number) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
- mergeFrom(ClusterMessages.ObserverReachability) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
-
- mergeFrom(ClusterMessages.SubjectReachability) - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
-
- mergeFrom(ClusterMessages.UniqueAddress) - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
- mergeFrom(ClusterMessages.VectorClock) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
-
- mergeFrom(ClusterMessages.VectorClock.Version) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
-
- mergeFrom(ClusterMessages.Welcome) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
-
- mergeFrom(ClusterMessages.UniqueAddress) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
-
required .UniqueAddress from = 1;
- mergeFrom(Message) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
- mergeFrom(DistributedPubSubMessages.Address) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
- mergeFrom(DistributedPubSubMessages.Delta.Bucket) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Builder
-
- mergeFrom(DistributedPubSubMessages.Delta) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
- mergeFrom(DistributedPubSubMessages.Delta.Entry) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload.Builder
-
- mergeFrom(DistributedPubSubMessages.Payload) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish.Builder
-
- mergeFrom(DistributedPubSubMessages.Publish) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
- mergeFrom(DistributedPubSubMessages.Send) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
-
- mergeFrom(DistributedPubSubMessages.SendToAll) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
- mergeFrom(DistributedPubSubMessages.Status) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
-
- mergeFrom(DistributedPubSubMessages.Status.Version) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
-
- mergeFrom(Message) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
- mergeFrom(MessageFormats.AtLeastOnceDeliverySnapshot) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
- mergeFrom(Message) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
- mergeFrom(MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
- mergeFrom(Message) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
- mergeFrom(MessageFormats.PersistentMessage) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
- mergeFrom(Message) - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
-
- mergeFrom(MessageFormats.PersistentPayload) - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
-
- mergeFrom(AckedReceiveBuffer<T>) - Method in class akka.remote.AckedReceiveBuffer
-
Merges two receive buffers.
- mergeFrom(Message) - Method in class akka.remote.ContainerFormats.Selection.Builder
-
- mergeFrom(ContainerFormats.Selection) - Method in class akka.remote.ContainerFormats.Selection.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.ContainerFormats.Selection.Builder
-
- mergeFrom(Message) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
- mergeFrom(ContainerFormats.SelectionEnvelope) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
- mergeFrom(Message) - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
- mergeFrom(TestConductorProtocol.Address) - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
- mergeFrom(Message) - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
-
- mergeFrom(TestConductorProtocol.AddressRequest) - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
-
- mergeFrom(Message) - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
-
- mergeFrom(TestConductorProtocol.EnterBarrier) - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
-
- mergeFrom(Message) - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
-
- mergeFrom(TestConductorProtocol.Hello) - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
-
- mergeFrom(Message) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
- mergeFrom(TestConductorProtocol.InjectFailure) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
- mergeFrom(Message) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
- mergeFrom(TestConductorProtocol.Wrapper) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
- mergeFrom(Message) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
- mergeFrom(WireFormats.AckAndEnvelopeContainer) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
- mergeFrom(Message) - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
-
- mergeFrom(WireFormats.AcknowledgementInfo) - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
-
- mergeFrom(Message) - Method in class akka.remote.WireFormats.ActorRefData.Builder
-
- mergeFrom(WireFormats.ActorRefData) - Method in class akka.remote.WireFormats.ActorRefData.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.WireFormats.ActorRefData.Builder
-
- mergeFrom(Message) - Method in class akka.remote.WireFormats.AddressData.Builder
-
- mergeFrom(WireFormats.AddressData) - Method in class akka.remote.WireFormats.AddressData.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.WireFormats.AddressData.Builder
-
- mergeFrom(Message) - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
-
- mergeFrom(WireFormats.AkkaControlMessage) - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
-
- mergeFrom(Message) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
- mergeFrom(WireFormats.AkkaHandshakeInfo) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
- mergeFrom(Message) - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
-
- mergeFrom(WireFormats.AkkaProtocolMessage) - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
-
- mergeFrom(Message) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
- mergeFrom(WireFormats.DaemonMsgCreateData) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
- mergeFrom(Message) - Method in class akka.remote.WireFormats.DeployData.Builder
-
- mergeFrom(WireFormats.DeployData) - Method in class akka.remote.WireFormats.DeployData.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.WireFormats.DeployData.Builder
-
- mergeFrom(Message) - Method in class akka.remote.WireFormats.PropsData.Builder
-
- mergeFrom(WireFormats.PropsData) - Method in class akka.remote.WireFormats.PropsData.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.WireFormats.PropsData.Builder
-
- mergeFrom(Message) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
- mergeFrom(WireFormats.RemoteEnvelope) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
- mergeFrom(Message) - Method in class akka.remote.WireFormats.SerializedMessage.Builder
-
- mergeFrom(WireFormats.SerializedMessage) - Method in class akka.remote.WireFormats.SerializedMessage.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.WireFormats.SerializedMessage.Builder
-
- mergeGossip(ClusterMetricsMessages.MetricsGossip) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
required .MetricsGossip gossip = 2;
- mergeGossip(ClusterMessages.MetricsGossip) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
required .MetricsGossip gossip = 2;
- mergeGossip(ClusterMessages.Gossip) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
-
required .Gossip gossip = 2;
- mergeHandshakeInfo(WireFormats.AkkaHandshakeInfo) - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
-
optional .AkkaHandshakeInfo handshakeInfo = 2;
- mergeHello(TestConductorProtocol.Hello) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .Hello hello = 1;
- mergeInstruction(WireFormats.AkkaControlMessage) - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
-
optional .AkkaControlMessage instruction = 2;
- mergeMessage(WireFormats.SerializedMessage) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
required .SerializedMessage message = 2;
- mergeNode(ClusterMessages.UniqueAddress) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
-
required .UniqueAddress node = 1;
- mergeNumber(ClusterMetricsMessages.NodeMetrics.Number) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
required .NodeMetrics.Number number = 2;
- mergeNumber(ClusterMessages.NodeMetrics.Number) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
required .NodeMetrics.Number number = 2;
- mergeOrigin(WireFormats.AddressData) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
required .AddressData origin = 1;
- mergeOverview(ClusterMessages.GossipOverview) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
required .GossipOverview overview = 5;
- mergeOwner(DistributedPubSubMessages.Address) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
required .Address owner = 1;
- mergePayload(DistributedPubSubMessages.Payload) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish.Builder
-
required .Payload payload = 3;
- mergePayload(DistributedPubSubMessages.Payload) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
required .Payload payload = 3;
- mergePayload(DistributedPubSubMessages.Payload) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
-
required .Payload payload = 3;
- mergePayload(MessageFormats.PersistentPayload) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
required .PersistentPayload payload = 3;
- mergePayload(MessageFormats.PersistentPayload) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional .PersistentPayload payload = 1;
- mergeProps(WireFormats.PropsData) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required .PropsData props = 1;
- mergeRecipient(WireFormats.ActorRefData) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
required .ActorRefData recipient = 1;
- mergeSeen(Gossip) - Method in class akka.cluster.Gossip
-
Merges the seen table of two Gossip instances.
- mergeSender(WireFormats.ActorRefData) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
optional .ActorRefData sender = 4;
- mergeSupervisor(WireFormats.ActorRefData) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required .ActorRefData supervisor = 4;
- mergeTo(ClusterMessages.UniqueAddress) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
required .UniqueAddress to = 2;
- mergeVersion(ClusterMessages.VectorClock) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
required .VectorClock version = 6;
- mergeVersion(ClusterMessages.VectorClock) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
required .VectorClock version = 3;
- message() - Method in exception akka.actor.ActorKilledException
-
- message() - Method in interface akka.actor.AllDeadLetters
-
- message() - Method in class akka.actor.DeadLetter
-
- message() - Method in exception akka.actor.IllegalActorStateException
-
- message() - Method in exception akka.actor.InvalidActorNameException
-
- message() - Method in exception akka.actor.InvalidMessageException
-
- message() - Method in class akka.actor.SuppressedDeadLetter
-
- message() - Method in class akka.actor.UnhandledMessage
-
- message() - Method in class akka.camel.MessageResult
-
- message() - Method in class akka.cluster.pubsub.DistributedPubSubMediator.Internal$.MediatorRouterEnvelope
-
- Message(Object, ActorRef, int) - Constructor for class akka.contrib.pattern.ReliableProxy.Message
-
- Message(Object, ActorRef) - Constructor for class akka.contrib.throttle.TimerBasedThrottler.Message
-
- message() - Method in class akka.contrib.throttle.TimerBasedThrottler.Message
-
- message() - Method in class akka.dispatch.Envelope
-
- message() - Method in class akka.event.Logging.Debug
-
- message() - Method in class akka.event.Logging.Error
-
- message() - Method in class akka.event.Logging.Info
-
- message() - Method in interface akka.event.Logging.LogEvent
-
The message, may be any object or null.
- message() - Method in class akka.event.Logging.Warning
-
- message() - Method in class akka.persistence.AtLeastOnceDelivery.Internal$.Delivery
-
- message() - Method in class akka.persistence.AtLeastOnceDelivery.UnconfirmedDelivery
-
- message() - Method in class akka.persistence.JournalProtocol.LoopMessageSuccess
-
- message() - Method in class akka.persistence.JournalProtocol.WriteMessageFailure
-
- Message - Interface in akka.persistence.serialization
-
Marker trait for all protobuf-serializable messages in akka.persistence
.
- message() - Method in class akka.remote.EndpointManager.Send
-
- Message(InternalActorRef, Address, WireFormats.SerializedMessage, Option<ActorRef>, Option<SeqNo>) - Constructor for class akka.remote.transport.AkkaPduCodec.Message
-
- message() - Method in class akka.routing.Broadcast
-
- message() - Method in class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope
-
- message() - Method in interface akka.routing.RouterEnvelope
-
- message() - Method in class akka.testkit.DebugFilter
-
- message() - Method in class akka.testkit.ErrorFilter
-
- message() - Method in class akka.testkit.EventFilter
-
- message() - Method in class akka.testkit.InfoFilter
-
- message(String) - Method in class akka.testkit.JavaTestKit.EventFilter
-
- message() - Method in class akka.testkit.WarningFilter
-
- message(ActorContext<Object>, Object) - Method in class akka.typed.Behavior.emptyBehavior$
-
- message(ActorContext<Object>, Object) - Method in class akka.typed.Behavior.ignoreBehavior$
-
- message(ActorContext<T>, T) - Method in class akka.typed.Behavior
-
Process an incoming message and return the next behavior.
- message(ActorContext<Nothing$>, Nothing$) - Method in class akka.typed.Behavior.sameBehavior$
-
- message(ActorContext<Nothing$>, Nothing$) - Method in class akka.typed.Behavior.stoppedBehavior$
-
- message(ActorContext<Nothing$>, Nothing$) - Method in class akka.typed.Behavior.unhandledBehavior$
-
- message(ActorContext<T>, T) - Method in class akka.typed.ScalaDSL.And
-
- message(ActorContext<T>, T) - Method in class akka.typed.ScalaDSL.Full
-
- message(ActorContext<T>, T) - Method in class akka.typed.ScalaDSL.FullTotal
-
- message(ActorContext<T>, T) - Method in class akka.typed.ScalaDSL.Or
-
- message(ActorContext<T>, T) - Method in class akka.typed.ScalaDSL.Partial
-
- message(ActorContext<T>, T) - Method in class akka.typed.ScalaDSL.Static
-
- message(ActorContext<T>, T) - Method in class akka.typed.ScalaDSL.SynchronousSelf
-
- message(ActorContext<T>, T) - Method in class akka.typed.ScalaDSL.Tap
-
- message(ActorContext<T>, T) - Method in class akka.typed.ScalaDSL.Total
-
- message(ActorContext<U>, U) - Method in class akka.typed.ScalaDSL.Widened
-
- Message$() - Constructor for class akka.contrib.pattern.ReliableProxy.Message$
-
- Message$() - Constructor for class akka.contrib.throttle.TimerBasedThrottler.Message$
-
- Message$() - Constructor for class akka.remote.transport.AkkaPduCodec.Message$
-
- MESSAGE_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.RemoteEnvelope
-
- MESSAGE_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.SerializedMessage
-
- messageBuffers() - Method in class akka.cluster.sharding.Shard
-
- messageClass() - Method in class akka.testkit.DeadLettersFilter
-
- messageClassName() - Method in class akka.pattern.PromiseActorRef
-
- MessageContainerSerializer - Class in akka.remote.serialization
-
- MessageContainerSerializer(ExtendedActorSystem) - Constructor for class akka.remote.serialization.MessageContainerSerializer
-
- MessageContainerSerializer() - Constructor for class akka.remote.serialization.MessageContainerSerializer
-
- Messaged(ActorRef<U>, U) - Constructor for class akka.typed.Effect.Messaged
-
- Messaged$() - Constructor for class akka.typed.Effect.Messaged$
-
- MessageDispatcher - Class in akka.dispatch
-
- MessageDispatcher(MessageDispatcherConfigurator) - Constructor for class akka.dispatch.MessageDispatcher
-
- MessageDispatcher$ - Class in akka.dispatch
-
INTERNAL API
- MessageDispatcher$() - Constructor for class akka.dispatch.MessageDispatcher$
-
- MessageDispatcherConfigurator - Class in akka.dispatch
-
Base class to be used for hooking in new dispatchers into Dispatchers.
- MessageDispatcherConfigurator(Config, DispatcherPrerequisites) - Constructor for class akka.dispatch.MessageDispatcherConfigurator
-
- MessageExchangeId() - Method in class akka.camel.CamelMessage$
-
CamelMessage header to correlate request with response messages.
- MessageExchangeId() - Static method in class akka.camel.CamelMessage
-
CamelMessage header to correlate request with response messages.
- messageFormat() - Method in class akka.osgi.DefaultOSGiLogger
-
- MessageFormats - Class in akka.persistence.serialization
-
- MessageFormats.AtLeastOnceDeliverySnapshot - Class in akka.persistence.serialization
-
Protobuf type AtLeastOnceDeliverySnapshot
- MessageFormats.AtLeastOnceDeliverySnapshot.Builder - Class in akka.persistence.serialization
-
Protobuf type AtLeastOnceDeliverySnapshot
- MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery - Class in akka.persistence.serialization
-
Protobuf type AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
- MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder - Class in akka.persistence.serialization
-
Protobuf type AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
- MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder - Interface in akka.persistence.serialization
-
- MessageFormats.AtLeastOnceDeliverySnapshotOrBuilder - Interface in akka.persistence.serialization
-
- MessageFormats.PersistentMessage - Class in akka.persistence.serialization
-
Protobuf type PersistentMessage
- MessageFormats.PersistentMessage.Builder - Class in akka.persistence.serialization
-
Protobuf type PersistentMessage
- MessageFormats.PersistentMessageOrBuilder - Interface in akka.persistence.serialization
-
- MessageFormats.PersistentPayload - Class in akka.persistence.serialization
-
Protobuf type PersistentPayload
- MessageFormats.PersistentPayload.Builder - Class in akka.persistence.serialization
-
Protobuf type PersistentPayload
- MessageFormats.PersistentPayloadOrBuilder - Interface in akka.persistence.serialization
-
- messageId() - Method in class akka.actor.Identify
-
- MESSAGEMANIFEST_FIELD_NUMBER - Static variable in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload
-
- MESSAGEMANIFEST_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.SelectionEnvelope
-
- MESSAGEMANIFEST_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.SerializedMessage
-
- messageOption() - Method in exception akka.actor.PreRestartException
-
- messagePredicate() - Method in class akka.actor.dsl.Inbox.InboxActor
-
- messageQueue() - Method in class akka.dispatch.BalancingDispatcher
-
INTERNAL API
- MessageQueue(int, FiniteDuration) - Constructor for class akka.dispatch.BoundedControlAwareMailbox.MessageQueue
-
- MessageQueue(int, FiniteDuration) - Constructor for class akka.dispatch.BoundedDequeBasedMailbox.MessageQueue
-
- MessageQueue(int, FiniteDuration) - Constructor for class akka.dispatch.BoundedMailbox.MessageQueue
-
- MessageQueue(int, Comparator<Envelope>, Duration) - Constructor for class akka.dispatch.BoundedPriorityMailbox.MessageQueue
-
- MessageQueue(int, Comparator<Envelope>, Duration) - Constructor for class akka.dispatch.BoundedStablePriorityMailbox.MessageQueue
-
- messageQueue() - Method in class akka.dispatch.Mailbox
-
- MessageQueue - Interface in akka.dispatch
-
A MessageQueue is one of the core components in forming an Akka Mailbox.
- MessageQueue() - Constructor for class akka.dispatch.UnboundedControlAwareMailbox.MessageQueue
-
- MessageQueue() - Constructor for class akka.dispatch.UnboundedDequeBasedMailbox.MessageQueue
-
- MessageQueue() - Constructor for class akka.dispatch.UnboundedMailbox.MessageQueue
-
- MessageQueue(int, Comparator<Envelope>) - Constructor for class akka.dispatch.UnboundedPriorityMailbox.MessageQueue
-
- MessageQueue(int, Comparator<Envelope>) - Constructor for class akka.dispatch.UnboundedStablePriorityMailbox.MessageQueue
-
- messageQueue() - Method in class akka.testkit.CallingThreadMailbox
-
This is only a marker to be put in the messageQueue’s stead to make error
messages pertaining to violated mailbox type requirements less cryptic.
- messageReceived(ChannelHandlerContext, MessageEvent) - Method in class akka.remote.testconductor.ConductorHandler
-
- messageReceived(ChannelHandlerContext, MessageEvent) - Method in class akka.remote.testconductor.PlayerHandler
-
- messageReceived(ChannelHandlerContext, MessageEvent) - Method in interface akka.remote.transport.netty.NettyClientHelpers
-
- messageReceived(ChannelHandlerContext, MessageEvent) - Method in interface akka.remote.transport.netty.NettyServerHelpers
-
- MessageResult - Class in akka.camel
-
INTERNAL API
- MessageResult(CamelMessage) - Constructor for class akka.camel.MessageResult
-
- MessageResult$ - Class in akka.camel
-
- MessageResult$() - Constructor for class akka.camel.MessageResult$
-
- messages() - Method in class akka.actor.dsl.Inbox.InboxActor
-
- messages() - Method in class akka.persistence.journal.AsyncWriteTarget.WriteMessages
-
- messages() - Method in interface akka.persistence.journal.inmem.InmemMessages
-
- messages() - Method in class akka.persistence.JournalProtocol.WriteMessages
-
- MessageSerializer - Class in akka.cluster.metrics.protobuf
-
- MessageSerializer(ExtendedActorSystem) - Constructor for class akka.cluster.metrics.protobuf.MessageSerializer
-
- MessageSerializer - Class in akka.persistence.serialization
-
- MessageSerializer(ExtendedActorSystem) - Constructor for class akka.persistence.serialization.MessageSerializer
-
- MessageSerializer - Class in akka.remote
-
INTERNAL API
- MessageSerializer() - Constructor for class akka.remote.MessageSerializer
-
- MessageSerializer$ - Class in akka.remote
-
INTERNAL API
- MessageSerializer$() - Constructor for class akka.remote.MessageSerializer$
-
- messagesPerResize() - Method in class akka.routing.DefaultResizer
-
- MessageWrapper - Class in akka.typed
-
INTERNAL API.
- MessageWrapper(Function1<Object, Object>) - Constructor for class akka.typed.MessageWrapper
-
- metadata() - Method in class akka.persistence.SaveSnapshotFailure
-
- metadata() - Method in class akka.persistence.SaveSnapshotSuccess
-
- metadata() - Method in class akka.persistence.SelectedSnapshot
-
- metadata() - Method in class akka.persistence.SnapshotOffer
-
- metadata() - Method in class akka.persistence.SnapshotProtocol.DeleteSnapshot
-
- metadata() - Method in class akka.persistence.SnapshotProtocol.SaveSnapshot
-
- method() - Method in class akka.actor.TypedActor.MethodCall
-
- MethodCall(Method, Object[]) - Constructor for class akka.actor.TypedActor.MethodCall
-
- MethodCall$() - Constructor for class akka.actor.TypedActor.MethodCall$
-
- methodName() - Method in class akka.actor.TypedActor.SerializedMethodCall
-
- Metric - Class in akka.cluster
-
Metrics key/value.
- Metric(String, Number, Option<EWMA>) - Constructor for class akka.cluster.Metric
-
- Metric - Class in akka.cluster.metrics
-
Metrics key/value.
- Metric(String, Number, Option<EWMA>) - Constructor for class akka.cluster.metrics.Metric
-
- metric(String) - Method in class akka.cluster.metrics.NodeMetrics
-
- metric(String) - Method in class akka.cluster.NodeMetrics
-
- Metric$ - Class in akka.cluster
-
Factory for creating valid Metric instances.
- Metric$() - Constructor for class akka.cluster.Metric$
-
- Metric$ - Class in akka.cluster.metrics
-
Factory for creating valid Metric instances.
- Metric$() - Constructor for class akka.cluster.metrics.Metric$
-
- MetricNumericConverter - Interface in akka.cluster
-
INTERNAL API
- MetricNumericConverter - Interface in akka.cluster.metrics
-
INTERNAL API
- metrics() - Method in class akka.cluster.JmxMetricsCollector
-
- metrics() - Method in class akka.cluster.metrics.ClusterMetricsCollector
-
- metrics() - Method in class akka.cluster.metrics.ClusterMetricsSupervisor
-
- metrics() - Method in class akka.cluster.metrics.JmxMetricsCollector
-
Generate metrics set.
- metrics() - Method in class akka.cluster.metrics.NodeMetrics
-
- metrics() - Method in class akka.cluster.metrics.SigarMetricsCollector
-
- metrics() - Method in class akka.cluster.NodeMetrics
-
- metrics() - Method in class akka.cluster.SigarMetricsCollector
-
- METRICS_FIELD_NUMBER - Static variable in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics
-
- METRICS_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics
-
- metricsChanged(ClusterMetricsChanged) - Method in class akka.cluster.metrics.AdaptiveLoadBalancingRoutingLogic
-
- metricsChanged(ClusterEvent.ClusterMetricsChanged) - Method in class akka.cluster.routing.AdaptiveLoadBalancingRoutingLogic
-
- MetricsCollector - Interface in akka.cluster.metrics
-
Metrics sampler.
- MetricsCollector - Interface in akka.cluster
-
Implementations of cluster system metrics extends this trait.
- MetricsCollector$ - Class in akka.cluster.metrics
-
INTERNAL API
- MetricsCollector$() - Constructor for class akka.cluster.metrics.MetricsCollector$
-
- MetricsCollector$ - Class in akka.cluster
-
INTERNAL API
Factory to create configured MetricsCollector.
- MetricsCollector$() - Constructor for class akka.cluster.MetricsCollector$
-
- MetricsCollectorClass() - Method in class akka.cluster.ClusterSettings
-
- metricsDecider() - Method in class akka.cluster.metrics.ClusterMetricsStrategy$
-
SupervisorStrategy
Decider
which allows to survive intermittent Sigar native method calls failures.
- metricsDecider() - Static method in class akka.cluster.metrics.ClusterMetricsStrategy
-
SupervisorStrategy
Decider
which allows to survive intermittent Sigar native method calls failures.
- MetricsDispatcher() - Method in class akka.cluster.metrics.ClusterMetricsSettings
-
- MetricsEnabled() - Method in class akka.cluster.ClusterSettings
-
- MetricsGossip - Class in akka.cluster.metrics
-
- MetricsGossip(Set<NodeMetrics>) - Constructor for class akka.cluster.metrics.MetricsGossip
-
- MetricsGossip - Class in akka.cluster
-
- MetricsGossip(Set<NodeMetrics>) - Constructor for class akka.cluster.MetricsGossip
-
- MetricsGossip$ - Class in akka.cluster.metrics
-
INTERNAL API
- MetricsGossip$() - Constructor for class akka.cluster.metrics.MetricsGossip$
-
- MetricsGossip$ - Class in akka.cluster
-
INTERNAL API
- MetricsGossip$() - Constructor for class akka.cluster.MetricsGossip$
-
- MetricsGossipEnvelope - Class in akka.cluster.metrics
-
INTERNAL API.
- MetricsGossipEnvelope(Address, MetricsGossip, boolean) - Constructor for class akka.cluster.metrics.MetricsGossipEnvelope
-
- MetricsGossipEnvelope - Class in akka.cluster
-
INTERNAL API
Envelope adding a sender address to the gossip.
- MetricsGossipEnvelope(Address, MetricsGossip, boolean) - Constructor for class akka.cluster.MetricsGossipEnvelope
-
- MetricsGossipEnvelope$ - Class in akka.cluster.metrics
-
- MetricsGossipEnvelope$() - Constructor for class akka.cluster.metrics.MetricsGossipEnvelope$
-
- MetricsGossipEnvelope$ - Class in akka.cluster
-
- MetricsGossipEnvelope$() - Constructor for class akka.cluster.MetricsGossipEnvelope$
-
- MetricsGossipInterval() - Method in class akka.cluster.ClusterSettings
-
- MetricsInterval() - Method in class akka.cluster.ClusterSettings
-
- MetricsMovingAverageHalfLife() - Method in class akka.cluster.ClusterSettings
-
- metricsSelector() - Method in class akka.cluster.metrics.AdaptiveLoadBalancingGroup
-
- metricsSelector() - Method in class akka.cluster.metrics.AdaptiveLoadBalancingPool
-
- metricsSelector() - Method in class akka.cluster.metrics.AdaptiveLoadBalancingRoutingLogic
-
- MetricsSelector - Interface in akka.cluster.metrics
-
A MetricsSelector is responsible for producing weights from the node metrics.
- metricsSelector() - Method in class akka.cluster.routing.AdaptiveLoadBalancingGroup
-
- metricsSelector() - Method in class akka.cluster.routing.AdaptiveLoadBalancingPool
-
- metricsSelector() - Method in class akka.cluster.routing.AdaptiveLoadBalancingRoutingLogic
-
- MetricsSelector - Interface in akka.cluster.routing
-
A MetricsSelector is responsible for producing weights from the node metrics.
- MetricsSelector$ - Class in akka.cluster.metrics
-
- MetricsSelector$() - Constructor for class akka.cluster.metrics.MetricsSelector$
-
- MetricsSelector$ - Class in akka.cluster.routing
-
- MetricsSelector$() - Constructor for class akka.cluster.routing.MetricsSelector$
-
- metricsTask() - Method in class akka.cluster.ClusterMetricsCollector
-
Start periodic metrics collection
- MetricsTick$() - Constructor for class akka.cluster.InternalClusterAction.MetricsTick$
-
- MinimalActorRef - Interface in akka.actor
-
Trait for ActorRef implementations where all methods contain default stubs.
- MinNrOfMembers() - Method in class akka.cluster.ClusterSettings
-
- MinNrOfMembersOfRole() - Method in class akka.cluster.ClusterSettings
-
- minStdDeviation() - Method in class akka.remote.PhiAccrualFailureDetector
-
- MixMetricsSelector - Class in akka.cluster.metrics
-
- MixMetricsSelector(IndexedSeq<CapacityMetricsSelector>) - Constructor for class akka.cluster.metrics.MixMetricsSelector
-
- MixMetricsSelector - Class in akka.cluster.routing
-
- MixMetricsSelector(IndexedSeq<CapacityMetricsSelector>) - Constructor for class akka.cluster.routing.MixMetricsSelector
-
- MixMetricsSelector$ - Class in akka.cluster.metrics
-
Singleton instance of the default MixMetricsSelector, which uses [akka.cluster.routing.HeapMetricsSelector],
[akka.cluster.routing.CpuMetricsSelector], and [akka.cluster.routing.SystemLoadAverageMetricsSelector]
- MixMetricsSelector$() - Constructor for class akka.cluster.metrics.MixMetricsSelector$
-
- MixMetricsSelector$ - Class in akka.cluster.routing
-
Singleton instance of the default MixMetricsSelector, which uses [akka.cluster.routing.HeapMetricsSelector],
[akka.cluster.routing.CpuMetricsSelector], and [akka.cluster.routing.SystemLoadAverageMetricsSelector]
- MixMetricsSelector$() - Constructor for class akka.cluster.routing.MixMetricsSelector$
-
- MixMetricsSelectorBase - Class in akka.cluster.metrics
-
Base class for MetricsSelector that combines other selectors and aggregates their capacity.
- MixMetricsSelectorBase(IndexedSeq<CapacityMetricsSelector>) - Constructor for class akka.cluster.metrics.MixMetricsSelectorBase
-
- MixMetricsSelectorBase(Iterable<CapacityMetricsSelector>) - Constructor for class akka.cluster.metrics.MixMetricsSelectorBase
-
Java API: construct a mix-selector from a sequence of selectors
- MixMetricsSelectorBase - Class in akka.cluster.routing
-
Base class for MetricsSelector that combines other selectors and aggregates their capacity.
- MixMetricsSelectorBase(IndexedSeq<CapacityMetricsSelector>) - Constructor for class akka.cluster.routing.MixMetricsSelectorBase
-
- MixMetricsSelectorBase(Iterable<CapacityMetricsSelector>) - Constructor for class akka.cluster.routing.MixMetricsSelectorBase
-
Java API: construct a mix-selector from a sequence of selectors
- mkChild(Props, String) - Method in class akka.actor.ActorDSL.Extension
-
- mkKey(ActorRef) - Method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- mkKey(ActorPath) - Method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- mkProps(Class<?>, Function0<Actor>) - Method in interface akka.actor.dsl.Creators
-
- mode() - Method in class akka.persistence.journal.JournalPerfSpec.Cmd
-
- mode() - Method in class akka.remote.transport.FailureInjectorTransportAdapter.All
-
- mode() - Method in class akka.remote.transport.FailureInjectorTransportAdapter.One
-
- mode() - Method in class akka.remote.transport.ThrottlerManager.ListenerAndMode
-
- mode() - Method in class akka.remote.transport.ThrottlerTransportAdapter.SetThrottle
-
- MODULE$ - Static variable in class akka.actor.AbstractActor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.AbstractFSM$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Actor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Actor.emptyBehavior$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Actor.ignoringBehavior$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorCell$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorDSL$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorDSL.Extension$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorIdentity$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorInitializationException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorKilledException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorNotFound$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorPath$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorPathExtractor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorRef$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorSelection$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorSelectionMessage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ActorSystem$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Address$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.AddressFromURIString$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.AddressTerminated$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.AllForOneStrategy$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ChildNameReserved$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ChildRestartStats$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ContextualTypedActorFactory$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.DeadLetter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.DeadLetterActorRef$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.DeathPactException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Deploy$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dsl.Inbox$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dsl.Inbox.Get$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dsl.Inbox.Kick$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dsl.Inbox.Select$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dsl.Inbox.StartWatch$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer.Creation$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer.Recreation$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer.TerminatedChildrenContainer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer.Termination$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dungeon.ChildrenContainer.UserRequest$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.dungeon.ReceiveTimeout$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.$minus$greater$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.CurrentState$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.Event$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.Failure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.LogEntry$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.Normal$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.NullFunction$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.Shutdown$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.State$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.StateTimeout$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.StopEvent$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.SubscribeTransitionCallBack$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.TimeoutMarker$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.Timer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.Transition$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.FSM.UnsubscribeTransitionCallBack$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Identify$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.IllegalActorStateException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Inbox$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.IndirectActorProducer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.InvalidActorNameException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.InvalidMessageException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Kill$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.LightArrayRevolverScheduler$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.LocalActorRefProvider$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.LocalScope$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Nobody$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.NoScopeGiven$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.OneForOneStrategy$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.OriginalRestartException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.PoisonPill$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.PostRestartException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.PreRestartException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Props$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ReceiveTimeout$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.RelativeActorPath$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.RootActorPath$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SchedulerException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SelectChildName$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SelectChildPattern$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SelectParent$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SerializedActorRef$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.StashOverflowException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Status$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Status.Failure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Status.Success$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.StopChild$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SupervisorStrategy$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SupervisorStrategy.Escalate$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SupervisorStrategy.Restart$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SupervisorStrategy.Resume$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SupervisorStrategy.Stop$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SuppressedDeadLetter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SystemGuardian$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SystemGuardian.RegisterTerminationHook$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SystemGuardian.TerminationHook$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.SystemGuardian.TerminationHookDone$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.Terminated$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.TypedActor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.TypedActor.MethodCall$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.TypedActor.SerializedMethodCall$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.TypedActor.SerializedTypedActorInvocationHandler$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.TypedProps$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.UnhandledMessage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.agent.Agent$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.camel.Ack$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.camel.CamelExtension$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.camel.CamelMessage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.camel.Consumer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.camel.ConsumerConfig$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.camel.FailureResult$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.camel.internal.ActivationProtocol$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.camel.internal.ActivationProtocol.ActivationMessage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.camel.internal.ActivationProtocol.EndpointActivated$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.camel.internal.ActivationProtocol.EndpointDeActivated$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.camel.internal.ActivationProtocol.EndpointFailedToActivate$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.camel.internal.ActivationProtocol.EndpointFailedToDeActivate$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.camel.internal.AwaitActivation$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.camel.internal.AwaitDeActivation$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.camel.internal.CamelSupervisor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.camel.internal.CamelSupervisor.AddWatch$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.camel.internal.CamelSupervisor.CamelProducerObjects$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.camel.internal.CamelSupervisor.DeRegister$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.camel.internal.CamelSupervisor.Register$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.camel.internal.component.ActorEndpointPath$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.camel.internal.component.CamelPath$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.camel.internal.component.DurationTypeConverter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.camel.MessageResult$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.AutoDown$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.AutoDown.UnreachableTimeout$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.client.ClusterClient$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.client.ClusterClient.Internal$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.client.ClusterClient.Publish$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.client.ClusterClient.Send$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.client.ClusterClient.SendToAll$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.client.ClusterClientReceptionist$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.client.ClusterClientSettings$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.client.ClusterReceptionist$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.client.ClusterReceptionist.Internal$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.client.ClusterReceptionistSettings$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.Cluster$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterEvent$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterEvent.ClusterMetricsChanged$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterEvent.ClusterShuttingDown$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterEvent.CurrentClusterState$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterEvent.CurrentInternalStats$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterEvent.InitialStateAsEvents$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterEvent.InitialStateAsSnapshot$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterEvent.LeaderChanged$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterEvent.MemberExited$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterEvent.MemberRemoved$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterEvent.MemberUp$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterEvent.ReachabilityChanged$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterEvent.ReachableMember$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterEvent.RoleLeaderChanged$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterEvent.SeenChanged$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterEvent.UnreachableMember$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterHeartbeatSender$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterHeartbeatSender.ExpectedFirstHeartbeat$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterHeartbeatSender.Heartbeat$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterHeartbeatSender.HeartbeatRsp$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterHeartbeatSender.HeartbeatTick$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterHeartbeatSenderState$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterRemoteWatcher$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterScope$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterUserAction$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterUserAction.Down$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterUserAction.JoinTo$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterUserAction.Leave$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.EWMA$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.Gossip$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.GossipEnvelope$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.GossipOverview$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.GossipStats$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.GossipStatus$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.HeartbeatNodeRing$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.InternalClusterAction$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.InternalClusterAction.AddOnMemberRemovedListener$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.InternalClusterAction.AddOnMemberUpListener$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.InternalClusterAction.GetClusterCoreRef$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.InternalClusterAction.GossipSpeedupTick$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.InternalClusterAction.GossipTick$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.InternalClusterAction.InitJoin$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.InternalClusterAction.InitJoinAck$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.InternalClusterAction.InitJoinNack$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.InternalClusterAction.Join$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.InternalClusterAction.JoinSeedNode$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.InternalClusterAction.JoinSeedNodes$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.InternalClusterAction.LeaderActionsTick$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.InternalClusterAction.MetricsTick$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.InternalClusterAction.PublishChanges$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.InternalClusterAction.PublisherCreated$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.InternalClusterAction.PublishEvent$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.InternalClusterAction.PublishStatsTick$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.InternalClusterAction.ReapUnreachableTick$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.InternalClusterAction.SendCurrentClusterState$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.InternalClusterAction.SendGossipTo$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.InternalClusterAction.Subscribe$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.InternalClusterAction.Unsubscribe$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.InternalClusterAction.Welcome$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.Member$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.MemberStatus$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.MemberStatus.Down$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.MemberStatus.Exiting$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.MemberStatus.Joining$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.MemberStatus.Leaving$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.MemberStatus.Removed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.MemberStatus.Up$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.Metric$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.metrics.AdaptiveLoadBalancingGroup$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.metrics.AdaptiveLoadBalancingPool$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.metrics.AdaptiveLoadBalancingRoutingLogic$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.metrics.ClusterMetricsChanged$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.metrics.ClusterMetricsExtension$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.metrics.ClusterMetricsSettings$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.metrics.ClusterMetricsStrategy$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.metrics.CollectionStartMessage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.metrics.CollectionStopMessage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.metrics.CpuMetricsSelector$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.metrics.DefaultSigarProvider$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.metrics.EWMA$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.metrics.HeapMetricsSelector$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.metrics.Metric$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.metrics.MetricsCollector$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.metrics.MetricsGossip$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.metrics.MetricsGossipEnvelope$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.metrics.MetricsSelector$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.metrics.MixMetricsSelector$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.metrics.NodeMetrics$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.metrics.SigarProvider$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.metrics.StandardMetrics$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.metrics.StandardMetrics.Cpu$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.metrics.StandardMetrics.HeapMemory$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.metrics.SystemLoadAverageMetricsSelector$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.metrics.TryNative$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.MetricsCollector$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.MetricsGossip$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.MetricsGossipEnvelope$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.NodeMetrics$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.pubsub.DistributedPubSub$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.pubsub.DistributedPubSubMediator$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.pubsub.DistributedPubSubMediator.Count$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.pubsub.DistributedPubSubMediator.CurrentTopics$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.pubsub.DistributedPubSubMediator.GetTopics$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.pubsub.DistributedPubSubMediator.Internal$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.pubsub.DistributedPubSubMediator.Publish$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.pubsub.DistributedPubSubMediator.Put$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.pubsub.DistributedPubSubMediator.Remove$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.pubsub.DistributedPubSubMediator.Send$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.pubsub.DistributedPubSubMediator.SendToAll$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.pubsub.DistributedPubSubMediator.Subscribe$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.pubsub.DistributedPubSubMediator.SubscribeAck$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.pubsub.DistributedPubSubMediator.Unsubscribe$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.pubsub.DistributedPubSubMediator.UnsubscribeAck$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.pubsub.DistributedPubSubSettings$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.Reachability$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.Reachability.Reachable$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.Reachability.Record$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.Reachability.Terminated$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.Reachability.Unreachable$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.routing.AdaptiveLoadBalancingGroup$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.routing.AdaptiveLoadBalancingPool$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.routing.AdaptiveLoadBalancingRoutingLogic$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.routing.ClusterRouterGroup$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.routing.ClusterRouterGroupSettings$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.routing.ClusterRouterPool$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.routing.ClusterRouterPoolSettings$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.routing.ClusterRouterSettingsBase$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.routing.CpuMetricsSelector$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.routing.HeapMetricsSelector$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.routing.MetricsSelector$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.routing.MixMetricsSelector$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.routing.SystemLoadAverageMetricsSelector$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.ClusterSharding$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.ClusterShardingGuardian$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.ClusterShardingGuardian.Start$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.ClusterShardingGuardian.Started$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.Shard$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.Shard.EntryStarted$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.Shard.EntryStopped$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.Shard.RestartEntry$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.Shard.RetryPersistence$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.Shard.State$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.ShardCoordinator$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.ShardCoordinator.Internal$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.ShardCoordinatorSupervisor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.ShardRegion$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.ShardRegion.Passivate$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.singleton.ClusterSingletonManager$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.singleton.ClusterSingletonManagerSettings$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.singleton.ClusterSingletonProxy$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.singleton.ClusterSingletonProxySettings$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.StandardMetrics$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.StandardMetrics.Cpu$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.StandardMetrics.HeapMemory$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.UniqueAddress$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.VectorClock$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.VectorClock.After$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.VectorClock.Before$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.VectorClock.Concurrent$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.VectorClock.Node$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.VectorClock.Same$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.VectorClock.Timestamp$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.VectorClockStats$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.mailbox.PeekMailboxExtension$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.pattern.ReliableProxy$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.pattern.ReliableProxy.Active$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.pattern.ReliableProxy.Connecting$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.pattern.ReliableProxy.Idle$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.pattern.ReliableProxy.Message$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.pattern.ReliableProxy.ProxyTerminated$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.pattern.ReliableProxy.TargetChanged$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.pattern.ReliableProxy.Unsent$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.pattern.WorkList$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.throttle.Throttler$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.throttle.Throttler.Rate$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.throttle.Throttler.RateInt$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.throttle.Throttler.SetRate$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.throttle.Throttler.SetTarget$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.throttle.TimerBasedThrottler$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.throttle.TimerBasedThrottler.Active$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.throttle.TimerBasedThrottler.Data$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.throttle.TimerBasedThrottler.Idle$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.throttle.TimerBasedThrottler.Message$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.throttle.TimerBasedThrottler.Tick$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.BalancingDispatcherConfigurator$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.BoundedControlAwareMailbox$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.BoundedDequeBasedMailbox$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.BoundedMailbox$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.BoundedPriorityMailbox$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.BoundedStablePriorityMailbox$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.CachingConfig$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.CachingConfig.StringPathEntry$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.CachingConfig.ValuePathEntry$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.DefaultDispatcherPrerequisites$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.Dispatchers$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.Envelope$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.ExecutionContexts$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.ExecutionContexts.sameThreadExecutionContext$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.Filter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.ForkJoinExecutorConfigurator$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.Futures$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.japi$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.Mailbox$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.Mailboxes$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.MessageDispatcher$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.MonitorableThreadFactory$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.NonBlockingBoundedMailbox$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.PriorityGenerator$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.SingleConsumerOnlyUnboundedMailbox$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.Create$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.DeathWatchNotification$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.EarliestFirstSystemMessageList$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.Failed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.LatestFirstSystemMessageList$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.NoMessage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.Recreate$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.Resume$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.Supervise$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.Suspend$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.SystemMessageList$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.Terminate$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.Unwatch$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.sysmsg.Watch$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.TaskInvocation$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.ThreadPoolConfig$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.ThreadPoolConfigBuilder$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.UnboundedControlAwareMailbox$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.UnboundedDequeBasedMailbox$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.UnboundedMailbox$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.UnboundedPriorityMailbox$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.dispatch.UnboundedStablePriorityMailbox$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.ActorClassificationUnsubscriber$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.ActorClassificationUnsubscriber.Register$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.ActorClassificationUnsubscriber.Unregister$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.AddressTerminatedTopic$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.EventStream$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.EventStreamUnsubscriber$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.EventStreamUnsubscriber.Register$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.EventStreamUnsubscriber.UnregisterIfNoMoreSubscribedChannels$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.Logging$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.Logging.Debug$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.Logging.Error$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.Logging.Error.NoCause$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.Logging.Error2$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.Logging.Extension$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.Logging.Info$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.Logging.InitializeLogger$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.Logging.LoggerInitialized$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.Logging.LogLevel$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.Logging.Warning$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.LoggingReceive$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.LogSource$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.NoLogging$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.event.slf4j.Logger$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Dns$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Dns.Resolve$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Dns.Resolved$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Inet$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Inet.DatagramChannelCreator$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Inet.SO$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.IO$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.SelectionHandler$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.SelectionHandler.ChannelAcceptable$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.SelectionHandler.ChannelConnectable$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.SelectionHandler.ChannelReadable$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.SelectionHandler.ChannelWritable$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.SelectionHandler.Retry$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.SelectionHandler.WorkerForCommand$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.SimpleDnsCache$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.SimpleDnsManager$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.Abort$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.Aborted$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.Bind$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.Bound$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.Close$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.Closed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.CommandFailed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.CompoundWrite$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.ConfirmedClose$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.ConfirmedClosed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.Connect$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.Connected$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.ErrorClosed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.NoAck$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.PeerClosed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.Received$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.Register$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.ResumeAccepting$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.ResumeReading$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.ResumeWriting$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.SO$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.SuspendReading$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.Unbind$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.Unbound$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.Write$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.WriteCommand$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.WriteFile$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Tcp.WritingResumed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpConnection$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpConnection.AllRead$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpConnection.CloseInformation$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpConnection.ConnectionInfo$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpConnection.EmptyPendingWrite$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpConnection.EndOfStream$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpConnection.MoreDataWaiting$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpConnection.UpdatePendingWriteAndThen$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpConnection.WriteFileFailed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpListener$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpListener.FailedRegisterIncoming$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpListener.RegisterIncoming$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpMessage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.TcpSO$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp.Bind$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp.Bound$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp.CommandFailed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp.NoAck$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp.Received$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp.ResumeReading$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp.Send$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp.SimpleSender$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp.SimpleSenderReady$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp.SO$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp.SuspendReading$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp.Unbind$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.Udp.Unbound$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpConnected$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpConnected.CommandFailed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpConnected.Connect$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpConnected.Connected$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpConnected.Disconnect$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpConnected.Disconnected$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpConnected.NoAck$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpConnected.Received$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpConnected.ResumeReading$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpConnected.Send$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpConnected.SuspendReading$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpConnectedMessage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpMessage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.io.UdpSO$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.JavaPartialFunction$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in exception akka.japi.JavaPartialFunction.NoMatch$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.Option$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.Option.Some$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.Pair$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.pf.CaseStatement$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.Util$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.kernel.Main$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.Main$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.osgi.BundleDelegatingClassLoader$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.osgi.OsgiActorSystemFactory$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.osgi.UnregisteringLogService$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.AskableActorRef$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.AskableActorSelection$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.CircuitBreaker$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.CircuitBreakerOpenException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.Patterns$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.PromiseActorRef$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.AtLeastOnceDelivery$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.AtLeastOnceDelivery.Internal$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.AtLeastOnceDelivery.UnconfirmedDelivery$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.AtLeastOnceDelivery.UnconfirmedWarning$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.Eventsourced$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.Eventsourced.AsyncHandlerInvocation$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.Eventsourced.StashingHandlerInvocation$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteJournal$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteJournal.Desequenced$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteProxy$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteProxy.SetStore$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteTarget$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteTarget.DeleteMessagesTo$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteTarget.ReadHighestSequenceNr$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteTarget.ReplayFailure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteTarget.ReplayMessages$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteTarget.ReplaySuccess$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteTarget.WriteMessages$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.JournalPerfSpec$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.JournalPerfSpec.Cmd$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.JournalPerfSpec.ResetCounter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.JournalSpec$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.leveldb.Key$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.leveldb.SharedLeveldbJournal$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.JournalProtocol$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.JournalProtocol.DeleteMessagesFailure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.JournalProtocol.DeleteMessagesTo$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.JournalProtocol.LoopMessageSuccess$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.JournalProtocol.ReadHighestSequenceNr$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.JournalProtocol.ReadHighestSequenceNrFailure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.JournalProtocol.ReadHighestSequenceNrSuccess$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.JournalProtocol.ReplayedMessage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.JournalProtocol.ReplayMessages$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.JournalProtocol.ReplayMessagesFailure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.JournalProtocol.ReplayMessagesSuccess$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.JournalProtocol.WriteMessageFailure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.JournalProtocol.WriteMessages$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.JournalProtocol.WriteMessagesFailed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.JournalProtocol.WriteMessagesSuccessful$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.JournalProtocol.WriteMessageSuccess$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.NonPersistentRepr$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.Persistence$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.Persistence.PluginHolder$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.PersistenceFailure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.PersistentImpl$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.PersistentRepr$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.PersistentView$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.PersistentView.ScheduledUpdate$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.Protocol$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.Recover$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.RecoveryCompleted$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.RecoveryFailure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.SaveSnapshotFailure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.SaveSnapshotSuccess$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.SelectedSnapshot$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.serialization.Snapshot$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.serialization.SnapshotHeader$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.serialization.SnapshotSerializer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.snapshot.SnapshotStoreSpec$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.SnapshotMetadata$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.SnapshotOffer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.SnapshotProtocol$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.SnapshotProtocol.DeleteSnapshot$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.SnapshotProtocol.DeleteSnapshots$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.SnapshotProtocol.LoadSnapshot$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.SnapshotProtocol.LoadSnapshotResult$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.SnapshotProtocol.SaveSnapshot$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.SnapshotSelectionCriteria$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.Update$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.Ack$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.AckedReceiveBuffer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.AckedSendBuffer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.AddressUidExtension$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.AddressUrlEncoder$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.AssociatedEvent$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.AssociationErrorEvent$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.BoundAddressesExtension$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.DaemonMsgCreate$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.DisassociatedEvent$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointManager$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointManager.Gated$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointManager.Link$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointManager.Listen$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointManager.ListensFailure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointManager.ListensResult$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointManager.ManagementCommand$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointManager.ManagementCommandAck$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointManager.Pass$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointManager.Prune$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointManager.Quarantine$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointManager.Quarantined$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointManager.ResendState$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointManager.Send$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointManager.ShutdownAndFlush$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointManager.StartupFinished$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointReader$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointWriter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointWriter.AckIdleCheckTimer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointWriter.BackoffTimer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointWriter.FlushAndStop$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointWriter.Handle$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointWriter.OutboundAck$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointWriter.StoppedReading$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointWriter.StopReading$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointWriter.TakeOver$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.EndpointWriter.TookOver$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.FailureDetector$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.FailureDetectorLoader$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.HasSequenceNumber$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.HeartbeatHistory$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.HopelessAssociation$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.InvalidAssociation$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.MessageSerializer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.QuarantinedEvent$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.RARP$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.ReliableDeliverySupervisor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.ReliableDeliverySupervisor.AttemptSysMsgRedelivery$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.ReliableDeliverySupervisor.GotUid$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.ReliableDeliverySupervisor.Idle$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.ReliableDeliverySupervisor.IsIdle$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.ReliableDeliverySupervisor.Ungate$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.RemoteActorRefProvider$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.RemoteActorRefProvider.Finished$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.RemoteActorRefProvider.Idle$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.RemoteActorRefProvider.Uninitialized$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.RemoteActorRefProvider.WaitDaemonShutdown$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.RemoteActorRefProvider.WaitTransportShutdown$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.RemoteDeploymentWatcher$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.RemoteDeploymentWatcher.WatchRemote$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.RemoteMetricsExtension$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.RemoteScope$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.RemoteWatcher$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.RemoteWatcher.ExpectedFirstHeartbeat$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.RemoteWatcher.Heartbeat$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.RemoteWatcher.HeartbeatRsp$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.RemoteWatcher.HeartbeatTick$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.RemoteWatcher.ReapUnreachableTick$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.RemoteWatcher.Stats$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.RemoteWatcher.UnwatchRemote$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.RemoteWatcher.WatchRemote$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.Remoting$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.Remoting.RegisterTransportActor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.RemotingErrorEvent$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.RemotingListenEvent$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.RemotingShutdownEvent$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.routing.RemoteRouterConfig$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.security.provider.AkkaProvider$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.security.provider.InternetSeedGenerator$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.security.provider.SeedSize$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.SeqNo$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.serialization.ProtobufSerializer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.ShutDownAssociation$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.AddressReply$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.BarrierCoordinator$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.BarrierCoordinator.BarrierEmpty$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.BarrierCoordinator.BarrierTimeout$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.BarrierCoordinator.ClientLost$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.BarrierCoordinator.Data$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.BarrierCoordinator.DuplicateNode$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.BarrierCoordinator.FailedBarrier$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.BarrierCoordinator.Idle$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.BarrierCoordinator.RemoveClient$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.BarrierCoordinator.Waiting$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.BarrierCoordinator.WrongBarrier$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.BarrierResult$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.Client$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.ClientFSM$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.ClientFSM.AwaitDone$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.ClientFSM.Connected$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.ClientFSM.Connecting$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.ClientFSM.ConnectionFailure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.ClientFSM.Data$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.ClientFSM.Disconnected$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.ClientFSM.Failed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.Controller$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.Controller.ClientDisconnected$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.Controller.CreateServerFSM$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.Controller.GetNodes$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.Controller.GetSockAddr$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.Controller.NodeInfo$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.Disconnect$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.DisconnectMsg$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.Done$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.EnterBarrier$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.FailBarrier$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.GetAddress$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.Hello$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.RemoteConnection$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.Remove$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.RoleName$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.Server$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.ServerFSM$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.ServerFSM.Initial$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.ServerFSM.Ready$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.Terminate$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.TerminateMsg$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.TestConductor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.Throttle$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.ThrottleMsg$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.ToClient$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testconductor.ToServer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.testkit.MultiNodeSpec$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ActorTransportAdapter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ActorTransportAdapter.AssociateUnderlying$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ActorTransportAdapter.DisassociateUnderlying$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ActorTransportAdapter.ListenerRegistered$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ActorTransportAdapter.ListenUnderlying$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.AkkaPduCodec$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.AkkaPduCodec.Associate$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.AkkaPduCodec.Disassociate$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.AkkaPduCodec.Heartbeat$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.AkkaPduCodec.Message$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.AkkaPduCodec.Payload$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.AkkaPduProtobufCodec$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.AkkaProtocolTransport$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.AkkaProtocolTransport.AssociateUnderlyingRefuseUid$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.AssociationHandle$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.AssociationHandle.ActorHandleEventListener$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.AssociationHandle.Disassociated$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.AssociationHandle.InboundPayload$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.AssociationHandle.Quarantined$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.AssociationHandle.Shutdown$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.AssociationHandle.Unknown$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.AssociationRegistry$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.FailureInjectorException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.FailureInjectorHandle$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.FailureInjectorTransportAdapter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.FailureInjectorTransportAdapter.All$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.FailureInjectorTransportAdapter.Drop$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.FailureInjectorTransportAdapter.One$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.FailureInjectorTransportAdapter.PassThru$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.HandshakeInfo$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.netty.ChannelLocalActor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.netty.NettyFutureBridge$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.netty.NettySSLSupport$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.netty.NettyTransport$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.netty.NettyTransportSettings$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.netty.NettyTransportSettings.Tcp$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.netty.NettyTransportSettings.Udp$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.AssociatedWaitHandler$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.Closed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.ForbiddenUidReason$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.Handle$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.HandleListenerRegistered$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.HeartbeatTimer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.InboundUnassociated$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.ListenerReady$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.Open$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.OutboundUnassociated$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.OutboundUnderlyingAssociated$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.TimeoutReason$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.WaitHandshake$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.TestAssociationHandle$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.TestTransport$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.TestTransport.AssociateAttempt$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.TestTransport.DisassociateAttempt$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.TestTransport.ListenAttempt$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.TestTransport.ShutdownAttempt$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.TestTransport.WriteAttempt$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.Dequeue$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.ExposedHandle$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.FailWith$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.Throttling$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.Uninitialized$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.WaitExposedHandle$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.WaitMode$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.WaitModeAndUpstreamListener$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.WaitOrigin$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.WaitUpstreamListener$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottlerHandle$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottlerManager$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottlerManager.AssociateResult$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottlerManager.Checkin$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottlerManager.Handle$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottlerManager.Listener$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottlerManager.ListenerAndMode$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.Blackhole$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.Direction$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Both$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Receive$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Send$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociate$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociateAck$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociateExplicitly$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.SetThrottle$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.SetThrottleAck$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.Unthrottled$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.Transport$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.Transport.ActorAssociationEventListener$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.Transport.InboundAssociation$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.Transport.InvalidAssociationException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.transport.TransportAdaptersExtension$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ActorRefRoutee$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ActorSelectionRoutee$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.AddRoutee$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.AdjustPoolSize$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.BalancingPool$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.BalancingPoolDeploy$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.BalancingRoutingLogic$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.Broadcast$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.BroadcastGroup$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.BroadcastPool$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.BroadcastRoutingLogic$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ConsistentHash$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ConsistentHashingGroup$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ConsistentHashingPool$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ConsistentHashingRouter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ConsistentHashingRouter.ConsistentHashableEnvelope$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ConsistentHashingRouter.emptyConsistentHashMapping$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ConsistentHashingRoutingLogic$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ConsistentRoutee$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.Deafen$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.DefaultResizer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.FromConfig$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.GetRoutees$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.Listen$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.MurmurHash$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.NoRoutee$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.NoRouter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.Pool$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.RandomGroup$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.RandomPool$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.RandomRoutingLogic$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.RemoveRoutee$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ResizablePoolActor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ResizablePoolActor.Resize$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.RoundRobinGroup$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.RoundRobinPool$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.RoundRobinRoutingLogic$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.RoutedActorCell$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.Routees$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.Router$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ScatterGatherFirstCompletedGroup$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ScatterGatherFirstCompletedPool$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ScatterGatherFirstCompletedRoutees$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.ScatterGatherFirstCompletedRoutingLogic$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.SeveralRoutees$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.SmallestMailboxPool$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.SmallestMailboxRoutingLogic$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.TailChoppingGroup$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.TailChoppingPool$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.TailChoppingRoutees$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.TailChoppingRoutingLogic$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.WithListeners$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.serialization.JavaSerializer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.serialization.NullSerializer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.serialization.Serialization$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.serialization.Serialization.Information$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.serialization.SerializationExtension$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.CallingThreadDispatcher$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.CallingThreadDispatcherQueues$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.CustomEventFilter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.DeadLettersFilter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.DebugFilter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.ErrorFilter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.EventFilter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.InfoFilter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.SocketUtil$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.TestActor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.TestActor.KeepRunning$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.TestActor.NoAutoPilot$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.TestActor.NullMessage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.TestActor.RealMessage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.TestActor.SetAutoPilot$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.TestActor.SetIgnore$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.TestActor.UnWatch$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.TestActor.Watch$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.TestActorRef$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.TestActors$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.TestBarrier$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.TestEvent$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.TestEvent.Mute$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.TestEvent.UnMute$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.TestFSMRef$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.TestKit$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.TestKitExtension$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.TestLatch$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.TestProbe$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.testkit.WarningFilter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.ActorRef$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.ActorSystem$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.AskPattern$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.AskPattern.Askable$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Behavior$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Behavior.emptyBehavior$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Behavior.ignoreBehavior$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Behavior.sameBehavior$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Behavior.stoppedBehavior$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Behavior.unhandledBehavior$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Effect$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Effect.EmptyEffect$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Effect.Messaged$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Effect.ReceiveTimeoutSet$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Effect.Scheduled$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Effect.Spawned$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Effect.Stopped$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Effect.Unwatched$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Effect.Watched$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Failed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Failed.Escalate$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Failed.NoFailureResponse$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Failed.Restart$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Failed.Resume$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Failed.Stop$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Inbox$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Ops$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Ops.ActorContextOps$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Ops.ActorSystemOps$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.patterns.Receiver$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.patterns.Receiver.ExternalAddress$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.patterns.Receiver.GetAll$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.patterns.Receiver.GetAllResult$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.patterns.Receiver.GetOne$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.patterns.Receiver.GetOneResult$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.patterns.Receptionist$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.patterns.Receptionist.Find$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.patterns.Receptionist.Listing$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.patterns.Receptionist.Register$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.patterns.Receptionist.Registered$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.PostRestart$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.PostStop$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.PreRestart$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.PreStart$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Props$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.ReceiveTimeout$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.ScalaDSL$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.ScalaDSL.And$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.ScalaDSL.BehaviorDecorators$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.ScalaDSL.Full$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.ScalaDSL.FullTotal$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.ScalaDSL.Msg$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.ScalaDSL.Or$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.ScalaDSL.Partial$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.ScalaDSL.Sig$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.ScalaDSL.Static$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.ScalaDSL.SynchronousSelf$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.ScalaDSL.Tap$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.ScalaDSL.Total$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.ScalaDSL.Widened$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.StepWise$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.StepWise.Steps$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Terminated$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.BoxedType$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.ByteIterator$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.ByteIterator.ByteArrayIterator$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.ByteIterator.MultiByteArrayIterator$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.ByteString$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.ByteString.ByteString1$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.ByteString.ByteString1C$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.ByteString.ByteStrings$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.ByteString.Companion$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.Collections$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.Collections.EmptyImmutableSeq$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.CompactByteString$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.Crypt$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.HashCode$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.Helpers$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.Helpers.ConfigOps$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.Helpers.Requiring$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.LineNumbers$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.LineNumbers.NoSourceInfo$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.LineNumbers.SourceFile$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.LineNumbers.SourceFileLines$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.LineNumbers.UnknownSourceFormat$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.PriorityQueueStabilizer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.Reflect$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.SerializedSuspendableExecutionContext$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.SubclassifiedIndex$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.Switch$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.Timeout$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.TypedMultiMap$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.WildcardTree$
-
Static reference to the singleton instance of this Scala object.
- monitor(ActorRef<T>, Behavior<T>) - Method in class akka.typed.ScalaDSL.Tap$
-
- MonitorableThreadFactory - Class in akka.dispatch
-
- MonitorableThreadFactory(String, boolean, Option<ClassLoader>, Thread.UncaughtExceptionHandler, AtomicLong) - Constructor for class akka.dispatch.MonitorableThreadFactory
-
- MonitorableThreadFactory$ - Class in akka.dispatch
-
- MonitorableThreadFactory$() - Constructor for class akka.dispatch.MonitorableThreadFactory$
-
- MonitorableThreadFactory.AkkaForkJoinWorkerThread - Class in akka.dispatch
-
- MonitoredByNrOfMembers() - Method in class akka.cluster.ClusterSettings
-
- monitoredByNrOfMembers() - Method in class akka.cluster.HeartbeatNodeRing
-
- MoreDataWaiting$() - Constructor for class akka.io.TcpConnection.MoreDataWaiting$
-
- msg() - Method in class akka.actor.ActorSelectionMessage
-
- msg() - Method in class akka.actor.FSM.Timer
-
- msg() - Method in exception akka.actor.SchedulerException
-
- msg() - Method in class akka.cluster.client.ClusterClient.Publish
-
- msg() - Method in class akka.cluster.client.ClusterClient.Send
-
- msg() - Method in class akka.cluster.client.ClusterClient.SendToAll
-
- msg() - Method in class akka.cluster.pubsub.DistributedPubSubMediator.Internal$.MediatorRouterEnvelope
-
- msg() - Method in class akka.cluster.pubsub.DistributedPubSubMediator.Internal$.SendToOneSubscriber
-
- msg() - Method in class akka.cluster.pubsub.DistributedPubSubMediator.Publish
-
- msg() - Method in class akka.cluster.pubsub.DistributedPubSubMediator.Send
-
- msg() - Method in class akka.cluster.pubsub.DistributedPubSubMediator.SendToAll
-
- msg() - Method in class akka.contrib.pattern.ReliableProxy.Message
-
- msg() - Method in class akka.persistence.journal.AsyncWriteJournal.Desequenced
-
- msg() - Method in exception akka.remote.testconductor.BarrierCoordinator.BarrierEmpty
-
- msg() - Method in exception akka.remote.testconductor.ClientFSM.ConnectionFailure
-
- msg() - Method in class akka.remote.testconductor.ToClient
-
- msg() - Method in class akka.remote.testconductor.ToServer
-
- msg() - Method in exception akka.remote.transport.FailureInjectorException
-
- msg() - Method in exception akka.remote.transport.Transport.InvalidAssociationException
-
- msg() - Method in interface akka.testkit.TestActor.Message
-
- msg() - Method in class akka.testkit.TestActor.NullMessage$
-
- msg() - Method in class akka.testkit.TestActor.RealMessage
-
- msg() - Method in class akka.typed.Effect.Messaged
-
- msg() - Method in class akka.typed.Effect.Scheduled
-
- msg() - Method in class akka.typed.patterns.Receiver.GetOneResult
-
- Msg(ActorContext<T>, T) - Constructor for class akka.typed.ScalaDSL.Msg
-
- msg() - Method in class akka.typed.ScalaDSL.Msg
-
- Msg$() - Constructor for class akka.typed.ScalaDSL.Msg$
-
- msgAvailable() - Method in class akka.testkit.JavaTestKit
-
Query queue status.
- msgAvailable() - Method in interface akka.testkit.TestKitBase
-
Query queue status.
- MsgDecoder - Class in akka.remote.testconductor
-
- MsgDecoder() - Constructor for class akka.remote.testconductor.MsgDecoder
-
- msgDispatch() - Method in class akka.remote.EndpointWriter
-
- MsgEncoder - Class in akka.remote.testconductor
-
- MsgEncoder() - Constructor for class akka.remote.testconductor.MsgEncoder
-
- msgs() - Method in class akka.typed.patterns.Receiver.GetAllResult
-
- msgsPer(int, TimeUnit) - Method in class akka.contrib.throttle.Throttler.RateInt
-
- msgsPer(FiniteDuration) - Method in class akka.contrib.throttle.Throttler.RateInt
-
- msgsPerHour() - Method in class akka.contrib.throttle.Throttler.RateInt
-
- msgsPerMinute() - Method in class akka.contrib.throttle.Throttler.RateInt
-
- msgsPerSecond() - Method in class akka.contrib.throttle.Throttler.RateInt
-
- MultiByteArrayIterator$() - Constructor for class akka.util.ByteIterator.MultiByteArrayIterator$
-
- MultiNodeConfig - Class in akka.remote.testkit
-
Configure the role names and participants of the test, including configuration settings.
- MultiNodeConfig() - Constructor for class akka.remote.testkit.MultiNodeConfig
-
- MultiNodeSpec - Class in akka.remote.testkit
-
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(RoleName, ActorSystem, Seq<RoleName>, Function1<RoleName, Seq<String>>) - Constructor for class akka.remote.testkit.MultiNodeSpec
-
- MultiNodeSpec(MultiNodeConfig) - Constructor for class akka.remote.testkit.MultiNodeSpec
-
- MultiNodeSpec$ - Class in akka.remote.testkit
-
- MultiNodeSpec$() - Constructor for class akka.remote.testkit.MultiNodeSpec$
-
- MultiNodeSpec.AwaitHelper<T> - Class in akka.remote.testkit
-
- multiNodeSpecAfterAll() - Method in class akka.remote.testkit.MultiNodeSpec
-
- multiNodeSpecAfterAll() - Method in interface akka.remote.testkit.MultiNodeSpecCallbacks
-
Call this after the all test cases have run.
- multiNodeSpecBeforeAll() - Method in class akka.remote.testkit.MultiNodeSpec
-
- multiNodeSpecBeforeAll() - Method in interface akka.remote.testkit.MultiNodeSpecCallbacks
-
Call this before the start of the test run.
- MultiNodeSpecCallbacks - Interface in akka.remote.testkit
-
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 - Interface in akka.dispatch
-
This is a marker trait for message queues which support multiple consumers,
as is required by the BalancingDispatcher.
- MurmurHash - Class in akka.routing
-
An object designed to generate well-distributed non-cryptographic
hashes.
- MurmurHash() - Constructor for class akka.routing.MurmurHash
-
- MurmurHash$ - Class in akka.routing
-
An object designed to generate well-distributed non-cryptographic
hashes.
- MurmurHash$() - Constructor for class akka.routing.MurmurHash$
-
- Mute(Seq<EventFilter>) - Constructor for class akka.testkit.TestEvent.Mute
-
- Mute(Iterable<EventFilter>) - Constructor for class akka.testkit.TestEvent.Mute
-
Java API: create a Mute command from a list of filters
- Mute$() - Constructor for class akka.testkit.TestEvent.Mute$
-
- muteDeadLetters(Seq<Class<?>>, ActorSystem) - Method in class akka.remote.testkit.MultiNodeSpec
-
- myAddress() - Method in class akka.remote.testkit.MultiNodeSpec
-
- myReceivers() - Method in class akka.cluster.HeartbeatNodeRing
-
Receivers for selfAddress
.
- myself() - Method in class akka.remote.testkit.MultiNodeConfig
-
- myself() - Method in class akka.remote.testkit.MultiNodeSpec
-
- myVersions() - Method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- safeLongToInt(long) - Method in interface akka.persistence.journal.inmem.InmemMessages
-
- safeShutdownOutput() - Method in class akka.io.TcpConnection
-
- Same() - Method in class akka.cluster.ClusterCoreDaemon
-
- Same() - Constructor for class akka.cluster.ClusterCoreDaemon.Same
-
- Same() - Method in class akka.typed.ScalaDSL$
-
Return this behavior from message processing in order to advise the
system to reuse the previous behavior.
- Same() - Static method in class akka.typed.ScalaDSL
-
Return this behavior from message processing in order to advise the
system to reuse the previous behavior.
- Same$() - Constructor for class akka.cluster.VectorClock.Same$
-
- sameAs(Metric) - Method in class akka.cluster.Metric
-
Returns true if that
is tracking the same metric as this.
- sameAs(Metric) - Method in class akka.cluster.metrics.Metric
-
Returns true if that
is tracking the same metric as this.
- sameAs(NodeMetrics) - Method in class akka.cluster.metrics.NodeMetrics
-
Returns true if that
address is the same as this
- sameAs(NodeMetrics) - Method in class akka.cluster.NodeMetrics
-
Returns true if that
address is the same as this
- sameBehavior$() - Constructor for class akka.typed.Behavior.sameBehavior$
-
- sameCount() - Method in class akka.cluster.GossipStats
-
- sameThreadExecutionContext$() - Constructor for class akka.dispatch.ExecutionContexts.sameThreadExecutionContext$
-
- sample() - Method in class akka.cluster.JmxMetricsCollector
-
Samples and collects new data points.
- sample() - Method in class akka.cluster.metrics.ClusterMetricsCollector
-
Samples the latest metrics for the node, updates metrics statistics in
MetricsGossip
, and publishes the change to the event bus.
- sample() - Method in class akka.cluster.metrics.JmxMetricsCollector
-
Samples and collects new data points.
- sample() - Method in interface akka.cluster.metrics.MetricsCollector
-
Samples and collects new data points.
- sample() - Method in interface akka.cluster.MetricsCollector
-
Samples and collects new data points.
- sampleTask() - Method in class akka.cluster.metrics.ClusterMetricsCollector
-
Start periodic metrics collection
- SaneRejectedExecutionHandler - Class in akka.dispatch
-
The RejectedExecutionHandler used by Akka, it improves on CallerRunsPolicy
by throwing a RejectedExecutionException if the executor isShutdown.
- SaneRejectedExecutionHandler() - Constructor for class akka.dispatch.SaneRejectedExecutionHandler
-
- satisfiesRole(Set<String>) - Method in interface akka.cluster.routing.ClusterRouterActor
-
- save(SnapshotMetadata, Object) - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
-
- saveAsync(SnapshotMetadata, Object) - Method in class akka.persistence.snapshot.japi.SnapshotStore
-
- saveAsync(SnapshotMetadata, Object) - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
-
- saveAsync(SnapshotMetadata, Object) - Method in interface akka.persistence.snapshot.SnapshotStore
-
Plugin API: asynchronously saves a snapshot.
- saved(SnapshotMetadata) - Method in class akka.persistence.snapshot.japi.SnapshotStore
-
- saved(SnapshotMetadata) - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
-
- saved(SnapshotMetadata) - Method in interface akka.persistence.snapshot.SnapshotStore
-
Plugin API: called after successful saving of a snapshot.
- SaveSnapshot(SnapshotMetadata, Object) - Constructor for class akka.persistence.SnapshotProtocol.SaveSnapshot
-
- saveSnapshot(Object) - Method in interface akka.persistence.Snapshotter
-
Saves a snapshot
of this snapshotter's state.
- SaveSnapshot$() - Constructor for class akka.persistence.SnapshotProtocol.SaveSnapshot$
-
- SaveSnapshotFailure - Class in akka.persistence
-
- SaveSnapshotFailure(SnapshotMetadata, Throwable) - Constructor for class akka.persistence.SaveSnapshotFailure
-
- SaveSnapshotFailure$ - Class in akka.persistence
-
- SaveSnapshotFailure$() - Constructor for class akka.persistence.SaveSnapshotFailure$
-
- SaveSnapshotSuccess - Class in akka.persistence
-
- SaveSnapshotSuccess(SnapshotMetadata) - Constructor for class akka.persistence.SaveSnapshotSuccess
-
- SaveSnapshotSuccess$ - Class in akka.persistence
-
- SaveSnapshotSuccess$() - Constructor for class akka.persistence.SaveSnapshotSuccess$
-
- saveState() - Method in class akka.remote.EndpointReader
-
- scala2JavaOption(Option<A>) - Method in class akka.japi.Option$
-
- scala2JavaOption(Option<A>) - Static method in class akka.japi.Option
-
- ScalaActorRef - Interface in akka.actor
-
This trait represents the Scala Actor API
There are implicit conversions in ../actor/Implicits.scala
from ActorRef -> ScalaActorRef and back
- ScalaActorRef<T> - Interface in akka.typed
-
This trait is used to hide the !
method from Java code.
- ScalaActorSelection - Interface in akka.actor
-
Contains the Scala API (!-method) for ActorSelections) which provides automatic tracking of the sender,
as per the usual implicit ActorRef pattern.
- ScalaDSL - Class in akka.typed
-
This object holds several behavior factories and combinators that can be
used to construct Behavior instances.
- ScalaDSL() - Constructor for class akka.typed.ScalaDSL
-
- ScalaDSL$ - Class in akka.typed
-
This object holds several behavior factories and combinators that can be
used to construct Behavior instances.
- ScalaDSL$() - Constructor for class akka.typed.ScalaDSL$
-
- ScalaDSL.And<T> - Class in akka.typed
-
A behavior combinator that feeds incoming messages and signals both into
the left and right sub-behavior and allows them to evolve independently of
each other.
- ScalaDSL.And$ - Class in akka.typed
-
- ScalaDSL.BehaviorDecorators<T> - Class in akka.typed
-
- ScalaDSL.BehaviorDecorators$ - Class in akka.typed
-
- ScalaDSL.Full<T> - Class in akka.typed
-
This type of behavior allows to handle all incoming messages within
the same user-provided partial function, be that a user message or a system
signal.
- ScalaDSL.Full$ - Class in akka.typed
-
- ScalaDSL.FullTotal<T> - Class in akka.typed
-
This type of behavior expects a total function that describes the actor’s
reaction to all system signals or user messages, without providing a
fallback mechanism for either.
- ScalaDSL.FullTotal$ - Class in akka.typed
-
- ScalaDSL.MessageOrSignal<T> - Interface in akka.typed
-
- ScalaDSL.Msg<T> - Class in akka.typed
-
- ScalaDSL.Msg$ - Class in akka.typed
-
- ScalaDSL.Or<T> - Class in akka.typed
-
A behavior combinator that feeds incoming messages and signals either into
the left or right sub-behavior and allows them to evolve independently of
each other.
- ScalaDSL.Or$ - Class in akka.typed
-
- ScalaDSL.Partial<T> - Class in akka.typed
-
This type of Behavior is created from a partial function from the declared
message type to the next behavior, flagging all unmatched messages as
Unhandled
.
- ScalaDSL.Partial$ - Class in akka.typed
-
- ScalaDSL.Sig<T> - Class in akka.typed
-
- ScalaDSL.Sig$ - Class in akka.typed
-
- ScalaDSL.Static<T> - Class in akka.typed
-
This type of behavior is a variant of
ScalaDSL.Total
that does not
allow the actor to change behavior.
- ScalaDSL.Static$ - Class in akka.typed
-
- ScalaDSL.SynchronousSelf<T> - Class in akka.typed
-
This behavior allows sending messages to itself without going through the
Actor’s mailbox.
- ScalaDSL.SynchronousSelf$ - Class in akka.typed
-
- ScalaDSL.Tap<T> - Class in akka.typed
-
This type of Behavior wraps another Behavior while allowing you to perform
some action upon each received message or signal.
- ScalaDSL.Tap$ - Class in akka.typed
-
- ScalaDSL.Total<T> - Class in akka.typed
-
This type of behavior is created from a total function from the declared
message type to the next behavior, which means that all possible incoming
messages for the given type must be handled.
- ScalaDSL.Total$ - Class in akka.typed
-
- ScalaDSL.Widened<T,U> - Class in akka.typed
-
Widen the wrapped Behavior by placing a funnel in front of it: the supplied
PartialFunction decides which message to pull in (those that it is defined
at) and may transform the incoming message to place them into the wrapped
Behavior’s type hierarchy.
- ScalaDSL.Widened$ - Class in akka.typed
-
- scaledPoolSize(int, double, int) - Method in class akka.dispatch.ThreadPoolConfig$
-
- scaledPoolSize(int, double, int) - Static method in class akka.dispatch.ThreadPoolConfig
-
- ScanningClassification - Interface in akka.event
-
Maps Classifiers to Subscribers and selects which Subscriber should receive which publication through scanning through all Subscribers
through the matches(classifier, event) method
- ScanningEventBus<E,S,C> - Class in akka.event.japi
-
Java API: See documentation for
ScanningClassification
E is the Event type
S is the Subscriber type
C is the Classifier type
- ScanningEventBus() - Constructor for class akka.event.japi.ScanningEventBus
-
- ScatterGatherFirstCompletedGroup - Class in akka.routing
-
A router group that broadcasts the message to all routees, and replies with the first response.
- ScatterGatherFirstCompletedGroup(Iterable<String>, FiniteDuration, String) - Constructor for class akka.routing.ScatterGatherFirstCompletedGroup
-
- ScatterGatherFirstCompletedGroup(Config) - Constructor for class akka.routing.ScatterGatherFirstCompletedGroup
-
- ScatterGatherFirstCompletedGroup(Iterable<String>, FiniteDuration) - Constructor for class akka.routing.ScatterGatherFirstCompletedGroup
-
Java API
- ScatterGatherFirstCompletedGroup$ - Class in akka.routing
-
- ScatterGatherFirstCompletedGroup$() - Constructor for class akka.routing.ScatterGatherFirstCompletedGroup$
-
- ScatterGatherFirstCompletedPool - Class in akka.routing
-
A router pool that broadcasts the message to all routees, and replies with the first response.
- ScatterGatherFirstCompletedPool(int, Option<Resizer>, FiniteDuration, SupervisorStrategy, String, boolean) - Constructor for class akka.routing.ScatterGatherFirstCompletedPool
-
- ScatterGatherFirstCompletedPool(Config) - Constructor for class akka.routing.ScatterGatherFirstCompletedPool
-
- ScatterGatherFirstCompletedPool(int, FiniteDuration) - Constructor for class akka.routing.ScatterGatherFirstCompletedPool
-
Java API
- ScatterGatherFirstCompletedPool$ - Class in akka.routing
-
- ScatterGatherFirstCompletedPool$() - Constructor for class akka.routing.ScatterGatherFirstCompletedPool$
-
- ScatterGatherFirstCompletedRoutees - Class in akka.routing
-
INTERNAL API
- ScatterGatherFirstCompletedRoutees(IndexedSeq<Routee>, FiniteDuration) - Constructor for class akka.routing.ScatterGatherFirstCompletedRoutees
-
- ScatterGatherFirstCompletedRoutees$ - Class in akka.routing
-
- ScatterGatherFirstCompletedRoutees$() - Constructor for class akka.routing.ScatterGatherFirstCompletedRoutees$
-
- ScatterGatherFirstCompletedRoutingLogic - Class in akka.routing
-
Broadcasts the message to all routees, and replies with the first response.
- ScatterGatherFirstCompletedRoutingLogic(FiniteDuration) - Constructor for class akka.routing.ScatterGatherFirstCompletedRoutingLogic
-
- ScatterGatherFirstCompletedRoutingLogic$ - Class in akka.routing
-
- ScatterGatherFirstCompletedRoutingLogic$() - Constructor for class akka.routing.ScatterGatherFirstCompletedRoutingLogic$
-
- schedule(FiniteDuration, FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.AbstractScheduler
-
Schedules a function to be run repeatedly with an initial delay and
a frequency.
- schedule(ActorRef, FiniteDuration) - Method in class akka.actor.FSM.Timer
-
- schedule(FiniteDuration, FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.LightArrayRevolverScheduler
-
- schedule(FiniteDuration, FiniteDuration, ActorRef, Object, ExecutionContext, ActorRef) - Method in interface akka.actor.Scheduler
-
Schedules a message to be sent repeatedly with an initial delay and
frequency.
- schedule(FiniteDuration, FiniteDuration, Function0<BoxedUnit>, ExecutionContext) - Method in interface akka.actor.Scheduler
-
Schedules a function to be run repeatedly with an initial delay and a
frequency.
- schedule(FiniteDuration, FiniteDuration, Runnable, ExecutionContext) - Method in interface akka.actor.Scheduler
-
Schedules a function to be run repeatedly with an initial delay and
a frequency.
- schedule() - Method in interface akka.persistence.PersistentView
-
- schedule(FiniteDuration, ActorRef<U>, U) - Method in interface akka.typed.ActorContext
-
Schedule the sending of the given message to the given target Actor after
the given time period has elapsed.
- schedule(FiniteDuration, ActorRef<U>, U) - Method in class akka.typed.ActorContextAdapter
-
- schedule(FiniteDuration, ActorRef<U>, U) - Method in class akka.typed.EffectfulActorContext
-
- schedule(FiniteDuration, ActorRef<U>, U) - Method in class akka.typed.StubbedActorContext
-
- scheduleBackoffTimer() - Method in class akka.remote.EndpointWriter
-
- Scheduled() - Method in class akka.dispatch.Mailbox$
-
- Scheduled() - Static method in class akka.dispatch.Mailbox
-
- SCHEDULED() - Method in class akka.dispatch.MessageDispatcher$
-
- SCHEDULED() - Static method in class akka.dispatch.MessageDispatcher
-
- Scheduled(FiniteDuration, ActorRef<U>, U) - Constructor for class akka.typed.Effect.Scheduled
-
- Scheduled$() - Constructor for class akka.typed.Effect.Scheduled$
-
- scheduleDequeue(FiniteDuration) - Method in class akka.remote.transport.ThrottledAssociation
-
- scheduledUnreachable() - Method in class akka.cluster.AutoDownBase
-
- ScheduledUpdate(long) - Constructor for class akka.persistence.PersistentView.ScheduledUpdate
-
- ScheduledUpdate$() - Constructor for class akka.persistence.PersistentView.ScheduledUpdate$
-
- scheduleOnce(FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.AbstractScheduler
-
Schedules a Runnable to be run once with a delay, i.e.
- scheduleOnce(FiniteDuration, Runnable, ExecutionContext) - Method in class akka.actor.LightArrayRevolverScheduler
-
- scheduleOnce(FiniteDuration, ActorRef, Object, ExecutionContext, ActorRef) - Method in interface akka.actor.Scheduler
-
Schedules a message to be sent once with a delay, i.e.
- scheduleOnce(FiniteDuration, Function0<BoxedUnit>, ExecutionContext) - Method in interface akka.actor.Scheduler
-
Schedules a function to be run once with a delay, i.e.
- scheduleOnce(FiniteDuration, Runnable, ExecutionContext) - Method in interface akka.actor.Scheduler
-
Schedules a Runnable to be run once with a delay, i.e.
- scheduler() - Method in class akka.actor.ActorSystem
-
Light-weight scheduler for running asynchronous tasks after some deadline
in the future.
- scheduler() - Method in class akka.actor.ActorSystemImpl
-
- Scheduler - Interface in akka.actor
-
An Akka scheduler service.
- scheduler() - Method in class akka.cluster.AutoDown
-
- scheduler() - Method in class akka.cluster.AutoDownBase
-
- scheduler() - Method in class akka.cluster.Cluster
-
INTERNAL API
- scheduler() - Method in class akka.dispatch.DefaultDispatcherPrerequisites
-
- scheduler() - Method in interface akka.dispatch.DispatcherPrerequisites
-
- scheduler() - Method in class akka.remote.RemoteWatcher
-
- scheduler() - Method in class akka.routing.TailChoppingRoutees
-
- scheduler() - Method in class akka.routing.TailChoppingRoutingLogic
-
- SchedulerClass() - Method in class akka.actor.ActorSystem.Settings
-
- scheduleReconnectTick() - Method in class akka.contrib.pattern.ReliableProxy
-
- scheduleRefreshContactsTick(FiniteDuration) - Method in class akka.cluster.client.ClusterClient
-
- SchedulerException - Exception in akka.actor
-
This exception is thrown by Scheduler.schedule* when scheduling is not
possible, e.g.
- SchedulerException(String) - Constructor for exception akka.actor.SchedulerException
-
- SchedulerException$ - Class in akka.actor
-
- SchedulerException$() - Constructor for class akka.actor.SchedulerException$
-
- SchedulerTickDuration() - Method in class akka.cluster.ClusterSettings
-
- SchedulerTicksPerWheel() - Method in class akka.cluster.ClusterSettings
-
- scheduleTick() - Method in class akka.contrib.pattern.ReliableProxy
-
- scheduleUnreachable(UniqueAddress) - Method in class akka.cluster.AutoDownBase
-
- SchemeAugmenter - Interface in akka.remote.transport
-
- schemeIdentifier() - Method in class akka.remote.transport.AbstractTransportAdapter
-
- schemeIdentifier() - Method in class akka.remote.transport.netty.NettyTransport
-
- schemeIdentifier() - Method in class akka.remote.transport.TestTransport
-
- SchemeIdentifier() - Method in class akka.remote.transport.ThrottlerTransportAdapter$
-
- SchemeIdentifier() - Static method in class akka.remote.transport.ThrottlerTransportAdapter
-
- schemeIdentifier() - Method in interface akka.remote.transport.Transport
-
Returns a string that will be used as the scheme part of the URLs corresponding to this transport
- scope() - Method in class akka.actor.Deploy
-
- Scope - Interface in akka.actor
-
The scope of a
Deploy
serves two purposes: as a marker for
pattern matching the “scope” (i.e.
- SCOPE_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DeployData
-
- second() - Method in class akka.japi.Pair
-
- SecureCookie() - Method in class akka.remote.transport.AkkaProtocolSettings
-
- SEED() - Method in class akka.util.HashCode$
-
- SEED() - Static method in class akka.util.HashCode
-
- Seed128() - Method in class akka.remote.security.provider.SeedSize$
-
- Seed128() - Static method in class akka.remote.security.provider.SeedSize
-
- Seed192() - Method in class akka.remote.security.provider.SeedSize$
-
- Seed192() - Static method in class akka.remote.security.provider.SeedSize
-
- Seed256() - Method in class akka.remote.security.provider.SeedSize$
-
- Seed256() - Static method in class akka.remote.security.provider.SeedSize
-
- seedNodeProcess() - Method in class akka.cluster.ClusterCoreDaemon
-
- seedNodeProcessCounter() - Method in class akka.cluster.ClusterCoreDaemon
-
- seedNodes() - Method in class akka.cluster.ClusterCoreDaemon
-
- SeedNodes() - Method in class akka.cluster.ClusterSettings
-
- seedNodes() - Method in class akka.cluster.InternalClusterAction.JoinSeedNodes
-
- SeedNodeTimeout() - Method in class akka.cluster.ClusterSettings
-
- SeedSize - Class in akka.remote.security.provider
-
INTERNAL API
From AESCounterRNG API docs:
Valid values are 16 (128 bits), 24 (192 bits) and 32 (256 bits).
- SeedSize() - Constructor for class akka.remote.security.provider.SeedSize
-
- SeedSize$ - Class in akka.remote.security.provider
-
INTERNAL API
From AESCounterRNG API docs:
Valid values are 16 (128 bits), 24 (192 bits) and 32 (256 bits).
- SeedSize$() - Constructor for class akka.remote.security.provider.SeedSize$
-
- seen(UniqueAddress) - Method in class akka.cluster.Gossip
-
Marks the gossip as seen by this node (address) by updating the address entry in the 'gossip.overview.seen'
- seen() - Method in class akka.cluster.GossipOverview
-
- SEEN_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview
-
- seenBy() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
-
- seenBy() - Method in class akka.cluster.ClusterEvent.SeenChanged
-
- seenBy() - Method in class akka.cluster.ClusterReadView
-
INTERNAL API
The nodes that has seen current version of the Gossip.
- seenBy() - Method in class akka.cluster.Gossip
-
The nodes that have seen the current version of the Gossip.
- seenByNode(UniqueAddress) - Method in class akka.cluster.Gossip
-
Has this Gossip been seen by this node.
- SeenChanged(boolean, Set<Address>) - Constructor for class akka.cluster.ClusterEvent.SeenChanged
-
- SeenChanged$() - Constructor for class akka.cluster.ClusterEvent.SeenChanged$
-
- seenLatest() - Method in class akka.cluster.VectorClockStats
-
- select(FiniteDuration, PartialFunction<Object, T>) - Method in class akka.actor.dsl.Inbox.Inbox
-
Receive a single message for which the given partial function is defined
and return the transformed result, using the internal receiver
actor.
- Select(Deadline, PartialFunction<Object, Object>, ActorRef) - Constructor for class akka.actor.dsl.Inbox.Select
-
- select(Object, IndexedSeq<Routee>) - Method in class akka.cluster.metrics.AdaptiveLoadBalancingRoutingLogic
-
- select(Object, IndexedSeq<Routee>) - Method in class akka.cluster.routing.AdaptiveLoadBalancingRoutingLogic
-
- select(Object, IndexedSeq<Routee>) - Method in class akka.routing.BalancingRoutingLogic
-
- select(Object, IndexedSeq<Routee>) - Method in class akka.routing.BroadcastRoutingLogic
-
- select(Object, IndexedSeq<Routee>) - Method in class akka.routing.ConsistentHashingRoutingLogic
-
- select(Object, IndexedSeq<Routee>) - Method in class akka.routing.RandomRoutingLogic
-
- select(Object, IndexedSeq<Routee>) - Method in class akka.routing.RoundRobinRoutingLogic
-
- select(Object, IndexedSeq<Routee>) - Method in interface akka.routing.RoutingLogic
-
Pick the destination for a given message.
- select(Object, IndexedSeq<Routee>) - Method in class akka.routing.ScatterGatherFirstCompletedRoutingLogic
-
- select(Object, IndexedSeq<Routee>) - Method in class akka.routing.SmallestMailboxRoutingLogic
-
- select(Object, IndexedSeq<Routee>) - Method in class akka.routing.TailChoppingRoutingLogic
-
- Select$() - Constructor for class akka.actor.dsl.Inbox.Select$
-
- SelectChildName - Class in akka.actor
-
INTERNAL API
- SelectChildName(String) - Constructor for class akka.actor.SelectChildName
-
- SelectChildName$ - Class in akka.actor
-
- SelectChildName$() - Constructor for class akka.actor.SelectChildName$
-
- SelectChildPattern - Class in akka.actor
-
INTERNAL API
- SelectChildPattern(String) - Constructor for class akka.actor.SelectChildPattern
-
- SelectChildPattern$ - Class in akka.actor
-
- SelectChildPattern$() - Constructor for class akka.actor.SelectChildPattern$
-
- selectDeploymentTarget() - Method in class akka.cluster.routing.ClusterRouterGroupActor
-
- selectDeploymentTarget() - Method in class akka.cluster.routing.ClusterRouterPoolActor
-
- SelectedSnapshot - Class in akka.persistence
-
- SelectedSnapshot(SnapshotMetadata, Object) - Constructor for class akka.persistence.SelectedSnapshot
-
- SelectedSnapshot$ - Class in akka.persistence
-
- SelectedSnapshot$() - Constructor for class akka.persistence.SelectedSnapshot$
-
- selection() - Method in exception akka.actor.ActorNotFound
-
- selection() - Method in class akka.routing.ActorSelectionRoutee
-
- SelectionHandler - Class in akka.io
-
- SelectionHandler(SelectionHandlerSettings) - Constructor for class akka.io.SelectionHandler
-
- SelectionHandler$ - Class in akka.io
-
- SelectionHandler$() - Constructor for class akka.io.SelectionHandler$
-
- SelectionHandler.ChannelAcceptable$ - Class in akka.io
-
- SelectionHandler.ChannelConnectable$ - Class in akka.io
-
- SelectionHandler.ChannelReadable$ - Class in akka.io
-
- SelectionHandler.ChannelWritable$ - Class in akka.io
-
- SelectionHandler.HasFailureMessage - Interface in akka.io
-
- SelectionHandler.Retry - Class in akka.io
-
- SelectionHandler.Retry$ - Class in akka.io
-
- SelectionHandler.SelectorBasedManager - Class in akka.io
-
- SelectionHandler.WorkerForCommand - Class in akka.io
-
- SelectionHandler.WorkerForCommand$ - Class in akka.io
-
- SelectionHandlerSettings - Class in akka.io
-
- SelectionHandlerSettings(Config) - Constructor for class akka.io.SelectionHandlerSettings
-
- SelectionPathElement - Interface in akka.actor
-
INTERNAL API
- selector() - Method in class akka.io.UdpListener
-
- SelectorAssociationRetries() - Method in class akka.io.SelectionHandlerSettings
-
- SelectorBasedManager(SelectionHandlerSettings, int) - Constructor for class akka.io.SelectionHandler.SelectorBasedManager
-
- SelectorDispatcher() - Method in class akka.io.SelectionHandlerSettings
-
- selectorPool() - Method in class akka.io.SelectionHandler.SelectorBasedManager
-
- selectors() - Method in class akka.cluster.metrics.MixMetricsSelector
-
- selectors() - Method in class akka.cluster.routing.MixMetricsSelector
-
- SelectParent - Class in akka.actor
-
INTERNAL API
- SelectParent() - Constructor for class akka.actor.SelectParent
-
- SelectParent$ - Class in akka.actor
-
INTERNAL API
- SelectParent$() - Constructor for class akka.actor.SelectParent$
-
- selectRandomNode(IndexedSeq<UniqueAddress>) - Method in class akka.cluster.ClusterCoreDaemon
-
- selectRandomNode(IndexedSeq<Address>) - Method in class akka.cluster.ClusterMetricsCollector
-
- selectRandomNode(IndexedSeq<Address>) - Method in class akka.cluster.metrics.ClusterMetricsCollector
-
- selectRandomNode(IndexedSeq<Address>) - Method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- self() - Method in interface akka.actor.Actor
-
The 'self' field holds the ActorRef for this actor.
- self() - Method in class akka.actor.ActorCell
-
- self() - Method in interface akka.actor.ActorContext
-
- self() - Method in interface akka.actor.Cell
-
The “self” reference which this Cell is attached to.
- self() - Method in interface akka.actor.StashSupport
-
INTERNAL API.
- self() - Method in class akka.actor.TypedActor$
-
Returns the reference to the proxy when called inside a method call in a TypedActor
- self() - Static method in class akka.actor.TypedActor
-
Returns the reference to the proxy when called inside a method call in a TypedActor
- self() - Method in class akka.actor.UnstartedCell
-
- self() - Method in class akka.cluster.ClusterReadView
-
- self() - Method in class akka.testkit.CallingThreadMailbox
-
- self() - Method in interface akka.testkit.ImplicitSender
-
- self() - Method in interface akka.typed.ActorContext
-
The identity of this Actor, bound to the lifecycle of this Actor instance.
- self() - Method in class akka.typed.ActorContextAdapter
-
- self() - Method in class akka.typed.StubbedActorContext
-
- selfAddress() - Method in class akka.cluster.AutoDown
-
- selfAddress() - Method in class akka.cluster.AutoDownBase
-
- selfAddress() - Method in class akka.cluster.Cluster
-
The address of this cluster member.
- selfAddress() - Method in class akka.cluster.ClusterHeartbeatSenderState
-
- selfAddress() - Method in class akka.cluster.ClusterReadView
-
- selfAddress() - Method in class akka.cluster.FirstSeedNodeProcess
-
- selfAddress() - Method in class akka.cluster.HeartbeatNodeRing
-
- selfAddress() - Method in class akka.cluster.JoinSeedNodeProcess
-
- selfAddress() - Method in class akka.routing.ConsistentRoutee
-
- selfAddressOption() - Method in class akka.cluster.singleton.ClusterSingletonManager
-
- SelfAware(Function1<ActorRef<T>, Behavior<T>>) - Method in class akka.typed.ScalaDSL$
-
A behavior decorator that extracts the self
ActorRef
while receiving the
the first signal or message and uses that to construct the real behavior
(which will then also receive that signal or message).
- SelfAware(Function1<ActorRef<T>, Behavior<T>>) - Static method in class akka.typed.ScalaDSL
-
A behavior decorator that extracts the self
ActorRef
while receiving the
the first signal or message and uses that to construct the real behavior
(which will then also receive that signal or message).
- selfExited() - Method in class akka.cluster.singleton.ClusterSingletonManager
-
- selfHeartbeat() - Method in class akka.cluster.ClusterHeartbeatSender
-
- selfHeartbeatRsp() - Method in class akka.cluster.ClusterHeartbeatReceiver
-
- selfHeartbeatRspMsg() - Method in class akka.remote.RemoteWatcher
-
- selfIndex() - Method in class akka.remote.testkit.MultiNodeSpec$
-
Index of this node in the roles sequence.
- selfIndex() - Static method in class akka.remote.testkit.MultiNodeSpec
-
Index of this node in the roles sequence.
- selfName() - Method in class akka.remote.testkit.MultiNodeSpec$
-
Name (or IP address; must be resolvable using InetAddress.getByName)
of the host this node is running on.
- selfName() - Static method in class akka.remote.testkit.MultiNodeSpec
-
Name (or IP address; must be resolvable using InetAddress.getByName)
of the host this node is running on.
- selfPort() - Method in class akka.remote.testkit.MultiNodeSpec$
-
Port number of this node.
- selfPort() - Static method in class akka.remote.testkit.MultiNodeSpec
-
Port number of this node.
- selfRoles() - Method in class akka.cluster.Cluster
-
roles that this member has
- selfUniqueAddress() - Method in class akka.cluster.Cluster
-
The address including a uid
of this cluster member.
- selfUniqueAddress() - Method in class akka.cluster.ClusterCoreDaemon
-
- selfUniqueAddress() - Method in class akka.cluster.ClusterDomainEventPublisher
-
- send(ActorRef, Object) - Method in class akka.actor.dsl.Inbox.Inbox
-
- send(ActorRef, Object) - Method in class akka.actor.Inbox
-
Have the internal actor act as the sender of the given message which will
be sent to the given target.
- send(T) - Method in class akka.agent.Agent
-
Dispatch a new value for the internal state.
- send(Function1<T, T>) - Method in class akka.agent.Agent
-
Dispatch a function to update the internal state.
- Send(String, Object, boolean) - Constructor for class akka.cluster.client.ClusterClient.Send
-
- Send(String, Object) - Constructor for class akka.cluster.client.ClusterClient.Send
-
Convenience constructor with localAffinity
false
- Send(String, Object, boolean) - Constructor for class akka.cluster.pubsub.DistributedPubSubMediator.Send
-
- Send(String, Object) - Constructor for class akka.cluster.pubsub.DistributedPubSubMediator.Send
-
Convenience constructor with localAffinity
false
- send(Object, ActorRef) - Method in class akka.contrib.pattern.ReliableProxy
-
- Send(ByteString, InetSocketAddress, Udp.Event) - Constructor for class akka.io.Udp.Send
-
- Send(ByteString, Object) - Constructor for class akka.io.UdpConnected.Send
-
- send(ByteString, Object) - Method in class akka.io.UdpConnectedMessage$
-
This message is understood by the connection actors to send data to their
designated destination.
- send(ByteString) - Method in class akka.io.UdpConnectedMessage$
-
Send without requesting acknowledgment.
- send(ByteString, Object) - Static method in class akka.io.UdpConnectedMessage
-
This message is understood by the connection actors to send data to their
designated destination.
- send(ByteString) - Static method in class akka.io.UdpConnectedMessage
-
Send without requesting acknowledgment.
- send(ByteString, InetSocketAddress, Udp.Event) - Method in class akka.io.UdpMessage$
-
This message is understood by the “simple sender” which can be obtained by
sending the
Udp.SimpleSender
query to the
UdpExt.manager()
as well as by
the listener actors which are created in response to
Udp.Bind
.
- send(ByteString, InetSocketAddress) - Method in class akka.io.UdpMessage$
-
The same as send(payload, target, noAck())
.
- send(ByteString, InetSocketAddress, Udp.Event) - Static method in class akka.io.UdpMessage
-
This message is understood by the “simple sender” which can be obtained by
sending the
Udp.SimpleSender
query to the
UdpExt.manager()
as well as by
the listener actors which are created in response to
Udp.Bind
.
- send(ByteString, InetSocketAddress) - Static method in class akka.io.UdpMessage
-
The same as send(payload, target, noAck())
.
- send(long, akka.persistence.AtLeastOnceDelivery.Internal.Delivery, long) - Method in interface akka.persistence.AtLeastOnceDelivery
-
- Send(Object, Option<ActorRef>, RemoteActorRef, Option<SeqNo>) - Constructor for class akka.remote.EndpointManager.Send
-
- send(Object, Option<ActorRef>, RemoteActorRef) - Method in class akka.remote.RemoteTransport
-
Sends the given message to the recipient supplying the sender() if any
- send(Object, Option<ActorRef>, RemoteActorRef) - Method in class akka.remote.Remoting
-
- send(Object, ActorRef) - Method in class akka.routing.ActorRefRoutee
-
- send(Object, ActorRef) - Method in class akka.routing.ActorSelectionRoutee
-
- send(Object, ActorRef) - Method in class akka.routing.NoRoutee$
-
- send(Object, ActorRef) - Static method in class akka.routing.NoRoutee
-
- send(Object, ActorRef) - Method in interface akka.routing.Routee
-
- send(Object, ActorRef) - Method in class akka.routing.ScatterGatherFirstCompletedRoutees
-
- send(Object, ActorRef) - Method in class akka.routing.SeveralRoutees
-
- send(Object, ActorRef) - Method in class akka.routing.TailChoppingRoutees
-
- send(ActorRef, Object) - Method in class akka.testkit.JavaTestKit
-
- send(ActorRef, Object) - Method in class akka.testkit.TestProbe
-
Send message to an actor while using the probe's TestActor as the sender.
- Send$() - Constructor for class akka.cluster.client.ClusterClient.Send$
-
- Send$() - Constructor for class akka.cluster.pubsub.DistributedPubSubMediator.Send$
-
- Send$() - Constructor for class akka.io.Udp.Send$
-
- Send$() - Constructor for class akka.io.UdpConnected.Send$
-
- Send$() - Constructor for class akka.remote.EndpointManager.Send$
-
- Send$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.Direction.Send$
-
- Send_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.Direction
-
Send = 1;
- sendBufferedMessages() - Method in class akka.remote.EndpointWriter
-
- SendBufferSize(int) - Constructor for class akka.io.Inet.SO$.SendBufferSize
-
- SendBufferSize() - Method in interface akka.io.Inet.SoForwarders
-
- sendBufferSize(int) - Method in interface akka.io.Inet.SoJavaFactories
-
- SendBufferSize() - Method in class akka.remote.transport.netty.NettyTransportSettings
-
- sendCurrentClusterState(ActorRef) - Method in class akka.cluster.Cluster
-
Send current (full) state of the cluster to the specified
receiver.
- sendCurrentClusterState(ActorRef) - Method in class akka.cluster.ClusterDomainEventPublisher
-
The current snapshot state corresponding to latest gossip
to mimic what you would have seen if you were listening to the events.
- SendCurrentClusterState(ActorRef) - Constructor for class akka.cluster.InternalClusterAction.SendCurrentClusterState
-
- SendCurrentClusterState$() - Constructor for class akka.cluster.InternalClusterAction.SendCurrentClusterState$
-
- sender() - Method in interface akka.actor.Actor
-
The reference sender Actor of the last received message.
- sender() - Method in class akka.actor.ActorCell
-
- sender() - Method in interface akka.actor.ActorContext
-
Returns the sender 'ActorRef' of the current message.
- sender() - Method in interface akka.actor.AllDeadLetters
-
- sender() - Method in class akka.actor.DeadLetter
-
- sender() - Method in class akka.actor.SuppressedDeadLetter
-
- sender() - Method in class akka.actor.UnhandledMessage
-
- sender() - Method in class akka.contrib.pattern.ReliableProxy.Message
-
- sender() - Method in class akka.contrib.throttle.TimerBasedThrottler.Message
-
- sender() - Method in class akka.dispatch.Envelope
-
- sender() - Method in class akka.io.Udp.Received
-
- sender() - Method in class akka.persistence.journal.AsyncWriteJournal.Desequenced
-
- sender() - Method in class akka.persistence.NonPersistentRepr
-
- sender() - Method in interface akka.persistence.PersistentEnvelope
-
- sender() - Method in class akka.persistence.PersistentImpl
-
- sender() - Method in interface akka.persistence.PersistentRepr
-
Sender of this message.
- sender() - Method in class akka.remote.transport.TestTransport.WriteAttempt
-
- sender() - Method in interface akka.testkit.TestActor.Message
-
- sender() - Method in class akka.testkit.TestActor.NullMessage$
-
- sender() - Method in class akka.testkit.TestActor.RealMessage
-
- sender() - Method in class akka.testkit.TestProbe
-
Get sender of last received message.
- SENDER_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
- SENDER_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.RemoteEnvelope
-
- senderFromInbox(akka.actor.dsl.Inbox.Inbox) - Method in interface akka.actor.dsl.Inbox
-
- senderOption() - Method in class akka.remote.EndpointManager.Send
-
- senderOption() - Method in class akka.remote.transport.AkkaPduCodec.Message
-
- sendGetContacts() - Method in class akka.cluster.client.ClusterClient
-
- sendGossip(Address, MetricsGossipEnvelope) - Method in class akka.cluster.ClusterMetricsCollector
-
- sendGossip(Address, MetricsGossipEnvelope) - Method in class akka.cluster.metrics.ClusterMetricsCollector
-
- sendGossipTo(Address) - Method in class akka.cluster.ClusterCoreDaemon
-
- SendGossipTo(Address) - Constructor for class akka.cluster.InternalClusterAction.SendGossipTo
-
- SendGossipTo$() - Constructor for class akka.cluster.InternalClusterAction.SendGossipTo$
-
- sendHandlers(ChannelRegistration) - Method in interface akka.io.WithUdpSend
-
- sendHeartbeat() - Method in class akka.remote.RemoteWatcher
-
- sendHostShardMsg(String, ActorRef) - Method in class akka.cluster.sharding.ShardCoordinator
-
- sendMessage(Envelope) - Method in interface akka.actor.Cell
-
Enqueue a message to be sent to the actor; may or may not actually
schedule the actor to run, depending on which type of cell it is.
- sendMessage(Object, ActorRef) - Method in interface akka.actor.Cell
-
Enqueue a message to be sent to the actor; may or may not actually
schedule the actor to run, depending on which type of cell it is.
- sendMessage(Envelope) - Method in interface akka.actor.dungeon.Dispatch
-
- sendMessage(Envelope) - Method in class akka.actor.UnstartedCell
-
- sendMessage(Envelope) - Method in class akka.routing.ResizablePoolCell
-
- sendMessage(Envelope) - Method in class akka.routing.RoutedActorCell
-
Route the message via the router to the selected destination.
- sendMsgBuffer(Shard.EntryStarted) - Method in class akka.cluster.sharding.Shard
-
- sendOff(Function1<T, T>, ExecutionContext) - Method in class akka.agent.Agent
-
Dispatch a function to update the internal state but on its own thread.
- sendOneMessageToEachGroup() - Method in class akka.cluster.pubsub.DistributedPubSubMediator.Publish
-
- sendSystemMessage(SystemMessage) - Method in interface akka.actor.Cell
-
Enqueue a message to be sent to the actor; may or may not actually
schedule the actor to run, depending on which type of cell it is.
- sendSystemMessage(SystemMessage) - Method in interface akka.actor.dungeon.Dispatch
-
- sendSystemMessage(SystemMessage) - Method in class akka.actor.EmptyLocalActorRef
-
- sendSystemMessage(SystemMessage) - Method in class akka.actor.InternalActorRef
-
- sendSystemMessage(SystemMessage) - Method in class akka.actor.LocalActorRef
-
- sendSystemMessage(SystemMessage) - Method in interface akka.actor.MinimalActorRef
-
- sendSystemMessage(SystemMessage) - Method in class akka.actor.RepointableActorRef
-
- sendSystemMessage(SystemMessage) - Method in class akka.actor.UnstartedCell
-
- sendSystemMessage(SystemMessage) - Method in class akka.pattern.PromiseActorRef
-
- sendSystemMessage(SystemMessage) - Method in class akka.remote.RemoteActorRef
-
- sendSystemMessage(SystemMessage) - Method in class akka.remote.RemoteSystemDaemon
-
- SendToAll(String, Object) - Constructor for class akka.cluster.client.ClusterClient.SendToAll
-
- SendToAll(String, Object, boolean) - Constructor for class akka.cluster.pubsub.DistributedPubSubMediator.SendToAll
-
- SendToAll(String, Object) - Constructor for class akka.cluster.pubsub.DistributedPubSubMediator.SendToAll
-
- SendToAll$() - Constructor for class akka.cluster.client.ClusterClient.SendToAll$
-
- SendToAll$() - Constructor for class akka.cluster.pubsub.DistributedPubSubMediator.SendToAll$
-
- SendToOneSubscriber(Object) - Constructor for class akka.cluster.pubsub.DistributedPubSubMediator.Internal$.SendToOneSubscriber
-
- seq() - Method in class akka.event.ActorClassificationUnsubscriber.Register
-
- seq() - Method in class akka.event.ActorClassificationUnsubscriber.Unregister
-
- seq(T...) - Static method in class akka.japi.JAPI
-
- seq() - Method in class akka.remote.EndpointManager.Send
-
- seq() - Method in interface akka.remote.HasSequenceNumber
-
Sequence number of the message
- seq() - Method in class akka.remote.transport.AkkaPduCodec.Message
-
- SEQ_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.RemoteEnvelope
-
- seqCauseDirective2Decider(Iterable<Tuple2<Class<? extends Throwable>, SupervisorStrategy.Directive>>) - Method in interface akka.actor.SupervisorStrategyLowPriorityImplicits
-
Implicit conversion from Seq
of Cause-Directive pairs to a Decider
.
- seqCounter() - Method in class akka.remote.ReliableDeliverySupervisor
-
- SeqNo - Class in akka.remote
-
- SeqNo(long) - Constructor for class akka.remote.SeqNo
-
- SeqNo$ - Class in akka.remote
-
- SeqNo$() - Constructor for class akka.remote.SeqNo$
-
- seqNr() - Method in class akka.event.ManagedActorClassification.ManagedActorClassificationMappings
-
- seqNum() - Method in interface akka.util.PriorityQueueStabilizer
-
- seqNum() - Method in class akka.util.PriorityQueueStabilizer.WrappedElement
-
- seqOpt() - Method in class akka.remote.EndpointManager.Send
-
- seqOption() - Method in class akka.remote.transport.AkkaPduCodec.Message
-
- seqOrdering() - Method in class akka.remote.AckedReceiveBuffer
-
- seqOrdering() - Method in class akka.remote.HasSequenceNumber$
-
- seqThrowable2Decider(Seq<Class<? extends Throwable>>) - Method in class akka.actor.SupervisorStrategy$
-
Implicit conversion from Seq
of Throwables to a Decider
.
- seqThrowable2Decider(Seq<Class<? extends Throwable>>) - Static method in class akka.actor.SupervisorStrategy
-
Implicit conversion from Seq
of Throwables to a Decider
.
- sequence(Iterable<Future<A>>, ExecutionContext) - Method in class akka.dispatch.Futures$
-
- sequence(Iterable<Future<A>>, ExecutionContext) - Static method in class akka.dispatch.Futures
-
- sequenceNr() - Method in interface akka.persistence.Eventsourced
-
- sequenceNr() - Method in class akka.persistence.journal.leveldb.Key
-
- sequenceNr() - Method in class akka.persistence.PersistenceFailure
-
- sequenceNr() - Method in class akka.persistence.PersistentImpl
-
- sequenceNr() - Method in interface akka.persistence.PersistentRepr
-
This persistent message's sequence number.
- sequenceNr() - Method in class akka.persistence.RecoveryFailure
-
- sequenceNr() - Method in class akka.persistence.SnapshotMetadata
-
- SEQUENCENR_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
- ser() - Method in class akka.cluster.GossipEnvelope
-
- serial() - Method in class akka.contrib.pattern.ReliableProxy.Message
-
- serialization() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
-
- serialization() - Method in class akka.remote.RemoteActorRefProvider
-
- serialization() - Method in class akka.remote.serialization.DaemonMsgCreateSerializer
-
- Serialization - Class in akka.serialization
-
Serialization module.
- Serialization(ExtendedActorSystem) - Constructor for class akka.serialization.Serialization
-
- Serialization$ - Class in akka.serialization
-
- Serialization$() - Constructor for class akka.serialization.Serialization$
-
- Serialization.Information - Class in akka.serialization
-
Serialization information needed for serializing local actor refs.
- Serialization.Information$ - Class in akka.serialization
-
- Serialization.Settings - Class in akka.serialization
-
- SerializationBindings() - Method in class akka.serialization.Serialization.Settings
-
- SerializationExtension - Class in akka.serialization
-
SerializationExtension is an Akka Extension to interact with the Serialization
that is built into Akka
- SerializationExtension() - Constructor for class akka.serialization.SerializationExtension
-
- SerializationExtension$ - Class in akka.serialization
-
SerializationExtension is an Akka Extension to interact with the Serialization
that is built into Akka
- SerializationExtension$() - Constructor for class akka.serialization.SerializationExtension$
-
- SerializationIdentifiers() - Method in interface akka.serialization.BaseSerializer
-
Configuration namespace of serialization identifiers in the reference.conf
.
- SerializationIdentity() - Method in class akka.util.ByteString.ByteString1$
-
- SerializationIdentity() - Method in class akka.util.ByteString.ByteString1C$
-
- SerializationIdentity() - Method in class akka.util.ByteString.ByteStrings$
-
- SerializationIdentity() - Method in interface akka.util.ByteString.Companion
-
- serialize(OutputStream, Snapshot) - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
-
- serialize(ExtendedActorSystem, Object) - Method in class akka.remote.MessageSerializer$
-
Uses Akka Serialization for the specified ActorSystem to transform the given message to a MessageProtocol
- serialize(ExtendedActorSystem, Object) - Static method in class akka.remote.MessageSerializer
-
Uses Akka Serialization for the specified ActorSystem to transform the given message to a MessageProtocol
- serialize(Object) - Method in class akka.remote.serialization.DaemonMsgCreateSerializer
-
- serialize(Object) - Method in class akka.serialization.Serialization
-
Serializes the given AnyRef/java.lang.Object according to the Serialization configuration
to either an Array of Bytes or an Exception if one was thrown.
- serializeActorRef(ActorRef) - Method in class akka.remote.serialization.ProtobufSerializer$
-
Helper to serialize an
ActorRef
to Akka's
protobuf representation.
- serializeActorRef(ActorRef) - Static method in class akka.remote.serialization.ProtobufSerializer
-
Helper to serialize an
ActorRef
to Akka's
protobuf representation.
- SerializeAllCreators() - Method in class akka.actor.ActorSystem.Settings
-
- SerializeAllMessages() - Method in class akka.actor.ActorSystem.Settings
-
- serialized() - Method in class akka.actor.DeadLetterActorRef$
-
- serialized() - Static method in class akka.actor.DeadLetterActorRef
-
- SERIALIZED_FIELD_NUMBER - Static variable in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number
-
- SERIALIZED_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number
-
- Serialized_VALUE - Static variable in enum akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.NumberType
-
Serialized = 0;
- Serialized_VALUE - Static variable in enum akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.NumberType
-
Serialized = 0;
- serializedActorPath(ActorRef) - Method in class akka.serialization.Serialization$
-
The serialized path of an actorRef, based on the current transport serialization information.
- serializedActorPath(ActorRef) - Static method in class akka.serialization.Serialization
-
The serialized path of an actorRef, based on the current transport serialization information.
- SerializedActorRef - Class in akka.actor
-
Memento pattern for serializing ActorRefs transparently
INTERNAL API
- SerializedActorRef(ActorRef) - Constructor for class akka.actor.SerializedActorRef
-
- SerializedActorRef$ - Class in akka.actor
-
INTERNAL API
- SerializedActorRef$() - Constructor for class akka.actor.SerializedActorRef$
-
- SerializedDeadLetterActorRef() - Constructor for class akka.actor.DeadLetterActorRef.SerializedDeadLetterActorRef
-
- SERIALIZEDGOSSIP_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope
-
- serializedMessage() - Method in class akka.remote.transport.AkkaPduCodec.Message
-
- SerializedMethodCall(Class<?>, String, Class<?>[], Tuple3<Object, Class<?>, byte[]>[]) - Constructor for class akka.actor.TypedActor.SerializedMethodCall
-
- SerializedMethodCall$() - Constructor for class akka.actor.TypedActor.SerializedMethodCall$
-
- SerializedNobody - Class in akka.actor
-
INTERNAL API
- SerializedNobody() - Constructor for class akka.actor.SerializedNobody
-
- serializedParameters() - Method in class akka.actor.TypedActor.SerializedMethodCall
-
- SerializedStandardOutLogger() - Constructor for class akka.event.Logging.SerializedStandardOutLogger
-
- SerializedSuspendableExecutionContext - Class in akka.util
-
This ExecutionContext
allows to wrap an underlying ExecutionContext
and provide guaranteed serial execution
of tasks submitted to it.
- SerializedSuspendableExecutionContext(int, ExecutionContext) - Constructor for class akka.util.SerializedSuspendableExecutionContext
-
- SerializedSuspendableExecutionContext$ - Class in akka.util
-
- SerializedSuspendableExecutionContext$() - Constructor for class akka.util.SerializedSuspendableExecutionContext$
-
- SerializedTypedActorInvocationHandler(ActorRef, FiniteDuration) - Constructor for class akka.actor.TypedActor.SerializedTypedActorInvocationHandler
-
- SerializedTypedActorInvocationHandler$() - Constructor for class akka.actor.TypedActor.SerializedTypedActorInvocationHandler$
-
- Serializer - Interface in akka.serialization
-
A Serializer represents a bimap between an object and an array of bytes representing that object.
- serializerByIdentity() - Method in class akka.serialization.Serialization
-
Maps from a Serializer Identity (Int) to a Serializer instance (optimization)
- serializerFor(Class<?>) - Method in class akka.serialization.Serialization
-
Returns the configured Serializer for the given Class.
- serializerId() - Method in class akka.persistence.serialization.SnapshotHeader
-
- SERIALIZERID_FIELD_NUMBER - Static variable in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload
-
- SERIALIZERID_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentPayload
-
- SERIALIZERID_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.SelectionEnvelope
-
- SERIALIZERID_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.SerializedMessage
-
- serializerOf(String) - Method in class akka.serialization.Serialization
-
Tries to load the specified Serializer by the fully-qualified name; the actual
loading is performed by the system’s
DynamicAccess
.
- Serializers() - Method in class akka.serialization.Serialization.Settings
-
- Server - Class in akka.remote.testconductor
-
INTERNAL API.
- Server() - Constructor for class akka.remote.testconductor.Server
-
- Server$ - Class in akka.remote.testconductor
-
INTERNAL API.
- Server$() - Constructor for class akka.remote.testconductor.Server$
-
- ServerFSM - Class in akka.remote.testconductor
-
The server part of each client connection is represented by a ServerFSM.
- ServerFSM(ActorRef, Channel) - Constructor for class akka.remote.testconductor.ServerFSM
-
- ServerFSM$ - Class in akka.remote.testconductor
-
INTERNAL API.
- ServerFSM$() - Constructor for class akka.remote.testconductor.ServerFSM$
-
- ServerFSM.Initial$ - Class in akka.remote.testconductor
-
- ServerFSM.Ready$ - Class in akka.remote.testconductor
-
- ServerFSM.State - Interface in akka.remote.testconductor
-
- ServerHandler - Class in akka.remote.transport.netty
-
INTERNAL API
- ServerHandler(NettyTransport, Future<Transport.AssociationEventListener>) - Constructor for class akka.remote.transport.netty.ServerHandler
-
- serverName() - Method in class akka.remote.testkit.MultiNodeSpec$
-
Name (or IP address; must be resolvable using InetAddress.getByName)
of the host that the server node is running on.
- serverName() - Static method in class akka.remote.testkit.MultiNodeSpec
-
Name (or IP address; must be resolvable using InetAddress.getByName)
of the host that the server node is running on.
- ServerOp - Interface in akka.remote.testconductor
-
- serverPort() - Method in class akka.remote.testkit.MultiNodeSpec$
-
Port number of the node that's running the server system.
- serverPort() - Static method in class akka.remote.testkit.MultiNodeSpec
-
Port number of the node that's running the server system.
- ServerSocketWorkerPoolSize() - Method in class akka.remote.testconductor.TestConductorExt.Settings
-
- ServerSocketWorkerPoolSize() - Method in class akka.remote.transport.netty.NettyTransportSettings
-
- serviceForReference(BundleContext, ServiceReference<?>) - Method in class akka.osgi.ActorSystemActivator
-
Convenience method to find a service by its reference.
- setAck(WireFormats.AcknowledgementInfo) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
optional .AcknowledgementInfo ack = 1;
- setAck(WireFormats.AcknowledgementInfo.Builder) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
optional .AcknowledgementInfo ack = 1;
- setActor(ActorCell) - Method in class akka.dispatch.Mailbox
-
- setActorFields(Actor, ActorContext, ActorRef) - Method in class akka.actor.ActorCell
-
- setAddr(TestConductorProtocol.Address) - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
-
optional .Address addr = 2;
- setAddr(TestConductorProtocol.Address.Builder) - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
-
optional .Address addr = 2;
- setAddr(TestConductorProtocol.AddressRequest) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .AddressRequest addr = 5;
- setAddr(TestConductorProtocol.AddressRequest.Builder) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .AddressRequest addr = 5;
- setAddress(ClusterMessages.Address) - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
-
required .Address address = 1;
- setAddress(ClusterMessages.Address.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
-
required .Address address = 1;
- setAddress(DistributedPubSubMessages.Address) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
-
required .Address address = 1;
- setAddress(DistributedPubSubMessages.Address.Builder) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
-
required .Address address = 1;
- setAddress(TestConductorProtocol.Address) - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
-
required .Address address = 2;
- setAddress(TestConductorProtocol.Address.Builder) - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
-
required .Address address = 2;
- setAddress(TestConductorProtocol.Address) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
optional .Address address = 3;
- setAddress(TestConductorProtocol.Address.Builder) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
optional .Address address = 3;
- setAddressIndex(int) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
required int32 addressIndex = 1;
- setAddressIndex(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
required int32 addressIndex = 1;
- setAddressIndex(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
required int32 addressIndex = 1;
- setAddressIndex(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
required int32 addressIndex = 1;
- setAddressIndex(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
-
required int32 addressIndex = 1;
- setAllAddresses(int, ClusterMetricsMessages.Address) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- setAllAddresses(int, ClusterMetricsMessages.Address.Builder) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- setAllAddresses(int, ClusterMessages.UniqueAddress) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .UniqueAddress allAddresses = 1;
- setAllAddresses(int, ClusterMessages.UniqueAddress.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .UniqueAddress allAddresses = 1;
- setAllAddresses(int, ClusterMessages.Address) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- setAllAddresses(int, ClusterMessages.Address.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .Address allAddresses = 1;
- setAllButSelf(boolean) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
-
required bool allButSelf = 2;
- setAllHashes(int, String) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated string allHashes = 3;
- setAllHashes(int, String) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
repeated string allHashes = 2;
- setAllMetricNames(int, String) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated string allMetricNames = 2;
- setAllMetricNames(int, String) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated string allMetricNames = 2;
- setAllowCoreThreadTimeout(boolean) - Method in class akka.dispatch.ThreadPoolConfigBuilder
-
- setAllRoles(int, String) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated string allRoles = 2;
- setAlpha(double) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA.Builder
-
required double alpha = 2;
- setAlpha(double) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
-
required double alpha = 2;
- setArgs(int, ByteString) - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated bytes args = 4;
- setAsIdle() - Method in class akka.dispatch.Mailbox
-
Reset Scheduled status, keeping primary status as is.
- setAsScheduled() - Method in class akka.dispatch.Mailbox
-
Set Scheduled status, keeping primary status as is.
- setAutoAck(boolean) - Method in interface akka.camel.internal.component.ActorEndpointConfig
-
- setAutoPilot(TestActor.AutoPilot) - Method in class akka.testkit.JavaTestKit
-
Install an AutoPilot to drive the testActor: the AutoPilot will be run for
each received message and can be used to send or forward messages, etc.
- SetAutoPilot(TestActor.AutoPilot) - Constructor for class akka.testkit.TestActor.SetAutoPilot
-
- setAutoPilot(TestActor.AutoPilot) - Method in interface akka.testkit.TestKitBase
-
Install an AutoPilot to drive the testActor: the AutoPilot will be run
for each received message and can be used to send or forward messages,
etc.
- SetAutoPilot$() - Constructor for class akka.testkit.TestActor.SetAutoPilot$
-
- setBarrier(TestConductorProtocol.EnterBarrier) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .EnterBarrier barrier = 2;
- setBarrier(TestConductorProtocol.EnterBarrier.Builder) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .EnterBarrier barrier = 2;
- setBuckets(int, DistributedPubSubMessages.Delta.Bucket) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Builder
-
repeated .Delta.Bucket buckets = 1;
- setBuckets(int, DistributedPubSubMessages.Delta.Bucket.Builder) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Builder
-
repeated .Delta.Bucket buckets = 1;
- setChildrenTerminationReason(ChildrenContainer.SuspendReason) - Method in interface akka.actor.dungeon.Children
-
- setClasses(int, String) - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated string classes = 5;
- setClazz(String) - Method in class akka.remote.WireFormats.PropsData.Builder
-
required string clazz = 3;
- setClazzBytes(ByteString) - Method in class akka.remote.WireFormats.PropsData.Builder
-
required string clazz = 3;
- setCommandType(WireFormats.CommandType) - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
-
required .CommandType commandType = 1;
- setConfig(ByteString) - Method in class akka.remote.WireFormats.DeployData.Builder
-
optional bytes config = 2;
- setContent(int, DistributedPubSubMessages.Delta.Entry) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
repeated .Delta.Entry content = 3;
- setContent(int, DistributedPubSubMessages.Delta.Entry.Builder) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
repeated .Delta.Entry content = 3;
- setCookie(String) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
optional string cookie = 3;
- setCookieBytes(ByteString) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
optional string cookie = 3;
- setCorePoolSize(int) - Method in class akka.dispatch.ThreadPoolConfigBuilder
-
- setCorePoolSizeFromFactor(int, double, int) - Method in class akka.dispatch.ThreadPoolConfigBuilder
-
- setCumulativeAck(long) - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
-
required fixed64 cumulativeAck = 1;
- setCurrentDeliveryId(long) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
required int64 currentDeliveryId = 1;
- setDeleted(boolean) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional bool deleted = 4;
- setDeliveryId(long) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
required int64 deliveryId = 1;
- setDeliverySnapshot(AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot) - Method in interface akka.persistence.AtLeastOnceDelivery
-
- setDeploy(WireFormats.DeployData) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required .DeployData deploy = 2;
- setDeploy(WireFormats.DeployData.Builder) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required .DeployData deploy = 2;
- setDeploy(WireFormats.DeployData) - Method in class akka.remote.WireFormats.PropsData.Builder
-
required .DeployData deploy = 2;
- setDeploy(WireFormats.DeployData.Builder) - Method in class akka.remote.WireFormats.PropsData.Builder
-
required .DeployData deploy = 2;
- setDestination(String) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
required string destination = 2;
- setDestinationBytes(ByteString) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
required string destination = 2;
- setDirection(TestConductorProtocol.Direction) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
optional .Direction direction = 2;
- setDispatcher(String) - Method in class akka.remote.WireFormats.DeployData.Builder
-
optional string dispatcher = 5;
- setDispatcherBytes(ByteString) - Method in class akka.remote.WireFormats.DeployData.Builder
-
optional string dispatcher = 5;
- setDone(String) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional string done = 4;
- setDoneBytes(ByteString) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional string done = 4;
- setEnclosedMessage(ByteString) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload.Builder
-
required bytes enclosedMessage = 1;
- setEnclosedMessage(ByteString) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
required bytes enclosedMessage = 1;
- setEnvelope(WireFormats.RemoteEnvelope) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
optional .RemoteEnvelope envelope = 2;
- setEnvelope(WireFormats.RemoteEnvelope.Builder) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
optional .RemoteEnvelope envelope = 2;
- setEwma(ClusterMetricsMessages.NodeMetrics.EWMA) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
optional .NodeMetrics.EWMA ewma = 3;
- setEwma(ClusterMetricsMessages.NodeMetrics.EWMA.Builder) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
optional .NodeMetrics.EWMA ewma = 3;
- setEwma(ClusterMessages.NodeMetrics.EWMA) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
optional .NodeMetrics.EWMA ewma = 3;
- setEwma(ClusterMessages.NodeMetrics.EWMA.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
optional .NodeMetrics.EWMA ewma = 3;
- setExitValue(int) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
optional int32 exitValue = 7;
- setFailed(ActorRef) - Method in interface akka.actor.dungeon.FaultHandling
-
- setFailure(FailureResult) - Method in class akka.camel.internal.CamelExchangeAdapter
-
Sets Exchange.getException from the given FailureResult message.
- setFailure(TestConductorProtocol.FailType) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
required .FailType failure = 1;
- setFailure(TestConductorProtocol.InjectFailure) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .InjectFailure failure = 3;
- setFailure(TestConductorProtocol.InjectFailure.Builder) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .InjectFailure failure = 3;
- setFrom(ClusterMetricsMessages.Address) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
required .Address from = 1;
- setFrom(ClusterMetricsMessages.Address.Builder) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
required .Address from = 1;
- setFrom(ClusterMessages.UniqueAddress) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
required .UniqueAddress from = 1;
- setFrom(ClusterMessages.UniqueAddress.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
required .UniqueAddress from = 1;
- setFrom(ClusterMessages.UniqueAddress) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
required .UniqueAddress from = 1;
- setFrom(ClusterMessages.UniqueAddress.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
required .UniqueAddress from = 1;
- setFrom(ClusterMessages.Address) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
required .Address from = 1;
- setFrom(ClusterMessages.Address.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
required .Address from = 1;
- setFrom(ClusterMessages.UniqueAddress) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
-
required .UniqueAddress from = 1;
- setFrom(ClusterMessages.UniqueAddress.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
-
required .UniqueAddress from = 1;
- setGossip(ClusterMetricsMessages.MetricsGossip) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
required .MetricsGossip gossip = 2;
- setGossip(ClusterMetricsMessages.MetricsGossip.Builder) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
required .MetricsGossip gossip = 2;
- setGossip(ClusterMessages.MetricsGossip) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
required .MetricsGossip gossip = 2;
- setGossip(ClusterMessages.MetricsGossip.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
required .MetricsGossip gossip = 2;
- setGossip(ClusterMessages.Gossip) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
-
required .Gossip gossip = 2;
- setGossip(ClusterMessages.Gossip.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Welcome.Builder
-
required .Gossip gossip = 2;
- setHandshakeInfo(WireFormats.AkkaHandshakeInfo) - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
-
optional .AkkaHandshakeInfo handshakeInfo = 2;
- setHandshakeInfo(WireFormats.AkkaHandshakeInfo.Builder) - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
-
optional .AkkaHandshakeInfo handshakeInfo = 2;
- setHashIndex(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
-
required int32 hashIndex = 1;
- setHello(TestConductorProtocol.Hello) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .Hello hello = 1;
- setHello(TestConductorProtocol.Hello.Builder) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .Hello hello = 1;
- setHost(String) - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
required string host = 3;
- setHostBytes(ByteString) - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
required string host = 3;
- setHostname(String) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
required string hostname = 2;
- setHostname(String) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
required string hostname = 2;
- setHostname(String) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
required string hostname = 2;
- setHostname(String) - Method in class akka.remote.WireFormats.AddressData.Builder
-
required string hostname = 2;
- setHostnameBytes(ByteString) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
required string hostname = 2;
- setHostnameBytes(ByteString) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
required string hostname = 2;
- setHostnameBytes(ByteString) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
required string hostname = 2;
- setHostnameBytes(ByteString) - Method in class akka.remote.WireFormats.AddressData.Builder
-
required string hostname = 2;
- SetIgnore(Option<PartialFunction<Object, Object>>) - Constructor for class akka.testkit.TestActor.SetIgnore
-
- SetIgnore$() - Constructor for class akka.testkit.TestActor.SetIgnore$
-
- setInstruction(WireFormats.AkkaControlMessage) - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
-
optional .AkkaControlMessage instruction = 2;
- setInstruction(WireFormats.AkkaControlMessage.Builder) - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
-
optional .AkkaControlMessage instruction = 2;
- setKeepAliveTime(Duration) - Method in class akka.dispatch.ThreadPoolConfigBuilder
-
- setKeepAliveTimeInMillis(long) - Method in class akka.dispatch.ThreadPoolConfigBuilder
-
- setKey(String) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
required string key = 1;
- setKeyBytes(ByteString) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
required string key = 1;
- setLastSequenceNr(long) - Method in interface akka.persistence.Eventsourced
-
- setLastSequenceNr(long) - Method in interface akka.persistence.PersistentView
-
- setLocalAffinity(boolean) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
required bool localAffinity = 2;
- setLogLevel(Logging.LogLevel) - Method in interface akka.event.LoggingBus
-
Change log level: default loggers (i.e.
- setMatcher(String) - Method in class akka.remote.ContainerFormats.Selection.Builder
-
optional string matcher = 2;
- setMatcherBytes(ByteString) - Method in class akka.remote.ContainerFormats.Selection.Builder
-
optional string matcher = 2;
- setMaxPoolSize(int) - Method in class akka.dispatch.ThreadPoolConfigBuilder
-
- setMaxPoolSizeFromFactor(int, double, int) - Method in class akka.dispatch.ThreadPoolConfigBuilder
-
- setMDC(Map<String, Object>) - Method in interface akka.event.DiagnosticLoggingAdapter
-
Java API:
Sets the values to be added to the MDC (Mapped Diagnostic Context) before the log is appended.
- setMembers(int, ClusterMessages.Member) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .Member members = 4;
- setMembers(int, ClusterMessages.Member.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
repeated .Member members = 4;
- setMessage(WireFormats.SerializedMessage) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
required .SerializedMessage message = 2;
- setMessage(WireFormats.SerializedMessage.Builder) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
required .SerializedMessage message = 2;
- setMessage(ByteString) - Method in class akka.remote.WireFormats.SerializedMessage.Builder
-
required bytes message = 1;
- setMessageManifest(ByteString) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload.Builder
-
optional bytes messageManifest = 4;
- setMessageManifest(ByteString) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
optional bytes messageManifest = 4;
- setMessageManifest(ByteString) - Method in class akka.remote.WireFormats.SerializedMessage.Builder
-
optional bytes messageManifest = 3;
- setMetrics(int, ClusterMetricsMessages.NodeMetrics.Metric) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- setMetrics(int, ClusterMetricsMessages.NodeMetrics.Metric.Builder) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- setMetrics(int, ClusterMessages.NodeMetrics.Metric) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- setMetrics(int, ClusterMessages.NodeMetrics.Metric.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
repeated .NodeMetrics.Metric metrics = 3;
- setNacks(int, long) - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
-
repeated fixed64 nacks = 2;
- setName(String) - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
-
required string name = 1;
- setName(String) - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
-
required string name = 1;
- setNameBytes(ByteString) - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
-
required string name = 1;
- setNameBytes(ByteString) - Method in class akka.remote.testconductor.TestConductorProtocol.Hello.Builder
-
required string name = 1;
- setNameIndex(int) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
required int32 nameIndex = 1;
- setNameIndex(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
required int32 nameIndex = 1;
- setNext(AbstractBoundedNodeQueue.Node<T>) - Method in class akka.dispatch.AbstractBoundedNodeQueue.Node
-
- setNext(AbstractNodeQueue.Node<T>) - Method in class akka.dispatch.AbstractNodeQueue.Node
-
- setNode(ClusterMessages.UniqueAddress) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
-
required .UniqueAddress node = 1;
- setNode(ClusterMessages.UniqueAddress.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
-
required .UniqueAddress node = 1;
- setNode(String) - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
-
required string node = 1;
- setNodeBytes(ByteString) - Method in class akka.remote.testconductor.TestConductorProtocol.AddressRequest.Builder
-
required string node = 1;
- setNodeMetrics(int, ClusterMetricsMessages.NodeMetrics) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- setNodeMetrics(int, ClusterMetricsMessages.NodeMetrics.Builder) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- setNodeMetrics(int, ClusterMessages.NodeMetrics) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- setNodeMetrics(int, ClusterMessages.NodeMetrics.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossip.Builder
-
repeated .NodeMetrics nodeMetrics = 3;
- setNumber(ClusterMetricsMessages.NodeMetrics.Number) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
required .NodeMetrics.Number number = 2;
- setNumber(ClusterMetricsMessages.NodeMetrics.Number.Builder) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Metric.Builder
-
required .NodeMetrics.Number number = 2;
- setNumber(ClusterMessages.NodeMetrics.Number) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
required .NodeMetrics.Number number = 2;
- setNumber(ClusterMessages.NodeMetrics.Number.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Metric.Builder
-
required .NodeMetrics.Number number = 2;
- setObserverReachability(int, ClusterMessages.ObserverReachability) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated .ObserverReachability observerReachability = 2;
- setObserverReachability(int, ClusterMessages.ObserverReachability.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated .ObserverReachability observerReachability = 2;
- setOp(TestConductorProtocol.BarrierOp) - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
-
required .BarrierOp op = 2;
- setOrigin(WireFormats.AddressData) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
required .AddressData origin = 1;
- setOrigin(WireFormats.AddressData.Builder) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
required .AddressData origin = 1;
- setOverview(ClusterMessages.GossipOverview) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
required .GossipOverview overview = 5;
- setOverview(ClusterMessages.GossipOverview.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
required .GossipOverview overview = 5;
- setOwner(DistributedPubSubMessages.Address) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
required .Address owner = 1;
- setOwner(DistributedPubSubMessages.Address.Builder) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
required .Address owner = 1;
- setPath(String) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
required string path = 1;
- setPath(String) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
-
required string path = 1;
- setPath(String) - Method in class akka.remote.WireFormats.ActorRefData.Builder
-
required string path = 1;
- setPath(String) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required string path = 3;
- setPath(String) - Method in class akka.remote.WireFormats.DeployData.Builder
-
required string path = 1;
- setPathBytes(ByteString) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
required string path = 1;
- setPathBytes(ByteString) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
-
required string path = 1;
- setPathBytes(ByteString) - Method in class akka.remote.WireFormats.ActorRefData.Builder
-
required string path = 1;
- setPathBytes(ByteString) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required string path = 3;
- setPathBytes(ByteString) - Method in class akka.remote.WireFormats.DeployData.Builder
-
required string path = 1;
- setPattern(int, ContainerFormats.Selection) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
repeated .Selection pattern = 3;
- setPattern(int, ContainerFormats.Selection.Builder) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
repeated .Selection pattern = 3;
- setPayload(DistributedPubSubMessages.Payload) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish.Builder
-
required .Payload payload = 3;
- setPayload(DistributedPubSubMessages.Payload.Builder) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish.Builder
-
required .Payload payload = 3;
- setPayload(DistributedPubSubMessages.Payload) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
required .Payload payload = 3;
- setPayload(DistributedPubSubMessages.Payload.Builder) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
required .Payload payload = 3;
- setPayload(DistributedPubSubMessages.Payload) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
-
required .Payload payload = 3;
- setPayload(DistributedPubSubMessages.Payload.Builder) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToAll.Builder
-
required .Payload payload = 3;
- setPayload(MessageFormats.PersistentPayload) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
required .PersistentPayload payload = 3;
- setPayload(MessageFormats.PersistentPayload.Builder) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
required .PersistentPayload payload = 3;
- setPayload(MessageFormats.PersistentPayload) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional .PersistentPayload payload = 1;
- setPayload(MessageFormats.PersistentPayload.Builder) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional .PersistentPayload payload = 1;
- setPayload(ByteString) - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
-
required bytes payload = 2;
- setPayload(ByteString) - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
-
optional bytes payload = 1;
- setPayloadManifest(ByteString) - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
-
optional bytes payloadManifest = 3;
- setPersistenceId(String) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional string persistenceId = 3;
- setPersistenceIdBytes(ByteString) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional string persistenceId = 3;
- setPort(int) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
required uint32 port = 3;
- setPort(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
required uint32 port = 3;
- setPort(int) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
required uint32 port = 3;
- setPort(int) - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
required int32 port = 4;
- setPort(int) - Method in class akka.remote.WireFormats.AddressData.Builder
-
required uint32 port = 3;
- setProps(WireFormats.PropsData) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required .PropsData props = 1;
- setProps(WireFormats.PropsData.Builder) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required .PropsData props = 1;
- setProtocol(String) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
optional string protocol = 4;
- setProtocol(String) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
optional string protocol = 4;
- setProtocol(String) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
optional string protocol = 4;
- setProtocol(String) - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
required string protocol = 1;
- setProtocol(String) - Method in class akka.remote.WireFormats.AddressData.Builder
-
optional string protocol = 4;
- setProtocolBytes(ByteString) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
optional string protocol = 4;
- setProtocolBytes(ByteString) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
optional string protocol = 4;
- setProtocolBytes(ByteString) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
optional string protocol = 4;
- setProtocolBytes(ByteString) - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
required string protocol = 1;
- setProtocolBytes(ByteString) - Method in class akka.remote.WireFormats.AddressData.Builder
-
optional string protocol = 4;
- setQueueFactory(Function0<BlockingQueue<Runnable>>) - Method in class akka.dispatch.ThreadPoolConfigBuilder
-
- SetRate(Throttler.Rate) - Constructor for class akka.contrib.throttle.Throttler.SetRate
-
- SetRate$() - Constructor for class akka.contrib.throttle.Throttler.SetRate$
-
- setRateMBit(float) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
optional float rateMBit = 6;
- setRawResult(BoxedUnit) - Method in class akka.dispatch.ForkJoinExecutorConfigurator.AkkaForkJoinTask
-
- setRawResult(BoxedUnit) - Method in class akka.dispatch.Mailbox
-
- setReceiveTimeout(Duration) - Method in interface akka.actor.ActorContext
-
Defines the inactivity timeout after which the sending of a
ReceiveTimeout
message is triggered.
- setReceiveTimeout(Duration) - Method in interface akka.actor.dungeon.ReceiveTimeout
-
- setReceiveTimeout(Duration) - Method in interface akka.typed.ActorContext
-
Schedule the sending of a
ReceiveTimeout
notification in case no other
message is received during the given period of time.
- setReceiveTimeout(Duration) - Method in class akka.typed.ActorContextAdapter
-
- setReceiveTimeout(Duration) - Method in class akka.typed.EffectfulActorContext
-
- setReceiveTimeout(Duration) - Method in class akka.typed.StubbedActorContext
-
- setRecipient(WireFormats.ActorRefData) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
required .ActorRefData recipient = 1;
- setRecipient(WireFormats.ActorRefData.Builder) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
required .ActorRefData recipient = 1;
- setRef(String) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
optional string ref = 3;
- setRefBytes(ByteString) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
optional string ref = 3;
- setReply(boolean) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.MetricsGossipEnvelope.Builder
-
required bool reply = 3;
- setReply(boolean) - Method in class akka.cluster.protobuf.msg.ClusterMessages.MetricsGossipEnvelope.Builder
-
required bool reply = 3;
- setReplyTimeout(FiniteDuration) - Method in interface akka.camel.internal.component.ActorEndpointConfig
-
- setRequest(CamelMessage) - Method in class akka.camel.internal.CamelExchangeAdapter
-
Sets Exchange.getIn from the given CamelMessage object.
- setResponse(CamelMessage) - Method in class akka.camel.internal.CamelExchangeAdapter
-
Depending on the exchange pattern, sets Exchange.getIn or Exchange.getOut from the given
CamelMessage object.
- setRoles(int, String) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Join.Builder
-
repeated string roles = 2;
- setRolesIndexes(int, int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
repeated int32 rolesIndexes = 4 [packed = true];
- setRouterConfig(ByteString) - Method in class akka.remote.WireFormats.DeployData.Builder
-
optional bytes routerConfig = 3;
- setScope(ByteString) - Method in class akka.remote.WireFormats.DeployData.Builder
-
optional bytes scope = 4;
- setSeen(int, int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated int32 seen = 1;
- setSender(String) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional string sender = 11;
- setSender(WireFormats.ActorRefData) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
optional .ActorRefData sender = 4;
- setSender(WireFormats.ActorRefData.Builder) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
optional .ActorRefData sender = 4;
- setSenderBytes(ByteString) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional string sender = 11;
- setSeq(long) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
optional fixed64 seq = 5;
- setSequenceNr(long) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional int64 sequenceNr = 2;
- setSerialized(ByteString) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number.Builder
-
optional bytes serialized = 4;
- setSerialized(ByteString) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
-
optional bytes serialized = 4;
- setSerializedGossip(ByteString) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
required bytes serializedGossip = 3;
- setSerializerId(int) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload.Builder
-
required int32 serializerId = 2;
- setSerializerId(int) - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
-
required int32 serializerId = 1;
- setSerializerId(int) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
required int32 serializerId = 2;
- setSerializerId(int) - Method in class akka.remote.WireFormats.SerializedMessage.Builder
-
required int32 serializerId = 2;
- setState(S, D, FiniteDuration, Option<FSM.Reason>) - Method in class akka.testkit.TestFSMRef
-
Change FSM state; any value left out defaults to the current FSM state
(timeout defaults to None).
- setStateTimeout(S, Option<FiniteDuration>) - Method in interface akka.actor.FSM
-
- setStatus(ClusterMessages.MemberStatus) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
required .MemberStatus status = 3;
- setStatus(ClusterMessages.ReachabilityStatus) - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
-
required .ReachabilityStatus status = 3;
- setStatus(int) - Method in class akka.dispatch.Mailbox
-
- SetStore(ActorRef) - Constructor for class akka.persistence.journal.AsyncWriteProxy.SetStore
-
- setStore(ActorRef, ActorSystem) - Method in class akka.persistence.journal.leveldb.SharedLeveldbJournal$
-
Sets the shared LevelDB store
for the given actor system
.
- setStore(ActorRef, ActorSystem) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
Sets the shared LevelDB store
for the given actor system
.
- SetStore$() - Constructor for class akka.persistence.journal.AsyncWriteProxy.SetStore$
-
- setSubjectReachability(int, ClusterMessages.SubjectReachability) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
repeated .SubjectReachability subjectReachability = 2;
- setSubjectReachability(int, ClusterMessages.SubjectReachability.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
repeated .SubjectReachability subjectReachability = 2;
- setSupervisor(WireFormats.ActorRefData) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required .ActorRefData supervisor = 4;
- setSupervisor(WireFormats.ActorRefData.Builder) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
-
required .ActorRefData supervisor = 4;
- setSystem(String) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
required string system = 1;
- setSystem(String) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
required string system = 1;
- setSystem(String) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
required string system = 1;
- setSystem(String) - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
required string system = 2;
- setSystem(String) - Method in class akka.remote.WireFormats.AddressData.Builder
-
required string system = 1;
- setSystemBytes(ByteString) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address.Builder
-
required string system = 1;
- setSystemBytes(ByteString) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Address.Builder
-
required string system = 1;
- setSystemBytes(ByteString) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address.Builder
-
required string system = 1;
- setSystemBytes(ByteString) - Method in class akka.remote.testconductor.TestConductorProtocol.Address.Builder
-
required string system = 2;
- setSystemBytes(ByteString) - Method in class akka.remote.WireFormats.AddressData.Builder
-
required string system = 1;
- SetTarget(Option<ActorRef>) - Constructor for class akka.contrib.throttle.Throttler.SetTarget
-
- SetTarget(ActorRef) - Constructor for class akka.contrib.throttle.Throttler.SetTarget
-
Java API:
- SetTarget$() - Constructor for class akka.contrib.throttle.Throttler.SetTarget$
-
- setTerminated() - Method in interface akka.actor.dungeon.Children
-
- SetThrottle(Address, ThrottlerTransportAdapter.Direction, ThrottlerTransportAdapter.ThrottleMode) - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.SetThrottle
-
- SetThrottle$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.SetThrottle$
-
- SetThrottleAck$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.SetThrottleAck$
-
- setTimeout(long) - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
-
optional int64 timeout = 3;
- setTimer(String, Object, FiniteDuration) - Method in class akka.actor.AbstractFSM
-
Schedule named timer to deliver message after given delay, possibly repeating.
- setTimer(String, Object, FiniteDuration, boolean) - Method in interface akka.actor.FSM
-
- setTimer(String, Object, FiniteDuration, boolean) - Method in class akka.testkit.TestFSMRef
-
- setTimestamp(long) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Builder
-
required int64 timestamp = 2;
- setTimestamp(long) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Builder
-
required int64 timestamp = 2;
- setTimestamp(long) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
optional int64 timestamp = 1;
- setTimestamp(long) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Version.Builder
-
required int64 timestamp = 2;
- setTimestamp(long) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Version.Builder
-
required int64 timestamp = 2;
- settings() - Method in interface akka.actor.ActorRefProvider
-
The Settings associated with this ActorRefProvider
- settings() - Method in class akka.actor.ActorSystem
-
The core settings extracted from the supplied configuration.
- Settings(ClassLoader, Config, String) - Constructor for class akka.actor.ActorSystem.Settings
-
- settings() - Method in class akka.actor.ActorSystemImpl
-
- settings() - Method in class akka.actor.Deployer
-
- settings() - Method in class akka.actor.LocalActorRefProvider
-
- settings() - Method in interface akka.camel.Camel
-
The settings for the CamelExtension
- settings() - Method in class akka.camel.internal.DefaultCamel
-
- settings() - Method in class akka.cluster.Cluster
-
- settings() - Method in class akka.cluster.metrics.ClusterMetricsExtension
-
Metrics extension configuration.
- settings() - Method in class akka.cluster.metrics.DefaultSigarProvider
-
- settings() - Method in interface akka.cluster.routing.ClusterRouterActor
-
- settings() - Method in interface akka.cluster.routing.ClusterRouterConfigBase
-
- settings() - Method in class akka.cluster.routing.ClusterRouterGroup
-
- settings() - Method in class akka.cluster.routing.ClusterRouterGroupActor
-
- settings() - Method in class akka.cluster.routing.ClusterRouterPool
-
- settings() - Method in class akka.cluster.routing.ClusterRouterPoolActor
-
- Settings() - Method in class akka.cluster.sharding.ClusterSharding
-
Accessor for nested Scala object
- settings() - Method in class akka.dispatch.DefaultDispatcherPrerequisites
-
- settings() - Method in interface akka.dispatch.DispatcherPrerequisites
-
- settings() - Method in class akka.dispatch.Dispatchers
-
- settings() - Method in class akka.dispatch.Mailboxes
-
- Settings() - Method in class akka.io.DnsExt
-
- Settings(Config) - Constructor for class akka.io.DnsExt.Settings
-
- Settings() - Method in class akka.io.TcpExt
-
- Settings(Config) - Constructor for class akka.io.TcpExt.Settings
-
- settings() - Method in class akka.io.UdpConnectedExt
-
- settings() - Method in class akka.io.UdpExt
-
- settings() - Method in interface akka.io.WithUdpSend
-
- settings() - Method in class akka.persistence.Persistence
-
- settings() - Method in class akka.remote.EndpointActor
-
- settings() - Method in class akka.remote.EndpointManager
-
- settings() - Method in class akka.remote.ReliableDeliverySupervisor
-
- settings() - Method in class akka.remote.RemoteActorRefProvider
-
- settings() - Method in class akka.remote.testconductor.ClientFSM
-
- settings() - Method in class akka.remote.testconductor.Controller
-
- Settings() - Method in class akka.remote.testconductor.TestConductorExt
-
- Settings() - Constructor for class akka.remote.testconductor.TestConductorExt.Settings
-
- settings() - Method in class akka.remote.transport.netty.NettyTransport
-
- settings() - Method in class akka.remote.transport.TransportAdapters
-
- settings() - Method in class akka.serialization.Serialization
-
- Settings(Config) - Constructor for class akka.serialization.Serialization.Settings
-
- settings() - Method in class akka.typed.ActorSystem
-
The core settings extracted from the supplied configuration.
- Settings$() - Constructor for class akka.cluster.sharding.ClusterSharding.Settings$
-
- setTo(ClusterMessages.UniqueAddress) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
required .UniqueAddress to = 2;
- setTo(ClusterMessages.UniqueAddress.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipEnvelope.Builder
-
required .UniqueAddress to = 2;
- setTopic(String) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish.Builder
-
required string topic = 1;
- setTopicBytes(ByteString) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish.Builder
-
required string topic = 1;
- setType(ClusterMetricsMessages.NodeMetrics.NumberType) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number.Builder
-
required .NodeMetrics.NumberType type = 1;
- setType(ClusterMessages.NodeMetrics.NumberType) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
-
required .NodeMetrics.NumberType type = 1;
- setType(ContainerFormats.PatternType) - Method in class akka.remote.ContainerFormats.Selection.Builder
-
required .PatternType type = 1;
- setUid(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
-
required uint32 uid = 2;
- setUid(long) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
required fixed64 uid = 2;
- setUnconfirmedDeliveries(int, MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- setUnconfirmedDeliveries(int, MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- setUpNumber(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Member.Builder
-
required int32 upNumber = 2;
- setUpStdoutLogger(ActorSystem.Settings) - Method in interface akka.event.LoggingBus
-
- setValue(double) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.EWMA.Builder
-
required double value = 1;
- setValue(double) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.EWMA.Builder
-
required double value = 1;
- setValue32(int) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number.Builder
-
optional uint32 value32 = 2;
- setValue32(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
-
optional uint32 value32 = 2;
- setValue64(long) - Method in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.Number.Builder
-
optional uint64 value64 = 3;
- setValue64(long) - Method in class akka.cluster.protobuf.msg.ClusterMessages.NodeMetrics.Number.Builder
-
optional uint64 value64 = 3;
- setVersion(ClusterMessages.VectorClock) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
required .VectorClock version = 6;
- setVersion(ClusterMessages.VectorClock.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.Gossip.Builder
-
required .VectorClock version = 6;
- setVersion(ClusterMessages.VectorClock) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
required .VectorClock version = 3;
- setVersion(ClusterMessages.VectorClock.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipStatus.Builder
-
required .VectorClock version = 3;
- setVersion(long) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
required int64 version = 4;
- setVersion(long) - Method in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability.Builder
-
required int64 version = 4;
- setVersion(long) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
required int64 version = 2;
- setVersion(long) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
required int64 version = 2;
- setVersions(int, ClusterMessages.VectorClock.Version) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
repeated .VectorClock.Version versions = 2;
- setVersions(int, ClusterMessages.VectorClock.Version.Builder) - Method in class akka.cluster.protobuf.msg.ClusterMessages.VectorClock.Builder
-
repeated .VectorClock.Version versions = 2;
- setVersions(int, DistributedPubSubMessages.Status.Version) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
repeated .Status.Version versions = 1;
- setVersions(int, DistributedPubSubMessages.Status.Version.Builder) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
repeated .Status.Version versions = 1;
- setWildcardFanOut(boolean) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
optional bool wildcardFanOut = 5;
- SeveralRoutees - Class in akka.routing
-
Routee
that sends each message to all
routees
.
- SeveralRoutees(IndexedSeq<Routee>) - Constructor for class akka.routing.SeveralRoutees
-
- SeveralRoutees(Iterable<Routee>) - Constructor for class akka.routing.SeveralRoutees
-
Java API
- SeveralRoutees$ - Class in akka.routing
-
- SeveralRoutees$() - Constructor for class akka.routing.SeveralRoutees$
-
- sha1(String) - Method in class akka.util.Crypt$
-
- sha1(byte[]) - Method in class akka.util.Crypt$
-
- sha1(String) - Static method in class akka.util.Crypt
-
- sha1(byte[]) - Static method in class akka.util.Crypt
-
- shallDie(ActorRef) - Method in interface akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer
-
- shallDie(ActorRef) - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
-
- shallDie(ActorRef) - Method in interface akka.actor.dungeon.ChildrenContainer
-
- shallDie(ActorRef) - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
-
- Shard - Class in akka.cluster.sharding
-
INTERNAL API
- Shard(String, String, Props, FiniteDuration, FiniteDuration, FiniteDuration, int, boolean, PartialFunction<Object, Tuple2<String, Object>>, Function1<Object, String>) - Constructor for class akka.cluster.sharding.Shard
-
- shard() - Method in class akka.cluster.sharding.ShardCoordinator.Internal$.AllocateShardResult
-
- shard() - Method in class akka.cluster.sharding.ShardCoordinator.Internal$.BeginHandOff
-
- shard() - Method in class akka.cluster.sharding.ShardCoordinator.Internal$.BeginHandOffAck
-
- shard() - Method in class akka.cluster.sharding.ShardCoordinator.Internal$.GetShardHome
-
- shard() - Method in class akka.cluster.sharding.ShardCoordinator.Internal$.HandOff
-
- shard() - Method in class akka.cluster.sharding.ShardCoordinator.Internal$.HostShard
-
- shard() - Method in class akka.cluster.sharding.ShardCoordinator.Internal$.ShardHome
-
- shard() - Method in class akka.cluster.sharding.ShardCoordinator.Internal$.ShardHomeAllocated
-
- shard() - Method in class akka.cluster.sharding.ShardCoordinator.Internal$.ShardHomeDeallocated
-
- shard() - Method in class akka.cluster.sharding.ShardCoordinator.Internal$.ShardStarted
-
- shard() - Method in class akka.cluster.sharding.ShardCoordinator.Internal$.ShardStopped
-
- Shard$ - Class in akka.cluster.sharding
-
INTERNAL API
- Shard$() - Constructor for class akka.cluster.sharding.Shard$
-
- Shard.EntryStarted - Class in akka.cluster.sharding
-
- Shard.EntryStarted$ - Class in akka.cluster.sharding
-
- Shard.EntryStopped - Class in akka.cluster.sharding
-
- Shard.EntryStopped$ - Class in akka.cluster.sharding
-
- Shard.RestartEntry - Class in akka.cluster.sharding
-
- Shard.RestartEntry$ - Class in akka.cluster.sharding
-
- Shard.RetryPersistence - Class in akka.cluster.sharding
-
- Shard.RetryPersistence$ - Class in akka.cluster.sharding
-
- Shard.ShardCommand - Interface in akka.cluster.sharding
-
- Shard.State - Class in akka.cluster.sharding
-
- Shard.State$ - Class in akka.cluster.sharding
-
- Shard.StateChange - Interface in akka.cluster.sharding
-
- shardBuffers() - Method in class akka.cluster.sharding.ShardRegion
-
- ShardCoordinator - Class in akka.cluster.sharding
-
Singleton coordinator that decides where to allocate shards.
- ShardCoordinator(FiniteDuration, FiniteDuration, FiniteDuration, FiniteDuration, akka.cluster.sharding.ShardCoordinator.ShardAllocationStrategy) - Constructor for class akka.cluster.sharding.ShardCoordinator
-
- ShardCoordinator$ - Class in akka.cluster.sharding
-
- ShardCoordinator$() - Constructor for class akka.cluster.sharding.ShardCoordinator$
-
- ShardCoordinator.AbstractShardAllocationStrategy - Class in akka.cluster.sharding
-
Java API: Java implementations of custom shard allocation and rebalancing logic used by the
ShardCoordinator
should extend this abstract class and implement the two methods.
- ShardCoordinator.Internal$ - Class in akka.cluster.sharding
-
INTERNAL API
- ShardCoordinator.Internal$.AllocateShardResult - Class in akka.cluster.sharding
-
Result of allocateShard
is piped to self with this message.
- ShardCoordinator.Internal$.BeginHandOff - Class in akka.cluster.sharding
-
ShardCoordinator
initiates rebalancing process by sending this message
to all registered ShardRegion
actors (including proxy only).
- ShardCoordinator.Internal$.BeginHandOffAck - Class in akka.cluster.sharding
-
- ShardCoordinator.Internal$.CoordinatorCommand - Interface in akka.cluster.sharding
-
Messages sent to the coordinator
- ShardCoordinator.Internal$.CoordinatorMessage - Interface in akka.cluster.sharding
-
Messages sent from the coordinator
- ShardCoordinator.Internal$.DomainEvent - Interface in akka.cluster.sharding
-
- ShardCoordinator.Internal$.GetShardHome - Class in akka.cluster.sharding
-
ShardRegion
requests the location of a shard by sending this message
to the ShardCoordinator
.
- ShardCoordinator.Internal$.HandOff - Class in akka.cluster.sharding
-
When all ShardRegion
actors have acknoledged the BeginHandOff
the
ShardCoordinator
sends this message to the ShardRegion
responsible for the
shard.
- ShardCoordinator.Internal$.HostShard - Class in akka.cluster.sharding
-
ShardCoodinator
informs a ShardRegion
that it is hosting this shard
- ShardCoordinator.Internal$.RebalanceResult - Class in akka.cluster.sharding
-
Result of rebalance
is piped to self with this message.
- ShardCoordinator.Internal$.Register - Class in akka.cluster.sharding
-
- ShardCoordinator.Internal$.RegisterAck - Class in akka.cluster.sharding
-
- ShardCoordinator.Internal$.RegisterProxy - Class in akka.cluster.sharding
-
- ShardCoordinator.Internal$.ShardHome - Class in akka.cluster.sharding
-
- ShardCoordinator.Internal$.ShardHomeAllocated - Class in akka.cluster.sharding
-
- ShardCoordinator.Internal$.ShardHomeDeallocated - Class in akka.cluster.sharding
-
- ShardCoordinator.Internal$.ShardRegionProxyRegistered - Class in akka.cluster.sharding
-
- ShardCoordinator.Internal$.ShardRegionProxyTerminated - Class in akka.cluster.sharding
-
- ShardCoordinator.Internal$.ShardRegionRegistered - Class in akka.cluster.sharding
-
- ShardCoordinator.Internal$.ShardRegionTerminated - Class in akka.cluster.sharding
-
- ShardCoordinator.Internal$.ShardStarted - Class in akka.cluster.sharding
-
- ShardCoordinator.Internal$.ShardStopped - Class in akka.cluster.sharding
-
Reply to HandOff
when all entries in the shard have been terminated.
- ShardCoordinator.Internal$.SnapshotTick - Class in akka.cluster.sharding
-
Periodic message to trigger persistent snapshot
- ShardCoordinator.Internal$.State - Class in akka.cluster.sharding
-
- ShardCoordinator.LeastShardAllocationStrategy - Class in akka.cluster.sharding
-
- ShardCoordinator.RebalanceWorker - Class in akka.cluster.sharding
-
INTERNAL API.
- ShardCoordinator.ShardAllocationStrategy - Interface in akka.cluster.sharding
-
Interface of the pluggable shard allocation and rebalancing logic used by the
ShardCoordinator
.
- ShardCoordinatorSupervisor - Class in akka.cluster.sharding
-
- ShardCoordinatorSupervisor(FiniteDuration, Props) - Constructor for class akka.cluster.sharding.ShardCoordinatorSupervisor
-
- ShardCoordinatorSupervisor$ - Class in akka.cluster.sharding
-
- ShardCoordinatorSupervisor$() - Constructor for class akka.cluster.sharding.ShardCoordinatorSupervisor$
-
- ShardFailureBackoff() - Method in class akka.cluster.sharding.ClusterSharding.Settings$
-
- ShardHome(String, ActorRef) - Constructor for class akka.cluster.sharding.ShardCoordinator.Internal$.ShardHome
-
- ShardHomeAllocated(String, ActorRef) - Constructor for class akka.cluster.sharding.ShardCoordinator.Internal$.ShardHomeAllocated
-
- ShardHomeDeallocated(String) - Constructor for class akka.cluster.sharding.ShardCoordinator.Internal$.ShardHomeDeallocated
-
- shardId(Object) - Method in interface akka.cluster.sharding.ShardRegion.MessageExtractor
-
Extract the entry id from an incoming message
.
- sharding() - Method in class akka.cluster.sharding.ClusterShardingGuardian
-
- shardRegion(String) - Method in class akka.cluster.sharding.ClusterSharding
-
Retrieve the actor reference of the
ShardRegion
actor responsible for the named entry type.
- shardRegion() - Method in class akka.cluster.sharding.ClusterShardingGuardian.Started
-
- shardRegion() - Method in class akka.cluster.sharding.ShardCoordinator.Internal$.AllocateShardResult
-
- shardRegion() - Method in class akka.cluster.sharding.ShardCoordinator.Internal$.Register
-
- ShardRegion - Class in akka.cluster.sharding
-
This actor creates children entry actors on demand for the shards that it is told to be
responsible for.
- ShardRegion(String, Option<Props>, Option<String>, String, FiniteDuration, FiniteDuration, FiniteDuration, FiniteDuration, int, boolean, PartialFunction<Object, Tuple2<String, Object>>, Function1<Object, String>) - Constructor for class akka.cluster.sharding.ShardRegion
-
- ShardRegion$ - Class in akka.cluster.sharding
-
- ShardRegion$() - Constructor for class akka.cluster.sharding.ShardRegion$
-
- ShardRegion.HandOffStopper - Class in akka.cluster.sharding
-
INTERNAL API.
- ShardRegion.MessageExtractor - Interface in akka.cluster.sharding
-
Java API: Interface of functions to extract entry id,
shard id, and the message to send to the entry from an
incoming message.
- ShardRegion.Passivate - Class in akka.cluster.sharding
-
If the state of the entries are persistent you may stop entries that are not used to
reduce memory consumption.
- ShardRegion.Passivate$ - Class in akka.cluster.sharding
-
- ShardRegion.ShardRegionCommand - Interface in akka.cluster.sharding
-
- shardRegionProxy() - Method in class akka.cluster.sharding.ShardCoordinator.Internal$.RegisterProxy
-
- ShardRegionProxyRegistered(ActorRef) - Constructor for class akka.cluster.sharding.ShardCoordinator.Internal$.ShardRegionProxyRegistered
-
- ShardRegionProxyTerminated(ActorRef) - Constructor for class akka.cluster.sharding.ShardCoordinator.Internal$.ShardRegionProxyTerminated
-
- ShardRegionRegistered(ActorRef) - Constructor for class akka.cluster.sharding.ShardCoordinator.Internal$.ShardRegionRegistered
-
- ShardRegionTerminated(ActorRef) - Constructor for class akka.cluster.sharding.ShardCoordinator.Internal$.ShardRegionTerminated
-
- shardResolver() - Method in class akka.cluster.sharding.ClusterShardingGuardian.Start
-
- shards() - Method in class akka.cluster.sharding.ShardCoordinator.Internal$.RebalanceResult
-
- shards() - Method in class akka.cluster.sharding.ShardRegion
-
- shardsByRef() - Method in class akka.cluster.sharding.ShardRegion
-
- ShardStarted(String) - Constructor for class akka.cluster.sharding.ShardCoordinator.Internal$.ShardStarted
-
- ShardStartTimeout() - Method in class akka.cluster.sharding.ClusterSharding.Settings$
-
- ShardStopped(String) - Constructor for class akka.cluster.sharding.ShardCoordinator.Internal$.ShardStopped
-
- SharedLeveldbJournal - Class in akka.persistence.journal.leveldb
-
INTERNAL API.
- SharedLeveldbJournal() - Constructor for class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- SharedLeveldbJournal$ - Class in akka.persistence.journal.leveldb
-
- SharedLeveldbJournal$() - Constructor for class akka.persistence.journal.leveldb.SharedLeveldbJournal$
-
- SharedLeveldbStore - Class in akka.persistence.journal.leveldb
-
A LevelDB store that can be shared by multiple actor systems.
- SharedLeveldbStore() - Constructor for class akka.persistence.journal.leveldb.SharedLeveldbStore
-
- shouldDropInbound(Address, Object, String) - Method in class akka.remote.transport.FailureInjectorTransportAdapter
-
- shouldDropOutbound(Address, Object, String) - Method in class akka.remote.transport.FailureInjectorTransportAdapter
-
- shouldNotProcessMask() - Method in class akka.dispatch.Mailbox$
-
- shouldNotProcessMask() - Static method in class akka.dispatch.Mailbox
-
- shouldProcessMessage() - Method in class akka.dispatch.Mailbox
-
- shouldScheduleMask() - Method in class akka.dispatch.Mailbox$
-
- shouldScheduleMask() - Static method in class akka.dispatch.Mailbox
-
- Shutdown() - Method in class akka.actor.AbstractFSM
-
Reason given when someone was calling system.stop(fsm)
from outside;
also applies to Stop
supervision directive.
- shutdown() - Method in class akka.actor.ActorSystem
-
Stop this actor system.
- shutdown() - Method in class akka.actor.ActorSystemImpl
-
- shutdown() - Method in class akka.camel.internal.DefaultCamel
-
Stops camel and underlying camel context and template.
- shutdown() - Method in class akka.cluster.Cluster
-
INTERNAL API.
- shutdown() - Method in class akka.cluster.ClusterCoreDaemon
-
This method is called when a member sees itself as Exiting or Down.
- shutdown() - Method in class akka.dispatch.Dispatcher
-
INTERNAL API
- shutdown() - Method in interface akka.dispatch.ExecutorServiceDelegate
-
- shutdown() - Method in class akka.dispatch.MessageDispatcher
-
Called one time every time an actor is detached from this dispatcher and this dispatcher has no actors left attached
Must be idempotent
- shutdown() - Method in interface akka.kernel.Bootable
-
Callback run on microkernel shutdown.
- shutdown() - Method in class akka.remote.RemoteTransport
-
Shuts down the remoting
- shutdown() - Method in class akka.remote.Remoting
-
- shutdown(RoleName) - Method in interface akka.remote.testconductor.Conductor
-
Tell the actor system at the remote node to shut itself down.
- shutdown(RoleName, boolean) - Method in interface akka.remote.testconductor.Conductor
-
Tell the actor system at the remote node to shut itself down without
awaiting termination of remote-deployed children.
- shutdown(Channel) - Method in class akka.remote.testconductor.RemoteConnection$
-
- shutdown(Channel) - Static method in class akka.remote.testconductor.RemoteConnection
-
- shutdown() - Method in class akka.remote.transport.AbstractTransportAdapter
-
- shutdown() - Method in class akka.remote.transport.ActorTransportAdapter
-
- shutdown() - Method in class akka.remote.transport.netty.NettyTransport
-
- shutdown() - Method in class akka.remote.transport.TestTransport
-
- shutdown() - Method in interface akka.remote.transport.Transport
-
Shuts down the transport layer and releases all the corresponding resources.
- shutdown() - Method in class akka.testkit.CallingThreadDispatcher
-
- shutdown(ActorSystem, Duration, Boolean) - Method in class akka.testkit.JavaTestKit
-
Shut down an actor system and wait for termination.
- shutdown(ActorSystem) - Method in class akka.testkit.JavaTestKit
-
- shutdown(ActorSystem, Duration) - Method in class akka.testkit.JavaTestKit
-
- shutdown(ActorSystem, Boolean) - Method in class akka.testkit.JavaTestKit
-
- shutdown(ActorSystem, Duration, boolean) - Method in interface akka.testkit.TestKitBase
-
Shut down an actor system and wait for termination.
- Shutdown$() - Constructor for class akka.actor.FSM.Shutdown$
-
- Shutdown$() - Constructor for class akka.remote.transport.AssociationHandle.Shutdown$
-
- Shutdown_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.FailType
-
Shutdown = 5;
- ShutdownAbrupt_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.FailType
-
ShutdownAbrupt = 6;
- shutdownActorSystem(ActorSystem, Duration, Boolean) - Static method in class akka.testkit.JavaTestKit
-
Shut down an actor system and wait for termination.
- shutdownActorSystem(ActorSystem) - Static method in class akka.testkit.JavaTestKit
-
- shutdownActorSystem(ActorSystem, Duration) - Static method in class akka.testkit.JavaTestKit
-
- shutdownActorSystem(ActorSystem, Boolean) - Static method in class akka.testkit.JavaTestKit
-
- shutdownActorSystem(ActorSystem, Duration, boolean) - Method in class akka.testkit.TestKit$
-
Shut down an actor system and wait for termination.
- shutdownActorSystem(ActorSystem, Duration, boolean) - Static method in class akka.testkit.TestKit
-
Shut down an actor system and wait for termination.
- ShutdownAndFlush$() - Constructor for class akka.remote.EndpointManager.ShutdownAndFlush$
-
- ShutDownAssociation - Exception in akka.remote
-
INTERNAL API
- ShutDownAssociation(Address, Address, Throwable) - Constructor for exception akka.remote.ShutDownAssociation
-
- ShutDownAssociation$ - Class in akka.remote
-
- ShutDownAssociation$() - Constructor for class akka.remote.ShutDownAssociation$
-
- ShutdownAttempt(Address) - Constructor for class akka.remote.transport.TestTransport.ShutdownAttempt
-
- ShutdownAttempt$() - Constructor for class akka.remote.transport.TestTransport.ShutdownAttempt$
-
- shutdownBehavior() - Method in class akka.remote.transport.TestTransport
-
- shutdownNow() - Method in interface akka.dispatch.ExecutorServiceDelegate
-
- shutdownOrExit() - Method in class akka.remote.testconductor.Terminate
-
- shutdownOrExit() - Method in class akka.remote.testconductor.TerminateMsg
-
- ShutdownTimeout() - Method in class akka.actor.LightArrayRevolverScheduler
-
- shutdownTimeout() - Method in class akka.dispatch.Dispatcher
-
- shutdownTimeout() - Method in class akka.dispatch.MessageDispatcher
-
When the dispatcher no longer has any actors registered, how long will it wait until it shuts itself down,
defaulting to your akka configs "akka.actor.default-dispatcher.shutdown-timeout" or default specified in
reference.conf
- ShutdownTimeout() - Method in class akka.remote.RemoteSettings
-
- shutdownTimeout() - Method in class akka.remote.testkit.MultiNodeSpec
-
- shutdownTimeout() - Method in class akka.testkit.CallingThreadDispatcher
-
- shuttingDown() - Method in class akka.cluster.sharding.ShardCoordinator
-
- Sig(ActorContext<T>, Signal) - Constructor for class akka.typed.ScalaDSL.Sig
-
- Sig$() - Constructor for class akka.typed.ScalaDSL.Sig$
-
- SigarMetricsCollector - Class in akka.cluster.metrics
-
Loads metrics through Hyperic SIGAR and JMX monitoring beans.
- SigarMetricsCollector(Address, double, SigarProxy) - Constructor for class akka.cluster.metrics.SigarMetricsCollector
-
- SigarMetricsCollector(Address, ClusterMetricsSettings, SigarProxy) - Constructor for class akka.cluster.metrics.SigarMetricsCollector
-
- SigarMetricsCollector(Address, ClusterMetricsSettings) - Constructor for class akka.cluster.metrics.SigarMetricsCollector
-
- SigarMetricsCollector(ActorSystem) - Constructor for class akka.cluster.metrics.SigarMetricsCollector
-
This constructor is used when creating an instance from configured FQCN
- SigarMetricsCollector - Class in akka.cluster
-
Loads metrics through Hyperic SIGAR and JMX monitoring beans.
- SigarMetricsCollector(Address, double, Object) - Constructor for class akka.cluster.SigarMetricsCollector
-
- SigarMetricsCollector(ActorSystem) - Constructor for class akka.cluster.SigarMetricsCollector
-
This constructor is used when creating an instance from configured FQCN
- SigarProvider - Interface in akka.cluster.metrics
-
Provide sigar instance as SigarProxy
.
- SigarProvider$ - Class in akka.cluster.metrics
-
- SigarProvider$() - Constructor for class akka.cluster.metrics.SigarProvider$
-
- signal(Signal) - Method in class akka.typed.EffectfulActorContext
-
- signal() - Method in class akka.typed.ScalaDSL.Sig
-
- Signal - Interface in akka.typed
-
System signals are notifications that are generated by the system and
delivered to the Actor behavior in a reliable fashion (i.e.
- SilentState(S, D, Option<FiniteDuration>, Option<FSM.Reason>, List<Object>) - Constructor for class akka.actor.FSM.SilentState
-
- SimpleDnsCache - Class in akka.io
-
- SimpleDnsCache() - Constructor for class akka.io.SimpleDnsCache
-
- SimpleDnsCache$ - Class in akka.io
-
- SimpleDnsCache$() - Constructor for class akka.io.SimpleDnsCache$
-
- SimpleDnsManager - Class in akka.io
-
- SimpleDnsManager(DnsExt) - Constructor for class akka.io.SimpleDnsManager
-
- SimpleDnsManager$ - Class in akka.io
-
- SimpleDnsManager$() - Constructor for class akka.io.SimpleDnsManager$
-
- simpleName(Object) - Method in class akka.event.Logging$
-
Returns a 'safe' getSimpleName for the provided object's Class
- simpleName(Class<?>) - Method in class akka.event.Logging$
-
Returns a 'safe' getSimpleName for the provided Class
- simpleName(Object) - Static method in class akka.event.Logging
-
Returns a 'safe' getSimpleName for the provided object's Class
- simpleName(Class<?>) - Static method in class akka.event.Logging
-
Returns a 'safe' getSimpleName for the provided Class
- SimpleSender(Traversable<Inet.SocketOption>) - Constructor for class akka.io.Udp.SimpleSender
-
- simpleSender(Iterable<Inet.SocketOption>) - Method in class akka.io.UdpMessage$
-
Retrieve a reference to a “simple sender” actor of the UDP extension.
- simpleSender() - Method in class akka.io.UdpMessage$
-
Retrieve a simple sender without specifying options.
- simpleSender(Iterable<Inet.SocketOption>) - Static method in class akka.io.UdpMessage
-
Retrieve a reference to a “simple sender” actor of the UDP extension.
- simpleSender() - Static method in class akka.io.UdpMessage
-
Retrieve a simple sender without specifying options.
- SimpleSender$() - Constructor for class akka.io.Udp.SimpleSender$
-
- SimpleSenderReady$() - Constructor for class akka.io.Udp.SimpleSenderReady$
-
- SimpleWriteCommand() - Constructor for class akka.io.Tcp.SimpleWriteCommand
-
- SingleConsumerOnlyUnboundedMailbox - Class in akka.dispatch
-
SingleConsumerOnlyUnboundedMailbox is a high-performance, multiple producer—single consumer, unbounded MailboxType,
the only drawback is that you can't have multiple consumers,
which rules out using it with BalancingPool (BalancingDispatcher) for instance.
- SingleConsumerOnlyUnboundedMailbox() - Constructor for class akka.dispatch.SingleConsumerOnlyUnboundedMailbox
-
- SingleConsumerOnlyUnboundedMailbox(ActorSystem.Settings, Config) - Constructor for class akka.dispatch.SingleConsumerOnlyUnboundedMailbox
-
- SingleConsumerOnlyUnboundedMailbox$ - Class in akka.dispatch
-
- SingleConsumerOnlyUnboundedMailbox$() - Constructor for class akka.dispatch.SingleConsumerOnlyUnboundedMailbox$
-
- SingleExpectDefaultTimeout() - Method in class akka.testkit.TestKitSettings
-
- singleton() - Method in class akka.cluster.singleton.ClusterSingletonProxy
-
- singletonIdentificationInterval() - Method in class akka.cluster.singleton.ClusterSingletonProxySettings
-
- singletonName() - Method in class akka.cluster.singleton.ClusterSingletonManagerSettings
-
- singletonPath() - Method in class akka.cluster.singleton.ClusterSingletonProxy
-
- size() - Method in class akka.dispatch.AbstractBoundedNodeQueue
-
Returns an approximation of the queue's "current" size
- size() - Method in class akka.dispatch.sysmsg.EarliestFirstSystemMessageList
-
Indicates if the list is empty or not.
- size() - Method in class akka.dispatch.sysmsg.LatestFirstSystemMessageList
-
Indicates if the list is empty or not.
- size() - Method in class akka.io.Inet.SO$.ReceiveBufferSize
-
- size() - Method in class akka.io.Inet.SO$.SendBufferSize
-
- size() - Method in class akka.util.BoundedBlockingQueue
-
- size() - Method in class akka.util.Collections.PartialImmutableValuesIterable
-
- size() - Method in interface akka.util.PriorityQueueStabilizer
-
- size() - Method in class akka.util.SerializedSuspendableExecutionContext
-
O(N)
- sizeHint(int) - Method in class akka.util.ByteStringBuilder
-
- sizeInner(SystemMessage, int) - Method in class akka.dispatch.sysmsg.SystemMessageList$
-
- sizeInner(SystemMessage, int) - Static method in class akka.dispatch.sysmsg.SystemMessageList
-
- skipMemberStatus() - Method in class akka.cluster.AutoDownBase
-
- Slf4jLogger - Class in akka.event.slf4j
-
SLF4J logger.
- Slf4jLogger() - Constructor for class akka.event.slf4j.Slf4jLogger
-
- SLF4JLogging - Interface in akka.event.slf4j
-
Base trait for all classes that wants to be able use the SLF4J logging infrastructure.
- Slf4jLoggingFilter - Class in akka.event.slf4j
-
LoggingFilter
that uses the log level defined in in the SLF4J
backend configuration (e.g.
- Slf4jLoggingFilter(ActorSystem.Settings, EventStream) - Constructor for class akka.event.slf4j.Slf4jLoggingFilter
-
- slice(int, int) - Method in class akka.util.ByteIterator
-
- slice(int, int) - Method in class akka.util.ByteString.ByteString1C
-
- slice(int, int) - Method in class akka.util.ByteString
-
- smallBackoffCount() - Method in class akka.remote.EndpointWriter
-
- SmallestMailboxPool - Class in akka.routing
-
A router pool that tries to send to the non-suspended routee with fewest messages in mailbox.
- SmallestMailboxPool(int, Option<Resizer>, SupervisorStrategy, String, boolean) - Constructor for class akka.routing.SmallestMailboxPool
-
- SmallestMailboxPool(Config) - Constructor for class akka.routing.SmallestMailboxPool
-
- SmallestMailboxPool(int) - Constructor for class akka.routing.SmallestMailboxPool
-
Java API
- SmallestMailboxPool$ - Class in akka.routing
-
- SmallestMailboxPool$() - Constructor for class akka.routing.SmallestMailboxPool$
-
- SmallestMailboxRoutingLogic - Class in akka.routing
-
Tries to send to the non-suspended routee with fewest messages in mailbox.
- SmallestMailboxRoutingLogic() - Constructor for class akka.routing.SmallestMailboxRoutingLogic
-
- SmallestMailboxRoutingLogic$ - Class in akka.routing
-
- SmallestMailboxRoutingLogic$() - Constructor for class akka.routing.SmallestMailboxRoutingLogic$
-
- smoothValue() - Method in class akka.cluster.Metric
-
The numerical value of the average, if defined, otherwise the latest value
- smoothValue() - Method in class akka.cluster.metrics.Metric
-
The numerical value of the average, if defined, otherwise the latest value
- snapshot() - Method in class akka.persistence.SelectedSnapshot
-
- Snapshot - Class in akka.persistence.serialization
-
Wrapper for snapshot data
.
- Snapshot(Object) - Constructor for class akka.persistence.serialization.Snapshot
-
- snapshot() - Method in class akka.persistence.SnapshotOffer
-
- snapshot() - Method in class akka.persistence.SnapshotProtocol.LoadSnapshotResult
-
- snapshot() - Method in class akka.persistence.SnapshotProtocol.SaveSnapshot
-
- Snapshot$ - Class in akka.persistence.serialization
-
- Snapshot$() - Constructor for class akka.persistence.serialization.Snapshot$
-
- SnapshotHeader - Class in akka.persistence.serialization
-
INTERNAL API.
- SnapshotHeader(int, Option<String>) - Constructor for class akka.persistence.serialization.SnapshotHeader
-
- SnapshotHeader$ - Class in akka.persistence.serialization
-
- SnapshotHeader$() - Constructor for class akka.persistence.serialization.SnapshotHeader$
-
- SnapshotInterval() - Method in class akka.cluster.sharding.ClusterSharding.Settings$
-
- SnapshotMetadata - Class in akka.persistence
-
Snapshot metadata.
- SnapshotMetadata(String, long, long) - Constructor for class akka.persistence.SnapshotMetadata
-
- SnapshotMetadata$ - Class in akka.persistence
-
- SnapshotMetadata$() - Constructor for class akka.persistence.SnapshotMetadata$
-
- SnapshotOffer - Class in akka.persistence
-
- SnapshotOffer(SnapshotMetadata, Object) - Constructor for class akka.persistence.SnapshotOffer
-
- SnapshotOffer$ - Class in akka.persistence
-
- SnapshotOffer$() - Constructor for class akka.persistence.SnapshotOffer$
-
- snapshotPluginId() - Method in interface akka.persistence.PersistenceIdentity
-
Configuration id of the snapshot plugin servicing this persistent actor or view.
- SnapshotProtocol - Class in akka.persistence
-
INTERNAL API.
- SnapshotProtocol() - Constructor for class akka.persistence.SnapshotProtocol
-
- SnapshotProtocol$ - Class in akka.persistence
-
INTERNAL API.
- SnapshotProtocol$() - Constructor for class akka.persistence.SnapshotProtocol$
-
- SnapshotProtocol.DeleteSnapshot - Class in akka.persistence
-
Instructs snapshot store to delete a snapshot.
- SnapshotProtocol.DeleteSnapshot$ - Class in akka.persistence
-
- SnapshotProtocol.DeleteSnapshots - Class in akka.persistence
-
Instructs snapshot store to delete all snapshots that match criteria
.
- SnapshotProtocol.DeleteSnapshots$ - Class in akka.persistence
-
- SnapshotProtocol.LoadSnapshot - Class in akka.persistence
-
Instructs a snapshot store to load a snapshot.
- SnapshotProtocol.LoadSnapshot$ - Class in akka.persistence
-
- SnapshotProtocol.LoadSnapshotResult - Class in akka.persistence
-
- SnapshotProtocol.LoadSnapshotResult$ - Class in akka.persistence
-
- SnapshotProtocol.Message - Interface in akka.persistence
-
Marker trait shared by internal snapshot messages.
- SnapshotProtocol.Request - Interface in akka.persistence
-
Internal snapshot command.
- SnapshotProtocol.Response - Interface in akka.persistence
-
Internal snapshot acknowledgement.
- SnapshotProtocol.SaveSnapshot - Class in akka.persistence
-
Instructs snapshot store to save a snapshot.
- SnapshotProtocol.SaveSnapshot$ - Class in akka.persistence
-
- SnapshotSelectionCriteria - Class in akka.persistence
-
Selection criteria for loading and deleting snapshots.
- SnapshotSelectionCriteria(long, long) - Constructor for class akka.persistence.SnapshotSelectionCriteria
-
- SnapshotSelectionCriteria$ - Class in akka.persistence
-
- SnapshotSelectionCriteria$() - Constructor for class akka.persistence.SnapshotSelectionCriteria$
-
- snapshotSequenceNr() - Method in interface akka.persistence.Eventsourced
-
Returns lastSequenceNr
.
- snapshotSequenceNr() - Method in interface akka.persistence.PersistentView
-
Returns lastSequenceNr
.
- snapshotSequenceNr() - Method in interface akka.persistence.Snapshotter
-
Sequence number to use when taking a snapshot.
- SnapshotSerializer - Class in akka.persistence.serialization
-
- SnapshotSerializer(ExtendedActorSystem) - Constructor for class akka.persistence.serialization.SnapshotSerializer
-
- SnapshotSerializer$ - Class in akka.persistence.serialization
-
- SnapshotSerializer$() - Constructor for class akka.persistence.serialization.SnapshotSerializer$
-
- snapshotStore() - Method in interface akka.persistence.Eventsourced
-
- snapshotStore() - Method in interface akka.persistence.PersistentView
-
- SnapshotStore - Class in akka.persistence.snapshot.japi
-
Java API: abstract snapshot store.
- SnapshotStore() - Constructor for class akka.persistence.snapshot.japi.SnapshotStore
-
- SnapshotStore - Interface in akka.persistence.snapshot
-
Abstract snapshot store.
- snapshotStore() - Method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- snapshotStore() - Method in interface akka.persistence.Snapshotter
-
Snapshot store plugin actor.
- snapshotStoreFor(String) - Method in class akka.persistence.Persistence
-
Returns a snapshot store plugin actor identified by snapshotPluginId
.
- SnapshotStoreSpec - Class in akka.persistence.snapshot
-
This spec aims to verify custom akka-persistence
SnapshotStore
implementations.
- SnapshotStoreSpec(Config) - Constructor for class akka.persistence.snapshot.SnapshotStoreSpec
-
- SnapshotStoreSpec$ - Class in akka.persistence.snapshot
-
- SnapshotStoreSpec$() - Constructor for class akka.persistence.snapshot.SnapshotStoreSpec$
-
- snapshotTask() - Method in class akka.cluster.sharding.Shard
-
- snapshotTask() - Method in class akka.cluster.sharding.ShardCoordinator
-
- Snapshotter - Interface in akka.persistence
-
Snapshot API on top of the internal snapshot protocol.
- snapshotterId() - Method in interface akka.persistence.Eventsourced
-
Returns persistenceId
.
- snapshotterId() - Method in interface akka.persistence.PersistentView
-
Returns viewId
.
- snapshotterId() - Method in interface akka.persistence.Snapshotter
-
Snapshotter id.
- SnapshotTick() - Constructor for class akka.cluster.sharding.ShardCoordinator.Internal$.SnapshotTick
-
- snr() - Method in class akka.persistence.journal.AsyncWriteJournal.Desequenced
-
- SO$() - Constructor for class akka.io.Inet.SO$
-
- SO$() - Constructor for class akka.io.Tcp.SO$
-
- SO$() - Constructor for class akka.io.Udp.SO$
-
- sockAddr() - Method in interface akka.remote.testconductor.Conductor
-
Obtain the port to which the controller’s socket is actually bound.
- SocketUtil - Class in akka.testkit
-
Utilities to get free socket address.
- SocketUtil() - Constructor for class akka.testkit.SocketUtil
-
- SocketUtil$ - Class in akka.testkit
-
Utilities to get free socket address.
- SocketUtil$() - Constructor for class akka.testkit.SocketUtil$
-
- some(A) - Method in class akka.japi.Option$
-
Option
factory that creates Some
- some(A) - Static method in class akka.japi.Option
-
Option
factory that creates Some
- Some(A) - Constructor for class akka.japi.Option.Some
-
- Some$() - Constructor for class akka.japi.Option.Some$
-
- sort(Iterable<Tuple2<Class<? extends Throwable>, SupervisorStrategy.Directive>>) - Method in class akka.actor.SupervisorStrategy$
-
Sort so that subtypes always precede their supertypes, but without
obeying any order between unrelated subtypes (insert sort).
- sort(Iterable<Tuple2<Class<? extends Throwable>, SupervisorStrategy.Directive>>) - Static method in class akka.actor.SupervisorStrategy
-
Sort so that subtypes always precede their supertypes, but without
obeying any order between unrelated subtypes (insert sort).
- source() - Method in class akka.testkit.DebugFilter
-
- source() - Method in class akka.testkit.ErrorFilter
-
- source() - Method in class akka.testkit.EventFilter
-
- source() - Method in class akka.testkit.InfoFilter
-
- source() - Method in class akka.testkit.WarningFilter
-
- SourceFile(String) - Constructor for class akka.util.LineNumbers.SourceFile
-
- SourceFile$() - Constructor for class akka.util.LineNumbers.SourceFile$
-
- SourceFileLines(String, int, int) - Constructor for class akka.util.LineNumbers.SourceFileLines
-
- SourceFileLines$() - Constructor for class akka.util.LineNumbers.SourceFileLines$
-
- span(Function1<Object, Object>) - Method in class akka.util.ByteIterator
-
- span(Function1<Object, Object>) - Method in class akka.util.ByteString
-
- spawn(Props<U>, String) - Method in interface akka.typed.ActorContext
-
Create a child Actor from the given
Props
and with the given name.
- spawn(Props<U>, String) - Method in class akka.typed.ActorContextAdapter
-
- spawn(Props<U>, String) - Method in class akka.typed.EffectfulActorContext
-
- spawn(Props<T>) - Method in class akka.typed.Ops.ActorContextOps
-
- spawn(Props<T>, String) - Method in class akka.typed.Ops.ActorContextOps
-
- spawn(Props<T>) - Method in class akka.typed.Ops.ActorSystemOps
-
- spawn(Props<T>, String) - Method in class akka.typed.Ops.ActorSystemOps
-
- spawn(Props<U>, String) - Method in class akka.typed.StubbedActorContext
-
- spawnAdapter(Function1<U, T>) - Method in interface akka.typed.ActorContext
-
Create a child actor that will wrap messages such that other Actor’s
protocols can be ingested by this Actor.
- spawnAdapter(Function1<U, T>) - Method in class akka.typed.ActorContextAdapter
-
- spawnAdapter(Function1<U, T>) - Method in class akka.typed.StubbedActorContext
-
- spawnAnonymous(Props<U>) - Method in interface akka.typed.ActorContext
-
Create a child Actor from the given
Props
under a randomly chosen name.
- spawnAnonymous(Props<U>) - Method in class akka.typed.ActorContextAdapter
-
- spawnAnonymous(Props<U>) - Method in class akka.typed.EffectfulActorContext
-
- spawnAnonymous(Props<U>) - Method in class akka.typed.StubbedActorContext
-
- spawnChildWithCapacityProtection(SelectionHandler.WorkerForCommand, int) - Method in class akka.io.SelectionHandler
-
- Spawned(String) - Constructor for class akka.typed.Effect.Spawned
-
- Spawned$() - Constructor for class akka.typed.Effect.Spawned$
-
- specialHandle(Object, ActorRef) - Method in class akka.actor.DeadLetterActorRef
-
- specialHandle(Object, ActorRef) - Method in class akka.actor.EmptyLocalActorRef
-
- split(String, String) - Method in interface akka.actor.PathUtils
-
- splitAt(int) - Method in class akka.util.ByteString
-
- splitNameAndUid(String) - Method in class akka.actor.ActorCell$
-
- splitNameAndUid(String) - Static method in class akka.actor.ActorCell
-
- squaredIntervalSum() - Method in class akka.remote.HeartbeatHistory
-
- SSLEnabledAlgorithms() - Method in class akka.remote.transport.netty.SSLSettings
-
- SSLKeyPassword() - Method in class akka.remote.transport.netty.SSLSettings
-
- SSLKeyStore() - Method in class akka.remote.transport.netty.SSLSettings
-
- SSLKeyStorePassword() - Method in class akka.remote.transport.netty.SSLSettings
-
- SSLProtocol() - Method in class akka.remote.transport.netty.SSLSettings
-
- SSLRandomNumberGenerator() - Method in class akka.remote.transport.netty.SSLSettings
-
- SslSettings() - Method in class akka.remote.transport.netty.NettyTransportSettings
-
- SSLSettings - Class in akka.remote.transport.netty
-
INTERNAL API
- SSLSettings(Config) - Constructor for class akka.remote.transport.netty.SSLSettings
-
- SSLTrustStore() - Method in class akka.remote.transport.netty.SSLSettings
-
- SSLTrustStorePassword() - Method in class akka.remote.transport.netty.SSLSettings
-
- StablePriorityBlockingQueue<E> - Class in akka.util
-
StablePriorityBlockingQueue is a blocking priority queue that preserves order for elements of equal priority.
- StablePriorityBlockingQueue(int, Comparator<E>) - Constructor for class akka.util.StablePriorityBlockingQueue
-
- StablePriorityQueue<E> - Class in akka.util
-
StablePriorityQueue is a priority queue that preserves order for elements of equal priority.
- StablePriorityQueue(int, Comparator<E>) - Constructor for class akka.util.StablePriorityQueue
-
- stackTraceFor(Throwable) - Method in class akka.event.Logging$
-
Returns the StackTrace for the given Throwable as a String
- stackTraceFor(Throwable) - Static method in class akka.event.Logging
-
Returns the StackTrace for the given Throwable as a String
- StandardMetrics - Class in akka.cluster.metrics
-
Definitions of the built-in standard metrics.
- StandardMetrics() - Constructor for class akka.cluster.metrics.StandardMetrics
-
- StandardMetrics - Class in akka.cluster
-
Definitions of the built-in standard metrics.
- StandardMetrics() - Constructor for class akka.cluster.StandardMetrics
-
- StandardMetrics$ - Class in akka.cluster.metrics
-
Definitions of the built-in standard metrics.
- StandardMetrics$() - Constructor for class akka.cluster.metrics.StandardMetrics$
-
- StandardMetrics$ - Class in akka.cluster
-
Definitions of the built-in standard metrics.
- StandardMetrics$() - Constructor for class akka.cluster.StandardMetrics$
-
- StandardMetrics.Cpu - Class in akka.cluster.metrics
-
- StandardMetrics.Cpu - Class in akka.cluster
-
- StandardMetrics.Cpu$ - Class in akka.cluster.metrics
-
- StandardMetrics.Cpu$ - Class in akka.cluster
-
- StandardMetrics.HeapMemory - Class in akka.cluster.metrics
-
- StandardMetrics.HeapMemory - Class in akka.cluster
-
- StandardMetrics.HeapMemory$ - Class in akka.cluster.metrics
-
- StandardMetrics.HeapMemory$ - Class in akka.cluster
-
- StandardOutLogger() - Method in class akka.event.Logging$
-
- StandardOutLogger() - Static method in class akka.event.Logging
-
- StandardOutLogger() - Constructor for class akka.event.Logging.StandardOutLogger
-
- start() - Method in class akka.actor.ActorSystemImpl
-
- start() - Method in interface akka.actor.Cell
-
Start the cell: enqueued message must not be processed before this has
been called.
- start() - Method in interface akka.actor.dungeon.Dispatch
-
Start this cell, i.e.
- start() - Method in class akka.actor.InternalActorRef
-
- start() - Method in class akka.actor.LocalActorRef
-
Starts the actor after initialization.
- start() - Method in interface akka.actor.MinimalActorRef
-
- start() - Method in class akka.actor.RepointableActorRef
-
- start() - Method in class akka.actor.UnstartedCell
-
- start() - Method in class akka.camel.internal.DefaultCamel
-
Starts camel and underlying camel context and template.
- start(String, Option<Props>, Option<String>, boolean, PartialFunction<Object, Tuple2<String, Object>>, Function1<Object, String>, ShardCoordinator.ShardAllocationStrategy) - Method in class akka.cluster.sharding.ClusterSharding
-
Scala API: Register a named entry type by defining the
Props
of the entry actor
and functions to extract entry and shard identifier from messages.
- start(String, Option<Props>, Option<String>, boolean, PartialFunction<Object, Tuple2<String, Object>>, Function1<Object, String>) - Method in class akka.cluster.sharding.ClusterSharding
-
Register a named entry type by defining the
Props
of the entry actor and
functions to extract entry and shard identifier from messages.
- start(String, Props, Option<String>, boolean, ShardRegion.MessageExtractor, ShardCoordinator.ShardAllocationStrategy) - Method in class akka.cluster.sharding.ClusterSharding
-
Java API: Register a named entry type by defining the
Props
of the entry actor
and functions to extract entry and shard identifier from messages.
- start(String, Props, Option<String>, boolean, ShardRegion.MessageExtractor) - Method in class akka.cluster.sharding.ClusterSharding
-
Java API: Register a named entry type by defining the
Props
of the entry actor
and functions to extract entry and shard identifier from messages.
- Start(String, Option<Props>, Option<String>, boolean, PartialFunction<Object, Tuple2<String, Object>>, Function1<Object, String>, ShardCoordinator.ShardAllocationStrategy) - Constructor for class akka.cluster.sharding.ClusterShardingGuardian.Start
-
- start(ActorSystem, ManagedActorClassification, boolean) - Method in class akka.event.ActorClassificationUnsubscriber$
-
- start(ActorSystem, ManagedActorClassification, boolean) - Static method in class akka.event.ActorClassificationUnsubscriber
-
- start(ActorSystem, EventStream) - Method in class akka.event.EventStreamUnsubscriber$
-
- start(ActorSystem, EventStream) - Static method in class akka.event.EventStreamUnsubscriber
-
- start(BundleContext) - Method in class akka.osgi.ActorSystemActivator
-
Sets up a new ActorSystem
- start() - Method in class akka.remote.RemoteActorRef
-
- start() - Method in class akka.remote.RemoteTransport
-
Start up the transport, i.e.
- start() - Method in class akka.remote.Remoting
-
- start() - Method in class akka.routing.RoutedActorCell
-
- Start$() - Constructor for class akka.cluster.sharding.ClusterShardingGuardian.Start$
-
- startClient(RoleName, InetSocketAddress) - Method in interface akka.remote.testconductor.Player
-
Connect to the conductor on the given port (the host is taken from setting
akka.testconductor.host
).
- startController(int, RoleName, InetSocketAddress) - Method in interface akka.remote.testconductor.Conductor
-
Start the
Controller
, which in turn will
bind to a TCP port as specified in the
akka.testconductor.port
config
property, where 0 denotes automatic allocation.
- startCoordinator() - Method in class akka.cluster.sharding.ShardCoordinatorSupervisor
-
- startDefaultLoggers(ActorSystemImpl) - Method in interface akka.event.LoggingBus
-
Internal Akka use only
- Started(ActorRef) - Constructor for class akka.cluster.sharding.ClusterShardingGuardian.Started
-
- Started$() - Constructor for class akka.cluster.sharding.ClusterShardingGuardian.Started$
-
- startHash(int) - Method in class akka.routing.MurmurHash$
-
Begin a new hash with a seed value.
- startHash(int) - Static method in class akka.routing.MurmurHash
-
Begin a new hash with a seed value.
- startMagicA() - Method in class akka.routing.MurmurHash$
-
The initial magic integers in the first stream.
- startMagicA() - Static method in class akka.routing.MurmurHash
-
The initial magic integers in the first stream.
- startMagicB() - Method in class akka.routing.MurmurHash$
-
The initial magic integer in the second stream.
- startMagicB() - Static method in class akka.routing.MurmurHash
-
The initial magic integer in the second stream.
- startNewSystem() - Method in class akka.remote.testkit.MultiNodeSpec
-
This method starts a new ActorSystem with the same configuration as the
previous one on the current node, including deployments.
- startStdoutLogger(ActorSystem.Settings) - Method in interface akka.event.LoggingBus
-
Internal Akka use only
- startsWith(String) - Method in class akka.testkit.JavaTestKit.EventFilter
-
- startTime() - Method in class akka.actor.ActorSystem
-
Start-up time in milliseconds since the epoch.
- startTime() - Method in class akka.typed.ActorSystem
-
Start-up time in milliseconds since the epoch.
- startUnsubscriber() - Method in class akka.event.EventStream
-
''Must'' be called after actor system is "ready".
- startup() - Method in interface akka.kernel.Bootable
-
Callback run on microkernel startup.
- StartupFinished$() - Constructor for class akka.remote.EndpointManager.StartupFinished$
-
- StartupTimeout() - Method in class akka.remote.RemoteSettings
-
- StartWatch(ActorRef) - Constructor for class akka.actor.dsl.Inbox.StartWatch
-
- StartWatch$() - Constructor for class akka.actor.dsl.Inbox.StartWatch$
-
- startWith(S, D) - Method in class akka.actor.AbstractFSM
-
Set initial state.
- startWith(S, D, FiniteDuration) - Method in class akka.actor.AbstractFSM
-
Set initial state.
- startWith(S, D, Option<FiniteDuration>) - Method in interface akka.actor.FSM
-
Set initial state.
- StartWith(boolean) - Constructor for class akka.typed.StepWise.StartWith
-
- stash(SystemMessage) - Method in class akka.actor.ActorCell
-
- Stash - Interface in akka.actor
-
The Stash
trait enables an actor to temporarily stash away messages that can not or
should not be handled using the actor's current behavior.
- stash() - Method in interface akka.actor.StashSupport
-
Adds the current message (the message that the actor received last) to the
actor's stash.
- stashedInbound() - Method in class akka.remote.EndpointManager
-
- StashFactory - Interface in akka.actor
-
INTERNAL API.
- StashingHandlerInvocation(Object, Function1<Object, BoxedUnit>) - Constructor for class akka.persistence.Eventsourced.StashingHandlerInvocation
-
- StashingHandlerInvocation$() - Constructor for class akka.persistence.Eventsourced.StashingHandlerInvocation$
-
- StashOverflowException - Exception in akka.actor
-
Is thrown when the size of the Stash exceeds the capacity of the Stash
- StashOverflowException(String, Throwable) - Constructor for exception akka.actor.StashOverflowException
-
- StashOverflowException$ - Class in akka.actor
-
- StashOverflowException$() - Constructor for class akka.actor.StashOverflowException$
-
- StashSupport - Interface in akka.actor
-
INTERNAL API.
- StashWhenFailed - Interface in akka.dispatch.sysmsg
-
INTERNAL API
- StashWhenWaitingForChildren - Interface in akka.dispatch.sysmsg
-
INTERNAL API
- state() - Method in class akka.actor.FSM.CurrentState
-
- State(S, D, Option<FiniteDuration>, Option<FSM.Reason>, List<Object>) - Constructor for class akka.actor.FSM.State
-
- state() - Method in class akka.cluster.Cluster
-
Current snapshot state of the cluster.
- state() - Method in class akka.cluster.ClusterHeartbeatSender
-
- state() - Method in class akka.cluster.ClusterReadView
-
- state() - Method in class akka.cluster.sharding.Shard
-
- State() - Constructor for class akka.cluster.sharding.ShardCoordinator.Internal$.State
-
- state(S, S, FI.UnitApplyVoid) - Method in class akka.japi.pf.FSMTransitionHandlerBuilder
-
Add a case statement that matches on a from state and a to state.
- state(S, S, FI.UnitApply2<S, S>) - Method in class akka.japi.pf.FSMTransitionHandlerBuilder
-
Add a case statement that matches on a from state and a to state.
- State$() - Constructor for class akka.actor.FSM.State$
-
- State$() - Constructor for class akka.cluster.sharding.Shard.State$
-
- stateData() - Method in class akka.actor.FSM.Event
-
- stateData() - Method in class akka.actor.FSM.LogEntry
-
- stateData() - Method in class akka.actor.FSM.State
-
- stateData() - Method in interface akka.actor.FSM
-
- stateData() - Method in class akka.actor.FSM.StopEvent
-
- stateData() - Method in class akka.testkit.TestFSMRef
-
Get current state data of this FSM.
- stateFunctions() - Method in interface akka.actor.FSM
-
- stateName() - Method in class akka.actor.FSM.LogEntry
-
- stateName() - Method in class akka.actor.FSM.State
-
- stateName() - Method in interface akka.actor.FSM
-
- stateName() - Method in class akka.testkit.TestFSMRef
-
Get current state name of this FSM.
- stateReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.persistence.Eventsourced.State
-
- stateReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.persistence.PersistentView.State
-
- states() - Method in interface akka.actor.LoggingFSM
-
- StateTimeout() - Method in interface akka.actor.FSM
-
This case object is received in case of a state timeout.
- StateTimeout$() - Constructor for class akka.actor.FSM.StateTimeout$
-
- stateTimeouts() - Method in interface akka.actor.FSM
-
- Static(Function1<T, BoxedUnit>) - Constructor for class akka.typed.ScalaDSL.Static
-
- Static$() - Constructor for class akka.typed.ScalaDSL.Static$
-
- stats() - Method in interface akka.actor.dungeon.ChildrenContainer.EmptyChildrenContainer
-
- stats() - Method in class akka.actor.dungeon.ChildrenContainer.NormalChildrenContainer
-
- stats() - Method in interface akka.actor.dungeon.ChildrenContainer
-
- stats() - Method in class akka.actor.dungeon.ChildrenContainer.TerminatingChildrenContainer
-
- Stats(int, int, Set<Tuple2<ActorRef, ActorRef>>, Set<Address>) - Constructor for class akka.remote.RemoteWatcher.Stats
-
- Stats$() - Constructor for class akka.remote.RemoteWatcher.Stats$
-
- statsEnabled() - Method in class akka.cluster.ClusterCoreDaemon
-
- Status - Class in akka.actor
-
Classes for passing status back to the sender.
- Status() - Constructor for class akka.actor.Status
-
- status() - Method in class akka.actor.Status.Success
-
- status() - Method in class akka.cluster.ClusterReadView
-
- status() - Method in class akka.cluster.Member
-
- Status(Map<Address, Object>) - Constructor for class akka.cluster.pubsub.DistributedPubSubMediator.Internal$.Status
-
- status() - Method in class akka.cluster.Reachability.Record
-
- status(UniqueAddress, UniqueAddress) - Method in class akka.cluster.Reachability
-
- status(UniqueAddress) - Method in class akka.cluster.Reachability
-
- status() - Method in class akka.remote.EndpointManager.ManagementCommandAck
-
- Status$ - Class in akka.actor
-
Classes for passing status back to the sender.
- Status$() - Constructor for class akka.actor.Status$
-
- Status.Failure - Class in akka.actor
-
This class/message type is preferably used to indicate failure of some operation performed.
- Status.Failure$ - Class in akka.actor
-
- Status.Status - Interface in akka.actor
-
- Status.Success - Class in akka.actor
-
This class/message type is preferably used to indicate success of some operation performed.
- Status.Success$ - Class in akka.actor
-
- STATUS_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Member
-
- STATUS_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.SubjectReachability
-
- statusFuture() - Method in class akka.remote.transport.netty.ClientHandler
-
- statusPromise() - Method in class akka.remote.transport.ActorTransportAdapter.AssociateUnderlying
-
- statusPromise() - Method in class akka.remote.transport.AkkaProtocolTransport.AssociateUnderlyingRefuseUid
-
- statusPromise() - Method in class akka.remote.transport.netty.ClientHandler
-
- statusPromise() - Method in class akka.remote.transport.ProtocolStateActor.OutboundUnassociated
-
- statusPromise() - Method in class akka.remote.transport.ProtocolStateActor.OutboundUnderlyingAssociated
-
- statusPromise() - Method in class akka.remote.transport.ThrottlerManager.AssociateResult
-
- stay() - Method in interface akka.actor.FSM
-
Produce "empty" transition descriptor.
- stdDeviation() - Method in class akka.remote.HeartbeatHistory
-
- StdoutLogLevel() - Method in class akka.actor.ActorSystem.Settings
-
- Steps(List<StepWise.AST>, boolean) - Constructor for class akka.typed.StepWise.Steps
-
- Steps$() - Constructor for class akka.typed.StepWise.Steps$
-
- StepWise - Class in akka.typed
-
- StepWise() - Constructor for class akka.typed.StepWise
-
- StepWise$ - Class in akka.typed
-
This object contains tools for building step-wise behaviors for formulating
a linearly progressing protocol.
- StepWise$() - Constructor for class akka.typed.StepWise$
-
- StepWise.AST - Interface in akka.typed
-
- StepWise.StartWith<T> - Class in akka.typed
-
- StepWise.Steps<T,U> - Class in akka.typed
-
- StepWise.Steps$ - Class in akka.typed
-
- stop(ActorRef) - Method in interface akka.actor.ActorRefFactory
-
Stop the actor pointed to by the given
ActorRef
; this is
an asynchronous operation, i.e.
- stop(ActorRef) - Method in class akka.actor.ActorSystemImpl
-
- stop() - Method in interface akka.actor.Cell
-
Recursively terminate this actor and all its children.
- Stop() - Method in interface akka.actor.dsl.Creators.Act
-
- stop(ActorRef) - Method in interface akka.actor.dungeon.Children
-
- stop() - Method in interface akka.actor.dungeon.Dispatch
-
- stop() - Method in interface akka.actor.FSM
-
Produce change descriptor to stop this FSM actor with reason "Normal".
- stop(FSM.Reason) - Method in interface akka.actor.FSM
-
Produce change descriptor to stop this FSM actor including specified reason.
- stop(FSM.Reason, D) - Method in interface akka.actor.FSM
-
Produce change descriptor to stop this FSM actor including specified reason.
- stop() - Method in class akka.actor.InternalActorRef
-
- stop() - Method in class akka.actor.LocalActorRef
-
Shuts down the actor and its message queue
- stop() - Method in interface akka.actor.MinimalActorRef
-
- stop() - Method in class akka.actor.RepointableActorRef
-
- stop() - Method in class akka.actor.SupervisorStrategy$
-
Java API: Returning this directive stops the Actor
- stop() - Static method in class akka.actor.SupervisorStrategy
-
Java API: Returning this directive stops the Actor
- stop(Object) - Method in interface akka.actor.TypedActorFactory
-
Stops the underlying ActorRef for the supplied TypedActor proxy,
if any, returns whether it could find the find the ActorRef or not
- stop() - Method in class akka.actor.UnstartedCell
-
- stop(FSM.Reason, FI.UnitApply2<S, D>) - Method in class akka.japi.pf.FSMStopBuilder
-
Add a case statement that matches on an FSM.Reason
.
- stop(Class<P>, FI.UnitApply3<P, S, D>) - Method in class akka.japi.pf.FSMStopBuilder
-
Add a case statement that matches on a reason type.
- stop(Class<P>, FI.TypedPredicate<P>, FI.UnitApply3<P, S, D>) - Method in class akka.japi.pf.FSMStopBuilder
-
Add a case statement that matches on a reason type and a predicate.
- stop(BundleContext) - Method in class akka.osgi.ActorSystemActivator
-
Shuts down the ActorSystem when the bundle is stopped and, if necessary, unregisters a service registration.
- stop() - Method in class akka.pattern.PromiseActorRef
-
- stop() - Method in class akka.remote.RemoteActorRef
-
- stop(ActorRef<Nothing$>) - Method in interface akka.typed.ActorContext
-
Force the child Actor under the given name to terminate after it finishes
processing its current message.
- stop(ActorRef<Nothing$>) - Method in class akka.typed.ActorContextAdapter
-
- stop(ActorRef<Nothing$>) - Method in class akka.typed.EffectfulActorContext
-
- stop(ActorRef<Nothing$>) - Method in class akka.typed.StubbedActorContext
-
- Stop$() - Constructor for class akka.actor.SupervisorStrategy.Stop$
-
- Stop$() - Constructor for class akka.typed.Failed.Stop$
-
- StopChild - Class in akka.actor
-
Internal Akka use only, used in implementation of system.stop(child).
- StopChild(ActorRef) - Constructor for class akka.actor.StopChild
-
- StopChild$ - Class in akka.actor
-
- StopChild$() - Constructor for class akka.actor.StopChild$
-
- stopDefaultLoggers(ActorSystem) - Method in interface akka.event.LoggingBus
-
Internal Akka use only
- StopEvent() - Method in interface akka.actor.FSM
-
- StopEvent(FSM.Reason, S, D) - Constructor for class akka.actor.FSM.StopEvent
-
- StopEvent$() - Constructor for class akka.actor.FSM.StopEvent$
-
- stopIfAllRouteesRemoved() - Method in class akka.routing.RouterActor
-
- stopMessage() - Method in class akka.cluster.sharding.ShardRegion.Passivate
-
- Stopped(String) - Constructor for class akka.typed.Effect.Stopped
-
- Stopped() - Method in class akka.typed.ScalaDSL$
-
Return this behavior from message processing to signal that this actor
shall terminate voluntarily.
- Stopped() - Static method in class akka.typed.ScalaDSL
-
Return this behavior from message processing to signal that this actor
shall terminate voluntarily.
- Stopped$() - Constructor for class akka.typed.Effect.Stopped$
-
- stoppedBehavior$() - Constructor for class akka.typed.Behavior.stoppedBehavior$
-
- StoppedReading(ActorRef) - Constructor for class akka.remote.EndpointWriter.StoppedReading
-
- StoppedReading$() - Constructor for class akka.remote.EndpointWriter.StoppedReading$
-
- stoppingShard() - Method in class akka.cluster.sharding.ShardCoordinator.RebalanceWorker
-
- stoppingStrategy() - Method in class akka.actor.SupervisorStrategy$
-
This strategy resembles Erlang in that failing children are always
terminated (one-for-one).
- stoppingStrategy() - Static method in class akka.actor.SupervisorStrategy
-
This strategy resembles Erlang in that failing children are always
terminated (one-for-one).
- StoppingSupervisorStrategy - Class in akka.actor
-
- StoppingSupervisorStrategy() - Constructor for class akka.actor.StoppingSupervisorStrategy
-
- StopReading(ActorRef, ActorRef) - Constructor for class akka.remote.EndpointWriter.StopReading
-
- StopReading$() - Constructor for class akka.remote.EndpointWriter.StopReading$
-
- stopReason() - Method in class akka.actor.FSM.State
-
- stopReason() - Method in class akka.remote.EndpointWriter
-
- stopRouterWhenAllRouteesRemoved() - Method in interface akka.cluster.routing.ClusterRouterConfigBase
-
- stopRouterWhenAllRouteesRemoved() - Method in interface akka.routing.Pool
-
- stopRouterWhenAllRouteesRemoved() - Method in interface akka.routing.RouterConfig
-
- stopScheduler() - Method in class akka.actor.ActorSystemImpl
-
- stopSeedNodeProcess() - Method in class akka.cluster.ClusterCoreDaemon
-
- stopWith(TcpConnection.CloseInformation) - Method in class akka.io.TcpConnection
-
- store() - Method in interface akka.persistence.journal.AsyncWriteProxy
-
- strategy() - Method in class akka.cluster.metrics.ClusterMetricsExtension
-
INTERNAL API
- StreamingCache() - Method in class akka.camel.CamelSettings
-
enables or disables streamingCache on the Camel Context
- stringHash(String) - Method in class akka.routing.MurmurHash$
-
Compute a high-quality hash of a string
- stringHash(String) - Static method in class akka.routing.MurmurHash
-
Compute a high-quality hash of a string
- StringPathEntry(boolean, boolean, Config, String) - Constructor for class akka.dispatch.CachingConfig.StringPathEntry
-
- StringPathEntry$() - Constructor for class akka.dispatch.CachingConfig.StringPathEntry$
-
- StubbedActorContext<T> - Class in akka.typed
-
An
ActorContext
for synchronous execution of a
Behavior
that
provides only stubs for the effects an Actor can perform and replaces
created child Actors by a synchronous Inbox (see
Inbox.sync
).
- StubbedActorContext(String, Props<T>, ActorSystem<Nothing$>) - Constructor for class akka.typed.StubbedActorContext
-
- SubchannelClassification - Interface in akka.event
-
Classification which respects relationships between channels: subscribing
to one channel automatically and idempotently subscribes to all sub-channels.
- SubchannelEventBus<E,S,C> - Class in akka.event.japi
-
Java API: See documentation for
SubchannelClassification
E is the Event type
S is the Subscriber type
C is the Classifier type
- SubchannelEventBus() - Constructor for class akka.event.japi.SubchannelEventBus
-
- subclassification() - Method in class akka.event.EventStream
-
- subclassification() - Method in class akka.event.japi.SubchannelEventBus
-
The logic to form sub-class hierarchy
- subclassification() - Method in interface akka.event.SubchannelClassification
-
The logic to form sub-class hierarchy
- Subclassification<K> - Interface in akka.util
-
Typeclass which describes a classification hierarchy.
- SubclassifiedIndex<K,V> - Class in akka.util
-
Mutable index which respects sub-class relationships between keys:
- SubclassifiedIndex(Subclassification<K>) - Constructor for class akka.util.SubclassifiedIndex
-
- SubclassifiedIndex$ - Class in akka.util
-
- SubclassifiedIndex$() - Constructor for class akka.util.SubclassifiedIndex$
-
- SubclassifiedIndex.Nonroot<K,V> - Class in akka.util
-
- subject() - Method in class akka.cluster.Reachability.Record
-
- SUBJECTREACHABILITY_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
-
- subkeys() - Method in class akka.util.SubclassifiedIndex
-
- submit(Callable<T>) - Method in interface akka.dispatch.ExecutorServiceDelegate
-
- submit(Runnable, T) - Method in interface akka.dispatch.ExecutorServiceDelegate
-
- submit(Runnable) - Method in interface akka.dispatch.ExecutorServiceDelegate
-
- subscribe(ActorRef, Class<?>...) - Method in class akka.cluster.Cluster
-
Subscribe to one or more cluster domain events.
- subscribe(ActorRef, ClusterEvent.SubscriptionInitialStateMode, Class<?>...) - Method in class akka.cluster.Cluster
-
Subscribe to one or more cluster domain events.
- subscribe(ActorRef, Seq<Class<?>>) - Method in class akka.cluster.Cluster
-
Subscribe to one or more cluster domain events.
- subscribe(ActorRef, ClusterEvent.SubscriptionInitialStateMode, Seq<Class<?>>) - Method in class akka.cluster.Cluster
-
Subscribe to one or more cluster domain events.
- subscribe(ActorRef, ClusterEvent.SubscriptionInitialStateMode, Set<Class<?>>) - Method in class akka.cluster.ClusterDomainEventPublisher
-
- Subscribe(ActorRef, ClusterEvent.SubscriptionInitialStateMode, Set<Class<?>>) - Constructor for class akka.cluster.InternalClusterAction.Subscribe
-
- subscribe(ActorRef) - Method in class akka.cluster.metrics.ClusterMetricsExtension
-
Subscribe user metrics listener actor unto
ClusterMetricsEvent
events published by extension on the system event bus.
- Subscribe(String, Option<String>, ActorRef) - Constructor for class akka.cluster.pubsub.DistributedPubSubMediator.Subscribe
-
- Subscribe(String, ActorRef) - Constructor for class akka.cluster.pubsub.DistributedPubSubMediator.Subscribe
-
Convenience constructor with group
None
- Subscribe(String, String, ActorRef) - Constructor for class akka.cluster.pubsub.DistributedPubSubMediator.Subscribe
-
Java API: constructor with group: String
- subscribe() - Method in class akka.cluster.pubsub.DistributedPubSubMediator.SubscribeAck
-
- subscribe(ActorRef, ActorRef) - Method in interface akka.event.ActorClassification
-
- subscribe(ActorRef) - Method in class akka.event.AddressTerminatedTopic
-
- subscribe(EventBus, EventBus) - Method in interface akka.event.EventBus
-
- subscribe(ActorRef, Class<?>) - Method in class akka.event.EventStream
-
- subscribe(ActorRef, ActorRef) - Method in class akka.event.japi.ActorEventBus
-
- subscribe(S, C) - Method in interface akka.event.japi.EventBus
-
Attempts to register the subscriber to the specified Classifier
- subscribe(S, C) - Method in class akka.event.japi.LookupEventBus
-
- subscribe(ActorRef, ActorRef) - Method in class akka.event.japi.ManagedActorEventBus
-
- subscribe(S, C) - Method in class akka.event.japi.ScanningEventBus
-
- subscribe(S, C) - Method in class akka.event.japi.SubchannelEventBus
-
- subscribe(LookupClassification, LookupClassification) - Method in interface akka.event.LookupClassification
-
- subscribe(ActorRef, ActorRef) - Method in interface akka.event.ManagedActorClassification
-
- subscribe(ScanningClassification, ScanningClassification) - Method in interface akka.event.ScanningClassification
-
- subscribe(SubchannelClassification, SubchannelClassification) - Method in interface akka.event.SubchannelClassification
-
- subscribe(ActorRef, ClassTag<T>) - Method in class akka.persistence.PluginSpec
-
- Subscribe$() - Constructor for class akka.cluster.InternalClusterAction.Subscribe$
-
- Subscribe$() - Constructor for class akka.cluster.pubsub.DistributedPubSubMediator.Subscribe$
-
- SubscribeAck(DistributedPubSubMediator.Subscribe) - Constructor for class akka.cluster.pubsub.DistributedPubSubMediator.SubscribeAck
-
- SubscribeAck$() - Constructor for class akka.cluster.pubsub.DistributedPubSubMediator.SubscribeAck$
-
- subscribeAddressTerminated() - Method in interface akka.actor.dungeon.DeathWatch
-
- Subscribed(DistributedPubSubMediator.SubscribeAck, ActorRef) - Constructor for class akka.cluster.pubsub.DistributedPubSubMediator.Internal$.Subscribed
-
- subscriber() - Method in class akka.cluster.InternalClusterAction.Subscribe
-
- subscriber() - Method in class akka.cluster.InternalClusterAction.Unsubscribe
-
- subscriber() - Method in class akka.cluster.pubsub.DistributedPubSubMediator.Internal$.Subscribed
-
- subscriber() - Method in class akka.cluster.pubsub.DistributedPubSubMediator.Internal$.Unsubscribed
-
- subscribers() - Method in interface akka.cluster.pubsub.DistributedPubSubMediator.Internal$.TopicLike
-
- subscribers() - Method in interface akka.event.LookupClassification
-
- subscribers() - Method in interface akka.event.ScanningClassification
-
- SubscribeTransitionCallBack(ActorRef) - Constructor for class akka.actor.FSM.SubscribeTransitionCallBack
-
- SubscribeTransitionCallBack$() - Constructor for class akka.actor.FSM.SubscribeTransitionCallBack$
-
- SubscriptionInitialStateMode() - Constructor for class akka.cluster.ClusterEvent.SubscriptionInitialStateMode
-
- subscriptions() - Method in interface akka.event.SubchannelClassification
-
- Succeeded_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.BarrierOp
-
Succeeded = 3;
- Success(Object) - Constructor for class akka.actor.Status.Success
-
- success() - Method in class akka.remote.testconductor.BarrierResult
-
- Success$() - Constructor for class akka.actor.Status.Success$
-
- successful(T) - Method in class akka.dispatch.Futures$
-
Creates an already completed Promise with the specified result
- successful(T) - Static method in class akka.dispatch.Futures
-
Creates an already completed Promise with the specified result
- Supervise - Class in akka.dispatch.sysmsg
-
INTERNAL API
- Supervise(ActorRef, boolean) - Constructor for class akka.dispatch.sysmsg.Supervise
-
- Supervise$ - Class in akka.dispatch.sysmsg
-
- Supervise$() - Constructor for class akka.dispatch.sysmsg.Supervise$
-
- superviseWith(SupervisorStrategy) - Method in interface akka.actor.dsl.Creators.Act
-
Set the supervisor strategy of this actor, i.e.
- supervisor() - Method in class akka.actor.RepointableActorRef
-
- supervisor() - Method in class akka.actor.UnstartedCell
-
- supervisor() - Method in interface akka.camel.Camel
-
INTERNAL API
Returns the camel supervisor actor.
- supervisor() - Method in class akka.camel.internal.DefaultCamel
-
- supervisor() - Method in class akka.cluster.metrics.ClusterMetricsExtension
-
Supervisor actor.
- supervisor() - Method in class akka.remote.DaemonMsgCreate
-
- supervisor() - Method in class akka.remote.RemoteDeploymentWatcher.WatchRemote
-
- SUPERVISOR_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DaemonMsgCreateData
-
- SupervisorName() - Method in class akka.cluster.metrics.ClusterMetricsSettings
-
- supervisors() - Method in class akka.remote.RemoteDeploymentWatcher
-
- supervisorStrategy() - Method in interface akka.actor.Actor
-
User overridable definition the strategy to use for supervising
child actors.
- supervisorStrategy() - Method in interface akka.actor.dsl.Creators.Act
-
- SupervisorStrategy - Class in akka.actor
-
An Akka SupervisorStrategy is the policy to apply for crashing children.
- SupervisorStrategy() - Constructor for class akka.actor.SupervisorStrategy
-
- supervisorStrategy() - Method in interface akka.actor.TypedActor.Supervisor
-
User overridable definition the strategy to use for supervising
child actors.
- supervisorStrategy() - Method in class akka.actor.TypedActor.TypedActor
-
- supervisorStrategy() - Method in class akka.actor.UntypedActor
-
User overridable definition the strategy to use for supervising
child actors.
- supervisorStrategy() - Method in class akka.camel.internal.CamelSupervisor
-
- supervisorStrategy() - Method in class akka.camel.internal.Registry
-
- supervisorStrategy() - Method in class akka.cluster.ClusterCoreSupervisor
-
- supervisorStrategy() - Method in class akka.cluster.metrics.AdaptiveLoadBalancingPool
-
- supervisorStrategy() - Method in class akka.cluster.metrics.ClusterMetricsSupervisor
-
- supervisorStrategy() - Method in class akka.cluster.routing.AdaptiveLoadBalancingPool
-
- supervisorStrategy() - Method in class akka.cluster.routing.ClusterRouterPool
-
- supervisorStrategy() - Method in class akka.contrib.pattern.ReliableProxy
-
- supervisorStrategy() - Method in class akka.io.SelectionHandler.SelectorBasedManager
-
- supervisorStrategy() - Method in class akka.io.SelectionHandler
-
- supervisorStrategy() - Method in class akka.io.TcpListener
-
- supervisorStrategy() - Method in class akka.remote.EndpointManager
-
- supervisorStrategy() - Method in class akka.remote.EndpointWriter
-
- supervisorStrategy() - Method in class akka.remote.ReliableDeliverySupervisor
-
- supervisorStrategy() - Method in class akka.remote.Remoting.TransportSupervisor
-
- supervisorStrategy() - Method in class akka.remote.routing.RemoteRouterConfig
-
- supervisorStrategy() - Method in class akka.remote.testconductor.Controller
-
- supervisorStrategy() - Method in class akka.remote.transport.AkkaProtocolManager
-
- supervisorStrategy() - Method in class akka.routing.BalancingPool
-
- supervisorStrategy() - Method in class akka.routing.BroadcastPool
-
- supervisorStrategy() - Method in class akka.routing.ConsistentHashingPool
-
- supervisorStrategy() - Method in class akka.routing.FromConfig
-
- supervisorStrategy() - Method in interface akka.routing.Pool
-
SupervisorStrategy for the head actor, i.e.
- supervisorStrategy() - Method in class akka.routing.RandomPool
-
- supervisorStrategy() - Method in class akka.routing.RoundRobinPool
-
- supervisorStrategy() - Method in class akka.routing.RouterPoolActor
-
- supervisorStrategy() - Method in class akka.routing.ScatterGatherFirstCompletedPool
-
- supervisorStrategy() - Method in class akka.routing.SmallestMailboxPool
-
- supervisorStrategy() - Method in class akka.routing.TailChoppingPool
-
- supervisorStrategy() - Method in class akka.typed.ActorAdapter
-
- SupervisorStrategy$ - Class in akka.actor
-
- SupervisorStrategy$() - Constructor for class akka.actor.SupervisorStrategy$
-
- SupervisorStrategy.Directive - Interface in akka.actor
-
- SupervisorStrategy.Escalate$ - Class in akka.actor
-
Escalates the failure to the supervisor of the supervisor,
by rethrowing the cause of the failure, i.e.
- SupervisorStrategy.Restart$ - Class in akka.actor
-
Discards the old Actor instance and replaces it with a new,
then resumes message processing.
- SupervisorStrategy.Resume$ - Class in akka.actor
-
Resumes message processing for the failed Actor
- SupervisorStrategy.Stop$ - Class in akka.actor
-
Stops the Actor
- SupervisorStrategyClass() - Method in class akka.actor.ActorSystem.Settings
-
- SupervisorStrategyConfiguration() - Method in class akka.cluster.metrics.ClusterMetricsSettings
-
- SupervisorStrategyConfigurator - Interface in akka.actor
-
Implement this interface in order to configure the supervisorStrategy for
the top-level guardian actor (/user
).
- SupervisorStrategyLowPriorityImplicits - Interface in akka.actor
-
- SupervisorStrategyProvider() - Method in class akka.cluster.metrics.ClusterMetricsSettings
-
- SuppressedDeadLetter - Class in akka.actor
-
Similar to
DeadLetter
with the slight twist of NOT being logged by the default dead letters listener.
- SuppressedDeadLetter(DeadLetterSuppression, ActorRef, ActorRef) - Constructor for class akka.actor.SuppressedDeadLetter
-
- SuppressedDeadLetter$ - Class in akka.actor
-
- SuppressedDeadLetter$() - Constructor for class akka.actor.SuppressedDeadLetter$
-
- suspend() - Method in interface akka.actor.Cell
-
Recursively suspend this actor and all its children.
- suspend() - Method in interface akka.actor.dungeon.Dispatch
-
- suspend() - Method in class akka.actor.InternalActorRef
-
- suspend() - Method in class akka.actor.LocalActorRef
-
Suspends the actor so that it will not process messages until resumed.
- suspend() - Method in interface akka.actor.MinimalActorRef
-
- suspend() - Method in class akka.actor.RepointableActorRef
-
- suspend() - Method in class akka.actor.UnstartedCell
-
- suspend() - Method in class akka.dispatch.Mailbox
-
Increment the suspend count by one.
- suspend(ActorCell) - Method in class akka.dispatch.MessageDispatcher
-
After the call to this method, the dispatcher mustn't begin any new message processing for the specified reference
- Suspend - Class in akka.dispatch.sysmsg
-
INTERNAL API
- Suspend() - Constructor for class akka.dispatch.sysmsg.Suspend
-
- suspend() - Method in class akka.remote.RemoteActorRef
-
- suspend(ActorCell) - Method in class akka.testkit.CallingThreadDispatcher
-
- suspend() - Method in class akka.util.SerializedSuspendableExecutionContext
-
Suspends execution of tasks until resume
is called,
this operation is idempotent.
- Suspend$ - Class in akka.dispatch.sysmsg
-
- Suspend$() - Constructor for class akka.dispatch.sysmsg.Suspend$
-
- suspendChildren(Set<ActorRef>) - Method in interface akka.actor.dungeon.Children
-
- suspendCount() - Method in class akka.dispatch.Mailbox
-
- Suspended() - Method in class akka.util.SerializedSuspendableExecutionContext$
-
- Suspended() - Static method in class akka.util.SerializedSuspendableExecutionContext
-
- SuspendedState() - Method in class akka.actor.ActorCell$
-
- SuspendedState() - Static method in class akka.actor.ActorCell
-
- SuspendedWaitForChildrenState() - Method in class akka.actor.ActorCell$
-
- SuspendedWaitForChildrenState() - Static method in class akka.actor.ActorCell
-
- suspendMask() - Method in class akka.dispatch.Mailbox$
-
- suspendMask() - Static method in class akka.dispatch.Mailbox
-
- suspendNonRecursive() - Method in interface akka.actor.dungeon.FaultHandling
-
- suspendReading(TcpConnection.ConnectionInfo) - Method in class akka.io.TcpConnection
-
- suspendReading() - Method in class akka.io.TcpMessage$
-
Sending this command to the connection actor will disable reading from the TCP
socket.
- suspendReading() - Static method in class akka.io.TcpMessage
-
Sending this command to the connection actor will disable reading from the TCP
socket.
- suspendReading() - Method in class akka.io.UdpConnectedMessage$
-
Send this message to a listener actor (which sent a
Udp.Bound
message) to
have it stop reading datagrams from the network.
- suspendReading() - Static method in class akka.io.UdpConnectedMessage
-
Send this message to a listener actor (which sent a
Udp.Bound
message) to
have it stop reading datagrams from the network.
- suspendReading() - Method in class akka.io.UdpMessage$
-
Send this message to a listener actor (which sent a
Udp.Bound
message) to
have it stop reading datagrams from the network.
- suspendReading() - Static method in class akka.io.UdpMessage
-
Send this message to a listener actor (which sent a
Udp.Bound
message) to
have it stop reading datagrams from the network.
- SuspendReading$() - Constructor for class akka.io.Tcp.SuspendReading$
-
- SuspendReading$() - Constructor for class akka.io.Udp.SuspendReading$
-
- SuspendReading$() - Constructor for class akka.io.UdpConnected.SuspendReading$
-
- suspendSwitch() - Method in class akka.testkit.CallingThreadMailbox
-
- suspendUnit() - Method in class akka.dispatch.Mailbox$
-
- suspendUnit() - Static method in class akka.dispatch.Mailbox
-
- swapCell(Cell) - Method in class akka.actor.RepointableActorRef
-
- swapChildrenRefs(ChildrenContainer, ChildrenContainer) - Method in interface akka.actor.dungeon.Children
-
- swapLookup(Cell) - Method in class akka.actor.RepointableActorRef
-
- swapMailbox(Mailbox) - Method in interface akka.actor.dungeon.Dispatch
-
- Switch - Class in akka.util
-
An atomic switch that can be either on or off
- Switch(boolean) - Constructor for class akka.util.Switch
-
- Switch$ - Class in akka.util
-
- Switch$() - Constructor for class akka.util.Switch$
-
- SwitchableLoggedBehavior(Function1<A, Future<B>>, Function1<A, BoxedUnit>) - Constructor for class akka.remote.transport.TestTransport.SwitchableLoggedBehavior
-
- switchOff(Function0<BoxedUnit>) - Method in class akka.util.Switch
-
Executes the provided action if the lock is on under a lock, so be _very_ careful with longrunning/blocking operations in it
Only executes the action if the switch is on, and switches it off immediately after obtaining the lock
Will switch it back on if the provided action throws an exception
- switchOff() - Method in class akka.util.Switch
-
Switches the switch off (if on), uses locking
- switchOn(Function0<BoxedUnit>) - Method in class akka.util.Switch
-
Executes the provided action if the lock is off under a lock, so be _very_ careful with longrunning/blocking operations in it
Only executes the action if the switch is off, and switches it on immediately after obtaining the lock
Will switch it back off if the provided action throws an exception
- switchOn() - Method in class akka.util.Switch
-
Switches the switch on (if off), uses locking
- symmetricHash(TraversableOnce<T>, int) - Method in class akka.routing.MurmurHash$
-
Compute a hash that is symmetric in its arguments--that is,
where the order of appearance of elements does not matter.
- symmetricHash(TraversableOnce<T>, int) - Static method in class akka.routing.MurmurHash
-
Compute a hash that is symmetric in its arguments--that is,
where the order of appearance of elements does not matter.
- sync(String) - Method in class akka.typed.Inbox$
-
- sync(String) - Static method in class akka.typed.Inbox
-
- synchronousQueue(boolean) - Method in class akka.dispatch.ThreadPoolConfig$
-
- synchronousQueue(boolean) - Static method in class akka.dispatch.ThreadPoolConfig
-
- SynchronousSelf(Function1<ActorRef<T>, Behavior<T>>) - Constructor for class akka.typed.ScalaDSL.SynchronousSelf
-
- SynchronousSelf$() - Constructor for class akka.typed.ScalaDSL.SynchronousSelf$
-
- SyncInbox(String) - Constructor for class akka.typed.Inbox.SyncInbox
-
- SyncWriteJournal - Class in akka.persistence.journal.japi
-
Java API: abstract journal, optimized for synchronous writes.
- SyncWriteJournal() - Constructor for class akka.persistence.journal.japi.SyncWriteJournal
-
- SyncWriteJournal - Interface in akka.persistence.journal
-
Abstract journal, optimized for synchronous writes.
- sys() - Method in class akka.typed.Ops.ActorSystemOps
-
- SysMsgAckTimeout() - Method in class akka.remote.RemoteSettings
-
- SysMsgBufferSize() - Method in class akka.remote.RemoteSettings
-
- SysResendTimeout() - Method in class akka.remote.RemoteSettings
-
- system() - Method in class akka.actor.ActorCell
-
- system() - Method in interface akka.actor.ActorContext
-
The system that the actor belongs to.
- system() - Method in class akka.actor.ActorDSL.Extension
-
- system() - Method in class akka.actor.Address
-
- system() - Method in interface akka.actor.Cell
-
The system within which this Cell lives.
- system() - Method in class akka.actor.RepointableActorRef
-
- system() - Method in class akka.actor.TypedActorExtension
-
- system() - Method in class akka.actor.UnstartedCell
-
- system() - Method in interface akka.camel.Camel
-
INTERNAL API
Returns the associated ActorSystem.
- system() - Method in class akka.camel.internal.DefaultCamel
-
- system() - Method in class akka.cluster.Cluster
-
- system() - Method in class akka.cluster.metrics.AdaptiveLoadBalancingRoutingLogic
-
- system() - Method in class akka.cluster.metrics.protobuf.MessageSerializer
-
- system() - Method in class akka.cluster.protobuf.ClusterMessageSerializer
-
- system() - Method in class akka.cluster.pubsub.protobuf.DistributedPubSubMessageSerializer
-
- system() - Method in class akka.cluster.routing.AdaptiveLoadBalancingRoutingLogic
-
- system() - Method in class akka.contrib.mailbox.PeekMailboxExtension
-
- system() - Method in interface akka.event.ManagedActorClassification
-
- system() - Method in class akka.persistence.journal.JournalSpec
-
- system() - Method in class akka.persistence.Persistence
-
- system() - Method in class akka.persistence.serialization.MessageSerializer
-
- system() - Method in class akka.persistence.serialization.SnapshotSerializer
-
- system() - Method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- system() - Method in class akka.remote.AddressUidExtension
-
- system() - Method in class akka.remote.BoundAddressesExtension
-
- system() - Method in class akka.remote.RemoteTransport
-
- system() - Method in class akka.remote.serialization.DaemonMsgCreateSerializer
-
- system() - Method in class akka.remote.serialization.MessageContainerSerializer
-
- system() - Method in class akka.remote.serialization.ProtobufSerializer
-
- system() - Method in class akka.remote.testconductor.TestConductorExt
-
- system() - Method in class akka.remote.transport.netty.NettyTransport
-
- system() - Method in class akka.routing.ConsistentHashingRoutingLogic
-
- system() - Method in interface akka.serialization.BaseSerializer
-
Actor system which is required by most serializer implementations.
- system() - Method in class akka.serialization.ByteArraySerializer
-
- system() - Method in class akka.serialization.JavaSerializer
-
- system() - Method in class akka.serialization.Serialization.Information
-
- system() - Method in class akka.serialization.Serialization
-
- system() - Method in class akka.testkit.CallingThreadMailbox
-
- system() - Method in class akka.testkit.TestKit
-
- system() - Method in interface akka.testkit.TestKitBase
-
- system() - Method in interface akka.typed.ActorContext
-
- system() - Method in class akka.typed.ActorContextAdapter
-
- system() - Method in class akka.typed.StubbedActorContext
-
- SYSTEM_FIELD_NUMBER - Static variable in class akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.Address
-
- SYSTEM_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.Address
-
- SYSTEM_FIELD_NUMBER - Static variable in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Address
-
- SYSTEM_FIELD_NUMBER - Static variable in class akka.remote.testconductor.TestConductorProtocol.Address
-
- SYSTEM_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AddressData
-
- systemActorOf(Props, String) - Method in class akka.actor.ActorSystemImpl
-
- systemActorOf(Props, String) - Method in class akka.actor.ExtendedActorSystem
-
Create an actor in the "/system" namespace.
- systemDispatch(ActorCell, SystemMessage) - Method in class akka.dispatch.Dispatcher
-
INTERNAL API
- systemDispatch(ActorCell, SystemMessage) - Method in class akka.dispatch.MessageDispatcher
-
Will be called when the dispatcher is to queue an invocation for execution
- systemDispatch(ActorCell, SystemMessage) - Method in class akka.testkit.CallingThreadDispatcher
-
- systemDrain(LatestFirstSystemMessageList) - Method in interface akka.dispatch.DefaultSystemMessageQueue
-
- systemDrain(LatestFirstSystemMessageList) - Method in interface akka.dispatch.SystemMessageQueue
-
Dequeue all messages from system queue and return them as single-linked list.
- systemEnqueue(ActorRef, SystemMessage) - Method in interface akka.dispatch.DefaultSystemMessageQueue
-
- systemEnqueue(ActorRef, SystemMessage) - Method in interface akka.dispatch.SystemMessageQueue
-
Enqueue a new system message, e.g.
- systemGuardian() - Method in interface akka.actor.ActorRefProvider
-
Reference to the supervisor used for all top-level system actors.
- systemGuardian() - Method in class akka.actor.ActorSystemImpl
-
- systemGuardian() - Method in class akka.actor.ExtendedActorSystem
-
The top-level supervisor of all system-internal services like logging.
- systemGuardian() - Method in class akka.actor.LocalActorRefProvider
-
- SystemGuardian - Class in akka.actor
-
INTERNAL API
- SystemGuardian() - Constructor for class akka.actor.SystemGuardian
-
- systemGuardian() - Method in class akka.remote.RemoteActorRefProvider
-
- SystemGuardian$ - Class in akka.actor
-
INTERNAL API
- SystemGuardian$() - Constructor for class akka.actor.SystemGuardian$
-
- SystemGuardian.RegisterTerminationHook$ - Class in akka.actor
-
For the purpose of orderly shutdown it's possible
to register interest in the termination of systemGuardian
and receive a notification TerminationHook
before systemGuardian is stopped.
- SystemGuardian.TerminationHook$ - Class in akka.actor
-
- SystemGuardian.TerminationHookDone$ - Class in akka.actor
-
- systemGuardianStrategy() - Method in class akka.actor.LocalActorRefProvider
-
Overridable supervision strategy to be used by the “/user” guardian.
- SystemHome() - Method in class akka.actor.ActorSystem$
-
- SystemHome() - Static method in class akka.actor.ActorSystem
-
- systemImpl() - Method in class akka.actor.ActorCell
-
- systemImpl() - Method in interface akka.actor.ActorRefFactory
-
INTERNAL API
- systemImpl() - Method in class akka.actor.ActorSystemImpl
-
- systemImpl() - Method in interface akka.actor.Cell
-
The system internals where this Cell lives.
- systemImpl() - Method in class akka.actor.UnstartedCell
-
- systemInvoke(SystemMessage) - Method in class akka.actor.ActorCell
-
- systemLoadAverage() - Method in class akka.cluster.JmxMetricsCollector
-
JMX Returns the OS-specific average load on the CPUs in the system, for the past 1 minute.
- systemLoadAverage() - Method in class akka.cluster.metrics.JmxMetricsCollector
-
(JMX) Returns the OS-specific average load on the CPUs in the system, for the past 1 minute.
- systemLoadAverage() - Method in class akka.cluster.metrics.SigarMetricsCollector
-
(SIGAR) Returns the OS-specific average load on the CPUs in the system, for the past 1 minute.
- SystemLoadAverage() - Method in class akka.cluster.metrics.StandardMetrics$
-
- systemLoadAverage() - Method in class akka.cluster.metrics.StandardMetrics.Cpu
-
- SystemLoadAverage() - Static method in class akka.cluster.metrics.StandardMetrics
-
- systemLoadAverage() - Method in class akka.cluster.SigarMetricsCollector
-
(SIGAR / JMX) Returns the OS-specific average load on the CPUs in the system, for the past 1 minute.
- SystemLoadAverage() - Method in class akka.cluster.StandardMetrics$
-
- systemLoadAverage() - Method in class akka.cluster.StandardMetrics.Cpu
-
- SystemLoadAverage() - Static method in class akka.cluster.StandardMetrics
-
- SystemLoadAverageMetricsSelector - Class in akka.cluster.metrics
-
MetricsSelector that uses the system load average metrics.
- SystemLoadAverageMetricsSelector() - Constructor for class akka.cluster.metrics.SystemLoadAverageMetricsSelector
-
- SystemLoadAverageMetricsSelector - Class in akka.cluster.routing
-
MetricsSelector that uses the system load average metrics.
- SystemLoadAverageMetricsSelector() - Constructor for class akka.cluster.routing.SystemLoadAverageMetricsSelector
-
- SystemLoadAverageMetricsSelector$ - Class in akka.cluster.metrics
-
MetricsSelector that uses the system load average metrics.
- SystemLoadAverageMetricsSelector$() - Constructor for class akka.cluster.metrics.SystemLoadAverageMetricsSelector$
-
- SystemLoadAverageMetricsSelector$ - Class in akka.cluster.routing
-
MetricsSelector that uses the system load average metrics.
- SystemLoadAverageMetricsSelector$() - Constructor for class akka.cluster.routing.SystemLoadAverageMetricsSelector$
-
- SystemMessage - Interface in akka.dispatch.sysmsg
-
System messages are handled specially: they form their own queue within
each actor’s mailbox.
- SystemMessageList - Class in akka.dispatch.sysmsg
-
INTERNAL API
- SystemMessageList() - Constructor for class akka.dispatch.sysmsg.SystemMessageList
-
- SystemMessageList$ - Class in akka.dispatch.sysmsg
-
INTERNAL API
- SystemMessageList$() - Constructor for class akka.dispatch.sysmsg.SystemMessageList$
-
- SystemMessageQueue - Interface in akka.dispatch
-
INTERNAL API
- systemName() - Method in class akka.cluster.ClusterSettings
-
- systemName() - Method in class akka.remote.RemoteActorRefProvider
-
- systemQueueGet() - Method in class akka.dispatch.Mailbox
-
- systemQueuePut(LatestFirstSystemMessageList, LatestFirstSystemMessageList) - Method in class akka.dispatch.Mailbox
-