- a(ClassTag<T>) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- a() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- a(ClassTag<T>) - Static method in class akka.persistence.journal.JournalSpec
-
- a() - Static method in class akka.persistence.journal.JournalSpec
-
- a() - Method in class akka.persistence.PluginSpec
-
- a(ClassTag<T>) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- a() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- abbreviate(TimeUnit) - Method in class akka.util.PrettyDuration.PrettyPrintableDuration
-
- 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() - Static method in class akka.io.TcpOutgoingConnection
-
- 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(GraphInterpreterShell) - Constructor for class akka.stream.impl.fusing.ActorGraphInterpreter.Abort
-
- abort(Throwable) - Method in interface akka.stream.KillSwitch
-
After calling
KillSwitch#abort()
the linked
Graph
s of
FlowShape
are failed.
- abort(Throwable) - Method in class akka.stream.SharedKillSwitch
-
After calling
SharedKillSwitch#abort()
all materialized, running instances of all
Graph
s provided by the
SharedKillSwitch
will fail their downstreams with the provided exception and cancel their upstreams
(unless it finished or failed already in which case the command is ignored).
- abort(Throwable) - Method in class akka.stream.UniqueKillSwitch
-
After calling
UniqueKillSwitch#abort()
the running instance of the
Graph
of
FlowShape
that materialized to the
UniqueKillSwitch
will fail its downstream with the provided exception and cancel its upstream
(unless if finished or failed already in which case the command is ignored).
- Abort$() - Constructor for class akka.io.Tcp.Abort$
-
- Abort$() - Constructor for class akka.stream.impl.fusing.ActorGraphInterpreter.Abort$
-
- Abort_VALUE - Static variable in enum akka.remote.testconductor.TestConductorProtocol.FailType
-
Abort = 3;
- abortDownstream(Throwable) - Method in interface akka.stream.impl.SubscriberManagement
-
this method must be called by the implementing class to push an error downstream
- Aborted$() - Constructor for class akka.io.Tcp.Aborted$
-
- abortEmitting(Outlet<?>) - Method in class akka.stream.stage.GraphStageLogic
-
Abort outstanding (suspended) emissions for the given outlet, if there are any.
- aborting() - Method in class akka.actor.ActorSystemImpl
-
- abortReading(Inlet<?>) - Method in class akka.stream.stage.GraphStageLogic
-
Abort outstanding (suspended) reading for the given inlet, if there is any.
- AbruptStageTerminationException - Exception in akka.stream
-
Signal that the stage was abruptly terminated, usually seen as a call to postStop
of the GraphStageLogic
without
any of the handler callbacks seeing completion or failure from upstream or cancellation from downstream.
- AbruptStageTerminationException(GraphStageLogic) - Constructor for exception akka.stream.AbruptStageTerminationException
-
- AbruptTerminationException - Exception in akka.stream
-
This exception signals that an actor implementing a Reactive Streams Subscriber, Publisher or Processor
has been terminated without being notified by an onError, onComplete or cancel signal.
- AbruptTerminationException(ActorRef) - Constructor for exception akka.stream.AbruptTerminationException
-
- AbruptTerminationException$ - Class in akka.stream
-
- AbruptTerminationException$() - Constructor for class akka.stream.AbruptTerminationException$
-
- absorbTermination() - Method in interface akka.stream.stage.Context
-
Puts the stage in a finishing state so that
final elements can be pushed from onPull
.
- 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
- AbstractActorPublisher<T> - Class in akka.stream.actor
-
Java API compatible with lambda expressions
- AbstractActorPublisher() - Constructor for class akka.stream.actor.AbstractActorPublisher
-
- AbstractActorPublisher$ - Class in akka.stream.actor
-
Java API compatible with lambda expressions
- AbstractActorPublisher$() - Constructor for class akka.stream.actor.AbstractActorPublisher$
-
- AbstractActorPublisherWithStash<T> - Class in akka.stream.actor
-
Java API compatible with lambda expressions.
- AbstractActorPublisherWithStash() - Constructor for class akka.stream.actor.AbstractActorPublisherWithStash
-
- AbstractActorPublisherWithUnboundedStash<T> - Class in akka.stream.actor
-
Java API compatible with lambda expressions.
- AbstractActorPublisherWithUnboundedStash() - Constructor for class akka.stream.actor.AbstractActorPublisherWithUnboundedStash
-
- AbstractActorPublisherWithUnrestrictedStash<T> - Class in akka.stream.actor
-
Java API compatible with lambda expressions.
- AbstractActorPublisherWithUnrestrictedStash() - Constructor for class akka.stream.actor.AbstractActorPublisherWithUnrestrictedStash
-
- AbstractActorSubscriber - Class in akka.stream.actor
-
Java API compatible with lambda expressions
- AbstractActorSubscriber() - Constructor for class akka.stream.actor.AbstractActorSubscriber
-
- AbstractActorSubscriber$ - Class in akka.stream.actor
-
Java API compatible with lambda expressions
- AbstractActorSubscriber$() - Constructor for class akka.stream.actor.AbstractActorSubscriber$
-
- 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 single-consumer queue based on the works of:
Andriy Plokhotnuyk (https://github.com/plokhotnyuk)
- https://github.com/plokhotnyuk/actors/blob/2e65abb7ce4cbfcb1b29c98ee99303d6ced6b01f/src/test/scala/akka/dispatch/Mailboxes.scala
(Apache V2: https://github.com/plokhotnyuk/actors/blob/master/LICENSE)
Dmitriy Vyukov's non-intrusive MPSC queue:
- http://www.1024cores.net/home/lock-free-algorithms/queues/non-intrusive-mpsc-node-based-queue
(Simplified BSD)
- AbstractBoundedNodeQueue(int) - Constructor for class akka.dispatch.AbstractBoundedNodeQueue
-
- AbstractBoundedNodeQueue.Node<T> - Class in akka.dispatch
-
- AbstractEventsByPersistenceIdPublisher - Class in akka.persistence.query.journal.leveldb
-
INTERNAL API
- AbstractEventsByPersistenceIdPublisher(String, long, int, String) - Constructor for class akka.persistence.query.journal.leveldb.AbstractEventsByPersistenceIdPublisher
-
- AbstractEventsByTagPublisher - Class in akka.persistence.query.journal.leveldb
-
INTERNAL API
- AbstractEventsByTagPublisher(String, long, int, String) - Constructor for class akka.persistence.query.journal.leveldb.AbstractEventsByTagPublisher
-
- 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$
-
- AbstractFSMWithStash<S,D> - Class in akka.actor
-
Java API: compatible with lambda expressions
- AbstractFSMWithStash() - Constructor for class akka.actor.AbstractFSMWithStash
-
- AbstractInHandler - Class in akka.stream.stage
-
Java API: callbacks for an input port where termination logic is predefined
(completing when upstream completes, failing when upstream fails).
- AbstractInHandler() - Constructor for class akka.stream.stage.AbstractInHandler
-
- AbstractInOutHandler - Class in akka.stream.stage
-
Java API: callback combination for output and input ports where termination logic is predefined
(completing when upstream completes, failing when upstream fails, completing when downstream cancels).
- AbstractInOutHandler() - Constructor for class akka.stream.stage.AbstractInOutHandler
-
- 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
This queue could be wait-free (i.e.
- AbstractNodeQueue() - Constructor for class akka.dispatch.AbstractNodeQueue
-
- AbstractNodeQueue.Node<T> - Class in akka.dispatch
-
- AbstractOutHandler - Class in akka.stream.stage
-
Java API: callbacks for an output port where termination logic is predefined
(completing when downstream cancels).
- AbstractOutHandler() - Constructor for class akka.stream.stage.AbstractOutHandler
-
- 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
-
- AbstractPersistentFSM<S extends PersistentFSM.FSMState,D,E> - Class in akka.persistence.fsm
-
Java API: compatible with lambda expressions
- AbstractPersistentFSM() - Constructor for class akka.persistence.fsm.AbstractPersistentFSM
-
- AbstractPersistentFSMBase<S,D,E> - Class in akka.persistence.fsm
-
Java API: compatible with lambda expressions
- AbstractPersistentFSMBase() - Constructor for class akka.persistence.fsm.AbstractPersistentFSMBase
-
- AbstractPersistentFSMBase$ - Class in akka.persistence.fsm
-
Java API: compatible with lambda expressions
- AbstractPersistentFSMBase$() - Constructor for class akka.persistence.fsm.AbstractPersistentFSMBase$
-
- AbstractPersistentLoggingFSM<S extends PersistentFSM.FSMState,D,E> - Class in akka.persistence.fsm
-
Java API: compatible with lambda expressions
- AbstractPersistentLoggingFSM() - Constructor for class akka.persistence.fsm.AbstractPersistentLoggingFSM
-
- AbstractPersistentView - Class in akka.persistence
-
- AbstractPersistentView() - Constructor for class akka.persistence.AbstractPersistentView
-
Deprecated.
- AbstractProps - Interface in akka.actor
-
Java API: Factory for Props instances.
- AbstractReplicatedData<D extends AbstractReplicatedData<D>> - Class in akka.cluster.ddata
-
- AbstractReplicatedData() - Constructor for class akka.cluster.ddata.AbstractReplicatedData
-
- 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
-
- AbstractSerializationSupport - Class in akka.cluster.ddata.protobuf
-
Java API
- AbstractSerializationSupport() - Constructor for class akka.cluster.ddata.protobuf.AbstractSerializationSupport
-
- AbstractShape - Class in akka.stream
-
Java API for creating custom
Shape
types.
- AbstractShape() - Constructor for class akka.stream.AbstractShape
-
- 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
-
- AbstractStage<In,Out,PushD extends Directive,PullD extends Directive,Ctx extends Context<Out>,LifeCtx extends LifecycleContext> - Class in akka.stream.stage
-
- AbstractStage() - Constructor for class akka.stream.stage.AbstractStage
-
Deprecated.
- AbstractStage$ - Class in akka.stream.stage
-
- AbstractStage$() - Constructor for class akka.stream.stage.AbstractStage$
-
Deprecated.
- AbstractStage.PushPullGraphStage<In,Out,Ext> - Class in akka.stream.stage
-
Deprecated.
- AbstractStage.PushPullGraphStageWithMaterializedValue<In,Out,Ext,Mat> - Class in akka.stream.stage
-
Deprecated.
- 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.cluster.client.ClusterClientSettings
-
- acceptableHeartbeatPause() - Method in class akka.cluster.client.ClusterReceptionistSettings
-
- 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
-
- acceptUpstreamFinish() - Method in class akka.stream.impl.io.ByteStringParser.ParseResult
-
- AccessInboundCompressionFailed() - Constructor for exception akka.remote.artery.Decoder.AccessInboundCompressionFailed
-
- AccessOutboundCompressionFailed() - Constructor for exception akka.remote.artery.Encoder.AccessOutboundCompressionFailed
-
- accumulateAndGet(V, BinaryOperator<V>) - Static method in class akka.remote.artery.FlightRecorder
-
- accumulateAndGet(V, BinaryOperator<V>) - Static method in class akka.stream.impl.VirtualProcessor
-
- accumulateAndGet(V, BinaryOperator<V>) - Static method in class akka.util.SerializedSuspendableExecutionContext
-
- accumulated() - Method in class akka.stream.impl.CollectorState
-
- 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(long, UniqueAddress) - Constructor for class akka.remote.artery.SystemMessageDelivery.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$() - Constructor for class akka.remote.artery.SystemMessageDelivery.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.
- ackReplyTo() - Method in class akka.remote.artery.SystemMessageDelivery.SystemMessageEnvelope
-
- ACKREPLYTO_FIELD_NUMBER - Static variable in class akka.remote.ArteryControlFormats.SystemMessageEnvelope
-
- acquire() - Method in interface akka.io.BufferPool
-
- acquire() - Method in class akka.io.DirectByteBufferPool
-
- acquire() - Method in class akka.remote.artery.EnvelopeBufferPool
-
- acquire() - Method in class akka.remote.artery.ObjectPool
-
- action() - Method in class akka.stream.impl.TransferPhase
-
- actionInterval() - Method in class akka.routing.DefaultOptimalSizeExploringResizer
-
- activate() - Method in class akka.cluster.sharding.DDataShardCoordinator
-
- 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.
- activationMask() - Method in class akka.typed.internal.ActorCell$
-
- activationMask() - Static method in class akka.typed.internal.ActorCell
-
- 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
-
- activations(int) - Method in class akka.typed.internal.ActorCell$
-
- activations(int) - Static method in class akka.typed.internal.ActorCell
-
- 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.cluster.ddata.LmdbDurableStore
-
- active() - Method in class akka.cluster.sharding.ShardCoordinator
-
- active() - Method in class akka.contrib.pattern.ReliableProxy$
-
- active() - Static method in class akka.contrib.pattern.ReliableProxy
-
- active(ActorRef, boolean) - Method in class akka.persistence.journal.PersistencePluginProxy
-
- active() - Method in class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher
-
- Active() - Constructor for class akka.stream.actor.ActorPublisher.Internal$.Active
-
- active() - Method in class akka.stream.impl.ActorSubscriptionWithCursor
-
- active() - Method in interface akka.stream.impl.SubscriptionWithCursor
-
- Active$() - Constructor for class akka.contrib.pattern.ReliableProxy.Active$
-
- Active$() - Constructor for class akka.contrib.throttle.TimerBasedThrottler.Active$
-
- activeInterpreters() - Method in class akka.stream.impl.fusing.ActorGraphInterpreter
-
- activeReceive() - Method in class akka.stream.impl.ActorProcessorImpl
-
- activeReceive() - Static method in class akka.stream.impl.FanoutProcessorImpl
-
- activeReceivers() - Method in class akka.cluster.ClusterHeartbeatSenderState
-
- activeStage() - Method in class akka.stream.impl.fusing.GraphInterpreter
-
INTERNAL API
- activeTable() - Method in class akka.remote.artery.compress.InboundCompression.State
-
- Actor - Interface in akka.actor
-
- actor() - Method in class akka.actor.ActorCell
-
- actor(Function0<T>, ClassTag<T>, ActorRefFactory) - Static method in class akka.actor.ActorDSL
-
- actor(String, Function0<T>, ClassTag<T>, ActorRefFactory) - Static method in class akka.actor.ActorDSL
-
- actor(ActorRefFactory, String, Function0<T>, ClassTag<T>) - Static method in class akka.actor.ActorDSL
-
- actor(ActorRefFactory, Function0<T>, ClassTag<T>) - Static method in class akka.actor.ActorDSL
-
- 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() - Static method in class akka.camel.internal.AwaitActivation
-
- actor() - Static method in class akka.camel.internal.AwaitDeActivation
-
- 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() - Static method in class akka.routing.RoutedActorCell
-
- actor() - Method in exception akka.stream.AbruptTerminationException
-
- actor() - Method in class akka.stream.impl.SimpleOutputs
-
- actor() - Method in class akka.typed.internal.DeathWatchNotification
-
- actor() - Method in class akka.typed.internal.EventStreamImpl.Register
-
- actor() - Method in class akka.typed.internal.EventStreamImpl.UnregisterIfNoMoreSubscribedChannels
-
- 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.
- actor_$eq(Actor) - Static method in class akka.routing.RoutedActorCell
-
- ACTOR_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.ActorInitializationException
-
- ACTOR_FIELD_NUMBER - Static variable in class akka.remote.SystemMessageFormats.DeathWatchNotificationData
-
- 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.adapter
-
- ActorAdapter(Behavior<T>) - Constructor for class akka.typed.adapter.ActorAdapter
-
- ActorAssociationEventListener(ActorRef) - Constructor for class akka.remote.transport.Transport.ActorAssociationEventListener
-
- ActorAssociationEventListener$() - Constructor for class akka.remote.transport.Transport.ActorAssociationEventListener$
-
- ActorAttributes - Class in akka.stream
-
- ActorAttributes() - Constructor for class akka.stream.ActorAttributes
-
- ActorAttributes$ - Class in akka.stream
-
- ActorAttributes$() - Constructor for class akka.stream.ActorAttributes$
-
- ActorAttributes.Dispatcher - Class in akka.stream
-
- ActorAttributes.Dispatcher$ - Class in akka.stream
-
- ActorAttributes.SupervisionStrategy - Class in akka.stream
-
- ActorAttributes.SupervisionStrategy$ - Class in akka.stream
-
- 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<T> - Class in akka.typed.internal
-
INTERNAL API
- ActorCell(ActorSystem<Nothing$>, Behavior<T>, ExecutionContextExecutor, int, ActorRefImpl<Nothing$>) - Constructor for class akka.typed.internal.ActorCell
-
- ActorCell$ - Class in akka.actor
-
Everything in here is completely Akka PRIVATE.
- ActorCell$() - Constructor for class akka.actor.ActorCell$
-
- ActorCell$ - Class in akka.typed.internal
-
INTERNAL API
- ActorCell$() - Constructor for class akka.typed.internal.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
-
- 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() - Static method in class akka.testkit.TestActorRef
-
- actorContext() - Static method in class akka.testkit.TestFSMRef
-
- 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.adapter
-
INTERNAL API.
- ActorContextAdapter(ActorContext) - Constructor for class akka.typed.adapter.ActorContextAdapter
-
- 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
-
- ActorEventBus() - Constructor for class akka.event.japi.ActorEventBus
-
Deprecated.
- 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) - Static method in class akka.actor.ActorCell
-
- actorFor(String) - Static method in class akka.actor.ActorCell
-
- actorFor(Iterable<String>) - Static method in class akka.actor.ActorCell
-
- actorFor(Iterable<String>) - Static method in class akka.actor.ActorCell
-
- actorFor(ActorPath) - Method in interface akka.actor.ActorRefFactory
-
- actorFor(String) - Method in interface akka.actor.ActorRefFactory
-
- actorFor(Iterable<String>) - Method in interface akka.actor.ActorRefFactory
-
- actorFor(Iterable<String>) - Method in interface akka.actor.ActorRefFactory
-
- actorFor(ActorPath) - Method in interface akka.actor.ActorRefProvider
-
- actorFor(InternalActorRef, String) - Method in interface akka.actor.ActorRefProvider
-
- actorFor(InternalActorRef, Iterable<String>) - Method in interface akka.actor.ActorRefProvider
-
- actorFor(ActorPath) - Static method in class akka.actor.ActorSystem
-
- actorFor(String) - Static method in class akka.actor.ActorSystem
-
- actorFor(Iterable<String>) - Static method in class akka.actor.ActorSystem
-
- actorFor(Iterable<String>) - Static method in class akka.actor.ActorSystem
-
- 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
-
- actorFor(ActorPath) - Static method in class akka.routing.RoutedActorCell
-
- actorFor(String) - Static method in class akka.routing.RoutedActorCell
-
- actorFor(Iterable<String>) - Static method in class akka.routing.RoutedActorCell
-
- actorFor(Iterable<String>) - Static method in class akka.routing.RoutedActorCell
-
- ActorGraphInterpreter - Class in akka.stream.impl.fusing
-
INTERNAL API
- ActorGraphInterpreter(GraphInterpreterShell) - Constructor for class akka.stream.impl.fusing.ActorGraphInterpreter
-
- ActorGraphInterpreter$ - Class in akka.stream.impl.fusing
-
INTERNAL API
- ActorGraphInterpreter$() - Constructor for class akka.stream.impl.fusing.ActorGraphInterpreter$
-
- ActorGraphInterpreter.Abort - Class in akka.stream.impl.fusing
-
- ActorGraphInterpreter.Abort$ - Class in akka.stream.impl.fusing
-
- ActorGraphInterpreter.ActorOutputBoundary - Class in akka.stream.impl.fusing
-
- ActorGraphInterpreter.AsyncInput - Class in akka.stream.impl.fusing
-
- ActorGraphInterpreter.AsyncInput$ - Class in akka.stream.impl.fusing
-
- ActorGraphInterpreter.BatchingActorInputBoundary - Class in akka.stream.impl.fusing
-
- ActorGraphInterpreter.BoundaryEvent - Interface in akka.stream.impl.fusing
-
- ActorGraphInterpreter.BoundaryPublisher - Class in akka.stream.impl.fusing
-
- ActorGraphInterpreter.BoundarySubscriber - Class in akka.stream.impl.fusing
-
- ActorGraphInterpreter.BoundarySubscription - Class in akka.stream.impl.fusing
-
- ActorGraphInterpreter.Cancel - Class in akka.stream.impl.fusing
-
- ActorGraphInterpreter.Cancel$ - Class in akka.stream.impl.fusing
-
- ActorGraphInterpreter.ExposedPublisher - Class in akka.stream.impl.fusing
-
- ActorGraphInterpreter.ExposedPublisher$ - Class in akka.stream.impl.fusing
-
- ActorGraphInterpreter.OnComplete - Class in akka.stream.impl.fusing
-
- ActorGraphInterpreter.OnComplete$ - Class in akka.stream.impl.fusing
-
- ActorGraphInterpreter.OnError - Class in akka.stream.impl.fusing
-
- ActorGraphInterpreter.OnError$ - Class in akka.stream.impl.fusing
-
- ActorGraphInterpreter.OnNext - Class in akka.stream.impl.fusing
-
- ActorGraphInterpreter.OnNext$ - Class in akka.stream.impl.fusing
-
- ActorGraphInterpreter.OnSubscribe - Class in akka.stream.impl.fusing
-
- ActorGraphInterpreter.OnSubscribe$ - Class in akka.stream.impl.fusing
-
- ActorGraphInterpreter.RequestMore - Class in akka.stream.impl.fusing
-
- ActorGraphInterpreter.RequestMore$ - Class in akka.stream.impl.fusing
-
- ActorGraphInterpreter.Resume - Class in akka.stream.impl.fusing
-
- ActorGraphInterpreter.Resume$ - Class in akka.stream.impl.fusing
-
- ActorGraphInterpreter.SubscribePending - Class in akka.stream.impl.fusing
-
- ActorGraphInterpreter.SubscribePending$ - Class in akka.stream.impl.fusing
-
- 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 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() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- actorInstanceId() - Static method in class akka.persistence.journal.JournalSpec
-
- actorInstanceId() - Method in class akka.persistence.JournalProtocol.LoopMessageSuccess
-
- actorInstanceId() - Method in class akka.persistence.JournalProtocol.WriteMessageFailure
-
- actorInstanceId() - Method in class akka.persistence.JournalProtocol.WriteMessageRejected
-
- actorInstanceId() - Method in class akka.persistence.JournalProtocol.WriteMessages
-
- actorInstanceId() - Method in class akka.persistence.JournalProtocol.WriteMessageSuccess
-
- actorInstanceId() - Method in class akka.persistence.PluginSpec
-
- actorInstanceId() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- 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".
- ActorMaterializer - Class in akka.stream
-
An ActorMaterializer takes the list of transformations comprising a
Flow
and materializes them in the form of
Processor
instances.
- ActorMaterializer() - Constructor for class akka.stream.ActorMaterializer
-
- ActorMaterializer$ - Class in akka.stream
-
- ActorMaterializer$() - Constructor for class akka.stream.ActorMaterializer$
-
- ActorMaterializerHelper - Class in akka.stream
-
INTERNAL API
- ActorMaterializerHelper() - Constructor for class akka.stream.ActorMaterializerHelper
-
- ActorMaterializerHelper$ - Class in akka.stream
-
INTERNAL API
- ActorMaterializerHelper$() - Constructor for class akka.stream.ActorMaterializerHelper$
-
- ActorMaterializerImpl - Class in akka.stream.impl
-
INTERNAL API
- ActorMaterializerImpl(ActorSystem, ActorMaterializerSettings, Dispatchers, ActorRef, AtomicBoolean, SeqActorName) - Constructor for class akka.stream.impl.ActorMaterializerImpl
-
- ActorMaterializerImpl$ - Class in akka.stream.impl
-
- ActorMaterializerImpl$() - Constructor for class akka.stream.impl.ActorMaterializerImpl$
-
- ActorMaterializerSettings - Class in akka.stream
-
- ActorMaterializerSettings(int, int, String, Function1<Throwable, Supervision.Directive>, StreamSubscriptionTimeoutSettings, boolean, int, boolean, boolean, int) - Constructor for class akka.stream.ActorMaterializerSettings
-
- ActorMaterializerSettings$ - Class in akka.stream
-
- ActorMaterializerSettings$() - Constructor for class akka.stream.ActorMaterializerSettings$
-
- 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) - Static method in class akka.actor.ActorCell
-
- actorOf(Props, String) - Static method in class akka.actor.ActorCell
-
- 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) - Static method in class akka.actor.ActorSystem
-
- actorOf(Props, String) - Static method in class akka.actor.ActorSystem
-
- 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) - Static method in class akka.routing.RoutedActorCell
-
- actorOf(Props, String) - Static method in class akka.routing.RoutedActorCell
-
- actorOf(MaterializationContext, Props) - Method in class akka.stream.ActorMaterializer
-
INTERNAL API
- actorOf(MaterializationContext, Props) - Static method in class akka.stream.impl.ActorMaterializerImpl
-
- actorOf(Props, String, String) - Static method in class akka.stream.impl.ActorMaterializerImpl
-
- actorOf(MaterializationContext, Props) - Method in class akka.stream.impl.ExtendedActorMaterializer
-
INTERNAL API
- actorOf(Props, String, String) - Method in class akka.stream.impl.ExtendedActorMaterializer
-
INTERNAL API
- ActorOutputBoundary(ActorRef, GraphInterpreterShell, int) - Constructor for class akka.stream.impl.fusing.ActorGraphInterpreter.ActorOutputBoundary
-
- ActorPath - Interface in akka.actor
-
Actor path is a unique path to an actor that shows the creation path
up through the actor tree to the root actor.
- actorPath() - 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$
-
- ActorPaths - Class in akka.actor
-
Java API
- ActorPaths() - Constructor for class akka.actor.ActorPaths
-
- ActorPaths$ - Class in akka.actor
-
Java API
- ActorPaths$() - Constructor for class akka.actor.ActorPaths$
-
- ActorProcessor<I,O> - Class in akka.stream.impl
-
INTERNAL API
- ActorProcessor(ActorRef) - Constructor for class akka.stream.impl.ActorProcessor
-
- ActorProcessor$ - Class in akka.stream.impl
-
INTERNAL API
- ActorProcessor$() - Constructor for class akka.stream.impl.ActorProcessor$
-
- ActorProcessorImpl - Class in akka.stream.impl
-
INTERNAL API
- ActorProcessorImpl(ActorMaterializerSettings) - Constructor for class akka.stream.impl.ActorProcessorImpl
-
- 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
- ActorPublisher<T> - Interface in akka.stream.actor
-
Extend/mixin this trait in your
Actor
to make it a
stream publisher that keeps track of the subscription life cycle and
requested elements.
- ActorPublisher<T> - Class in akka.stream.impl
-
INTERNAL API
- ActorPublisher(ActorRef) - Constructor for class akka.stream.impl.ActorPublisher
-
- actorPublisher(Props) - Method in class akka.stream.javadsl.Source$
-
Creates a
Source
that is materialized to an
ActorRef
which points to an Actor
created according to the passed in
Props
.
- actorPublisher(Props) - Static method in class akka.stream.javadsl.Source
-
Creates a
Source
that is materialized to an
ActorRef
which points to an Actor
created according to the passed in
Props
.
- actorPublisher(Props) - Method in class akka.stream.scaladsl.Source$
-
Creates a
Source
that is materialized to an
ActorRef
which points to an Actor
created according to the passed in
Props
.
- actorPublisher(Props) - Static method in class akka.stream.scaladsl.Source
-
Creates a
Source
that is materialized to an
ActorRef
which points to an Actor
created according to the passed in
Props
.
- ActorPublisher$ - Class in akka.stream.actor
-
- ActorPublisher$() - Constructor for class akka.stream.actor.ActorPublisher$
-
- ActorPublisher$ - Class in akka.stream.impl
-
INTERNAL API
- ActorPublisher$() - Constructor for class akka.stream.impl.ActorPublisher$
-
- ActorPublisher.Internal$ - Class in akka.stream.actor
-
INTERNAL API
- ActorPublisher.Internal$.Active - Class in akka.stream.actor
-
- ActorPublisher.Internal$.Canceled - Class in akka.stream.actor
-
- ActorPublisher.Internal$.Completed - Class in akka.stream.actor
-
- ActorPublisher.Internal$.CompleteThenStop - Class in akka.stream.actor
-
- ActorPublisher.Internal$.ErrorEmitted - Class in akka.stream.actor
-
- ActorPublisher.Internal$.LifecycleState - Interface in akka.stream.actor
-
- ActorPublisher.Internal$.PreSubscriber - Class in akka.stream.actor
-
- ActorPublisher.Internal$.Subscribe - Class in akka.stream.actor
-
- ActorPublisher.NormalShutdownException - Exception in akka.stream.impl
-
- ActorPublisherImpl<T> - Class in akka.stream.actor
-
INTERNAL API
- ActorPublisherImpl(ActorRef) - Constructor for class akka.stream.actor.ActorPublisherImpl
-
- ActorPublisherImpl$ - Class in akka.stream.actor
-
- ActorPublisherImpl$() - Constructor for class akka.stream.actor.ActorPublisherImpl$
-
- ActorPublisherMessage - Class in akka.stream.actor
-
- ActorPublisherMessage() - Constructor for class akka.stream.actor.ActorPublisherMessage
-
- ActorPublisherMessage$ - Class in akka.stream.actor
-
- ActorPublisherMessage$() - Constructor for class akka.stream.actor.ActorPublisherMessage$
-
- ActorPublisherMessage.Cancel - Class in akka.stream.actor
-
- ActorPublisherMessage.Cancel$ - Class in akka.stream.actor
-
This message is delivered to the
ActorPublisher
actor when the stream subscriber cancels the
subscription.
- ActorPublisherMessage.Request - Class in akka.stream.actor
-
This message is delivered to the
ActorPublisher
actor when the stream subscriber requests
more elements.
- ActorPublisherMessage.Request$ - Class in akka.stream.actor
-
- ActorPublisherMessage.SubscriptionTimeoutExceeded - Class in akka.stream.actor
-
- ActorPublisherMessage.SubscriptionTimeoutExceeded$ - Class in akka.stream.actor
-
This message is delivered to the
ActorPublisher
actor in order to signal the exceeding of an subscription timeout.
- ActorPublisherSource<Out> - Class in akka.stream.impl
-
INTERNAL API
Creates and wraps an actor into
Publisher
from the given
props
,
which should be
Props
for an
ActorPublisher
.
- ActorPublisherSource(Props, Attributes, SourceShape<Out>) - Constructor for class akka.stream.impl.ActorPublisherSource
-
- actorPublisherSource() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- ActorPublisherState - Class in akka.stream.actor
-
INTERNAL API
- ActorPublisherState() - Constructor for class akka.stream.actor.ActorPublisherState
-
- ActorPublisherState$ - Class in akka.stream.actor
-
INTERNAL API
Some state must survive restarts.
- ActorPublisherState$() - Constructor for class akka.stream.actor.ActorPublisherState$
-
- ActorPublisherState.State - Class in akka.stream.actor
-
- ActorPublisherState.State$ - Class in akka.stream.actor
-
- ActorPublisherSubscription<T> - Class in akka.stream.actor
-
INTERNAL API
- ActorPublisherSubscription(ActorRef) - Constructor for class akka.stream.actor.ActorPublisherSubscription
-
- 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.contrib.circuitbreaker.AskeableWithCircuitBreakerActor
-
- actorRef() - Method in class akka.pattern.AskableActorRef
-
- actorRef() - Method in class akka.pattern.ExplicitlyAskableActorRef
-
- actorRef() - Method in class akka.persistence.fsm.PersistentFSM.SubscribeTransitionCallBack
-
- actorRef() - Method in class akka.persistence.fsm.PersistentFSM.UnsubscribeTransitionCallBack
-
- actorRef(ActorRef, Object) - Method in class akka.stream.javadsl.Sink$
-
Sends the elements of the stream to the given ActorRef
.
- actorRef(ActorRef, Object) - Static method in class akka.stream.javadsl.Sink
-
Sends the elements of the stream to the given ActorRef
.
- actorRef(int, OverflowStrategy) - Method in class akka.stream.javadsl.Source$
-
Creates a
Source
that is materialized as an
ActorRef
.
- actorRef(int, OverflowStrategy) - Static method in class akka.stream.javadsl.Source
-
Creates a
Source
that is materialized as an
ActorRef
.
- actorRef(ActorRef, Object) - Method in class akka.stream.scaladsl.Sink$
-
Sends the elements of the stream to the given ActorRef
.
- actorRef(ActorRef, Object) - Static method in class akka.stream.scaladsl.Sink
-
Sends the elements of the stream to the given ActorRef
.
- actorRef(int, OverflowStrategy) - Method in class akka.stream.scaladsl.Source$
-
Creates a
Source
that is materialized as an
ActorRef
.
- actorRef(int, OverflowStrategy) - Static method in class akka.stream.scaladsl.Source
-
Creates a
Source
that is materialized as an
ActorRef
.
- ActorRef<T> - Class in akka.typed
-
An ActorRef is the identity or address of an Actor instance.
- ActorRef(ActorPath) - 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<T> - Class in akka.typed.adapter
-
- ActorRefAdapter(InternalActorRef) - Constructor for class akka.typed.adapter.ActorRefAdapter
-
- ActorRefAdapter$ - Class in akka.typed.adapter
-
- ActorRefAdapter$() - Constructor for class akka.typed.adapter.ActorRefAdapter$
-
- ActorRefBackpressureSinkStage<In> - Class in akka.stream.impl
-
INTERNAL API
- ActorRefBackpressureSinkStage(ActorRef, Object, Object, Object, Function1<Throwable, Object>) - Constructor for class akka.stream.impl.ActorRefBackpressureSinkStage
-
- ActorRefCompressionAdvertisement(UniqueAddress, CompressionTable<ActorRef>) - Constructor for class akka.remote.artery.compress.CompressionProtocol.ActorRefCompressionAdvertisement
-
- ActorRefCompressionAdvertisement$() - Constructor for class akka.remote.artery.compress.CompressionProtocol.ActorRefCompressionAdvertisement$
-
- ActorRefCompressionAdvertisementAck(UniqueAddress, byte) - Constructor for class akka.remote.artery.compress.CompressionProtocol.ActorRefCompressionAdvertisementAck
-
- ActorRefCompressionAdvertisementAck$() - Constructor for class akka.remote.artery.compress.CompressionProtocol.ActorRefCompressionAdvertisementAck$
-
- ActorRefCompressionTableVersionOffset() - Method in class akka.remote.artery.EnvelopeBuffer$
-
- ActorRefCompressionTableVersionOffset() - Static method in class akka.remote.artery.EnvelopeBuffer
-
- ActorRefFactory - Interface in akka.actor
-
Interface implemented by ActorSystem and ActorContext, the only two places
from which you can get fresh actors.
- ActorRefImpl<T> - Interface in akka.typed.internal
-
Every ActorRef is also an ActorRefImpl, but these two methods shall be
completely hidden from client code.
- ActorRefProvider - Interface in akka.actor
-
Interface for all ActorRef providers to implement.
- actorRefProvider() - Method in class akka.actor.BootstrapSetup
-
- ActorRefResolveCache - Class in akka.remote.serialization
-
INTERNAL API
- ActorRefResolveCache(RemoteActorRefProvider) - Constructor for class akka.remote.serialization.ActorRefResolveCache
-
- ActorRefResolveCacheWithAddress - Class in akka.remote.artery
-
INTERNAL API
- ActorRefResolveCacheWithAddress(RemoteActorRefProvider, UniqueAddress) - Constructor for class akka.remote.artery.ActorRefResolveCacheWithAddress
-
- ActorRefResolveThreadLocalCache - Class in akka.remote.serialization
-
INTERNAL API
- ActorRefResolveThreadLocalCache(ExtendedActorSystem) - Constructor for class akka.remote.serialization.ActorRefResolveThreadLocalCache
-
- ActorRefResolveThreadLocalCache$ - Class in akka.remote.serialization
-
INTERNAL API: Thread local cache per actor system
- ActorRefResolveThreadLocalCache$() - Constructor for class akka.remote.serialization.ActorRefResolveThreadLocalCache$
-
- 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$
-
- ActorRefs() - Method in class akka.remote.artery.ArterySettings.Compression
-
Accessor for nested Scala object
- ActorRefs$() - Constructor for class akka.remote.artery.ArterySettings.Compression.ActorRefs$
-
- ActorRefScope - Interface in akka.actor
-
All ActorRefs have a scope which describes where they live.
- ActorRefSink<In> - Class in akka.stream.impl
-
INTERNAL API
- ActorRefSink(ActorRef, Object, Attributes, SinkShape<In>) - Constructor for class akka.stream.impl.ActorRefSink
-
- actorRefSink() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- ActorRefSinkActor - Class in akka.stream.impl
-
INTERNAL API
- ActorRefSinkActor(ActorRef, int, Object) - Constructor for class akka.stream.impl.ActorRefSinkActor
-
- ActorRefSinkActor$ - Class in akka.stream.impl
-
INTERNAL API
- ActorRefSinkActor$() - Constructor for class akka.stream.impl.ActorRefSinkActor$
-
- ActorRefSource<Out> - Class in akka.stream.impl
-
INTERNAL API
- ActorRefSource(int, OverflowStrategy, Attributes, SourceShape<Out>) - Constructor for class akka.stream.impl.ActorRefSource
-
- actorRefSource() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- ActorRefSourceActor - Class in akka.stream.impl
-
INTERNAL API
- ActorRefSourceActor(int, OverflowStrategy, int) - Constructor for class akka.stream.impl.ActorRefSourceActor
-
- ActorRefSourceActor$ - Class in akka.stream.impl
-
INTERNAL API
- ActorRefSourceActor$() - Constructor for class akka.stream.impl.ActorRefSourceActor$
-
- actorRefWithAck() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- actorRefWithAck(ActorRef, Object, Object, Object, Function<Throwable, Object>) - Method in class akka.stream.javadsl.Sink$
-
Sends the elements of the stream to the given ActorRef
that sends back back-pressure signal.
- actorRefWithAck(ActorRef, Object, Object, Object, Function<Throwable, Object>) - Static method in class akka.stream.javadsl.Sink
-
Sends the elements of the stream to the given ActorRef
that sends back back-pressure signal.
- actorRefWithAck(ActorRef, Object, Object, Object, Function1<Throwable, Object>) - Method in class akka.stream.scaladsl.Sink$
-
Sends the elements of the stream to the given ActorRef
that sends back back-pressure signal.
- actorRefWithAck(ActorRef, Object, Object, Object, Function1<Throwable, Object>) - Static method in class akka.stream.scaladsl.Sink
-
Sends the elements of the stream to the given ActorRef
that sends back back-pressure signal.
- 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
-
- actorSel() - Method in class akka.pattern.ExplicitlyAskableActorSelection
-
- actorSelection(String) - Static method in class akka.actor.ActorCell
-
- actorSelection(ActorPath) - Static method in class akka.actor.ActorCell
-
- 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(String) - Static method in class akka.actor.ActorSystem
-
- actorSelection(ActorPath) - Static method in class akka.actor.ActorSystem
-
- actorSelection() - Method in class akka.contrib.circuitbreaker.AskeableWithCircuitBreakerActorSelection
-
- actorSelection(String) - Static method in class akka.routing.RoutedActorCell
-
- actorSelection(ActorPath) - Static method in class akka.routing.RoutedActorCell
-
- 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$
-
- ActorSubscriber - Interface in akka.stream.actor
-
Extend/mixin this trait in your
Actor
to make it a
stream subscriber with full control of stream back pressure.
- actorSubscriber(Props) - Method in class akka.stream.javadsl.Sink$
-
Creates a
Sink
that is materialized to an
ActorRef
which points to an Actor
created according to the passed in
Props
.
- actorSubscriber(Props) - Static method in class akka.stream.javadsl.Sink
-
Creates a
Sink
that is materialized to an
ActorRef
which points to an Actor
created according to the passed in
Props
.
- actorSubscriber(Props) - Method in class akka.stream.scaladsl.Sink$
-
Creates a
Sink
that is materialized to an
ActorRef
which points to an Actor
created according to the passed in
Props
.
- actorSubscriber(Props) - Static method in class akka.stream.scaladsl.Sink
-
Creates a
Sink
that is materialized to an
ActorRef
which points to an Actor
created according to the passed in
Props
.
- ActorSubscriber$ - Class in akka.stream.actor
-
- ActorSubscriber$() - Constructor for class akka.stream.actor.ActorSubscriber$
-
- ActorSubscriber.OnSubscribe - Class in akka.stream.actor
-
INTERNAL API
- ActorSubscriber.OnSubscribe$ - Class in akka.stream.actor
-
- ActorSubscriberImpl<T> - Class in akka.stream.actor
-
INTERNAL API
- ActorSubscriberImpl(ActorRef) - Constructor for class akka.stream.actor.ActorSubscriberImpl
-
- ActorSubscriberMessage - Class in akka.stream.actor
-
- ActorSubscriberMessage() - Constructor for class akka.stream.actor.ActorSubscriberMessage
-
- ActorSubscriberMessage$ - Class in akka.stream.actor
-
- ActorSubscriberMessage$() - Constructor for class akka.stream.actor.ActorSubscriberMessage$
-
- ActorSubscriberMessage.OnComplete$ - Class in akka.stream.actor
-
- ActorSubscriberMessage.OnError - Class in akka.stream.actor
-
- ActorSubscriberMessage.OnError$ - Class in akka.stream.actor
-
- ActorSubscriberMessage.OnNext - Class in akka.stream.actor
-
- ActorSubscriberMessage.OnNext$ - Class in akka.stream.actor
-
- ActorSubscriberSink<In> - Class in akka.stream.impl
-
INTERNAL API
Creates and wraps an actor into
Subscriber
from the given
props
,
which should be
Props
for an
ActorSubscriber
.
- ActorSubscriberSink(Props, Attributes, SinkShape<In>) - Constructor for class akka.stream.impl.ActorSubscriberSink
-
- actorSubscriberSink() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- ActorSubscriberState - Class in akka.stream.actor
-
INTERNAL API
- ActorSubscriberState() - Constructor for class akka.stream.actor.ActorSubscriberState
-
- ActorSubscriberState$ - Class in akka.stream.actor
-
INTERNAL API
Some state must survive restarts.
- ActorSubscriberState$() - Constructor for class akka.stream.actor.ActorSubscriberState$
-
- ActorSubscriberState.State - Class in akka.stream.actor
-
- ActorSubscriberState.State$ - Class in akka.stream.actor
-
- ActorSubscription<T> - Class in akka.stream.impl
-
INTERNAL API
- ActorSubscription(ActorRef, Subscriber<? super T>) - Constructor for class akka.stream.impl.ActorSubscription
-
- ActorSubscriptionWithCursor<T> - Class in akka.stream.impl
-
INTERNAL API
- ActorSubscriptionWithCursor(ActorRef, Subscriber<? super T>) - Constructor for class akka.stream.impl.ActorSubscriptionWithCursor
-
- 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> - Interface in akka.typed
-
An ActorSystem is home to a hierarchy of Actors.
- 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
-
- ActorSystemAdapter<T> - Class in akka.typed.adapter
-
Lightweight wrapper for presenting an untyped ActorSystem to a Behavior (via the context).
- ActorSystemAdapter(ActorSystemImpl) - Constructor for class akka.typed.adapter.ActorSystemAdapter
-
- ActorSystemAdapter$ - Class in akka.typed.adapter
-
- ActorSystemAdapter$() - Constructor for class akka.typed.adapter.ActorSystemAdapter$
-
- 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>, ActorSystemSetup) - Constructor for class akka.actor.ActorSystemImpl
-
- ActorSystemImpl<T> - Class in akka.typed.internal
-
- ActorSystemImpl(String, Config, ClassLoader, Option<ExecutionContext>, Behavior<T>, DeploymentConfig) - Constructor for class akka.typed.internal.ActorSystemImpl
-
- ActorSystemImpl$ - Class in akka.typed.internal
-
- ActorSystemImpl$() - Constructor for class akka.typed.internal.ActorSystemImpl$
-
- ActorSystemImpl.CreateSystemActor<T> - Class in akka.typed.internal
-
- ActorSystemImpl.CreateSystemActor$ - Class in akka.typed.internal
-
- ActorSystemImpl.SystemCommand - Interface in akka.typed.internal
-
- ActorSystemImpl.TerminationCallbacks<T> - Class in akka.actor
-
- actorSystemName() - Method in class akka.event.slf4j.Slf4jLogger
-
- 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
- ActorSystemSetup - Class in akka.actor.setup
-
A set of setup settings for programmatic configuration of the actor system.
- ActorSystemSetup(Map<Class<?>, Object>) - Constructor for class akka.actor.setup.ActorSystemSetup
-
- ActorSystemSetup$ - Class in akka.actor.setup
-
- ActorSystemSetup$() - Constructor for class akka.actor.setup.ActorSystemSetup$
-
- ActorSystemTerminating - Class in akka.remote.artery
-
INTERNAL API
- ActorSystemTerminating(UniqueAddress) - Constructor for class akka.remote.artery.ActorSystemTerminating
-
- ActorSystemTerminating$ - Class in akka.remote.artery
-
- ActorSystemTerminating$() - Constructor for class akka.remote.artery.ActorSystemTerminating$
-
- ActorSystemTerminatingAck - Class in akka.remote.artery
-
INTERNAL API
- ActorSystemTerminatingAck(UniqueAddress) - Constructor for class akka.remote.artery.ActorSystemTerminatingAck
-
- ActorSystemTerminatingAck$ - Class in akka.remote.artery
-
- ActorSystemTerminatingAck$() - Constructor for class akka.remote.artery.ActorSystemTerminatingAck$
-
- 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
-
- adapter(String, Behavior<T>, DeploymentConfig, Option<Config>, Option<ClassLoader>, Option<ExecutionContext>, ActorSystemSetup) - Method in class akka.typed.ActorSystem$
-
Create an ActorSystem based on the untyped
ActorSystem
which runs Akka Typed
Behavior
on an emulation layer.
- adapters() - Method in class akka.persistence.journal.EventAdapters.CombinedReadEventAdapter
-
- adapters() - Method in class akka.persistence.Persistence.PluginHolder
-
- Adapters() - Method in class akka.remote.RemoteSettings
-
- adaptersFor(String) - Method in class akka.persistence.Persistence
-
Returns an
EventAdapters
object which serves as a per-journal collection of bound event adapters.
- adaptersFor(ActorRef) - Method in class akka.persistence.Persistence
-
INTERNAL API
Looks up
EventAdapters
by journal plugin's ActorRef.
- adaptFromJournal(PersistentRepr) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- adaptFromJournal(PersistentRepr) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- adaptFromJournal(PersistentRepr) - Method in interface akka.persistence.journal.WriteJournalBase
-
INTERNAL API
- 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
-
- AdaptiveLoadBalancingGroup(MetricsSelector, Iterable<String>, String) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingGroup
-
Deprecated.
- AdaptiveLoadBalancingGroup(Config, DynamicAccess) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingGroup
-
Deprecated.
- AdaptiveLoadBalancingGroup(MetricsSelector, Iterable<String>) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingGroup
-
Deprecated.
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$
-
Deprecated.
- 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
-
- AdaptiveLoadBalancingPool(MetricsSelector, int, SupervisorStrategy, String, boolean) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingPool
-
Deprecated.
- AdaptiveLoadBalancingPool(Config, DynamicAccess) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingPool
-
Deprecated.
- AdaptiveLoadBalancingPool(MetricsSelector, int) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingPool
-
Deprecated.
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$
-
Deprecated.
- 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
-
- AdaptiveLoadBalancingRoutingLogic(ActorSystem, MetricsSelector) - Constructor for class akka.cluster.routing.AdaptiveLoadBalancingRoutingLogic
-
Deprecated.
- 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$
-
Deprecated.
- adaptToJournal(PersistentRepr) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- adaptToJournal(PersistentRepr) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- adaptToJournal(PersistentRepr) - Method in interface akka.persistence.journal.WriteJournalBase
-
INTERNAL API
- 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(A) - Method in class akka.cluster.ddata.GSet
-
Adds an element to the set
- add(Cluster, A) - Method in class akka.cluster.ddata.ORSet
-
Adds an element to the set
- add(UniqueAddress, A) - Method in class akka.cluster.ddata.ORSet
-
INTERNAL API
- add(A, B) - Method in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer.SmallCache
-
Add entry to the cache.
- add(Tuple2<A, B>) - Method in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer.SmallCache
-
- 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 an element to the head of the queue.
- add(ActorRef, ActorRef) - Method in class akka.event.ManagedActorClassification.ManagedActorClassificationMappings
-
- add(PersistentRepr) - Method in interface akka.persistence.journal.inmem.InmemMessages
-
- Add(Function0<Object>) - Constructor for class akka.remote.artery.TaskRunner.Add
-
- add(T) - Method in class akka.routing.ConsistentHash
-
Java API: Adds a node to the node ring.
- add(Graph<S, ?>) - Method in class akka.stream.javadsl.GraphDSL.Builder
-
Import a graph into this module, performing a deep copy, discarding its
materialized value and returning the copied Ports that are now to be
connected.
- add(Graph<S, ?>) - Method in class akka.stream.scaladsl.GraphDSL.Builder
-
Import a graph into this module, performing a deep copy, discarding its
materialized value and returning the copied Ports that are now to be
connected.
- add(Graph<S, ?>, Function1<A, Object>) - Method in class akka.stream.scaladsl.GraphDSL.Builder
-
INTERNAL API.
- add(Graph<S, ?>, Function2<A, B, Object>) - Method in class akka.stream.scaladsl.GraphDSL.Builder
-
INTERNAL API.
- add(I) - Method in class akka.util.MessageBufferMap
-
Add an id to the buffer map
- add(T) - Static method in class akka.util.SerializedSuspendableExecutionContext
-
- Add$() - Constructor for class akka.remote.artery.TaskRunner.Add$
-
- addAdds(String) - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet.Builder
-
repeated string adds = 1;
- addAddsBytes(ByteString) - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet.Builder
-
repeated string adds = 1;
- 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;
- addAllAdds(Iterable<String>) - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet.Builder
-
repeated string adds = 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;
- addAllContactPoints(Iterable<String>) - Method in class akka.cluster.client.protobuf.msg.ClusterClientMessages.Contacts.Builder
-
repeated string contactPoints = 1;
- addAllContent(Iterable<? extends DistributedPubSubMessages.Delta.Entry>) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Bucket.Builder
-
repeated .Delta.Entry content = 3;
- addAllDots(Iterable<? extends ReplicatedDataMessages.VersionVector>) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- addAllElements(Iterable<String>) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet.Builder
-
repeated string elements = 1;
- addAllEntities(Iterable<String>) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState.Builder
-
repeated string entities = 1;
- addAllEntries(Iterable<? extends ReplicatedDataMessages.GCounter.Entry>) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Builder
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- addAllEntries(Iterable<? extends ReplicatedDataMessages.LWWMap.Entry>) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- addAllEntries(Iterable<? extends ReplicatedDataMessages.ORMap.Entry>) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- addAllEntries(Iterable<? extends ReplicatedDataMessages.ORMultiMap.Entry>) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- addAllEntries(Iterable<? extends ReplicatedDataMessages.PNCounterMap.Entry>) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- addAllEntries(Iterable<? extends ReplicatedDataMessages.VersionVector.Entry>) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Builder
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- addAllEntries(Iterable<? extends ReplicatorMessages.Gossip.Entry>) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- addAllEntries(Iterable<? extends ReplicatorMessages.Status.Entry>) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
repeated .akka.cluster.ddata.Status.Entry entries = 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;
- addAllHasManifest(Iterable<? extends Boolean>) - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated bool hasManifest = 7;
- addAllIntElements(Iterable<? extends Integer>) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated sint32 intElements = 2 [packed = true];
- addAllIntElements(Iterable<? extends Integer>) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated sint32 intElements = 4 [packed = true];
- addAllKeys(Iterable<String>) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
repeated string keys = 4;
- addAllLongElements(Iterable<? extends Long>) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated sint64 longElements = 3 [packed = true];
- addAllLongElements(Iterable<? extends Long>) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated sint64 longElements = 5 [packed = true];
- addAllManifests(Iterable<String>) - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated string manifests = 5;
- 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;
- addAllOtherElements(Iterable<? extends ReplicatorMessages.OtherMessage>) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- addAllOtherElements(Iterable<? extends ReplicatorMessages.OtherMessage>) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- addAllPattern(Iterable<? extends ContainerFormats.Selection>) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
repeated .Selection pattern = 3;
- addAllPayload(Iterable<? extends MessageFormats.PersistentMessage>) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
-
repeated .PersistentMessage payload = 1;
- addAllPersistenceIdsSubscriber(ActorRef) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- addAllPersistenceIdsSubscriber(ActorRef) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
-
- addAllPruning(Iterable<? extends ReplicatorMessages.DataEnvelope.PruningEntry>) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- addAllRegionProxies(Iterable<String>) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string regionProxies = 3;
- addAllRegions(Iterable<String>) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string regions = 2;
- addAllRemovals(Iterable<String>) - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet.Builder
-
repeated string removals = 2;
- 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 ReplicatorMessages.Address>) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
repeated .akka.cluster.ddata.Address seen = 4;
- addAllSeen(Iterable<? extends Integer>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated int32 seen = 1;
- addAllSerializerIds(Iterable<? extends Integer>) - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated int32 serializerIds = 6;
- addAllShards(Iterable<? extends ClusterShardingMessages.CoordinatorState.ShardEntry>) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated .CoordinatorState.ShardEntry shards = 1;
- addAllStackTrace(Iterable<? extends ContainerFormats.StackTraceElement>) - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
repeated .StackTraceElement stackTrace = 4;
- addAllStringElements(Iterable<String>) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated string stringElements = 1;
- addAllStringElements(Iterable<String>) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated string stringElements = 3;
- addAllSubjectReachability(Iterable<? extends ClusterMessages.SubjectReachability>) - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
repeated .SubjectReachability subjectReachability = 2;
- addAllUnallocatedShards(Iterable<String>) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string unallocatedShards = 4;
- addAllUnconfirmedDeliveries(Iterable<? extends MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery>) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
-
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
- addAllValues(Iterable<? extends Integer>) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
repeated uint32 values = 5;
- 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;
- addAttributes(Attributes) - Static method in class akka.remote.artery.AeronSink
-
- addAttributes(Attributes) - Static method in class akka.remote.artery.AeronSource
-
- addAttributes(Attributes) - Static method in class akka.remote.artery.Decoder
-
- addAttributes(Attributes) - Static method in class akka.remote.artery.Encoder
-
- addAttributes(Attributes) - Static method in class akka.remote.artery.InboundControlJunction
-
- addAttributes(Attributes) - Static method in class akka.remote.artery.OutboundControlJunction
-
- addAttributes(Attributes) - Static method in class akka.remote.artery.OutboundHandshake
-
- addAttributes(Attributes) - Static method in class akka.remote.artery.SendQueue
-
- addAttributes(Attributes) - Static method in class akka.remote.artery.SystemMessageDelivery
-
- addAttributes(Attributes) - Method in interface akka.stream.Graph
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.EmptySource
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.fusing.Batch
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.fusing.Buffer
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.fusing.Collect
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.fusing.Drop
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.fusing.DropWhile
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.fusing.Filter
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.fusing.Fold
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.fusing.Grouped
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.fusing.Intersperse
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.fusing.LimitWeighted
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.fusing.Log
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.fusing.Map
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.fusing.MapAsync
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.fusing.MapAsyncUnordered
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.fusing.MapError
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.fusing.Recover
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.fusing.RecoverWith
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.fusing.Scan
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.fusing.ScanAsync
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.fusing.Sliding
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.fusing.Split
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.fusing.SubSink
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.fusing.SubSource
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.fusing.Take
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.fusing.TakeWhile
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.io.ByteStringParser
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.io.compression.DeflateDecompressorBase
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.io.compression.GzipDecompressor
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.io.ConnectionSourceStage
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.io.InputStreamSinkStage
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.io.OutgoingConnectionStage
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.io.OutputStreamSourceStage
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.LazySource
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.QueueSink
-
- addAttributes(Attributes) - Static method in class akka.stream.impl.QueueSource
-
- addAttributes(Attributes) - Method in class akka.stream.impl.SubFlowImpl
-
- addAttributes(Attributes) - Method in class akka.stream.javadsl.BidiFlow
-
Add the given attributes to this Source.
- addAttributes(Attributes) - Method in class akka.stream.javadsl.Flow
-
Add the given attributes to this Source.
- addAttributes(Attributes) - Method in class akka.stream.javadsl.RunnableGraph
-
- addAttributes(Attributes) - Method in class akka.stream.javadsl.Sink
-
Add the given attributes to this Sink.
- addAttributes(Attributes) - Method in class akka.stream.javadsl.Source
-
Add the given attributes to this Source.
- addAttributes(Attributes) - Method in class akka.stream.javadsl.SubFlow
-
Add the given attributes to this Source.
- addAttributes(Attributes) - Method in class akka.stream.javadsl.SubSource
-
Add the given attributes to this Source.
- addAttributes(Attributes) - Static method in class akka.stream.scaladsl.Balance
-
- addAttributes(Attributes) - Method in class akka.stream.scaladsl.BidiFlow
-
Add the given attributes to this Source.
- addAttributes(Attributes) - Static method in class akka.stream.scaladsl.Broadcast
-
- addAttributes(Attributes) - Static method in class akka.stream.scaladsl.BroadcastHub
-
- addAttributes(Attributes) - Static method in class akka.stream.scaladsl.Concat
-
- addAttributes(Attributes) - Method in class akka.stream.scaladsl.Flow
-
Add the given attributes to this Flow.
- addAttributes(Attributes) - Method in interface akka.stream.scaladsl.FlowOps
-
- addAttributes(Attributes) - Static method in class akka.stream.scaladsl.Interleave
-
- addAttributes(Attributes) - Static method in class akka.stream.scaladsl.Merge
-
- addAttributes(Attributes) - Static method in class akka.stream.scaladsl.MergeHub
-
- addAttributes(Attributes) - Static method in class akka.stream.scaladsl.MergePreferred
-
- addAttributes(Attributes) - Static method in class akka.stream.scaladsl.OrElse
-
- addAttributes(Attributes) - Static method in class akka.stream.scaladsl.Partition
-
- addAttributes(Attributes) - Method in class akka.stream.scaladsl.RunnableGraph
-
- addAttributes(Attributes) - Method in class akka.stream.scaladsl.Sink
-
Add the given attributes to this Sink.
- addAttributes(Attributes) - Method in class akka.stream.scaladsl.Source
-
Add the given attributes to this Source.
- addAttributes(Attributes) - Static method in class akka.stream.scaladsl.Unzip
-
- addAttributes(Attributes) - Static method in class akka.stream.scaladsl.Zip
-
- addAttributes(Attributes) - Static method in class akka.stream.scaladsl.ZipN
-
- addAttributes(Attributes) - Static method in class akka.stream.scaladsl.ZipWithN
-
- addAttributes(Attributes) - Static method in class akka.stream.testkit.TestSinkStage
-
- addAttributes(Attributes) - Static method in class akka.stream.testkit.TestSourceStage
-
- addBinding(String, A, Cluster) - Method in class akka.cluster.ddata.ORMultiMap
-
Scala API: Add an element to a set associated with a key.
- addBinding(Cluster, String, A) - Method in class akka.cluster.ddata.ORMultiMap
-
Java API: Add an element to a set associated with a key.
- addBinding(UniqueAddress, String, A) - Method in class akka.cluster.ddata.ORMultiMap
-
INTERNAL API
- 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;
- addChild(String, InternalActorRef) - Method in class akka.actor.VirtualPathContainer
-
- addClass(Class<?>) - Static method in class akka.osgi.BundleDelegatingClassLoader
-
- addContactPoints(String) - Method in class akka.cluster.client.protobuf.msg.ClusterClientMessages.Contacts.Builder
-
repeated string contactPoints = 1;
- addContactPointsBytes(ByteString) - Method in class akka.cluster.client.protobuf.msg.ClusterClientMessages.Contacts.Builder
-
repeated string contactPoints = 1;
- 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;
- addDots(ReplicatedDataMessages.VersionVector) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- addDots(int, ReplicatedDataMessages.VersionVector) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- addDots(ReplicatedDataMessages.VersionVector.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- addDots(int, ReplicatedDataMessages.VersionVector.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- addDotsBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- addDotsBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- addEdge(Outlet<T>, Inlet<U>) - Method in class akka.stream.scaladsl.GraphDSL.Builder
-
INTERNAL API
- addedSchemeIdentifier() - Method in class akka.remote.transport.AbstractTransportAdapterHandle
-
- addedSchemeIdentifier() - Static method in class akka.remote.transport.ActorTransportAdapter
-
- addedSchemeIdentifier() - Method in class akka.remote.transport.AkkaProtocolTransport
-
- addedSchemeIdentifier() - Static method in class akka.remote.transport.FailureInjectorHandle
-
- addedSchemeIdentifier() - Method in class akka.remote.transport.FailureInjectorTransportAdapter
-
- addedSchemeIdentifier() - Method in interface akka.remote.transport.SchemeAugmenter
-
- addedSchemeIdentifier() - Static method in class akka.remote.transport.ThrottlerHandle
-
- addedSchemeIdentifier() - Method in class akka.remote.transport.ThrottlerTransportAdapter
-
- addElements(String) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet.Builder
-
repeated string elements = 1;
- addElementsBytes(ByteString) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet.Builder
-
repeated string elements = 1;
- addEntities(String) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState.Builder
-
repeated string entities = 1;
- addEntitiesBytes(ByteString) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState.Builder
-
repeated string entities = 1;
- addEntries(ReplicatedDataMessages.GCounter.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Builder
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- addEntries(int, ReplicatedDataMessages.GCounter.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Builder
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- addEntries(ReplicatedDataMessages.GCounter.Entry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Builder
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- addEntries(int, ReplicatedDataMessages.GCounter.Entry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Builder
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- addEntries(ReplicatedDataMessages.LWWMap.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- addEntries(int, ReplicatedDataMessages.LWWMap.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- addEntries(ReplicatedDataMessages.LWWMap.Entry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- addEntries(int, ReplicatedDataMessages.LWWMap.Entry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- addEntries(ReplicatedDataMessages.ORMap.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- addEntries(int, ReplicatedDataMessages.ORMap.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- addEntries(ReplicatedDataMessages.ORMap.Entry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- addEntries(int, ReplicatedDataMessages.ORMap.Entry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- addEntries(ReplicatedDataMessages.ORMultiMap.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- addEntries(int, ReplicatedDataMessages.ORMultiMap.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- addEntries(ReplicatedDataMessages.ORMultiMap.Entry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- addEntries(int, ReplicatedDataMessages.ORMultiMap.Entry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- addEntries(ReplicatedDataMessages.PNCounterMap.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- addEntries(int, ReplicatedDataMessages.PNCounterMap.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- addEntries(ReplicatedDataMessages.PNCounterMap.Entry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- addEntries(int, ReplicatedDataMessages.PNCounterMap.Entry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- addEntries(ReplicatedDataMessages.VersionVector.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Builder
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- addEntries(int, ReplicatedDataMessages.VersionVector.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Builder
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- addEntries(ReplicatedDataMessages.VersionVector.Entry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Builder
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- addEntries(int, ReplicatedDataMessages.VersionVector.Entry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Builder
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- addEntries(ReplicatorMessages.Gossip.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- addEntries(int, ReplicatorMessages.Gossip.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- addEntries(ReplicatorMessages.Gossip.Entry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- addEntries(int, ReplicatorMessages.Gossip.Entry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- addEntries(ReplicatorMessages.Status.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
repeated .akka.cluster.ddata.Status.Entry entries = 3;
- addEntries(int, ReplicatorMessages.Status.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
repeated .akka.cluster.ddata.Status.Entry entries = 3;
- addEntries(ReplicatorMessages.Status.Entry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
repeated .akka.cluster.ddata.Status.Entry entries = 3;
- addEntries(int, ReplicatorMessages.Status.Entry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
repeated .akka.cluster.ddata.Status.Entry entries = 3;
- addEntriesBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Builder
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- addEntriesBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Builder
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- addEntriesBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- addEntriesBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- addEntriesBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- addEntriesBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- addEntriesBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- addEntriesBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- addEntriesBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- addEntriesBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- addEntriesBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Builder
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- addEntriesBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Builder
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- addEntriesBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- addEntriesBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- addEntriesBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
repeated .akka.cluster.ddata.Status.Entry entries = 3;
- addEntriesBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
repeated .akka.cluster.ddata.Status.Entry entries = 3;
- addFilter(EventFilter) - Method in class akka.testkit.TestEventListener
-
- addFunctionRef(Function2<ActorRef, Object, BoxedUnit>) - Static method in class akka.actor.ActorCell
-
- addFunctionRef(Function2<ActorRef, Object, BoxedUnit>) - Method in interface akka.actor.dungeon.Children
-
- addFunctionRef(Function2<ActorRef, Object, BoxedUnit>) - Static method in class akka.routing.RoutedActorCell
-
- addHasManifest(boolean) - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated bool hasManifest = 7;
- addIntElements(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated sint32 intElements = 2 [packed = true];
- addIntElements(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated sint32 intElements = 4 [packed = true];
- 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.
- addKeys(String) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
repeated string keys = 4;
- addKeysBytes(ByteString) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
repeated string keys = 4;
- 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
- addLongElements(long) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated sint64 longElements = 3 [packed = true];
- addLongElements(long) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated sint64 longElements = 5 [packed = true];
- addManifests(String) - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated string manifests = 5;
- addManifestsBytes(ByteString) - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated string manifests = 5;
- 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;
- addModule(StreamLayout.Module, Set<StreamLayout.Module>, Attributes, int, Shape) - Method in class akka.stream.impl.fusing.Fusing.BuildStructuralInfo
-
Add a module to the given group, performing normalization (i.e.
- 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
-
Add an element to the head of the queue, providing the queue node to be used.
- addNode(AbstractNodeQueue.Node<T>) - Static method in class akka.util.SerializedSuspendableExecutionContext
-
- 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;
- addObjectAndEstimateCount(Object, long) - Method in class akka.remote.artery.compress.CountMinSketch
-
Similar to add
, however we reuse the fact that the hask buckets have to be calculated for add
already, and a separate estimateCount
operation would have to calculate them again, so we do it all in one go.
- 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$
-
- addOtherElements(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- addOtherElements(int, ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- addOtherElements(ReplicatorMessages.OtherMessage.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- addOtherElements(int, ReplicatorMessages.OtherMessage.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- addOtherElements(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- addOtherElements(int, ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- addOtherElements(ReplicatorMessages.OtherMessage.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- addOtherElements(int, ReplicatorMessages.OtherMessage.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- addOtherElementsBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- addOtherElementsBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- addOtherElementsBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- addOtherElementsBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- 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;
- addPayload(MessageFormats.PersistentMessage) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
-
repeated .PersistentMessage payload = 1;
- addPayload(int, MessageFormats.PersistentMessage) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
-
repeated .PersistentMessage payload = 1;
- addPayload(MessageFormats.PersistentMessage.Builder) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
-
repeated .PersistentMessage payload = 1;
- addPayload(int, MessageFormats.PersistentMessage.Builder) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
-
repeated .PersistentMessage payload = 1;
- addPayloadBuilder() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
-
repeated .PersistentMessage payload = 1;
- addPayloadBuilder(int) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
-
repeated .PersistentMessage payload = 1;
- addPersistenceIdSubscriber(ActorRef, String) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- addPersistenceIdSubscriber(ActorRef, String) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
-
- addPruning(ReplicatorMessages.DataEnvelope.PruningEntry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- addPruning(int, ReplicatorMessages.DataEnvelope.PruningEntry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- addPruning(ReplicatorMessages.DataEnvelope.PruningEntry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- addPruning(int, ReplicatorMessages.DataEnvelope.PruningEntry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- addPruningBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- addPruningBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- 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
-
- addRegionProxies(String) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string regionProxies = 3;
- addRegionProxiesBytes(ByteString) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string regionProxies = 3;
- addRegions(String) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string regions = 2;
- addRegionsBytes(ByteString) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string regions = 2;
- addRemovals(String) - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet.Builder
-
repeated string removals = 2;
- addRemovalsBytes(ByteString) - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet.Builder
-
repeated string removals = 2;
- addRemoved(UniqueAddress) - Method in class akka.cluster.singleton.ClusterSingletonManager
-
- address() - Method in interface akka.actor.ActorPath
-
The Address under which this path can be reached; walks up the tree to
the RootActorPath.
- Address - Class in akka.actor
-
The address specifies the physical location under which an Actor can be
reached.
- Address(String, String) - Constructor for class akka.actor.Address
-
- Address(String, String, String, int) - Constructor for class akka.actor.Address
-
- address() - Method in class akka.actor.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
-
- 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
-
Deprecated.
- address() - Method in class akka.cluster.StandardMetrics.Cpu
-
Deprecated.
- address() - Method in class akka.cluster.StandardMetrics.HeapMemory
-
Deprecated.
- address() - Method in class akka.cluster.UniqueAddress
-
- address() - Method in class akka.persistence.journal.PersistencePluginProxy.TargetLocation
-
- 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.remote.UniqueAddress
-
- 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.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress
-
- 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.ArteryControlFormats.MessageWithAddress
-
- ADDRESS_FIELD_NUMBER - Static variable in class akka.remote.ArteryControlFormats.UniqueAddress
-
- 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.artery.ArteryTransport
-
- 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
-
- addressForWriter(ActorRef) - Method in class akka.remote.EndpointManager.EndpointRegistry
-
- addressFromProto(ReplicatorMessages.Address) - Static method in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer
-
- addressFromProto(ReplicatorMessages.Address) - Method in interface akka.cluster.ddata.protobuf.SerializationSupport
-
- 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.actor.Address$
-
Address
ordering type class, sorts addresses by protocol, name, host and port.
- addressOrdering() - Static method in class akka.actor.Address
-
Address
ordering type class, sorts addresses by protocol, name, host and port.
- 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.
- addressProtocol() - Static method in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer
-
- addressProtocol() - Method in interface akka.cluster.ddata.protobuf.SerializationSupport
-
- 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(Address) - Static method in class akka.actor.ActorCell
-
- 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(Address) - Static method in class akka.routing.RoutedActorCell
-
- addressTerminated(Address) - Static method in class akka.typed.internal.ActorCell
-
- addressTerminated(Address) - Method in interface akka.typed.internal.DeathWatch
-
- AddressTerminated$ - Class in akka.actor
-
- AddressTerminated$() - Constructor for class akka.actor.AddressTerminated$
-
- ADDRESSTERMINATED_FIELD_NUMBER - Static variable in class akka.remote.SystemMessageFormats.DeathWatchNotificationData
-
- 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$
-
- addressToProto(Address) - Static method in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer
-
- addressToProto(Address) - Method in interface akka.cluster.ddata.protobuf.SerializationSupport
-
- 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 Long
or Int
depending
on which version of remoting that is used.
- AddressUidExtension$() - Constructor for class akka.remote.AddressUidExtension$
-
- addressUids() - Static method in class akka.cluster.ClusterRemoteWatcher
-
- addressUids() - Method in class akka.remote.RemoteWatcher
-
- addressUids_$eq(Map<Address, Object>) - Static method in class akka.cluster.ClusterRemoteWatcher
-
- 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
.
- ADDS_FIELD_NUMBER - Static variable in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet
-
- ADDS_FIELD_NUMBER - Static variable in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2
-
- addSeen(ReplicatorMessages.Address) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
repeated .akka.cluster.ddata.Address seen = 4;
- addSeen(int, ReplicatorMessages.Address) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
repeated .akka.cluster.ddata.Address seen = 4;
- addSeen(ReplicatorMessages.Address.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
repeated .akka.cluster.ddata.Address seen = 4;
- addSeen(int, ReplicatorMessages.Address.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
repeated .akka.cluster.ddata.Address seen = 4;
- addSeen(Address) - Method in class akka.cluster.ddata.PruningState
-
- addSeen(Address) - Method in class akka.cluster.ddata.Replicator.Internal$.DataEnvelope
-
- addSeen(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated int32 seen = 1;
- addSeenBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
repeated .akka.cluster.ddata.Address seen = 4;
- addSeenBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
repeated .akka.cluster.ddata.Address seen = 4;
- addSelf(String) - Static method in class akka.contrib.pattern.ReliableProxy
-
- addSelf(String) - Method in interface akka.contrib.pattern.ReliableProxyDebugLogging
-
- addSerializerIds(int) - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated int32 serializerIds = 6;
- addShards(ClusterShardingMessages.CoordinatorState.ShardEntry) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated .CoordinatorState.ShardEntry shards = 1;
- addShards(int, ClusterShardingMessages.CoordinatorState.ShardEntry) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated .CoordinatorState.ShardEntry shards = 1;
- addShards(ClusterShardingMessages.CoordinatorState.ShardEntry.Builder) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated .CoordinatorState.ShardEntry shards = 1;
- addShards(int, ClusterShardingMessages.CoordinatorState.ShardEntry.Builder) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated .CoordinatorState.ShardEntry shards = 1;
- addShardsBuilder() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated .CoordinatorState.ShardEntry shards = 1;
- addShardsBuilder(int) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated .CoordinatorState.ShardEntry shards = 1;
- addStackTrace(ContainerFormats.StackTraceElement) - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
repeated .StackTraceElement stackTrace = 4;
- addStackTrace(int, ContainerFormats.StackTraceElement) - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
repeated .StackTraceElement stackTrace = 4;
- addStackTrace(ContainerFormats.StackTraceElement.Builder) - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
repeated .StackTraceElement stackTrace = 4;
- addStackTrace(int, ContainerFormats.StackTraceElement.Builder) - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
repeated .StackTraceElement stackTrace = 4;
- addStackTraceBuilder() - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
repeated .StackTraceElement stackTrace = 4;
- addStackTraceBuilder(int) - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
repeated .StackTraceElement stackTrace = 4;
- addString(StringBuilder, String, String, String) - Static method in class akka.util.ByteIterator
-
- addString(StringBuilder, String) - Static method in class akka.util.ByteIterator
-
- addString(StringBuilder) - Static method in class akka.util.ByteIterator
-
- addString(StringBuilder, String, String, String) - Static method in class akka.util.ByteString
-
- addString(StringBuilder, String) - Static method in class akka.util.ByteString
-
- addString(StringBuilder) - Static method in class akka.util.ByteString
-
- addString(StringBuilder, String, String, String) - Static method in class akka.util.CompactByteString
-
- addString(StringBuilder, String) - Static method in class akka.util.CompactByteString
-
- addString(StringBuilder) - Static method in class akka.util.CompactByteString
-
- addStringElements(String) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated string stringElements = 1;
- addStringElements(String) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated string stringElements = 3;
- addStringElementsBytes(ByteString) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated string stringElements = 1;
- addStringElementsBytes(ByteString) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated string stringElements = 3;
- 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;
- addSubscription(Subscriber<? super T>) - Method in interface akka.stream.impl.SubscriberManagement
-
- addSuppressed(Throwable) - Static method in exception akka.actor.ActorInitializationException
-
- addSuppressed(Throwable) - Static method in exception akka.actor.ActorKilledException
-
- addSuppressed(Throwable) - Static method in exception akka.actor.ActorNotFound
-
- addSuppressed(Throwable) - Static method in exception akka.actor.DeathPactException
-
- addSuppressed(Throwable) - Static method in exception akka.actor.IllegalActorStateException
-
- addSuppressed(Throwable) - Static method in exception akka.actor.InvalidActorNameException
-
- addSuppressed(Throwable) - Static method in exception akka.actor.InvalidMessageException
-
- addSuppressed(Throwable) - Static method in exception akka.actor.PostRestartException
-
- addSuppressed(Throwable) - Static method in exception akka.actor.PreRestartException
-
- addSuppressed(Throwable) - Static method in exception akka.actor.SchedulerException
-
- addSuppressed(Throwable) - Static method in exception akka.actor.StashOverflowException
-
- addSuppressed(Throwable) - Static method in exception akka.contrib.circuitbreaker.OpenCircuitException
-
- addSuppressed(Throwable) - Static method in exception akka.pattern.CircuitBreakerOpenException
-
- addSuppressed(Throwable) - Static method in exception akka.remote.HopelessAssociation
-
- addSuppressed(Throwable) - Static method in exception akka.remote.InvalidAssociation
-
- addSuppressed(Throwable) - Static method in exception akka.remote.ShutDownAssociation
-
- addSuppressed(Throwable) - Static method in exception akka.remote.transport.FailureInjectorException
-
- addSuppressed(Throwable) - Static method in exception akka.stream.AbruptTerminationException
-
- addSuppressed(Throwable) - Static method in exception akka.stream.BindFailedException
-
- addSuppressed(Throwable) - Static method in exception akka.stream.BufferOverflowException
-
- addSuppressed(Throwable) - Static method in exception akka.stream.MaterializationException
-
- addSuppressed(Throwable) - Static method in exception akka.typed.DeathPactException
-
- addTagSubscriber(ActorRef, String) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- addTagSubscriber(ActorRef, String) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
-
- addToCache(Seq<Tuple2<Object, Set<Object>>>) - Method in interface akka.event.SubchannelClassification
-
- addToMessageBatch(PersistentRepr, Set<String>, WriteBatch) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
-
- addUnallocatedShards(String) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string unallocatedShards = 4;
- addUnallocatedShardsBytes(ByteString) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string unallocatedShards = 4;
- 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.
- addValues(int) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
repeated uint32 values = 5;
- 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) - Static method in class akka.cluster.ClusterRemoteWatcher
-
- addWatch(InternalActorRef, InternalActorRef) - Method in class akka.remote.RemoteWatcher
-
- AddWatch$() - Constructor for class akka.camel.internal.CamelSupervisor.AddWatch$
-
- addWatcher(ActorRef, ActorRef) - Static method in class akka.actor.ActorCell
-
- addWatcher(ActorRef, ActorRef) - Method in interface akka.actor.dungeon.DeathWatch
-
- addWatcher(ActorRef, ActorRef) - Static method in class akka.routing.RoutedActorCell
-
- addWatcher(ActorRefImpl<Nothing$>, ActorRefImpl<Nothing$>) - Static method in class akka.typed.internal.ActorCell
-
- addWatcher(ActorRefImpl<Nothing$>, ActorRefImpl<Nothing$>) - Method in interface akka.typed.internal.DeathWatch
-
- addWatcher(ActorRefImpl<Nothing$>) - Static method in class akka.typed.internal.FutureRef
-
- addWatcher(ActorRefImpl<Nothing$>, ActorRefImpl<Nothing$>) - Method in interface akka.typed.internal.SupervisionMechanics
-
- addWatcher(ActorRefImpl<Nothing$>) - Method in class akka.typed.internal.WatchableRef
-
- 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
-
- advance() - Method in interface akka.persistence.fsm.LoggingPersistentFSM
-
- Advanced() - Method in class akka.remote.artery.ArterySettings
-
Accessor for nested Scala object
- Advanced$() - Constructor for class akka.remote.artery.ArterySettings.Advanced$
-
- advertiseCompressionTable(OutboundContext, CompressionTable<ActorRef>) - Method in class akka.remote.artery.compress.InboundActorRefCompression
-
- advertiseCompressionTable(OutboundContext, CompressionTable<T>) - Method in class akka.remote.artery.compress.InboundCompression
-
Must be implemented by extending classes in order to send a ControlMessage
of appropriate type to the remote system in order to advertise the compression table to it.
- advertiseCompressionTable(OutboundContext, CompressionTable<String>) - Method in class akka.remote.artery.compress.InboundManifestCompression
-
- advertisementInProgress() - Method in class akka.remote.artery.compress.InboundCompression.State
-
- AdvertisementInterval() - Method in class akka.remote.artery.ArterySettings.Compression.ActorRefs$
-
- AdvertisementInterval() - Method in class akka.remote.artery.ArterySettings.Compression.Manifests$
-
- aeronBuffer() - Method in class akka.remote.artery.EnvelopeBuffer
-
- AeronDirectoryName() - Method in class akka.remote.artery.ArterySettings.Advanced$
-
- AeronErrorLog - Class in akka.remote.artery
-
Application to print out errors recorded in the command-and-control (cnc) file is maintained by media driver in shared
memory.
- AeronErrorLog(File) - Constructor for class akka.remote.artery.AeronErrorLog
-
- AeronSink - Class in akka.remote.artery
-
INTERNAL API
param: channel eg.
- AeronSink(String, int, Aeron, TaskRunner, EnvelopeBufferPool, Duration, EventSink) - Constructor for class akka.remote.artery.AeronSink
-
- aeronSink(OutboundContext) - Method in class akka.remote.artery.ArteryTransport
-
- AeronSink$ - Class in akka.remote.artery
-
INTERNAL API
- AeronSink$() - Constructor for class akka.remote.artery.AeronSink$
-
- AeronSink.GaveUpMessageException - Exception in akka.remote.artery
-
- AeronSink.PublicationClosedException - Exception in akka.remote.artery
-
- AeronSink_DelegateToTaskRunner() - Method in class akka.remote.artery.FlightRecorderEvents$
-
- AeronSink_DelegateToTaskRunner() - Static method in class akka.remote.artery.FlightRecorderEvents
-
- AeronSink_EnvelopeGrabbed() - Method in class akka.remote.artery.FlightRecorderEvents$
-
- AeronSink_EnvelopeGrabbed() - Static method in class akka.remote.artery.FlightRecorderEvents
-
- AeronSink_EnvelopeOffered() - Method in class akka.remote.artery.FlightRecorderEvents$
-
- AeronSink_EnvelopeOffered() - Static method in class akka.remote.artery.FlightRecorderEvents
-
- AeronSink_GaveUpEnvelope() - Method in class akka.remote.artery.FlightRecorderEvents$
-
- AeronSink_GaveUpEnvelope() - Static method in class akka.remote.artery.FlightRecorderEvents
-
- AeronSink_PublicationClosed() - Method in class akka.remote.artery.FlightRecorderEvents$
-
- AeronSink_PublicationClosed() - Static method in class akka.remote.artery.FlightRecorderEvents
-
- AeronSink_ReturnFromTaskRunner() - Method in class akka.remote.artery.FlightRecorderEvents$
-
- AeronSink_ReturnFromTaskRunner() - Static method in class akka.remote.artery.FlightRecorderEvents
-
- AeronSink_Started() - Method in class akka.remote.artery.FlightRecorderEvents$
-
- AeronSink_Started() - Static method in class akka.remote.artery.FlightRecorderEvents
-
- AeronSink_Stopped() - Method in class akka.remote.artery.FlightRecorderEvents$
-
- AeronSink_Stopped() - Static method in class akka.remote.artery.FlightRecorderEvents
-
- AeronSink_TaskRunnerRemoved() - Method in class akka.remote.artery.FlightRecorderEvents$
-
- AeronSink_TaskRunnerRemoved() - Static method in class akka.remote.artery.FlightRecorderEvents
-
- AeronSource - Class in akka.remote.artery
-
INTERNAL API
param: channel eg.
- AeronSource(String, int, Aeron, TaskRunner, EnvelopeBufferPool, EventSink, int) - Constructor for class akka.remote.artery.AeronSource
-
- aeronSource(int, EnvelopeBufferPool) - Method in class akka.remote.artery.ArteryTransport
-
- AeronSource$ - Class in akka.remote.artery
-
INTERNAL API
- AeronSource$() - Constructor for class akka.remote.artery.AeronSource$
-
- AeronSource.Fragments - Class in akka.remote.artery
-
- AeronSource.MessageHandler - Class in akka.remote.artery
-
- AeronSource.ResourceLifecycle - Interface in akka.remote.artery
-
- AeronSource_DelegateToTaskRunner() - Method in class akka.remote.artery.FlightRecorderEvents$
-
- AeronSource_DelegateToTaskRunner() - Static method in class akka.remote.artery.FlightRecorderEvents
-
- AeronSource_Received() - Method in class akka.remote.artery.FlightRecorderEvents$
-
- AeronSource_Received() - Static method in class akka.remote.artery.FlightRecorderEvents
-
- AeronSource_ReturnFromTaskRunner() - Method in class akka.remote.artery.FlightRecorderEvents$
-
- AeronSource_ReturnFromTaskRunner() - Static method in class akka.remote.artery.FlightRecorderEvents
-
- AeronSource_Started() - Method in class akka.remote.artery.FlightRecorderEvents$
-
- AeronSource_Started() - Static method in class akka.remote.artery.FlightRecorderEvents
-
- AeronSource_Stopped() - Method in class akka.remote.artery.FlightRecorderEvents$
-
- AeronSource_Stopped() - Static method in class akka.remote.artery.FlightRecorderEvents
-
- aeronSourceLifecycle() - Method in class akka.remote.artery.ArteryTransport.InboundStreamMatValues
-
- AeronTerminated(Throwable) - Constructor for exception akka.remote.artery.ArteryTransport.AeronTerminated
-
- AES128CounterInetRNG - Class in akka.remote.security.provider
-
- AES128CounterInetRNG() - Constructor for class akka.remote.security.provider.AES128CounterInetRNG
-
Deprecated.
- 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
-
- AES256CounterInetRNG() - Constructor for class akka.remote.security.provider.AES256CounterInetRNG
-
Deprecated.
- 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
-
- afrFile() - Method in class akka.remote.artery.ArteryTransport
-
- afrFileChannel() - Method in class akka.remote.artery.ArteryTransport
-
- after() - Method in class akka.contrib.pattern.ReceivePipeline.InnerAndAfter
-
- 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 Callable
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 Callable
after the specified duration.
- after(FiniteDuration, Scheduler, ExecutionContext, Callable<CompletionStage<T>>) - Method in class akka.pattern.PatternsCS$
-
Returns a CompletionStage
that will be completed with the success or failure of the provided Callable
after the specified duration.
- after(FiniteDuration, Scheduler, ExecutionContext, CompletionStage<T>) - Method in class akka.pattern.PatternsCS$
-
Returns a CompletionStage
that will be completed with the success or failure of the provided value
after the specified duration.
- after(FiniteDuration, Scheduler, ExecutionContext, Callable<CompletionStage<T>>) - Static method in class akka.pattern.PatternsCS
-
Returns a CompletionStage
that will be completed with the success or failure of the provided Callable
after the specified duration.
- after(FiniteDuration, Scheduler, ExecutionContext, CompletionStage<T>) - Static method in class akka.pattern.PatternsCS
-
Returns a CompletionStage
that will be completed with the success or failure of the provided value
after the specified duration.
- after() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- after() - Static method in class akka.persistence.journal.JournalSpec
-
- after() - Method in class akka.persistence.PluginSpec
-
- after() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- after(Function1<T, Object>, SubstreamCancelStrategy) - Method in class akka.stream.impl.fusing.Split$
-
- after(Function1<T, Object>, SubstreamCancelStrategy) - Static method in class akka.stream.impl.fusing.Split
-
- After$() - Constructor for class akka.cluster.ddata.VersionVector.After$
-
- After$() - Constructor for class akka.cluster.VectorClock.After$
-
- afterAll() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- afterAll() - Static method in class akka.persistence.journal.JournalSpec
-
- afterAll() - Method in class akka.persistence.PluginSpec
-
- afterAll() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- 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.
- afterBytesRead(byte[], int, int) - Method in class akka.stream.impl.io.compression.DeflateDecompressorBase.DecompressorParsingLogic
-
- afterCompletionStage(FiniteDuration, Scheduler, Function0<CompletionStage<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.
- 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
-
- afterEach() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- afterEach() - Static method in class akka.persistence.journal.JournalSpec
-
- afterEach() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- afterFlush() - Method in class akka.stream.impl.FanoutProcessorImpl
-
- afterInflate() - Method in class akka.stream.impl.io.compression.DeflateDecompressorBase.DecompressorParsingLogic
-
- AfterInstance() - Method in class akka.cluster.ddata.VersionVector$
-
Java API: The VersionVector.After
instance
- AfterInstance() - Static method in class akka.cluster.ddata.VersionVector
-
Java API: The VersionVector.After
instance
- afterPostStop() - Method in class akka.stream.stage.GraphStageLogic
-
INTERNAL API
- afterPostStop() - Method in class akka.stream.stage.TimerGraphStageLogic
-
- afterShutdown() - Method in class akka.stream.impl.FanoutOutputs
-
- afterStageHasRun(GraphStageLogic) - Method in class akka.stream.impl.fusing.GraphInterpreter
-
- afterTermination() - Method in class akka.remote.testkit.MultiNodeSpec
-
Override this method to do something when the whole test is terminating.
- afterTransitionDo() - Method in class akka.persistence.fsm.PersistentFSM.State
-
- afterWord(String) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- afterWord(String) - Static method in class akka.persistence.journal.JournalSpec
-
- afterWord(String) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- 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.Member$
-
Sort members by age, i.e.
- ageOrdering() - Static method in class akka.cluster.Member
-
Sort members by age, i.e.
- ageOrdering() - Method in class akka.cluster.sharding.ShardRegion
-
- ageOrdering() - Method in class akka.cluster.singleton.ClusterSingletonProxy
-
- aggregate() - Method in class akka.stream.impl.fusing.Batch
-
- aggregate(Function0<B>, Function2<B, A, B>, Function2<B, B, B>) - Static method in class akka.util.ByteIterator
-
- aggregate(Function0<B>, Function2<B, A, B>, Function2<B, B, B>) - Static method in class akka.util.ByteString
-
- aggregate(Function0<B>, Function2<B, A, B>, Function2<B, B, B>) - Static method in class akka.util.CompactByteString
-
- Aggregator - Interface in akka.contrib.pattern
-
The aggregator is to be mixed into an actor for the aggregator behavior.
- aggressive(Graph<S, M>) - Method in class akka.stream.Fusing$
-
Fuse all operations where this is technically possible (i.e.
- aggressive(Graph<S, M>) - Static method in class akka.stream.Fusing
-
Fuse all operations where this is technically possible (i.e.
- aggressive(Graph<S, M>) - Method in class akka.stream.impl.fusing.Fusing$
-
Fuse everything that is not forbidden via AsyncBoundary attribute.
- aggressive(Graph<S, M>) - Static method in class akka.stream.impl.fusing.Fusing
-
Fuse everything that is not forbidden via AsyncBoundary attribute.
- akka - package akka
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.actor.AbstractActor
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.actor.AbstractFSM
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.camel.internal.CamelSupervisor
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.cluster.AutoDown
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.cluster.client.ClusterClient
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.cluster.client.ClusterReceptionist
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.cluster.ClusterHeartbeatSender
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.cluster.ClusterRemoteWatcher
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.cluster.ddata.LmdbDurableStore
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.cluster.ddata.ReadAggregator
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.cluster.ddata.ReadWriteAggregator
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.cluster.ddata.Replicator
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.cluster.ddata.WriteAggregator
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.cluster.sharding.ClusterShardingGuardian
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.cluster.sharding.RemoveInternalClusterShardingData
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.cluster.sharding.Shard
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.cluster.sharding.ShardCoordinator
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.cluster.sharding.ShardRegion
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.cluster.singleton.ClusterSingletonProxy
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.event.ActorClassificationUnsubscriber
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.event.EventStreamUnsubscriber
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.io.SelectionHandler
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.io.SimpleDnsManager
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.io.TcpConnection
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.io.TcpListener
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.io.TcpOutgoingConnection
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.pattern.BackoffSupervisor
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.persistence.journal.PersistencePluginProxy
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.persistence.journal.ReplayFilter
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.persistence.RecoveryPermitter
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.remote.artery.FlushOnShutdown
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.remote.EndpointManager
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.remote.EndpointReader
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.remote.EndpointWriter
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.remote.ReliableDeliverySupervisor
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.remote.RemoteDeploymentWatcher
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.remote.RemoteWatcher
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.remote.testconductor.Controller
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.remote.transport.ThrottlerManager
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.routing.ResizablePoolActor
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.stream.actor.AbstractActorPublisher
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.stream.actor.AbstractActorSubscriber
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.stream.actor.UntypedActorPublisher
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.stream.actor.UntypedActorSubscriber
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.stream.impl.ActorRefSinkActor
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.stream.impl.ActorRefSourceActor
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.stream.impl.FanIn
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.stream.impl.FanOut
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.stream.impl.FanoutProcessorImpl
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.stream.impl.fusing.ActorGraphInterpreter
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.stream.impl.io.FilePublisher
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.stream.impl.io.FileSubscriber
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.stream.impl.io.InputStreamPublisher
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.stream.impl.io.OutputStreamSubscriber
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.stream.impl.io.TLSActor
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.stream.impl.StreamSupervisor
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.stream.impl.Unzip
-
- akka$actor$Actor$_setter_$context_$eq(ActorContext) - Static method in class akka.testkit.TestActor
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.actor.AbstractActor
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.actor.AbstractFSM
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.camel.internal.CamelSupervisor
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.cluster.AutoDown
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.cluster.client.ClusterClient
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.cluster.client.ClusterReceptionist
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.cluster.ClusterHeartbeatSender
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.cluster.ClusterRemoteWatcher
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.cluster.ddata.LmdbDurableStore
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.cluster.ddata.ReadAggregator
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.cluster.ddata.ReadWriteAggregator
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.cluster.ddata.Replicator
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.cluster.ddata.WriteAggregator
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.cluster.sharding.ClusterShardingGuardian
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.cluster.sharding.RemoveInternalClusterShardingData
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.cluster.sharding.Shard
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.cluster.sharding.ShardCoordinator
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.cluster.sharding.ShardRegion
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.cluster.singleton.ClusterSingletonProxy
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.event.ActorClassificationUnsubscriber
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.event.EventStreamUnsubscriber
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.io.SelectionHandler
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.io.SimpleDnsManager
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.io.TcpConnection
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.io.TcpListener
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.io.TcpOutgoingConnection
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.pattern.BackoffSupervisor
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.persistence.journal.PersistencePluginProxy
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.persistence.journal.ReplayFilter
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.persistence.RecoveryPermitter
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.remote.artery.FlushOnShutdown
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.remote.EndpointManager
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.remote.EndpointReader
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.remote.EndpointWriter
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.remote.ReliableDeliverySupervisor
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.remote.RemoteDeploymentWatcher
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.remote.RemoteWatcher
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.remote.testconductor.Controller
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.remote.transport.ThrottlerManager
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.routing.ResizablePoolActor
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.stream.actor.AbstractActorPublisher
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.stream.actor.AbstractActorSubscriber
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.stream.actor.UntypedActorPublisher
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.stream.actor.UntypedActorSubscriber
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.stream.impl.ActorRefSinkActor
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.stream.impl.ActorRefSourceActor
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.stream.impl.FanIn
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.stream.impl.FanOut
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.stream.impl.FanoutProcessorImpl
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.stream.impl.fusing.ActorGraphInterpreter
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.stream.impl.io.FilePublisher
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.stream.impl.io.FileSubscriber
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.stream.impl.io.InputStreamPublisher
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.stream.impl.io.OutputStreamSubscriber
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.stream.impl.io.TLSActor
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.stream.impl.StreamSupervisor
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.stream.impl.Unzip
-
- akka$actor$Actor$_setter_$self_$eq(ActorRef) - Static method in class akka.testkit.TestActor
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.actor.AbstractFSM
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.cluster.AutoDown
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.cluster.client.ClusterClient
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.cluster.client.ClusterReceptionist
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.cluster.ClusterHeartbeatSender
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.cluster.ClusterRemoteWatcher
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.cluster.ddata.LmdbDurableStore
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.cluster.ddata.Replicator
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.cluster.sharding.RemoveInternalClusterShardingData
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.cluster.sharding.Shard
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.cluster.sharding.ShardCoordinator
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.cluster.sharding.ShardRegion
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.cluster.singleton.ClusterSingletonProxy
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.io.SelectionHandler
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.io.SimpleDnsManager
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.io.TcpConnection
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.io.TcpListener
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.io.TcpOutgoingConnection
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.persistence.journal.PersistencePluginProxy
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.persistence.journal.ReplayFilter
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.persistence.RecoveryPermitter
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.remote.EndpointReader
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.remote.EndpointWriter
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.remote.ReliableDeliverySupervisor
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.remote.RemoteWatcher
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.remote.transport.ThrottlerManager
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.stream.impl.ActorRefSourceActor
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.stream.impl.FanIn
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.stream.impl.FanOut
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.stream.impl.FanoutProcessorImpl
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.stream.impl.fusing.ActorGraphInterpreter
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.stream.impl.io.FilePublisher
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.stream.impl.io.FileSubscriber
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.stream.impl.io.InputStreamPublisher
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.stream.impl.io.OutputStreamSubscriber
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.stream.impl.io.TLSActor
-
- akka$actor$ActorLogging$$_log() - Static method in class akka.stream.impl.Unzip
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.actor.AbstractFSM
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.cluster.AutoDown
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.cluster.client.ClusterClient
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.cluster.client.ClusterReceptionist
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.cluster.ClusterHeartbeatSender
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.cluster.ClusterRemoteWatcher
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.cluster.ddata.LmdbDurableStore
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.cluster.ddata.Replicator
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.cluster.sharding.RemoveInternalClusterShardingData
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.cluster.sharding.Shard
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.cluster.sharding.ShardCoordinator
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.cluster.sharding.ShardRegion
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.cluster.singleton.ClusterSingletonProxy
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.io.SelectionHandler
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.io.SimpleDnsManager
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.io.TcpConnection
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.io.TcpListener
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.io.TcpOutgoingConnection
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.persistence.journal.PersistencePluginProxy
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.persistence.journal.ReplayFilter
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.persistence.RecoveryPermitter
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.remote.EndpointReader
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.remote.EndpointWriter
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.remote.ReliableDeliverySupervisor
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.remote.RemoteWatcher
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.remote.transport.ThrottlerManager
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.stream.impl.ActorRefSourceActor
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.stream.impl.FanIn
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.stream.impl.FanOut
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.stream.impl.FanoutProcessorImpl
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.stream.impl.fusing.ActorGraphInterpreter
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.stream.impl.io.FilePublisher
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.stream.impl.io.FileSubscriber
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.stream.impl.io.InputStreamPublisher
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.stream.impl.io.OutputStreamSubscriber
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.stream.impl.io.TLSActor
-
- akka$actor$ActorLogging$$_log_$eq(LoggingAdapter) - Static method in class akka.stream.impl.Unzip
-
- akka$actor$dsl$Inbox$$deadlineOrder() - Static method in class akka.actor.ActorDSL
-
- akka$actor$dsl$Inbox$$extraTime() - Static method in class akka.actor.ActorDSL
-
- akka$actor$dsl$Inbox$_setter_$akka$actor$dsl$Inbox$$deadlineOrder_$eq(Ordering<Inbox.Query>) - Static method in class akka.actor.ActorDSL
-
- akka$actor$dsl$Inbox$_setter_$akka$actor$dsl$Inbox$$extraTime_$eq(FiniteDuration) - Static method in class akka.actor.ActorDSL
-
- akka$actor$dungeon$Children$$_childrenRefsDoNotCallMeDirectly() - Static method in class akka.actor.ActorCell
-
- akka$actor$dungeon$Children$$_childrenRefsDoNotCallMeDirectly() - Static method in class akka.routing.RoutedActorCell
-
- akka$actor$dungeon$Children$$_childrenRefsDoNotCallMeDirectly_$eq(ChildrenContainer) - Static method in class akka.actor.ActorCell
-
- akka$actor$dungeon$Children$$_childrenRefsDoNotCallMeDirectly_$eq(ChildrenContainer) - Static method in class akka.routing.RoutedActorCell
-
- akka$actor$dungeon$Children$$_functionRefsDoNotCallMeDirectly() - Static method in class akka.actor.ActorCell
-
- akka$actor$dungeon$Children$$_functionRefsDoNotCallMeDirectly() - Static method in class akka.routing.RoutedActorCell
-
- akka$actor$dungeon$Children$$_functionRefsDoNotCallMeDirectly_$eq(Map<String, FunctionRef>) - Static method in class akka.actor.ActorCell
-
- akka$actor$dungeon$Children$$_functionRefsDoNotCallMeDirectly_$eq(Map<String, FunctionRef>) - Static method in class akka.routing.RoutedActorCell
-
- akka$actor$dungeon$Children$$_nextNameDoNotCallMeDirectly() - Static method in class akka.actor.ActorCell
-
- akka$actor$dungeon$Children$$_nextNameDoNotCallMeDirectly() - Static method in class akka.routing.RoutedActorCell
-
- akka$actor$dungeon$Children$$_nextNameDoNotCallMeDirectly_$eq(long) - Static method in class akka.actor.ActorCell
-
- akka$actor$dungeon$Children$$_nextNameDoNotCallMeDirectly_$eq(long) - Static method in class akka.routing.RoutedActorCell
-
- akka$actor$dungeon$DeathWatch$$terminatedQueued() - Static method in class akka.actor.ActorCell
-
- akka$actor$dungeon$DeathWatch$$terminatedQueued() - Static method in class akka.routing.RoutedActorCell
-
- akka$actor$dungeon$DeathWatch$$terminatedQueued_$eq(Set<ActorRef>) - Static method in class akka.actor.ActorCell
-
- akka$actor$dungeon$DeathWatch$$terminatedQueued_$eq(Set<ActorRef>) - Static method in class akka.routing.RoutedActorCell
-
- akka$actor$dungeon$DeathWatch$$watchedBy() - Static method in class akka.actor.ActorCell
-
- akka$actor$dungeon$DeathWatch$$watchedBy() - Static method in class akka.routing.RoutedActorCell
-
- akka$actor$dungeon$DeathWatch$$watchedBy_$eq(Set<ActorRef>) - Static method in class akka.actor.ActorCell
-
- akka$actor$dungeon$DeathWatch$$watchedBy_$eq(Set<ActorRef>) - Static method in class akka.routing.RoutedActorCell
-
- akka$actor$dungeon$DeathWatch$$watching() - Static method in class akka.actor.ActorCell
-
- akka$actor$dungeon$DeathWatch$$watching() - Static method in class akka.routing.RoutedActorCell
-
- akka$actor$dungeon$DeathWatch$$watching_$eq(Set<ActorRef>) - Static method in class akka.actor.ActorCell
-
- akka$actor$dungeon$DeathWatch$$watching_$eq(Set<ActorRef>) - Static method in class akka.routing.RoutedActorCell
-
- akka$actor$dungeon$Dispatch$$_mailboxDoNotCallMeDirectly() - Static method in class akka.actor.ActorCell
-
- akka$actor$dungeon$Dispatch$$_mailboxDoNotCallMeDirectly() - Static method in class akka.routing.RoutedActorCell
-
- akka$actor$dungeon$Dispatch$$_mailboxDoNotCallMeDirectly_$eq(Mailbox) - Static method in class akka.actor.ActorCell
-
- akka$actor$dungeon$Dispatch$$_mailboxDoNotCallMeDirectly_$eq(Mailbox) - Static method in class akka.routing.RoutedActorCell
-
- akka$actor$dungeon$FaultHandling$$_failed() - Static method in class akka.actor.ActorCell
-
- akka$actor$dungeon$FaultHandling$$_failed() - Static method in class akka.routing.RoutedActorCell
-
- akka$actor$dungeon$FaultHandling$$_failed_$eq(ActorRef) - Static method in class akka.actor.ActorCell
-
- akka$actor$dungeon$FaultHandling$$_failed_$eq(ActorRef) - Static method in class akka.routing.RoutedActorCell
-
- akka$actor$dungeon$ReceiveTimeout$$receiveTimeoutData() - Static method in class akka.actor.ActorCell
-
- akka$actor$dungeon$ReceiveTimeout$$receiveTimeoutData() - Static method in class akka.routing.RoutedActorCell
-
- akka$actor$dungeon$ReceiveTimeout$$receiveTimeoutData_$eq(Tuple2<Duration, Cancellable>) - Static method in class akka.actor.ActorCell
-
- akka$actor$dungeon$ReceiveTimeout$$receiveTimeoutData_$eq(Tuple2<Duration, Cancellable>) - Static method in class akka.routing.RoutedActorCell
-
- akka$actor$FSM$$currentState() - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$$currentState() - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$$currentState() - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$$currentState() - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$$currentState() - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$$currentState() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$$currentState() - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$$currentState() - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$$currentState() - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$$currentState() - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$$currentState_$eq(FSM.State<S, D>) - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$$currentState_$eq(FSM.State<S, D>) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$$currentState_$eq(FSM.State<S, D>) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$$currentState_$eq(FSM.State<S, D>) - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$$currentState_$eq(FSM.State<S, D>) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$$currentState_$eq(FSM.State<S, D>) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$$currentState_$eq(FSM.State<S, D>) - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$$currentState_$eq(FSM.State<S, D>) - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$$currentState_$eq(FSM.State<S, D>) - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$$currentState_$eq(FSM.State<S, D>) - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$$generation() - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$$generation() - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$$generation() - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$$generation() - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$$generation() - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$$generation() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$$generation() - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$$generation() - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$$generation() - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$$generation() - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$$generation_$eq(long) - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$$generation_$eq(long) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$$generation_$eq(long) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$$generation_$eq(long) - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$$generation_$eq(long) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$$generation_$eq(long) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$$generation_$eq(long) - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$$generation_$eq(long) - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$$generation_$eq(long) - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$$generation_$eq(long) - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$$handleEvent() - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$$handleEvent() - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$$handleEvent() - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$$handleEvent() - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$$handleEvent() - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$$handleEvent() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$$handleEvent() - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$$handleEvent() - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$$handleEvent() - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$$handleEvent() - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$$handleEvent_$eq(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$$handleEvent_$eq(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$$handleEvent_$eq(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$$handleEvent_$eq(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$$handleEvent_$eq(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$$handleEvent_$eq(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$$handleEvent_$eq(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$$handleEvent_$eq(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$$handleEvent_$eq(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$$handleEvent_$eq(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$$handleEventDefault() - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$$handleEventDefault() - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$$handleEventDefault() - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$$handleEventDefault() - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$$handleEventDefault() - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$$handleEventDefault() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$$handleEventDefault() - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$$handleEventDefault() - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$$handleEventDefault() - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$$handleEventDefault() - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$$nextState() - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$$nextState() - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$$nextState() - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$$nextState() - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$$nextState() - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$$nextState() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$$nextState() - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$$nextState() - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$$nextState() - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$$nextState() - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$$nextState_$eq(FSM.State<S, D>) - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$$nextState_$eq(FSM.State<S, D>) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$$nextState_$eq(FSM.State<S, D>) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$$nextState_$eq(FSM.State<S, D>) - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$$nextState_$eq(FSM.State<S, D>) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$$nextState_$eq(FSM.State<S, D>) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$$nextState_$eq(FSM.State<S, D>) - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$$nextState_$eq(FSM.State<S, D>) - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$$nextState_$eq(FSM.State<S, D>) - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$$nextState_$eq(FSM.State<S, D>) - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$$stateFunctions() - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$$stateFunctions() - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$$stateFunctions() - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$$stateFunctions() - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$$stateFunctions() - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$$stateFunctions() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$$stateFunctions() - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$$stateFunctions() - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$$stateFunctions() - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$$stateFunctions() - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$$stateTimeouts() - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$$stateTimeouts() - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$$stateTimeouts() - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$$stateTimeouts() - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$$stateTimeouts() - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$$stateTimeouts() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$$stateTimeouts() - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$$stateTimeouts() - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$$stateTimeouts() - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$$stateTimeouts() - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$$terminateEvent() - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$$terminateEvent() - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$$terminateEvent() - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$$terminateEvent() - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$$terminateEvent() - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$$terminateEvent() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$$terminateEvent() - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$$terminateEvent() - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$$terminateEvent() - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$$terminateEvent() - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$$terminateEvent_$eq(PartialFunction<FSM.StopEvent<S, D>, BoxedUnit>) - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$$terminateEvent_$eq(PartialFunction<FSM.StopEvent<S, D>, BoxedUnit>) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$$terminateEvent_$eq(PartialFunction<FSM.StopEvent<S, D>, BoxedUnit>) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$$terminateEvent_$eq(PartialFunction<FSM.StopEvent<S, D>, BoxedUnit>) - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$$terminateEvent_$eq(PartialFunction<FSM.StopEvent<S, D>, BoxedUnit>) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$$terminateEvent_$eq(PartialFunction<FSM.StopEvent<S, D>, BoxedUnit>) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$$terminateEvent_$eq(PartialFunction<FSM.StopEvent<S, D>, BoxedUnit>) - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$$terminateEvent_$eq(PartialFunction<FSM.StopEvent<S, D>, BoxedUnit>) - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$$terminateEvent_$eq(PartialFunction<FSM.StopEvent<S, D>, BoxedUnit>) - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$$terminateEvent_$eq(PartialFunction<FSM.StopEvent<S, D>, BoxedUnit>) - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$$timeoutFuture() - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$$timeoutFuture() - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$$timeoutFuture() - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$$timeoutFuture() - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$$timeoutFuture() - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$$timeoutFuture() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$$timeoutFuture() - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$$timeoutFuture() - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$$timeoutFuture() - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$$timeoutFuture() - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$$timeoutFuture_$eq(Option<Cancellable>) - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$$timeoutFuture_$eq(Option<Cancellable>) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$$timeoutFuture_$eq(Option<Cancellable>) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$$timeoutFuture_$eq(Option<Cancellable>) - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$$timeoutFuture_$eq(Option<Cancellable>) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$$timeoutFuture_$eq(Option<Cancellable>) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$$timeoutFuture_$eq(Option<Cancellable>) - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$$timeoutFuture_$eq(Option<Cancellable>) - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$$timeoutFuture_$eq(Option<Cancellable>) - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$$timeoutFuture_$eq(Option<Cancellable>) - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$$timerGen() - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$$timerGen() - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$$timerGen() - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$$timerGen() - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$$timerGen() - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$$timerGen() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$$timerGen() - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$$timerGen() - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$$timerGen() - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$$timerGen() - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$$timers() - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$$timers() - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$$timers() - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$$timers() - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$$timers() - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$$timers() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$$timers() - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$$timers() - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$$timers() - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$$timers() - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$$transitionEvent() - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$$transitionEvent() - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$$transitionEvent() - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$$transitionEvent() - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$$transitionEvent() - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$$transitionEvent() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$$transitionEvent() - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$$transitionEvent() - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$$transitionEvent() - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$$transitionEvent() - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$$transitionEvent_$eq(List<PartialFunction<Tuple2<S, S>, BoxedUnit>>) - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$$transitionEvent_$eq(List<PartialFunction<Tuple2<S, S>, BoxedUnit>>) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$$transitionEvent_$eq(List<PartialFunction<Tuple2<S, S>, BoxedUnit>>) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$$transitionEvent_$eq(List<PartialFunction<Tuple2<S, S>, BoxedUnit>>) - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$$transitionEvent_$eq(List<PartialFunction<Tuple2<S, S>, BoxedUnit>>) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$$transitionEvent_$eq(List<PartialFunction<Tuple2<S, S>, BoxedUnit>>) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$$transitionEvent_$eq(List<PartialFunction<Tuple2<S, S>, BoxedUnit>>) - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$$transitionEvent_$eq(List<PartialFunction<Tuple2<S, S>, BoxedUnit>>) - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$$transitionEvent_$eq(List<PartialFunction<Tuple2<S, S>, BoxedUnit>>) - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$$transitionEvent_$eq(List<PartialFunction<Tuple2<S, S>, BoxedUnit>>) - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$_setter_$$minus$greater_$eq(FSM.$minus$greater$) - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$_setter_$$minus$greater_$eq(FSM.$minus$greater$) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$_setter_$$minus$greater_$eq(FSM.$minus$greater$) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$_setter_$$minus$greater_$eq(FSM.$minus$greater$) - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$_setter_$$minus$greater_$eq(FSM.$minus$greater$) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$_setter_$$minus$greater_$eq(FSM.$minus$greater$) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$_setter_$$minus$greater_$eq(FSM.$minus$greater$) - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$_setter_$$minus$greater_$eq(FSM.$minus$greater$) - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$_setter_$$minus$greater_$eq(FSM.$minus$greater$) - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$_setter_$$minus$greater_$eq(FSM.$minus$greater$) - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$handleEventDefault_$eq(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$handleEventDefault_$eq(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$handleEventDefault_$eq(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$handleEventDefault_$eq(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$handleEventDefault_$eq(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$handleEventDefault_$eq(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$handleEventDefault_$eq(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$handleEventDefault_$eq(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$handleEventDefault_$eq(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$handleEventDefault_$eq(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$stateFunctions_$eq(Map<S, PartialFunction<FSM.Event<D>, FSM.State<S, D>>>) - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$stateFunctions_$eq(Map<S, PartialFunction<FSM.Event<D>, FSM.State<S, D>>>) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$stateFunctions_$eq(Map<S, PartialFunction<FSM.Event<D>, FSM.State<S, D>>>) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$stateFunctions_$eq(Map<S, PartialFunction<FSM.Event<D>, FSM.State<S, D>>>) - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$stateFunctions_$eq(Map<S, PartialFunction<FSM.Event<D>, FSM.State<S, D>>>) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$stateFunctions_$eq(Map<S, PartialFunction<FSM.Event<D>, FSM.State<S, D>>>) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$stateFunctions_$eq(Map<S, PartialFunction<FSM.Event<D>, FSM.State<S, D>>>) - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$stateFunctions_$eq(Map<S, PartialFunction<FSM.Event<D>, FSM.State<S, D>>>) - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$stateFunctions_$eq(Map<S, PartialFunction<FSM.Event<D>, FSM.State<S, D>>>) - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$stateFunctions_$eq(Map<S, PartialFunction<FSM.Event<D>, FSM.State<S, D>>>) - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$stateTimeouts_$eq(Map<S, Option<FiniteDuration>>) - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$stateTimeouts_$eq(Map<S, Option<FiniteDuration>>) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$stateTimeouts_$eq(Map<S, Option<FiniteDuration>>) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$stateTimeouts_$eq(Map<S, Option<FiniteDuration>>) - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$stateTimeouts_$eq(Map<S, Option<FiniteDuration>>) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$stateTimeouts_$eq(Map<S, Option<FiniteDuration>>) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$stateTimeouts_$eq(Map<S, Option<FiniteDuration>>) - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$stateTimeouts_$eq(Map<S, Option<FiniteDuration>>) - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$stateTimeouts_$eq(Map<S, Option<FiniteDuration>>) - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$stateTimeouts_$eq(Map<S, Option<FiniteDuration>>) - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$timerGen_$eq(Iterator<Object>) - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$timerGen_$eq(Iterator<Object>) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$timerGen_$eq(Iterator<Object>) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$timerGen_$eq(Iterator<Object>) - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$timerGen_$eq(Iterator<Object>) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$timerGen_$eq(Iterator<Object>) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$timerGen_$eq(Iterator<Object>) - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$timerGen_$eq(Iterator<Object>) - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$timerGen_$eq(Iterator<Object>) - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$timerGen_$eq(Iterator<Object>) - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$timers_$eq(Map<String, FSM.Timer>) - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$timers_$eq(Map<String, FSM.Timer>) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$timers_$eq(Map<String, FSM.Timer>) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$timers_$eq(Map<String, FSM.Timer>) - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$timers_$eq(Map<String, FSM.Timer>) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$timers_$eq(Map<String, FSM.Timer>) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$timers_$eq(Map<String, FSM.Timer>) - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$timers_$eq(Map<String, FSM.Timer>) - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$timers_$eq(Map<String, FSM.Timer>) - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$_setter_$akka$actor$FSM$$timers_$eq(Map<String, FSM.Timer>) - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$_setter_$Event_$eq(FSM.Event$) - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$_setter_$Event_$eq(FSM.Event$) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$_setter_$Event_$eq(FSM.Event$) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$_setter_$Event_$eq(FSM.Event$) - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$_setter_$Event_$eq(FSM.Event$) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$_setter_$Event_$eq(FSM.Event$) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$_setter_$Event_$eq(FSM.Event$) - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$_setter_$Event_$eq(FSM.Event$) - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$_setter_$Event_$eq(FSM.Event$) - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$_setter_$Event_$eq(FSM.Event$) - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$_setter_$StateTimeout_$eq(FSM.StateTimeout$) - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$_setter_$StateTimeout_$eq(FSM.StateTimeout$) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$_setter_$StateTimeout_$eq(FSM.StateTimeout$) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$_setter_$StateTimeout_$eq(FSM.StateTimeout$) - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$_setter_$StateTimeout_$eq(FSM.StateTimeout$) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$_setter_$StateTimeout_$eq(FSM.StateTimeout$) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$_setter_$StateTimeout_$eq(FSM.StateTimeout$) - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$_setter_$StateTimeout_$eq(FSM.StateTimeout$) - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$_setter_$StateTimeout_$eq(FSM.StateTimeout$) - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$_setter_$StateTimeout_$eq(FSM.StateTimeout$) - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$FSM$_setter_$StopEvent_$eq(FSM.StopEvent$) - Static method in class akka.actor.AbstractFSM
-
- akka$actor$FSM$_setter_$StopEvent_$eq(FSM.StopEvent$) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$actor$FSM$_setter_$StopEvent_$eq(FSM.StopEvent$) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$actor$FSM$_setter_$StopEvent_$eq(FSM.StopEvent$) - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$FSM$_setter_$StopEvent_$eq(FSM.StopEvent$) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$actor$FSM$_setter_$StopEvent_$eq(FSM.StopEvent$) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$FSM$_setter_$StopEvent_$eq(FSM.StopEvent$) - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$FSM$_setter_$StopEvent_$eq(FSM.StopEvent$) - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$FSM$_setter_$StopEvent_$eq(FSM.StopEvent$) - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$actor$FSM$_setter_$StopEvent_$eq(FSM.StopEvent$) - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$LoggingFSM$$events() - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$LoggingFSM$$events() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$LoggingFSM$$events() - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$LoggingFSM$$events() - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$LoggingFSM$$events() - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$LoggingFSM$$full() - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$LoggingFSM$$full() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$LoggingFSM$$full() - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$LoggingFSM$$full() - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$LoggingFSM$$full() - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$LoggingFSM$$full_$eq(boolean) - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$LoggingFSM$$full_$eq(boolean) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$LoggingFSM$$full_$eq(boolean) - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$LoggingFSM$$full_$eq(boolean) - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$LoggingFSM$$full_$eq(boolean) - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$LoggingFSM$$pos() - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$LoggingFSM$$pos() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$LoggingFSM$$pos() - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$LoggingFSM$$pos() - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$LoggingFSM$$pos() - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$LoggingFSM$$pos_$eq(int) - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$LoggingFSM$$pos_$eq(int) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$LoggingFSM$$pos_$eq(int) - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$LoggingFSM$$pos_$eq(int) - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$LoggingFSM$$pos_$eq(int) - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$LoggingFSM$$states() - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$LoggingFSM$$states() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$LoggingFSM$$states() - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$LoggingFSM$$states() - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$LoggingFSM$$states() - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$LoggingFSM$_setter_$akka$actor$LoggingFSM$$events_$eq(FSM.Event<D>[]) - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$LoggingFSM$_setter_$akka$actor$LoggingFSM$$events_$eq(FSM.Event<D>[]) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$LoggingFSM$_setter_$akka$actor$LoggingFSM$$events_$eq(FSM.Event<D>[]) - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$LoggingFSM$_setter_$akka$actor$LoggingFSM$$events_$eq(FSM.Event<D>[]) - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$LoggingFSM$_setter_$akka$actor$LoggingFSM$$events_$eq(FSM.Event<D>[]) - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$LoggingFSM$_setter_$akka$actor$LoggingFSM$$states_$eq(Object[]) - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$LoggingFSM$_setter_$akka$actor$LoggingFSM$$states_$eq(Object[]) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$LoggingFSM$_setter_$akka$actor$LoggingFSM$$states_$eq(Object[]) - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$LoggingFSM$_setter_$akka$actor$LoggingFSM$$states_$eq(Object[]) - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$LoggingFSM$_setter_$akka$actor$LoggingFSM$$states_$eq(Object[]) - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$LoggingFSM$_setter_$debugEvent_$eq(boolean) - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$actor$LoggingFSM$_setter_$debugEvent_$eq(boolean) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$actor$LoggingFSM$_setter_$debugEvent_$eq(boolean) - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$actor$LoggingFSM$_setter_$debugEvent_$eq(boolean) - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$actor$LoggingFSM$_setter_$debugEvent_$eq(boolean) - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$actor$StashSupport$$capacity() - Static method in class akka.event.ActorClassificationUnsubscriber
-
- akka$actor$StashSupport$$capacity() - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$actor$StashSupport$$capacity() - Static method in class akka.persistence.journal.PersistencePluginProxy
-
- akka$actor$StashSupport$$theStash() - Static method in class akka.event.ActorClassificationUnsubscriber
-
- akka$actor$StashSupport$$theStash() - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$actor$StashSupport$$theStash() - Static method in class akka.persistence.journal.PersistencePluginProxy
-
- akka$actor$StashSupport$$theStash_$eq(Vector<Envelope>) - Static method in class akka.event.ActorClassificationUnsubscriber
-
- akka$actor$StashSupport$$theStash_$eq(Vector<Envelope>) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$actor$StashSupport$$theStash_$eq(Vector<Envelope>) - Static method in class akka.persistence.journal.PersistencePluginProxy
-
- akka$actor$StashSupport$_setter_$akka$actor$StashSupport$$capacity_$eq(int) - Static method in class akka.event.ActorClassificationUnsubscriber
-
- akka$actor$StashSupport$_setter_$akka$actor$StashSupport$$capacity_$eq(int) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$actor$StashSupport$_setter_$akka$actor$StashSupport$$capacity_$eq(int) - Static method in class akka.persistence.journal.PersistencePluginProxy
-
- akka$actor$StashSupport$_setter_$mailbox_$eq(DequeBasedMessageQueueSemantics) - Static method in class akka.event.ActorClassificationUnsubscriber
-
- akka$actor$StashSupport$_setter_$mailbox_$eq(DequeBasedMessageQueueSemantics) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$actor$StashSupport$_setter_$mailbox_$eq(DequeBasedMessageQueueSemantics) - Static method in class akka.persistence.journal.PersistencePluginProxy
-
- akka$camel$CamelSupport$_setter_$camel_$eq(Camel) - Static method in class akka.camel.internal.CamelSupervisor
-
- akka$cluster$ddata$FastMerge$$ancestor() - Static method in class akka.cluster.ddata.GCounter
-
- akka$cluster$ddata$FastMerge$$ancestor() - Static method in class akka.cluster.ddata.GSet
-
- akka$cluster$ddata$FastMerge$$ancestor() - Static method in class akka.cluster.ddata.ORSet
-
- akka$cluster$ddata$FastMerge$$ancestor_$eq(FastMerge) - Static method in class akka.cluster.ddata.GCounter
-
- akka$cluster$ddata$FastMerge$$ancestor_$eq(FastMerge) - Static method in class akka.cluster.ddata.GSet
-
- akka$cluster$ddata$FastMerge$$ancestor_$eq(FastMerge) - Static method in class akka.cluster.ddata.ORSet
-
- akka$cluster$ddata$protobuf$SerializationSupport$$protocol() - Static method in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer
-
- akka$cluster$ddata$protobuf$SerializationSupport$$protocol_$eq(String) - Static method in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer
-
- akka$cluster$ddata$protobuf$SerializationSupport$$ser() - Static method in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer
-
- akka$cluster$ddata$protobuf$SerializationSupport$$ser_$eq(Serialization) - Static method in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer
-
- akka$cluster$ddata$protobuf$SerializationSupport$$transportInfo() - Static method in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer
-
- akka$cluster$ddata$protobuf$SerializationSupport$$transportInfo_$eq(Serialization.Information) - Static method in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer
-
- akka$cluster$pubsub$PerGroupingBuffer$$buffers() - Static method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- akka$cluster$pubsub$PerGroupingBuffer$_setter_$akka$cluster$pubsub$PerGroupingBuffer$$buffers_$eq(MessageBufferMap<String>) - Static method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- akka$contrib$pattern$ReliableProxyDebugLogging$_setter_$debug_$eq(boolean) - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$dispatch$BatchingExecutor$$_blockContext() - Static method in class akka.dispatch.MessageDispatcher
-
- akka$dispatch$BatchingExecutor$$_blockContext() - Static method in class akka.testkit.CallingThreadDispatcher
-
- akka$dispatch$BatchingExecutor$$_tasksLocal() - Static method in class akka.dispatch.MessageDispatcher
-
- akka$dispatch$BatchingExecutor$$_tasksLocal() - Static method in class akka.testkit.CallingThreadDispatcher
-
- akka$dispatch$BatchingExecutor$_setter_$akka$dispatch$BatchingExecutor$$_blockContext_$eq(ThreadLocal<BlockContext>) - Static method in class akka.dispatch.MessageDispatcher
-
- akka$dispatch$BatchingExecutor$_setter_$akka$dispatch$BatchingExecutor$$_blockContext_$eq(ThreadLocal<BlockContext>) - Static method in class akka.testkit.CallingThreadDispatcher
-
- akka$dispatch$BatchingExecutor$_setter_$akka$dispatch$BatchingExecutor$$_tasksLocal_$eq(ThreadLocal<BatchingExecutor.AbstractBatch>) - Static method in class akka.dispatch.MessageDispatcher
-
- akka$dispatch$BatchingExecutor$_setter_$akka$dispatch$BatchingExecutor$$_tasksLocal_$eq(ThreadLocal<BatchingExecutor.AbstractBatch>) - Static method in class akka.testkit.CallingThreadDispatcher
-
- akka$event$LoggingBus$$_logLevel() - Static method in class akka.event.EventStream
-
- akka$event$LoggingBus$$_logLevel_$eq(Logging.LogLevel) - Static method in class akka.event.EventStream
-
- akka$event$LoggingBus$$guard() - Static method in class akka.event.EventStream
-
- akka$event$LoggingBus$$loggers() - Static method in class akka.event.EventStream
-
- akka$event$LoggingBus$$loggers_$eq(Seq<ActorRef>) - Static method in class akka.event.EventStream
-
- akka$event$LoggingBus$_setter_$akka$event$LoggingBus$$guard_$eq(ReentrantGuard) - Static method in class akka.event.EventStream
-
- akka$event$SubchannelClassification$$cache() - Static method in class akka.event.EventStream
-
- akka$event$SubchannelClassification$$cache_$eq(Map<Object, Set<Object>>) - Static method in class akka.event.EventStream
-
- akka$event$SubchannelClassification$$subscriptions() - Static method in class akka.event.EventStream
-
- akka$persistence$fsm$PersistentFSMBase$$currentState() - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$$currentState_$eq(PersistentFSM.State<S, D, E>) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$$generation() - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$$generation_$eq(long) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$$handleEvent() - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$$handleEvent_$eq(PartialFunction<PersistentFSM.Event<D>, PersistentFSM.State<S, D, E>>) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$$handleEventDefault() - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$$nextState() - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$$nextState_$eq(PersistentFSM.State<S, D, E>) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$$stateFunctions() - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$$stateTimeouts() - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$$terminateEvent() - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$$terminateEvent_$eq(PartialFunction<PersistentFSM.StopEvent<S, D>, BoxedUnit>) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$$timeoutFuture() - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$$timeoutFuture_$eq(Option<Cancellable>) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$$timerGen() - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$$timers() - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$$transitionEvent() - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$$transitionEvent_$eq(List<PartialFunction<Tuple2<S, S>, BoxedUnit>>) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$_setter_$$minus$greater_$eq(PersistentFSM.$minus$greater$) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$_setter_$akka$persistence$fsm$PersistentFSMBase$$handleEventDefault_$eq(PartialFunction<PersistentFSM.Event<D>, PersistentFSM.State<S, D, E>>) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$_setter_$akka$persistence$fsm$PersistentFSMBase$$stateFunctions_$eq(Map<S, PartialFunction<PersistentFSM.Event<D>, PersistentFSM.State<S, D, E>>>) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$_setter_$akka$persistence$fsm$PersistentFSMBase$$stateTimeouts_$eq(Map<S, Option<FiniteDuration>>) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$_setter_$akka$persistence$fsm$PersistentFSMBase$$timerGen_$eq(Iterator<Object>) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$_setter_$akka$persistence$fsm$PersistentFSMBase$$timers_$eq(Map<String, PersistentFSM.Timer>) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$_setter_$Event_$eq(PersistentFSM.Event$) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$_setter_$StateTimeout_$eq(PersistentFSM.StateTimeout$) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$fsm$PersistentFSMBase$_setter_$StopEvent_$eq(PersistentFSM.StopEvent$) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$persistence$journal$AsyncWriteJournal$$breaker() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$$breaker() - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$$config() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$$config() - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$$extension() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$$extension() - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$$publish() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$$publish() - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$$replayFilterMaxOldWriters() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$$replayFilterMaxOldWriters() - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$$replayFilterMode() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$$replayFilterMode() - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$$replayFilterWindowSize() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$$replayFilterWindowSize() - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$$resequencer() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$$resequencer() - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$$resequencerCounter() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$$resequencerCounter() - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$$resequencerCounter_$eq(long) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$$resequencerCounter_$eq(long) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$_setter_$akka$persistence$journal$AsyncWriteJournal$$breaker_$eq(CircuitBreaker) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$_setter_$akka$persistence$journal$AsyncWriteJournal$$breaker_$eq(CircuitBreaker) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$_setter_$akka$persistence$journal$AsyncWriteJournal$$config_$eq(Config) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$_setter_$akka$persistence$journal$AsyncWriteJournal$$config_$eq(Config) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$_setter_$akka$persistence$journal$AsyncWriteJournal$$extension_$eq(Persistence) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$_setter_$akka$persistence$journal$AsyncWriteJournal$$extension_$eq(Persistence) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$_setter_$akka$persistence$journal$AsyncWriteJournal$$publish_$eq(boolean) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$_setter_$akka$persistence$journal$AsyncWriteJournal$$publish_$eq(boolean) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$_setter_$akka$persistence$journal$AsyncWriteJournal$$replayFilterMaxOldWriters_$eq(int) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$_setter_$akka$persistence$journal$AsyncWriteJournal$$replayFilterMaxOldWriters_$eq(int) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$_setter_$akka$persistence$journal$AsyncWriteJournal$$replayFilterMode_$eq(ReplayFilter.Mode) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$_setter_$akka$persistence$journal$AsyncWriteJournal$$replayFilterMode_$eq(ReplayFilter.Mode) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$_setter_$akka$persistence$journal$AsyncWriteJournal$$replayFilterWindowSize_$eq(int) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$_setter_$akka$persistence$journal$AsyncWriteJournal$$replayFilterWindowSize_$eq(int) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$_setter_$akka$persistence$journal$AsyncWriteJournal$$resequencer_$eq(ActorRef) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$_setter_$akka$persistence$journal$AsyncWriteJournal$$resequencer_$eq(ActorRef) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$_setter_$receiveWriteJournal_$eq(PartialFunction<Object, BoxedUnit>) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$AsyncWriteJournal$_setter_$receiveWriteJournal_$eq(PartialFunction<Object, BoxedUnit>) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$AsyncWriteProxy$$isInitialized() - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$AsyncWriteProxy$$isInitialized_$eq(boolean) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$AsyncWriteProxy$$isInitTimedOut() - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$AsyncWriteProxy$$isInitTimedOut_$eq(boolean) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$AsyncWriteProxy$$storeNotInitialized() - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$AsyncWriteProxy$_setter_$akka$persistence$journal$AsyncWriteProxy$$storeNotInitialized_$eq(Future<Nothing$>) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$leveldb$LeveldbIdMapping$$idMap() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$leveldb$LeveldbIdMapping$$idMap_$eq(Map<String, Object>) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$leveldb$LeveldbIdMapping$$idMapLock() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$leveldb$LeveldbIdMapping$$idOffset() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$leveldb$LeveldbIdMapping$_setter_$akka$persistence$journal$leveldb$LeveldbIdMapping$$idMapLock_$eq(Object) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$leveldb$LeveldbIdMapping$_setter_$akka$persistence$journal$leveldb$LeveldbIdMapping$$idOffset_$eq(int) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$leveldb$LeveldbRecovery$$replayDispatcher() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$leveldb$LeveldbRecovery$$replayDispatcherId() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$leveldb$LeveldbStore$$allPersistenceIdsSubscribers() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$leveldb$LeveldbStore$$allPersistenceIdsSubscribers_$eq(Set<ActorRef>) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$leveldb$LeveldbStore$$persistenceIdSubscribers() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$leveldb$LeveldbStore$$tagPersistenceIdPrefix() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$leveldb$LeveldbStore$$tagSequenceNr() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$leveldb$LeveldbStore$$tagSequenceNr_$eq(Map<String, Object>) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$leveldb$LeveldbStore$$tagSubscribers() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$leveldb$LeveldbStore$_setter_$akka$persistence$journal$leveldb$LeveldbStore$$persistenceIdSubscribers_$eq(HashMap<String, Set<ActorRef>>) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$leveldb$LeveldbStore$_setter_$akka$persistence$journal$leveldb$LeveldbStore$$tagPersistenceIdPrefix_$eq(String) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$leveldb$LeveldbStore$_setter_$akka$persistence$journal$leveldb$LeveldbStore$$tagSubscribers_$eq(HashMap<String, Set<ActorRef>>) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$leveldb$LeveldbStore$_setter_$config_$eq(Config) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$leveldb$LeveldbStore$_setter_$leveldbDir_$eq(File) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$leveldb$LeveldbStore$_setter_$leveldbOptions_$eq(Options) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$leveldb$LeveldbStore$_setter_$leveldbWriteOptions_$eq(WriteOptions) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$leveldb$LeveldbStore$_setter_$nativeLeveldb_$eq(boolean) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$leveldb$LeveldbStore$_setter_$serialization_$eq(Serialization) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$WriteJournalBase$$eventAdapters() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$WriteJournalBase$$eventAdapters() - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$WriteJournalBase$_setter_$akka$persistence$journal$WriteJournalBase$$eventAdapters_$eq(EventAdapters) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$WriteJournalBase$_setter_$akka$persistence$journal$WriteJournalBase$$eventAdapters_$eq(EventAdapters) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$persistence$journal$WriteJournalBase$_setter_$persistence_$eq(Persistence) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- akka$persistence$journal$WriteJournalBase$_setter_$persistence_$eq(Persistence) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- akka$routing$Listeners$_setter_$listeners_$eq(Set<ActorRef>) - Static method in class akka.actor.AbstractFSM
-
- akka$routing$Listeners$_setter_$listeners_$eq(Set<ActorRef>) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- akka$routing$Listeners$_setter_$listeners_$eq(Set<ActorRef>) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- akka$routing$Listeners$_setter_$listeners_$eq(Set<ActorRef>) - Static method in class akka.contrib.pattern.ReliableProxy
-
- akka$routing$Listeners$_setter_$listeners_$eq(Set<ActorRef>) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- akka$routing$Listeners$_setter_$listeners_$eq(Set<ActorRef>) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- akka$routing$Listeners$_setter_$listeners_$eq(Set<ActorRef>) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- akka$routing$Listeners$_setter_$listeners_$eq(Set<ActorRef>) - Static method in class akka.remote.testconductor.ClientFSM
-
- akka$routing$Listeners$_setter_$listeners_$eq(Set<ActorRef>) - Static method in class akka.remote.testconductor.ServerFSM
-
- akka$routing$Listeners$_setter_$listeners_$eq(Set<ActorRef>) - Static method in class akka.remote.transport.ProtocolStateActor
-
- akka$routing$Listeners$_setter_$listeners_$eq(Set<ActorRef>) - Static method in class akka.remote.transport.ThrottledAssociation
-
- akka$serialization$BaseSerializer$_setter_$identifier_$eq(int) - Static method in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer
-
- akka$serialization$BaseSerializer$_setter_$identifier_$eq(int) - Static method in class akka.persistence.serialization.SnapshotSerializer
-
- akka$serialization$BaseSerializer$_setter_$identifier_$eq(int) - Static method in class akka.remote.serialization.ArteryMessageSerializer
-
- akka$serialization$BaseSerializer$_setter_$identifier_$eq(int) - Static method in class akka.remote.serialization.ProtobufSerializer
-
- akka$serialization$BaseSerializer$_setter_$identifier_$eq(int) - Static method in class akka.serialization.JavaSerializer
-
- akka$stream$actor$ActorPublisher$$demand() - Static method in class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher
-
- akka$stream$actor$ActorPublisher$$demand() - Static method in class akka.stream.actor.AbstractActorPublisher
-
- akka$stream$actor$ActorPublisher$$demand() - Static method in class akka.stream.actor.UntypedActorPublisher
-
- akka$stream$actor$ActorPublisher$$demand() - Static method in class akka.stream.impl.ActorRefSourceActor
-
- akka$stream$actor$ActorPublisher$$demand() - Static method in class akka.stream.impl.io.FilePublisher
-
- akka$stream$actor$ActorPublisher$$demand() - Static method in class akka.stream.impl.io.InputStreamPublisher
-
- akka$stream$actor$ActorPublisher$$demand_$eq(long) - Static method in class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher
-
- akka$stream$actor$ActorPublisher$$demand_$eq(long) - Static method in class akka.stream.actor.AbstractActorPublisher
-
- akka$stream$actor$ActorPublisher$$demand_$eq(long) - Static method in class akka.stream.actor.UntypedActorPublisher
-
- akka$stream$actor$ActorPublisher$$demand_$eq(long) - Static method in class akka.stream.impl.ActorRefSourceActor
-
- akka$stream$actor$ActorPublisher$$demand_$eq(long) - Static method in class akka.stream.impl.io.FilePublisher
-
- akka$stream$actor$ActorPublisher$$demand_$eq(long) - Static method in class akka.stream.impl.io.InputStreamPublisher
-
- akka$stream$actor$ActorPublisher$$lifecycleState() - Static method in class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher
-
- akka$stream$actor$ActorPublisher$$lifecycleState() - Static method in class akka.stream.actor.AbstractActorPublisher
-
- akka$stream$actor$ActorPublisher$$lifecycleState() - Static method in class akka.stream.actor.UntypedActorPublisher
-
- akka$stream$actor$ActorPublisher$$lifecycleState() - Static method in class akka.stream.impl.ActorRefSourceActor
-
- akka$stream$actor$ActorPublisher$$lifecycleState() - Static method in class akka.stream.impl.io.FilePublisher
-
- akka$stream$actor$ActorPublisher$$lifecycleState() - Static method in class akka.stream.impl.io.InputStreamPublisher
-
- akka$stream$actor$ActorPublisher$$lifecycleState_$eq(akka.stream.actor.ActorPublisher.Internal.LifecycleState) - Static method in class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher
-
- akka$stream$actor$ActorPublisher$$lifecycleState_$eq(akka.stream.actor.ActorPublisher.Internal.LifecycleState) - Static method in class akka.stream.actor.AbstractActorPublisher
-
- akka$stream$actor$ActorPublisher$$lifecycleState_$eq(akka.stream.actor.ActorPublisher.Internal.LifecycleState) - Static method in class akka.stream.actor.UntypedActorPublisher
-
- akka$stream$actor$ActorPublisher$$lifecycleState_$eq(akka.stream.actor.ActorPublisher.Internal.LifecycleState) - Static method in class akka.stream.impl.ActorRefSourceActor
-
- akka$stream$actor$ActorPublisher$$lifecycleState_$eq(akka.stream.actor.ActorPublisher.Internal.LifecycleState) - Static method in class akka.stream.impl.io.FilePublisher
-
- akka$stream$actor$ActorPublisher$$lifecycleState_$eq(akka.stream.actor.ActorPublisher.Internal.LifecycleState) - Static method in class akka.stream.impl.io.InputStreamPublisher
-
- akka$stream$actor$ActorPublisher$$scheduledSubscriptionTimeout() - Static method in class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher
-
- akka$stream$actor$ActorPublisher$$scheduledSubscriptionTimeout() - Static method in class akka.stream.actor.AbstractActorPublisher
-
- akka$stream$actor$ActorPublisher$$scheduledSubscriptionTimeout() - Static method in class akka.stream.actor.UntypedActorPublisher
-
- akka$stream$actor$ActorPublisher$$scheduledSubscriptionTimeout() - Static method in class akka.stream.impl.ActorRefSourceActor
-
- akka$stream$actor$ActorPublisher$$scheduledSubscriptionTimeout() - Static method in class akka.stream.impl.io.FilePublisher
-
- akka$stream$actor$ActorPublisher$$scheduledSubscriptionTimeout() - Static method in class akka.stream.impl.io.InputStreamPublisher
-
- akka$stream$actor$ActorPublisher$$scheduledSubscriptionTimeout_$eq(Cancellable) - Static method in class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher
-
- akka$stream$actor$ActorPublisher$$scheduledSubscriptionTimeout_$eq(Cancellable) - Static method in class akka.stream.actor.AbstractActorPublisher
-
- akka$stream$actor$ActorPublisher$$scheduledSubscriptionTimeout_$eq(Cancellable) - Static method in class akka.stream.actor.UntypedActorPublisher
-
- akka$stream$actor$ActorPublisher$$scheduledSubscriptionTimeout_$eq(Cancellable) - Static method in class akka.stream.impl.ActorRefSourceActor
-
- akka$stream$actor$ActorPublisher$$scheduledSubscriptionTimeout_$eq(Cancellable) - Static method in class akka.stream.impl.io.FilePublisher
-
- akka$stream$actor$ActorPublisher$$scheduledSubscriptionTimeout_$eq(Cancellable) - Static method in class akka.stream.impl.io.InputStreamPublisher
-
- akka$stream$actor$ActorPublisher$$state() - Static method in class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher
-
- akka$stream$actor$ActorPublisher$$state() - Static method in class akka.stream.actor.AbstractActorPublisher
-
- akka$stream$actor$ActorPublisher$$state() - Static method in class akka.stream.actor.UntypedActorPublisher
-
- akka$stream$actor$ActorPublisher$$state() - Static method in class akka.stream.impl.ActorRefSourceActor
-
- akka$stream$actor$ActorPublisher$$state() - Static method in class akka.stream.impl.io.FilePublisher
-
- akka$stream$actor$ActorPublisher$$state() - Static method in class akka.stream.impl.io.InputStreamPublisher
-
- akka$stream$actor$ActorPublisher$$subscriber() - Static method in class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher
-
- akka$stream$actor$ActorPublisher$$subscriber() - Static method in class akka.stream.actor.AbstractActorPublisher
-
- akka$stream$actor$ActorPublisher$$subscriber() - Static method in class akka.stream.actor.UntypedActorPublisher
-
- akka$stream$actor$ActorPublisher$$subscriber() - Static method in class akka.stream.impl.ActorRefSourceActor
-
- akka$stream$actor$ActorPublisher$$subscriber() - Static method in class akka.stream.impl.io.FilePublisher
-
- akka$stream$actor$ActorPublisher$$subscriber() - Static method in class akka.stream.impl.io.InputStreamPublisher
-
- akka$stream$actor$ActorPublisher$$subscriber_$eq(Subscriber<Object>) - Static method in class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher
-
- akka$stream$actor$ActorPublisher$$subscriber_$eq(Subscriber<Object>) - Static method in class akka.stream.actor.AbstractActorPublisher
-
- akka$stream$actor$ActorPublisher$$subscriber_$eq(Subscriber<Object>) - Static method in class akka.stream.actor.UntypedActorPublisher
-
- akka$stream$actor$ActorPublisher$$subscriber_$eq(Subscriber<Object>) - Static method in class akka.stream.impl.ActorRefSourceActor
-
- akka$stream$actor$ActorPublisher$$subscriber_$eq(Subscriber<Object>) - Static method in class akka.stream.impl.io.FilePublisher
-
- akka$stream$actor$ActorPublisher$$subscriber_$eq(Subscriber<Object>) - Static method in class akka.stream.impl.io.InputStreamPublisher
-
- akka$stream$actor$ActorPublisher$_setter_$akka$stream$actor$ActorPublisher$$state_$eq(ActorPublisherState) - Static method in class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher
-
- akka$stream$actor$ActorPublisher$_setter_$akka$stream$actor$ActorPublisher$$state_$eq(ActorPublisherState) - Static method in class akka.stream.actor.AbstractActorPublisher
-
- akka$stream$actor$ActorPublisher$_setter_$akka$stream$actor$ActorPublisher$$state_$eq(ActorPublisherState) - Static method in class akka.stream.actor.UntypedActorPublisher
-
- akka$stream$actor$ActorPublisher$_setter_$akka$stream$actor$ActorPublisher$$state_$eq(ActorPublisherState) - Static method in class akka.stream.impl.ActorRefSourceActor
-
- akka$stream$actor$ActorPublisher$_setter_$akka$stream$actor$ActorPublisher$$state_$eq(ActorPublisherState) - Static method in class akka.stream.impl.io.FilePublisher
-
- akka$stream$actor$ActorPublisher$_setter_$akka$stream$actor$ActorPublisher$$state_$eq(ActorPublisherState) - Static method in class akka.stream.impl.io.InputStreamPublisher
-
- akka$stream$actor$ActorSubscriber$$_canceled() - Static method in class akka.stream.actor.AbstractActorSubscriber
-
- akka$stream$actor$ActorSubscriber$$_canceled() - Static method in class akka.stream.actor.UntypedActorSubscriber
-
- akka$stream$actor$ActorSubscriber$$_canceled() - Static method in class akka.stream.impl.ActorRefSinkActor
-
- akka$stream$actor$ActorSubscriber$$_canceled() - Static method in class akka.stream.impl.io.FileSubscriber
-
- akka$stream$actor$ActorSubscriber$$_canceled() - Static method in class akka.stream.impl.io.OutputStreamSubscriber
-
- akka$stream$actor$ActorSubscriber$$_canceled_$eq(boolean) - Static method in class akka.stream.actor.AbstractActorSubscriber
-
- akka$stream$actor$ActorSubscriber$$_canceled_$eq(boolean) - Static method in class akka.stream.actor.UntypedActorSubscriber
-
- akka$stream$actor$ActorSubscriber$$_canceled_$eq(boolean) - Static method in class akka.stream.impl.ActorRefSinkActor
-
- akka$stream$actor$ActorSubscriber$$_canceled_$eq(boolean) - Static method in class akka.stream.impl.io.FileSubscriber
-
- akka$stream$actor$ActorSubscriber$$_canceled_$eq(boolean) - Static method in class akka.stream.impl.io.OutputStreamSubscriber
-
- akka$stream$actor$ActorSubscriber$$requested() - Static method in class akka.stream.actor.AbstractActorSubscriber
-
- akka$stream$actor$ActorSubscriber$$requested() - Static method in class akka.stream.actor.UntypedActorSubscriber
-
- akka$stream$actor$ActorSubscriber$$requested() - Static method in class akka.stream.impl.ActorRefSinkActor
-
- akka$stream$actor$ActorSubscriber$$requested() - Static method in class akka.stream.impl.io.FileSubscriber
-
- akka$stream$actor$ActorSubscriber$$requested() - Static method in class akka.stream.impl.io.OutputStreamSubscriber
-
- akka$stream$actor$ActorSubscriber$$requested_$eq(long) - Static method in class akka.stream.actor.AbstractActorSubscriber
-
- akka$stream$actor$ActorSubscriber$$requested_$eq(long) - Static method in class akka.stream.actor.UntypedActorSubscriber
-
- akka$stream$actor$ActorSubscriber$$requested_$eq(long) - Static method in class akka.stream.impl.ActorRefSinkActor
-
- akka$stream$actor$ActorSubscriber$$requested_$eq(long) - Static method in class akka.stream.impl.io.FileSubscriber
-
- akka$stream$actor$ActorSubscriber$$requested_$eq(long) - Static method in class akka.stream.impl.io.OutputStreamSubscriber
-
- akka$stream$actor$ActorSubscriber$$state() - Static method in class akka.stream.actor.AbstractActorSubscriber
-
- akka$stream$actor$ActorSubscriber$$state() - Static method in class akka.stream.actor.UntypedActorSubscriber
-
- akka$stream$actor$ActorSubscriber$$state() - Static method in class akka.stream.impl.ActorRefSinkActor
-
- akka$stream$actor$ActorSubscriber$$state() - Static method in class akka.stream.impl.io.FileSubscriber
-
- akka$stream$actor$ActorSubscriber$$state() - Static method in class akka.stream.impl.io.OutputStreamSubscriber
-
- akka$stream$actor$ActorSubscriber$$subscription() - Static method in class akka.stream.actor.AbstractActorSubscriber
-
- akka$stream$actor$ActorSubscriber$$subscription() - Static method in class akka.stream.actor.UntypedActorSubscriber
-
- akka$stream$actor$ActorSubscriber$$subscription() - Static method in class akka.stream.impl.ActorRefSinkActor
-
- akka$stream$actor$ActorSubscriber$$subscription() - Static method in class akka.stream.impl.io.FileSubscriber
-
- akka$stream$actor$ActorSubscriber$$subscription() - Static method in class akka.stream.impl.io.OutputStreamSubscriber
-
- akka$stream$actor$ActorSubscriber$$subscription_$eq(Option<Subscription>) - Static method in class akka.stream.actor.AbstractActorSubscriber
-
- akka$stream$actor$ActorSubscriber$$subscription_$eq(Option<Subscription>) - Static method in class akka.stream.actor.UntypedActorSubscriber
-
- akka$stream$actor$ActorSubscriber$$subscription_$eq(Option<Subscription>) - Static method in class akka.stream.impl.ActorRefSinkActor
-
- akka$stream$actor$ActorSubscriber$$subscription_$eq(Option<Subscription>) - Static method in class akka.stream.impl.io.FileSubscriber
-
- akka$stream$actor$ActorSubscriber$$subscription_$eq(Option<Subscription>) - Static method in class akka.stream.impl.io.OutputStreamSubscriber
-
- akka$stream$actor$ActorSubscriber$_setter_$akka$stream$actor$ActorSubscriber$$state_$eq(ActorSubscriberState) - Static method in class akka.stream.actor.AbstractActorSubscriber
-
- akka$stream$actor$ActorSubscriber$_setter_$akka$stream$actor$ActorSubscriber$$state_$eq(ActorSubscriberState) - Static method in class akka.stream.actor.UntypedActorSubscriber
-
- akka$stream$actor$ActorSubscriber$_setter_$akka$stream$actor$ActorSubscriber$$state_$eq(ActorSubscriberState) - Static method in class akka.stream.impl.ActorRefSinkActor
-
- akka$stream$actor$ActorSubscriber$_setter_$akka$stream$actor$ActorSubscriber$$state_$eq(ActorSubscriberState) - Static method in class akka.stream.impl.io.FileSubscriber
-
- akka$stream$actor$ActorSubscriber$_setter_$akka$stream$actor$ActorSubscriber$$state_$eq(ActorSubscriberState) - Static method in class akka.stream.impl.io.OutputStreamSubscriber
-
- akka$stream$impl$Pump$$currentAction() - Static method in class akka.stream.impl.FanIn
-
- akka$stream$impl$Pump$$currentAction() - Static method in class akka.stream.impl.FanOut
-
- akka$stream$impl$Pump$$currentAction() - Static method in class akka.stream.impl.FanoutProcessorImpl
-
- akka$stream$impl$Pump$$currentAction() - Static method in class akka.stream.impl.io.TLSActor
-
- akka$stream$impl$Pump$$currentAction() - Static method in class akka.stream.impl.Unzip
-
- akka$stream$impl$Pump$$currentAction_$eq(Function0<BoxedUnit>) - Static method in class akka.stream.impl.FanIn
-
- akka$stream$impl$Pump$$currentAction_$eq(Function0<BoxedUnit>) - Static method in class akka.stream.impl.FanOut
-
- akka$stream$impl$Pump$$currentAction_$eq(Function0<BoxedUnit>) - Static method in class akka.stream.impl.FanoutProcessorImpl
-
- akka$stream$impl$Pump$$currentAction_$eq(Function0<BoxedUnit>) - Static method in class akka.stream.impl.io.TLSActor
-
- akka$stream$impl$Pump$$currentAction_$eq(Function0<BoxedUnit>) - Static method in class akka.stream.impl.Unzip
-
- akka$stream$impl$Pump$$transferState() - Static method in class akka.stream.impl.FanIn
-
- akka$stream$impl$Pump$$transferState() - Static method in class akka.stream.impl.FanOut
-
- akka$stream$impl$Pump$$transferState() - Static method in class akka.stream.impl.FanoutProcessorImpl
-
- akka$stream$impl$Pump$$transferState() - Static method in class akka.stream.impl.io.TLSActor
-
- akka$stream$impl$Pump$$transferState() - Static method in class akka.stream.impl.Unzip
-
- akka$stream$impl$Pump$$transferState_$eq(TransferState) - Static method in class akka.stream.impl.FanIn
-
- akka$stream$impl$Pump$$transferState_$eq(TransferState) - Static method in class akka.stream.impl.FanOut
-
- akka$stream$impl$Pump$$transferState_$eq(TransferState) - Static method in class akka.stream.impl.FanoutProcessorImpl
-
- akka$stream$impl$Pump$$transferState_$eq(TransferState) - Static method in class akka.stream.impl.io.TLSActor
-
- akka$stream$impl$Pump$$transferState_$eq(TransferState) - Static method in class akka.stream.impl.Unzip
-
- akka$stream$impl$Pump$_setter_$completedPhase_$eq(TransferPhase) - Static method in class akka.stream.impl.FanIn
-
- akka$stream$impl$Pump$_setter_$completedPhase_$eq(TransferPhase) - Static method in class akka.stream.impl.FanOut
-
- akka$stream$impl$Pump$_setter_$completedPhase_$eq(TransferPhase) - Static method in class akka.stream.impl.FanoutProcessorImpl
-
- akka$stream$impl$Pump$_setter_$completedPhase_$eq(TransferPhase) - Static method in class akka.stream.impl.io.TLSActor
-
- akka$stream$impl$Pump$_setter_$completedPhase_$eq(TransferPhase) - Static method in class akka.stream.impl.Unzip
-
- akka$testkit$TestKitBase$$end() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- akka$testkit$TestKitBase$$end() - Static method in class akka.persistence.journal.JournalSpec
-
- akka$testkit$TestKitBase$$end() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- akka$testkit$TestKitBase$$end() - Static method in class akka.remote.testkit.MultiNodeSpec
-
- akka$testkit$TestKitBase$$end() - Static method in class akka.testkit.TestKit
-
- akka$testkit$TestKitBase$$end() - Static method in class akka.testkit.TestProbe
-
- akka$testkit$TestKitBase$$end_$eq(Duration) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- akka$testkit$TestKitBase$$end_$eq(Duration) - Static method in class akka.persistence.journal.JournalSpec
-
- akka$testkit$TestKitBase$$end_$eq(Duration) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- akka$testkit$TestKitBase$$end_$eq(Duration) - Static method in class akka.remote.testkit.MultiNodeSpec
-
- akka$testkit$TestKitBase$$end_$eq(Duration) - Static method in class akka.testkit.TestKit
-
- akka$testkit$TestKitBase$$end_$eq(Duration) - Static method in class akka.testkit.TestProbe
-
- akka$testkit$TestKitBase$$lastWasNoMsg() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- akka$testkit$TestKitBase$$lastWasNoMsg() - Static method in class akka.persistence.journal.JournalSpec
-
- akka$testkit$TestKitBase$$lastWasNoMsg() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- akka$testkit$TestKitBase$$lastWasNoMsg() - Static method in class akka.remote.testkit.MultiNodeSpec
-
- akka$testkit$TestKitBase$$lastWasNoMsg() - Static method in class akka.testkit.TestKit
-
- akka$testkit$TestKitBase$$lastWasNoMsg() - Static method in class akka.testkit.TestProbe
-
- akka$testkit$TestKitBase$$lastWasNoMsg_$eq(boolean) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- akka$testkit$TestKitBase$$lastWasNoMsg_$eq(boolean) - Static method in class akka.persistence.journal.JournalSpec
-
- akka$testkit$TestKitBase$$lastWasNoMsg_$eq(boolean) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- akka$testkit$TestKitBase$$lastWasNoMsg_$eq(boolean) - Static method in class akka.remote.testkit.MultiNodeSpec
-
- akka$testkit$TestKitBase$$lastWasNoMsg_$eq(boolean) - Static method in class akka.testkit.TestKit
-
- akka$testkit$TestKitBase$$lastWasNoMsg_$eq(boolean) - Static method in class akka.testkit.TestProbe
-
- akka$testkit$TestKitBase$$queue() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- akka$testkit$TestKitBase$$queue() - Static method in class akka.persistence.journal.JournalSpec
-
- akka$testkit$TestKitBase$$queue() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- akka$testkit$TestKitBase$$queue() - Static method in class akka.remote.testkit.MultiNodeSpec
-
- akka$testkit$TestKitBase$$queue() - Static method in class akka.testkit.TestKit
-
- akka$testkit$TestKitBase$$queue() - Static method in class akka.testkit.TestProbe
-
- akka$testkit$TestKitBase$_setter_$akka$testkit$TestKitBase$$queue_$eq(LinkedBlockingDeque<TestActor.Message>) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- akka$testkit$TestKitBase$_setter_$akka$testkit$TestKitBase$$queue_$eq(LinkedBlockingDeque<TestActor.Message>) - Static method in class akka.persistence.journal.JournalSpec
-
- akka$testkit$TestKitBase$_setter_$akka$testkit$TestKitBase$$queue_$eq(LinkedBlockingDeque<TestActor.Message>) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- akka$testkit$TestKitBase$_setter_$akka$testkit$TestKitBase$$queue_$eq(LinkedBlockingDeque<TestActor.Message>) - Static method in class akka.remote.testkit.MultiNodeSpec
-
- akka$testkit$TestKitBase$_setter_$akka$testkit$TestKitBase$$queue_$eq(LinkedBlockingDeque<TestActor.Message>) - Static method in class akka.testkit.TestKit
-
- akka$testkit$TestKitBase$_setter_$akka$testkit$TestKitBase$$queue_$eq(LinkedBlockingDeque<TestActor.Message>) - Static method in class akka.testkit.TestProbe
-
- akka$testkit$TestKitBase$_setter_$testActor_$eq(ActorRef) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- akka$testkit$TestKitBase$_setter_$testActor_$eq(ActorRef) - Static method in class akka.persistence.journal.JournalSpec
-
- akka$testkit$TestKitBase$_setter_$testActor_$eq(ActorRef) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- akka$testkit$TestKitBase$_setter_$testActor_$eq(ActorRef) - Static method in class akka.remote.testkit.MultiNodeSpec
-
- akka$testkit$TestKitBase$_setter_$testActor_$eq(ActorRef) - Static method in class akka.testkit.TestKit
-
- akka$testkit$TestKitBase$_setter_$testActor_$eq(ActorRef) - Static method in class akka.testkit.TestProbe
-
- akka$testkit$TestKitBase$_setter_$testKitSettings_$eq(TestKitSettings) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- akka$testkit$TestKitBase$_setter_$testKitSettings_$eq(TestKitSettings) - Static method in class akka.persistence.journal.JournalSpec
-
- akka$testkit$TestKitBase$_setter_$testKitSettings_$eq(TestKitSettings) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- akka$testkit$TestKitBase$_setter_$testKitSettings_$eq(TestKitSettings) - Static method in class akka.remote.testkit.MultiNodeSpec
-
- akka$testkit$TestKitBase$_setter_$testKitSettings_$eq(TestKitSettings) - Static method in class akka.testkit.TestKit
-
- akka$testkit$TestKitBase$_setter_$testKitSettings_$eq(TestKitSettings) - Static method in class akka.testkit.TestProbe
-
- akka$typed$internal$DeathWatch$$watchedBy() - Static method in class akka.typed.internal.ActorCell
-
- akka$typed$internal$DeathWatch$$watchedBy_$eq(Set<ActorRefImpl<Nothing$>>) - Static method in class akka.typed.internal.ActorCell
-
- akka$typed$internal$DeathWatch$$watching() - Static method in class akka.typed.internal.ActorCell
-
- akka$typed$internal$DeathWatch$$watching_$eq(Set<ActorRefImpl<Nothing$>>) - Static method in class akka.typed.internal.ActorCell
-
- akka$typed$internal$SupervisionMechanics$$_failed() - Static method in class akka.typed.internal.ActorCell
-
- akka$typed$internal$SupervisionMechanics$$_failed_$eq(Throwable) - Static method in class akka.typed.internal.ActorCell
-
- akka.actor - package akka.actor
-
- akka.actor.dsl - package akka.actor.dsl
-
- akka.actor.dungeon - package akka.actor.dungeon
-
- akka.actor.setup - package akka.actor.setup
-
- akka.agent - package akka.agent
-
- akka.annotation - package akka.annotation
-
- 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.client.protobuf - package akka.cluster.client.protobuf
-
- akka.cluster.client.protobuf.msg - package akka.cluster.client.protobuf.msg
-
- akka.cluster.ddata - package akka.cluster.ddata
-
- akka.cluster.ddata.protobuf - package akka.cluster.ddata.protobuf
-
- akka.cluster.ddata.protobuf.msg - package akka.cluster.ddata.protobuf.msg
-
- 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.sharding.protobuf - package akka.cluster.sharding.protobuf
-
- akka.cluster.sharding.protobuf.msg - package akka.cluster.sharding.protobuf.msg
-
- akka.cluster.singleton - package akka.cluster.singleton
-
- akka.cluster.singleton.protobuf - package akka.cluster.singleton.protobuf
-
- akka.contrib.circuitbreaker - package akka.contrib.circuitbreaker
-
- 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.japi.tuple - package akka.japi.tuple
-
- akka.kernel - package akka.kernel
-
- akka.osgi - package akka.osgi
-
- akka.pattern - package akka.pattern
-
- akka.persistence - package akka.persistence
-
- akka.persistence.fsm - package akka.persistence.fsm
-
- akka.persistence.fsm.japi.pf - package akka.persistence.fsm.japi.pf
-
- 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.query - package akka.persistence.query
-
- akka.persistence.query.javadsl - package akka.persistence.query.javadsl
-
- akka.persistence.query.journal.leveldb - package akka.persistence.query.journal.leveldb
-
- akka.persistence.query.journal.leveldb.javadsl - package akka.persistence.query.journal.leveldb.javadsl
-
- akka.persistence.query.journal.leveldb.scaladsl - package akka.persistence.query.journal.leveldb.scaladsl
-
- akka.persistence.query.scaladsl - package akka.persistence.query.scaladsl
-
- akka.persistence.scalatest - package akka.persistence.scalatest
-
- 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.artery - package akka.remote.artery
-
- akka.remote.artery.compress - package akka.remote.artery.compress
-
- 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.stream - package akka.stream
-
- akka.stream.actor - package akka.stream.actor
-
- akka.stream.extra - package akka.stream.extra
-
- akka.stream.impl - package akka.stream.impl
-
- akka.stream.impl.fusing - package akka.stream.impl.fusing
-
- akka.stream.impl.io - package akka.stream.impl.io
-
- akka.stream.impl.io.compression - package akka.stream.impl.io.compression
-
- akka.stream.javadsl - package akka.stream.javadsl
-
- akka.stream.scaladsl - package akka.stream.scaladsl
-
- akka.stream.stage - package akka.stream.stage
-
- akka.stream.testkit - package akka.stream.testkit
-
- akka.stream.testkit.javadsl - package akka.stream.testkit.javadsl
-
- akka.stream.testkit.scaladsl - package akka.stream.testkit.scaladsl
-
- akka.testkit - package akka.testkit
-
- akka.typed - package akka.typed
-
- akka.typed.adapter - package akka.typed.adapter
-
- akka.typed.internal - package akka.typed.internal
-
- 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
-
- AkkaLoggerBridge - Class in com.typesafe.sslconfig.akka.util
-
- AkkaLoggerBridge(EventStream, String, Class<?>) - Constructor for class com.typesafe.sslconfig.akka.util.AkkaLoggerBridge
-
- AkkaLoggerBridge(EventStream, Class<?>) - Constructor for class com.typesafe.sslconfig.akka.util.AkkaLoggerBridge
-
- AkkaLoggerFactory - Class in com.typesafe.sslconfig.akka.util
-
- AkkaLoggerFactory(ActorSystem) - Constructor for class com.typesafe.sslconfig.akka.util.AkkaLoggerFactory
-
- 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
-
- AkkaSSLConfig - Class in com.typesafe.sslconfig.akka
-
- AkkaSSLConfig(ExtendedActorSystem, SSLConfigSettings) - Constructor for class com.typesafe.sslconfig.akka.AkkaSSLConfig
-
- AkkaSSLConfig$ - Class in com.typesafe.sslconfig.akka
-
- AkkaSSLConfig$() - Constructor for class com.typesafe.sslconfig.akka.AkkaSSLConfig$
-
- alert() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- alert() - Static method in class akka.persistence.journal.JournalSpec
-
- alert() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- alert(int, byte[]) - Method in interface akka.remote.artery.EventSink
-
- alert(int, byte[]) - Method in class akka.remote.artery.IgnoreEventSink$
-
- alert(int, byte[]) - Static method in class akka.remote.artery.IgnoreEventSink
-
- alert(int, byte[]) - Method in class akka.remote.artery.SynchronizedEventSink
-
- alertLog() - Method in class akka.remote.artery.FlightRecorderReader.Structure
-
- AlertLogSize() - Method in class akka.remote.artery.FlightRecorder$
-
- AlertLogSize() - Static method in class akka.remote.artery.FlightRecorder
-
- AlertRecordSize() - Method in class akka.remote.artery.FlightRecorder$
-
- AlertRecordSize() - Static method in class akka.remote.artery.FlightRecorder
-
- AlertSectionOffset() - Method in class akka.remote.artery.FlightRecorder$
-
- AlertSectionOffset() - Static method in class akka.remote.artery.FlightRecorder
-
- AlertSectionParameters() - Method in class akka.remote.artery.FlightRecorderReader$
-
- AlertSectionParameters() - Static method in class akka.remote.artery.FlightRecorderReader
-
- AlertSectionSize() - Method in class akka.remote.artery.FlightRecorder$
-
- AlertSectionSize() - Static method in class akka.remote.artery.FlightRecorder
-
- AlertWindow() - Method in class akka.remote.artery.FlightRecorder$
-
- AlertWindow() - Static method in class akka.remote.artery.FlightRecorder
-
- alias() - Method in class akka.serialization.SerializerDetails
-
- Alignment() - Method in class akka.remote.artery.FlightRecorder$
-
- Alignment() - Static method in class akka.remote.artery.FlightRecorder
-
- aliveRegions() - Method in class akka.cluster.sharding.ShardCoordinator
-
- all(C, Collecting<E, C>, Prettifier, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- all(JMAP, Collecting<Entry<K, V>, JMAP>, Prettifier, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- all(String, Collecting<Object, String>, Prettifier, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- all(C, Collecting<E, C>, Prettifier, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- all(JMAP, Collecting<Entry<K, V>, JMAP>, Prettifier, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- all(String, Collecting<Object, String>, Prettifier, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- all(C, Collecting<E, C>, Prettifier, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- all(JMAP, Collecting<Entry<K, V>, JMAP>, Prettifier, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- all(String, Collecting<Object, String>, Prettifier, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- 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
-
- allAssociations() - Method in class akka.remote.artery.AssociationRegistry
-
- AllAtOnceEntityRecoveryStrategy - Class in akka.cluster.sharding
-
- AllAtOnceEntityRecoveryStrategy() - Constructor for class akka.cluster.sharding.AllAtOnceEntityRecoveryStrategy
-
- 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 suppressed ones).
- allElementsOf(GenTraversable<R>) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- allElementsOf(GenTraversable<R>) - Static method in class akka.persistence.journal.JournalSpec
-
- allElementsOf(GenTraversable<R>) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- 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
-
- allInlets() - Method in class akka.stream.AbstractShape
-
Provide the list of all input ports of this shape.
- 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.
- allocateShardHomesForRememberEntities() - Method in class akka.cluster.sharding.ShardCoordinator
-
- allocationStrategy() - Method in class akka.cluster.sharding.ClusterShardingGuardian.Start
-
- allOf(Object, Object, Seq<Object>, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- allOf(Object, Object, Seq<Object>, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- allOf(Object, Object, Seq<Object>, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- allOf(ClassTag<T>) - Method in class akka.typed.DeploymentConfig
-
Retrieve all configuration nodes of a given type in the order that they
are present in this DeploymentConfig.
- allOf(ClassTag<T>) - Static method in class akka.typed.DispatcherDefault
-
- allOf(ClassTag<T>) - Static method in class akka.typed.DispatcherFromConfig
-
- allOf(ClassTag<T>) - Static method in class akka.typed.DispatcherFromExecutionContext
-
- allOf(ClassTag<T>) - Static method in class akka.typed.DispatcherFromExecutor
-
- allOf(ClassTag<T>) - Static method in class akka.typed.EmptyDeploymentConfig
-
- allOf(ClassTag<T>) - Static method in class akka.typed.MailboxCapacity
-
- AllOfMarkedInputs() - Method in class akka.stream.impl.FanIn.InputBunch
-
- AllOfMarkedOutputs() - Method in class akka.stream.impl.FanOut.OutputBunch
-
Will only transfer an element when all marked outputs
have demand, and will complete as soon as any of the marked
outputs have canceled.
- allOutlets() - Method in class akka.stream.AbstractShape
-
Provide the list of all output ports of this shape.
- 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
- AllowJavaSerialization() - Method in class akka.actor.ActorSystem.Settings
-
- AllowJavaSerialization() - Method in class akka.serialization.Serialization
-
- allowLocalRoutees() - Method in class akka.cluster.routing.ClusterRouterGroupSettings
-
- allowLocalRoutees() - Method in class akka.cluster.routing.ClusterRouterPoolSettings
-
- allowLocalRoutees() - Method in interface akka.cluster.routing.ClusterRouterSettingsBase
-
- allowNull() - Static method in class akka.camel.internal.component.DurationTypeConverter
-
- AllowWeaklyUpMembers() - Method in class akka.cluster.ClusterSettings
-
- allPersistenceIds() - Method in interface akka.persistence.journal.leveldb.LeveldbIdMapping
-
- allPersistenceIds() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- allPersistenceIds() - Method in class akka.persistence.journal.leveldb.LeveldbJournal.CurrentPersistenceIds
-
- allPersistenceIds() - Method in interface akka.persistence.query.javadsl.AllPersistenceIdsQuery
-
Query all PersistentActor
identifiers, i.e.
- allPersistenceIds() - Method in class akka.persistence.query.journal.leveldb.javadsl.LeveldbReadJournal
-
allPersistenceIds
is used for retrieving all persistenceIds
of all
persistent actors.
- allPersistenceIds() - Method in class akka.persistence.query.journal.leveldb.scaladsl.LeveldbReadJournal
-
allPersistenceIds
is used for retrieving all persistenceIds
of all
persistent actors.
- allPersistenceIds() - Method in interface akka.persistence.query.scaladsl.AllPersistenceIdsQuery
-
Query all PersistentActor
identifiers, i.e.
- AllPersistenceIdsPublisher - Class in akka.persistence.query.journal.leveldb
-
INTERNAL API
- AllPersistenceIdsPublisher(boolean, int, String) - Constructor for class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher
-
- AllPersistenceIdsPublisher$ - Class in akka.persistence.query.journal.leveldb
-
INTERNAL API
- AllPersistenceIdsPublisher$() - Constructor for class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher$
-
- AllPersistenceIdsQuery - Interface in akka.persistence.query.javadsl
-
A plugin may optionally support this query by implementing this interface.
- AllPersistenceIdsQuery - Interface in akka.persistence.query.scaladsl
-
A plugin may optionally support this query by implementing this trait.
- allReachableClockTime() - Method in class akka.cluster.ddata.Replicator
-
- AllRead$() - Constructor for class akka.io.TcpConnection.AllRead$
-
- allRegionsRegistered() - Method in class akka.cluster.sharding.ShardCoordinator
-
- 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
-
- allStrategy() - Method in class akka.cluster.sharding.EntityRecoveryStrategy$
-
- 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
-
- alsoTo(Graph<SinkShape<Out>, ?>) - Static method in class akka.stream.impl.SubFlowImpl
-
- alsoTo(Graph<SinkShape<Out>, ?>) - Method in class akka.stream.javadsl.Flow
-
Attaches the given
Sink
to this
Flow
, meaning that elements that passes
through will also be sent to the
Sink
.
- alsoTo(Graph<SinkShape<Out>, ?>) - Method in class akka.stream.javadsl.Source
-
Attaches the given
Sink
to this
Flow
, meaning that elements that passes
through will also be sent to the
Sink
.
- alsoTo(Graph<SinkShape<Out>, ?>) - Method in class akka.stream.javadsl.SubFlow
-
Attaches the given
Sink
to this
Flow
, meaning that elements that passes
through will also be sent to the
Sink
.
- alsoTo(Graph<SinkShape<Out>, ?>) - Method in class akka.stream.javadsl.SubSource
-
Attaches the given
Sink
to this
Flow
, meaning that elements that passes
through will also be sent to the
Sink
.
- alsoTo(Graph<SinkShape<Out>, ?>) - Static method in class akka.stream.scaladsl.Flow
-
- alsoTo(Graph<SinkShape<Out>, ?>) - Method in interface akka.stream.scaladsl.FlowOps
-
Attaches the given
Sink
to this
Flow
, meaning that elements that passes
through will also be sent to the
Sink
.
- alsoTo(Graph<SinkShape<Out>, ?>) - Static method in class akka.stream.scaladsl.Source
-
- alsoToGraph(Graph<SinkShape<Out>, M>) - Static method in class akka.stream.impl.SubFlowImpl
-
- alsoToGraph(Graph<SinkShape<Out>, M>) - Static method in class akka.stream.scaladsl.Flow
-
- alsoToGraph(Graph<SinkShape<Out>, M>) - Method in interface akka.stream.scaladsl.FlowOps
-
- alsoToGraph(Graph<SinkShape<Out>, M>) - Static method in class akka.stream.scaladsl.Source
-
- alsoToMat(Graph<SinkShape<Out>, M2>, Function2<Mat, M2, M3>) - Method in class akka.stream.javadsl.Flow
-
Attaches the given
Sink
to this
Flow
, meaning that elements that passes
through will also be sent to the
Sink
.
- alsoToMat(Graph<SinkShape<Out>, M2>, Function2<Mat, M2, M3>) - Method in class akka.stream.javadsl.Source
-
Attaches the given
Sink
to this
Flow
, meaning that elements that passes
through will also be sent to the
Sink
.
- alsoToMat(Graph<SinkShape<Out>, Mat2>, Function2<Mat, Mat2, Mat3>) - Static method in class akka.stream.scaladsl.Flow
-
- alsoToMat(Graph<SinkShape<Out>, Mat2>, Function2<Mat, Mat2, Mat3>) - Method in interface akka.stream.scaladsl.FlowOpsMat
-
Attaches the given
Sink
to this
Flow
, meaning that elements that passes
through will also be sent to the
Sink
.
- alsoToMat(Graph<SinkShape<Out>, Mat2>, Function2<Mat, Mat2, Mat3>) - Static method in class akka.stream.scaladsl.Source
-
- 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.
- Always - Class in akka.stream.impl
-
INTERNAL API
- Always() - Constructor for class akka.stream.impl.Always
-
- Always$ - Class in akka.stream.impl
-
INTERNAL API
- Always$() - Constructor for class akka.stream.impl.Always$
-
- amendConfig(Config) - Method in class akka.dispatch.BalancingDispatcherConfigurator$
-
- amendConfig(Config) - Static method in class akka.dispatch.BalancingDispatcherConfigurator
-
- amendShape(Attributes) - Method in class akka.stream.impl.SinkModule
-
- amendShape(Attributes) - Method in class akka.stream.impl.SourceModule
-
- AmorphousShape - Class in akka.stream
-
This type of
Shape
can express any number of inputs and outputs at the
expense of forgetting about their specific types.
- AmorphousShape(Seq<Inlet<?>>, Seq<Outlet<?>>) - Constructor for class akka.stream.AmorphousShape
-
- AmorphousShape$ - Class in akka.stream
-
- AmorphousShape$() - Constructor for class akka.stream.AmorphousShape$
-
- an(ClassTag<T>) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- an() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- an(ClassTag<T>) - Static method in class akka.persistence.journal.JournalSpec
-
- an() - Static method in class akka.persistence.journal.JournalSpec
-
- an() - Method in class akka.persistence.PluginSpec
-
- an(ClassTag<T>) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- an() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- anchor() - Method in class akka.actor.ActorSelection
-
- anchorPath() - Method in class akka.actor.ActorSelection
-
- and(Setup) - Static method in class akka.actor.BootstrapSetup
-
- and(T) - Method in class akka.actor.setup.ActorSystemSetup
-
alias for
withSetting
allowing for fluent combination of settings:
a and b and c
, where
a
,
b
and
c
are
concrete
Setup
instances.
- and(Setup) - Method in class akka.actor.setup.Setup
-
- and(Setup) - Static method in class akka.serialization.SerializationSetup
-
- and(Attributes) - Method in class akka.stream.Attributes
-
Adds given attributes to the end of these attributes.
- and(Attributes.Attribute) - Method in class akka.stream.Attributes
-
Adds given attribute to the end of these attributes.
- And(Behavior<T>, Behavior<T>) - Constructor for class akka.typed.ScalaDSL.And
-
- And$() - Constructor for class akka.typed.ScalaDSL.And$
-
- andAfter(Function0<BoxedUnit>) - Method in class akka.contrib.pattern.ReceivePipeline.Inner
-
Add a block of code to be executed after the message (which may be further transformed and processed by
inner interceptors) is handled by the actor's receive.
- andThen(Function1<B, C>) - Static method in class akka.event.LoggingReceive
-
- andThen(Function1<B, C>) - Static method in class akka.japi.JavaPartialFunction
-
- andThen(Function1<B, C>) - Static method in class akka.japi.pf.CaseStatement
-
- andThen(Function1<D, BoxedUnit>) - Method in class akka.persistence.fsm.PersistentFSM.State
-
Register a handler to be triggered after the state has been persisted successfully
- andThen(Stages.SymbolicStage<Out, T>) - Static method in class akka.stream.impl.SubFlowImpl
-
- andThen() - Method in class akka.stream.impl.WaitingForUpstreamSubscription
-
- andThen(Stages.SymbolicStage<Out, T>) - Static method in class akka.stream.scaladsl.Flow
-
- andThen(Stages.SymbolicStage<Out, T>) - Method in interface akka.stream.scaladsl.FlowOps
-
INTERNAL API
- andThen(Stages.SymbolicStage<Out, T>) - Static method in class akka.stream.scaladsl.Source
-
- andThen(Function1<B, C>) - Static method in class akka.util.ByteString
-
- andThen(Function1<B, C>) - Static method in class akka.util.CompactByteString
-
- 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.
- anyEvent(FI.Apply2<Object, D, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.japi.pf.FSMStateFunctionBuilder
-
Add a case statement that matches on any type of event.
- AnyOfMarkedInputs() - Method in class akka.stream.impl.FanIn.InputBunch
-
- AnyOfMarkedOutputs() - Method in class akka.stream.impl.FanOut.OutputBunch
-
Will transfer an element when any of the marked outputs
have demand, and will complete when all of the marked
outputs have canceled.
- ap() - Method in class akka.testkit.TestActor.SetAutoPilot
-
- apiCommand() - Method in class akka.io.SelectionHandler.WorkerForCommand
-
- ApiMayChange - Annotation Type in akka.annotation
-
Marks APIs that are meant to evolve towards becoming stable APIs, but are not stable APIs yet.
- 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.
- append(Object, ActorRef) - Method in class akka.util.MessageBuffer
-
Add one element to the end of the message buffer.
- append(I, Object, ActorRef) - Method in class akka.util.MessageBufferMap
-
Append an element to the buffer for an id.
- appendToBuilder(ByteStringBuilder) - Method in class akka.util.ByteString.ByteString1C
-
INTERNAL API: Specialized for internal use, appending ByteString1C to a ByteStringBuilder.
- 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, ActorSystemSetup) - Method in class akka.actor.ActorSystem$
-
Scala API: Creates a new actor system with the specified name and settings
The core actor system settings are defined in
BootstrapSetup
- apply(String, BootstrapSetup) - Method in class akka.actor.ActorSystem$
-
Scala API: Shortcut for creating an actor system with custom bootstrap settings.
- 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, ActorSystemSetup) - Static method in class akka.actor.ActorSystem
-
Scala API: Creates a new actor system with the specified name and settings
The core actor system settings are defined in
BootstrapSetup
- apply(String, BootstrapSetup) - Static method in class akka.actor.ActorSystem
-
Scala API: Shortcut for creating an actor system with custom bootstrap settings.
- 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() - Method in class akka.actor.BootstrapSetup$
-
Scala API: Construct a bootstrap settings with default values.
- apply(Option<ClassLoader>, Option<Config>, Option<ExecutionContext>) - Method in class akka.actor.BootstrapSetup$
-
Scala API: Create bootstrap settings needed for starting the actor system
- apply(Config) - Method in class akka.actor.BootstrapSetup$
-
Scala API: Short for using custom config but keeping default classloader and default execution context
- apply() - Static method in class akka.actor.BootstrapSetup
-
Scala API: Construct a bootstrap settings with default values.
- apply(Option<ClassLoader>, Option<Config>, Option<ExecutionContext>) - Static method in class akka.actor.BootstrapSetup
-
Scala API: Create bootstrap settings needed for starting the actor system
- apply(Config) - Static method in class akka.actor.BootstrapSetup
-
Scala API: Short for using custom config but keeping default classloader and default execution context
- 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$
-
Scala API: Returns a Props that has default values except for "creator" which will be a function that creates an instance
of the supplied type using the default constructor.
- apply(Function0<T>, ClassTag<T>) - Method in class akka.actor.Props$
-
Scala API: Returns a Props that has default values except for "creator" which will be a function that creates an instance
using the supplied thunk.
- apply(Class<?>, Seq<Object>) - Method in class akka.actor.Props$
-
Scala API: create a Props given a class and its constructor arguments.
- apply(ClassTag<T>) - Static method in class akka.actor.Props
-
Scala API: Returns a Props that has default values except for "creator" which will be a function that creates an instance
of the supplied type using the default constructor.
- apply(Function0<T>, ClassTag<T>) - Static method in class akka.actor.Props
-
Scala API: Returns a Props that has default values except for "creator" which will be a function that creates an instance
using the supplied thunk.
- apply(Class<?>, Seq<Object>) - Static method in class akka.actor.Props
-
Scala API: create a Props given a class and its constructor arguments.
- apply(ActorRef) - Method in class akka.actor.SerializedActorRef$
-
- apply(ActorRef) - Static method in class akka.actor.SerializedActorRef
-
- apply(Seq<Setup>) - Method in class akka.actor.setup.ActorSystemSetup$
-
- apply(Seq<Setup>) - Static method in class akka.actor.setup.ActorSystemSetup
-
- 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(ActorSystem) - Static method in class akka.camel.CamelExtension
-
- apply(Object, Map<String, Object>) - Method in class akka.camel.CamelMessage$
-
Returns a new CamelMessage based on the body
and headers
.
- apply(Object, Map<String, Object>, Map<String, DataHandler>) - Method in class akka.camel.CamelMessage$
-
Returns a new CamelMessage based on the body
, headers
and attachments
.
- apply(Object, Map<String, Object>) - Static method in class akka.camel.CamelMessage
-
Returns a new CamelMessage based on the body
and headers
.
- apply(Object, Map<String, Object>, Map<String, DataHandler>) - Static method in class akka.camel.CamelMessage
-
Returns a new CamelMessage based on the body
, headers
and attachments
.
- 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() - Method in class akka.cluster.ddata.Flag$
-
- apply() - Static method in class akka.cluster.ddata.Flag
-
- apply() - Method in class akka.cluster.ddata.GCounter$
-
- apply() - Static method in class akka.cluster.ddata.GCounter
-
- apply() - Method in class akka.cluster.ddata.GSet$
-
- apply() - Static method in class akka.cluster.ddata.GSet
-
- apply() - Method in class akka.cluster.ddata.LWWMap$
-
- apply() - Static method in class akka.cluster.ddata.LWWMap
-
- apply(UniqueAddress, A, LWWRegister.Clock<A>) - Method in class akka.cluster.ddata.LWWRegister$
-
INTERNAL API
- apply(A, Cluster, LWWRegister.Clock<A>) - Method in class akka.cluster.ddata.LWWRegister$
-
- apply(UniqueAddress, A, LWWRegister.Clock<A>) - Static method in class akka.cluster.ddata.LWWRegister
-
INTERNAL API
- apply(A, Cluster, LWWRegister.Clock<A>) - Static method in class akka.cluster.ddata.LWWRegister
-
- apply(long, A) - Method in interface akka.cluster.ddata.LWWRegister.Clock
-
- apply() - Method in class akka.cluster.ddata.ORMap$
-
- apply() - Static method in class akka.cluster.ddata.ORMap
-
- apply() - Method in class akka.cluster.ddata.ORMultiMap$
-
- apply() - Static method in class akka.cluster.ddata.ORMultiMap
-
- apply() - Method in class akka.cluster.ddata.ORSet$
-
- apply() - Static method in class akka.cluster.ddata.ORSet
-
- apply() - Method in class akka.cluster.ddata.PNCounter$
-
- apply() - Static method in class akka.cluster.ddata.PNCounter
-
- apply() - Method in class akka.cluster.ddata.PNCounterMap$
-
- apply() - Static method in class akka.cluster.ddata.PNCounterMap
-
- apply(Key<A>, A, Replicator.WriteConsistency, Option<Object>, Function1<A, A>) - Method in class akka.cluster.ddata.Replicator.Update$
-
Modify value of local Replicator
and replicate with given writeConsistency
.
- apply(ActorSystem) - Method in class akka.cluster.ddata.ReplicatorSettings$
-
Create settings from the default configuration
akka.cluster.distributed-data
.
- apply(Config) - Method in class akka.cluster.ddata.ReplicatorSettings$
-
Create settings from a configuration with the same layout as
the default configuration akka.cluster.distributed-data
.
- apply(ActorSystem) - Static method in class akka.cluster.ddata.ReplicatorSettings
-
Create settings from the default configuration
akka.cluster.distributed-data
.
- apply(Config) - Static method in class akka.cluster.ddata.ReplicatorSettings
-
Create settings from a configuration with the same layout as
the default configuration akka.cluster.distributed-data
.
- apply() - Method in class akka.cluster.ddata.VersionVector$
-
- apply(TreeMap<UniqueAddress, Object>) - Method in class akka.cluster.ddata.VersionVector$
-
- apply(UniqueAddress, long) - Method in class akka.cluster.ddata.VersionVector$
-
- apply(List<Tuple2<UniqueAddress, Object>>) - Method in class akka.cluster.ddata.VersionVector$
-
INTERNAL API
- apply() - Static method in class akka.cluster.ddata.VersionVector
-
- apply(TreeMap<UniqueAddress, Object>) - Static method in class akka.cluster.ddata.VersionVector
-
- apply(UniqueAddress, long) - Static method in class akka.cluster.ddata.VersionVector
-
- apply(List<Tuple2<UniqueAddress, Object>>) - Static method in class akka.cluster.ddata.VersionVector
-
INTERNAL API
- 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$
-
Deprecated.
- 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.sharding.ClusterShardingSettings$
-
Create settings from the default configuration
akka.cluster.sharding
.
- apply(Config) - Method in class akka.cluster.sharding.ClusterShardingSettings$
-
Create settings from a configuration with the same layout as
the default configuration akka.cluster.sharding
.
- apply(ActorSystem) - Static method in class akka.cluster.sharding.ClusterShardingSettings
-
Create settings from the default configuration
akka.cluster.sharding
.
- apply(Config) - Static method in class akka.cluster.sharding.ClusterShardingSettings
-
Create settings from a configuration with the same layout as
the default configuration akka.cluster.sharding
.
- 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(Address, int) - Method in class akka.cluster.UniqueAddress$
-
- apply(Address, int) - Static method in class akka.cluster.UniqueAddress
-
- 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
-
Deprecated.
- apply(T) - Method in class akka.dispatch.japi.CallbackBridge
-
Deprecated.
- apply(Throwable) - Method in class akka.dispatch.japi.RecoverBridge
-
Deprecated.
- apply(T) - Method in class akka.dispatch.japi.UnitFunctionBridge
-
Deprecated.
- 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, Map<String, Object>, LogMarker) - Method in class akka.event.Logging.Debug$
-
- apply(String, Class<?>, Object) - Method in class akka.event.Logging.Error$
-
- apply(String, Class<?>, Object, LogMarker) - Method in class akka.event.Logging.Error$
-
- apply(Throwable, String, Class<?>, Object, Map<String, Object>) - Method in class akka.event.Logging.Error$
-
- apply(Throwable, String, Class<?>, Object, Map<String, Object>, LogMarker) - 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>, LogMarker) - 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>, LogMarker) - Method in class akka.event.Logging.Info$
-
- apply(Logging.LogLevel, String, Class<?>, Object) - Method in class akka.event.Logging.LogEvent$
-
- apply(Logging.LogLevel, String, Class<?>, Object, Map<String, Object>) - Method in class akka.event.Logging.LogEvent$
-
- apply(Logging.LogLevel, String, Class<?>, Object, Map<String, Object>, LogMarker) - Method in class akka.event.Logging.LogEvent$
-
- apply(String, Class<?>, Object, Map<String, Object>) - Method in class akka.event.Logging.Warning$
-
- apply(String, Class<?>, Object, Map<String, Object>, LogMarker) - 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(Logging.LogLevel, PartialFunction<Object, BoxedUnit>, ActorContext) - Method in class akka.event.LoggingReceive$
-
Wrap a Receive partial function in a logging enclosure, which sends a
message with given log level to the event bus each time before a message is matched.
- apply(Object) - Method in class akka.event.LoggingReceive
-
- apply(String) - Method in class akka.event.LogMarker$
-
- apply(String) - Static method in class akka.event.LogMarker
-
- apply(T, LogSource<T>) - Method in class akka.event.LogSource$
-
- apply(T, ActorSystem, LogSource<T>) - Method in class akka.event.LogSource$
-
- 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(ActorSystem) - Static method in class akka.io.Tcp
-
- 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(ActorSystem) - Static method in class akka.io.Udp
-
- apply(ByteString, InetSocketAddress) - Method in class akka.io.Udp.Send$
-
- apply(ActorSystem) - Static method in class akka.io.UdpConnected
-
- 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(I1, I2, I3, I4) - Method in interface akka.japi.pf.FI.UnitApply4
-
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(ActorRefProvider, Timeout) - Method in class akka.pattern.AskPromiseRef$
-
- apply(ActorRefProvider, Timeout) - Static method in class akka.pattern.AskPromiseRef
-
- 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(ActorSystem, Timeout) - Method in class akka.pattern.FutureRef$
-
Constructs a new FutureRef which will be completed with the first message sent to it.
- apply(Timeout, ActorSystem) - Method in class akka.pattern.FutureRef$
-
Constructs a new PromiseRef which will be completed with the first message sent to it.
- 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(ActorSystem, Timeout) - Method in class akka.pattern.PromiseRef$
-
Constructs a new PromiseRef which will be completed with the first message sent to it.
- apply(Timeout, ActorSystem) - Method in class akka.pattern.PromiseRef$
-
Constructs a new PromiseRef which will be completed with the first message sent to it.
- apply(PersistentRepr) - Method in class akka.persistence.AtomicWrite$
-
- apply(PersistentRepr) - Static method in class akka.persistence.AtomicWrite
-
- apply(Object) - Method in class akka.persistence.fsm.PersistentFSM.NullFunction$
-
- apply(ExtendedActorSystem, Config) - Method in class akka.persistence.journal.EventAdapters$
-
- apply(ExtendedActorSystem, Config) - Static method in class akka.persistence.journal.EventAdapters
-
- apply(Seq<Object>) - Method in class akka.persistence.journal.EventSeq$
-
- apply(Seq<Object>) - Static method in class akka.persistence.journal.EventSeq
-
- apply(ActorSystem) - Static method in class akka.persistence.journal.PersistencePluginProxyExtension
-
- apply(Object, long, String, String, boolean, ActorRef, String) - 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(Config) - Method in class akka.remote.artery.ArterySettings$
-
- apply(Config) - Static method in class akka.remote.artery.ArterySettings
-
- apply() - Method in class akka.remote.artery.AssociationState$
-
- apply() - Static method in class akka.remote.artery.AssociationState
-
- apply(OptionVal<InternalActorRef>, Object, OptionVal<ActorRef>, long, OptionVal<OutboundContext>) - Method in class akka.remote.artery.InboundEnvelope$
-
Only used in tests
- apply(OptionVal<RemoteActorRef>, Object, OptionVal<ActorRef>) - Method in class akka.remote.artery.OutboundEnvelope$
-
- apply(ExtendedActorSystem) - Method in class akka.remote.artery.RemoteInstruments$
-
- apply(ExtendedActorSystem) - Static method in class akka.remote.artery.RemoteInstruments
-
- 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(Address, int) - Method in class akka.remote.QuarantinedEvent$
-
- apply(Address, int) - Static method in class akka.remote.QuarantinedEvent
-
- apply(ActorSystem) - Static method in class akka.remote.RemoteMetricsExtension
-
- 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, MarkerLoggingAdapter, boolean) - Method in class akka.remote.transport.netty.NettySSLSupport$
-
Construct a SSLHandler which can be inserted into a Netty server/client pipeline
- apply(SSLSettings, MarkerLoggingAdapter, 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(ActorSystem) - Static method in class akka.remote.transport.TransportAdaptersExtension
-
- 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(Config) - Method in class akka.routing.OptimalSizeExploringResizer$
-
- 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(ActorSystem) - Static method in class akka.serialization.SerializationExtension
-
- apply(Function1<ExtendedActorSystem, Seq<SerializerDetails>>) - Method in class akka.serialization.SerializationSetup$
-
Scala API: Programmatic definition of serializers
- apply(Function1<ExtendedActorSystem, Seq<SerializerDetails>>) - Static method in class akka.serialization.SerializationSetup
-
Scala API: Programmatic definition of serializers
- apply(String, Serializer, Seq<Class<?>>) - Method in class akka.serialization.SerializerDetails$
-
Scala API: factory for details about one programmatically setup serializer
- apply(String, Serializer, Seq<Class<?>>) - Static method in class akka.serialization.SerializerDetails
-
Scala API: factory for details about one programmatically setup serializer
- apply(ActorRef) - Method in class akka.stream.actor.ActorPublisher$
-
- apply(ActorRef) - Method in class akka.stream.actor.ActorSubscriber$
-
- apply(int) - Method in class akka.stream.actor.WatermarkRequestStrategy$
-
- apply(int) - Static method in class akka.stream.actor.WatermarkRequestStrategy
-
- apply(Option<ActorMaterializerSettings>, Option<String>, ActorRefFactory) - Method in class akka.stream.ActorMaterializer$
-
Scala API: Creates an ActorMaterializer which will execute every step of a transformation
pipeline within its own
Actor
.
- apply(ActorMaterializerSettings, String, ActorRefFactory) - Method in class akka.stream.ActorMaterializer$
-
Scala API: Creates an ActorMaterializer which will execute every step of a transformation
pipeline within its own
Actor
.
- apply(ActorMaterializerSettings, ActorRefFactory) - Method in class akka.stream.ActorMaterializer$
-
Scala API: Creates an ActorMaterializer which will execute every step of a transformation
pipeline within its own
Actor
.
- apply(Option<ActorMaterializerSettings>, Option<String>, ActorRefFactory) - Static method in class akka.stream.ActorMaterializer
-
Scala API: Creates an ActorMaterializer which will execute every step of a transformation
pipeline within its own
Actor
.
- apply(ActorMaterializerSettings, String, ActorRefFactory) - Static method in class akka.stream.ActorMaterializer
-
Scala API: Creates an ActorMaterializer which will execute every step of a transformation
pipeline within its own
Actor
.
- apply(ActorMaterializerSettings, ActorRefFactory) - Static method in class akka.stream.ActorMaterializer
-
Scala API: Creates an ActorMaterializer which will execute every step of a transformation
pipeline within its own
Actor
.
- apply(int, int, String, Function1<Throwable, Supervision.Directive>, StreamSubscriptionTimeoutSettings, boolean, int, boolean, boolean, int) - Method in class akka.stream.ActorMaterializerSettings$
-
- apply(ActorSystem) - Method in class akka.stream.ActorMaterializerSettings$
-
- apply(Config) - Method in class akka.stream.ActorMaterializerSettings$
-
- apply(int, int, String, Function1<Throwable, Supervision.Directive>, StreamSubscriptionTimeoutSettings, boolean, int, boolean, boolean, int) - Static method in class akka.stream.ActorMaterializerSettings
-
- apply(ActorSystem) - Static method in class akka.stream.ActorMaterializerSettings
-
- apply(Config) - Static method in class akka.stream.ActorMaterializerSettings
-
- apply(Attributes.Attribute) - Method in class akka.stream.Attributes$
-
INTERNAL API
- apply(Attributes.Attribute) - Static method in class akka.stream.Attributes
-
INTERNAL API
- apply(ActorRef) - Method in class akka.stream.impl.ActorProcessor$
-
- apply(ActorRef) - Static method in class akka.stream.impl.ActorProcessor
-
- apply(ActorRef) - Method in class akka.stream.impl.ActorPublisher$
-
- apply(ActorRef) - Static method in class akka.stream.impl.ActorPublisher
-
- apply(int, ActorMaterializerSettings) - Method in class akka.stream.impl.Buffer$
-
- apply(int, Materializer) - Method in class akka.stream.impl.Buffer$
-
- apply(int, int) - Method in class akka.stream.impl.Buffer$
-
- apply() - Method in class akka.stream.impl.EmptyPublisher$
-
- apply() - Static method in class akka.stream.impl.EmptyPublisher
-
- apply() - Method in class akka.stream.impl.ErrorPublisher
-
- apply(Object) - Method in class akka.stream.impl.ExposedPublisherReceive
-
- apply(int) - Method in class akka.stream.impl.FixedSizeBuffer$
-
INTERNAL API
- apply(int) - Static method in class akka.stream.impl.FixedSizeBuffer
-
INTERNAL API
- apply(Seq<Inlet<?>>, Seq<Outlet<?>>, Seq<GraphStageWithMaterializedValue<Shape, ?>>) - Method in class akka.stream.impl.fusing.GraphInterpreter.GraphAssembly$
-
INTERNAL API
- apply(Try<T>) - Method in class akka.stream.impl.fusing.MapAsync.Holder
-
- apply(FiniteDuration, Option<InetSocketAddress>) - Method in class akka.stream.impl.io.TcpIdleTimeout$
-
- apply(FiniteDuration, Option<InetSocketAddress>) - Static method in class akka.stream.impl.io.TcpIdleTimeout
-
- apply(Attributes, Function1<ActorSystem, SSLEngine>, Function2<ActorSystem, SSLSession, Try<BoxedUnit>>, TLSClosing) - Method in class akka.stream.impl.io.TlsModule$
-
- apply(Attributes, Function1<ActorSystem, SSLEngine>, Function2<ActorSystem, SSLSession, Try<BoxedUnit>>, TLSClosing) - Static method in class akka.stream.impl.io.TlsModule
-
- apply(Function0<Source<T, M>>) - Method in class akka.stream.impl.LazySource$
-
- apply(Function0<Source<T, M>>) - Static method in class akka.stream.impl.LazySource
-
- apply() - Method in class akka.stream.impl.RejectAdditionalSubscribers$
-
- apply() - Static method in class akka.stream.impl.RejectAdditionalSubscribers
-
- apply(String) - Method in class akka.stream.impl.SeqActorName$
-
- apply(String) - Static method in class akka.stream.impl.SeqActorName
-
- apply(StreamLayout.Module, Shape) - Method in class akka.stream.impl.StreamLayout.CompositeModule$
-
- apply(StreamLayout.MaterializedValueNode) - Method in class akka.stream.impl.StreamLayout.IgnorableMatValComp$
-
- apply(StreamLayout.Module) - Method in class akka.stream.impl.StreamLayout.IgnorableMatValComp$
-
- apply(Flow<In, T, NotUsed>, int) - Method in interface akka.stream.impl.SubFlowImpl.MergeBack
-
- apply(Object) - Method in class akka.stream.impl.SubReceive
-
- apply(Subscriber<T>) - Method in class akka.stream.impl.SubscriberManagement.Completed$
-
- apply(Subscriber<T>) - Method in interface akka.stream.impl.SubscriberManagement.EndOfStream
-
- apply(Subscriber<T>) - Method in class akka.stream.impl.SubscriberManagement.ErrorCompleted
-
- apply(Subscriber<T>) - Method in class akka.stream.impl.SubscriberManagement.NotReached$
-
- apply(String) - Method in class akka.stream.Inlet$
-
Scala API
- apply(String) - Static method in class akka.stream.Inlet
-
Scala API
- apply(String) - Method in class akka.stream.Outlet$
-
Scala API
- apply(String) - Static method in class akka.stream.Outlet
-
Scala API
- apply(int, boolean) - Method in class akka.stream.scaladsl.Balance$
-
Create a new Balance
with the specified number of output ports.
- apply(int, boolean) - Static method in class akka.stream.scaladsl.Balance
-
Create a new Balance
with the specified number of output ports.
- apply(int, boolean) - Method in class akka.stream.scaladsl.Broadcast$
-
Create a new Broadcast
with the specified number of output ports.
- apply(int, boolean) - Static method in class akka.stream.scaladsl.Broadcast
-
Create a new Broadcast
with the specified number of output ports.
- apply(int) - Method in class akka.stream.scaladsl.Concat$
-
Create a new Concat
.
- apply(int) - Static method in class akka.stream.scaladsl.Concat
-
Create a new Concat
.
- apply() - Method in class akka.stream.scaladsl.Flow$
-
Returns a Flow
which outputs all its inputs.
- apply() - Static method in class akka.stream.scaladsl.Flow
-
Returns a Flow
which outputs all its inputs.
- apply(int, int, boolean) - Method in class akka.stream.scaladsl.Interleave$
-
Create a new Interleave
with the specified number of input ports and given size of elements
to take from each input.
- apply(int, int, boolean) - Static method in class akka.stream.scaladsl.Interleave
-
Create a new Interleave
with the specified number of input ports and given size of elements
to take from each input.
- apply(int, boolean) - Method in class akka.stream.scaladsl.Merge$
-
Create a new Merge
with the specified number of input ports.
- apply(int, boolean) - Static method in class akka.stream.scaladsl.Merge
-
Create a new Merge
with the specified number of input ports.
- apply(int, boolean) - Method in class akka.stream.scaladsl.MergePreferred$
-
Create a new MergePreferred
with the specified number of secondary input ports.
- apply(int, boolean) - Static method in class akka.stream.scaladsl.MergePreferred
-
Create a new MergePreferred
with the specified number of secondary input ports.
- apply() - Method in class akka.stream.scaladsl.OrElse$
-
- apply() - Static method in class akka.stream.scaladsl.OrElse
-
- apply(int, Function1<T, Object>) - Method in class akka.stream.scaladsl.Partition$
-
Create a new Partition
stage with the specified input type.
- apply(int, Function1<T, Object>) - Static method in class akka.stream.scaladsl.Partition
-
Create a new Partition
stage with the specified input type.
- apply(SSLSession) - Method in class akka.stream.scaladsl.ScalaSessionAPI$
-
Constructs a ScalaSessionAPI instance from an SSLSession
- apply(Iterable<T>) - Method in class akka.stream.scaladsl.Source$
-
Helper to create
Source
from
Iterable
.
- apply(Iterable<T>) - Static method in class akka.stream.scaladsl.Source
-
Helper to create
Source
from
Iterable
.
- apply(ActorSystem) - Method in class akka.stream.scaladsl.Tcp$
-
- apply(ActorSystem) - Static method in class akka.stream.scaladsl.Tcp
-
- apply(SSLContext, Option<AkkaSSLConfig>, TLSProtocol.NegotiateNewSession, TLSRole, TLSClosing, Option<Tuple2<String, Object>>) - Method in class akka.stream.scaladsl.TLS$
-
- apply(SSLContext, TLSProtocol.NegotiateNewSession, TLSRole, TLSClosing, Option<Tuple2<String, Object>>) - Method in class akka.stream.scaladsl.TLS$
-
- apply(SSLContext, TLSProtocol.NegotiateNewSession, TLSRole) - Method in class akka.stream.scaladsl.TLS$
-
- apply(Function0<SSLEngine>, Function1<SSLSession, Try<BoxedUnit>>, TLSClosing) - Method in class akka.stream.scaladsl.TLS$
-
- apply(Function0<SSLEngine>, TLSClosing) - Method in class akka.stream.scaladsl.TLS$
-
- apply(SSLContext, Option<AkkaSSLConfig>, TLSProtocol.NegotiateNewSession, TLSRole, TLSClosing, Option<Tuple2<String, Object>>) - Static method in class akka.stream.scaladsl.TLS
-
- apply(SSLContext, TLSProtocol.NegotiateNewSession, TLSRole, TLSClosing, Option<Tuple2<String, Object>>) - Static method in class akka.stream.scaladsl.TLS
-
- apply(SSLContext, TLSProtocol.NegotiateNewSession, TLSRole) - Static method in class akka.stream.scaladsl.TLS
-
- apply(Function0<SSLEngine>, Function1<SSLSession, Try<BoxedUnit>>, TLSClosing) - Static method in class akka.stream.scaladsl.TLS
-
- apply(Function0<SSLEngine>, TLSClosing) - Static method in class akka.stream.scaladsl.TLS
-
- apply() - Method in class akka.stream.scaladsl.TLSPlacebo$
-
- apply() - Static method in class akka.stream.scaladsl.TLSPlacebo
-
- apply() - Method in class akka.stream.scaladsl.Unzip$
-
Create a new Unzip
.
- apply() - Static method in class akka.stream.scaladsl.Unzip
-
Create a new Unzip
.
- apply(Function1<In, Tuple2<A1, A2>>, UnzipWithApply.UnzipWithCreator2<Object, Object, Object>) - Static method in class akka.stream.scaladsl.UnzipWith
-
- apply(Function1<In, Tuple3<A1, A2, A3>>, UnzipWithApply.UnzipWithCreator3<Object, Object, Object, Object>) - Static method in class akka.stream.scaladsl.UnzipWith
-
- apply(Function1<In, Tuple4<A1, A2, A3, A4>>, UnzipWithApply.UnzipWithCreator4<Object, Object, Object, Object, Object>) - Static method in class akka.stream.scaladsl.UnzipWith
-
- apply(Function1<In, Tuple5<A1, A2, A3, A4, A5>>, UnzipWithApply.UnzipWithCreator5<Object, Object, Object, Object, Object, Object>) - Static method in class akka.stream.scaladsl.UnzipWith
-
- apply(Function1<In, Tuple6<A1, A2, A3, A4, A5, A6>>, UnzipWithApply.UnzipWithCreator6<Object, Object, Object, Object, Object, Object, Object>) - Static method in class akka.stream.scaladsl.UnzipWith
-
- apply(Function1<In, Tuple7<A1, A2, A3, A4, A5, A6, A7>>, UnzipWithApply.UnzipWithCreator7<Object, Object, Object, Object, Object, Object, Object, Object>) - Static method in class akka.stream.scaladsl.UnzipWith
-
- apply(Function1<In, Tuple8<A1, A2, A3, A4, A5, A6, A7, A8>>, UnzipWithApply.UnzipWithCreator8<Object, Object, Object, Object, Object, Object, Object, Object, Object>) - Static method in class akka.stream.scaladsl.UnzipWith
-
- apply(Function1<In, Tuple9<A1, A2, A3, A4, A5, A6, A7, A8, A9>>, UnzipWithApply.UnzipWithCreator9<Object, Object, Object, Object, Object, Object, Object, Object, Object, Object>) - Static method in class akka.stream.scaladsl.UnzipWith
-
- apply(Function1<In, Tuple10<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10>>, UnzipWithApply.UnzipWithCreator10<Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object>) - Static method in class akka.stream.scaladsl.UnzipWith
-
- apply(Function1<In, Tuple11<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11>>, UnzipWithApply.UnzipWithCreator11<Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object>) - Static method in class akka.stream.scaladsl.UnzipWith
-
- apply(Function1<In, Tuple12<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12>>, UnzipWithApply.UnzipWithCreator12<Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object>) - Static method in class akka.stream.scaladsl.UnzipWith
-
- apply(Function1<In, Tuple13<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13>>, UnzipWithApply.UnzipWithCreator13<Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object>) - Static method in class akka.stream.scaladsl.UnzipWith
-
- apply(Function1<In, Tuple14<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14>>, UnzipWithApply.UnzipWithCreator14<Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object>) - Static method in class akka.stream.scaladsl.UnzipWith
-
- apply(Function1<In, Tuple15<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15>>, UnzipWithApply.UnzipWithCreator15<Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object>) - Static method in class akka.stream.scaladsl.UnzipWith
-
- apply(Function1<In, Tuple16<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16>>, UnzipWithApply.UnzipWithCreator16<Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object>) - Static method in class akka.stream.scaladsl.UnzipWith
-
- apply(Function1<In, Tuple17<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17>>, UnzipWithApply.UnzipWithCreator17<Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object>) - Static method in class akka.stream.scaladsl.UnzipWith
-
- apply(Function1<In, Tuple18<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18>>, UnzipWithApply.UnzipWithCreator18<Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object>) - Static method in class akka.stream.scaladsl.UnzipWith
-
- apply(Function1<In, Tuple19<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19>>, UnzipWithApply.UnzipWithCreator19<Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object>) - Static method in class akka.stream.scaladsl.UnzipWith
-
- apply(Function1<In, Tuple20<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19, A20>>, UnzipWithApply.UnzipWithCreator20<Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object>) - Static method in class akka.stream.scaladsl.UnzipWith
-
- apply(Function1<In, Tuple2<A1, A2>>, UnzipWithApply.UnzipWithCreator2<Object, Object, Object>) - Method in interface akka.stream.scaladsl.UnzipWithApply
-
Create a new UnzipWith
specialized for 2 outputs.
- apply(Function1<In, Tuple3<A1, A2, A3>>, UnzipWithApply.UnzipWithCreator3<Object, Object, Object, Object>) - Method in interface akka.stream.scaladsl.UnzipWithApply
-
Create a new UnzipWith
specialized for 3 outputs.
- apply(Function1<In, Tuple4<A1, A2, A3, A4>>, UnzipWithApply.UnzipWithCreator4<Object, Object, Object, Object, Object>) - Method in interface akka.stream.scaladsl.UnzipWithApply
-
Create a new UnzipWith
specialized for 4 outputs.
- apply(Function1<In, Tuple5<A1, A2, A3, A4, A5>>, UnzipWithApply.UnzipWithCreator5<Object, Object, Object, Object, Object, Object>) - Method in interface akka.stream.scaladsl.UnzipWithApply
-
Create a new UnzipWith
specialized for 5 outputs.
- apply(Function1<In, Tuple6<A1, A2, A3, A4, A5, A6>>, UnzipWithApply.UnzipWithCreator6<Object, Object, Object, Object, Object, Object, Object>) - Method in interface akka.stream.scaladsl.UnzipWithApply
-
Create a new UnzipWith
specialized for 6 outputs.
- apply(Function1<In, Tuple7<A1, A2, A3, A4, A5, A6, A7>>, UnzipWithApply.UnzipWithCreator7<Object, Object, Object, Object, Object, Object, Object, Object>) - Method in interface akka.stream.scaladsl.UnzipWithApply
-
Create a new UnzipWith
specialized for 7 outputs.
- apply(Function1<In, Tuple8<A1, A2, A3, A4, A5, A6, A7, A8>>, UnzipWithApply.UnzipWithCreator8<Object, Object, Object, Object, Object, Object, Object, Object, Object>) - Method in interface akka.stream.scaladsl.UnzipWithApply
-
Create a new UnzipWith
specialized for 8 outputs.
- apply(Function1<In, Tuple9<A1, A2, A3, A4, A5, A6, A7, A8, A9>>, UnzipWithApply.UnzipWithCreator9<Object, Object, Object, Object, Object, Object, Object, Object, Object, Object>) - Method in interface akka.stream.scaladsl.UnzipWithApply
-
Create a new UnzipWith
specialized for 9 outputs.
- apply(Function1<In, Tuple10<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10>>, UnzipWithApply.UnzipWithCreator10<Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object>) - Method in interface akka.stream.scaladsl.UnzipWithApply
-
Create a new UnzipWith
specialized for 10 outputs.
- apply(Function1<In, Tuple11<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11>>, UnzipWithApply.UnzipWithCreator11<Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object>) - Method in interface akka.stream.scaladsl.UnzipWithApply
-
Create a new UnzipWith
specialized for 11 outputs.
- apply(Function1<In, Tuple12<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12>>, UnzipWithApply.UnzipWithCreator12<Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object>) - Method in interface akka.stream.scaladsl.UnzipWithApply
-
Create a new UnzipWith
specialized for 12 outputs.
- apply(Function1<In, Tuple13<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13>>, UnzipWithApply.UnzipWithCreator13<Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object>) - Method in interface akka.stream.scaladsl.UnzipWithApply
-
Create a new UnzipWith
specialized for 13 outputs.
- apply(Function1<In, Tuple14<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14>>, UnzipWithApply.UnzipWithCreator14<Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object>) - Method in interface akka.stream.scaladsl.UnzipWithApply
-
Create a new UnzipWith
specialized for 14 outputs.
- apply(Function1<In, Tuple15<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15>>, UnzipWithApply.UnzipWithCreator15<Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object>) - Method in interface akka.stream.scaladsl.UnzipWithApply
-
Create a new UnzipWith
specialized for 15 outputs.
- apply(Function1<In, Tuple16<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16>>, UnzipWithApply.UnzipWithCreator16<Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object>) - Method in interface akka.stream.scaladsl.UnzipWithApply
-
Create a new UnzipWith
specialized for 16 outputs.
- apply(Function1<In, Tuple17<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17>>, UnzipWithApply.UnzipWithCreator17<Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object>) - Method in interface akka.stream.scaladsl.UnzipWithApply
-
Create a new UnzipWith
specialized for 17 outputs.
- apply(Function1<In, Tuple18<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18>>, UnzipWithApply.UnzipWithCreator18<Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object>) - Method in interface akka.stream.scaladsl.UnzipWithApply
-
Create a new UnzipWith
specialized for 18 outputs.
- apply(Function1<In, Tuple19<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19>>, UnzipWithApply.UnzipWithCreator19<Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object>) - Method in interface akka.stream.scaladsl.UnzipWithApply
-
Create a new UnzipWith
specialized for 19 outputs.
- apply(Function1<In, Tuple20<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19, A20>>, UnzipWithApply.UnzipWithCreator20<Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object>) - Method in interface akka.stream.scaladsl.UnzipWithApply
-
Create a new UnzipWith
specialized for 20 outputs.
- apply() - Method in class akka.stream.scaladsl.Zip$
-
Create a new Zip
.
- apply() - Static method in class akka.stream.scaladsl.Zip
-
Create a new Zip
.
- apply(int) - Method in class akka.stream.scaladsl.ZipN$
-
Create a new ZipN
.
- apply(int) - Static method in class akka.stream.scaladsl.ZipN
-
Create a new ZipN
.
- apply(Function2<A1, A2, O>) - Static method in class akka.stream.scaladsl.ZipWith
-
- apply(Function3<A1, A2, A3, O>) - Static method in class akka.stream.scaladsl.ZipWith
-
- apply(Function4<A1, A2, A3, A4, O>) - Static method in class akka.stream.scaladsl.ZipWith
-
- apply(Function5<A1, A2, A3, A4, A5, O>) - Static method in class akka.stream.scaladsl.ZipWith
-
- apply(Function6<A1, A2, A3, A4, A5, A6, O>) - Static method in class akka.stream.scaladsl.ZipWith
-
- apply(Function7<A1, A2, A3, A4, A5, A6, A7, O>) - Static method in class akka.stream.scaladsl.ZipWith
-
- apply(Function8<A1, A2, A3, A4, A5, A6, A7, A8, O>) - Static method in class akka.stream.scaladsl.ZipWith
-
- apply(Function9<A1, A2, A3, A4, A5, A6, A7, A8, A9, O>) - Static method in class akka.stream.scaladsl.ZipWith
-
- apply(Function10<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, O>) - Static method in class akka.stream.scaladsl.ZipWith
-
- apply(Function11<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, O>) - Static method in class akka.stream.scaladsl.ZipWith
-
- apply(Function12<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, O>) - Static method in class akka.stream.scaladsl.ZipWith
-
- apply(Function13<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, O>) - Static method in class akka.stream.scaladsl.ZipWith
-
- apply(Function14<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, O>) - Static method in class akka.stream.scaladsl.ZipWith
-
- apply(Function15<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, O>) - Static method in class akka.stream.scaladsl.ZipWith
-
- apply(Function16<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, O>) - Static method in class akka.stream.scaladsl.ZipWith
-
- apply(Function17<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, O>) - Static method in class akka.stream.scaladsl.ZipWith
-
- apply(Function18<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, O>) - Static method in class akka.stream.scaladsl.ZipWith
-
- apply(Function19<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19, O>) - Static method in class akka.stream.scaladsl.ZipWith
-
- apply(Function20<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19, A20, O>) - Static method in class akka.stream.scaladsl.ZipWith
-
- apply(Function2<A1, A2, O>) - Method in interface akka.stream.scaladsl.ZipWithApply
-
Create a new ZipWith
specialized for 2 inputs.
- apply(Function3<A1, A2, A3, O>) - Method in interface akka.stream.scaladsl.ZipWithApply
-
Create a new ZipWith
specialized for 3 inputs.
- apply(Function4<A1, A2, A3, A4, O>) - Method in interface akka.stream.scaladsl.ZipWithApply
-
Create a new ZipWith
specialized for 4 inputs.
- apply(Function5<A1, A2, A3, A4, A5, O>) - Method in interface akka.stream.scaladsl.ZipWithApply
-
Create a new ZipWith
specialized for 5 inputs.
- apply(Function6<A1, A2, A3, A4, A5, A6, O>) - Method in interface akka.stream.scaladsl.ZipWithApply
-
Create a new ZipWith
specialized for 6 inputs.
- apply(Function7<A1, A2, A3, A4, A5, A6, A7, O>) - Method in interface akka.stream.scaladsl.ZipWithApply
-
Create a new ZipWith
specialized for 7 inputs.
- apply(Function8<A1, A2, A3, A4, A5, A6, A7, A8, O>) - Method in interface akka.stream.scaladsl.ZipWithApply
-
Create a new ZipWith
specialized for 8 inputs.
- apply(Function9<A1, A2, A3, A4, A5, A6, A7, A8, A9, O>) - Method in interface akka.stream.scaladsl.ZipWithApply
-
Create a new ZipWith
specialized for 9 inputs.
- apply(Function10<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, O>) - Method in interface akka.stream.scaladsl.ZipWithApply
-
Create a new ZipWith
specialized for 10 inputs.
- apply(Function11<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, O>) - Method in interface akka.stream.scaladsl.ZipWithApply
-
Create a new ZipWith
specialized for 11 inputs.
- apply(Function12<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, O>) - Method in interface akka.stream.scaladsl.ZipWithApply
-
Create a new ZipWith
specialized for 12 inputs.
- apply(Function13<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, O>) - Method in interface akka.stream.scaladsl.ZipWithApply
-
Create a new ZipWith
specialized for 13 inputs.
- apply(Function14<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, O>) - Method in interface akka.stream.scaladsl.ZipWithApply
-
Create a new ZipWith
specialized for 14 inputs.
- apply(Function15<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, O>) - Method in interface akka.stream.scaladsl.ZipWithApply
-
Create a new ZipWith
specialized for 15 inputs.
- apply(Function16<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, O>) - Method in interface akka.stream.scaladsl.ZipWithApply
-
Create a new ZipWith
specialized for 16 inputs.
- apply(Function17<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, O>) - Method in interface akka.stream.scaladsl.ZipWithApply
-
Create a new ZipWith
specialized for 17 inputs.
- apply(Function18<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, O>) - Method in interface akka.stream.scaladsl.ZipWithApply
-
Create a new ZipWith
specialized for 18 inputs.
- apply(Function19<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19, O>) - Method in interface akka.stream.scaladsl.ZipWithApply
-
Create a new ZipWith
specialized for 19 inputs.
- apply(Function20<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19, A20, O>) - Method in interface akka.stream.scaladsl.ZipWithApply
-
Create a new ZipWith
specialized for 20 inputs.
- apply(Function1<Seq<A>, O>, int) - Method in class akka.stream.scaladsl.ZipWithN$
-
Create a new ZipWithN
.
- apply(Function1<Seq<A>, O>, int) - Static method in class akka.stream.scaladsl.ZipWithN
-
Create a new ZipWithN
.
- apply(StreamSubscriptionTimeoutTerminationMode, FiniteDuration) - Method in class akka.stream.StreamSubscriptionTimeoutSettings$
-
Create settings from individual values (Scala).
- apply(Config) - Method in class akka.stream.StreamSubscriptionTimeoutSettings$
-
Create settings from a Config subsection (Scala).
- apply(StreamSubscriptionTimeoutTerminationMode, FiniteDuration) - Static method in class akka.stream.StreamSubscriptionTimeoutSettings
-
Create settings from individual values (Scala).
- apply(Config) - Static method in class akka.stream.StreamSubscriptionTimeoutSettings
-
Create settings from a Config subsection (Scala).
- apply(GraphStageWithMaterializedValue<SinkShape<T>, M>, TestProbe) - Method in class akka.stream.testkit.TestSinkStage$
-
Creates a sink out of the
stageUnderTest
that will inform the
probe
of graph stage events and callbacks by sending it the various messages found under
GraphStageMessages
.
- apply(GraphStageWithMaterializedValue<SinkShape<T>, M>, TestProbe) - Static method in class akka.stream.testkit.TestSinkStage
-
Creates a sink out of the
stageUnderTest
that will inform the
probe
of graph stage events and callbacks by sending it the various messages found under
GraphStageMessages
.
- apply(GraphStageWithMaterializedValue<SourceShape<T>, M>, TestProbe) - Method in class akka.stream.testkit.TestSourceStage$
-
Creates a source out of the
stageUnderTest
that will inform the
probe
of graph stage events and callbacks by sending it the various messages found under
GraphStageMessages
.
- apply(GraphStageWithMaterializedValue<SourceShape<T>, M>, TestProbe) - Static method in class akka.stream.testkit.TestSourceStage
-
Creates a source out of the
stageUnderTest
that will inform the
probe
of graph stage events and callbacks by sending it the various messages found under
GraphStageMessages
.
- apply(Outlet<O>, Seq<Inlet<I>>) - Method in class akka.stream.UniformFanInShape$
-
- apply(Outlet<O>, Seq<Inlet<I>>) - Static method in class akka.stream.UniformFanInShape
-
- apply(Inlet<I>, Seq<Outlet<O>>) - Method in class akka.stream.UniformFanOutShape$
-
- apply(Inlet<I>, Seq<Outlet<O>>) - Static method in class akka.stream.UniformFanOutShape
-
- apply(A) - Method in class akka.testkit.CachingPartialFunction
-
- apply(Logging.LogEvent) - Static method in class akka.testkit.CustomEventFilter
-
- apply(ClassTag<T>) - Method in class akka.testkit.DeadLettersFilter$
-
- apply(ClassTag<T>) - Static method in class akka.testkit.DeadLettersFilter
-
- apply(Logging.LogEvent) - Static method in class akka.testkit.DebugFilter
-
- apply(Logging.LogEvent) - Static method in class akka.testkit.ErrorFilter
-
- 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(Logging.LogEvent) - Static method in class akka.testkit.InfoFilter
-
- apply(ActorRefFactory) - Method in class akka.testkit.TestActor.Spawn
-
- 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, 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(ActorRef, ClassTag<T>, ActorSystem) - Method in class akka.testkit.TestActorRef$
-
- apply(ActorRef, 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, 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(ActorRef, ClassTag<T>, ActorSystem) - Static method in class akka.testkit.TestActorRef
-
- apply(ActorRef, 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>, ActorRef, String, ClassTag<T>, Predef.$less$colon$less<T, FSM<S, D>>, ActorSystem) - Method in class akka.testkit.TestFSMRef$
-
- apply(Function0<T>, ActorRef, 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(Function0<T>, ActorRef, String, ClassTag<T>, Predef.$less$colon$less<T, FSM<S, D>>, ActorSystem) - Static method in class akka.testkit.TestFSMRef
-
- apply(Function0<T>, ActorRef, ClassTag<T>, Predef.$less$colon$less<T, FSM<S, D>>, ActorSystem) - Static method in class akka.testkit.TestFSMRef
-
- apply(ActorSystem) - Static method in class akka.testkit.TestKitExtension
-
- 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(Logging.LogEvent) - Static method in class akka.testkit.WarningFilter
-
- apply(Future<ActorRef<T>>, int) - Method in class akka.typed.ActorRef$
-
Create an ActorRef from a Future, buffering up to the given number of
messages in while the Future is not fulfilled.
- apply(Function2<T, FunctionRef<T>, BoxedUnit>, Function1<FunctionRef<T>, BoxedUnit>) - Method in class akka.typed.ActorRef$
-
Create an ActorRef by providing a function that is invoked for sending
messages and a termination callback.
- apply(Future<ActorRef<T>>, int) - Static method in class akka.typed.ActorRef
-
Create an ActorRef from a Future, buffering up to the given number of
messages in while the Future is not fulfilled.
- apply(Function2<T, FunctionRef<T>, BoxedUnit>, Function1<FunctionRef<T>, BoxedUnit>) - Static method in class akka.typed.ActorRef
-
Create an ActorRef by providing a function that is invoked for sending
messages and a termination callback.
- apply(String, Behavior<T>, DeploymentConfig, Option<Config>, Option<ClassLoader>, Option<ExecutionContext>) - Method in class akka.typed.ActorSystem$
-
Create an ActorSystem implementation that is optimized for running
Akka Typed
Behavior
hierarchies—this system cannot run untyped
Actor
instances.
- apply(ActorRef) - Method in class akka.typed.adapter.ActorRefAdapter$
-
- apply(ActorRef) - Static method in class akka.typed.adapter.ActorRefAdapter
-
- apply(ActorSystem) - Method in class akka.typed.adapter.ActorSystemAdapter$
-
- apply(ActorSystem) - Static method in class akka.typed.adapter.ActorSystemAdapter
-
- apply(Behavior<?>, DeploymentConfig) - Method in class akka.typed.adapter.PropsAdapter$
-
- apply(Props) - Method in class akka.typed.adapter.PropsAdapter$
-
- apply(Behavior<?>, DeploymentConfig) - Static method in class akka.typed.adapter.PropsAdapter
-
- apply(Props) - Static method in class akka.typed.adapter.PropsAdapter
-
- apply() - Method in class akka.typed.DispatcherDefault$
-
Retrieve an instance for this configuration node with empty next
reference.
- apply() - Static method in class akka.typed.DispatcherDefault
-
Retrieve an instance for this configuration node with empty next
reference.
- apply(String) - Method in class akka.typed.Inbox$
-
- apply(String) - Static method in class akka.typed.Inbox
-
- apply(boolean, ClassTag<Thr>) - Method in class akka.typed.patterns.Restarter$
-
- apply(boolean, ClassTag<Thr>) - Static method in class akka.typed.patterns.Restarter
-
- Apply(ClassTag<Thr>, boolean) - Constructor for class akka.typed.patterns.Restarter.Apply
-
- 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(A) - Method in class akka.util.OptionVal$
-
- apply(A) - Static method in class akka.util.OptionVal
-
- apply(A) - Method in class akka.util.OptionVal.Some$
-
- 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
-
- apply(ActorSystem) - Method in class com.typesafe.sslconfig.akka.AkkaSSLConfig$
-
- apply(ActorSystem) - Static method in class com.typesafe.sslconfig.akka.AkkaSSLConfig
-
- apply(Class<?>) - Method in class com.typesafe.sslconfig.akka.util.AkkaLoggerFactory
-
- apply(String) - Method in class com.typesafe.sslconfig.akka.util.AkkaLoggerFactory
-
- apply$mcDD$sp(double) - Static method in class akka.event.LoggingReceive
-
- apply$mcDD$sp(double) - Static method in class akka.japi.JavaPartialFunction
-
- apply$mcDD$sp(double) - Static method in class akka.japi.pf.CaseStatement
-
- apply$mcDD$sp(double) - Static method in class akka.util.ByteString
-
- apply$mcDD$sp(double) - Static method in class akka.util.CompactByteString
-
- apply$mcDF$sp(float) - Static method in class akka.event.LoggingReceive
-
- apply$mcDF$sp(float) - Static method in class akka.japi.JavaPartialFunction
-
- apply$mcDF$sp(float) - Static method in class akka.japi.pf.CaseStatement
-
- apply$mcDF$sp(float) - Static method in class akka.util.ByteString
-
- apply$mcDF$sp(float) - Static method in class akka.util.CompactByteString
-
- apply$mcDI$sp(int) - Static method in class akka.event.LoggingReceive
-
- apply$mcDI$sp(int) - Static method in class akka.japi.JavaPartialFunction
-
- apply$mcDI$sp(int) - Static method in class akka.japi.pf.CaseStatement
-
- apply$mcDI$sp(int) - Static method in class akka.util.ByteString
-
- apply$mcDI$sp(int) - Static method in class akka.util.CompactByteString
-
- apply$mcDJ$sp(long) - Static method in class akka.event.LoggingReceive
-
- apply$mcDJ$sp(long) - Static method in class akka.japi.JavaPartialFunction
-
- apply$mcDJ$sp(long) - Static method in class akka.japi.pf.CaseStatement
-
- apply$mcDJ$sp(long) - Static method in class akka.util.ByteString
-
- apply$mcDJ$sp(long) - Static method in class akka.util.CompactByteString
-
- apply$mcFD$sp(double) - Static method in class akka.event.LoggingReceive
-
- apply$mcFD$sp(double) - Static method in class akka.japi.JavaPartialFunction
-
- apply$mcFD$sp(double) - Static method in class akka.japi.pf.CaseStatement
-
- apply$mcFD$sp(double) - Static method in class akka.util.ByteString
-
- apply$mcFD$sp(double) - Static method in class akka.util.CompactByteString
-
- apply$mcFF$sp(float) - Static method in class akka.event.LoggingReceive
-
- apply$mcFF$sp(float) - Static method in class akka.japi.JavaPartialFunction
-
- apply$mcFF$sp(float) - Static method in class akka.japi.pf.CaseStatement
-
- apply$mcFF$sp(float) - Static method in class akka.util.ByteString
-
- apply$mcFF$sp(float) - Static method in class akka.util.CompactByteString
-
- apply$mcFI$sp(int) - Static method in class akka.event.LoggingReceive
-
- apply$mcFI$sp(int) - Static method in class akka.japi.JavaPartialFunction
-
- apply$mcFI$sp(int) - Static method in class akka.japi.pf.CaseStatement
-
- apply$mcFI$sp(int) - Static method in class akka.util.ByteString
-
- apply$mcFI$sp(int) - Static method in class akka.util.CompactByteString
-
- apply$mcFJ$sp(long) - Static method in class akka.event.LoggingReceive
-
- apply$mcFJ$sp(long) - Static method in class akka.japi.JavaPartialFunction
-
- apply$mcFJ$sp(long) - Static method in class akka.japi.pf.CaseStatement
-
- apply$mcFJ$sp(long) - Static method in class akka.util.ByteString
-
- apply$mcFJ$sp(long) - Static method in class akka.util.CompactByteString
-
- apply$mcID$sp(double) - Static method in class akka.event.LoggingReceive
-
- apply$mcID$sp(double) - Static method in class akka.japi.JavaPartialFunction
-
- apply$mcID$sp(double) - Static method in class akka.japi.pf.CaseStatement
-
- apply$mcID$sp(double) - Static method in class akka.util.ByteString
-
- apply$mcID$sp(double) - Static method in class akka.util.CompactByteString
-
- apply$mcIF$sp(float) - Static method in class akka.event.LoggingReceive
-
- apply$mcIF$sp(float) - Static method in class akka.japi.JavaPartialFunction
-
- apply$mcIF$sp(float) - Static method in class akka.japi.pf.CaseStatement
-
- apply$mcIF$sp(float) - Static method in class akka.util.ByteString
-
- apply$mcIF$sp(float) - Static method in class akka.util.CompactByteString
-
- apply$mcII$sp(int) - Static method in class akka.event.LoggingReceive
-
- apply$mcII$sp(int) - Static method in class akka.japi.JavaPartialFunction
-
- apply$mcII$sp(int) - Static method in class akka.japi.pf.CaseStatement
-
- apply$mcII$sp(int) - Static method in class akka.util.ByteString
-
- apply$mcII$sp(int) - Static method in class akka.util.CompactByteString
-
- apply$mcIJ$sp(long) - Static method in class akka.event.LoggingReceive
-
- apply$mcIJ$sp(long) - Static method in class akka.japi.JavaPartialFunction
-
- apply$mcIJ$sp(long) - Static method in class akka.japi.pf.CaseStatement
-
- apply$mcIJ$sp(long) - Static method in class akka.util.ByteString
-
- apply$mcIJ$sp(long) - Static method in class akka.util.CompactByteString
-
- apply$mcJD$sp(double) - Static method in class akka.event.LoggingReceive
-
- apply$mcJD$sp(double) - Static method in class akka.japi.JavaPartialFunction
-
- apply$mcJD$sp(double) - Static method in class akka.japi.pf.CaseStatement
-
- apply$mcJD$sp(double) - Static method in class akka.util.ByteString
-
- apply$mcJD$sp(double) - Static method in class akka.util.CompactByteString
-
- apply$mcJF$sp(float) - Static method in class akka.event.LoggingReceive
-
- apply$mcJF$sp(float) - Static method in class akka.japi.JavaPartialFunction
-
- apply$mcJF$sp(float) - Static method in class akka.japi.pf.CaseStatement
-
- apply$mcJF$sp(float) - Static method in class akka.util.ByteString
-
- apply$mcJF$sp(float) - Static method in class akka.util.CompactByteString
-
- apply$mcJI$sp(int) - Static method in class akka.event.LoggingReceive
-
- apply$mcJI$sp(int) - Static method in class akka.japi.JavaPartialFunction
-
- apply$mcJI$sp(int) - Static method in class akka.japi.pf.CaseStatement
-
- apply$mcJI$sp(int) - Static method in class akka.util.ByteString
-
- apply$mcJI$sp(int) - Static method in class akka.util.CompactByteString
-
- apply$mcJJ$sp(long) - Static method in class akka.event.LoggingReceive
-
- apply$mcJJ$sp(long) - Static method in class akka.japi.JavaPartialFunction
-
- apply$mcJJ$sp(long) - Static method in class akka.japi.pf.CaseStatement
-
- apply$mcJJ$sp(long) - Static method in class akka.util.ByteString
-
- apply$mcJJ$sp(long) - Static method in class akka.util.CompactByteString
-
- apply$mcVD$sp(double) - Static method in class akka.event.LoggingReceive
-
- apply$mcVD$sp(double) - Static method in class akka.japi.JavaPartialFunction
-
- apply$mcVD$sp(double) - Static method in class akka.japi.pf.CaseStatement
-
- apply$mcVD$sp(double) - Static method in class akka.util.ByteString
-
- apply$mcVD$sp(double) - Static method in class akka.util.CompactByteString
-
- apply$mcVF$sp(float) - Static method in class akka.event.LoggingReceive
-
- apply$mcVF$sp(float) - Static method in class akka.japi.JavaPartialFunction
-
- apply$mcVF$sp(float) - Static method in class akka.japi.pf.CaseStatement
-
- apply$mcVF$sp(float) - Static method in class akka.util.ByteString
-
- apply$mcVF$sp(float) - Static method in class akka.util.CompactByteString
-
- apply$mcVI$sp(int) - Static method in class akka.event.LoggingReceive
-
- apply$mcVI$sp(int) - Static method in class akka.japi.JavaPartialFunction
-
- apply$mcVI$sp(int) - Static method in class akka.japi.pf.CaseStatement
-
- apply$mcVI$sp(int) - Static method in class akka.util.ByteString
-
- apply$mcVI$sp(int) - Static method in class akka.util.CompactByteString
-
- apply$mcVJ$sp(long) - Static method in class akka.event.LoggingReceive
-
- apply$mcVJ$sp(long) - Static method in class akka.japi.JavaPartialFunction
-
- apply$mcVJ$sp(long) - Static method in class akka.japi.pf.CaseStatement
-
- apply$mcVJ$sp(long) - Static method in class akka.util.ByteString
-
- apply$mcVJ$sp(long) - Static method in class akka.util.CompactByteString
-
- apply$mcZD$sp(double) - Static method in class akka.event.LoggingReceive
-
- apply$mcZD$sp(double) - Static method in class akka.japi.JavaPartialFunction
-
- apply$mcZD$sp(double) - Static method in class akka.japi.pf.CaseStatement
-
- apply$mcZD$sp(double) - Static method in class akka.util.ByteString
-
- apply$mcZD$sp(double) - Static method in class akka.util.CompactByteString
-
- apply$mcZF$sp(float) - Static method in class akka.event.LoggingReceive
-
- apply$mcZF$sp(float) - Static method in class akka.japi.JavaPartialFunction
-
- apply$mcZF$sp(float) - Static method in class akka.japi.pf.CaseStatement
-
- apply$mcZF$sp(float) - Static method in class akka.util.ByteString
-
- apply$mcZF$sp(float) - Static method in class akka.util.CompactByteString
-
- apply$mcZI$sp(int) - Static method in class akka.event.LoggingReceive
-
- apply$mcZI$sp(int) - Static method in class akka.japi.JavaPartialFunction
-
- apply$mcZI$sp(int) - Static method in class akka.japi.pf.CaseStatement
-
- apply$mcZI$sp(int) - Static method in class akka.util.ByteString
-
- apply$mcZI$sp(int) - Static method in class akka.util.CompactByteString
-
- apply$mcZJ$sp(long) - Static method in class akka.event.LoggingReceive
-
- apply$mcZJ$sp(long) - Static method in class akka.japi.JavaPartialFunction
-
- apply$mcZJ$sp(long) - Static method in class akka.japi.pf.CaseStatement
-
- apply$mcZJ$sp(long) - Static method in class akka.util.ByteString
-
- apply$mcZJ$sp(long) - Static method in class akka.util.CompactByteString
-
- applyEvent(E, D) - Method in interface akka.persistence.fsm.PersistentFSM
-
Override this handler to define the action on Domain Event
- applying(Object...) - Method in class akka.persistence.fsm.PersistentFSM.State
-
Specify domain events to be applied when transitioning to the new state.
- applying(Seq<E>) - Method in class akka.persistence.fsm.PersistentFSM.State
-
Specify domain events to be applied when transitioning to the new state.
- applyOrElse(A1, Function1<A1, B1>) - Static method in class akka.event.LoggingReceive
-
- applyOrElse(A1, Function1<A1, B1>) - Method in class akka.japi.JavaPartialFunction
-
- applyOrElse(A1, Function1<A1, B1>) - Static method in class akka.japi.pf.CaseStatement
-
- applyOrElse(A1, Function1<A1, B1>) - Static method in class akka.util.ByteString
-
- applyOrElse(A1, Function1<A1, B1>) - Static method in class akka.util.CompactByteString
-
- applySessionParameters(SSLEngine, TLSProtocol.NegotiateNewSession) - Method in class akka.stream.impl.io.TlsUtils$
-
- applySessionParameters(SSLEngine, TLSProtocol.NegotiateNewSession) - Static method in class akka.stream.impl.io.TlsUtils
-
- applyState(FSM.State<S, D>) - Static method in class akka.actor.AbstractFSM
-
- applyState(FSM.State<S, D>) - Method in interface akka.actor.FSM
-
- applyState(FSM.State<S, D>) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- applyState(FSM.State<S, D>) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- applyState(FSM.State<S, D>) - Static method in class akka.contrib.pattern.ReliableProxy
-
- applyState(FSM.State<S, D>) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- applyState(PersistentFSM.State<S, D, E>) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- applyState(PersistentFSM.State<S, D, E>) - Method in interface akka.persistence.fsm.PersistentFSM
-
Persist FSM State and FSM State Data
- applyState(PersistentFSM.State<S, D, E>) - Method in interface akka.persistence.fsm.PersistentFSMBase
-
- applyState(FSM.State<S, D>) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- applyState(FSM.State<S, D>) - Static method in class akka.remote.testconductor.ClientFSM
-
- applyState(FSM.State<S, D>) - Static method in class akka.remote.testconductor.ServerFSM
-
- applyState(FSM.State<S, D>) - Static method in class akka.remote.transport.ProtocolStateActor
-
- applyState(FSM.State<S, D>) - Static method in class akka.remote.transport.ThrottledAssociation
-
- applyUserRouteCustomization(RouteDefinition) - Method in class akka.camel.internal.ConsumerActorRouteBuilder
-
- args() - Method in class akka.actor.Props
-
- args() - Static method in class akka.remote.artery.FlightRecorderDump
-
- 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
-
- aroundPostRestart(Throwable) - Static method in class akka.actor.AbstractActor
-
- aroundPostRestart(Throwable) - Static method in class akka.actor.AbstractFSM
-
- aroundPostRestart(Throwable) - Method in interface akka.actor.Actor
-
Can be overridden to intercept calls to postRestart
.
- aroundPostRestart(Throwable) - Static method in class akka.camel.internal.CamelSupervisor
-
- aroundPostRestart(Throwable) - Static method in class akka.cluster.AutoDown
-
- aroundPostRestart(Throwable) - Static method in class akka.cluster.client.ClusterClient
-
- aroundPostRestart(Throwable) - Static method in class akka.cluster.client.ClusterReceptionist
-
- aroundPostRestart(Throwable) - Static method in class akka.cluster.ClusterHeartbeatSender
-
- aroundPostRestart(Throwable) - Static method in class akka.cluster.ClusterRemoteWatcher
-
- aroundPostRestart(Throwable) - Static method in class akka.cluster.ddata.LmdbDurableStore
-
- aroundPostRestart(Throwable) - Static method in class akka.cluster.ddata.ReadAggregator
-
- aroundPostRestart(Throwable) - Static method in class akka.cluster.ddata.ReadWriteAggregator
-
- aroundPostRestart(Throwable) - Static method in class akka.cluster.ddata.Replicator
-
- aroundPostRestart(Throwable) - Static method in class akka.cluster.ddata.WriteAggregator
-
- aroundPostRestart(Throwable) - Static method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- aroundPostRestart(Throwable) - Static method in class akka.cluster.sharding.ClusterShardingGuardian
-
- aroundPostRestart(Throwable) - Static method in class akka.cluster.sharding.RemoveInternalClusterShardingData
-
- aroundPostRestart(Throwable) - Static method in class akka.cluster.sharding.Shard
-
- aroundPostRestart(Throwable) - Static method in class akka.cluster.sharding.ShardCoordinator
-
- aroundPostRestart(Throwable) - Static method in class akka.cluster.sharding.ShardRegion
-
- aroundPostRestart(Throwable) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- aroundPostRestart(Throwable) - Static method in class akka.cluster.singleton.ClusterSingletonProxy
-
- aroundPostRestart(Throwable) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- aroundPostRestart(Throwable) - Static method in class akka.contrib.pattern.ReliableProxy
-
- aroundPostRestart(Throwable) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- aroundPostRestart(Throwable) - Static method in class akka.event.ActorClassificationUnsubscriber
-
- aroundPostRestart(Throwable) - Static method in class akka.event.EventStreamUnsubscriber
-
- aroundPostRestart(Throwable) - Static method in class akka.io.SelectionHandler
-
- aroundPostRestart(Throwable) - Static method in class akka.io.SimpleDnsManager
-
- aroundPostRestart(Throwable) - Static method in class akka.io.TcpConnection
-
- aroundPostRestart(Throwable) - Static method in class akka.io.TcpListener
-
- aroundPostRestart(Throwable) - Static method in class akka.io.TcpOutgoingConnection
-
- aroundPostRestart(Throwable) - Static method in class akka.pattern.BackoffSupervisor
-
- aroundPostRestart(Throwable) - Method in interface akka.persistence.Eventsourced
-
INTERNAL API.
- aroundPostRestart(Throwable) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- aroundPostRestart(Throwable) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- aroundPostRestart(Throwable) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- aroundPostRestart(Throwable) - Static method in class akka.persistence.journal.PersistencePluginProxy
-
- aroundPostRestart(Throwable) - Static method in class akka.persistence.journal.ReplayFilter
-
- aroundPostRestart(Throwable) - Static method in class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher
-
- aroundPostRestart(Throwable) - Static method in class akka.persistence.RecoveryPermitter
-
- aroundPostRestart(Throwable) - Static method in class akka.remote.artery.FlushOnShutdown
-
- aroundPostRestart(Throwable) - Static method in class akka.remote.EndpointManager
-
- aroundPostRestart(Throwable) - Static method in class akka.remote.EndpointReader
-
- aroundPostRestart(Throwable) - Static method in class akka.remote.EndpointWriter
-
- aroundPostRestart(Throwable) - Static method in class akka.remote.ReliableDeliverySupervisor
-
- aroundPostRestart(Throwable) - Static method in class akka.remote.RemoteDeploymentWatcher
-
- aroundPostRestart(Throwable) - Static method in class akka.remote.RemoteWatcher
-
- aroundPostRestart(Throwable) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- aroundPostRestart(Throwable) - Static method in class akka.remote.testconductor.ClientFSM
-
- aroundPostRestart(Throwable) - Static method in class akka.remote.testconductor.Controller
-
- aroundPostRestart(Throwable) - Static method in class akka.remote.testconductor.ServerFSM
-
- aroundPostRestart(Throwable) - Static method in class akka.remote.transport.ProtocolStateActor
-
- aroundPostRestart(Throwable) - Static method in class akka.remote.transport.ThrottledAssociation
-
- aroundPostRestart(Throwable) - Static method in class akka.remote.transport.ThrottlerManager
-
- aroundPostRestart(Throwable) - Static method in class akka.routing.ResizablePoolActor
-
- aroundPostRestart(Throwable) - Static method in class akka.stream.actor.AbstractActorPublisher
-
- aroundPostRestart(Throwable) - Static method in class akka.stream.actor.AbstractActorSubscriber
-
- aroundPostRestart(Throwable) - Method in interface akka.stream.actor.ActorPublisher
-
INTERNAL API
- aroundPostRestart(Throwable) - Method in interface akka.stream.actor.ActorSubscriber
-
INTERNAL API
- aroundPostRestart(Throwable) - Static method in class akka.stream.actor.UntypedActorPublisher
-
- aroundPostRestart(Throwable) - Static method in class akka.stream.actor.UntypedActorSubscriber
-
- aroundPostRestart(Throwable) - Static method in class akka.stream.impl.ActorRefSinkActor
-
- aroundPostRestart(Throwable) - Static method in class akka.stream.impl.ActorRefSourceActor
-
- aroundPostRestart(Throwable) - Static method in class akka.stream.impl.FanIn
-
- aroundPostRestart(Throwable) - Static method in class akka.stream.impl.FanOut
-
- aroundPostRestart(Throwable) - Static method in class akka.stream.impl.FanoutProcessorImpl
-
- aroundPostRestart(Throwable) - Static method in class akka.stream.impl.fusing.ActorGraphInterpreter
-
- aroundPostRestart(Throwable) - Static method in class akka.stream.impl.io.FilePublisher
-
- aroundPostRestart(Throwable) - Static method in class akka.stream.impl.io.FileSubscriber
-
- aroundPostRestart(Throwable) - Static method in class akka.stream.impl.io.InputStreamPublisher
-
- aroundPostRestart(Throwable) - Static method in class akka.stream.impl.io.OutputStreamSubscriber
-
- aroundPostRestart(Throwable) - Static method in class akka.stream.impl.io.TLSActor
-
- aroundPostRestart(Throwable) - Static method in class akka.stream.impl.StreamSupervisor
-
- aroundPostRestart(Throwable) - Static method in class akka.stream.impl.Unzip
-
- aroundPostRestart(Throwable) - Static method in class akka.testkit.TestActor
-
- aroundPostStop() - Static method in class akka.actor.AbstractActor
-
- aroundPostStop() - Static method in class akka.actor.AbstractFSM
-
- aroundPostStop() - Method in interface akka.actor.Actor
-
Can be overridden to intercept calls to postStop
.
- aroundPostStop() - Static method in class akka.camel.internal.CamelSupervisor
-
- aroundPostStop() - Static method in class akka.cluster.AutoDown
-
- aroundPostStop() - Static method in class akka.cluster.client.ClusterClient
-
- aroundPostStop() - Static method in class akka.cluster.client.ClusterReceptionist
-
- aroundPostStop() - Static method in class akka.cluster.ClusterHeartbeatSender
-
- aroundPostStop() - Static method in class akka.cluster.ClusterRemoteWatcher
-
- aroundPostStop() - Static method in class akka.cluster.ddata.LmdbDurableStore
-
- aroundPostStop() - Static method in class akka.cluster.ddata.ReadAggregator
-
- aroundPostStop() - Static method in class akka.cluster.ddata.ReadWriteAggregator
-
- aroundPostStop() - Static method in class akka.cluster.ddata.Replicator
-
- aroundPostStop() - Static method in class akka.cluster.ddata.WriteAggregator
-
- aroundPostStop() - Static method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- aroundPostStop() - Static method in class akka.cluster.sharding.ClusterShardingGuardian
-
- aroundPostStop() - Static method in class akka.cluster.sharding.RemoveInternalClusterShardingData
-
- aroundPostStop() - Static method in class akka.cluster.sharding.Shard
-
- aroundPostStop() - Static method in class akka.cluster.sharding.ShardCoordinator
-
- aroundPostStop() - Static method in class akka.cluster.sharding.ShardRegion
-
- aroundPostStop() - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- aroundPostStop() - Static method in class akka.cluster.singleton.ClusterSingletonProxy
-
- aroundPostStop() - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- aroundPostStop() - Static method in class akka.contrib.pattern.ReliableProxy
-
- aroundPostStop() - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- aroundPostStop() - Static method in class akka.event.ActorClassificationUnsubscriber
-
- aroundPostStop() - Static method in class akka.event.EventStreamUnsubscriber
-
- aroundPostStop() - Static method in class akka.io.SelectionHandler
-
- aroundPostStop() - Static method in class akka.io.SimpleDnsManager
-
- aroundPostStop() - Static method in class akka.io.TcpConnection
-
- aroundPostStop() - Static method in class akka.io.TcpListener
-
- aroundPostStop() - Static method in class akka.io.TcpOutgoingConnection
-
- aroundPostStop() - Static method in class akka.pattern.BackoffSupervisor
-
- aroundPostStop() - Method in interface akka.persistence.AtLeastOnceDeliveryLike
-
INTERNAL API
- aroundPostStop() - Method in interface akka.persistence.Eventsourced
-
INTERNAL API.
- aroundPostStop() - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- aroundPostStop() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- aroundPostStop() - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- aroundPostStop() - Static method in class akka.persistence.journal.PersistencePluginProxy
-
- aroundPostStop() - Static method in class akka.persistence.journal.ReplayFilter
-
- aroundPostStop() - Static method in class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher
-
- aroundPostStop() - Static method in class akka.persistence.RecoveryPermitter
-
- aroundPostStop() - Static method in class akka.remote.artery.FlushOnShutdown
-
- aroundPostStop() - Static method in class akka.remote.EndpointManager
-
- aroundPostStop() - Static method in class akka.remote.EndpointReader
-
- aroundPostStop() - Static method in class akka.remote.EndpointWriter
-
- aroundPostStop() - Static method in class akka.remote.ReliableDeliverySupervisor
-
- aroundPostStop() - Static method in class akka.remote.RemoteDeploymentWatcher
-
- aroundPostStop() - Static method in class akka.remote.RemoteWatcher
-
- aroundPostStop() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- aroundPostStop() - Static method in class akka.remote.testconductor.ClientFSM
-
- aroundPostStop() - Static method in class akka.remote.testconductor.Controller
-
- aroundPostStop() - Static method in class akka.remote.testconductor.ServerFSM
-
- aroundPostStop() - Static method in class akka.remote.transport.ProtocolStateActor
-
- aroundPostStop() - Static method in class akka.remote.transport.ThrottledAssociation
-
- aroundPostStop() - Static method in class akka.remote.transport.ThrottlerManager
-
- aroundPostStop() - Static method in class akka.routing.ResizablePoolActor
-
- aroundPostStop() - Static method in class akka.stream.actor.AbstractActorPublisher
-
- aroundPostStop() - Static method in class akka.stream.actor.AbstractActorSubscriber
-
- aroundPostStop() - Method in interface akka.stream.actor.ActorPublisher
-
INTERNAL API
- aroundPostStop() - Method in interface akka.stream.actor.ActorSubscriber
-
INTERNAL API
- aroundPostStop() - Static method in class akka.stream.actor.UntypedActorPublisher
-
- aroundPostStop() - Static method in class akka.stream.actor.UntypedActorSubscriber
-
- aroundPostStop() - Static method in class akka.stream.impl.ActorRefSinkActor
-
- aroundPostStop() - Static method in class akka.stream.impl.ActorRefSourceActor
-
- aroundPostStop() - Static method in class akka.stream.impl.FanIn
-
- aroundPostStop() - Static method in class akka.stream.impl.FanOut
-
- aroundPostStop() - Static method in class akka.stream.impl.FanoutProcessorImpl
-
- aroundPostStop() - Static method in class akka.stream.impl.fusing.ActorGraphInterpreter
-
- aroundPostStop() - Static method in class akka.stream.impl.io.FilePublisher
-
- aroundPostStop() - Static method in class akka.stream.impl.io.FileSubscriber
-
- aroundPostStop() - Static method in class akka.stream.impl.io.InputStreamPublisher
-
- aroundPostStop() - Static method in class akka.stream.impl.io.OutputStreamSubscriber
-
- aroundPostStop() - Static method in class akka.stream.impl.io.TLSActor
-
- aroundPostStop() - Static method in class akka.stream.impl.StreamSupervisor
-
- aroundPostStop() - Static method in class akka.stream.impl.Unzip
-
- aroundPostStop() - Static method in class akka.testkit.TestActor
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.actor.AbstractActor
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.actor.AbstractFSM
-
- aroundPreRestart(Throwable, Option<Object>) - Method in interface akka.actor.Actor
-
Can be overridden to intercept calls to preRestart
.
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.camel.internal.CamelSupervisor
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.cluster.AutoDown
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.cluster.client.ClusterClient
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.cluster.client.ClusterReceptionist
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.cluster.ClusterHeartbeatSender
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.cluster.ClusterRemoteWatcher
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.cluster.ddata.LmdbDurableStore
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.cluster.ddata.ReadAggregator
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.cluster.ddata.ReadWriteAggregator
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.cluster.ddata.Replicator
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.cluster.ddata.WriteAggregator
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.cluster.sharding.ClusterShardingGuardian
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.cluster.sharding.RemoveInternalClusterShardingData
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.cluster.sharding.Shard
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.cluster.sharding.ShardCoordinator
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.cluster.sharding.ShardRegion
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.cluster.singleton.ClusterSingletonProxy
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.contrib.pattern.ReliableProxy
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.event.ActorClassificationUnsubscriber
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.event.EventStreamUnsubscriber
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.io.SelectionHandler
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.io.SimpleDnsManager
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.io.TcpConnection
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.io.TcpListener
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.io.TcpOutgoingConnection
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.pattern.BackoffSupervisor
-
- aroundPreRestart(Throwable, Option<Object>) - Method in interface akka.persistence.AtLeastOnceDeliveryLike
-
INTERNAL API
- aroundPreRestart(Throwable, Option<Object>) - Method in interface akka.persistence.Eventsourced
-
INTERNAL API.
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.persistence.journal.PersistencePluginProxy
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.persistence.journal.ReplayFilter
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.persistence.RecoveryPermitter
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.remote.artery.FlushOnShutdown
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.remote.EndpointManager
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.remote.EndpointReader
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.remote.EndpointWriter
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.remote.ReliableDeliverySupervisor
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.remote.RemoteDeploymentWatcher
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.remote.RemoteWatcher
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.remote.testconductor.ClientFSM
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.remote.testconductor.Controller
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.remote.testconductor.ServerFSM
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.remote.transport.ProtocolStateActor
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.remote.transport.ThrottledAssociation
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.remote.transport.ThrottlerManager
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.routing.ResizablePoolActor
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.stream.actor.AbstractActorPublisher
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.stream.actor.AbstractActorSubscriber
-
- aroundPreRestart(Throwable, Option<Object>) - Method in interface akka.stream.actor.ActorPublisher
-
INTERNAL API
- aroundPreRestart(Throwable, Option<Object>) - Method in interface akka.stream.actor.ActorSubscriber
-
INTERNAL API
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.stream.actor.UntypedActorPublisher
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.stream.actor.UntypedActorSubscriber
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.stream.impl.ActorRefSinkActor
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.stream.impl.ActorRefSourceActor
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.stream.impl.FanIn
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.stream.impl.FanOut
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.stream.impl.FanoutProcessorImpl
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.stream.impl.fusing.ActorGraphInterpreter
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.stream.impl.io.FilePublisher
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.stream.impl.io.FileSubscriber
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.stream.impl.io.InputStreamPublisher
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.stream.impl.io.OutputStreamSubscriber
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.stream.impl.io.TLSActor
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.stream.impl.StreamSupervisor
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.stream.impl.Unzip
-
- aroundPreRestart(Throwable, Option<Object>) - Static method in class akka.testkit.TestActor
-
- aroundPreStart() - Static method in class akka.actor.AbstractActor
-
- aroundPreStart() - Static method in class akka.actor.AbstractFSM
-
- aroundPreStart() - Method in interface akka.actor.Actor
-
Can be overridden to intercept calls to preStart
.
- aroundPreStart() - Static method in class akka.camel.internal.CamelSupervisor
-
- aroundPreStart() - Static method in class akka.cluster.AutoDown
-
- aroundPreStart() - Static method in class akka.cluster.client.ClusterClient
-
- aroundPreStart() - Static method in class akka.cluster.client.ClusterReceptionist
-
- aroundPreStart() - Static method in class akka.cluster.ClusterHeartbeatSender
-
- aroundPreStart() - Static method in class akka.cluster.ClusterRemoteWatcher
-
- aroundPreStart() - Static method in class akka.cluster.ddata.LmdbDurableStore
-
- aroundPreStart() - Static method in class akka.cluster.ddata.ReadAggregator
-
- aroundPreStart() - Static method in class akka.cluster.ddata.ReadWriteAggregator
-
- aroundPreStart() - Static method in class akka.cluster.ddata.Replicator
-
- aroundPreStart() - Static method in class akka.cluster.ddata.WriteAggregator
-
- aroundPreStart() - Static method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- aroundPreStart() - Static method in class akka.cluster.sharding.ClusterShardingGuardian
-
- aroundPreStart() - Static method in class akka.cluster.sharding.RemoveInternalClusterShardingData
-
- aroundPreStart() - Static method in class akka.cluster.sharding.Shard
-
- aroundPreStart() - Static method in class akka.cluster.sharding.ShardCoordinator
-
- aroundPreStart() - Static method in class akka.cluster.sharding.ShardRegion
-
- aroundPreStart() - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- aroundPreStart() - Static method in class akka.cluster.singleton.ClusterSingletonProxy
-
- aroundPreStart() - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- aroundPreStart() - Static method in class akka.contrib.pattern.ReliableProxy
-
- aroundPreStart() - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- aroundPreStart() - Static method in class akka.event.ActorClassificationUnsubscriber
-
- aroundPreStart() - Static method in class akka.event.EventStreamUnsubscriber
-
- aroundPreStart() - Static method in class akka.io.SelectionHandler
-
- aroundPreStart() - Static method in class akka.io.SimpleDnsManager
-
- aroundPreStart() - Static method in class akka.io.TcpConnection
-
- aroundPreStart() - Static method in class akka.io.TcpListener
-
- aroundPreStart() - Static method in class akka.io.TcpOutgoingConnection
-
- aroundPreStart() - Static method in class akka.pattern.BackoffSupervisor
-
- aroundPreStart() - Method in interface akka.persistence.Eventsourced
-
INTERNAL API.
- aroundPreStart() - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- aroundPreStart() - Method in interface akka.persistence.journal.AsyncWriteProxy
-
- aroundPreStart() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- aroundPreStart() - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- aroundPreStart() - Static method in class akka.persistence.journal.PersistencePluginProxy
-
- aroundPreStart() - Static method in class akka.persistence.journal.ReplayFilter
-
- aroundPreStart() - Method in interface akka.persistence.PersistentView
-
Deprecated.
INTERNAL API.
- aroundPreStart() - Static method in class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher
-
- aroundPreStart() - Static method in class akka.persistence.RecoveryPermitter
-
- aroundPreStart() - Static method in class akka.remote.artery.FlushOnShutdown
-
- aroundPreStart() - Static method in class akka.remote.EndpointManager
-
- aroundPreStart() - Static method in class akka.remote.EndpointReader
-
- aroundPreStart() - Static method in class akka.remote.EndpointWriter
-
- aroundPreStart() - Static method in class akka.remote.ReliableDeliverySupervisor
-
- aroundPreStart() - Static method in class akka.remote.RemoteDeploymentWatcher
-
- aroundPreStart() - Static method in class akka.remote.RemoteWatcher
-
- aroundPreStart() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- aroundPreStart() - Static method in class akka.remote.testconductor.ClientFSM
-
- aroundPreStart() - Static method in class akka.remote.testconductor.Controller
-
- aroundPreStart() - Static method in class akka.remote.testconductor.ServerFSM
-
- aroundPreStart() - Static method in class akka.remote.transport.ProtocolStateActor
-
- aroundPreStart() - Static method in class akka.remote.transport.ThrottledAssociation
-
- aroundPreStart() - Static method in class akka.remote.transport.ThrottlerManager
-
- aroundPreStart() - Static method in class akka.routing.ResizablePoolActor
-
- aroundPreStart() - Static method in class akka.stream.actor.AbstractActorPublisher
-
- aroundPreStart() - Static method in class akka.stream.actor.AbstractActorSubscriber
-
- aroundPreStart() - Method in interface akka.stream.actor.ActorPublisher
-
INTERNAL API
- aroundPreStart() - Method in interface akka.stream.actor.ActorSubscriber
-
INTERNAL API
- aroundPreStart() - Static method in class akka.stream.actor.UntypedActorPublisher
-
- aroundPreStart() - Static method in class akka.stream.actor.UntypedActorSubscriber
-
- aroundPreStart() - Static method in class akka.stream.impl.ActorRefSinkActor
-
- aroundPreStart() - Static method in class akka.stream.impl.ActorRefSourceActor
-
- aroundPreStart() - Static method in class akka.stream.impl.FanIn
-
- aroundPreStart() - Static method in class akka.stream.impl.FanOut
-
- aroundPreStart() - Static method in class akka.stream.impl.FanoutProcessorImpl
-
- aroundPreStart() - Static method in class akka.stream.impl.fusing.ActorGraphInterpreter
-
- aroundPreStart() - Static method in class akka.stream.impl.io.FilePublisher
-
- aroundPreStart() - Static method in class akka.stream.impl.io.FileSubscriber
-
- aroundPreStart() - Static method in class akka.stream.impl.io.InputStreamPublisher
-
- aroundPreStart() - Static method in class akka.stream.impl.io.OutputStreamSubscriber
-
- aroundPreStart() - Static method in class akka.stream.impl.io.TLSActor
-
- aroundPreStart() - Static method in class akka.stream.impl.StreamSupervisor
-
- aroundPreStart() - Static method in class akka.stream.impl.Unzip
-
- aroundPreStart() - Static method in class akka.testkit.TestActor
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.actor.AbstractActor
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.actor.AbstractFSM
-
- 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) - Static method in class akka.camel.internal.CamelSupervisor
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.cluster.AutoDown
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.cluster.client.ClusterClient
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.cluster.client.ClusterReceptionist
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.cluster.ClusterHeartbeatSender
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.cluster.ClusterRemoteWatcher
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.cluster.ddata.LmdbDurableStore
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.cluster.ddata.ReadAggregator
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.cluster.ddata.ReadWriteAggregator
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.cluster.ddata.Replicator
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.cluster.ddata.WriteAggregator
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.cluster.sharding.ClusterShardingGuardian
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.cluster.sharding.RemoveInternalClusterShardingData
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.cluster.sharding.Shard
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.cluster.sharding.ShardCoordinator
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.cluster.sharding.ShardRegion
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.cluster.singleton.ClusterSingletonProxy
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.contrib.pattern.ReceivePipeline
-
INTERNAL API.
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.contrib.pattern.ReliableProxy
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.event.ActorClassificationUnsubscriber
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.event.EventStreamUnsubscriber
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.io.SelectionHandler
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.io.SimpleDnsManager
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.io.TcpConnection
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.io.TcpListener
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.io.TcpOutgoingConnection
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.pattern.BackoffSupervisor
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.persistence.AtLeastOnceDeliveryLike
-
INTERNAL API
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.persistence.Eventsourced
-
INTERNAL API.
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.persistence.journal.AsyncWriteProxy
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.persistence.journal.PersistencePluginProxy
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.persistence.journal.ReplayFilter
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.persistence.PersistentView
-
Deprecated.
INTERNAL API.
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.persistence.RecoveryPermitter
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.remote.artery.FlushOnShutdown
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.remote.EndpointManager
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.remote.EndpointReader
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.remote.EndpointWriter
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.remote.ReliableDeliverySupervisor
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.remote.RemoteDeploymentWatcher
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.remote.RemoteWatcher
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.remote.testconductor.ClientFSM
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.remote.testconductor.Controller
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.remote.testconductor.ServerFSM
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.remote.transport.ProtocolStateActor
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.remote.transport.ThrottledAssociation
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.remote.transport.ThrottlerManager
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.routing.ResizablePoolActor
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.stream.actor.AbstractActorPublisher
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.stream.actor.AbstractActorSubscriber
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.stream.actor.ActorPublisher
-
INTERNAL API
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.stream.actor.ActorSubscriber
-
INTERNAL API
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.stream.actor.UntypedActorPublisher
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.stream.actor.UntypedActorSubscriber
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.stream.impl.ActorRefSinkActor
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.stream.impl.ActorRefSourceActor
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.stream.impl.FanIn
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.stream.impl.FanOut
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.stream.impl.FanoutProcessorImpl
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.stream.impl.fusing.ActorGraphInterpreter
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.stream.impl.io.FilePublisher
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.stream.impl.io.FileSubscriber
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.stream.impl.io.InputStreamPublisher
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.stream.impl.io.OutputStreamSubscriber
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.stream.impl.io.TLSActor
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.stream.impl.StreamSupervisor
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.stream.impl.Unzip
-
- aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class akka.testkit.TestActor
-
- arr() - Method in class akka.stream.impl.io.InputStreamPublisher
-
- array() - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- 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
-
- artery() - Static method in class akka.cluster.ClusterRemoteWatcher
-
- Artery() - Method in class akka.remote.RemoteSettings
-
- artery() - Method in class akka.remote.RemoteWatcher
-
- ArteryControlFormats - Class in akka.remote
-
- ArteryControlFormats.Address - Class in akka.remote
-
Protobuf type Address
- ArteryControlFormats.Address.Builder - Class in akka.remote
-
Protobuf type Address
- ArteryControlFormats.AddressOrBuilder - Interface in akka.remote
-
- ArteryControlFormats.ArteryHeartbeatRsp - Class in akka.remote
-
Protobuf type ArteryHeartbeatRsp
- ArteryControlFormats.ArteryHeartbeatRsp.Builder - Class in akka.remote
-
Protobuf type ArteryHeartbeatRsp
- ArteryControlFormats.ArteryHeartbeatRspOrBuilder - Interface in akka.remote
-
- ArteryControlFormats.CompressionTableAdvertisement - Class in akka.remote
-
Protobuf type CompressionTableAdvertisement
- ArteryControlFormats.CompressionTableAdvertisement.Builder - Class in akka.remote
-
Protobuf type CompressionTableAdvertisement
- ArteryControlFormats.CompressionTableAdvertisementAck - Class in akka.remote
-
Protobuf type CompressionTableAdvertisementAck
- ArteryControlFormats.CompressionTableAdvertisementAck.Builder - Class in akka.remote
-
Protobuf type CompressionTableAdvertisementAck
- ArteryControlFormats.CompressionTableAdvertisementAckOrBuilder - Interface in akka.remote
-
- ArteryControlFormats.CompressionTableAdvertisementOrBuilder - Interface in akka.remote
-
- ArteryControlFormats.HandshakeReq - Class in akka.remote
-
Protobuf type HandshakeReq
- ArteryControlFormats.HandshakeReq.Builder - Class in akka.remote
-
Protobuf type HandshakeReq
- ArteryControlFormats.HandshakeReqOrBuilder - Interface in akka.remote
-
- ArteryControlFormats.MessageWithAddress - Class in akka.remote
-
Protobuf type MessageWithAddress
- ArteryControlFormats.MessageWithAddress.Builder - Class in akka.remote
-
Protobuf type MessageWithAddress
- ArteryControlFormats.MessageWithAddressOrBuilder - Interface in akka.remote
-
- ArteryControlFormats.Quarantined - Class in akka.remote
-
Protobuf type Quarantined
- ArteryControlFormats.Quarantined.Builder - Class in akka.remote
-
Protobuf type Quarantined
- ArteryControlFormats.QuarantinedOrBuilder - Interface in akka.remote
-
- ArteryControlFormats.SystemMessageDeliveryAck - Class in akka.remote
-
Protobuf type SystemMessageDeliveryAck
- ArteryControlFormats.SystemMessageDeliveryAck.Builder - Class in akka.remote
-
Protobuf type SystemMessageDeliveryAck
- ArteryControlFormats.SystemMessageDeliveryAckOrBuilder - Interface in akka.remote
-
- ArteryControlFormats.SystemMessageEnvelope - Class in akka.remote
-
Protobuf type SystemMessageEnvelope
- ArteryControlFormats.SystemMessageEnvelope.Builder - Class in akka.remote
-
Protobuf type SystemMessageEnvelope
- ArteryControlFormats.SystemMessageEnvelopeOrBuilder - Interface in akka.remote
-
- ArteryControlFormats.UniqueAddress - Class in akka.remote
-
Protobuf type UniqueAddress
- ArteryControlFormats.UniqueAddress.Builder - Class in akka.remote
-
Protobuf type UniqueAddress
- ArteryControlFormats.UniqueAddressOrBuilder - Interface in akka.remote
-
- ArteryHeartbeat$() - Constructor for class akka.remote.RemoteWatcher.ArteryHeartbeat$
-
- ArteryHeartbeatRsp(long) - Constructor for class akka.remote.RemoteWatcher.ArteryHeartbeatRsp
-
- ArteryHeartbeatRsp$() - Constructor for class akka.remote.RemoteWatcher.ArteryHeartbeatRsp$
-
- ArteryMessage - Interface in akka.remote.artery
-
INTERNAL API: marker trait for protobuf-serializable artery messages
- ArteryMessageSerializer - Class in akka.remote.serialization
-
INTERNAL API
- ArteryMessageSerializer(ExtendedActorSystem) - Constructor for class akka.remote.serialization.ArteryMessageSerializer
-
- ArteryMessageSerializer$ - Class in akka.remote.serialization
-
INTERNAL API
- ArteryMessageSerializer$() - Constructor for class akka.remote.serialization.ArteryMessageSerializer$
-
- ArterySettings - Class in akka.remote.artery
-
INTERNAL API
- ArterySettings$ - Class in akka.remote.artery
-
INTERNAL API
- ArterySettings$() - Constructor for class akka.remote.artery.ArterySettings$
-
- ArterySettings.Advanced$ - Class in akka.remote.artery
-
- ArterySettings.Bind$ - Class in akka.remote.artery
-
- ArterySettings.Canonical$ - Class in akka.remote.artery
-
- ArterySettings.Compression - Class in akka.remote.artery
-
INTERNAL API
- ArterySettings.Compression$ - Class in akka.remote.artery
-
- ArterySettings.Compression.ActorRefs$ - Class in akka.remote.artery
-
- ArterySettings.Compression.Manifests$ - Class in akka.remote.artery
-
- ArteryTransport - Class in akka.remote.artery
-
INTERNAL API
- ArteryTransport(ExtendedActorSystem, RemoteActorRefProvider) - Constructor for class akka.remote.artery.ArteryTransport
-
- ArteryTransport$ - Class in akka.remote.artery
-
INTERNAL API
- ArteryTransport$() - Constructor for class akka.remote.artery.ArteryTransport$
-
- ArteryTransport.AeronTerminated - Exception in akka.remote.artery
-
- ArteryTransport.InboundStreamMatValues - Class in akka.remote.artery
-
- ArteryTransport.InboundStreamMatValues$ - Class in akka.remote.artery
-
- ArteryTransport.ShutdownSignal$ - Exception in akka.remote.artery
-
- ArteryTransport.ShuttingDown$ - Exception in akka.remote.artery
-
- as() - Method in class akka.stream.Inlet
-
INTERNAL API.
- as() - Method in class akka.stream.Outlet
-
INTERNAL API.
- 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
-
- asByteBuffer() - Static method in class akka.util.CompactByteString
-
- 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
-
- asByteBuffers() - Static method in class akka.util.CompactByteString
-
- asInputStream() - Method in class akka.stream.javadsl.StreamConverters$
-
Creates a Sink which when materialized will return an InputStream
which it is possible
to read the values produced by the stream this Sink is attached to.
- asInputStream(FiniteDuration) - Method in class akka.stream.javadsl.StreamConverters$
-
Creates a Sink which when materialized will return an InputStream
which it is possible
to read the values produced by the stream this Sink is attached to.
- asInputStream() - Static method in class akka.stream.javadsl.StreamConverters
-
Creates a Sink which when materialized will return an InputStream
which it is possible
to read the values produced by the stream this Sink is attached to.
- asInputStream(FiniteDuration) - Static method in class akka.stream.javadsl.StreamConverters
-
Creates a Sink which when materialized will return an InputStream
which it is possible
to read the values produced by the stream this Sink is attached to.
- asInputStream(FiniteDuration) - Method in class akka.stream.scaladsl.StreamConverters$
-
Creates a Sink which when materialized will return an InputStream
which it is possible
to read the values produced by the stream this Sink is attached to.
- asInputStream(FiniteDuration) - Static method in class akka.stream.scaladsl.StreamConverters
-
Creates a Sink which when materialized will return an InputStream
which it is possible
to read the values produced by the stream this Sink is attached to.
- 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
-
- asJava() - Method in class akka.stream.scaladsl.BidiFlow
-
- asJava() - Method in class akka.stream.scaladsl.Flow
-
Converts this Scala DSL element to it's Java DSL counterpart.
- asJava() - Method in class akka.stream.scaladsl.GraphDSL.Builder
-
Converts this Scala DSL element to it's Java DSL counterpart.
- asJava() - Method in class akka.stream.scaladsl.Sink
-
Converts this Scala DSL element to it's Java DSL counterpart.
- asJava() - Method in class akka.stream.scaladsl.Source
-
Converts this Scala DSL element to it's Java DSL counterpart.
- asJava() - Method in class akka.util.JavaDurationConverters.ScalaDurationOps
-
- asJavaStream() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- asJavaStream() - Method in class akka.stream.javadsl.StreamConverters$
-
Creates a sink which materializes into Java 8
Stream
that can be run to trigger demand through the sink.
- asJavaStream() - Static method in class akka.stream.javadsl.StreamConverters
-
Creates a sink which materializes into Java 8
Stream
that can be run to trigger demand through the sink.
- asJavaStream() - Method in class akka.stream.scaladsl.StreamConverters$
-
Creates a sink which materializes into Java 8
Stream
that can be run to trigger demand through the sink.
- asJavaStream() - Static method in class akka.stream.scaladsl.StreamConverters
-
Creates a sink which materializes into Java 8
Stream
that can be run to trigger demand through the sink.
- 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) - Method in interface akka.pattern.ExplicitAskSupport
-
Import this implicit conversion to gain
?
and
ask
methods on
ActorRef
, which will defer to the
ask(actorRef, askSender => message)(timeout)
method defined here.
- ask(ActorRef, Function1<ActorRef, Object>, Timeout) - Method in interface akka.pattern.ExplicitAskSupport
-
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, Function1<ActorRef, Object>, ActorRef, Timeout) - Method in interface akka.pattern.ExplicitAskSupport
-
- ask(ActorSelection) - Method in interface akka.pattern.ExplicitAskSupport
-
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, Function1<ActorRef, Object>, Timeout) - Method in interface akka.pattern.ExplicitAskSupport
-
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, Function1<ActorRef, Object>, ActorRef, Timeout) - Method in interface akka.pattern.ExplicitAskSupport
-
- ask(Function1<ActorRef, Object>, Timeout, ActorRef) - Method in class akka.pattern.ExplicitlyAskableActorRef
-
- ask(Function1<ActorRef, Object>, Timeout, ActorRef) - Method in class akka.pattern.ExplicitlyAskableActorSelection
-
- 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, Function<ActorRef, Object>, Timeout) - Method in class akka.pattern.Patterns$
-
A variation of ask which allows to implement "replyTo" pattern by including
sender reference in message.
- ask(ActorRef, Object, long) - Method in class akka.pattern.Patterns$
-
Java API for akka.pattern.ask
:
Sends a message asynchronously and returns a Future
holding the eventual reply message; this means that the target actor
needs to send the result to the sender
reference provided.
- ask(ActorRef, Function<ActorRef, Object>, long) - Method in class akka.pattern.Patterns$
-
A variation of ask which allows to implement "replyTo" pattern by including
sender reference in message.
- 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(ActorSelection, Function<ActorRef, Object>, long) - Method in class akka.pattern.Patterns$
-
A variation of ask which allows to implement "replyTo" pattern by including
sender reference in message.
- 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, Function<ActorRef, Object>, Timeout) - Static method in class akka.pattern.Patterns
-
A variation of ask which allows to implement "replyTo" pattern by including
sender reference in message.
- 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(ActorRef, Function<ActorRef, Object>, long) - Static method in class akka.pattern.Patterns
-
A variation of ask which allows to implement "replyTo" pattern by including
sender reference in message.
- 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(ActorSelection, Function<ActorRef, Object>, long) - Static method in class akka.pattern.Patterns
-
A variation of ask which allows to implement "replyTo" pattern by including
sender reference in message.
- ask(ActorRef, Object, Timeout) - Method in class akka.pattern.PatternsCS$
-
Java API for akka.pattern.ask
:
Sends a message asynchronously and returns a CompletionStage
holding the eventual reply message; this means that the target actor
needs to send the result to the sender
reference provided.
- ask(ActorRef, Function<ActorRef, Object>, Timeout) - Method in class akka.pattern.PatternsCS$
-
A variation of ask which allows to implement "replyTo" pattern by including
sender reference in message.
- ask(ActorRef, Object, long) - Method in class akka.pattern.PatternsCS$
-
Java API for akka.pattern.ask
:
Sends a message asynchronously and returns a CompletionStage
holding the eventual reply message; this means that the target actor
needs to send the result to the sender
reference provided.
- ask(ActorRef, Function<ActorRef, Object>, long) - Method in class akka.pattern.PatternsCS$
-
A variation of ask which allows to implement "replyTo" pattern by including
sender reference in message.
- ask(ActorSelection, Object, Timeout) - Method in class akka.pattern.PatternsCS$
-
Java API for akka.pattern.ask
:
Sends a message asynchronously and returns a
CompletionStage
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.PatternsCS$
-
Java API for akka.pattern.ask
:
Sends a message asynchronously and returns a
CompletionStage
holding the eventual reply message; this means that the target
ActorSelection
needs to send the result to the
sender
reference provided.
- ask(ActorSelection, Function<ActorRef, Object>, long) - Method in class akka.pattern.PatternsCS$
-
A variation of ask which allows to implement "replyTo" pattern by including
sender reference in message.
- ask(ActorRef, Object, Timeout) - Static method in class akka.pattern.PatternsCS
-
Java API for akka.pattern.ask
:
Sends a message asynchronously and returns a CompletionStage
holding the eventual reply message; this means that the target actor
needs to send the result to the sender
reference provided.
- ask(ActorRef, Function<ActorRef, Object>, Timeout) - Static method in class akka.pattern.PatternsCS
-
A variation of ask which allows to implement "replyTo" pattern by including
sender reference in message.
- ask(ActorRef, Object, long) - Static method in class akka.pattern.PatternsCS
-
Java API for akka.pattern.ask
:
Sends a message asynchronously and returns a CompletionStage
holding the eventual reply message; this means that the target actor
needs to send the result to the sender
reference provided.
- ask(ActorRef, Function<ActorRef, Object>, long) - Static method in class akka.pattern.PatternsCS
-
A variation of ask which allows to implement "replyTo" pattern by including
sender reference in message.
- ask(ActorSelection, Object, Timeout) - Static method in class akka.pattern.PatternsCS
-
Java API for akka.pattern.ask
:
Sends a message asynchronously and returns a
CompletionStage
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.PatternsCS
-
Java API for akka.pattern.ask
:
Sends a message asynchronously and returns a
CompletionStage
holding the eventual reply message; this means that the target
ActorSelection
needs to send the result to the
sender
reference provided.
- ask(ActorSelection, Function<ActorRef, Object>, long) - Static method in class akka.pattern.PatternsCS
-
A variation of ask which allows to implement "replyTo" pattern by including
sender reference in message.
- 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$
-
- askAllShards(Object, ClassTag<T>) - Method in class akka.cluster.sharding.ShardRegion
-
- AskeableWithCircuitBreakerActor - Class in akka.contrib.circuitbreaker
-
- AskeableWithCircuitBreakerActor(ActorRef) - Constructor for class akka.contrib.circuitbreaker.AskeableWithCircuitBreakerActor
-
- AskeableWithCircuitBreakerActor$ - Class in akka.contrib.circuitbreaker
-
- AskeableWithCircuitBreakerActor$() - Constructor for class akka.contrib.circuitbreaker.AskeableWithCircuitBreakerActor$
-
- AskeableWithCircuitBreakerActorSelection - Class in akka.contrib.circuitbreaker
-
- AskeableWithCircuitBreakerActorSelection(ActorSelection) - Constructor for class akka.contrib.circuitbreaker.AskeableWithCircuitBreakerActorSelection
-
- AskeableWithCircuitBreakerActorSelection$ - Class in akka.contrib.circuitbreaker
-
- AskeableWithCircuitBreakerActorSelection$() - Constructor for class akka.contrib.circuitbreaker.AskeableWithCircuitBreakerActorSelection$
-
- AskPath() - Method in class akka.typed.AskPattern$
-
- AskPath() - Static method in 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$ - 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
-
- AskPromiseRef - Class in akka.pattern
-
- AskPromiseRef$ - Class in akka.pattern
-
- AskPromiseRef$() - Constructor for class akka.pattern.AskPromiseRef$
-
- 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
-
- askWithCircuitBreaker(Object, ExecutionContext, Timeout, ActorRef) - Method in class akka.contrib.circuitbreaker.AskeableWithCircuitBreakerActor
-
- askWithCircuitBreaker(Object, ExecutionContext, Timeout, ActorRef) - Method in class akka.contrib.circuitbreaker.AskeableWithCircuitBreakerActorSelection
-
- askWithCircuitBreaker(ActorRef) - Method in class akka.contrib.circuitbreaker.Implicits$
-
- askWithCircuitBreaker(ActorRef, Object, ExecutionContext, Timeout) - Method in class akka.contrib.circuitbreaker.Implicits$
-
- askWithCircuitBreaker(ActorRef, Object, ActorRef, ExecutionContext, Timeout) - Method in class akka.contrib.circuitbreaker.Implicits$
-
Wraps the
ask
method in
AskSupport
method to convert failures connected to the circuit
breaker being in open state
- askWithCircuitBreaker(ActorRef) - Static method in class akka.contrib.circuitbreaker.Implicits
-
- askWithCircuitBreaker(ActorRef, Object, ExecutionContext, Timeout) - Static method in class akka.contrib.circuitbreaker.Implicits
-
- askWithCircuitBreaker(ActorRef, Object, ActorRef, ExecutionContext, Timeout) - Static method in class akka.contrib.circuitbreaker.Implicits
-
Wraps the
ask
method in
AskSupport
method to convert failures connected to the circuit
breaker being in open state
- asOutputStream(FiniteDuration) - Method in class akka.stream.javadsl.StreamConverters$
-
Creates a Source which when materialized will return an OutputStream
which it is possible
to write the ByteStrings to the stream this Source is attached to.
- asOutputStream() - Method in class akka.stream.javadsl.StreamConverters$
-
Creates a Source which when materialized will return an OutputStream
which it is possible
to write the ByteStrings to the stream this Source is attached to.
- asOutputStream(FiniteDuration) - Static method in class akka.stream.javadsl.StreamConverters
-
Creates a Source which when materialized will return an OutputStream
which it is possible
to write the ByteStrings to the stream this Source is attached to.
- asOutputStream() - Static method in class akka.stream.javadsl.StreamConverters
-
Creates a Source which when materialized will return an OutputStream
which it is possible
to write the ByteStrings to the stream this Source is attached to.
- asOutputStream(FiniteDuration) - Method in class akka.stream.scaladsl.StreamConverters$
-
Creates a Source which when materialized will return an OutputStream
which it is possible
to write the ByteStrings to the stream this Source is attached to.
- asOutputStream(FiniteDuration) - Static method in class akka.stream.scaladsl.StreamConverters
-
Creates a Source which when materialized will return an OutputStream
which it is possible
to write the ByteStrings to the stream this Source is attached to.
- asOutputStream() - Method in class akka.util.ByteStringBuilder
-
Directly wraps this ByteStringBuilder in an OutputStream.
- asPretty(ByteString) - Constructor for class akka.util.PrettyByteString.asPretty
-
- AsPublisher - Enum in akka.stream.javadsl
-
- asPublisher(AsPublisher) - Method in class akka.stream.javadsl.Sink$
-
A Sink
that materializes into a Publisher
.
- asPublisher(AsPublisher) - Static method in class akka.stream.javadsl.Sink
-
A Sink
that materializes into a Publisher
.
- asPublisher(boolean) - Method in class akka.stream.scaladsl.Sink$
-
A Sink
that materializes into a Publisher
.
- asPublisher(boolean) - Static method in class akka.stream.scaladsl.Sink
-
A Sink
that materializes into a Publisher
.
- asScala() - Method in class akka.japi.Option
-
- asScala() - Method in class akka.japi.Option.Some
-
- asScala() - Method in class akka.stream.javadsl.BidiFlow
-
- asScala() - Method in class akka.stream.javadsl.Flow
-
Converts this Flow to its Scala DSL counterpart
- asScala() - Method in class akka.stream.javadsl.Sink
-
Converts this Sink to its Scala DSL counterpart.
- asScala() - Method in class akka.stream.javadsl.Source
-
Converts this Java DSL element to its Scala DSL counterpart.
- asScala() - Method in class akka.stream.javadsl.SubFlow
-
Converts this Flow to its Scala DSL counterpart
- asScala() - Method in class akka.stream.javadsl.SubSource
-
Converts this Flow to its Scala DSL counterpart
- asScala() - Method in class akka.util.JavaDurationConverters.JavaDurationOps
-
- assembly() - Method in class akka.stream.impl.fusing.GraphModule
-
- assertCompiles(String, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- assertCompiles(String, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- assertCompiles(String, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- assertDoesNotCompile(String, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- assertDoesNotCompile(String, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- assertDoesNotCompile(String, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- assertDone(Duration) - Static method in class akka.testkit.CustomEventFilter
-
- assertDone(Duration) - Static method in class akka.testkit.DeadLettersFilter
-
- assertDone(Duration) - Static method in class akka.testkit.DebugFilter
-
- assertDone(Duration) - Static method in class akka.testkit.ErrorFilter
-
- assertDone(Duration) - Method in class akka.testkit.EventFilter
-
Assert that this filter has matched as often as requested by its
occurrences
parameter specifies.
- assertDone(Duration) - Static method in class akka.testkit.InfoFilter
-
- assertDone(Duration) - Static method in class akka.testkit.WarningFilter
-
- assertionsHelper() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- assertionsHelper() - Static method in class akka.persistence.journal.JournalSpec
-
- assertionsHelper() - Method in class akka.persistence.PluginSpec
-
- assertionsHelper() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- assertLatestGossip() - Method in class akka.cluster.ClusterCoreDaemon
-
- assertResult(Object, Object, Object, Prettifier, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- assertResult(Object, Object, Prettifier, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- assertResult(Object, Object, Object, Prettifier, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- assertResult(Object, Object, Prettifier, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- assertResult(Object, Object, Object, Prettifier, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- assertResult(Object, Object, Prettifier, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- assertThrows(Function0<Object>, ClassTag<T>, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- assertThrows(Function0<Object>, ClassTag<T>, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- assertThrows(Function0<Object>, ClassTag<T>, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- assertTypeError(String, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- assertTypeError(String, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- assertTypeError(String, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- assignAncestor(akka.cluster.ddata.ReplicatedData.T) - Method in interface akka.cluster.ddata.FastMerge
-
INTERNAL API: should be called from "updating" methods
- assignAncestor(akka.cluster.ddata.ReplicatedData.T) - Static method in class akka.cluster.ddata.GCounter
-
- assignAncestor(akka.cluster.ddata.ReplicatedData.T) - Static method in class akka.cluster.ddata.GSet
-
- assignAncestor(akka.cluster.ddata.ReplicatedData.T) - Static method in class akka.cluster.ddata.ORSet
-
- assignPort(InPort, Object) - Method in class akka.stream.impl.MaterializerSession
-
- assignPort(OutPort, Publisher<Object>) - Method in class akka.stream.impl.MaterializerSession
-
- associate(ActorRef, ActorRef) - Method in interface akka.event.ActorClassification
-
Deprecated.
- associate(ActorRef, ActorRef) - Method in interface akka.event.ManagedActorClassification
-
- associate() - Method in class akka.remote.artery.Association
-
Called once after construction when the Association
instance
wins the CAS in the AssociationRegistry
.
- associate(Address) - Method in class akka.remote.transport.AbstractTransportAdapter
-
- associate(Address) - Static method in class akka.remote.transport.ActorTransportAdapter
-
- Associate(HandshakeInfo) - Constructor for class akka.remote.transport.AkkaPduCodec.Associate
-
- associate(Address, Option<Object>) - Method in class akka.remote.transport.AkkaProtocolTransport
-
- associate(Address) - Static method in class akka.remote.transport.FailureInjectorTransportAdapter
-
- associate(Address) - Method in class akka.remote.transport.netty.NettyTransport
-
- associate(Address) - Method in class akka.remote.transport.TestTransport
-
- associate(Address) - Static method in class akka.remote.transport.ThrottlerTransportAdapter
-
- 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(Address) - Method in class akka.remote.artery.ArteryTransport
-
- association(long) - Method in class akka.remote.artery.ArteryTransport
-
- Association - Class in akka.remote.artery
-
INTERNAL API
- Association(ArteryTransport, Materializer, Materializer, Address, InboundControlJunction.ControlMessageSubject, WildcardIndex<NotUsed>, WildcardIndex<NotUsed>, ObjectPool<ReusableOutboundEnvelope>) - Constructor for class akka.remote.artery.Association
-
- association(Address) - Method in class akka.remote.artery.AssociationRegistry
-
- association(long) - Method in class akka.remote.artery.AssociationRegistry
-
- association(Address) - Method in interface akka.remote.artery.InboundContext
-
Lookup the outbound association for a given address.
- association(long) - Method in interface akka.remote.artery.InboundContext
-
Lookup the outbound association for a given UID.
- association() - Method in interface akka.remote.artery.InboundEnvelope
-
- association() - Method in class akka.remote.artery.ReusableInboundEnvelope
-
- association() - Method in class akka.remote.transport.Transport.InboundAssociation
-
- Association$ - Class in akka.remote.artery
-
INTERNAL API
- Association$() - Constructor for class akka.remote.artery.Association$
-
- Association.DisabledQueueWrapper$ - Class in akka.remote.artery
-
- Association.LazyQueueWrapper - Class in akka.remote.artery
-
- Association.LazyQueueWrapper$ - Class in akka.remote.artery
-
- Association.OutboundStreamMatValues - Class in akka.remote.artery
-
- Association.OutboundStreamMatValues$ - Class in akka.remote.artery
-
- Association.QueueWrapper - Interface in akka.remote.artery
-
- Association.QueueWrapperImpl - Class in akka.remote.artery
-
- Association.QueueWrapperImpl$ - Class in akka.remote.artery
-
- 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
-
- associationListener() - Static method in class akka.remote.transport.ThrottlerManager
-
- associationListener_$eq(Transport.AssociationEventListener) - Static method in class akka.remote.transport.ThrottlerManager
-
- AssociationProblem - Interface in akka.remote
-
INTERNAL API
- AssociationRegistry - Class in akka.remote.artery
-
INTERNAL API
- AssociationRegistry(Function1<Address, Association>) - Constructor for class akka.remote.artery.AssociationRegistry
-
- 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$
-
- associationState() - Method in class akka.remote.artery.Association
-
- AssociationState - Class in akka.remote.artery
-
INTERNAL API
- AssociationState(int, Promise<UniqueAddress>, ImmutableLongMap<AssociationState.QuarantinedTimestamp>) - Constructor for class akka.remote.artery.AssociationState
-
- associationState() - Method in interface akka.remote.artery.OutboundContext
-
- AssociationState$ - Class in akka.remote.artery
-
INTERNAL API
- AssociationState$() - Constructor for class akka.remote.artery.AssociationState$
-
- AssociationState.QuarantinedTimestamp - Class in akka.remote.artery
-
- AssociationState.QuarantinedTimestamp$ - Class in akka.remote.artery
-
- asSubscriber() - Method in class akka.stream.javadsl.Source$
-
Creates a Source
that is materialized as a Subscriber
- asSubscriber() - Static method in class akka.stream.javadsl.Source
-
Creates a Source
that is materialized as a Subscriber
- asSubscriber() - Method in class akka.stream.scaladsl.Source$
-
Creates a Source
that is materialized as a Subscriber
- asSubscriber() - Static method in class akka.stream.scaladsl.Source
-
Creates a Source
that is materialized as a Subscriber
- assume(boolean, Prettifier, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- assume(boolean, Object, Prettifier, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- assume(boolean, Prettifier, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- assume(boolean, Object, Prettifier, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- assume(boolean, Prettifier, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- assume(boolean, Object, Prettifier, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- async() - Method in class akka.dispatch.sysmsg.Supervise
-
- async() - Static method in class akka.remote.artery.AeronSink
-
- async() - Static method in class akka.remote.artery.AeronSource
-
- async() - Static method in class akka.remote.artery.Decoder
-
- async() - Static method in class akka.remote.artery.Encoder
-
- async() - Static method in class akka.remote.artery.InboundControlJunction
-
- async() - Static method in class akka.remote.artery.OutboundControlJunction
-
- async() - Static method in class akka.remote.artery.OutboundHandshake
-
- async() - Static method in class akka.remote.artery.SendQueue
-
- async() - Static method in class akka.remote.artery.SystemMessageDelivery
-
- async() - Method in interface akka.stream.Graph
-
Put an asynchronous boundary around this Graph
- async() - Static method in class akka.stream.impl.EmptySource
-
- async() - Static method in class akka.stream.impl.fusing.Batch
-
- async() - Static method in class akka.stream.impl.fusing.Buffer
-
- async() - Static method in class akka.stream.impl.fusing.Collect
-
- async() - Static method in class akka.stream.impl.fusing.Drop
-
- async() - Static method in class akka.stream.impl.fusing.DropWhile
-
- async() - Static method in class akka.stream.impl.fusing.Filter
-
- async() - Static method in class akka.stream.impl.fusing.Fold
-
- async() - Static method in class akka.stream.impl.fusing.Grouped
-
- async() - Static method in class akka.stream.impl.fusing.Intersperse
-
- async() - Static method in class akka.stream.impl.fusing.LimitWeighted
-
- async() - Static method in class akka.stream.impl.fusing.Log
-
- async() - Static method in class akka.stream.impl.fusing.Map
-
- async() - Static method in class akka.stream.impl.fusing.MapAsync
-
- async() - Static method in class akka.stream.impl.fusing.MapAsyncUnordered
-
- async() - Static method in class akka.stream.impl.fusing.MapError
-
- async() - Static method in class akka.stream.impl.fusing.Recover
-
- async() - Static method in class akka.stream.impl.fusing.RecoverWith
-
- async() - Static method in class akka.stream.impl.fusing.Scan
-
- async() - Static method in class akka.stream.impl.fusing.ScanAsync
-
- async() - Static method in class akka.stream.impl.fusing.Sliding
-
- async() - Static method in class akka.stream.impl.fusing.Split
-
- async() - Static method in class akka.stream.impl.fusing.SubSink
-
- async() - Static method in class akka.stream.impl.fusing.SubSource
-
- async() - Static method in class akka.stream.impl.fusing.Take
-
- async() - Static method in class akka.stream.impl.fusing.TakeWhile
-
- async() - Static method in class akka.stream.impl.io.ByteStringParser
-
- async() - Static method in class akka.stream.impl.io.compression.DeflateDecompressorBase
-
- async() - Static method in class akka.stream.impl.io.compression.GzipDecompressor
-
- async() - Static method in class akka.stream.impl.io.ConnectionSourceStage
-
- async() - Static method in class akka.stream.impl.io.InputStreamSinkStage
-
- async() - Static method in class akka.stream.impl.io.OutgoingConnectionStage
-
- async() - Static method in class akka.stream.impl.io.OutputStreamSourceStage
-
- async() - Static method in class akka.stream.impl.LazySource
-
- async() - Static method in class akka.stream.impl.QueueSink
-
- async() - Static method in class akka.stream.impl.QueueSource
-
- async() - Method in class akka.stream.impl.SubFlowImpl
-
- async() - Static method in class akka.stream.javadsl.BidiFlow
-
- async() - Method in class akka.stream.javadsl.Flow
-
Put an asynchronous boundary around this Flow
- async() - Static method in class akka.stream.javadsl.RunnableGraph
-
- async() - Method in class akka.stream.javadsl.Sink
-
Put an asynchronous boundary around this Sink
- async() - Method in class akka.stream.javadsl.Source
-
Put an asynchronous boundary around this Source
- async() - Method in class akka.stream.javadsl.SubFlow
-
Put an asynchronous boundary around this SubFlow
- async() - Method in class akka.stream.javadsl.SubSource
-
Put an asynchronous boundary around this SubSource
- async() - Static method in class akka.stream.scaladsl.Balance
-
- async() - Method in class akka.stream.scaladsl.BidiFlow
-
- async() - Static method in class akka.stream.scaladsl.Broadcast
-
- async() - Static method in class akka.stream.scaladsl.BroadcastHub
-
- async() - Static method in class akka.stream.scaladsl.Concat
-
- async() - Method in class akka.stream.scaladsl.Flow
-
Put an asynchronous boundary around this Flow
- async() - Method in interface akka.stream.scaladsl.FlowOps
-
Put an asynchronous boundary around this Flow
.
- async() - Static method in class akka.stream.scaladsl.Interleave
-
- async() - Static method in class akka.stream.scaladsl.Merge
-
- async() - Static method in class akka.stream.scaladsl.MergeHub
-
- async() - Static method in class akka.stream.scaladsl.MergePreferred
-
- async() - Static method in class akka.stream.scaladsl.OrElse
-
- async() - Static method in class akka.stream.scaladsl.Partition
-
- async() - Method in class akka.stream.scaladsl.RunnableGraph
-
- async() - Method in class akka.stream.scaladsl.Sink
-
Put an asynchronous boundary around this Sink
- async() - Method in class akka.stream.scaladsl.Source
-
Put an asynchronous boundary around this Source
- async() - Static method in class akka.stream.scaladsl.Unzip
-
- async() - Static method in class akka.stream.scaladsl.Zip
-
- async() - Static method in class akka.stream.scaladsl.ZipN
-
- async() - Static method in class akka.stream.scaladsl.ZipWithN
-
- async() - Static method in class akka.stream.testkit.TestSinkStage
-
- async() - Static method in class akka.stream.testkit.TestSourceStage
-
- ASYNC_FIELD_NUMBER - Static variable in class akka.remote.SystemMessageFormats.SuperviseData
-
- asyncBoundary() - Method in class akka.stream.Attributes$
-
- asyncBoundary() - Static method in class akka.stream.Attributes
-
- AsyncBoundary$() - Constructor for class akka.stream.Attributes.AsyncBoundary$
-
- AsyncCallback<T> - Interface in akka.stream.stage
-
- asyncDeleteMessagesTo(String, long) - Method in interface akka.persistence.journal.AsyncWriteJournal
-
Plugin API: asynchronously deletes all persistent messages up to toSequenceNr
(inclusive).
- asyncDeleteMessagesTo(String, long) - Method in interface akka.persistence.journal.AsyncWriteProxy
-
- asyncDeleteMessagesTo(String, long) - Method in class akka.persistence.journal.inmem.InmemJournal
-
- asyncDeleteMessagesTo(String, long) - Method in class akka.persistence.journal.japi.AsyncWriteJournal
-
- asyncDeleteMessagesTo(String, long) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- asyncDeleteMessagesTo(String, long) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
-
- asyncDeleteMessagesTo(String, long) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- AsyncDirective - Interface in akka.stream.stage
-
- AsyncHandlerInvocation(Object, Function1<Object, BoxedUnit>) - Constructor for class akka.persistence.Eventsourced.AsyncHandlerInvocation
-
- AsyncHandlerInvocation$() - Constructor for class akka.persistence.Eventsourced.AsyncHandlerInvocation$
-
- AsyncInput(GraphInterpreterShell, GraphStageLogic, Object, Function1<Object, BoxedUnit>) - Constructor for class akka.stream.impl.fusing.ActorGraphInterpreter.AsyncInput
-
- AsyncInput$() - Constructor for class akka.stream.impl.fusing.ActorGraphInterpreter.AsyncInput$
-
- 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.inmem.InmemJournal
-
- asyncReadHighestSequenceNr(String, long) - Method in class akka.persistence.journal.japi.AsyncRecovery
-
- asyncReadHighestSequenceNr(String, long) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- asyncReadHighestSequenceNr(String, long) - Method in interface akka.persistence.journal.leveldb.LeveldbRecovery
-
- asyncReadHighestSequenceNr(String, long) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- 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.inmem.InmemJournal
-
- asyncReplayMessages(String, long, long, long, Function1<PersistentRepr, BoxedUnit>) - Method in class akka.persistence.journal.japi.AsyncRecovery
-
- asyncReplayMessages(String, long, long, long, Function1<PersistentRepr, BoxedUnit>) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- asyncReplayMessages(String, long, long, long, Function1<PersistentRepr, BoxedUnit>) - Method in interface akka.persistence.journal.leveldb.LeveldbRecovery
-
- asyncReplayMessages(String, long, long, long, Function1<PersistentRepr, BoxedUnit>) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- asyncReplayTaggedMessages(String, long, long, long, Function1<LeveldbJournal.ReplayedTaggedMessage, BoxedUnit>) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- asyncReplayTaggedMessages(String, long, long, long, Function1<LeveldbJournal.ReplayedTaggedMessage, 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<AtomicWrite>) - Method in interface akka.persistence.journal.AsyncWriteJournal
-
Plugin API: asynchronously writes a batch (Seq
) of persistent messages to the
journal.
- asyncWriteMessages(Seq<AtomicWrite>) - Method in interface akka.persistence.journal.AsyncWriteProxy
-
- asyncWriteMessages(Seq<AtomicWrite>) - Method in class akka.persistence.journal.inmem.InmemJournal
-
- asyncWriteMessages(Seq<AtomicWrite>) - Method in class akka.persistence.journal.japi.AsyncWriteJournal
-
- asyncWriteMessages(Seq<AtomicWrite>) - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- asyncWriteMessages(Seq<AtomicWrite>) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
-
- asyncWriteMessages(Seq<AtomicWrite>) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- 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.InitTimeout$ - Class in akka.persistence.journal
-
- 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.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.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
-
- atLeast(int, C, Collecting<E, C>, Prettifier, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- atLeast(int, JMAP, Collecting<Entry<K, V>, JMAP>, Prettifier, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- atLeast(int, String, Collecting<Object, String>, Prettifier, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- atLeast(int, C, Collecting<E, C>, Prettifier, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- atLeast(int, JMAP, Collecting<Entry<K, V>, JMAP>, Prettifier, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- atLeast(int, String, Collecting<Object, String>, Prettifier, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- atLeast(int, C, Collecting<E, C>, Prettifier, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- atLeast(int, JMAP, Collecting<Entry<K, V>, JMAP>, Prettifier, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- atLeast(int, String, Collecting<Object, String>, Prettifier, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- 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
-
INTERNAL API
- 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
-
- AtLeastOnceDeliveryLike - Interface 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
-
- atLeastOneElementOf(GenTraversable<Object>) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- atLeastOneElementOf(GenTraversable<Object>) - Static method in class akka.persistence.journal.JournalSpec
-
- atLeastOneElementOf(GenTraversable<Object>) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- atLeastOneOf(Object, Object, Seq<Object>, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- atLeastOneOf(Object, Object, Seq<Object>, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- atLeastOneOf(Object, Object, Seq<Object>, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- atMost(int, C, Collecting<E, C>, Prettifier, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- atMost(int, JMAP, Collecting<Entry<K, V>, JMAP>, Prettifier, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- atMost(int, String, Collecting<Object, String>, Prettifier, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- atMost(int, C, Collecting<E, C>, Prettifier, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- atMost(int, JMAP, Collecting<Entry<K, V>, JMAP>, Prettifier, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- atMost(int, String, Collecting<Object, String>, Prettifier, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- atMost(int, C, Collecting<E, C>, Prettifier, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- atMost(int, JMAP, Collecting<Entry<K, V>, JMAP>, Prettifier, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- atMost(int, String, Collecting<Object, String>, Prettifier, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- atMostOneElementOf(GenTraversable<R>) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- atMostOneElementOf(GenTraversable<R>) - Static method in class akka.persistence.journal.JournalSpec
-
- atMostOneElementOf(GenTraversable<R>) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- atMostOneOf(Object, Object, Seq<Object>, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- atMostOneOf(Object, Object, Seq<Object>, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- atMostOneOf(Object, Object, Seq<Object>, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- Atomic(StreamLayout.Module) - Constructor for class akka.stream.impl.StreamLayout.Atomic
-
- Atomic$() - Constructor for class akka.stream.impl.StreamLayout.Atomic$
-
- AtomicModule() - Constructor for class akka.stream.impl.StreamLayout.AtomicModule
-
- AtomicWrite - Class in akka.persistence
-
- AtomicWrite(Seq<PersistentRepr>) - Constructor for class akka.persistence.AtomicWrite
-
- AtomicWrite$ - Class in akka.persistence
-
- AtomicWrite$() - Constructor for class akka.persistence.AtomicWrite$
-
- AtomicWriteClass() - Method in class akka.persistence.serialization.MessageSerializer
-
- atop(BidiFlow<O1, OO1, II2, I2, Mat2>) - Method in class akka.stream.javadsl.BidiFlow
-
Add the given BidiFlow as the next step in a bidirectional transformation
pipeline.
- atop(BidiFlow<O1, OO1, II2, I2, Mat2>, Function2<Mat, Mat2, M>) - Method in class akka.stream.javadsl.BidiFlow
-
Add the given BidiFlow as the next step in a bidirectional transformation 161
- atop(Graph<BidiShape<O1, OO1, II2, I2>, Mat2>) - Method in class akka.stream.scaladsl.BidiFlow
-
Add the given BidiFlow as the next step in a bidirectional transformation
pipeline.
- atopMat(Graph<BidiShape<O1, OO1, II2, I2>, Mat2>, Function2<Mat, Mat2, M>) - Method in class akka.stream.scaladsl.BidiFlow
-
Add the given BidiFlow as the next step in a bidirectional transformation
pipeline.
- 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(InboundControlJunction.ControlMessageObserver, Promise<Done>) - Constructor for class akka.remote.artery.InboundControlJunction.Attach
-
- attach(InboundControlJunction.ControlMessageObserver) - Method in interface akka.remote.artery.InboundControlJunction.ControlMessageSubject
-
- attach(ActorCell) - Static method in class akka.testkit.CallingThreadDispatcher
-
- attach() - Method in class akka.util.SerializedSuspendableExecutionContext
-
- Attach$() - Constructor for class akka.remote.artery.InboundControlJunction.Attach$
-
- attachChild(Props, boolean) - Static method in class akka.actor.ActorCell
-
- attachChild(Props, String, boolean) - Static method in class akka.actor.ActorCell
-
- attachChild(Props, boolean) - Method in interface akka.actor.dungeon.Children
-
- attachChild(Props, String, boolean) - Method in interface akka.actor.dungeon.Children
-
- attachChild(Props, boolean) - Static method in class akka.routing.RoutedActorCell
-
- attachChild(Props, String, boolean) - Static method in class akka.routing.RoutedActorCell
-
- attachConductor(TestConductorExt) - Method in class akka.remote.testkit.MultiNodeSpec
-
- attachDownstreamBoundary(GraphInterpreter.Connection, GraphInterpreter.DownstreamBoundaryStageLogic<?>) - Method in class akka.stream.impl.fusing.GraphInterpreter
-
Assign the boundary logic to a given connection.
- attachDownstreamBoundary(int, GraphInterpreter.DownstreamBoundaryStageLogic<?>) - Method in class akka.stream.impl.fusing.GraphInterpreter
-
- attachments() - Method in class akka.camel.CamelMessage
-
- attachments(Set<String>) - Method in class akka.camel.CamelMessage
-
Returns those attachments from this message whose name is contained in names
.
- attachUpstreamBoundary(GraphInterpreter.Connection, GraphInterpreter.UpstreamBoundaryStageLogic<?>) - Method in class akka.stream.impl.fusing.GraphInterpreter
-
Assign the boundary logic to a given connection.
- attachUpstreamBoundary(int, GraphInterpreter.UpstreamBoundaryStageLogic<?>) - Method in class akka.stream.impl.fusing.GraphInterpreter
-
- attempt() - Method in class akka.cluster.JoinSeedNodeProcess
-
- 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$
-
- attributeList() - Method in class akka.stream.Attributes
-
- Attributes - Class in akka.stream
-
- Attributes(List<Attributes.Attribute>) - Constructor for class akka.stream.Attributes
-
- attributes() - Method in class akka.stream.impl.ActorPublisherSource
-
- attributes() - Method in class akka.stream.impl.ActorRefSink
-
- attributes() - Method in class akka.stream.impl.ActorRefSource
-
- attributes() - Method in class akka.stream.impl.ActorSubscriberSink
-
- attributes() - Method in class akka.stream.impl.CancelSink
-
- attributes() - Method in class akka.stream.impl.FanoutPublisherSink
-
- attributes() - Method in class akka.stream.impl.fusing.GraphModule
-
- attributes() - Method in class akka.stream.impl.fusing.GraphStageModule
-
- attributes() - Method in class akka.stream.impl.io.FileSink
-
- attributes() - Method in class akka.stream.impl.io.FileSource
-
- attributes() - Method in class akka.stream.impl.io.InputStreamSource
-
- attributes() - Method in class akka.stream.impl.io.OutputStreamSink
-
- attributes() - Method in class akka.stream.impl.io.TlsModule
-
- attributes() - Method in class akka.stream.impl.MaybeSource
-
- attributes() - Method in class akka.stream.impl.ProcessorModule
-
- attributes() - Method in class akka.stream.impl.PublisherSink
-
- attributes() - Method in class akka.stream.impl.PublisherSource
-
- attributes() - Method in interface akka.stream.impl.Stages.SymbolicStage
-
- attributes() - Method in class akka.stream.impl.StreamLayout.CompositeModule
-
- attributes() - Method in class akka.stream.impl.StreamLayout.CopiedModule
-
- attributes() - Method in class akka.stream.impl.StreamLayout.EmptyModule$
-
- attributes() - Method in class akka.stream.impl.StreamLayout.FusedModule
-
- attributes() - Method in interface akka.stream.impl.StreamLayout.Module
-
- attributes() - Method in class akka.stream.impl.StreamLayout.StructuralInfoModule
-
- attributes() - Method in class akka.stream.impl.SubscriberSink
-
- attributes() - Method in class akka.stream.impl.SubscriberSource
-
- attributes() - Method in interface akka.stream.stage.LifecycleContext
-
Returns operation attributes associated with the this Stage
- attributes() - Method in class akka.stream.testkit.StreamTestKit.ProbeSink
-
- attributes() - Method in class akka.stream.testkit.StreamTestKit.ProbeSource
-
- Attributes$ - Class in akka.stream
-
- Attributes$() - Constructor for class akka.stream.Attributes$
-
- Attributes.AsyncBoundary$ - Class in akka.stream
-
- Attributes.Attribute - Interface in akka.stream
-
- Attributes.InputBuffer - Class in akka.stream
-
- Attributes.InputBuffer$ - Class in akka.stream
-
- Attributes.LogLevels - Class in akka.stream
-
- Attributes.LogLevels$ - Class in akka.stream
-
- Attributes.Name - Class in akka.stream
-
- Attributes.Name$ - Class in akka.stream
-
- augmentScheme(String) - Static method in class akka.remote.transport.ActorTransportAdapter
-
- augmentScheme(Address) - Static method in class akka.remote.transport.ActorTransportAdapter
-
- augmentScheme(String) - Static method in class akka.remote.transport.AkkaProtocolTransport
-
- augmentScheme(Address) - Static method in class akka.remote.transport.AkkaProtocolTransport
-
- augmentScheme(String) - Static method in class akka.remote.transport.FailureInjectorHandle
-
- augmentScheme(Address) - Static method in class akka.remote.transport.FailureInjectorHandle
-
- augmentScheme(String) - Static method in class akka.remote.transport.FailureInjectorTransportAdapter
-
- augmentScheme(Address) - Static method in class akka.remote.transport.FailureInjectorTransportAdapter
-
- augmentScheme(String) - Method in interface akka.remote.transport.SchemeAugmenter
-
- augmentScheme(Address) - Method in interface akka.remote.transport.SchemeAugmenter
-
- augmentScheme(String) - Static method in class akka.remote.transport.ThrottlerHandle
-
- augmentScheme(Address) - Static method in class akka.remote.transport.ThrottlerHandle
-
- augmentScheme(String) - Static method in class akka.remote.transport.ThrottlerTransportAdapter
-
- augmentScheme(Address) - Static method in class akka.remote.transport.ThrottlerTransportAdapter
-
- 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 class akka.camel.internal.component.ActorEndpoint
-
- 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
-
- AutoDowning - Class in akka.cluster
-
Used when no custom provider is configured and 'auto-down-unreachable-after' is enabled.
- AutoDowning(ActorSystem) - Constructor for class akka.cluster.AutoDowning
-
- AutoDownUnreachableAfter() - Method in class akka.cluster.ClusterSettings
-
- autoFusing() - Method in class akka.stream.ActorMaterializerSettings
-
- 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
-
- autoReceiveMessage(Envelope) - Static method in class akka.routing.RoutedActorCell
-
- autoResendTimer() - Method in class akka.remote.ReliableDeliverySupervisor
-
- AutoReset - Class in akka.pattern
-
- AutoReset(FiniteDuration) - Constructor for class akka.pattern.AutoReset
-
- AutoReset$ - Class in akka.pattern
-
- AutoReset$() - Constructor for class akka.pattern.AutoReset$
-
- autoSelectPort(String) - Method in class akka.remote.artery.ArteryTransport$
-
- autoSelectPort(String) - Static method in class akka.remote.artery.ArteryTransport
-
- autoUpdate() - Method in class akka.persistence.PersistenceSettings.view
-
- autoUpdate() - Method in interface akka.persistence.PersistentView
-
Deprecated.
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
-
Deprecated.
The interval for automated updates.
- autoUpdateReplayMax() - Method in class akka.persistence.PersistenceSettings.view
-
- autoUpdateReplayMax() - Method in interface akka.persistence.PersistentView
-
Deprecated.
The maximum number of messages to replay per update.
- availableChunks() - Method in class akka.stream.impl.io.FilePublisher
-
- availableNodes() - Method in interface akka.cluster.routing.ClusterRouterActor
-
- availableTokens() - Method in class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket
-
- average() - Method in class akka.cluster.Metric
-
Deprecated.
- average() - Method in class akka.cluster.metrics.Metric
-
- averageProbeDistance() - Method in class akka.remote.artery.CacheStatistics
-
- 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(Function0<Object>, Duration, Duration) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- awaitAssert(Function0<Object>, Duration, Duration) - Static method in class akka.persistence.journal.JournalSpec
-
- awaitAssert(Function0<Object>, Duration, Duration) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- awaitAssert(Function0<Object>, Duration, Duration) - Static method in class akka.remote.testkit.MultiNodeSpec
-
- 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) - Static method in class akka.testkit.TestKit
-
- 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.
- awaitAssert(Function0<Object>, Duration, Duration) - Static method in class akka.testkit.TestProbe
-
- awaitAssert$default$2() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- awaitAssert$default$2() - Static method in class akka.persistence.journal.JournalSpec
-
- awaitAssert$default$2() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- awaitAssert$default$2() - Static method in class akka.remote.testkit.MultiNodeSpec
-
- awaitAssert$default$2() - Static method in class akka.testkit.TestKit
-
- awaitAssert$default$2() - Static method in class akka.testkit.TestProbe
-
- awaitAssert$default$3() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- awaitAssert$default$3() - Static method in class akka.persistence.journal.JournalSpec
-
- awaitAssert$default$3() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- awaitAssert$default$3() - Static method in class akka.remote.testkit.MultiNodeSpec
-
- awaitAssert$default$3() - Static method in class akka.testkit.TestKit
-
- awaitAssert$default$3() - Static method in class akka.testkit.TestProbe
-
- awaitCond(Function0<Object>, Duration, Duration, String) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- awaitCond(Function0<Object>, Duration, Duration, String) - Static method in class akka.persistence.journal.JournalSpec
-
- awaitCond(Function0<Object>, Duration, Duration, String) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- awaitCond(Function0<Object>, Duration, Duration, String) - Static method in class akka.remote.testkit.MultiNodeSpec
-
- 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.
- awaitCond(Function0<Object>, Duration, Duration, String) - Static method in class akka.testkit.TestProbe
-
- awaitCond$default$2() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- awaitCond$default$2() - Static method in class akka.persistence.journal.JournalSpec
-
- awaitCond$default$2() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- awaitCond$default$2() - Static method in class akka.remote.testkit.MultiNodeSpec
-
- awaitCond$default$2() - Static method in class akka.testkit.TestKit
-
- awaitCond$default$2() - Static method in class akka.testkit.TestProbe
-
- awaitCond$default$3() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- awaitCond$default$3() - Static method in class akka.persistence.journal.JournalSpec
-
- awaitCond$default$3() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- awaitCond$default$3() - Static method in class akka.remote.testkit.MultiNodeSpec
-
- awaitCond$default$3() - Static method in class akka.testkit.TestKit
-
- awaitCond$default$3() - Static method in class akka.testkit.TestProbe
-
- awaitCond$default$4() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- awaitCond$default$4() - Static method in class akka.persistence.journal.JournalSpec
-
- awaitCond$default$4() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- awaitCond$default$4() - Static method in class akka.remote.testkit.MultiNodeSpec
-
- awaitCond$default$4() - Static method in class akka.testkit.TestKit
-
- awaitCond$default$4() - Static method in class akka.testkit.TestProbe
-
- 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) - Static method in class akka.testkit.CustomEventFilter
-
- awaitDone(Duration) - Static method in class akka.testkit.DeadLettersFilter
-
- awaitDone(Duration) - Static method in class akka.testkit.DebugFilter
-
- awaitDone(Duration) - Static method in class akka.testkit.ErrorFilter
-
- awaitDone(Duration) - Method in class akka.testkit.EventFilter
-
- awaitDone(Duration) - Static method in class akka.testkit.InfoFilter
-
- awaitDone(Duration) - Static method in class akka.testkit.WarningFilter
-
- 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
-
- awaitingClose() - Method in class akka.stream.impl.io.TLSActor
-
- awaitTermination(Duration) - Method in class akka.actor.ActorSystem
-
- awaitTermination() - Method in class akka.actor.ActorSystem
-
- 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 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
-
- cachedAssociation() - Method in class akka.remote.RemoteActorRef
-
- cachedSendQueueIndex() - Method in class akka.remote.RemoteActorRef
-
- CacheStatistics - Class in akka.remote.artery
-
INTERNAL API
- CacheStatistics(int, int, double) - Constructor for class akka.remote.artery.CacheStatistics
-
- CacheStatistics$ - Class in akka.remote.artery
-
- CacheStatistics$() - Constructor for class akka.remote.artery.CacheStatistics$
-
- CachingConfig - Class in akka.dispatch
-
INTERNAL API
- CachingConfig(Config) - Constructor for class akka.dispatch.CachingConfig
-
- cachingConfig() - Method in class akka.dispatch.Dispatchers
-
- cachingConfig() - Method in class akka.typed.internal.DispatchersImpl
-
- 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
-
- calculateDelay(int, FiniteDuration, FiniteDuration, double) - Method in class akka.pattern.BackoffSupervisor$
-
INTERNAL API
- calculateDelay(int, FiniteDuration, FiniteDuration, double) - Static method in class akka.pattern.BackoffSupervisor
-
INTERNAL API
- callback() - Method in class akka.cluster.InternalClusterAction.AddOnMemberRemovedListener
-
- callback() - Method in class akka.cluster.InternalClusterAction.AddOnMemberUpListener
-
- CallbackBridge() - Constructor for class akka.dispatch.japi.CallbackBridge
-
Deprecated.
- CallbackWrapper<T> - Interface in akka.stream.stage
-
INTERNAL API
This trait wraps callback for GraphStage
stage instances and handle gracefully cases when stage is
not yet initialized or already finished.
- CallbackWrapper.CallbackState - Interface in akka.stream.stage
-
- CallbackWrapper.Initialized - Class in akka.stream.stage
-
- CallbackWrapper.NotInitialized - Class in akka.stream.stage
-
- CallbackWrapper.Stopped - Class in akka.stream.stage
-
- CallFailed() - Constructor for class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitBreakerInternalEvents$.CallFailed
-
- 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
-
- CallSucceeded() - Constructor for class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitBreakerInternalEvents$.CallSucceeded
-
- callSucceededHandling() - Method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- callTimeout() - Method in class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitBreakerPropsBuilder
-
- callWithCircuitBreaker(Callable<Future<T>>) - Method in class akka.pattern.CircuitBreaker
-
- callWithCircuitBreakerCS(Callable<CompletionStage<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.CamelSupervisor
-
- camel() - Method in class akka.camel.internal.component.ActorEndpoint
-
- camel() - Method in interface akka.camel.internal.component.ActorEndpointConfig
-
- camel() - Method in class akka.camel.internal.ConsumerRegistrar
-
- camel() - Method in class akka.camel.internal.ProducerRegistrar
-
- camel() - Method in class akka.camel.internal.Registry
-
- camel() - Method in class akka.camel.javaapi.UntypedConsumerActor
-
- camel() - Method in class akka.camel.javaapi.UntypedProducerActor
-
- camelContext() - Method in interface akka.camel.CamelSupport
-
Returns the CamelContext.
- camelContext() - Static method in class akka.camel.internal.CamelSupervisor
-
- 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>, Map<String, DataHandler>) - Constructor for class akka.camel.CamelMessage
-
- CamelMessage(Object, Map<String, Object>) - Constructor for class akka.camel.CamelMessage
-
- CamelMessage(Object, Map<String, Object>, Map<String, DataHandler>) - 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
-
- cancel(boolean) - Static method in class akka.dispatch.Mailbox
-
- cancel() - Method in class akka.persistence.fsm.PersistentFSM.Timer
-
- cancel(Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- cancel(String, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- cancel(String, Throwable, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- cancel(Throwable, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- cancel(Position) - Static method in class akka.persistence.journal.JournalSpec
-
- cancel(String, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- cancel(String, Throwable, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- cancel(Throwable, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- cancel(Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- cancel(String, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- cancel(String, Throwable, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- cancel(Throwable, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- cancel() - Static method in class akka.stream.actor.AbstractActorSubscriber
-
- Cancel() - Constructor for class akka.stream.actor.ActorPublisherMessage.Cancel
-
- cancel() - Method in class akka.stream.actor.ActorPublisherSubscription
-
- cancel() - Method in interface akka.stream.actor.ActorSubscriber
-
Cancel upstream subscription.
- cancel() - Static method in class akka.stream.actor.UntypedActorSubscriber
-
- cancel() - Static method in class akka.stream.impl.ActorRefSinkActor
-
- cancel() - Method in class akka.stream.impl.ActorSubscription
-
- cancel() - Method in class akka.stream.impl.BatchingInputBuffer
-
- Cancel - Class in akka.stream.impl
-
INTERNAL API
- Cancel(ActorSubscription<?>) - Constructor for class akka.stream.impl.Cancel
-
- cancel() - Method in class akka.stream.impl.CancelledSubscription$
-
- cancel() - Static method in class akka.stream.impl.CancelledSubscription
-
- cancel() - Method in class akka.stream.impl.FanIn.InputBunch
-
- cancel(int) - Method in class akka.stream.impl.FanIn.InputBunch
-
- cancel(Throwable) - Method in class akka.stream.impl.FanOut.OutputBunch
-
- cancel() - Method in class akka.stream.impl.FanOut.SubstreamSubscription
-
- cancel() - Method in class akka.stream.impl.FanoutOutputs
-
- cancel() - Method in class akka.stream.impl.fusing.ActorGraphInterpreter.ActorOutputBoundary
-
- cancel() - Method in class akka.stream.impl.fusing.ActorGraphInterpreter.BatchingActorInputBoundary
-
- cancel() - Method in class akka.stream.impl.fusing.ActorGraphInterpreter.BoundarySubscription
-
- Cancel(GraphInterpreterShell, int) - Constructor for class akka.stream.impl.fusing.ActorGraphInterpreter.Cancel
-
- cancel(GraphInterpreter.Connection) - Method in class akka.stream.impl.fusing.GraphInterpreter
-
- cancel() - Method in interface akka.stream.impl.Inputs
-
- cancel() - Static method in class akka.stream.impl.io.FileSubscriber
-
- cancel() - Static method in class akka.stream.impl.io.OutputStreamSubscriber
-
- cancel() - Method in interface akka.stream.impl.Outputs
-
- cancel() - Method in class akka.stream.impl.SimpleOutputs
-
- cancel() - Method in class akka.stream.impl.SinkQueueAdapter
-
- cancel(Publisher<?>, FiniteDuration) - Method in interface akka.stream.impl.StreamSubscriptionTimeoutSupport
-
- cancel() - Method in class akka.stream.impl.StreamSubscriptionTimeoutSupport.NoopSubscriptionTimeout$
-
- cancel() - Method in interface akka.stream.javadsl.SinkQueueWithCancel
-
Cancel the stream.
- cancel() - Method in interface akka.stream.scaladsl.SinkQueueWithCancel
-
Cancel the stream.
- cancel(Inlet<T>) - Method in class akka.stream.stage.GraphStageLogic
-
Requests to stop receiving events from a given input port.
- cancel() - Method in class akka.stream.stage.GraphStageLogic.SubSinkInlet
-
- cancel() - Method in class akka.stream.StreamSubscriptionTimeoutTerminationMode$
-
When the timeout expires attach a Subscriber that will immediately cancel its subscription.
- cancel() - Static method in class akka.stream.StreamSubscriptionTimeoutTerminationMode
-
When the timeout expires attach a Subscriber that will immediately cancel its subscription.
- cancel() - Method in class akka.stream.testkit.StreamTestKit.CompletedSubscription
-
- cancel() - Method in class akka.stream.testkit.StreamTestKit.FailedSubscription
-
- cancel() - Method in class akka.stream.testkit.StreamTestKit.PublisherProbeSubscription
-
- cancel() - Method in class akka.stream.testkit.TestSubscriber.Probe
-
- Cancel$() - Constructor for class akka.stream.actor.ActorPublisherMessage.Cancel$
-
- Cancel$ - Class in akka.stream.impl
-
- Cancel$() - Constructor for class akka.stream.impl.Cancel$
-
- Cancel$() - Constructor for class akka.stream.impl.fusing.ActorGraphInterpreter.Cancel$
-
- Cancel$() - Constructor for class akka.stream.impl.fusing.SubSink.Cancel$
-
- Cancel$() - Constructor for class akka.stream.impl.QueueSink.Cancel$
-
- canceled() - Static method in class akka.stream.actor.AbstractActorSubscriber
-
- Canceled() - Constructor for class akka.stream.actor.ActorPublisher.Internal$.Canceled
-
- canceled() - Method in interface akka.stream.actor.ActorSubscriber
-
- canceled() - Method in class akka.stream.actor.ActorSubscriberState.State
-
- canceled() - Static method in class akka.stream.actor.UntypedActorSubscriber
-
- canceled() - Static method in class akka.stream.impl.ActorRefSinkActor
-
- canceled() - Static method in class akka.stream.impl.io.FileSubscriber
-
- canceled() - Static method in class akka.stream.impl.io.OutputStreamSubscriber
-
- Canceled$() - Constructor for class akka.stream.impl.io.OutputStreamSourceStage.Canceled$
-
- CancelingSubscriber$() - Constructor for class akka.stream.impl.StreamSubscriptionTimeoutSupport.CancelingSubscriber$
-
- cancelInstance() - Method in class akka.stream.actor.ActorPublisherMessage$
-
Java API: get the singleton instance of the Cancel
message
- cancelInstance() - Static method in class akka.stream.actor.ActorPublisherMessage
-
Java API: get the singleton instance of the Cancel
message
- 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.
- Cancelled() - Method in class akka.stream.impl.FanIn$
-
- Cancelled() - Static method in class akka.stream.impl.FanIn
-
- cancelled() - Method in class akka.stream.javadsl.Sink$
-
A Sink
that immediately cancels its upstream after materialization.
- cancelled() - Static method in class akka.stream.javadsl.Sink
-
A Sink
that immediately cancels its upstream after materialization.
- cancelled() - Method in class akka.stream.scaladsl.Sink$
-
A Sink
that immediately cancels its upstream after materialization.
- cancelled() - Static method in class akka.stream.scaladsl.Sink
-
A Sink
that immediately cancels its upstream after materialization.
- cancelledSink() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- CancelledSubscription - Class in akka.stream.impl
-
INTERNAL API
This is only a legal subscription when it is immediately followed by
a termination signal (onComplete, onError).
- CancelledSubscription() - Constructor for class akka.stream.impl.CancelledSubscription
-
- CancelledSubscription$ - Class in akka.stream.impl
-
INTERNAL API
This is only a legal subscription when it is immediately followed by
a termination signal (onComplete, onError).
- CancelledSubscription$() - Constructor for class akka.stream.impl.CancelledSubscription$
-
- CancellingSubscriber<T> - Class in akka.stream.impl
-
- CancellingSubscriber() - Constructor for class akka.stream.impl.CancellingSubscriber
-
- cancelReceiveTimeout() - Static method in class akka.actor.ActorCell
-
- cancelReceiveTimeout() - Method in interface akka.actor.dungeon.ReceiveTimeout
-
- cancelReceiveTimeout() - Static method in class akka.routing.RoutedActorCell
-
- cancelReceiveTimeout() - Method in interface akka.typed.ActorContext
-
Cancel the sending of receive timeout notifications.
- cancelReceiveTimeout() - Method in class akka.typed.adapter.ActorContextAdapter
-
- cancelReceiveTimeout() - Method in class akka.typed.EffectfulActorContext
-
- cancelReceiveTimeout() - Method in class akka.typed.internal.ActorCell
-
- cancelReceiveTimeout() - Method in class akka.typed.StubbedActorContext
-
- CancelScheduledBeforeMaterialization$() - Constructor for class akka.stream.impl.fusing.SubSink.CancelScheduledBeforeMaterialization$
-
- cancelSelf() - Method in interface akka.stream.actor.ActorPublisher
-
- CancelSink - Class in akka.stream.impl
-
INTERNAL API
A sink that immediately cancels its upstream upon materialization.
- CancelSink(Attributes, SinkShape<Object>) - Constructor for class akka.stream.impl.CancelSink
-
- CancelSubscription(Subscription) - Constructor for class akka.stream.testkit.TestPublisher.CancelSubscription
-
- CancelSubscription$() - Constructor for class akka.stream.testkit.TestPublisher.CancelSubscription$
-
- cancelSubstream() - Method in class akka.stream.impl.fusing.SubSink
-
- CancelTermination$() - Constructor for class akka.stream.StreamSubscriptionTimeoutTerminationMode.CancelTermination$
-
- cancelTimer(String) - Static method in class akka.actor.AbstractFSM
-
- cancelTimer(String) - Method in interface akka.actor.FSM
-
- cancelTimer(String) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- cancelTimer() - Method in class akka.cluster.singleton.ClusterSingletonProxy
-
- cancelTimer(String) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- cancelTimer(String) - Static method in class akka.contrib.pattern.ReliableProxy
-
- cancelTimer(String) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- cancelTimer(String) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- cancelTimer(String) - Method in interface akka.persistence.fsm.PersistentFSMBase
-
- cancelTimer(String) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- cancelTimer(String) - Static method in class akka.remote.testconductor.ClientFSM
-
- cancelTimer(String) - Static method in class akka.remote.testconductor.ServerFSM
-
- cancelTimer(String) - Static method in class akka.remote.transport.ProtocolStateActor
-
- cancelTimer(String) - Static method in class akka.remote.transport.ThrottledAssociation
-
- cancelTimer(Object) - Method in class akka.stream.stage.TimerGraphStageLogic
-
- cancelTimer(String) - Method in class akka.testkit.TestFSMRef
-
- cancelUpstream() - Method in class akka.stream.impl.FanoutOutputs
-
- cancelUpstream() - Method in interface akka.stream.impl.SubscriberManagement
-
called before shutdown()
if the stream is *not* being regularly completed
but shut-down due to the last subscriber having canceled its subscription
- canEqual(Object) - Static method in class akka.actor.ActorIdentity
-
- canEqual(Object) - Static method in exception akka.actor.ActorKilledException
-
- canEqual(Object) - Static method in exception akka.actor.ActorNotFound
-
- canEqual(Object) - Static method in class akka.actor.ActorSelectionMessage
-
- canEqual(Object) - Static method in class akka.actor.Address
-
- canEqual(Object) - Static method in class akka.actor.AddressTerminated
-
- canEqual(Object) - Static method in class akka.actor.AllForOneStrategy
-
- canEqual(Object) - Static method in class akka.actor.ChildNameReserved
-
- canEqual(Object) - Static method in class akka.actor.ChildRestartStats
-
- canEqual(Object) - Static method in class akka.actor.ContextualTypedActorFactory
-
- canEqual(Object) - Static method in class akka.actor.DeadLetter
-
- canEqual(Object) - Static method in exception akka.actor.DeathPactException
-
- canEqual(Object) - Static method in class akka.actor.Deploy
-
- canEqual(Object) - Static method in class akka.actor.Identify
-
- canEqual(Object) - Static method in exception akka.actor.IllegalActorStateException
-
- canEqual(Object) - Static method in exception akka.actor.InvalidActorNameException
-
- canEqual(Object) - Static method in exception akka.actor.InvalidMessageException
-
- canEqual(Object) - Static method in class akka.actor.Nobody
-
- canEqual(Object) - Static method in class akka.actor.OneForOneStrategy
-
- canEqual(Object) - Static method in exception akka.actor.PostRestartException
-
- canEqual(Object) - Static method in exception akka.actor.PreRestartException
-
- canEqual(Object) - Static method in class akka.actor.Props
-
- canEqual(Object) - Static method in class akka.actor.RootActorPath
-
- canEqual(Object) - Static method in exception akka.actor.SchedulerException
-
- canEqual(Object) - Static method in class akka.actor.SelectChildName
-
- canEqual(Object) - Static method in class akka.actor.SelectChildPattern
-
- canEqual(Object) - Static method in class akka.actor.SelectParent
-
- canEqual(Object) - Static method in class akka.actor.SerializedActorRef
-
- canEqual(Object) - Static method in class akka.actor.StopChild
-
- canEqual(Object) - Static method in class akka.actor.SuppressedDeadLetter
-
- canEqual(Object) - Static method in class akka.actor.Terminated
-
- canEqual(Object) - Static method in class akka.actor.TypedProps
-
- canEqual(Object) - Static method in class akka.actor.UnhandledMessage
-
- canEqual(Object) - Static method in class akka.camel.Ack
-
- canEqual(Object) - Method in class akka.camel.CamelMessage
-
Indicates if some other object can be compared (based on type).
- canEqual(Object) - Static method in class akka.camel.FailureResult
-
- canEqual(Object) - Static method in class akka.camel.internal.AwaitActivation
-
- canEqual(Object) - Static method in class akka.camel.internal.AwaitDeActivation
-
- canEqual(Object) - Static method in class akka.camel.internal.component.ActorEndpointPath
-
- canEqual(Object) - Static method in class akka.camel.MessageResult
-
- canEqual(Object) - Static method in class akka.cluster.client.ClusterClients
-
- canEqual(Object) - Static method in class akka.cluster.client.ClusterClientUnreachable
-
- canEqual(Object) - Static method in class akka.cluster.client.ClusterClientUp
-
- canEqual(Object) - Static method in class akka.cluster.client.ContactPointAdded
-
- canEqual(Object) - Static method in class akka.cluster.client.ContactPointRemoved
-
- canEqual(Object) - Static method in class akka.cluster.client.ContactPoints
-
- canEqual(Object) - Static method in class akka.cluster.ClusterHeartbeatSenderState
-
- canEqual(Object) - Static method in class akka.cluster.ddata.Flag
-
- canEqual(Object) - Static method in class akka.cluster.ddata.FlagKey
-
- canEqual(Object) - Static method in class akka.cluster.ddata.GCounterKey
-
- canEqual(Object) - Static method in class akka.cluster.ddata.GSet
-
- canEqual(Object) - Static method in class akka.cluster.ddata.GSetKey
-
- canEqual(Object) - Static method in class akka.cluster.ddata.LWWMapKey
-
- canEqual(Object) - Static method in class akka.cluster.ddata.LWWRegisterKey
-
- canEqual(Object) - Static method in class akka.cluster.ddata.ManyVersionVector
-
- canEqual(Object) - Static method in class akka.cluster.ddata.OneVersionVector
-
- canEqual(Object) - Static method in class akka.cluster.ddata.ORMapKey
-
- canEqual(Object) - Static method in class akka.cluster.ddata.ORMultiMapKey
-
- canEqual(Object) - Static method in class akka.cluster.ddata.ORSetKey
-
- canEqual(Object) - Static method in class akka.cluster.ddata.PNCounterKey
-
- canEqual(Object) - Static method in class akka.cluster.ddata.PNCounterMapKey
-
- canEqual(Object) - Static method in class akka.cluster.ddata.PruningState
-
- canEqual(Object) - Static method in class akka.cluster.EWMA
-
- canEqual(Object) - Static method in class akka.cluster.Gossip
-
- canEqual(Object) - Static method in class akka.cluster.GossipOverview
-
- canEqual(Object) - Static method in class akka.cluster.GossipStats
-
- canEqual(Object) - Static method in class akka.cluster.GossipStatus
-
- canEqual(Object) - Static method in class akka.cluster.HeartbeatNodeRing
-
- canEqual(Object) - Static method in class akka.cluster.Metric
-
Deprecated.
- canEqual(Object) - Static method in class akka.cluster.metrics.AdaptiveLoadBalancingGroup
-
- canEqual(Object) - Static method in class akka.cluster.metrics.AdaptiveLoadBalancingPool
-
- canEqual(Object) - Static method in class akka.cluster.metrics.AdaptiveLoadBalancingRoutingLogic
-
- canEqual(Object) - Static method in class akka.cluster.metrics.ClusterMetricsChanged
-
- canEqual(Object) - Static method in class akka.cluster.metrics.ClusterMetricsSettings
-
- canEqual(Object) - Static method in class akka.cluster.metrics.ClusterMetricsStrategy
-
- canEqual(Object) - Static method in class akka.cluster.metrics.CollectionStartMessage
-
- canEqual(Object) - Static method in class akka.cluster.metrics.CollectionStopMessage
-
- canEqual(Object) - Static method in class akka.cluster.metrics.CpuMetricsSelector
-
- canEqual(Object) - Static method in class akka.cluster.metrics.DefaultSigarProvider
-
- canEqual(Object) - Static method in class akka.cluster.metrics.EWMA
-
- canEqual(Object) - Static method in class akka.cluster.metrics.HeapMetricsSelector
-
- canEqual(Object) - Static method in class akka.cluster.metrics.Metric
-
- canEqual(Object) - Static method in class akka.cluster.metrics.MetricsGossip
-
- canEqual(Object) - Static method in class akka.cluster.metrics.MetricsGossipEnvelope
-
- canEqual(Object) - Static method in class akka.cluster.metrics.MixMetricsSelector
-
- canEqual(Object) - Static method in class akka.cluster.metrics.NodeMetrics
-
- canEqual(Object) - Static method in class akka.cluster.metrics.SystemLoadAverageMetricsSelector
-
- canEqual(Object) - Static method in class akka.cluster.MetricsGossip
-
- canEqual(Object) - Static method in class akka.cluster.MetricsGossipEnvelope
-
- canEqual(Object) - Static method in class akka.cluster.NodeMetrics
-
Deprecated.
- canEqual(Object) - Static method in class akka.cluster.routing.AdaptiveLoadBalancingGroup
-
Deprecated.
- canEqual(Object) - Static method in class akka.cluster.routing.AdaptiveLoadBalancingPool
-
Deprecated.
- canEqual(Object) - Static method in class akka.cluster.routing.AdaptiveLoadBalancingRoutingLogic
-
Deprecated.
- canEqual(Object) - Static method in class akka.cluster.routing.ClusterRouterGroup
-
- canEqual(Object) - Static method in class akka.cluster.routing.ClusterRouterGroupSettings
-
- canEqual(Object) - Static method in class akka.cluster.routing.ClusterRouterPool
-
- canEqual(Object) - Static method in class akka.cluster.routing.ClusterRouterPoolSettings
-
- canEqual(Object) - Static method in class akka.cluster.routing.CpuMetricsSelector
-
Deprecated.
- canEqual(Object) - Static method in class akka.cluster.routing.HeapMetricsSelector
-
Deprecated.
- canEqual(Object) - Static method in class akka.cluster.routing.MixMetricsSelector
-
Deprecated.
- canEqual(Object) - Static method in class akka.cluster.routing.SystemLoadAverageMetricsSelector
-
Deprecated.
- canEqual(Object) - Static method in class akka.cluster.UniqueAddress
-
- canEqual(Object) - Static method in class akka.cluster.VectorClock
-
- canEqual(Object) - Static method in class akka.cluster.VectorClockStats
-
- canEqual(Object) - Static method in class akka.dispatch.BoundedControlAwareMailbox
-
- canEqual(Object) - Static method in class akka.dispatch.BoundedDequeBasedMailbox
-
- canEqual(Object) - Static method in class akka.dispatch.BoundedMailbox
-
- canEqual(Object) - Static method in class akka.dispatch.DefaultDispatcherPrerequisites
-
- canEqual(Object) - Static method in class akka.dispatch.Envelope
-
- canEqual(Object) - Static method in class akka.dispatch.MonitorableThreadFactory
-
- canEqual(Object) - Static method in class akka.dispatch.NonBlockingBoundedMailbox
-
- canEqual(Object) - Static method in class akka.dispatch.SingleConsumerOnlyUnboundedMailbox
-
- canEqual(Object) - Static method in class akka.dispatch.sysmsg.Create
-
- canEqual(Object) - Static method in class akka.dispatch.sysmsg.DeathWatchNotification
-
- canEqual(Object) - Static method in class akka.dispatch.sysmsg.Failed
-
- canEqual(Object) - Static method in class akka.dispatch.sysmsg.NoMessage
-
- canEqual(Object) - Static method in class akka.dispatch.sysmsg.Recreate
-
- canEqual(Object) - Static method in class akka.dispatch.sysmsg.Resume
-
- canEqual(Object) - Static method in class akka.dispatch.sysmsg.Supervise
-
- canEqual(Object) - Static method in class akka.dispatch.sysmsg.Suspend
-
- canEqual(Object) - Static method in class akka.dispatch.sysmsg.Terminate
-
- canEqual(Object) - Static method in class akka.dispatch.sysmsg.Unwatch
-
- canEqual(Object) - Static method in class akka.dispatch.sysmsg.Watch
-
- canEqual(Object) - Static method in class akka.dispatch.TaskInvocation
-
- canEqual(Object) - Static method in class akka.dispatch.ThreadPoolConfig
-
- canEqual(Object) - Static method in class akka.dispatch.ThreadPoolConfigBuilder
-
- canEqual(Object) - Static method in class akka.dispatch.UnboundedControlAwareMailbox
-
- canEqual(Object) - Static method in class akka.dispatch.UnboundedDequeBasedMailbox
-
- canEqual(Object) - Static method in class akka.dispatch.UnboundedMailbox
-
- canEqual(Object) - Static method in class akka.japi.Pair
-
- canEqual(Object) - Static method in class akka.japi.tuple.Tuple10
-
- canEqual(Object) - Static method in class akka.japi.tuple.Tuple11
-
- canEqual(Object) - Static method in class akka.japi.tuple.Tuple12
-
- canEqual(Object) - Static method in class akka.japi.tuple.Tuple13
-
- canEqual(Object) - Static method in class akka.japi.tuple.Tuple14
-
- canEqual(Object) - Static method in class akka.japi.tuple.Tuple15
-
- canEqual(Object) - Static method in class akka.japi.tuple.Tuple16
-
- canEqual(Object) - Static method in class akka.japi.tuple.Tuple17
-
- canEqual(Object) - Static method in class akka.japi.tuple.Tuple18
-
- canEqual(Object) - Static method in class akka.japi.tuple.Tuple19
-
- canEqual(Object) - Static method in class akka.japi.tuple.Tuple20
-
- canEqual(Object) - Static method in class akka.japi.tuple.Tuple21
-
- canEqual(Object) - Static method in class akka.japi.tuple.Tuple22
-
- canEqual(Object) - Static method in class akka.japi.tuple.Tuple3
-
- canEqual(Object) - Static method in class akka.japi.tuple.Tuple4
-
- canEqual(Object) - Static method in class akka.japi.tuple.Tuple5
-
- canEqual(Object) - Static method in class akka.japi.tuple.Tuple6
-
- canEqual(Object) - Static method in class akka.japi.tuple.Tuple7
-
- canEqual(Object) - Static method in class akka.japi.tuple.Tuple8
-
- canEqual(Object) - Static method in class akka.japi.tuple.Tuple9
-
- canEqual(Object) - Static method in class akka.osgi.UnregisteringLogService
-
- canEqual(Object) - Static method in class akka.pattern.AutoReset
-
- canEqual(Object) - Static method in class akka.pattern.BackoffOptionsImpl
-
- canEqual(Object) - Static method in class akka.pattern.ManualReset
-
- canEqual(Object) - Static method in class akka.pattern.RestartImpliesFailure
-
- canEqual(Object) - Static method in class akka.pattern.StopImpliesFailure
-
- canEqual(Object) - Static method in class akka.persistence.AtomicWrite
-
- canEqual(Object) - Static method in class akka.persistence.DeleteMessagesFailure
-
- canEqual(Object) - Static method in class akka.persistence.DeleteMessagesSuccess
-
- canEqual(Object) - Static method in class akka.persistence.DeleteSnapshotFailure
-
- canEqual(Object) - Static method in class akka.persistence.DeleteSnapshotsFailure
-
- canEqual(Object) - Static method in class akka.persistence.DeleteSnapshotsSuccess
-
- canEqual(Object) - Static method in class akka.persistence.DeleteSnapshotSuccess
-
- canEqual(Object) - Static method in class akka.persistence.DiscardToDeadLetterStrategy
-
- canEqual(Object) - Static method in class akka.persistence.journal.EventsSeq
-
- canEqual(Object) - Static method in class akka.persistence.journal.IdentityEventAdapter
-
- canEqual(Object) - Static method in class akka.persistence.journal.IdentityEventAdapters
-
- canEqual(Object) - Static method in class akka.persistence.journal.leveldb.Key
-
- canEqual(Object) - Static method in class akka.persistence.journal.NoopReadEventAdapter
-
- canEqual(Object) - Static method in class akka.persistence.journal.NoopWriteEventAdapter
-
- canEqual(Object) - Static method in class akka.persistence.journal.SingleEventSeq
-
- canEqual(Object) - Static method in class akka.persistence.journal.Tagged
-
- canEqual(Object) - Static method in class akka.persistence.NonPersistentRepr
-
- canEqual(Object) - Static method in class akka.persistence.PersistentImpl
-
- canEqual(Object) - Static method in class akka.persistence.query.EventEnvelope
-
- canEqual(Object) - Static method in class akka.persistence.query.EventEnvelope2
-
- canEqual(Object) - Static method in class akka.persistence.query.NoOffset
-
- canEqual(Object) - Static method in class akka.persistence.query.Sequence
-
- canEqual(Object) - Static method in class akka.persistence.query.TimeBasedUUID
-
- canEqual(Object) - Static method in class akka.persistence.Recovery
-
- canEqual(Object) - Static method in class akka.persistence.ReplyToStrategy
-
- canEqual(Object) - Static method in class akka.persistence.SaveSnapshotFailure
-
- canEqual(Object) - Static method in class akka.persistence.SaveSnapshotSuccess
-
- canEqual(Object) - Static method in class akka.persistence.SelectedSnapshot
-
- canEqual(Object) - Static method in class akka.persistence.serialization.Snapshot
-
- canEqual(Object) - Static method in class akka.persistence.serialization.SnapshotHeader
-
- canEqual(Object) - Static method in class akka.persistence.SnapshotMetadata
-
- canEqual(Object) - Static method in class akka.persistence.SnapshotOffer
-
- canEqual(Object) - Static method in class akka.persistence.SnapshotSelectionCriteria
-
- canEqual(Object) - Static method in class akka.persistence.ThrowOverflowExceptionStrategy
-
- canEqual(Object) - Static method in class akka.persistence.Update
-
- canEqual(Object) - Static method in class akka.remote.Ack
-
- canEqual(Object) - Static method in class akka.remote.AckedReceiveBuffer
-
- canEqual(Object) - Static method in class akka.remote.AckedSendBuffer
-
- canEqual(Object) - Static method in class akka.remote.artery.ActorSystemTerminating
-
- canEqual(Object) - Static method in class akka.remote.artery.ActorSystemTerminatingAck
-
- canEqual(Object) - Static method in class akka.remote.artery.CacheStatistics
-
- canEqual(Object) - Static method in class akka.remote.artery.compress.CompressionTable
-
- canEqual(Object) - Static method in class akka.remote.artery.compress.DecompressionTable
-
- canEqual(Object) - Static method in class akka.remote.artery.compress.NoInboundCompressions
-
- canEqual(Object) - Static method in class akka.remote.artery.Quarantined
-
- canEqual(Object) - Static method in class akka.remote.artery.Running
-
- canEqual(Object) - Static method in class akka.remote.artery.ShutDown
-
- canEqual(Object) - Static method in class akka.remote.artery.SnapshotInProgress
-
- canEqual(Object) - Static method in class akka.remote.artery.TestState
-
- canEqual(Object) - Static method in class akka.remote.AssociatedEvent
-
- canEqual(Object) - Static method in class akka.remote.AssociationErrorEvent
-
- canEqual(Object) - Static method in class akka.remote.DaemonMsgCreate
-
- canEqual(Object) - Static method in class akka.remote.DisassociatedEvent
-
- canEqual(Object) - Static method in class akka.remote.HeartbeatHistory
-
- canEqual(Object) - Static method in exception akka.remote.HopelessAssociation
-
- canEqual(Object) - Static method in exception akka.remote.InvalidAssociation
-
- canEqual(Object) - Static method in class akka.remote.QuarantinedEvent
-
- canEqual(Object) - Static method in class akka.remote.RARP
-
- canEqual(Object) - Static method in class akka.remote.RemoteScope
-
- canEqual(Object) - Static method in class akka.remote.RemotingErrorEvent
-
- canEqual(Object) - Static method in class akka.remote.RemotingListenEvent
-
- canEqual(Object) - Static method in class akka.remote.RemotingShutdownEvent
-
- canEqual(Object) - Static method in class akka.remote.routing.RemoteRouterConfig
-
- canEqual(Object) - Static method in class akka.remote.SeqNo
-
- canEqual(Object) - Static method in exception akka.remote.ShutDownAssociation
-
- canEqual(Object) - Static method in class akka.remote.testconductor.AddressReply
-
- canEqual(Object) - Static method in class akka.remote.testconductor.BarrierResult
-
- canEqual(Object) - Static method in class akka.remote.testconductor.Client
-
- canEqual(Object) - Static method in class akka.remote.testconductor.Disconnect
-
- canEqual(Object) - Static method in class akka.remote.testconductor.DisconnectMsg
-
- canEqual(Object) - Static method in class akka.remote.testconductor.EnterBarrier
-
- canEqual(Object) - Static method in class akka.remote.testconductor.FailBarrier
-
- canEqual(Object) - Static method in class akka.remote.testconductor.GetAddress
-
- canEqual(Object) - Static method in class akka.remote.testconductor.Hello
-
- canEqual(Object) - Static method in class akka.remote.testconductor.Remove
-
- canEqual(Object) - Static method in class akka.remote.testconductor.RoleName
-
- canEqual(Object) - Static method in class akka.remote.testconductor.Server
-
- canEqual(Object) - Static method in class akka.remote.testconductor.Terminate
-
- canEqual(Object) - Static method in class akka.remote.testconductor.TerminateMsg
-
- canEqual(Object) - Static method in class akka.remote.testconductor.Throttle
-
- canEqual(Object) - Static method in class akka.remote.testconductor.ThrottleMsg
-
- canEqual(Object) - Static method in class akka.remote.testconductor.ToClient
-
- canEqual(Object) - Static method in class akka.remote.testconductor.ToServer
-
- canEqual(Object) - Static method in class akka.remote.ThisActorSystemQuarantinedEvent
-
- canEqual(Object) - Static method in exception akka.remote.transport.FailureInjectorException
-
- canEqual(Object) - Static method in class akka.remote.transport.FailureInjectorHandle
-
- canEqual(Object) - Static method in class akka.remote.transport.HandshakeInfo
-
- canEqual(Object) - Static method in class akka.remote.transport.TestAssociationHandle
-
- canEqual(Object) - Static method in class akka.remote.transport.ThrottlerHandle
-
- canEqual(Object) - Static method in class akka.remote.UniqueAddress
-
- canEqual(Object) - Static method in class akka.routing.ActorRefRoutee
-
- canEqual(Object) - Static method in class akka.routing.ActorSelectionRoutee
-
- canEqual(Object) - Static method in class akka.routing.AddRoutee
-
- canEqual(Object) - Static method in class akka.routing.AdjustPoolSize
-
- canEqual(Object) - Static method in class akka.routing.BalancingPool
-
- canEqual(Object) - Static method in class akka.routing.Broadcast
-
- canEqual(Object) - Static method in class akka.routing.BroadcastGroup
-
- canEqual(Object) - Static method in class akka.routing.BroadcastPool
-
- canEqual(Object) - Static method in class akka.routing.ConsistentHashingGroup
-
- canEqual(Object) - Static method in class akka.routing.ConsistentHashingPool
-
- canEqual(Object) - Static method in class akka.routing.ConsistentHashingRoutingLogic
-
- canEqual(Object) - Static method in class akka.routing.ConsistentRoutee
-
- canEqual(Object) - Static method in class akka.routing.Deafen
-
- canEqual(Object) - Static method in class akka.routing.DefaultOptimalSizeExploringResizer
-
- canEqual(Object) - Static method in class akka.routing.DefaultResizer
-
- canEqual(Object) - Static method in class akka.routing.Listen
-
- canEqual(Object) - Static method in class akka.routing.RandomGroup
-
- canEqual(Object) - Static method in class akka.routing.RandomPool
-
- canEqual(Object) - Static method in class akka.routing.RemoveRoutee
-
- canEqual(Object) - Static method in class akka.routing.RoundRobinGroup
-
- canEqual(Object) - Static method in class akka.routing.RoundRobinPool
-
- canEqual(Object) - Static method in class akka.routing.Routees
-
- canEqual(Object) - Static method in class akka.routing.Router
-
- canEqual(Object) - Static method in class akka.routing.ScatterGatherFirstCompletedGroup
-
- canEqual(Object) - Static method in class akka.routing.ScatterGatherFirstCompletedPool
-
- canEqual(Object) - Static method in class akka.routing.ScatterGatherFirstCompletedRoutees
-
- canEqual(Object) - Static method in class akka.routing.ScatterGatherFirstCompletedRoutingLogic
-
- canEqual(Object) - Static method in class akka.routing.SeveralRoutees
-
- canEqual(Object) - Static method in class akka.routing.SmallestMailboxPool
-
- canEqual(Object) - Static method in class akka.routing.TailChoppingGroup
-
- canEqual(Object) - Static method in class akka.routing.TailChoppingPool
-
- canEqual(Object) - Static method in class akka.routing.TailChoppingRoutees
-
- canEqual(Object) - Static method in class akka.routing.TailChoppingRoutingLogic
-
- canEqual(Object) - Static method in class akka.routing.WithListeners
-
- canEqual(Object) - Static method in class akka.serialization.DisabledJavaSerializer
-
- canEqual(Object) - Static method in exception akka.stream.AbruptTerminationException
-
- canEqual(Object) - Static method in class akka.stream.actor.ActorPublisherImpl
-
- canEqual(Object) - Static method in class akka.stream.actor.OneByOneRequestStrategy
-
- canEqual(Object) - Static method in class akka.stream.actor.WatermarkRequestStrategy
-
- canEqual(Object) - Static method in class akka.stream.actor.ZeroRequestStrategy
-
- canEqual(Object) - Static method in class akka.stream.AmorphousShape
-
- canEqual(Object) - Static method in class akka.stream.Attributes
-
- canEqual(Object) - Static method in class akka.stream.BidiShape
-
- canEqual(Object) - Static method in exception akka.stream.BufferOverflowException
-
- canEqual(Object) - Static method in class akka.stream.FlowShape
-
- canEqual(Object) - Static method in class akka.stream.impl.ActorMaterializerImpl
-
- canEqual(Object) - Static method in class akka.stream.impl.Cancel
-
- canEqual(Object) - Static method in class akka.stream.impl.CancelledSubscription
-
- canEqual(Object) - Static method in class akka.stream.impl.EmptyPublisher
-
- canEqual(Object) - Static method in class akka.stream.impl.ErrorPublisher
-
- canEqual(Object) - Static method in class akka.stream.impl.ExposedPublisher
-
- canEqual(Object) - Static method in class akka.stream.impl.fusing.Batch
-
- canEqual(Object) - Static method in class akka.stream.impl.fusing.Buffer
-
- canEqual(Object) - Static method in class akka.stream.impl.fusing.Collect
-
- canEqual(Object) - Static method in class akka.stream.impl.fusing.Drop
-
- canEqual(Object) - Static method in class akka.stream.impl.fusing.DropWhile
-
- canEqual(Object) - Static method in class akka.stream.impl.fusing.Filter
-
- canEqual(Object) - Static method in class akka.stream.impl.fusing.Fold
-
- canEqual(Object) - Static method in class akka.stream.impl.fusing.GraphModule
-
- canEqual(Object) - Static method in class akka.stream.impl.fusing.GraphStageModule
-
- canEqual(Object) - Static method in class akka.stream.impl.fusing.Grouped
-
- canEqual(Object) - Static method in class akka.stream.impl.fusing.Intersperse
-
- canEqual(Object) - Static method in class akka.stream.impl.fusing.LimitWeighted
-
- canEqual(Object) - Static method in class akka.stream.impl.fusing.Log
-
- canEqual(Object) - Static method in class akka.stream.impl.fusing.Map
-
- canEqual(Object) - Static method in class akka.stream.impl.fusing.MapAsync
-
- canEqual(Object) - Static method in class akka.stream.impl.fusing.MapAsyncUnordered
-
- canEqual(Object) - Static method in class akka.stream.impl.fusing.MapError
-
- canEqual(Object) - Static method in class akka.stream.impl.fusing.Recover
-
- canEqual(Object) - Static method in class akka.stream.impl.fusing.Scan
-
- canEqual(Object) - Static method in class akka.stream.impl.fusing.ScanAsync
-
- canEqual(Object) - Static method in class akka.stream.impl.fusing.Sliding
-
- canEqual(Object) - Static method in class akka.stream.impl.fusing.Take
-
- canEqual(Object) - Static method in class akka.stream.impl.fusing.TakeWhile
-
- canEqual(Object) - Static method in class akka.stream.impl.io.TlsModule
-
- canEqual(Object) - Static method in class akka.stream.impl.MaybePublisher
-
- canEqual(Object) - Static method in class akka.stream.impl.ProcessorModule
-
- canEqual(Object) - Static method in class akka.stream.impl.RejectAdditionalSubscribers
-
- canEqual(Object) - Static method in class akka.stream.impl.RequestMore
-
- canEqual(Object) - Static method in class akka.stream.impl.SubscribePending
-
- canEqual(Object) - Static method in class akka.stream.impl.TransferPhase
-
- canEqual(Object) - Static method in class akka.stream.impl.WaitingForUpstreamSubscription
-
- canEqual(Object) - Static method in class akka.stream.IOResult
-
- canEqual(Object) - Static method in class akka.stream.MaterializationContext
-
- canEqual(Object) - Static method in class akka.stream.scaladsl.RunnableGraph
-
- canEqual(Object) - Static method in class akka.stream.SinkShape
-
- canEqual(Object) - Static method in class akka.stream.SourceShape
-
- canEqual(Object) - Static method in class akka.testkit.CustomEventFilter
-
- canEqual(Object) - Static method in class akka.testkit.DeadLettersFilter
-
- canEqual(Object) - Static method in class akka.testkit.DebugFilter
-
- canEqual(Object) - Static method in class akka.testkit.ErrorFilter
-
- canEqual(Object) - Static method in class akka.testkit.InfoFilter
-
- canEqual(Object) - Static method in class akka.testkit.WarningFilter
-
- canEqual(Object) - Static method in class akka.typed.DeadLetter
-
- canEqual(Object) - Static method in exception akka.typed.DeathPactException
-
- canEqual(Object) - Static method in class akka.typed.DispatcherDefault
-
- canEqual(Object) - Static method in class akka.typed.DispatcherFromConfig
-
- canEqual(Object) - Static method in class akka.typed.DispatcherFromExecutionContext
-
- canEqual(Object) - Static method in class akka.typed.DispatcherFromExecutor
-
- canEqual(Object) - Static method in class akka.typed.Dropped
-
- canEqual(Object) - Static method in class akka.typed.EmptyDeploymentConfig
-
- canEqual(Object) - Static method in class akka.typed.internal.Create
-
- canEqual(Object) - Static method in class akka.typed.internal.DeathWatchNotification
-
- canEqual(Object) - Static method in class akka.typed.internal.NoMessage
-
- canEqual(Object) - Static method in class akka.typed.internal.Terminate
-
- canEqual(Object) - Static method in class akka.typed.internal.Unwatch
-
- canEqual(Object) - Static method in class akka.typed.internal.Watch
-
- canEqual(Object) - Static method in class akka.typed.MailboxCapacity
-
- canEqual(Object) - Static method in class akka.typed.patterns.Restarter
-
- canEqual(Object) - Static method in class akka.typed.PostStop
-
- canEqual(Object) - Static method in class akka.typed.PreRestart
-
- canEqual(Object) - Static method in class akka.typed.PreStart
-
- canEqual(Object) - Static method in class akka.typed.Terminated
-
- canEqual(Object) - Static method in class akka.util.ByteString
-
- canEqual(Object) - Static method in class akka.util.CompactByteString
-
- canEqual(Object) - Static method in class akka.util.Timeout
-
- canEqual(Object) - Static method in class akka.util.WildcardIndex
-
- canEqual(Object) - Static method in class akka.util.WildcardTree
-
- CanNotSubscribeTheSameSubscriberMultipleTimes() - Method in class akka.stream.impl.ReactiveStreamsCompliance$
-
- CanNotSubscribeTheSameSubscriberMultipleTimes() - Static method in class akka.stream.impl.ReactiveStreamsCompliance
-
- canNotSubscribeTheSameSubscriberMultipleTimesException() - Method in class akka.stream.impl.ReactiveStreamsCompliance$
-
- canNotSubscribeTheSameSubscriberMultipleTimesException() - Static method in class akka.stream.impl.ReactiveStreamsCompliance
-
- Canonical() - Method in class akka.remote.artery.ArterySettings
-
Accessor for nested Scala object
- Canonical$() - Constructor for class akka.remote.artery.ArterySettings.Canonical$
-
- 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(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(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.
- canWorkWithPartialData() - Method in interface akka.stream.impl.io.ByteStringParser.ParseStep
-
Must return true when NeedMoreData will clean buffer.
- canWorkWithPartialData() - Method in class akka.stream.impl.io.compression.DeflateDecompressorBase.DecompressorParsingLogic.Inflate
-
- CapabilityFlag - Class in akka.persistence
-
- CapabilityFlag() - Constructor for class akka.persistence.CapabilityFlag
-
- CapabilityFlag$ - Class in akka.persistence
-
- CapabilityFlag$() - Constructor for class akka.persistence.CapabilityFlag$
-
- CapabilityFlags - Interface in akka.persistence
-
- 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>) - Static method in class akka.cluster.metrics.MixMetricsSelector
-
- 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
-
Deprecated.
Remaining capacity for each node.
- capacity(Set<NodeMetrics>) - Method in class akka.cluster.routing.CpuMetricsSelector$
-
Deprecated.
- capacity(Set<NodeMetrics>) - Static method in class akka.cluster.routing.CpuMetricsSelector
-
Deprecated.
- capacity(Set<NodeMetrics>) - Method in class akka.cluster.routing.HeapMetricsSelector$
-
Deprecated.
- capacity(Set<NodeMetrics>) - Static method in class akka.cluster.routing.HeapMetricsSelector
-
Deprecated.
- capacity(Set<NodeMetrics>) - Static method in class akka.cluster.routing.MixMetricsSelector
-
Deprecated.
- capacity(Set<NodeMetrics>) - Method in class akka.cluster.routing.MixMetricsSelectorBase
-
Deprecated.
- capacity(Set<NodeMetrics>) - Method in class akka.cluster.routing.SystemLoadAverageMetricsSelector$
-
Deprecated.
- capacity(Set<NodeMetrics>) - Static method in class akka.cluster.routing.SystemLoadAverageMetricsSelector
-
Deprecated.
- 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.artery.compress.TopHeavyHitters
-
- 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.
- capacity() - Method in class akka.stream.impl.BoundedBuffer
-
- capacity() - Method in interface akka.stream.impl.Buffer
-
- capacity() - Method in class akka.stream.impl.FixedSizeBuffer.FixedSizeBuffer
-
- capacity() - Method in class akka.typed.MailboxCapacity
-
- 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
-
- CapacityMetricsSelector() - Constructor for class akka.cluster.routing.CapacityMetricsSelector
-
Deprecated.
- carbonCopy() - Method in class akka.stream.impl.fusing.GraphModule
-
- carbonCopy() - Method in class akka.stream.impl.fusing.GraphStageModule
-
- carbonCopy() - Method in class akka.stream.impl.io.TlsModule
-
- carbonCopy() - Method in class akka.stream.impl.ProcessorModule
-
- carbonCopy() - Method in class akka.stream.impl.SinkModule
-
- carbonCopy() - Method in class akka.stream.impl.SourceModule
-
- carbonCopy() - Method in class akka.stream.impl.StreamLayout.CompositeModule
-
- carbonCopy() - Method in class akka.stream.impl.StreamLayout.CopiedModule
-
- carbonCopy() - Method in class akka.stream.impl.StreamLayout.EmptyModule$
-
- carbonCopy() - Method in class akka.stream.impl.StreamLayout.FusedModule
-
- carbonCopy() - Method in interface akka.stream.impl.StreamLayout.Module
-
The purpose of this method is to create a copy to be included in a larger
graph such that port identity clashes are avoided.
- carbonCopy() - Method in class akka.stream.impl.StreamLayout.StructuralInfoModule
-
- carbonCopy() - Method in class akka.stream.Inlet
-
- carbonCopy() - Method in class akka.stream.Outlet
-
- 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.cluster.ddata.Replicator.ModifyFailure
-
- 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.CommandFailed
-
Optionally contains the cause why the command failed.
- cause() - Method in class akka.io.Tcp.ErrorClosed
-
- cause() - Method in class akka.persistence.DeleteMessagesFailure
-
- cause() - Method in class akka.persistence.DeleteSnapshotFailure
-
- cause() - Method in class akka.persistence.DeleteSnapshotsFailure
-
- cause() - Method in class akka.persistence.fsm.PersistentFSM.Failure
-
- cause() - Method in class akka.persistence.journal.AsyncWriteTarget.ReplayFailure
-
- cause() - Method in class akka.persistence.JournalProtocol.ReplayMessagesFailure
-
- cause() - Method in class akka.persistence.JournalProtocol.WriteMessageFailure
-
- cause() - Method in class akka.persistence.JournalProtocol.WriteMessageRejected
-
- cause() - Method in class akka.persistence.JournalProtocol.WriteMessagesFailed
-
- cause() - Method in class akka.persistence.SaveSnapshotFailure
-
- cause() - Method in class akka.persistence.SnapshotProtocol.LoadSnapshotFailed
-
- 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.stream.actor.ActorPublisher.Internal$.ErrorEmitted
-
- cause() - Method in class akka.stream.actor.ActorSubscriberMessage.OnError
-
- cause() - Method in class akka.stream.FlowMonitorState.Failed
-
- cause() - Method in class akka.stream.impl.FanIn.OnError
-
- cause() - Method in class akka.stream.impl.fusing.ActorGraphInterpreter.OnError
-
- cause() - Method in class akka.stream.impl.io.InputStreamSinkStage.Failed
-
- cause() - Method in class akka.stream.impl.SubscriberManagement.ErrorCompleted
-
- cause() - Method in class akka.stream.QueueOfferResult.Failure
-
- cause() - Method in class akka.stream.testkit.StreamTestKit.FailedSubscription
-
- cause() - Method in class akka.stream.testkit.TestSubscriber.OnError
-
- CAUSE_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.ActorInitializationException
-
- CAUSE_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.Throwable
-
- CAUSEDATA_FIELD_NUMBER - Static variable in class akka.remote.SystemMessageFormats.SystemMessage
-
- causedByFailure() - Method in class akka.dispatch.sysmsg.Resume
-
- causedByString() - Method in class akka.io.Tcp.CommandFailed
-
- cb() - Method in class akka.stream.impl.fusing.MapAsync.Holder
-
- Cell - Interface in akka.actor
-
INTERNAL API
- cell() - Static method in class akka.routing.ResizablePoolActor
-
- cell() - Method in class akka.routing.RouterActor
-
- chanceOfScalingDownWhenFull() - Method in class akka.routing.DefaultOptimalSizeExploringResizer
-
- change(UniqueAddress, long) - Method in class akka.cluster.ddata.PNCounter
-
- change() - Method in class akka.routing.AdjustPoolSize
-
- changeActorRefCompression(CompressionTable<ActorRef>) - Method in class akka.remote.artery.Association
-
- changeActorRefCompression(CompressionTable<ActorRef>) - Method in interface akka.remote.artery.Encoder.OutboundCompressionAccess
-
- changeClassManifestCompression(CompressionTable<String>) - Method in class akka.remote.artery.Association
-
- changeClassManifestCompression(CompressionTable<String>) - Method in interface akka.remote.artery.Encoder.OutboundCompressionAccess
-
- changed() - Method in class akka.cluster.ddata.Replicator
-
- Changed(Key<A>, A) - Constructor for class akka.cluster.ddata.Replicator.Changed
-
- Changed$() - Constructor for class akka.cluster.ddata.Replicator.Changed$
-
- ChangedManifest() - Method in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer
-
- 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
-
Deprecated.
- 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() - Static method in class akka.io.TcpOutgoingConnection
-
- 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
-
- chasePull(GraphInterpreter.Connection) - Method in class akka.stream.impl.fusing.GraphInterpreter
-
- chasePush(GraphInterpreter.Connection) - Method in class akka.stream.impl.fusing.GraphInterpreter
-
- check() - Method in class akka.testkit.JavaTestKit.AwaitAssert
-
- checkCreatorClosingOver(Class<?>) - Method in interface akka.actor.AbstractProps
-
- CheckDeadlines() - Constructor for class akka.cluster.client.ClusterReceptionist.Internal$.CheckDeadlines
-
- checkDeadlinesTask() - Method in class akka.cluster.client.ClusterReceptionist
-
- 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() - Static method in class akka.actor.ActorCell
-
- checkReceiveTimeout() - Method in interface akka.actor.dungeon.ReceiveTimeout
-
- checkReceiveTimeout() - Static method in class akka.routing.RoutedActorCell
-
- checkTime() - Method in class akka.routing.OptimalSizeExploringResizer.ResizeRecord
-
- checkValid(Config, Seq<String>) - Method in class akka.dispatch.CachingConfig
-
- checkValid(Config, String[]) - Method in class akka.dispatch.CachingConfig
-
- child(String) - Static method in class akka.actor.ActorCell
-
- child(String) - Method in interface akka.actor.ActorContext
-
Get the child with the given name if it exists.
- child(String) - Method in interface akka.actor.ActorPath
-
Java API: Create a new child actor path.
- child(String) - Method in class akka.actor.ActorSystem
-
Java API: Create a new child actor path.
- child() - Method in class akka.actor.ChildRestartStats
-
- child(String) - Method in interface akka.actor.dungeon.Children
-
- child(String) - Static method in class akka.actor.RootActorPath
-
- child() - Method in class akka.actor.StopChild
-
- child() - Method in class akka.dispatch.sysmsg.Failed
-
- child() - Method in class akka.dispatch.sysmsg.Supervise
-
- child() - Method in class akka.pattern.BackoffOnRestartSupervisor
-
- child() - Method in class akka.pattern.BackoffSupervisor
-
- child() - Method in interface akka.pattern.HandleBackoff
-
- child(String) - Static method in class akka.routing.RoutedActorCell
-
- child(String) - Method in interface akka.typed.ActorContext
-
The named child Actor if it is alive.
- child(String) - Method in class akka.typed.adapter.ActorContextAdapter
-
- child(String) - Method in class akka.typed.internal.ActorCell
-
- child(String) - Method in class akka.typed.StubbedActorContext
-
- child_$eq(Option<ActorRef>) - Static method in class akka.pattern.BackoffSupervisor
-
- CHILD_FIELD_NUMBER - Static variable in class akka.remote.SystemMessageFormats.FailedData
-
- CHILD_FIELD_NUMBER - Static variable in class akka.remote.SystemMessageFormats.SuperviseData
-
- 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;
- childActorOf(Props, String, SupervisorStrategy) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- childActorOf(Props, SupervisorStrategy) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- childActorOf(Props, String) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- childActorOf(Props) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- childActorOf(Props, String, SupervisorStrategy) - Static method in class akka.persistence.journal.JournalSpec
-
- childActorOf(Props, SupervisorStrategy) - Static method in class akka.persistence.journal.JournalSpec
-
- childActorOf(Props, String) - Static method in class akka.persistence.journal.JournalSpec
-
- childActorOf(Props) - Static method in class akka.persistence.journal.JournalSpec
-
- childActorOf(Props, String, SupervisorStrategy) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- childActorOf(Props, SupervisorStrategy) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- childActorOf(Props, String) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- childActorOf(Props) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- childActorOf(Props, String, SupervisorStrategy) - Static method in class akka.remote.testkit.MultiNodeSpec
-
- childActorOf(Props, SupervisorStrategy) - Static method in class akka.remote.testkit.MultiNodeSpec
-
- childActorOf(Props, String) - Static method in class akka.remote.testkit.MultiNodeSpec
-
- childActorOf(Props) - Static method in class akka.remote.testkit.MultiNodeSpec
-
- childActorOf(Props, String, SupervisorStrategy) - Method in class akka.testkit.JavaTestKit
-
Spawns an actor as a child of this test actor, and returns the child's ActorRef.
- childActorOf(Props, SupervisorStrategy) - Method in class akka.testkit.JavaTestKit
-
Spawns an actor as a child of this test actor, and returns the child's ActorRef.
- childActorOf(Props, String) - Method in class akka.testkit.JavaTestKit
-
Spawns an actor as a child of this test actor, and returns the child's ActorRef.
- childActorOf(Props) - Method in class akka.testkit.JavaTestKit
-
Spawns an actor as a child of this test actor, and returns the child's ActorRef.
- childActorOf(Props, String, SupervisorStrategy) - Static method in class akka.testkit.TestKit
-
- childActorOf(Props, SupervisorStrategy) - Static method in class akka.testkit.TestKit
-
- childActorOf(Props, String) - Static method in class akka.testkit.TestKit
-
- childActorOf(Props) - Static method in class akka.testkit.TestKit
-
- childActorOf(Props, String, SupervisorStrategy) - Method in interface akka.testkit.TestKitBase
-
Spawns an actor as a child of this test actor, and returns the child's ActorRef.
- childActorOf(Props, SupervisorStrategy) - Method in interface akka.testkit.TestKitBase
-
Spawns an actor as a child of this test actor with an auto-generated name, and returns the child's ActorRef.
- childActorOf(Props, String) - Method in interface akka.testkit.TestKitBase
-
Spawns an actor as a child of this test actor with a stopping supervisor strategy, and returns the child's ActorRef.
- childActorOf(Props) - Method in interface akka.testkit.TestKitBase
-
Spawns an actor as a child of this test actor with an auto-generated name and stopping supervisor strategy, returning the child's ActorRef.
- childActorOf(Props, String, SupervisorStrategy) - Static method in class akka.testkit.TestProbe
-
- childActorOf(Props, SupervisorStrategy) - Static method in class akka.testkit.TestProbe
-
- childActorOf(Props, String) - Static method in class akka.testkit.TestProbe
-
- childActorOf(Props) - Static method in class akka.testkit.TestProbe
-
- 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.pattern.BackoffOnRestartSupervisor
-
- childName() - Method in class akka.pattern.BackoffOptionsImpl
-
- childName() - Method in class akka.pattern.BackoffSupervisor
-
- childName() - Method in interface akka.pattern.HandleBackoff
-
- 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
-
- childProps() - Method in class akka.pattern.BackoffOnRestartSupervisor
-
- childProps() - Method in class akka.pattern.BackoffOptionsImpl
-
- childProps() - Method in class akka.pattern.BackoffSupervisor
-
- childProps() - Method in interface akka.pattern.HandleBackoff
-
- children() - Static method in class akka.actor.ActorCell
-
- 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() - Static method in class akka.routing.RoutedActorCell
-
- Children(Set<ActorRef>) - Constructor for class akka.stream.impl.StreamSupervisor.Children
-
- children() - Method in class akka.stream.impl.StreamSupervisor.Children
-
- children() - Static method in class akka.testkit.TestActorRef
-
- children() - Static method in class akka.testkit.TestFSMRef
-
- 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.adapter.ActorContextAdapter
-
- children() - Method in class akka.typed.internal.ActorCell
-
- children() - Method in class akka.typed.StubbedActorContext
-
- children() - Method in class akka.util.WildcardTree
-
- Children$ - Class in akka.actor.dungeon
-
- Children$() - Constructor for class akka.actor.dungeon.Children$
-
- Children$() - Constructor for class akka.stream.impl.StreamSupervisor.Children$
-
- 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
-
- childrenMap() - Method in class akka.typed.internal.ActorCell
-
- childrenMap() - Method in interface akka.typed.internal.DeathWatch
-
- childrenRefs() - Static method in class akka.actor.ActorCell
-
- 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
-
- childrenRefs() - Static method in class akka.routing.RoutedActorCell
-
- 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
- chooseUnit(long) - Method in class akka.util.PrettyDuration.PrettyPrintableDuration
-
- chopInto(ByteBuffer) - Method in class akka.stream.impl.io.TLSActor.ChoppingBlock
-
Pour as many bytes as are available either on the chopping block or in
the inputBunch’s next ByteString into the supplied ByteBuffer, which is
expected to be in “read left-overs” mode, i.e.
- ChoppingBlock(int, String) - Constructor for class akka.stream.impl.io.TLSActor.ChoppingBlock
-
- chunk() - Method in class akka.cluster.ddata.Replicator.Internal$.Status
-
- CHUNK_FIELD_NUMBER - Static variable in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status
-
- cipherIn() - Method in class akka.stream.impl.io.TlsModule
-
- cipherOut() - Method in class akka.stream.impl.io.TlsModule
-
- circuit() - Method in class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitClosed
-
- circuit() - Method in class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitHalfOpen
-
- circuit() - Method in class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitOpen
-
- CircuitBreaker - Class in akka.pattern
-
Provides circuit breaker functionality to provide stability when working with "dangerous" operations, e.g.
- CircuitBreaker(Scheduler, int, FiniteDuration, FiniteDuration, FiniteDuration, double, ExecutionContext) - Constructor for class akka.pattern.CircuitBreaker
-
- CircuitBreaker(ExecutionContext, Scheduler, int, FiniteDuration, FiniteDuration) - Constructor for class akka.pattern.CircuitBreaker
-
- CircuitBreaker(Scheduler, int, FiniteDuration, FiniteDuration, ExecutionContext) - 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$
-
- CircuitBreakerAwareFuture - Class in akka.contrib.circuitbreaker
-
- CircuitBreakerAwareFuture(Future<Object>) - Constructor for class akka.contrib.circuitbreaker.CircuitBreakerAwareFuture
-
- CircuitBreakerAwareFuture$ - Class in akka.contrib.circuitbreaker
-
- CircuitBreakerAwareFuture$() - Constructor for class akka.contrib.circuitbreaker.CircuitBreakerAwareFuture$
-
- CircuitBreakerInternalEvents$() - Constructor for class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitBreakerInternalEvents$
-
- 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$
-
- CircuitBreakerPropsBuilder(int, Timeout, Timeout, Option<ActorRef>, Function1<Object, Object>, Function1<CircuitBreakerProxy.CircuitOpenFailure, Object>) - Constructor for class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitBreakerPropsBuilder
-
- CircuitBreakerPropsBuilder$() - Constructor for class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitBreakerPropsBuilder$
-
- CircuitBreakerProxy - Class in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy(ActorRef, int, Timeout, Timeout, Option<ActorRef>, Function1<Object, Object>, Function1<CircuitBreakerProxy.CircuitOpenFailure, Object>) - Constructor for class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- CircuitBreakerProxy$ - Class in akka.contrib.circuitbreaker
-
This is an Actor which implements the circuit breaker pattern,
you may also be interested in the raw circuit breaker
CircuitBreaker
- CircuitBreakerProxy$() - Constructor for class akka.contrib.circuitbreaker.CircuitBreakerProxy$
-
- CircuitBreakerProxy.CircuitBreakerCommand - Interface in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy.CircuitBreakerEvent - Interface in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy.CircuitBreakerInternalEvents$ - Class in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy.CircuitBreakerInternalEvents$.CallFailed - Class in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy.CircuitBreakerInternalEvents$.CallSucceeded - Class in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy.CircuitBreakerInternalEvents$.CircuitBreakerInternalEvent - Interface in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy.CircuitBreakerPropsBuilder - Class in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy.CircuitBreakerPropsBuilder$ - Class in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy.CircuitBreakerResponse - Interface in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy.CircuitBreakerState - Interface in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy.CircuitBreakerStateData - Class in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy.CircuitBreakerStateData$ - Class in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy.CircuitClosed - Class in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy.CircuitClosed$ - Class in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy.CircuitHalfOpen - Class in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy.CircuitHalfOpen$ - Class in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy.CircuitOpen - Class in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy.CircuitOpen$ - Class in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy.CircuitOpenFailure - Class in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy.CircuitOpenFailure$ - Class in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy.Closed$ - Class in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy.HalfOpen$ - Class in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy.Open$ - Class in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy.Passthrough - Class in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy.Passthrough$ - Class in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy.TellOnly - Class in akka.contrib.circuitbreaker
-
- CircuitBreakerProxy.TellOnly$ - Class in akka.contrib.circuitbreaker
-
- CircuitBreakerStateData(int, boolean) - Constructor for class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitBreakerStateData
-
- CircuitBreakerStateData$() - Constructor for class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitBreakerStateData$
-
- CircuitClosed(ActorRef) - Constructor for class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitClosed
-
- CircuitClosed$() - Constructor for class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitClosed$
-
- circuitEventListener() - Method in class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitBreakerPropsBuilder
-
- CircuitHalfOpen(ActorRef) - Constructor for class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitHalfOpen
-
- CircuitHalfOpen$() - Constructor for class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitHalfOpen$
-
- CircuitOpen(ActorRef) - Constructor for class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitOpen
-
- CircuitOpen$() - Constructor for class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitOpen$
-
- CircuitOpenFailure(Object) - Constructor for class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitOpenFailure
-
- CircuitOpenFailure$() - Constructor for class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitOpenFailure$
-
- 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
-
Deprecated.
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
-
Deprecated.
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.BootstrapSetup
-
- 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
-
- classManifest() - Method in interface akka.remote.artery.InboundEnvelope
-
- classManifest() - Method in class akka.remote.artery.ReusableInboundEnvelope
-
- ClassManifestCompressionAdvertisement(UniqueAddress, CompressionTable<String>) - Constructor for class akka.remote.artery.compress.CompressionProtocol.ClassManifestCompressionAdvertisement
-
- ClassManifestCompressionAdvertisement$() - Constructor for class akka.remote.artery.compress.CompressionProtocol.ClassManifestCompressionAdvertisement$
-
- ClassManifestCompressionAdvertisementAck(UniqueAddress, byte) - Constructor for class akka.remote.artery.compress.CompressionProtocol.ClassManifestCompressionAdvertisementAck
-
- ClassManifestCompressionAdvertisementAck$() - Constructor for class akka.remote.artery.compress.CompressionProtocol.ClassManifestCompressionAdvertisementAck$
-
- ClassManifestCompressionTableVersionOffset() - Method in class akka.remote.artery.EnvelopeBuffer$
-
- ClassManifestCompressionTableVersionOffset() - Static method in class akka.remote.artery.EnvelopeBuffer
-
- ClassManifestTagOffset() - Method in class akka.remote.artery.EnvelopeBuffer$
-
- ClassManifestTagOffset() - Static method in class akka.remote.artery.EnvelopeBuffer
-
- CLASSNAME_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.StackTraceElement
-
- CLASSNAME_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.Throwable
-
- 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(Object) - Static method in class akka.routing.RoutedActorCell
-
- clazz(Object) - Method in class akka.typed.internal.ActorCell
-
- clazz(Object) - Method in interface akka.typed.internal.DeathWatch
-
- clazz(Object) - Method in interface akka.typed.internal.SupervisionMechanics
-
- CLAZZ_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.PropsData
-
- Cleanup() - Constructor for class akka.cluster.singleton.ClusterSingletonManager.Internal$.Cleanup
-
- 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(ActorRef, MessageQueue) - Method in class akka.event.LoggerMailbox
-
- cleanup() - Method in interface akka.io.PeriodicCacheCleanup
-
- cleanup() - Method in class akka.io.SimpleDnsCache
-
- cleanup() - Method in class akka.stream.TransformerLike
-
Invoked after normal completion or failure.
- cleanUp() - Method in class akka.testkit.CallingThreadMailbox
-
- cleanupOverdueNotMemberAnyMore() - Method in class akka.cluster.singleton.ClusterSingletonManager
-
- CleanupTimer() - Method in class akka.cluster.singleton.ClusterSingletonManager.Internal$
-
- clear() - Method in class akka.cluster.client.protobuf.msg.ClusterClientMessages.Contacts.Builder
-
- clear(Cluster) - Method in class akka.cluster.ddata.ORSet
-
Removes all elements from the set, but keeps the history.
- clear(UniqueAddress) - Method in class akka.cluster.ddata.ORSet
-
INTERNAL API
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.Flag.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Address.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelope.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Empty.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Read.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResult.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe.Builder
-
- clear() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write.Builder
-
- 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.SendToOneSubscriber.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.cluster.sharding.protobuf.msg.ClusterShardingMessages.ActorRefMessage.Builder
-
- clear() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
- clear() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry.Builder
-
- clear() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStarted.Builder
-
- clear() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState.Builder
-
- clear() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStopped.Builder
-
- clear() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome.Builder
-
- clear() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated.Builder
-
- clear() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessage.Builder
-
- clear() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats.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.AtomicWrite.Builder
-
- clear() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot.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.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
-
- clear() - Method in class akka.remote.artery.ReusableInboundEnvelope
-
- clear() - Method in class akka.remote.artery.ReusableOutboundEnvelope
-
- clear(int) - Method in class akka.remote.artery.RollingEventLogSection
-
- clear() - Method in class akka.remote.ArteryControlFormats.Address.Builder
-
- clear() - Method in class akka.remote.ArteryControlFormats.ArteryHeartbeatRsp.Builder
-
- clear() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
- clear() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck.Builder
-
- clear() - Method in class akka.remote.ArteryControlFormats.HandshakeReq.Builder
-
- clear() - Method in class akka.remote.ArteryControlFormats.MessageWithAddress.Builder
-
- clear() - Method in class akka.remote.ArteryControlFormats.Quarantined.Builder
-
- clear() - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck.Builder
-
- clear() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope.Builder
-
- clear() - Method in class akka.remote.ArteryControlFormats.UniqueAddress.Builder
-
- clear() - Method in class akka.remote.ContainerFormats.ActorIdentity.Builder
-
- clear() - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
- clear() - Method in class akka.remote.ContainerFormats.ActorRef.Builder
-
- clear() - Method in class akka.remote.ContainerFormats.Identify.Builder
-
- clear() - Method in class akka.remote.ContainerFormats.Option.Builder
-
- clear() - Method in class akka.remote.ContainerFormats.Payload.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.ContainerFormats.StackTraceElement.Builder
-
- clear() - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
- clear() - Method in class akka.remote.ContainerFormats.WatcherHeartbeatResponse.Builder
-
- clear() - Static method in class akka.remote.security.provider.AkkaProvider
-
- clear() - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData.Builder
-
- clear() - Method in class akka.remote.SystemMessageFormats.FailedData.Builder
-
- clear() - Method in class akka.remote.SystemMessageFormats.SuperviseData.Builder
-
- clear() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
- clear() - Method in class akka.remote.SystemMessageFormats.WatchData.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.stream.impl.BoundedBuffer
-
- clear() - Method in interface akka.stream.impl.Buffer
-
- clear() - Method in class akka.stream.impl.FixedSizeBuffer.FixedSizeBuffer
-
- clear() - Method in class akka.util.BoundedBlockingQueue
-
- clear() - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- clear() - Method in class akka.util.ByteIterator
-
- clear() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- clear() - Method in class akka.util.ByteStringBuilder
-
- clear() - Method in class akka.util.Index
-
Removes all keys and all values
- clear() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet.Builder
-
- clear() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2.Builder
-
- clear() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved.Builder
-
- clearAck() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
optional .AcknowledgementInfo ack = 1;
- clearAckReplyTo() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope.Builder
-
required .UniqueAddress ackReplyTo = 5;
- clearActor() - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
optional .ActorRef actor = 1;
- clearActor() - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData.Builder
-
required .ActorRef actor = 1;
- clearActorCellFields(ActorCell) - Method in class akka.actor.ActorCell
-
- clearActorCellFields(ActorCell) - Static method in class akka.routing.RoutedActorCell
-
- clearActorFields(Actor, boolean) - Method in class akka.actor.ActorCell
-
- clearActorFields(Actor, boolean) - Static method in class akka.routing.RoutedActorCell
-
- 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.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress.Builder
-
required .akka.cluster.ddata.Address address = 1;
- 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.ArteryControlFormats.MessageWithAddress.Builder
-
required .UniqueAddress address = 1;
- clearAddress() - Method in class akka.remote.ArteryControlFormats.UniqueAddress.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;
- clearAddressTerminated() - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData.Builder
-
required bool addressTerminated = 3;
- clearAdds() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet.Builder
-
repeated string adds = 1;
- clearAdds() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2.Builder
-
optional bytes adds = 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;
- clearAncestor() - Method in interface akka.cluster.ddata.FastMerge
-
INTERNAL API: should be called from merge
- clearAncestor() - Static method in class akka.cluster.ddata.GCounter
-
- clearAncestor() - Static method in class akka.cluster.ddata.GSet
-
- clearAncestor() - Static method in class akka.cluster.ddata.ORSet
-
- clearArgs() - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated bytes args = 4;
- clearAssertionStatus() - Static method in class akka.osgi.BundleDelegatingClassLoader
-
- clearAsync() - Method in class akka.remote.SystemMessageFormats.SuperviseData.Builder
-
required bool async = 2;
- 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;
- clearCause() - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
required .Payload cause = 3;
- clearCause() - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
optional .Payload cause = 3;
- clearCauseData() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .Payload causeData = 3;
- clearChild() - Method in class akka.remote.SystemMessageFormats.FailedData.Builder
-
required .ActorRef child = 1;
- clearChild() - Method in class akka.remote.SystemMessageFormats.SuperviseData.Builder
-
required .ActorRef child = 1;
- clearChunk() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
required uint32 chunk = 1;
- clearClassName() - Method in class akka.remote.ContainerFormats.StackTraceElement.Builder
-
required string className = 1;
- clearClassName() - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
required string className = 1;
- 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;
- clearCompression() - Method in interface akka.remote.artery.Encoder.OutboundCompressionAccess
-
- clearConfig() - Method in class akka.remote.WireFormats.DeployData.Builder
-
optional bytes config = 2;
- clearConsistency() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
required sint32 consistency = 2;
- clearContactPoints() - Method in class akka.cluster.client.protobuf.msg.ClusterClientMessages.Contacts.Builder
-
repeated string contactPoints = 1;
- 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;
- clearCorrelationId() - Method in class akka.remote.ContainerFormats.ActorIdentity.Builder
-
required .Payload correlationId = 1;
- 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;
- clearData() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed.Builder
-
required .akka.cluster.ddata.OtherMessage data = 2;
- clearData() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
required .akka.cluster.ddata.OtherMessage data = 1;
- clearData() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelope.Builder
-
required .akka.cluster.ddata.OtherMessage data = 1;
- clearData() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
required .akka.cluster.ddata.OtherMessage data = 2;
- clearData() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot.Builder
-
required .PersistentPayload data = 2;
- clearDecrements() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter.Builder
-
required .akka.cluster.ddata.GCounter decrements = 2;
- 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;
- clearDigest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry.Builder
-
required bytes digest = 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;
- clearDots() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- clearDwNotificationData() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .DeathWatchNotificationData dwNotificationData = 7;
- clearedList() - Method in class akka.util.ByteIterator.MultiByteArrayIterator$
-
- clearElements() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet.Builder
-
repeated string elements = 1;
- clearEnabled() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.Flag.Builder
-
required bool enabled = 1;
- clearEnclosedMessage() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage.Builder
-
required bytes enclosedMessage = 1;
- clearEnclosedMessage() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload.Builder
-
required bytes enclosedMessage = 1;
- clearEnclosedMessage() - Method in class akka.remote.ContainerFormats.Payload.Builder
-
required bytes enclosedMessage = 1;
- clearEnclosedMessage() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
required bytes enclosedMessage = 1;
- clearEntities() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState.Builder
-
repeated string entities = 1;
- clearEntityCount() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats.Builder
-
required int32 entityCount = 2;
- clearEntityId() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStarted.Builder
-
required string entityId = 1;
- clearEntityId() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStopped.Builder
-
required string entityId = 1;
- clearEntries() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Builder
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- clearEntries() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- clearEntries() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- clearEntries() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- clearEntries() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- clearEntries() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Builder
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- clearEntries() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- clearEntries() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
repeated .akka.cluster.ddata.Status.Entry entries = 3;
- clearEnvelope() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry.Builder
-
required .akka.cluster.ddata.DataEnvelope envelope = 2;
- clearEnvelope() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResult.Builder
-
optional .akka.cluster.ddata.DataEnvelope envelope = 1;
- clearEnvelope() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write.Builder
-
required .akka.cluster.ddata.DataEnvelope envelope = 2;
- 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;
- clearExistenceConfirmed() - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData.Builder
-
required bool existenceConfirmed = 2;
- clearExitValue() - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
optional int32 exitValue = 7;
- clearFailed() - Method in interface akka.actor.dungeon.FaultHandling
-
- clearFailedData() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .FailedData failedData = 6;
- 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;
- clearFileName() - Method in class akka.remote.ContainerFormats.StackTraceElement.Builder
-
required string fileName = 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;
- clearFrom() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
required .UniqueAddress from = 1;
- clearFrom() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck.Builder
-
required .UniqueAddress from = 1;
- clearFrom() - Method in class akka.remote.ArteryControlFormats.HandshakeReq.Builder
-
required .UniqueAddress from = 1;
- clearFrom() - Method in class akka.remote.ArteryControlFormats.Quarantined.Builder
-
required .UniqueAddress from = 1;
- clearFrom() - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck.Builder
-
required .UniqueAddress from = 2;
- 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;
- clearHasManifest() - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated bool hasManifest = 7;
- 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.ddata.protobuf.msg.ReplicatorMessages.Address.Builder
-
required string hostname = 1;
- 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.ArteryControlFormats.Address.Builder
-
required string hostname = 3;
- clearHostname() - Method in class akka.remote.WireFormats.AddressData.Builder
-
required string hostname = 2;
- clearIncrements() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter.Builder
-
required .akka.cluster.ddata.GCounter increments = 1;
- clearInstruction() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
-
optional .AkkaControlMessage instruction = 2;
- clearIntElements() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated sint32 intElements = 2 [packed = true];
- clearIntElements() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated sint32 intElements = 4 [packed = true];
- clearKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry.Builder
-
required string key = 1;
- clearKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry.Builder
-
required string key = 1;
- clearKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry.Builder
-
required string key = 1;
- clearKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry.Builder
-
required string key = 1;
- clearKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- clearKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- clearKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- clearKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- clearKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry.Builder
-
required string key = 1;
- clearKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- clearKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Read.Builder
-
required string key = 1;
- clearKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry.Builder
-
required string key = 1;
- clearKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- clearKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- clearKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write.Builder
-
required string key = 1;
- clearKey() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
required string key = 1;
- clearKeys() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- clearKeys() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- clearKeys() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- clearKeys() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- clearKeys() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
repeated string keys = 4;
- clearLetter() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved.Builder
-
required string letter = 1;
- clearLineNumber() - Method in class akka.remote.ContainerFormats.StackTraceElement.Builder
-
required int32 lineNumber = 4;
- 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.
- clearLongElements() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated sint64 longElements = 3 [packed = true];
- clearLongElements() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated sint64 longElements = 5 [packed = true];
- clearManifest() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional string manifest = 12;
- clearManifests() - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated string manifests = 5;
- 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.ArteryControlFormats.SystemMessageEnvelope.Builder
-
required bytes message = 1;
- clearMessage() - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
required string message = 2;
- clearMessage() - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
optional string message = 2;
- 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;
- clearMessageId() - Method in class akka.remote.ContainerFormats.Identify.Builder
-
required .Payload messageId = 1;
- clearMessageManifest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage.Builder
-
optional bytes messageManifest = 4;
- clearMessageManifest() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload.Builder
-
optional bytes messageManifest = 4;
- clearMessageManifest() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope.Builder
-
optional bytes messageManifest = 3;
- clearMessageManifest() - Method in class akka.remote.ContainerFormats.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;
- clearMethodName() - Method in class akka.remote.ContainerFormats.StackTraceElement.Builder
-
required string methodName = 2;
- 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.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry.Builder
-
required .akka.cluster.ddata.UniqueAddress node = 1;
- clearNode() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
required .akka.cluster.ddata.UniqueAddress node = 2;
- clearNode() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry.Builder
-
required .akka.cluster.ddata.UniqueAddress node = 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;
- clearOriginUid() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
required uint64 originUid = 2;
- clearOtherElements() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- clearOtherElements() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- 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;
- clearOwnerAddress() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
required .akka.cluster.ddata.UniqueAddress ownerAddress = 2;
- 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.ContainerFormats.ActorRef.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.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToOneSubscriber.Builder
-
required .Payload payload = 1;
- clearPayload() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
required .PersistentPayload payload = 3;
- clearPayload() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
-
repeated .PersistentMessage payload = 1;
- 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;
- clearPerformed() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
required bool performed = 3;
- clearPersistenceId() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional string persistenceId = 3;
- clearPort() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Address.Builder
-
required uint32 port = 2;
- 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.ArteryControlFormats.Address.Builder
-
required uint32 port = 4;
- 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.ArteryControlFormats.Address.Builder
-
required string protocol = 1;
- 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;
- clearPruning() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- 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.ddata.protobuf.msg.ReplicatorMessages.Subscribe.Builder
-
required string ref = 2;
- clearRef() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe.Builder
-
required string ref = 2;
- clearRef() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
optional string ref = 3;
- clearRef() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ActorRefMessage.Builder
-
required string ref = 1;
- clearRef() - Method in class akka.remote.ContainerFormats.ActorIdentity.Builder
-
optional .ActorRef ref = 2;
- clearRegion() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome.Builder
-
required string region = 2;
- clearRegion() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated.Builder
-
required string region = 2;
- clearRegionProxies() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string regionProxies = 3;
- clearRegionRef() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry.Builder
-
required string regionRef = 2;
- clearRegions() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string regions = 2;
- clearRemovals() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet.Builder
-
repeated string removals = 2;
- clearRemovals() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2.Builder
-
optional bytes removals = 2;
- clearRemovedAddress() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
required .akka.cluster.ddata.UniqueAddress removedAddress = 1;
- 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;
- clearReplyToStatus() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
optional bool replyToStatus = 2;
- clearRequest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- clearRequest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- clearRequest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- clearRequest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- 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;
- clearRow() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved.Builder
-
required uint32 row = 2;
- clearScope() - Method in class akka.remote.WireFormats.DeployData.Builder
-
optional bytes scope = 4;
- clearSeatType() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved.Builder
-
optional string seatType = 3;
- clearSeen() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
repeated .akka.cluster.ddata.Address seen = 4;
- clearSeen() - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated int32 seen = 1;
- clearSendBack() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
required bool sendBack = 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;
- clearSeqNo() - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck.Builder
-
required uint64 seqNo = 1;
- clearSeqNo() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope.Builder
-
required uint64 seqNo = 4;
- 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.ddata.protobuf.msg.ReplicatorMessages.OtherMessage.Builder
-
required int32 serializerId = 2;
- 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.ArteryControlFormats.SystemMessageEnvelope.Builder
-
required int32 serializerId = 2;
- clearSerializerId() - Method in class akka.remote.ContainerFormats.Payload.Builder
-
required int32 serializerId = 2;
- 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;
- clearSerializerIds() - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated int32 serializerIds = 6;
- clearShard() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome.Builder
-
required string shard = 1;
- clearShard() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated.Builder
-
required string shard = 1;
- clearShard() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessage.Builder
-
required string shard = 1;
- clearShard() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats.Builder
-
required string shard = 1;
- clearShardId() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry.Builder
-
required string shardId = 1;
- clearShards() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated .CoordinatorState.ShardEntry shards = 1;
- clearStackTrace() - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
repeated .StackTraceElement stackTrace = 4;
- clearStash() - Method in interface akka.actor.StashSupport
-
INTERNAL API.
- clearStash() - Static method in class akka.event.ActorClassificationUnsubscriber
-
- clearStash() - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- clearStash() - Static method in class akka.persistence.journal.PersistencePluginProxy
-
- clearState() - Method in class akka.cluster.ClusterDomainEventPublisher
-
- clearState() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
required .akka.cluster.ddata.OtherMessage state = 3;
- clearStateIdentifier() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot.Builder
-
required string stateIdentifier = 1;
- clearStateIdentifier() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
-
required string stateIdentifier = 1;
- 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;
- clearStringElements() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated string stringElements = 1;
- clearStringElements() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated string stringElements = 3;
- clearSubjectReachability() - Method in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability.Builder
-
repeated .SubjectReachability subjectReachability = 2;
- clearSuperviseData() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .SuperviseData superviseData = 5;
- 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.ArteryControlFormats.Address.Builder
-
required string system = 2;
- 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;
- ClearSystemMessageDelivery$() - Constructor for class akka.remote.artery.SystemMessageDelivery.ClearSystemMessageDelivery$
-
- clearTableVersion() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
required uint32 tableVersion = 3;
- clearTimeout() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
required uint32 timeout = 3;
- clearTimeout() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
-
optional string timeout = 2;
- clearTimeout() - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
-
optional int64 timeout = 3;
- clearTimeoutNanos() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot.Builder
-
optional int64 timeoutNanos = 3;
- clearTimeoutNanos() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
-
optional int64 timeoutNanos = 3;
- clearTimestamp() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
required sint64 timestamp = 1;
- 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;
- clearTo() - Method in class akka.remote.ArteryControlFormats.HandshakeReq.Builder
-
required .Address to = 2;
- clearTo() - Method in class akka.remote.ArteryControlFormats.Quarantined.Builder
-
required .UniqueAddress to = 2;
- clearTopic() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Publish.Builder
-
required string topic = 1;
- clearTotChunks() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
required uint32 totChunks = 2;
- 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;
- clearType() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
required .SystemMessage.Type type = 1;
- clearUid() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress.Builder
-
required sfixed32 uid = 2;
- clearUid() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
-
required uint32 uid = 2;
- clearUid() - Method in class akka.remote.ArteryControlFormats.ArteryHeartbeatRsp.Builder
-
required uint64 uid = 1;
- clearUid() - Method in class akka.remote.ArteryControlFormats.UniqueAddress.Builder
-
required uint64 uid = 2;
- clearUid() - Method in class akka.remote.ContainerFormats.WatcherHeartbeatResponse.Builder
-
required uint64 uid = 1;
- clearUid() - Method in class akka.remote.SystemMessageFormats.FailedData.Builder
-
required uint64 uid = 2;
- clearUid() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
required fixed64 uid = 2;
- clearUid2() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress.Builder
-
optional sfixed32 uid2 = 3;
- clearUid2() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
-
optional uint32 uid2 = 3;
- clearUnallocatedShards() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string unallocatedShards = 4;
- 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.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry.Builder
-
required bytes value = 2;
- clearValue() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry.Builder
-
required .akka.cluster.ddata.LWWRegister value = 2;
- clearValue() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry.Builder
-
required .akka.cluster.ddata.OtherMessage value = 2;
- clearValue() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry.Builder
-
required .akka.cluster.ddata.ORSet value = 2;
- clearValue() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry.Builder
-
required .akka.cluster.ddata.PNCounter value = 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;
- clearValue() - Method in class akka.remote.ContainerFormats.Option.Builder
-
optional .Payload 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;
- clearValues() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
repeated uint32 values = 5;
- clearVersion() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry.Builder
-
required int64 version = 2;
- 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;
- clearVersion() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck.Builder
-
required uint32 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;
- clearVvector() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
required .akka.cluster.ddata.VersionVector vvector = 1;
- clearWatchData() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .WatchData watchData = 2;
- clearWatchee() - Method in class akka.remote.SystemMessageFormats.WatchData.Builder
-
required .ActorRef watchee = 1;
- clearWatcher() - Method in class akka.remote.SystemMessageFormats.WatchData.Builder
-
required .ActorRef watcher = 2;
- clearWildcardFanOut() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
optional bool wildcardFanOut = 5;
- clearWriterUuid() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional string writerUuid = 13;
- 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.stream
-
The client is usually the side that consumes the service provided by its
interlocutor.
- Client() - Constructor for class akka.stream.Client
-
- client() - Method in class akka.stream.TLSRole$
-
Java API: obtain the
Client
singleton value.
- client() - Static method in class akka.stream.TLSRole
-
Java API: obtain the
Client
singleton value.
- Client$ - Class in akka.remote.testconductor
-
INTERNAL API.
- Client$() - Constructor for class akka.remote.testconductor.Client$
-
- Client$ - Class in akka.stream
-
- Client$() - Constructor for class akka.stream.Client$
-
- clientAuth() - Method in class akka.stream.TLSProtocol.NegotiateNewSession
-
- 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
-
- clientInteractions() - Method in class akka.cluster.client.ClusterReceptionist
-
- ClientLivenessTimeout() - Method in class akka.remote.artery.ArterySettings.Advanced$
-
- 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
-
- clientsPublished() - Method in class akka.cluster.client.ClusterReceptionist
-
- 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
-
- clockTask() - Method in class akka.cluster.ddata.Replicator
-
- ClockTick() - Constructor for class akka.cluster.ddata.Replicator.Internal$.ClockTick
-
- clone() - Method in class akka.cluster.client.protobuf.msg.ClusterClientMessages.Contacts.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.Flag.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Address.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelope.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Empty.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Read.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResult.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe.Builder
-
- clone() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write.Builder
-
- 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.SendToOneSubscriber.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.cluster.sharding.protobuf.msg.ClusterShardingMessages.ActorRefMessage.Builder
-
- clone() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
- clone() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry.Builder
-
- clone() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStarted.Builder
-
- clone() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState.Builder
-
- clone() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStopped.Builder
-
- clone() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome.Builder
-
- clone() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated.Builder
-
- clone() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessage.Builder
-
- clone() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats.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.AtomicWrite.Builder
-
- clone() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot.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.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
-
- clone() - Method in class akka.remote.ArteryControlFormats.Address.Builder
-
- clone() - Method in class akka.remote.ArteryControlFormats.ArteryHeartbeatRsp.Builder
-
- clone() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
- clone() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck.Builder
-
- clone() - Method in class akka.remote.ArteryControlFormats.HandshakeReq.Builder
-
- clone() - Method in class akka.remote.ArteryControlFormats.MessageWithAddress.Builder
-
- clone() - Method in class akka.remote.ArteryControlFormats.Quarantined.Builder
-
- clone() - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck.Builder
-
- clone() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope.Builder
-
- clone() - Method in class akka.remote.ArteryControlFormats.UniqueAddress.Builder
-
- clone() - Method in class akka.remote.ContainerFormats.ActorIdentity.Builder
-
- clone() - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
- clone() - Method in class akka.remote.ContainerFormats.ActorRef.Builder
-
- clone() - Method in class akka.remote.ContainerFormats.Identify.Builder
-
- clone() - Method in class akka.remote.ContainerFormats.Option.Builder
-
- clone() - Method in class akka.remote.ContainerFormats.Payload.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.ContainerFormats.StackTraceElement.Builder
-
- clone() - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
- clone() - Method in class akka.remote.ContainerFormats.WatcherHeartbeatResponse.Builder
-
- clone() - Static method in class akka.remote.security.provider.AkkaProvider
-
- clone() - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData.Builder
-
- clone() - Method in class akka.remote.SystemMessageFormats.FailedData.Builder
-
- clone() - Method in class akka.remote.SystemMessageFormats.SuperviseData.Builder
-
- clone() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
- clone() - Method in class akka.remote.SystemMessageFormats.WatchData.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
-
- clone() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet.Builder
-
- clone() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2.Builder
-
- clone() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved.Builder
-
- cloneParameters(SSLParameters) - Method in class akka.stream.impl.io.TlsUtils$
-
- cloneParameters(SSLParameters) - Static method in class akka.stream.impl.io.TlsUtils
-
- 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
-
Deprecated.
- 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
-
Deprecated.
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() - Method in class akka.remote.artery.AeronErrorLog
-
- close(long) - Method in interface akka.remote.artery.compress.InboundCompressions
-
Remove compression and cancel advertisement scheduling for a specific origin
- close(long) - Method in class akka.remote.artery.compress.InboundCompressionsImpl
-
- close(long) - Method in class akka.remote.artery.compress.NoInboundCompressions$
-
- close(long) - Static method in class akka.remote.artery.compress.NoInboundCompressions
-
- close() - Method in class akka.remote.artery.FlightRecorder
-
- close() - Method in class akka.remote.artery.FlightRecorderReader
-
- close() - Method in class akka.remote.artery.RollingEventLogSection
-
- close() - Method in class akka.stream.impl.io.compression.Compressor
-
Make sure any resources have been released
- close() - Method in class akka.stream.impl.io.compression.DeflateCompressor
-
- close() - Method in class akka.stream.impl.io.InputStreamAdapter
-
- close() - Method in class akka.stream.impl.io.OutputStreamAdapter
-
- close() - Method in class akka.stream.scaladsl.MergeHub.InputState
-
- Close$() - Constructor for class akka.io.Tcp.Close$
-
- Close$() - Constructor for class akka.stream.impl.io.InputStreamSinkStage.Close$
-
- Close$() - Constructor for class akka.stream.impl.io.OutputStreamSourceStage.Close$
-
- closeCompressionFor(long) - Method in interface akka.remote.artery.Decoder.InboundCompressionAccess
-
- closeCompressionFor(long) - Method in interface akka.remote.artery.Decoder.InboundCompressionAccessImpl
-
External call from ChangeInboundCompression materialized value
- Closed() - Method in class akka.dispatch.Mailbox$
-
- Closed() - Static method in class akka.dispatch.Mailbox
-
- Closed$() - Constructor for class akka.contrib.circuitbreaker.CircuitBreakerProxy.Closed$
-
- 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
-
- closedMessage() - Static method in class akka.io.TcpOutgoingConnection
-
- closedMessage_$eq(TcpConnection.CloseInformation) - Static method in class akka.io.TcpOutgoingConnection
-
- ClosedShape - Class in akka.stream
-
This
Shape
is used for graphs that have neither open inputs nor open
outputs.
- ClosedShape() - Constructor for class akka.stream.ClosedShape
-
- ClosedShape$ - Class in akka.stream
-
- ClosedShape$() - Constructor for class akka.stream.ClosedShape$
-
- 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
-
- closeReason() - Static method in class akka.io.TcpOutgoingConnection
-
- 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
- closing(TcpConnection.ConnectionInfo, Option<ActorRef>) - Static method in class akka.io.TcpOutgoingConnection
-
- closing() - Method in class akka.stream.impl.io.TlsModule
-
- closingWithPendingWrite(TcpConnection.ConnectionInfo, Option<ActorRef>, Tcp.ConnectionClosed) - Method in class akka.io.TcpConnection
-
connection is closing but a write has to be finished first
- closingWithPendingWrite(TcpConnection.ConnectionInfo, Option<ActorRef>, Tcp.ConnectionClosed) - Static method in class akka.io.TcpOutgoingConnection
-
- cluster() - Method in class akka.actor.ProviderSelection$
-
- cluster() - Static method in class akka.actor.ProviderSelection
-
- 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.ddata.Replicator
-
- 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.ShardCoordinator
-
- 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$() - Constructor for class akka.actor.ProviderSelection.Cluster$
-
- 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() - Method in interface akka.cluster.client.ClusterClientInteraction
-
- clusterClient() - Method in class akka.cluster.client.ClusterClientUnreachable
-
- clusterClient() - Method in class akka.cluster.client.ClusterClientUp
-
- 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$.HeartbeatTick - Class in akka.cluster.client
-
- ClusterClient.Internal$.ReconnectTimeout - Class in akka.cluster.client
-
- 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
-
- ClusterClientInteraction - Interface in akka.cluster.client
-
Declares a super type for all events emitted by the ClusterReceptionist
.
- ClusterClientMessage - Interface in akka.cluster.client
-
Marker trait for remote messages with special serializer.
- ClusterClientMessages - Class in akka.cluster.client.protobuf.msg
-
- ClusterClientMessages.Contacts - Class in akka.cluster.client.protobuf.msg
-
Protobuf type Contacts
- ClusterClientMessages.Contacts.Builder - Class in akka.cluster.client.protobuf.msg
-
Protobuf type Contacts
- ClusterClientMessages.ContactsOrBuilder - Interface in akka.cluster.client.protobuf.msg
-
- ClusterClientMessageSerializer - Class in akka.cluster.client.protobuf
-
INTERNAL API: Serializer of ClusterClient messages.
- ClusterClientMessageSerializer(ExtendedActorSystem) - Constructor for class akka.cluster.client.protobuf.ClusterClientMessageSerializer
-
- 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$
-
- ClusterClients - Class in akka.cluster.client
-
The reply to
GetClusterClients
.
- ClusterClients(Set<ActorRef>) - Constructor for class akka.cluster.client.ClusterClients
-
- clusterClients() - Method in class akka.cluster.client.ClusterClients
-
- ClusterClients$ - Class in akka.cluster.client
-
- ClusterClients$() - Constructor for class akka.cluster.client.ClusterClients$
-
- 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, FiniteDuration, FiniteDuration, int, Option<FiniteDuration>) - Constructor for class akka.cluster.client.ClusterClientSettings
-
- ClusterClientSettings(Set<ActorPath>, FiniteDuration, FiniteDuration, FiniteDuration, FiniteDuration, int) - Constructor for class akka.cluster.client.ClusterClientSettings
-
For binary/source compatibility
- ClusterClientSettings$ - Class in akka.cluster.client
-
- ClusterClientSettings$() - Constructor for class akka.cluster.client.ClusterClientSettings$
-
- ClusterClientUnreachable - Class in akka.cluster.client
-
Emitted to the Akka event stream when a cluster client was previously connected
but then not seen for some time.
- ClusterClientUnreachable(ActorRef) - Constructor for class akka.cluster.client.ClusterClientUnreachable
-
- ClusterClientUnreachable$ - Class in akka.cluster.client
-
- ClusterClientUnreachable$() - Constructor for class akka.cluster.client.ClusterClientUnreachable$
-
- ClusterClientUp - Class in akka.cluster.client
-
Emitted to the Akka event stream when a cluster client has interacted with
a receptionist.
- ClusterClientUp(ActorRef) - Constructor for class akka.cluster.client.ClusterClientUp
-
- ClusterClientUp$ - Class in akka.cluster.client
-
- ClusterClientUp$() - Constructor for class akka.cluster.client.ClusterClientUp$
-
- 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
-
- 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.MemberJoined - Class in akka.cluster
-
Member status changed to Joining.
- ClusterEvent.MemberJoined$ - Class in akka.cluster
-
- ClusterEvent.MemberLeft - Class in akka.cluster
-
Member status changed to Leaving.
- ClusterEvent.MemberLeft$ - 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.MemberWeaklyUp - Class in akka.cluster
-
Member status changed to WeaklyUp.
- ClusterEvent.MemberWeaklyUp$ - 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
-
Deprecated.
- 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$
-
Deprecated.
- 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$.CheckDeadlines - Class in akka.cluster.client
-
- 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$.Heartbeat - Class in akka.cluster.client
-
- ClusterReceptionist.Internal$.HeartbeatRsp - 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(Option<String>, int, FiniteDuration, FiniteDuration, FiniteDuration, 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
-
- ClusterSettings.Debug - Class in akka.cluster
-
- 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$
-
- 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
-
- ClusterShardingGuardian.StartProxy - Class in akka.cluster.sharding
-
- ClusterShardingGuardian.StartProxy$ - Class in akka.cluster.sharding
-
- ClusterShardingMessages - Class in akka.cluster.sharding.protobuf.msg
-
- ClusterShardingMessages.ActorRefMessage - Class in akka.cluster.sharding.protobuf.msg
-
Protobuf type ActorRefMessage
- ClusterShardingMessages.ActorRefMessage.Builder - Class in akka.cluster.sharding.protobuf.msg
-
Protobuf type ActorRefMessage
- ClusterShardingMessages.ActorRefMessageOrBuilder - Interface in akka.cluster.sharding.protobuf.msg
-
- ClusterShardingMessages.CoordinatorState - Class in akka.cluster.sharding.protobuf.msg
-
Protobuf type CoordinatorState
- ClusterShardingMessages.CoordinatorState.Builder - Class in akka.cluster.sharding.protobuf.msg
-
Protobuf type CoordinatorState
- ClusterShardingMessages.CoordinatorState.ShardEntry - Class in akka.cluster.sharding.protobuf.msg
-
Protobuf type CoordinatorState.ShardEntry
- ClusterShardingMessages.CoordinatorState.ShardEntry.Builder - Class in akka.cluster.sharding.protobuf.msg
-
Protobuf type CoordinatorState.ShardEntry
- ClusterShardingMessages.CoordinatorState.ShardEntryOrBuilder - Interface in akka.cluster.sharding.protobuf.msg
-
- ClusterShardingMessages.CoordinatorStateOrBuilder - Interface in akka.cluster.sharding.protobuf.msg
-
- ClusterShardingMessages.EntityStarted - Class in akka.cluster.sharding.protobuf.msg
-
Protobuf type EntityStarted
- ClusterShardingMessages.EntityStarted.Builder - Class in akka.cluster.sharding.protobuf.msg
-
Protobuf type EntityStarted
- ClusterShardingMessages.EntityStartedOrBuilder - Interface in akka.cluster.sharding.protobuf.msg
-
- ClusterShardingMessages.EntityState - Class in akka.cluster.sharding.protobuf.msg
-
Protobuf type EntityState
- ClusterShardingMessages.EntityState.Builder - Class in akka.cluster.sharding.protobuf.msg
-
Protobuf type EntityState
- ClusterShardingMessages.EntityStateOrBuilder - Interface in akka.cluster.sharding.protobuf.msg
-
- ClusterShardingMessages.EntityStopped - Class in akka.cluster.sharding.protobuf.msg
-
Protobuf type EntityStopped
- ClusterShardingMessages.EntityStopped.Builder - Class in akka.cluster.sharding.protobuf.msg
-
Protobuf type EntityStopped
- ClusterShardingMessages.EntityStoppedOrBuilder - Interface in akka.cluster.sharding.protobuf.msg
-
- ClusterShardingMessages.ShardHome - Class in akka.cluster.sharding.protobuf.msg
-
Protobuf type ShardHome
- ClusterShardingMessages.ShardHome.Builder - Class in akka.cluster.sharding.protobuf.msg
-
Protobuf type ShardHome
- ClusterShardingMessages.ShardHomeAllocated - Class in akka.cluster.sharding.protobuf.msg
-
Protobuf type ShardHomeAllocated
- ClusterShardingMessages.ShardHomeAllocated.Builder - Class in akka.cluster.sharding.protobuf.msg
-
Protobuf type ShardHomeAllocated
- ClusterShardingMessages.ShardHomeAllocatedOrBuilder - Interface in akka.cluster.sharding.protobuf.msg
-
- ClusterShardingMessages.ShardHomeOrBuilder - Interface in akka.cluster.sharding.protobuf.msg
-
- ClusterShardingMessages.ShardIdMessage - Class in akka.cluster.sharding.protobuf.msg
-
Protobuf type ShardIdMessage
- ClusterShardingMessages.ShardIdMessage.Builder - Class in akka.cluster.sharding.protobuf.msg
-
Protobuf type ShardIdMessage
- ClusterShardingMessages.ShardIdMessageOrBuilder - Interface in akka.cluster.sharding.protobuf.msg
-
- ClusterShardingMessages.ShardStats - Class in akka.cluster.sharding.protobuf.msg
-
Protobuf type ShardStats
- ClusterShardingMessages.ShardStats.Builder - Class in akka.cluster.sharding.protobuf.msg
-
Protobuf type ShardStats
- ClusterShardingMessages.ShardStatsOrBuilder - Interface in akka.cluster.sharding.protobuf.msg
-
- ClusterShardingMessageSerializer - Class in akka.cluster.sharding.protobuf
-
INTERNAL API: Protobuf serializer of ClusterSharding messages.
- ClusterShardingMessageSerializer(ExtendedActorSystem) - Constructor for class akka.cluster.sharding.protobuf.ClusterShardingMessageSerializer
-
- ClusterShardingSerializable - Interface in akka.cluster.sharding
-
Marker trait for remote messages and persistent events/snapshots with special serializer.
- ClusterShardingSettings - Class in akka.cluster.sharding
-
param: role specifies that this entity type requires cluster nodes with a specific role.
- ClusterShardingSettings(Option<String>, boolean, String, String, String, ClusterShardingSettings.TuningParameters, ClusterSingletonManagerSettings) - Constructor for class akka.cluster.sharding.ClusterShardingSettings
-
- ClusterShardingSettings$ - Class in akka.cluster.sharding
-
- ClusterShardingSettings$() - Constructor for class akka.cluster.sharding.ClusterShardingSettings$
-
- ClusterShardingSettings.TuningParameters - Class in akka.cluster.sharding
-
- ClusterShardingStats(Map<Address, ShardRegion.ShardRegionStats>) - Constructor for class akka.cluster.sharding.ShardRegion.ClusterShardingStats
-
- ClusterShardingStats$() - Constructor for class akka.cluster.sharding.ShardRegion.ClusterShardingStats$
-
- 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.Internal$ - Class in akka.cluster.singleton
-
INTERNAL API
- ClusterSingletonManager.Internal$.BecomingOldest - Class in akka.cluster.singleton
-
- ClusterSingletonManager.Internal$.BecomingOldestData - Class in akka.cluster.singleton
-
- ClusterSingletonManager.Internal$.Cleanup - Class in akka.cluster.singleton
-
- ClusterSingletonManager.Internal$.DelayedMemberRemoved - Class in akka.cluster.singleton
-
- ClusterSingletonManager.Internal$.End - Class in akka.cluster.singleton
-
- ClusterSingletonManager.Internal$.EndData - Class in akka.cluster.singleton
-
- ClusterSingletonManager.Internal$.HandingOver - Class in akka.cluster.singleton
-
- ClusterSingletonManager.Internal$.HandingOverData - Class in akka.cluster.singleton
-
- ClusterSingletonManager.Internal$.HandOverDone - Class in akka.cluster.singleton
-
Confirmation by the previous oldest that the singleton
actor has been terminated and the hand-over process is
completed.
- ClusterSingletonManager.Internal$.HandOverInProgress - Class in akka.cluster.singleton
-
Confirmation by the previous oldest that the hand
over process, shut down of the singleton actor, has
started.
- ClusterSingletonManager.Internal$.HandOverRetry - Class in akka.cluster.singleton
-
- ClusterSingletonManager.Internal$.HandOverToMe - Class in akka.cluster.singleton
-
Sent from new oldest to previous oldest to initiate the
hand-over process.
- ClusterSingletonManager.Internal$.Oldest - Class in akka.cluster.singleton
-
- ClusterSingletonManager.Internal$.OldestChangedBuffer - Class in akka.cluster.singleton
-
- ClusterSingletonManager.Internal$.OldestChangedBuffer.GetNext - Class in akka.cluster.singleton
-
Request to deliver one more event.
- ClusterSingletonManager.Internal$.OldestChangedBuffer.InitialOldestState - Class in akka.cluster.singleton
-
The first event, corresponding to CurrentClusterState.
- ClusterSingletonManager.Internal$.OldestChangedBuffer.OldestChanged - Class in akka.cluster.singleton
-
- ClusterSingletonManager.Internal$.OldestData - Class in akka.cluster.singleton
-
- ClusterSingletonManager.Internal$.Start - Class in akka.cluster.singleton
-
- ClusterSingletonManager.Internal$.StartOldestChangedBuffer - Class in akka.cluster.singleton
-
- ClusterSingletonManager.Internal$.Stopping - Class in akka.cluster.singleton
-
- ClusterSingletonManager.Internal$.StoppingData - Class in akka.cluster.singleton
-
- ClusterSingletonManager.Internal$.TakeOver - Class in akka.cluster.singleton
-
- ClusterSingletonManager.Internal$.TakeOverFromMe - Class in akka.cluster.singleton
-
Sent from from previous oldest to new oldest to
initiate the normal hand-over process.
- ClusterSingletonManager.Internal$.TakeOverRetry - Class in akka.cluster.singleton
-
- ClusterSingletonManager.Internal$.Uninitialized - Class in akka.cluster.singleton
-
- ClusterSingletonManager.Internal$.WasOldest - Class in akka.cluster.singleton
-
- ClusterSingletonManager.Internal$.WasOldestData - Class in akka.cluster.singleton
-
- ClusterSingletonManager.Internal$.Younger - Class in akka.cluster.singleton
-
- ClusterSingletonManager.Internal$.YoungerData - Class in akka.cluster.singleton
-
- 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>, FiniteDuration, FiniteDuration) - Constructor for class akka.cluster.singleton.ClusterSingletonManagerSettings
-
- ClusterSingletonManagerSettings$ - Class in akka.cluster.singleton
-
- ClusterSingletonManagerSettings$() - Constructor for class akka.cluster.singleton.ClusterSingletonManagerSettings$
-
- ClusterSingletonMessage - Interface in akka.cluster.singleton
-
Marker trait for remote messages with special serializer.
- ClusterSingletonMessageSerializer - Class in akka.cluster.singleton.protobuf
-
INTERNAL API: Serializer of ClusterSingleton messages.
- ClusterSingletonMessageSerializer(ExtendedActorSystem) - Constructor for class akka.cluster.singleton.protobuf.ClusterSingletonMessageSerializer
-
- 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
-
- ClusterSingletonProxySettings(String, Option<String>, FiniteDuration, int) - 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
-
- code() - Method in class akka.remote.artery.FlightRecorderReader.CompactEntry
-
- code() - Method in class akka.remote.artery.FlightRecorderReader.RichEntry
-
- codec() - Method in class akka.remote.EndpointActor
-
- codec() - Static method in class akka.remote.EndpointReader
-
- codec() - Static method in class akka.remote.EndpointWriter
-
- 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.
- Collect<In,Out> - Class in akka.stream.impl.fusing
-
- Collect(PartialFunction<In, Out>) - Constructor for class akka.stream.impl.fusing.Collect
-
- collect() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- collect(PartialFunction<Out, T>) - Static method in class akka.stream.impl.SubFlowImpl
-
- collect(PartialFunction<Out, T>) - Method in class akka.stream.javadsl.Flow
-
Transform this stream by applying the given partial function to each of the elements
on which the function is defined as they pass through this processing step.
- collect(PartialFunction<Out, T>) - Method in class akka.stream.javadsl.Source
-
Transform this stream by applying the given partial function to each of the elements
on which the function is defined as they pass through this processing step.
- collect(PartialFunction<Out, T>) - Method in class akka.stream.javadsl.SubFlow
-
Transform this stream by applying the given partial function to each of the elements
on which the function is defined as they pass through this processing step.
- collect(PartialFunction<Out, T>) - Method in class akka.stream.javadsl.SubSource
-
Transform this stream by applying the given partial function to each of the elements
on which the function is defined as they pass through this processing step.
- collect(PartialFunction<Out, T>) - Static method in class akka.stream.scaladsl.Flow
-
- collect(PartialFunction<Out, T>) - Method in interface akka.stream.scaladsl.FlowOps
-
Transform this stream by applying the given partial function to each of the elements
on which the function is defined as they pass through this processing step.
- collect(PartialFunction<Out, T>) - Static method in class akka.stream.scaladsl.Source
-
- collect(PartialFunction<A, B>) - Static method in class akka.util.ByteIterator
-
- collect(PartialFunction<A, B>, CanBuildFrom<Repr, B, That>) - Static method in class akka.util.ByteString
-
- collect(PartialFunction<A, B>, CanBuildFrom<Repr, B, That>) - Static method in class akka.util.CompactByteString
-
- Collect$ - Class in akka.stream.impl.fusing
-
- Collect$() - Constructor for class akka.stream.impl.fusing.Collect$
-
- collectDelta(Map<Address, Object>) - Method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- collectFirst(PartialFunction<A, B>) - Static method in class akka.util.ByteIterator
-
- collectFirst(PartialFunction<A, B>) - Static method in class akka.util.ByteString
-
- collectFirst(PartialFunction<A, B>) - Static method in class akka.util.CompactByteString
-
- 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.
- collector() - Method in class akka.stream.impl.CollectorState
-
INTERNAL API
- collector() - Method in class akka.stream.impl.ReducerState
-
INTERNAL API
- 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
-
- CollectorState<T,R> - Class in akka.stream.impl
-
- CollectorState(Collector<T, Object, R>) - Constructor for class akka.stream.impl.CollectorState
-
- com.typesafe.sslconfig.akka - package com.typesafe.sslconfig.akka
-
- com.typesafe.sslconfig.akka.util - package com.typesafe.sslconfig.akka.util
-
- combinations(int) - Static method in class akka.util.ByteString
-
- combinations(int) - Static method in class akka.util.CompactByteString
-
- Combine(Function2<Object, Object, Object>, StreamLayout.MaterializedValueNode, StreamLayout.MaterializedValueNode) - Constructor for class akka.stream.impl.StreamLayout.Combine
-
- combine(Sink<U, ?>, Sink<U, ?>, List<Sink<U, ?>>, Function<Integer, Graph<UniformFanOutShape<T, U>, NotUsed>>) - Method in class akka.stream.javadsl.Sink$
-
Combine several sinks with fan-out strategy like Broadcast
or Balance
and returns Sink
.
- combine(Sink<U, ?>, Sink<U, ?>, List<Sink<U, ?>>, Function<Integer, Graph<UniformFanOutShape<T, U>, NotUsed>>) - Static method in class akka.stream.javadsl.Sink
-
Combine several sinks with fan-out strategy like Broadcast
or Balance
and returns Sink
.
- combine(Source<T, ?>, Source<T, ?>, List<Source<T, ?>>, Function<Integer, ? extends Graph<UniformFanInShape<T, U>, NotUsed>>) - Method in class akka.stream.javadsl.Source$
-
Combines several sources with fan-in strategy like Merge
or Concat
and returns Source
.
- combine(Source<T, ?>, Source<T, ?>, List<Source<T, ?>>, Function<Integer, ? extends Graph<UniformFanInShape<T, U>, NotUsed>>) - Static method in class akka.stream.javadsl.Source
-
Combines several sources with fan-in strategy like Merge
or Concat
and returns Source
.
- combine(Sink<U, ?>, Sink<U, ?>, Seq<Sink<U, ?>>, Function1<Object, Graph<UniformFanOutShape<T, U>, NotUsed>>) - Method in class akka.stream.scaladsl.Sink$
-
Combine several sinks with fan-out strategy like Broadcast
or Balance
and returns Sink
.
- combine(Sink<U, ?>, Sink<U, ?>, Seq<Sink<U, ?>>, Function1<Object, Graph<UniformFanOutShape<T, U>, NotUsed>>) - Static method in class akka.stream.scaladsl.Sink
-
Combine several sinks with fan-out strategy like Broadcast
or Balance
and returns Sink
.
- combine(Source<T, ?>, Source<T, ?>, Seq<Source<T, ?>>, Function1<Object, Graph<UniformFanInShape<T, U>, NotUsed>>) - Method in class akka.stream.scaladsl.Source$
-
Combines several sources with fun-in strategy like Merge
or Concat
and returns Source
.
- combine(Source<T, ?>, Source<T, ?>, Seq<Source<T, ?>>, Function1<Object, Graph<UniformFanInShape<T, U>, NotUsed>>) - Method in class akka.stream.scaladsl.Source
-
Combines several sources with fun-in strategy like Merge
or Concat
and returns Source
.
- Combine$() - Constructor for class akka.stream.impl.StreamLayout.Combine$
-
- combinedDecorator() - Method in interface akka.contrib.pattern.ReceivePipeline
-
- CombinedReadEventAdapter(Seq<EventAdapter>) - Constructor for class akka.persistence.journal.EventAdapters.CombinedReadEventAdapter
-
- CombinedReadEventAdapter$() - Constructor for class akka.persistence.journal.EventAdapters.CombinedReadEventAdapter$
-
- combineKeyLength(byte, int) - Method in class akka.remote.artery.RemoteInstruments$
-
- combineKeyLength(byte, int) - Static method in class akka.remote.artery.RemoteInstruments
-
- Comma() - Method in class akka.stream.impl.JsonObjectParser$
-
- Comma() - Static method in class akka.stream.impl.JsonObjectParser
-
- command() - Method in class akka.io.SelectionHandler.Retry
-
- command(TaskRunner.Command) - Method in class akka.remote.artery.TaskRunner
-
- command() - Method in class akka.stream.impl.fusing.SubSink.CommandScheduledBeforeMaterialization
-
- 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
-
- CommandQueue() - Constructor for class akka.remote.artery.TaskRunner.CommandQueue
-
- CommandScheduledBeforeMaterialization(SubSink.Command) - Constructor for class akka.stream.impl.fusing.SubSink.CommandScheduledBeforeMaterialization
-
- COMMANDTYPE_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AkkaControlMessage
-
- CommitEntrySize() - Method in class akka.remote.artery.RollingEventLogSection$
-
- CommitEntrySize() - Static method in class akka.remote.artery.RollingEventLogSection
-
- committed() - Method in class akka.cluster.metrics.StandardMetrics.HeapMemory
-
- committed() - Method in class akka.cluster.StandardMetrics.HeapMemory
-
Deprecated.
- Committed() - Method in class akka.remote.artery.RollingEventLogSection$
-
- Committed() - Static method in class akka.remote.artery.RollingEventLogSection
-
- 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
- commonStateHandling() - Method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- 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$
-
- compactEntries() - Method in class akka.remote.artery.FlightRecorderReader.Log
-
- CompactEntry(Instant, boolean, long, long) - Constructor for class akka.remote.artery.FlightRecorderReader.CompactEntry
-
- CompactEntry$() - Constructor for class akka.remote.artery.FlightRecorderReader.CompactEntry$
-
- CompactionThreshold() - Method in class akka.stream.impl.io.ByteStringParser$
-
- CompactionThreshold() - Static method in class akka.stream.impl.io.ByteStringParser
-
- companion() - Static method in class akka.util.ByteString
-
- companion() - Static method in class akka.util.CompactByteString
-
- Companion$() - Constructor for class akka.util.ByteString.Companion$
-
- compare(ReplicatorMessages.OtherMessage, ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.OtherMessageComparator$
-
- compare(ReplicatorMessages.OtherMessage, ReplicatorMessages.OtherMessage) - Static method in class akka.cluster.ddata.protobuf.OtherMessageComparator
-
- 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(Sequence) - Method in class akka.persistence.query.Sequence
-
- compare(TimeBasedUUID) - Method in class akka.persistence.query.TimeBasedUUID
-
- compare(SeqNo) - Method in class akka.remote.SeqNo
-
- compare(UniqueAddress) - Method in class akka.remote.UniqueAddress
-
- compare(ByteString, ByteString) - Method in class akka.util.ByteString.ByteStrings$
-
- compare(PriorityQueueStabilizer.WrappedElement<E>, PriorityQueueStabilizer.WrappedElement<E>) - Method in class akka.util.PriorityQueueStabilizer.WrappedElementComparator
-
- compareAndSet(V, V) - Static method in class akka.remote.artery.FlightRecorder
-
- compareAndSet(V, V) - Static method in class akka.stream.impl.VirtualProcessor
-
- compareAndSet(V, V) - Static method in class akka.util.SerializedSuspendableExecutionContext
-
- compareAndSetForkJoinTaskTag(short, short) - Static method in class akka.dispatch.Mailbox
-
- CompareBy2ndValue() - Method in class akka.remote.artery.compress.CompressionTable$
-
- compareBy2ndValue() - Method in class akka.remote.artery.compress.CompressionTable$
-
- CompareBy2ndValue() - Static method in class akka.remote.artery.compress.CompressionTable
-
- compareBy2ndValue() - Static method in class akka.remote.artery.compress.CompressionTable
-
- 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(ActorRef, ActorRef) - Static method in class akka.event.EventStream
-
- 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(ActorRef) - Static method in class akka.actor.DeadLetterActorRef
-
- compareTo(ActorRef) - Static method in class akka.actor.Nobody
-
- compareTo(ActorPath) - Method in class akka.actor.RootActorPath
-
- compareTo(VersionVector) - Static method in class akka.cluster.ddata.ManyVersionVector
-
- compareTo(VersionVector) - Static method in class akka.cluster.ddata.OneVersionVector
-
- compareTo(VersionVector) - Method in class akka.cluster.ddata.VersionVector
-
Compare two version vectors.
- compareTo(A) - Static method in class akka.cluster.UniqueAddress
-
- compareTo(VectorClock) - Method in class akka.cluster.VectorClock
-
Compare two vector clocks.
- compareTo(ActorRef) - Static method in class akka.pattern.PromiseActorRef
-
- compareTo(A) - Static method in class akka.persistence.query.Sequence
-
- compareTo(A) - Static method in class akka.persistence.query.TimeBasedUUID
-
- compareTo(A) - Static method in class akka.remote.SeqNo
-
- compareTo(A) - Static method in class akka.remote.UniqueAddress
-
- compareTo(ActorRef) - Static method in class akka.testkit.TestActorRef
-
- compareTo(ActorRef) - Static method in class akka.testkit.TestFSMRef
-
- compareTo(ActorRef<Nothing$>) - Method in class akka.typed.ActorRef
-
Comparison takes path and the unique id of the actor cell into account.
- compareTo(ActorRef<Nothing$>) - Static method in class akka.typed.adapter.ActorRefAdapter
-
- compareTo(ActorRef<Nothing$>) - Static method in class akka.typed.adapter.ActorSystemAdapter
-
- compareTo(ActorRef<Nothing$>) - Static method in class akka.typed.internal.ActorSystemImpl
-
- compareTo(ActorRef<Nothing$>) - Static method in class akka.typed.internal.BlackholeActorRef
-
- compareTo(ActorRef<Nothing$>) - Static method in class akka.typed.internal.FutureRef
-
- compareTo(ActorRef<Nothing$>) - Static method in class akka.typed.internal.WatchableRef
-
- compile() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- compile() - Static method in class akka.persistence.journal.JournalSpec
-
- compile() - Method in class akka.persistence.PluginSpec
-
- compile() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- complete(V) - Static method in class akka.dispatch.Mailbox
-
- complete() - Method in class akka.stream.impl.FanOut.OutputBunch
-
- complete(int) - Method in class akka.stream.impl.FanOut.OutputBunch
-
- complete() - Method in class akka.stream.impl.FanoutOutputs
-
- complete(GraphInterpreter.Connection) - Method in class akka.stream.impl.fusing.GraphInterpreter
-
- complete() - Method in interface akka.stream.impl.Outputs
-
- complete() - Method in class akka.stream.impl.SimpleOutputs
-
- complete() - Method in class akka.stream.impl.SourceQueueAdapter
-
- complete() - Method in interface akka.stream.javadsl.SourceQueueWithComplete
-
Complete the stream normally.
- complete() - Method in interface akka.stream.scaladsl.SourceQueueWithComplete
-
Complete the stream normally.
- complete(Outlet<T>) - Method in class akka.stream.stage.GraphStageLogic
-
Signals that there will be no more elements emitted on the given port.
- complete() - Method in class akka.stream.stage.GraphStageLogic.SubSourceOutlet
-
Complete this output port.
- complete() - Static method in class akka.testkit.CustomEventFilter
-
- complete() - Static method in class akka.testkit.DeadLettersFilter
-
- 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
- completeConnect(ChannelRegistration, ActorRef, Traversable<Inet.SocketOption>) - Static method in class akka.io.TcpOutgoingConnection
-
- completed() - Method in class akka.remote.artery.ArteryTransport.InboundStreamMatValues
-
- completed() - Method in class akka.remote.artery.Association.OutboundStreamMatValues
-
- Completed() - Constructor for class akka.stream.actor.ActorPublisher.Internal$.Completed
-
- completed() - Method in class akka.stream.impl.BatchingInputBuffer
-
- Completed - Class in akka.stream.impl
-
INTERNAL API
- Completed() - Constructor for class akka.stream.impl.Completed
-
- Completed() - Method in class akka.stream.impl.FanIn$
-
- Completed() - Static method in class akka.stream.impl.FanIn
-
- Completed$ - Class in akka.stream.impl
-
INTERNAL API
- Completed$() - Constructor for class akka.stream.impl.Completed$
-
- Completed$() - Constructor for class akka.stream.impl.SubscriberManagement.Completed$
-
- completeDownstream() - Method in interface akka.stream.impl.SubscriberManagement
-
this method must be called by the implementing class whenever
it has been determined that no more elements will be produced
- completedPhase() - Method in class akka.stream.impl.ActorProcessorImpl
-
- completedPhase() - Method in class akka.stream.impl.FanIn
-
- completedPhase() - Method in class akka.stream.impl.FanOut
-
- completedPhase() - Static method in class akka.stream.impl.FanoutProcessorImpl
-
- completedPhase() - Method in class akka.stream.impl.io.TLSActor
-
- completedPhase() - Method in interface akka.stream.impl.Pump
-
- completedPhase() - Static method in class akka.stream.impl.Unzip
-
- CompletedSubscription(Subscriber<T>) - Constructor for class akka.stream.testkit.StreamTestKit.CompletedSubscription
-
- CompletedSubscription$() - Constructor for class akka.stream.testkit.StreamTestKit.CompletedSubscription$
-
- completeExceptionally(Throwable) - Static method in class akka.dispatch.Mailbox
-
- completeHandshake(UniqueAddress) - Method in class akka.remote.artery.ArteryTransport
-
- completeHandshake(UniqueAddress) - Method in class akka.remote.artery.Association
-
- completeHandshake(UniqueAddress) - Method in interface akka.remote.artery.InboundContext
-
- completeOrFlush() - Method in class akka.stream.impl.io.TLSActor
-
- completeStage() - Method in class akka.stream.stage.GraphStageLogic
-
Automatically invokes cancel()
or complete()
on all the input or output ports that have been called,
then marks the stage as stopped.
- completeSubstream() - Method in class akka.stream.impl.fusing.SubSource
-
- CompleteThenStop() - Constructor for class akka.stream.actor.ActorPublisher.Internal$.CompleteThenStop
-
- completion() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- Completion(FiniteDuration) - Constructor for class akka.stream.impl.Timers.Completion
-
- Completion$() - Constructor for class akka.stream.impl.QueueSource.Completion$
-
- completionTimeout(FiniteDuration) - Static method in class akka.stream.impl.SubFlowImpl
-
- completionTimeout(FiniteDuration) - Method in class akka.stream.javadsl.Flow
-
If the completion of the stream does not happen until the provided timeout, the stream is failed
with a TimeoutException
.
- completionTimeout(FiniteDuration) - Method in class akka.stream.javadsl.Source
-
If the completion of the stream does not happen until the provided timeout, the stream is failed
with a TimeoutException
.
- completionTimeout(FiniteDuration) - Method in class akka.stream.javadsl.SubFlow
-
If the completion of the stream does not happen until the provided timeout, the stream is failed
with a TimeoutException
.
- completionTimeout(FiniteDuration) - Method in class akka.stream.javadsl.SubSource
-
If the completion of the stream does not happen until the provided timeout, the stream is failed
with a TimeoutException
.
- completionTimeout(FiniteDuration) - Static method in class akka.stream.scaladsl.Flow
-
- completionTimeout(FiniteDuration) - Method in interface akka.stream.scaladsl.FlowOps
-
If the completion of the stream does not happen until the provided timeout, the stream is failed
with a scala.concurrent.TimeoutException
.
- completionTimeout(FiniteDuration) - Static method in class akka.stream.scaladsl.Source
-
- compose(Function1<A, T1>) - Static method in class akka.event.LoggingReceive
-
- compose(Function1<A, T1>) - Static method in class akka.japi.JavaPartialFunction
-
- compose(Function1<A, T1>) - Static method in class akka.japi.pf.CaseStatement
-
- compose(StreamLayout.Module) - Static method in class akka.stream.impl.fusing.GraphModule
-
- compose(StreamLayout.Module, Function2<A, B, C>) - Static method in class akka.stream.impl.fusing.GraphModule
-
- compose(StreamLayout.Module) - Static method in class akka.stream.impl.fusing.GraphStageModule
-
- compose(StreamLayout.Module, Function2<A, B, C>) - Static method in class akka.stream.impl.fusing.GraphStageModule
-
- compose(StreamLayout.Module) - Static method in class akka.stream.impl.io.TlsModule
-
- compose(StreamLayout.Module, Function2<A, B, C>) - Static method in class akka.stream.impl.io.TlsModule
-
- compose(StreamLayout.Module) - Static method in class akka.stream.impl.ProcessorModule
-
- compose(StreamLayout.Module, Function2<A, B, C>) - Static method in class akka.stream.impl.ProcessorModule
-
- compose(StreamLayout.Module) - Method in class akka.stream.impl.StreamLayout.EmptyModule$
-
- compose(StreamLayout.Module, Function2<A, B, C>) - Method in class akka.stream.impl.StreamLayout.EmptyModule$
-
- compose(StreamLayout.Module) - Method in interface akka.stream.impl.StreamLayout.Module
-
Creates a new Module which is this
Module composed with that
Module.
- compose(StreamLayout.Module, Function2<A, B, C>) - Method in interface akka.stream.impl.StreamLayout.Module
-
Creates a new Module which is this
Module composed with that
Module,
using the given function f
to compose the materialized value of this
with
the materialized value of that
.
- compose(Function1<A, T1>) - Static method in class akka.util.ByteString
-
- compose(Function1<A, T1>) - Static method in class akka.util.CompactByteString
-
- composeNoMat(StreamLayout.Module) - Static method in class akka.stream.impl.fusing.GraphModule
-
- composeNoMat(StreamLayout.Module) - Static method in class akka.stream.impl.fusing.GraphStageModule
-
- composeNoMat(StreamLayout.Module) - Static method in class akka.stream.impl.io.TlsModule
-
- composeNoMat(StreamLayout.Module) - Static method in class akka.stream.impl.ProcessorModule
-
- composeNoMat(StreamLayout.Module) - Method in interface akka.stream.impl.StreamLayout.Module
-
Creates a new Module which is this
Module composed with that
Module.
- CompositeModule(Set<StreamLayout.Module>, Shape, Map<OutPort, InPort>, Map<InPort, OutPort>, StreamLayout.MaterializedValueNode, Attributes) - Constructor for class akka.stream.impl.StreamLayout.CompositeModule
-
- CompositeModule$() - Constructor for class akka.stream.impl.StreamLayout.CompositeModule$
-
- CompoundWrite(Tcp.SimpleWriteCommand, Tcp.WriteCommand) - Constructor for class akka.io.Tcp.CompoundWrite
-
- CompoundWrite$() - Constructor for class akka.io.Tcp.CompoundWrite$
-
- compress(MessageLite) - Static method in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer
-
- compress(MessageLite) - Method in interface akka.cluster.ddata.protobuf.SerializationSupport
-
- compress(MessageLite) - Method in class akka.cluster.metrics.protobuf.MessageSerializer
-
- compress(MessageLite) - Method in class akka.cluster.protobuf.ClusterMessageSerializer
-
- compress(T) - Method in class akka.remote.artery.compress.CompressionTable
-
- compress(ByteString) - Method in class akka.stream.impl.io.compression.Compressor
-
Compresses the given input and returns compressed data.
- compress(ByteString) - Method in class akka.stream.impl.io.compression.DeflateCompressor
-
- compressAndFinish(ByteString) - Method in class akka.stream.impl.io.compression.Compressor
-
Combines `compress` + `finish`
- compressAndFinish(ByteString) - Method in class akka.stream.impl.io.compression.DeflateCompressor
-
- compressAndFlush(ByteString) - Method in class akka.stream.impl.io.compression.Compressor
-
Combines `compress` + `flush`
- compressAndFlush(ByteString) - Method in class akka.stream.impl.io.compression.DeflateCompressor
-
- Compression() - Method in class akka.remote.artery.ArterySettings.Advanced$
-
- Compression(Config) - Constructor for class akka.remote.artery.ArterySettings.Compression
-
- Compression - Class in akka.stream.javadsl
-
- Compression() - Constructor for class akka.stream.javadsl.Compression
-
- Compression - Class in akka.stream.scaladsl
-
- Compression() - Constructor for class akka.stream.scaladsl.Compression
-
- Compression$() - Constructor for class akka.remote.artery.ArterySettings.Compression$
-
- Compression$ - Class in akka.stream.javadsl
-
- Compression$() - Constructor for class akka.stream.javadsl.Compression$
-
- Compression$ - Class in akka.stream.scaladsl
-
- Compression$() - Constructor for class akka.stream.scaladsl.Compression$
-
- Compression_AllocatedActorRefCompressionId() - Method in class akka.remote.artery.FlightRecorderEvents$
-
- Compression_AllocatedActorRefCompressionId() - Static method in class akka.remote.artery.FlightRecorderEvents
-
- Compression_AllocatedManifestCompressionId() - Method in class akka.remote.artery.FlightRecorderEvents$
-
- Compression_AllocatedManifestCompressionId() - Static method in class akka.remote.artery.FlightRecorderEvents
-
- Compression_CompressedActorRef() - Method in class akka.remote.artery.FlightRecorderEvents$
-
- Compression_CompressedActorRef() - Static method in class akka.remote.artery.FlightRecorderEvents
-
- Compression_CompressedManifest() - Method in class akka.remote.artery.FlightRecorderEvents$
-
- Compression_CompressedManifest() - Static method in class akka.remote.artery.FlightRecorderEvents
-
- Compression_Inbound_RunActorRefAdvertisement() - Method in class akka.remote.artery.FlightRecorderEvents$
-
- Compression_Inbound_RunActorRefAdvertisement() - Static method in class akka.remote.artery.FlightRecorderEvents
-
- Compression_Inbound_RunClassManifestAdvertisement() - Method in class akka.remote.artery.FlightRecorderEvents$
-
- Compression_Inbound_RunClassManifestAdvertisement() - Static method in class akka.remote.artery.FlightRecorderEvents
-
- CompressionProtocol - Class in akka.remote.artery.compress
-
INTERNAL API
- CompressionProtocol() - Constructor for class akka.remote.artery.compress.CompressionProtocol
-
- CompressionProtocol$ - Class in akka.remote.artery.compress
-
INTERNAL API
- CompressionProtocol$() - Constructor for class akka.remote.artery.compress.CompressionProtocol$
-
- CompressionProtocol.ActorRefCompressionAdvertisement - Class in akka.remote.artery.compress
-
INTERNAL API
Sent by the "receiving" node after allocating a compression id to a given
ActorRef
- CompressionProtocol.ActorRefCompressionAdvertisement$ - Class in akka.remote.artery.compress
-
- CompressionProtocol.ActorRefCompressionAdvertisementAck - Class in akka.remote.artery.compress
-
INTERNAL API
Sent by the "sending" node after receiving
CompressionProtocol.ActorRefCompressionAdvertisement
The advertisement is also confirmed by the first message using that table version,
but we need separate ack in case the sender is not using any of the refs in the advertised
table.
- CompressionProtocol.ActorRefCompressionAdvertisementAck$ - Class in akka.remote.artery.compress
-
- CompressionProtocol.ClassManifestCompressionAdvertisement - Class in akka.remote.artery.compress
-
INTERNAL API
Sent by the "receiving" node after allocating a compression id to a given class manifest
- CompressionProtocol.ClassManifestCompressionAdvertisement$ - Class in akka.remote.artery.compress
-
- CompressionProtocol.ClassManifestCompressionAdvertisementAck - Class in akka.remote.artery.compress
-
INTERNAL API
Sent by the "sending" node after receiving
CompressionProtocol.ClassManifestCompressionAdvertisement
The advertisement is also confirmed by the first message using that table version,
but we need separate ack in case the sender is not using any of the refs in the advertised
table.
- CompressionProtocol.ClassManifestCompressionAdvertisementAck$ - Class in akka.remote.artery.compress
-
- CompressionProtocol.CompressionAckMessage - Interface in akka.remote.artery.compress
-
INTERNAL API
- CompressionProtocol.CompressionAdvertisement<T> - Interface in akka.remote.artery.compress
-
INTERNAL API
- CompressionProtocol.CompressionMessage - Interface in akka.remote.artery.compress
-
INTERNAL API
- CompressionProtocol.Events$ - Class in akka.remote.artery.compress
-
INTERNAL API
- CompressionProtocol.Events$.Event - Interface in akka.remote.artery.compress
-
INTERNAL API
- CompressionProtocol.Events$.HeavyHitterDetected - Class in akka.remote.artery.compress
-
INTERNAL API
- CompressionProtocol.Events$.ReceivedActorRefCompressionTable - Class in akka.remote.artery.compress
-
INTERNAL API
- CompressionProtocol.Events$.ReceivedClassManifestCompressionTable - Class in akka.remote.artery.compress
-
INTERNAL API
- compressions() - Method in interface akka.remote.artery.Decoder.InboundCompressionAccessImpl
-
- CompressionTable<T> - Class in akka.remote.artery.compress
-
INTERNAL API: Versioned compression table to be advertised between systems
- CompressionTable(long, byte, Map<T, Object>) - Constructor for class akka.remote.artery.compress.CompressionTable
-
- CompressionTable$ - Class in akka.remote.artery.compress
-
INTERNAL API
- CompressionTable$() - Constructor for class akka.remote.artery.compress.CompressionTable$
-
- CompressionUtils - Class in akka.stream.impl.io.compression
-
INTERNAL API
- CompressionUtils() - Constructor for class akka.stream.impl.io.compression.CompressionUtils
-
- CompressionUtils$ - Class in akka.stream.impl.io.compression
-
INTERNAL API
- CompressionUtils$() - Constructor for class akka.stream.impl.io.compression.CompressionUtils$
-
- Compressor - Class in akka.stream.impl.io.compression
-
INTERNAL API
- Compressor() - Constructor for class akka.stream.impl.io.compression.Compressor
-
- compressorFlow(Function0<Compressor>) - Method in class akka.stream.impl.io.compression.CompressionUtils$
-
Creates a flow from a compressor constructor.
- compressorFlow(Function0<Compressor>) - Static method in class akka.stream.impl.io.compression.CompressionUtils
-
Creates a flow from a compressor constructor.
- compressWithBuffer(ByteString, byte[]) - Method in class akka.stream.impl.io.compression.DeflateCompressor
-
- compressWithBuffer(ByteString, byte[]) - Method in class akka.stream.impl.io.compression.GzipCompressor
-
- computation() - Method in class akka.stream.impl.fusing.GraphStages.MaterializedValueSource
-
- compute(String) - Method in class akka.remote.artery.ActorRefResolveCacheWithAddress
-
- compute(K) - Method in class akka.remote.artery.LruBoundedCache
-
- compute(ActorRef) - Method in class akka.remote.artery.SerializationFormatCache
-
- compute(K, BiFunction<? super K, ? super V, ? extends V>) - Static method in class akka.remote.security.provider.AkkaProvider
-
- compute(String) - Method in class akka.remote.serialization.ActorRefResolveCache
-
- computeIfAbsent(K, Function<? super K, ? extends V>) - Static method in class akka.remote.security.provider.AkkaProvider
-
- computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Static method in class akka.remote.security.provider.AkkaProvider
-
- concat() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- concat(Graph<SourceShape<U>, Mat2>) - Static method in class akka.stream.impl.SubFlowImpl
-
- Concat - Class in akka.stream.javadsl
-
Takes two streams and outputs an output stream formed from the two input streams
by consuming one stream first emitting all of its elements, then consuming the
second stream emitting all of its elements.
- Concat() - Constructor for class akka.stream.javadsl.Concat
-
- concat(Graph<SourceShape<T>, M>) - Method in class akka.stream.javadsl.Flow
-
Concatenate the given
Source
to this
Flow
, meaning that once this
Flow’s input is exhausted and all result elements have been generated,
the Source’s elements will be produced.
- concat(Graph<SourceShape<T>, M>) - Method in class akka.stream.javadsl.Source
-
Concatenate this
Source
with the given one, meaning that once current
is exhausted and all result elements have been generated,
the given source elements will be produced.
- concat(Graph<SourceShape<T>, M>) - Method in class akka.stream.javadsl.SubFlow
-
Concatenate the given
Source
to this
Flow
, meaning that once this
Flow’s input is exhausted and all result elements have been generated,
the Source’s elements will be produced.
- concat(Graph<SourceShape<T>, M>) - Method in class akka.stream.javadsl.SubSource
-
Concatenate the given
Source
to this
Flow
, meaning that once this
Flow’s input is exhausted and all result elements have been generated,
the Source’s elements will be produced.
- Concat<T> - Class in akka.stream.scaladsl
-
Takes multiple streams and outputs one stream formed from the input streams
by first emitting all of the elements from the first stream and then emitting
all of the elements from the second stream, etc.
- Concat(int) - Constructor for class akka.stream.scaladsl.Concat
-
- concat(Graph<SourceShape<U>, Mat2>) - Static method in class akka.stream.scaladsl.Flow
-
- concat(Graph<SourceShape<U>, Mat2>) - Method in interface akka.stream.scaladsl.FlowOps
-
Concatenate the given
Source
to this
Flow
, meaning that once this
Flow’s input is exhausted and all result elements have been generated,
the Source’s elements will be produced.
- concat(Graph<SourceShape<U>, Mat2>) - Static method in class akka.stream.scaladsl.Source
-
- concat(ByteString) - Method in class akka.util.ByteString
-
Java API: efficiently concatenate another ByteString.
- concat(ByteString) - Static method in class akka.util.CompactByteString
-
- Concat$ - Class in akka.stream.javadsl
-
Takes two streams and outputs an output stream formed from the two input streams
by consuming one stream first emitting all of its elements, then consuming the
second stream emitting all of its elements.
- Concat$() - Constructor for class akka.stream.javadsl.Concat$
-
- Concat$ - Class in akka.stream.scaladsl
-
- Concat$() - Constructor for class akka.stream.scaladsl.Concat$
-
- concatAll() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- concatGraph(Graph<SourceShape<U>, Mat2>) - Static method in class akka.stream.impl.SubFlowImpl
-
- concatGraph(Graph<SourceShape<U>, Mat2>) - Static method in class akka.stream.scaladsl.Flow
-
- concatGraph(Graph<SourceShape<U>, Mat2>) - Method in interface akka.stream.scaladsl.FlowOps
-
- concatGraph(Graph<SourceShape<U>, Mat2>) - Static method in class akka.stream.scaladsl.Source
-
- concatMat(Graph<SourceShape<T>, M>, Function2<Mat, M, M2>) - Method in class akka.stream.javadsl.Flow
-
Concatenate the given
Source
to this
Flow
, meaning that once this
Flow’s input is exhausted and all result elements have been generated,
the Source’s elements will be produced.
- concatMat(Graph<SourceShape<T>, M>, Function2<Mat, M, M2>) - Method in class akka.stream.javadsl.Source
-
Concatenate this
Source
with the given one, meaning that once current
is exhausted and all result elements have been generated,
the given source elements will be produced.
- concatMat(Graph<SourceShape<U>, Mat2>, Function2<Mat, Mat2, Mat3>) - Static method in class akka.stream.scaladsl.Flow
-
- concatMat(Graph<SourceShape<U>, Mat2>, Function2<Mat, Mat2, Mat3>) - Method in interface akka.stream.scaladsl.FlowOpsMat
-
Concatenate the given
Source
to this
Flow
, meaning that once this
Flow’s input is exhausted and all result elements have been generated,
the Source’s elements will be produced.
- concatMat(Graph<SourceShape<U>, Mat2>, Function2<Mat, Mat2, Mat3>) - Static method in class akka.stream.scaladsl.Source
-
- concatMatSource() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- concatSource() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- concatSubstreams() - Static method in class akka.stream.impl.SubFlowImpl
-
- concatSubstreams() - Method in class akka.stream.javadsl.SubFlow
-
Flatten the sub-flows back into the super-flow by concatenating them.
- concatSubstreams() - Method in class akka.stream.javadsl.SubSource
-
Flatten the sub-flows back into the super-source by concatenating them.
- concatSubstreams() - Method in interface akka.stream.scaladsl.SubFlow
-
Flatten the sub-flows back into the super-flow by concatenating them.
- Concurrent$() - Constructor for class akka.cluster.ddata.VersionVector.Concurrent$
-
- Concurrent$() - Constructor for class akka.cluster.VectorClock.Concurrent$
-
- ConcurrentInstance() - Method in class akka.cluster.ddata.VersionVector$
-
Java API: The VersionVector.Concurrent
instance
- ConcurrentInstance() - Static method in class akka.cluster.ddata.VersionVector
-
Java API: The VersionVector.Concurrent
instance
- 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
-
- conditionalTerminateInput(Function0<Object>) - Method in class akka.stream.stage.GraphStageLogic
-
Input handler that terminates the state upon receiving completion if the
given condition holds at that time.
- ConditionalTerminateInput(Function0<Object>) - Constructor for class akka.stream.stage.GraphStageLogic.ConditionalTerminateInput
-
- conditionalTerminateOutput(Function0<Object>) - Method in class akka.stream.stage.GraphStageLogic
-
Output handler that terminates the state upon receiving completion if the
given condition holds at that time.
- ConditionalTerminateOutput(Function0<Object>) - Constructor for class akka.stream.stage.GraphStageLogic.ConditionalTerminateOutput
-
- 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
-
- confidence() - Method in class akka.remote.artery.compress.CountMinSketch
-
- 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.BootstrapSetup
-
- 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() - Static method in class akka.dispatch.BalancingDispatcherConfigurator
-
- 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() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- config() - Method in class akka.persistence.journal.JournalSpec$
-
- config() - Static method in class akka.persistence.journal.JournalSpec
-
- config() - Method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- config() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
-
- config() - Method in class akka.persistence.journal.leveldb.SharedLeveldbStore
-
- config() - Method in class akka.persistence.Persistence.PluginHolder
-
- 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.artery.ArterySettings.Advanced$
-
- config() - Method in class akka.remote.artery.ArterySettings.Bind$
-
- config() - Method in class akka.remote.artery.ArterySettings.Canonical$
-
- config() - Method in class akka.remote.artery.ArterySettings.Compression.ActorRefs$
-
- config() - Method in class akka.remote.artery.ArterySettings.Compression.Manifests$
-
- 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(String) - Method in class akka.typed.internal.DispatchersImpl
-
INTERNAL API
- config() - Method in class akka.typed.internal.MessageDispatcherConfigurator
-
- config() - Method in class akka.typed.Settings
-
- config() - Method in class akka.util.Helpers.ConfigOps
-
- config() - Method in class com.typesafe.sslconfig.akka.AkkaSSLConfig
-
- CONFIG_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DeployData
-
- configFor(ActorRef) - Method in class akka.persistence.Persistence
-
INTERNAL API
Looks up the plugin config by plugin's ActorRef.
- ConfigOps(Config) - Constructor for class akka.util.Helpers.ConfigOps
-
- ConfigOps$() - Constructor for class akka.util.Helpers.ConfigOps$
-
- 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
-
- configurator() - Static method in class akka.testkit.CallingThreadDispatcher
-
- 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.
- configure(SSLEngine, SSLContext) - Method in class com.typesafe.sslconfig.akka.DefaultSSLEngineConfigurator
-
- configure(SSLEngine, SSLContext) - Method in interface com.typesafe.sslconfig.akka.SSLEngineConfigurator
-
- configureCipherSuites(String[], SSLConfigSettings) - Method in class com.typesafe.sslconfig.akka.AkkaSSLConfig
-
- configureDispatcher(Props) - Method in class akka.remote.RARP
-
- configureDispatcher(Props) - Method in class akka.remote.RemoteSettings
-
- configureExecutor() - Static method in class akka.dispatch.BalancingDispatcherConfigurator
-
- configureExecutor() - Method in class akka.dispatch.MessageDispatcherConfigurator
-
- configureExecutor() - Method in class akka.typed.internal.MessageDispatcherConfigurator
-
- configureProtocols(String[], SSLConfigSettings) - Method in class com.typesafe.sslconfig.akka.AkkaSSLConfig
-
- ConfigVersion() - Method in class akka.actor.ActorSystem.Settings
-
- confirmActorRefCompressionAdvertisement(long, byte) - Method in interface akka.remote.artery.compress.InboundCompressions
-
- confirmActorRefCompressionAdvertisement(long, byte) - Method in class akka.remote.artery.compress.InboundCompressionsImpl
-
- confirmActorRefCompressionAdvertisement(long, byte) - Method in class akka.remote.artery.compress.NoInboundCompressions$
-
- confirmActorRefCompressionAdvertisement(long, byte) - Static method in class akka.remote.artery.compress.NoInboundCompressions
-
- confirmActorRefCompressionAdvertisementAck(CompressionProtocol.ActorRefCompressionAdvertisementAck) - Method in interface akka.remote.artery.Decoder.InboundCompressionAccess
-
- confirmActorRefCompressionAdvertisementAck(CompressionProtocol.ActorRefCompressionAdvertisementAck) - Method in interface akka.remote.artery.Decoder.InboundCompressionAccessImpl
-
External call from ChangeInboundCompression materialized value
- confirmAdvertisement(byte) - Method in class akka.remote.artery.compress.InboundCompression
-
- confirmClassManifestCompressionAdvertisement(long, byte) - Method in interface akka.remote.artery.compress.InboundCompressions
-
- confirmClassManifestCompressionAdvertisement(long, byte) - Method in class akka.remote.artery.compress.InboundCompressionsImpl
-
- confirmClassManifestCompressionAdvertisement(long, byte) - Method in class akka.remote.artery.compress.NoInboundCompressions$
-
- confirmClassManifestCompressionAdvertisement(long, byte) - Static method in class akka.remote.artery.compress.NoInboundCompressions
-
- confirmClassManifestCompressionAdvertisementAck(CompressionProtocol.ClassManifestCompressionAdvertisementAck) - Method in interface akka.remote.artery.Decoder.InboundCompressionAccess
-
- confirmClassManifestCompressionAdvertisementAck(CompressionProtocol.ClassManifestCompressionAdvertisementAck) - Method in interface akka.remote.artery.Decoder.InboundCompressionAccessImpl
-
External call from ChangeInboundCompression materialized value
- confirmDelivery(long) - Method in interface akka.persistence.AtLeastOnceDeliveryLike
-
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$
-
- conflate() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- conflate(Function2<O2, O2, O2>) - Static method in class akka.stream.impl.SubFlowImpl
-
- conflate(Function2<O2, O2, O2>) - Method in class akka.stream.javadsl.Flow
-
Allows a faster upstream to progress independently of a slower subscriber by conflating elements into a summary
until the subscriber is ready to accept them.
- conflate(Function2<O2, O2, O2>) - Method in class akka.stream.javadsl.Source
-
Allows a faster upstream to progress independently of a slower subscriber by conflating elements into a summary
until the subscriber is ready to accept them.
- conflate(Function2<O2, O2, O2>) - Method in class akka.stream.javadsl.SubFlow
-
Allows a faster upstream to progress independently of a slower subscriber by conflating elements into a summary
until the subscriber is ready to accept them.
- conflate(Function2<O2, O2, O2>) - Method in class akka.stream.javadsl.SubSource
-
Allows a faster upstream to progress independently of a slower subscriber by conflating elements into a summary
until the subscriber is ready to accept them.
- conflate(Function2<O2, O2, O2>) - Static method in class akka.stream.scaladsl.Flow
-
- conflate(Function2<O2, O2, O2>) - Method in interface akka.stream.scaladsl.FlowOps
-
Allows a faster upstream to progress independently of a slower subscriber by conflating elements into a summary
until the subscriber is ready to accept them.
- conflate(Function2<O2, O2, O2>) - Static method in class akka.stream.scaladsl.Source
-
- conflateWithSeed(Function1<Out, S>, Function2<S, Out, S>) - Static method in class akka.stream.impl.SubFlowImpl
-
- conflateWithSeed(Function<Out, S>, Function2<S, Out, S>) - Method in class akka.stream.javadsl.Flow
-
Allows a faster upstream to progress independently of a slower subscriber by conflating elements into a summary
until the subscriber is ready to accept them.
- conflateWithSeed(Function<Out, S>, Function2<S, Out, S>) - Method in class akka.stream.javadsl.Source
-
Allows a faster upstream to progress independently of a slower subscriber by conflating elements into a summary
until the subscriber is ready to accept them.
- conflateWithSeed(Function<Out, S>, Function2<S, Out, S>) - Method in class akka.stream.javadsl.SubFlow
-
Allows a faster upstream to progress independently of a slower subscriber by conflating elements into a summary
until the subscriber is ready to accept them.
- conflateWithSeed(Function<Out, S>, Function2<S, Out, S>) - Method in class akka.stream.javadsl.SubSource
-
Allows a faster upstream to progress independently of a slower subscriber by conflating elements into a summary
until the subscriber is ready to accept them.
- conflateWithSeed(Function1<Out, S>, Function2<S, Out, S>) - Static method in class akka.stream.scaladsl.Flow
-
- conflateWithSeed(Function1<Out, S>, Function2<S, Out, S>) - Method in interface akka.stream.scaladsl.FlowOps
-
Allows a faster upstream to progress independently of a slower subscriber by conflating elements into a summary
until the subscriber is ready to accept them.
- conflateWithSeed(Function1<Out, S>, Function2<S, Out, S>) - Static method in class akka.stream.scaladsl.Source
-
- conforms() - Method in class akka.stream.impl.ConstantFun$
-
- conforms() - Static method in class akka.stream.impl.ConstantFun
-
- 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$
-
- connectCmd() - Method in class akka.stream.impl.io.TcpConnectionStage.Outbound
-
- Connected(InetSocketAddress, InetSocketAddress) - Constructor for class akka.io.Tcp.Connected
-
- connected(TcpConnection.ConnectionInfo) - Method in class akka.io.TcpConnection
-
normal connected state
- connected(TcpConnection.ConnectionInfo) - Static method in class akka.io.TcpOutgoingConnection
-
- 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
-
- Connection(int, int, GraphStageLogic, int, GraphStageLogic, InHandler, OutHandler) - Constructor for class akka.stream.impl.fusing.GraphInterpreter.Connection
-
- connection() - Method in class akka.stream.impl.io.TcpConnectionStage.Inbound
-
- connectionCount() - Method in class akka.stream.impl.fusing.GraphInterpreter.GraphAssembly
-
- ConnectionException - Exception in akka.stream
-
- ConnectionException(String) - Constructor for exception akka.stream.ConnectionException
-
- 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$
-
- connections() - Method in class akka.stream.impl.fusing.GraphInterpreter
-
- ConnectionSourceStage - Class in akka.stream.impl.io
-
INTERNAL API
- ConnectionSourceStage(ActorRef, InetSocketAddress, int, Traversable<Inet.SocketOption>, boolean, Duration, FiniteDuration) - Constructor for class akka.stream.impl.io.ConnectionSourceStage
-
- ConnectionSourceStage$ - Class in akka.stream.impl.io
-
- ConnectionSourceStage$() - Constructor for class akka.stream.impl.io.ConnectionSourceStage$
-
- 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
-
- connectTimeoutExpired(Option<FiniteDuration>) - Method in class akka.io.TcpOutgoingConnection$
-
- connectTimeoutExpired(Option<FiniteDuration>) - Static method in class akka.io.TcpOutgoingConnection
-
- consistency() - Method in class akka.cluster.ddata.Replicator.Delete
-
- consistency() - Method in class akka.cluster.ddata.Replicator.Get
-
- CONSISTENCY_FIELD_NUMBER - Static variable in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get
-
- 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$
-
- ConstantFun - Class in akka.stream.impl
-
- ConstantFun() - Constructor for class akka.stream.impl.ConstantFun
-
- ConstantFun$ - Class in akka.stream.impl
-
- ConstantFun$() - Constructor for class akka.stream.impl.ConstantFun$
-
- ConstantRateEntityRecoveryStrategy - Class in akka.cluster.sharding
-
- ConstantRateEntityRecoveryStrategy(ActorSystem, FiniteDuration, int) - Constructor for class akka.cluster.sharding.ConstantRateEntityRecoveryStrategy
-
- constantStrategy(ActorSystem, FiniteDuration, int) - Method in class akka.cluster.sharding.EntityRecoveryStrategy$
-
- construct(FanInShape.Init<O>) - Method in class akka.stream.FanInShape
-
- construct(FanInShape.Init<O>) - Method in class akka.stream.FanInShape10
-
- construct(FanInShape.Init<O>) - Method in class akka.stream.FanInShape11
-
- construct(FanInShape.Init<O>) - Method in class akka.stream.FanInShape12
-
- construct(FanInShape.Init<O>) - Method in class akka.stream.FanInShape13
-
- construct(FanInShape.Init<O>) - Method in class akka.stream.FanInShape14
-
- construct(FanInShape.Init<O>) - Method in class akka.stream.FanInShape15
-
- construct(FanInShape.Init<O>) - Method in class akka.stream.FanInShape16
-
- construct(FanInShape.Init<O>) - Method in class akka.stream.FanInShape17
-
- construct(FanInShape.Init<O>) - Method in class akka.stream.FanInShape18
-
- construct(FanInShape.Init<O>) - Method in class akka.stream.FanInShape19
-
- construct(FanInShape.Init<O>) - Method in class akka.stream.FanInShape1N
-
- construct(FanInShape.Init<O>) - Method in class akka.stream.FanInShape2
-
- construct(FanInShape.Init<O>) - Method in class akka.stream.FanInShape20
-
- construct(FanInShape.Init<O>) - Method in class akka.stream.FanInShape21
-
- construct(FanInShape.Init<O>) - Method in class akka.stream.FanInShape22
-
- construct(FanInShape.Init<O>) - Method in class akka.stream.FanInShape3
-
- construct(FanInShape.Init<O>) - Method in class akka.stream.FanInShape4
-
- construct(FanInShape.Init<O>) - Method in class akka.stream.FanInShape5
-
- construct(FanInShape.Init<O>) - Method in class akka.stream.FanInShape6
-
- construct(FanInShape.Init<O>) - Method in class akka.stream.FanInShape7
-
- construct(FanInShape.Init<O>) - Method in class akka.stream.FanInShape8
-
- construct(FanInShape.Init<O>) - Method in class akka.stream.FanInShape9
-
- construct(FanOutShape.Init<I>) - Method in class akka.stream.FanOutShape
-
- construct(FanOutShape.Init<I>) - Method in class akka.stream.FanOutShape10
-
- construct(FanOutShape.Init<I>) - Method in class akka.stream.FanOutShape11
-
- construct(FanOutShape.Init<I>) - Method in class akka.stream.FanOutShape12
-
- construct(FanOutShape.Init<I>) - Method in class akka.stream.FanOutShape13
-
- construct(FanOutShape.Init<I>) - Method in class akka.stream.FanOutShape14
-
- construct(FanOutShape.Init<I>) - Method in class akka.stream.FanOutShape15
-
- construct(FanOutShape.Init<I>) - Method in class akka.stream.FanOutShape16
-
- construct(FanOutShape.Init<I>) - Method in class akka.stream.FanOutShape17
-
- construct(FanOutShape.Init<I>) - Method in class akka.stream.FanOutShape18
-
- construct(FanOutShape.Init<I>) - Method in class akka.stream.FanOutShape19
-
- construct(FanOutShape.Init<I>) - Method in class akka.stream.FanOutShape2
-
- construct(FanOutShape.Init<I>) - Method in class akka.stream.FanOutShape20
-
- construct(FanOutShape.Init<I>) - Method in class akka.stream.FanOutShape21
-
- construct(FanOutShape.Init<I>) - Method in class akka.stream.FanOutShape22
-
- construct(FanOutShape.Init<I>) - Method in class akka.stream.FanOutShape3
-
- construct(FanOutShape.Init<I>) - Method in class akka.stream.FanOutShape4
-
- construct(FanOutShape.Init<I>) - Method in class akka.stream.FanOutShape5
-
- construct(FanOutShape.Init<I>) - Method in class akka.stream.FanOutShape6
-
- construct(FanOutShape.Init<I>) - Method in class akka.stream.FanOutShape7
-
- construct(FanOutShape.Init<I>) - Method in class akka.stream.FanOutShape8
-
- construct(FanOutShape.Init<I>) - Method in class akka.stream.FanOutShape9
-
- construct(FanInShape.Init<T>) - Method in class akka.stream.scaladsl.MergePreferred.MergePreferredShape
-
- construct(FanInShape.Init<O>) - Method in class akka.stream.UniformFanInShape
-
- construct(FanOutShape.Init<I>) - Method in class akka.stream.UniformFanOutShape
-
- 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, OptionVal<ActorRef>, Option<SeqNo>, Option<Ack>) - Method in interface akka.remote.transport.AkkaPduCodec
-
- constructMessage(Address, ActorRef, WireFormats.SerializedMessage, OptionVal<ActorRef>, Option<SeqNo>, Option<Ack>) - Method in class akka.remote.transport.AkkaPduProtobufCodec$
-
- constructMessage(Address, ActorRef, WireFormats.SerializedMessage, OptionVal<ActorRef>, Option<SeqNo>, Option<Ack>) - Static method in class akka.remote.transport.AkkaPduProtobufCodec
-
- constructMessage$default$5() - Static method in class akka.remote.transport.AkkaPduProtobufCodec
-
- constructMessage$default$6() - 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
-
- contactPaths() - Method in class akka.cluster.client.ClusterClient
-
- contactPathsPublished() - Method in class akka.cluster.client.ClusterClient
-
- contactPoint() - Method in class akka.cluster.client.ContactPointAdded
-
- contactPoint() - Method in interface akka.cluster.client.ContactPointChange
-
- contactPoint() - Method in class akka.cluster.client.ContactPointRemoved
-
- ContactPointAdded - Class in akka.cluster.client
-
Emitted to a subscriber when contact points have been
received by the ClusterClient and a new one has been added.
- ContactPointAdded(ActorPath) - Constructor for class akka.cluster.client.ContactPointAdded
-
- ContactPointAdded$ - Class in akka.cluster.client
-
- ContactPointAdded$() - Constructor for class akka.cluster.client.ContactPointAdded$
-
- ContactPointChange - Interface in akka.cluster.client
-
Declares a super type for all events emitted by the ClusterClient
in relation to contact points being added or removed.
- contactPointMessages() - Method in class akka.cluster.client.ClusterClient
-
- ContactPointRemoved - Class in akka.cluster.client
-
Emitted to a subscriber when contact points have been
received by the ClusterClient and a new one has been added.
- ContactPointRemoved(ActorPath) - Constructor for class akka.cluster.client.ContactPointRemoved
-
- ContactPointRemoved$ - Class in akka.cluster.client
-
- ContactPointRemoved$() - Constructor for class akka.cluster.client.ContactPointRemoved$
-
- contactPoints() - Method in class akka.cluster.client.ClusterReceptionist.Internal$.Contacts
-
- ContactPoints - Class in akka.cluster.client
-
The reply to
GetContactPoints
.
- ContactPoints(Set<ActorPath>) - Constructor for class akka.cluster.client.ContactPoints
-
- contactPoints() - Method in class akka.cluster.client.ContactPoints
-
- ContactPoints$ - Class in akka.cluster.client
-
- ContactPoints$() - Constructor for class akka.cluster.client.ContactPoints$
-
- CONTACTPOINTS_FIELD_NUMBER - Static variable in class akka.cluster.client.protobuf.msg.ClusterClientMessages.Contacts
-
- contacts() - Method in class akka.cluster.client.ClusterClient
-
- Contacts(IndexedSeq<String>) - Constructor for class akka.cluster.client.ClusterReceptionist.Internal$.Contacts
-
- contain() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- contain() - Static method in class akka.persistence.journal.JournalSpec
-
- contain() - Method in class akka.persistence.PluginSpec
-
- contain() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- ContainerFormats - Class in akka.remote
-
- ContainerFormats.ActorIdentity - Class in akka.remote
-
Protobuf type ActorIdentity
- ContainerFormats.ActorIdentity.Builder - Class in akka.remote
-
Protobuf type ActorIdentity
- ContainerFormats.ActorIdentityOrBuilder - Interface in akka.remote
-
- ContainerFormats.ActorInitializationException - Class in akka.remote
-
Protobuf type ActorInitializationException
- ContainerFormats.ActorInitializationException.Builder - Class in akka.remote
-
Protobuf type ActorInitializationException
- ContainerFormats.ActorInitializationExceptionOrBuilder - Interface in akka.remote
-
- ContainerFormats.ActorRef - Class in akka.remote
-
Protobuf type ActorRef
- ContainerFormats.ActorRef.Builder - Class in akka.remote
-
Protobuf type ActorRef
- ContainerFormats.ActorRefOrBuilder - Interface in akka.remote
-
- ContainerFormats.Identify - Class in akka.remote
-
Protobuf type Identify
- ContainerFormats.Identify.Builder - Class in akka.remote
-
Protobuf type Identify
- ContainerFormats.IdentifyOrBuilder - Interface in akka.remote
-
- ContainerFormats.Option - Class in akka.remote
-
Protobuf type Option
- ContainerFormats.Option.Builder - Class in akka.remote
-
Protobuf type Option
- ContainerFormats.OptionOrBuilder - Interface in akka.remote
-
- ContainerFormats.PatternType - Enum in akka.remote
-
Protobuf enum PatternType
- ContainerFormats.Payload - Class in akka.remote
-
Protobuf type Payload
- ContainerFormats.Payload.Builder - Class in akka.remote
-
Protobuf type Payload
- ContainerFormats.PayloadOrBuilder - Interface in akka.remote
-
- 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
-
- ContainerFormats.StackTraceElement - Class in akka.remote
-
Protobuf type StackTraceElement
- ContainerFormats.StackTraceElement.Builder - Class in akka.remote
-
Protobuf type StackTraceElement
- ContainerFormats.StackTraceElementOrBuilder - Interface in akka.remote
-
- ContainerFormats.Throwable - Class in akka.remote
-
Protobuf type Throwable
- ContainerFormats.Throwable.Builder - Class in akka.remote
-
Protobuf type Throwable
- ContainerFormats.ThrowableOrBuilder - Interface in akka.remote
-
- ContainerFormats.WatcherHeartbeatResponse - Class in akka.remote
-
Protobuf type WatcherHeartbeatResponse
- ContainerFormats.WatcherHeartbeatResponse.Builder - Class in akka.remote
-
Protobuf type WatcherHeartbeatResponse
- ContainerFormats.WatcherHeartbeatResponseOrBuilder - Interface in akka.remote
-
- contains(UniqueAddress) - Method in class akka.cluster.ClusterHeartbeatSenderState
-
- contains(A) - Method in class akka.cluster.ddata.GSet
-
- contains(String) - Method in class akka.cluster.ddata.LWWMap
-
- contains(UniqueAddress) - Method in class akka.cluster.ddata.ManyVersionVector
-
INTERNAL API
- contains(UniqueAddress) - Method in class akka.cluster.ddata.OneVersionVector
-
INTERNAL API
- contains(String) - Method in class akka.cluster.ddata.ORMap
-
- contains(String) - Method in class akka.cluster.ddata.ORMultiMap
-
- contains(A) - Method in class akka.cluster.ddata.ORSet
-
- contains(String) - Method in class akka.cluster.ddata.PNCounterMap
-
- contains(UniqueAddress) - Method in class akka.cluster.ddata.VersionVector
-
INTERNAL API
- contains(long) - Method in class akka.remote.artery.ImmutableLongMap
-
Worst case O(log n)
, allocation free.
- contains(Object) - Static method in class akka.remote.security.provider.AkkaProvider
-
- contains(Attributes.Attribute) - Method in class akka.stream.Attributes
-
Test whether the given attribute is contained within this attributes list.
- contains(Object) - Method in class akka.util.BoundedBlockingQueue
-
- contains(Object) - Static method in class akka.util.ByteIterator
-
- contains(A1) - Static method in class akka.util.ByteString
-
- contains(A1) - Static method in class akka.util.CompactByteString
-
- contains(I) - Method in class akka.util.MessageBufferMap
-
Check if the buffer map contains an id.
- containsAll(Collection<?>) - Method in class akka.util.BoundedBlockingQueue
-
- containsKey(Object) - Static method in class akka.remote.security.provider.AkkaProvider
-
- containsSlice(GenSeq<B>) - Static method in class akka.util.ByteString
-
- containsSlice(GenSeq<B>) - Static method in class akka.util.CompactByteString
-
- containsValue(Object) - Static method in class akka.remote.security.provider.AkkaProvider
-
- 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 class akka.actor.AbstractActor
-
- context() - Method in class akka.actor.AbstractFSM
-
- context() - Method in interface akka.actor.Actor
-
Stores the context for this actor, including self, and sender.
- context() - Method in class akka.actor.dsl.Inbox.InboxActor
-
- context() - Method in class akka.actor.Props.EmptyActor
-
- context() - Method in interface akka.actor.StashSupport
-
- context() - Method in class akka.actor.TypedActor$
-
Returns the ActorContext (for a TypedActor) when inside a method call in a TypedActor.
- context() - Static method in class akka.actor.TypedActor
-
Returns the ActorContext (for a TypedActor) when inside a method call in a TypedActor.
- context() - Method in class akka.actor.TypedActor.TypedActor
-
- context() - Method in class akka.actor.UntypedActor
-
- context() - Method in interface akka.camel.Camel
-
Underlying camel context.
- context() - Method in class akka.camel.internal.ActivationTracker
-
- context() - Method in class akka.camel.internal.CamelSupervisor
-
- context() - Method in class akka.camel.internal.ConsumerRegistrar
-
- context() - Method in class akka.camel.internal.DefaultCamel
-
- context() - Method in class akka.camel.internal.ProducerRegistrar
-
- context() - Method in class akka.camel.internal.Registry
-
- context() - Method in class akka.camel.ProducerSupport.ProducerChild
-
- context() - Static method in class akka.cluster.AutoDown
-
- context() - Method in class akka.cluster.AutoDownBase
-
- context() - Method in class akka.cluster.client.ClusterClient
-
- context() - Method in class akka.cluster.client.ClusterReceptionist
-
- context() - Method in class akka.cluster.client.ClusterReceptionist.Internal$.ClientResponseTunnel
-
- context() - Method in class akka.cluster.ClusterCoreDaemon
-
- context() - Method in class akka.cluster.ClusterCoreSupervisor
-
- context() - Method in class akka.cluster.ClusterDaemon
-
- context() - Method in class akka.cluster.ClusterDomainEventPublisher
-
- context() - Method in class akka.cluster.ClusterHeartbeatReceiver
-
- context() - Method in class akka.cluster.ClusterHeartbeatSender
-
- context() - Method in class akka.cluster.ClusterMetricsCollector
-
- context() - Static method in class akka.cluster.ClusterRemoteWatcher
-
- context() - Method in class akka.cluster.ddata.LmdbDurableStore
-
- context() - Static method in class akka.cluster.ddata.ReadAggregator
-
- context() - Method in class akka.cluster.ddata.ReadWriteAggregator
-
- context() - Method in class akka.cluster.ddata.Replicator
-
- context() - Static method in class akka.cluster.ddata.WriteAggregator
-
- context() - Method in class akka.cluster.FirstSeedNodeProcess
-
- context() - Method in class akka.cluster.JoinSeedNodeProcess
-
- context() - Method in class akka.cluster.metrics.AdaptiveLoadBalancingMetricsListener
-
- context() - Method in class akka.cluster.metrics.ClusterMetricsCollector
-
- context() - Method in class akka.cluster.metrics.ClusterMetricsSupervisor
-
- context() - Method in class akka.cluster.OnMemberStatusChangedListener
-
- context() - Method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- context() - Method in class akka.cluster.pubsub.DistributedPubSubMediator.Internal$.Group
-
- context() - Method in class akka.cluster.pubsub.DistributedPubSubMediator.Internal$.Topic
-
- context() - Method in class akka.cluster.routing.AdaptiveLoadBalancingMetricsListener
-
- context() - Method in class akka.cluster.sharding.ClusterShardingGuardian
-
- context() - Method in class akka.cluster.sharding.RemoveInternalClusterShardingData
-
- context() - Method in class akka.cluster.sharding.RemoveInternalClusterShardingData.RemoveOnePersistenceId
-
- context() - Method in class akka.cluster.sharding.Shard
-
- context() - Method in class akka.cluster.sharding.ShardCoordinator
-
- context() - Method in class akka.cluster.sharding.ShardCoordinator.RebalanceWorker
-
- context() - Method in class akka.cluster.sharding.ShardRegion
-
- context() - Method in class akka.cluster.sharding.ShardRegion.HandOffStopper
-
- context() - Method in class akka.cluster.singleton.ClusterSingletonManager
-
- context() - Method in class akka.cluster.singleton.ClusterSingletonProxy
-
- context() - Method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- context() - Method in class akka.contrib.jul.JavaLogger
-
- context() - Method in class akka.contrib.pattern.ReliableProxy
-
- context() - Method in class akka.contrib.pattern.ReliableProxy.Receiver
-
- context() - Method in class akka.contrib.throttle.TimerBasedThrottler
-
- context() - Method in class akka.event.ActorClassificationUnsubscriber
-
- context() - Method in class akka.event.DeadLetterListener
-
- context() - Method in class akka.event.EventStreamUnsubscriber
-
- context() - Method in class akka.event.Logging.DefaultLogger
-
- context() - Method in class akka.event.slf4j.Slf4jLogger
-
- context() - Method in class akka.io.InetAddressDnsResolver
-
- context() - Method in class akka.io.SelectionHandler
-
- context() - Method in class akka.io.SelectionHandler.SelectorBasedManager
-
- context() - Method in class akka.io.SimpleDnsManager
-
- context() - Method in class akka.io.TcpConnection
-
- context() - Method in class akka.io.TcpListener
-
- context() - Static method in class akka.io.TcpOutgoingConnection
-
- context() - Method in class akka.io.UdpConnection
-
- context() - Method in class akka.io.UdpListener
-
- context() - Method in class akka.io.UdpSender
-
- context() - Method in class akka.Main.Terminator
-
- context() - Method in class akka.osgi.OsgiActorSystemFactory
-
- context() - Method in class akka.pattern.BackoffOnRestartSupervisor
-
- context() - Method in class akka.pattern.BackoffSupervisor
-
- context() - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- context() - Method in class akka.persistence.journal.AsyncWriteJournal.Resequencer
-
- context() - Method in class akka.persistence.journal.inmem.InmemJournal
-
- context() - Method in class akka.persistence.journal.japi.AsyncWriteJournal
-
- context() - Method in class akka.persistence.journal.JournalPerfSpec.BenchActor
-
- context() - Method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- context() - Method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- context() - Method in class akka.persistence.journal.leveldb.SharedLeveldbStore
-
- context() - Method in class akka.persistence.journal.PersistencePluginProxy
-
- context() - Method in class akka.persistence.journal.ReplayFilter
-
- context() - Method in class akka.persistence.journal.ReplayMediator
-
- context() - Method in class akka.persistence.query.journal.leveldb.AbstractEventsByPersistenceIdPublisher
-
- context() - Method in class akka.persistence.query.journal.leveldb.AbstractEventsByTagPublisher
-
- context() - Method in class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher
-
- context() - Method in class akka.persistence.RecoveryPermitter
-
- context() - Method in class akka.persistence.snapshot.japi.SnapshotStore
-
- context() - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
-
- context() - Method in class akka.persistence.snapshot.NoSnapshotStore
-
- context() - Method in class akka.remote.artery.FlushOnShutdown
-
- context() - Method in class akka.remote.EndpointActor
-
- context() - Method in class akka.remote.EndpointManager
-
- context() - Static method in class akka.remote.EndpointReader
-
- context() - Static method in class akka.remote.EndpointWriter
-
- context() - Method in class akka.remote.ReliableDeliverySupervisor
-
- context() - Method in class akka.remote.RemoteDeploymentWatcher
-
- context() - Method in class akka.remote.RemoteWatcher
-
- context() - Method in class akka.remote.Remoting.TransportSupervisor
-
- context() - Method in class akka.remote.testconductor.BarrierCoordinator
-
- context() - Method in class akka.remote.testconductor.ClientFSM
-
- context() - Method in class akka.remote.testconductor.Controller
-
- context() - Method in class akka.remote.testconductor.ServerFSM
-
- context() - Method in class akka.remote.transport.ActorTransportAdapterManager
-
- context() - Method in class akka.remote.transport.ProtocolStateActor
-
- context() - Method in class akka.remote.transport.ThrottledAssociation
-
- context() - Static method in class akka.remote.transport.ThrottlerManager
-
- context() - Static method in class akka.routing.ResizablePoolActor
-
- context() - Method in class akka.routing.RouterActor
-
- context() - Method in class akka.routing.TailChoppingRoutingLogic
-
- context() - Static method in class akka.stream.actor.AbstractActorPublisher
-
- context() - Static method in class akka.stream.actor.AbstractActorSubscriber
-
- context() - Static method in class akka.stream.actor.UntypedActorPublisher
-
- context() - Static method in class akka.stream.actor.UntypedActorSubscriber
-
- context() - Method in class akka.stream.impl.ActorProcessorImpl
-
- context() - Method in class akka.stream.impl.ActorRefSinkActor
-
- context() - Method in class akka.stream.impl.ActorRefSourceActor
-
- context() - Method in class akka.stream.impl.FanIn
-
- context() - Method in class akka.stream.impl.FanOut
-
- context() - Static method in class akka.stream.impl.FanoutProcessorImpl
-
- context() - Method in class akka.stream.impl.fusing.ActorGraphInterpreter
-
- context() - Method in class akka.stream.impl.fusing.GraphInterpreter
-
- context() - Method in class akka.stream.impl.io.FilePublisher
-
- context() - Method in class akka.stream.impl.io.FileSubscriber
-
- context() - Method in class akka.stream.impl.io.InputStreamPublisher
-
- context() - Method in class akka.stream.impl.io.OutputStreamSubscriber
-
- context() - Method in class akka.stream.impl.io.TLSActor
-
- context() - Method in class akka.stream.impl.StreamSupervisor
-
- context() - Static method in class akka.stream.impl.Unzip
-
- Context<Out> - Interface in akka.stream.stage
-
- context() - Method in class akka.testkit.TestActor
-
- context() - Method in class akka.testkit.TestActors.BlackholeActor
-
- context() - Method in class akka.testkit.TestActors.EchoActor
-
- context() - Method in class akka.testkit.TestActors.ForwardActor
-
- context() - Method in class akka.typed.adapter.ActorAdapter
-
- 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/retrieve 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$
-
- Continue$() - Constructor for class akka.persistence.query.journal.leveldb.EventsByPersistenceIdPublisher.Continue$
-
- Continue$() - Constructor for class akka.persistence.query.journal.leveldb.EventsByTagPublisher.Continue$
-
- continueGetShardHome(String, ActorRef, ActorRef) - Method in class akka.cluster.sharding.ShardCoordinator
-
- continueRebalance(Set<String>) - Method in class akka.cluster.sharding.ShardCoordinator
-
- contramap(Function<In2, In>) - Method in class akka.stream.javadsl.Sink
-
Transform this Sink by applying a function to each *incoming* upstream element before
it is passed to the
Sink
- contramap(Function1<In2, In>) - Method in class akka.stream.scaladsl.Sink
-
Transform this Sink by applying a function to each *incoming* upstream element before
it is passed to the
Sink
- 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
-
- controlMaterializer() - Method in class akka.remote.artery.Association
-
- ControlMessage - Interface in akka.dispatch
-
Messages that extend this trait will be handled with priority by control aware mailboxes.
- ControlMessage - Interface in akka.remote.artery
-
INTERNAL API
Marker trait for control messages that can be sent via the system message sub-channel
but don't need full reliable delivery.
- controlQueue() - Method in class akka.dispatch.BoundedControlAwareMailbox.MessageQueue
-
- controlQueue() - Method in interface akka.dispatch.ControlAwareMessageQueueSemantics
-
- controlQueue() - Method in class akka.dispatch.UnboundedControlAwareMailbox.MessageQueue
-
- ControlQueueIndex() - Method in class akka.remote.artery.Association$
-
- ControlQueueIndex() - Static method in class akka.remote.artery.Association
-
- ControlStreamDispatcher() - Method in class akka.remote.artery.ArterySettings.Advanced$
-
- ControlStreamMaterializerSettings() - Method in class akka.remote.artery.ArterySettings.Advanced$
-
- controlSubject() - Method in class akka.remote.artery.Association
-
- controlSubject() - Method in interface akka.remote.artery.OutboundContext
-
An outbound stage can listen to control messages
via this observer subject.
- 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
-
- conversionCheckedConstraint(Equivalence<A>, Function1<B, A>) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- conversionCheckedConstraint(Equivalence<A>, Function1<B, A>) - Static method in class akka.persistence.journal.JournalSpec
-
- conversionCheckedConstraint(Equivalence<A>, Function1<B, A>) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- Conversions() - Method in class akka.camel.CamelSettings
-
- convertEquivalenceToAToBConstraint(Equivalence<B>, Predef.$less$colon$less<A, B>) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- convertEquivalenceToAToBConstraint(Equivalence<B>, Predef.$less$colon$less<A, B>) - Static method in class akka.persistence.journal.JournalSpec
-
- convertEquivalenceToAToBConstraint(Equivalence<B>, Predef.$less$colon$less<A, B>) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- convertEquivalenceToAToBConversionConstraint(Equivalence<B>, Function1<A, B>) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- convertEquivalenceToAToBConversionConstraint(Equivalence<B>, Function1<A, B>) - Static method in class akka.persistence.journal.JournalSpec
-
- convertEquivalenceToAToBConversionConstraint(Equivalence<B>, Function1<A, B>) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- convertEquivalenceToBToAConstraint(Equivalence<A>, Predef.$less$colon$less<B, A>) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- convertEquivalenceToBToAConstraint(Equivalence<A>, Predef.$less$colon$less<B, A>) - Static method in class akka.persistence.journal.JournalSpec
-
- convertEquivalenceToBToAConstraint(Equivalence<A>, Predef.$less$colon$less<B, A>) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- convertEquivalenceToBToAConversionConstraint(Equivalence<A>, Function1<B, A>) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- convertEquivalenceToBToAConversionConstraint(Equivalence<A>, Function1<B, A>) - Static method in class akka.persistence.journal.JournalSpec
-
- convertEquivalenceToBToAConversionConstraint(Equivalence<A>, Function1<B, A>) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- convertNumber(Object) - Static method in class akka.cluster.Metric
-
Deprecated.
- convertNumber(Object) - Method in interface akka.cluster.MetricNumericConverter
-
May involve rounding or truncation.
- convertNumber(Object) - Static method in class akka.cluster.metrics.Metric
-
- convertNumber(Object) - Method in interface akka.cluster.metrics.MetricNumericConverter
-
May involve rounding or truncation.
- convertNumericToPlusOrMinusWrapper(T, Numeric<T>) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- convertNumericToPlusOrMinusWrapper(T, Numeric<T>) - Static method in class akka.persistence.journal.JournalSpec
-
- convertNumericToPlusOrMinusWrapper(T, Numeric<T>) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- convertSettings(Function<SSLConfigSettings, SSLConfigSettings>) - Method in class com.typesafe.sslconfig.akka.AkkaSSLConfig
-
Returns a new
AkkaSSLConfig
instance with the settings changed by the given function.
- convertSymbolToHavePropertyMatcherGenerator(Symbol, Prettifier, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- convertSymbolToHavePropertyMatcherGenerator(Symbol, Prettifier, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- convertSymbolToHavePropertyMatcherGenerator(Symbol, Prettifier, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- 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
-
- convertToAnyShouldWrapper(T, Position, Prettifier) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- convertToAnyShouldWrapper(T, Position, Prettifier) - Static method in class akka.persistence.journal.JournalSpec
-
- convertToAnyShouldWrapper(T, Position, Prettifier) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- convertToCheckingEqualizer(T) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- convertToCheckingEqualizer(T) - Static method in class akka.persistence.journal.JournalSpec
-
- convertToCheckingEqualizer(T) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- convertToEqualizer(T) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- convertToEqualizer(T) - Static method in class akka.persistence.journal.JournalSpec
-
- convertToEqualizer(T) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- convertToRegexWrapper(Regex) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- convertToRegexWrapper(Regex) - Static method in class akka.persistence.journal.JournalSpec
-
- convertToRegexWrapper(Regex) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- convertToStringCanWrapper(String, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- convertToStringCanWrapper(String, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- convertToStringCanWrapper(String, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- convertToStringMayWrapper(String) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- convertToStringMayWrapper(String) - Static method in class akka.persistence.journal.JournalSpec
-
- convertToStringMayWrapper(String) - Method in interface akka.persistence.scalatest.MayVerb
-
Implicitly converts an object of type String
to a StringMayWrapper
,
to enable may
methods to be invokable on that object.
- convertToStringMustWrapperForVerb(String, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- convertToStringMustWrapperForVerb(String, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- convertToStringMustWrapperForVerb(String, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- convertToStringShouldWrapper(String, Position, Prettifier) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- convertToStringShouldWrapper(String, Position, Prettifier) - Static method in class akka.persistence.journal.JournalSpec
-
- convertToStringShouldWrapper(String, Position, Prettifier) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- convertToStringShouldWrapperForVerb(String, Position) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- convertToStringShouldWrapperForVerb(String, Position) - Static method in class akka.persistence.journal.JournalSpec
-
- convertToStringShouldWrapperForVerb(String, Position) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- convertToWordSpecStringWrapper(String) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- convertToWordSpecStringWrapper(String) - Static method in class akka.persistence.journal.JournalSpec
-
- convertToWordSpecStringWrapper(String) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- 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.ClusterShardingSettings.TuningParameters
-
- coordinatorSelection() - Method in class akka.cluster.sharding.ShardRegion
-
- coordinatorSingletonSettings() - Method in class akka.cluster.sharding.ClusterShardingSettings
-
- CoordinatorStateKey() - Method in class akka.cluster.sharding.DDataShardCoordinator
-
- CopiedModule(Shape, Attributes, StreamLayout.Module) - Constructor for class akka.stream.impl.StreamLayout.CopiedModule
-
- CopiedModule$() - Constructor for class akka.stream.impl.StreamLayout.CopiedModule$
-
- 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(Object, Map<String, Object>) - Method in class akka.camel.CamelMessage
-
- copy(MemberStatus) - Method in class akka.cluster.Member
-
- copy(int, Duration, boolean, PartialFunction<Throwable, SupervisorStrategy.Directive>) - Static method in class akka.cluster.metrics.ClusterMetricsStrategy
-
- copy(Address, int) - Method in class akka.cluster.UniqueAddress
-
- copy(S, D, Option<FiniteDuration>, Option<PersistentFSM.Reason>, List<Object>, boolean, Seq<E>, Function1<D, BoxedUnit>) - Method in class akka.persistence.fsm.PersistentFSM.State
-
Copy object and update values if needed.
- copy() - Method in interface akka.remote.artery.OutboundEnvelope
-
- copy() - Method in class akka.remote.artery.ReusableOutboundEnvelope
-
- copy(Address, int) - Method in class akka.remote.QuarantinedEvent
-
- copy(String) - Method in class akka.stream.impl.SeqActorName
-
- copy(String) - Method in class akka.stream.impl.SeqActorNameImpl
-
- copy$default$1() - Static method in class akka.cluster.metrics.ClusterMetricsStrategy
-
- copy$default$2() - Static method in class akka.cluster.metrics.ClusterMetricsStrategy
-
- copy$default$3() - Static method in class akka.cluster.metrics.ClusterMetricsStrategy
-
- copyContent(CamelMessage, Message) - Method in class akka.camel.CamelMessage$
-
INTERNAL API
copies the content of this CamelMessageWithAttachments to an Apache Camel Message.
- copyContent(CamelMessage, Message) - Static method in class akka.camel.CamelMessage
-
INTERNAL API
copies the content of this CamelMessageWithAttachments to an Apache Camel Message.
- copyFromPorts(Seq<Inlet<?>>, Seq<Outlet<?>>) - Method in class akka.stream.AmorphousShape
-
- copyFromPorts(Seq<Inlet<?>>, Seq<Outlet<?>>) - Method in class akka.stream.BidiShape
-
- copyFromPorts(Seq<Inlet<?>>, Seq<Outlet<?>>) - Method in class akka.stream.ClosedShape$
-
- copyFromPorts(Seq<Inlet<?>>, Seq<Outlet<?>>) - Static method in class akka.stream.ClosedShape
-
- copyFromPorts(Seq<Inlet<?>>, Seq<Outlet<?>>) - Method in class akka.stream.FanInShape
-
- copyFromPorts(Seq<Inlet<?>>, Seq<Outlet<?>>) - Method in class akka.stream.FanOutShape
-
- copyFromPorts(Seq<Inlet<?>>, Seq<Outlet<?>>) - Method in class akka.stream.FlowShape
-
- copyFromPorts(Seq<Inlet<?>>, Seq<Outlet<?>>) - Method in class akka.stream.Shape
-
Create a copy of this Shape object, returning the same type as the
original but containing the ports given within the passed-in Shape.
- copyFromPorts(Seq<Inlet<?>>, Seq<Outlet<?>>) - Method in class akka.stream.SinkShape
-
- copyFromPorts(Seq<Inlet<?>>, Seq<Outlet<?>>) - Method in class akka.stream.SourceShape
-
- copyFromPorts(Seq<Inlet<?>>, Seq<Outlet<?>>) - Static method in class akka.stream.UniformFanInShape
-
- copyFromPorts(Seq<Inlet<?>>, Seq<Outlet<?>>) - Static method in class akka.stream.UniformFanOutShape
-
- copyOf() - Method in class akka.stream.impl.StreamLayout.CopiedModule
-
- copySrc() - Method in class akka.stream.impl.fusing.GraphStages.MaterializedValueSource
-
- copyToArray(Object, int, int) - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- copyToArray(Object, int) - Static method in class akka.util.ByteIterator
-
- copyToArray(Object) - Static method in class akka.util.ByteIterator
-
- copyToArray(Object, int, int) - Static method in class akka.util.ByteIterator
-
- copyToArray(Object, int, int) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- copyToArray(Object, int, int) - Method in class akka.util.ByteString
-
- copyToArray(Object, int) - Static method in class akka.util.CompactByteString
-
- copyToArray(Object) - Static method in class akka.util.CompactByteString
-
- copyToArray(Object, int, int) - Static method in class akka.util.CompactByteString
-
- copyToBuffer(ByteBuffer) - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- copyToBuffer(ByteBuffer) - Method in class akka.util.ByteIterator
-
For performance sensitive code, call take() directly on ByteString (it's optimised there)
- copyToBuffer(ByteBuffer) - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
For performance sensitive code, call copyToBuffer() directly on ByteString (it's optimised there)
- copyToBuffer(ByteBuffer) - Method in class akka.util.ByteString.ByteString1
-
- copyToBuffer(ByteBuffer) - Method in class akka.util.ByteString.ByteString1C
-
- copyToBuffer(ByteBuffer) - Method in class akka.util.ByteString.ByteStrings
-
- copyToBuffer(ByteBuffer) - Method in class akka.util.ByteString
-
Copy as many bytes as possible to a ByteBuffer, starting from it's
current position.
- copyToBuffer(Buffer<B>) - Static method in class akka.util.CompactByteString
-
- copyToBuffer(ByteBuffer) - Static method in class akka.util.CompactByteString
-
- 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
-
- corkUser() - Method in class akka.stream.impl.io.TLSActor
-
- correlationId() - Method in class akka.actor.ActorIdentity
-
- CORRELATIONID_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.ActorIdentity
-
- corresponds(GenTraversableOnce<B>, Function2<A, B, Object>) - Static method in class akka.util.ByteIterator
-
- corresponds(GenSeq<B>, Function2<A, B, Object>) - Static method in class akka.util.ByteString
-
- corresponds(GenSeq<B>, Function2<A, B, Object>) - Static method in class akka.util.CompactByteString
-
- cost() - Method in class akka.stream.impl.Throttle
-
- costCalculation() - Method in class akka.stream.impl.Throttle
-
- costFn() - Method in class akka.stream.impl.fusing.Batch
-
- costFn() - Method in class akka.stream.impl.fusing.LimitWeighted
-
- count() - Method in class akka.cluster.singleton.ClusterSingletonManager.Internal$.HandOverRetry
-
- count() - Method in class akka.cluster.singleton.ClusterSingletonManager.Internal$.TakeOverRetry
-
- count - Variable in class akka.dispatch.AbstractBoundedNodeQueue.Node
-
- count() - Method in class akka.dispatch.AbstractNodeQueue
-
This method returns an upper bound on the queue size at the time it
starts executing.
- count() - Method in class akka.event.DeadLetterListener
-
- count() - Method in class akka.io.Tcp.WriteFile
-
- count() - Method in class akka.pattern.BackoffSupervisor.RestartCount
-
- count() - Method in class akka.remote.artery.compress.CompressionProtocol.Events$.HeavyHitterDetected
-
- count() - Method in class akka.remote.artery.RestartCounter
-
Current number of restarts.
- count() - Method in class akka.remote.artery.RestartCounter.State
-
- count() - Method in class akka.stream.impl.fusing.Drop
-
- count() - Method in class akka.stream.impl.fusing.Take
-
- count(ResizableMultiReaderRingBuffer.Cursor) - Method in class akka.stream.impl.ResizableMultiReaderRingBuffer
-
Returns the number of elements that the buffer currently contains for the given cursor.
- count() - Method in class akka.stream.IOResult
-
- count(Function1<A, Object>) - Static method in class akka.util.ByteIterator
-
- count(Function1<A, Object>) - Static method in class akka.util.ByteString
-
- count(Function1<A, Object>) - Static method in class akka.util.CompactByteString
-
- count() - Static method in class akka.util.SerializedSuspendableExecutionContext
-
- Count$() - Constructor for class akka.cluster.pubsub.DistributedPubSubMediator.Count$
-
- countDown() - Method in class akka.testkit.TestLatch
-
- counter() - Method in class akka.cluster.ddata.VersionVector.Timestamp$
-
- 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
-
- CountMinSketch - Class in akka.remote.artery.compress
-
INTERNAL API: Count-Min Sketch datastructure.
- CountMinSketch(int, int, int) - Constructor for class akka.remote.artery.compress.CountMinSketch
-
- counts(int, int) - Method in class akka.remote.RemoteWatcher.Stats$
-
- CoupledTerminationBidi<I,O> - Class in akka.stream.scaladsl
-
INTERNAL API
- CoupledTerminationBidi() - Constructor for class akka.stream.scaladsl.CoupledTerminationBidi
-
- CoupledTerminationFlow - Class in akka.stream.javadsl
-
Allows coupling termination (cancellation, completion, erroring) of Sinks and Sources while creating a Flow them them.
- CoupledTerminationFlow() - Constructor for class akka.stream.javadsl.CoupledTerminationFlow
-
- CoupledTerminationFlow - Class in akka.stream.scaladsl
-
Allows coupling termination (cancellation, completion, erroring) of Sinks and Sources while creating a Flow them them.
- CoupledTerminationFlow() - Constructor for class akka.stream.scaladsl.CoupledTerminationFlow
-
- CoupledTerminationFlow$ - Class in akka.stream.javadsl
-
Allows coupling termination (cancellation, completion, erroring) of Sinks and Sources while creating a Flow them them.
- CoupledTerminationFlow$() - Constructor for class akka.stream.javadsl.CoupledTerminationFlow$
-
- CoupledTerminationFlow$ - Class in akka.stream.scaladsl
-
Allows coupling termination (cancellation, completion, erroring) of Sinks and Sources while creating a Flow them them.
- CoupledTerminationFlow$() - Constructor for class akka.stream.scaladsl.CoupledTerminationFlow$
-
- 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
-
Deprecated.
- Cpu$() - Constructor for class akka.cluster.metrics.StandardMetrics.Cpu$
-
- Cpu$() - Constructor for class akka.cluster.StandardMetrics.Cpu$
-
Deprecated.
- 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
-
Deprecated.
(SIGAR) Returns the combined CPU sum of User + Sys + Nice + Wait, in percentage.
- CpuCombined() - Method in class akka.cluster.StandardMetrics$
-
Deprecated.
- cpuCombined() - Method in class akka.cluster.StandardMetrics.Cpu
-
Deprecated.
- CpuCombined() - Static method in class akka.cluster.StandardMetrics
-
Deprecated.
- 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
-
- CpuMetricsSelector() - Constructor for class akka.cluster.routing.CpuMetricsSelector
-
Deprecated.
- 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
-
- CpuMetricsSelector$() - Constructor for class akka.cluster.routing.CpuMetricsSelector$
-
Deprecated.
- 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(Class<?>, Object...) - Method in interface akka.actor.AbstractProps
-
Java API: create a Props given a class and its constructor arguments.
- create(Class<?>, Seq<Object>) - Method in interface akka.actor.AbstractProps
-
Java API: create a Props given a class and its constructor arguments.
- create(Creator<T>) - Method in interface akka.actor.AbstractProps
-
Create new Props from the given
Creator
.
- create(Class<T>, Creator<T>) - Method in interface akka.actor.AbstractProps
-
Create new Props from the given
Creator
with the type set to the given actorClass.
- 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, ActorSystemSetup) - Method in class akka.actor.ActorSystem$
-
Java API: Creates a new actor system with the specified name and settings
The core actor system settings are defined in
BootstrapSetup
- create(String, BootstrapSetup) - Method in class akka.actor.ActorSystem$
-
Java API: Shortcut for creating an actor system with custom bootstrap settings.
- 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, ActorSystemSetup) - Static method in class akka.actor.ActorSystem
-
Java API: Creates a new actor system with the specified name and settings
The core actor system settings are defined in
BootstrapSetup
- create(String, BootstrapSetup) - Static method in class akka.actor.ActorSystem
-
Java API: Shortcut for creating an actor system with custom bootstrap settings.
- 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(Optional<ClassLoader>, Optional<Config>, Optional<ExecutionContext>) - Method in class akka.actor.BootstrapSetup$
-
Java API: Create bootstrap settings needed for starting the actor system
- create(Config) - Method in class akka.actor.BootstrapSetup$
-
Java API: Short for using custom config but keeping default classloader and default execution context
- create() - Method in class akka.actor.BootstrapSetup$
-
Java API: Construct a bootstrap settings with default values.
- create(Optional<ClassLoader>, Optional<Config>, Optional<ExecutionContext>) - Static method in class akka.actor.BootstrapSetup
-
Java API: Create bootstrap settings needed for starting the actor system
- create(Config) - Static method in class akka.actor.BootstrapSetup
-
Java API: Short for using custom config but keeping default classloader and default execution context
- create() - Static method in class akka.actor.BootstrapSetup
-
Java API: Construct a bootstrap settings with default values.
- 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(Setup...) - Method in class akka.actor.setup.ActorSystemSetup$
-
- create(Seq<Setup>) - Method in class akka.actor.setup.ActorSystemSetup$
-
- create(Setup...) - Static method in class akka.actor.setup.ActorSystemSetup
-
- create(Seq<Setup>) - Static method in class akka.actor.setup.ActorSystemSetup
-
- 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() - Method in class akka.cluster.ddata.Flag$
-
Java API: Flag
that is initialized to false
.
- create() - Static method in class akka.cluster.ddata.Flag
-
Java API: Flag
that is initialized to false
.
- create(String) - Method in class akka.cluster.ddata.FlagKey$
-
- create(String) - Static method in class akka.cluster.ddata.FlagKey
-
- create() - Method in class akka.cluster.ddata.GCounter$
-
Java API
- create() - Static method in class akka.cluster.ddata.GCounter
-
Java API
- create(String) - Method in class akka.cluster.ddata.GCounterKey$
-
- create(String) - Static method in class akka.cluster.ddata.GCounterKey
-
- create() - Method in class akka.cluster.ddata.GSet$
-
Java API
- create() - Static method in class akka.cluster.ddata.GSet
-
Java API
- create(String) - Method in class akka.cluster.ddata.GSetKey$
-
- create(String) - Static method in class akka.cluster.ddata.GSetKey
-
- create() - Method in class akka.cluster.ddata.LWWMap$
-
Java API
- create() - Static method in class akka.cluster.ddata.LWWMap
-
Java API
- create(String) - Method in class akka.cluster.ddata.LWWMapKey$
-
- create(String) - Static method in class akka.cluster.ddata.LWWMapKey
-
- create(Cluster, A) - Method in class akka.cluster.ddata.LWWRegister$
-
Java API
- create(Cluster, A, LWWRegister.Clock<A>) - Method in class akka.cluster.ddata.LWWRegister$
-
Java API
- create(Cluster, A) - Static method in class akka.cluster.ddata.LWWRegister
-
Java API
- create(Cluster, A, LWWRegister.Clock<A>) - Static method in class akka.cluster.ddata.LWWRegister
-
Java API
- create(String) - Method in class akka.cluster.ddata.LWWRegisterKey$
-
- create(String) - Static method in class akka.cluster.ddata.LWWRegisterKey
-
- create() - Method in class akka.cluster.ddata.ORMap$
-
Java API
- create() - Static method in class akka.cluster.ddata.ORMap
-
Java API
- create(String) - Method in class akka.cluster.ddata.ORMapKey$
-
- create(String) - Static method in class akka.cluster.ddata.ORMapKey
-
- create() - Method in class akka.cluster.ddata.ORMultiMap$
-
Java API
- create() - Static method in class akka.cluster.ddata.ORMultiMap
-
Java API
- create(String) - Method in class akka.cluster.ddata.ORMultiMapKey$
-
- create(String) - Static method in class akka.cluster.ddata.ORMultiMapKey
-
- create() - Method in class akka.cluster.ddata.ORSet$
-
Java API
- create() - Static method in class akka.cluster.ddata.ORSet
-
Java API
- create(String) - Method in class akka.cluster.ddata.ORSetKey$
-
- create(String) - Static method in class akka.cluster.ddata.ORSetKey
-
- create() - Method in class akka.cluster.ddata.PNCounter$
-
Java API
- create() - Static method in class akka.cluster.ddata.PNCounter
-
Java API
- create(String) - Method in class akka.cluster.ddata.PNCounterKey$
-
- create(String) - Static method in class akka.cluster.ddata.PNCounterKey
-
- create() - Method in class akka.cluster.ddata.PNCounterMap$
-
Java API
- create() - Static method in class akka.cluster.ddata.PNCounterMap
-
Java API
- create(String) - Method in class akka.cluster.ddata.PNCounterMapKey$
-
- create(String) - Static method in class akka.cluster.ddata.PNCounterMapKey
-
- create() - Method in class akka.cluster.ddata.VersionVector$
-
Java API
- create() - Static method in class akka.cluster.ddata.VersionVector
-
Java API
- create(String, Number, Option<Object>) - Method in class akka.cluster.Metric$
-
Deprecated.
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$
-
Deprecated.
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
-
Deprecated.
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
-
Deprecated.
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.sharding.ClusterShardingSettings$
-
Java API: Create settings from the default configuration
akka.cluster.sharding
.
- create(Config) - Method in class akka.cluster.sharding.ClusterShardingSettings$
-
Java API: Create settings from a configuration with the same layout as
the default configuration akka.cluster.sharding
.
- create(ActorSystem) - Static method in class akka.cluster.sharding.ClusterShardingSettings
-
Java API: Create settings from the default configuration
akka.cluster.sharding
.
- create(Config) - Static method in class akka.cluster.sharding.ClusterShardingSettings
-
Java API: Create settings from a configuration with the same layout as
the default configuration akka.cluster.sharding
.
- 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(Option<ActorRef>, Option<ActorSystem>) - Method in class akka.event.LoggerMailboxType
-
- 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(String) - Method in class akka.event.LogMarker$
-
Java API
- create(String) - Static method in class akka.event.LogMarker
-
Java API
- 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(A, B) - Method in class akka.japi.Pair$
-
- create(A, B) - Static method in class akka.japi.Pair
-
- create(PFBuilder<F, T>) - Static method in class akka.japi.pf.Match
-
Create a
Match
from the builder.
- create() - Static method in class akka.japi.pf.ReceiveBuilder
-
- create(UnitPFBuilder<F>) - Static method in class akka.japi.pf.UnitMatch
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Method in class akka.japi.tuple.Tuple10$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Static method in class akka.japi.tuple.Tuple10
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Method in class akka.japi.tuple.Tuple11$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Static method in class akka.japi.tuple.Tuple11
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Method in class akka.japi.tuple.Tuple12$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Static method in class akka.japi.tuple.Tuple12
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Method in class akka.japi.tuple.Tuple13$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Static method in class akka.japi.tuple.Tuple13
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Method in class akka.japi.tuple.Tuple14$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Static method in class akka.japi.tuple.Tuple14
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Method in class akka.japi.tuple.Tuple15$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Static method in class akka.japi.tuple.Tuple15
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Method in class akka.japi.tuple.Tuple16$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Static method in class akka.japi.tuple.Tuple16
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Method in class akka.japi.tuple.Tuple17$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Static method in class akka.japi.tuple.Tuple17
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Method in class akka.japi.tuple.Tuple18$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Static method in class akka.japi.tuple.Tuple18
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Method in class akka.japi.tuple.Tuple19$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Static method in class akka.japi.tuple.Tuple19
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Method in class akka.japi.tuple.Tuple20$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Static method in class akka.japi.tuple.Tuple20
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Method in class akka.japi.tuple.Tuple21$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Static method in class akka.japi.tuple.Tuple21
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Method in class akka.japi.tuple.Tuple22$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Static method in class akka.japi.tuple.Tuple22
-
- create(T1, T2, T3) - Method in class akka.japi.tuple.Tuple3$
-
- create(T1, T2, T3) - Static method in class akka.japi.tuple.Tuple3
-
- create(T1, T2, T3, T4) - Method in class akka.japi.tuple.Tuple4$
-
- create(T1, T2, T3, T4) - Static method in class akka.japi.tuple.Tuple4
-
- create(T1, T2, T3, T4, T5) - Method in class akka.japi.tuple.Tuple5$
-
- create(T1, T2, T3, T4, T5) - Static method in class akka.japi.tuple.Tuple5
-
- create(T1, T2, T3, T4, T5, T6) - Method in class akka.japi.tuple.Tuple6$
-
- create(T1, T2, T3, T4, T5, T6) - Static method in class akka.japi.tuple.Tuple6
-
- create(T1, T2, T3, T4, T5, T6, T7) - Method in class akka.japi.tuple.Tuple7$
-
- create(T1, T2, T3, T4, T5, T6, T7) - Static method in class akka.japi.tuple.Tuple7
-
- create(T1, T2, T3, T4, T5, T6, T7, T8) - Method in class akka.japi.tuple.Tuple8$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8) - Static method in class akka.japi.tuple.Tuple8
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in class akka.japi.tuple.Tuple9$
-
- create(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Static method in class akka.japi.tuple.Tuple9
-
- 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(boolean) - Method in class akka.persistence.CapabilityFlag$
-
Java DSL
- create(boolean) - Static method in class akka.persistence.CapabilityFlag
-
Java DSL
- create(Config) - Method in class akka.persistence.DiscardConfigurator
-
- create(Object...) - Method in class akka.persistence.journal.EventSeq$
-
Java API
- create(Seq<Object>) - Method in class akka.persistence.journal.EventSeq$
-
Java API
- create(Object...) - Static method in class akka.persistence.journal.EventSeq
-
Java API
- create(Seq<Object>) - Static method in class akka.persistence.journal.EventSeq
-
Java API
- create() - Method in class akka.persistence.PersistentRepr$
-
Java API, Plugin API.
- create() - Method in class akka.persistence.Recovery$
-
Java API
- create(long) - Method in class akka.persistence.Recovery$
-
Java API
- create(SnapshotSelectionCriteria) - Method in class akka.persistence.Recovery$
-
Java API
- create(SnapshotSelectionCriteria, long) - Method in class akka.persistence.Recovery$
-
Java API
- create(SnapshotSelectionCriteria, long, long) - Method in class akka.persistence.Recovery$
-
Java API
- create() - Static method in class akka.persistence.Recovery
-
Java API
- create(long) - Static method in class akka.persistence.Recovery
-
Java API
- create(SnapshotSelectionCriteria) - Static method in class akka.persistence.Recovery
-
Java API
- create(SnapshotSelectionCriteria, long) - Static method in class akka.persistence.Recovery
-
Java API
- create(SnapshotSelectionCriteria, long, long) - Static method in class akka.persistence.Recovery
-
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, long, long) - Method in class akka.persistence.SnapshotSelectionCriteria$
-
Java API.
- create(long, long) - Static method in class akka.persistence.SnapshotSelectionCriteria
-
Java API.
- create(long, long, long, long) - Static method in class akka.persistence.SnapshotSelectionCriteria
-
Java API.
- create(Config) - Method in interface akka.persistence.StashOverflowStrategyConfigurator
-
- create(Config) - Method in class akka.persistence.ThrowExceptionConfigurator
-
- 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(ExtendedActorSystem, LoggingAdapter) - Method in class akka.remote.artery.RemoteInstruments$
-
- create(ExtendedActorSystem, LoggingAdapter) - Static method in class akka.remote.artery.RemoteInstruments
-
- 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(Option<ActorInitializationException>) - Static method in class akka.routing.RoutedActorCell
-
- create(Function<ExtendedActorSystem, List<SerializerDetails>>) - Method in class akka.serialization.SerializationSetup$
-
Java API: Programmatic definition of serializers
- create(Function<ExtendedActorSystem, List<SerializerDetails>>) - Static method in class akka.serialization.SerializationSetup
-
Java API: Programmatic definition of serializers
- create(String, Serializer, List<Class<?>>) - Method in class akka.serialization.SerializerDetails$
-
Java API: factory for details about one programmatically setup serializer
- create(String, Serializer, List<Class<?>>) - Static method in class akka.serialization.SerializerDetails
-
Java API: factory for details about one programmatically setup serializer
- create(ActorRef) - Method in class akka.stream.actor.AbstractActorPublisher$
-
- create(ActorRef) - Static method in class akka.stream.actor.AbstractActorPublisher
-
- create(ActorRef) - Method in class akka.stream.actor.AbstractActorSubscriber$
-
- create(ActorRef) - Static method in class akka.stream.actor.AbstractActorSubscriber
-
- create(ActorRef) - Method in class akka.stream.actor.UntypedActorPublisher$
-
- create(ActorRef) - Static method in class akka.stream.actor.UntypedActorPublisher
-
- create(ActorRef) - Method in class akka.stream.actor.UntypedActorSubscriber$
-
- create(ActorRef) - Static method in class akka.stream.actor.UntypedActorSubscriber
-
- create(ActorRefFactory) - Method in class akka.stream.ActorMaterializer$
-
Java API: Creates an ActorMaterializer which will execute every step of a transformation
pipeline within its own
Actor
.
- create(ActorMaterializerSettings, ActorRefFactory) - Method in class akka.stream.ActorMaterializer$
-
Java API: Creates an ActorMaterializer which will execute every step of a transformation
pipeline within its own
Actor
.
- create(ActorMaterializerSettings, ActorRefFactory, String) - Method in class akka.stream.ActorMaterializer$
-
Java API: Creates an ActorMaterializer which will execute every step of a transformation
pipeline within its own
Actor
.
- create(ActorRefFactory) - Static method in class akka.stream.ActorMaterializer
-
Java API: Creates an ActorMaterializer which will execute every step of a transformation
pipeline within its own
Actor
.
- create(ActorMaterializerSettings, ActorRefFactory) - Static method in class akka.stream.ActorMaterializer
-
Java API: Creates an ActorMaterializer which will execute every step of a transformation
pipeline within its own
Actor
.
- create(ActorMaterializerSettings, ActorRefFactory, String) - Static method in class akka.stream.ActorMaterializer
-
Java API: Creates an ActorMaterializer which will execute every step of a transformation
pipeline within its own
Actor
.
- create(int, int, String, Function1<Throwable, Supervision.Directive>, StreamSubscriptionTimeoutSettings, boolean, int, boolean, boolean, int) - Method in class akka.stream.ActorMaterializerSettings$
-
- create(ActorSystem) - Method in class akka.stream.ActorMaterializerSettings$
-
- create(Config) - Method in class akka.stream.ActorMaterializerSettings$
-
- create(int, int, String, Function1<Throwable, Supervision.Directive>, StreamSubscriptionTimeoutSettings, boolean, int, boolean, boolean, int) - Static method in class akka.stream.ActorMaterializerSettings
-
- create(ActorSystem) - Static method in class akka.stream.ActorMaterializerSettings
-
- create(Config) - Static method in class akka.stream.ActorMaterializerSettings
-
- create(MaterializationContext) - Method in class akka.stream.impl.ActorPublisherSource
-
- create(MaterializationContext) - Method in class akka.stream.impl.ActorRefSink
-
- create(MaterializationContext) - Method in class akka.stream.impl.ActorRefSource
-
- create(MaterializationContext) - Method in class akka.stream.impl.ActorSubscriberSink
-
- create(MaterializationContext) - Method in class akka.stream.impl.CancelSink
-
- create(MaterializationContext) - Method in class akka.stream.impl.FanoutPublisherSink
-
- create(MaterializationContext) - Method in class akka.stream.impl.io.FileSink
-
- create(MaterializationContext) - Method in class akka.stream.impl.io.FileSource
-
- create(MaterializationContext) - Method in class akka.stream.impl.io.InputStreamSource
-
- create(MaterializationContext) - Method in class akka.stream.impl.io.OutputStreamSink
-
- create(MaterializationContext) - Method in class akka.stream.impl.MaybeSource
-
- create(MaterializationContext) - Method in class akka.stream.impl.PublisherSink
-
- create(MaterializationContext) - Method in class akka.stream.impl.PublisherSource
-
- create(MaterializationContext) - Method in class akka.stream.impl.SinkModule
-
Create the Subscriber or VirtualPublisher that consumes the incoming
stream, plus the materialized value.
- create(MaterializationContext) - Method in class akka.stream.impl.SourceModule
-
- create(Attributes) - Method in interface akka.stream.impl.Stages.SymbolicStage
-
- create(MaterializationContext) - Method in class akka.stream.impl.SubscriberSink
-
- create(MaterializationContext) - Method in class akka.stream.impl.SubscriberSource
-
- create(Subscriber<?>) - Method in class akka.stream.impl.VirtualProcessor.Both$
-
- create(String) - Method in class akka.stream.Inlet$
-
JAVA API
- create(String) - Static method in class akka.stream.Inlet
-
JAVA API
- create(int, boolean) - Method in class akka.stream.javadsl.Balance$
-
Create a new Balance
stage with the specified input type.
- create(int) - Method in class akka.stream.javadsl.Balance$
-
Create a new Balance
stage with the specified input type.
- create(Class<T>, int) - Method in class akka.stream.javadsl.Balance$
-
Create a new Balance
stage with the specified input type.
- create(Class<T>, int, boolean) - Method in class akka.stream.javadsl.Balance$
-
Create a new Balance
stage with the specified input type.
- create(int, boolean) - Static method in class akka.stream.javadsl.Balance
-
Create a new Balance
stage with the specified input type.
- create(int) - Static method in class akka.stream.javadsl.Balance
-
Create a new Balance
stage with the specified input type.
- create(Class<T>, int) - Static method in class akka.stream.javadsl.Balance
-
Create a new Balance
stage with the specified input type.
- create(Class<T>, int, boolean) - Static method in class akka.stream.javadsl.Balance
-
Create a new Balance
stage with the specified input type.
- create(int, boolean) - Method in class akka.stream.javadsl.Broadcast$
-
Create a new Broadcast
stage with the specified input type.
- create(int) - Method in class akka.stream.javadsl.Broadcast$
-
Create a new Broadcast
stage with the specified input type.
- create(Class<T>, int) - Method in class akka.stream.javadsl.Broadcast$
-
Create a new Broadcast
stage with the specified input type.
- create(int, boolean) - Static method in class akka.stream.javadsl.Broadcast
-
Create a new Broadcast
stage with the specified input type.
- create(int) - Static method in class akka.stream.javadsl.Broadcast
-
Create a new Broadcast
stage with the specified input type.
- create(Class<T>, int) - Static method in class akka.stream.javadsl.Broadcast
-
Create a new Broadcast
stage with the specified input type.
- create() - Method in class akka.stream.javadsl.Concat$
-
Create a new anonymous Concat
stage with the specified input types.
- create(int) - Method in class akka.stream.javadsl.Concat$
-
Create a new anonymous Concat
stage with the specified input types.
- create(Class<T>) - Method in class akka.stream.javadsl.Concat$
-
Create a new anonymous Concat
stage with the specified input types.
- create() - Static method in class akka.stream.javadsl.Concat
-
Create a new anonymous Concat
stage with the specified input types.
- create(int) - Static method in class akka.stream.javadsl.Concat
-
Create a new anonymous Concat
stage with the specified input types.
- create(Class<T>) - Static method in class akka.stream.javadsl.Concat
-
Create a new anonymous Concat
stage with the specified input types.
- create() - Method in class akka.stream.javadsl.Flow$
-
Create a `Flow` which can process elements of type `T`.
- create() - Static method in class akka.stream.javadsl.Flow
-
Create a `Flow` which can process elements of type `T`.
- create(Function<GraphDSL.Builder<NotUsed>, S>) - Method in class akka.stream.javadsl.GraphCreate
-
Creates a new
Graph
of the given
Shape
by passing a
GraphDSL.Builder
to the given create function.
- create(Graph<S1, M>, Function2<GraphDSL.Builder<M>, S1, S>) - Method in class akka.stream.javadsl.GraphCreate
-
Creates a new
Graph
by importing the given graph
g1
and its
Shape
along with the
GraphDSL.Builder
to the given create function.
- create(Graph<S1, M1>, Graph<S2, M2>, Function2<M1, M2, M>, Function3<GraphDSL.Builder<M>, S1, S2, S>) - Method in class akka.stream.javadsl.GraphCreate
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create(Function<GraphDSL.Builder<NotUsed>, S>) - Static method in class akka.stream.javadsl.GraphDSL
-
- create(Graph<S1, M>, Function2<GraphDSL.Builder<M>, S1, S>) - Static method in class akka.stream.javadsl.GraphDSL
-
- create(Graph<S1, M1>, Graph<S2, M2>, Function2<M1, M2, M>, Function3<GraphDSL.Builder<M>, S1, S2, S>) - Static method in class akka.stream.javadsl.GraphDSL
-
- create(int) - Method in class akka.stream.javadsl.Merge$
-
Create a new Merge
stage with the specified output type.
- create(Class<T>, int) - Method in class akka.stream.javadsl.Merge$
-
Create a new Merge
stage with the specified output type.
- create(int, boolean) - Method in class akka.stream.javadsl.Merge$
-
Create a new Merge
stage with the specified output type.
- create(Class<T>, int, boolean) - Method in class akka.stream.javadsl.Merge$
-
Create a new Merge
stage with the specified output type.
- create(int) - Static method in class akka.stream.javadsl.Merge
-
Create a new Merge
stage with the specified output type.
- create(Class<T>, int) - Static method in class akka.stream.javadsl.Merge
-
Create a new Merge
stage with the specified output type.
- create(int, boolean) - Static method in class akka.stream.javadsl.Merge
-
Create a new Merge
stage with the specified output type.
- create(Class<T>, int, boolean) - Static method in class akka.stream.javadsl.Merge
-
Create a new Merge
stage with the specified output type.
- create(int) - Method in class akka.stream.javadsl.MergePreferred$
-
Create a new MergePreferred
stage with the specified output type.
- create(Class<T>, int) - Method in class akka.stream.javadsl.MergePreferred$
-
Create a new MergePreferred
stage with the specified output type.
- create(int, boolean) - Method in class akka.stream.javadsl.MergePreferred$
-
Create a new MergePreferred
stage with the specified output type.
- create(Class<T>, int, boolean) - Method in class akka.stream.javadsl.MergePreferred$
-
Create a new MergePreferred
stage with the specified output type.
- create(int) - Static method in class akka.stream.javadsl.MergePreferred
-
Create a new MergePreferred
stage with the specified output type.
- create(Class<T>, int) - Static method in class akka.stream.javadsl.MergePreferred
-
Create a new MergePreferred
stage with the specified output type.
- create(int, boolean) - Static method in class akka.stream.javadsl.MergePreferred
-
Create a new MergePreferred
stage with the specified output type.
- create(Class<T>, int, boolean) - Static method in class akka.stream.javadsl.MergePreferred
-
Create a new MergePreferred
stage with the specified output type.
- create(int, Function<T, Object>) - Method in class akka.stream.javadsl.Partition$
-
Create a new Partition
stage with the specified input type.
- create(Class<T>, int, Function<T, Object>) - Method in class akka.stream.javadsl.Partition$
-
Create a new Partition
stage with the specified input type.
- create(int, Function<T, Object>) - Static method in class akka.stream.javadsl.Partition
-
Create a new Partition
stage with the specified input type.
- create(Class<T>, int, Function<T, Object>) - Static method in class akka.stream.javadsl.Partition
-
Create a new Partition
stage with the specified input type.
- create(SSLContext, Optional<AkkaSSLConfig>, TLSProtocol.NegotiateNewSession, TLSRole) - Method in class akka.stream.javadsl.TLS$
-
Create a StreamTls
BidiFlow
in client mode.
- create(SSLContext, TLSProtocol.NegotiateNewSession, TLSRole) - Method in class akka.stream.javadsl.TLS$
-
Create a StreamTls
BidiFlow
in client mode.
- create(SSLContext, Optional<AkkaSSLConfig>, TLSProtocol.NegotiateNewSession, TLSRole, Optional<Pair<String, Integer>>, TLSClosing) - Method in class akka.stream.javadsl.TLS$
-
Create a StreamTls
BidiFlow
in client mode.
- create(SSLContext, TLSProtocol.NegotiateNewSession, TLSRole, Optional<Pair<String, Integer>>, TLSClosing) - Method in class akka.stream.javadsl.TLS$
-
Create a StreamTls
BidiFlow
in client mode.
- create(Supplier<SSLEngine>, Consumer<SSLSession>, TLSClosing) - Method in class akka.stream.javadsl.TLS$
-
- create(Supplier<SSLEngine>, TLSClosing) - Method in class akka.stream.javadsl.TLS$
-
- create(SSLContext, Optional<AkkaSSLConfig>, TLSProtocol.NegotiateNewSession, TLSRole) - Static method in class akka.stream.javadsl.TLS
-
Create a StreamTls
BidiFlow
in client mode.
- create(SSLContext, TLSProtocol.NegotiateNewSession, TLSRole) - Static method in class akka.stream.javadsl.TLS
-
Create a StreamTls
BidiFlow
in client mode.
- create(SSLContext, Optional<AkkaSSLConfig>, TLSProtocol.NegotiateNewSession, TLSRole, Optional<Pair<String, Integer>>, TLSClosing) - Static method in class akka.stream.javadsl.TLS
-
Create a StreamTls
BidiFlow
in client mode.
- create(SSLContext, TLSProtocol.NegotiateNewSession, TLSRole, Optional<Pair<String, Integer>>, TLSClosing) - Static method in class akka.stream.javadsl.TLS
-
Create a StreamTls
BidiFlow
in client mode.
- create(Supplier<SSLEngine>, Consumer<SSLSession>, TLSClosing) - Static method in class akka.stream.javadsl.TLS
-
- create(Supplier<SSLEngine>, TLSClosing) - Static method in class akka.stream.javadsl.TLS
-
- create() - Method in class akka.stream.javadsl.Unzip$
-
Creates a new Unzip
stage with the specified output types.
- create(Class<A>, Class<B>) - Method in class akka.stream.javadsl.Unzip$
-
Creates a new Unzip
stage with the specified output types.
- create() - Static method in class akka.stream.javadsl.Unzip
-
Creates a new Unzip
stage with the specified output types.
- create(Class<A>, Class<B>) - Static method in class akka.stream.javadsl.Unzip
-
Creates a new Unzip
stage with the specified output types.
- create(Function<In, Pair<A, B>>) - Method in class akka.stream.javadsl.UnzipWith$
-
Create a new UnzipWith
vertex with the specified input type and unzipping-function f
.
- create(Function<In, Pair<A, B>>) - Static method in class akka.stream.javadsl.UnzipWith
-
Create a new UnzipWith
vertex with the specified input type and unzipping-function f
.
- create() - Method in class akka.stream.javadsl.Zip$
-
Create a new Zip
stage with the specified input types and zipping-function
which creates akka.japi.Pair
s.
- create() - Static method in class akka.stream.javadsl.Zip
-
Create a new Zip
stage with the specified input types and zipping-function
which creates akka.japi.Pair
s.
- create(int) - Method in class akka.stream.javadsl.ZipN$
-
- create(int) - Static method in class akka.stream.javadsl.ZipN
-
- create(Function2<A, B, Out>) - Method in class akka.stream.javadsl.ZipWith$
-
Create a new ZipWith
vertex with the specified input types and zipping-function f
.
- create(Function2<A, B, Out>) - Static method in class akka.stream.javadsl.ZipWith
-
Create a new ZipWith
vertex with the specified input types and zipping-function f
.
- create(Function<List<A>, O>, int) - Method in class akka.stream.javadsl.ZipWithN$
-
- create(Function<List<A>, O>, int) - Static method in class akka.stream.javadsl.ZipWithN
-
- create(String) - Method in class akka.stream.Outlet$
-
JAVA API
- create(String) - Static method in class akka.stream.Outlet
-
JAVA API
- create(Function1<GraphDSL.Builder<NotUsed>, S>) - Method in interface akka.stream.scaladsl.GraphApply
-
- create(Graph<Shape, Mat>, Function1<GraphDSL.Builder<Mat>, Function1<Shape, S>>) - Method in interface akka.stream.scaladsl.GraphApply
-
Creates a new
Graph
by importing the given graph
g1
and passing its
Shape
along with the
GraphDSL.Builder
to the given create function.
- create(Graph<Shape, M1>, Graph<Shape, M2>, Function2<M1, M2, Mat>, Function1<GraphDSL.Builder<Mat>, Function2<Shape, Shape, S>>) - Method in interface akka.stream.scaladsl.GraphApply
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Function3<M1, M2, M3, Mat>, Function1<GraphDSL.Builder<Mat>, Function3<Shape, Shape, Shape, S>>) - Method in interface akka.stream.scaladsl.GraphApply
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Function4<M1, M2, M3, M4, Mat>, Function1<GraphDSL.Builder<Mat>, Function4<Shape, Shape, Shape, Shape, S>>) - Method in interface akka.stream.scaladsl.GraphApply
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Function5<M1, M2, M3, M4, M5, Mat>, Function1<GraphDSL.Builder<Mat>, Function5<Shape, Shape, Shape, Shape, Shape, S>>) - Method in interface akka.stream.scaladsl.GraphApply
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Function6<M1, M2, M3, M4, M5, M6, Mat>, Function1<GraphDSL.Builder<Mat>, Function6<Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Method in interface akka.stream.scaladsl.GraphApply
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Function7<M1, M2, M3, M4, M5, M6, M7, Mat>, Function1<GraphDSL.Builder<Mat>, Function7<Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Method in interface akka.stream.scaladsl.GraphApply
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Function8<M1, M2, M3, M4, M5, M6, M7, M8, Mat>, Function1<GraphDSL.Builder<Mat>, Function8<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Method in interface akka.stream.scaladsl.GraphApply
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Function9<M1, M2, M3, M4, M5, M6, M7, M8, M9, Mat>, Function1<GraphDSL.Builder<Mat>, Function9<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Method in interface akka.stream.scaladsl.GraphApply
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Graph<Shape, M10>, Function10<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, Mat>, Function1<GraphDSL.Builder<Mat>, Function10<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Method in interface akka.stream.scaladsl.GraphApply
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Graph<Shape, M10>, Graph<Shape, M11>, Function11<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, Mat>, Function1<GraphDSL.Builder<Mat>, Function11<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Method in interface akka.stream.scaladsl.GraphApply
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Graph<Shape, M10>, Graph<Shape, M11>, Graph<Shape, M12>, Function12<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, Mat>, Function1<GraphDSL.Builder<Mat>, Function12<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Method in interface akka.stream.scaladsl.GraphApply
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Graph<Shape, M10>, Graph<Shape, M11>, Graph<Shape, M12>, Graph<Shape, M13>, Function13<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, Mat>, Function1<GraphDSL.Builder<Mat>, Function13<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Method in interface akka.stream.scaladsl.GraphApply
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Graph<Shape, M10>, Graph<Shape, M11>, Graph<Shape, M12>, Graph<Shape, M13>, Graph<Shape, M14>, Function14<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, Mat>, Function1<GraphDSL.Builder<Mat>, Function14<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Method in interface akka.stream.scaladsl.GraphApply
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Graph<Shape, M10>, Graph<Shape, M11>, Graph<Shape, M12>, Graph<Shape, M13>, Graph<Shape, M14>, Graph<Shape, M15>, Function15<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, Mat>, Function1<GraphDSL.Builder<Mat>, Function15<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Method in interface akka.stream.scaladsl.GraphApply
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Graph<Shape, M10>, Graph<Shape, M11>, Graph<Shape, M12>, Graph<Shape, M13>, Graph<Shape, M14>, Graph<Shape, M15>, Graph<Shape, M16>, Function16<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M16, Mat>, Function1<GraphDSL.Builder<Mat>, Function16<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Method in interface akka.stream.scaladsl.GraphApply
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Graph<Shape, M10>, Graph<Shape, M11>, Graph<Shape, M12>, Graph<Shape, M13>, Graph<Shape, M14>, Graph<Shape, M15>, Graph<Shape, M16>, Graph<Shape, M17>, Function17<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M16, M17, Mat>, Function1<GraphDSL.Builder<Mat>, Function17<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Method in interface akka.stream.scaladsl.GraphApply
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Graph<Shape, M10>, Graph<Shape, M11>, Graph<Shape, M12>, Graph<Shape, M13>, Graph<Shape, M14>, Graph<Shape, M15>, Graph<Shape, M16>, Graph<Shape, M17>, Graph<Shape, M18>, Function18<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M16, M17, M18, Mat>, Function1<GraphDSL.Builder<Mat>, Function18<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Method in interface akka.stream.scaladsl.GraphApply
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Graph<Shape, M10>, Graph<Shape, M11>, Graph<Shape, M12>, Graph<Shape, M13>, Graph<Shape, M14>, Graph<Shape, M15>, Graph<Shape, M16>, Graph<Shape, M17>, Graph<Shape, M18>, Graph<Shape, M19>, Function19<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M16, M17, M18, M19, Mat>, Function1<GraphDSL.Builder<Mat>, Function19<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Method in interface akka.stream.scaladsl.GraphApply
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Graph<Shape, M10>, Graph<Shape, M11>, Graph<Shape, M12>, Graph<Shape, M13>, Graph<Shape, M14>, Graph<Shape, M15>, Graph<Shape, M16>, Graph<Shape, M17>, Graph<Shape, M18>, Graph<Shape, M19>, Graph<Shape, M20>, Function20<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M16, M17, M18, M19, M20, Mat>, Function1<GraphDSL.Builder<Mat>, Function20<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Method in interface akka.stream.scaladsl.GraphApply
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Graph<Shape, M10>, Graph<Shape, M11>, Graph<Shape, M12>, Graph<Shape, M13>, Graph<Shape, M14>, Graph<Shape, M15>, Graph<Shape, M16>, Graph<Shape, M17>, Graph<Shape, M18>, Graph<Shape, M19>, Graph<Shape, M20>, Graph<Shape, M21>, Function21<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M16, M17, M18, M19, M20, M21, Mat>, Function1<GraphDSL.Builder<Mat>, Function21<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Method in interface akka.stream.scaladsl.GraphApply
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Graph<Shape, M10>, Graph<Shape, M11>, Graph<Shape, M12>, Graph<Shape, M13>, Graph<Shape, M14>, Graph<Shape, M15>, Graph<Shape, M16>, Graph<Shape, M17>, Graph<Shape, M18>, Graph<Shape, M19>, Graph<Shape, M20>, Graph<Shape, M21>, Graph<Shape, M22>, Function22<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M16, M17, M18, M19, M20, M21, M22, Mat>, Function1<GraphDSL.Builder<Mat>, Function22<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Method in interface akka.stream.scaladsl.GraphApply
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create(Function1<<any>, S>) - Static method in class akka.stream.scaladsl.GraphDSL
-
- create(Graph<Shape, Mat>, Function1<<any>, Function1<Shape, S>>) - Static method in class akka.stream.scaladsl.GraphDSL
-
- create(Graph<Shape, M1>, Graph<Shape, M2>, Function2<M1, M2, Mat>, Function1<<any>, Function2<Shape, Shape, S>>) - Static method in class akka.stream.scaladsl.GraphDSL
-
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Function3<M1, M2, M3, Mat>, Function1<<any>, Function3<Shape, Shape, Shape, S>>) - Static method in class akka.stream.scaladsl.GraphDSL
-
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Function4<M1, M2, M3, M4, Mat>, Function1<<any>, Function4<Shape, Shape, Shape, Shape, S>>) - Static method in class akka.stream.scaladsl.GraphDSL
-
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Function5<M1, M2, M3, M4, M5, Mat>, Function1<<any>, Function5<Shape, Shape, Shape, Shape, Shape, S>>) - Static method in class akka.stream.scaladsl.GraphDSL
-
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Function6<M1, M2, M3, M4, M5, M6, Mat>, Function1<<any>, Function6<Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Static method in class akka.stream.scaladsl.GraphDSL
-
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Function7<M1, M2, M3, M4, M5, M6, M7, Mat>, Function1<<any>, Function7<Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Static method in class akka.stream.scaladsl.GraphDSL
-
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Function8<M1, M2, M3, M4, M5, M6, M7, M8, Mat>, Function1<<any>, Function8<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Static method in class akka.stream.scaladsl.GraphDSL
-
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Function9<M1, M2, M3, M4, M5, M6, M7, M8, M9, Mat>, Function1<<any>, Function9<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Static method in class akka.stream.scaladsl.GraphDSL
-
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Graph<Shape, M10>, Function10<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, Mat>, Function1<<any>, Function10<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Static method in class akka.stream.scaladsl.GraphDSL
-
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Graph<Shape, M10>, Graph<Shape, M11>, Function11<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, Mat>, Function1<<any>, Function11<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Static method in class akka.stream.scaladsl.GraphDSL
-
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Graph<Shape, M10>, Graph<Shape, M11>, Graph<Shape, M12>, Function12<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, Mat>, Function1<<any>, Function12<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Static method in class akka.stream.scaladsl.GraphDSL
-
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Graph<Shape, M10>, Graph<Shape, M11>, Graph<Shape, M12>, Graph<Shape, M13>, Function13<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, Mat>, Function1<<any>, Function13<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Static method in class akka.stream.scaladsl.GraphDSL
-
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Graph<Shape, M10>, Graph<Shape, M11>, Graph<Shape, M12>, Graph<Shape, M13>, Graph<Shape, M14>, Function14<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, Mat>, Function1<<any>, Function14<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Static method in class akka.stream.scaladsl.GraphDSL
-
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Graph<Shape, M10>, Graph<Shape, M11>, Graph<Shape, M12>, Graph<Shape, M13>, Graph<Shape, M14>, Graph<Shape, M15>, Function15<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, Mat>, Function1<<any>, Function15<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Static method in class akka.stream.scaladsl.GraphDSL
-
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Graph<Shape, M10>, Graph<Shape, M11>, Graph<Shape, M12>, Graph<Shape, M13>, Graph<Shape, M14>, Graph<Shape, M15>, Graph<Shape, M16>, Function16<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M16, Mat>, Function1<<any>, Function16<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Static method in class akka.stream.scaladsl.GraphDSL
-
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Graph<Shape, M10>, Graph<Shape, M11>, Graph<Shape, M12>, Graph<Shape, M13>, Graph<Shape, M14>, Graph<Shape, M15>, Graph<Shape, M16>, Graph<Shape, M17>, Function17<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M16, M17, Mat>, Function1<<any>, Function17<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Static method in class akka.stream.scaladsl.GraphDSL
-
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Graph<Shape, M10>, Graph<Shape, M11>, Graph<Shape, M12>, Graph<Shape, M13>, Graph<Shape, M14>, Graph<Shape, M15>, Graph<Shape, M16>, Graph<Shape, M17>, Graph<Shape, M18>, Function18<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M16, M17, M18, Mat>, Function1<<any>, Function18<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Static method in class akka.stream.scaladsl.GraphDSL
-
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Graph<Shape, M10>, Graph<Shape, M11>, Graph<Shape, M12>, Graph<Shape, M13>, Graph<Shape, M14>, Graph<Shape, M15>, Graph<Shape, M16>, Graph<Shape, M17>, Graph<Shape, M18>, Graph<Shape, M19>, Function19<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M16, M17, M18, M19, Mat>, Function1<<any>, Function19<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Static method in class akka.stream.scaladsl.GraphDSL
-
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Graph<Shape, M10>, Graph<Shape, M11>, Graph<Shape, M12>, Graph<Shape, M13>, Graph<Shape, M14>, Graph<Shape, M15>, Graph<Shape, M16>, Graph<Shape, M17>, Graph<Shape, M18>, Graph<Shape, M19>, Graph<Shape, M20>, Function20<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M16, M17, M18, M19, M20, Mat>, Function1<<any>, Function20<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Static method in class akka.stream.scaladsl.GraphDSL
-
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Graph<Shape, M10>, Graph<Shape, M11>, Graph<Shape, M12>, Graph<Shape, M13>, Graph<Shape, M14>, Graph<Shape, M15>, Graph<Shape, M16>, Graph<Shape, M17>, Graph<Shape, M18>, Graph<Shape, M19>, Graph<Shape, M20>, Graph<Shape, M21>, Function21<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M16, M17, M18, M19, M20, M21, Mat>, Function1<<any>, Function21<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Static method in class akka.stream.scaladsl.GraphDSL
-
- create(Graph<Shape, M1>, Graph<Shape, M2>, Graph<Shape, M3>, Graph<Shape, M4>, Graph<Shape, M5>, Graph<Shape, M6>, Graph<Shape, M7>, Graph<Shape, M8>, Graph<Shape, M9>, Graph<Shape, M10>, Graph<Shape, M11>, Graph<Shape, M12>, Graph<Shape, M13>, Graph<Shape, M14>, Graph<Shape, M15>, Graph<Shape, M16>, Graph<Shape, M17>, Graph<Shape, M18>, Graph<Shape, M19>, Graph<Shape, M20>, Graph<Shape, M21>, Graph<Shape, M22>, Function22<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M16, M17, M18, M19, M20, M21, M22, Mat>, Function1<<any>, Function22<Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, Shape, S>>) - Static method in class akka.stream.scaladsl.GraphDSL
-
- create(Function1<In, Out>) - Method in interface akka.stream.scaladsl.UnzipWithApply.UnzipWithCreator
-
- create(Function1<In, Tuple10<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10>>) - Method in interface akka.stream.scaladsl.UnzipWithApply.UnzipWithCreator10
-
- create(Function1<In, Tuple11<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11>>) - Method in interface akka.stream.scaladsl.UnzipWithApply.UnzipWithCreator11
-
- create(Function1<In, Tuple12<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12>>) - Method in interface akka.stream.scaladsl.UnzipWithApply.UnzipWithCreator12
-
- create(Function1<In, Tuple13<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13>>) - Method in interface akka.stream.scaladsl.UnzipWithApply.UnzipWithCreator13
-
- create(Function1<In, Tuple14<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14>>) - Method in interface akka.stream.scaladsl.UnzipWithApply.UnzipWithCreator14
-
- create(Function1<In, Tuple15<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15>>) - Method in interface akka.stream.scaladsl.UnzipWithApply.UnzipWithCreator15
-
- create(Function1<In, Tuple16<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16>>) - Method in interface akka.stream.scaladsl.UnzipWithApply.UnzipWithCreator16
-
- create(Function1<In, Tuple17<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17>>) - Method in interface akka.stream.scaladsl.UnzipWithApply.UnzipWithCreator17
-
- create(Function1<In, Tuple18<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18>>) - Method in interface akka.stream.scaladsl.UnzipWithApply.UnzipWithCreator18
-
- create(Function1<In, Tuple19<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19>>) - Method in interface akka.stream.scaladsl.UnzipWithApply.UnzipWithCreator19
-
- create(Function1<In, Tuple2<A1, A2>>) - Method in interface akka.stream.scaladsl.UnzipWithApply.UnzipWithCreator2
-
- create(Function1<In, Tuple20<A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19, A20>>) - Method in interface akka.stream.scaladsl.UnzipWithApply.UnzipWithCreator20
-
- create(Function1<In, Tuple3<A1, A2, A3>>) - Method in interface akka.stream.scaladsl.UnzipWithApply.UnzipWithCreator3
-
- create(Function1<In, Tuple4<A1, A2, A3, A4>>) - Method in interface akka.stream.scaladsl.UnzipWithApply.UnzipWithCreator4
-
- create(Function1<In, Tuple5<A1, A2, A3, A4, A5>>) - Method in interface akka.stream.scaladsl.UnzipWithApply.UnzipWithCreator5
-
- create(Function1<In, Tuple6<A1, A2, A3, A4, A5, A6>>) - Method in interface akka.stream.scaladsl.UnzipWithApply.UnzipWithCreator6
-
- create(Function1<In, Tuple7<A1, A2, A3, A4, A5, A6, A7>>) - Method in interface akka.stream.scaladsl.UnzipWithApply.UnzipWithCreator7
-
- create(Function1<In, Tuple8<A1, A2, A3, A4, A5, A6, A7, A8>>) - Method in interface akka.stream.scaladsl.UnzipWithApply.UnzipWithCreator8
-
- create(Function1<In, Tuple9<A1, A2, A3, A4, A5, A6, A7, A8, A9>>) - Method in interface akka.stream.scaladsl.UnzipWithApply.UnzipWithCreator9
-
- create(StreamSubscriptionTimeoutTerminationMode, FiniteDuration) - Method in class akka.stream.StreamSubscriptionTimeoutSettings$
-
Create settings from individual values (Java).
- create(Config) - Method in class akka.stream.StreamSubscriptionTimeoutSettings$
-
Create settings from a Config subsection (Java).
- create(StreamSubscriptionTimeoutTerminationMode, FiniteDuration) - Static method in class akka.stream.StreamSubscriptionTimeoutSettings
-
Create settings from individual values (Java).
- create(Config) - Static method in class akka.stream.StreamSubscriptionTimeoutSettings
-
Create settings from a Config subsection (Java).
- create(MaterializationContext) - Method in class akka.stream.testkit.StreamTestKit.ProbeSink
-
- create(MaterializationContext) - Method in class akka.stream.testkit.StreamTestKit.ProbeSource
-
- create(ActorSystem, Props, ActorRef, String) - Method in class akka.testkit.TestActorRef$
-
Java API: create a TestActorRef in the given system for the given props,
with the given supervisor and name.
- create(ActorSystem, Props, ActorRef) - Method in class akka.testkit.TestActorRef$
-
Java API: create a TestActorRef in the given system for the given props,
with the given supervisor and a random name.
- 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, ActorRef, String) - Static method in class akka.testkit.TestActorRef
-
Java API: create a TestActorRef in the given system for the given props,
with the given supervisor and name.
- create(ActorSystem, Props, ActorRef) - Static method in class akka.testkit.TestActorRef
-
Java API: create a TestActorRef in the given system for the given props,
with the given supervisor and 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.typed.internal
-
INTERNAL API
- Create() - Constructor for class akka.typed.internal.Create
-
- create() - Method in interface akka.typed.internal.SupervisionMechanics
-
- Create$ - Class in akka.dispatch.sysmsg
-
- Create$() - Constructor for class akka.dispatch.sysmsg.Create$
-
- Create$ - Class in akka.typed.internal
-
- Create$() - Constructor for class akka.typed.internal.Create$
-
- create10(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Graph<S9, M9>, Graph<S10, M10>, Function10<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M>, Function11<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S9, S10, S>) - Method in class akka.stream.javadsl.GraphCreate
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create10(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Graph<S9, M9>, Graph<S10, M10>, Function10<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M>, Function11<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S9, S10, S>) - Static method in class akka.stream.javadsl.GraphDSL
-
- create10(Function<In, Tuple10<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10>>) - Method in class akka.stream.javadsl.UnzipWith$
-
Create a new UnzipWith
specialized for 10 outputs.
- create10(Function<In, Tuple10<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10>>) - Static method in class akka.stream.javadsl.UnzipWith
-
Create a new UnzipWith
specialized for 10 outputs.
- create10(Function10<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, Out>) - Method in class akka.stream.javadsl.ZipWith$
-
Create a new ZipWith
specialized for 10 inputs.
- create10(Function10<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, Out>) - Static method in class akka.stream.javadsl.ZipWith
-
Create a new ZipWith
specialized for 10 inputs.
- create11(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Graph<S9, M9>, Graph<S10, M10>, Graph<S11, M11>, Function11<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M>, Function12<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S9, S10, S11, S>) - Method in class akka.stream.javadsl.GraphCreate
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create11(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Graph<S9, M9>, Graph<S10, M10>, Graph<S11, M11>, Function11<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M>, Function12<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S9, S10, S11, S>) - Static method in class akka.stream.javadsl.GraphDSL
-
- create11(Function<In, Tuple11<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11>>) - Method in class akka.stream.javadsl.UnzipWith$
-
Create a new UnzipWith
specialized for 11 outputs.
- create11(Function<In, Tuple11<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11>>) - Static method in class akka.stream.javadsl.UnzipWith
-
Create a new UnzipWith
specialized for 11 outputs.
- create11(Function11<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, Out>) - Method in class akka.stream.javadsl.ZipWith$
-
Create a new ZipWith
specialized for 11 inputs.
- create11(Function11<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, Out>) - Static method in class akka.stream.javadsl.ZipWith
-
Create a new ZipWith
specialized for 11 inputs.
- create12(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Graph<S9, M9>, Graph<S10, M10>, Graph<S11, M11>, Graph<S12, M12>, Function12<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M>, Function13<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S9, S10, S11, S12, S>) - Method in class akka.stream.javadsl.GraphCreate
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create12(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Graph<S9, M9>, Graph<S10, M10>, Graph<S11, M11>, Graph<S12, M12>, Function12<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M>, Function13<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S9, S10, S11, S12, S>) - Static method in class akka.stream.javadsl.GraphDSL
-
- create12(Function<In, Tuple12<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12>>) - Method in class akka.stream.javadsl.UnzipWith$
-
Create a new UnzipWith
specialized for 12 outputs.
- create12(Function<In, Tuple12<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12>>) - Static method in class akka.stream.javadsl.UnzipWith
-
Create a new UnzipWith
specialized for 12 outputs.
- create12(Function12<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, Out>) - Method in class akka.stream.javadsl.ZipWith$
-
Create a new ZipWith
specialized for 12 inputs.
- create12(Function12<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, Out>) - Static method in class akka.stream.javadsl.ZipWith
-
Create a new ZipWith
specialized for 12 inputs.
- create13(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Graph<S9, M9>, Graph<S10, M10>, Graph<S11, M11>, Graph<S12, M12>, Graph<S13, M13>, Function13<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M>, Function14<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S9, S10, S11, S12, S13, S>) - Method in class akka.stream.javadsl.GraphCreate
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create13(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Graph<S9, M9>, Graph<S10, M10>, Graph<S11, M11>, Graph<S12, M12>, Graph<S13, M13>, Function13<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M>, Function14<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S9, S10, S11, S12, S13, S>) - Static method in class akka.stream.javadsl.GraphDSL
-
- create13(Function<In, Tuple13<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13>>) - Method in class akka.stream.javadsl.UnzipWith$
-
Create a new UnzipWith
specialized for 13 outputs.
- create13(Function<In, Tuple13<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13>>) - Static method in class akka.stream.javadsl.UnzipWith
-
Create a new UnzipWith
specialized for 13 outputs.
- create13(Function13<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, Out>) - Method in class akka.stream.javadsl.ZipWith$
-
Create a new ZipWith
specialized for 13 inputs.
- create13(Function13<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, Out>) - Static method in class akka.stream.javadsl.ZipWith
-
Create a new ZipWith
specialized for 13 inputs.
- create14(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Graph<S9, M9>, Graph<S10, M10>, Graph<S11, M11>, Graph<S12, M12>, Graph<S13, M13>, Graph<S14, M14>, Function14<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M>, Function15<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S9, S10, S11, S12, S13, S14, S>) - Method in class akka.stream.javadsl.GraphCreate
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create14(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Graph<S9, M9>, Graph<S10, M10>, Graph<S11, M11>, Graph<S12, M12>, Graph<S13, M13>, Graph<S14, M14>, Function14<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M>, Function15<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S9, S10, S11, S12, S13, S14, S>) - Static method in class akka.stream.javadsl.GraphDSL
-
- create14(Function<In, Tuple14<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14>>) - Method in class akka.stream.javadsl.UnzipWith$
-
Create a new UnzipWith
specialized for 14 outputs.
- create14(Function<In, Tuple14<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14>>) - Static method in class akka.stream.javadsl.UnzipWith
-
Create a new UnzipWith
specialized for 14 outputs.
- create14(Function14<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, Out>) - Method in class akka.stream.javadsl.ZipWith$
-
Create a new ZipWith
specialized for 14 inputs.
- create14(Function14<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, Out>) - Static method in class akka.stream.javadsl.ZipWith
-
Create a new ZipWith
specialized for 14 inputs.
- create15(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Graph<S9, M9>, Graph<S10, M10>, Graph<S11, M11>, Graph<S12, M12>, Graph<S13, M13>, Graph<S14, M14>, Graph<S15, M15>, Function15<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M>, Function16<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S9, S10, S11, S12, S13, S14, S15, S>) - Method in class akka.stream.javadsl.GraphCreate
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create15(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Graph<S9, M9>, Graph<S10, M10>, Graph<S11, M11>, Graph<S12, M12>, Graph<S13, M13>, Graph<S14, M14>, Graph<S15, M15>, Function15<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M>, Function16<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S9, S10, S11, S12, S13, S14, S15, S>) - Static method in class akka.stream.javadsl.GraphDSL
-
- create15(Function<In, Tuple15<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15>>) - Method in class akka.stream.javadsl.UnzipWith$
-
Create a new UnzipWith
specialized for 15 outputs.
- create15(Function<In, Tuple15<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15>>) - Static method in class akka.stream.javadsl.UnzipWith
-
Create a new UnzipWith
specialized for 15 outputs.
- create15(Function15<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, Out>) - Method in class akka.stream.javadsl.ZipWith$
-
Create a new ZipWith
specialized for 15 inputs.
- create15(Function15<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, Out>) - Static method in class akka.stream.javadsl.ZipWith
-
Create a new ZipWith
specialized for 15 inputs.
- create16(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Graph<S9, M9>, Graph<S10, M10>, Graph<S11, M11>, Graph<S12, M12>, Graph<S13, M13>, Graph<S14, M14>, Graph<S15, M15>, Graph<S16, M16>, Function16<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M16, M>, Function17<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S9, S10, S11, S12, S13, S14, S15, S16, S>) - Method in class akka.stream.javadsl.GraphCreate
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create16(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Graph<S9, M9>, Graph<S10, M10>, Graph<S11, M11>, Graph<S12, M12>, Graph<S13, M13>, Graph<S14, M14>, Graph<S15, M15>, Graph<S16, M16>, Function16<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M16, M>, Function17<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S9, S10, S11, S12, S13, S14, S15, S16, S>) - Static method in class akka.stream.javadsl.GraphDSL
-
- create16(Function<In, Tuple16<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16>>) - Method in class akka.stream.javadsl.UnzipWith$
-
Create a new UnzipWith
specialized for 16 outputs.
- create16(Function<In, Tuple16<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16>>) - Static method in class akka.stream.javadsl.UnzipWith
-
Create a new UnzipWith
specialized for 16 outputs.
- create16(Function16<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, Out>) - Method in class akka.stream.javadsl.ZipWith$
-
Create a new ZipWith
specialized for 16 inputs.
- create16(Function16<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, Out>) - Static method in class akka.stream.javadsl.ZipWith
-
Create a new ZipWith
specialized for 16 inputs.
- create17(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Graph<S9, M9>, Graph<S10, M10>, Graph<S11, M11>, Graph<S12, M12>, Graph<S13, M13>, Graph<S14, M14>, Graph<S15, M15>, Graph<S16, M16>, Graph<S17, M17>, Function17<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M16, M17, M>, Function18<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S9, S10, S11, S12, S13, S14, S15, S16, S17, S>) - Method in class akka.stream.javadsl.GraphCreate
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create17(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Graph<S9, M9>, Graph<S10, M10>, Graph<S11, M11>, Graph<S12, M12>, Graph<S13, M13>, Graph<S14, M14>, Graph<S15, M15>, Graph<S16, M16>, Graph<S17, M17>, Function17<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M16, M17, M>, Function18<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S9, S10, S11, S12, S13, S14, S15, S16, S17, S>) - Static method in class akka.stream.javadsl.GraphDSL
-
- create17(Function<In, Tuple17<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17>>) - Method in class akka.stream.javadsl.UnzipWith$
-
Create a new UnzipWith
specialized for 17 outputs.
- create17(Function<In, Tuple17<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17>>) - Static method in class akka.stream.javadsl.UnzipWith
-
Create a new UnzipWith
specialized for 17 outputs.
- create17(Function17<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, Out>) - Method in class akka.stream.javadsl.ZipWith$
-
Create a new ZipWith
specialized for 17 inputs.
- create17(Function17<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, Out>) - Static method in class akka.stream.javadsl.ZipWith
-
Create a new ZipWith
specialized for 17 inputs.
- create18(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Graph<S9, M9>, Graph<S10, M10>, Graph<S11, M11>, Graph<S12, M12>, Graph<S13, M13>, Graph<S14, M14>, Graph<S15, M15>, Graph<S16, M16>, Graph<S17, M17>, Graph<S18, M18>, Function18<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M16, M17, M18, M>, Function19<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S9, S10, S11, S12, S13, S14, S15, S16, S17, S18, S>) - Method in class akka.stream.javadsl.GraphCreate
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create18(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Graph<S9, M9>, Graph<S10, M10>, Graph<S11, M11>, Graph<S12, M12>, Graph<S13, M13>, Graph<S14, M14>, Graph<S15, M15>, Graph<S16, M16>, Graph<S17, M17>, Graph<S18, M18>, Function18<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M16, M17, M18, M>, Function19<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S9, S10, S11, S12, S13, S14, S15, S16, S17, S18, S>) - Static method in class akka.stream.javadsl.GraphDSL
-
- create18(Function<In, Tuple18<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18>>) - Method in class akka.stream.javadsl.UnzipWith$
-
Create a new UnzipWith
specialized for 18 outputs.
- create18(Function<In, Tuple18<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18>>) - Static method in class akka.stream.javadsl.UnzipWith
-
Create a new UnzipWith
specialized for 18 outputs.
- create18(Function18<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, Out>) - Method in class akka.stream.javadsl.ZipWith$
-
Create a new ZipWith
specialized for 18 inputs.
- create18(Function18<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, Out>) - Static method in class akka.stream.javadsl.ZipWith
-
Create a new ZipWith
specialized for 18 inputs.
- create19(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Graph<S9, M9>, Graph<S10, M10>, Graph<S11, M11>, Graph<S12, M12>, Graph<S13, M13>, Graph<S14, M14>, Graph<S15, M15>, Graph<S16, M16>, Graph<S17, M17>, Graph<S18, M18>, Graph<S19, M19>, Function19<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M16, M17, M18, M19, M>, Function20<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S9, S10, S11, S12, S13, S14, S15, S16, S17, S18, S19, S>) - Method in class akka.stream.javadsl.GraphCreate
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create19(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Graph<S9, M9>, Graph<S10, M10>, Graph<S11, M11>, Graph<S12, M12>, Graph<S13, M13>, Graph<S14, M14>, Graph<S15, M15>, Graph<S16, M16>, Graph<S17, M17>, Graph<S18, M18>, Graph<S19, M19>, Function19<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M16, M17, M18, M19, M>, Function20<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S9, S10, S11, S12, S13, S14, S15, S16, S17, S18, S19, S>) - Static method in class akka.stream.javadsl.GraphDSL
-
- create19(Function<In, Tuple19<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19>>) - Method in class akka.stream.javadsl.UnzipWith$
-
Create a new UnzipWith
specialized for 19 outputs.
- create19(Function<In, Tuple19<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19>>) - Static method in class akka.stream.javadsl.UnzipWith
-
Create a new UnzipWith
specialized for 19 outputs.
- create19(Function19<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, Out>) - Method in class akka.stream.javadsl.ZipWith$
-
Create a new ZipWith
specialized for 19 inputs.
- create19(Function19<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, Out>) - Static method in class akka.stream.javadsl.ZipWith
-
Create a new ZipWith
specialized for 19 inputs.
- create20(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Graph<S9, M9>, Graph<S10, M10>, Graph<S11, M11>, Graph<S12, M12>, Graph<S13, M13>, Graph<S14, M14>, Graph<S15, M15>, Graph<S16, M16>, Graph<S17, M17>, Graph<S18, M18>, Graph<S19, M19>, Graph<S20, M20>, Function20<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M16, M17, M18, M19, M20, M>, Function21<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S9, S10, S11, S12, S13, S14, S15, S16, S17, S18, S19, S20, S>) - Method in class akka.stream.javadsl.GraphCreate
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create20(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Graph<S9, M9>, Graph<S10, M10>, Graph<S11, M11>, Graph<S12, M12>, Graph<S13, M13>, Graph<S14, M14>, Graph<S15, M15>, Graph<S16, M16>, Graph<S17, M17>, Graph<S18, M18>, Graph<S19, M19>, Graph<S20, M20>, Function20<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M16, M17, M18, M19, M20, M>, Function21<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S9, S10, S11, S12, S13, S14, S15, S16, S17, S18, S19, S20, S>) - Static method in class akka.stream.javadsl.GraphDSL
-
- create20(Function<In, Tuple20<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20>>) - Method in class akka.stream.javadsl.UnzipWith$
-
Create a new UnzipWith
specialized for 20 outputs.
- create20(Function<In, Tuple20<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20>>) - Static method in class akka.stream.javadsl.UnzipWith
-
Create a new UnzipWith
specialized for 20 outputs.
- create20(Function20<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, Out>) - Method in class akka.stream.javadsl.ZipWith$
-
Create a new ZipWith
specialized for 20 inputs.
- create20(Function20<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, Out>) - Static method in class akka.stream.javadsl.ZipWith
-
Create a new ZipWith
specialized for 20 inputs.
- create21(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Graph<S9, M9>, Graph<S10, M10>, Graph<S11, M11>, Graph<S12, M12>, Graph<S13, M13>, Graph<S14, M14>, Graph<S15, M15>, Graph<S16, M16>, Graph<S17, M17>, Graph<S18, M18>, Graph<S19, M19>, Graph<S20, M20>, Graph<S21, M21>, Function21<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M16, M17, M18, M19, M20, M21, M>, Function22<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S9, S10, S11, S12, S13, S14, S15, S16, S17, S18, S19, S20, S21, S>) - Method in class akka.stream.javadsl.GraphCreate
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create21(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Graph<S9, M9>, Graph<S10, M10>, Graph<S11, M11>, Graph<S12, M12>, Graph<S13, M13>, Graph<S14, M14>, Graph<S15, M15>, Graph<S16, M16>, Graph<S17, M17>, Graph<S18, M18>, Graph<S19, M19>, Graph<S20, M20>, Graph<S21, M21>, Function21<M1, M2, M3, M4, M5, M6, M7, M8, M9, M10, M11, M12, M13, M14, M15, M16, M17, M18, M19, M20, M21, M>, Function22<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S9, S10, S11, S12, S13, S14, S15, S16, S17, S18, S19, S20, S21, S>) - Static method in class akka.stream.javadsl.GraphDSL
-
- create3(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Function3<M1, M2, M3, M>, Function4<GraphDSL.Builder<M>, S1, S2, S3, S>) - Method in class akka.stream.javadsl.GraphCreate
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create3(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Function3<M1, M2, M3, M>, Function4<GraphDSL.Builder<M>, S1, S2, S3, S>) - Static method in class akka.stream.javadsl.GraphDSL
-
- create3(Function<In, Tuple3<T1, T2, T3>>) - Method in class akka.stream.javadsl.UnzipWith$
-
Create a new UnzipWith
specialized for 3 outputs.
- create3(Function<In, Tuple3<T1, T2, T3>>) - Static method in class akka.stream.javadsl.UnzipWith
-
Create a new UnzipWith
specialized for 3 outputs.
- create3(Function3<T1, T2, T3, Out>) - Method in class akka.stream.javadsl.ZipWith$
-
Create a new ZipWith
specialized for 3 inputs.
- create3(Function3<T1, T2, T3, Out>) - Static method in class akka.stream.javadsl.ZipWith
-
Create a new ZipWith
specialized for 3 inputs.
- create4(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Function4<M1, M2, M3, M4, M>, Function5<GraphDSL.Builder<M>, S1, S2, S3, S4, S>) - Method in class akka.stream.javadsl.GraphCreate
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create4(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Function4<M1, M2, M3, M4, M>, Function5<GraphDSL.Builder<M>, S1, S2, S3, S4, S>) - Static method in class akka.stream.javadsl.GraphDSL
-
- create4(Function<In, Tuple4<T1, T2, T3, T4>>) - Method in class akka.stream.javadsl.UnzipWith$
-
Create a new UnzipWith
specialized for 4 outputs.
- create4(Function<In, Tuple4<T1, T2, T3, T4>>) - Static method in class akka.stream.javadsl.UnzipWith
-
Create a new UnzipWith
specialized for 4 outputs.
- create4(Function4<T1, T2, T3, T4, Out>) - Method in class akka.stream.javadsl.ZipWith$
-
Create a new ZipWith
specialized for 4 inputs.
- create4(Function4<T1, T2, T3, T4, Out>) - Static method in class akka.stream.javadsl.ZipWith
-
Create a new ZipWith
specialized for 4 inputs.
- create5(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Function5<M1, M2, M3, M4, M5, M>, Function6<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S>) - Method in class akka.stream.javadsl.GraphCreate
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create5(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Function5<M1, M2, M3, M4, M5, M>, Function6<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S>) - Static method in class akka.stream.javadsl.GraphDSL
-
- create5(Function<In, Tuple5<T1, T2, T3, T4, T5>>) - Method in class akka.stream.javadsl.UnzipWith$
-
Create a new UnzipWith
specialized for 5 outputs.
- create5(Function<In, Tuple5<T1, T2, T3, T4, T5>>) - Static method in class akka.stream.javadsl.UnzipWith
-
Create a new UnzipWith
specialized for 5 outputs.
- create5(Function5<T1, T2, T3, T4, T5, Out>) - Method in class akka.stream.javadsl.ZipWith$
-
Create a new ZipWith
specialized for 5 inputs.
- create5(Function5<T1, T2, T3, T4, T5, Out>) - Static method in class akka.stream.javadsl.ZipWith
-
Create a new ZipWith
specialized for 5 inputs.
- create6(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Function6<M1, M2, M3, M4, M5, M6, M>, Function7<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S>) - Method in class akka.stream.javadsl.GraphCreate
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create6(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Function6<M1, M2, M3, M4, M5, M6, M>, Function7<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S>) - Static method in class akka.stream.javadsl.GraphDSL
-
- create6(Function<In, Tuple6<T1, T2, T3, T4, T5, T6>>) - Method in class akka.stream.javadsl.UnzipWith$
-
Create a new UnzipWith
specialized for 6 outputs.
- create6(Function<In, Tuple6<T1, T2, T3, T4, T5, T6>>) - Static method in class akka.stream.javadsl.UnzipWith
-
Create a new UnzipWith
specialized for 6 outputs.
- create6(Function6<T1, T2, T3, T4, T5, T6, Out>) - Method in class akka.stream.javadsl.ZipWith$
-
Create a new ZipWith
specialized for 6 inputs.
- create6(Function6<T1, T2, T3, T4, T5, T6, Out>) - Static method in class akka.stream.javadsl.ZipWith
-
Create a new ZipWith
specialized for 6 inputs.
- create7(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Function7<M1, M2, M3, M4, M5, M6, M7, M>, Function8<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S>) - Method in class akka.stream.javadsl.GraphCreate
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create7(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Function7<M1, M2, M3, M4, M5, M6, M7, M>, Function8<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S>) - Static method in class akka.stream.javadsl.GraphDSL
-
- create7(Function<In, Tuple7<T1, T2, T3, T4, T5, T6, T7>>) - Method in class akka.stream.javadsl.UnzipWith$
-
Create a new UnzipWith
specialized for 7 outputs.
- create7(Function<In, Tuple7<T1, T2, T3, T4, T5, T6, T7>>) - Static method in class akka.stream.javadsl.UnzipWith
-
Create a new UnzipWith
specialized for 7 outputs.
- create7(Function7<T1, T2, T3, T4, T5, T6, T7, Out>) - Method in class akka.stream.javadsl.ZipWith$
-
Create a new ZipWith
specialized for 7 inputs.
- create7(Function7<T1, T2, T3, T4, T5, T6, T7, Out>) - Static method in class akka.stream.javadsl.ZipWith
-
Create a new ZipWith
specialized for 7 inputs.
- create8(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Function8<M1, M2, M3, M4, M5, M6, M7, M8, M>, Function9<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S>) - Method in class akka.stream.javadsl.GraphCreate
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create8(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Function8<M1, M2, M3, M4, M5, M6, M7, M8, M>, Function9<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S>) - Static method in class akka.stream.javadsl.GraphDSL
-
- create8(Function<In, Tuple8<T1, T2, T3, T4, T5, T6, T7, T8>>) - Method in class akka.stream.javadsl.UnzipWith$
-
Create a new UnzipWith
specialized for 8 outputs.
- create8(Function<In, Tuple8<T1, T2, T3, T4, T5, T6, T7, T8>>) - Static method in class akka.stream.javadsl.UnzipWith
-
Create a new UnzipWith
specialized for 8 outputs.
- create8(Function8<T1, T2, T3, T4, T5, T6, T7, T8, Out>) - Method in class akka.stream.javadsl.ZipWith$
-
Create a new ZipWith
specialized for 8 inputs.
- create8(Function8<T1, T2, T3, T4, T5, T6, T7, T8, Out>) - Static method in class akka.stream.javadsl.ZipWith
-
Create a new ZipWith
specialized for 8 inputs.
- create9(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Graph<S9, M9>, Function9<M1, M2, M3, M4, M5, M6, M7, M8, M9, M>, Function10<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S9, S>) - Method in class akka.stream.javadsl.GraphCreate
-
Creates a new
Graph
by importing the given graphs and passing their
Shape
s
along with the
GraphDSL.Builder
to the given create function.
- create9(Graph<S1, M1>, Graph<S2, M2>, Graph<S3, M3>, Graph<S4, M4>, Graph<S5, M5>, Graph<S6, M6>, Graph<S7, M7>, Graph<S8, M8>, Graph<S9, M9>, Function9<M1, M2, M3, M4, M5, M6, M7, M8, M9, M>, Function10<GraphDSL.Builder<M>, S1, S2, S3, S4, S5, S6, S7, S8, S9, S>) - Static method in class akka.stream.javadsl.GraphDSL
-
- create9(Function<In, Tuple9<T1, T2, T3, T4, T5, T6, T7, T8, T9>>) - Method in class akka.stream.javadsl.UnzipWith$
-
Create a new UnzipWith
specialized for 9 outputs.
- create9(Function<In, Tuple9<T1, T2, T3, T4, T5, T6, T7, T8, T9>>) - Static method in class akka.stream.javadsl.UnzipWith
-
Create a new UnzipWith
specialized for 9 outputs.
- create9(Function9<T1, T2, T3, T4, T5, T6, T7, T8, T9, Out>) - Method in class akka.stream.javadsl.ZipWith$
-
Create a new ZipWith
specialized for 9 inputs.
- create9(Function9<T1, T2, T3, T4, T5, T6, T7, T8, T9, Out>) - Static method in class akka.stream.javadsl.ZipWith
-
Create a new ZipWith
specialized for 9 inputs.
- CREATE_VALUE - Static variable in enum akka.remote.SystemMessageFormats.SystemMessage.Type
-
CREATE = 0;
- 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
-
- createAsyncCallback(Procedure<T>) - Method in class akka.stream.stage.GraphStageLogic
-
Java API: Obtain a callback object that can be used asynchronously to re-enter the
current
GraphStage
with an asynchronous notification.
- createBuilder() - Method in class akka.util.ByteString$
-
Java API
- createBuilder() - Static method in class akka.util.ByteString
-
Java API
- createCatchReporter(Reporter) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- createCatchReporter(Reporter) - Static method in class akka.persistence.journal.JournalSpec
-
- createCatchReporter(Reporter) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- createChildren() - Method in class akka.cluster.ClusterCoreSupervisor
-
- createChildren() - Method in class akka.cluster.ClusterDaemon
-
- createConsumer(Processor) - Method in class akka.camel.internal.component.ActorEndpoint
-
The ActorEndpoint only supports receiving messages from Camel.
- createDecoder(ArterySettings, InboundCompressions, EnvelopeBufferPool) - Method in class akka.remote.artery.ArteryTransport
-
- 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
- createDeserializer(EnvelopeBufferPool) - Method in class akka.remote.artery.ArteryTransport
-
- 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.
- createEncoder(EnvelopeBufferPool) - Method in class akka.remote.artery.ArteryTransport
-
- createEndpoint(String, String, Map<String, Object>) - Method in class akka.camel.internal.component.ActorComponent
-
- createEventSink() - Method in class akka.remote.artery.FlightRecorder
-
- 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.ddata.DistributedData$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.cluster.ddata.DistributedData
-
- 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.journal.PersistencePluginProxyExtension$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.persistence.journal.PersistencePluginProxyExtension
-
- createExtension(ExtendedActorSystem) - Method in class akka.persistence.Persistence$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.persistence.Persistence
-
- createExtension(ExtendedActorSystem) - Method in class akka.persistence.query.PersistenceQuery$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.persistence.query.PersistenceQuery
-
- 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.serialization.ActorRefResolveThreadLocalCache$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.remote.serialization.ActorRefResolveThreadLocalCache
-
- 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.stream.actor.ActorPublisherState$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.stream.actor.ActorPublisherState
-
- createExtension(ExtendedActorSystem) - Method in class akka.stream.actor.ActorSubscriberState$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.stream.actor.ActorSubscriberState
-
- createExtension(ExtendedActorSystem) - Method in class akka.stream.impl.FlowNames$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.stream.impl.FlowNames
-
- createExtension(ExtendedActorSystem) - Method in class akka.stream.javadsl.Tcp$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.stream.javadsl.Tcp
-
- createExtension(ExtendedActorSystem) - Method in class akka.stream.scaladsl.Tcp$
-
- createExtension(ExtendedActorSystem) - Static method in class akka.stream.scaladsl.Tcp
-
- 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
-
- createExtension(ExtendedActorSystem) - Method in class com.typesafe.sslconfig.akka.AkkaSSLConfig$
-
- createExtension(ExtendedActorSystem) - Static method in class com.typesafe.sslconfig.akka.AkkaSSLConfig
-
- createFailed(long, Throwable) - Method in class akka.stream.IOResult$
-
JAVA API: Creates failed IOResult, `count` should be the number of bytes (or other unit, please document in your APIs) processed before failing
- createFailed(long, Throwable) - Static method in class akka.stream.IOResult
-
JAVA API: Creates failed IOResult, `count` should be the number of bytes (or other unit, please document in your APIs) processed before failing
- createFlightRecorderEventSink(boolean) - Method in class akka.remote.artery.ArteryTransport
-
- createFlightRecorderFile(String, FileSystem) - Method in class akka.remote.artery.FlightRecorder$
-
- createFlightRecorderFile(String, FileSystem) - Static method in class akka.remote.artery.FlightRecorder
-
- 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
-
- createIdleStrategy(int) - Method in class akka.remote.artery.TaskRunner$
-
- createIdleStrategy(int) - Static method in class akka.remote.artery.TaskRunner
-
- 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
-
- createLogic(Attributes) - Method in class akka.remote.artery.Deserializer
-
- createLogic(Attributes) - Method in class akka.remote.artery.InboundHandshake
-
- createLogic(Attributes) - Method in class akka.remote.artery.InboundQuarantineCheck
-
- createLogic(Attributes) - Method in class akka.remote.artery.InboundTestStage
-
- createLogic(Attributes) - Method in class akka.remote.artery.OutboundHandshake
-
- createLogic(Attributes) - Method in class akka.remote.artery.OutboundTestStage
-
- createLogic(Attributes) - Method in class akka.remote.artery.SystemMessageAcker
-
- createLogic(Attributes) - Method in class akka.remote.artery.SystemMessageDelivery
-
- createLogic(Attributes) - Method in class akka.stream.extra.Timed.StartTimed
-
Deprecated.
- createLogic(Attributes) - Method in class akka.stream.extra.Timed.StopTimed
-
Deprecated.
- createLogic(Attributes) - Method in class akka.stream.extra.Timed.TimedInterval
-
Deprecated.
- createLogic(Attributes) - Method in class akka.stream.impl.ActorRefBackpressureSinkStage
-
- createLogic(Attributes) - Method in class akka.stream.impl.EmptySource$
-
- createLogic(Attributes) - Static method in class akka.stream.impl.EmptySource
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.Batch
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.Buffer
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.Collect
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.Delay
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.Drop
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.DropWhile
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.DropWithin
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.Expand
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.Filter
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.FlattenMerge
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.Fold
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.FoldAsync
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.GraphStages.Detacher
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.GraphStages.FutureSource
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.GraphStages.Identity$
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.GraphStages.MaterializedValueSource
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.GraphStages.SingleSource
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.GroupBy
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.Grouped
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.GroupedWithin
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.Intersperse
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.LimitWeighted
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.Log
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.Map
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.MapAsync
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.MapAsyncUnordered
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.MapError
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.PrefixAndTail
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.Recover
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.RecoverWith
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.Reduce
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.Scan
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.ScanAsync
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.Sliding
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.Split
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.StatefulMapConcat
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.SubSink
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.SubSource
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.Take
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.TakeWhile
-
- createLogic(Attributes) - Method in class akka.stream.impl.fusing.TakeWithin
-
- createLogic(Attributes) - Static method in class akka.stream.impl.io.ByteStringParser
-
- createLogic(Attributes) - Method in class akka.stream.impl.io.compression.DeflateDecompressor
-
- createLogic(Attributes) - Static method in class akka.stream.impl.io.compression.DeflateDecompressorBase
-
- createLogic(Attributes) - Method in class akka.stream.impl.io.compression.GzipDecompressor
-
- createLogic(Attributes) - Method in class akka.stream.impl.io.IncomingConnectionStage
-
- createLogic(Attributes) - Method in class akka.stream.impl.JavaStreamSource
-
- createLogic(Attributes) - Method in class akka.stream.impl.Throttle
-
- createLogic(Attributes) - Method in class akka.stream.impl.Timers.BackpressureTimeout
-
- createLogic(Attributes) - Method in class akka.stream.impl.Timers.Completion
-
- createLogic(Attributes) - Method in class akka.stream.impl.Timers.DelayInitial
-
- createLogic(Attributes) - Method in class akka.stream.impl.Timers.Idle
-
- createLogic(Attributes) - Method in class akka.stream.impl.Timers.IdleInject
-
- createLogic(Attributes) - Method in class akka.stream.impl.Timers.IdleTimeoutBidi
-
- createLogic(Attributes) - Method in class akka.stream.impl.Timers.Initial
-
- createLogic(Attributes) - Method in class akka.stream.impl.Unfold
-
- createLogic(Attributes) - Method in class akka.stream.impl.UnfoldAsync
-
- createLogic(Attributes) - Method in class akka.stream.impl.UnfoldResourceSource
-
- createLogic(Attributes) - Method in class akka.stream.impl.UnfoldResourceSourceAsync
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.Balance
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.Broadcast
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.Concat
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.CoupledTerminationBidi
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.Interleave
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.Merge
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.MergePreferred
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.MergeSorted
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.OrElse
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.Partition
-
- createLogic(Attributes) - Static method in class akka.stream.scaladsl.Unzip
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.UnzipWith10
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.UnzipWith11
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.UnzipWith12
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.UnzipWith13
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.UnzipWith14
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.UnzipWith15
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.UnzipWith16
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.UnzipWith17
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.UnzipWith18
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.UnzipWith19
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.UnzipWith2
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.UnzipWith20
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.UnzipWith3
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.UnzipWith4
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.UnzipWith5
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.UnzipWith6
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.UnzipWith7
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.UnzipWith8
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.UnzipWith9
-
- createLogic(Attributes) - Static method in class akka.stream.scaladsl.Zip
-
- createLogic(Attributes) - Static method in class akka.stream.scaladsl.ZipN
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.ZipWith10
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.ZipWith11
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.ZipWith12
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.ZipWith13
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.ZipWith14
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.ZipWith15
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.ZipWith16
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.ZipWith17
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.ZipWith18
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.ZipWith19
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.ZipWith2
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.ZipWith20
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.ZipWith3
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.ZipWith4
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.ZipWith5
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.ZipWith6
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.ZipWith7
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.ZipWith8
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.ZipWith9
-
- createLogic(Attributes) - Method in class akka.stream.scaladsl.ZipWithN
-
- createLogic(Attributes) - Method in class akka.stream.stage.GraphStage
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.remote.artery.AeronSink
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.remote.artery.AeronSource
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.remote.artery.Decoder
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.remote.artery.Encoder
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.remote.artery.InboundControlJunction
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.remote.artery.OutboundControlJunction
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.remote.artery.OutboundHandshake
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.remote.artery.SendQueue
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.remote.artery.SystemMessageDelivery
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.EmptySource
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.fusing.Batch
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.fusing.Buffer
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.fusing.Collect
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.fusing.Drop
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.fusing.DropWhile
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.fusing.Filter
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.fusing.Fold
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.stream.impl.fusing.GraphStages.IgnoreSink$
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.stream.impl.fusing.GraphStages.TickSource
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.fusing.Grouped
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.fusing.Intersperse
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.fusing.LimitWeighted
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.fusing.Log
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.fusing.Map
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.fusing.MapAsync
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.fusing.MapAsyncUnordered
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.fusing.MapError
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.fusing.Recover
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.fusing.RecoverWith
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.fusing.Scan
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.fusing.ScanAsync
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.fusing.Sliding
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.fusing.Split
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.fusing.SubSink
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.fusing.SubSource
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.fusing.Take
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.fusing.TakeWhile
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.stream.impl.HeadOptionStage
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.io.ByteStringParser
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.io.compression.DeflateDecompressorBase
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.impl.io.compression.GzipDecompressor
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.stream.impl.io.ConnectionSourceStage
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.stream.impl.io.InputStreamSinkStage
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.stream.impl.io.OutgoingConnectionStage
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.stream.impl.io.OutputStreamSourceStage
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.stream.impl.LastOptionStage
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.stream.impl.LazySink
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.stream.impl.LazySource
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.stream.impl.QueueSink
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.stream.impl.QueueSource
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.stream.impl.SeqStage
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.stream.KillSwitches.UniqueBidiKillSwitchStage$
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.stream.KillSwitches.UniqueKillSwitchStage$
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.scaladsl.Balance
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.scaladsl.Broadcast
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.stream.scaladsl.BroadcastHub
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.scaladsl.Concat
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.scaladsl.Interleave
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.scaladsl.Merge
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.stream.scaladsl.MergeHub
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.scaladsl.MergePreferred
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.scaladsl.OrElse
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.scaladsl.Partition
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.scaladsl.Unzip
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.scaladsl.Zip
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.scaladsl.ZipN
-
- createLogicAndMaterializedValue(Attributes) - Static method in class akka.stream.scaladsl.ZipWithN
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.stream.stage.AbstractStage.PushPullGraphStageWithMaterializedValue
-
Deprecated.
- createLogicAndMaterializedValue(Attributes) - Method in class akka.stream.stage.GraphStage
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.stream.stage.GraphStageWithMaterializedValue
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.stream.testkit.TestSinkStage
-
- createLogicAndMaterializedValue(Attributes) - Method in class akka.stream.testkit.TestSourceStage
-
- createLogLevels(Logging.LogLevel, Logging.LogLevel, Logging.LogLevel) - Method in class akka.stream.ActorAttributes$
-
Java API
- createLogLevels(Logging.LogLevel, Logging.LogLevel, Logging.LogLevel) - Static method in class akka.stream.ActorAttributes
-
Java API
- createLogLevels(Logging.LogLevel, Logging.LogLevel, Logging.LogLevel) - Method in class akka.stream.Attributes$
-
Java API
- createLogLevels(Logging.LogLevel, Logging.LogLevel, Logging.LogLevel) - Static method in class akka.stream.Attributes
-
Java API
- createMailbox(Cell, MailboxType) - Method in class akka.dispatch.BalancingDispatcher
-
Deprecated.
- 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.
- createObjectPool(int) - Method in class akka.remote.artery.ReusableInboundEnvelope$
-
- createObjectPool(int) - Static method in class akka.remote.artery.ReusableInboundEnvelope
-
- createObjectPool(int) - Method in class akka.remote.artery.ReusableOutboundEnvelope$
-
- createObjectPool(int) - Static method in class akka.remote.artery.ReusableOutboundEnvelope
-
- createProcessor() - Method in class akka.stream.impl.ProcessorModule
-
- createProducer() - Method in class akka.camel.internal.component.ActorEndpoint
-
Creates a new producer which is used send messages into the endpoint.
- createQueue(int) - Method in class akka.remote.artery.Association
-
- 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
-
Deprecated.
- createRouter(ActorSystem) - Method in class akka.cluster.routing.AdaptiveLoadBalancingPool
-
Deprecated.
- createRouter(ActorSystem) - Method in interface akka.cluster.routing.ClusterRouterConfigBase
-
- createRouter(ActorSystem) - Static method in class akka.cluster.routing.ClusterRouterGroup
-
- createRouter(ActorSystem) - Static method in class akka.cluster.routing.ClusterRouterPool
-
- 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() - Static method in class akka.cluster.metrics.AdaptiveLoadBalancingGroup
-
- createRouterActor() - Static method in class akka.cluster.metrics.AdaptiveLoadBalancingPool
-
- createRouterActor() - Static method in class akka.cluster.routing.AdaptiveLoadBalancingGroup
-
Deprecated.
- createRouterActor() - Static method in class akka.cluster.routing.AdaptiveLoadBalancingPool
-
Deprecated.
- 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() - Static method in class akka.routing.BalancingPool
-
- createRouterActor() - Static method in class akka.routing.BroadcastGroup
-
- createRouterActor() - Static method in class akka.routing.BroadcastPool
-
- createRouterActor() - Static method in class akka.routing.ConsistentHashingGroup
-
- createRouterActor() - Static method in class akka.routing.ConsistentHashingPool
-
- 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() - Static method in class akka.routing.RandomGroup
-
- createRouterActor() - Static method in class akka.routing.RandomPool
-
- createRouterActor() - Static method in class akka.routing.RoundRobinGroup
-
- createRouterActor() - Static method in class akka.routing.RoundRobinPool
-
- createRouterActor() - Method in interface akka.routing.RouterConfig
-
INTERNAL API
The router "head" actor.
- createRouterActor() - Static method in class akka.routing.ScatterGatherFirstCompletedGroup
-
- createRouterActor() - Static method in class akka.routing.ScatterGatherFirstCompletedPool
-
- createRouterActor() - Static method in class akka.routing.SmallestMailboxPool
-
- createRouterActor() - Static method in class akka.routing.TailChoppingGroup
-
- createRouterActor() - Static method in class akka.routing.TailChoppingPool
-
- 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.
- createScheduler() - Method in class akka.typed.internal.ActorSystemImpl
-
Create the scheduler service.
- createSecureRandom(MarkerLoggingAdapter) - Method in class akka.remote.transport.netty.SSLSettings
-
- createSerializers() - Method in class akka.serialization.SerializationSetup
-
- CreateServerFSM(Channel) - Constructor for class akka.remote.testconductor.Controller.CreateServerFSM
-
- CreateServerFSM$() - Constructor for class akka.remote.testconductor.Controller.CreateServerFSM$
-
- createSigarInstance() - Static method in class akka.cluster.metrics.DefaultSigarProvider
-
- createSigarInstance() - Method in interface akka.cluster.metrics.SigarProvider
-
Create sigar instance with 2-phase sigar library loading.
- createSSLEngine() - Method in class akka.stream.impl.io.TlsModule
-
- createStash(ActorContext, ActorRef) - Method in interface akka.actor.StashFactory
-
- createSubscription() - Method in class akka.stream.impl.FanOut.FanoutOutputs
-
- createSubscription(Subscriber<? super Object>) - Method in class akka.stream.impl.FanoutOutputs
-
- createSubscription() - Method in class akka.stream.impl.SimpleOutputs
-
- createSubscription(Subscriber<? super T>) - Method in interface akka.stream.impl.SubscriberManagement
-
Use to register a subscriber
- createSuccessful(long) - Method in class akka.stream.IOResult$
-
JAVA API: Creates successful IOResult
- createSuccessful(long) - Static method in class akka.stream.IOResult
-
JAVA API: Creates successful IOResult
- CreateSystemActor(Behavior<T>, String, DeploymentConfig, ActorRef<ActorRef<T>>) - Constructor for class akka.typed.internal.ActorSystemImpl.CreateSystemActor
-
- CreateSystemActor$() - Constructor for class akka.typed.internal.ActorSystemImpl.CreateSystemActor$
-
- 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.
- 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.DeleteSnapshotsFailure
-
- criteria() - Method in class akka.persistence.DeleteSnapshotsSuccess
-
- 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
-
Deprecated.
- Crypt$ - Class in akka.util
-
- Crypt$() - Constructor for class akka.util.Crypt$
-
Deprecated.
- ctdLock() - Method in class akka.testkit.CallingThreadMailbox
-
- ctx() - Method in class akka.typed.adapter.ActorAdapter
-
- ctx() - Method in class akka.typed.internal.ActorCell
-
- ctx() - Method in interface akka.typed.internal.DeathWatch
-
- ctx() - Method in interface akka.typed.internal.SupervisionMechanics
-
- 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
-
- CurlyBraceEnd() - Method in class akka.stream.impl.JsonObjectParser$
-
- CurlyBraceEnd() - Static method in class akka.stream.impl.JsonObjectParser
-
- CurlyBraceStart() - Method in class akka.stream.impl.JsonObjectParser$
-
- CurlyBraceStart() - Static method in class akka.stream.impl.JsonObjectParser
-
- current() - Method in class akka.pattern.BackoffSupervisor.ResetRestartCount
-
- current() - Method in class akka.stream.stage.StatefulStage
-
Deprecated.
Current state.
- current() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- current() - Method in class akka.Version$
-
- current() - Static method in class akka.Version
-
- currentBehavior() - Method in class akka.typed.EffectfulActorContext
-
- CurrentChild(Option<ActorRef>) - Constructor for class akka.pattern.BackoffSupervisor.CurrentChild
-
- CurrentChild$() - Constructor for class akka.pattern.BackoffSupervisor.CurrentChild$
-
- 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
-
- currentEventsByPersistenceId(String, long, long) - Method in interface akka.persistence.query.javadsl.CurrentEventsByPersistenceIdQuery
-
- currentEventsByPersistenceId(String, long, long) - Method in class akka.persistence.query.journal.leveldb.javadsl.LeveldbReadJournal
-
- currentEventsByPersistenceId(String, long, long) - Method in class akka.persistence.query.journal.leveldb.scaladsl.LeveldbReadJournal
-
- currentEventsByPersistenceId(String, long, long) - Method in interface akka.persistence.query.scaladsl.CurrentEventsByPersistenceIdQuery
-
- CurrentEventsByPersistenceIdPublisher - Class in akka.persistence.query.journal.leveldb
-
INTERNAL API
- CurrentEventsByPersistenceIdPublisher(String, long, long, int, String) - Constructor for class akka.persistence.query.journal.leveldb.CurrentEventsByPersistenceIdPublisher
-
- CurrentEventsByPersistenceIdQuery - Interface in akka.persistence.query.javadsl
-
A plugin may optionally support this query by implementing this interface.
- CurrentEventsByPersistenceIdQuery - Interface in akka.persistence.query.scaladsl
-
A plugin may optionally support this query by implementing this trait.
- currentEventsByTag(String, long) - Method in interface akka.persistence.query.javadsl.CurrentEventsByTagQuery
-
Deprecated.
- currentEventsByTag(String, Offset) - Method in interface akka.persistence.query.javadsl.CurrentEventsByTagQuery2
-
- currentEventsByTag(String, Offset) - Method in class akka.persistence.query.journal.leveldb.javadsl.LeveldbReadJournal
-
- currentEventsByTag(String, long) - Method in class akka.persistence.query.journal.leveldb.javadsl.LeveldbReadJournal
-
- currentEventsByTag(String, Offset) - Method in class akka.persistence.query.journal.leveldb.scaladsl.LeveldbReadJournal
-
- currentEventsByTag(String, long) - Method in class akka.persistence.query.journal.leveldb.scaladsl.LeveldbReadJournal
-
- currentEventsByTag(String, long) - Method in interface akka.persistence.query.scaladsl.CurrentEventsByTagQuery
-
Deprecated.
- currentEventsByTag(String, Offset) - Method in interface akka.persistence.query.scaladsl.CurrentEventsByTagQuery2
-
- CurrentEventsByTagPublisher - Class in akka.persistence.query.journal.leveldb
-
INTERNAL API
- CurrentEventsByTagPublisher(String, long, long, int, String) - Constructor for class akka.persistence.query.journal.leveldb.CurrentEventsByTagPublisher
-
- CurrentEventsByTagQuery - Interface in akka.persistence.query.javadsl
-
- CurrentEventsByTagQuery - Interface in akka.persistence.query.scaladsl
-
- CurrentEventsByTagQuery2 - Interface in akka.persistence.query.javadsl
-
A plugin may optionally support this query by implementing this interface.
- CurrentEventsByTagQuery2 - Interface in akka.persistence.query.scaladsl
-
A plugin may optionally support this query by implementing this trait.
- 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$
-
- currentInterpreter() - Method in class akka.stream.impl.fusing.GraphInterpreter$
-
INTERNAL API
- currentInterpreter() - Static method in class akka.stream.impl.fusing.GraphInterpreter
-
INTERNAL API
- currentInterpreterOrNull() - Method in class akka.stream.impl.fusing.GraphInterpreter$
-
INTERNAL API
- currentInterpreterOrNull() - Static method in class akka.stream.impl.fusing.GraphInterpreter
-
INTERNAL API
- currentMessage() - Method in class akka.actor.ActorCell
-
- currentMessage() - Static method in class akka.routing.RoutedActorCell
-
- currentMessage_$eq(Envelope) - Static method in class akka.routing.RoutedActorCell
-
- currentMsg() - Method in class akka.actor.dsl.Inbox.InboxActor
-
- currentOffset() - Method in class akka.stream.impl.io.ByteStringParser.ByteReader
-
- CurrentPersistenceIds(Set<String>) - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal.CurrentPersistenceIds
-
- currentPersistenceIds() - Method in interface akka.persistence.query.javadsl.CurrentPersistenceIdsQuery
-
- currentPersistenceIds() - Method in class akka.persistence.query.journal.leveldb.javadsl.LeveldbReadJournal
-
- currentPersistenceIds() - Method in class akka.persistence.query.journal.leveldb.scaladsl.LeveldbReadJournal
-
- currentPersistenceIds() - Method in interface akka.persistence.query.scaladsl.CurrentPersistenceIdsQuery
-
- CurrentPersistenceIds$() - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal.CurrentPersistenceIds$
-
- CurrentPersistenceIdsQuery - Interface in akka.persistence.query.javadsl
-
A plugin may optionally support this query by implementing this interface.
- CurrentPersistenceIdsQuery - Interface in akka.persistence.query.scaladsl
-
A plugin may optionally support this query by implementing this trait.
- currentPid() - Method in class akka.cluster.sharding.RemoveInternalClusterShardingData
-
- currentRef() - Method in class akka.cluster.sharding.RemoveInternalClusterShardingData
-
- CurrentRegions(Set<Address>) - Constructor for class akka.cluster.sharding.ShardRegion.CurrentRegions
-
- CurrentRegions$() - Constructor for class akka.cluster.sharding.ShardRegion.CurrentRegions$
-
- currentSelect() - Method in class akka.actor.dsl.Inbox.InboxActor
-
- currentSerial() - Method in class akka.contrib.pattern.ReliableProxy
-
- currentSession() - Method in class akka.stream.impl.io.TLSActor
-
- CurrentShardRegionState(Set<ShardRegion.ShardState>) - Constructor for class akka.cluster.sharding.ShardRegion.CurrentShardRegionState
-
- CurrentShardRegionState$() - Constructor for class akka.cluster.sharding.ShardRegion.CurrentShardRegionState$
-
- CurrentShardState(String, Set<String>) - Constructor for class akka.cluster.sharding.Shard.CurrentShardState
-
- CurrentShardState$() - Constructor for class akka.cluster.sharding.Shard.CurrentShardState$
-
- CurrentState(ActorRef, S) - Constructor for class akka.actor.FSM.CurrentState
-
- currentState() - Method in class akka.actor.FSM.StopEvent
-
- CurrentState(ActorRef, S, Option<FiniteDuration>) - Constructor for class akka.persistence.fsm.PersistentFSM.CurrentState
-
- currentState() - Method in class akka.persistence.fsm.PersistentFSM.StopEvent
-
- CurrentState$() - Constructor for class akka.actor.FSM.CurrentState$
-
- CurrentState$() - Constructor for class akka.persistence.fsm.PersistentFSM.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
-
- currentTime() - Method in class akka.util.NanoTimeTokenBucket
-
- currentTime() - Method in class akka.util.TokenBucket
-
The current time in nanos.
- 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.
- currOffset() - Method in class akka.persistence.query.journal.leveldb.AbstractEventsByTagPublisher
-
- currSeqNo() - Method in class akka.persistence.query.journal.leveldb.AbstractEventsByPersistenceIdPublisher
-
- cursor() - Method in class akka.stream.impl.ActorSubscriptionWithCursor
-
- cursor() - Method in interface akka.stream.impl.ResizableMultiReaderRingBuffer.Cursor
-
- cursor() - Method in interface akka.stream.impl.SubscriptionWithCursor
-
- cursors() - Method in class akka.stream.impl.ResizableMultiReaderRingBuffer
-
- cursors() - Method in interface akka.stream.impl.ResizableMultiReaderRingBuffer.Cursors
-
- cursors() - Method in interface akka.stream.impl.SubscriberManagement
-
- 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
-
- cycle(Creator<Iterator<O>>) - Method in class akka.stream.javadsl.Source$
-
Helper to create 'cycled'
Source
from iterator provider.
- cycle(Creator<Iterator<O>>) - Static method in class akka.stream.javadsl.Source
-
Helper to create 'cycled'
Source
from iterator provider.
- cycle(Function0<Iterator<T>>) - Method in class akka.stream.scaladsl.Source$
-
Create
Source
that will continually produce given elements in specified order.
- cycle(Function0<Iterator<T>>) - Static method in class akka.stream.scaladsl.Source
-
Create
Source
that will continually produce given elements in specified order.
- cycledSource() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- g() - Method in class akka.cluster.GossipEnvelope
-
- Gated(Deadline, Option<Object>) - Constructor for class akka.remote.EndpointManager.Gated
-
- gated(boolean, boolean) - Method in class akka.remote.ReliableDeliverySupervisor
-
- Gated$() - Constructor for class akka.remote.EndpointManager.Gated$
-
- gatherFromAllOtherQueues(CallingThreadMailbox, MessageQueue) - Method in class akka.testkit.CallingThreadDispatcherQueues
-
- GaveUpMessageException(String) - Constructor for exception akka.remote.artery.AeronSink.GaveUpMessageException
-
- GaveUpSystemMessageException(String) - Constructor for exception akka.remote.artery.SystemMessageDelivery.GaveUpSystemMessageException
-
- GCounter - Class in akka.cluster.ddata
-
- GCounter(Map<UniqueAddress, BigInt>) - Constructor for class akka.cluster.ddata.GCounter
-
- GCounter$ - Class in akka.cluster.ddata
-
- GCounter$() - Constructor for class akka.cluster.ddata.GCounter$
-
- gcounterFromBinary(byte[]) - Method in class akka.cluster.ddata.protobuf.ReplicatedDataSerializer
-
- gcounterFromProto(ReplicatedDataMessages.GCounter) - Method in class akka.cluster.ddata.protobuf.ReplicatedDataSerializer
-
- GCounterKey - Class in akka.cluster.ddata
-
- GCounterKey(String) - Constructor for class akka.cluster.ddata.GCounterKey
-
- GCounterKey$ - Class in akka.cluster.ddata
-
- GCounterKey$() - Constructor for class akka.cluster.ddata.GCounterKey$
-
- gcounterToProto(GCounter) - Method in class akka.cluster.ddata.protobuf.ReplicatedDataSerializer
-
- gen(Object) - Method in class akka.dispatch.PriorityGenerator
-
- generateSecureCookie() - Method in class akka.util.Crypt$
-
Deprecated.
- generateSecureCookie() - Static method in class akka.util.Crypt
-
Deprecated.
- 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 class akka.actor.FSM.TimeoutMarker
-
- generation() - Method in class akka.actor.FSM.Timer
-
- generation() - Method in class akka.persistence.fsm.PersistentFSM.TimeoutMarker
-
- generation() - Method in class akka.persistence.fsm.PersistentFSM.Timer
-
- generation() - Method in class akka.remote.testconductor.Controller
-
- genericBuilder() - Static method in class akka.util.ByteString
-
- genericBuilder() - Static method in class akka.util.CompactByteString
-
- 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(Class<T>) - Method in class akka.actor.setup.ActorSystemSetup
-
Java API: Extract a concrete
Setup
of type
T
if it is defined in the settings.
- get(ClassTag<T>) - Method in class akka.actor.setup.ActorSystemSetup
-
Scala API: Extract a concrete
Setup
of type
T
if it is defined in the settings.
- 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.ddata.DistributedData$
-
- get(ActorSystem) - Static method in class akka.cluster.ddata.DistributedData
-
- get(String) - Method in class akka.cluster.ddata.LWWMap
-
- get(String) - Method in class akka.cluster.ddata.ORMap
-
- get(String) - Method in class akka.cluster.ddata.ORMultiMap
-
Get the set associated with the key if there is one.
- get(String) - Method in class akka.cluster.ddata.PNCounterMap
-
Scala API: The count for a key
- get(A) - Method in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer.SmallCache
-
Get value from cache or null
if it doesn't exist.
- get(Key<T>) - Method in class akka.cluster.ddata.Replicator.Changed
-
The data value, with correct type.
- Get(Key<A>, Replicator.ReadConsistency, Option<Object>) - Constructor for class akka.cluster.ddata.Replicator.Get
-
- Get(Key<A>, Replicator.ReadConsistency) - Constructor for class akka.cluster.ddata.Replicator.Get
-
Java API: Get
value from local Replicator
, i.e.
- Get(Key<A>, Replicator.ReadConsistency, Optional<Object>) - Constructor for class akka.cluster.ddata.Replicator.Get
-
Java API: Get
value from local Replicator
, i.e.
- get(Key<T>) - Method in class akka.cluster.ddata.Replicator.GetSuccess
-
The data value, with correct type.
- 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() - Static method in class akka.dispatch.Mailbox
-
- get(long, TimeUnit) - Static method in class akka.dispatch.Mailbox
-
- 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(Class<?>) - Method in class akka.persistence.journal.EventAdapters
-
Finds the "most specific" matching adapter for the given class (i.e.
- get(Class<?>) - Method in class akka.persistence.journal.IdentityEventAdapters$
-
- get(Class<?>) - Static method in class akka.persistence.journal.IdentityEventAdapters
-
- get(ActorSystem) - Method in class akka.persistence.journal.PersistencePluginProxyExtension$
-
- get(ActorSystem) - Static method in class akka.persistence.journal.PersistencePluginProxyExtension
-
- 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.persistence.query.PersistenceQuery$
-
Java API.
- get(ActorSystem) - Static method in class akka.persistence.query.PersistenceQuery
-
Java API.
- get(ActorSystem) - Method in class akka.remote.AddressUidExtension$
-
- get(ActorSystem) - Static method in class akka.remote.AddressUidExtension
-
- get(int) - Method in class akka.remote.artery.compress.DecompressionTable
-
- get() - Method in class akka.remote.artery.compress.TopHeavyHitters.HashCodeVal
-
- get() - Static method in class akka.remote.artery.FlightRecorder
-
- get(long) - Method in class akka.remote.artery.ImmutableLongMap
-
Worst case O(log n)
, allocation free.
- get(K) - Method in class akka.remote.artery.LruBoundedCache
-
- 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(Object) - Static method in class akka.remote.security.provider.AkkaProvider
-
- get(ActorSystem) - Method in class akka.remote.serialization.ActorRefResolveThreadLocalCache$
-
- get(ActorSystem) - Static method in class akka.remote.serialization.ActorRefResolveThreadLocalCache
-
- 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(Channel) - Static method in class akka.remote.transport.netty.ChannelLocalActor
-
- 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(ActorSystem) - Method in class akka.stream.actor.ActorPublisherState$
-
- get(ActorRef) - Method in class akka.stream.actor.ActorPublisherState
-
- get(ActorSystem) - Method in class akka.stream.actor.ActorSubscriberState$
-
- get(ActorRef) - Method in class akka.stream.actor.ActorSubscriberState
-
- get(T, ClassTag<T>) - Method in class akka.stream.Attributes
-
Scala API: Get the last (most specific) attribute of a given type parameter T Class
or subclass thereof.
- get(ClassTag<T>) - Method in class akka.stream.Attributes
-
Scala API: Get the last (most specific) attribute of a given type parameter T Class
or subclass thereof.
- get(ActorSystem) - Method in class akka.stream.impl.FlowNames$
-
- get(ActorSystem) - Static method in class akka.stream.impl.FlowNames
-
- get() - Static method in class akka.stream.impl.VirtualProcessor
-
- get(ActorSystem) - Method in class akka.stream.javadsl.Tcp$
-
- get(ActorSystem) - Static method in class akka.stream.javadsl.Tcp
-
- get(ActorSystem) - Method in class akka.stream.scaladsl.Tcp$
-
- get(ActorSystem) - Static method in class akka.stream.scaladsl.Tcp
-
- 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() - Method in class akka.util.OptionVal
-
- get() - Static method in class akka.util.SerializedSuspendableExecutionContext
-
- get(T) - Method in class akka.util.TypedMultiMap
-
Obtain all mappings for the given key.
- get(ActorSystem) - Method in class com.typesafe.sslconfig.akka.AkkaSSLConfig$
-
- get(ActorSystem) - Static method in class com.typesafe.sslconfig.akka.AkkaSSLConfig
-
- Get$() - Constructor for class akka.actor.dsl.Inbox.Get$
-
- Get$() - Constructor for class akka.cluster.ddata.Replicator.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;
- getAckReplyTo() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope.Builder
-
required .UniqueAddress ackReplyTo = 5;
- getAckReplyTo() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope
-
required .UniqueAddress ackReplyTo = 5;
- getAckReplyTo() - Method in interface akka.remote.ArteryControlFormats.SystemMessageEnvelopeOrBuilder
-
required .UniqueAddress ackReplyTo = 5;
- getAckReplyToBuilder() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope.Builder
-
required .UniqueAddress ackReplyTo = 5;
- getAckReplyToOrBuilder() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope.Builder
-
required .UniqueAddress ackReplyTo = 5;
- getAckReplyToOrBuilder() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope
-
required .UniqueAddress ackReplyTo = 5;
- getAckReplyToOrBuilder() - Method in interface akka.remote.ArteryControlFormats.SystemMessageEnvelopeOrBuilder
-
required .UniqueAddress ackReplyTo = 5;
- 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() - Static method in exception akka.actor.PostRestartException
-
- getActor() - Static method in exception akka.actor.PreRestartException
-
- getActor() - Method in class akka.actor.Terminated
-
- getActor() - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
optional .ActorRef actor = 1;
- getActor() - Method in class akka.remote.ContainerFormats.ActorInitializationException
-
optional .ActorRef actor = 1;
- getActor() - Method in interface akka.remote.ContainerFormats.ActorInitializationExceptionOrBuilder
-
optional .ActorRef actor = 1;
- getActor() - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData.Builder
-
required .ActorRef actor = 1;
- getActor() - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData
-
required .ActorRef actor = 1;
- getActor() - Method in interface akka.remote.SystemMessageFormats.DeathWatchNotificationDataOrBuilder
-
required .ActorRef actor = 1;
- getActorBuilder() - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
optional .ActorRef actor = 1;
- getActorBuilder() - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData.Builder
-
required .ActorRef actor = 1;
- getActorOrBuilder() - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
optional .ActorRef actor = 1;
- getActorOrBuilder() - Method in class akka.remote.ContainerFormats.ActorInitializationException
-
optional .ActorRef actor = 1;
- getActorOrBuilder() - Method in interface akka.remote.ContainerFormats.ActorInitializationExceptionOrBuilder
-
optional .ActorRef actor = 1;
- getActorOrBuilder() - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData.Builder
-
required .ActorRef actor = 1;
- getActorOrBuilder() - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData
-
required .ActorRef actor = 1;
- getActorOrBuilder() - Method in interface akka.remote.SystemMessageFormats.DeathWatchNotificationDataOrBuilder
-
required .ActorRef actor = 1;
- 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.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress.Builder
-
required .akka.cluster.ddata.Address address = 1;
- getAddress() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress
-
required .akka.cluster.ddata.Address address = 1;
- getAddress() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddressOrBuilder
-
required .akka.cluster.ddata.Address address = 1;
- 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() - Method in class akka.remote.ArteryControlFormats.MessageWithAddress.Builder
-
required .UniqueAddress address = 1;
- getAddress() - Method in class akka.remote.ArteryControlFormats.MessageWithAddress
-
required .UniqueAddress address = 1;
- getAddress() - Method in interface akka.remote.ArteryControlFormats.MessageWithAddressOrBuilder
-
required .UniqueAddress address = 1;
- getAddress() - Method in class akka.remote.ArteryControlFormats.UniqueAddress.Builder
-
required .Address address = 1;
- getAddress() - Method in class akka.remote.ArteryControlFormats.UniqueAddress
-
required .Address address = 1;
- getAddress() - Method in interface akka.remote.ArteryControlFormats.UniqueAddressOrBuilder
-
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.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress.Builder
-
required .akka.cluster.ddata.Address address = 1;
- 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.ArteryControlFormats.MessageWithAddress.Builder
-
required .UniqueAddress address = 1;
- getAddressBuilder() - Method in class akka.remote.ArteryControlFormats.UniqueAddress.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.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress.Builder
-
required .akka.cluster.ddata.Address address = 1;
- getAddressOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress
-
required .akka.cluster.ddata.Address address = 1;
- getAddressOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddressOrBuilder
-
required .akka.cluster.ddata.Address address = 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.ArteryControlFormats.MessageWithAddress.Builder
-
required .UniqueAddress address = 1;
- getAddressOrBuilder() - Method in class akka.remote.ArteryControlFormats.MessageWithAddress
-
required .UniqueAddress address = 1;
- getAddressOrBuilder() - Method in interface akka.remote.ArteryControlFormats.MessageWithAddressOrBuilder
-
required .UniqueAddress address = 1;
- getAddressOrBuilder() - Method in class akka.remote.ArteryControlFormats.UniqueAddress.Builder
-
required .Address address = 1;
- getAddressOrBuilder() - Method in class akka.remote.ArteryControlFormats.UniqueAddress
-
required .Address address = 1;
- getAddressOrBuilder() - Method in interface akka.remote.ArteryControlFormats.UniqueAddressOrBuilder
-
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
-
- getAddressTerminated() - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData.Builder
-
required bool addressTerminated = 3;
- getAddressTerminated() - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData
-
required bool addressTerminated = 3;
- getAddressTerminated() - Method in interface akka.remote.SystemMessageFormats.DeathWatchNotificationDataOrBuilder
-
required bool addressTerminated = 3;
- 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
-
- getAdds(int) - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet.Builder
-
repeated string adds = 1;
- getAdds(int) - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet
-
repeated string adds = 1;
- getAdds() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2.Builder
-
optional bytes adds = 1;
- getAdds() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2
-
optional bytes adds = 1;
- getAdds() - Method in interface docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2OrBuilder
-
optional bytes adds = 1;
- getAdds(int) - Method in interface docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSetOrBuilder
-
repeated string adds = 1;
- getAddsBytes(int) - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet.Builder
-
repeated string adds = 1;
- getAddsBytes(int) - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet
-
repeated string adds = 1;
- getAddsBytes(int) - Method in interface docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSetOrBuilder
-
repeated string adds = 1;
- getAddsCount() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet.Builder
-
repeated string adds = 1;
- getAddsCount() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet
-
repeated string adds = 1;
- getAddsCount() - Method in interface docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSetOrBuilder
-
repeated string adds = 1;
- getAddsList() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet.Builder
-
repeated string adds = 1;
- getAddsList() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet
-
repeated string adds = 1;
- getAddsList() - Method in interface docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSetOrBuilder
-
repeated string adds = 1;
- 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() - Static method in class akka.actor.ActorCell
-
- getAllChildStats() - Method in interface akka.actor.dungeon.Children
-
- getAllChildStats() - Static method in class akka.routing.RoutedActorCell
-
- 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;
- getAndAccumulate(V, BinaryOperator<V>) - Static method in class akka.remote.artery.FlightRecorder
-
- getAndAccumulate(V, BinaryOperator<V>) - Static method in class akka.stream.impl.VirtualProcessor
-
- getAndAccumulate(V, BinaryOperator<V>) - Static method in class akka.util.SerializedSuspendableExecutionContext
-
- getAndSet(V) - Static method in class akka.remote.artery.FlightRecorder
-
- getAndSet(V) - Static method in class akka.stream.impl.VirtualProcessor
-
- getAndSet(V) - Static method in class akka.util.SerializedSuspendableExecutionContext
-
- getAndUpdate(UnaryOperator<V>) - Static method in class akka.remote.artery.FlightRecorder
-
- getAndUpdate(UnaryOperator<V>) - Static method in class akka.stream.impl.VirtualProcessor
-
- getAndUpdate(UnaryOperator<V>) - Static method in class akka.util.SerializedSuspendableExecutionContext
-
- 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;
- getAsync() - Method in class akka.remote.SystemMessageFormats.SuperviseData.Builder
-
required bool async = 2;
- getAsync() - Method in class akka.remote.SystemMessageFormats.SuperviseData
-
required bool async = 2;
- getAsync() - Method in interface akka.remote.SystemMessageFormats.SuperviseDataOrBuilder
-
required bool async = 2;
- getAsyncCallback(Function1<T, BoxedUnit>) - Method in class akka.stream.stage.GraphStageLogic
-
Obtain a callback object that can be used asynchronously to re-enter the
current
GraphStage
with an asynchronous notification.
- getAttachments(Set<String>) - Method in class akka.camel.CamelMessage
-
Java API: Returns those attachments from this message whose name is contained in names
.
- getAttachments() - Method in class akka.camel.CamelMessage
-
Java API: Returns all attachments from this message.
- getAttribute(Class<T>, T) - Method in class akka.stream.Attributes
-
Java API: Get the last (most specific) attribute of a given Class
or subclass thereof.
- getAttribute(Class<T>) - Method in class akka.stream.Attributes
-
Java API: Get the last (most specific) attribute of a given Class
or subclass thereof.
- getAttributeList() - Method in class akka.stream.Attributes
-
Java API
- getAttributeList(Class<T>) - Method in class akka.stream.Attributes
-
Java API: Get all attributes of a given Class
or
subclass thereof.
- 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.
- getByteBuffers() - Static method in class akka.util.CompactByteString
-
- 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() - Static method in exception akka.actor.ActorInitializationException
-
- getCause() - Static method in exception akka.actor.ActorKilledException
-
- getCause() - Static method in exception akka.actor.ActorNotFound
-
- getCause() - Static method in exception akka.actor.DeathPactException
-
- getCause() - Static method in exception akka.actor.IllegalActorStateException
-
- getCause() - Static method in exception akka.actor.InvalidActorNameException
-
- getCause() - Static method in exception akka.actor.InvalidMessageException
-
- getCause() - Static method in exception akka.actor.PostRestartException
-
- getCause() - Static method in exception akka.actor.PreRestartException
-
- getCause() - Static method in exception akka.actor.SchedulerException
-
- getCause() - Static method in exception akka.actor.StashOverflowException
-
- getCause() - Static method in exception akka.contrib.circuitbreaker.OpenCircuitException
-
- getCause() - Method in class akka.event.Logging.LogEventException
-
- getCause() - Method in exception akka.pattern.AskTimeoutException
-
- getCause() - Static method in exception akka.pattern.CircuitBreakerOpenException
-
- getCause() - Method in class akka.remote.AssociationErrorEvent
-
- getCause() - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
required .Payload cause = 3;
- getCause() - Method in class akka.remote.ContainerFormats.ActorInitializationException
-
required .Payload cause = 3;
- getCause() - Method in interface akka.remote.ContainerFormats.ActorInitializationExceptionOrBuilder
-
required .Payload cause = 3;
- getCause() - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
optional .Payload cause = 3;
- getCause() - Method in class akka.remote.ContainerFormats.Throwable
-
optional .Payload cause = 3;
- getCause() - Method in interface akka.remote.ContainerFormats.ThrowableOrBuilder
-
optional .Payload cause = 3;
- getCause() - Static method in exception akka.remote.HopelessAssociation
-
- getCause() - Static method in exception akka.remote.InvalidAssociation
-
- getCause() - Method in class akka.remote.RemotingErrorEvent
-
- getCause() - Static method in exception akka.remote.ShutDownAssociation
-
- getCause() - Static method in exception akka.remote.transport.FailureInjectorException
-
- getCause() - Static method in exception akka.stream.AbruptTerminationException
-
- getCause() - Static method in exception akka.stream.BindFailedException
-
- getCause() - Static method in exception akka.stream.BufferOverflowException
-
- getCause() - Static method in exception akka.stream.MaterializationException
-
- getCause() - Static method in exception akka.typed.DeathPactException
-
- getCauseBuilder() - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
required .Payload cause = 3;
- getCauseBuilder() - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
optional .Payload cause = 3;
- getCauseData() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .Payload causeData = 3;
- getCauseData() - Method in class akka.remote.SystemMessageFormats.SystemMessage
-
optional .Payload causeData = 3;
- getCauseData() - Method in interface akka.remote.SystemMessageFormats.SystemMessageOrBuilder
-
optional .Payload causeData = 3;
- getCauseDataBuilder() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .Payload causeData = 3;
- getCauseDataOrBuilder() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .Payload causeData = 3;
- getCauseDataOrBuilder() - Method in class akka.remote.SystemMessageFormats.SystemMessage
-
optional .Payload causeData = 3;
- getCauseDataOrBuilder() - Method in interface akka.remote.SystemMessageFormats.SystemMessageOrBuilder
-
optional .Payload causeData = 3;
- getCauseOrBuilder() - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
required .Payload cause = 3;
- getCauseOrBuilder() - Method in class akka.remote.ContainerFormats.ActorInitializationException
-
required .Payload cause = 3;
- getCauseOrBuilder() - Method in interface akka.remote.ContainerFormats.ActorInitializationExceptionOrBuilder
-
required .Payload cause = 3;
- getCauseOrBuilder() - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
optional .Payload cause = 3;
- getCauseOrBuilder() - Method in class akka.remote.ContainerFormats.Throwable
-
optional .Payload cause = 3;
- getCauseOrBuilder() - Method in interface akka.remote.ContainerFormats.ThrowableOrBuilder
-
optional .Payload cause = 3;
- getCell() - Method in class akka.typed.internal.LocalActorRef
-
- 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) - Static method in class akka.actor.ActorCell
-
- getChild(Iterator<String>) - Static method in class akka.actor.DeadLetterActorRef
-
- 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>) - Static method in class akka.actor.Nobody
-
- 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>) - Static method in class akka.pattern.PromiseActorRef
-
- 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).
- getChild() - Method in class akka.remote.SystemMessageFormats.FailedData.Builder
-
required .ActorRef child = 1;
- getChild() - Method in class akka.remote.SystemMessageFormats.FailedData
-
required .ActorRef child = 1;
- getChild() - Method in interface akka.remote.SystemMessageFormats.FailedDataOrBuilder
-
required .ActorRef child = 1;
- getChild() - Method in class akka.remote.SystemMessageFormats.SuperviseData.Builder
-
required .ActorRef child = 1;
- getChild() - Method in class akka.remote.SystemMessageFormats.SuperviseData
-
required .ActorRef child = 1;
- getChild() - Method in interface akka.remote.SystemMessageFormats.SuperviseDataOrBuilder
-
required .ActorRef child = 1;
- getChild(String) - Static method in class akka.routing.RoutedActorCell
-
- getChild(Iterator<String>) - Static method in class akka.testkit.TestActorRef
-
- getChild(Iterator<String>) - Static method in class akka.testkit.TestFSMRef
-
- getChildBuilder() - Method in class akka.remote.SystemMessageFormats.FailedData.Builder
-
required .ActorRef child = 1;
- getChildBuilder() - Method in class akka.remote.SystemMessageFormats.SuperviseData.Builder
-
required .ActorRef child = 1;
- getChildByName(String) - Static method in class akka.actor.ActorCell
-
- 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
-
- getChildByName(String) - Static method in class akka.routing.RoutedActorCell
-
- getChildByRef(ActorRef) - Static method in class akka.actor.ActorCell
-
- getChildByRef(ActorRef) - Method in interface akka.actor.dungeon.Children
-
- getChildByRef(ActorRef) - Static method in class akka.routing.RoutedActorCell
-
- getChildOrBuilder() - Method in class akka.remote.SystemMessageFormats.FailedData.Builder
-
required .ActorRef child = 1;
- getChildOrBuilder() - Method in class akka.remote.SystemMessageFormats.FailedData
-
required .ActorRef child = 1;
- getChildOrBuilder() - Method in interface akka.remote.SystemMessageFormats.FailedDataOrBuilder
-
required .ActorRef child = 1;
- getChildOrBuilder() - Method in class akka.remote.SystemMessageFormats.SuperviseData.Builder
-
required .ActorRef child = 1;
- getChildOrBuilder() - Method in class akka.remote.SystemMessageFormats.SuperviseData
-
required .ActorRef child = 1;
- getChildOrBuilder() - Method in interface akka.remote.SystemMessageFormats.SuperviseDataOrBuilder
-
required .ActorRef child = 1;
- 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() - Static method in class akka.actor.ActorCell
-
- 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
- getChildren() - Static method in class akka.routing.RoutedActorCell
-
- GetChildren$() - Constructor for class akka.stream.impl.StreamSupervisor.GetChildren$
-
- getChunk() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
required uint32 chunk = 1;
- getChunk() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status
-
required uint32 chunk = 1;
- getChunk() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StatusOrBuilder
-
required uint32 chunk = 1;
- getClass() - Static method in class akka.contrib.circuitbreaker.AskeableWithCircuitBreakerActor
-
- getClass() - Static method in class akka.contrib.circuitbreaker.AskeableWithCircuitBreakerActorSelection
-
- getClass() - Static method in class akka.contrib.circuitbreaker.CircuitBreakerAwareFuture
-
- getClass() - Static method in class akka.dispatch.sysmsg.EarliestFirstSystemMessageList
-
- getClass() - Static method in class akka.dispatch.sysmsg.LatestFirstSystemMessageList
-
- getClass() - Static method in class akka.pattern.AskableActorRef
-
- getClass() - Static method in class akka.pattern.AskableActorSelection
-
- getClass() - Static method in class akka.pattern.ExplicitlyAskableActorRef
-
- getClass() - Static method in class akka.pattern.ExplicitlyAskableActorSelection
-
- getClass() - Static method in class akka.remote.artery.ByteFlag
-
- getClass() - Static method in class akka.typed.internal.EarliestFirstSystemMessageList
-
- getClass() - Static method in class akka.typed.internal.LatestFirstSystemMessageList
-
- getClass() - Static method in class akka.util.OptionVal
-
- 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
-
- getClassLoadingLock(String) - Static method in class akka.osgi.BundleDelegatingClassLoader
-
- getClassName() - Method in class akka.remote.ContainerFormats.StackTraceElement.Builder
-
required string className = 1;
- getClassName() - Method in class akka.remote.ContainerFormats.StackTraceElement
-
required string className = 1;
- getClassName() - Method in interface akka.remote.ContainerFormats.StackTraceElementOrBuilder
-
required string className = 1;
- getClassName() - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
required string className = 1;
- getClassName() - Method in class akka.remote.ContainerFormats.Throwable
-
required string className = 1;
- getClassName() - Method in interface akka.remote.ContainerFormats.ThrowableOrBuilder
-
required string className = 1;
- getClassNameBytes() - Method in class akka.remote.ContainerFormats.StackTraceElement.Builder
-
required string className = 1;
- getClassNameBytes() - Method in class akka.remote.ContainerFormats.StackTraceElement
-
required string className = 1;
- getClassNameBytes() - Method in interface akka.remote.ContainerFormats.StackTraceElementOrBuilder
-
required string className = 1;
- getClassNameBytes() - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
required string className = 1;
- getClassNameBytes() - Method in class akka.remote.ContainerFormats.Throwable
-
required string className = 1;
- getClassNameBytes() - Method in interface akka.remote.ContainerFormats.ThrowableOrBuilder
-
required string className = 1;
- 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;
- getClusterClients() - Method in class akka.cluster.client.ClusterClients
-
Java API
- GetClusterClients - Class in akka.cluster.client
-
- GetClusterClients() - Constructor for class akka.cluster.client.GetClusterClients
-
- GetClusterClients$ - Class in akka.cluster.client
-
Get the cluster clients known to this receptionist.
- GetClusterClients$() - Constructor for class akka.cluster.client.GetClusterClients$
-
- GetClusterCoreRef$() - Constructor for class akka.cluster.InternalClusterAction.GetClusterCoreRef$
-
- GetClusterShardingStats(FiniteDuration) - Constructor for class akka.cluster.sharding.ShardRegion.GetClusterShardingStats
-
- GetClusterShardingStats$() - Constructor for class akka.cluster.sharding.ShardRegion.GetClusterShardingStats$
-
- 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
-
- getConsistency() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
required sint32 consistency = 2;
- getConsistency() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get
-
required sint32 consistency = 2;
- getConsistency() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetOrBuilder
-
required sint32 consistency = 2;
- getContactPoints() - Method in class akka.cluster.client.ContactPoints
-
Java API
- GetContactPoints - Class in akka.cluster.client
-
- GetContactPoints() - Constructor for class akka.cluster.client.GetContactPoints
-
- getContactPoints(int) - Method in class akka.cluster.client.protobuf.msg.ClusterClientMessages.Contacts.Builder
-
repeated string contactPoints = 1;
- getContactPoints(int) - Method in class akka.cluster.client.protobuf.msg.ClusterClientMessages.Contacts
-
repeated string contactPoints = 1;
- getContactPoints(int) - Method in interface akka.cluster.client.protobuf.msg.ClusterClientMessages.ContactsOrBuilder
-
repeated string contactPoints = 1;
- GetContactPoints$ - Class in akka.cluster.client
-
Get the contact points known to this client.
- GetContactPoints$() - Constructor for class akka.cluster.client.GetContactPoints$
-
- getContactPointsBytes(int) - Method in class akka.cluster.client.protobuf.msg.ClusterClientMessages.Contacts.Builder
-
repeated string contactPoints = 1;
- getContactPointsBytes(int) - Method in class akka.cluster.client.protobuf.msg.ClusterClientMessages.Contacts
-
repeated string contactPoints = 1;
- getContactPointsBytes(int) - Method in interface akka.cluster.client.protobuf.msg.ClusterClientMessages.ContactsOrBuilder
-
repeated string contactPoints = 1;
- getContactPointsCount() - Method in class akka.cluster.client.protobuf.msg.ClusterClientMessages.Contacts.Builder
-
repeated string contactPoints = 1;
- getContactPointsCount() - Method in class akka.cluster.client.protobuf.msg.ClusterClientMessages.Contacts
-
repeated string contactPoints = 1;
- getContactPointsCount() - Method in interface akka.cluster.client.protobuf.msg.ClusterClientMessages.ContactsOrBuilder
-
repeated string contactPoints = 1;
- getContactPointsList() - Method in class akka.cluster.client.protobuf.msg.ClusterClientMessages.Contacts.Builder
-
repeated string contactPoints = 1;
- getContactPointsList() - Method in class akka.cluster.client.protobuf.msg.ClusterClientMessages.Contacts
-
repeated string contactPoints = 1;
- getContactPointsList() - Method in interface akka.cluster.client.protobuf.msg.ClusterClientMessages.ContactsOrBuilder
-
repeated string contactPoints = 1;
- 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
-
- getContext() - Static method in class akka.stream.actor.AbstractActorPublisher
-
- getContext() - Static method in class akka.stream.actor.AbstractActorSubscriber
-
- getContext() - Static method in class akka.stream.actor.UntypedActorPublisher
-
- getContext() - Static method in class akka.stream.actor.UntypedActorSubscriber
-
- 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;
- getCorrelationId() - Method in class akka.remote.ContainerFormats.ActorIdentity.Builder
-
required .Payload correlationId = 1;
- getCorrelationId() - Method in class akka.remote.ContainerFormats.ActorIdentity
-
required .Payload correlationId = 1;
- getCorrelationId() - Method in interface akka.remote.ContainerFormats.ActorIdentityOrBuilder
-
required .Payload correlationId = 1;
- getCorrelationIdBuilder() - Method in class akka.remote.ContainerFormats.ActorIdentity.Builder
-
required .Payload correlationId = 1;
- getCorrelationIdOrBuilder() - Method in class akka.remote.ContainerFormats.ActorIdentity.Builder
-
required .Payload correlationId = 1;
- getCorrelationIdOrBuilder() - Method in class akka.remote.ContainerFormats.ActorIdentity
-
required .Payload correlationId = 1;
- getCorrelationIdOrBuilder() - Method in interface akka.remote.ContainerFormats.ActorIdentityOrBuilder
-
required .Payload correlationId = 1;
- getCount() - Method in class akka.stream.IOResult
-
Java API: Numeric value depending on context, for example IO operations performed or bytes processed.
- 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;
- getCurrentChild() - Method in class akka.pattern.BackoffSupervisor$
-
- getCurrentChild() - Static method in class akka.pattern.BackoffSupervisor
-
- GetCurrentChild$() - Constructor for class akka.pattern.BackoffSupervisor.GetCurrentChild$
-
- 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;
- GetCurrentRegions$() - Constructor for class akka.cluster.sharding.ShardRegion.GetCurrentRegions$
-
- getCurrentRegionsInstance() - Method in class akka.cluster.sharding.ShardRegion$
-
Java API:
- getCurrentRegionsInstance() - Static method in class akka.cluster.sharding.ShardRegion
-
Java API:
- GetCurrentShardState$() - Constructor for class akka.cluster.sharding.Shard.GetCurrentShardState$
-
- getCurrentTopics() - Method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- getData() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed.Builder
-
required .akka.cluster.ddata.OtherMessage data = 2;
- getData() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed
-
required .akka.cluster.ddata.OtherMessage data = 2;
- getData() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ChangedOrBuilder
-
required .akka.cluster.ddata.OtherMessage data = 2;
- getData() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
required .akka.cluster.ddata.OtherMessage data = 1;
- getData() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope
-
required .akka.cluster.ddata.OtherMessage data = 1;
- getData() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelopeOrBuilder
-
required .akka.cluster.ddata.OtherMessage data = 1;
- getData() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelope.Builder
-
required .akka.cluster.ddata.OtherMessage data = 1;
- getData() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelope
-
required .akka.cluster.ddata.OtherMessage data = 1;
- getData() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelopeOrBuilder
-
required .akka.cluster.ddata.OtherMessage data = 1;
- getData() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
required .akka.cluster.ddata.OtherMessage data = 2;
- getData() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess
-
required .akka.cluster.ddata.OtherMessage data = 2;
- getData() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccessOrBuilder
-
required .akka.cluster.ddata.OtherMessage data = 2;
- getData(String) - Method in class akka.cluster.ddata.Replicator
-
- getData() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot.Builder
-
required .PersistentPayload data = 2;
- getData() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot
-
required .PersistentPayload data = 2;
- getData() - Method in interface akka.persistence.serialization.MessageFormats.PersistentFSMSnapshotOrBuilder
-
required .PersistentPayload data = 2;
- getDataBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed.Builder
-
required .akka.cluster.ddata.OtherMessage data = 2;
- getDataBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
required .akka.cluster.ddata.OtherMessage data = 1;
- getDataBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelope.Builder
-
required .akka.cluster.ddata.OtherMessage data = 1;
- getDataBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
required .akka.cluster.ddata.OtherMessage data = 2;
- getDataBuilder() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot.Builder
-
required .PersistentPayload data = 2;
- getDataOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed.Builder
-
required .akka.cluster.ddata.OtherMessage data = 2;
- getDataOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed
-
required .akka.cluster.ddata.OtherMessage data = 2;
- getDataOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ChangedOrBuilder
-
required .akka.cluster.ddata.OtherMessage data = 2;
- getDataOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
required .akka.cluster.ddata.OtherMessage data = 1;
- getDataOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope
-
required .akka.cluster.ddata.OtherMessage data = 1;
- getDataOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelopeOrBuilder
-
required .akka.cluster.ddata.OtherMessage data = 1;
- getDataOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelope.Builder
-
required .akka.cluster.ddata.OtherMessage data = 1;
- getDataOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelope
-
required .akka.cluster.ddata.OtherMessage data = 1;
- getDataOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelopeOrBuilder
-
required .akka.cluster.ddata.OtherMessage data = 1;
- getDataOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
required .akka.cluster.ddata.OtherMessage data = 2;
- getDataOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess
-
required .akka.cluster.ddata.OtherMessage data = 2;
- getDataOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccessOrBuilder
-
required .akka.cluster.ddata.OtherMessage data = 2;
- getDataOrBuilder() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot.Builder
-
required .PersistentPayload data = 2;
- getDataOrBuilder() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot
-
required .PersistentPayload data = 2;
- getDataOrBuilder() - Method in interface akka.persistence.serialization.MessageFormats.PersistentFSMSnapshotOrBuilder
-
required .PersistentPayload data = 2;
- getDeadline(Option<FiniteDuration>) - Method in class akka.remote.testconductor.BarrierCoordinator
-
- getDecrements() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter.Builder
-
required .akka.cluster.ddata.GCounter decrements = 2;
- getDecrements() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter
-
required .akka.cluster.ddata.GCounter decrements = 2;
- getDecrements() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterOrBuilder
-
required .akka.cluster.ddata.GCounter decrements = 2;
- getDecrementsBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter.Builder
-
required .akka.cluster.ddata.GCounter decrements = 2;
- getDecrementsOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter.Builder
-
required .akka.cluster.ddata.GCounter decrements = 2;
- getDecrementsOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter
-
required .akka.cluster.ddata.GCounter decrements = 2;
- getDecrementsOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterOrBuilder
-
required .akka.cluster.ddata.GCounter decrements = 2;
- 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.client.protobuf.msg.ClusterClientMessages.Contacts
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.Flag
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Address
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelope
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Empty
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Read
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResult
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe
-
- getDefaultInstance() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write
-
- 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.SendToOneSubscriber
-
- 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.cluster.sharding.protobuf.msg.ClusterShardingMessages.ActorRefMessage
-
- getDefaultInstance() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState
-
- getDefaultInstance() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry
-
- getDefaultInstance() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStarted
-
- getDefaultInstance() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState
-
- getDefaultInstance() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStopped
-
- getDefaultInstance() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome
-
- getDefaultInstance() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated
-
- getDefaultInstance() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessage
-
- getDefaultInstance() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats
-
- 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.AtomicWrite
-
- getDefaultInstance() - Static method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot
-
- 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.persistence.serialization.MessageFormats.PersistentStateChangeEvent
-
- getDefaultInstance() - Static method in class akka.remote.ArteryControlFormats.Address
-
- getDefaultInstance() - Static method in class akka.remote.ArteryControlFormats.ArteryHeartbeatRsp
-
- getDefaultInstance() - Static method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement
-
- getDefaultInstance() - Static method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck
-
- getDefaultInstance() - Static method in class akka.remote.ArteryControlFormats.HandshakeReq
-
- getDefaultInstance() - Static method in class akka.remote.ArteryControlFormats.MessageWithAddress
-
- getDefaultInstance() - Static method in class akka.remote.ArteryControlFormats.Quarantined
-
- getDefaultInstance() - Static method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck
-
- getDefaultInstance() - Static method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope
-
- getDefaultInstance() - Static method in class akka.remote.ArteryControlFormats.UniqueAddress
-
- getDefaultInstance() - Static method in class akka.remote.ContainerFormats.ActorIdentity
-
- getDefaultInstance() - Static method in class akka.remote.ContainerFormats.ActorInitializationException
-
- getDefaultInstance() - Static method in class akka.remote.ContainerFormats.ActorRef
-
- getDefaultInstance() - Static method in class akka.remote.ContainerFormats.Identify
-
- getDefaultInstance() - Static method in class akka.remote.ContainerFormats.Option
-
- getDefaultInstance() - Static method in class akka.remote.ContainerFormats.Payload
-
- 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.ContainerFormats.StackTraceElement
-
- getDefaultInstance() - Static method in class akka.remote.ContainerFormats.Throwable
-
- getDefaultInstance() - Static method in class akka.remote.ContainerFormats.WatcherHeartbeatResponse
-
- getDefaultInstance() - Static method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData
-
- getDefaultInstance() - Static method in class akka.remote.SystemMessageFormats.FailedData
-
- getDefaultInstance() - Static method in class akka.remote.SystemMessageFormats.SuperviseData
-
- getDefaultInstance() - Static method in class akka.remote.SystemMessageFormats.SystemMessage
-
- getDefaultInstance() - Static method in class akka.remote.SystemMessageFormats.WatchData
-
- 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
-
- getDefaultInstance() - Static method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet
-
- getDefaultInstance() - Static method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2
-
- getDefaultInstance() - Static method in class docs.persistence.proto.FlightAppModels.SeatReserved
-
- getDefaultInstanceForType() - Method in class akka.cluster.client.protobuf.msg.ClusterClientMessages.Contacts.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.client.protobuf.msg.ClusterClientMessages.Contacts
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.Flag.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.Flag
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Address.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Address
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelope.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelope
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Empty.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Empty
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Read.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Read
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResult.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResult
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write
-
- 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.SendToOneSubscriber.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToOneSubscriber
-
- 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.cluster.sharding.protobuf.msg.ClusterShardingMessages.ActorRefMessage.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ActorRefMessage
-
- getDefaultInstanceForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState
-
- getDefaultInstanceForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry
-
- getDefaultInstanceForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStarted.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStarted
-
- getDefaultInstanceForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState
-
- getDefaultInstanceForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStopped.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStopped
-
- getDefaultInstanceForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome
-
- getDefaultInstanceForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated
-
- getDefaultInstanceForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessage.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessage
-
- getDefaultInstanceForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats.Builder
-
- getDefaultInstanceForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats
-
- 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.AtomicWrite.Builder
-
- getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite
-
- getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot.Builder
-
- getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot
-
- 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.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
-
- getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
-
- getDefaultInstanceForType() - Method in class akka.remote.ArteryControlFormats.Address.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.ArteryControlFormats.Address
-
- getDefaultInstanceForType() - Method in class akka.remote.ArteryControlFormats.ArteryHeartbeatRsp.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.ArteryControlFormats.ArteryHeartbeatRsp
-
- getDefaultInstanceForType() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement
-
- getDefaultInstanceForType() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck
-
- getDefaultInstanceForType() - Method in class akka.remote.ArteryControlFormats.HandshakeReq.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.ArteryControlFormats.HandshakeReq
-
- getDefaultInstanceForType() - Method in class akka.remote.ArteryControlFormats.MessageWithAddress.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.ArteryControlFormats.MessageWithAddress
-
- getDefaultInstanceForType() - Method in class akka.remote.ArteryControlFormats.Quarantined.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.ArteryControlFormats.Quarantined
-
- getDefaultInstanceForType() - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck
-
- getDefaultInstanceForType() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope
-
- getDefaultInstanceForType() - Method in class akka.remote.ArteryControlFormats.UniqueAddress.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.ArteryControlFormats.UniqueAddress
-
- getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.ActorIdentity.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.ActorIdentity
-
- getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.ActorInitializationException
-
- getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.ActorRef.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.ActorRef
-
- getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.Identify.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.Identify
-
- getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.Option.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.Option
-
- getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.Payload.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.Payload
-
- 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.ContainerFormats.StackTraceElement.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.StackTraceElement
-
- getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.Throwable
-
- getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.WatcherHeartbeatResponse.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.ContainerFormats.WatcherHeartbeatResponse
-
- getDefaultInstanceForType() - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData
-
- getDefaultInstanceForType() - Method in class akka.remote.SystemMessageFormats.FailedData.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.SystemMessageFormats.FailedData
-
- getDefaultInstanceForType() - Method in class akka.remote.SystemMessageFormats.SuperviseData.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.SystemMessageFormats.SuperviseData
-
- getDefaultInstanceForType() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.SystemMessageFormats.SystemMessage
-
- getDefaultInstanceForType() - Method in class akka.remote.SystemMessageFormats.WatchData.Builder
-
- getDefaultInstanceForType() - Method in class akka.remote.SystemMessageFormats.WatchData
-
- 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
-
- getDefaultInstanceForType() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet.Builder
-
- getDefaultInstanceForType() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet
-
- getDefaultInstanceForType() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2.Builder
-
- getDefaultInstanceForType() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2
-
- getDefaultInstanceForType() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved.Builder
-
- getDefaultInstanceForType() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved
-
- 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.AtLeastOnceDeliveryLike
-
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.client.protobuf.msg.ClusterClientMessages.Contacts.Builder
-
- getDescriptor() - Static method in class akka.cluster.client.protobuf.msg.ClusterClientMessages.Contacts
-
- getDescriptor() - Static method in class akka.cluster.client.protobuf.msg.ClusterClientMessages
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.Flag.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.Flag
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Address.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Address
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelope.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelope
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Empty.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Empty
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Read.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Read
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResult.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResult
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write.Builder
-
- getDescriptor() - Static method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write
-
- 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.SendToOneSubscriber.Builder
-
- getDescriptor() - Static method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToOneSubscriber
-
- 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.cluster.sharding.protobuf.msg.ClusterShardingMessages.ActorRefMessage.Builder
-
- getDescriptor() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ActorRefMessage
-
- getDescriptor() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
- getDescriptor() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState
-
- getDescriptor() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry.Builder
-
- getDescriptor() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry
-
- getDescriptor() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStarted.Builder
-
- getDescriptor() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStarted
-
- getDescriptor() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState.Builder
-
- getDescriptor() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState
-
- getDescriptor() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStopped.Builder
-
- getDescriptor() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStopped
-
- getDescriptor() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages
-
- getDescriptor() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome.Builder
-
- getDescriptor() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome
-
- getDescriptor() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated.Builder
-
- getDescriptor() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated
-
- getDescriptor() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessage.Builder
-
- getDescriptor() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessage
-
- getDescriptor() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats.Builder
-
- getDescriptor() - Static method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats
-
- 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.AtomicWrite.Builder
-
- getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.AtomicWrite
-
- getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats
-
- getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot.Builder
-
- getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot
-
- 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.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
-
- getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
-
- getDescriptor() - Static method in class akka.remote.ArteryControlFormats.Address.Builder
-
- getDescriptor() - Static method in class akka.remote.ArteryControlFormats.Address
-
- getDescriptor() - Static method in class akka.remote.ArteryControlFormats.ArteryHeartbeatRsp.Builder
-
- getDescriptor() - Static method in class akka.remote.ArteryControlFormats.ArteryHeartbeatRsp
-
- getDescriptor() - Static method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
- getDescriptor() - Static method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement
-
- getDescriptor() - Static method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck.Builder
-
- getDescriptor() - Static method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck
-
- getDescriptor() - Static method in class akka.remote.ArteryControlFormats
-
- getDescriptor() - Static method in class akka.remote.ArteryControlFormats.HandshakeReq.Builder
-
- getDescriptor() - Static method in class akka.remote.ArteryControlFormats.HandshakeReq
-
- getDescriptor() - Static method in class akka.remote.ArteryControlFormats.MessageWithAddress.Builder
-
- getDescriptor() - Static method in class akka.remote.ArteryControlFormats.MessageWithAddress
-
- getDescriptor() - Static method in class akka.remote.ArteryControlFormats.Quarantined.Builder
-
- getDescriptor() - Static method in class akka.remote.ArteryControlFormats.Quarantined
-
- getDescriptor() - Static method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck.Builder
-
- getDescriptor() - Static method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck
-
- getDescriptor() - Static method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope.Builder
-
- getDescriptor() - Static method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope
-
- getDescriptor() - Static method in class akka.remote.ArteryControlFormats.UniqueAddress.Builder
-
- getDescriptor() - Static method in class akka.remote.ArteryControlFormats.UniqueAddress
-
- getDescriptor() - Static method in class akka.remote.ContainerFormats.ActorIdentity.Builder
-
- getDescriptor() - Static method in class akka.remote.ContainerFormats.ActorIdentity
-
- getDescriptor() - Static method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
- getDescriptor() - Static method in class akka.remote.ContainerFormats.ActorInitializationException
-
- getDescriptor() - Static method in class akka.remote.ContainerFormats.ActorRef.Builder
-
- getDescriptor() - Static method in class akka.remote.ContainerFormats.ActorRef
-
- getDescriptor() - Static method in class akka.remote.ContainerFormats
-
- getDescriptor() - Static method in class akka.remote.ContainerFormats.Identify.Builder
-
- getDescriptor() - Static method in class akka.remote.ContainerFormats.Identify
-
- getDescriptor() - Static method in class akka.remote.ContainerFormats.Option.Builder
-
- getDescriptor() - Static method in class akka.remote.ContainerFormats.Option
-
- getDescriptor() - Static method in enum akka.remote.ContainerFormats.PatternType
-
- getDescriptor() - Static method in class akka.remote.ContainerFormats.Payload.Builder
-
- getDescriptor() - Static method in class akka.remote.ContainerFormats.Payload
-
- 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.ContainerFormats.StackTraceElement.Builder
-
- getDescriptor() - Static method in class akka.remote.ContainerFormats.StackTraceElement
-
- getDescriptor() - Static method in class akka.remote.ContainerFormats.Throwable.Builder
-
- getDescriptor() - Static method in class akka.remote.ContainerFormats.Throwable
-
- getDescriptor() - Static method in class akka.remote.ContainerFormats.WatcherHeartbeatResponse.Builder
-
- getDescriptor() - Static method in class akka.remote.ContainerFormats.WatcherHeartbeatResponse
-
- getDescriptor() - Static method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData.Builder
-
- getDescriptor() - Static method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData
-
- getDescriptor() - Static method in class akka.remote.SystemMessageFormats.FailedData.Builder
-
- getDescriptor() - Static method in class akka.remote.SystemMessageFormats.FailedData
-
- getDescriptor() - Static method in class akka.remote.SystemMessageFormats
-
- getDescriptor() - Static method in class akka.remote.SystemMessageFormats.SuperviseData.Builder
-
- getDescriptor() - Static method in class akka.remote.SystemMessageFormats.SuperviseData
-
- getDescriptor() - Static method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
- getDescriptor() - Static method in class akka.remote.SystemMessageFormats.SystemMessage
-
- getDescriptor() - Static method in enum akka.remote.SystemMessageFormats.SystemMessage.Type
-
- getDescriptor() - Static method in class akka.remote.SystemMessageFormats.WatchData.Builder
-
- getDescriptor() - Static method in class akka.remote.SystemMessageFormats.WatchData
-
- 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
-
- getDescriptor() - Static method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages
-
- getDescriptor() - Static method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet.Builder
-
- getDescriptor() - Static method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet
-
- getDescriptor() - Static method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2.Builder
-
- getDescriptor() - Static method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2
-
- getDescriptor() - Static method in class docs.persistence.proto.FlightAppModels
-
- getDescriptor() - Static method in class docs.persistence.proto.FlightAppModels.SeatReserved.Builder
-
- getDescriptor() - Static method in class docs.persistence.proto.FlightAppModels.SeatReserved
-
- getDescriptorForType() - Method in class akka.cluster.client.protobuf.msg.ClusterClientMessages.Contacts.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.Flag.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Address.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelope.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Empty.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Read.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResult.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe.Builder
-
- getDescriptorForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write.Builder
-
- 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.SendToOneSubscriber.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.cluster.sharding.protobuf.msg.ClusterShardingMessages.ActorRefMessage.Builder
-
- getDescriptorForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
- getDescriptorForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry.Builder
-
- getDescriptorForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStarted.Builder
-
- getDescriptorForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState.Builder
-
- getDescriptorForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStopped.Builder
-
- getDescriptorForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome.Builder
-
- getDescriptorForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated.Builder
-
- getDescriptorForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessage.Builder
-
- getDescriptorForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats.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.AtomicWrite.Builder
-
- getDescriptorForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot.Builder
-
- getDescriptorForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
- getDescriptorForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
-
- getDescriptorForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
-
- getDescriptorForType() - Method in class akka.remote.ArteryControlFormats.Address.Builder
-
- getDescriptorForType() - Method in class akka.remote.ArteryControlFormats.ArteryHeartbeatRsp.Builder
-
- getDescriptorForType() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
- getDescriptorForType() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck.Builder
-
- getDescriptorForType() - Method in class akka.remote.ArteryControlFormats.HandshakeReq.Builder
-
- getDescriptorForType() - Method in class akka.remote.ArteryControlFormats.MessageWithAddress.Builder
-
- getDescriptorForType() - Method in class akka.remote.ArteryControlFormats.Quarantined.Builder
-
- getDescriptorForType() - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck.Builder
-
- getDescriptorForType() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope.Builder
-
- getDescriptorForType() - Method in class akka.remote.ArteryControlFormats.UniqueAddress.Builder
-
- getDescriptorForType() - Method in class akka.remote.ContainerFormats.ActorIdentity.Builder
-
- getDescriptorForType() - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
- getDescriptorForType() - Method in class akka.remote.ContainerFormats.ActorRef.Builder
-
- getDescriptorForType() - Method in class akka.remote.ContainerFormats.Identify.Builder
-
- getDescriptorForType() - Method in class akka.remote.ContainerFormats.Option.Builder
-
- getDescriptorForType() - Method in enum akka.remote.ContainerFormats.PatternType
-
- getDescriptorForType() - Method in class akka.remote.ContainerFormats.Payload.Builder
-
- getDescriptorForType() - Method in class akka.remote.ContainerFormats.Selection.Builder
-
- getDescriptorForType() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
- getDescriptorForType() - Method in class akka.remote.ContainerFormats.StackTraceElement.Builder
-
- getDescriptorForType() - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
- getDescriptorForType() - Method in class akka.remote.ContainerFormats.WatcherHeartbeatResponse.Builder
-
- getDescriptorForType() - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData.Builder
-
- getDescriptorForType() - Method in class akka.remote.SystemMessageFormats.FailedData.Builder
-
- getDescriptorForType() - Method in class akka.remote.SystemMessageFormats.SuperviseData.Builder
-
- getDescriptorForType() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
- getDescriptorForType() - Method in enum akka.remote.SystemMessageFormats.SystemMessage.Type
-
- getDescriptorForType() - Method in class akka.remote.SystemMessageFormats.WatchData.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
-
- getDescriptorForType() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet.Builder
-
- getDescriptorForType() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2.Builder
-
- getDescriptorForType() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved.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;
- getDigest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry.Builder
-
required bytes digest = 2;
- getDigest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry
-
required bytes digest = 2;
- getDigest() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.EntryOrBuilder
-
required bytes digest = 2;
- getDigest(String) - Method in class akka.cluster.ddata.Replicator
-
- 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;
- getDots(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- getDots(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- getDots(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSetOrBuilder
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- getDotsBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- getDotsBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- getDotsCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- getDotsCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- getDotsCount() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSetOrBuilder
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- getDotsList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- getDotsList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- getDotsList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSetOrBuilder
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- getDotsOrBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- getDotsOrBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- getDotsOrBuilder(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSetOrBuilder
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- getDotsOrBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- getDotsOrBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- getDotsOrBuilderList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSetOrBuilder
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- 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
-
- getDwNotificationData() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .DeathWatchNotificationData dwNotificationData = 7;
- getDwNotificationData() - Method in class akka.remote.SystemMessageFormats.SystemMessage
-
optional .DeathWatchNotificationData dwNotificationData = 7;
- getDwNotificationData() - Method in interface akka.remote.SystemMessageFormats.SystemMessageOrBuilder
-
optional .DeathWatchNotificationData dwNotificationData = 7;
- getDwNotificationDataBuilder() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .DeathWatchNotificationData dwNotificationData = 7;
- getDwNotificationDataOrBuilder() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .DeathWatchNotificationData dwNotificationData = 7;
- getDwNotificationDataOrBuilder() - Method in class akka.remote.SystemMessageFormats.SystemMessage
-
optional .DeathWatchNotificationData dwNotificationData = 7;
- getDwNotificationDataOrBuilder() - Method in interface akka.remote.SystemMessageFormats.SystemMessageOrBuilder
-
optional .DeathWatchNotificationData dwNotificationData = 7;
- getEffect() - Method in class akka.typed.EffectfulActorContext
-
- getElements() - Method in interface akka.actor.ActorPath
-
Java API: Sequence of names for this path from root to this.
- getElements() - Static method in class akka.actor.RootActorPath
-
- getElements() - Method in class akka.cluster.ddata.GSet
-
Java API
- getElements() - Method in class akka.cluster.ddata.ORSet
-
Java API
- getElements(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet.Builder
-
repeated string elements = 1;
- getElements(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet
-
repeated string elements = 1;
- getElements(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSetOrBuilder
-
repeated string elements = 1;
- getElementsBytes(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet.Builder
-
repeated string elements = 1;
- getElementsBytes(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet
-
repeated string elements = 1;
- getElementsBytes(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSetOrBuilder
-
repeated string elements = 1;
- getElementsCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet.Builder
-
repeated string elements = 1;
- getElementsCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet
-
repeated string elements = 1;
- getElementsCount() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSetOrBuilder
-
repeated string elements = 1;
- getElementsList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet.Builder
-
repeated string elements = 1;
- getElementsList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet
-
repeated string elements = 1;
- getElementsList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSetOrBuilder
-
repeated string elements = 1;
- getEnabled() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.Flag.Builder
-
required bool enabled = 1;
- getEnabled() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.Flag
-
required bool enabled = 1;
- getEnabled() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.FlagOrBuilder
-
required bool enabled = 1;
- getEnclosedMessage() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage.Builder
-
required bytes enclosedMessage = 1;
- getEnclosedMessage() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage
-
required bytes enclosedMessage = 1;
- getEnclosedMessage() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessageOrBuilder
-
required bytes enclosedMessage = 1;
- 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.Payload.Builder
-
required bytes enclosedMessage = 1;
- getEnclosedMessage() - Method in class akka.remote.ContainerFormats.Payload
-
required bytes enclosedMessage = 1;
- getEnclosedMessage() - Method in interface akka.remote.ContainerFormats.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.
- getEntities(int) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState.Builder
-
repeated string entities = 1;
- getEntities(int) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState
-
repeated string entities = 1;
- getEntities(int) - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStateOrBuilder
-
repeated string entities = 1;
- getEntitiesBytes(int) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState.Builder
-
repeated string entities = 1;
- getEntitiesBytes(int) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState
-
repeated string entities = 1;
- getEntitiesBytes(int) - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStateOrBuilder
-
repeated string entities = 1;
- getEntitiesCount() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState.Builder
-
repeated string entities = 1;
- getEntitiesCount() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState
-
repeated string entities = 1;
- getEntitiesCount() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStateOrBuilder
-
repeated string entities = 1;
- getEntitiesList() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState.Builder
-
repeated string entities = 1;
- getEntitiesList() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState
-
repeated string entities = 1;
- getEntitiesList() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStateOrBuilder
-
repeated string entities = 1;
- getEntity(String) - Method in class akka.cluster.sharding.Shard
-
- getEntityCount() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats.Builder
-
required int32 entityCount = 2;
- getEntityCount() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats
-
required int32 entityCount = 2;
- getEntityCount() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStatsOrBuilder
-
required int32 entityCount = 2;
- getEntityId() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStarted.Builder
-
required string entityId = 1;
- getEntityId() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStarted
-
required string entityId = 1;
- getEntityId() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStartedOrBuilder
-
required string entityId = 1;
- getEntityId() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStopped.Builder
-
required string entityId = 1;
- getEntityId() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStopped
-
required string entityId = 1;
- getEntityId() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStoppedOrBuilder
-
required string entityId = 1;
- getEntityIdBytes() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStarted.Builder
-
required string entityId = 1;
- getEntityIdBytes() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStarted
-
required string entityId = 1;
- getEntityIdBytes() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStartedOrBuilder
-
required string entityId = 1;
- getEntityIdBytes() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStopped.Builder
-
required string entityId = 1;
- getEntityIdBytes() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStopped
-
required string entityId = 1;
- getEntityIdBytes() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStoppedOrBuilder
-
required string entityId = 1;
- getEntityIds() - Method in class akka.cluster.sharding.ShardRegion.ShardState
-
Java API:
- getEntries() - Method in class akka.cluster.ddata.LWWMap
-
Java API: All entries of the map.
- getEntries() - Method in class akka.cluster.ddata.ORMap
-
Java API: All entries of the map.
- getEntries() - Method in class akka.cluster.ddata.ORMultiMap
-
Java API: All entries of a multimap where keys are strings and values are sets.
- getEntries() - Method in class akka.cluster.ddata.PNCounterMap
-
Java API
- getEntries(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Builder
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- getEntries(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- getEntries(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounterOrBuilder
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- getEntries(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- getEntries(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- getEntries(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMapOrBuilder
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- getEntries(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- getEntries(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- getEntries(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMapOrBuilder
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- getEntries(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- getEntries(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- getEntries(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMapOrBuilder
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- getEntries(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- getEntries(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- getEntries(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMapOrBuilder
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- getEntries(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Builder
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- getEntries(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- getEntries(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVectorOrBuilder
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- getEntries(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- getEntries(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- getEntries(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GossipOrBuilder
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- getEntries(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
repeated .akka.cluster.ddata.Status.Entry entries = 3;
- getEntries(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status
-
repeated .akka.cluster.ddata.Status.Entry entries = 3;
- getEntries(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StatusOrBuilder
-
repeated .akka.cluster.ddata.Status.Entry entries = 3;
- getEntriesBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Builder
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- getEntriesBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- getEntriesBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- getEntriesBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- getEntriesBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- getEntriesBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Builder
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- getEntriesBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- getEntriesBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
repeated .akka.cluster.ddata.Status.Entry entries = 3;
- getEntriesBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Builder
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- getEntriesBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- getEntriesBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- getEntriesBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- getEntriesBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- getEntriesBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Builder
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- getEntriesBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- getEntriesBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
repeated .akka.cluster.ddata.Status.Entry entries = 3;
- getEntriesCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Builder
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- getEntriesCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- getEntriesCount() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounterOrBuilder
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- getEntriesCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- getEntriesCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- getEntriesCount() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMapOrBuilder
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- getEntriesCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- getEntriesCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- getEntriesCount() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMapOrBuilder
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- getEntriesCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- getEntriesCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- getEntriesCount() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMapOrBuilder
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- getEntriesCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- getEntriesCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- getEntriesCount() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMapOrBuilder
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- getEntriesCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Builder
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- getEntriesCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- getEntriesCount() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVectorOrBuilder
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- getEntriesCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- getEntriesCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- getEntriesCount() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GossipOrBuilder
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- getEntriesCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
repeated .akka.cluster.ddata.Status.Entry entries = 3;
- getEntriesCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status
-
repeated .akka.cluster.ddata.Status.Entry entries = 3;
- getEntriesCount() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StatusOrBuilder
-
repeated .akka.cluster.ddata.Status.Entry entries = 3;
- getEntriesList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Builder
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- getEntriesList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- getEntriesList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounterOrBuilder
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- getEntriesList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- getEntriesList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- getEntriesList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMapOrBuilder
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- getEntriesList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- getEntriesList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- getEntriesList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMapOrBuilder
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- getEntriesList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- getEntriesList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- getEntriesList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMapOrBuilder
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- getEntriesList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- getEntriesList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- getEntriesList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMapOrBuilder
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- getEntriesList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Builder
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- getEntriesList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- getEntriesList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVectorOrBuilder
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- getEntriesList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- getEntriesList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- getEntriesList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GossipOrBuilder
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- getEntriesList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
repeated .akka.cluster.ddata.Status.Entry entries = 3;
- getEntriesList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status
-
repeated .akka.cluster.ddata.Status.Entry entries = 3;
- getEntriesList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StatusOrBuilder
-
repeated .akka.cluster.ddata.Status.Entry entries = 3;
- getEntriesOrBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Builder
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- getEntriesOrBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- getEntriesOrBuilder(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounterOrBuilder
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- getEntriesOrBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- getEntriesOrBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- getEntriesOrBuilder(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMapOrBuilder
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- getEntriesOrBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- getEntriesOrBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- getEntriesOrBuilder(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMapOrBuilder
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- getEntriesOrBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- getEntriesOrBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- getEntriesOrBuilder(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMapOrBuilder
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- getEntriesOrBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- getEntriesOrBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- getEntriesOrBuilder(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMapOrBuilder
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- getEntriesOrBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Builder
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- getEntriesOrBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- getEntriesOrBuilder(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVectorOrBuilder
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- getEntriesOrBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- getEntriesOrBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- getEntriesOrBuilder(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GossipOrBuilder
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- getEntriesOrBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
repeated .akka.cluster.ddata.Status.Entry entries = 3;
- getEntriesOrBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status
-
repeated .akka.cluster.ddata.Status.Entry entries = 3;
- getEntriesOrBuilder(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StatusOrBuilder
-
repeated .akka.cluster.ddata.Status.Entry entries = 3;
- getEntriesOrBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Builder
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- getEntriesOrBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- getEntriesOrBuilderList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounterOrBuilder
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- getEntriesOrBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- getEntriesOrBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- getEntriesOrBuilderList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMapOrBuilder
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- getEntriesOrBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- getEntriesOrBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- getEntriesOrBuilderList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMapOrBuilder
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- getEntriesOrBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- getEntriesOrBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- getEntriesOrBuilderList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMapOrBuilder
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- getEntriesOrBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- getEntriesOrBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- getEntriesOrBuilderList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMapOrBuilder
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- getEntriesOrBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Builder
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- getEntriesOrBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- getEntriesOrBuilderList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVectorOrBuilder
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- getEntriesOrBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- getEntriesOrBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- getEntriesOrBuilderList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GossipOrBuilder
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- getEntriesOrBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
repeated .akka.cluster.ddata.Status.Entry entries = 3;
- getEntriesOrBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status
-
repeated .akka.cluster.ddata.Status.Entry entries = 3;
- getEntriesOrBuilderList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StatusOrBuilder
-
repeated .akka.cluster.ddata.Status.Entry entries = 3;
- getEnvelope() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry.Builder
-
required .akka.cluster.ddata.DataEnvelope envelope = 2;
- getEnvelope() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry
-
required .akka.cluster.ddata.DataEnvelope envelope = 2;
- getEnvelope() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.EntryOrBuilder
-
required .akka.cluster.ddata.DataEnvelope envelope = 2;
- getEnvelope() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResult.Builder
-
optional .akka.cluster.ddata.DataEnvelope envelope = 1;
- getEnvelope() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResult
-
optional .akka.cluster.ddata.DataEnvelope envelope = 1;
- getEnvelope() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResultOrBuilder
-
optional .akka.cluster.ddata.DataEnvelope envelope = 1;
- getEnvelope() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write.Builder
-
required .akka.cluster.ddata.DataEnvelope envelope = 2;
- getEnvelope() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write
-
required .akka.cluster.ddata.DataEnvelope envelope = 2;
- getEnvelope() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.WriteOrBuilder
-
required .akka.cluster.ddata.DataEnvelope envelope = 2;
- 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.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry.Builder
-
required .akka.cluster.ddata.DataEnvelope envelope = 2;
- getEnvelopeBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResult.Builder
-
optional .akka.cluster.ddata.DataEnvelope envelope = 1;
- getEnvelopeBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write.Builder
-
required .akka.cluster.ddata.DataEnvelope envelope = 2;
- getEnvelopeBuilder() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
optional .RemoteEnvelope envelope = 2;
- getEnvelopeOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry.Builder
-
required .akka.cluster.ddata.DataEnvelope envelope = 2;
- getEnvelopeOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry
-
required .akka.cluster.ddata.DataEnvelope envelope = 2;
- getEnvelopeOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.EntryOrBuilder
-
required .akka.cluster.ddata.DataEnvelope envelope = 2;
- getEnvelopeOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResult.Builder
-
optional .akka.cluster.ddata.DataEnvelope envelope = 1;
- getEnvelopeOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResult
-
optional .akka.cluster.ddata.DataEnvelope envelope = 1;
- getEnvelopeOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResultOrBuilder
-
optional .akka.cluster.ddata.DataEnvelope envelope = 1;
- getEnvelopeOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write.Builder
-
required .akka.cluster.ddata.DataEnvelope envelope = 2;
- getEnvelopeOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write
-
required .akka.cluster.ddata.DataEnvelope envelope = 2;
- getEnvelopeOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.WriteOrBuilder
-
required .akka.cluster.ddata.DataEnvelope 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;
- getError() - Method in class akka.stream.IOResult
-
Java API: If the IO operation resulted in an error, returns the corresponding Throwable
or throws UnsupportedOperationException
otherwise.
- 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;
- getException() - Static method in class akka.dispatch.Mailbox
-
- getExchangeId() - Method in class akka.camel.internal.CamelExchangeAdapter
-
Returns the exchange id
- getExistenceConfirmed() - Method in class akka.actor.Terminated
-
- getExistenceConfirmed() - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData.Builder
-
required bool existenceConfirmed = 2;
- getExistenceConfirmed() - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData
-
required bool existenceConfirmed = 2;
- getExistenceConfirmed() - Method in interface akka.remote.SystemMessageFormats.DeathWatchNotificationDataOrBuilder
-
required bool existenceConfirmed = 2;
- 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
-
- getFailedData() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .FailedData failedData = 6;
- getFailedData() - Method in class akka.remote.SystemMessageFormats.SystemMessage
-
optional .FailedData failedData = 6;
- getFailedData() - Method in interface akka.remote.SystemMessageFormats.SystemMessageOrBuilder
-
optional .FailedData failedData = 6;
- getFailedDataBuilder() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .FailedData failedData = 6;
- getFailedDataOrBuilder() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .FailedData failedData = 6;
- getFailedDataOrBuilder() - Method in class akka.remote.SystemMessageFormats.SystemMessage
-
optional .FailedData failedData = 6;
- getFailedDataOrBuilder() - Method in interface akka.remote.SystemMessageFormats.SystemMessageOrBuilder
-
optional .FailedData failedData = 6;
- GetFailure(Key<A>, Option<Object>) - Constructor for class akka.cluster.ddata.Replicator.GetFailure
-
- 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;
- GetFailure$() - Constructor for class akka.cluster.ddata.Replicator.GetFailure$
-
- getFailureBuilder() - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .InjectFailure failure = 3;
- GetFailureManifest() - Method in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer
-
- 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;
- getFileName() - Method in class akka.remote.ContainerFormats.StackTraceElement.Builder
-
required string fileName = 3;
- getFileName() - Method in class akka.remote.ContainerFormats.StackTraceElement
-
required string fileName = 3;
- getFileName() - Method in interface akka.remote.ContainerFormats.StackTraceElementOrBuilder
-
required string fileName = 3;
- getFileNameBytes() - Method in class akka.remote.ContainerFormats.StackTraceElement.Builder
-
required string fileName = 3;
- getFileNameBytes() - Method in class akka.remote.ContainerFormats.StackTraceElement
-
required string fileName = 3;
- getFileNameBytes() - Method in interface akka.remote.ContainerFormats.StackTraceElementOrBuilder
-
required string fileName = 3;
- getFirst(T, ClassTag<T>) - Method in class akka.stream.Attributes
-
Scala API: Get the first (least specific) attribute of a given type parameter T Class
or subclass thereof.
- getFirst(ClassTag<T>) - Method in class akka.stream.Attributes
-
Scala API: Get the first (least specific) attribute of a given type parameter T Class
or subclass thereof.
- getFirstAttribute(Class<T>, T) - Method in class akka.stream.Attributes
-
Java API: Get the first (least specific) attribute of a given Class
or subclass thereof.
- getFirstAttribute(Class<T>) - Method in class akka.stream.Attributes
-
Java API: Get the first (least specific) attribute of a given Class
or subclass thereof.
- 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
-
- getForkJoinTaskTag() - Static method in class akka.dispatch.Mailbox
-
- 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;
- getFrom() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
required .UniqueAddress from = 1;
- getFrom() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement
-
required .UniqueAddress from = 1;
- getFrom() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck.Builder
-
required .UniqueAddress from = 1;
- getFrom() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck
-
required .UniqueAddress from = 1;
- getFrom() - Method in interface akka.remote.ArteryControlFormats.CompressionTableAdvertisementAckOrBuilder
-
required .UniqueAddress from = 1;
- getFrom() - Method in interface akka.remote.ArteryControlFormats.CompressionTableAdvertisementOrBuilder
-
required .UniqueAddress from = 1;
- getFrom() - Method in class akka.remote.ArteryControlFormats.HandshakeReq.Builder
-
required .UniqueAddress from = 1;
- getFrom() - Method in class akka.remote.ArteryControlFormats.HandshakeReq
-
required .UniqueAddress from = 1;
- getFrom() - Method in interface akka.remote.ArteryControlFormats.HandshakeReqOrBuilder
-
required .UniqueAddress from = 1;
- getFrom() - Method in class akka.remote.ArteryControlFormats.Quarantined.Builder
-
required .UniqueAddress from = 1;
- getFrom() - Method in class akka.remote.ArteryControlFormats.Quarantined
-
required .UniqueAddress from = 1;
- getFrom() - Method in interface akka.remote.ArteryControlFormats.QuarantinedOrBuilder
-
required .UniqueAddress from = 1;
- getFrom() - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck.Builder
-
required .UniqueAddress from = 2;
- getFrom() - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck
-
required .UniqueAddress from = 2;
- getFrom() - Method in interface akka.remote.ArteryControlFormats.SystemMessageDeliveryAckOrBuilder
-
required .UniqueAddress from = 2;
- 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;
- getFromBuilder() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
required .UniqueAddress from = 1;
- getFromBuilder() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck.Builder
-
required .UniqueAddress from = 1;
- getFromBuilder() - Method in class akka.remote.ArteryControlFormats.HandshakeReq.Builder
-
required .UniqueAddress from = 1;
- getFromBuilder() - Method in class akka.remote.ArteryControlFormats.Quarantined.Builder
-
required .UniqueAddress from = 1;
- getFromBuilder() - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck.Builder
-
required .UniqueAddress from = 2;
- 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;
- getFromOrBuilder() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
required .UniqueAddress from = 1;
- getFromOrBuilder() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement
-
required .UniqueAddress from = 1;
- getFromOrBuilder() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck.Builder
-
required .UniqueAddress from = 1;
- getFromOrBuilder() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck
-
required .UniqueAddress from = 1;
- getFromOrBuilder() - Method in interface akka.remote.ArteryControlFormats.CompressionTableAdvertisementAckOrBuilder
-
required .UniqueAddress from = 1;
- getFromOrBuilder() - Method in interface akka.remote.ArteryControlFormats.CompressionTableAdvertisementOrBuilder
-
required .UniqueAddress from = 1;
- getFromOrBuilder() - Method in class akka.remote.ArteryControlFormats.HandshakeReq.Builder
-
required .UniqueAddress from = 1;
- getFromOrBuilder() - Method in class akka.remote.ArteryControlFormats.HandshakeReq
-
required .UniqueAddress from = 1;
- getFromOrBuilder() - Method in interface akka.remote.ArteryControlFormats.HandshakeReqOrBuilder
-
required .UniqueAddress from = 1;
- getFromOrBuilder() - Method in class akka.remote.ArteryControlFormats.Quarantined.Builder
-
required .UniqueAddress from = 1;
- getFromOrBuilder() - Method in class akka.remote.ArteryControlFormats.Quarantined
-
required .UniqueAddress from = 1;
- getFromOrBuilder() - Method in interface akka.remote.ArteryControlFormats.QuarantinedOrBuilder
-
required .UniqueAddress from = 1;
- getFromOrBuilder() - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck.Builder
-
required .UniqueAddress from = 2;
- getFromOrBuilder() - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck
-
required .UniqueAddress from = 2;
- getFromOrBuilder() - Method in interface akka.remote.ArteryControlFormats.SystemMessageDeliveryAckOrBuilder
-
required .UniqueAddress from = 2;
- getFunctionRefOrNobody(String, int) - Static method in class akka.actor.ActorCell
-
- getFunctionRefOrNobody(String, int) - Method in interface akka.actor.dungeon.Children
-
- getFunctionRefOrNobody(String, int) - Static method in class akka.routing.RoutedActorCell
-
- getFunctionRefOrNobody$default$2() - Static method in class akka.actor.ActorCell
-
- getFunctionRefOrNobody$default$2() - Static method in class akka.routing.RoutedActorCell
-
- 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;
- getHandler(Inlet<?>) - Method in class akka.stream.stage.GraphStageLogic
-
Retrieves the current callback for the events on the given Inlet
- getHandler(Outlet<?>) - Method in class akka.stream.stage.GraphStageLogic
-
Retrieves the current callback for the events on the given Outlet
- 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;
- getHasManifest(int) - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated bool hasManifest = 7;
- getHasManifest(int) - Method in class akka.remote.WireFormats.PropsData
-
repeated bool hasManifest = 7;
- getHasManifest(int) - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
-
repeated bool hasManifest = 7;
- getHasManifestCount() - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated bool hasManifest = 7;
- getHasManifestCount() - Method in class akka.remote.WireFormats.PropsData
-
repeated bool hasManifest = 7;
- getHasManifestCount() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
-
repeated bool hasManifest = 7;
- getHasManifestList() - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated bool hasManifest = 7;
- getHasManifestList() - Method in class akka.remote.WireFormats.PropsData
-
repeated bool hasManifest = 7;
- getHasManifestList() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
-
repeated bool hasManifest = 7;
- getHead() - Method in class akka.util.MessageBuffer
-
Java API
- 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.ddata.protobuf.msg.ReplicatorMessages.Address.Builder
-
required string hostname = 1;
- getHostname() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Address
-
required string hostname = 1;
- getHostname() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.AddressOrBuilder
-
required string hostname = 1;
- 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(String, Config) - Method in class akka.remote.artery.ArterySettings$
-
- getHostname(String, Config) - Static method in class akka.remote.artery.ArterySettings
-
- getHostname() - Method in class akka.remote.ArteryControlFormats.Address.Builder
-
required string hostname = 3;
- getHostname() - Method in class akka.remote.ArteryControlFormats.Address
-
required string hostname = 3;
- getHostname() - Method in interface akka.remote.ArteryControlFormats.AddressOrBuilder
-
required string hostname = 3;
- 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.ddata.protobuf.msg.ReplicatorMessages.Address.Builder
-
required string hostname = 1;
- getHostnameBytes() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Address
-
required string hostname = 1;
- getHostnameBytes() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.AddressOrBuilder
-
required string hostname = 1;
- 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.ArteryControlFormats.Address.Builder
-
required string hostname = 3;
- getHostnameBytes() - Method in class akka.remote.ArteryControlFormats.Address
-
required string hostname = 3;
- getHostnameBytes() - Method in interface akka.remote.ArteryControlFormats.AddressOrBuilder
-
required string hostname = 3;
- 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;
- getInboundFailureOnce() - Method in class akka.remote.artery.SharedTestState
-
Get the exception to fail the inbound stream with and immediately reset the state to not-failed.
- getInbox(ActorRef<U>) - Method in class akka.typed.StubbedActorContext
-
Retrieve the named inbox.
- getIncrements() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter.Builder
-
required .akka.cluster.ddata.GCounter increments = 1;
- getIncrements() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter
-
required .akka.cluster.ddata.GCounter increments = 1;
- getIncrements() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterOrBuilder
-
required .akka.cluster.ddata.GCounter increments = 1;
- getIncrementsBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter.Builder
-
required .akka.cluster.ddata.GCounter increments = 1;
- getIncrementsOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter.Builder
-
required .akka.cluster.ddata.GCounter increments = 1;
- getIncrementsOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter
-
required .akka.cluster.ddata.GCounter increments = 1;
- getIncrementsOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterOrBuilder
-
required .akka.cluster.ddata.GCounter increments = 1;
- getInetAddress(Option<Inet4Address>, Option<Inet6Address>) - Method in class akka.io.IpVersionSelector$
-
- getInetAddress(Option<Inet4Address>, Option<Inet6Address>) - Static method in class akka.io.IpVersionSelector
-
- getInfo() - Static method in class akka.remote.security.provider.AkkaProvider
-
- getInlets() - Method in class akka.stream.AbstractShape
-
- getInlets() - Static method in class akka.stream.AmorphousShape
-
- getInlets() - Static method in class akka.stream.BidiShape
-
- getInlets() - Static method in class akka.stream.ClosedShape
-
- getInlets() - Static method in class akka.stream.FanInShape
-
- getInlets() - Static method in class akka.stream.FanOutShape
-
- getInlets() - Static method in class akka.stream.FlowShape
-
- getInlets() - Method in class akka.stream.Shape
-
Java API: get a list of all input ports
- getInlets() - Static method in class akka.stream.SinkShape
-
- getInlets() - Static method in class akka.stream.SourceShape
-
- getInlets() - Static method in class akka.stream.UniformFanInShape
-
- getInlets() - Static method in class akka.stream.UniformFanOutShape
-
- 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.client.GetClusterClients$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.cluster.client.GetClusterClients
-
Java API: get the singleton instance
- getInstance() - Method in class akka.cluster.client.GetContactPoints$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.cluster.client.GetContactPoints
-
Java API: get the singleton instance
- getInstance() - Method in class akka.cluster.client.SubscribeClusterClients$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.cluster.client.SubscribeClusterClients
-
Java API: get the singleton instance
- getInstance() - Method in class akka.cluster.client.SubscribeContactPoints$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.cluster.client.SubscribeContactPoints
-
Java API: get the singleton instance
- getInstance() - Method in class akka.cluster.client.UnsubscribeClusterClients$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.cluster.client.UnsubscribeClusterClients
-
Java API: get the singleton instance
- getInstance() - Method in class akka.cluster.client.UnsubscribeContactPoints$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.cluster.client.UnsubscribeContactPoints
-
Java API: get the singleton instance
- 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$
-
Deprecated.
Java API: get the singleton instance
- getInstance() - Static method in class akka.cluster.routing.CpuMetricsSelector
-
Deprecated.
Java API: get the singleton instance
- getInstance() - Method in class akka.cluster.routing.HeapMetricsSelector$
-
Deprecated.
Java API: get the singleton instance
- getInstance() - Static method in class akka.cluster.routing.HeapMetricsSelector
-
Deprecated.
Java API: get the singleton instance
- getInstance() - Method in class akka.cluster.routing.MixMetricsSelector$
-
Deprecated.
Java API: get the default singleton instance
- getInstance() - Static method in class akka.cluster.routing.MixMetricsSelector
-
Deprecated.
Java API: get the default singleton instance
- getInstance() - Method in class akka.cluster.routing.SystemLoadAverageMetricsSelector$
-
Deprecated.
Java API: get the singleton instance
- getInstance() - Static method in class akka.cluster.routing.SystemLoadAverageMetricsSelector
-
Deprecated.
Java API: get the singleton instance
- getInstance() - Method in class akka.Done$
-
Java API: the singleton instance
- getInstance() - Static method in class akka.Done
-
Java API: the singleton instance
- getInstance() - Method in class akka.event.Logging.LoggerInitialized$
-
- 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.event.NoMarkerLogging$
-
Java API to return the reference to NoLogging
- getInstance() - Static method in class akka.event.NoMarkerLogging
-
Java API to return the reference to NoLogging
- getInstance() - Method in class akka.NotUsed$
-
Java API: the singleton instance
- getInstance() - Static method in class akka.NotUsed
-
Java API: the singleton instance
- getInstance() - Method in class akka.persistence.DiscardToDeadLetterStrategy$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.persistence.DiscardToDeadLetterStrategy
-
Java API: get the singleton instance
- getInstance() - Method in class akka.persistence.query.NoOffset$
-
Java API:
- getInstance() - Static method in class akka.persistence.query.NoOffset
-
Java API:
- 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.persistence.ThrowOverflowExceptionStrategy$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.persistence.ThrowOverflowExceptionStrategy
-
Java API: get the singleton instance
- getInstance() - Method in class akka.remote.security.provider.InternetSeedGenerator$
-
Deprecated.
- 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
- getInstance() - Method in class akka.stream.actor.OneByOneRequestStrategy$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.stream.actor.OneByOneRequestStrategy
-
Java API: get the singleton instance
- getInstance() - Method in class akka.stream.actor.ZeroRequestStrategy$
-
Java API: get the singleton instance
- getInstance() - Static method in class akka.stream.actor.ZeroRequestStrategy
-
Java API: get the singleton instance
- getInstance() - Method in class akka.stream.ClosedShape$
-
Java API: obtain ClosedShape instance
- getInstance() - Static method in class akka.stream.ClosedShape
-
Java API: obtain ClosedShape instance
- getInstance() - Method in class akka.stream.javadsl.TLSPlacebo$
-
- getInstance() - Static method in class akka.stream.javadsl.TLSPlacebo
-
- 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.
- getIntElements(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated sint32 intElements = 2 [packed = true];
- getIntElements(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet
-
repeated sint32 intElements = 2 [packed = true];
- getIntElements(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSetOrBuilder
-
repeated sint32 intElements = 2 [packed = true];
- getIntElements(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated sint32 intElements = 4 [packed = true];
- getIntElements(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
repeated sint32 intElements = 4 [packed = true];
- getIntElements(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSetOrBuilder
-
repeated sint32 intElements = 4 [packed = true];
- getIntElementsCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated sint32 intElements = 2 [packed = true];
- getIntElementsCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet
-
repeated sint32 intElements = 2 [packed = true];
- getIntElementsCount() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSetOrBuilder
-
repeated sint32 intElements = 2 [packed = true];
- getIntElementsCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated sint32 intElements = 4 [packed = true];
- getIntElementsCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
repeated sint32 intElements = 4 [packed = true];
- getIntElementsCount() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSetOrBuilder
-
repeated sint32 intElements = 4 [packed = true];
- getIntElementsList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated sint32 intElements = 2 [packed = true];
- getIntElementsList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet
-
repeated sint32 intElements = 2 [packed = true];
- getIntElementsList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSetOrBuilder
-
repeated sint32 intElements = 2 [packed = true];
- getIntElementsList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated sint32 intElements = 4 [packed = true];
- getIntElementsList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
repeated sint32 intElements = 4 [packed = true];
- getIntElementsList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSetOrBuilder
-
repeated sint32 intElements = 4 [packed = true];
- 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.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry.Builder
-
required string key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry
-
required string key = 1;
- getKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.EntryOrBuilder
-
required string key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry.Builder
-
required string key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry
-
required string key = 1;
- getKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.EntryOrBuilder
-
required string key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry.Builder
-
required string key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry
-
required string key = 1;
- getKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.EntryOrBuilder
-
required string key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry.Builder
-
required string key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry
-
required string key = 1;
- getKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.EntryOrBuilder
-
required string key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ChangedOrBuilder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailureOrBuilder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetOrBuilder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccessOrBuilder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry.Builder
-
required string key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry
-
required string key = 1;
- getKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.EntryOrBuilder
-
required string key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFoundOrBuilder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Read.Builder
-
required string key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Read
-
required string key = 1;
- getKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadOrBuilder
-
required string key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry.Builder
-
required string key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry
-
required string key = 1;
- getKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.EntryOrBuilder
-
required string key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.SubscribeOrBuilder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UnsubscribeOrBuilder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write.Builder
-
required string key = 1;
- getKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write
-
required string key = 1;
- getKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.WriteOrBuilder
-
required string key = 1;
- 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;
- getKey(int) - Method in class akka.remote.artery.RemoteInstruments$
-
- getKey(int) - Static method in class akka.remote.artery.RemoteInstruments
-
- getKeyBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyBytes() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry.Builder
-
required string key = 1;
- getKeyBytes() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry
-
required string key = 1;
- getKeyBytes() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.EntryOrBuilder
-
required string key = 1;
- getKeyBytes() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry.Builder
-
required string key = 1;
- getKeyBytes() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry
-
required string key = 1;
- getKeyBytes() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.EntryOrBuilder
-
required string key = 1;
- getKeyBytes() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry.Builder
-
required string key = 1;
- getKeyBytes() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry
-
required string key = 1;
- getKeyBytes() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.EntryOrBuilder
-
required string key = 1;
- getKeyBytes() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry.Builder
-
required string key = 1;
- getKeyBytes() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry
-
required string key = 1;
- getKeyBytes() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.EntryOrBuilder
-
required string key = 1;
- getKeyBytes() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry.Builder
-
required string key = 1;
- getKeyBytes() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry
-
required string key = 1;
- getKeyBytes() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.EntryOrBuilder
-
required string key = 1;
- getKeyBytes() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Read.Builder
-
required string key = 1;
- getKeyBytes() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Read
-
required string key = 1;
- getKeyBytes() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadOrBuilder
-
required string key = 1;
- getKeyBytes() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry.Builder
-
required string key = 1;
- getKeyBytes() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry
-
required string key = 1;
- getKeyBytes() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.EntryOrBuilder
-
required string key = 1;
- getKeyBytes() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write.Builder
-
required string key = 1;
- getKeyBytes() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write
-
required string key = 1;
- getKeyBytes() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.WriteOrBuilder
-
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;
- getKeyIds() - Method in class akka.cluster.ddata.Replicator.GetKeyIdsResult
-
Java API
- GetKeyIds$() - Constructor for class akka.cluster.ddata.Replicator.GetKeyIds$
-
- GetKeyIdsResult(Set<String>) - Constructor for class akka.cluster.ddata.Replicator.GetKeyIdsResult
-
- GetKeyIdsResult$() - Constructor for class akka.cluster.ddata.Replicator.GetKeyIdsResult$
-
- getKeyOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ChangedOrBuilder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailureOrBuilder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetOrBuilder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccessOrBuilder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFoundOrBuilder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.SubscribeOrBuilder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeyOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UnsubscribeOrBuilder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- getKeys() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeys() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeys() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMapOrBuilder
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeys() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeys() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeys() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMapOrBuilder
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeys() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeys() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeys() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMapOrBuilder
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeys() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeys() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeys() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMapOrBuilder
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeys(int) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
repeated string keys = 4;
- getKeys(int) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement
-
repeated string keys = 4;
- getKeys(int) - Method in interface akka.remote.ArteryControlFormats.CompressionTableAdvertisementOrBuilder
-
repeated string keys = 4;
- getKeysBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeysBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeysBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeysBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeysBytes(int) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
repeated string keys = 4;
- getKeysBytes(int) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement
-
repeated string keys = 4;
- getKeysBytes(int) - Method in interface akka.remote.ArteryControlFormats.CompressionTableAdvertisementOrBuilder
-
repeated string keys = 4;
- getKeysCount() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
repeated string keys = 4;
- getKeysCount() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement
-
repeated string keys = 4;
- getKeysCount() - Method in interface akka.remote.ArteryControlFormats.CompressionTableAdvertisementOrBuilder
-
repeated string keys = 4;
- getKeysList() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
repeated string keys = 4;
- getKeysList() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement
-
repeated string keys = 4;
- getKeysList() - Method in interface akka.remote.ArteryControlFormats.CompressionTableAdvertisementOrBuilder
-
repeated string keys = 4;
- getKeysOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeysOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeysOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMapOrBuilder
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeysOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeysOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeysOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMapOrBuilder
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeysOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeysOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeysOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMapOrBuilder
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeysOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeysOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap
-
required .akka.cluster.ddata.ORSet keys = 1;
- getKeysOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMapOrBuilder
-
required .akka.cluster.ddata.ORSet keys = 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.
- getLength(int) - Method in class akka.remote.artery.RemoteInstruments$
-
- getLength(int) - Static method in class akka.remote.artery.RemoteInstruments
-
- getLetter() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved.Builder
-
required string letter = 1;
- getLetter() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved
-
required string letter = 1;
- getLetter() - Method in interface docs.persistence.proto.FlightAppModels.SeatReservedOrBuilder
-
required string letter = 1;
- getLetterBytes() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved.Builder
-
required string letter = 1;
- getLetterBytes() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved
-
required string letter = 1;
- getLetterBytes() - Method in interface docs.persistence.proto.FlightAppModels.SeatReservedOrBuilder
-
required string letter = 1;
- getLineNumber() - Method in class akka.remote.ContainerFormats.StackTraceElement.Builder
-
required int32 lineNumber = 4;
- getLineNumber() - Method in class akka.remote.ContainerFormats.StackTraceElement
-
required int32 lineNumber = 4;
- getLineNumber() - Method in interface akka.remote.ContainerFormats.StackTraceElementOrBuilder
-
required int32 lineNumber = 4;
- getList(String) - Method in class akka.dispatch.CachingConfig
-
- getListenAddresses() - Method in class akka.remote.RemotingListenEvent
-
- getLocalAddress() - Static method in class akka.remote.AssociatedEvent
-
- getLocalAddress() - Static method in class akka.remote.AssociationErrorEvent
-
- getLocalAddress() - Method in interface akka.remote.AssociationEvent
-
- getLocalAddress() - Static method in class akka.remote.DisassociatedEvent
-
- 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;
- getLocalizedMessage() - Static method in exception akka.actor.ActorInitializationException
-
- getLocalizedMessage() - Static method in exception akka.actor.ActorKilledException
-
- getLocalizedMessage() - Static method in exception akka.actor.ActorNotFound
-
- getLocalizedMessage() - Static method in exception akka.actor.DeathPactException
-
- getLocalizedMessage() - Static method in exception akka.actor.IllegalActorStateException
-
- getLocalizedMessage() - Static method in exception akka.actor.InvalidActorNameException
-
- getLocalizedMessage() - Static method in exception akka.actor.InvalidMessageException
-
- getLocalizedMessage() - Static method in exception akka.actor.PostRestartException
-
- getLocalizedMessage() - Static method in exception akka.actor.PreRestartException
-
- getLocalizedMessage() - Static method in exception akka.actor.SchedulerException
-
- getLocalizedMessage() - Static method in exception akka.actor.StashOverflowException
-
- getLocalizedMessage() - Static method in exception akka.contrib.circuitbreaker.OpenCircuitException
-
- getLocalizedMessage() - Static method in exception akka.pattern.CircuitBreakerOpenException
-
- getLocalizedMessage() - Static method in exception akka.remote.HopelessAssociation
-
- getLocalizedMessage() - Static method in exception akka.remote.InvalidAssociation
-
- getLocalizedMessage() - Static method in exception akka.remote.ShutDownAssociation
-
- getLocalizedMessage() - Static method in exception akka.remote.transport.FailureInjectorException
-
- getLocalizedMessage() - Static method in exception akka.stream.AbruptTerminationException
-
- getLocalizedMessage() - Static method in exception akka.stream.BindFailedException
-
- getLocalizedMessage() - Static method in exception akka.stream.BufferOverflowException
-
- getLocalizedMessage() - Static method in exception akka.stream.MaterializationException
-
- getLocalizedMessage() - Static method in exception akka.typed.DeathPactException
-
- getLog() - Method in interface akka.actor.LoggingFSM
-
Retrieve current rolling log in oldest-first order.
- getLog() - Static method in class akka.contrib.pattern.ReliableProxy
-
- getLog() - Method in interface akka.persistence.fsm.LoggingPersistentFSM
-
Retrieve current rolling log in oldest-first order.
- getLog() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- getLog() - Static method in class akka.remote.testconductor.ClientFSM
-
- getLog() - Static method in class akka.remote.testconductor.ServerFSM
-
- getLog() - Static method in class akka.remote.transport.ThrottledAssociation
-
- 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(Actor) - Method in class akka.event.Logging$
-
Obtain LoggingAdapter with MDC support for the given actor.
- 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(Actor) - Static method in class akka.event.Logging
-
Obtain LoggingAdapter with MDC support for the given actor.
- 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.
- getLongElements(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated sint64 longElements = 3 [packed = true];
- getLongElements(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet
-
repeated sint64 longElements = 3 [packed = true];
- getLongElements(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSetOrBuilder
-
repeated sint64 longElements = 3 [packed = true];
- getLongElements(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated sint64 longElements = 5 [packed = true];
- getLongElements(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
repeated sint64 longElements = 5 [packed = true];
- getLongElements(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSetOrBuilder
-
repeated sint64 longElements = 5 [packed = true];
- getLongElementsCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated sint64 longElements = 3 [packed = true];
- getLongElementsCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet
-
repeated sint64 longElements = 3 [packed = true];
- getLongElementsCount() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSetOrBuilder
-
repeated sint64 longElements = 3 [packed = true];
- getLongElementsCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated sint64 longElements = 5 [packed = true];
- getLongElementsCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
repeated sint64 longElements = 5 [packed = true];
- getLongElementsCount() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSetOrBuilder
-
repeated sint64 longElements = 5 [packed = true];
- getLongElementsList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated sint64 longElements = 3 [packed = true];
- getLongElementsList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet
-
repeated sint64 longElements = 3 [packed = true];
- getLongElementsList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSetOrBuilder
-
repeated sint64 longElements = 3 [packed = true];
- getLongElementsList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated sint64 longElements = 5 [packed = true];
- getLongElementsList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
repeated sint64 longElements = 5 [packed = true];
- getLongElementsList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSetOrBuilder
-
repeated sint64 longElements = 5 [packed = true];
- 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.
- GetManifest() - Method in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer
-
- getManifest() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional string manifest = 12;
- getManifest() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
optional string manifest = 12;
- getManifest() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
-
optional string manifest = 12;
- getManifestBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional string manifest = 12;
- getManifestBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
optional string manifest = 12;
- getManifestBytes() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
-
optional string manifest = 12;
- getManifests(int) - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated string manifests = 5;
- getManifests(int) - Method in class akka.remote.WireFormats.PropsData
-
repeated string manifests = 5;
- getManifests(int) - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
-
repeated string manifests = 5;
- getManifestsBytes(int) - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated string manifests = 5;
- getManifestsBytes(int) - Method in class akka.remote.WireFormats.PropsData
-
repeated string manifests = 5;
- getManifestsBytes(int) - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
-
repeated string manifests = 5;
- getManifestsCount() - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated string manifests = 5;
- getManifestsCount() - Method in class akka.remote.WireFormats.PropsData
-
repeated string manifests = 5;
- getManifestsCount() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
-
repeated string manifests = 5;
- getManifestsList() - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated string manifests = 5;
- getManifestsList() - Method in class akka.remote.WireFormats.PropsData
-
repeated string manifests = 5;
- getManifestsList() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
-
repeated string manifests = 5;
- 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;
- getMaxTotalNrOfInstances(Config) - Method in class akka.cluster.routing.ClusterRouterSettingsBase$
-
For backwards compatibility reasons, nr-of-instances
has the same purpose as max-total-nr-of-instances for cluster
aware routers and nr-of-instances (if defined by user) takes
precedence over max-total-nr-of-instances.
- 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
-
- 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() - Static method in exception akka.actor.ActorInitializationException
-
- getMessage() - Static method in exception akka.actor.ActorKilledException
-
- getMessage() - Static method in exception akka.actor.ActorNotFound
-
- getMessage() - Static method in exception akka.actor.DeathPactException
-
- getMessage() - Static method in exception akka.actor.IllegalActorStateException
-
- getMessage() - Static method in exception akka.actor.InvalidActorNameException
-
- getMessage() - Static method in exception akka.actor.InvalidMessageException
-
- getMessage() - Static method in exception akka.actor.PostRestartException
-
- getMessage() - Static method in exception akka.actor.PreRestartException
-
- getMessage() - Static method in exception akka.actor.SchedulerException
-
- getMessage() - Static method in exception akka.actor.StashOverflowException
-
- getMessage() - Method in class akka.actor.UnhandledMessage
-
- getMessage() - Method in exception akka.camel.ActorNotRegisteredException
-
- getMessage() - Static method in exception akka.contrib.circuitbreaker.OpenCircuitException
-
- getMessage() - Method in class akka.event.Logging.LogEventException
-
- getMessage() - Static method in exception akka.pattern.CircuitBreakerOpenException
-
- getMessage() - Method in class akka.persistence.AtLeastOnceDelivery.UnconfirmedDelivery
-
Java API
- getMessage() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope.Builder
-
required bytes message = 1;
- getMessage() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope
-
required bytes message = 1;
- getMessage() - Method in interface akka.remote.ArteryControlFormats.SystemMessageEnvelopeOrBuilder
-
required bytes message = 1;
- getMessage() - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
required string message = 2;
- getMessage() - Method in class akka.remote.ContainerFormats.ActorInitializationException
-
required string message = 2;
- getMessage() - Method in interface akka.remote.ContainerFormats.ActorInitializationExceptionOrBuilder
-
required string message = 2;
- getMessage() - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
optional string message = 2;
- getMessage() - Method in class akka.remote.ContainerFormats.Throwable
-
optional string message = 2;
- getMessage() - Method in interface akka.remote.ContainerFormats.ThrowableOrBuilder
-
optional string message = 2;
- getMessage() - Static method in exception akka.remote.HopelessAssociation
-
- getMessage() - Static method in exception akka.remote.InvalidAssociation
-
- getMessage() - Static method in exception akka.remote.ShutDownAssociation
-
- getMessage() - Static method in exception akka.remote.transport.FailureInjectorException
-
- 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;
- getMessage() - Static method in exception akka.stream.AbruptTerminationException
-
- getMessage() - Static method in exception akka.stream.BindFailedException
-
- getMessage() - Static method in exception akka.stream.BufferOverflowException
-
- getMessage() - Static method in exception akka.stream.MaterializationException
-
- getMessage() - Static method in exception akka.typed.DeathPactException
-
- getMessageBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
required .SerializedMessage message = 2;
- getMessageBytes() - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
required string message = 2;
- getMessageBytes() - Method in class akka.remote.ContainerFormats.ActorInitializationException
-
required string message = 2;
- getMessageBytes() - Method in interface akka.remote.ContainerFormats.ActorInitializationExceptionOrBuilder
-
required string message = 2;
- getMessageBytes() - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
optional string message = 2;
- getMessageBytes() - Method in class akka.remote.ContainerFormats.Throwable
-
optional string message = 2;
- getMessageBytes() - Method in interface akka.remote.ContainerFormats.ThrowableOrBuilder
-
optional string message = 2;
- getMessageId() - Method in class akka.remote.ContainerFormats.Identify.Builder
-
required .Payload messageId = 1;
- getMessageId() - Method in class akka.remote.ContainerFormats.Identify
-
required .Payload messageId = 1;
- getMessageId() - Method in interface akka.remote.ContainerFormats.IdentifyOrBuilder
-
required .Payload messageId = 1;
- getMessageIdBuilder() - Method in class akka.remote.ContainerFormats.Identify.Builder
-
required .Payload messageId = 1;
- getMessageIdOrBuilder() - Method in class akka.remote.ContainerFormats.Identify.Builder
-
required .Payload messageId = 1;
- getMessageIdOrBuilder() - Method in class akka.remote.ContainerFormats.Identify
-
required .Payload messageId = 1;
- getMessageIdOrBuilder() - Method in interface akka.remote.ContainerFormats.IdentifyOrBuilder
-
required .Payload messageId = 1;
- getMessageManifest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage.Builder
-
optional bytes messageManifest = 4;
- getMessageManifest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage
-
optional bytes messageManifest = 4;
- getMessageManifest() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessageOrBuilder
-
optional bytes messageManifest = 4;
- 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.ArteryControlFormats.SystemMessageEnvelope.Builder
-
optional bytes messageManifest = 3;
- getMessageManifest() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope
-
optional bytes messageManifest = 3;
- getMessageManifest() - Method in interface akka.remote.ArteryControlFormats.SystemMessageEnvelopeOrBuilder
-
optional bytes messageManifest = 3;
- getMessageManifest() - Method in class akka.remote.ContainerFormats.Payload.Builder
-
optional bytes messageManifest = 4;
- getMessageManifest() - Method in class akka.remote.ContainerFormats.Payload
-
optional bytes messageManifest = 4;
- getMessageManifest() - Method in interface akka.remote.ContainerFormats.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;
- getMethodName() - Method in class akka.remote.ContainerFormats.StackTraceElement.Builder
-
required string methodName = 2;
- getMethodName() - Method in class akka.remote.ContainerFormats.StackTraceElement
-
required string methodName = 2;
- getMethodName() - Method in interface akka.remote.ContainerFormats.StackTraceElementOrBuilder
-
required string methodName = 2;
- getMethodNameBytes() - Method in class akka.remote.ContainerFormats.StackTraceElement.Builder
-
required string methodName = 2;
- getMethodNameBytes() - Method in class akka.remote.ContainerFormats.StackTraceElement
-
required string methodName = 2;
- getMethodNameBytes() - Method in interface akka.remote.ContainerFormats.StackTraceElementOrBuilder
-
required string methodName = 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
-
Deprecated.
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() - Static method in class akka.remote.security.provider.AkkaProvider
-
- 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
-
- GetNext() - Constructor for class akka.cluster.singleton.ClusterSingletonManager.Internal$.OldestChangedBuffer.GetNext
-
- getNextOldestChanged() - Method in class akka.cluster.singleton.ClusterSingletonManager
-
- GetNobody() - Method in class akka.actor.dungeon.Children$
-
- getNode() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry.Builder
-
required .akka.cluster.ddata.UniqueAddress node = 1;
- getNode() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry
-
required .akka.cluster.ddata.UniqueAddress node = 1;
- getNode() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.EntryOrBuilder
-
required .akka.cluster.ddata.UniqueAddress node = 1;
- getNode() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
required .akka.cluster.ddata.UniqueAddress node = 2;
- getNode() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister
-
required .akka.cluster.ddata.UniqueAddress node = 2;
- getNode() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegisterOrBuilder
-
required .akka.cluster.ddata.UniqueAddress node = 2;
- getNode() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry.Builder
-
required .akka.cluster.ddata.UniqueAddress node = 1;
- getNode() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry
-
required .akka.cluster.ddata.UniqueAddress node = 1;
- getNode() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.EntryOrBuilder
-
required .akka.cluster.ddata.UniqueAddress node = 1;
- 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.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry.Builder
-
required .akka.cluster.ddata.UniqueAddress node = 1;
- getNodeBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
required .akka.cluster.ddata.UniqueAddress node = 2;
- getNodeBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry.Builder
-
required .akka.cluster.ddata.UniqueAddress 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
-
Deprecated.
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.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry.Builder
-
required .akka.cluster.ddata.UniqueAddress node = 1;
- getNodeOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry
-
required .akka.cluster.ddata.UniqueAddress node = 1;
- getNodeOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.EntryOrBuilder
-
required .akka.cluster.ddata.UniqueAddress node = 1;
- getNodeOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
required .akka.cluster.ddata.UniqueAddress node = 2;
- getNodeOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister
-
required .akka.cluster.ddata.UniqueAddress node = 2;
- getNodeOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegisterOrBuilder
-
required .akka.cluster.ddata.UniqueAddress node = 2;
- getNodeOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry.Builder
-
required .akka.cluster.ddata.UniqueAddress node = 1;
- getNodeOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry
-
required .akka.cluster.ddata.UniqueAddress node = 1;
- getNodeOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.EntryOrBuilder
-
required .akka.cluster.ddata.UniqueAddress node = 1;
- 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.SystemMessageFormats.SystemMessage.Type
-
- 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;
- getOrAdd(A) - Method in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer.SmallCache
-
Get value from cache or create new value with the
getOrAddFactory
that was given in the constructor.
- getOrCompute(K) - Method in class akka.remote.artery.LruBoundedCache
-
- getOrCreateContext(MarkerLoggingAdapter) - Method in class akka.remote.transport.netty.SSLSettings
-
- getOrDefault(Object, Object) - Static method in class akka.remote.security.provider.AkkaProvider
-
- getOrElse(String, Function0<A>) - Method in class akka.cluster.ddata.ORMap
-
Scala API: Get the value associated with the key if there is one,
else return the given default.
- getOrElse(String, Function0<Set<A>>) - Method in class akka.cluster.ddata.ORMultiMap
-
Scala API: Get the set associated with the key if there is one,
else return the given default.
- 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
-
- getOrElse(B) - Method in class akka.util.OptionVal
-
- getOrEmpty(I) - Method in class akka.util.MessageBufferMap
-
Get the message buffer for an id, or an empty buffer if the id doesn't exist in the map.
- 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;
- getOriginUid() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
required uint64 originUid = 2;
- getOriginUid() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement
-
required uint64 originUid = 2;
- getOriginUid() - Method in interface akka.remote.ArteryControlFormats.CompressionTableAdvertisementOrBuilder
-
required uint64 originUid = 2;
- getOtherElements(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- getOtherElements(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- getOtherElements(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSetOrBuilder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- getOtherElements(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- getOtherElements(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- getOtherElements(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSetOrBuilder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- getOtherElementsBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- getOtherElementsBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- getOtherElementsBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- getOtherElementsBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- getOtherElementsCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- getOtherElementsCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- getOtherElementsCount() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSetOrBuilder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- getOtherElementsCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- getOtherElementsCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- getOtherElementsCount() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSetOrBuilder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- getOtherElementsList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- getOtherElementsList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- getOtherElementsList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSetOrBuilder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- getOtherElementsList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- getOtherElementsList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- getOtherElementsList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSetOrBuilder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- getOtherElementsOrBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- getOtherElementsOrBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- getOtherElementsOrBuilder(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSetOrBuilder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- getOtherElementsOrBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- getOtherElementsOrBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- getOtherElementsOrBuilder(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSetOrBuilder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- getOtherElementsOrBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- getOtherElementsOrBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- getOtherElementsOrBuilderList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSetOrBuilder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- getOtherElementsOrBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- getOtherElementsOrBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- getOtherElementsOrBuilderList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSetOrBuilder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- getOutlets() - Method in class akka.stream.AbstractShape
-
- getOutlets() - Static method in class akka.stream.AmorphousShape
-
- getOutlets() - Static method in class akka.stream.BidiShape
-
- getOutlets() - Static method in class akka.stream.ClosedShape
-
- getOutlets() - Static method in class akka.stream.FanInShape
-
- getOutlets() - Static method in class akka.stream.FanOutShape
-
- getOutlets() - Static method in class akka.stream.FlowShape
-
- getOutlets() - Method in class akka.stream.Shape
-
Java API: get a list of all output ports
- getOutlets() - Static method in class akka.stream.SinkShape
-
- getOutlets() - Static method in class akka.stream.SourceShape
-
- getOutlets() - Static method in class akka.stream.UniformFanInShape
-
- getOutlets() - Static method in class akka.stream.UniformFanOutShape
-
- 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;
- getOwnerAddress() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
required .akka.cluster.ddata.UniqueAddress ownerAddress = 2;
- getOwnerAddress() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry
-
required .akka.cluster.ddata.UniqueAddress ownerAddress = 2;
- getOwnerAddress() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntryOrBuilder
-
required .akka.cluster.ddata.UniqueAddress ownerAddress = 2;
- getOwnerAddressBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
required .akka.cluster.ddata.UniqueAddress ownerAddress = 2;
- getOwnerAddressOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
required .akka.cluster.ddata.UniqueAddress ownerAddress = 2;
- getOwnerAddressOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry
-
required .akka.cluster.ddata.UniqueAddress ownerAddress = 2;
- getOwnerAddressOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntryOrBuilder
-
required .akka.cluster.ddata.UniqueAddress ownerAddress = 2;
- 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;
- getPackage(String) - Static method in class akka.osgi.BundleDelegatingClassLoader
-
- getPackages() - Static method in class akka.osgi.BundleDelegatingClassLoader
-
- getParent() - Static method in class akka.actor.DeadLetterActorRef
-
- 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() - Static method in class akka.actor.Nobody
-
- getParent() - Method in class akka.actor.RepointableActorRef
-
- getParent() - Method in class akka.actor.VirtualPathContainer
-
- getParent() - Static method in class akka.osgi.BundleDelegatingClassLoader
-
- getParent() - Method in class akka.pattern.PromiseActorRef
-
- getParent() - Method in class akka.remote.RemoteActorRef
-
- getParent() - Static method in class akka.testkit.TestActorRef
-
- getParent() - Static method in class akka.testkit.TestFSMRef
-
- getParserForType() - Method in class akka.cluster.client.protobuf.msg.ClusterClientMessages.Contacts
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.Flag
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Address
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelope
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Empty
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Read
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResult
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe
-
- getParserForType() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write
-
- 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.SendToOneSubscriber
-
- 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.cluster.sharding.protobuf.msg.ClusterShardingMessages.ActorRefMessage
-
- getParserForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState
-
- getParserForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry
-
- getParserForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStarted
-
- getParserForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState
-
- getParserForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStopped
-
- getParserForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome
-
- getParserForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated
-
- getParserForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessage
-
- getParserForType() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats
-
- 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.AtomicWrite
-
- getParserForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot
-
- getParserForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
- getParserForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
-
- getParserForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
-
- getParserForType() - Method in class akka.remote.ArteryControlFormats.Address
-
- getParserForType() - Method in class akka.remote.ArteryControlFormats.ArteryHeartbeatRsp
-
- getParserForType() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement
-
- getParserForType() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck
-
- getParserForType() - Method in class akka.remote.ArteryControlFormats.HandshakeReq
-
- getParserForType() - Method in class akka.remote.ArteryControlFormats.MessageWithAddress
-
- getParserForType() - Method in class akka.remote.ArteryControlFormats.Quarantined
-
- getParserForType() - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck
-
- getParserForType() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope
-
- getParserForType() - Method in class akka.remote.ArteryControlFormats.UniqueAddress
-
- getParserForType() - Method in class akka.remote.ContainerFormats.ActorIdentity
-
- getParserForType() - Method in class akka.remote.ContainerFormats.ActorInitializationException
-
- getParserForType() - Method in class akka.remote.ContainerFormats.ActorRef
-
- getParserForType() - Method in class akka.remote.ContainerFormats.Identify
-
- getParserForType() - Method in class akka.remote.ContainerFormats.Option
-
- getParserForType() - Method in class akka.remote.ContainerFormats.Payload
-
- getParserForType() - Method in class akka.remote.ContainerFormats.Selection
-
- getParserForType() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
-
- getParserForType() - Method in class akka.remote.ContainerFormats.StackTraceElement
-
- getParserForType() - Method in class akka.remote.ContainerFormats.Throwable
-
- getParserForType() - Method in class akka.remote.ContainerFormats.WatcherHeartbeatResponse
-
- getParserForType() - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData
-
- getParserForType() - Method in class akka.remote.SystemMessageFormats.FailedData
-
- getParserForType() - Method in class akka.remote.SystemMessageFormats.SuperviseData
-
- getParserForType() - Method in class akka.remote.SystemMessageFormats.SystemMessage
-
- getParserForType() - Method in class akka.remote.SystemMessageFormats.WatchData
-
- 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
-
- getParserForType() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet
-
- getParserForType() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2
-
- getParserForType() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved
-
- 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.ContainerFormats.ActorRef.Builder
-
required string path = 1;
- getPath() - Method in class akka.remote.ContainerFormats.ActorRef
-
required string path = 1;
- getPath() - Method in interface akka.remote.ContainerFormats.ActorRefOrBuilder
-
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.ContainerFormats.ActorRef.Builder
-
required string path = 1;
- getPathBytes() - Method in class akka.remote.ContainerFormats.ActorRef
-
required string path = 1;
- getPathBytes() - Method in interface akka.remote.ContainerFormats.ActorRefOrBuilder
-
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
-
- getPaths(ActorSystem) - 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.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToOneSubscriber.Builder
-
required .Payload payload = 1;
- getPayload() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToOneSubscriber
-
required .Payload payload = 1;
- getPayload() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToOneSubscriberOrBuilder
-
required .Payload payload = 1;
- 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(int) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
-
repeated .PersistentMessage payload = 1;
- getPayload(int) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite
-
repeated .PersistentMessage payload = 1;
- getPayload(int) - Method in interface akka.persistence.serialization.MessageFormats.AtomicWriteOrBuilder
-
repeated .PersistentMessage payload = 1;
- 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.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToOneSubscriber.Builder
-
required .Payload payload = 1;
- getPayloadBuilder() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
-
required .PersistentPayload payload = 3;
- getPayloadBuilder(int) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
-
repeated .PersistentMessage payload = 1;
- getPayloadBuilder() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional .PersistentPayload payload = 1;
- getPayloadBuilderList() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
-
repeated .PersistentMessage payload = 1;
- getPayloadCount() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
-
repeated .PersistentMessage payload = 1;
- getPayloadCount() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite
-
repeated .PersistentMessage payload = 1;
- getPayloadCount() - Method in interface akka.persistence.serialization.MessageFormats.AtomicWriteOrBuilder
-
repeated .PersistentMessage payload = 1;
- getPayloadList() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
-
repeated .PersistentMessage payload = 1;
- getPayloadList() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite
-
repeated .PersistentMessage payload = 1;
- getPayloadList() - Method in interface akka.persistence.serialization.MessageFormats.AtomicWriteOrBuilder
-
repeated .PersistentMessage 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.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToOneSubscriber.Builder
-
required .Payload payload = 1;
- getPayloadOrBuilder() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToOneSubscriber
-
required .Payload payload = 1;
- getPayloadOrBuilder() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToOneSubscriberOrBuilder
-
required .Payload payload = 1;
- 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(int) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
-
repeated .PersistentMessage payload = 1;
- getPayloadOrBuilder(int) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite
-
repeated .PersistentMessage payload = 1;
- getPayloadOrBuilder(int) - Method in interface akka.persistence.serialization.MessageFormats.AtomicWriteOrBuilder
-
repeated .PersistentMessage payload = 1;
- 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;
- getPayloadOrBuilderList() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
-
repeated .PersistentMessage payload = 1;
- getPayloadOrBuilderList() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite
-
repeated .PersistentMessage payload = 1;
- getPayloadOrBuilderList() - Method in interface akka.persistence.serialization.MessageFormats.AtomicWriteOrBuilder
-
repeated .PersistentMessage payload = 1;
- getPerformed() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
required bool performed = 3;
- getPerformed() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry
-
required bool performed = 3;
- getPerformed() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntryOrBuilder
-
required bool performed = 3;
- 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.ddata.protobuf.msg.ReplicatorMessages.Address.Builder
-
required uint32 port = 2;
- getPort() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Address
-
required uint32 port = 2;
- getPort() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.AddressOrBuilder
-
required uint32 port = 2;
- 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.ArteryControlFormats.Address.Builder
-
required uint32 port = 4;
- getPort() - Method in class akka.remote.ArteryControlFormats.Address
-
required uint32 port = 4;
- getPort() - Method in interface akka.remote.ArteryControlFormats.AddressOrBuilder
-
required uint32 port = 4;
- 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
.
- getProperty(String, String) - Static method in class akka.remote.security.provider.AkkaProvider
-
- getProperty(String) - Static method in class akka.remote.security.provider.AkkaProvider
-
- 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.ArteryControlFormats.Address.Builder
-
required string protocol = 1;
- getProtocol() - Method in class akka.remote.ArteryControlFormats.Address
-
required string protocol = 1;
- getProtocol() - Method in interface akka.remote.ArteryControlFormats.AddressOrBuilder
-
required string protocol = 1;
- 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.ArteryControlFormats.Address.Builder
-
required string protocol = 1;
- getProtocolBytes() - Method in class akka.remote.ArteryControlFormats.Address
-
required string protocol = 1;
- getProtocolBytes() - Method in interface akka.remote.ArteryControlFormats.AddressOrBuilder
-
required string protocol = 1;
- 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;
- getPruning(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- getPruning(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- getPruning(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelopeOrBuilder
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- getPruningBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- getPruningBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- getPruningCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- getPruningCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- getPruningCount() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelopeOrBuilder
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- getPruningList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- getPruningList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- getPruningList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelopeOrBuilder
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- getPruningOrBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- getPruningOrBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- getPruningOrBuilder(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelopeOrBuilder
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- getPruningOrBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- getPruningOrBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- getPruningOrBuilderList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelopeOrBuilder
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- getPublisher() - Method in class akka.stream.testkit.TestPublisher.ManualProbe
-
- 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
-
- getReadJournalFor(Class<T>, String) - Method in class akka.persistence.query.PersistenceQuery
-
Java API: Returns the
ReadJournal
specified by the given
read journal configuration entry.
- 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.ddata.protobuf.msg.ReplicatorMessages.Subscribe.Builder
-
required string ref = 2;
- getRef() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe
-
required string ref = 2;
- getRef() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.SubscribeOrBuilder
-
required string ref = 2;
- getRef() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe.Builder
-
required string ref = 2;
- getRef() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe
-
required string ref = 2;
- getRef() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UnsubscribeOrBuilder
-
required string ref = 2;
- 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.cluster.sharding.protobuf.msg.ClusterShardingMessages.ActorRefMessage.Builder
-
required string ref = 1;
- getRef() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ActorRefMessage
-
required string ref = 1;
- getRef() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ActorRefMessageOrBuilder
-
required string ref = 1;
- getRef() - Method in class akka.pattern.BackoffSupervisor.CurrentChild
-
Java API: The ActorRef
of the current child, if any
- getRef() - Method in class akka.remote.ContainerFormats.ActorIdentity.Builder
-
optional .ActorRef ref = 2;
- getRef() - Method in class akka.remote.ContainerFormats.ActorIdentity
-
optional .ActorRef ref = 2;
- getRef() - Method in interface akka.remote.ContainerFormats.ActorIdentityOrBuilder
-
optional .ActorRef ref = 2;
- getRef() - Method in class akka.testkit.JavaTestKit
-
Shorthand to get the testActor.
- getRefBuilder() - Method in class akka.remote.ContainerFormats.ActorIdentity.Builder
-
optional .ActorRef ref = 2;
- getRefBytes() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe.Builder
-
required string ref = 2;
- getRefBytes() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe
-
required string ref = 2;
- getRefBytes() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.SubscribeOrBuilder
-
required string ref = 2;
- getRefBytes() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe.Builder
-
required string ref = 2;
- getRefBytes() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe
-
required string ref = 2;
- getRefBytes() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UnsubscribeOrBuilder
-
required string ref = 2;
- 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;
- getRefBytes() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ActorRefMessage.Builder
-
required string ref = 1;
- getRefBytes() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ActorRefMessage
-
required string ref = 1;
- getRefBytes() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ActorRefMessageOrBuilder
-
required string ref = 1;
- getRefOrBuilder() - Method in class akka.remote.ContainerFormats.ActorIdentity.Builder
-
optional .ActorRef ref = 2;
- getRefOrBuilder() - Method in class akka.remote.ContainerFormats.ActorIdentity
-
optional .ActorRef ref = 2;
- getRefOrBuilder() - Method in interface akka.remote.ContainerFormats.ActorIdentityOrBuilder
-
optional .ActorRef ref = 2;
- getRegion() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome.Builder
-
required string region = 2;
- getRegion() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome
-
required string region = 2;
- getRegion() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated.Builder
-
required string region = 2;
- getRegion() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated
-
required string region = 2;
- getRegion() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocatedOrBuilder
-
required string region = 2;
- getRegion() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeOrBuilder
-
required string region = 2;
- getRegionBytes() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome.Builder
-
required string region = 2;
- getRegionBytes() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome
-
required string region = 2;
- getRegionBytes() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated.Builder
-
required string region = 2;
- getRegionBytes() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated
-
required string region = 2;
- getRegionBytes() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocatedOrBuilder
-
required string region = 2;
- getRegionBytes() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeOrBuilder
-
required string region = 2;
- getRegionProxies(int) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string regionProxies = 3;
- getRegionProxies(int) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState
-
repeated string regionProxies = 3;
- getRegionProxies(int) - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorStateOrBuilder
-
repeated string regionProxies = 3;
- getRegionProxiesBytes(int) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string regionProxies = 3;
- getRegionProxiesBytes(int) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState
-
repeated string regionProxies = 3;
- getRegionProxiesBytes(int) - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorStateOrBuilder
-
repeated string regionProxies = 3;
- getRegionProxiesCount() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string regionProxies = 3;
- getRegionProxiesCount() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState
-
repeated string regionProxies = 3;
- getRegionProxiesCount() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorStateOrBuilder
-
repeated string regionProxies = 3;
- getRegionProxiesList() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string regionProxies = 3;
- getRegionProxiesList() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState
-
repeated string regionProxies = 3;
- getRegionProxiesList() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorStateOrBuilder
-
repeated string regionProxies = 3;
- getRegionRef() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry.Builder
-
required string regionRef = 2;
- getRegionRef() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry
-
required string regionRef = 2;
- getRegionRef() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntryOrBuilder
-
required string regionRef = 2;
- getRegionRefBytes() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry.Builder
-
required string regionRef = 2;
- getRegionRefBytes() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry
-
required string regionRef = 2;
- getRegionRefBytes() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntryOrBuilder
-
required string regionRef = 2;
- getRegions(int) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string regions = 2;
- getRegions(int) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState
-
repeated string regions = 2;
- getRegions(int) - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorStateOrBuilder
-
repeated string regions = 2;
- getRegions() - Method in class akka.cluster.sharding.ShardRegion.ClusterShardingStats
-
Java API
- getRegions() - Method in class akka.cluster.sharding.ShardRegion.CurrentRegions
-
Java API
- getRegionsBytes(int) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string regions = 2;
- getRegionsBytes(int) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState
-
repeated string regions = 2;
- getRegionsBytes(int) - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorStateOrBuilder
-
repeated string regions = 2;
- getRegionsCount() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string regions = 2;
- getRegionsCount() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState
-
repeated string regions = 2;
- getRegionsCount() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorStateOrBuilder
-
repeated string regions = 2;
- getRegionsList() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string regions = 2;
- getRegionsList() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState
-
repeated string regions = 2;
- getRegionsList() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorStateOrBuilder
-
repeated string regions = 2;
- getRegionStatsInstance() - Method in class akka.cluster.sharding.ShardRegion$
-
Java API:
- getRegionStatsInstance() - Static method in class akka.cluster.sharding.ShardRegion
-
Java API:
- getRemainingTime() - Method in class akka.testkit.JavaTestKit
-
- getRemainingTimeOr(FiniteDuration) - Method in class akka.testkit.JavaTestKit
-
- getRemoteAddress() - Static method in class akka.remote.AssociatedEvent
-
- getRemoteAddress() - Static method in class akka.remote.AssociationErrorEvent
-
- getRemoteAddress() - Method in interface akka.remote.AssociationEvent
-
- getRemoteAddress() - Static method in class akka.remote.DisassociatedEvent
-
- getRemoteReadHandlerFor(TestAssociationHandle) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
-
Returns the event handler corresponding to the remote endpoint of the given local handle.
- getRemovals(int) - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet.Builder
-
repeated string removals = 2;
- getRemovals(int) - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet
-
repeated string removals = 2;
- getRemovals() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2.Builder
-
optional bytes removals = 2;
- getRemovals() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2
-
optional bytes removals = 2;
- getRemovals() - Method in interface docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2OrBuilder
-
optional bytes removals = 2;
- getRemovals(int) - Method in interface docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSetOrBuilder
-
repeated string removals = 2;
- getRemovalsBytes(int) - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet.Builder
-
repeated string removals = 2;
- getRemovalsBytes(int) - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet
-
repeated string removals = 2;
- getRemovalsBytes(int) - Method in interface docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSetOrBuilder
-
repeated string removals = 2;
- getRemovalsCount() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet.Builder
-
repeated string removals = 2;
- getRemovalsCount() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet
-
repeated string removals = 2;
- getRemovalsCount() - Method in interface docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSetOrBuilder
-
repeated string removals = 2;
- getRemovalsList() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet.Builder
-
repeated string removals = 2;
- getRemovalsList() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet
-
repeated string removals = 2;
- getRemovalsList() - Method in interface docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSetOrBuilder
-
repeated string removals = 2;
- getRemovedAddress() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
required .akka.cluster.ddata.UniqueAddress removedAddress = 1;
- getRemovedAddress() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry
-
required .akka.cluster.ddata.UniqueAddress removedAddress = 1;
- getRemovedAddress() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntryOrBuilder
-
required .akka.cluster.ddata.UniqueAddress removedAddress = 1;
- getRemovedAddressBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
required .akka.cluster.ddata.UniqueAddress removedAddress = 1;
- getRemovedAddressOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
required .akka.cluster.ddata.UniqueAddress removedAddress = 1;
- getRemovedAddressOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry
-
required .akka.cluster.ddata.UniqueAddress removedAddress = 1;
- getRemovedAddressOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntryOrBuilder
-
required .akka.cluster.ddata.UniqueAddress removedAddress = 1;
- getReplicaCount() - Method in class akka.cluster.ddata.Replicator$
-
Java API: The GetReplicaCount
instance
- getReplicaCount() - Static method in class akka.cluster.ddata.Replicator
-
Java API: The GetReplicaCount
instance
- GetReplicaCount$() - Constructor for class akka.cluster.ddata.Replicator.GetReplicaCount$
-
- 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
-
- getReplyToStatus() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
optional bool replyToStatus = 2;
- getReplyToStatus() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status
-
optional bool replyToStatus = 2;
- getReplyToStatus() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.StatusOrBuilder
-
optional bool replyToStatus = 2;
- getRequest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- getRequest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- getRequest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- getRequest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- getRequest() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailureOrBuilder
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- getRequest() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetOrBuilder
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- getRequest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- getRequest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- getRequest() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccessOrBuilder
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- getRequest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- getRequest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- getRequest() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFoundOrBuilder
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- getRequest() - Method in class akka.cluster.ddata.Replicator.GetResponse
-
Java API
- getRequest() - Method in class akka.cluster.ddata.Replicator.UpdateResponse
-
Java API
- getRequestBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- getRequestBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- getRequestBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- getRequestBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- getRequestOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- getRequestOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- getRequestOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- getRequestOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- getRequestOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailureOrBuilder
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- getRequestOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetOrBuilder
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- getRequestOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- getRequestOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- getRequestOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccessOrBuilder
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- getRequestOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- getRequestOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- getRequestOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFoundOrBuilder
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- 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
-
- getResource(String) - Static method in class akka.osgi.BundleDelegatingClassLoader
-
- getResourceAsStream(String) - Static method in class akka.osgi.BundleDelegatingClassLoader
-
- getResources(String) - Static method in class akka.osgi.BundleDelegatingClassLoader
-
- GetResponse() - Constructor for class akka.cluster.ddata.Replicator.GetResponse
-
- getRestartCount() - Method in class akka.pattern.BackoffSupervisor$
-
- getRestartCount() - Static method in class akka.pattern.BackoffSupervisor
-
- GetRestartCount$() - Constructor for class akka.pattern.BackoffSupervisor.GetRestartCount$
-
- getRestartingDecider() - Method in class akka.stream.Supervision$
-
- getRestartingDecider() - Static method in class akka.stream.Supervision
-
- getResumingDecider() - Method in class akka.stream.Supervision$
-
- getResumingDecider() - Static method in class akka.stream.Supervision
-
- 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;
- getRow() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved.Builder
-
required uint32 row = 2;
- getRow() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved
-
required uint32 row = 2;
- getRow() - Method in interface docs.persistence.proto.FlightAppModels.SeatReservedOrBuilder
-
required uint32 row = 2;
- 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;
- getSeatType() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved.Builder
-
optional string seatType = 3;
- getSeatType() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved
-
optional string seatType = 3;
- getSeatType() - Method in interface docs.persistence.proto.FlightAppModels.SeatReservedOrBuilder
-
optional string seatType = 3;
- getSeatTypeBytes() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved.Builder
-
optional string seatType = 3;
- getSeatTypeBytes() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved
-
optional string seatType = 3;
- getSeatTypeBytes() - Method in interface docs.persistence.proto.FlightAppModels.SeatReservedOrBuilder
-
optional string seatType = 3;
- getSeen(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
repeated .akka.cluster.ddata.Address seen = 4;
- getSeen(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry
-
repeated .akka.cluster.ddata.Address seen = 4;
- getSeen(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntryOrBuilder
-
repeated .akka.cluster.ddata.Address seen = 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;
- getSeenBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
repeated .akka.cluster.ddata.Address seen = 4;
- getSeenBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
repeated .akka.cluster.ddata.Address seen = 4;
- getSeenBy() - Method in class akka.cluster.ClusterEvent.CurrentClusterState
-
Java API: get current “seen-by” set.
- getSeenCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
repeated .akka.cluster.ddata.Address seen = 4;
- getSeenCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry
-
repeated .akka.cluster.ddata.Address seen = 4;
- getSeenCount() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntryOrBuilder
-
repeated .akka.cluster.ddata.Address seen = 4;
- 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.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
repeated .akka.cluster.ddata.Address seen = 4;
- getSeenList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry
-
repeated .akka.cluster.ddata.Address seen = 4;
- getSeenList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntryOrBuilder
-
repeated .akka.cluster.ddata.Address seen = 4;
- 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;
- getSeenOrBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
repeated .akka.cluster.ddata.Address seen = 4;
- getSeenOrBuilder(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry
-
repeated .akka.cluster.ddata.Address seen = 4;
- getSeenOrBuilder(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntryOrBuilder
-
repeated .akka.cluster.ddata.Address seen = 4;
- getSeenOrBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
repeated .akka.cluster.ddata.Address seen = 4;
- getSeenOrBuilderList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry
-
repeated .akka.cluster.ddata.Address seen = 4;
- getSeenOrBuilderList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntryOrBuilder
-
repeated .akka.cluster.ddata.Address seen = 4;
- getSelf() - Method in class akka.actor.UntypedActor
-
Returns the ActorRef for this actor.
- getSelf() - Static method in class akka.stream.actor.UntypedActorPublisher
-
- getSelf() - Static method in class akka.stream.actor.UntypedActorSubscriber
-
- getSelfRoles() - Method in class akka.cluster.Cluster
-
Java API: roles that this member has
- getSendBack() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
required bool sendBack = 1;
- getSendBack() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip
-
required bool sendBack = 1;
- getSendBack() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GossipOrBuilder
-
required bool sendBack = 1;
- 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;
- getSender() - Static method in class akka.stream.actor.UntypedActorPublisher
-
- getSender() - Static method in class akka.stream.actor.UntypedActorSubscriber
-
- 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;
- getSeqNo() - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck.Builder
-
required uint64 seqNo = 1;
- getSeqNo() - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck
-
required uint64 seqNo = 1;
- getSeqNo() - Method in interface akka.remote.ArteryControlFormats.SystemMessageDeliveryAckOrBuilder
-
required uint64 seqNo = 1;
- getSeqNo() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope.Builder
-
required uint64 seqNo = 4;
- getSeqNo() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope
-
required uint64 seqNo = 4;
- getSeqNo() - Method in interface akka.remote.ArteryControlFormats.SystemMessageEnvelopeOrBuilder
-
required uint64 seqNo = 4;
- 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.client.protobuf.msg.ClusterClientMessages.Contacts
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.Flag
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Address
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelope
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Empty
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Read
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResult
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe
-
- getSerializedSize() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write
-
- 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.SendToOneSubscriber
-
- 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.cluster.sharding.protobuf.msg.ClusterShardingMessages.ActorRefMessage
-
- getSerializedSize() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState
-
- getSerializedSize() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry
-
- getSerializedSize() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStarted
-
- getSerializedSize() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState
-
- getSerializedSize() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStopped
-
- getSerializedSize() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome
-
- getSerializedSize() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated
-
- getSerializedSize() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessage
-
- getSerializedSize() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats
-
- 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.AtomicWrite
-
- getSerializedSize() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot
-
- getSerializedSize() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
- getSerializedSize() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
-
- getSerializedSize() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
-
- getSerializedSize() - Method in class akka.remote.ArteryControlFormats.Address
-
- getSerializedSize() - Method in class akka.remote.ArteryControlFormats.ArteryHeartbeatRsp
-
- getSerializedSize() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement
-
- getSerializedSize() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck
-
- getSerializedSize() - Method in class akka.remote.ArteryControlFormats.HandshakeReq
-
- getSerializedSize() - Method in class akka.remote.ArteryControlFormats.MessageWithAddress
-
- getSerializedSize() - Method in class akka.remote.ArteryControlFormats.Quarantined
-
- getSerializedSize() - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck
-
- getSerializedSize() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope
-
- getSerializedSize() - Method in class akka.remote.ArteryControlFormats.UniqueAddress
-
- getSerializedSize() - Method in class akka.remote.ContainerFormats.ActorIdentity
-
- getSerializedSize() - Method in class akka.remote.ContainerFormats.ActorInitializationException
-
- getSerializedSize() - Method in class akka.remote.ContainerFormats.ActorRef
-
- getSerializedSize() - Method in class akka.remote.ContainerFormats.Identify
-
- getSerializedSize() - Method in class akka.remote.ContainerFormats.Option
-
- getSerializedSize() - Method in class akka.remote.ContainerFormats.Payload
-
- getSerializedSize() - Method in class akka.remote.ContainerFormats.Selection
-
- getSerializedSize() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
-
- getSerializedSize() - Method in class akka.remote.ContainerFormats.StackTraceElement
-
- getSerializedSize() - Method in class akka.remote.ContainerFormats.Throwable
-
- getSerializedSize() - Method in class akka.remote.ContainerFormats.WatcherHeartbeatResponse
-
- getSerializedSize() - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData
-
- getSerializedSize() - Method in class akka.remote.SystemMessageFormats.FailedData
-
- getSerializedSize() - Method in class akka.remote.SystemMessageFormats.SuperviseData
-
- getSerializedSize() - Method in class akka.remote.SystemMessageFormats.SystemMessage
-
- getSerializedSize() - Method in class akka.remote.SystemMessageFormats.WatchData
-
- 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
-
- getSerializedSize() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet
-
- getSerializedSize() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2
-
- getSerializedSize() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved
-
- getSerializerId() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage.Builder
-
required int32 serializerId = 2;
- getSerializerId() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage
-
required int32 serializerId = 2;
- getSerializerId() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessageOrBuilder
-
required int32 serializerId = 2;
- 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.ArteryControlFormats.SystemMessageEnvelope.Builder
-
required int32 serializerId = 2;
- getSerializerId() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope
-
required int32 serializerId = 2;
- getSerializerId() - Method in interface akka.remote.ArteryControlFormats.SystemMessageEnvelopeOrBuilder
-
required int32 serializerId = 2;
- getSerializerId() - Method in class akka.remote.ContainerFormats.Payload.Builder
-
required int32 serializerId = 2;
- getSerializerId() - Method in class akka.remote.ContainerFormats.Payload
-
required int32 serializerId = 2;
- getSerializerId() - Method in interface akka.remote.ContainerFormats.PayloadOrBuilder
-
required int32 serializerId = 2;
- 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;
- getSerializerIds(int) - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated int32 serializerIds = 6;
- getSerializerIds(int) - Method in class akka.remote.WireFormats.PropsData
-
repeated int32 serializerIds = 6;
- getSerializerIds(int) - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
-
repeated int32 serializerIds = 6;
- getSerializerIdsCount() - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated int32 serializerIds = 6;
- getSerializerIdsCount() - Method in class akka.remote.WireFormats.PropsData
-
repeated int32 serializerIds = 6;
- getSerializerIdsCount() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
-
repeated int32 serializerIds = 6;
- getSerializerIdsList() - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated int32 serializerIds = 6;
- getSerializerIdsList() - Method in class akka.remote.WireFormats.PropsData
-
repeated int32 serializerIds = 6;
- getSerializerIdsList() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
-
repeated int32 serializerIds = 6;
- getService(String, String) - Static method in class akka.remote.security.provider.AkkaProvider
-
- getServices() - Static method in class akka.remote.security.provider.AkkaProvider
-
- getShard() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome.Builder
-
required string shard = 1;
- getShard() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome
-
required string shard = 1;
- getShard() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated.Builder
-
required string shard = 1;
- getShard() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated
-
required string shard = 1;
- getShard() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocatedOrBuilder
-
required string shard = 1;
- getShard() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeOrBuilder
-
required string shard = 1;
- getShard() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessage.Builder
-
required string shard = 1;
- getShard() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessage
-
required string shard = 1;
- getShard() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessageOrBuilder
-
required string shard = 1;
- getShard() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats.Builder
-
required string shard = 1;
- getShard() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats
-
required string shard = 1;
- getShard() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStatsOrBuilder
-
required string shard = 1;
- getShard(String) - Method in class akka.cluster.sharding.ShardRegion
-
- getShardBytes() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome.Builder
-
required string shard = 1;
- getShardBytes() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome
-
required string shard = 1;
- getShardBytes() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated.Builder
-
required string shard = 1;
- getShardBytes() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated
-
required string shard = 1;
- getShardBytes() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocatedOrBuilder
-
required string shard = 1;
- getShardBytes() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeOrBuilder
-
required string shard = 1;
- getShardBytes() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessage.Builder
-
required string shard = 1;
- getShardBytes() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessage
-
required string shard = 1;
- getShardBytes() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessageOrBuilder
-
required string shard = 1;
- getShardBytes() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats.Builder
-
required string shard = 1;
- getShardBytes() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats
-
required string shard = 1;
- getShardBytes() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStatsOrBuilder
-
required string shard = 1;
- GetShardHome(String) - Constructor for class akka.cluster.sharding.ShardCoordinator.Internal$.GetShardHome
-
- getShardId() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry.Builder
-
required string shardId = 1;
- getShardId() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry
-
required string shardId = 1;
- getShardId() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntryOrBuilder
-
required string shardId = 1;
- getShardIdBytes() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry.Builder
-
required string shardId = 1;
- getShardIdBytes() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry
-
required string shardId = 1;
- getShardIdBytes() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntryOrBuilder
-
required string shardId = 1;
- GetShardRegionState$() - Constructor for class akka.cluster.sharding.ShardRegion.GetShardRegionState$
-
- getShardRegionStateInstance() - Method in class akka.cluster.sharding.ShardRegion$
-
Java API:
- getShardRegionStateInstance() - Static method in class akka.cluster.sharding.ShardRegion
-
Java API:
- GetShardRegionStats$() - Constructor for class akka.cluster.sharding.ShardRegion.GetShardRegionStats$
-
- getShards(int) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated .CoordinatorState.ShardEntry shards = 1;
- getShards(int) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState
-
repeated .CoordinatorState.ShardEntry shards = 1;
- getShards(int) - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorStateOrBuilder
-
repeated .CoordinatorState.ShardEntry shards = 1;
- getShards() - Method in class akka.cluster.sharding.ShardRegion.CurrentShardRegionState
-
Java API:
- getShardsBuilder(int) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated .CoordinatorState.ShardEntry shards = 1;
- getShardsBuilderList() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated .CoordinatorState.ShardEntry shards = 1;
- getShardsCount() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated .CoordinatorState.ShardEntry shards = 1;
- getShardsCount() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState
-
repeated .CoordinatorState.ShardEntry shards = 1;
- getShardsCount() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorStateOrBuilder
-
repeated .CoordinatorState.ShardEntry shards = 1;
- getShardsList() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated .CoordinatorState.ShardEntry shards = 1;
- getShardsList() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState
-
repeated .CoordinatorState.ShardEntry shards = 1;
- getShardsList() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorStateOrBuilder
-
repeated .CoordinatorState.ShardEntry shards = 1;
- getShardsOrBuilder(int) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated .CoordinatorState.ShardEntry shards = 1;
- getShardsOrBuilder(int) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState
-
repeated .CoordinatorState.ShardEntry shards = 1;
- getShardsOrBuilder(int) - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorStateOrBuilder
-
repeated .CoordinatorState.ShardEntry shards = 1;
- getShardsOrBuilderList() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated .CoordinatorState.ShardEntry shards = 1;
- getShardsOrBuilderList() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState
-
repeated .CoordinatorState.ShardEntry shards = 1;
- getShardsOrBuilderList() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorStateOrBuilder
-
repeated .CoordinatorState.ShardEntry shards = 1;
- GetShardStats$() - Constructor for class akka.cluster.sharding.Shard.GetShardStats$
-
- 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) - Static method in class akka.actor.ActorCell
-
- 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
-
- getSingleChild(String) - Static method in class akka.routing.RoutedActorCell
-
- getSingleChild(String) - Static method in class akka.testkit.TestActorRef
-
- getSingleChild(String) - Static method in class akka.testkit.TestFSMRef
-
- GetSockAddr$() - Constructor for class akka.remote.testconductor.Controller.GetSockAddr$
-
- getStackTrace() - Static method in exception akka.actor.ActorInitializationException
-
- getStackTrace() - Static method in exception akka.actor.ActorKilledException
-
- getStackTrace() - Static method in exception akka.actor.ActorNotFound
-
- getStackTrace() - Static method in exception akka.actor.DeathPactException
-
- getStackTrace() - Static method in exception akka.actor.IllegalActorStateException
-
- getStackTrace() - Static method in exception akka.actor.InvalidActorNameException
-
- getStackTrace() - Static method in exception akka.actor.InvalidMessageException
-
- getStackTrace() - Static method in exception akka.actor.PostRestartException
-
- getStackTrace() - Static method in exception akka.actor.PreRestartException
-
- getStackTrace() - Static method in exception akka.actor.SchedulerException
-
- getStackTrace() - Static method in exception akka.actor.StashOverflowException
-
- getStackTrace() - Static method in exception akka.contrib.circuitbreaker.OpenCircuitException
-
- getStackTrace() - Static method in exception akka.pattern.CircuitBreakerOpenException
-
- getStackTrace() - Method in exception akka.persistence.scalatest.MayVerb.TestCanceledByFailure
-
- getStackTrace(int) - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
repeated .StackTraceElement stackTrace = 4;
- getStackTrace(int) - Method in class akka.remote.ContainerFormats.Throwable
-
repeated .StackTraceElement stackTrace = 4;
- getStackTrace(int) - Method in interface akka.remote.ContainerFormats.ThrowableOrBuilder
-
repeated .StackTraceElement stackTrace = 4;
- getStackTrace() - Static method in exception akka.remote.HopelessAssociation
-
- getStackTrace() - Static method in exception akka.remote.InvalidAssociation
-
- getStackTrace() - Static method in exception akka.remote.ShutDownAssociation
-
- getStackTrace() - Static method in exception akka.remote.transport.FailureInjectorException
-
- getStackTrace() - Static method in exception akka.stream.AbruptTerminationException
-
- getStackTrace() - Static method in exception akka.stream.BindFailedException
-
- getStackTrace() - Static method in exception akka.stream.BufferOverflowException
-
- getStackTrace() - Static method in exception akka.stream.MaterializationException
-
- getStackTrace() - Static method in exception akka.typed.DeathPactException
-
- getStackTraceBuilder(int) - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
repeated .StackTraceElement stackTrace = 4;
- getStackTraceBuilderList() - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
repeated .StackTraceElement stackTrace = 4;
- getStackTraceCount() - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
repeated .StackTraceElement stackTrace = 4;
- getStackTraceCount() - Method in class akka.remote.ContainerFormats.Throwable
-
repeated .StackTraceElement stackTrace = 4;
- getStackTraceCount() - Method in interface akka.remote.ContainerFormats.ThrowableOrBuilder
-
repeated .StackTraceElement stackTrace = 4;
- getStackTraceDepth() - Static method in exception akka.actor.ActorInitializationException
-
- getStackTraceDepth() - Static method in exception akka.actor.ActorKilledException
-
- getStackTraceDepth() - Static method in exception akka.actor.ActorNotFound
-
- getStackTraceDepth() - Static method in exception akka.actor.DeathPactException
-
- getStackTraceDepth() - Static method in exception akka.actor.IllegalActorStateException
-
- getStackTraceDepth() - Static method in exception akka.actor.InvalidActorNameException
-
- getStackTraceDepth() - Static method in exception akka.actor.InvalidMessageException
-
- getStackTraceDepth() - Static method in exception akka.actor.PostRestartException
-
- getStackTraceDepth() - Static method in exception akka.actor.PreRestartException
-
- getStackTraceDepth() - Static method in exception akka.actor.SchedulerException
-
- getStackTraceDepth() - Static method in exception akka.actor.StashOverflowException
-
- getStackTraceDepth() - Static method in exception akka.contrib.circuitbreaker.OpenCircuitException
-
- getStackTraceDepth() - Static method in exception akka.pattern.CircuitBreakerOpenException
-
- getStackTraceDepth() - Static method in exception akka.remote.HopelessAssociation
-
- getStackTraceDepth() - Static method in exception akka.remote.InvalidAssociation
-
- getStackTraceDepth() - Static method in exception akka.remote.ShutDownAssociation
-
- getStackTraceDepth() - Static method in exception akka.remote.transport.FailureInjectorException
-
- getStackTraceDepth() - Static method in exception akka.stream.AbruptTerminationException
-
- getStackTraceDepth() - Static method in exception akka.stream.BindFailedException
-
- getStackTraceDepth() - Static method in exception akka.stream.BufferOverflowException
-
- getStackTraceDepth() - Static method in exception akka.stream.MaterializationException
-
- getStackTraceDepth() - Static method in exception akka.typed.DeathPactException
-
- getStackTraceElement(int) - Static method in exception akka.actor.ActorInitializationException
-
- getStackTraceElement(int) - Static method in exception akka.actor.ActorKilledException
-
- getStackTraceElement(int) - Static method in exception akka.actor.ActorNotFound
-
- getStackTraceElement(int) - Static method in exception akka.actor.DeathPactException
-
- getStackTraceElement(int) - Static method in exception akka.actor.IllegalActorStateException
-
- getStackTraceElement(int) - Static method in exception akka.actor.InvalidActorNameException
-
- getStackTraceElement(int) - Static method in exception akka.actor.InvalidMessageException
-
- getStackTraceElement(int) - Static method in exception akka.actor.PostRestartException
-
- getStackTraceElement(int) - Static method in exception akka.actor.PreRestartException
-
- getStackTraceElement(int) - Static method in exception akka.actor.SchedulerException
-
- getStackTraceElement(int) - Static method in exception akka.actor.StashOverflowException
-
- getStackTraceElement(int) - Static method in exception akka.contrib.circuitbreaker.OpenCircuitException
-
- getStackTraceElement(int) - Static method in exception akka.pattern.CircuitBreakerOpenException
-
- getStackTraceElement(int) - Static method in exception akka.remote.HopelessAssociation
-
- getStackTraceElement(int) - Static method in exception akka.remote.InvalidAssociation
-
- getStackTraceElement(int) - Static method in exception akka.remote.ShutDownAssociation
-
- getStackTraceElement(int) - Static method in exception akka.remote.transport.FailureInjectorException
-
- getStackTraceElement(int) - Static method in exception akka.stream.AbruptTerminationException
-
- getStackTraceElement(int) - Static method in exception akka.stream.BindFailedException
-
- getStackTraceElement(int) - Static method in exception akka.stream.BufferOverflowException
-
- getStackTraceElement(int) - Static method in exception akka.stream.MaterializationException
-
- getStackTraceElement(int) - Static method in exception akka.typed.DeathPactException
-
- getStackTraceList() - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
repeated .StackTraceElement stackTrace = 4;
- getStackTraceList() - Method in class akka.remote.ContainerFormats.Throwable
-
repeated .StackTraceElement stackTrace = 4;
- getStackTraceList() - Method in interface akka.remote.ContainerFormats.ThrowableOrBuilder
-
repeated .StackTraceElement stackTrace = 4;
- getStackTraceOrBuilder(int) - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
repeated .StackTraceElement stackTrace = 4;
- getStackTraceOrBuilder(int) - Method in class akka.remote.ContainerFormats.Throwable
-
repeated .StackTraceElement stackTrace = 4;
- getStackTraceOrBuilder(int) - Method in interface akka.remote.ContainerFormats.ThrowableOrBuilder
-
repeated .StackTraceElement stackTrace = 4;
- getStackTraceOrBuilderList() - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
repeated .StackTraceElement stackTrace = 4;
- getStackTraceOrBuilderList() - Method in class akka.remote.ContainerFormats.Throwable
-
repeated .StackTraceElement stackTrace = 4;
- getStackTraceOrBuilderList() - Method in interface akka.remote.ContainerFormats.ThrowableOrBuilder
-
repeated .StackTraceElement stackTrace = 4;
- getStageActor(Function1<Tuple2<ActorRef, Object>, BoxedUnit>) - Method in class akka.stream.stage.GraphStageLogic
-
Initialize a StageActorRef
which can be used to interact with from the outside world "as-if" an Actor
.
- getState() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
required .akka.cluster.ddata.OtherMessage state = 3;
- getState() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister
-
required .akka.cluster.ddata.OtherMessage state = 3;
- getState() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegisterOrBuilder
-
required .akka.cluster.ddata.OtherMessage state = 3;
- getState() - Method in class akka.cluster.sharding.DDataShardCoordinator
-
- getStateBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
required .akka.cluster.ddata.OtherMessage state = 3;
- getStateIdentifier() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot.Builder
-
required string stateIdentifier = 1;
- getStateIdentifier() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot
-
required string stateIdentifier = 1;
- getStateIdentifier() - Method in interface akka.persistence.serialization.MessageFormats.PersistentFSMSnapshotOrBuilder
-
required string stateIdentifier = 1;
- getStateIdentifier() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
-
required string stateIdentifier = 1;
- getStateIdentifier() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
-
required string stateIdentifier = 1;
- getStateIdentifier() - Method in interface akka.persistence.serialization.MessageFormats.PersistentStateChangeEventOrBuilder
-
required string stateIdentifier = 1;
- getStateIdentifierBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot.Builder
-
required string stateIdentifier = 1;
- getStateIdentifierBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot
-
required string stateIdentifier = 1;
- getStateIdentifierBytes() - Method in interface akka.persistence.serialization.MessageFormats.PersistentFSMSnapshotOrBuilder
-
required string stateIdentifier = 1;
- getStateIdentifierBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
-
required string stateIdentifier = 1;
- getStateIdentifierBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
-
required string stateIdentifier = 1;
- getStateIdentifierBytes() - Method in interface akka.persistence.serialization.MessageFormats.PersistentStateChangeEventOrBuilder
-
required string stateIdentifier = 1;
- getStateOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
required .akka.cluster.ddata.OtherMessage state = 3;
- getStateOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister
-
required .akka.cluster.ddata.OtherMessage state = 3;
- getStateOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegisterOrBuilder
-
required .akka.cluster.ddata.OtherMessage state = 3;
- getStats() - Method in class akka.cluster.sharding.ShardRegion.ShardRegionStats
-
Java API
- 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;
- getStatus() - Method in class akka.typed.internal.ActorCell
-
- getStoppingDecider() - Method in class akka.stream.Supervision$
-
- getStoppingDecider() - Static method in class akka.stream.Supervision
-
- getString(String) - Method in class akka.dispatch.CachingConfig
-
- getStringElements(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated string stringElements = 1;
- getStringElements(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet
-
repeated string stringElements = 1;
- getStringElements(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSetOrBuilder
-
repeated string stringElements = 1;
- getStringElements(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated string stringElements = 3;
- getStringElements(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
repeated string stringElements = 3;
- getStringElements(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSetOrBuilder
-
repeated string stringElements = 3;
- getStringElementsBytes(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated string stringElements = 1;
- getStringElementsBytes(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet
-
repeated string stringElements = 1;
- getStringElementsBytes(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSetOrBuilder
-
repeated string stringElements = 1;
- getStringElementsBytes(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated string stringElements = 3;
- getStringElementsBytes(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
repeated string stringElements = 3;
- getStringElementsBytes(int) - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSetOrBuilder
-
repeated string stringElements = 3;
- getStringElementsCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated string stringElements = 1;
- getStringElementsCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet
-
repeated string stringElements = 1;
- getStringElementsCount() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSetOrBuilder
-
repeated string stringElements = 1;
- getStringElementsCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated string stringElements = 3;
- getStringElementsCount() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
repeated string stringElements = 3;
- getStringElementsCount() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSetOrBuilder
-
repeated string stringElements = 3;
- getStringElementsList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated string stringElements = 1;
- getStringElementsList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet
-
repeated string stringElements = 1;
- getStringElementsList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSetOrBuilder
-
repeated string stringElements = 1;
- getStringElementsList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated string stringElements = 3;
- getStringElementsList() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
repeated string stringElements = 3;
- getStringElementsList() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSetOrBuilder
-
repeated string stringElements = 3;
- 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;
- GetSuccess(Key<A>, Option<Object>, A) - Constructor for class akka.cluster.ddata.Replicator.GetSuccess
-
- GetSuccess$() - Constructor for class akka.cluster.ddata.Replicator.GetSuccess$
-
- GetSuccessManifest() - Method in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer
-
- getSuperviseData() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .SuperviseData superviseData = 5;
- getSuperviseData() - Method in class akka.remote.SystemMessageFormats.SystemMessage
-
optional .SuperviseData superviseData = 5;
- getSuperviseData() - Method in interface akka.remote.SystemMessageFormats.SystemMessageOrBuilder
-
optional .SuperviseData superviseData = 5;
- getSuperviseDataBuilder() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .SuperviseData superviseData = 5;
- getSuperviseDataOrBuilder() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .SuperviseData superviseData = 5;
- getSuperviseDataOrBuilder() - Method in class akka.remote.SystemMessageFormats.SystemMessage
-
optional .SuperviseData superviseData = 5;
- getSuperviseDataOrBuilder() - Method in interface akka.remote.SystemMessageFormats.SystemMessageOrBuilder
-
optional .SuperviseData superviseData = 5;
- 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;
- getSuppressed() - Static method in exception akka.actor.ActorInitializationException
-
- getSuppressed() - Static method in exception akka.actor.ActorKilledException
-
- getSuppressed() - Static method in exception akka.actor.ActorNotFound
-
- getSuppressed() - Static method in exception akka.actor.DeathPactException
-
- getSuppressed() - Static method in exception akka.actor.IllegalActorStateException
-
- getSuppressed() - Static method in exception akka.actor.InvalidActorNameException
-
- getSuppressed() - Static method in exception akka.actor.InvalidMessageException
-
- getSuppressed() - Static method in exception akka.actor.PostRestartException
-
- getSuppressed() - Static method in exception akka.actor.PreRestartException
-
- getSuppressed() - Static method in exception akka.actor.SchedulerException
-
- getSuppressed() - Static method in exception akka.actor.StashOverflowException
-
- getSuppressed() - Static method in exception akka.contrib.circuitbreaker.OpenCircuitException
-
- getSuppressed() - Static method in exception akka.pattern.CircuitBreakerOpenException
-
- getSuppressed() - Static method in exception akka.remote.HopelessAssociation
-
- getSuppressed() - Static method in exception akka.remote.InvalidAssociation
-
- getSuppressed() - Static method in exception akka.remote.ShutDownAssociation
-
- getSuppressed() - Static method in exception akka.remote.transport.FailureInjectorException
-
- getSuppressed() - Static method in exception akka.stream.AbruptTerminationException
-
- getSuppressed() - Static method in exception akka.stream.BindFailedException
-
- getSuppressed() - Static method in exception akka.stream.BufferOverflowException
-
- getSuppressed() - Static method in exception akka.stream.MaterializationException
-
- getSuppressed() - Static method in exception akka.typed.DeathPactException
-
- 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.ArteryControlFormats.Address.Builder
-
required string system = 2;
- getSystem() - Method in class akka.remote.ArteryControlFormats.Address
-
required string system = 2;
- getSystem() - Method in interface akka.remote.ArteryControlFormats.AddressOrBuilder
-
required string system = 2;
- 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.ArteryControlFormats.Address.Builder
-
required string system = 2;
- getSystemBytes() - Method in class akka.remote.ArteryControlFormats.Address
-
required string system = 2;
- getSystemBytes() - Method in interface akka.remote.ArteryControlFormats.AddressOrBuilder
-
required string system = 2;
- 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;
- getTableVersion() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
required uint32 tableVersion = 3;
- getTableVersion() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement
-
required uint32 tableVersion = 3;
- getTableVersion() - Method in interface akka.remote.ArteryControlFormats.CompressionTableAdvertisementOrBuilder
-
required uint32 tableVersion = 3;
- getTestActor() - Method in class akka.testkit.JavaTestKit
-
ActorRef of the test actor.
- getTimeout() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
required uint32 timeout = 3;
- getTimeout() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get
-
required uint32 timeout = 3;
- getTimeout() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetOrBuilder
-
required uint32 timeout = 3;
- getTimeout() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
-
optional string timeout = 2;
- getTimeout() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
-
optional string timeout = 2;
- getTimeout() - Method in interface akka.persistence.serialization.MessageFormats.PersistentStateChangeEventOrBuilder
-
optional string timeout = 2;
- 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;
- getTimeoutBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
-
optional string timeout = 2;
- getTimeoutBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
-
optional string timeout = 2;
- getTimeoutBytes() - Method in interface akka.persistence.serialization.MessageFormats.PersistentStateChangeEventOrBuilder
-
optional string timeout = 2;
- getTimeoutNanos() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot.Builder
-
optional int64 timeoutNanos = 3;
- getTimeoutNanos() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot
-
optional int64 timeoutNanos = 3;
- getTimeoutNanos() - Method in interface akka.persistence.serialization.MessageFormats.PersistentFSMSnapshotOrBuilder
-
optional int64 timeoutNanos = 3;
- getTimeoutNanos() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
-
optional int64 timeoutNanos = 3;
- getTimeoutNanos() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
-
optional int64 timeoutNanos = 3;
- getTimeoutNanos() - Method in interface akka.persistence.serialization.MessageFormats.PersistentStateChangeEventOrBuilder
-
optional int64 timeoutNanos = 3;
- getTimestamp() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
required sint64 timestamp = 1;
- getTimestamp() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister
-
required sint64 timestamp = 1;
- getTimestamp() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegisterOrBuilder
-
required sint64 timestamp = 1;
- 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;
- getTo() - Method in class akka.remote.ArteryControlFormats.HandshakeReq.Builder
-
required .Address to = 2;
- getTo() - Method in class akka.remote.ArteryControlFormats.HandshakeReq
-
required .Address to = 2;
- getTo() - Method in interface akka.remote.ArteryControlFormats.HandshakeReqOrBuilder
-
required .Address to = 2;
- getTo() - Method in class akka.remote.ArteryControlFormats.Quarantined.Builder
-
required .UniqueAddress to = 2;
- getTo() - Method in class akka.remote.ArteryControlFormats.Quarantined
-
required .UniqueAddress to = 2;
- getTo() - Method in interface akka.remote.ArteryControlFormats.QuarantinedOrBuilder
-
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;
- getToBuilder() - Method in class akka.remote.ArteryControlFormats.HandshakeReq.Builder
-
required .Address to = 2;
- getToBuilder() - Method in class akka.remote.ArteryControlFormats.Quarantined.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;
- getToOrBuilder() - Method in class akka.remote.ArteryControlFormats.HandshakeReq.Builder
-
required .Address to = 2;
- getToOrBuilder() - Method in class akka.remote.ArteryControlFormats.HandshakeReq
-
required .Address to = 2;
- getToOrBuilder() - Method in interface akka.remote.ArteryControlFormats.HandshakeReqOrBuilder
-
required .Address to = 2;
- getToOrBuilder() - Method in class akka.remote.ArteryControlFormats.Quarantined.Builder
-
required .UniqueAddress to = 2;
- getToOrBuilder() - Method in class akka.remote.ArteryControlFormats.Quarantined
-
required .UniqueAddress to = 2;
- getToOrBuilder() - Method in interface akka.remote.ArteryControlFormats.QuarantinedOrBuilder
-
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$
-
- getTopicsInstance() - Static method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- getTotChunks() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
required uint32 totChunks = 2;
- getTotChunks() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status
-
required uint32 totChunks = 2;
- getTotChunks() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StatusOrBuilder
-
required uint32 totChunks = 2;
- 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;
- getType() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
required .SystemMessage.Type type = 1;
- getType() - Method in class akka.remote.SystemMessageFormats.SystemMessage
-
required .SystemMessage.Type type = 1;
- getType() - Method in interface akka.remote.SystemMessageFormats.SystemMessageOrBuilder
-
required .SystemMessage.Type type = 1;
- getUid() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress.Builder
-
required sfixed32 uid = 2;
- getUid() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress
-
required sfixed32 uid = 2;
- getUid() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddressOrBuilder
-
required sfixed32 uid = 2;
- 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.ArteryControlFormats.ArteryHeartbeatRsp.Builder
-
required uint64 uid = 1;
- getUid() - Method in class akka.remote.ArteryControlFormats.ArteryHeartbeatRsp
-
required uint64 uid = 1;
- getUid() - Method in interface akka.remote.ArteryControlFormats.ArteryHeartbeatRspOrBuilder
-
required uint64 uid = 1;
- getUid() - Method in class akka.remote.ArteryControlFormats.UniqueAddress.Builder
-
required uint64 uid = 2;
- getUid() - Method in class akka.remote.ArteryControlFormats.UniqueAddress
-
required uint64 uid = 2;
- getUid() - Method in interface akka.remote.ArteryControlFormats.UniqueAddressOrBuilder
-
required uint64 uid = 2;
- getUid() - Method in class akka.remote.ContainerFormats.WatcherHeartbeatResponse.Builder
-
required uint64 uid = 1;
- getUid() - Method in class akka.remote.ContainerFormats.WatcherHeartbeatResponse
-
required uint64 uid = 1;
- getUid() - Method in interface akka.remote.ContainerFormats.WatcherHeartbeatResponseOrBuilder
-
required uint64 uid = 1;
- getUid() - Method in class akka.remote.SystemMessageFormats.FailedData.Builder
-
required uint64 uid = 2;
- getUid() - Method in class akka.remote.SystemMessageFormats.FailedData
-
required uint64 uid = 2;
- getUid() - Method in interface akka.remote.SystemMessageFormats.FailedDataOrBuilder
-
required uint64 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;
- getUid2() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress.Builder
-
optional sfixed32 uid2 = 3;
- getUid2() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress
-
optional sfixed32 uid2 = 3;
- getUid2() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddressOrBuilder
-
optional sfixed32 uid2 = 3;
- getUid2() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
-
optional uint32 uid2 = 3;
- getUid2() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
-
optional uint32 uid2 = 3;
- getUid2() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.UniqueAddressOrBuilder
-
optional uint32 uid2 = 3;
- getUnallocatedShards(int) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string unallocatedShards = 4;
- getUnallocatedShards(int) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState
-
repeated string unallocatedShards = 4;
- getUnallocatedShards(int) - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorStateOrBuilder
-
repeated string unallocatedShards = 4;
- getUnallocatedShardsBytes(int) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string unallocatedShards = 4;
- getUnallocatedShardsBytes(int) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState
-
repeated string unallocatedShards = 4;
- getUnallocatedShardsBytes(int) - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorStateOrBuilder
-
repeated string unallocatedShards = 4;
- getUnallocatedShardsCount() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string unallocatedShards = 4;
- getUnallocatedShardsCount() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState
-
repeated string unallocatedShards = 4;
- getUnallocatedShardsCount() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorStateOrBuilder
-
repeated string unallocatedShards = 4;
- getUnallocatedShardsList() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string unallocatedShards = 4;
- getUnallocatedShardsList() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState
-
repeated string unallocatedShards = 4;
- getUnallocatedShardsList() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorStateOrBuilder
-
repeated string unallocatedShards = 4;
- 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.client.protobuf.msg.ClusterClientMessages.Contacts
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.Flag
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Address
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelope
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Empty
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Read
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResult
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe
-
- getUnknownFields() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write
-
- 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.SendToOneSubscriber
-
- 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.cluster.sharding.protobuf.msg.ClusterShardingMessages.ActorRefMessage
-
- getUnknownFields() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState
-
- getUnknownFields() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry
-
- getUnknownFields() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStarted
-
- getUnknownFields() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState
-
- getUnknownFields() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStopped
-
- getUnknownFields() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome
-
- getUnknownFields() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated
-
- getUnknownFields() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessage
-
- getUnknownFields() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats
-
- 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.AtomicWrite
-
- getUnknownFields() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot
-
- getUnknownFields() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
- getUnknownFields() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
-
- getUnknownFields() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
-
- getUnknownFields() - Method in class akka.remote.ArteryControlFormats.Address
-
- getUnknownFields() - Method in class akka.remote.ArteryControlFormats.ArteryHeartbeatRsp
-
- getUnknownFields() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement
-
- getUnknownFields() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck
-
- getUnknownFields() - Method in class akka.remote.ArteryControlFormats.HandshakeReq
-
- getUnknownFields() - Method in class akka.remote.ArteryControlFormats.MessageWithAddress
-
- getUnknownFields() - Method in class akka.remote.ArteryControlFormats.Quarantined
-
- getUnknownFields() - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck
-
- getUnknownFields() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope
-
- getUnknownFields() - Method in class akka.remote.ArteryControlFormats.UniqueAddress
-
- getUnknownFields() - Method in class akka.remote.ContainerFormats.ActorIdentity
-
- getUnknownFields() - Method in class akka.remote.ContainerFormats.ActorInitializationException
-
- getUnknownFields() - Method in class akka.remote.ContainerFormats.ActorRef
-
- getUnknownFields() - Method in class akka.remote.ContainerFormats.Identify
-
- getUnknownFields() - Method in class akka.remote.ContainerFormats.Option
-
- getUnknownFields() - Method in class akka.remote.ContainerFormats.Payload
-
- getUnknownFields() - Method in class akka.remote.ContainerFormats.Selection
-
- getUnknownFields() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
-
- getUnknownFields() - Method in class akka.remote.ContainerFormats.StackTraceElement
-
- getUnknownFields() - Method in class akka.remote.ContainerFormats.Throwable
-
- getUnknownFields() - Method in class akka.remote.ContainerFormats.WatcherHeartbeatResponse
-
- getUnknownFields() - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData
-
- getUnknownFields() - Method in class akka.remote.SystemMessageFormats.FailedData
-
- getUnknownFields() - Method in class akka.remote.SystemMessageFormats.SuperviseData
-
- getUnknownFields() - Method in class akka.remote.SystemMessageFormats.SystemMessage
-
- getUnknownFields() - Method in class akka.remote.SystemMessageFormats.WatchData
-
- 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
-
- getUnknownFields() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet
-
- getUnknownFields() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2
-
- getUnknownFields() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved
-
- 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.ddata.GCounter
-
Java API: Current total value of the counter.
- getValue() - Method in class akka.cluster.ddata.LWWRegister
-
Java API
- getValue() - Method in class akka.cluster.ddata.PNCounter
-
Java API: Current total value of the counter.
- getValue(String) - Method in class akka.cluster.ddata.PNCounterMap
-
Java API: The count for a key, or null
if it doesn't exist
- getValue() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry.Builder
-
required bytes value = 2;
- getValue() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry
-
required bytes value = 2;
- getValue() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.EntryOrBuilder
-
required bytes value = 2;
- getValue() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry.Builder
-
required .akka.cluster.ddata.LWWRegister value = 2;
- getValue() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry
-
required .akka.cluster.ddata.LWWRegister value = 2;
- getValue() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.EntryOrBuilder
-
required .akka.cluster.ddata.LWWRegister value = 2;
- getValue() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry.Builder
-
required .akka.cluster.ddata.OtherMessage value = 2;
- getValue() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry
-
required .akka.cluster.ddata.OtherMessage value = 2;
- getValue() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.EntryOrBuilder
-
required .akka.cluster.ddata.OtherMessage value = 2;
- getValue() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry.Builder
-
required .akka.cluster.ddata.ORSet value = 2;
- getValue() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry
-
required .akka.cluster.ddata.ORSet value = 2;
- getValue() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.EntryOrBuilder
-
required .akka.cluster.ddata.ORSet value = 2;
- getValue() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry.Builder
-
required .akka.cluster.ddata.PNCounter value = 2;
- getValue() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry
-
required .akka.cluster.ddata.PNCounter value = 2;
- getValue() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.EntryOrBuilder
-
required .akka.cluster.ddata.PNCounter value = 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
-
- getValue() - Method in class akka.remote.ContainerFormats.Option.Builder
-
optional .Payload value = 1;
- getValue() - Method in class akka.remote.ContainerFormats.Option
-
optional .Payload value = 1;
- getValue() - Method in interface akka.remote.ContainerFormats.OptionOrBuilder
-
optional .Payload value = 1;
- 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;
- getValueBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry.Builder
-
required .akka.cluster.ddata.LWWRegister value = 2;
- getValueBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry.Builder
-
required .akka.cluster.ddata.OtherMessage value = 2;
- getValueBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry.Builder
-
required .akka.cluster.ddata.ORSet value = 2;
- getValueBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry.Builder
-
required .akka.cluster.ddata.PNCounter value = 2;
- getValueBuilder() - Method in class akka.remote.ContainerFormats.Option.Builder
-
optional .Payload value = 1;
- 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.SystemMessageFormats.SystemMessage.Type
-
- 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
-
- getValueOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry.Builder
-
required .akka.cluster.ddata.LWWRegister value = 2;
- getValueOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry
-
required .akka.cluster.ddata.LWWRegister value = 2;
- getValueOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.EntryOrBuilder
-
required .akka.cluster.ddata.LWWRegister value = 2;
- getValueOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry.Builder
-
required .akka.cluster.ddata.OtherMessage value = 2;
- getValueOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry
-
required .akka.cluster.ddata.OtherMessage value = 2;
- getValueOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.EntryOrBuilder
-
required .akka.cluster.ddata.OtherMessage value = 2;
- getValueOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry.Builder
-
required .akka.cluster.ddata.ORSet value = 2;
- getValueOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry
-
required .akka.cluster.ddata.ORSet value = 2;
- getValueOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.EntryOrBuilder
-
required .akka.cluster.ddata.ORSet value = 2;
- getValueOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry.Builder
-
required .akka.cluster.ddata.PNCounter value = 2;
- getValueOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry
-
required .akka.cluster.ddata.PNCounter value = 2;
- getValueOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.EntryOrBuilder
-
required .akka.cluster.ddata.PNCounter value = 2;
- getValueOrBuilder() - Method in class akka.remote.ContainerFormats.Option.Builder
-
optional .Payload value = 1;
- getValueOrBuilder() - Method in class akka.remote.ContainerFormats.Option
-
optional .Payload value = 1;
- getValueOrBuilder() - Method in interface akka.remote.ContainerFormats.OptionOrBuilder
-
optional .Payload value = 1;
- getValues(int) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
repeated uint32 values = 5;
- getValues(int) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement
-
repeated uint32 values = 5;
- getValues(int) - Method in interface akka.remote.ArteryControlFormats.CompressionTableAdvertisementOrBuilder
-
repeated uint32 values = 5;
- getValuesCount() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
repeated uint32 values = 5;
- getValuesCount() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement
-
repeated uint32 values = 5;
- getValuesCount() - Method in interface akka.remote.ArteryControlFormats.CompressionTableAdvertisementOrBuilder
-
repeated uint32 values = 5;
- getValuesList() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
repeated uint32 values = 5;
- getValuesList() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement
-
repeated uint32 values = 5;
- getValuesList() - Method in interface akka.remote.ArteryControlFormats.CompressionTableAdvertisementOrBuilder
-
repeated uint32 values = 5;
- getVersion() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry.Builder
-
required int64 version = 2;
- getVersion() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry
-
required int64 version = 2;
- getVersion() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.EntryOrBuilder
-
required int64 version = 2;
- 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;
- getVersion() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck.Builder
-
required uint32 version = 2;
- getVersion() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck
-
required uint32 version = 2;
- getVersion() - Method in interface akka.remote.ArteryControlFormats.CompressionTableAdvertisementAckOrBuilder
-
required uint32 version = 2;
- getVersion() - Static method in class akka.remote.security.provider.AkkaProvider
-
- 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;
- getVvector() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
required .akka.cluster.ddata.VersionVector vvector = 1;
- getVvector() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
required .akka.cluster.ddata.VersionVector vvector = 1;
- getVvector() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSetOrBuilder
-
required .akka.cluster.ddata.VersionVector vvector = 1;
- getVvectorBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
required .akka.cluster.ddata.VersionVector vvector = 1;
- getVvectorOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
required .akka.cluster.ddata.VersionVector vvector = 1;
- getVvectorOrBuilder() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
required .akka.cluster.ddata.VersionVector vvector = 1;
- getVvectorOrBuilder() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSetOrBuilder
-
required .akka.cluster.ddata.VersionVector vvector = 1;
- getWatchData() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .WatchData watchData = 2;
- getWatchData() - Method in class akka.remote.SystemMessageFormats.SystemMessage
-
optional .WatchData watchData = 2;
- getWatchData() - Method in interface akka.remote.SystemMessageFormats.SystemMessageOrBuilder
-
optional .WatchData watchData = 2;
- getWatchDataBuilder() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .WatchData watchData = 2;
- getWatchDataOrBuilder() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .WatchData watchData = 2;
- getWatchDataOrBuilder() - Method in class akka.remote.SystemMessageFormats.SystemMessage
-
optional .WatchData watchData = 2;
- getWatchDataOrBuilder() - Method in interface akka.remote.SystemMessageFormats.SystemMessageOrBuilder
-
optional .WatchData watchData = 2;
- getWatchee() - Method in class akka.remote.SystemMessageFormats.WatchData.Builder
-
required .ActorRef watchee = 1;
- getWatchee() - Method in class akka.remote.SystemMessageFormats.WatchData
-
required .ActorRef watchee = 1;
- getWatchee() - Method in interface akka.remote.SystemMessageFormats.WatchDataOrBuilder
-
required .ActorRef watchee = 1;
- getWatcheeBuilder() - Method in class akka.remote.SystemMessageFormats.WatchData.Builder
-
required .ActorRef watchee = 1;
- getWatcheeOrBuilder() - Method in class akka.remote.SystemMessageFormats.WatchData.Builder
-
required .ActorRef watchee = 1;
- getWatcheeOrBuilder() - Method in class akka.remote.SystemMessageFormats.WatchData
-
required .ActorRef watchee = 1;
- getWatcheeOrBuilder() - Method in interface akka.remote.SystemMessageFormats.WatchDataOrBuilder
-
required .ActorRef watchee = 1;
- getWatcher() - Method in class akka.remote.SystemMessageFormats.WatchData.Builder
-
required .ActorRef watcher = 2;
- getWatcher() - Method in class akka.remote.SystemMessageFormats.WatchData
-
required .ActorRef watcher = 2;
- getWatcher() - Method in interface akka.remote.SystemMessageFormats.WatchDataOrBuilder
-
required .ActorRef watcher = 2;
- getWatcherBuilder() - Method in class akka.remote.SystemMessageFormats.WatchData.Builder
-
required .ActorRef watcher = 2;
- getWatcherOrBuilder() - Method in class akka.remote.SystemMessageFormats.WatchData.Builder
-
required .ActorRef watcher = 2;
- getWatcherOrBuilder() - Method in class akka.remote.SystemMessageFormats.WatchData
-
required .ActorRef watcher = 2;
- getWatcherOrBuilder() - Method in interface akka.remote.SystemMessageFormats.WatchDataOrBuilder
-
required .ActorRef watcher = 2;
- 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;
- getWriterUuid() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional string writerUuid = 13;
- getWriterUuid() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
optional string writerUuid = 13;
- getWriterUuid() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
-
optional string writerUuid = 13;
- getWriterUuidBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional string writerUuid = 13;
- getWriterUuidBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
optional string writerUuid = 13;
- getWriterUuidBytes() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
-
optional string writerUuid = 13;
- GiveUpMessageAfter() - Method in class akka.remote.artery.ArterySettings.Advanced$
-
- GiveUpSystemMessageAfter() - Method in class akka.remote.artery.ArterySettings.Advanced$
-
- 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
-
- GlobalSectionSize() - Method in class akka.remote.artery.FlightRecorder$
-
- GlobalSectionSize() - Static method in class akka.remote.artery.FlightRecorder
-
- gossip(Object, ActorRef) - Static method in class akka.actor.AbstractFSM
-
- 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(Map<String, akka.cluster.ddata.Replicator.Internal.DataEnvelope>, boolean) - Constructor for class akka.cluster.ddata.Replicator.Internal$.Gossip
-
- 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) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- gossip(Object, ActorRef) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- gossip(Object, ActorRef) - Static method in class akka.contrib.pattern.ReliableProxy
-
- gossip(Object, ActorRef) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- gossip(Object, ActorRef) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- gossip(Object, ActorRef) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- gossip(Object, ActorRef) - Static method in class akka.remote.testconductor.ClientFSM
-
- gossip(Object, ActorRef) - Static method in class akka.remote.testconductor.ServerFSM
-
- gossip(Object, ActorRef) - Static method in class akka.remote.transport.ProtocolStateActor
-
- gossip(Object, ActorRef) - Static method in class akka.remote.transport.ThrottledAssociation
-
- 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$default$2(Object) - Static method in class akka.actor.AbstractFSM
-
- gossip$default$2(Object) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- gossip$default$2(Object) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- gossip$default$2(Object) - Static method in class akka.contrib.pattern.ReliableProxy
-
- gossip$default$2(Object) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- gossip$default$2(Object) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- gossip$default$2(Object) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- gossip$default$2(Object) - Static method in class akka.remote.testconductor.ClientFSM
-
- gossip$default$2(Object) - Static method in class akka.remote.testconductor.ServerFSM
-
- gossip$default$2(Object) - Static method in class akka.remote.transport.ProtocolStateActor
-
- gossip$default$2(Object) - Static method in class akka.remote.transport.ThrottledAssociation
-
- 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.ddata.ReplicatorSettings
-
- gossipInterval() - Method in class akka.cluster.pubsub.DistributedPubSubSettings
-
- GossipManifest() - Method in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer
-
- 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$
-
- gossipRandomN(int) - Method in class akka.cluster.ClusterCoreDaemon
-
Sends full gossip to n
other random members.
- 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.ddata.Replicator
-
- 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.ddata.Replicator.Internal$.GossipTick
-
- 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.ddata.Replicator
-
- gossipTo(Address) - Method in class akka.cluster.metrics.ClusterMetricsCollector
-
- gossipTo(Address) - Method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- gotLocalStoreReply() - Method in class akka.cluster.ddata.WriteAggregator
-
- goTo(S) - Method in class akka.actor.AbstractFSM
-
Produce transition to other state.
- goTo(S) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
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
-
- gotoStopping(ActorRef) - 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$
-
- gotUpstreamSubscription() - Static method in class akka.stream.impl.FanIn
-
- gotUpstreamSubscription() - Static method in class akka.stream.impl.FanOut
-
- gotUpstreamSubscription() - Static method in class akka.stream.impl.FanoutProcessorImpl
-
- gotUpstreamSubscription() - Static method in class akka.stream.impl.io.TLSActor
-
- gotUpstreamSubscription() - Method in interface akka.stream.impl.Pump
-
- gotUpstreamSubscription() - Static method in class akka.stream.impl.Unzip
-
- gotWriteNackFrom() - Method in class akka.cluster.ddata.WriteAggregator
-
- grab(Inlet<T>) - Method in class akka.stream.stage.GraphStageLogic
-
Once the callback InHandler.onPush()
for an input port has been invoked, the element that has been pushed
can be retrieved via this method.
- grab() - Method in class akka.stream.stage.GraphStageLogic.SubSinkInlet
-
- gracefulClose(Channel, ExecutionContext) - Method in class akka.remote.transport.netty.NettyTransport$
-
- gracefulClose(Channel, ExecutionContext) - Static method in class akka.remote.transport.netty.NettyTransport
-
- GracefulShutdown$() - Constructor for class akka.cluster.sharding.ShardRegion.GracefulShutdown$
-
- gracefulShutdownInProgress() - Method in class akka.cluster.sharding.ShardCoordinator
-
- gracefulShutdownInProgress() - Method in class akka.cluster.sharding.ShardRegion
-
- gracefulShutdownInstance() - Method in class akka.cluster.sharding.ShardRegion$
-
Java API: Send this message to the ShardRegion
actor to handoff all shards that are hosted by
the ShardRegion
and then the ShardRegion
actor will be stopped.
- gracefulShutdownInstance() - Static method in class akka.cluster.sharding.ShardRegion
-
Java API: Send this message to the ShardRegion
actor to handoff all shards that are hosted by
the ShardRegion
and then the ShardRegion
actor will be stopped.
- GracefulShutdownReq(ActorRef) - Constructor for class akka.cluster.sharding.ShardCoordinator.Internal$.GracefulShutdownReq
-
- 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.
- gracefulStop(ActorRef, FiniteDuration) - Method in class akka.pattern.PatternsCS$
-
Returns a CompletionStage
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.PatternsCS$
-
Returns a CompletionStage
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.PatternsCS
-
Returns a CompletionStage
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.PatternsCS
-
Returns a CompletionStage
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
-
- Graph<S extends Shape,M> - Interface in akka.stream
-
- GraphApply - Interface in akka.stream.scaladsl
-
- GraphApply$ - Class in akka.stream.scaladsl
-
INTERNAL API
- GraphApply$() - Constructor for class akka.stream.scaladsl.GraphApply$
-
- GraphApply.GraphImpl<S extends Shape,Mat> - Class in akka.stream.scaladsl
-
- GraphAssembly(GraphStageWithMaterializedValue<Shape, Object>[], Attributes[], Inlet<?>[], int[], Outlet<?>[], int[]) - Constructor for class akka.stream.impl.fusing.GraphInterpreter.GraphAssembly
-
- GraphAssembly$() - Constructor for class akka.stream.impl.fusing.GraphInterpreter.GraphAssembly$
-
- GraphCreate - Class in akka.stream.javadsl
-
- GraphCreate() - Constructor for class akka.stream.javadsl.GraphCreate
-
- GraphDSL - Class in akka.stream.javadsl
-
- GraphDSL() - Constructor for class akka.stream.javadsl.GraphDSL
-
- GraphDSL - Class in akka.stream.scaladsl
-
- GraphDSL() - Constructor for class akka.stream.scaladsl.GraphDSL
-
- GraphDSL$ - Class in akka.stream.javadsl
-
- GraphDSL$() - Constructor for class akka.stream.javadsl.GraphDSL$
-
- GraphDSL$ - Class in akka.stream.scaladsl
-
- GraphDSL$() - Constructor for class akka.stream.scaladsl.GraphDSL$
-
- GraphDSL.Builder<Mat> - Class in akka.stream.javadsl
-
- GraphDSL.Builder<M> - Class in akka.stream.scaladsl
-
- GraphDSL.Builder.ForwardOps<T> - Class in akka.stream.javadsl
-
- GraphDSL.Builder.ReverseOps<T> - Class in akka.stream.javadsl
-
- GraphDSL.Implicits$ - Class in akka.stream.scaladsl
-
- GraphDSL.Implicits$.BidiFlowShapeArrow<I1,O1,I2,O2> - Class in akka.stream.scaladsl
-
- GraphDSL.Implicits$.CombinerBase<T> - Interface in akka.stream.scaladsl
-
- GraphDSL.Implicits$.DisabledReversePortOps<In> - Class in akka.stream.scaladsl
-
- GraphDSL.Implicits$.FanInOps<In,Out> - Class in akka.stream.scaladsl
-
- GraphDSL.Implicits$.FanOutOps<In,Out> - Class in akka.stream.scaladsl
-
- GraphDSL.Implicits$.FlowArrow<I,O,M> - Class in akka.stream.scaladsl
-
- GraphDSL.Implicits$.FlowShapeArrow<I,O> - Class in akka.stream.scaladsl
-
- GraphDSL.Implicits$.PortOps<Out> - Interface in akka.stream.scaladsl
-
- GraphDSL.Implicits$.ReverseCombinerBase<T> - Interface in akka.stream.scaladsl
-
- GraphDSL.Implicits$.ReversePortOps<In> - Class in akka.stream.scaladsl
-
- GraphDSL.Implicits$.SinkArrow<T> - Class in akka.stream.scaladsl
-
- GraphDSL.Implicits$.SinkShapeArrow<T> - Class in akka.stream.scaladsl
-
- GraphDSL.Implicits$.SourceArrow<T> - Class in akka.stream.scaladsl
-
- GraphDSL.Implicits$.SourceShapeArrow<T> - Class in akka.stream.scaladsl
-
- GraphImpl(S, StreamLayout.Module) - Constructor for class akka.stream.scaladsl.GraphApply.GraphImpl
-
- GraphInterpreter - Class in akka.stream.impl.fusing
-
INTERNAL API
- GraphInterpreter(GraphInterpreter.GraphAssembly, Materializer, LoggingAdapter, GraphStageLogic[], GraphInterpreter.Connection[], Function3<GraphStageLogic, Object, Function1<Object, BoxedUnit>, BoxedUnit>, boolean, ActorRef) - Constructor for class akka.stream.impl.fusing.GraphInterpreter
-
- GraphInterpreter$ - Class in akka.stream.impl.fusing
-
INTERNAL API
- GraphInterpreter$() - Constructor for class akka.stream.impl.fusing.GraphInterpreter$
-
- GraphInterpreter.Connection - Class in akka.stream.impl.fusing
-
INERNAL API
- GraphInterpreter.DownstreamBoundaryStageLogic<T> - Class in akka.stream.impl.fusing
-
- GraphInterpreter.Empty$ - Class in akka.stream.impl.fusing
-
Marker object that indicates that a port holds no element since it was already grabbed.
- GraphInterpreter.Failed - Class in akka.stream.impl.fusing
-
- GraphInterpreter.Failed$ - Class in akka.stream.impl.fusing
-
- GraphInterpreter.GraphAssembly - Class in akka.stream.impl.fusing
-
INTERNAL API
- GraphInterpreter.GraphAssembly$ - Class in akka.stream.impl.fusing
-
- GraphInterpreter.UpstreamBoundaryStageLogic<T> - Class in akka.stream.impl.fusing
-
- GraphInterpreterShell - Class in akka.stream.impl.fusing
-
INTERNAL API
- GraphInterpreterShell(GraphInterpreter.GraphAssembly, GraphInterpreter.Connection[], GraphStageLogic[], Shape, ActorMaterializerSettings, ExtendedActorMaterializer) - Constructor for class akka.stream.impl.fusing.GraphInterpreterShell
-
- GraphModule - Class in akka.stream.impl.fusing
-
INTERNAL API
- GraphModule(GraphInterpreter.GraphAssembly, Shape, Attributes, StreamLayout.Module[]) - Constructor for class akka.stream.impl.fusing.GraphModule
-
- GraphModule$ - Class in akka.stream.impl.fusing
-
- GraphModule$() - Constructor for class akka.stream.impl.fusing.GraphModule$
-
- GraphStage<S extends Shape> - Class in akka.stream.stage
-
A GraphStage represents a reusable graph stream processing stage.
- GraphStage() - Constructor for class akka.stream.stage.GraphStage
-
- GraphStageLogic - Class in akka.stream.stage
-
Represents the processing logic behind a
GraphStage
.
- GraphStageLogic(int, int) - Constructor for class akka.stream.stage.GraphStageLogic
-
- GraphStageLogic(Shape) - Constructor for class akka.stream.stage.GraphStageLogic
-
- GraphStageLogic$ - Class in akka.stream.stage
-
- GraphStageLogic$() - Constructor for class akka.stream.stage.GraphStageLogic$
-
- GraphStageLogic.ConditionalTerminateInput - Class in akka.stream.stage
-
Input handler that terminates the state upon receiving completion if the
given condition holds at that time.
- GraphStageLogic.ConditionalTerminateOutput - Class in akka.stream.stage
-
Output handler that terminates the state upon receiving completion if the
given condition holds at that time.
- GraphStageLogic.EagerTerminateInput$ - Class in akka.stream.stage
-
Input handler that terminates the stage upon receiving completion.
- GraphStageLogic.EagerTerminateOutput$ - Class in akka.stream.stage
-
Output handler that terminates the stage upon cancellation.
- GraphStageLogic.IgnoreTerminateInput$ - Class in akka.stream.stage
-
Input handler that does not terminate the stage upon receiving completion.
- GraphStageLogic.IgnoreTerminateOutput$ - Class in akka.stream.stage
-
Output handler that does not terminate the stage upon cancellation.
- GraphStageLogic.StageActor - Class in akka.stream.stage
-
Minimal actor to work with other actors and watch them in a synchronous ways
- GraphStageLogic.StageActorRef$ - Class in akka.stream.stage
-
- GraphStageLogic.StageActorRefNotInitializedException - Exception in akka.stream.stage
-
- GraphStageLogic.StageActorRefNotInitializedException$ - Class in akka.stream.stage
-
- GraphStageLogic.SubSinkInlet<T> - Class in akka.stream.stage
-
INTERNAL API
- GraphStageLogic.SubSourceOutlet<T> - Class in akka.stream.stage
-
INTERNAL API
- GraphStageLogic.TotallyIgnorantInput$ - Class in akka.stream.stage
-
Input handler that does not terminate the stage upon receiving completion
nor failure.
- GraphStageLogicTimer$() - Constructor for class akka.stream.impl.Timers.GraphStageLogicTimer$
-
- GraphStageLogicWithLogging - Class in akka.stream.stage
-
- GraphStageLogicWithLogging(Shape) - Constructor for class akka.stream.stage.GraphStageLogicWithLogging
-
- GraphStageMessages - Class in akka.stream.testkit
-
Messages emitted after the corresponding stageUnderTest
methods has been invoked.
- GraphStageMessages() - Constructor for class akka.stream.testkit.GraphStageMessages
-
- GraphStageMessages$ - Class in akka.stream.testkit
-
Messages emitted after the corresponding stageUnderTest
methods has been invoked.
- GraphStageMessages$() - Constructor for class akka.stream.testkit.GraphStageMessages$
-
- GraphStageMessages.DownstreamFinish$ - Class in akka.stream.testkit
-
- GraphStageMessages.Failure - Class in akka.stream.testkit
-
- GraphStageMessages.Failure$ - Class in akka.stream.testkit
-
- GraphStageMessages.Pull$ - Class in akka.stream.testkit
-
- GraphStageMessages.Push$ - Class in akka.stream.testkit
-
- GraphStageMessages.StageFailure - Class in akka.stream.testkit
-
Sent to the probe when the stage callback threw an exception
param: operation The operation that failed
- GraphStageMessages.StageFailure$ - Class in akka.stream.testkit
-
- GraphStageMessages.StageMessage - Interface in akka.stream.testkit
-
- GraphStageMessages.UpstreamFinish$ - Class in akka.stream.testkit
-
- GraphStageModule - Class in akka.stream.impl.fusing
-
INTERNAL API
- GraphStageModule(Shape, Attributes, GraphStageWithMaterializedValue<Shape, Object>) - Constructor for class akka.stream.impl.fusing.GraphStageModule
-
- GraphStageModule$ - Class in akka.stream.impl.fusing
-
- GraphStageModule$() - Constructor for class akka.stream.impl.fusing.GraphStageModule$
-
- GraphStages - Class in akka.stream.impl.fusing
-
INTERNAL API
- GraphStages() - Constructor for class akka.stream.impl.fusing.GraphStages
-
- GraphStages$ - Class in akka.stream.impl.fusing
-
INTERNAL API
- GraphStages$() - Constructor for class akka.stream.impl.fusing.GraphStages$
-
- GraphStages.Detacher<T> - Class in akka.stream.impl.fusing
-
INTERNAL API
- GraphStages.FutureSource<T> - Class in akka.stream.impl.fusing
-
- GraphStages.Identity$ - Class in akka.stream.impl.fusing
-
- GraphStages.IgnoreSink$ - Class in akka.stream.impl.fusing
-
INTERNAL API
Discards all received elements.
- GraphStages.MaterializedValueSource<T> - Class in akka.stream.impl.fusing
-
INTERNAL API.
- GraphStages.SimpleLinearGraphStage<T> - Class in akka.stream.impl.fusing
-
INTERNAL API
- GraphStages.SingleSource<T> - Class in akka.stream.impl.fusing
-
- GraphStages.TickSource<T> - Class in akka.stream.impl.fusing
-
- GraphStageWithMaterializedValue<S extends Shape,M> - Class in akka.stream.stage
-
- GraphStageWithMaterializedValue() - Constructor for class akka.stream.stage.GraphStageWithMaterializedValue
-
- 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
-
- GroupBy<T,K> - Class in akka.stream.impl.fusing
-
INTERNAL API
- GroupBy(int, Function1<T, K>) - Constructor for class akka.stream.impl.fusing.GroupBy
-
- groupBy() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- groupBy(int, Function1<Out, K>) - Static method in class akka.stream.impl.SubFlowImpl
-
- groupBy(int, Function<Out, K>) - Method in class akka.stream.javadsl.Flow
-
This operation demultiplexes the incoming stream into separate output
streams, one for each element key.
- groupBy(int, Function<Out, K>) - Method in class akka.stream.javadsl.Source
-
This operation demultiplexes the incoming stream into separate output
streams, one for each element key.
- groupBy(int, Function1<Out, K>) - Static method in class akka.stream.scaladsl.Flow
-
- groupBy(int, Function1<Out, K>) - Method in interface akka.stream.scaladsl.FlowOps
-
This operation demultiplexes the incoming stream into separate output
streams, one for each element key.
- groupBy(int, Function1<Out, K>) - Static method in class akka.stream.scaladsl.Source
-
- groupBy(Function1<A, K>) - Static method in class akka.util.ByteString
-
- groupBy(Function1<A, K>) - Static method in class akka.util.CompactByteString
-
- Grouped<T> - Class in akka.stream.impl.fusing
-
INTERNAL API
- Grouped(int) - Constructor for class akka.stream.impl.fusing.Grouped
-
- grouped() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- grouped(int) - Static method in class akka.stream.impl.SubFlowImpl
-
- grouped(int) - Method in class akka.stream.javadsl.Flow
-
Chunk up this stream into groups of the given size, with the last group
possibly smaller than requested due to end-of-stream.
- grouped(int) - Method in class akka.stream.javadsl.Source
-
Chunk up this stream into groups of the given size, with the last group
possibly smaller than requested due to end-of-stream.
- grouped(int) - Method in class akka.stream.javadsl.SubFlow
-
Chunk up this stream into groups of the given size, with the last group
possibly smaller than requested due to end-of-stream.
- grouped(int) - Method in class akka.stream.javadsl.SubSource
-
Chunk up this stream into groups of the given size, with the last group
possibly smaller than requested due to end-of-stream.
- grouped(int) - Static method in class akka.stream.scaladsl.Flow
-
- grouped(int) - Method in interface akka.stream.scaladsl.FlowOps
-
Chunk up this stream into groups of the given size, with the last group
possibly smaller than requested due to end-of-stream.
- grouped(int) - Static method in class akka.stream.scaladsl.Source
-
- grouped(int) - Static method in class akka.util.ByteIterator
-
- grouped(int) - Static method in class akka.util.ByteString
-
- grouped(int) - Static method in class akka.util.CompactByteString
-
- Grouped$ - Class in akka.stream.impl.fusing
-
- Grouped$() - Constructor for class akka.stream.impl.fusing.Grouped$
-
- GroupedWithin<T> - Class in akka.stream.impl.fusing
-
- GroupedWithin(int, FiniteDuration) - Constructor for class akka.stream.impl.fusing.GroupedWithin
-
- groupedWithin() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- groupedWithin(int, FiniteDuration) - Static method in class akka.stream.impl.SubFlowImpl
-
- groupedWithin(int, FiniteDuration) - Method in class akka.stream.javadsl.Flow
-
Chunk up this stream into groups of elements received within a time window,
or limited by the given number of elements, whatever happens first.
- groupedWithin(int, FiniteDuration) - Method in class akka.stream.javadsl.Source
-
Chunk up this stream into groups of elements received within a time window,
or limited by the given number of elements, whatever happens first.
- groupedWithin(int, FiniteDuration) - Method in class akka.stream.javadsl.SubFlow
-
Chunk up this stream into groups of elements received within a time window,
or limited by the given number of elements, whatever happens first.
- groupedWithin(int, FiniteDuration) - Method in class akka.stream.javadsl.SubSource
-
Chunk up this stream into groups of elements received within a time window,
or limited by the given number of elements, whatever happens first.
- groupedWithin(int, FiniteDuration) - Static method in class akka.stream.scaladsl.Flow
-
- groupedWithin(int, FiniteDuration) - Method in interface akka.stream.scaladsl.FlowOps
-
Chunk up this stream into groups of elements received within a time window,
or limited by the given number of elements, whatever happens first.
- groupedWithin(int, FiniteDuration) - Static method in class akka.stream.scaladsl.Source
-
- GroupedWithinTimerKey$() - Constructor for class akka.stream.impl.fusing.TimerKeys.GroupedWithinTimerKey$
-
- groups() - Method in class akka.stream.impl.fusing.Fusing.BuildStructuralInfo
-
the list of all groups of modules that are within each async boundary
- GSet<A> - Class in akka.cluster.ddata
-
- GSet(Set<A>) - Constructor for class akka.cluster.ddata.GSet
-
- GSet$ - Class in akka.cluster.ddata
-
- GSet$() - Constructor for class akka.cluster.ddata.GSet$
-
- gsetFromBinary(byte[]) - Method in class akka.cluster.ddata.protobuf.ReplicatedDataSerializer
-
- gsetFromProto(ReplicatedDataMessages.GSet) - Method in class akka.cluster.ddata.protobuf.ReplicatedDataSerializer
-
- GSetKey<A> - Class in akka.cluster.ddata
-
- GSetKey(String) - Constructor for class akka.cluster.ddata.GSetKey
-
- GSetKey$ - Class in akka.cluster.ddata
-
- GSetKey$() - Constructor for class akka.cluster.ddata.GSetKey$
-
- gsetToProto(GSet<?>) - Method in class akka.cluster.ddata.protobuf.ReplicatedDataSerializer
-
- 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() - Static method in class akka.actor.ActorSystem
-
- 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
-
- guardian() - Static method in class akka.routing.RoutedActorCell
-
- guardianProps() - Method in class akka.actor.ActorSystemImpl
-
- guardianStrategy() - Method in class akka.actor.LocalActorRefProvider
-
Overridable supervision strategy to be used by the “/user” guardian.
- gunzip(int) - Method in class akka.stream.javadsl.Compression$
-
Creates a Flow that decompresses gzip-compressed stream of data.
- gunzip(int) - Static method in class akka.stream.javadsl.Compression
-
Creates a Flow that decompresses gzip-compressed stream of data.
- gunzip(int) - Method in class akka.stream.scaladsl.Compression$
-
Creates a Flow that decompresses a gzip-compressed stream of data.
- gunzip(int) - Static method in class akka.stream.scaladsl.Compression
-
Creates a Flow that decompresses a gzip-compressed stream of data.
- gzip() - Method in class akka.stream.scaladsl.Compression$
-
Creates a flow that gzip-compresses a stream of ByteStrings.
- gzip() - Static method in class akka.stream.scaladsl.Compression
-
Creates a flow that gzip-compresses a stream of ByteStrings.
- GzipCompressor - Class in akka.stream.impl.io.compression
-
INTERNAL API
- GzipCompressor() - Constructor for class akka.stream.impl.io.compression.GzipCompressor
-
- GzipDecompressor - Class in akka.stream.impl.io.compression
-
INTERNAL API
- GzipDecompressor(int) - Constructor for class akka.stream.impl.io.compression.GzipDecompressor
-
- GzipDecompressor$ - Class in akka.stream.impl.io.compression
-
INTERNAL API
- GzipDecompressor$() - Constructor for class akka.stream.impl.io.compression.GzipDecompressor$
-
- halfClose() - Method in class akka.stream.impl.io.ConnectionSourceStage
-
- halfClose() - Method in class akka.stream.impl.io.TcpConnectionStage.Inbound
-
- halfClose() - Method in class akka.stream.impl.io.TcpConnectionStage.Outbound
-
- halfClose() - Method in interface akka.stream.impl.io.TcpConnectionStage.TcpRole
-
- HalfOpen$() - Constructor for class akka.contrib.circuitbreaker.CircuitBreakerProxy.HalfOpen$
-
- handingOff() - Method in class akka.cluster.sharding.ShardRegion
-
- HandingOver() - Constructor for class akka.cluster.singleton.ClusterSingletonManager.Internal$.HandingOver
-
- HandingOverData(ActorRef, Option<ActorRef>) - Constructor for class akka.cluster.singleton.ClusterSingletonManager.Internal$.HandingOverData
-
- 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$
-
- handleBackoff() - Static method in class akka.pattern.BackoffSupervisor
-
- HandleBackoff - Interface in akka.pattern
-
- handleBackoff() - Method in interface akka.pattern.HandleBackoff
-
- handleBarrier(BarrierCoordinator.Data) - Method in class akka.remote.testconductor.BarrierCoordinator
-
- handleChildTerminated(ActorRef) - Static method in class akka.actor.ActorCell
-
- 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.
- handleChildTerminated(ActorContext, ActorRef, Iterable<ActorRef>) - Static method in class akka.cluster.metrics.ClusterMetricsStrategy
-
- handleChildTerminated(ActorRef) - Static method in class akka.routing.RoutedActorCell
-
- handleChildTerminated(ActorContext, ActorRef, Iterable<ActorRef>) - Method in class akka.testkit.TestActor.DelegatingSupervisorStrategy
-
- handleClose(TcpConnection.ConnectionInfo, Option<ActorRef>, Tcp.ConnectionClosed) - Method in class akka.io.TcpConnection
-
- handleClose(TcpConnection.ConnectionInfo, Option<ActorRef>, Tcp.ConnectionClosed) - Static method in class akka.io.TcpOutgoingConnection
-
- HandledCompletely$() - Constructor for class akka.contrib.pattern.ReceivePipeline.HandledCompletely$
-
- handleError(ActorRef, IOException) - Method in class akka.io.TcpConnection
-
- handleError(ActorRef, IOException) - Static method in class akka.io.TcpOutgoingConnection
-
- handleException() - Method in interface akka.actor.dungeon.Dispatch
-
- handleFailure(Failed) - Static method in class akka.actor.ActorCell
-
- handleFailure(ActorContext, ActorRef, Throwable, ChildRestartStats, Iterable<ChildRestartStats>) - Static method in class akka.actor.AllForOneStrategy
-
- handleFailure(Failed) - Method in interface akka.actor.dungeon.FaultHandling
-
- handleFailure(ActorContext, ActorRef, Throwable, ChildRestartStats, Iterable<ChildRestartStats>) - Static method in class akka.actor.OneForOneStrategy
-
- 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.
- handleFailure(ActorContext, ActorRef, Throwable, ChildRestartStats, Iterable<ChildRestartStats>) - Static method in class akka.cluster.metrics.ClusterMetricsStrategy
-
- handleFailure() - Method in class akka.cluster.sharding.RemoveInternalClusterShardingData.RemoveOnePersistenceId
-
- handleFailure(Failed) - Static method in class akka.routing.RoutedActorCell
-
- handleFailure(ActorContext, ActorRef, Throwable, ChildRestartStats, Iterable<ChildRestartStats>) - Method in class akka.testkit.TestActor.DelegatingSupervisorStrategy
-
- handleInboundAssociation(Transport.InboundAssociation, boolean) - Method in class akka.remote.EndpointManager
-
- handleInitial(ClusterEvent.CurrentClusterState) - Method in class akka.cluster.singleton.ClusterSingletonProxy
-
- handleInvokeFailure(Iterable<ActorRef>, Throwable) - Static method in class akka.actor.ActorCell
-
- handleInvokeFailure(Iterable<ActorRef>, Throwable) - Method in interface akka.actor.dungeon.FaultHandling
-
- handleInvokeFailure(Iterable<ActorRef>, Throwable) - Static method in class akka.routing.RoutedActorCell
-
- 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>) - Static method in class akka.actor.ActorCell
-
- handleNonFatalOrInterruptedException(Function1<Throwable, BoxedUnit>) - Method in interface akka.actor.dungeon.FaultHandling
-
- handleNonFatalOrInterruptedException(Function1<Throwable, BoxedUnit>) - Static method in class akka.routing.RoutedActorCell
-
- 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
-
- handler() - Method in class akka.stream.impl.fusing.ActorGraphInterpreter.AsyncInput
-
- handlers() - Method in class akka.stream.stage.GraphStageLogic
-
INTERNAL API
- handleStashedInbound(ActorRef, boolean) - Method in class akka.remote.EndpointManager
-
- handleSubscriptionTimeout(Publisher<?>, Exception) - Method in interface akka.stream.impl.StreamSubscriptionTimeoutSupport
-
Callback that should ensure that the target is canceled with the given cause.
- handleSupervise(ActorRef, boolean) - Method in class akka.actor.ActorCell
-
- handleSupervise(ActorRef, boolean) - Static method in class akka.routing.RoutedActorCell
-
- handleTransition(S, S) - Method in interface akka.actor.FSM
-
- handleTransition(S, S) - Method in interface akka.persistence.fsm.PersistentFSMBase
-
- handleWith(Flow<ByteString, ByteString, Mat>, Materializer) - Method in class akka.stream.javadsl.Tcp.IncomingConnection
-
Handles the connection using the given flow, which is materialized exactly once and the respective
materialized value is returned.
- handleWith(Flow<ByteString, ByteString, Mat>, Materializer) - Method in class akka.stream.scaladsl.Tcp.IncomingConnection
-
Handles the connection using the given flow, which is materialized exactly once and the respective
materialized instance is returned.
- handleWriteMessages(TcpConnection.ConnectionInfo) - Method in class akka.io.TcpConnection
-
- handleWriteMessages(TcpConnection.ConnectionInfo) - Static method in class akka.io.TcpOutgoingConnection
-
- 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
-
- handOffStopMessage() - Method in class akka.cluster.sharding.ClusterShardingGuardian.Start
-
- handOffStopper() - Method in class akka.cluster.sharding.Shard
-
- HandOffStopper(String, ActorRef, Set<ActorRef>, Object) - Constructor for class akka.cluster.sharding.ShardRegion.HandOffStopper
-
- handOffStopperProps(String, ActorRef, Set<ActorRef>, Object) - Method in class akka.cluster.sharding.ShardRegion$
-
- handOffStopperProps(String, ActorRef, Set<ActorRef>, Object) - Static method in class akka.cluster.sharding.ShardRegion
-
- handOffTimeout() - Method in class akka.cluster.sharding.ClusterShardingSettings.TuningParameters
-
- handOverDone(Option<ActorRef>) - Method in class akka.cluster.singleton.ClusterSingletonManager
-
- HandOverDone() - Constructor for class akka.cluster.singleton.ClusterSingletonManager.Internal$.HandOverDone
-
- HandOverInProgress() - Constructor for class akka.cluster.singleton.ClusterSingletonManager.Internal$.HandOverInProgress
-
- HandOverRetry(int) - Constructor for class akka.cluster.singleton.ClusterSingletonManager.Internal$.HandOverRetry
-
- handOverRetryInterval() - Method in class akka.cluster.singleton.ClusterSingletonManagerSettings
-
- HandOverRetryTimer() - Method in class akka.cluster.singleton.ClusterSingletonManager.Internal$
-
- handOverTo() - Method in class akka.cluster.singleton.ClusterSingletonManager.Internal$.HandingOverData
-
- HandOverToMe() - Constructor for class akka.cluster.singleton.ClusterSingletonManager.Internal$.HandOverToMe
-
- 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
-
- HandshakeReq(UniqueAddress, Address) - Constructor for class akka.remote.artery.OutboundHandshake.HandshakeReq
-
- HandshakeReq$() - Constructor for class akka.remote.artery.OutboundHandshake.HandshakeReq$
-
- HandshakeRetryInterval() - Method in class akka.remote.artery.ArterySettings.Advanced$
-
- HandshakeRsp(UniqueAddress) - Constructor for class akka.remote.artery.OutboundHandshake.HandshakeRsp
-
- HandshakeRsp$() - Constructor for class akka.remote.artery.OutboundHandshake.HandshakeRsp$
-
- HandshakeTimeout() - Method in class akka.remote.artery.ArterySettings.Advanced$
-
- HandshakeTimeout() - Method in class akka.remote.transport.AkkaProtocolSettings
-
- HandshakeTimeoutException(String) - Constructor for exception akka.remote.artery.OutboundHandshake.HandshakeTimeoutException
-
- HandshakeTimer$() - Constructor for class akka.remote.transport.ProtocolStateActor.HandshakeTimer$
-
- handshakeTimerKey() - Method in class akka.remote.transport.ProtocolStateActor
-
- 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;
- hasAckReplyTo() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope.Builder
-
required .UniqueAddress ackReplyTo = 5;
- hasAckReplyTo() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope
-
required .UniqueAddress ackReplyTo = 5;
- hasAckReplyTo() - Method in interface akka.remote.ArteryControlFormats.SystemMessageEnvelopeOrBuilder
-
required .UniqueAddress ackReplyTo = 5;
- hasActor() - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
optional .ActorRef actor = 1;
- hasActor() - Method in class akka.remote.ContainerFormats.ActorInitializationException
-
optional .ActorRef actor = 1;
- hasActor() - Method in interface akka.remote.ContainerFormats.ActorInitializationExceptionOrBuilder
-
optional .ActorRef actor = 1;
- hasActor() - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData.Builder
-
required .ActorRef actor = 1;
- hasActor() - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData
-
required .ActorRef actor = 1;
- hasActor() - Method in interface akka.remote.SystemMessageFormats.DeathWatchNotificationDataOrBuilder
-
required .ActorRef actor = 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.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress.Builder
-
required .akka.cluster.ddata.Address address = 1;
- hasAddress() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress
-
required .akka.cluster.ddata.Address address = 1;
- hasAddress() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddressOrBuilder
-
required .akka.cluster.ddata.Address address = 1;
- 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.ArteryControlFormats.MessageWithAddress.Builder
-
required .UniqueAddress address = 1;
- hasAddress() - Method in class akka.remote.ArteryControlFormats.MessageWithAddress
-
required .UniqueAddress address = 1;
- hasAddress() - Method in interface akka.remote.ArteryControlFormats.MessageWithAddressOrBuilder
-
required .UniqueAddress address = 1;
- hasAddress() - Method in class akka.remote.ArteryControlFormats.UniqueAddress.Builder
-
required .Address address = 1;
- hasAddress() - Method in class akka.remote.ArteryControlFormats.UniqueAddress
-
required .Address address = 1;
- hasAddress() - Method in interface akka.remote.ArteryControlFormats.UniqueAddressOrBuilder
-
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;
- hasAddressTerminated() - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData.Builder
-
required bool addressTerminated = 3;
- hasAddressTerminated() - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData
-
required bool addressTerminated = 3;
- hasAddressTerminated() - Method in interface akka.remote.SystemMessageFormats.DeathWatchNotificationDataOrBuilder
-
required bool addressTerminated = 3;
- hasAdds() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2.Builder
-
optional bytes adds = 1;
- hasAdds() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2
-
optional bytes adds = 1;
- hasAdds() - Method in interface docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2OrBuilder
-
optional bytes adds = 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;
- hasAllPersistenceIdsSubscribers() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- hasAllPersistenceIdsSubscribers() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
-
- hasAllRegionsRegistered() - Method in class akka.cluster.sharding.ShardCoordinator
-
- 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;
- hasAsync() - Method in class akka.remote.SystemMessageFormats.SuperviseData.Builder
-
required bool async = 2;
- hasAsync() - Method in class akka.remote.SystemMessageFormats.SuperviseData
-
required bool async = 2;
- hasAsync() - Method in interface akka.remote.SystemMessageFormats.SuperviseDataOrBuilder
-
required bool async = 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;
- hasBeenPulled(Inlet<T>) - Method in class akka.stream.stage.GraphStageLogic
-
Indicates whether there is already a pending pull for the given input port.
- hasBeenPulled() - Method in class akka.stream.stage.GraphStageLogic.SubSinkInlet
-
- hasCause() - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
required .Payload cause = 3;
- hasCause() - Method in class akka.remote.ContainerFormats.ActorInitializationException
-
required .Payload cause = 3;
- hasCause() - Method in interface akka.remote.ContainerFormats.ActorInitializationExceptionOrBuilder
-
required .Payload cause = 3;
- hasCause() - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
optional .Payload cause = 3;
- hasCause() - Method in class akka.remote.ContainerFormats.Throwable
-
optional .Payload cause = 3;
- hasCause() - Method in interface akka.remote.ContainerFormats.ThrowableOrBuilder
-
optional .Payload cause = 3;
- hasCauseData() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .Payload causeData = 3;
- hasCauseData() - Method in class akka.remote.SystemMessageFormats.SystemMessage
-
optional .Payload causeData = 3;
- hasCauseData() - Method in interface akka.remote.SystemMessageFormats.SystemMessageOrBuilder
-
optional .Payload causeData = 3;
- hasChild() - Method in class akka.remote.SystemMessageFormats.FailedData.Builder
-
required .ActorRef child = 1;
- hasChild() - Method in class akka.remote.SystemMessageFormats.FailedData
-
required .ActorRef child = 1;
- hasChild() - Method in interface akka.remote.SystemMessageFormats.FailedDataOrBuilder
-
required .ActorRef child = 1;
- hasChild() - Method in class akka.remote.SystemMessageFormats.SuperviseData.Builder
-
required .ActorRef child = 1;
- hasChild() - Method in class akka.remote.SystemMessageFormats.SuperviseData
-
required .ActorRef child = 1;
- hasChild() - Method in interface akka.remote.SystemMessageFormats.SuperviseDataOrBuilder
-
required .ActorRef child = 1;
- hasChildren() - Method in class akka.actor.VirtualPathContainer
-
- hasChunk() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
required uint32 chunk = 1;
- hasChunk() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status
-
required uint32 chunk = 1;
- hasChunk() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StatusOrBuilder
-
required uint32 chunk = 1;
- hasClassName() - Method in class akka.remote.ContainerFormats.StackTraceElement.Builder
-
required string className = 1;
- hasClassName() - Method in class akka.remote.ContainerFormats.StackTraceElement
-
required string className = 1;
- hasClassName() - Method in interface akka.remote.ContainerFormats.StackTraceElementOrBuilder
-
required string className = 1;
- hasClassName() - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
required string className = 1;
- hasClassName() - Method in class akka.remote.ContainerFormats.Throwable
-
required string className = 1;
- hasClassName() - Method in interface akka.remote.ContainerFormats.ThrowableOrBuilder
-
required string className = 1;
- 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;
- hasConsistency() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
required sint32 consistency = 2;
- hasConsistency() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get
-
required sint32 consistency = 2;
- hasConsistency() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetOrBuilder
-
required sint32 consistency = 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;
- hasCorrelationId() - Method in class akka.remote.ContainerFormats.ActorIdentity.Builder
-
required .Payload correlationId = 1;
- hasCorrelationId() - Method in class akka.remote.ContainerFormats.ActorIdentity
-
required .Payload correlationId = 1;
- hasCorrelationId() - Method in interface akka.remote.ContainerFormats.ActorIdentityOrBuilder
-
required .Payload correlationId = 1;
- 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;
- hasData() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed.Builder
-
required .akka.cluster.ddata.OtherMessage data = 2;
- hasData() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed
-
required .akka.cluster.ddata.OtherMessage data = 2;
- hasData() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ChangedOrBuilder
-
required .akka.cluster.ddata.OtherMessage data = 2;
- hasData() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
required .akka.cluster.ddata.OtherMessage data = 1;
- hasData() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope
-
required .akka.cluster.ddata.OtherMessage data = 1;
- hasData() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelopeOrBuilder
-
required .akka.cluster.ddata.OtherMessage data = 1;
- hasData() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelope.Builder
-
required .akka.cluster.ddata.OtherMessage data = 1;
- hasData() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelope
-
required .akka.cluster.ddata.OtherMessage data = 1;
- hasData() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelopeOrBuilder
-
required .akka.cluster.ddata.OtherMessage data = 1;
- hasData() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
required .akka.cluster.ddata.OtherMessage data = 2;
- hasData() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess
-
required .akka.cluster.ddata.OtherMessage data = 2;
- hasData() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccessOrBuilder
-
required .akka.cluster.ddata.OtherMessage data = 2;
- hasData() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot.Builder
-
required .PersistentPayload data = 2;
- hasData() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot
-
required .PersistentPayload data = 2;
- hasData() - Method in interface akka.persistence.serialization.MessageFormats.PersistentFSMSnapshotOrBuilder
-
required .PersistentPayload data = 2;
- hasDecrements() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter.Builder
-
required .akka.cluster.ddata.GCounter decrements = 2;
- hasDecrements() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter
-
required .akka.cluster.ddata.GCounter decrements = 2;
- hasDecrements() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterOrBuilder
-
required .akka.cluster.ddata.GCounter decrements = 2;
- hasDefiniteSize() - Static method in class akka.util.ByteIterator
-
- hasDefiniteSize() - Static method in class akka.util.ByteString
-
- hasDefiniteSize() - Static method in class akka.util.CompactByteString
-
- 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;
- hasDigest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry.Builder
-
required bytes digest = 2;
- hasDigest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry
-
required bytes digest = 2;
- hasDigest() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.EntryOrBuilder
-
required bytes digest = 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;
- hasDispatcher(String) - Method in class akka.typed.internal.DispatchersImpl
-
Checks that the configuration provides a section for the given dispatcher.
- 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;
- hasDurableKeys() - Method in class akka.cluster.ddata.Replicator
-
- hasDwNotificationData() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .DeathWatchNotificationData dwNotificationData = 7;
- hasDwNotificationData() - Method in class akka.remote.SystemMessageFormats.SystemMessage
-
optional .DeathWatchNotificationData dwNotificationData = 7;
- hasDwNotificationData() - Method in interface akka.remote.SystemMessageFormats.SystemMessageOrBuilder
-
optional .DeathWatchNotificationData dwNotificationData = 7;
- hasEffects() - Method in class akka.typed.EffectfulActorContext
-
- hasEnabled() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.Flag.Builder
-
required bool enabled = 1;
- hasEnabled() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.Flag
-
required bool enabled = 1;
- hasEnabled() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.FlagOrBuilder
-
required bool enabled = 1;
- hasEnclosedMessage() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage.Builder
-
required bytes enclosedMessage = 1;
- hasEnclosedMessage() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage
-
required bytes enclosedMessage = 1;
- hasEnclosedMessage() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessageOrBuilder
-
required bytes enclosedMessage = 1;
- 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.Payload.Builder
-
required bytes enclosedMessage = 1;
- hasEnclosedMessage() - Method in class akka.remote.ContainerFormats.Payload
-
required bytes enclosedMessage = 1;
- hasEnclosedMessage() - Method in interface akka.remote.ContainerFormats.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;
- hasEntityCount() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats.Builder
-
required int32 entityCount = 2;
- hasEntityCount() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats
-
required int32 entityCount = 2;
- hasEntityCount() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStatsOrBuilder
-
required int32 entityCount = 2;
- hasEntityId() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStarted.Builder
-
required string entityId = 1;
- hasEntityId() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStarted
-
required string entityId = 1;
- hasEntityId() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStartedOrBuilder
-
required string entityId = 1;
- hasEntityId() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStopped.Builder
-
required string entityId = 1;
- hasEntityId() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStopped
-
required string entityId = 1;
- hasEntityId() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStoppedOrBuilder
-
required string entityId = 1;
- hasEnvelope() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry.Builder
-
required .akka.cluster.ddata.DataEnvelope envelope = 2;
- hasEnvelope() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry
-
required .akka.cluster.ddata.DataEnvelope envelope = 2;
- hasEnvelope() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.EntryOrBuilder
-
required .akka.cluster.ddata.DataEnvelope envelope = 2;
- hasEnvelope() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResult.Builder
-
optional .akka.cluster.ddata.DataEnvelope envelope = 1;
- hasEnvelope() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResult
-
optional .akka.cluster.ddata.DataEnvelope envelope = 1;
- hasEnvelope() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResultOrBuilder
-
optional .akka.cluster.ddata.DataEnvelope envelope = 1;
- hasEnvelope() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write.Builder
-
required .akka.cluster.ddata.DataEnvelope envelope = 2;
- hasEnvelope() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write
-
required .akka.cluster.ddata.DataEnvelope envelope = 2;
- hasEnvelope() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.WriteOrBuilder
-
required .akka.cluster.ddata.DataEnvelope envelope = 2;
- 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;
- hasExistenceConfirmed() - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData.Builder
-
required bool existenceConfirmed = 2;
- hasExistenceConfirmed() - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData
-
required bool existenceConfirmed = 2;
- hasExistenceConfirmed() - Method in interface akka.remote.SystemMessageFormats.DeathWatchNotificationDataOrBuilder
-
required bool existenceConfirmed = 2;
- 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
-
- hasFailedData() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .FailedData failedData = 6;
- hasFailedData() - Method in class akka.remote.SystemMessageFormats.SystemMessage
-
optional .FailedData failedData = 6;
- hasFailedData() - Method in interface akka.remote.SystemMessageFormats.SystemMessageOrBuilder
-
optional .FailedData failedData = 6;
- 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;
- hasFileName() - Method in class akka.remote.ContainerFormats.StackTraceElement.Builder
-
required string fileName = 3;
- hasFileName() - Method in class akka.remote.ContainerFormats.StackTraceElement
-
required string fileName = 3;
- hasFileName() - Method in interface akka.remote.ContainerFormats.StackTraceElementOrBuilder
-
required string fileName = 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;
- hasFrom() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
required .UniqueAddress from = 1;
- hasFrom() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement
-
required .UniqueAddress from = 1;
- hasFrom() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck.Builder
-
required .UniqueAddress from = 1;
- hasFrom() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck
-
required .UniqueAddress from = 1;
- hasFrom() - Method in interface akka.remote.ArteryControlFormats.CompressionTableAdvertisementAckOrBuilder
-
required .UniqueAddress from = 1;
- hasFrom() - Method in interface akka.remote.ArteryControlFormats.CompressionTableAdvertisementOrBuilder
-
required .UniqueAddress from = 1;
- hasFrom() - Method in class akka.remote.ArteryControlFormats.HandshakeReq.Builder
-
required .UniqueAddress from = 1;
- hasFrom() - Method in class akka.remote.ArteryControlFormats.HandshakeReq
-
required .UniqueAddress from = 1;
- hasFrom() - Method in interface akka.remote.ArteryControlFormats.HandshakeReqOrBuilder
-
required .UniqueAddress from = 1;
- hasFrom() - Method in class akka.remote.ArteryControlFormats.Quarantined.Builder
-
required .UniqueAddress from = 1;
- hasFrom() - Method in class akka.remote.ArteryControlFormats.Quarantined
-
required .UniqueAddress from = 1;
- hasFrom() - Method in interface akka.remote.ArteryControlFormats.QuarantinedOrBuilder
-
required .UniqueAddress from = 1;
- hasFrom() - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck.Builder
-
required .UniqueAddress from = 2;
- hasFrom() - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck
-
required .UniqueAddress from = 2;
- hasFrom() - Method in interface akka.remote.ArteryControlFormats.SystemMessageDeliveryAckOrBuilder
-
required .UniqueAddress from = 2;
- 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(String) - Method in class akka.remote.artery.ActorRefResolveCacheWithAddress
-
- hash(K) - Method in class akka.remote.artery.LruBoundedCache
-
- hash(ActorRef) - Method in class akka.remote.artery.SerializationFormatCache
-
- hash(String) - Method in class akka.remote.serialization.ActorRefResolveCache
-
- hash(Object) - Method in class akka.stream.impl.fusing.Fusing.BuildStructuralInfo
-
- 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() - Static method in class akka.actor.DeadLetterActorRef
-
- hashCode() - Method in interface akka.actor.ExtensionId
-
- hashCode() - Static method in class akka.actor.Nobody
-
- hashCode() - Static method in class akka.actor.TypedActor
-
- hashCode() - Static method in class akka.camel.CamelExtension
-
- hashCode() - Method in class akka.camel.CamelMessage
-
Returns a hash code value for the object.
- hashCode() - Method in class akka.cluster.ddata.DurableStore.DurableDataEnvelope
-
- hashCode() - Static method in class akka.cluster.ddata.FlagKey
-
- hashCode() - Method in class akka.cluster.ddata.GCounter
-
- hashCode() - Static method in class akka.cluster.ddata.GCounterKey
-
- hashCode() - Static method in class akka.cluster.ddata.GSetKey
-
- hashCode() - Method in class akka.cluster.ddata.Key
-
- hashCode() - Method in class akka.cluster.ddata.LWWMap
-
- hashCode() - Static method in class akka.cluster.ddata.LWWMapKey
-
- hashCode() - Method in class akka.cluster.ddata.LWWRegister
-
- hashCode() - Static method in class akka.cluster.ddata.LWWRegisterKey
-
- hashCode() - Method in class akka.cluster.ddata.ORMap
-
- hashCode() - Static method in class akka.cluster.ddata.ORMapKey
-
- hashCode() - Method in class akka.cluster.ddata.ORMultiMap
-
- hashCode() - Static method in class akka.cluster.ddata.ORMultiMapKey
-
- hashCode() - Method in class akka.cluster.ddata.ORSet
-
- hashCode() - Static method in class akka.cluster.ddata.ORSetKey
-
- hashCode() - Method in class akka.cluster.ddata.PNCounter
-
- hashCode() - Static method in class akka.cluster.ddata.PNCounterKey
-
- hashCode() - Method in class akka.cluster.ddata.PNCounterMap
-
- hashCode() - Static method in class akka.cluster.ddata.PNCounterMapKey
-
- hashCode() - Method in class akka.cluster.Member
-
- hashCode() - Method in class akka.cluster.Metric
-
Deprecated.
- hashCode() - Static method in class akka.cluster.metrics.ClusterMetricsStrategy
-
- hashCode() - Method in class akka.cluster.metrics.Metric
-
- hashCode() - Method in class akka.cluster.metrics.NodeMetrics
-
- hashCode() - Method in class akka.cluster.NodeMetrics
-
Deprecated.
- hashCode() - Method in class akka.cluster.Reachability
-
- hashCode() - Method in class akka.cluster.UniqueAddress
-
- hashCode() - Static method in class akka.io.Tcp
-
- hashCode() - Static method in class akka.io.Udp
-
- hashCode() - Static method in class akka.io.UdpConnected
-
- hashCode() - Static method in class akka.pattern.PromiseActorRef
-
- hashCode() - Static method in class akka.persistence.journal.PersistencePluginProxyExtension
-
- hashCode() - Method in class akka.remote.artery.ImmutableLongMap
-
- hashCode() - Static method in class akka.remote.RemoteMetricsExtension
-
- hashCode() - Static method in class akka.remote.security.provider.AkkaProvider
-
- hashCode() - Static method in class akka.remote.testconductor.TestConductor
-
- hashCode() - Static method in class akka.remote.transport.TransportAdaptersExtension
-
- hashCode() - Method in class akka.remote.UniqueAddress
-
- hashCode() - Static method in class akka.serialization.SerializationExtension
-
- hashCode() - Static method in class akka.stream.impl.fusing.GraphModule
-
- hashCode() - Static method in class akka.stream.impl.fusing.GraphStageModule
-
- hashCode() - Static method in class akka.stream.impl.io.TlsModule
-
- hashCode() - Static method in class akka.stream.impl.ProcessorModule
-
- hashCode() - Method in interface akka.stream.impl.StreamLayout.MaterializedValueNode
-
- hashCode() - Method in interface akka.stream.impl.StreamLayout.Module
-
- hashCode() - Static method in class akka.stream.Inlet
-
- hashCode() - Method in class akka.stream.InPort
-
- hashCode() - Static method in class akka.stream.Outlet
-
- hashCode() - Method in class akka.stream.OutPort
-
- hashCode() - Static method in class akka.testkit.TestActorRef
-
- hashCode() - Static method in class akka.testkit.TestFSMRef
-
- hashCode() - Static method in class akka.testkit.TestKitExtension
-
- hashCode() - Method in class akka.typed.ActorRef
-
- hashCode() - Static method in class akka.typed.adapter.ActorRefAdapter
-
- hashCode() - Static method in class akka.typed.adapter.ActorSystemAdapter
-
- hashCode() - Static method in class akka.typed.internal.ActorSystemImpl
-
- hashCode() - Static method in class akka.typed.internal.BlackholeActorRef
-
- hashCode() - Static method in class akka.typed.internal.FutureRef
-
- hashCode() - Static method in class akka.typed.internal.WatchableRef
-
- hashCode() - Static method in class akka.util.ByteString
-
- hashCode() - Static method in class akka.util.CompactByteString
-
- 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$
-
- HashCodeMessageExtractor(int) - Constructor for class akka.cluster.sharding.ShardRegion.HashCodeMessageExtractor
-
- HashCodeVal(int) - Constructor for class akka.remote.artery.compress.TopHeavyHitters.HashCodeVal
-
- HashCodeVal$() - Constructor for class akka.remote.artery.compress.TopHeavyHitters.HashCodeVal$
-
- 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.ddata.protobuf.msg.ReplicatorMessages.Address.Builder
-
required string hostname = 1;
- hasHostname() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Address
-
required string hostname = 1;
- hasHostname() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.AddressOrBuilder
-
required string hostname = 1;
- 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.ArteryControlFormats.Address.Builder
-
required string hostname = 3;
- hasHostname() - Method in class akka.remote.ArteryControlFormats.Address
-
required string hostname = 3;
- hasHostname() - Method in interface akka.remote.ArteryControlFormats.AddressOrBuilder
-
required string hostname = 3;
- 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;
- hasIncrements() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter.Builder
-
required .akka.cluster.ddata.GCounter increments = 1;
- hasIncrements() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter
-
required .akka.cluster.ddata.GCounter increments = 1;
- hasIncrements() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterOrBuilder
-
required .akka.cluster.ddata.GCounter increments = 1;
- 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.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry.Builder
-
required string key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry
-
required string key = 1;
- hasKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.EntryOrBuilder
-
required string key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry.Builder
-
required string key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry
-
required string key = 1;
- hasKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.EntryOrBuilder
-
required string key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry.Builder
-
required string key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry
-
required string key = 1;
- hasKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.EntryOrBuilder
-
required string key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry.Builder
-
required string key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry
-
required string key = 1;
- hasKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.EntryOrBuilder
-
required string key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed
-
required .akka.cluster.ddata.OtherMessage key = 1;
- hasKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ChangedOrBuilder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get
-
required .akka.cluster.ddata.OtherMessage key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure
-
required .akka.cluster.ddata.OtherMessage key = 1;
- hasKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailureOrBuilder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- hasKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetOrBuilder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess
-
required .akka.cluster.ddata.OtherMessage key = 1;
- hasKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccessOrBuilder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry.Builder
-
required string key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry
-
required string key = 1;
- hasKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.EntryOrBuilder
-
required string key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound
-
required .akka.cluster.ddata.OtherMessage key = 1;
- hasKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFoundOrBuilder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Read.Builder
-
required string key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Read
-
required string key = 1;
- hasKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadOrBuilder
-
required string key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry.Builder
-
required string key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry
-
required string key = 1;
- hasKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.EntryOrBuilder
-
required string key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe
-
required .akka.cluster.ddata.OtherMessage key = 1;
- hasKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.SubscribeOrBuilder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe
-
required .akka.cluster.ddata.OtherMessage key = 1;
- hasKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UnsubscribeOrBuilder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write.Builder
-
required string key = 1;
- hasKey() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write
-
required string key = 1;
- hasKey() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.WriteOrBuilder
-
required string key = 1;
- 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;
- hasKeys() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- hasKeys() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap
-
required .akka.cluster.ddata.ORSet keys = 1;
- hasKeys() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMapOrBuilder
-
required .akka.cluster.ddata.ORSet keys = 1;
- hasKeys() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- hasKeys() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap
-
required .akka.cluster.ddata.ORSet keys = 1;
- hasKeys() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMapOrBuilder
-
required .akka.cluster.ddata.ORSet keys = 1;
- hasKeys() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- hasKeys() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap
-
required .akka.cluster.ddata.ORSet keys = 1;
- hasKeys() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMapOrBuilder
-
required .akka.cluster.ddata.ORSet keys = 1;
- hasKeys() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- hasKeys() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap
-
required .akka.cluster.ddata.ORSet keys = 1;
- hasKeys() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMapOrBuilder
-
required .akka.cluster.ddata.ORSet keys = 1;
- hasLetter() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved.Builder
-
required string letter = 1;
- hasLetter() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved
-
required string letter = 1;
- hasLetter() - Method in interface docs.persistence.proto.FlightAppModels.SeatReservedOrBuilder
-
required string letter = 1;
- hasLineNumber() - Method in class akka.remote.ContainerFormats.StackTraceElement.Builder
-
required int32 lineNumber = 4;
- hasLineNumber() - Method in class akka.remote.ContainerFormats.StackTraceElement
-
required int32 lineNumber = 4;
- hasLineNumber() - Method in interface akka.remote.ContainerFormats.StackTraceElementOrBuilder
-
required int32 lineNumber = 4;
- 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.
- hasManifest() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional string manifest = 12;
- hasManifest() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
optional string manifest = 12;
- hasManifest() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
-
optional string manifest = 12;
- HASMANIFEST_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.PropsData
-
- 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.ArteryControlFormats.SystemMessageEnvelope.Builder
-
required bytes message = 1;
- hasMessage() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope
-
required bytes message = 1;
- hasMessage() - Method in interface akka.remote.ArteryControlFormats.SystemMessageEnvelopeOrBuilder
-
required bytes message = 1;
- hasMessage() - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
required string message = 2;
- hasMessage() - Method in class akka.remote.ContainerFormats.ActorInitializationException
-
required string message = 2;
- hasMessage() - Method in interface akka.remote.ContainerFormats.ActorInitializationExceptionOrBuilder
-
required string message = 2;
- hasMessage() - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
optional string message = 2;
- hasMessage() - Method in class akka.remote.ContainerFormats.Throwable
-
optional string message = 2;
- hasMessage() - Method in interface akka.remote.ContainerFormats.ThrowableOrBuilder
-
optional string message = 2;
- 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;
- hasMessageId() - Method in class akka.remote.ContainerFormats.Identify.Builder
-
required .Payload messageId = 1;
- hasMessageId() - Method in class akka.remote.ContainerFormats.Identify
-
required .Payload messageId = 1;
- hasMessageId() - Method in interface akka.remote.ContainerFormats.IdentifyOrBuilder
-
required .Payload messageId = 1;
- hasMessageManifest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage.Builder
-
optional bytes messageManifest = 4;
- hasMessageManifest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage
-
optional bytes messageManifest = 4;
- hasMessageManifest() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessageOrBuilder
-
optional bytes messageManifest = 4;
- 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.ArteryControlFormats.SystemMessageEnvelope.Builder
-
optional bytes messageManifest = 3;
- hasMessageManifest() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope
-
optional bytes messageManifest = 3;
- hasMessageManifest() - Method in interface akka.remote.ArteryControlFormats.SystemMessageEnvelopeOrBuilder
-
optional bytes messageManifest = 3;
- hasMessageManifest() - Method in class akka.remote.ContainerFormats.Payload.Builder
-
optional bytes messageManifest = 4;
- hasMessageManifest() - Method in class akka.remote.ContainerFormats.Payload
-
optional bytes messageManifest = 4;
- hasMessageManifest() - Method in interface akka.remote.ContainerFormats.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() - Static method in class akka.actor.ActorCell
-
- 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() - Static method in class akka.routing.RoutedActorCell
-
- 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
-
- hasMethodName() - Method in class akka.remote.ContainerFormats.StackTraceElement.Builder
-
required string methodName = 2;
- hasMethodName() - Method in class akka.remote.ContainerFormats.StackTraceElement
-
required string methodName = 2;
- hasMethodName() - Method in interface akka.remote.ContainerFormats.StackTraceElementOrBuilder
-
required string methodName = 2;
- 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;
- hasNext() - Method in class akka.stream.impl.fusing.IteratorInterpreter.IteratorDownstream
-
- hasNext() - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- hasNext() - Static method in class akka.util.ByteIterator
-
- hasNext() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- hasNode() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry.Builder
-
required .akka.cluster.ddata.UniqueAddress node = 1;
- hasNode() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry
-
required .akka.cluster.ddata.UniqueAddress node = 1;
- hasNode() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.EntryOrBuilder
-
required .akka.cluster.ddata.UniqueAddress node = 1;
- hasNode() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
required .akka.cluster.ddata.UniqueAddress node = 2;
- hasNode() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister
-
required .akka.cluster.ddata.UniqueAddress node = 2;
- hasNode() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegisterOrBuilder
-
required .akka.cluster.ddata.UniqueAddress node = 2;
- hasNode() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry.Builder
-
required .akka.cluster.ddata.UniqueAddress node = 1;
- hasNode() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry
-
required .akka.cluster.ddata.UniqueAddress node = 1;
- hasNode() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.EntryOrBuilder
-
required .akka.cluster.ddata.UniqueAddress node = 1;
- 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;
- hasOriginUid() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
required uint64 originUid = 2;
- hasOriginUid() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement
-
required uint64 originUid = 2;
- hasOriginUid() - Method in interface akka.remote.ArteryControlFormats.CompressionTableAdvertisementOrBuilder
-
required uint64 originUid = 2;
- 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;
- hasOwnerAddress() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
required .akka.cluster.ddata.UniqueAddress ownerAddress = 2;
- hasOwnerAddress() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry
-
required .akka.cluster.ddata.UniqueAddress ownerAddress = 2;
- hasOwnerAddress() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntryOrBuilder
-
required .akka.cluster.ddata.UniqueAddress ownerAddress = 2;
- 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.ContainerFormats.ActorRef.Builder
-
required string path = 1;
- hasPath() - Method in class akka.remote.ContainerFormats.ActorRef
-
required string path = 1;
- hasPath() - Method in interface akka.remote.ContainerFormats.ActorRefOrBuilder
-
required string path = 1;
- 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.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToOneSubscriber.Builder
-
required .Payload payload = 1;
- hasPayload() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToOneSubscriber
-
required .Payload payload = 1;
- hasPayload() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToOneSubscriberOrBuilder
-
required .Payload payload = 1;
- 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;
- hasPerformed() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
required bool performed = 3;
- hasPerformed() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry
-
required bool performed = 3;
- hasPerformed() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntryOrBuilder
-
required bool performed = 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;
- hasPersistenceIdSubscribers() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- hasPersistenceIdSubscribers() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
-
- hasPort() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Address.Builder
-
required uint32 port = 2;
- hasPort() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Address
-
required uint32 port = 2;
- hasPort() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.AddressOrBuilder
-
required uint32 port = 2;
- 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.ArteryControlFormats.Address.Builder
-
required uint32 port = 4;
- hasPort() - Method in class akka.remote.ArteryControlFormats.Address
-
required uint32 port = 4;
- hasPort() - Method in interface akka.remote.ArteryControlFormats.AddressOrBuilder
-
required uint32 port = 4;
- 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.ArteryControlFormats.Address.Builder
-
required string protocol = 1;
- hasProtocol() - Method in class akka.remote.ArteryControlFormats.Address
-
required string protocol = 1;
- hasProtocol() - Method in interface akka.remote.ArteryControlFormats.AddressOrBuilder
-
required string protocol = 1;
- 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.ddata.protobuf.msg.ReplicatorMessages.Subscribe.Builder
-
required string ref = 2;
- hasRef() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe
-
required string ref = 2;
- hasRef() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.SubscribeOrBuilder
-
required string ref = 2;
- hasRef() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe.Builder
-
required string ref = 2;
- hasRef() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe
-
required string ref = 2;
- hasRef() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UnsubscribeOrBuilder
-
required string ref = 2;
- 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;
- hasRef() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ActorRefMessage.Builder
-
required string ref = 1;
- hasRef() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ActorRefMessage
-
required string ref = 1;
- hasRef() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ActorRefMessageOrBuilder
-
required string ref = 1;
- hasRef() - Method in class akka.remote.ContainerFormats.ActorIdentity.Builder
-
optional .ActorRef ref = 2;
- hasRef() - Method in class akka.remote.ContainerFormats.ActorIdentity
-
optional .ActorRef ref = 2;
- hasRef() - Method in interface akka.remote.ContainerFormats.ActorIdentityOrBuilder
-
optional .ActorRef ref = 2;
- hasRegion() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome.Builder
-
required string region = 2;
- hasRegion() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome
-
required string region = 2;
- hasRegion() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated.Builder
-
required string region = 2;
- hasRegion() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated
-
required string region = 2;
- hasRegion() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocatedOrBuilder
-
required string region = 2;
- hasRegion() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeOrBuilder
-
required string region = 2;
- hasRegionRef() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry.Builder
-
required string regionRef = 2;
- hasRegionRef() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry
-
required string regionRef = 2;
- hasRegionRef() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntryOrBuilder
-
required string regionRef = 2;
- hasRemaining() - Method in class akka.stream.impl.io.ByteStringParser.ByteReader
-
- hasRemovals() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2.Builder
-
optional bytes removals = 2;
- hasRemovals() - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2
-
optional bytes removals = 2;
- hasRemovals() - Method in interface docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2OrBuilder
-
optional bytes removals = 2;
- hasRemovedAddress() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
required .akka.cluster.ddata.UniqueAddress removedAddress = 1;
- hasRemovedAddress() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry
-
required .akka.cluster.ddata.UniqueAddress removedAddress = 1;
- hasRemovedAddress() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntryOrBuilder
-
required .akka.cluster.ddata.UniqueAddress removedAddress = 1;
- 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;
- hasReplyToStatus() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
optional bool replyToStatus = 2;
- hasReplyToStatus() - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status
-
optional bool replyToStatus = 2;
- hasReplyToStatus() - Method in interface akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.StatusOrBuilder
-
optional bool replyToStatus = 2;
- hasRequest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- hasRequest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- hasRequest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- hasRequest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- hasRequest() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailureOrBuilder
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- hasRequest() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetOrBuilder
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- hasRequest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- hasRequest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- hasRequest() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccessOrBuilder
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- hasRequest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- hasRequest() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- hasRequest() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFoundOrBuilder
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- 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;
- hasRow() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved.Builder
-
required uint32 row = 2;
- hasRow() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved
-
required uint32 row = 2;
- hasRow() - Method in interface docs.persistence.proto.FlightAppModels.SeatReservedOrBuilder
-
required uint32 row = 2;
- hasSamePortsAndShapeAs(Shape) - Static method in class akka.stream.AmorphousShape
-
- hasSamePortsAndShapeAs(Shape) - Static method in class akka.stream.BidiShape
-
- hasSamePortsAndShapeAs(Shape) - Static method in class akka.stream.ClosedShape
-
- hasSamePortsAndShapeAs(Shape) - Static method in class akka.stream.FanInShape
-
- hasSamePortsAndShapeAs(Shape) - Static method in class akka.stream.FanOutShape
-
- hasSamePortsAndShapeAs(Shape) - Static method in class akka.stream.FlowShape
-
- hasSamePortsAndShapeAs(Shape) - Method in class akka.stream.Shape
-
Compare this to another shape and determine whether the arrangement of ports is the same (including their ordering).
- hasSamePortsAndShapeAs(Shape) - Static method in class akka.stream.SinkShape
-
- hasSamePortsAndShapeAs(Shape) - Static method in class akka.stream.SourceShape
-
- hasSamePortsAndShapeAs(Shape) - Static method in class akka.stream.UniformFanInShape
-
- hasSamePortsAndShapeAs(Shape) - Static method in class akka.stream.UniformFanOutShape
-
- hasSamePortsAs(Shape) - Static method in class akka.stream.AmorphousShape
-
- hasSamePortsAs(Shape) - Static method in class akka.stream.BidiShape
-
- hasSamePortsAs(Shape) - Static method in class akka.stream.ClosedShape
-
- hasSamePortsAs(Shape) - Static method in class akka.stream.FanInShape
-
- hasSamePortsAs(Shape) - Static method in class akka.stream.FanOutShape
-
- hasSamePortsAs(Shape) - Static method in class akka.stream.FlowShape
-
- hasSamePortsAs(Shape) - Method in class akka.stream.Shape
-
Compare this to another shape and determine whether the set of ports is the same (ignoring their ordering).
- hasSamePortsAs(Shape) - Static method in class akka.stream.SinkShape
-
- hasSamePortsAs(Shape) - Static method in class akka.stream.SourceShape
-
- hasSamePortsAs(Shape) - Static method in class akka.stream.UniformFanInShape
-
- hasSamePortsAs(Shape) - Static method in class akka.stream.UniformFanOutShape
-
- 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;
- hasSeatType() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved.Builder
-
optional string seatType = 3;
- hasSeatType() - Method in class docs.persistence.proto.FlightAppModels.SeatReserved
-
optional string seatType = 3;
- hasSeatType() - Method in interface docs.persistence.proto.FlightAppModels.SeatReservedOrBuilder
-
optional string seatType = 3;
- hasSendBack() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
required bool sendBack = 1;
- hasSendBack() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip
-
required bool sendBack = 1;
- hasSendBack() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GossipOrBuilder
-
required bool sendBack = 1;
- 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;
- hasSeqNo() - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck.Builder
-
required uint64 seqNo = 1;
- hasSeqNo() - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck
-
required uint64 seqNo = 1;
- hasSeqNo() - Method in interface akka.remote.ArteryControlFormats.SystemMessageDeliveryAckOrBuilder
-
required uint64 seqNo = 1;
- hasSeqNo() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope.Builder
-
required uint64 seqNo = 4;
- hasSeqNo() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope
-
required uint64 seqNo = 4;
- hasSeqNo() - Method in interface akka.remote.ArteryControlFormats.SystemMessageEnvelopeOrBuilder
-
required uint64 seqNo = 4;
- 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.ddata.protobuf.msg.ReplicatorMessages.OtherMessage.Builder
-
required int32 serializerId = 2;
- hasSerializerId() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage
-
required int32 serializerId = 2;
- hasSerializerId() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessageOrBuilder
-
required int32 serializerId = 2;
- 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.ArteryControlFormats.SystemMessageEnvelope.Builder
-
required int32 serializerId = 2;
- hasSerializerId() - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope
-
required int32 serializerId = 2;
- hasSerializerId() - Method in interface akka.remote.ArteryControlFormats.SystemMessageEnvelopeOrBuilder
-
required int32 serializerId = 2;
- hasSerializerId() - Method in class akka.remote.ContainerFormats.Payload.Builder
-
required int32 serializerId = 2;
- hasSerializerId() - Method in class akka.remote.ContainerFormats.Payload
-
required int32 serializerId = 2;
- hasSerializerId() - Method in interface akka.remote.ContainerFormats.PayloadOrBuilder
-
required int32 serializerId = 2;
- 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;
- hasShard() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome.Builder
-
required string shard = 1;
- hasShard() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome
-
required string shard = 1;
- hasShard() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated.Builder
-
required string shard = 1;
- hasShard() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated
-
required string shard = 1;
- hasShard() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocatedOrBuilder
-
required string shard = 1;
- hasShard() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeOrBuilder
-
required string shard = 1;
- hasShard() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessage.Builder
-
required string shard = 1;
- hasShard() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessage
-
required string shard = 1;
- hasShard() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessageOrBuilder
-
required string shard = 1;
- hasShard() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats.Builder
-
required string shard = 1;
- hasShard() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats
-
required string shard = 1;
- hasShard() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStatsOrBuilder
-
required string shard = 1;
- hasShardId() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry.Builder
-
required string shardId = 1;
- hasShardId() - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry
-
required string shardId = 1;
- hasShardId() - Method in interface akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntryOrBuilder
-
required string shardId = 1;
- hasSnapshots() - Method in class akka.cluster.sharding.RemoveInternalClusterShardingData.RemoveOnePersistenceId
-
- hasState() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
required .akka.cluster.ddata.OtherMessage state = 3;
- hasState() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister
-
required .akka.cluster.ddata.OtherMessage state = 3;
- hasState() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegisterOrBuilder
-
required .akka.cluster.ddata.OtherMessage state = 3;
- hasStateIdentifier() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot.Builder
-
required string stateIdentifier = 1;
- hasStateIdentifier() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot
-
required string stateIdentifier = 1;
- hasStateIdentifier() - Method in interface akka.persistence.serialization.MessageFormats.PersistentFSMSnapshotOrBuilder
-
required string stateIdentifier = 1;
- hasStateIdentifier() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
-
required string stateIdentifier = 1;
- hasStateIdentifier() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
-
required string stateIdentifier = 1;
- hasStateIdentifier() - Method in interface akka.persistence.serialization.MessageFormats.PersistentStateChangeEventOrBuilder
-
required string stateIdentifier = 1;
- 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;
- hasSubscriber(ActorRef) - Method in class akka.cluster.ddata.Replicator
-
- hasSubscriptions(SubchannelClassification) - Static method in class akka.event.EventStream
-
- hasSubscriptions(SubchannelClassification) - Method in interface akka.event.SubchannelClassification
-
INTERNAL API
Expensive call! Avoid calling directly from event bus subscribe / unsubscribe.
- hasSuperviseData() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .SuperviseData superviseData = 5;
- hasSuperviseData() - Method in class akka.remote.SystemMessageFormats.SystemMessage
-
optional .SuperviseData superviseData = 5;
- hasSuperviseData() - Method in interface akka.remote.SystemMessageFormats.SystemMessageOrBuilder
-
optional .SuperviseData superviseData = 5;
- 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.ArteryControlFormats.Address.Builder
-
required string system = 2;
- hasSystem() - Method in class akka.remote.ArteryControlFormats.Address
-
required string system = 2;
- hasSystem() - Method in interface akka.remote.ArteryControlFormats.AddressOrBuilder
-
required string system = 2;
- 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() - Static method in class akka.dispatch.Mailbox
-
- hasSystemMessages() - Method in interface akka.dispatch.SystemMessageQueue
-
- hasTableVersion() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
required uint32 tableVersion = 3;
- hasTableVersion() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement
-
required uint32 tableVersion = 3;
- hasTableVersion() - Method in interface akka.remote.ArteryControlFormats.CompressionTableAdvertisementOrBuilder
-
required uint32 tableVersion = 3;
- hasTagSubscribers() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- hasTagSubscribers() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
-
- hasTimeout() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
required uint32 timeout = 3;
- hasTimeout() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get
-
required uint32 timeout = 3;
- hasTimeout() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetOrBuilder
-
required uint32 timeout = 3;
- hasTimeout() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
-
optional string timeout = 2;
- hasTimeout() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
-
optional string timeout = 2;
- hasTimeout() - Method in interface akka.persistence.serialization.MessageFormats.PersistentStateChangeEventOrBuilder
-
optional string timeout = 2;
- 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;
- hasTimeoutNanos() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot.Builder
-
optional int64 timeoutNanos = 3;
- hasTimeoutNanos() - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot
-
optional int64 timeoutNanos = 3;
- hasTimeoutNanos() - Method in interface akka.persistence.serialization.MessageFormats.PersistentFSMSnapshotOrBuilder
-
optional int64 timeoutNanos = 3;
- hasTimeoutNanos() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
-
optional int64 timeoutNanos = 3;
- hasTimeoutNanos() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
-
optional int64 timeoutNanos = 3;
- hasTimeoutNanos() - Method in interface akka.persistence.serialization.MessageFormats.PersistentStateChangeEventOrBuilder
-
optional int64 timeoutNanos = 3;
- hasTimestamp() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
required sint64 timestamp = 1;
- hasTimestamp() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister
-
required sint64 timestamp = 1;
- hasTimestamp() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegisterOrBuilder
-
required sint64 timestamp = 1;
- 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;
- hasTo() - Method in class akka.remote.ArteryControlFormats.HandshakeReq.Builder
-
required .Address to = 2;
- hasTo() - Method in class akka.remote.ArteryControlFormats.HandshakeReq
-
required .Address to = 2;
- hasTo() - Method in interface akka.remote.ArteryControlFormats.HandshakeReqOrBuilder
-
required .Address to = 2;
- hasTo() - Method in class akka.remote.ArteryControlFormats.Quarantined.Builder
-
required .UniqueAddress to = 2;
- hasTo() - Method in class akka.remote.ArteryControlFormats.Quarantined
-
required .UniqueAddress to = 2;
- hasTo() - Method in interface akka.remote.ArteryControlFormats.QuarantinedOrBuilder
-
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;
- hasTotChunks() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
required uint32 totChunks = 2;
- hasTotChunks() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status
-
required uint32 totChunks = 2;
- hasTotChunks() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StatusOrBuilder
-
required uint32 totChunks = 2;
- 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;
- hasType() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
required .SystemMessage.Type type = 1;
- hasType() - Method in class akka.remote.SystemMessageFormats.SystemMessage
-
required .SystemMessage.Type type = 1;
- hasType() - Method in interface akka.remote.SystemMessageFormats.SystemMessageOrBuilder
-
required .SystemMessage.Type type = 1;
- hasUid() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress.Builder
-
required sfixed32 uid = 2;
- hasUid() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress
-
required sfixed32 uid = 2;
- hasUid() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddressOrBuilder
-
required sfixed32 uid = 2;
- 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.ArteryControlFormats.ArteryHeartbeatRsp.Builder
-
required uint64 uid = 1;
- hasUid() - Method in class akka.remote.ArteryControlFormats.ArteryHeartbeatRsp
-
required uint64 uid = 1;
- hasUid() - Method in interface akka.remote.ArteryControlFormats.ArteryHeartbeatRspOrBuilder
-
required uint64 uid = 1;
- hasUid() - Method in class akka.remote.ArteryControlFormats.UniqueAddress.Builder
-
required uint64 uid = 2;
- hasUid() - Method in class akka.remote.ArteryControlFormats.UniqueAddress
-
required uint64 uid = 2;
- hasUid() - Method in interface akka.remote.ArteryControlFormats.UniqueAddressOrBuilder
-
required uint64 uid = 2;
- hasUid() - Method in class akka.remote.ContainerFormats.WatcherHeartbeatResponse.Builder
-
required uint64 uid = 1;
- hasUid() - Method in class akka.remote.ContainerFormats.WatcherHeartbeatResponse
-
required uint64 uid = 1;
- hasUid() - Method in interface akka.remote.ContainerFormats.WatcherHeartbeatResponseOrBuilder
-
required uint64 uid = 1;
- hasUid() - Method in class akka.remote.SystemMessageFormats.FailedData.Builder
-
required uint64 uid = 2;
- hasUid() - Method in class akka.remote.SystemMessageFormats.FailedData
-
required uint64 uid = 2;
- hasUid() - Method in interface akka.remote.SystemMessageFormats.FailedDataOrBuilder
-
required uint64 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;
- hasUid2() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress.Builder
-
optional sfixed32 uid2 = 3;
- hasUid2() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress
-
optional sfixed32 uid2 = 3;
- hasUid2() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddressOrBuilder
-
optional sfixed32 uid2 = 3;
- hasUid2() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
-
optional uint32 uid2 = 3;
- hasUid2() - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress
-
optional uint32 uid2 = 3;
- hasUid2() - Method in interface akka.cluster.protobuf.msg.ClusterMessages.UniqueAddressOrBuilder
-
optional uint32 uid2 = 3;
- 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.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry.Builder
-
required bytes value = 2;
- hasValue() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry
-
required bytes value = 2;
- hasValue() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.EntryOrBuilder
-
required bytes value = 2;
- hasValue() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry.Builder
-
required .akka.cluster.ddata.LWWRegister value = 2;
- hasValue() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry
-
required .akka.cluster.ddata.LWWRegister value = 2;
- hasValue() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.EntryOrBuilder
-
required .akka.cluster.ddata.LWWRegister value = 2;
- hasValue() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry.Builder
-
required .akka.cluster.ddata.OtherMessage value = 2;
- hasValue() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry
-
required .akka.cluster.ddata.OtherMessage value = 2;
- hasValue() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.EntryOrBuilder
-
required .akka.cluster.ddata.OtherMessage value = 2;
- hasValue() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry.Builder
-
required .akka.cluster.ddata.ORSet value = 2;
- hasValue() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry
-
required .akka.cluster.ddata.ORSet value = 2;
- hasValue() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.EntryOrBuilder
-
required .akka.cluster.ddata.ORSet value = 2;
- hasValue() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry.Builder
-
required .akka.cluster.ddata.PNCounter value = 2;
- hasValue() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry
-
required .akka.cluster.ddata.PNCounter value = 2;
- hasValue() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.EntryOrBuilder
-
required .akka.cluster.ddata.PNCounter value = 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;
- hasValue() - Method in class akka.remote.ContainerFormats.Option.Builder
-
optional .Payload value = 1;
- hasValue() - Method in class akka.remote.ContainerFormats.Option
-
optional .Payload value = 1;
- hasValue() - Method in interface akka.remote.ContainerFormats.OptionOrBuilder
-
optional .Payload 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.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry.Builder
-
required int64 version = 2;
- hasVersion() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry
-
required int64 version = 2;
- hasVersion() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.EntryOrBuilder
-
required int64 version = 2;
- 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;
- hasVersion() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck.Builder
-
required uint32 version = 2;
- hasVersion() - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck
-
required uint32 version = 2;
- hasVersion() - Method in interface akka.remote.ArteryControlFormats.CompressionTableAdvertisementAckOrBuilder
-
required uint32 version = 2;
- hasVvector() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
required .akka.cluster.ddata.VersionVector vvector = 1;
- hasVvector() - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
required .akka.cluster.ddata.VersionVector vvector = 1;
- hasVvector() - Method in interface akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSetOrBuilder
-
required .akka.cluster.ddata.VersionVector vvector = 1;
- hasWatchData() - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .WatchData watchData = 2;
- hasWatchData() - Method in class akka.remote.SystemMessageFormats.SystemMessage
-
optional .WatchData watchData = 2;
- hasWatchData() - Method in interface akka.remote.SystemMessageFormats.SystemMessageOrBuilder
-
optional .WatchData watchData = 2;
- hasWatchee() - Method in class akka.remote.SystemMessageFormats.WatchData.Builder
-
required .ActorRef watchee = 1;
- hasWatchee() - Method in class akka.remote.SystemMessageFormats.WatchData
-
required .ActorRef watchee = 1;
- hasWatchee() - Method in interface akka.remote.SystemMessageFormats.WatchDataOrBuilder
-
required .ActorRef watchee = 1;
- hasWatcher() - Method in class akka.remote.SystemMessageFormats.WatchData.Builder
-
required .ActorRef watcher = 2;
- hasWatcher() - Method in class akka.remote.SystemMessageFormats.WatchData
-
required .ActorRef watcher = 2;
- hasWatcher() - Method in interface akka.remote.SystemMessageFormats.WatchDataOrBuilder
-
required .ActorRef watcher = 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
-
- hasWriterUuid() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional string writerUuid = 13;
- hasWriterUuid() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
optional string writerUuid = 13;
- hasWriterUuid() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
-
optional string writerUuid = 13;
- have() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- have() - Static method in class akka.persistence.journal.JournalSpec
-
- have() - Method in class akka.persistence.PluginSpec
-
- have() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- haveShutDown() - Method in class akka.stream.impl.ActorMaterializerImpl
-
- 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.remote.artery.FlightRecorderReader.Log
-
- head() - Method in class akka.stream.javadsl.Sink$
-
A Sink
that materializes into a CompletionStage
of the first value received.
- head() - Static method in class akka.stream.javadsl.Sink
-
A Sink
that materializes into a CompletionStage
of the first value received.
- head() - Method in class akka.stream.scaladsl.Sink$
-
A Sink
that materializes into a Future
of the first value received.
- head() - Static method in class akka.stream.scaladsl.Sink
-
A Sink
that materializes into a Future
of the first value received.
- head() - Method in class akka.typed.internal.EarliestFirstSystemMessageList
-
- head() - Method in class akka.typed.internal.LatestFirstSystemMessageList
-
- head() - Method in class akka.util.ByteIterator.ByteArrayIterator
-
- head() - Method in class akka.util.ByteIterator
-
- head() - Method in class akka.util.ByteIterator.MultiByteArrayIterator
-
- head() - Method in class akka.util.ByteString
-
- head() - Static method in class akka.util.CompactByteString
-
- head() - Method in class akka.util.MessageBuffer
-
Return the first element of the message buffer.
- Header() - Method in class akka.stream.impl.io.compression.GzipDecompressor$
-
- Header() - Static method in class akka.stream.impl.io.compression.GzipDecompressor
-
- headerAs(String, ClassTag<T>, CamelContext) - Method in class akka.camel.CamelMessage
-
Returns the header by given name
parameter in a Try
.
- HeaderBuilder - Interface in akka.remote.artery
-
INTERNAL API
- HeaderBuilder$ - Class in akka.remote.artery
-
INTERNAL API
- HeaderBuilder$() - Constructor for class akka.remote.artery.HeaderBuilder$
-
- HeaderBuilderImpl - Class in akka.remote.artery
-
INTERNAL API
- HeaderBuilderImpl(InboundCompressions, CompressionTable<ActorRef>, CompressionTable<String>) - Constructor for class akka.remote.artery.HeaderBuilderImpl
-
- 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.
- headOption() - Method in class akka.stream.javadsl.Sink$
-
A Sink
that materializes into a CompletionStage
of the optional first value received.
- headOption() - Static method in class akka.stream.javadsl.Sink
-
A Sink
that materializes into a CompletionStage
of the optional first value received.
- headOption() - Method in class akka.stream.scaladsl.Sink$
-
A Sink
that materializes into a Future
of the optional first value received.
- headOption() - Static method in class akka.stream.scaladsl.Sink
-
A Sink
that materializes into a Future
of the optional first value received.
- headOption() - Static method in class akka.util.ByteIterator
-
- headOption() - Static method in class akka.util.ByteString
-
- headOption() - Static method in class akka.util.CompactByteString
-
- headOptionSink() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- HeadOptionStage<T> - Class in akka.stream.impl
-
- HeadOptionStage() - Constructor for class akka.stream.impl.HeadOptionStage
-
- HeadPointerOffset() - Method in class akka.remote.artery.RollingEventLogSection$
-
- HeadPointerOffset() - Static method in class akka.remote.artery.RollingEventLogSection
-
- headSink() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- heapCommitted(MemoryUsage) - Method in class akka.cluster.JmxMetricsCollector
-
Deprecated.
(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
-
Deprecated.
(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
-
Deprecated.
- HeapMemory$() - Constructor for class akka.cluster.metrics.StandardMetrics.HeapMemory$
-
- HeapMemory$() - Constructor for class akka.cluster.StandardMetrics.HeapMemory$
-
Deprecated.
- HeapMemoryCommitted() - Method in class akka.cluster.metrics.StandardMetrics$
-
- HeapMemoryCommitted() - Static method in class akka.cluster.metrics.StandardMetrics
-
- HeapMemoryCommitted() - Method in class akka.cluster.StandardMetrics$
-
Deprecated.
- HeapMemoryCommitted() - Static method in class akka.cluster.StandardMetrics
-
Deprecated.
- HeapMemoryMax() - Method in class akka.cluster.metrics.StandardMetrics$
-
- HeapMemoryMax() - Static method in class akka.cluster.metrics.StandardMetrics
-
- HeapMemoryMax() - Method in class akka.cluster.StandardMetrics$
-
Deprecated.
- HeapMemoryMax() - Static method in class akka.cluster.StandardMetrics
-
Deprecated.
- heapMemoryUsage() - Method in class akka.cluster.JmxMetricsCollector
-
Deprecated.
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$
-
Deprecated.
- HeapMemoryUsed() - Static method in class akka.cluster.StandardMetrics
-
Deprecated.
- 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
-
- HeapMetricsSelector() - Constructor for class akka.cluster.routing.HeapMetricsSelector
-
Deprecated.
- 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
-
- HeapMetricsSelector$() - Constructor for class akka.cluster.routing.HeapMetricsSelector$
-
Deprecated.
- heapUsed(MemoryUsage) - Method in class akka.cluster.JmxMetricsCollector
-
Deprecated.
(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() - Constructor for class akka.cluster.client.ClusterReceptionist.Internal$.Heartbeat
-
- 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.client.ClusterClientSettings
-
- heartbeatInterval() - Method in class akka.cluster.client.ClusterReceptionistSettings
-
- HeartbeatInterval() - Method in class akka.cluster.ClusterSettings
-
- heartbeatInterval() - Method in class akka.remote.DeadlineFailureDetector
-
- HeartbeatMessage - Interface in akka.remote
-
Failure detector heartbeat messages are marked with this trait.
- heartBeatMsg() - Static method in class akka.cluster.ClusterRemoteWatcher
-
- heartBeatMsg() - Method in class akka.remote.RemoteWatcher
-
- 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() - Constructor for class akka.cluster.client.ClusterReceptionist.Internal$.HeartbeatRsp
-
- 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.client.ClusterClient
-
- heartbeatTask() - Method in class akka.cluster.ClusterHeartbeatSender
-
- heartbeatTask() - Static method in class akka.cluster.ClusterRemoteWatcher
-
- heartbeatTask() - Method in class akka.remote.RemoteWatcher
-
- HeartbeatTick() - Constructor for class akka.cluster.client.ClusterClient.Internal$.HeartbeatTick
-
- 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$
-
- HeavyHitterDetected(Object, int, long) - Constructor for class akka.remote.artery.compress.CompressionProtocol.Events$.HeavyHitterDetected
-
- heavyHitters() - Method in class akka.remote.artery.compress.InboundCompression
-
- 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$
-
Deprecated.
- hex() - Static method in class akka.util.Crypt
-
Deprecated.
- hexify(byte[]) - Method in class akka.util.Crypt$
-
Deprecated.
- hexify(byte[]) - Static method in class akka.util.Crypt
-
Deprecated.
- hiddenMagicA() - Method in class akka.routing.MurmurHash$
-
- hiddenMagicA() - Static method in class akka.routing.MurmurHash
-
- hiddenMagicB() - Method in class akka.routing.MurmurHash$
-
- hiddenMagicB() - Static method in class akka.routing.MurmurHash
-
- hiFreq(long, long) - Method in interface akka.remote.artery.EventSink
-
- hiFreq(long, long) - Method in class akka.remote.artery.IgnoreEventSink$
-
- hiFreq(long, long) - Static method in class akka.remote.artery.IgnoreEventSink
-
- hiFreq(long, long) - Method in class akka.remote.artery.SynchronizedEventSink
-
- HiFreqBatchSize() - Method in class akka.remote.artery.FlightRecorder$
-
- HiFreqBatchSize() - Static method in class akka.remote.artery.FlightRecorder
-
- HiFreqEntryCountFieldOffset() - Method in class akka.remote.artery.FlightRecorder$
-
- HiFreqEntryCountFieldOffset() - Static method in class akka.remote.artery.FlightRecorder
-
- hiFreqLog() - Method in class akka.remote.artery.FlightRecorderReader.Structure
-
- HiFreqLogSize() - Method in class akka.remote.artery.FlightRecorder$
-
- HiFreqLogSize() - Static method in class akka.remote.artery.FlightRecorder
-
- HiFreqRecordSize() - Method in class akka.remote.artery.FlightRecorder$
-
- HiFreqRecordSize() - Static method in class akka.remote.artery.FlightRecorder
-
- HiFreqSectionOffset() - Method in class akka.remote.artery.FlightRecorder$
-
- HiFreqSectionOffset() - Static method in class akka.remote.artery.FlightRecorder
-
- HiFreqSectionParameters() - Method in class akka.remote.artery.FlightRecorderReader$
-
- HiFreqSectionParameters() - Static method in class akka.remote.artery.FlightRecorderReader
-
- HiFreqSectionSize() - Method in class akka.remote.artery.FlightRecorder$
-
- HiFreqSectionSize() - Static method in class akka.remote.artery.FlightRecorder
-
- HiFreqWindow() - Method in class akka.remote.artery.FlightRecorder$
-
- HiFreqWindow() - Static method in class akka.remote.artery.FlightRecorder
-
- 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() - Method in class akka.persistence.AtomicWrite
-
- highestSequenceNr() - Method in class akka.persistence.journal.AsyncWriteTarget.ReplaySuccess
-
- highestSequenceNr(String) - Method in interface akka.persistence.journal.inmem.InmemMessages
-
- highestSequenceNr() - Method in class akka.persistence.JournalProtocol.RecoverySuccess
-
- highestUtilization() - Method in class akka.routing.OptimalSizeExploringResizer.UnderUtilizationStreak
-
- highSpeedPart() - Method in interface akka.remote.artery.EventClock
-
- highSpeedPart() - Method in class akka.remote.artery.EventClockImpl
-
- highWatermark() - Method in class akka.stream.actor.WatermarkRequestStrategy
-
- hitActorRef(long, Address, ActorRef, int) - Method in interface akka.remote.artery.compress.InboundCompressions
-
- hitActorRef(long, Address, ActorRef, int) - Method in class akka.remote.artery.compress.InboundCompressionsImpl
-
- hitActorRef(long, Address, ActorRef, int) - Method in class akka.remote.artery.compress.NoInboundCompressions$
-
- hitActorRef(long, Address, ActorRef, int) - Static method in class akka.remote.artery.compress.NoInboundCompressions
-
- hitClassManifest(long, Address, String, int) - Method in interface akka.remote.artery.compress.InboundCompressions
-
- hitClassManifest(long, Address, String, int) - Method in class akka.remote.artery.compress.InboundCompressionsImpl
-
- hitClassManifest(long, Address, String, int) - Method in class akka.remote.artery.compress.NoInboundCompressions$
-
- hitClassManifest(long, Address, String, int) - Static method in class akka.remote.artery.compress.NoInboundCompressions
-
- holdDownstream() - Method in interface akka.stream.stage.DetachedContext
-
- holdDownstreamAndPull() - Method in interface akka.stream.stage.DetachedContext
-
- Holder(Try<T>, AsyncCallback<MapAsync.Holder<T>>) - Constructor for class akka.stream.impl.fusing.MapAsync.Holder
-
- holdUpstream() - Method in interface akka.stream.stage.DetachedContext
-
- holdUpstreamAndPush(Out) - Method in interface akka.stream.stage.DetachedContext
-
- 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.artery.ArterySettings.Bind$
-
- Hostname() - Method in class akka.remote.artery.ArterySettings.Canonical$
-
- Hostname() - Method in class akka.remote.transport.netty.NettyTransportSettings
-
- HOSTNAME_FIELD_NUMBER - Static variable in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Address
-
- 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.ArteryControlFormats.Address
-
- HOSTNAME_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AddressData
-
- hostnameVerifier() - Method in class com.typesafe.sslconfig.akka.AkkaSSLConfig
-
- hostPort() - Method in class akka.actor.Address
-
Returns a String representation formatted as:
- HostShard(String) - Constructor for class akka.cluster.sharding.ShardCoordinator.Internal$.HostShard
-
- MagicString() - Method in class akka.remote.artery.FlightRecorder$
-
- MagicString() - Static method in class akka.remote.artery.FlightRecorder
-
- mailbox() - Method in class akka.actor.AbstractActorWithStash
-
- mailbox() - Method in class akka.actor.AbstractActorWithUnboundedStash
-
- mailbox() - Method in class akka.actor.AbstractActorWithUnrestrictedStash
-
- mailbox() - Method in class akka.actor.AbstractFSMWithStash
-
- mailbox() - Static method in class akka.actor.ActorCell
-
- 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
-
- mailbox() - Method in class akka.actor.UntypedActorWithStash
-
- mailbox() - Method in class akka.actor.UntypedActorWithUnboundedStash
-
- mailbox() - Method in class akka.actor.UntypedActorWithUnrestrictedStash
-
- mailbox() - Method in class akka.cluster.sharding.DDataShardCoordinator
-
- mailbox() - Method in class akka.cluster.sharding.PersistentShard
-
- mailbox() - Method in class akka.cluster.sharding.PersistentShardCoordinator
-
- mailbox() - Method in class akka.cluster.sharding.RemoveInternalClusterShardingData.RemoveOnePersistenceId
-
- 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() - Method in class akka.event.ActorClassificationUnsubscriber
-
- mailbox() - Method in class akka.persistence.AbstractPersistentActor
-
- mailbox() - Method in class akka.persistence.AbstractPersistentView
-
Deprecated.
- mailbox() - Method in class akka.persistence.fsm.AbstractPersistentFSM
-
- mailbox() - Method in class akka.persistence.fsm.AbstractPersistentLoggingFSM
-
- mailbox() - Method in class akka.persistence.journal.JournalPerfSpec.BenchActor
-
- mailbox() - Method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- mailbox() - Method in class akka.persistence.journal.PersistencePluginProxy
-
- mailbox() - Method in class akka.persistence.UntypedPersistentActor
-
- mailbox() - Method in class akka.persistence.UntypedPersistentView
-
Deprecated.
- mailbox() - Static method in class akka.routing.RoutedActorCell
-
- mailbox() - Method in class akka.stream.actor.AbstractActorPublisherWithStash
-
- mailbox() - Method in class akka.stream.actor.AbstractActorPublisherWithUnboundedStash
-
- mailbox() - Method in class akka.stream.actor.AbstractActorPublisherWithUnrestrictedStash
-
- Mailbox$ - Class in akka.dispatch
-
INTERNAL API
- Mailbox$() - Constructor for class akka.dispatch.Mailbox$
-
- mailboxCapacity() - Method in interface akka.typed.ActorContext
-
Return the mailbox capacity that was configured by the parent for this actor.
- mailboxCapacity() - Method in class akka.typed.adapter.ActorContextAdapter
-
- mailboxCapacity() - Method in class akka.typed.internal.ActorCell
-
- MailboxCapacity - Class in akka.typed
-
Configure the maximum mailbox capacity for the actor.
- MailboxCapacity(int, DeploymentConfig) - Constructor for class akka.typed.MailboxCapacity
-
- mailboxCapacity() - Method in class akka.typed.StubbedActorContext
-
- MailboxCapacity$ - Class in akka.typed
-
- MailboxCapacity$() - Constructor for class akka.typed.MailboxCapacity$
-
- 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() - Static method in class akka.testkit.CallingThreadDispatcher
-
- 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(String[]) - Method in class akka.cluster.sharding.RemoveInternalClusterShardingData$
-
- main(String[]) - Static method in class akka.cluster.sharding.RemoveInternalClusterShardingData
-
- Main - Class in akka.kernel
-
- Main() - Constructor for class akka.kernel.Main
-
Deprecated.
- main(String[]) - Method in class akka.kernel.Main$
-
Deprecated.
- main(String[]) - Static method in class akka.kernel.Main
-
Deprecated.
- 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(String[]) - Static method in class akka.remote.artery.FlightRecorderDump
-
- Main$ - Class in akka.kernel
-
- Main$() - Constructor for class akka.kernel.Main$
-
Deprecated.
- 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.
- maintainAddressTerminatedSubscription(ActorRefImpl<Nothing$>, Function0<U>) - Method in interface akka.typed.internal.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
- makeLogger(Class<?>) - Static method in class akka.stream.ActorMaterializer
-
- makeLogger(Class<?>) - Method in class akka.stream.impl.ActorMaterializerImpl
-
- makeLogger(Class<?>) - Method in interface akka.stream.MaterializerLoggingProvider
-
- makePattern(String) - Method in class akka.util.Helpers$
-
- makePattern(String) - Static method in class akka.util.Helpers
-
- makeTransition(FSM.State<S, D>) - Static method in class akka.actor.AbstractFSM
-
- makeTransition(FSM.State<S, D>) - Method in interface akka.actor.FSM
-
- makeTransition(FSM.State<S, D>) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- makeTransition(FSM.State<S, D>) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- makeTransition(FSM.State<S, D>) - Static method in class akka.contrib.pattern.ReliableProxy
-
- makeTransition(FSM.State<S, D>) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- makeTransition(PersistentFSM.State<S, D, E>) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- makeTransition(PersistentFSM.State<S, D, E>) - Method in interface akka.persistence.fsm.PersistentFSMBase
-
- makeTransition(FSM.State<S, D>) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- makeTransition(FSM.State<S, D>) - Static method in class akka.remote.testconductor.ClientFSM
-
- makeTransition(FSM.State<S, D>) - Static method in class akka.remote.testconductor.ServerFSM
-
- makeTransition(FSM.State<S, D>) - Static method in class akka.remote.transport.ProtocolStateActor
-
- makeTransition(FSM.State<S, D>) - Static method in class akka.remote.transport.ThrottledAssociation
-
- 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.patterns.Restarter
-
- management(ActorContext<T>, Signal) - Method in class akka.typed.ScalaDSL.And
-
- management(ActorContext<T>, Signal) - Method in class akka.typed.ScalaDSL.Deferred
-
- 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) - Method in class akka.remote.artery.ArteryTransport
-
- 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) - Static method in class akka.remote.transport.ActorTransportAdapter
-
- managementCommand(Object) - Method in class akka.remote.transport.AkkaProtocolTransport
-
- managementCommand(Object) - Method in class akka.remote.transport.FailureInjectorTransportAdapter
-
- managementCommand(Object) - Static method in class akka.remote.transport.netty.NettyTransport
-
- managementCommand(Object) - Static method in class akka.remote.transport.TestTransport
-
- 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() - Static method in class akka.remote.transport.AkkaProtocolTransport
-
- manager() - Method in class akka.remote.transport.ThrottledAssociation
-
- manager() - Static method in class akka.remote.transport.ThrottlerTransportAdapter
-
- manager() - Method in class akka.stream.impl.io.TcpConnectionStage.Outbound
-
- manager_$eq(ActorRef) - Static method in class akka.remote.transport.AkkaProtocolTransport
-
- manager_$eq(ActorRef) - Static method in class akka.remote.transport.ThrottlerTransportAdapter
-
- 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
-
- mandatoryConvertTo(Class<T>, Object) - Static method in class akka.camel.internal.component.DurationTypeConverter
-
- mandatoryConvertTo(Class<T>, Exchange, Object) - Static method in class akka.camel.internal.component.DurationTypeConverter
-
- manifest(Object) - Method in class akka.cluster.client.protobuf.ClusterClientMessageSerializer
-
- manifest() - Method in class akka.cluster.ddata.LmdbDurableStore
-
- manifest(Object) - Method in class akka.cluster.ddata.protobuf.ReplicatedDataSerializer
-
- manifest(Object) - Method in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer
-
- manifest(Object) - Method in class akka.cluster.metrics.protobuf.MessageSerializer
-
- manifest(Object) - Method in class akka.cluster.pubsub.protobuf.DistributedPubSubMessageSerializer
-
- manifest(Object) - Method in class akka.cluster.sharding.protobuf.ClusterShardingMessageSerializer
-
- manifest(Object) - Method in class akka.cluster.singleton.protobuf.ClusterSingletonMessageSerializer
-
- manifest(Object) - Method in class akka.persistence.journal.EventAdapters.CombinedReadEventAdapter
-
- manifest(Object) - Method in class akka.persistence.journal.IdentityEventAdapter$
-
- manifest(Object) - Static method in class akka.persistence.journal.IdentityEventAdapter
-
- manifest(Object) - Method in class akka.persistence.journal.NoopReadEventAdapter
-
- manifest(Object) - Method in class akka.persistence.journal.NoopWriteEventAdapter
-
- manifest(Object) - Method in interface akka.persistence.journal.WriteEventAdapter
-
Return the manifest (type hint) that will be provided in the fromJournal
method.
- manifest() - Method in class akka.persistence.PersistentImpl
-
- manifest() - Method in interface akka.persistence.PersistentRepr
-
Returns the persistent payload's manifest if available
- manifest() - Method in class akka.persistence.serialization.SnapshotHeader
-
- manifest(long) - Method in interface akka.remote.artery.HeaderBuilder
-
- manifest(long) - Method in class akka.remote.artery.HeaderBuilderImpl
-
- manifest(Object) - Method in class akka.remote.serialization.ArteryMessageSerializer
-
- manifest(Object) - Method in class akka.remote.serialization.MiscMessageSerializer
-
- manifest(Object) - Method in class akka.serialization.SerializerWithStringManifest
-
Return the manifest (type hint) that will be provided in the fromBinary method.
- MANIFEST_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentMessage
-
- Manifests() - Method in class akka.remote.artery.ArterySettings.Compression
-
Accessor for nested Scala object
- Manifests$() - Constructor for class akka.remote.artery.ArterySettings.Compression.Manifests$
-
- MANIFESTS_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.PropsData
-
- manualProbe(boolean, ActorSystem) - Method in class akka.stream.testkit.TestPublisher$
-
Probe that implements Publisher
interface.
- manualProbe(boolean, ActorSystem) - Static method in class akka.stream.testkit.TestPublisher
-
Probe that implements Publisher
interface.
- ManualProbe(boolean, ActorSystem) - Constructor for class akka.stream.testkit.TestPublisher.ManualProbe
-
- manualProbe(ActorSystem) - Method in class akka.stream.testkit.TestSubscriber$
-
Probe that implements Subscriber
interface.
- manualProbe(ActorSystem) - Static method in class akka.stream.testkit.TestSubscriber
-
Probe that implements Subscriber
interface.
- ManualProbe(ActorSystem) - Constructor for class akka.stream.testkit.TestSubscriber.ManualProbe
-
- ManualProbe$() - Constructor for class akka.stream.testkit.TestPublisher.ManualProbe$
-
- ManualReset - Class in akka.pattern
-
- ManualReset() - Constructor for class akka.pattern.ManualReset
-
- ManualReset$ - Class in akka.pattern
-
- ManualReset$() - Constructor for class akka.pattern.ManualReset$
-
- ManyVersionVector - Class in akka.cluster.ddata
-
- ManyVersionVector(TreeMap<UniqueAddress, Object>) - Constructor for class akka.cluster.ddata.ManyVersionVector
-
- ManyVersionVector$ - Class in akka.cluster.ddata
-
- ManyVersionVector$() - Constructor for class akka.cluster.ddata.ManyVersionVector$
-
- map(Function1<T, B>) - Method in class akka.agent.Agent
-
Map this agent to a new agent, applying the function to the internal state.
- Map<In,Out> - Class in akka.stream.impl.fusing
-
INTERNAL API
- Map(Function1<In, Out>) - Constructor for class akka.stream.impl.fusing.Map
-
- map() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- map(Function1<Out, T>) - Static method in class akka.stream.impl.SubFlowImpl
-
- map(Function<Out, T>) - Method in class akka.stream.javadsl.Flow
-
Transform this stream by applying the given function to each of the elements
as they pass through this processing step.
- map(Function<Out, T>) - Method in class akka.stream.javadsl.Source
-
Transform this stream by applying the given function to each of the elements
as they pass through this processing step.
- map(Function<Out, T>) - Method in class akka.stream.javadsl.SubFlow
-
Transform this stream by applying the given function to each of the elements
as they pass through this processing step.
- map(Function<Out, T>) - Method in class akka.stream.javadsl.SubSource
-
Transform this stream by applying the given function to each of the elements
as they pass through this processing step.
- map(Function1<Out, T>) - Static method in class akka.stream.scaladsl.Flow
-
- map(Function1<Out, T>) - Method in interface akka.stream.scaladsl.FlowOps
-
Transform this stream by applying the given function to each of the elements
as they pass through this processing step.
- map(Function1<Out, T>) - Static method in class akka.stream.scaladsl.Source
-
- map(Function1<A, B>) - Static method in class akka.util.ByteIterator
-
- map(Function1<A, B>, CanBuildFrom<Repr, B, That>) - Static method in class akka.util.ByteString
-
- map(Function1<A, B>, CanBuildFrom<Repr, B, That>) - Static method in class akka.util.CompactByteString
-
- Map$ - Class in akka.stream.impl.fusing
-
- Map$() - Constructor for class akka.stream.impl.fusing.Map$
-
- MapAsync<In,Out> - Class in akka.stream.impl.fusing
-
- MapAsync(int, Function1<In, Future<Out>>) - Constructor for class akka.stream.impl.fusing.MapAsync
-
- mapAsync() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- mapAsync(int, Function1<Out, Future<T>>) - Static method in class akka.stream.impl.SubFlowImpl
-
- mapAsync(int, Function<Out, CompletionStage<T>>) - Method in class akka.stream.javadsl.Flow
-
Transform this stream by applying the given function to each of the elements
as they pass through this processing step.
- mapAsync(int, Function<Out, CompletionStage<T>>) - Method in class akka.stream.javadsl.Source
-
Transform this stream by applying the given function to each of the elements
as they pass through this processing step.
- mapAsync(int, Function<Out, CompletionStage<T>>) - Method in class akka.stream.javadsl.SubFlow
-
Transform this stream by applying the given function to each of the elements
as they pass through this processing step.
- mapAsync(int, Function<Out, CompletionStage<T>>) - Method in class akka.stream.javadsl.SubSource
-
Transform this stream by applying the given function to each of the elements
as they pass through this processing step.
- mapAsync(int, Function1<Out, Future<T>>) - Static method in class akka.stream.scaladsl.Flow
-
- mapAsync(int, Function1<Out, Future<T>>) - Method in interface akka.stream.scaladsl.FlowOps
-
Transform this stream by applying the given function to each of the elements
as they pass through this processing step.
- mapAsync(int, Function1<Out, Future<T>>) - Static method in class akka.stream.scaladsl.Source
-
- MapAsync$ - Class in akka.stream.impl.fusing
-
INTERNAL API
- MapAsync$() - Constructor for class akka.stream.impl.fusing.MapAsync$
-
- MapAsync.Holder<T> - Class in akka.stream.impl.fusing
-
- MapAsyncUnordered<In,Out> - Class in akka.stream.impl.fusing
-
INTERNAL API
- MapAsyncUnordered(int, Function1<In, Future<Out>>) - Constructor for class akka.stream.impl.fusing.MapAsyncUnordered
-
- mapAsyncUnordered() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- mapAsyncUnordered(int, Function1<Out, Future<T>>) - Static method in class akka.stream.impl.SubFlowImpl
-
- mapAsyncUnordered(int, Function<Out, CompletionStage<T>>) - Method in class akka.stream.javadsl.Flow
-
Transform this stream by applying the given function to each of the elements
as they pass through this processing step.
- mapAsyncUnordered(int, Function<Out, CompletionStage<T>>) - Method in class akka.stream.javadsl.Source
-
Transform this stream by applying the given function to each of the elements
as they pass through this processing step.
- mapAsyncUnordered(int, Function<Out, CompletionStage<T>>) - Method in class akka.stream.javadsl.SubFlow
-
Transform this stream by applying the given function to each of the elements
as they pass through this processing step.
- mapAsyncUnordered(int, Function<Out, CompletionStage<T>>) - Method in class akka.stream.javadsl.SubSource
-
Transform this stream by applying the given function to each of the elements
as they pass through this processing step.
- mapAsyncUnordered(int, Function1<Out, Future<T>>) - Static method in class akka.stream.scaladsl.Flow
-
- mapAsyncUnordered(int, Function1<Out, Future<T>>) - Method in interface akka.stream.scaladsl.FlowOps
-
Transform this stream by applying the given function to each of the elements
as they pass through this processing step.
- mapAsyncUnordered(int, Function1<Out, Future<T>>) - Static method in class akka.stream.scaladsl.Source
-
- MapAsyncUnordered$ - Class in akka.stream.impl.fusing
-
- MapAsyncUnordered$() - Constructor for class akka.stream.impl.fusing.MapAsyncUnordered$
-
- 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.
- mapConcat(Function1<Out, Iterable<T>>) - Static method in class akka.stream.impl.SubFlowImpl
-
- mapConcat(Function<Out, Iterable<T>>) - Method in class akka.stream.javadsl.Flow
-
Transform each input element into an Iterable
of output elements that is
then flattened into the output stream.
- mapConcat(Function<Out, ? extends Iterable<T>>) - Method in class akka.stream.javadsl.Source
-
Transform each input element into an Iterable
of output elements that is
then flattened into the output stream.
- mapConcat(Function<Out, Iterable<T>>) - Method in class akka.stream.javadsl.SubFlow
-
Transform each input element into an Iterable
of output elements that is
then flattened into the output stream.
- mapConcat(Function<Out, Iterable<T>>) - Method in class akka.stream.javadsl.SubSource
-
Transform each input element into an Iterable
of output elements that is
then flattened into the output stream.
- mapConcat(Function1<Out, Iterable<T>>) - Static method in class akka.stream.scaladsl.Flow
-
- mapConcat(Function1<Out, Iterable<T>>) - Method in interface akka.stream.scaladsl.FlowOps
-
Transform each input element into an Iterable
of output elements that is
then flattened into the output stream.
- mapConcat(Function1<Out, Iterable<T>>) - Static method in class akka.stream.scaladsl.Source
-
- MapError<T> - Class in akka.stream.impl.fusing
-
Maps error with the provided function if it is defined for an error or, otherwise, passes it on unchanged.
- MapError(PartialFunction<Throwable, Throwable>) - Constructor for class akka.stream.impl.fusing.MapError
-
- mapError(PartialFunction<Throwable, Throwable>) - Static method in class akka.stream.impl.SubFlowImpl
-
- mapError(PartialFunction<Throwable, Throwable>) - Method in class akka.stream.javadsl.Flow
-
While similar to recover
this stage can be used to transform an error signal to a different one *without* logging
it as an error in the process.
- mapError(PartialFunction<Throwable, Throwable>) - Method in class akka.stream.javadsl.Source
-
While similar to recover
this stage can be used to transform an error signal to a different one *without* logging
it as an error in the process.
- mapError(PartialFunction<Throwable, Throwable>) - Method in class akka.stream.javadsl.SubFlow
-
While similar to recover
this stage can be used to transform an error signal to a different one *without* logging
it as an error in the process.
- mapError(PartialFunction<Throwable, Throwable>) - Method in class akka.stream.javadsl.SubSource
-
While similar to recover
this stage can be used to transform an error signal to a different one *without* logging
it as an error in the process.
- mapError(PartialFunction<Throwable, Throwable>) - Static method in class akka.stream.scaladsl.Flow
-
- mapError(PartialFunction<Throwable, Throwable>) - Method in interface akka.stream.scaladsl.FlowOps
-
While similar to recover
this stage can be used to transform an error signal to a different one *without* logging
it as an error in the process.
- mapError(PartialFunction<Throwable, Throwable>) - Static method in class akka.stream.scaladsl.Source
-
- MapError$ - Class in akka.stream.impl.fusing
-
- MapError$() - Constructor for class akka.stream.impl.fusing.MapError$
-
- mapI(Function1<Object, Object>) - Method in class akka.util.ByteString
-
map method that will automatically cast Int back into Byte.
- mapI(Function1<Object, Object>) - Static method in class akka.util.CompactByteString
-
- mapMaterializedValue(Function<Mat, Mat2>) - Method in class akka.stream.javadsl.BidiFlow
-
Transform only the materialized value of this BidiFlow, leaving all other properties as they were.
- mapMaterializedValue(Function<Mat, Mat2>) - Method in class akka.stream.javadsl.Flow
-
Transform only the materialized value of this Flow, leaving all other properties as they were.
- mapMaterializedValue(Function<Mat, Mat2>) - Method in class akka.stream.javadsl.RunnableGraph
-
Transform only the materialized value of this RunnableGraph, leaving all other properties as they were.
- mapMaterializedValue(Function<Mat, Mat2>) - Method in class akka.stream.javadsl.Sink
-
Transform only the materialized value of this Sink, leaving all other properties as they were.
- mapMaterializedValue(Function<Mat, Mat2>) - Method in class akka.stream.javadsl.Source
-
Transform only the materialized value of this Source, leaving all other properties as they were.
- mapMaterializedValue(Function1<Mat, Mat2>) - Method in class akka.stream.scaladsl.BidiFlow
-
Transform only the materialized value of this BidiFlow, leaving all other properties as they were.
- mapMaterializedValue(Function1<Mat, Mat2>) - Method in class akka.stream.scaladsl.Flow
-
Transform the materialized value of this Flow, leaving all other properties as they were.
- mapMaterializedValue(Function1<Mat, Mat2>) - Method in interface akka.stream.scaladsl.FlowOpsMat
-
Transform the materialized value of this graph, leaving all other properties as they were.
- mapMaterializedValue(Function1<Mat, Mat2>) - Method in class akka.stream.scaladsl.RunnableGraph
-
Transform only the materialized value of this RunnableGraph, leaving all other properties as they were.
- mapMaterializedValue(Function1<Mat, Mat2>) - Method in class akka.stream.scaladsl.Sink
-
Transform only the materialized value of this Sink, leaving all other properties as they were.
- mapMaterializedValue(Function1<Mat, Mat2>) - Method in class akka.stream.scaladsl.Source
-
Transform only the materialized value of this Source, leaving all other properties as they were.
- 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
-
- mapSettings(Function1<SSLConfigSettings, SSLConfigSettings>) - Method in class com.typesafe.sslconfig.akka.AkkaSSLConfig
-
Returns a new
AkkaSSLConfig
instance with the settings changed by the given function.
- mapSize() - Method in interface akka.event.ActorClassification
-
Deprecated.
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
-
Deprecated.
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
-
- markAllInputs() - Method in class akka.stream.impl.FanIn.InputBunch
-
- markAllOutputs() - Method in class akka.stream.impl.FanOut.OutputBunch
-
- 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
-
- Marked() - Method in class akka.stream.impl.FanIn$
-
- Marked() - Static method in class akka.stream.impl.FanIn
-
- Marker() - Method in class akka.contrib.mailbox.PeekMailbox
-
- marker() - Method in class akka.event.Logging.Debug3
-
- marker() - Method in class akka.event.Logging.Error3
-
- marker() - Method in class akka.event.Logging.Info3
-
- marker() - Method in interface akka.event.Logging.LogEventWithMarker
-
- marker() - Method in class akka.event.Logging.Warning3
-
- MarkerLoggingAdapter - Class in akka.event
-
- MarkerLoggingAdapter(LoggingBus, String, Class<?>, LoggingFilter) - Constructor for class akka.event.MarkerLoggingAdapter
-
- MarkerLoggingAdapter(LoggingBus, String, Class<?>) - Constructor for class akka.event.MarkerLoggingAdapter
-
- markInput(int) - Method in class akka.stream.impl.FanIn.InputBunch
-
- markLive(int) - Method in class akka.remote.artery.RollingEventLogSection
-
- markOutput(int) - Method in class akka.stream.impl.FanOut.OutputBunch
-
- markProcessed() - Method in class akka.stream.actor.ActorPublisherMessage.Request
-
INTERNAL API: needed for stash support
- markSnapshot(int) - Method in class akka.remote.artery.RollingEventLogSection
-
- markup() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- markup() - Static method in class akka.persistence.journal.JournalSpec
-
- markup() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- mask() - Method in class akka.remote.artery.ByteFlag
-
- mask() - Method in class akka.remote.artery.compress.TopHeavyHitters
-
- mat() - Method in class akka.stream.impl.fusing.GraphInterpreterShell
-
- 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<Throwable, SupervisorStrategy.Directive>) - Static method in class akka.japi.pf.DeciderBuilder
-
Return a new
PFBuilder
with a case statement added.
- matchAny(FI.Apply<F, T>) - Static method in class akka.japi.pf.Match
-
Convenience function to create a
PFBuilder
with the first
case statement added.
- matchAny(FI.Apply<I, 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
-
- matchAnyEvent(FI.Apply2<Object, D, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- 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
-
- matchData(Class<DT>, FI.UnitApply<DT>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- matchData(Class<DT>, FI.TypedPredicate<DT>, FI.UnitApply<DT>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- 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
-
- matchEvent(Class<ET>, Class<DT>, FI.TypedPredicate2<ET, DT>, FI.Apply2<ET, DT, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- matchEvent(Class<ET>, Class<DT>, FI.Apply2<ET, DT, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- matchEvent(Class<ET>, FI.TypedPredicate2<ET, D>, FI.Apply2<ET, D, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- matchEvent(Class<ET>, FI.Apply2<ET, D, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- matchEvent(FI.TypedPredicate2<Object, D>, FI.Apply2<Object, D, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- matchEvent(List<Object>, Class<DT>, FI.Apply2<Object, DT, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- matchEvent(List<Object>, FI.Apply2<Object, D, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- 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
-
- matchEventEquals(Ev, Class<DT>, FI.Apply2<Ev, DT, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- matchEventEquals(Ev, FI.Apply2<Ev, D, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- matchingRole(Member) - Method in class akka.cluster.client.ClusterReceptionist
-
- matchingRole(Member) - Method in class akka.cluster.ddata.Replicator
-
- 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
-
- matchPattern() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- matchPattern() - Static method in class akka.persistence.journal.JournalSpec
-
- matchPattern() - Method in class akka.persistence.PluginSpec
-
- matchPattern() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- matchState(S, S, FI.UnitApplyVoid) - Method in class akka.actor.AbstractFSM
-
- matchState(S, S, FI.UnitApply2<S, S>) - Method in class akka.actor.AbstractFSM
-
- matchState(S, S, FI.UnitApplyVoid) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- matchState(S, S, FI.UnitApply2<S, S>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- 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
-
- matchStop(PersistentFSM.Reason, FI.UnitApply2<S, D>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- matchStop(Class<RT>, FI.UnitApply3<RT, S, D>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- matchStop(Class<RT>, FI.TypedPredicate<RT>, FI.UnitApply3<RT, S, D>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- MaterializationContext - Class in akka.stream
-
Context parameter to the create
methods of sources and sinks.
- MaterializationContext(Materializer, Attributes, String) - Constructor for class akka.stream.MaterializationContext
-
- MaterializationContext$ - Class in akka.stream
-
- MaterializationContext$() - Constructor for class akka.stream.MaterializationContext$
-
- MaterializationException - Exception in akka.stream
-
This exception or subtypes thereof should be used to signal materialization
failures.
- MaterializationException(String, Throwable) - Constructor for exception akka.stream.MaterializationException
-
- MaterializationException$ - Class in akka.stream
-
- MaterializationException$() - Constructor for class akka.stream.MaterializationException$
-
- MaterializationPanic(Throwable) - Constructor for exception akka.stream.impl.MaterializerSession.MaterializationPanic
-
- materialize() - Method in class akka.remote.artery.Association.LazyQueueWrapper
-
- materialize(Graph<ClosedShape, Mat>) - Static method in class akka.stream.ActorMaterializer
-
- materialize(Graph<ClosedShape, Mat>, Attributes) - Static method in class akka.stream.ActorMaterializer
-
- materialize(Graph<ClosedShape, Mat>) - Method in class akka.stream.impl.ActorMaterializerImpl
-
- materialize(Graph<ClosedShape, Mat>, Attributes) - Method in class akka.stream.impl.ActorMaterializerImpl
-
- materialize(Graph<ClosedShape, Mat>, Function1<GraphInterpreterShell, ActorRef>) - Method in class akka.stream.impl.ActorMaterializerImpl
-
- materialize(Graph<ClosedShape, Mat>, Function1<GraphInterpreterShell, ActorRef>, Attributes) - Method in class akka.stream.impl.ActorMaterializerImpl
-
- materialize(Graph<ClosedShape, Mat>, Function1<GraphInterpreterShell, ActorRef>) - Method in class akka.stream.impl.ExtendedActorMaterializer
-
INTERNAL API
- materialize(Graph<ClosedShape, Mat>, Function1<GraphInterpreterShell, ActorRef>, Attributes) - Method in class akka.stream.impl.ExtendedActorMaterializer
-
INTERNAL API
- materialize(Attributes, StreamLayout.Module[], Map<StreamLayout.Module, Object>, Function1<GraphStages.MaterializedValueSource<Object>, BoxedUnit>) - Method in class akka.stream.impl.fusing.GraphInterpreter.GraphAssembly
-
Takes an interpreter and returns three arrays required by the interpreter containing the input, output port
handlers and the stage logic instances.
- materialize() - Method in class akka.stream.impl.MaterializerSession
-
- Materialize(Props, String) - Constructor for class akka.stream.impl.StreamSupervisor.Materialize
-
- materialize(Graph<ClosedShape, Mat>) - Method in class akka.stream.impl.SubFusingActorMaterializerImpl
-
- materialize(Graph<ClosedShape, Mat>, Attributes) - Method in class akka.stream.impl.SubFusingActorMaterializerImpl
-
- materialize(Graph<ClosedShape, Mat>) - Method in class akka.stream.Materializer
-
This method interprets the given Flow description and creates the running
stream.
- materialize(Graph<ClosedShape, Mat>, Attributes) - Method in class akka.stream.Materializer
-
This method interprets the given Flow description and creates the running
stream using an explicitly provided
Attributes
as top level attributes.
- materialize(Graph<ClosedShape, Mat>) - Method in class akka.stream.NoMaterializer$
-
- materialize(Graph<ClosedShape, Mat>, Attributes) - Method in class akka.stream.NoMaterializer$
-
- materialize(Graph<ClosedShape, Mat>) - Static method in class akka.stream.NoMaterializer
-
- materialize(Graph<ClosedShape, Mat>, Attributes) - Static method in class akka.stream.NoMaterializer
-
- Materialize$() - Constructor for class akka.stream.impl.StreamSupervisor.Materialize$
-
- materializeAtomic(StreamLayout.AtomicModule, Attributes, Map<StreamLayout.Module, Object>) - Method in class akka.stream.impl.MaterializerSession
-
- materializeComposite(StreamLayout.Module, Attributes) - Method in class akka.stream.impl.MaterializerSession
-
- materializedValue() - Method in class akka.stream.javadsl.GraphDSL.Builder
-
Returns an Outlet
that gives access to the materialized value of this graph.
- materializedValue() - Method in class akka.stream.scaladsl.GraphDSL.Builder
-
Returns an Outlet
that gives access to the materialized value of this graph.
- materializedValueComputation() - Static method in class akka.stream.impl.fusing.GraphModule
-
- materializedValueComputation() - Static method in class akka.stream.impl.fusing.GraphStageModule
-
- materializedValueComputation() - Static method in class akka.stream.impl.io.TlsModule
-
- materializedValueComputation() - Static method in class akka.stream.impl.ProcessorModule
-
- materializedValueComputation() - Method in class akka.stream.impl.StreamLayout.CompositeModule
-
- materializedValueComputation() - Method in class akka.stream.impl.StreamLayout.CopiedModule
-
- materializedValueComputation() - Method in class akka.stream.impl.StreamLayout.EmptyModule$
-
- materializedValueComputation() - Method in class akka.stream.impl.StreamLayout.FusedModule
-
- materializedValueComputation() - Method in interface akka.stream.impl.StreamLayout.Module
-
- materializedValueComputation() - Method in class akka.stream.impl.StreamLayout.StructuralInfoModule
-
- MaterializedValueSource(StreamLayout.MaterializedValueNode, Outlet<T>) - Constructor for class akka.stream.impl.fusing.GraphStages.MaterializedValueSource
-
- MaterializedValueSource(StreamLayout.MaterializedValueNode) - Constructor for class akka.stream.impl.fusing.GraphStages.MaterializedValueSource
-
- materializedValueSource() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- materializeModule(StreamLayout.Module, Attributes) - Method in class akka.stream.impl.MaterializerSession
-
- materializer() - Method in class akka.remote.artery.Association
-
- materializer() - Method in class akka.stream.impl.fusing.GraphInterpreter
-
- materializer() - Method in class akka.stream.MaterializationContext
-
- Materializer - Class in akka.stream
-
Materializer SPI (Service Provider Interface)
- Materializer() - Constructor for class akka.stream.Materializer
-
- materializer() - Method in class akka.stream.stage.GraphStageLogic
-
- materializer() - Method in interface akka.stream.stage.LifecycleContext
-
Returns the Materializer that was used to materialize this
Stage
.
- MaterializerLoggingProvider - Interface in akka.stream
-
SPI intended only to be extended by custom
Materializer
implementations,
that also want to provide stages they materialize with specialized
LoggingAdapter
instances.
- MaterializerSession - Class in akka.stream.impl
-
INTERNAL API
- MaterializerSession(StreamLayout.Module, Attributes) - Constructor for class akka.stream.impl.MaterializerSession
-
- MaterializerSession$ - Class in akka.stream.impl
-
INERNAL API
- MaterializerSession$() - Constructor for class akka.stream.impl.MaterializerSession$
-
- MaterializerSession.MaterializationPanic - Exception in akka.stream.impl
-
- MaterializerSettings() - Method in class akka.remote.artery.ArterySettings.Advanced$
-
- matValIDs() - Method in class akka.stream.impl.fusing.GraphModule
-
- matValues() - Method in class akka.stream.impl.StreamLayout.StructuralInfoModule
-
- max() - Method in class akka.cluster.metrics.StandardMetrics.HeapMemory
-
- max() - Method in class akka.cluster.StandardMetrics.HeapMemory
-
Deprecated.
- max() - Method in class akka.persistence.journal.AsyncWriteTarget.ReplayMessages
-
- max() - Method in class akka.persistence.journal.leveldb.LeveldbJournal.ReplayTaggedMessages
-
- max() - Method in class akka.persistence.JournalProtocol.ReplayMessages
-
- Max() - Method in class akka.remote.artery.ArterySettings.Compression.ActorRefs$
-
- Max() - Method in class akka.remote.artery.ArterySettings.Compression.Manifests$
-
- max() - Method in class akka.remote.artery.compress.TopHeavyHitters
-
- max() - Method in class akka.stream.Attributes.InputBuffer
-
- max() - Method in class akka.stream.impl.fusing.Batch
-
- max(Ordering<B>) - Static method in class akka.util.ByteIterator
-
- max(Ordering<B>) - Static method in class akka.util.ByteString
-
- max(Ordering<B>) - Static method in class akka.util.CompactByteString
-
- maxActivations() - Method in class akka.typed.internal.ActorCell$
-
- maxActivations() - Static method in class akka.typed.internal.ActorCell
-
- maxAvailable() - Method in class akka.stream.impl.ResizableMultiReaderRingBuffer
-
The maximum number of elements the buffer can still take.
- maxBackoff() - Method in class akka.pattern.BackoffOptionsImpl
-
- maxBufferSize() - Method in class akka.stream.impl.FanoutOutputs
-
- maxBufferSize() - Method in interface akka.stream.impl.SubscriberManagement
-
- maxBufSize() - Method in class akka.persistence.query.journal.leveldb.AbstractEventsByPersistenceIdPublisher
-
- maxBufSize() - Method in class akka.persistence.query.journal.leveldb.AbstractEventsByTagPublisher
-
- maxBy(Function1<A, B>, Ordering<B>) - Static method in class akka.util.ByteIterator
-
- maxBy(Function1<A, B>, Ordering<B>) - Static method in class akka.util.ByteString
-
- maxBy(Function1<A, B>, Ordering<B>) - Static method in class akka.util.CompactByteString
-
- MaxBytesPerChunkDefault() - Method in class akka.stream.scaladsl.Compression$
-
- MaxBytesPerChunkDefault() - Static method in class akka.stream.scaladsl.Compression
-
- 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
-
- maxDeltaElements() - Method in class akka.cluster.ddata.ReplicatorSettings
-
- maxDeltaElements() - Method in class akka.cluster.pubsub.DistributedPubSubSettings
-
- MaxDirectBufferPoolSize() - Method in class akka.io.TcpExt.Settings
-
- MaxDirectBufferPoolSize() - Method in class akka.io.Udp.UdpSettings
-
- maxFailures() - Method in class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitBreakerPropsBuilder
-
- maxFixedBufferSize() - Method in class akka.stream.ActorMaterializerSettings
-
- 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.
- MaxGossipsBeforeShuttingDownMyself() - Method in class akka.cluster.ClusterCoreDaemon
-
- maxHandOverRetries() - Method in class akka.cluster.singleton.ClusterSingletonManager
-
- maximumBurst() - Method in class akka.stream.impl.Throttle
-
- MaximumFrameSize() - Method in class akka.remote.artery.ArterySettings.Advanced$
-
- MaximumLargeFrameSize() - Method in class akka.remote.artery.ArterySettings.Advanced$
-
- maximumOverhead() - Method in class akka.remote.transport.AbstractTransportAdapter
-
- maximumOverhead() - Static method in class akka.remote.transport.ActorTransportAdapter
-
- 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() - Static method in class akka.remote.transport.ActorTransportAdapter
-
- maximumPayloadBytes() - Static method in class akka.remote.transport.AkkaProtocolTransport
-
- maximumPayloadBytes() - Static method in class akka.remote.transport.FailureInjectorTransportAdapter
-
- maximumPayloadBytes() - Method in class akka.remote.transport.netty.NettyTransport
-
- maximumPayloadBytes() - Method in class akka.remote.transport.TestTransport
-
- maximumPayloadBytes() - Static method in class akka.remote.transport.ThrottlerTransportAdapter
-
- maximumPayloadBytes() - Method in interface akka.remote.transport.Transport
-
Defines the maximum size of payload this transport is able to deliver.
- maximumRetries() - Method in class akka.stream.impl.fusing.RecoverWith
-
- MaxInFlightRequestStrategy - Class in akka.stream.actor
-
Requests up to the max
and also takes the number of messages
that have been queued internally or delegated to other actors into account.
- MaxInFlightRequestStrategy(int) - Constructor for class akka.stream.actor.MaxInFlightRequestStrategy
-
- maxInputBufferSize() - Method in class akka.stream.ActorMaterializerSettings
-
- maxInstancesPerNode() - Method in class akka.cluster.routing.ClusterRouterPoolSettings
-
- 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
-
- maxNrOfRetries() - Static method in class akka.cluster.metrics.ClusterMetricsStrategy
-
- 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
-
- maxProbeDistance() - Method in class akka.remote.artery.CacheStatistics
-
- maxPruningDissemination() - Method in class akka.cluster.ddata.ReplicatorSettings
-
- maxPruningDisseminationNanos() - Method in class akka.cluster.ddata.Replicator
-
- maxSampleSize() - Method in class akka.remote.HeartbeatHistory
-
- maxSampleSize() - Method in class akka.remote.PhiAccrualFailureDetector
-
- MaxSecondaryNodes() - Method in class akka.cluster.ddata.ReadWriteAggregator$
-
- MaxSecondaryNodes() - Static method in class akka.cluster.ddata.ReadWriteAggregator
-
- maxSeq() - Method in class akka.remote.AckedSendBuffer
-
- maxSequenceNr() - Method in class akka.persistence.SnapshotSelectionCriteria
-
- maxSilenceTimer() - Method in class akka.remote.ReliableDeliverySupervisor
-
- maxSubstreams() - Method in class akka.stream.impl.fusing.GroupBy
-
- maxTakeOverRetries() - Method in class akka.cluster.singleton.ClusterSingletonManager
-
- maxTimestamp() - Method in class akka.persistence.SnapshotSelectionCriteria
-
- maxUnconfirmedMessages() - Method in interface akka.persistence.AtLeastOnceDeliveryLike
-
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
-
- may(Function0<BoxedUnit>, StringVerbBlockRegistration, Position) - Method in interface akka.persistence.scalatest.MayVerb.StringMayWrapperForVerb
-
Block of tests which MAY pass, and if not should be ignored.
- maybe() - Method in class akka.stream.javadsl.Source$
-
Create a Source
which materializes a CompletableFuture
which controls what element
will be emitted by the Source.
- maybe() - Static method in class akka.stream.javadsl.Source
-
Create a Source
which materializes a CompletableFuture
which controls what element
will be emitted by the Source.
- maybe() - Method in class akka.stream.scaladsl.Source$
-
Create a Source
which materializes a Promise
which controls what element
will be emitted by the Source.
- maybe() - Static method in class akka.stream.scaladsl.Source
-
Create a Source
which materializes a Promise
which controls what element
will be emitted by the Source.
- MaybePublisher<T> - Class in akka.stream.impl
-
INTERNAL API
- MaybePublisher(Promise<Option<T>>, String, ExecutionContext) - Constructor for class akka.stream.impl.MaybePublisher
-
- MaybePublisher$ - Class in akka.stream.impl
-
- MaybePublisher$() - Constructor for class akka.stream.impl.MaybePublisher$
-
- MaybeSource<Out> - Class in akka.stream.impl
-
INTERNAL API
- MaybeSource(Attributes, SourceShape<Out>) - Constructor for class akka.stream.impl.MaybeSource
-
- maybeSource() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- maySend() - Method in class akka.typed.internal.ActorCell
-
- maySend() - Method in interface akka.typed.internal.DeathWatch
-
- maySend() - Method in interface akka.typed.internal.SupervisionMechanics
-
- MayVerb - Interface in akka.persistence.scalatest
-
- MayVerb$ - Class in akka.persistence.scalatest
-
- MayVerb$() - Constructor for class akka.persistence.scalatest.MayVerb$
-
- MayVerb.StringMayWrapperForVerb - Interface in akka.persistence.scalatest
-
- MayVerb.TestCanceledByFailure - Exception in akka.persistence.scalatest
-
- MayVerb.TestCanceledByFailure$ - Class in akka.persistence.scalatest
-
- mayVerbStacktraceContextFrames() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- mayVerbStacktraceContextFrames() - Static method in class akka.persistence.journal.JournalSpec
-
- mayVerbStacktraceContextFrames() - Method in interface akka.persistence.scalatest.MayVerb
-
Configurable number of frames to be shown when a MAY test fails (is canceled).
- md5(String) - Method in class akka.util.Crypt$
-
Deprecated.
- md5(byte[]) - Method in class akka.util.Crypt$
-
Deprecated.
- md5(String) - Static method in class akka.util.Crypt
-
Deprecated.
- md5(byte[]) - Static method in class akka.util.Crypt
-
Deprecated.
- 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.Debug3
-
- mdc() - Method in class akka.event.Logging.Error2
-
- mdc() - Method in class akka.event.Logging.Error3
-
- mdc() - Method in class akka.event.Logging.Info2
-
- mdc() - Method in class akka.event.Logging.Info3
-
- mdc() - Method in interface akka.event.Logging.LogEvent
-
- mdc() - Method in class akka.event.Logging.Warning2
-
- mdc() - Method in class akka.event.Logging.Warning3
-
- mdc() - Method in interface akka.event.LoggingAdapter
-
LoggingAdapter extension which adds MDC support.
- mdc() - Static method in class akka.event.NoLogging
-
- mdc() - Static method in class akka.event.NoMarkerLogging
-
- mdcActorSystemAttributeName() - Method in class akka.event.slf4j.Slf4jLogger
-
- mdcAkkaSourceAttributeName() - Method in class akka.event.slf4j.Slf4jLogger
-
- mdcAkkaTimestamp() - Method in class akka.event.slf4j.Slf4jLogger
-
- MDCKey() - Method in class akka.event.LogMarker$
-
The Marker is internally transferred via MDC using using this key
- MDCKey() - Static method in class akka.event.LogMarker
-
The Marker is internally transferred via MDC using using this key
- 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 warm-up)
- 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.MemberJoined
-
- member() - Method in class akka.cluster.ClusterEvent.MemberLeft
-
- member() - Method in class akka.cluster.ClusterEvent.MemberRemoved
-
- member() - Method in class akka.cluster.ClusterEvent.MemberUp
-
- member() - Method in class akka.cluster.ClusterEvent.MemberWeaklyUp
-
- 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() - Method in class akka.cluster.singleton.ClusterSingletonManager.Internal$.DelayedMemberRemoved
-
- 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$
-
- MemberJoined(Member) - Constructor for class akka.cluster.ClusterEvent.MemberJoined
-
- MemberJoined$() - Constructor for class akka.cluster.ClusterEvent.MemberJoined$
-
- MemberLeft(Member) - Constructor for class akka.cluster.ClusterEvent.MemberLeft
-
- MemberLeft$() - Constructor for class akka.cluster.ClusterEvent.MemberLeft$
-
- MemberRemoved(Member, MemberStatus) - Constructor for class akka.cluster.ClusterEvent.MemberRemoved
-
- memberRemoved(Member, MemberStatus) - Method in class akka.cluster.ClusterRemoteWatcher
-
- 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
-
- MemberStatus.WeaklyUp$ - Class in akka.cluster
-
WeaklyUp is an EXPERIMENTAL feature and is subject to change until
it has received more real world testing.
- MemberUp(Member) - Constructor for class akka.cluster.ClusterEvent.MemberUp
-
- memberUp(Member) - Method in class akka.cluster.ClusterRemoteWatcher
-
- MemberUp$() - Constructor for class akka.cluster.ClusterEvent.MemberUp$
-
- MemberWeaklyUp(Member) - Constructor for class akka.cluster.ClusterEvent.MemberWeaklyUp
-
- MemberWeaklyUp$() - Constructor for class akka.cluster.ClusterEvent.MemberWeaklyUp$
-
- Merge() - Method in class akka.cluster.ClusterCoreDaemon
-
- Merge() - Constructor for class akka.cluster.ClusterCoreDaemon.Merge
-
- merge(ReplicatedData) - Method in class akka.cluster.ddata.AbstractReplicatedData
-
- merge(Flag) - Method in class akka.cluster.ddata.Flag
-
- merge(GCounter) - Method in class akka.cluster.ddata.GCounter
-
INTERNAL API
- merge(GSet<A>) - Method in class akka.cluster.ddata.GSet
-
- merge(LWWMap<A>) - Method in class akka.cluster.ddata.LWWMap
-
- merge(LWWRegister<A>) - Method in class akka.cluster.ddata.LWWRegister
-
INTERNAL API
- merge(VersionVector) - Method in class akka.cluster.ddata.ManyVersionVector
-
- merge(VersionVector) - Method in class akka.cluster.ddata.OneVersionVector
-
- merge(ORMap<A>) - Method in class akka.cluster.ddata.ORMap
-
- merge(ORMultiMap<A>) - Method in class akka.cluster.ddata.ORMultiMap
-
- merge(ORSet<A>) - Method in class akka.cluster.ddata.ORSet
-
When element is in this Set but not in that Set:
Compare the "birth dot" of the present element to the version vector in the Set it is absent from.
- merge(PNCounter) - Method in class akka.cluster.ddata.PNCounter
-
- merge(PNCounterMap) - Method in class akka.cluster.ddata.PNCounterMap
-
- merge(PruningState) - Method in class akka.cluster.ddata.PruningState
-
- merge(ReplicatedData) - Method in interface akka.cluster.ddata.ReplicatedData
-
Monotonic merge function.
- merge(akka.cluster.ddata.Replicator.Internal.DataEnvelope) - Method in class akka.cluster.ddata.Replicator.Internal$.DataEnvelope
-
- merge(ReplicatedData) - Method in class akka.cluster.ddata.Replicator.Internal$.DataEnvelope
-
- merge(ReplicatedData) - Method in class akka.cluster.ddata.Replicator.Internal$.DeletedData
-
- merge(VersionVector) - Method in class akka.cluster.ddata.VersionVector
-
Merges this VersionVector with another VersionVector.
- 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
-
Deprecated.
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.
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Static method in class akka.remote.security.provider.AkkaProvider
-
- merge() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- merge(Graph<SourceShape<U>, M>, boolean) - Static method in class akka.stream.impl.SubFlowImpl
-
- merge(Graph<SourceShape<T>, ?>) - Method in class akka.stream.javadsl.Flow
-
Merge the given
Source
to this
Flow
, taking elements as they arrive from input streams,
picking randomly when several elements ready.
- merge(Graph<SourceShape<T>, ?>, boolean) - Method in class akka.stream.javadsl.Flow
-
Merge the given
Source
to this
Flow
, taking elements as they arrive from input streams,
picking randomly when several elements ready.
- Merge - Class in akka.stream.javadsl
-
Merge several streams, taking elements as they arrive from input streams
(picking randomly when several have elements ready).
- Merge() - Constructor for class akka.stream.javadsl.Merge
-
- merge(Graph<SourceShape<T>, ?>) - Method in class akka.stream.javadsl.Source
-
Merge the given
Source
to the current one, taking elements as they arrive from input streams,
picking randomly when several elements ready.
- merge(Graph<SourceShape<T>, ?>) - Method in class akka.stream.javadsl.SubFlow
-
Merge the given
Source
to this
Flow
, taking elements as they arrive from input streams,
picking randomly when several elements ready.
- merge(Graph<SourceShape<T>, ?>) - Method in class akka.stream.javadsl.SubSource
-
Merge the given
Source
to this
Flow
, taking elements as they arrive from input streams,
picking randomly when several elements ready.
- merge(Graph<SourceShape<U>, M>, boolean) - Static method in class akka.stream.scaladsl.Flow
-
- merge(Graph<SourceShape<U>, M>, boolean) - Method in interface akka.stream.scaladsl.FlowOps
-
Merge the given
Source
to this
Flow
, taking elements as they arrive from input streams,
picking randomly when several elements ready.
- Merge<T> - Class in akka.stream.scaladsl
-
Merge several streams, taking elements as they arrive from input streams
(picking randomly when several have elements ready).
- Merge(int, boolean) - Constructor for class akka.stream.scaladsl.Merge
-
- merge(Graph<SourceShape<U>, M>, boolean) - Static method in class akka.stream.scaladsl.Source
-
- Merge$ - Class in akka.stream.javadsl
-
Merge several streams, taking elements as they arrive from input streams
(picking randomly when several have elements ready).
- Merge$() - Constructor for class akka.stream.javadsl.Merge$
-
- Merge$ - Class in akka.stream.scaladsl
-
- Merge$() - Constructor for class akka.stream.scaladsl.Merge$
-
- merge$default$2() - Static method in class akka.stream.impl.SubFlowImpl
-
- merge$default$2() - Static method in class akka.stream.scaladsl.Flow
-
- merge$default$2() - Static method in class akka.stream.scaladsl.Source
-
- mergeAck(WireFormats.AcknowledgementInfo) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
-
optional .AcknowledgementInfo ack = 1;
- mergeAckReplyTo(ArteryControlFormats.UniqueAddress) - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope.Builder
-
required .UniqueAddress ackReplyTo = 5;
- mergeActor(ContainerFormats.ActorRef) - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
optional .ActorRef actor = 1;
- mergeActor(ContainerFormats.ActorRef) - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData.Builder
-
required .ActorRef actor = 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(ReplicatorMessages.Address) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress.Builder
-
required .akka.cluster.ddata.Address address = 1;
- 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(ArteryControlFormats.UniqueAddress) - Method in class akka.remote.ArteryControlFormats.MessageWithAddress.Builder
-
required .UniqueAddress address = 1;
- mergeAddress(ArteryControlFormats.Address) - Method in class akka.remote.ArteryControlFormats.UniqueAddress.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;
- mergeAttributes(Attributes, Attributes) - Method in class akka.stream.impl.MaterializerSession
-
- mergeBarrier(TestConductorProtocol.EnterBarrier) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .EnterBarrier barrier = 2;
- mergeCause(ContainerFormats.Payload) - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
required .Payload cause = 3;
- mergeCause(ContainerFormats.Payload) - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
optional .Payload cause = 3;
- mergeCauseData(ContainerFormats.Payload) - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .Payload causeData = 3;
- mergeChild(ContainerFormats.ActorRef) - Method in class akka.remote.SystemMessageFormats.FailedData.Builder
-
required .ActorRef child = 1;
- mergeChild(ContainerFormats.ActorRef) - Method in class akka.remote.SystemMessageFormats.SuperviseData.Builder
-
required .ActorRef child = 1;
- mergeCommonKeys(Set<A>, ORSet<A>, ORSet<A>) - Method in class akka.cluster.ddata.ORSet$
-
INTERNAL API
- mergeCommonKeys(Set<A>, ORSet<A>, ORSet<A>) - Static method in class akka.cluster.ddata.ORSet
-
INTERNAL API
- mergeCorrelationId(ContainerFormats.Payload) - Method in class akka.remote.ContainerFormats.ActorIdentity.Builder
-
required .Payload correlationId = 1;
- mergeCount() - Method in class akka.cluster.GossipStats
-
- mergeData(D) - Method in class akka.cluster.ddata.AbstractReplicatedData
-
Java API: Monotonic merge function.
- mergeData(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed.Builder
-
required .akka.cluster.ddata.OtherMessage data = 2;
- mergeData(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
required .akka.cluster.ddata.OtherMessage data = 1;
- mergeData(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelope.Builder
-
required .akka.cluster.ddata.OtherMessage data = 1;
- mergeData(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
required .akka.cluster.ddata.OtherMessage data = 2;
- mergeData(MessageFormats.PersistentPayload) - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot.Builder
-
required .PersistentPayload data = 2;
- mergeDecrements(ReplicatedDataMessages.GCounter) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter.Builder
-
required .akka.cluster.ddata.GCounter decrements = 2;
- 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;
- mergeDisjointKeys(Set<A>, Map<A, VersionVector>, VersionVector, Map<A, VersionVector>) - Method in class akka.cluster.ddata.ORSet$
-
INTERNAL API
- mergeDisjointKeys(Set<A>, Map<A, VersionVector>, VersionVector, Map<A, VersionVector>) - Static method in class akka.cluster.ddata.ORSet
-
INTERNAL API
- MergedSourceLogic(SourceShape<T>, AtomicLong) - Constructor for class akka.stream.scaladsl.MergeHub.MergedSourceLogic
-
- mergeDwNotificationData(SystemMessageFormats.DeathWatchNotificationData) - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .DeathWatchNotificationData dwNotificationData = 7;
- mergeEnvelope(ReplicatorMessages.DataEnvelope) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry.Builder
-
required .akka.cluster.ddata.DataEnvelope envelope = 2;
- mergeEnvelope(ReplicatorMessages.DataEnvelope) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResult.Builder
-
optional .akka.cluster.ddata.DataEnvelope envelope = 1;
- mergeEnvelope(ReplicatorMessages.DataEnvelope) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write.Builder
-
required .akka.cluster.ddata.DataEnvelope envelope = 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;
- mergeFailedData(SystemMessageFormats.FailedData) - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .FailedData failedData = 6;
- mergeFailure(TestConductorProtocol.InjectFailure) - Method in class akka.remote.testconductor.TestConductorProtocol.Wrapper.Builder
-
optional .InjectFailure failure = 3;
- mergeFrom(Message) - Method in class akka.cluster.client.protobuf.msg.ClusterClientMessages.Contacts.Builder
-
- mergeFrom(ClusterClientMessages.Contacts) - Method in class akka.cluster.client.protobuf.msg.ClusterClientMessages.Contacts.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.client.protobuf.msg.ClusterClientMessages.Contacts.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.Flag.Builder
-
- mergeFrom(ReplicatedDataMessages.Flag) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.Flag.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.Flag.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Builder
-
- mergeFrom(ReplicatedDataMessages.GCounter) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry.Builder
-
- mergeFrom(ReplicatedDataMessages.GCounter.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
- mergeFrom(ReplicatedDataMessages.GSet) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
- mergeFrom(ReplicatedDataMessages.LWWMap) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry.Builder
-
- mergeFrom(ReplicatedDataMessages.LWWMap.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
- mergeFrom(ReplicatedDataMessages.LWWRegister) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
- mergeFrom(ReplicatedDataMessages.ORMap) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry.Builder
-
- mergeFrom(ReplicatedDataMessages.ORMap.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
- mergeFrom(ReplicatedDataMessages.ORMultiMap) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry.Builder
-
- mergeFrom(ReplicatedDataMessages.ORMultiMap.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
- mergeFrom(ReplicatedDataMessages.ORSet) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter.Builder
-
- mergeFrom(ReplicatedDataMessages.PNCounter) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
- mergeFrom(ReplicatedDataMessages.PNCounterMap) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry.Builder
-
- mergeFrom(ReplicatedDataMessages.PNCounterMap.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Builder
-
- mergeFrom(ReplicatedDataMessages.VersionVector) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry.Builder
-
- mergeFrom(ReplicatedDataMessages.VersionVector.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Address.Builder
-
- mergeFrom(ReplicatorMessages.Address) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Address.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Address.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed.Builder
-
- mergeFrom(ReplicatorMessages.Changed) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
- mergeFrom(ReplicatorMessages.DataEnvelope) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
- mergeFrom(ReplicatorMessages.DataEnvelope.PruningEntry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelope.Builder
-
- mergeFrom(ReplicatorMessages.DurableDataEnvelope) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelope.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelope.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Empty.Builder
-
- mergeFrom(ReplicatorMessages.Empty) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Empty.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Empty.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
- mergeFrom(ReplicatorMessages.Get) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure.Builder
-
- mergeFrom(ReplicatorMessages.GetFailure) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
- mergeFrom(ReplicatorMessages.GetSuccess) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
- mergeFrom(ReplicatorMessages.Gossip) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry.Builder
-
- mergeFrom(ReplicatorMessages.Gossip.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound.Builder
-
- mergeFrom(ReplicatorMessages.NotFound) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage.Builder
-
- mergeFrom(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Read.Builder
-
- mergeFrom(ReplicatorMessages.Read) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Read.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Read.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResult.Builder
-
- mergeFrom(ReplicatorMessages.ReadResult) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResult.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResult.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
- mergeFrom(ReplicatorMessages.Status) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry.Builder
-
- mergeFrom(ReplicatorMessages.Status.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet.Builder
-
- mergeFrom(ReplicatorMessages.StringGSet) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe.Builder
-
- mergeFrom(ReplicatorMessages.Subscribe) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress.Builder
-
- mergeFrom(ReplicatorMessages.UniqueAddress) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe.Builder
-
- mergeFrom(ReplicatorMessages.Unsubscribe) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write.Builder
-
- mergeFrom(ReplicatorMessages.Write) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write.Builder
-
- 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.SendToOneSubscriber.Builder
-
- mergeFrom(DistributedPubSubMessages.SendToOneSubscriber) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToOneSubscriber.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToOneSubscriber.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.cluster.sharding.protobuf.msg.ClusterShardingMessages.ActorRefMessage.Builder
-
- mergeFrom(ClusterShardingMessages.ActorRefMessage) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ActorRefMessage.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ActorRefMessage.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
- mergeFrom(ClusterShardingMessages.CoordinatorState) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry.Builder
-
- mergeFrom(ClusterShardingMessages.CoordinatorState.ShardEntry) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStarted.Builder
-
- mergeFrom(ClusterShardingMessages.EntityStarted) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStarted.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStarted.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState.Builder
-
- mergeFrom(ClusterShardingMessages.EntityState) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStopped.Builder
-
- mergeFrom(ClusterShardingMessages.EntityStopped) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStopped.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStopped.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome.Builder
-
- mergeFrom(ClusterShardingMessages.ShardHome) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated.Builder
-
- mergeFrom(ClusterShardingMessages.ShardHomeAllocated) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessage.Builder
-
- mergeFrom(ClusterShardingMessages.ShardIdMessage) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessage.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessage.Builder
-
- mergeFrom(Message) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats.Builder
-
- mergeFrom(ClusterShardingMessages.ShardStats) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats.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.AtomicWrite.Builder
-
- mergeFrom(MessageFormats.AtomicWrite) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
-
- mergeFrom(Message) - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot.Builder
-
- mergeFrom(MessageFormats.PersistentFSMSnapshot) - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot.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(Message) - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
-
- mergeFrom(MessageFormats.PersistentStateChangeEvent) - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
-
- mergeFrom(AckedReceiveBuffer<T>) - Method in class akka.remote.AckedReceiveBuffer
-
Merges two receive buffers.
- mergeFrom(Message) - Method in class akka.remote.ArteryControlFormats.Address.Builder
-
- mergeFrom(ArteryControlFormats.Address) - Method in class akka.remote.ArteryControlFormats.Address.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.ArteryControlFormats.Address.Builder
-
- mergeFrom(Message) - Method in class akka.remote.ArteryControlFormats.ArteryHeartbeatRsp.Builder
-
- mergeFrom(ArteryControlFormats.ArteryHeartbeatRsp) - Method in class akka.remote.ArteryControlFormats.ArteryHeartbeatRsp.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.ArteryControlFormats.ArteryHeartbeatRsp.Builder
-
- mergeFrom(Message) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
- mergeFrom(ArteryControlFormats.CompressionTableAdvertisement) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
- mergeFrom(ArteryControlFormats.UniqueAddress) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
required .UniqueAddress from = 1;
- mergeFrom(Message) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck.Builder
-
- mergeFrom(ArteryControlFormats.CompressionTableAdvertisementAck) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck.Builder
-
- mergeFrom(ArteryControlFormats.UniqueAddress) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck.Builder
-
required .UniqueAddress from = 1;
- mergeFrom(Message) - Method in class akka.remote.ArteryControlFormats.HandshakeReq.Builder
-
- mergeFrom(ArteryControlFormats.HandshakeReq) - Method in class akka.remote.ArteryControlFormats.HandshakeReq.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.ArteryControlFormats.HandshakeReq.Builder
-
- mergeFrom(ArteryControlFormats.UniqueAddress) - Method in class akka.remote.ArteryControlFormats.HandshakeReq.Builder
-
required .UniqueAddress from = 1;
- mergeFrom(Message) - Method in class akka.remote.ArteryControlFormats.MessageWithAddress.Builder
-
- mergeFrom(ArteryControlFormats.MessageWithAddress) - Method in class akka.remote.ArteryControlFormats.MessageWithAddress.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.ArteryControlFormats.MessageWithAddress.Builder
-
- mergeFrom(Message) - Method in class akka.remote.ArteryControlFormats.Quarantined.Builder
-
- mergeFrom(ArteryControlFormats.Quarantined) - Method in class akka.remote.ArteryControlFormats.Quarantined.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.ArteryControlFormats.Quarantined.Builder
-
- mergeFrom(ArteryControlFormats.UniqueAddress) - Method in class akka.remote.ArteryControlFormats.Quarantined.Builder
-
required .UniqueAddress from = 1;
- mergeFrom(Message) - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck.Builder
-
- mergeFrom(ArteryControlFormats.SystemMessageDeliveryAck) - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck.Builder
-
- mergeFrom(ArteryControlFormats.UniqueAddress) - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck.Builder
-
required .UniqueAddress from = 2;
- mergeFrom(Message) - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope.Builder
-
- mergeFrom(ArteryControlFormats.SystemMessageEnvelope) - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope.Builder
-
- mergeFrom(Message) - Method in class akka.remote.ArteryControlFormats.UniqueAddress.Builder
-
- mergeFrom(ArteryControlFormats.UniqueAddress) - Method in class akka.remote.ArteryControlFormats.UniqueAddress.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.ArteryControlFormats.UniqueAddress.Builder
-
- mergeFrom(Message) - Method in class akka.remote.ContainerFormats.ActorIdentity.Builder
-
- mergeFrom(ContainerFormats.ActorIdentity) - Method in class akka.remote.ContainerFormats.ActorIdentity.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.ContainerFormats.ActorIdentity.Builder
-
- mergeFrom(Message) - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
- mergeFrom(ContainerFormats.ActorInitializationException) - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
- mergeFrom(Message) - Method in class akka.remote.ContainerFormats.ActorRef.Builder
-
- mergeFrom(ContainerFormats.ActorRef) - Method in class akka.remote.ContainerFormats.ActorRef.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.ContainerFormats.ActorRef.Builder
-
- mergeFrom(Message) - Method in class akka.remote.ContainerFormats.Identify.Builder
-
- mergeFrom(ContainerFormats.Identify) - Method in class akka.remote.ContainerFormats.Identify.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.ContainerFormats.Identify.Builder
-
- mergeFrom(Message) - Method in class akka.remote.ContainerFormats.Option.Builder
-
- mergeFrom(ContainerFormats.Option) - Method in class akka.remote.ContainerFormats.Option.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.ContainerFormats.Option.Builder
-
- mergeFrom(Message) - Method in class akka.remote.ContainerFormats.Payload.Builder
-
- mergeFrom(ContainerFormats.Payload) - Method in class akka.remote.ContainerFormats.Payload.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.ContainerFormats.Payload.Builder
-
- 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.ContainerFormats.StackTraceElement.Builder
-
- mergeFrom(ContainerFormats.StackTraceElement) - Method in class akka.remote.ContainerFormats.StackTraceElement.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.ContainerFormats.StackTraceElement.Builder
-
- mergeFrom(Message) - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
- mergeFrom(ContainerFormats.Throwable) - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
- mergeFrom(Message) - Method in class akka.remote.ContainerFormats.WatcherHeartbeatResponse.Builder
-
- mergeFrom(ContainerFormats.WatcherHeartbeatResponse) - Method in class akka.remote.ContainerFormats.WatcherHeartbeatResponse.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.ContainerFormats.WatcherHeartbeatResponse.Builder
-
- mergeFrom(Message) - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData.Builder
-
- mergeFrom(SystemMessageFormats.DeathWatchNotificationData) - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData.Builder
-
- mergeFrom(Message) - Method in class akka.remote.SystemMessageFormats.FailedData.Builder
-
- mergeFrom(SystemMessageFormats.FailedData) - Method in class akka.remote.SystemMessageFormats.FailedData.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.SystemMessageFormats.FailedData.Builder
-
- mergeFrom(Message) - Method in class akka.remote.SystemMessageFormats.SuperviseData.Builder
-
- mergeFrom(SystemMessageFormats.SuperviseData) - Method in class akka.remote.SystemMessageFormats.SuperviseData.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.SystemMessageFormats.SuperviseData.Builder
-
- mergeFrom(Message) - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
- mergeFrom(SystemMessageFormats.SystemMessage) - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
- mergeFrom(Message) - Method in class akka.remote.SystemMessageFormats.WatchData.Builder
-
- mergeFrom(SystemMessageFormats.WatchData) - Method in class akka.remote.SystemMessageFormats.WatchData.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.SystemMessageFormats.WatchData.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
-
- mergeFrom(Message) - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet.Builder
-
- mergeFrom(TwoPhaseSetMessages.TwoPhaseSet) - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet.Builder
-
- mergeFrom(Message) - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2.Builder
-
- mergeFrom(TwoPhaseSetMessages.TwoPhaseSet2) - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2.Builder
-
- mergeFrom(Message) - Method in class docs.persistence.proto.FlightAppModels.SeatReserved.Builder
-
- mergeFrom(FlightAppModels.SeatReserved) - Method in class docs.persistence.proto.FlightAppModels.SeatReserved.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class docs.persistence.proto.FlightAppModels.SeatReserved.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;
- mergeGraph(Graph<SourceShape<U>, M>, boolean) - Static method in class akka.stream.impl.SubFlowImpl
-
- mergeGraph(Graph<SourceShape<U>, M>, boolean) - Static method in class akka.stream.scaladsl.Flow
-
- mergeGraph(Graph<SourceShape<U>, M>, boolean) - Method in interface akka.stream.scaladsl.FlowOps
-
- mergeGraph(Graph<SourceShape<U>, M>, boolean) - Static method in class akka.stream.scaladsl.Source
-
- 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;
- MergeHub - Class in akka.stream.javadsl
-
A MergeHub is a special streaming hub that is able to collect streamed elements from a dynamic set of
producers.
- MergeHub() - Constructor for class akka.stream.javadsl.MergeHub
-
- MergeHub<T> - Class in akka.stream.scaladsl
-
INTERNAL API
- MergeHub(int) - Constructor for class akka.stream.scaladsl.MergeHub
-
- MergeHub$ - Class in akka.stream.javadsl
-
A MergeHub is a special streaming hub that is able to collect streamed elements from a dynamic set of
producers.
- MergeHub$() - Constructor for class akka.stream.javadsl.MergeHub$
-
- MergeHub$ - Class in akka.stream.scaladsl
-
A MergeHub is a special streaming hub that is able to collect streamed elements from a dynamic set of
producers.
- MergeHub$() - Constructor for class akka.stream.scaladsl.MergeHub$
-
- MergeHub.InputState - Class in akka.stream.scaladsl
-
- MergeHub.MergedSourceLogic - Class in akka.stream.scaladsl
-
- MergeHub.ProducerFailed - Exception in akka.stream.scaladsl
-
- mergeIncrements(ReplicatedDataMessages.GCounter) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter.Builder
-
required .akka.cluster.ddata.GCounter increments = 1;
- mergeInstruction(WireFormats.AkkaControlMessage) - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
-
optional .AkkaControlMessage instruction = 2;
- mergeKey(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- mergeKey(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- mergeKey(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- mergeKey(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- mergeKey(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- mergeKey(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- mergeKey(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- mergeKeys(ReplicatedDataMessages.ORSet) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- mergeKeys(ReplicatedDataMessages.ORSet) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- mergeKeys(ReplicatedDataMessages.ORSet) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- mergeKeys(ReplicatedDataMessages.ORSet) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- mergeMat(Graph<SourceShape<T>, M>, Function2<Mat, M, M2>) - Method in class akka.stream.javadsl.Flow
-
Merge the given
Source
to this
Flow
, taking elements as they arrive from input streams,
picking randomly when several elements ready.
- mergeMat(Graph<SourceShape<T>, M>, Function2<Mat, M, M2>, boolean) - Method in class akka.stream.javadsl.Flow
-
Merge the given
Source
to this
Flow
, taking elements as they arrive from input streams,
picking randomly when several elements ready.
- mergeMat(Graph<SourceShape<T>, M>, Function2<Mat, M, M2>) - Method in class akka.stream.javadsl.Source
-
Merge the given
Source
to the current one, taking elements as they arrive from input streams,
picking randomly when several elements ready.
- mergeMat(Graph<SourceShape<U>, Mat2>, boolean, Function2<Mat, Mat2, Mat3>) - Static method in class akka.stream.scaladsl.Flow
-
- mergeMat(Graph<SourceShape<U>, Mat2>, boolean, Function2<Mat, Mat2, Mat3>) - Method in interface akka.stream.scaladsl.FlowOpsMat
-
Merge the given
Source
to this
Flow
, taking elements as they arrive from input streams,
picking randomly when several elements ready.
- mergeMat(Graph<SourceShape<U>, Mat2>, boolean, Function2<Mat, Mat2, Mat3>) - Static method in class akka.stream.scaladsl.Source
-
- mergeMat$default$2() - Static method in class akka.stream.scaladsl.Flow
-
- mergeMat$default$2() - Static method in class akka.stream.scaladsl.Source
-
- mergeMessage(WireFormats.SerializedMessage) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
-
required .SerializedMessage message = 2;
- mergeMessageId(ContainerFormats.Payload) - Method in class akka.remote.ContainerFormats.Identify.Builder
-
required .Payload messageId = 1;
- mergeNode(ReplicatorMessages.UniqueAddress) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry.Builder
-
required .akka.cluster.ddata.UniqueAddress node = 1;
- mergeNode(ReplicatorMessages.UniqueAddress) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
required .akka.cluster.ddata.UniqueAddress node = 2;
- mergeNode(ReplicatorMessages.UniqueAddress) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry.Builder
-
required .akka.cluster.ddata.UniqueAddress node = 1;
- 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;
- mergeOwnerAddress(ReplicatorMessages.UniqueAddress) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
required .akka.cluster.ddata.UniqueAddress ownerAddress = 2;
- 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(DistributedPubSubMessages.Payload) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToOneSubscriber.Builder
-
required .Payload payload = 1;
- 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;
- mergePreferred() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- MergePreferred - Class in akka.stream.javadsl
-
Merge several streams, taking elements as they arrive from input streams
(picking from preferred when several have elements ready).
- MergePreferred() - Constructor for class akka.stream.javadsl.MergePreferred
-
- MergePreferred<T> - Class in akka.stream.scaladsl
-
Merge several streams, taking elements as they arrive from input streams
(picking from preferred when several have elements ready).
- MergePreferred(int, boolean) - Constructor for class akka.stream.scaladsl.MergePreferred
-
- MergePreferred$ - Class in akka.stream.javadsl
-
Merge several streams, taking elements as they arrive from input streams
(picking from preferred when several have elements ready).
- MergePreferred$() - Constructor for class akka.stream.javadsl.MergePreferred$
-
- MergePreferred$ - Class in akka.stream.scaladsl
-
- MergePreferred$() - Constructor for class akka.stream.scaladsl.MergePreferred$
-
- MergePreferred.MergePreferredShape<T> - Class in akka.stream.scaladsl
-
- MergePreferredShape(int, FanInShape.Init<T>) - Constructor for class akka.stream.scaladsl.MergePreferred.MergePreferredShape
-
- MergePreferredShape(int, String) - Constructor for class akka.stream.scaladsl.MergePreferred.MergePreferredShape
-
- 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;
- mergeRef(ContainerFormats.ActorRef) - Method in class akka.remote.ContainerFormats.ActorIdentity.Builder
-
optional .ActorRef ref = 2;
- mergeRemovedAddress(ReplicatorMessages.UniqueAddress) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
required .akka.cluster.ddata.UniqueAddress removedAddress = 1;
- mergeRequest(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- mergeRequest(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- mergeRequest(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- mergeRequest(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- 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;
- mergeSorted(Graph<SourceShape<U>, M>, Ordering<U>) - Static method in class akka.stream.impl.SubFlowImpl
-
- mergeSorted(Graph<SourceShape<U>, M>, Comparator<U>) - Method in class akka.stream.javadsl.Flow
-
Merge the given
Source
to this
Flow
, taking elements as they arrive from input streams,
picking always the smallest of the available elements (waiting for one element from each side
to be available).
- mergeSorted(Graph<SourceShape<U>, M>, Comparator<U>) - Method in class akka.stream.javadsl.Source
-
Merge the given
Source
to this
Source
, taking elements as they arrive from input streams,
picking always the smallest of the available elements (waiting for one element from each side
to be available).
- mergeSorted(Graph<SourceShape<U>, M>, Comparator<U>) - Method in class akka.stream.javadsl.SubFlow
-
Merge the given
Source
to this
Flow
, taking elements as they arrive from input streams,
picking always the smallest of the available elements (waiting for one element from each side
to be available).
- mergeSorted(Graph<SourceShape<U>, M>, Comparator<U>) - Method in class akka.stream.javadsl.SubSource
-
Merge the given
Source
to this
Source
, taking elements as they arrive from input streams,
picking always the smallest of the available elements (waiting for one element from each side
to be available).
- mergeSorted(Graph<SourceShape<U>, M>, Ordering<U>) - Static method in class akka.stream.scaladsl.Flow
-
- mergeSorted(Graph<SourceShape<U>, M>, Ordering<U>) - Method in interface akka.stream.scaladsl.FlowOps
-
Merge the given
Source
to this
Flow
, taking elements as they arrive from input streams,
picking always the smallest of the available elements (waiting for one element from each side
to be available).
- MergeSorted<T> - Class in akka.stream.scaladsl
-
Merge two pre-sorted streams such that the resulting stream is sorted.
- MergeSorted(Ordering<T>) - Constructor for class akka.stream.scaladsl.MergeSorted
-
- mergeSorted(Graph<SourceShape<U>, M>, Ordering<U>) - Static method in class akka.stream.scaladsl.Source
-
- mergeSortedGraph(Graph<SourceShape<U>, M>, Ordering<U>) - Static method in class akka.stream.impl.SubFlowImpl
-
- mergeSortedGraph(Graph<SourceShape<U>, M>, Ordering<U>) - Static method in class akka.stream.scaladsl.Flow
-
- mergeSortedGraph(Graph<SourceShape<U>, M>, Ordering<U>) - Method in interface akka.stream.scaladsl.FlowOps
-
- mergeSortedGraph(Graph<SourceShape<U>, M>, Ordering<U>) - Static method in class akka.stream.scaladsl.Source
-
- mergeSortedMat(Graph<SourceShape<U>, Mat2>, Comparator<U>, Function2<Mat, Mat2, Mat3>) - Method in class akka.stream.javadsl.Flow
-
Merge the given
Source
to this
Flow
, taking elements as they arrive from input streams,
picking always the smallest of the available elements (waiting for one element from each side
to be available).
- mergeSortedMat(Graph<SourceShape<U>, Mat2>, Comparator<U>, Function2<Mat, Mat2, Mat3>) - Method in class akka.stream.javadsl.Source
-
Merge the given
Source
to this
Source
, taking elements as they arrive from input streams,
picking always the smallest of the available elements (waiting for one element from each side
to be available).
- mergeSortedMat(Graph<SourceShape<U>, Mat2>, Function2<Mat, Mat2, Mat3>, Ordering<U>) - Static method in class akka.stream.scaladsl.Flow
-
- mergeSortedMat(Graph<SourceShape<U>, Mat2>, Function2<Mat, Mat2, Mat3>, Ordering<U>) - Method in interface akka.stream.scaladsl.FlowOpsMat
-
Merge the given
Source
to this
Flow
, taking elements as they arrive from input streams,
picking always the smallest of the available elements (waiting for one element from each side
to be available).
- mergeSortedMat(Graph<SourceShape<U>, Mat2>, Function2<Mat, Mat2, Mat3>, Ordering<U>) - Static method in class akka.stream.scaladsl.Source
-
- mergeState(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
required .akka.cluster.ddata.OtherMessage state = 3;
- mergeSubstreams() - Static method in class akka.stream.impl.SubFlowImpl
-
- mergeSubstreams() - Method in class akka.stream.javadsl.SubFlow
-
Flatten the sub-flows back into the super-flow by performing a merge
without parallelism limit (i.e.
- mergeSubstreams() - Method in class akka.stream.javadsl.SubSource
-
Flatten the sub-flows back into the super-source by performing a merge
without parallelism limit (i.e.
- mergeSubstreams() - Method in interface akka.stream.scaladsl.SubFlow
-
Flatten the sub-flows back into the super-flow by performing a merge
without parallelism limit (i.e.
- mergeSubstreamsWithParallelism(int) - Method in class akka.stream.impl.SubFlowImpl
-
- mergeSubstreamsWithParallelism(int) - Method in class akka.stream.javadsl.SubFlow
-
Flatten the sub-flows back into the super-flow by performing a merge
with the given parallelism limit.
- mergeSubstreamsWithParallelism(int) - Method in class akka.stream.javadsl.SubSource
-
Flatten the sub-flows back into the super-source by performing a merge
with the given parallelism limit.
- mergeSubstreamsWithParallelism(int) - Method in interface akka.stream.scaladsl.SubFlow
-
Flatten the sub-flows back into the super-flow by performing a merge
with the given parallelism limit.
- mergeSuperviseData(SystemMessageFormats.SuperviseData) - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .SuperviseData superviseData = 5;
- 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;
- mergeTo(ArteryControlFormats.Address) - Method in class akka.remote.ArteryControlFormats.HandshakeReq.Builder
-
required .Address to = 2;
- mergeTo(ArteryControlFormats.UniqueAddress) - Method in class akka.remote.ArteryControlFormats.Quarantined.Builder
-
required .UniqueAddress to = 2;
- mergeValue(ReplicatedDataMessages.LWWRegister) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry.Builder
-
required .akka.cluster.ddata.LWWRegister value = 2;
- mergeValue(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry.Builder
-
required .akka.cluster.ddata.OtherMessage value = 2;
- mergeValue(ReplicatedDataMessages.ORSet) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry.Builder
-
required .akka.cluster.ddata.ORSet value = 2;
- mergeValue(ReplicatedDataMessages.PNCounter) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry.Builder
-
required .akka.cluster.ddata.PNCounter value = 2;
- mergeValue(ContainerFormats.Payload) - Method in class akka.remote.ContainerFormats.Option.Builder
-
optional .Payload value = 1;
- 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;
- mergeVvector(ReplicatedDataMessages.VersionVector) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
required .akka.cluster.ddata.VersionVector vvector = 1;
- mergeWatchData(SystemMessageFormats.WatchData) - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .WatchData watchData = 2;
- mergeWatchee(ContainerFormats.ActorRef) - Method in class akka.remote.SystemMessageFormats.WatchData.Builder
-
required .ActorRef watchee = 1;
- mergeWatcher(ContainerFormats.ActorRef) - Method in class akka.remote.SystemMessageFormats.WatchData.Builder
-
required .ActorRef watcher = 2;
- 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
-
- 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(String) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- message(String) - Static method in class akka.persistence.journal.JournalSpec
-
- message() - Method in class akka.persistence.JournalProtocol.LoopMessageSuccess
-
- message() - Method in class akka.persistence.JournalProtocol.WriteMessageFailure
-
- message() - Method in class akka.persistence.JournalProtocol.WriteMessageRejected
-
- Message - Interface in akka.persistence.serialization
-
Marker trait for all protobuf-serializable messages in akka.persistence
.
- message(String) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- message() - Method in interface akka.remote.artery.InboundEnvelope
-
- message() - Method in interface akka.remote.artery.OutboundEnvelope
-
- message() - Method in class akka.remote.artery.ReusableInboundEnvelope
-
- message() - Method in class akka.remote.artery.ReusableOutboundEnvelope
-
- message() - Method in class akka.remote.artery.SystemMessageDelivery.SystemMessageEnvelope
-
- message() - Method in class akka.remote.EndpointManager.Send
-
- Message(InternalActorRef, Address, WireFormats.SerializedMessage, OptionVal<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() - Static method in class akka.testkit.CustomEventFilter
-
- message() - Static method in class akka.testkit.DeadLettersFilter
-
- 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.patterns.Restarter
-
- message(ActorContext<T>, T) - Method in class akka.typed.ScalaDSL.And
-
- message(ActorContext<T>, T) - Method in class akka.typed.ScalaDSL.Deferred
-
- 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.ArteryControlFormats.SystemMessageEnvelope
-
- MESSAGE_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.ActorInitializationException
-
- MESSAGE_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.Throwable
-
- MESSAGE_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.RemoteEnvelope
-
- MESSAGE_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.SerializedMessage
-
- MessageBuffer - Class in akka.util
-
A non thread safe mutable message buffer that can be used to buffer messages inside actors.
- MessageBuffer$ - Class in akka.util
-
- MessageBuffer$() - Constructor for class akka.util.MessageBuffer$
-
- MessageBufferMap<I> - Class in akka.util
-
A non thread safe mutable message buffer map that can be used to buffer messages inside actors.
- MessageBufferMap() - Constructor for class akka.util.MessageBufferMap
-
- messageBuffers() - Method in class akka.cluster.sharding.Shard
-
- messageClass() - Method in class akka.testkit.DeadLettersFilter
-
- messageClassName(Object) - Method in class akka.event.Logging$
-
- messageClassName(Object) - Static method in class akka.event.Logging
-
- 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
-
- messageCount() - Method in class akka.routing.OptimalSizeExploringResizer.ResizeRecord
-
- messageCount(int) - Method in class akka.typed.internal.ActorCell$
-
- messageCount(int) - Static method in class akka.typed.internal.ActorCell
-
- 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.remote.artery
-
INTERNAL API
- MessageDispatcher(ExtendedActorSystem, RemoteActorRefProvider) - Constructor for class akka.remote.artery.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
-
- MessageDispatcherConfigurator - Class in akka.typed.internal
-
Base class to be used for hooking in new dispatchers into Dispatchers.
- MessageDispatcherConfigurator(Config, DispatcherPrerequisites) - Constructor for class akka.typed.internal.MessageDispatcherConfigurator
-
- messageDispatcherSink() - Method in class akka.remote.artery.ArteryTransport
-
- 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.AtomicWrite - Class in akka.persistence.serialization
-
Protobuf type AtomicWrite
- MessageFormats.AtomicWrite.Builder - Class in akka.persistence.serialization
-
Protobuf type AtomicWrite
- MessageFormats.AtomicWriteOrBuilder - Interface in akka.persistence.serialization
-
- MessageFormats.PersistentFSMSnapshot - Class in akka.persistence.serialization
-
Protobuf type PersistentFSMSnapshot
- MessageFormats.PersistentFSMSnapshot.Builder - Class in akka.persistence.serialization
-
Protobuf type PersistentFSMSnapshot
- MessageFormats.PersistentFSMSnapshotOrBuilder - 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
-
- MessageFormats.PersistentStateChangeEvent - Class in akka.persistence.serialization
-
Protobuf type PersistentStateChangeEvent
- MessageFormats.PersistentStateChangeEvent.Builder - Class in akka.persistence.serialization
-
Protobuf type PersistentStateChangeEvent
- MessageFormats.PersistentStateChangeEventOrBuilder - Interface in akka.persistence.serialization
-
- MessageHandler(EnvelopeBufferPool) - Constructor for class akka.remote.artery.AeronSource.MessageHandler
-
- messageId() - Method in class akka.actor.Identify
-
- MESSAGEID_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.Identify
-
- MESSAGEMANIFEST_FIELD_NUMBER - Static variable in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage
-
- MESSAGEMANIFEST_FIELD_NUMBER - Static variable in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload
-
- MESSAGEMANIFEST_FIELD_NUMBER - Static variable in class akka.remote.ArteryControlFormats.SystemMessageEnvelope
-
- MESSAGEMANIFEST_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.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
-
Deprecated.
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() - Method in class akka.remote.artery.AeronSource.MessageHandler
-
- messageReceived(InboundEnvelope, int, long) - Method in class akka.remote.artery.RemoteInstruments
-
- 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 class akka.persistence.journal.inmem.InmemJournal
-
- messages() - Method in interface akka.persistence.journal.inmem.InmemMessages
-
- messages() - Method in class akka.persistence.JournalProtocol.WriteMessages
-
- messageSent(OutboundEnvelope, int, long) - Method in class akka.remote.artery.RemoteInstruments
-
- 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$
-
- MessageSerializer.SerializationException - Exception in akka.remote
-
- messagesPerResize() - Method in class akka.routing.DefaultResizer
-
- metadata() - Method in class akka.persistence.DeleteSnapshotFailure
-
- metadata() - Method in class akka.persistence.DeleteSnapshotSuccess
-
- 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
-
- metadata() - Method in class akka.remote.artery.FlightRecorderReader.RichEntry
-
- MetadataContainerAndLiteralSectionOffset() - Method in class akka.remote.artery.EnvelopeBuffer$
-
- MetadataContainerAndLiteralSectionOffset() - Static method in class akka.remote.artery.EnvelopeBuffer
-
- MetadataPresentFlag() - Method in class akka.remote.artery.EnvelopeBuffer$
-
- MetadataPresentFlag() - Static method in class akka.remote.artery.EnvelopeBuffer
-
- 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
-
- METHODNAME_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.StackTraceElement
-
- Metric - Class in akka.cluster
-
- Metric(String, Number, Option<EWMA>) - Constructor for class akka.cluster.Metric
-
Deprecated.
- 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
-
Deprecated.
- Metric$ - Class in akka.cluster
-
- Metric$() - Constructor for class akka.cluster.Metric$
-
Deprecated.
- 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
-
Deprecated.
- 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
-
Deprecated.
- metrics() - Method in class akka.cluster.SigarMetricsCollector
-
Deprecated.
- 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
-
Deprecated.
- MetricsCollector - Interface in akka.cluster.metrics
-
Metrics sampler.
- MetricsCollector - Interface in akka.cluster
-
- MetricsCollector$ - Class in akka.cluster.metrics
-
INTERNAL API
- MetricsCollector$() - Constructor for class akka.cluster.metrics.MetricsCollector$
-
- MetricsCollector$ - Class in akka.cluster
-
- MetricsCollector$() - Constructor for class akka.cluster.MetricsCollector$
-
Deprecated.
- 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
-
Deprecated.
- metricsSelector() - Method in class akka.cluster.routing.AdaptiveLoadBalancingPool
-
Deprecated.
- metricsSelector() - Method in class akka.cluster.routing.AdaptiveLoadBalancingRoutingLogic
-
Deprecated.
- MetricsSelector - Interface in akka.cluster.routing
-
- 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$
-
Deprecated.
- metricsTask() - Method in class akka.cluster.ClusterMetricsCollector
-
Start periodic metrics collection
- MetricsTick$() - Constructor for class akka.cluster.InternalClusterAction.MetricsTick$
-
- min(Ordering<B>) - Static method in class akka.util.ByteIterator
-
- min(Ordering<B>) - Static method in class akka.util.ByteString
-
- min(Ordering<B>) - Static method in class akka.util.CompactByteString
-
- minBackoff() - Method in class akka.pattern.BackoffOptionsImpl
-
- MinBufferSize() - Method in class akka.stream.impl.io.compression.DeflateCompressor$
-
- MinBufferSize() - Static method in class akka.stream.impl.io.compression.DeflateCompressor
-
- minBy(Function1<A, B>, Ordering<B>) - Static method in class akka.util.ByteIterator
-
- minBy(Function1<A, B>, Ordering<B>) - Static method in class akka.util.ByteString
-
- minBy(Function1<A, B>, Ordering<B>) - Static method in class akka.util.CompactByteString
-
- MinimalActorRef - Interface in akka.actor
-
Trait for ActorRef implementations where all methods contain default stubs.
- minMembers() - Method in class akka.cluster.sharding.ShardCoordinator
-
- MinNrOfMembers() - Method in class akka.cluster.ClusterSettings
-
- MinNrOfMembersOfRole() - Method in class akka.cluster.ClusterSettings
-
- minSequenceNr() - Method in class akka.persistence.SnapshotSelectionCriteria
-
- minStdDeviation() - Method in class akka.remote.PhiAccrualFailureDetector
-
- minTimestamp() - Method in class akka.persistence.SnapshotSelectionCriteria
-
- MiscMessageSerializer - Class in akka.remote.serialization
-
- MiscMessageSerializer(ExtendedActorSystem) - Constructor for class akka.remote.serialization.MiscMessageSerializer
-
- 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
-
Deprecated.
- 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
-
- MixMetricsSelector$() - Constructor for class akka.cluster.routing.MixMetricsSelector$
-
Deprecated.
- 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
-
- MixMetricsSelectorBase(IndexedSeq<CapacityMetricsSelector>) - Constructor for class akka.cluster.routing.MixMetricsSelectorBase
-
Deprecated.
- MixMetricsSelectorBase(Iterable<CapacityMetricsSelector>) - Constructor for class akka.cluster.routing.MixMetricsSelectorBase
-
Deprecated.
Java API: construct a mix-selector from a sequence of selectors
- mkChild(Props, String) - Method in class akka.actor.ActorDSL.Extension
-
- mkFlag(boolean) - Method in class akka.persistence.CapabilityFlag$
-
- mkFlag(boolean) - Static method in class akka.persistence.CapabilityFlag
-
- mkKey(ActorRef) - Method in class akka.cluster.pubsub.DistributedPubSubMediator.Internal$
-
- mkKey(ActorPath) - Method in class akka.cluster.pubsub.DistributedPubSubMediator.Internal$
-
- 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
-
- mkString(String, String, String) - Static method in class akka.util.ByteIterator
-
- mkString(String) - Static method in class akka.util.ByteIterator
-
- mkString() - Static method in class akka.util.ByteIterator
-
- mkString(String, String, String) - Static method in class akka.util.ByteString
-
- mkString(String) - Static method in class akka.util.ByteString
-
- mkString() - Static method in class akka.util.ByteString
-
- mkString(String, String, String) - Static method in class akka.util.CompactByteString
-
- mkString(String) - Static method in class akka.util.CompactByteString
-
- mkString() - Static method in class akka.util.CompactByteString
-
- 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
-
- mode() - Method in class akka.stream.impl.Throttle
-
- mode() - Method in class akka.stream.StreamSubscriptionTimeoutSettings
-
- modify() - Method in class akka.cluster.ddata.Replicator.Update
-
- ModifyFailure(Key<A>, String, Throwable, Option<Object>) - Constructor for class akka.cluster.ddata.Replicator.ModifyFailure
-
- ModifyFailure$() - Constructor for class akka.cluster.ddata.Replicator.ModifyFailure$
-
- module() - Static method in class akka.remote.artery.AeronSink
-
- module() - Static method in class akka.remote.artery.AeronSource
-
- module() - Static method in class akka.remote.artery.Decoder
-
- module() - Static method in class akka.remote.artery.Encoder
-
- module() - Static method in class akka.remote.artery.InboundControlJunction
-
- module() - Static method in class akka.remote.artery.OutboundControlJunction
-
- module() - Static method in class akka.remote.artery.OutboundHandshake
-
- module() - Static method in class akka.remote.artery.SendQueue
-
- module() - Static method in class akka.remote.artery.SystemMessageDelivery
-
- module() - Method in class akka.stream.Fusing.FusedGraph
-
- module() - Method in interface akka.stream.Graph
-
INTERNAL API.
- module() - Static method in class akka.stream.impl.EmptySource
-
- module() - Static method in class akka.stream.impl.fusing.Batch
-
- module() - Static method in class akka.stream.impl.fusing.Buffer
-
- module() - Static method in class akka.stream.impl.fusing.Collect
-
- module() - Static method in class akka.stream.impl.fusing.Drop
-
- module() - Static method in class akka.stream.impl.fusing.DropWhile
-
- module() - Static method in class akka.stream.impl.fusing.Filter
-
- module() - Static method in class akka.stream.impl.fusing.Fold
-
- module() - Static method in class akka.stream.impl.fusing.Grouped
-
- module() - Static method in class akka.stream.impl.fusing.Intersperse
-
- module() - Static method in class akka.stream.impl.fusing.LimitWeighted
-
- module() - Static method in class akka.stream.impl.fusing.Log
-
- module() - Static method in class akka.stream.impl.fusing.Map
-
- module() - Static method in class akka.stream.impl.fusing.MapAsync
-
- module() - Static method in class akka.stream.impl.fusing.MapAsyncUnordered
-
- module() - Static method in class akka.stream.impl.fusing.MapError
-
- module() - Static method in class akka.stream.impl.fusing.Recover
-
- module() - Static method in class akka.stream.impl.fusing.RecoverWith
-
- module() - Static method in class akka.stream.impl.fusing.Scan
-
- module() - Static method in class akka.stream.impl.fusing.ScanAsync
-
- module() - Static method in class akka.stream.impl.fusing.Sliding
-
- module() - Static method in class akka.stream.impl.fusing.Split
-
- module() - Static method in class akka.stream.impl.fusing.SubSink
-
- module() - Static method in class akka.stream.impl.fusing.SubSource
-
- module() - Static method in class akka.stream.impl.fusing.Take
-
- module() - Static method in class akka.stream.impl.fusing.TakeWhile
-
- module() - Static method in class akka.stream.impl.io.ByteStringParser
-
- module() - Static method in class akka.stream.impl.io.compression.DeflateDecompressorBase
-
- module() - Static method in class akka.stream.impl.io.compression.GzipDecompressor
-
- module() - Static method in class akka.stream.impl.io.ConnectionSourceStage
-
- module() - Static method in class akka.stream.impl.io.InputStreamSinkStage
-
- module() - Static method in class akka.stream.impl.io.OutgoingConnectionStage
-
- module() - Static method in class akka.stream.impl.io.OutputStreamSourceStage
-
- module() - Static method in class akka.stream.impl.LazySource
-
- module() - Static method in class akka.stream.impl.QueueSink
-
- module() - Static method in class akka.stream.impl.QueueSource
-
- module() - Method in class akka.stream.impl.StreamLayout.Atomic
-
- module() - Method in class akka.stream.javadsl.BidiFlow
-
- module() - Method in class akka.stream.javadsl.Flow
-
- module() - Static method in class akka.stream.javadsl.RunnableGraph
-
- module() - Method in class akka.stream.javadsl.Sink
-
- module() - Method in class akka.stream.javadsl.Source
-
- module() - Static method in class akka.stream.scaladsl.Balance
-
- module() - Method in class akka.stream.scaladsl.BidiFlow
-
- module() - Static method in class akka.stream.scaladsl.Broadcast
-
- module() - Static method in class akka.stream.scaladsl.BroadcastHub
-
- module() - Static method in class akka.stream.scaladsl.Concat
-
- module() - Method in class akka.stream.scaladsl.Flow
-
- module() - Method in class akka.stream.scaladsl.GraphApply.GraphImpl
-
- module() - Method in class akka.stream.scaladsl.GraphDSL.Builder
-
- module() - Static method in class akka.stream.scaladsl.Interleave
-
- module() - Static method in class akka.stream.scaladsl.Merge
-
- module() - Static method in class akka.stream.scaladsl.MergeHub
-
- module() - Static method in class akka.stream.scaladsl.MergePreferred
-
- module() - Static method in class akka.stream.scaladsl.OrElse
-
- module() - Static method in class akka.stream.scaladsl.Partition
-
- module() - Method in class akka.stream.scaladsl.RunnableGraph
-
- module() - Method in class akka.stream.scaladsl.Sink
-
- module() - Method in class akka.stream.scaladsl.Source
-
- module() - Static method in class akka.stream.scaladsl.Unzip
-
- module() - Static method in class akka.stream.scaladsl.Zip
-
- module() - Static method in class akka.stream.scaladsl.ZipN
-
- module() - Static method in class akka.stream.scaladsl.ZipWithN
-
- module() - Method in class akka.stream.stage.GraphStageWithMaterializedValue
-
- module() - Static method in class akka.stream.testkit.TestSinkStage
-
- module() - Static method in class akka.stream.testkit.TestSourceStage
-
- 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.ActorPaths$
-
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.BootstrapSetup$
-
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.Children$
-
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.ProviderSelection$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ProviderSelection.Cluster$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ProviderSelection.Local$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.actor.ProviderSelection.Remote$
-
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.setup.ActorSystemSetup$
-
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.ClusterClients$
-
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.ClusterClientUnreachable$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.client.ClusterClientUp$
-
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.client.ContactPointAdded$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.client.ContactPointRemoved$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.client.ContactPoints$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.client.GetClusterClients$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.client.GetContactPoints$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.client.SubscribeClusterClients$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.client.SubscribeContactPoints$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.client.UnsubscribeClusterClients$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.client.UnsubscribeContactPoints$
-
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$
-
Deprecated.
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.MemberJoined$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ClusterEvent.MemberLeft$
-
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.MemberWeaklyUp$
-
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.ddata.DistributedData$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.DurableStore$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.DurableStore.LoadAll$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.DurableStore.LoadAllCompleted$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.DurableStore.LoadData$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.DurableStore.Store$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.DurableStore.StoreReply$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Flag$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.FlagKey$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.GCounter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.GCounterKey$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.GSet$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.GSetKey$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Key$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.LmdbDurableStore$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.LWWMap$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.LWWMapKey$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.LWWRegister$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.LWWRegisterKey$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.ManyVersionVector$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.OneVersionVector$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.ORMap$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.ORMapKey$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.ORMultiMap$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.ORMultiMapKey$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.ORSet$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.ORSetKey$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.PNCounter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.PNCounterKey$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.PNCounterMap$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.PNCounterMapKey$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.protobuf.OtherMessageComparator$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.PruningState$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.PruningState.PruningInitialized$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.PruningState.PruningPerformed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.ReadAggregator$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.ReadWriteAggregator$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.ReadWriteAggregator.SendToSecondary$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.Changed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.DataDeleted$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.Delete$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.DeleteSuccess$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.FlushChanges$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.Get$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.GetFailure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.GetKeyIds$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.GetKeyIdsResult$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.GetReplicaCount$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.GetSuccess$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.Internal$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.ModifyFailure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.NotFound$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.ReadAll$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.ReadFrom$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.ReadLocal$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.ReadMajority$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.ReplicaCount$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.ReplicationDeleteFailure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.StoreFailure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.Subscribe$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.Unsubscribe$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.Update$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.UpdateSuccess$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.UpdateTimeout$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.WriteAll$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.WriteLocal$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.WriteMajority$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.Replicator.WriteTo$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.ReplicatorSettings$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.VersionVector$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.VersionVector.After$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.VersionVector.Before$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.VersionVector.Concurrent$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.VersionVector.Same$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.VersionVector.Timestamp$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.ddata.WriteAggregator$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.DowningProvider$
-
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.MemberStatus.WeaklyUp$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.Metric$
-
Deprecated.
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$
-
Deprecated.
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$
-
Deprecated.
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$
-
Deprecated.
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.routing.AdaptiveLoadBalancingPool$
-
Deprecated.
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.routing.AdaptiveLoadBalancingRoutingLogic$
-
Deprecated.
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$
-
Deprecated.
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.routing.HeapMetricsSelector$
-
Deprecated.
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.routing.MetricsSelector$
-
Deprecated.
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.routing.MixMetricsSelector$
-
Deprecated.
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.routing.SystemLoadAverageMetricsSelector$
-
Deprecated.
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.ClusterShardingGuardian.StartProxy$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.ClusterShardingSettings$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.EntityRecoveryStrategy$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.RemoveInternalClusterShardingData$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.RemoveInternalClusterShardingData.RemoveOnePersistenceId$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.RemoveInternalClusterShardingData.RemoveOnePersistenceId$.Removals$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.RemoveInternalClusterShardingData.RemoveOnePersistenceId$.Result$
-
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.CurrentShardState$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.Shard.EntityStarted$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.Shard.EntityStopped$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.Shard.GetCurrentShardState$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.Shard.GetShardStats$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.Shard.RestartEntities$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.Shard.RestartEntity$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.Shard.ShardStats$
-
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.ShardRegion$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.ShardRegion.ClusterShardingStats$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.ShardRegion.CurrentRegions$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.ShardRegion.CurrentShardRegionState$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.ShardRegion.GetClusterShardingStats$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.ShardRegion.GetCurrentRegions$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.ShardRegion.GetShardRegionState$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.ShardRegion.GetShardRegionStats$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.ShardRegion.GracefulShutdown$
-
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.sharding.ShardRegion.ShardInitialized$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.ShardRegion.ShardRegionStats$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.sharding.ShardRegion.ShardState$
-
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.ClusterSingletonManager.Internal$
-
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$
-
Deprecated.
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.StandardMetrics.Cpu$
-
Deprecated.
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.cluster.StandardMetrics.HeapMemory$
-
Deprecated.
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.circuitbreaker.AskeableWithCircuitBreakerActor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.circuitbreaker.AskeableWithCircuitBreakerActorSelection$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.circuitbreaker.CircuitBreakerAwareFuture$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.circuitbreaker.CircuitBreakerProxy$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitBreakerInternalEvents$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitBreakerPropsBuilder$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitBreakerStateData$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitClosed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitHalfOpen$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitOpen$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.circuitbreaker.CircuitBreakerProxy.CircuitOpenFailure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.circuitbreaker.CircuitBreakerProxy.Closed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.circuitbreaker.CircuitBreakerProxy.HalfOpen$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.circuitbreaker.CircuitBreakerProxy.Open$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.circuitbreaker.CircuitBreakerProxy.Passthrough$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.circuitbreaker.CircuitBreakerProxy.TellOnly$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.circuitbreaker.Implicits$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in exception akka.contrib.circuitbreaker.OpenCircuitException$
-
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.ReceivePipeline$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.pattern.ReceivePipeline.Done$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.pattern.ReceivePipeline.HandledCompletely$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.pattern.ReceivePipeline.Inner$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.pattern.ReceivePipeline.InnerAndAfter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.contrib.pattern.ReceivePipeline.Undefined$
-
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.Done$
-
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.LogEvent$
-
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.StdOutLogger$
-
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.LogMarker$
-
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.NoMarkerLogging$
-
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.DirectByteBufferPool$
-
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.IpVersionSelector$
-
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.TcpOutgoingConnection$
-
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.tuple.Tuple10$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple11$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple12$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple13$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple14$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple15$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple16$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple17$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple18$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple19$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple20$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple21$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple22$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple3$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple4$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple5$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple6$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple7$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple8$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.japi.tuple.Tuple9$
-
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$
-
Deprecated.
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.NotUsed$
-
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.AskPromiseRef$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.AutoReset$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.Backoff$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.BackoffOptionsImpl$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.BackoffSupervisor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.BackoffSupervisor.CurrentChild$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.BackoffSupervisor.GetCurrentChild$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.BackoffSupervisor.GetRestartCount$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.BackoffSupervisor.Reset$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.BackoffSupervisor.ResetRestartCount$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.BackoffSupervisor.RestartCount$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.BackoffSupervisor.StartChild$
-
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.ExplicitlyAskableActorRef$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.ExplicitlyAskableActorSelection$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.FutureRef$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.ManualReset$
-
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.PatternsCS$
-
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.pattern.PromiseRef$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.RestartImpliesFailure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.pattern.StopImpliesFailure$
-
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.AtomicWrite$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.CapabilityFlag$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.DeleteMessagesFailure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.DeleteMessagesSuccess$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.DeleteSnapshotFailure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.DeleteSnapshotsFailure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.DeleteSnapshotsSuccess$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.DeleteSnapshotSuccess$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.DiscardToDeadLetterStrategy$
-
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.RecoveryTick$
-
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.fsm.AbstractPersistentFSMBase$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.$minus$greater$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.CurrentState$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.Event$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.Failure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.LogEntry$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.Normal$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.NullFunction$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.PersistentFSMSnapshot$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.Shutdown$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.State$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.StateChangeEvent$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.StateTimeout$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.StopEvent$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.SubscribeTransitionCallBack$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.TimeoutMarker$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.Timer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.Transition$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.UnsubscribeTransitionCallBack$
-
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.InitTimeout$
-
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.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.EmptyEventSeq$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.EventAdapters$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.EventAdapters.CombinedReadEventAdapter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.EventSeq$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.EventsSeq$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.IdentityEventAdapter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.IdentityEventAdapters$
-
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.LeveldbJournal$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.leveldb.LeveldbJournal.CurrentPersistenceIds$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.leveldb.LeveldbJournal.EventAppended$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.leveldb.LeveldbJournal.PersistenceIdAdded$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.leveldb.LeveldbJournal.ReplayedTaggedMessage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.leveldb.LeveldbJournal.ReplayTaggedMessages$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.leveldb.LeveldbJournal.SubscribeAllPersistenceIds$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.leveldb.LeveldbJournal.SubscribePersistenceId$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.leveldb.LeveldbJournal.SubscribeTag$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.leveldb.LeveldbJournal.TaggedEventAppended$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.leveldb.LeveldbStore$
-
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.journal.NoopReadEventAdapter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.NoopWriteEventAdapter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.PersistencePluginProxy$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.PersistencePluginProxy.TargetLocation$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.PersistencePluginProxyExtension$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.ReplayFilter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.ReplayFilter.Disabled$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.ReplayFilter.Fail$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.ReplayFilter.RepairByDiscardOld$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.ReplayFilter.Warn$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.SingleEventSeq$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.journal.Tagged$
-
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.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.RecoverySuccess$
-
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.WriteMessageFailure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.JournalProtocol.WriteMessageRejected$
-
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.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$
-
Deprecated.
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.PersistentView.ScheduledUpdate$
-
Deprecated.
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.query.EventEnvelope$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.query.EventEnvelope2$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.query.journal.leveldb.EventsByPersistenceIdPublisher$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.query.journal.leveldb.EventsByPersistenceIdPublisher.Continue$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.query.journal.leveldb.EventsByTagPublisher$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.query.journal.leveldb.EventsByTagPublisher.Continue$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.query.journal.leveldb.javadsl.LeveldbReadJournal$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.query.journal.leveldb.scaladsl.LeveldbReadJournal$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.query.NoOffset$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.query.Offset$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.query.PersistenceQuery$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.query.PersistenceQuery.PluginHolder$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.query.Sequence$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.query.TimeBasedUUID$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.Recovery$
-
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.RecoveryPermitter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.RecoveryPermitter.RecoveryPermitGranted$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.RecoveryPermitter.RequestRecoveryPermit$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.RecoveryPermitter.ReturnRecoveryPermit$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.ReplyToStrategy$
-
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.scalatest.MayVerb$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.persistence.scalatest.MayVerb.TestCanceledByFailure$
-
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.LoadSnapshotFailed$
-
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.ThrowOverflowExceptionStrategy$
-
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.artery.ActorSystemTerminating$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.ActorSystemTerminatingAck$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.AeronSink$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.AeronSource$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.ArterySettings$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.ArterySettings.Compression$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.ArteryTransport$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.ArteryTransport.InboundStreamMatValues$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in exception akka.remote.artery.ArteryTransport.ShutdownSignal$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in exception akka.remote.artery.ArteryTransport.ShuttingDown$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.Association$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.Association.DisabledQueueWrapper$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.Association.LazyQueueWrapper$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.Association.OutboundStreamMatValues$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.Association.QueueWrapperImpl$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.AssociationState$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.AssociationState.QuarantinedTimestamp$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.ByteFlag$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.CacheStatistics$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.compress.CompressionProtocol$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.compress.CompressionProtocol.ActorRefCompressionAdvertisement$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.compress.CompressionProtocol.ActorRefCompressionAdvertisementAck$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.compress.CompressionProtocol.ClassManifestCompressionAdvertisement$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.compress.CompressionProtocol.ClassManifestCompressionAdvertisementAck$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.compress.CompressionProtocol.Events$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.compress.CompressionTable$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.compress.DecompressionTable$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.compress.InboundCompression$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.compress.InboundCompression.State$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.compress.InboundCompressionsImpl$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.compress.NoInboundCompressions$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.compress.TopHeavyHitters$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.compress.TopHeavyHitters.HashCodeVal$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.Decoder$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.Encoder$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.EnvelopeBuffer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.FastHash$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.FlightRecorder$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.FlightRecorderDump$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.FlightRecorderEvents$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.FlightRecorderReader$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.FlightRecorderReader.Empty$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.FlightRecorderReader.Live$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.FlightRecorderReader.SectionParameters$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.FlightRecorderReader.Snapshot$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.FlushOnShutdown$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.FlushOnShutdown.Timeout$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.HeaderBuilder$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.IgnoreEventSink$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.ImmutableLongMap$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.InboundControlJunction$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.InboundControlJunction.Attach$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.InboundControlJunction.Dettach$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.InboundEnvelope$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.OutboundControlJunction$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.OutboundEnvelope$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.OutboundHandshake$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.OutboundHandshake.HandshakeReq$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.OutboundHandshake.HandshakeRsp$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.Quarantined$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.RemoteInstruments$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.RestartCounter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.RestartCounter.State$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.ReusableInboundEnvelope$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.ReusableOutboundEnvelope$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.RollingEventLogSection$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.Running$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.SendQueue$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.ShutDown$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.SnapshotInProgress$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.SystemMessageDelivery$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.SystemMessageDelivery.Ack$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.SystemMessageDelivery.ClearSystemMessageDelivery$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.SystemMessageDelivery.Nack$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.SystemMessageDelivery.SystemMessageEnvelope$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.TaskRunner$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.TaskRunner.Add$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.TaskRunner.Remove$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.TaskRunner.Shutdown$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.TestManagementCommands$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.TestManagementCommands.FailInboundStreamOnce$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.artery.TestState$
-
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.EndpointManager.WasGated$
-
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.TooLongIdle$
-
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.ArteryHeartbeat$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.RemoteWatcher.ArteryHeartbeatRsp$
-
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$
-
Deprecated.
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.ActorRefResolveThreadLocalCache$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.remote.serialization.ArteryMessageSerializer$
-
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.ThisActorSystemQuarantinedEvent$
-
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.HandshakeTimer$
-
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$.Both$
-
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$.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.remote.UniqueAddress$
-
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.DefaultOptimalSizeExploringResizer$
-
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.OptimalSizeExploringResizer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.OptimalSizeExploringResizer.ResizeRecord$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.routing.OptimalSizeExploringResizer.UnderUtilizationStreak$
-
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.Resizer$
-
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.BaseSerializer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.serialization.DisabledJavaSerializer$
-
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.serialization.SerializationSetup$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.serialization.SerializerDetails$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.AbruptTerminationException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.actor.AbstractActorPublisher$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.actor.AbstractActorSubscriber$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.actor.ActorPublisher$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.actor.ActorPublisher.Internal$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.actor.ActorPublisherImpl$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.actor.ActorPublisherMessage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.actor.ActorPublisherMessage.Cancel$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.actor.ActorPublisherMessage.Request$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.actor.ActorPublisherMessage.SubscriptionTimeoutExceeded$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.actor.ActorPublisherState$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.actor.ActorPublisherState.State$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.actor.ActorSubscriber$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.actor.ActorSubscriber.OnSubscribe$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.actor.ActorSubscriberMessage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.actor.ActorSubscriberMessage.OnComplete$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.actor.ActorSubscriberMessage.OnError$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.actor.ActorSubscriberMessage.OnNext$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.actor.ActorSubscriberState$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.actor.ActorSubscriberState.State$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.actor.OneByOneRequestStrategy$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.actor.UntypedActorPublisher$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.actor.UntypedActorSubscriber$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.actor.WatermarkRequestStrategy$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.actor.ZeroRequestStrategy$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.ActorAttributes$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.ActorAttributes.Dispatcher$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.ActorAttributes.SupervisionStrategy$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.ActorMaterializer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.ActorMaterializerHelper$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.ActorMaterializerSettings$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.AmorphousShape$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.Attributes$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.Attributes.AsyncBoundary$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.Attributes.InputBuffer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.Attributes.LogLevels$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.Attributes.Name$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.BidiShape$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in exception akka.stream.BindFailedException$
-
Deprecated.
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.BufferOverflowException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.Client$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.ClosedShape$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.DelayOverflowStrategy$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.EagerClose$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.extra.Implicits$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.extra.Implicits.TimedFlowDsl$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.extra.Implicits.TimedSourceDsl$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.extra.Timed$
-
Deprecated.
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.FanInShape$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.FanInShape.Name$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.FanInShape.Ports$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.FanOutShape$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.FanOutShape.Name$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.FanOutShape.Ports$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.FlowMonitorState$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.FlowMonitorState.Failed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.FlowMonitorState.Finished$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.FlowMonitorState.Initialized$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.FlowMonitorState.Received$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.FlowShape$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.Fusing$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.Fusing.FusedGraph$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.IgnoreBoth$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.IgnoreCancel$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.IgnoreComplete$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.ActorMaterializerImpl$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.ActorProcessor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.ActorPublisher$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.ActorRefSinkActor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.ActorRefSourceActor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.Always$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.Buffer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.Cancel$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.CancelledSubscription$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.Completed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.ConstantFun$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.EmptyPublisher$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.EmptySource$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.ErrorPublisher$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.ExposedPublisher$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.FanIn$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.FanIn.OnComplete$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.FanIn.OnError$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.FanIn.OnNext$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.FanIn.OnSubscribe$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.FanIn.SubInput$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.FanOut$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.FanOut.ExposedPublishers$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.FanOut.SubstreamCancel$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.FanOut.SubstreamRequestMore$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.FanOut.SubstreamSubscribePending$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.FanoutProcessorImpl$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.FixedSizeBuffer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.FlowNames$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.ActorGraphInterpreter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.ActorGraphInterpreter.Abort$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.ActorGraphInterpreter.AsyncInput$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.ActorGraphInterpreter.Cancel$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.ActorGraphInterpreter.ExposedPublisher$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.ActorGraphInterpreter.OnComplete$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.ActorGraphInterpreter.OnError$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.ActorGraphInterpreter.OnNext$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.ActorGraphInterpreter.OnSubscribe$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.ActorGraphInterpreter.RequestMore$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.ActorGraphInterpreter.Resume$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.ActorGraphInterpreter.SubscribePending$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.Batch$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.Buffer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.Collect$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.Drop$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.DropWhile$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.Filter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.Fold$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.Fusing$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.GraphInterpreter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.GraphInterpreter.Empty$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.GraphInterpreter.Failed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.GraphInterpreter.GraphAssembly$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.GraphModule$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.GraphStageModule$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.GraphStages$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.GraphStages.Identity$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.GraphStages.IgnoreSink$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.Grouped$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.Intersperse$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.IteratorInterpreter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.IteratorInterpreter.IteratorDownstream$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.IteratorInterpreter.IteratorUpstream$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.LimitWeighted$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.Log$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.Map$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.MapAsync$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.MapAsyncUnordered$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.MapError$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.Recover$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.RecoverWith$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.Scan$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.ScanAsync$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.Sliding$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.Split$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.Split.SplitAfter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.Split.SplitBefore$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.SubSink$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.SubSink.Cancel$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.SubSink.CancelScheduledBeforeMaterialization$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.SubSink.RequestOne$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.SubSink.RequestOneScheduledBeforeMaterialization$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.SubSink.Uninitialized$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.SubSource$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.Take$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.TakeWhile$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.TimerKeys$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.TimerKeys.DropWithinTimerKey$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.TimerKeys.GroupedWithinTimerKey$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.fusing.TimerKeys.TakeWithinTimerKey$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.ByteStringParser$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.ByteStringParser.FinishedParser$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.ByteStringParser.ParseResult$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.compression.CompressionUtils$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.compression.DeflateCompressor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.compression.DeflateDecompressorBase$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.compression.GzipDecompressor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.ConnectionSourceStage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.FilePublisher$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.FileSubscriber$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.InputStreamPublisher$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.InputStreamSinkStage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.InputStreamSinkStage.Close$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.InputStreamSinkStage.Data$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.InputStreamSinkStage.Failed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.InputStreamSinkStage.Finished$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.InputStreamSinkStage.Initialized$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.InputStreamSinkStage.ReadElementAcknowledgement$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.OutgoingConnectionStage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.OutputStreamSourceStage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.OutputStreamSourceStage.Canceled$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.OutputStreamSourceStage.Close$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.OutputStreamSourceStage.Flush$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.OutputStreamSourceStage.Ok$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.OutputStreamSubscriber$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.TcpConnectionStage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.TcpConnectionStage.Inbound$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.TcpConnectionStage.Outbound$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.TcpConnectionStage.WriteAck$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.TcpIdleTimeout$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.TLSActor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.TlsModule$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.io.TlsUtils$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.JsonObjectParser$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.LazySource$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.MaterializerSession$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.MaybePublisher$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.NotInitialized$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.ProcessorModule$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.QueueSink$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.QueueSink.Cancel$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.QueueSink.Pull$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.QueueSource$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.QueueSource.Completion$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.QueueSource.Failure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.QueueSource.Offer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.ReactiveStreamsCompliance$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.RejectAdditionalSubscribers$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.RequestMore$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.ResizableMultiReaderRingBuffer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in exception akka.stream.impl.ResizableMultiReaderRingBuffer.NothingToReadException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.SeqActorName$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.Stages$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.Stages.DefaultAttributes$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.Stages.SymbolicGraphStage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.StreamLayout$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.StreamLayout.Atomic$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.StreamLayout.Combine$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.StreamLayout.CompositeModule$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.StreamLayout.CopiedModule$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.StreamLayout.EmptyModule$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.StreamLayout.FusedModule$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.StreamLayout.IgnorableMatValComp$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.StreamLayout.Ignore$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.StreamLayout.StructuralInfoModule$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.StreamLayout.Transform$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.StreamSubscriptionTimeoutSupport$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.StreamSubscriptionTimeoutSupport.CancelingSubscriber$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.StreamSubscriptionTimeoutSupport.NoopSubscriptionTimeout$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.StreamSupervisor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.StreamSupervisor.Children$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.StreamSupervisor.GetChildren$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.StreamSupervisor.Materialize$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.StreamSupervisor.PrintDebugDump$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.StreamSupervisor.StopChildren$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.StreamSupervisor.StoppedChildren$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.SubFlowImpl$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.SubscribePending$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.SubscriberManagement$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.SubscriberManagement.Completed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.SubscriberManagement.ErrorCompleted$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.SubscriberManagement.NotReached$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.Timers$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.Timers.GraphStageLogicTimer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.TransferPhase$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.Unzip$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.VirtualProcessor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.VirtualProcessor.Both$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.VirtualProcessor.Inert$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.impl.WaitingForUpstreamSubscription$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.Inlet$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.IOResult$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.Balance$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.BidiFlow$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.Broadcast$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.BroadcastHub$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.Compression$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.Concat$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.CoupledTerminationFlow$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.FileIO$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.Flow$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.Framing$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.GraphDSL$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.JsonFraming$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.Keep$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.Merge$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.MergeHub$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.MergePreferred$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.Partition$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.RunnableGraph$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.Sink$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.Source$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.StreamConverters$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.Tcp$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.TLS$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.TLSPlacebo$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.Unzip$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.UnzipWith$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.Zip$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.ZipN$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.ZipWith$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.javadsl.ZipWithN$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.KillSwitches$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.KillSwitches.UniqueBidiKillSwitchStage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.KillSwitches.UniqueKillSwitchStage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.MaterializationContext$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.MaterializationException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.NoMaterializer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.Outlet$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.OverflowStrategies$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.OverflowStrategies.Backpressure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.OverflowStrategies.DropBuffer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.OverflowStrategies.DropHead$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.OverflowStrategies.DropNew$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.OverflowStrategies.DropTail$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.OverflowStrategies.EmitEarly$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.OverflowStrategies.Fail$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.OverflowStrategy$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.QueueOfferResult$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.QueueOfferResult.Dropped$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.QueueOfferResult.Enqueued$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.QueueOfferResult.Failure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.QueueOfferResult.QueueClosed$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.Balance$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.BidiFlow$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.Broadcast$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.BroadcastHub$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.Compression$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.Concat$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.CoupledTerminationFlow$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.FileIO$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.Flow$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.Framing$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.GraphApply$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.GraphDSL$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.GraphDSL.Implicits$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.Interleave$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.JsonFraming$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.Keep$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.Merge$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.MergeHub$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.MergePreferred$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.ModuleExtractor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.OrElse$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.Partition$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.Partition.PartitionOutOfBoundsException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.RunnableGraph$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.ScalaSessionAPI$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.Sink$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.Source$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.StreamConverters$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.Tcp$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.Tcp.IncomingConnection$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.Tcp.OutgoingConnection$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.Tcp.ServerBinding$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.TLS$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.TLSPlacebo$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.Unzip$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.UnzipWith$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.UnzipWithApply$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.UnzipWithApply.UnzipWithCreatorObject10$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.UnzipWithApply.UnzipWithCreatorObject11$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.UnzipWithApply.UnzipWithCreatorObject12$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.UnzipWithApply.UnzipWithCreatorObject13$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.UnzipWithApply.UnzipWithCreatorObject14$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.UnzipWithApply.UnzipWithCreatorObject15$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.UnzipWithApply.UnzipWithCreatorObject16$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.UnzipWithApply.UnzipWithCreatorObject17$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.UnzipWithApply.UnzipWithCreatorObject18$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.UnzipWithApply.UnzipWithCreatorObject19$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.UnzipWithApply.UnzipWithCreatorObject2$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.UnzipWithApply.UnzipWithCreatorObject20$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.UnzipWithApply.UnzipWithCreatorObject3$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.UnzipWithApply.UnzipWithCreatorObject4$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.UnzipWithApply.UnzipWithCreatorObject5$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.UnzipWithApply.UnzipWithCreatorObject6$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.UnzipWithApply.UnzipWithCreatorObject7$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.UnzipWithApply.UnzipWithCreatorObject8$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.UnzipWithApply.UnzipWithCreatorObject9$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.Zip$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.ZipN$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.ZipWith$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.scaladsl.ZipWithN$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.Server$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.SinkShape$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.SourceShape$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.stage.AbstractStage$
-
Deprecated.
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.stage.GraphStageLogic$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.stage.GraphStageLogic.EagerTerminateInput$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.stage.GraphStageLogic.EagerTerminateOutput$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.stage.GraphStageLogic.IgnoreTerminateInput$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.stage.GraphStageLogic.IgnoreTerminateOutput$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.stage.GraphStageLogic.StageActorRef$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.stage.GraphStageLogic.StageActorRefNotInitializedException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.stage.GraphStageLogic.TotallyIgnorantInput$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.stage.StatefulStage$
-
Deprecated.
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.stage.StatefulStage.Become$
-
Deprecated.
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.stage.StatefulStage.Finish$
-
Deprecated.
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.stage.StatefulStage.Stay$
-
Deprecated.
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.stage.TimerMessages$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.stage.TimerMessages.Scheduled$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.stage.TimerMessages.Timer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.StreamSubscriptionTimeoutSettings$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.StreamSubscriptionTimeoutTerminationMode$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.StreamSubscriptionTimeoutTerminationMode.CancelTermination$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.StreamSubscriptionTimeoutTerminationMode.NoopTermination$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.StreamSubscriptionTimeoutTerminationMode.WarnTermination$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.SubstreamCancelStrategies$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.SubstreamCancelStrategies.Drain$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.SubstreamCancelStrategies.Propagate$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.SubstreamCancelStrategy$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.Supervision$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.Supervision.Restart$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.Supervision.Resume$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.Supervision.Stop$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.GraphStageMessages$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.GraphStageMessages.DownstreamFinish$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.GraphStageMessages.Failure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.GraphStageMessages.Pull$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.GraphStageMessages.Push$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.GraphStageMessages.StageFailure$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.GraphStageMessages.UpstreamFinish$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.javadsl.TestSink$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.javadsl.TestSource$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.scaladsl.TestSink$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.scaladsl.TestSource$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.StreamTestKit$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.StreamTestKit.CompletedSubscription$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.StreamTestKit.FailedSubscription$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.StreamTestKit.PublisherProbeSubscription$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.TestPublisher$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.TestPublisher.CancelSubscription$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.TestPublisher.ManualProbe$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.TestPublisher.RequestMore$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.TestPublisher.Subscribe$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.TestSinkStage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.TestSourceStage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.TestSubscriber$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.TestSubscriber.OnComplete$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.TestSubscriber.OnError$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.TestSubscriber.OnNext$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.testkit.TestSubscriber.OnSubscribe$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.ThrottleMode$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.ThrottleMode.Enforcing$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.ThrottleMode.Shaping$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.TLSClientAuth$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.TLSClientAuth.Need$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.TLSClientAuth.None$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.TLSClientAuth.Want$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.TLSClosing$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.TLSProtocol$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.TLSProtocol.NegotiateNewSession$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.TLSProtocol.SendBytes$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.TLSProtocol.SessionBytes$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.TLSProtocol.SessionTruncated$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.TLSRole$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.UniformFanInShape$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.stream.UniformFanOutShape$
-
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.Spawn$
-
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.adapter.ActorRefAdapter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.adapter.ActorSystemAdapter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.adapter.PropsAdapter$
-
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.DeadLetter$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.DeathPactException$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.DispatcherDefault$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.DispatcherFromConfig$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.DispatcherFromExecutionContext$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.DispatcherFromExecutor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Dispatchers$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Dropped$
-
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.EmptyDeploymentConfig$
-
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.internal.ActorCell$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.internal.ActorSystemImpl$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.internal.ActorSystemImpl.CreateSystemActor$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.internal.BlackholeActorRef$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.internal.Create$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.internal.DeathWatchNotification$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.internal.EarliestFirstSystemMessageList$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.internal.EventStreamImpl$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.internal.EventStreamImpl.Register$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.internal.EventStreamImpl.UnregisterIfNoMoreSubscribedChannels$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.internal.FutureRef$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.internal.LatestFirstSystemMessageList$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.internal.NoMessage$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.internal.SystemMessageList$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.internal.Terminate$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.internal.Unwatch$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.internal.Watch$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.internal.WatchableRef$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Logger$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.Logger.Initialize$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.typed.MailboxCapacity$
-
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.Receiver.ReceiveTimeout$
-
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.patterns.Restarter$
-
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.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.Deferred$
-
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.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$
-
Deprecated.
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.JavaDurationConverters$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.JavaDurationConverters.JavaDurationOps$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.JavaDurationConverters.ScalaDurationOps$
-
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.MessageBuffer$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.OptionVal$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.OptionVal.Some$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.PrettyByteString$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.PrettyDuration$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class akka.util.PrettyDuration.PrettyPrintableDuration$
-
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.WildcardIndex$
-
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.
- MODULE$ - Static variable in class akka.Version$
-
Static reference to the singleton instance of this Scala object.
- MODULE$ - Static variable in class com.typesafe.sslconfig.akka.AkkaSSLConfig$
-
Static reference to the singleton instance of this Scala object.
- ModuleExtractor - Class in akka.stream.scaladsl
-
INTERNAL API
- ModuleExtractor() - Constructor for class akka.stream.scaladsl.ModuleExtractor
-
- ModuleExtractor$ - Class in akka.stream.scaladsl
-
INTERNAL API
- ModuleExtractor$() - Constructor for class akka.stream.scaladsl.ModuleExtractor$
-
- modules() - Method in class akka.stream.impl.fusing.Fusing.BuildStructuralInfo
-
the set of all contained modules
- ModuloFixedSizeBuffer(int) - Constructor for class akka.stream.impl.FixedSizeBuffer.ModuloFixedSizeBuffer
-
- monitor() - Method in class akka.stream.impl.fusing.GraphStages$
-
- monitor() - Static method in class akka.stream.impl.fusing.GraphStages
-
- monitor(Function2<Mat, FlowMonitor<Out>, M>) - Method in class akka.stream.javadsl.Flow
-
Materializes to FlowMonitor[Out]
that allows monitoring of the current flow.
- monitor(Function2<Mat, FlowMonitor<Out>, M>) - Method in class akka.stream.javadsl.Source
-
Materializes to FlowMonitor[Out]
that allows monitoring of the current flow.
- monitor(Function2<Mat, FlowMonitor<Out>, Mat2>) - Static method in class akka.stream.scaladsl.Flow
-
- monitor(Function2<Mat, FlowMonitor<Out>, Mat2>) - Method in interface akka.stream.scaladsl.FlowOpsMat
-
Materializes to FlowMonitor[Out]
that allows monitoring of the current flow.
- monitor(Function2<Mat, FlowMonitor<Out>, Mat2>) - Static method in class akka.stream.scaladsl.Source
-
- 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$
-
- moreRequested(SubscriptionWithCursor, long) - Method in interface akka.stream.impl.SubscriberManagement
-
more demand was signaled from a given subscriber
- moveJoiningToWeaklyUp() - Method in class akka.cluster.ClusterCoreDaemon
-
- 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.circuitbreaker.CircuitBreakerProxy.Passthrough
-
- msg() - Method in class akka.contrib.circuitbreaker.CircuitBreakerProxy.TellOnly
-
- msg() - Method in class akka.contrib.pattern.ReliableProxy.Message
-
- msg() - Method in class akka.persistence.fsm.PersistentFSM.Timer
-
- msg() - Method in class akka.persistence.journal.AsyncWriteJournal.Desequenced
-
- msg() - Method in exception akka.persistence.scalatest.MayVerb.TestCanceledByFailure
-
- 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 exception akka.stream.BufferOverflowException
-
- msg() - Method in class akka.stream.FlowMonitorState.Received
-
- msg() - Method in exception akka.stream.scaladsl.Partition.PartitionOutOfBoundsException
-
- 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.DeadLetter
-
- msg() - Method in class akka.typed.Dropped
-
- msg() - Method in class akka.typed.Effect.Messaged
-
- msg() - Method in class akka.typed.Effect.ReceiveTimeoutSet
-
- 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() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- msgAvailable() - Static method in class akka.persistence.journal.JournalSpec
-
- msgAvailable() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- msgAvailable() - Static method in class akka.remote.testkit.MultiNodeSpec
-
- msgAvailable() - Method in class akka.testkit.JavaTestKit
-
Query queue status.
- msgAvailable() - Static method in class akka.testkit.TestKit
-
- msgAvailable() - Method in interface akka.testkit.TestKitBase
-
Query queue status.
- msgAvailable() - Static method in class akka.testkit.TestProbe
-
- 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$
-
- multimapFromBinary(byte[]) - Method in class akka.cluster.ddata.protobuf.ReplicatedDataSerializer
-
- multimapFromProto(ReplicatedDataMessages.ORMultiMap) - Method in class akka.cluster.ddata.protobuf.ReplicatedDataSerializer
-
- multimapToProto(ORMultiMap<?>) - Method in class akka.cluster.ddata.protobuf.ReplicatedDataSerializer
-
- 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, Function1<Config, ActorSystem>) - Constructor for class akka.remote.testkit.MultiNodeSpec
-
Constructor for using arbitrary logic to create the actor system used in
the multi node spec (the Config
passed to the creator must be used in
the created actor system for the multi node tests to work)
- MultiNodeSpec(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
-
- myself() - Method in class akka.remote.testkit.MultiNodeConfig
-
- myself() - Method in class akka.remote.testkit.MultiNodeSpec
-
- myVersions() - Method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- s() - Method in class akka.stream.scaladsl.GraphDSL.Implicits$.SinkArrow
-
- s() - Method in class akka.stream.scaladsl.GraphDSL.Implicits$.SinkShapeArrow
-
- s() - Method in class akka.stream.scaladsl.GraphDSL.Implicits$.SourceArrow
-
- s() - Method in class akka.stream.scaladsl.GraphDSL.Implicits$.SourceShapeArrow
-
- safeLongToInt(long) - Method in interface akka.persistence.journal.inmem.InmemMessages
-
- safeShutdownOutput() - Method in class akka.io.TcpConnection
-
- safeShutdownOutput() - Static method in class akka.io.TcpOutgoingConnection
-
- safeToBeOldest() - Method in class akka.cluster.singleton.ClusterSingletonManager.Internal$.OldestChangedBuffer.InitialOldestState
-
- 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.ddata.VersionVector.Same$
-
- Same$() - Constructor for class akka.cluster.VectorClock.Same$
-
- sameAs(Metric) - Method in class akka.cluster.Metric
-
Deprecated.
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
-
Deprecated.
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
-
- sameElements(Iterator<?>) - Static method in class akka.util.ByteIterator
-
- sameElements(GenIterable<B>) - Static method in class akka.util.ByteString
-
- sameElements(GenIterable<B>) - Static method in class akka.util.CompactByteString
-
- SameInstance() - Method in class akka.cluster.ddata.VersionVector$
-
Java API: The VersionVector.Same
instance
- SameInstance() - Static method in class akka.cluster.ddata.VersionVector
-
Java API: The VersionVector.Same
instance
- sameThreadExecutionContext$() - Constructor for class akka.dispatch.ExecutionContexts.sameThreadExecutionContext$
-
- sample() - Method in class akka.cluster.JmxMetricsCollector
-
Deprecated.
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
-
Deprecated.
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
-
- save(OutputStream, String) - Static method in class akka.remote.security.provider.AkkaProvider
-
- 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 class akka.persistence.snapshot.NoSnapshotStore
-
- saveAsync(SnapshotMetadata, Object) - Method in interface akka.persistence.snapshot.SnapshotStore
-
Plugin API: asynchronously saves 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$
-
- saveSnapshotWhenNeeded() - Method in class akka.cluster.sharding.PersistentShard
-
- saveSnapshotWhenNeeded() - Method in class akka.cluster.sharding.PersistentShardCoordinator
-
- saveState() - Method in class akka.remote.EndpointReader
-
- saveStateSnapshot() - Method in interface akka.persistence.fsm.PersistentFSM
-
Save the current state as a snapshot
- scala$App$$_args() - Static method in class akka.remote.artery.FlightRecorderDump
-
- scala$App$$_args_$eq(String[]) - Static method in class akka.remote.artery.FlightRecorderDump
-
- scala$App$$initCode() - Static method in class akka.remote.artery.FlightRecorderDump
-
- scala$App$_setter_$executionStart_$eq(long) - Static method in class akka.remote.artery.FlightRecorderDump
-
- scala$App$_setter_$scala$App$$initCode_$eq(ListBuffer<Function0<BoxedUnit>>) - Static method in class akka.remote.artery.FlightRecorderDump
-
- 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
- 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.
- scalaAnyToNone() - Method in class akka.stream.impl.ConstantFun$
-
- scalaAnyToNone() - Static method in class akka.stream.impl.ConstantFun
-
- scalaAnyTwoToNone() - Method in class akka.stream.impl.ConstantFun$
-
- scalaAnyTwoToNone() - Static method in class akka.stream.impl.ConstantFun
-
- 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.Deferred<T> - Class in akka.typed
-
Wrap a behavior factory so that it runs upon PreStart, i.e.
- ScalaDSL.Deferred$ - 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
ScalaDSL.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
-
- scaladslPlugin() - Method in class akka.persistence.query.PersistenceQuery.PluginHolder
-
- scaladslReadJournal() - Method in class akka.persistence.query.journal.leveldb.LeveldbReadJournalProvider
-
- scaladslReadJournal() - Method in interface akka.persistence.query.ReadJournalProvider
-
The ReadJournal
implementation for the Scala API.
- ScalaDurationOps(Duration) - Constructor for class akka.util.JavaDurationConverters.ScalaDurationOps
-
- ScalaDurationOps$() - Constructor for class akka.util.JavaDurationConverters.ScalaDurationOps$
-
- scalaIdentityFunction() - Method in class akka.stream.impl.ConstantFun$
-
- scalaIdentityFunction() - Static method in class akka.stream.impl.ConstantFun
-
- ScalaSessionAPI - Interface in akka.stream.scaladsl
-
Allows access to an SSLSession with Scala types
- ScalaSessionAPI$ - Class in akka.stream.scaladsl
-
- ScalaSessionAPI$() - Constructor for class akka.stream.scaladsl.ScalaSessionAPI$
-
- scaledPoolSize(int, double, int) - Method in class akka.dispatch.ThreadPoolConfig$
-
- scaledPoolSize(int, double, int) - Static method in class akka.dispatch.ThreadPoolConfig
-
- Scan<In,Out> - Class in akka.stream.impl.fusing
-
INTERNAL API
- Scan(Out, Function2<Out, In, Out>) - Constructor for class akka.stream.impl.fusing.Scan
-
- scan() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- scan(T, Function2<T, Out, T>) - Static method in class akka.stream.impl.SubFlowImpl
-
- scan(T, Function2<T, Out, T>) - Method in class akka.stream.javadsl.Flow
-
Similar to fold
but is not a terminal operation,
emits its current value which starts at zero
and then
applies the current and next value to the given function f
,
emitting the next current value.
- scan(T, Function2<T, Out, T>) - Method in class akka.stream.javadsl.Source
-
Similar to fold
but is not a terminal operation,
emits its current value which starts at zero
and then
applies the current and next value to the given function f
,
emitting the next current value.
- scan(T, Function2<T, Out, T>) - Method in class akka.stream.javadsl.SubFlow
-
Similar to fold
but is not a terminal operation,
emits its current value which starts at zero
and then
applies the current and next value to the given function f
,
emitting the next current value.
- scan(T, Function2<T, Out, T>) - Method in class akka.stream.javadsl.SubSource
-
Similar to fold
but is not a terminal operation,
emits its current value which starts at zero
and then
applies the current and next value to the given function f
,
emitting the next current value.
- scan(T, Function2<T, Out, T>) - Static method in class akka.stream.scaladsl.Flow
-
- scan(T, Function2<T, Out, T>) - Method in interface akka.stream.scaladsl.FlowOps
-
Similar to fold
but is not a terminal operation,
emits its current value which starts at zero
and then
applies the current and next value to the given function f
,
emitting the next current value.
- scan(T, Function2<T, Out, T>) - Static method in class akka.stream.scaladsl.Source
-
- scan(B, Function2<B, B, B>, CanBuildFrom<Repr, B, That>) - Static method in class akka.util.ByteString
-
- scan(B, Function2<B, B, B>, CanBuildFrom<Repr, B, That>) - Static method in class akka.util.CompactByteString
-
- Scan$ - Class in akka.stream.impl.fusing
-
- Scan$() - Constructor for class akka.stream.impl.fusing.Scan$
-
- ScanAsync<In,Out> - Class in akka.stream.impl.fusing
-
INTERNAL API
- ScanAsync(Out, Function2<Out, In, Future<Out>>) - Constructor for class akka.stream.impl.fusing.ScanAsync
-
- scanAsync() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- scanAsync(T, Function2<T, Out, Future<T>>) - Static method in class akka.stream.impl.SubFlowImpl
-
- scanAsync(T, Function2<T, Out, CompletionStage<T>>) - Method in class akka.stream.javadsl.Flow
-
Similar to scan
but with a asynchronous function,
emits its current value which starts at zero
and then
applies the current and next value to the given function f
,
emitting a Future
that resolves to the next current value.
- scanAsync(T, Function2<T, Out, CompletionStage<T>>) - Method in class akka.stream.javadsl.Source
-
Similar to scan
but with a asynchronous function,
emits its current value which starts at zero
and then
applies the current and next value to the given function f
,
emitting a Future
that resolves to the next current value.
- scanAsync(T, Function2<T, Out, CompletionStage<T>>) - Method in class akka.stream.javadsl.SubFlow
-
Similar to scan
but with a asynchronous function,
emits its current value which starts at zero
and then
applies the current and next value to the given function f
,
emitting a Future
that resolves to the next current value.
- scanAsync(T, Function2<T, Out, CompletionStage<T>>) - Method in class akka.stream.javadsl.SubSource
-
Similar to scan
but with a asynchronous function,
emits its current value which starts at zero
and then
applies the current and next value to the given function f
,
emitting a Future
that resolves to the next current value.
- scanAsync(T, Function2<T, Out, Future<T>>) - Static method in class akka.stream.scaladsl.Flow
-
- scanAsync(T, Function2<T, Out, Future<T>>) - Method in interface akka.stream.scaladsl.FlowOps
-
Similar to scan
but with a asynchronous function,
emits its current value which starts at zero
and then
applies the current and next value to the given function f
,
emitting a Future
that resolves to the next current value.
- scanAsync(T, Function2<T, Out, Future<T>>) - Static method in class akka.stream.scaladsl.Source
-
- ScanAsync$ - Class in akka.stream.impl.fusing
-
- ScanAsync$() - Constructor for class akka.stream.impl.fusing.ScanAsync$
-
- scanLeft(B, Function2<B, A, B>) - Static method in class akka.util.ByteIterator
-
- scanLeft(B, Function2<B, A, B>, CanBuildFrom<Repr, B, That>) - Static method in class akka.util.ByteString
-
- scanLeft(B, Function2<B, A, B>, CanBuildFrom<Repr, B, That>) - Static method in class akka.util.CompactByteString
-
- 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
-
- scanRight(B, Function2<A, B, B>) - Static method in class akka.util.ByteIterator
-
- scanRight(B, Function2<A, B, B>, CanBuildFrom<Repr, B, That>) - Static method in class akka.util.ByteString
-
- scanRight(B, Function2<A, B, B>, CanBuildFrom<Repr, B, That>) - Static method in class akka.util.CompactByteString
-
- 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 Runnable
to be run repeatedly with an initial delay and
a frequency.
- schedule(ActorRef, FiniteDuration) - Method in class akka.persistence.fsm.PersistentFSM.Timer
-
- 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.adapter.ActorContextAdapter
-
- schedule(FiniteDuration, ActorRef<U>, U) - Method in class akka.typed.EffectfulActorContext
-
- schedule(FiniteDuration, ActorRef<U>, U) - Method in class akka.typed.internal.ActorCell
-
- schedule(FiniteDuration, ActorRef<U>, U) - Method in class akka.typed.StubbedActorContext
-
- schedule$default$6(FiniteDuration, FiniteDuration, ActorRef, Object) - Static method in class akka.actor.LightArrayRevolverScheduler
-
- 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(Object, int, boolean) - Constructor for class akka.stream.stage.TimerMessages.Scheduled
-
- Scheduled(FiniteDuration, ActorRef<U>, U) - Constructor for class akka.typed.Effect.Scheduled
-
- Scheduled$() - Constructor for class akka.stream.stage.TimerMessages.Scheduled$
-
- Scheduled$() - Constructor for class akka.typed.Effect.Scheduled$
-
- scheduleDelayedMemberRemoved(Member) - Method in class akka.cluster.singleton.ClusterSingletonManager
-
- scheduleDequeue(FiniteDuration) - Method in class akka.remote.transport.ThrottledAssociation
-
- scheduledUnreachable() - Static method in class akka.cluster.AutoDown
-
- scheduledUnreachable() - Method in class akka.cluster.AutoDownBase
-
- scheduledUnreachable_$eq(Map<UniqueAddress, Cancellable>) - Static method in class akka.cluster.AutoDown
-
- ScheduledUpdate(long) - Constructor for class akka.persistence.PersistentView.ScheduledUpdate
-
Deprecated.
- ScheduledUpdate$() - Constructor for class akka.persistence.PersistentView.ScheduledUpdate$
-
Deprecated.
- 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.
- scheduleOnce(FiniteDuration, Runnable) - Static method in class akka.stream.ActorMaterializer
-
- scheduleOnce(FiniteDuration, Runnable) - Method in class akka.stream.impl.ActorMaterializerImpl
-
- scheduleOnce(FiniteDuration, Runnable) - Method in class akka.stream.impl.SubFusingActorMaterializerImpl
-
- scheduleOnce(FiniteDuration, Runnable) - Method in class akka.stream.Materializer
-
Interface for stages that need timer services for their functionality.
- scheduleOnce(FiniteDuration, Runnable) - Method in class akka.stream.NoMaterializer$
-
- scheduleOnce(FiniteDuration, Runnable) - Static method in class akka.stream.NoMaterializer
-
- scheduleOnce(Object, FiniteDuration) - Method in class akka.stream.stage.TimerGraphStageLogic
-
- scheduleOnce$default$5(FiniteDuration, ActorRef, Object) - Static method in class akka.actor.LightArrayRevolverScheduler
-
- schedulePeriodically(FiniteDuration, FiniteDuration, Runnable) - Static method in class akka.stream.ActorMaterializer
-
- schedulePeriodically(FiniteDuration, FiniteDuration, Runnable) - Method in class akka.stream.impl.ActorMaterializerImpl
-
- schedulePeriodically(FiniteDuration, FiniteDuration, Runnable) - Method in class akka.stream.impl.SubFusingActorMaterializerImpl
-
- schedulePeriodically(FiniteDuration, FiniteDuration, Runnable) - Method in class akka.stream.Materializer
-
Interface for stages that need timer services for their functionality.
- schedulePeriodically(FiniteDuration, FiniteDuration, Runnable) - Method in class akka.stream.NoMaterializer$
-
- schedulePeriodically(FiniteDuration, FiniteDuration, Runnable) - Static method in class akka.stream.NoMaterializer
-
- schedulePeriodically(Object, FiniteDuration) - Method in class akka.stream.stage.TimerGraphStageLogic
-
- schedulePeriodicallyWithInitialDelay(Object, FiniteDuration, FiniteDuration) - Method in class akka.stream.stage.TimerGraphStageLogic
-
- 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() - Static method in class akka.cluster.ClusterRemoteWatcher
-
- 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
-
- scheduler() - Method in interface akka.typed.ActorSystem
-
A generic scheduler that can initiate the execution of tasks after some delay.
- scheduler() - Method in class akka.typed.adapter.ActorSystemAdapter
-
- scheduler() - Method in class akka.typed.internal.ActorSystemImpl
-
- 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
-
- scheduleSubscriptionTimeout(ActorRef, Object) - Method in interface akka.stream.impl.StreamSubscriptionTimeoutSupport
-
Schedules a Subscription timeout.
- scheduleTick() - Method in class akka.contrib.pattern.ReliableProxy
-
- scheduleUnreachable(UniqueAddress) - Static method in class akka.cluster.AutoDown
-
- scheduleUnreachable(UniqueAddress) - Method in class akka.cluster.AutoDownBase
-
- SchemeAugmenter - Interface in akka.remote.transport
-
- schemeIdentifier() - Method in class akka.remote.transport.AbstractTransportAdapter
-
- schemeIdentifier() - Static method in class akka.remote.transport.ActorTransportAdapter
-
- schemeIdentifier() - Static method in class akka.remote.transport.AkkaProtocolTransport
-
- schemeIdentifier() - Static method in class akka.remote.transport.FailureInjectorTransportAdapter
-
- 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() - 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
-
- SEATTYPE_FIELD_NUMBER - Static variable in class docs.persistence.proto.FlightAppModels.SeatReserved
-
- second() - Method in class akka.japi.Pair
-
- secondary() - Method in class akka.stream.scaladsl.OrElse
-
- secondaryNodes() - Static method in class akka.cluster.ddata.ReadAggregator
-
- secondaryNodes() - Method in class akka.cluster.ddata.ReadWriteAggregator
-
- secondaryNodes() - Static method in class akka.cluster.ddata.WriteAggregator
-
- secondaryPorts() - Method in class akka.stream.scaladsl.MergePreferred.MergePreferredShape
-
- secondaryPorts() - Method in class akka.stream.scaladsl.MergePreferred
-
- sectionParameters() - Method in class akka.remote.artery.FlightRecorderReader.Log
-
- sectionParameters() - Method in class akka.remote.artery.FlightRecorderReader.RollingLog
-
- SectionParameters(long, long, long, long, long, long) - Constructor for class akka.remote.artery.FlightRecorderReader.SectionParameters
-
- SectionParameters$() - Constructor for class akka.remote.artery.FlightRecorderReader.SectionParameters$
-
- sectionSize() - Method in class akka.remote.artery.FlightRecorderReader.SectionParameters
-
- SecureCookie() - Method in class akka.remote.transport.AkkaProtocolSettings
-
- Security() - Method in class akka.event.LogMarker$
-
- Security() - Static method in class akka.event.LogMarker
-
- seed() - Method in class akka.stream.impl.fusing.Batch
-
- 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
-
- seedArray() - Method in class akka.routing.MurmurHash$
-
- seedArray() - Static method in class akka.routing.MurmurHash
-
- 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() - Method in class akka.cluster.ddata.PruningState.PruningInitialized
-
- 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.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry
-
- 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
-
- segmentLength(Function1<A, Object>, int) - Static method in class akka.util.ByteString
-
- segmentLength(Function1<A, Object>, int) - Static method in class akka.util.CompactByteString
-
- segmentSize() - Method in class akka.stream.scaladsl.Interleave
-
- 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
-
Deprecated.
- 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
-
Deprecated.
- 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.ddata.Replicator
-
- selectRandomNode(IndexedSeq<Address>) - Method in class akka.cluster.metrics.ClusterMetricsCollector
-
- selectRandomNode(IndexedSeq<Address>) - Method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- self() - Method in class akka.actor.AbstractActor
-
- self() - Method in class akka.actor.AbstractFSM
-
- 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 class akka.actor.dsl.Inbox.InboxActor
-
- self() - Method in class akka.actor.Props.EmptyActor
-
- self() - Method in interface akka.actor.StashSupport
-
- 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.TypedActor.TypedActor
-
- self() - Method in class akka.actor.UnstartedCell
-
- self() - Method in class akka.actor.UntypedActor
-
- self() - Method in class akka.camel.internal.ActivationTracker
-
- self() - Method in class akka.camel.internal.CamelSupervisor
-
- self() - Method in class akka.camel.internal.ConsumerRegistrar
-
- self() - Method in class akka.camel.internal.ProducerRegistrar
-
- self() - Method in class akka.camel.internal.Registry
-
- self() - Method in class akka.camel.ProducerSupport.ProducerChild
-
- self() - Static method in class akka.cluster.AutoDown
-
- self() - Method in class akka.cluster.AutoDownBase
-
- self() - Method in class akka.cluster.client.ClusterClient
-
- self() - Method in class akka.cluster.client.ClusterReceptionist.Internal$.ClientResponseTunnel
-
- self() - Method in class akka.cluster.client.ClusterReceptionist
-
- self() - Method in class akka.cluster.ClusterCoreDaemon
-
- self() - Method in class akka.cluster.ClusterCoreSupervisor
-
- self() - Method in class akka.cluster.ClusterDaemon
-
- self() - Method in class akka.cluster.ClusterDomainEventPublisher
-
- self() - Method in class akka.cluster.ClusterHeartbeatReceiver
-
- self() - Method in class akka.cluster.ClusterHeartbeatSender
-
- self() - Method in class akka.cluster.ClusterMetricsCollector
-
- self() - Method in class akka.cluster.ClusterReadView
-
- self() - Static method in class akka.cluster.ClusterRemoteWatcher
-
- self() - Method in class akka.cluster.ddata.LmdbDurableStore
-
- self() - Static method in class akka.cluster.ddata.ReadAggregator
-
- self() - Method in class akka.cluster.ddata.ReadWriteAggregator
-
- self() - Method in class akka.cluster.ddata.Replicator
-
- self() - Static method in class akka.cluster.ddata.WriteAggregator
-
- self() - Method in class akka.cluster.FirstSeedNodeProcess
-
- self() - Method in class akka.cluster.JoinSeedNodeProcess
-
- self() - Method in class akka.cluster.metrics.AdaptiveLoadBalancingMetricsListener
-
- self() - Method in class akka.cluster.metrics.ClusterMetricsCollector
-
- self() - Method in class akka.cluster.metrics.ClusterMetricsSupervisor
-
- self() - Method in class akka.cluster.OnMemberStatusChangedListener
-
- self() - Method in class akka.cluster.pubsub.DistributedPubSubMediator.Internal$.Group
-
- self() - Method in class akka.cluster.pubsub.DistributedPubSubMediator.Internal$.Topic
-
- self() - Method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- self() - Method in class akka.cluster.routing.AdaptiveLoadBalancingMetricsListener
-
- self() - Method in class akka.cluster.sharding.ClusterShardingGuardian
-
- self() - Method in class akka.cluster.sharding.RemoveInternalClusterShardingData.RemoveOnePersistenceId
-
- self() - Method in class akka.cluster.sharding.RemoveInternalClusterShardingData
-
- self() - Method in class akka.cluster.sharding.Shard
-
- self() - Method in class akka.cluster.sharding.ShardCoordinator.RebalanceWorker
-
- self() - Method in class akka.cluster.sharding.ShardCoordinator
-
- self() - Method in class akka.cluster.sharding.ShardRegion.HandOffStopper
-
- self() - Method in class akka.cluster.sharding.ShardRegion
-
- self() - Method in class akka.cluster.singleton.ClusterSingletonManager
-
- self() - Method in class akka.cluster.singleton.ClusterSingletonProxy
-
- self() - Method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- self() - Method in class akka.contrib.jul.JavaLogger
-
- self() - Method in class akka.contrib.pattern.ReliableProxy.Receiver
-
- self() - Method in class akka.contrib.pattern.ReliableProxy
-
- self() - Method in class akka.contrib.throttle.TimerBasedThrottler
-
- self() - Method in class akka.event.ActorClassificationUnsubscriber
-
- self() - Method in class akka.event.DeadLetterListener
-
- self() - Method in class akka.event.EventStreamUnsubscriber
-
- self() - Method in class akka.event.Logging.DefaultLogger
-
- self() - Method in class akka.event.slf4j.Slf4jLogger
-
- self() - Method in class akka.io.InetAddressDnsResolver
-
- self() - Method in class akka.io.SelectionHandler.SelectorBasedManager
-
- self() - Method in class akka.io.SelectionHandler
-
- self() - Method in class akka.io.SimpleDnsManager
-
- self() - Method in class akka.io.TcpConnection
-
- self() - Method in class akka.io.TcpListener
-
- self() - Static method in class akka.io.TcpOutgoingConnection
-
- self() - Method in class akka.io.UdpConnection
-
- self() - Method in class akka.io.UdpListener
-
- self() - Method in class akka.io.UdpSender
-
- self() - Method in class akka.Main.Terminator
-
- self() - Method in class akka.pattern.BackoffOnRestartSupervisor
-
- self() - Method in class akka.pattern.BackoffSupervisor
-
- self() - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- self() - Method in class akka.persistence.journal.AsyncWriteJournal.Resequencer
-
- self() - Method in class akka.persistence.journal.inmem.InmemJournal
-
- self() - Method in class akka.persistence.journal.japi.AsyncWriteJournal
-
- self() - Method in class akka.persistence.journal.JournalPerfSpec.BenchActor
-
- self() - Method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- self() - Method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- self() - Method in class akka.persistence.journal.leveldb.SharedLeveldbStore
-
- self() - Method in class akka.persistence.journal.PersistencePluginProxy
-
- self() - Method in class akka.persistence.journal.ReplayFilter
-
- self() - Method in class akka.persistence.journal.ReplayMediator
-
- self() - Method in class akka.persistence.query.journal.leveldb.AbstractEventsByPersistenceIdPublisher
-
- self() - Method in class akka.persistence.query.journal.leveldb.AbstractEventsByTagPublisher
-
- self() - Method in class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher
-
- self() - Method in class akka.persistence.RecoveryPermitter
-
- self() - Method in class akka.persistence.snapshot.japi.SnapshotStore
-
- self() - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
-
- self() - Method in class akka.persistence.snapshot.NoSnapshotStore
-
- self() - Method in class akka.remote.artery.FlushOnShutdown
-
- self() - Method in class akka.remote.EndpointActor
-
- self() - Method in class akka.remote.EndpointManager
-
- self() - Static method in class akka.remote.EndpointReader
-
- self() - Static method in class akka.remote.EndpointWriter
-
- self() - Method in class akka.remote.ReliableDeliverySupervisor
-
- self() - Method in class akka.remote.RemoteDeploymentWatcher
-
- self() - Method in class akka.remote.RemoteWatcher
-
- self() - Method in class akka.remote.Remoting.TransportSupervisor
-
- self() - Method in class akka.remote.testconductor.BarrierCoordinator
-
- self() - Method in class akka.remote.testconductor.ClientFSM
-
- self() - Method in class akka.remote.testconductor.Controller
-
- self() - Method in class akka.remote.testconductor.ServerFSM
-
- self() - Method in class akka.remote.transport.ActorTransportAdapterManager
-
- self() - Method in class akka.remote.transport.ProtocolStateActor
-
- self() - Method in class akka.remote.transport.ThrottledAssociation
-
- self() - Static method in class akka.remote.transport.ThrottlerManager
-
- self() - Static method in class akka.routing.ResizablePoolActor
-
- self() - Static method in class akka.routing.RoutedActorCell
-
- self() - Method in class akka.routing.RouterActor
-
- self() - Static method in class akka.stream.actor.AbstractActorPublisher
-
- self() - Static method in class akka.stream.actor.AbstractActorSubscriber
-
- self() - Static method in class akka.stream.actor.UntypedActorPublisher
-
- self() - Static method in class akka.stream.actor.UntypedActorSubscriber
-
- self() - Method in class akka.stream.impl.ActorProcessorImpl
-
- self() - Method in class akka.stream.impl.ActorRefSinkActor
-
- self() - Method in class akka.stream.impl.ActorRefSourceActor
-
- self() - Method in class akka.stream.impl.FanIn
-
- self() - Method in class akka.stream.impl.FanOut
-
- self() - Static method in class akka.stream.impl.FanoutProcessorImpl
-
- self() - Method in class akka.stream.impl.fusing.ActorGraphInterpreter
-
- self() - Method in class akka.stream.impl.io.FilePublisher
-
- self() - Method in class akka.stream.impl.io.FileSubscriber
-
- self() - Method in class akka.stream.impl.io.InputStreamPublisher
-
- self() - Method in class akka.stream.impl.io.OutputStreamSubscriber
-
- self() - Method in class akka.stream.impl.io.TcpConnectionStage.TcpStreamLogic
-
- self() - Method in class akka.stream.impl.io.TLSActor
-
- self() - Method in class akka.stream.impl.StreamSupervisor
-
- self() - Static method in class akka.stream.impl.Unzip
-
- self() - Method in class akka.testkit.CallingThreadMailbox
-
- self() - Method in interface akka.testkit.ImplicitSender
-
- self() - Method in class akka.testkit.TestActor
-
- self() - Method in class akka.testkit.TestActors.BlackholeActor
-
- self() - Method in class akka.testkit.TestActors.EchoActor
-
- self() - Method in class akka.testkit.TestActors.ForwardActor
-
- 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.adapter.ActorAdapter
-
- self() - Method in class akka.typed.adapter.ActorContextAdapter
-
- self() - Method in class akka.typed.internal.ActorCell
-
- self() - Method in interface akka.typed.internal.DeathWatch
-
- self() - Method in interface akka.typed.internal.SupervisionMechanics
-
- self() - Method in class akka.typed.StubbedActorContext
-
- self() - Method in class akka.util.JavaDurationConverters.JavaDurationOps
-
- self() - Method in class akka.util.JavaDurationConverters.ScalaDurationOps
-
- 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.ddata.Replicator
-
- 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
-
- 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() - Static method in class akka.cluster.ClusterRemoteWatcher
-
- 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
-
- selfUniqueAddress() - Method in class akka.cluster.ddata.Replicator
-
- selfUniqueAddressOption() - Method in class akka.cluster.singleton.ClusterSingletonManager
-
- 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.AtLeastOnceDeliveryLike
-
- send(Object, OptionVal<ActorRef>, RemoteActorRef) - Method in class akka.remote.artery.ArteryTransport
-
- send(Object, OptionVal<ActorRef>, OptionVal<RemoteActorRef>) - Method in class akka.remote.artery.Association
-
- Send(Object, OptionVal<ActorRef>, RemoteActorRef, Option<SeqNo>) - Constructor for class akka.remote.EndpointManager.Send
-
- send(Object, OptionVal<ActorRef>, RemoteActorRef) - Method in class akka.remote.RemoteTransport
-
Sends the given message to the recipient supplying the sender() if any
- send(Object, OptionVal<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(T) - Method in class akka.typed.internal.ActorCell
-
- 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;
- sendBack() - Method in class akka.cluster.ddata.Replicator.Internal$.Gossip
-
- SENDBACK_FIELD_NUMBER - Static variable in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip
-
- sendBuffered(ActorRef) - Method in class akka.cluster.client.ClusterClient
-
- sendBuffered() - Method in class akka.cluster.singleton.ClusterSingletonProxy
-
- sendBuffered() - Method in class akka.persistence.journal.ReplayFilter
-
- 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.io.Tcp.SO$
-
- sendBufferSize(int) - Static method in class akka.io.TcpSO
-
- SendBufferSize() - Method in class akka.io.Udp.SO$
-
- sendBufferSize(int) - Static method in class akka.io.UdpSO
-
- SendBufferSize() - Method in class akka.remote.transport.netty.NettyTransportSettings
-
- SendBytes(ByteString) - Constructor for class akka.stream.TLSProtocol.SendBytes
-
- SendBytes$() - Constructor for class akka.stream.TLSProtocol.SendBytes$
-
- sendComplete() - Method in class akka.stream.testkit.StreamTestKit.PublisherProbeSubscription
-
- sendComplete() - Method in class akka.stream.testkit.TestPublisher.Probe
-
- sendControl(Address, ControlMessage) - Method in class akka.remote.artery.ArteryTransport
-
- sendControl(ControlMessage) - Method in class akka.remote.artery.Association
-
- sendControl(Address, ControlMessage) - Method in interface akka.remote.artery.InboundContext
-
An inbound stage can send control message, e.g.
- sendControl(ControlMessage) - Method in interface akka.remote.artery.OutboundContext
-
An inbound stage can send control message, e.g.
- sendControlMessage(ControlMessage) - Method in interface akka.remote.artery.OutboundControlJunction.OutboundControlIngress
-
- 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() - Static method in class akka.actor.AbstractActor
-
- sender() - Static method in class akka.actor.AbstractFSM
-
- 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() - Static method in class akka.camel.internal.CamelSupervisor
-
- sender() - Static method in class akka.cluster.AutoDown
-
- sender() - Static method in class akka.cluster.client.ClusterClient
-
- sender() - Static method in class akka.cluster.client.ClusterReceptionist
-
- sender() - Static method in class akka.cluster.ClusterHeartbeatSender
-
- sender() - Static method in class akka.cluster.ClusterRemoteWatcher
-
- sender() - Static method in class akka.cluster.ddata.LmdbDurableStore
-
- sender() - Static method in class akka.cluster.ddata.ReadAggregator
-
- sender() - Static method in class akka.cluster.ddata.ReadWriteAggregator
-
- sender() - Static method in class akka.cluster.ddata.Replicator
-
- sender() - Static method in class akka.cluster.ddata.WriteAggregator
-
- sender() - Static method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- sender() - Static method in class akka.cluster.sharding.ClusterShardingGuardian
-
- sender() - Static method in class akka.cluster.sharding.RemoveInternalClusterShardingData
-
- sender() - Static method in class akka.cluster.sharding.Shard
-
- sender() - Static method in class akka.cluster.sharding.ShardCoordinator
-
- sender() - Static method in class akka.cluster.sharding.ShardRegion
-
- sender() - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- sender() - Static method in class akka.cluster.singleton.ClusterSingletonProxy
-
- sender() - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- sender() - Method in class akka.contrib.pattern.ReliableProxy.Message
-
- sender() - Static method in class akka.contrib.pattern.ReliableProxy
-
- sender() - Method in class akka.contrib.throttle.TimerBasedThrottler.Message
-
- sender() - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- sender() - Method in class akka.dispatch.Envelope
-
- sender() - Static method in class akka.event.ActorClassificationUnsubscriber
-
- sender() - Static method in class akka.event.EventStreamUnsubscriber
-
- sender() - Static method in class akka.io.SelectionHandler
-
- sender() - Static method in class akka.io.SimpleDnsManager
-
- sender() - Static method in class akka.io.TcpConnection
-
- sender() - Static method in class akka.io.TcpListener
-
- sender() - Static method in class akka.io.TcpOutgoingConnection
-
- sender() - Method in class akka.io.Udp.Received
-
- sender() - Static method in class akka.pattern.BackoffSupervisor
-
- sender() - Method in class akka.persistence.AtomicWrite
-
- sender() - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- sender() - Method in class akka.persistence.journal.AsyncWriteJournal.Desequenced
-
- sender() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- sender() - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- sender() - Static method in class akka.persistence.journal.PersistencePluginProxy
-
- sender() - Static method in class akka.persistence.journal.ReplayFilter
-
- 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() - Static method in class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher
-
- sender() - Static method in class akka.persistence.RecoveryPermitter
-
- sender() - Static method in class akka.remote.artery.FlushOnShutdown
-
- sender() - Method in interface akka.remote.artery.InboundEnvelope
-
- sender() - Method in interface akka.remote.artery.OutboundEnvelope
-
- sender() - Method in class akka.remote.artery.ReusableInboundEnvelope
-
- sender() - Method in class akka.remote.artery.ReusableOutboundEnvelope
-
- sender() - Static method in class akka.remote.EndpointManager
-
- sender() - Static method in class akka.remote.EndpointReader
-
- sender() - Static method in class akka.remote.EndpointWriter
-
- sender() - Static method in class akka.remote.ReliableDeliverySupervisor
-
- sender() - Static method in class akka.remote.RemoteDeploymentWatcher
-
- sender() - Static method in class akka.remote.RemoteWatcher
-
- sender() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- sender() - Static method in class akka.remote.testconductor.ClientFSM
-
- sender() - Static method in class akka.remote.testconductor.Controller
-
- sender() - Static method in class akka.remote.testconductor.ServerFSM
-
- sender() - Static method in class akka.remote.transport.ProtocolStateActor
-
- sender() - Method in class akka.remote.transport.TestTransport.WriteAttempt
-
- sender() - Static method in class akka.remote.transport.ThrottledAssociation
-
- sender() - Static method in class akka.remote.transport.ThrottlerManager
-
- sender() - Static method in class akka.routing.ResizablePoolActor
-
- sender() - Static method in class akka.routing.RoutedActorCell
-
- sender() - Static method in class akka.stream.actor.AbstractActorPublisher
-
- sender() - Static method in class akka.stream.actor.AbstractActorSubscriber
-
- sender() - Static method in class akka.stream.actor.UntypedActorPublisher
-
- sender() - Static method in class akka.stream.actor.UntypedActorSubscriber
-
- sender() - Static method in class akka.stream.impl.ActorRefSinkActor
-
- sender() - Static method in class akka.stream.impl.ActorRefSourceActor
-
- sender() - Static method in class akka.stream.impl.FanIn
-
- sender() - Static method in class akka.stream.impl.FanOut
-
- sender() - Static method in class akka.stream.impl.FanoutProcessorImpl
-
- sender() - Static method in class akka.stream.impl.fusing.ActorGraphInterpreter
-
- sender() - Static method in class akka.stream.impl.io.FilePublisher
-
- sender() - Static method in class akka.stream.impl.io.FileSubscriber
-
- sender() - Static method in class akka.stream.impl.io.InputStreamPublisher
-
- sender() - Static method in class akka.stream.impl.io.OutputStreamSubscriber
-
- sender() - Static method in class akka.stream.impl.io.TLSActor
-
- sender() - Static method in class akka.stream.impl.StreamSupervisor
-
- sender() - Static method in class akka.stream.impl.Unzip
-
- 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() - Static method in class akka.testkit.TestActor
-
- 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
-
- senderActorRef(long) - Method in interface akka.remote.artery.HeaderBuilder
-
Retrive the compressed ActorRef by the compressionId carried by this header.
- senderActorRef(long) - Method in class akka.remote.artery.HeaderBuilderImpl
-
- senderActorRefPath() - Method in interface akka.remote.artery.HeaderBuilder
-
Retrive the raw literal actor path, instead of using the compressed value.
- senderActorRefPath() - Method in class akka.remote.artery.HeaderBuilderImpl
-
- SenderActorRefTagOffset() - Method in class akka.remote.artery.EnvelopeBuffer$
-
- SenderActorRefTagOffset() - Static method in class akka.remote.artery.EnvelopeBuffer
-
- senderAddress() - Method in class akka.cluster.ddata.WriteAggregator
-
- senderFromInbox(Inbox.Inbox) - Static method in class akka.actor.ActorDSL
-
- 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
-
- senderPersistentActor() - Method in interface akka.persistence.snapshot.SnapshotStore
-
Documents intent that the sender() is expected to be the PersistentActor
- sendError(Exception) - Method in class akka.stream.testkit.StreamTestKit.PublisherProbeSubscription
-
- sendError(Exception) - Method in class akka.stream.testkit.TestPublisher.Probe
-
- 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$
-
- sendGracefulShutdownToCoordinator() - Method in class akka.cluster.sharding.ShardRegion
-
- sendHandlers(ChannelRegistration) - Method in interface akka.io.WithUdpSend
-
- sendHeartbeat() - Static method in class akka.cluster.ClusterRemoteWatcher
-
- sendHeartbeat() - Method in class akka.remote.RemoteWatcher
-
- sendHostShardMsg(String, ActorRef) - Method in class akka.cluster.sharding.ShardCoordinator
-
- sendIdentify(Address) - Method in class akka.persistence.journal.PersistencePluginProxy
-
- sendMessage(Envelope) - Static method in class akka.actor.ActorCell
-
- sendMessage(Object, ActorRef) - Static method in class akka.actor.ActorCell
-
- 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.EntityStarted) - Method in class akka.cluster.sharding.Shard
-
- sendNext(I) - Method in class akka.stream.testkit.StreamTestKit.PublisherProbeSubscription
-
- sendNext(T) - Method in class akka.stream.testkit.TestPublisher.Probe
-
- 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
-
- sendOnSubscribe() - Method in class akka.stream.testkit.StreamTestKit.PublisherProbeSubscription
-
- SendQueue<T> - Class in akka.remote.artery
-
INTERNAL API
- SendQueue() - Constructor for class akka.remote.artery.SendQueue
-
- SendQueue$ - Class in akka.remote.artery
-
INTERNAL API
- SendQueue$() - Constructor for class akka.remote.artery.SendQueue$
-
- SendQueue.ProducerApi<T> - Interface in akka.remote.artery
-
- SendQueue.QueueValue<T> - Interface in akka.remote.artery
-
- sendResume(boolean) - Method in class akka.stream.impl.fusing.GraphInterpreterShell
-
- sendSystem(SystemMessage) - Method in class akka.typed.adapter.ActorRefAdapter
-
- sendSystem(SystemMessage) - Method in class akka.typed.adapter.ActorSystemAdapter
-
- sendSystem(SystemMessage) - Method in class akka.typed.internal.ActorCell
-
- sendSystem(SystemMessage) - Method in interface akka.typed.internal.ActorRefImpl
-
- sendSystem(SystemMessage) - Method in class akka.typed.internal.ActorSystemImpl
-
- sendSystem(SystemMessage) - Method in class akka.typed.internal.BlackholeActorRef$
-
- sendSystem(SystemMessage) - Static method in class akka.typed.internal.BlackholeActorRef
-
- sendSystem(SystemMessage) - Method in class akka.typed.internal.EventStreamImpl.StandardOutLogger
-
- sendSystem(SystemMessage) - Method in class akka.typed.internal.FunctionRef
-
- sendSystem(SystemMessage) - Method in class akka.typed.internal.FutureRef
-
- sendSystem(SystemMessage) - Method in class akka.typed.internal.LocalActorRef
-
- sendSystem(SystemMessage) - Static method in class akka.typed.internal.WatchableRef
-
- sendSystemMessage(SystemMessage) - Static method in class akka.actor.ActorCell
-
- 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) - Static method in class akka.actor.DeadLetterActorRef
-
- sendSystemMessage(SystemMessage) - Method in interface akka.actor.dungeon.Dispatch
-
- sendSystemMessage(SystemMessage) - Method in class akka.actor.EmptyLocalActorRef
-
- sendSystemMessage(SystemMessage) - Method in class akka.actor.FunctionRef
-
- 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) - Static method in class akka.actor.Nobody
-
- 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
-
- sendSystemMessage(SystemMessage) - Static method in class akka.routing.RoutedActorCell
-
- sendSystemMessage(SystemMessage) - Static method in class akka.testkit.TestActorRef
-
- sendSystemMessage(SystemMessage) - Static method in class akka.testkit.TestFSMRef
-
- sendTerminated() - Method in class akka.actor.FunctionRef
-
- sendTerminationHint(ActorRef) - Method in class akka.remote.artery.Association
-
- 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
-
- SendToSecondary$() - Constructor for class akka.cluster.ddata.ReadWriteAggregator.SendToSecondary$
-
- sendToSecondarySchedule() - Static method in class akka.cluster.ddata.ReadAggregator
-
- sendToSecondarySchedule() - Method in class akka.cluster.ddata.ReadWriteAggregator
-
- sendToSecondarySchedule() - Static method in class akka.cluster.ddata.WriteAggregator
-
- sendToSecondarySchedule_$eq(Cancellable) - Static method in class akka.cluster.ddata.ReadAggregator
-
- sendToSecondarySchedule_$eq(Cancellable) - Static method in class akka.cluster.ddata.WriteAggregator
-
- sendUpdate(akka.cluster.sharding.ShardCoordinator.Internal.DomainEvent) - Method in class akka.cluster.sharding.DDataShardCoordinator
-
- 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() - Method in class akka.stream.javadsl.Sink$
-
A Sink
that keeps on collecting incoming elements until upstream terminates.
- seq() - Static method in class akka.stream.javadsl.Sink
-
A Sink
that keeps on collecting incoming elements until upstream terminates.
- seq() - Method in class akka.stream.scaladsl.Sink$
-
A Sink
that keeps on collecting incoming elements until upstream terminates.
- seq() - Static method in class akka.stream.scaladsl.Sink
-
A Sink
that keeps on collecting incoming elements until upstream terminates.
- seq() - Static method in class akka.util.ByteIterator
-
- seq() - Static method in class akka.util.ByteString
-
- seq() - Static method in class akka.util.CompactByteString
-
- SEQ_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.RemoteEnvelope
-
- SeqActorName - Class in akka.stream.impl
-
INTERNAL API
As discussed in https://github.com/akka/akka/issues/16613
- SeqActorName() - Constructor for class akka.stream.impl.SeqActorName
-
- SeqActorName$ - Class in akka.stream.impl
-
- SeqActorName$() - Constructor for class akka.stream.impl.SeqActorName$
-
- SeqActorNameImpl - Class in akka.stream.impl
-
- SeqActorNameImpl(String, AtomicLong) - Constructor for class akka.stream.impl.SeqActorNameImpl
-
- 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() - Method in class akka.persistence.journal.ReplayFilter
-
- seqNo() - Method in class akka.remote.artery.SystemMessageDelivery.Ack
-
- seqNo() - Method in class akka.remote.artery.SystemMessageDelivery.Nack
-
- seqNo() - Method in class akka.remote.artery.SystemMessageDelivery.SystemMessageEnvelope
-
- 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$
-
- SEQNO_FIELD_NUMBER - Static variable in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck
-
- SEQNO_FIELD_NUMBER - Static variable in class akka.remote.ArteryControlFormats.SystemMessageEnvelope
-
- seqNr() - Method in class akka.event.ManagedActorClassification.ManagedActorClassificationMappings
-
- seqNum() - Method in interface akka.util.PriorityQueueStabilizer
-
- seqNum() - Method in class akka.util.PriorityQueueStabilizer.WrappedElement
-
- seqNum() - Method in class akka.util.StablePriorityBlockingQueue
-
- seqNum() - Method in class akka.util.StablePriorityQueue
-
- 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$
-
- seqSink() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- SeqStage<T> - Class in akka.stream.impl
-
- SeqStage() - Constructor for class akka.stream.impl.SeqStage
-
- 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
-
- sequence(long) - Method in class akka.persistence.query.Offset$
-
- Sequence - Class in akka.persistence.query
-
- Sequence(long) - Constructor for class akka.persistence.query.Sequence
-
- Sequence$ - Class in akka.persistence.query
-
- Sequence$() - Constructor for class akka.persistence.query.Sequence$
-
- sequenceNr() - Method in class akka.persistence.journal.leveldb.Key
-
- 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.query.EventEnvelope
-
- sequenceNr() - Method in class akka.persistence.query.EventEnvelope2
-
- 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 class akka.cluster.ddata.LmdbDurableStore
-
- serialization() - Static method in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer
-
- serialization() - Method in interface akka.cluster.ddata.protobuf.SerializationSupport
-
- serialization() - Method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- serialization() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
-
- serialization() - Method in class akka.persistence.journal.leveldb.SharedLeveldbStore
-
- serialization() - Method in class akka.remote.RemoteActorRefProvider
-
- Serialization - Class in akka.serialization
-
Serialization module.
- Serialization(ExtendedActorSystem) - Constructor for class akka.serialization.Serialization
-
- Serialization$ - Class in akka.serialization
-
- Serialization$() - Constructor for class akka.serialization.Serialization$
-
- Serialization.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
-
- SerializationException(String, Throwable) - Constructor for exception akka.remote.MessageSerializer.SerializationException
-
- 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$
-
- SerializationFormatCache - Class in akka.remote.artery
-
INTERNAL API
- SerializationFormatCache() - Constructor for class akka.remote.artery.SerializationFormatCache
-
- SerializationIdentifiers() - Static method in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer
-
- SerializationIdentifiers() - Static method in class akka.persistence.serialization.SnapshotSerializer
-
- SerializationIdentifiers() - Static method in class akka.remote.serialization.ArteryMessageSerializer
-
- SerializationIdentifiers() - Static method in class akka.remote.serialization.ProtobufSerializer
-
- SerializationIdentifiers() - Method in class akka.serialization.BaseSerializer$
-
Configuration namespace of serialization identifiers in the reference.conf
.
- SerializationIdentifiers() - Method in interface akka.serialization.BaseSerializer
-
Configuration namespace of serialization identifiers in the reference.conf
.
- SerializationIdentifiers() - Static method in class akka.serialization.JavaSerializer
-
- 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
-
- SerializationSetup - Class in akka.serialization
-
Setup for the serialization subsystem, constructor is *Internal API*, use factories in SerializationSetup()
- SerializationSetup$ - Class in akka.serialization
-
- SerializationSetup$() - Constructor for class akka.serialization.SerializationSetup$
-
- SerializationSupport - Interface in akka.cluster.ddata.protobuf
-
Some useful serialization helper methods.
- serializationTimingEnabled() - Method in class akka.remote.artery.RemoteInstrument
-
Should the serialization be timed? Otherwise times are always 0.
- serialize(OutputStream, Snapshot) - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
-
- serialize(OptionVal<OutboundEnvelope>, ByteBuffer) - Method in class akka.remote.artery.RemoteInstruments
-
- serialize(ExtendedActorSystem, Object) - Method in class akka.remote.MessageSerializer$
-
Uses Akka Serialization for the specified ActorSystem to transform the given message to a MessageProtocol
Throws NotSerializableException
if serializer was not configured for the message type.
- 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
Throws NotSerializableException
if serializer was not configured for the message type.
- 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.ArteryMessageSerializer
-
- 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.
- serializeActorRefCompressionAdvertisement(CompressionProtocol.ActorRefCompressionAdvertisement) - Method in class akka.remote.serialization.ArteryMessageSerializer
-
- serializeAddress(Address) - Method in class akka.remote.serialization.ArteryMessageSerializer
-
- SerializeAllCreators() - Method in class akka.actor.ActorSystem.Settings
-
- SerializeAllMessages() - Method in class akka.actor.ActorSystem.Settings
-
- serializeArteryHeartbeatRsp(long) - Method in class akka.remote.serialization.ArteryMessageSerializer
-
- serializeCompressionAdvertisement(CompressionProtocol.CompressionAdvertisement<T>, Function1<T, String>) - Method in class akka.remote.serialization.ArteryMessageSerializer
-
- serializeCompressionTableAdvertisementAck(UniqueAddress, int) - Method in class akka.remote.serialization.ArteryMessageSerializer
-
- 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
-
- SerializedStandardOutLogger() - Constructor for class akka.typed.internal.EventStreamImpl.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$
-
- serializeForArtery(Serialization, OutboundEnvelope, HeaderBuilder, EnvelopeBuffer) - Method in class akka.remote.MessageSerializer$
-
- serializeForArtery(Serialization, OutboundEnvelope, HeaderBuilder, EnvelopeBuffer) - Static method in class akka.remote.MessageSerializer
-
- serializeHandshakeReq(UniqueAddress, Address) - Method in class akka.remote.serialization.ArteryMessageSerializer
-
- serializeQuarantined(Quarantined) - Method in class akka.remote.serialization.ArteryMessageSerializer
-
- serializer() - Method in class akka.cluster.ddata.LmdbDurableStore
-
- serializer() - Method in class akka.cluster.ddata.Replicator
-
- serializer() - Method in interface akka.remote.artery.HeaderBuilder
-
- serializer() - Method in class akka.remote.artery.HeaderBuilderImpl
-
- serializer() - Method in interface akka.remote.artery.InboundEnvelope
-
- serializer() - Method in class akka.remote.artery.ReusableInboundEnvelope
-
- Serializer - Interface in akka.serialization
-
A Serializer represents a bimap between an object and an array of bytes representing that object.
- serializer() - Method in class akka.serialization.SerializerDetails
-
- serializerByIdentity() - Method in class akka.serialization.Serialization
-
Maps from a Serializer Identity (Int) to a Serializer instance (optimization)
- SerializerDetails - Class in akka.serialization
-
- SerializerDetails$ - Class in akka.serialization
-
- SerializerDetails$() - Constructor for class akka.serialization.SerializerDetails$
-
- 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.ddata.protobuf.msg.ReplicatorMessages.OtherMessage
-
- 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.ArteryControlFormats.SystemMessageEnvelope
-
- SERIALIZERID_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.Payload
-
- SERIALIZERID_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.SelectionEnvelope
-
- SERIALIZERID_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.SerializedMessage
-
- SERIALIZERIDS_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.PropsData
-
- 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
.
- SerializerOffset() - Method in class akka.remote.artery.EnvelopeBuffer$
-
- SerializerOffset() - Static method in class akka.remote.artery.EnvelopeBuffer
-
- Serializers() - Method in class akka.serialization.Serialization.Settings
-
- SerializerWithStringManifest - Class in akka.serialization
-
A Serializer represents a bimap between an object and an array of bytes representing that object.
- SerializerWithStringManifest() - Constructor for class akka.serialization.SerializerWithStringManifest
-
- serializeSystemMessageDeliveryAck(long, UniqueAddress) - Method in class akka.remote.serialization.ArteryMessageSerializer
-
- serializeSystemMessageEnvelope(SystemMessageDelivery.SystemMessageEnvelope) - Method in class akka.remote.serialization.ArteryMessageSerializer
-
- serializeThrowable(Throwable) - Method in class akka.remote.serialization.ThrowableSupport
-
- serializeUniqueAddress(UniqueAddress) - Method in class akka.remote.serialization.ArteryMessageSerializer
-
- serializeWithAddress(UniqueAddress) - Method in class akka.remote.serialization.ArteryMessageSerializer
-
- Server - Class in akka.remote.testconductor
-
INTERNAL API.
- Server() - Constructor for class akka.remote.testconductor.Server
-
- Server - Class in akka.stream
-
The server is usually the side the provides the service to its interlocutor.
- Server() - Constructor for class akka.stream.Server
-
- server() - Method in class akka.stream.TLSRole$
-
Java API: obtain the
Server
singleton value.
- server() - Static method in class akka.stream.TLSRole
-
Java API: obtain the
Server
singleton value.
- Server$ - Class in akka.remote.testconductor
-
INTERNAL API.
- Server$() - Constructor for class akka.remote.testconductor.Server$
-
- Server$ - Class in akka.stream
-
- Server$() - Constructor for class akka.stream.Server$
-
- ServerBinding(Tcp.ServerBinding) - Constructor for class akka.stream.javadsl.Tcp.ServerBinding
-
- ServerBinding(InetSocketAddress, Function0<Future<BoxedUnit>>) - Constructor for class akka.stream.scaladsl.Tcp.ServerBinding
-
- ServerBinding$() - Constructor for class akka.stream.scaladsl.Tcp.ServerBinding$
-
- 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.
- session() - Method in interface akka.stream.scaladsl.ScalaSessionAPI
-
The underlying SSLSession
.
- session() - Method in class akka.stream.TLSProtocol.SessionBytes
-
- SessionBytes(SSLSession, ByteString) - Constructor for class akka.stream.TLSProtocol.SessionBytes
-
- SessionBytes$() - Constructor for class akka.stream.TLSProtocol.SessionBytes$
-
- SessionTruncated() - Constructor for class akka.stream.TLSProtocol.SessionTruncated
-
- SessionTruncated$() - Constructor for class akka.stream.TLSProtocol.SessionTruncated$
-
- set(V) - Static method in class akka.remote.artery.FlightRecorder
-
- set(Channel, T) - Static method in class akka.remote.transport.netty.ChannelLocalActor
-
- set(ActorRef, ActorPublisherState.State) - Method in class akka.stream.actor.ActorPublisherState
-
- set(ActorRef, ActorSubscriberState.State) - Method in class akka.stream.actor.ActorSubscriberState
-
- set(V) - Static method in class akka.stream.impl.VirtualProcessor
-
- set(V) - Static method in class akka.util.SerializedSuspendableExecutionContext
-
- 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;
- setAckReplyTo(ArteryControlFormats.UniqueAddress) - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope.Builder
-
required .UniqueAddress ackReplyTo = 5;
- setAckReplyTo(ArteryControlFormats.UniqueAddress.Builder) - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope.Builder
-
required .UniqueAddress ackReplyTo = 5;
- setActor(ActorCell) - Method in class akka.dispatch.Mailbox
-
- setActor(ContainerFormats.ActorRef) - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
optional .ActorRef actor = 1;
- setActor(ContainerFormats.ActorRef.Builder) - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
optional .ActorRef actor = 1;
- setActor(ContainerFormats.ActorRef) - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData.Builder
-
required .ActorRef actor = 1;
- setActor(ContainerFormats.ActorRef.Builder) - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData.Builder
-
required .ActorRef actor = 1;
- setActorFields(Actor, ActorContext, ActorRef) - Method in class akka.actor.ActorCell
-
- setActorFields(Actor, ActorContext, ActorRef) - Static method in class akka.routing.RoutedActorCell
-
- 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(ReplicatorMessages.Address) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress.Builder
-
required .akka.cluster.ddata.Address address = 1;
- setAddress(ReplicatorMessages.Address.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress.Builder
-
required .akka.cluster.ddata.Address address = 1;
- 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(ArteryControlFormats.UniqueAddress) - Method in class akka.remote.ArteryControlFormats.MessageWithAddress.Builder
-
required .UniqueAddress address = 1;
- setAddress(ArteryControlFormats.UniqueAddress.Builder) - Method in class akka.remote.ArteryControlFormats.MessageWithAddress.Builder
-
required .UniqueAddress address = 1;
- setAddress(ArteryControlFormats.Address) - Method in class akka.remote.ArteryControlFormats.UniqueAddress.Builder
-
required .Address address = 1;
- setAddress(ArteryControlFormats.Address.Builder) - Method in class akka.remote.ArteryControlFormats.UniqueAddress.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;
- setAddressTerminated(boolean) - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData.Builder
-
required bool addressTerminated = 3;
- setAdds(int, String) - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet.Builder
-
repeated string adds = 1;
- setAdds(ByteString) - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2.Builder
-
optional bytes adds = 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.
- setAsync(boolean) - Method in class akka.remote.SystemMessageFormats.SuperviseData.Builder
-
required bool async = 2;
- setAutoAck(boolean) - Method in interface akka.camel.internal.component.ActorEndpointConfig
-
- setAutoPilot(TestActor.AutoPilot) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- setAutoPilot(TestActor.AutoPilot) - Static method in class akka.persistence.journal.JournalSpec
-
- setAutoPilot(TestActor.AutoPilot) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- setAutoPilot(TestActor.AutoPilot) - Static method in class akka.remote.testkit.MultiNodeSpec
-
- 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) - Static method in class akka.testkit.TestKit
-
- 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(TestActor.AutoPilot) - Static method in class akka.testkit.TestProbe
-
- 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;
- setCause(ContainerFormats.Payload) - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
required .Payload cause = 3;
- setCause(ContainerFormats.Payload.Builder) - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
required .Payload cause = 3;
- setCause(ContainerFormats.Payload) - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
optional .Payload cause = 3;
- setCause(ContainerFormats.Payload.Builder) - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
optional .Payload cause = 3;
- setCauseData(ContainerFormats.Payload) - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .Payload causeData = 3;
- setCauseData(ContainerFormats.Payload.Builder) - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .Payload causeData = 3;
- setChild(ContainerFormats.ActorRef) - Method in class akka.remote.SystemMessageFormats.FailedData.Builder
-
required .ActorRef child = 1;
- setChild(ContainerFormats.ActorRef.Builder) - Method in class akka.remote.SystemMessageFormats.FailedData.Builder
-
required .ActorRef child = 1;
- setChild(ContainerFormats.ActorRef) - Method in class akka.remote.SystemMessageFormats.SuperviseData.Builder
-
required .ActorRef child = 1;
- setChild(ContainerFormats.ActorRef.Builder) - Method in class akka.remote.SystemMessageFormats.SuperviseData.Builder
-
required .ActorRef child = 1;
- setChildrenTerminationReason(ChildrenContainer.SuspendReason) - Static method in class akka.actor.ActorCell
-
- setChildrenTerminationReason(ChildrenContainer.SuspendReason) - Method in interface akka.actor.dungeon.Children
-
- setChildrenTerminationReason(ChildrenContainer.SuspendReason) - Static method in class akka.routing.RoutedActorCell
-
- setChunk(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
required uint32 chunk = 1;
- setClassAssertionStatus(String, boolean) - Static method in class akka.osgi.BundleDelegatingClassLoader
-
- setClassName(String) - Method in class akka.remote.ContainerFormats.StackTraceElement.Builder
-
required string className = 1;
- setClassName(String) - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
required string className = 1;
- setClassNameBytes(ByteString) - Method in class akka.remote.ContainerFormats.StackTraceElement.Builder
-
required string className = 1;
- setClassNameBytes(ByteString) - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
required string className = 1;
- 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;
- setClosed() - Method in class akka.typed.internal.ActorCell
-
- setClosed() - Method in interface akka.typed.internal.SupervisionMechanics
-
- 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;
- setConsistency(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
required sint32 consistency = 2;
- setContactPoints(int, String) - Method in class akka.cluster.client.protobuf.msg.ClusterClientMessages.Contacts.Builder
-
repeated string contactPoints = 1;
- 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
-
- setCorrelationId(ContainerFormats.Payload) - Method in class akka.remote.ContainerFormats.ActorIdentity.Builder
-
required .Payload correlationId = 1;
- setCorrelationId(ContainerFormats.Payload.Builder) - Method in class akka.remote.ContainerFormats.ActorIdentity.Builder
-
required .Payload correlationId = 1;
- 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;
- setData(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed.Builder
-
required .akka.cluster.ddata.OtherMessage data = 2;
- setData(ReplicatorMessages.OtherMessage.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed.Builder
-
required .akka.cluster.ddata.OtherMessage data = 2;
- setData(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
required .akka.cluster.ddata.OtherMessage data = 1;
- setData(ReplicatorMessages.OtherMessage.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
required .akka.cluster.ddata.OtherMessage data = 1;
- setData(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelope.Builder
-
required .akka.cluster.ddata.OtherMessage data = 1;
- setData(ReplicatorMessages.OtherMessage.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DurableDataEnvelope.Builder
-
required .akka.cluster.ddata.OtherMessage data = 1;
- setData(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
required .akka.cluster.ddata.OtherMessage data = 2;
- setData(ReplicatorMessages.OtherMessage.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
required .akka.cluster.ddata.OtherMessage data = 2;
- setData(String, akka.cluster.ddata.Replicator.Internal.DataEnvelope) - Method in class akka.cluster.ddata.Replicator
-
- setData(MessageFormats.PersistentPayload) - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot.Builder
-
required .PersistentPayload data = 2;
- setData(MessageFormats.PersistentPayload.Builder) - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot.Builder
-
required .PersistentPayload data = 2;
- setDecrements(ReplicatedDataMessages.GCounter) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter.Builder
-
required .akka.cluster.ddata.GCounter decrements = 2;
- setDecrements(ReplicatedDataMessages.GCounter.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter.Builder
-
required .akka.cluster.ddata.GCounter decrements = 2;
- setDefaultAssertionStatus(boolean) - Static method in class akka.osgi.BundleDelegatingClassLoader
-
- 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.AtLeastOnceDeliveryLike
-
- 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;
- setDigest(ByteString) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry.Builder
-
required bytes digest = 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;
- setDots(int, ReplicatedDataMessages.VersionVector) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- setDots(int, ReplicatedDataMessages.VersionVector.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.VersionVector dots = 2;
- setDwNotificationData(SystemMessageFormats.DeathWatchNotificationData) - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .DeathWatchNotificationData dwNotificationData = 7;
- setDwNotificationData(SystemMessageFormats.DeathWatchNotificationData.Builder) - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .DeathWatchNotificationData dwNotificationData = 7;
- setElem(Try<T>) - Method in class akka.stream.impl.fusing.MapAsync.Holder
-
- setElements(int, String) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.StringGSet.Builder
-
repeated string elements = 1;
- setEnabled(boolean) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.Flag.Builder
-
required bool enabled = 1;
- setEnclosedMessage(ByteString) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage.Builder
-
required bytes enclosedMessage = 1;
- 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.Payload.Builder
-
required bytes enclosedMessage = 1;
- setEnclosedMessage(ByteString) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
required bytes enclosedMessage = 1;
- setEntities(int, String) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityState.Builder
-
repeated string entities = 1;
- setEntityCount(int) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats.Builder
-
required int32 entityCount = 2;
- setEntityId(String) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStarted.Builder
-
required string entityId = 1;
- setEntityId(String) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStopped.Builder
-
required string entityId = 1;
- setEntityIdBytes(ByteString) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStarted.Builder
-
required string entityId = 1;
- setEntityIdBytes(ByteString) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.EntityStopped.Builder
-
required string entityId = 1;
- setEntries(int, ReplicatedDataMessages.GCounter.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Builder
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- setEntries(int, ReplicatedDataMessages.GCounter.Entry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Builder
-
repeated .akka.cluster.ddata.GCounter.Entry entries = 1;
- setEntries(int, ReplicatedDataMessages.LWWMap.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- setEntries(int, ReplicatedDataMessages.LWWMap.Entry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
repeated .akka.cluster.ddata.LWWMap.Entry entries = 2;
- setEntries(int, ReplicatedDataMessages.ORMap.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- setEntries(int, ReplicatedDataMessages.ORMap.Entry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
repeated .akka.cluster.ddata.ORMap.Entry entries = 2;
- setEntries(int, ReplicatedDataMessages.ORMultiMap.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- setEntries(int, ReplicatedDataMessages.ORMultiMap.Entry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
repeated .akka.cluster.ddata.ORMultiMap.Entry entries = 2;
- setEntries(int, ReplicatedDataMessages.PNCounterMap.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- setEntries(int, ReplicatedDataMessages.PNCounterMap.Entry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
repeated .akka.cluster.ddata.PNCounterMap.Entry entries = 2;
- setEntries(int, ReplicatedDataMessages.VersionVector.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Builder
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- setEntries(int, ReplicatedDataMessages.VersionVector.Entry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Builder
-
repeated .akka.cluster.ddata.VersionVector.Entry entries = 1;
- setEntries(int, ReplicatorMessages.Gossip.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- setEntries(int, ReplicatorMessages.Gossip.Entry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
repeated .akka.cluster.ddata.Gossip.Entry entries = 2;
- setEntries(int, ReplicatorMessages.Status.Entry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
repeated .akka.cluster.ddata.Status.Entry entries = 3;
- setEntries(int, ReplicatorMessages.Status.Entry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
repeated .akka.cluster.ddata.Status.Entry entries = 3;
- setEnvelope(ReplicatorMessages.DataEnvelope) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry.Builder
-
required .akka.cluster.ddata.DataEnvelope envelope = 2;
- setEnvelope(ReplicatorMessages.DataEnvelope.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry.Builder
-
required .akka.cluster.ddata.DataEnvelope envelope = 2;
- setEnvelope(ReplicatorMessages.DataEnvelope) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResult.Builder
-
optional .akka.cluster.ddata.DataEnvelope envelope = 1;
- setEnvelope(ReplicatorMessages.DataEnvelope.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.ReadResult.Builder
-
optional .akka.cluster.ddata.DataEnvelope envelope = 1;
- setEnvelope(ReplicatorMessages.DataEnvelope) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write.Builder
-
required .akka.cluster.ddata.DataEnvelope envelope = 2;
- setEnvelope(ReplicatorMessages.DataEnvelope.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write.Builder
-
required .akka.cluster.ddata.DataEnvelope envelope = 2;
- 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;
- setExistenceConfirmed(boolean) - Method in class akka.remote.SystemMessageFormats.DeathWatchNotificationData.Builder
-
required bool existenceConfirmed = 2;
- setExitValue(int) - Method in class akka.remote.testconductor.TestConductorProtocol.InjectFailure.Builder
-
optional int32 exitValue = 7;
- setFailed(ActorRef) - Method in interface akka.actor.dungeon.FaultHandling
-
- setFailedData(SystemMessageFormats.FailedData) - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .FailedData failedData = 6;
- setFailedData(SystemMessageFormats.FailedData.Builder) - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .FailedData failedData = 6;
- 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;
- setFileName(String) - Method in class akka.remote.ContainerFormats.StackTraceElement.Builder
-
required string fileName = 3;
- setFileNameBytes(ByteString) - Method in class akka.remote.ContainerFormats.StackTraceElement.Builder
-
required string fileName = 3;
- setFixedPoolSize(int) - Method in class akka.dispatch.ThreadPoolConfigBuilder
-
- setFlag(ByteFlag, boolean) - Method in interface akka.remote.artery.HeaderBuilder
-
- setFlag(ByteFlag, boolean) - Method in class akka.remote.artery.HeaderBuilderImpl
-
- setFlags(byte) - Method in interface akka.remote.artery.HeaderBuilder
-
- setFlags(byte) - Method in class akka.remote.artery.HeaderBuilderImpl
-
- setForkJoinTaskTag(short) - Static method in class akka.dispatch.Mailbox
-
- 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;
- setFrom(ArteryControlFormats.UniqueAddress) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
required .UniqueAddress from = 1;
- setFrom(ArteryControlFormats.UniqueAddress.Builder) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
required .UniqueAddress from = 1;
- setFrom(ArteryControlFormats.UniqueAddress) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck.Builder
-
required .UniqueAddress from = 1;
- setFrom(ArteryControlFormats.UniqueAddress.Builder) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck.Builder
-
required .UniqueAddress from = 1;
- setFrom(ArteryControlFormats.UniqueAddress) - Method in class akka.remote.ArteryControlFormats.HandshakeReq.Builder
-
required .UniqueAddress from = 1;
- setFrom(ArteryControlFormats.UniqueAddress.Builder) - Method in class akka.remote.ArteryControlFormats.HandshakeReq.Builder
-
required .UniqueAddress from = 1;
- setFrom(ArteryControlFormats.UniqueAddress) - Method in class akka.remote.ArteryControlFormats.Quarantined.Builder
-
required .UniqueAddress from = 1;
- setFrom(ArteryControlFormats.UniqueAddress.Builder) - Method in class akka.remote.ArteryControlFormats.Quarantined.Builder
-
required .UniqueAddress from = 1;
- setFrom(ArteryControlFormats.UniqueAddress) - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck.Builder
-
required .UniqueAddress from = 2;
- setFrom(ArteryControlFormats.UniqueAddress.Builder) - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck.Builder
-
required .UniqueAddress from = 2;
- 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;
- setHandler(GraphInterpreter.Connection, InHandler) - Method in class akka.stream.impl.fusing.GraphInterpreter
-
Dynamic handler changes are communicated from a GraphStageLogic by this method.
- setHandler(GraphInterpreter.Connection, OutHandler) - Method in class akka.stream.impl.fusing.GraphInterpreter
-
Dynamic handler changes are communicated from a GraphStageLogic by this method.
- setHandler(Inlet<?>, InHandler) - Method in class akka.stream.stage.GraphStageLogic
-
Assigns callbacks for the events for an Inlet
- setHandler(Outlet<?>, OutHandler) - Method in class akka.stream.stage.GraphStageLogic
-
Assigns callbacks for the events for an Outlet
- setHandler(InHandler) - Method in class akka.stream.stage.GraphStageLogic.SubSinkInlet
-
- setHandler(OutHandler) - Method in class akka.stream.stage.GraphStageLogic.SubSourceOutlet
-
Set OutHandler for this dynamic output port; this needs to be done before
the first substream callback can arrive.
- setHandlers(Inlet<?>, Outlet<?>, InHandler) - Method in class akka.stream.stage.GraphStageLogic
-
Assign callbacks for linear stage for both Inlet
and Outlet
- 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;
- setHasManifest(int, boolean) - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated bool hasManifest = 7;
- 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.ddata.protobuf.msg.ReplicatorMessages.Address.Builder
-
required string hostname = 1;
- 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.ArteryControlFormats.Address.Builder
-
required string hostname = 3;
- setHostname(String) - Method in class akka.remote.WireFormats.AddressData.Builder
-
required string hostname = 2;
- setHostnameBytes(ByteString) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Address.Builder
-
required string hostname = 1;
- 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.ArteryControlFormats.Address.Builder
-
required string hostname = 3;
- setHostnameBytes(ByteString) - Method in class akka.remote.WireFormats.AddressData.Builder
-
required string hostname = 2;
- setIfAbsent(Channel, T) - Static method in class akka.remote.transport.netty.ChannelLocalActor
-
- SetIgnore(Option<PartialFunction<Object, Object>>) - Constructor for class akka.testkit.TestActor.SetIgnore
-
- SetIgnore$() - Constructor for class akka.testkit.TestActor.SetIgnore$
-
- setIncrements(ReplicatedDataMessages.GCounter) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter.Builder
-
required .akka.cluster.ddata.GCounter increments = 1;
- setIncrements(ReplicatedDataMessages.GCounter.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounter.Builder
-
required .akka.cluster.ddata.GCounter increments = 1;
- 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;
- setIntElements(int, int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated sint32 intElements = 2 [packed = true];
- setIntElements(int, int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated sint32 intElements = 4 [packed = true];
- setKeepAliveTime(Duration) - Method in class akka.dispatch.ThreadPoolConfigBuilder
-
- setKeepAliveTimeInMillis(long) - Method in class akka.dispatch.ThreadPoolConfigBuilder
-
- setKeepGoing(GraphStageLogic, boolean) - Method in class akka.stream.impl.fusing.GraphInterpreter
-
- setKeepGoing(boolean) - Method in class akka.stream.stage.GraphStageLogic
-
Controls whether this stage shall shut down when all its ports are closed, which
is the default.
- setKey(String) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry.Builder
-
required string key = 1;
- setKey(String) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry.Builder
-
required string key = 1;
- setKey(String) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry.Builder
-
required string key = 1;
- setKey(String) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry.Builder
-
required string key = 1;
- setKey(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- setKey(ReplicatorMessages.OtherMessage.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Changed.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- setKey(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- setKey(ReplicatorMessages.OtherMessage.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- setKey(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- setKey(ReplicatorMessages.OtherMessage.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- setKey(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- setKey(ReplicatorMessages.OtherMessage.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- setKey(String) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry.Builder
-
required string key = 1;
- setKey(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- setKey(ReplicatorMessages.OtherMessage.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- setKey(String) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Read.Builder
-
required string key = 1;
- setKey(String) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry.Builder
-
required string key = 1;
- setKey(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- setKey(ReplicatorMessages.OtherMessage.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- setKey(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- setKey(ReplicatorMessages.OtherMessage.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe.Builder
-
required .akka.cluster.ddata.OtherMessage key = 1;
- setKey(String) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write.Builder
-
required string key = 1;
- 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.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry.Builder
-
required string key = 1;
- setKeyBytes(ByteString) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry.Builder
-
required string key = 1;
- setKeyBytes(ByteString) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry.Builder
-
required string key = 1;
- setKeyBytes(ByteString) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry.Builder
-
required string key = 1;
- setKeyBytes(ByteString) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Entry.Builder
-
required string key = 1;
- setKeyBytes(ByteString) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Read.Builder
-
required string key = 1;
- setKeyBytes(ByteString) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Entry.Builder
-
required string key = 1;
- setKeyBytes(ByteString) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Write.Builder
-
required string key = 1;
- setKeyBytes(ByteString) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
required string key = 1;
- setKeys(ReplicatedDataMessages.ORSet) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- setKeys(ReplicatedDataMessages.ORSet.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- setKeys(ReplicatedDataMessages.ORSet) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- setKeys(ReplicatedDataMessages.ORSet.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- setKeys(ReplicatedDataMessages.ORSet) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- setKeys(ReplicatedDataMessages.ORSet.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- setKeys(ReplicatedDataMessages.ORSet) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- setKeys(ReplicatedDataMessages.ORSet.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Builder
-
required .akka.cluster.ddata.ORSet keys = 1;
- setKeys(int, String) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
repeated string keys = 4;
- setLastSequenceNr(long) - Method in interface akka.persistence.Eventsourced
-
- setLastSequenceNr(long) - Method in interface akka.persistence.PersistentView
-
Deprecated.
- setLetter(String) - Method in class docs.persistence.proto.FlightAppModels.SeatReserved.Builder
-
required string letter = 1;
- setLetterBytes(ByteString) - Method in class docs.persistence.proto.FlightAppModels.SeatReserved.Builder
-
required string letter = 1;
- setLineNumber(int) - Method in class akka.remote.ContainerFormats.StackTraceElement.Builder
-
required int32 lineNumber = 4;
- setLocalAffinity(boolean) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Send.Builder
-
required bool localAffinity = 2;
- setLogLevel(Logging.LogLevel) - Static method in class akka.event.EventStream
-
- setLogLevel(Logging.LogLevel) - Method in interface akka.event.LoggingBus
-
Change log level: default loggers (i.e.
- setLogLevel(Logging.LogLevel) - Method in class akka.typed.adapter.EventStreamAdapter
-
- setLogLevel(Logging.LogLevel) - Method in interface akka.typed.EventStream
-
Change the current minimum log level.
- setLogLevel(Logging.LogLevel) - Method in class akka.typed.internal.EventStreamImpl
-
Change log level: default loggers (i.e.
- setLongElements(int, long) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated sint64 longElements = 3 [packed = true];
- setLongElements(int, long) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated sint64 longElements = 5 [packed = true];
- setManifest(String) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional string manifest = 12;
- setManifest(String) - Method in interface akka.remote.artery.HeaderBuilder
-
- setManifest(String) - Method in class akka.remote.artery.HeaderBuilderImpl
-
- setManifestBytes(ByteString) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional string manifest = 12;
- setManifests(int, String) - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated string manifests = 5;
- 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(ByteString) - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope.Builder
-
required bytes message = 1;
- setMessage(String) - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
required string message = 2;
- setMessage(String) - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
optional string message = 2;
- 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;
- setMessageBytes(ByteString) - Method in class akka.remote.ContainerFormats.ActorInitializationException.Builder
-
required string message = 2;
- setMessageBytes(ByteString) - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
optional string message = 2;
- setMessageId(ContainerFormats.Payload) - Method in class akka.remote.ContainerFormats.Identify.Builder
-
required .Payload messageId = 1;
- setMessageId(ContainerFormats.Payload.Builder) - Method in class akka.remote.ContainerFormats.Identify.Builder
-
required .Payload messageId = 1;
- setMessageManifest(ByteString) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage.Builder
-
optional bytes messageManifest = 4;
- setMessageManifest(ByteString) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Payload.Builder
-
optional bytes messageManifest = 4;
- setMessageManifest(ByteString) - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope.Builder
-
optional bytes messageManifest = 3;
- setMessageManifest(ByteString) - Method in class akka.remote.ContainerFormats.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;
- setMethodName(String) - Method in class akka.remote.ContainerFormats.StackTraceElement.Builder
-
required string methodName = 2;
- setMethodNameBytes(ByteString) - Method in class akka.remote.ContainerFormats.StackTraceElement.Builder
-
required string methodName = 2;
- 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;
- setNewSessionParameters(TLSProtocol.NegotiateNewSession) - Method in class akka.stream.impl.io.TLSActor
-
- setNext(AbstractBoundedNodeQueue.Node<T>) - Method in class akka.dispatch.AbstractBoundedNodeQueue.Node
-
- setNext(AbstractNodeQueue.Node<T>) - Method in class akka.dispatch.AbstractNodeQueue.Node
-
- setNode(ReplicatorMessages.UniqueAddress) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry.Builder
-
required .akka.cluster.ddata.UniqueAddress node = 1;
- setNode(ReplicatorMessages.UniqueAddress.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry.Builder
-
required .akka.cluster.ddata.UniqueAddress node = 1;
- setNode(ReplicatorMessages.UniqueAddress) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
required .akka.cluster.ddata.UniqueAddress node = 2;
- setNode(ReplicatorMessages.UniqueAddress.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
required .akka.cluster.ddata.UniqueAddress node = 2;
- setNode(ReplicatorMessages.UniqueAddress) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry.Builder
-
required .akka.cluster.ddata.UniqueAddress node = 1;
- setNode(ReplicatorMessages.UniqueAddress.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry.Builder
-
required .akka.cluster.ddata.UniqueAddress node = 1;
- 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;
- setNoRecipient() - Method in interface akka.remote.artery.HeaderBuilder
-
- setNoRecipient() - Method in class akka.remote.artery.HeaderBuilderImpl
-
- setNoSender() - Method in interface akka.remote.artery.HeaderBuilder
-
- setNoSender() - Method in class akka.remote.artery.HeaderBuilderImpl
-
- 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;
- setOriginUid(long) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
required uint64 originUid = 2;
- setOtherElements(int, ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- setOtherElements(int, ReplicatorMessages.OtherMessage.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 4;
- setOtherElements(int, ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- setOtherElements(int, ReplicatorMessages.OtherMessage.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated .akka.cluster.ddata.OtherMessage otherElements = 6;
- setOutboundActorRefCompression(CompressionTable<ActorRef>) - Method in interface akka.remote.artery.HeaderBuilder
-
- setOutboundActorRefCompression(CompressionTable<ActorRef>) - Method in class akka.remote.artery.HeaderBuilderImpl
-
- setOutboundClassManifestCompression(CompressionTable<String>) - Method in interface akka.remote.artery.HeaderBuilder
-
- setOutboundClassManifestCompression(CompressionTable<String>) - Method in class akka.remote.artery.HeaderBuilderImpl
-
- 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;
- setOwnerAddress(ReplicatorMessages.UniqueAddress) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
required .akka.cluster.ddata.UniqueAddress ownerAddress = 2;
- setOwnerAddress(ReplicatorMessages.UniqueAddress.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
required .akka.cluster.ddata.UniqueAddress ownerAddress = 2;
- setPackageAssertionStatus(String, boolean) - Static method in class akka.osgi.BundleDelegatingClassLoader
-
- 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.ContainerFormats.ActorRef.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.ContainerFormats.ActorRef.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(DistributedPubSubMessages.Payload) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToOneSubscriber.Builder
-
required .Payload payload = 1;
- setPayload(DistributedPubSubMessages.Payload.Builder) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.SendToOneSubscriber.Builder
-
required .Payload payload = 1;
- 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(int, MessageFormats.PersistentMessage) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
-
repeated .PersistentMessage payload = 1;
- setPayload(int, MessageFormats.PersistentMessage.Builder) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
-
repeated .PersistentMessage payload = 1;
- 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;
- setPerformed(boolean) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
required bool performed = 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.ddata.protobuf.msg.ReplicatorMessages.Address.Builder
-
required uint32 port = 2;
- 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.ArteryControlFormats.Address.Builder
-
required uint32 port = 4;
- 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;
- setProperty(String, String) - Static method in class akka.remote.security.provider.AkkaProvider
-
- 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.ArteryControlFormats.Address.Builder
-
required string protocol = 1;
- 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.ArteryControlFormats.Address.Builder
-
required string protocol = 1;
- 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;
- setPruning(int, ReplicatorMessages.DataEnvelope.PruningEntry) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- setPruning(int, ReplicatorMessages.DataEnvelope.PruningEntry.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.Builder
-
repeated .akka.cluster.ddata.DataEnvelope.PruningEntry pruning = 2;
- 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) - Static method in class akka.actor.ActorCell
-
- 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) - Static method in class akka.routing.RoutedActorCell
-
- setReceiveTimeout(FiniteDuration, T) - Method in interface akka.typed.ActorContext
-
Schedule the sending of a notification in case no other
message is received during the given period of time.
- setReceiveTimeout(FiniteDuration, T) - Method in class akka.typed.adapter.ActorContextAdapter
-
- setReceiveTimeout(FiniteDuration, T) - Method in class akka.typed.EffectfulActorContext
-
- setReceiveTimeout(FiniteDuration, T) - Method in class akka.typed.internal.ActorCell
-
- setReceiveTimeout(FiniteDuration, T) - 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;
- setRecipientActorRef(ActorRef) - Method in interface akka.remote.artery.HeaderBuilder
-
- setRecipientActorRef(ActorRef) - Method in class akka.remote.artery.HeaderBuilderImpl
-
- setRef(String) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe.Builder
-
required string ref = 2;
- setRef(String) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe.Builder
-
required string ref = 2;
- setRef(String) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
optional string ref = 3;
- setRef(String) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ActorRefMessage.Builder
-
required string ref = 1;
- setRef(ContainerFormats.ActorRef) - Method in class akka.remote.ContainerFormats.ActorIdentity.Builder
-
optional .ActorRef ref = 2;
- setRef(ContainerFormats.ActorRef.Builder) - Method in class akka.remote.ContainerFormats.ActorIdentity.Builder
-
optional .ActorRef ref = 2;
- setRefBytes(ByteString) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Subscribe.Builder
-
required string ref = 2;
- setRefBytes(ByteString) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Unsubscribe.Builder
-
required string ref = 2;
- setRefBytes(ByteString) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Delta.Entry.Builder
-
optional string ref = 3;
- setRefBytes(ByteString) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ActorRefMessage.Builder
-
required string ref = 1;
- setRegion(String) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome.Builder
-
required string region = 2;
- setRegion(String) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated.Builder
-
required string region = 2;
- setRegionBytes(ByteString) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome.Builder
-
required string region = 2;
- setRegionBytes(ByteString) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated.Builder
-
required string region = 2;
- setRegionProxies(int, String) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string regionProxies = 3;
- setRegionRef(String) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry.Builder
-
required string regionRef = 2;
- setRegionRefBytes(ByteString) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry.Builder
-
required string regionRef = 2;
- setRegions(int, String) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string regions = 2;
- setRemoteInstruments(RemoteInstruments) - Method in interface akka.remote.artery.HeaderBuilder
-
- setRemoteInstruments(RemoteInstruments) - Method in class akka.remote.artery.HeaderBuilderImpl
-
- setRemovals(int, String) - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet.Builder
-
repeated string removals = 2;
- setRemovals(ByteString) - Method in class docs.ddata.protobuf.msg.TwoPhaseSetMessages.TwoPhaseSet2.Builder
-
optional bytes removals = 2;
- setRemovedAddress(ReplicatorMessages.UniqueAddress) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
required .akka.cluster.ddata.UniqueAddress removedAddress = 1;
- setRemovedAddress(ReplicatorMessages.UniqueAddress.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
required .akka.cluster.ddata.UniqueAddress removedAddress = 1;
- 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
-
- setReplyToStatus(boolean) - Method in class akka.cluster.pubsub.protobuf.msg.DistributedPubSubMessages.Status.Builder
-
optional bool replyToStatus = 2;
- setRequest(CamelMessage) - Method in class akka.camel.internal.CamelExchangeAdapter
-
Sets Exchange.getIn from the given CamelMessage object.
- setRequest(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- setRequest(ReplicatorMessages.OtherMessage.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- setRequest(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- setRequest(ReplicatorMessages.OtherMessage.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetFailure.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- setRequest(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- setRequest(ReplicatorMessages.OtherMessage.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.GetSuccess.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 4;
- setRequest(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- setRequest(ReplicatorMessages.OtherMessage.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.NotFound.Builder
-
optional .akka.cluster.ddata.OtherMessage request = 2;
- 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;
- setRow(int) - Method in class docs.persistence.proto.FlightAppModels.SeatReserved.Builder
-
required uint32 row = 2;
- setScope(ByteString) - Method in class akka.remote.WireFormats.DeployData.Builder
-
optional bytes scope = 4;
- setSeatType(String) - Method in class docs.persistence.proto.FlightAppModels.SeatReserved.Builder
-
optional string seatType = 3;
- setSeatTypeBytes(ByteString) - Method in class docs.persistence.proto.FlightAppModels.SeatReserved.Builder
-
optional string seatType = 3;
- setSeen(int, ReplicatorMessages.Address) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
repeated .akka.cluster.ddata.Address seen = 4;
- setSeen(int, ReplicatorMessages.Address.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.DataEnvelope.PruningEntry.Builder
-
repeated .akka.cluster.ddata.Address seen = 4;
- setSeen(int, int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.GossipOverview.Builder
-
repeated int32 seen = 1;
- setSelf(ActorRefImpl<T>) - Method in class akka.typed.internal.ActorCell
-
- setSendBack(boolean) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Gossip.Builder
-
required bool sendBack = 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;
- setSenderActorRef(ActorRef) - Method in interface akka.remote.artery.HeaderBuilder
-
- setSenderActorRef(ActorRef) - Method in class akka.remote.artery.HeaderBuilderImpl
-
- 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;
- setSeqNo(long) - Method in class akka.remote.ArteryControlFormats.SystemMessageDeliveryAck.Builder
-
required uint64 seqNo = 1;
- setSeqNo(long) - Method in class akka.remote.ArteryControlFormats.SystemMessageEnvelope.Builder
-
required uint64 seqNo = 4;
- 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;
- setSerializer(int) - Method in interface akka.remote.artery.HeaderBuilder
-
- setSerializer(int) - Method in class akka.remote.artery.HeaderBuilderImpl
-
- setSerializerId(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.OtherMessage.Builder
-
required int32 serializerId = 2;
- 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.ArteryControlFormats.SystemMessageEnvelope.Builder
-
required int32 serializerId = 2;
- setSerializerId(int) - Method in class akka.remote.ContainerFormats.Payload.Builder
-
required int32 serializerId = 2;
- 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;
- setSerializerIds(int, int) - Method in class akka.remote.WireFormats.PropsData.Builder
-
repeated int32 serializerIds = 6;
- setShard(String) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome.Builder
-
required string shard = 1;
- setShard(String) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated.Builder
-
required string shard = 1;
- setShard(String) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessage.Builder
-
required string shard = 1;
- setShard(String) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats.Builder
-
required string shard = 1;
- setShardBytes(ByteString) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome.Builder
-
required string shard = 1;
- setShardBytes(ByteString) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated.Builder
-
required string shard = 1;
- setShardBytes(ByteString) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessage.Builder
-
required string shard = 1;
- setShardBytes(ByteString) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats.Builder
-
required string shard = 1;
- setShardId(String) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry.Builder
-
required string shardId = 1;
- setShardIdBytes(ByteString) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry.Builder
-
required string shardId = 1;
- setShards(int, ClusterShardingMessages.CoordinatorState.ShardEntry) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated .CoordinatorState.ShardEntry shards = 1;
- setShards(int, ClusterShardingMessages.CoordinatorState.ShardEntry.Builder) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated .CoordinatorState.ShardEntry shards = 1;
- setSigners(Class<?>, Object[]) - Static method in class akka.osgi.BundleDelegatingClassLoader
-
- setStackTrace(StackTraceElement[]) - Static method in exception akka.actor.ActorInitializationException
-
- setStackTrace(StackTraceElement[]) - Static method in exception akka.actor.ActorKilledException
-
- setStackTrace(StackTraceElement[]) - Static method in exception akka.actor.ActorNotFound
-
- setStackTrace(StackTraceElement[]) - Static method in exception akka.actor.DeathPactException
-
- setStackTrace(StackTraceElement[]) - Static method in exception akka.actor.IllegalActorStateException
-
- setStackTrace(StackTraceElement[]) - Static method in exception akka.actor.InvalidActorNameException
-
- setStackTrace(StackTraceElement[]) - Static method in exception akka.actor.InvalidMessageException
-
- setStackTrace(StackTraceElement[]) - Static method in exception akka.actor.PostRestartException
-
- setStackTrace(StackTraceElement[]) - Static method in exception akka.actor.PreRestartException
-
- setStackTrace(StackTraceElement[]) - Static method in exception akka.actor.SchedulerException
-
- setStackTrace(StackTraceElement[]) - Static method in exception akka.actor.StashOverflowException
-
- setStackTrace(StackTraceElement[]) - Static method in exception akka.contrib.circuitbreaker.OpenCircuitException
-
- setStackTrace(StackTraceElement[]) - Static method in exception akka.pattern.CircuitBreakerOpenException
-
- setStackTrace(int, ContainerFormats.StackTraceElement) - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
repeated .StackTraceElement stackTrace = 4;
- setStackTrace(int, ContainerFormats.StackTraceElement.Builder) - Method in class akka.remote.ContainerFormats.Throwable.Builder
-
repeated .StackTraceElement stackTrace = 4;
- setStackTrace(StackTraceElement[]) - Static method in exception akka.remote.HopelessAssociation
-
- setStackTrace(StackTraceElement[]) - Static method in exception akka.remote.InvalidAssociation
-
- setStackTrace(StackTraceElement[]) - Static method in exception akka.remote.ShutDownAssociation
-
- setStackTrace(StackTraceElement[]) - Static method in exception akka.remote.transport.FailureInjectorException
-
- setStackTrace(StackTraceElement[]) - Static method in exception akka.stream.AbruptTerminationException
-
- setStackTrace(StackTraceElement[]) - Static method in exception akka.stream.BindFailedException
-
- setStackTrace(StackTraceElement[]) - Static method in exception akka.stream.BufferOverflowException
-
- setStackTrace(StackTraceElement[]) - Static method in exception akka.stream.MaterializationException
-
- setStackTrace(StackTraceElement[]) - Static method in exception akka.typed.DeathPactException
-
- setState(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
required .akka.cluster.ddata.OtherMessage state = 3;
- setState(ReplicatorMessages.OtherMessage.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
required .akka.cluster.ddata.OtherMessage state = 3;
- 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).
- setStateIdentifier(String) - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot.Builder
-
required string stateIdentifier = 1;
- setStateIdentifier(String) - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
-
required string stateIdentifier = 1;
- setStateIdentifierBytes(ByteString) - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot.Builder
-
required string stateIdentifier = 1;
- setStateIdentifierBytes(ByteString) - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
-
required string stateIdentifier = 1;
- setStateTimeout(S, Option<FiniteDuration>) - Static method in class akka.actor.AbstractFSM
-
- setStateTimeout(S, Option<FiniteDuration>) - Method in interface akka.actor.FSM
-
- setStateTimeout(S, Option<FiniteDuration>) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- setStateTimeout(S, Option<FiniteDuration>) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- setStateTimeout(S, Option<FiniteDuration>) - Static method in class akka.contrib.pattern.ReliableProxy
-
- setStateTimeout(S, Option<FiniteDuration>) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- setStateTimeout(S, Option<FiniteDuration>) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- setStateTimeout(S, Option<FiniteDuration>) - Method in interface akka.persistence.fsm.PersistentFSMBase
-
- setStateTimeout(S, Option<FiniteDuration>) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- setStateTimeout(S, Option<FiniteDuration>) - Static method in class akka.remote.testconductor.ClientFSM
-
- setStateTimeout(S, Option<FiniteDuration>) - Static method in class akka.remote.testconductor.ServerFSM
-
- setStateTimeout(S, Option<FiniteDuration>) - Static method in class akka.remote.transport.ProtocolStateActor
-
- setStateTimeout(S, Option<FiniteDuration>) - Static method in class akka.remote.transport.ThrottledAssociation
-
- 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$
-
- setStringElements(int, String) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet.Builder
-
repeated string stringElements = 1;
- setStringElements(int, String) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
repeated string stringElements = 3;
- 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;
- setSuperviseData(SystemMessageFormats.SuperviseData) - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .SuperviseData superviseData = 5;
- setSuperviseData(SystemMessageFormats.SuperviseData.Builder) - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .SuperviseData superviseData = 5;
- 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.ArteryControlFormats.Address.Builder
-
required string system = 2;
- 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.ArteryControlFormats.Address.Builder
-
required string system = 2;
- 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;
- setTableVersion(int) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
required uint32 tableVersion = 3;
- 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$
-
- setTargetLocation(ActorSystem, Address) - Method in class akka.persistence.journal.PersistencePluginProxy$
-
- setTargetLocation(ActorSystem, Address) - Static method in class akka.persistence.journal.PersistencePluginProxy
-
- setTerminated() - Static method in class akka.actor.ActorCell
-
- setTerminated() - Method in interface akka.actor.dungeon.Children
-
- setTerminated() - Static method in class akka.routing.RoutedActorCell
-
- setTerminating() - Method in class akka.typed.internal.ActorCell
-
- setTerminating() - Method in interface akka.typed.internal.SupervisionMechanics
-
- 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(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Get.Builder
-
required uint32 timeout = 3;
- setTimeout(String) - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
-
optional string timeout = 2;
- setTimeout(long) - Method in class akka.remote.testconductor.TestConductorProtocol.EnterBarrier.Builder
-
optional int64 timeout = 3;
- setTimeoutBytes(ByteString) - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
-
optional string timeout = 2;
- setTimeoutNanos(long) - Method in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot.Builder
-
optional int64 timeoutNanos = 3;
- setTimeoutNanos(long) - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
-
optional int64 timeoutNanos = 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) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- setTimer(String, Object, FiniteDuration, boolean) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- setTimer(String, Object, FiniteDuration, boolean) - Static method in class akka.contrib.pattern.ReliableProxy
-
- setTimer(String, Object, FiniteDuration, boolean) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- setTimer(String, Object, FiniteDuration) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
Schedule named timer to deliver message after given delay, possibly repeating.
- setTimer(String, Object, FiniteDuration, boolean) - Method in interface akka.persistence.fsm.PersistentFSMBase
-
- setTimer(String, Object, FiniteDuration, boolean) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- setTimer(String, Object, FiniteDuration, boolean) - Static method in class akka.remote.testconductor.ClientFSM
-
- setTimer(String, Object, FiniteDuration, boolean) - Static method in class akka.remote.testconductor.ServerFSM
-
- setTimer(String, Object, FiniteDuration, boolean) - Static method in class akka.remote.transport.ProtocolStateActor
-
- setTimer(String, Object, FiniteDuration, boolean) - Static method in class akka.remote.transport.ThrottledAssociation
-
- setTimer(String, Object, FiniteDuration, boolean) - Method in class akka.testkit.TestFSMRef
-
- setTimer$default$4() - Static method in class akka.actor.AbstractFSM
-
- setTimer$default$4() - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- setTimer$default$4() - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- setTimer$default$4() - Static method in class akka.contrib.pattern.ReliableProxy
-
- setTimer$default$4() - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- setTimer$default$4() - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- setTimer$default$4() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- setTimer$default$4() - Static method in class akka.remote.testconductor.ClientFSM
-
- setTimer$default$4() - Static method in class akka.remote.testconductor.ServerFSM
-
- setTimer$default$4() - Static method in class akka.remote.transport.ProtocolStateActor
-
- setTimer$default$4() - Static method in class akka.remote.transport.ThrottledAssociation
-
- setTimestamp(long) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister.Builder
-
required sint64 timestamp = 1;
- 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, ActorSystemSetup) - Constructor for class akka.actor.ActorSystem.Settings
-
- 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.ClusterShardingGuardian.Start
-
- settings() - Method in class akka.cluster.sharding.ClusterShardingGuardian.StartProxy
-
- 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 class akka.io.UdpListener
-
- settings() - Method in class akka.io.UdpSender
-
- settings() - Method in interface akka.io.WithUdpSend
-
- settings() - Method in class akka.persistence.Persistence
-
- settings() - Method in class akka.remote.artery.ArteryTransport
-
- settings() - Method in class akka.remote.artery.Association
-
- settings() - Method in class akka.remote.artery.compress.InboundCompression
-
- settings() - Method in interface akka.remote.artery.InboundContext
-
- settings() - Method in interface akka.remote.artery.OutboundContext
-
- settings() - Method in class akka.remote.EndpointActor
-
- settings() - Method in class akka.remote.EndpointManager
-
- settings() - Static method in class akka.remote.EndpointReader
-
- settings() - Static method in class akka.remote.EndpointWriter
-
- 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.stream.ActorMaterializer
-
- settings() - Method in class akka.stream.impl.ActorMaterializerImpl
-
- settings() - Method in class akka.stream.impl.ActorProcessorImpl
-
- settings() - Method in class akka.stream.impl.FanIn
-
- settings() - Method in class akka.stream.impl.FanOut
-
- settings() - Static method in class akka.stream.impl.FanoutProcessorImpl
-
- settings() - Static method in class akka.stream.impl.Unzip
-
- settings() - Method in interface akka.typed.ActorSystem
-
The core settings extracted from the supplied configuration.
- settings() - Method in class akka.typed.adapter.ActorSystemAdapter
-
- settings() - Method in class akka.typed.internal.ActorSystemImpl
-
- Settings - Class in akka.typed
-
The configuration settings that were parsed from the config by an
ActorSystem
.
- Settings(Config, ActorSystem.Settings, String) - Constructor for class akka.typed.Settings
-
- Settings(ClassLoader, Config, String) - Constructor for class akka.typed.Settings
-
- Settings(ActorSystem.Settings) - Constructor for class akka.typed.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;
- setTo(ArteryControlFormats.Address) - Method in class akka.remote.ArteryControlFormats.HandshakeReq.Builder
-
required .Address to = 2;
- setTo(ArteryControlFormats.Address.Builder) - Method in class akka.remote.ArteryControlFormats.HandshakeReq.Builder
-
required .Address to = 2;
- setTo(ArteryControlFormats.UniqueAddress) - Method in class akka.remote.ArteryControlFormats.Quarantined.Builder
-
required .UniqueAddress to = 2;
- setTo(ArteryControlFormats.UniqueAddress.Builder) - Method in class akka.remote.ArteryControlFormats.Quarantined.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;
- setTotChunks(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.Status.Builder
-
required uint32 totChunks = 2;
- 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;
- setType(SystemMessageFormats.SystemMessage.Type) - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
required .SystemMessage.Type type = 1;
- setUid(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress.Builder
-
required sfixed32 uid = 2;
- setUid(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
-
required uint32 uid = 2;
- setUID(UniqueAddress) - Method in class akka.remote.artery.AssociationRegistry
-
- setUid(long) - Method in interface akka.remote.artery.HeaderBuilder
-
- setUid(long) - Method in class akka.remote.artery.HeaderBuilderImpl
-
- setUid(long) - Method in class akka.remote.ArteryControlFormats.ArteryHeartbeatRsp.Builder
-
required uint64 uid = 1;
- setUid(long) - Method in class akka.remote.ArteryControlFormats.UniqueAddress.Builder
-
required uint64 uid = 2;
- setUid(long) - Method in class akka.remote.ContainerFormats.WatcherHeartbeatResponse.Builder
-
required uint64 uid = 1;
- setUid(long) - Method in class akka.remote.SystemMessageFormats.FailedData.Builder
-
required uint64 uid = 2;
- setUid(long) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
-
required fixed64 uid = 2;
- setUid2(int) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatorMessages.UniqueAddress.Builder
-
optional sfixed32 uid2 = 3;
- setUid2(int) - Method in class akka.cluster.protobuf.msg.ClusterMessages.UniqueAddress.Builder
-
optional uint32 uid2 = 3;
- setUnallocatedShards(int, String) - Method in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.Builder
-
repeated string unallocatedShards = 4;
- 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;
- setup() - Method in class akka.actor.ActorSystem.Settings
-
- Setup - Class in akka.actor.setup
-
Marker supertype for a setup part that can be put inside
ActorSystemSetup
, if a specific concrete setup
is not specified in the actor system setup that means defaults are used (usually from the config file) - no concrete
setup instance should be mandatory in the
ActorSystemSetup
that an actor system is created with.
- Setup() - Constructor for class akka.actor.setup.Setup
-
- 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(ByteString) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GCounter.Entry.Builder
-
required bytes value = 2;
- setValue(ReplicatedDataMessages.LWWRegister) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry.Builder
-
required .akka.cluster.ddata.LWWRegister value = 2;
- setValue(ReplicatedDataMessages.LWWRegister.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWMap.Entry.Builder
-
required .akka.cluster.ddata.LWWRegister value = 2;
- setValue(ReplicatorMessages.OtherMessage) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry.Builder
-
required .akka.cluster.ddata.OtherMessage value = 2;
- setValue(ReplicatorMessages.OtherMessage.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMap.Entry.Builder
-
required .akka.cluster.ddata.OtherMessage value = 2;
- setValue(ReplicatedDataMessages.ORSet) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry.Builder
-
required .akka.cluster.ddata.ORSet value = 2;
- setValue(ReplicatedDataMessages.ORSet.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMultiMap.Entry.Builder
-
required .akka.cluster.ddata.ORSet value = 2;
- setValue(ReplicatedDataMessages.PNCounter) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry.Builder
-
required .akka.cluster.ddata.PNCounter value = 2;
- setValue(ReplicatedDataMessages.PNCounter.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.PNCounterMap.Entry.Builder
-
required .akka.cluster.ddata.PNCounter value = 2;
- 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;
- setValue(ContainerFormats.Payload) - Method in class akka.remote.ContainerFormats.Option.Builder
-
optional .Payload value = 1;
- setValue(ContainerFormats.Payload.Builder) - Method in class akka.remote.ContainerFormats.Option.Builder
-
optional .Payload value = 1;
- setValue(T) - Method in class akka.stream.impl.fusing.GraphStages.MaterializedValueSource
-
- 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;
- setValues(int, int) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisement.Builder
-
repeated uint32 values = 5;
- setVersion(long) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.VersionVector.Entry.Builder
-
required int64 version = 2;
- 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;
- setVersion(byte) - Method in interface akka.remote.artery.HeaderBuilder
-
- setVersion(byte) - Method in class akka.remote.artery.HeaderBuilderImpl
-
- setVersion(int) - Method in class akka.remote.ArteryControlFormats.CompressionTableAdvertisementAck.Builder
-
required uint32 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;
- setVvector(ReplicatedDataMessages.VersionVector) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
required .akka.cluster.ddata.VersionVector vvector = 1;
- setVvector(ReplicatedDataMessages.VersionVector.Builder) - Method in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet.Builder
-
required .akka.cluster.ddata.VersionVector vvector = 1;
- setWatchData(SystemMessageFormats.WatchData) - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .WatchData watchData = 2;
- setWatchData(SystemMessageFormats.WatchData.Builder) - Method in class akka.remote.SystemMessageFormats.SystemMessage.Builder
-
optional .WatchData watchData = 2;
- setWatchee(ContainerFormats.ActorRef) - Method in class akka.remote.SystemMessageFormats.WatchData.Builder
-
required .ActorRef watchee = 1;
- setWatchee(ContainerFormats.ActorRef.Builder) - Method in class akka.remote.SystemMessageFormats.WatchData.Builder
-
required .ActorRef watchee = 1;
- setWatcher(ContainerFormats.ActorRef) - Method in class akka.remote.SystemMessageFormats.WatchData.Builder
-
required .ActorRef watcher = 2;
- setWatcher(ContainerFormats.ActorRef.Builder) - Method in class akka.remote.SystemMessageFormats.WatchData.Builder
-
required .ActorRef watcher = 2;
- setWildcardFanOut(boolean) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
-
optional bool wildcardFanOut = 5;
- setWriterUuid(String) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional string writerUuid = 13;
- setWriterUuidBytes(ByteString) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
-
optional string writerUuid = 13;
- 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$
-
Deprecated.
- sha1(byte[]) - Method in class akka.util.Crypt$
-
Deprecated.
- sha1(String) - Static method in class akka.util.Crypt
-
Deprecated.
- sha1(byte[]) - Static method in class akka.util.Crypt
-
Deprecated.
- 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
-
- shape() - Method in class akka.remote.artery.AeronSink
-
- shape() - Method in class akka.remote.artery.AeronSource
-
- shape() - Method in class akka.remote.artery.Decoder
-
- shape() - Method in class akka.remote.artery.Deserializer
-
- shape() - Method in class akka.remote.artery.Encoder
-
- shape() - Method in class akka.remote.artery.InboundControlJunction
-
- shape() - Method in class akka.remote.artery.InboundHandshake
-
- shape() - Method in class akka.remote.artery.InboundQuarantineCheck
-
- shape() - Method in class akka.remote.artery.InboundTestStage
-
- shape() - Method in class akka.remote.artery.OutboundControlJunction
-
- shape() - Method in class akka.remote.artery.OutboundHandshake
-
- shape() - Method in class akka.remote.artery.OutboundTestStage
-
- shape() - Method in class akka.remote.artery.SendQueue
-
- shape() - Method in class akka.remote.artery.SystemMessageAcker
-
- shape() - Method in class akka.remote.artery.SystemMessageDelivery
-
- shape() - Method in class akka.stream.Fusing.FusedGraph
-
- shape() - Method in interface akka.stream.Graph
-
The shape of a graph is all that is externally visible: its inlets and outlets.
- shape() - Method in class akka.stream.impl.ActorRefBackpressureSinkStage
-
- shape() - Method in class akka.stream.impl.EmptySource$
-
- shape() - Static method in class akka.stream.impl.EmptySource
-
- shape() - Method in class akka.stream.impl.fusing.Batch
-
- shape() - Static method in class akka.stream.impl.fusing.Buffer
-
- shape() - Method in class akka.stream.impl.fusing.Collect
-
- shape() - Static method in class akka.stream.impl.fusing.Drop
-
- shape() - Static method in class akka.stream.impl.fusing.DropWhile
-
- shape() - Method in class akka.stream.impl.fusing.Expand
-
- shape() - Static method in class akka.stream.impl.fusing.Filter
-
- shape() - Method in class akka.stream.impl.fusing.FlattenMerge
-
- shape() - Method in class akka.stream.impl.fusing.Fold
-
- shape() - Method in class akka.stream.impl.fusing.FoldAsync
-
- shape() - Method in class akka.stream.impl.fusing.GraphModule
-
- shape() - Method in class akka.stream.impl.fusing.GraphStageModule
-
- shape() - Method in class akka.stream.impl.fusing.GraphStages.FutureSource
-
- shape() - Method in class akka.stream.impl.fusing.GraphStages.IgnoreSink$
-
- shape() - Method in class akka.stream.impl.fusing.GraphStages.MaterializedValueSource
-
- shape() - Method in class akka.stream.impl.fusing.GraphStages.SimpleLinearGraphStage
-
- shape() - Method in class akka.stream.impl.fusing.GraphStages.SingleSource
-
- shape() - Method in class akka.stream.impl.fusing.GraphStages.TickSource
-
- shape() - Method in class akka.stream.impl.fusing.GroupBy
-
- shape() - Method in class akka.stream.impl.fusing.Grouped
-
- shape() - Method in class akka.stream.impl.fusing.GroupedWithin
-
- shape() - Static method in class akka.stream.impl.fusing.Intersperse
-
- shape() - Static method in class akka.stream.impl.fusing.LimitWeighted
-
- shape() - Static method in class akka.stream.impl.fusing.Log
-
- shape() - Method in class akka.stream.impl.fusing.Map
-
- shape() - Method in class akka.stream.impl.fusing.MapAsync
-
- shape() - Method in class akka.stream.impl.fusing.MapAsyncUnordered
-
- shape() - Static method in class akka.stream.impl.fusing.MapError
-
- shape() - Method in class akka.stream.impl.fusing.PrefixAndTail
-
- shape() - Static method in class akka.stream.impl.fusing.Recover
-
- shape() - Static method in class akka.stream.impl.fusing.RecoverWith
-
- shape() - Method in class akka.stream.impl.fusing.Scan
-
- shape() - Method in class akka.stream.impl.fusing.ScanAsync
-
- shape() - Method in class akka.stream.impl.fusing.Sliding
-
- shape() - Method in class akka.stream.impl.fusing.Split
-
- shape() - Method in class akka.stream.impl.fusing.StatefulMapConcat
-
- shape() - Method in class akka.stream.impl.fusing.SubSink
-
- shape() - Method in class akka.stream.impl.fusing.SubSource
-
- shape() - Static method in class akka.stream.impl.fusing.Take
-
- shape() - Static method in class akka.stream.impl.fusing.TakeWhile
-
- shape() - Method in class akka.stream.impl.HeadOptionStage
-
- shape() - Method in class akka.stream.impl.io.ByteStringParser
-
- shape() - Static method in class akka.stream.impl.io.compression.DeflateDecompressorBase
-
- shape() - Static method in class akka.stream.impl.io.compression.GzipDecompressor
-
- shape() - Method in class akka.stream.impl.io.ConnectionSourceStage
-
- shape() - Method in class akka.stream.impl.io.IncomingConnectionStage
-
- shape() - Method in class akka.stream.impl.io.InputStreamSinkStage
-
- shape() - Method in class akka.stream.impl.io.OutgoingConnectionStage
-
- shape() - Method in class akka.stream.impl.io.OutputStreamSourceStage
-
- shape() - Method in class akka.stream.impl.io.TcpConnectionStage.TcpStreamLogic
-
- shape() - Method in class akka.stream.impl.io.TlsModule
-
- shape() - Method in class akka.stream.impl.JavaStreamSource
-
- shape() - Method in class akka.stream.impl.LastOptionStage
-
- shape() - Method in class akka.stream.impl.LazySink
-
- shape() - Method in class akka.stream.impl.LazySource
-
- shape() - Method in class akka.stream.impl.ProcessorModule
-
- shape() - Method in class akka.stream.impl.QueueSink
-
- shape() - Method in class akka.stream.impl.QueueSource
-
- shape() - Method in class akka.stream.impl.SeqStage
-
- shape() - Method in class akka.stream.impl.SinkModule
-
- shape() - Method in class akka.stream.impl.SourceModule
-
- shape() - Method in class akka.stream.impl.StreamLayout.CompositeModule
-
- shape() - Method in class akka.stream.impl.StreamLayout.CopiedModule
-
- shape() - Method in class akka.stream.impl.StreamLayout.EmptyModule$
-
- shape() - Method in class akka.stream.impl.StreamLayout.FusedModule
-
- shape() - Method in interface akka.stream.impl.StreamLayout.Module
-
- shape() - Method in class akka.stream.impl.StreamLayout.StructuralInfoModule
-
- shape() - Method in class akka.stream.impl.Timers.IdleInject
-
- shape() - Method in class akka.stream.impl.Timers.IdleTimeoutBidi
-
- shape() - Method in class akka.stream.impl.Unfold
-
- shape() - Method in class akka.stream.impl.UnfoldAsync
-
- shape() - Method in class akka.stream.impl.UnfoldResourceSource
-
- shape() - Method in class akka.stream.impl.UnfoldResourceSourceAsync
-
- shape() - Method in class akka.stream.javadsl.BidiFlow
-
- shape() - Method in class akka.stream.javadsl.Flow
-
- shape() - Static method in class akka.stream.javadsl.RunnableGraph
-
- shape() - Method in class akka.stream.javadsl.Sink
-
- shape() - Method in class akka.stream.javadsl.Source
-
- shape() - Method in class akka.stream.KillSwitches.UniqueBidiKillSwitchStage$
-
- shape() - Method in class akka.stream.KillSwitches.UniqueKillSwitchStage$
-
- shape() - Method in class akka.stream.scaladsl.Balance
-
- shape() - Method in class akka.stream.scaladsl.BidiFlow
-
- shape() - Method in class akka.stream.scaladsl.Broadcast
-
- shape() - Method in class akka.stream.scaladsl.BroadcastHub
-
- shape() - Method in class akka.stream.scaladsl.Concat
-
- shape() - Method in class akka.stream.scaladsl.CoupledTerminationBidi
-
- shape() - Method in class akka.stream.scaladsl.Flow
-
- shape() - Method in class akka.stream.scaladsl.GraphApply.GraphImpl
-
- shape() - Method in class akka.stream.scaladsl.Interleave
-
- shape() - Method in class akka.stream.scaladsl.Merge
-
- shape() - Method in class akka.stream.scaladsl.MergeHub
-
- shape() - Method in class akka.stream.scaladsl.MergePreferred
-
- shape() - Method in class akka.stream.scaladsl.MergeSorted
-
- shape() - Method in class akka.stream.scaladsl.OrElse
-
- shape() - Method in class akka.stream.scaladsl.Partition
-
- shape() - Method in class akka.stream.scaladsl.RunnableGraph
-
- shape(String) - Method in class akka.stream.scaladsl.Sink$
-
INTERNAL API
- shape() - Method in class akka.stream.scaladsl.Sink
-
- shape(String) - Method in class akka.stream.scaladsl.Source$
-
INTERNAL API
- shape() - Method in class akka.stream.scaladsl.Source
-
- shape() - Static method in class akka.stream.scaladsl.Unzip
-
- shape() - Method in class akka.stream.scaladsl.UnzipWith10
-
- shape() - Method in class akka.stream.scaladsl.UnzipWith11
-
- shape() - Method in class akka.stream.scaladsl.UnzipWith12
-
- shape() - Method in class akka.stream.scaladsl.UnzipWith13
-
- shape() - Method in class akka.stream.scaladsl.UnzipWith14
-
- shape() - Method in class akka.stream.scaladsl.UnzipWith15
-
- shape() - Method in class akka.stream.scaladsl.UnzipWith16
-
- shape() - Method in class akka.stream.scaladsl.UnzipWith17
-
- shape() - Method in class akka.stream.scaladsl.UnzipWith18
-
- shape() - Method in class akka.stream.scaladsl.UnzipWith19
-
- shape() - Method in class akka.stream.scaladsl.UnzipWith2
-
- shape() - Method in class akka.stream.scaladsl.UnzipWith20
-
- shape() - Method in class akka.stream.scaladsl.UnzipWith3
-
- shape() - Method in class akka.stream.scaladsl.UnzipWith4
-
- shape() - Method in class akka.stream.scaladsl.UnzipWith5
-
- shape() - Method in class akka.stream.scaladsl.UnzipWith6
-
- shape() - Method in class akka.stream.scaladsl.UnzipWith7
-
- shape() - Method in class akka.stream.scaladsl.UnzipWith8
-
- shape() - Method in class akka.stream.scaladsl.UnzipWith9
-
- shape() - Static method in class akka.stream.scaladsl.Zip
-
- shape() - Static method in class akka.stream.scaladsl.ZipN
-
- shape() - Method in class akka.stream.scaladsl.ZipWith10
-
- shape() - Method in class akka.stream.scaladsl.ZipWith11
-
- shape() - Method in class akka.stream.scaladsl.ZipWith12
-
- shape() - Method in class akka.stream.scaladsl.ZipWith13
-
- shape() - Method in class akka.stream.scaladsl.ZipWith14
-
- shape() - Method in class akka.stream.scaladsl.ZipWith15
-
- shape() - Method in class akka.stream.scaladsl.ZipWith16
-
- shape() - Method in class akka.stream.scaladsl.ZipWith17
-
- shape() - Method in class akka.stream.scaladsl.ZipWith18
-
- shape() - Method in class akka.stream.scaladsl.ZipWith19
-
- shape() - Method in class akka.stream.scaladsl.ZipWith2
-
- shape() - Method in class akka.stream.scaladsl.ZipWith20
-
- shape() - Method in class akka.stream.scaladsl.ZipWith3
-
- shape() - Method in class akka.stream.scaladsl.ZipWith4
-
- shape() - Method in class akka.stream.scaladsl.ZipWith5
-
- shape() - Method in class akka.stream.scaladsl.ZipWith6
-
- shape() - Method in class akka.stream.scaladsl.ZipWith7
-
- shape() - Method in class akka.stream.scaladsl.ZipWith8
-
- shape() - Method in class akka.stream.scaladsl.ZipWith9
-
- shape() - Method in class akka.stream.scaladsl.ZipWithN
-
- Shape - Class in akka.stream
-
A Shape describes the inlets and outlets of a
Graph
.
- Shape() - Constructor for class akka.stream.Shape
-
- shape() - Method in class akka.stream.stage.AbstractStage.PushPullGraphStageWithMaterializedValue
-
Deprecated.
- shape() - Method in class akka.stream.testkit.TestSinkStage
-
- shape() - Method in class akka.stream.testkit.TestSourceStage
-
- shaping() - Method in class akka.stream.ThrottleMode$
-
Java API: Tells throttle to make pauses before emitting messages to meet throttle rate
- shaping() - Static method in class akka.stream.ThrottleMode
-
Java API: Tells throttle to make pauses before emitting messages to meet throttle rate
- Shaping$() - Constructor for class akka.stream.ThrottleMode.Shaping$
-
- Shard - Class in akka.cluster.sharding
-
INTERNAL API
- Shard(String, String, Props, ClusterShardingSettings, PartialFunction<Object, Tuple2<String, Object>>, Function1<Object, String>, Object) - Constructor for class akka.cluster.sharding.Shard
-
- 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.CurrentShardState - Class in akka.cluster.sharding
-
- Shard.CurrentShardState$ - Class in akka.cluster.sharding
-
- Shard.EntityStarted - Class in akka.cluster.sharding
-
State
change for starting an entity in this Shard
- Shard.EntityStarted$ - Class in akka.cluster.sharding
-
- Shard.EntityStopped - Class in akka.cluster.sharding
-
State
change for an entity which has terminated.
- Shard.EntityStopped$ - Class in akka.cluster.sharding
-
- Shard.GetCurrentShardState$ - Class in akka.cluster.sharding
-
- Shard.GetShardStats$ - Class in akka.cluster.sharding
-
- Shard.RestartEntities - Class in akka.cluster.sharding
-
When initialising a shard with remember entities enabled the following message is used
to restart batches of entity actors at a time.
- Shard.RestartEntities$ - Class in akka.cluster.sharding
-
- Shard.RestartEntity - Class in akka.cluster.sharding
-
When an remembering entities and the entity stops without issuing a Passivate
, we
restart it after a back off using this message.
- Shard.RestartEntity$ - Class in akka.cluster.sharding
-
- Shard.ShardCommand - Interface in akka.cluster.sharding
-
A Shard command
- Shard.ShardQuery - Interface in akka.cluster.sharding
-
A query for information about the shard
- Shard.ShardStats - Class in akka.cluster.sharding
-
- Shard.ShardStats$ - Class 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
-
A case class which represents a state change for the Shard
- SHARD_FIELD_NUMBER - Static variable in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHome
-
- SHARD_FIELD_NUMBER - Static variable in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardHomeAllocated
-
- SHARD_FIELD_NUMBER - Static variable in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardIdMessage
-
- SHARD_FIELD_NUMBER - Static variable in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.ShardStats
-
- shardBuffers() - Method in class akka.cluster.sharding.ShardRegion
-
- ShardCoordinator - Class in akka.cluster.sharding
-
Singleton coordinator that decides where to allocate shards.
- ShardCoordinator(String, ClusterShardingSettings, 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$.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$.GracefulShutdownReq - Class in akka.cluster.sharding
-
ShardRegion
requests full handoff to be able to shutdown gracefully.
- ShardCoordinator.Internal$.HandOff - Class in akka.cluster.sharding
-
When all ShardRegion
actors have acknowledged the BeginHandOff
the
ShardCoordinator
sends this message to the ShardRegion
responsible for the
shard.
- ShardCoordinator.Internal$.HostShard - Class in akka.cluster.sharding
-
ShardCoordinator
informs a ShardRegion
that it is hosting this shard
- 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 entities in the shard have been terminated.
- ShardCoordinator.Internal$.State - Class in akka.cluster.sharding
-
- ShardCoordinator.Internal$.StateInitialized - 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
.
- shardFailureBackoff() - Method in class akka.cluster.sharding.ClusterShardingSettings.TuningParameters
-
- 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() - Method in class akka.cluster.sharding.Shard.CurrentShardState
-
- shardId() - Method in class akka.cluster.sharding.Shard.ShardStats
-
- shardId(Object) - Method in class akka.cluster.sharding.ShardRegion.HashCodeMessageExtractor
-
- shardId(Object) - Method in interface akka.cluster.sharding.ShardRegion.MessageExtractor
-
Extract the entity id from an incoming message
.
- shardId() - Method in class akka.cluster.sharding.ShardRegion.ShardInitialized
-
- shardId() - Method in class akka.cluster.sharding.ShardRegion.ShardState
-
- SHARDID_FIELD_NUMBER - Static variable in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState.ShardEntry
-
- sharding() - Method in class akka.cluster.sharding.ClusterShardingGuardian
-
- ShardInitialized(String) - Constructor for class akka.cluster.sharding.ShardRegion.ShardInitialized
-
- ShardInitialized$() - Constructor for class akka.cluster.sharding.ShardRegion.ShardInitialized$
-
- shardRegion(String) - Method in class akka.cluster.sharding.ClusterSharding
-
Retrieve the actor reference of the
ShardRegion
actor responsible for the named entity type.
- shardRegion() - Method in class akka.cluster.sharding.ClusterShardingGuardian.Started
-
- shardRegion() - Method in class akka.cluster.sharding.ShardCoordinator.Internal$.GracefulShutdownReq
-
- shardRegion() - Method in class akka.cluster.sharding.ShardCoordinator.Internal$.Register
-
- ShardRegion - Class in akka.cluster.sharding
-
This actor creates children entity actors on demand for the shards that it is told to be
responsible for.
- ShardRegion(String, Option<Props>, ClusterShardingSettings, String, PartialFunction<Object, Tuple2<String, Object>>, Function1<Object, String>, Object) - Constructor for class akka.cluster.sharding.ShardRegion
-
- ShardRegion$ - Class in akka.cluster.sharding
-
- ShardRegion$() - Constructor for class akka.cluster.sharding.ShardRegion$
-
- ShardRegion.ClusterShardingStats - Class in akka.cluster.sharding
-
- ShardRegion.ClusterShardingStats$ - Class in akka.cluster.sharding
-
- ShardRegion.CurrentRegions - Class in akka.cluster.sharding
-
Reply to GetCurrentRegions
- ShardRegion.CurrentRegions$ - Class in akka.cluster.sharding
-
- ShardRegion.CurrentShardRegionState - Class in akka.cluster.sharding
-
- ShardRegion.CurrentShardRegionState$ - Class in akka.cluster.sharding
-
- ShardRegion.GetClusterShardingStats - Class in akka.cluster.sharding
-
Send this message to the
ShardRegion
actor to request for
ShardRegion.ClusterShardingStats
,
which contains statistics about the currently running sharded entities in the
entire cluster.
- ShardRegion.GetClusterShardingStats$ - Class in akka.cluster.sharding
-
- ShardRegion.GetCurrentRegions$ - Class in akka.cluster.sharding
-
Send this message to the
ShardRegion
actor to request for
ShardRegion.CurrentRegions
,
which contains the addresses of all registered regions.
- ShardRegion.GetShardRegionState$ - Class in akka.cluster.sharding
-
- ShardRegion.GetShardRegionStats$ - Class in akka.cluster.sharding
-
Send this message to the
ShardRegion
actor to request for
ShardRegion.ShardRegionStats
,
which contains statistics about the currently running sharded entities in the
entire region.
- ShardRegion.GracefulShutdown$ - Class in akka.cluster.sharding
-
- ShardRegion.HandOffStopper - Class in akka.cluster.sharding
-
INTERNAL API.
- ShardRegion.HashCodeMessageExtractor - Class in akka.cluster.sharding
-
- ShardRegion.MessageExtractor - Interface in akka.cluster.sharding
-
Java API: Interface of functions to extract entity id,
shard id, and the message to send to the entity from an
incoming message.
- ShardRegion.Passivate - Class in akka.cluster.sharding
-
If the state of the entities are persistent you may stop entities that are not used to
reduce memory consumption.
- ShardRegion.Passivate$ - Class in akka.cluster.sharding
-
- ShardRegion.ShardInitialized - Class in akka.cluster.sharding
-
We must be sure that a shard is initialized before to start send messages to it.
- ShardRegion.ShardInitialized$ - Class in akka.cluster.sharding
-
- ShardRegion.ShardRegionCommand - Interface in akka.cluster.sharding
-
- ShardRegion.ShardRegionQuery - Interface in akka.cluster.sharding
-
- ShardRegion.ShardRegionStats - Class in akka.cluster.sharding
-
- ShardRegion.ShardRegionStats$ - Class in akka.cluster.sharding
-
- ShardRegion.ShardState - Class in akka.cluster.sharding
-
- ShardRegion.ShardState$ - Class 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
-
- ShardRegionStats(Map<String, Object>) - Constructor for class akka.cluster.sharding.ShardRegion.ShardRegionStats
-
- ShardRegionStats$() - Constructor for class akka.cluster.sharding.ShardRegion.ShardRegionStats$
-
- ShardRegionTerminated(ActorRef) - Constructor for class akka.cluster.sharding.ShardCoordinator.Internal$.ShardRegionTerminated
-
- shards() - Method in class akka.cluster.sharding.ShardRegion.CurrentShardRegionState
-
- shards() - Method in class akka.cluster.sharding.ShardRegion
-
- SHARDS_FIELD_NUMBER - Static variable in class akka.cluster.sharding.protobuf.msg.ClusterShardingMessages.CoordinatorState
-
- 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.ClusterShardingSettings.TuningParameters
-
- ShardState(String, Set<String>) - Constructor for class akka.cluster.sharding.ShardRegion.ShardState
-
- ShardState$() - Constructor for class akka.cluster.sharding.ShardRegion.ShardState$
-
- ShardStats(String, int) - Constructor for class akka.cluster.sharding.Shard.ShardStats
-
- ShardStats$() - Constructor for class akka.cluster.sharding.Shard.ShardStats$
-
- ShardStopped(String) - Constructor for class akka.cluster.sharding.ShardCoordinator.Internal$.ShardStopped
-
- shared(String) - Method in class akka.stream.KillSwitches$
-
Creates a new
SharedKillSwitch
with the given name that can be used to control the completion of multiple
streams from the outside simultaneously.
- shared(String) - Static method in class akka.stream.KillSwitches
-
Creates a new
SharedKillSwitch
with the given name that can be used to control the completion of multiple
streams from the outside simultaneously.
- SharedKillSwitch - Class in akka.stream
-
- SharedKillSwitch(String) - Constructor for class akka.stream.SharedKillSwitch
-
- 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(Config) - Constructor for class akka.persistence.journal.leveldb.SharedLeveldbStore
-
- SharedLeveldbStore() - Constructor for class akka.persistence.journal.leveldb.SharedLeveldbStore
-
- SharedTestState - Class in akka.remote.artery
-
INTERNAL API: Thread safe mutable state that is shared among
the test stages.
- SharedTestState() - Constructor for class akka.remote.artery.SharedTestState
-
- shell() - Method in class akka.stream.impl.fusing.ActorGraphInterpreter.Abort
-
- shell() - Method in class akka.stream.impl.fusing.ActorGraphInterpreter.AsyncInput
-
- shell() - Method in interface akka.stream.impl.fusing.ActorGraphInterpreter.BoundaryEvent
-
- shell() - Method in class akka.stream.impl.fusing.ActorGraphInterpreter.Cancel
-
- shell() - Method in class akka.stream.impl.fusing.ActorGraphInterpreter.ExposedPublisher
-
- shell() - Method in class akka.stream.impl.fusing.ActorGraphInterpreter.OnComplete
-
- shell() - Method in class akka.stream.impl.fusing.ActorGraphInterpreter.OnError
-
- shell() - Method in class akka.stream.impl.fusing.ActorGraphInterpreter.OnNext
-
- shell() - Method in class akka.stream.impl.fusing.ActorGraphInterpreter.OnSubscribe
-
- shell() - Method in class akka.stream.impl.fusing.ActorGraphInterpreter.RequestMore
-
- shell() - Method in class akka.stream.impl.fusing.ActorGraphInterpreter.Resume
-
- shell() - Method in class akka.stream.impl.fusing.ActorGraphInterpreter.SubscribePending
-
- shellEventLimit() - Method in class akka.stream.impl.fusing.GraphInterpreterShell
-
- 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
-
- 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
-
Deprecated.
Callback run on microkernel shutdown.
- Shutdown() - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
Reason given when someone was calling system.stop(fsm)
from outside;
also applies to Stop
supervision directive.
- shutdown(ActorSystem, Duration, boolean) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- shutdown(ActorSystem, Duration, boolean) - Static method in class akka.persistence.journal.JournalSpec
-
- shutdown(ActorSystem, Duration, boolean) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- shutdown() - Method in class akka.remote.artery.ArteryTransport
-
- ShutDown - Class in akka.remote.artery
-
- ShutDown() - Constructor for class akka.remote.artery.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(ActorSystem, Duration, boolean) - Static method in class akka.remote.testkit.MultiNodeSpec
-
- shutdown() - Method in class akka.remote.transport.AbstractTransportAdapter
-
- shutdown() - Method in class akka.remote.transport.ActorTransportAdapter
-
- shutdown() - Static method in class akka.remote.transport.AkkaProtocolTransport
-
- shutdown() - Static method in class akka.remote.transport.FailureInjectorTransportAdapter
-
- shutdown() - Method in class akka.remote.transport.netty.NettyTransport
-
- shutdown() - Method in class akka.remote.transport.TestTransport
-
- shutdown() - Static method in class akka.remote.transport.ThrottlerTransportAdapter
-
- shutdown() - Method in interface akka.remote.transport.Transport
-
Shuts down the transport layer and releases all the corresponding resources.
- shutdown() - Method in class akka.stream.ActorMaterializer
-
Shuts down this materializer and all the stages that have been materialized through this materializer.
- shutdown() - Method in class akka.stream.impl.ActorMaterializerImpl
-
- shutdown(Option<Throwable>) - Static method in class akka.stream.impl.ActorProcessor
-
- shutdown(Option<Throwable>) - Method in class akka.stream.impl.ActorPublisher
-
- shutdown(boolean) - Method in class akka.stream.impl.FanoutOutputs
-
- ShutDown() - Method in class akka.stream.impl.SubscriberManagement$
-
- shutdown(boolean) - Method in interface akka.stream.impl.SubscriberManagement
-
called when the spi.Publisher/Processor is ready to be shut down
- shutdown() - Method in interface akka.stream.KillSwitch
-
- shutdown() - Method in class akka.stream.SharedKillSwitch
-
After calling
SharedKillSwitch.shutdown()
all materialized, running instances of all
Graph
s provided by the
SharedKillSwitch
will complete their downstreams and cancel their upstreams (unless if finished or failed already in which
case the command is ignored).
- shutdown() - Method in class akka.stream.UniqueKillSwitch
-
- 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) - Static method in class akka.testkit.TestKit
-
- shutdown(ActorSystem, Duration, boolean) - Method in interface akka.testkit.TestKitBase
-
Shut down an actor system and wait for termination.
- shutdown(ActorSystem, Duration, boolean) - Static method in class akka.testkit.TestProbe
-
- shutdown() - Method in class akka.typed.Dispatchers
-
- shutdown() - Method in class akka.typed.internal.DispatchersImpl
-
- Shutdown$() - Constructor for class akka.actor.FSM.Shutdown$
-
- Shutdown$() - Constructor for class akka.persistence.fsm.PersistentFSM.Shutdown$
-
- ShutDown$ - Class in akka.remote.artery
-
- ShutDown$() - Constructor for class akka.remote.artery.ShutDown$
-
- Shutdown$() - Constructor for class akka.remote.artery.TaskRunner.Shutdown$
-
- Shutdown$() - Constructor for class akka.remote.transport.AssociationHandle.Shutdown$
-
- shutdown$default$1() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- shutdown$default$1() - Static method in class akka.persistence.journal.JournalSpec
-
- shutdown$default$1() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- shutdown$default$1() - Static method in class akka.remote.testkit.MultiNodeSpec
-
- shutdown$default$1() - Static method in class akka.testkit.TestKit
-
- shutdown$default$1() - Static method in class akka.testkit.TestProbe
-
- shutdown$default$2() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- shutdown$default$2() - Static method in class akka.persistence.journal.JournalSpec
-
- shutdown$default$2() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- shutdown$default$2() - Static method in class akka.remote.testkit.MultiNodeSpec
-
- shutdown$default$2() - Static method in class akka.testkit.TestKit
-
- shutdown$default$2() - Static method in class akka.testkit.TestProbe
-
- shutdown$default$3() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- shutdown$default$3() - Static method in class akka.persistence.journal.JournalSpec
-
- shutdown$default$3() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- shutdown$default$3() - Static method in class akka.remote.testkit.MultiNodeSpec
-
- shutdown$default$3() - Static method in class akka.testkit.TestKit
-
- shutdown$default$3() - Static method in class akka.testkit.TestProbe
-
- 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
-
- ShutdownFlushTimeout() - Method in class akka.remote.artery.ArterySettings.Advanced$
-
- shutdownNow() - Method in interface akka.dispatch.ExecutorServiceDelegate
-
- shutdownOrExit() - Method in class akka.remote.testconductor.Terminate
-
- shutdownOrExit() - Method in class akka.remote.testconductor.TerminateMsg
-
- shutdownSelfWhenDown() - Method in class akka.cluster.ClusterCoreDaemon
-
- ShutdownSignal$() - Constructor for exception akka.remote.artery.ArteryTransport.ShutdownSignal$
-
- 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
-
- ShuttingDown$() - Constructor for exception akka.remote.artery.ArteryTransport.ShuttingDown$
-
- 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
-
- SigarMetricsCollector(Address, double, Object) - Constructor for class akka.cluster.SigarMetricsCollector
-
Deprecated.
- SigarMetricsCollector(ActorSystem) - Constructor for class akka.cluster.SigarMetricsCollector
-
Deprecated.
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.
- SignalThrewException(String, Throwable) - Constructor for exception akka.stream.impl.ReactiveStreamsCompliance.SignalThrewException
-
- signDeathPact(ActorRef) - Method in class akka.io.TcpConnection
-
- signDeathPact(ActorRef) - Static method in class akka.io.TcpOutgoingConnection
-
- 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$
-
- simpleFramingProtocol(int) - Method in class akka.stream.javadsl.Framing$
-
Returns a BidiFlow that implements a simple framing protocol.
- simpleFramingProtocol(int) - Static method in class akka.stream.javadsl.Framing
-
Returns a BidiFlow that implements a simple framing protocol.
- simpleFramingProtocol(int) - Method in class akka.stream.scaladsl.Framing$
-
Returns a BidiFlow that implements a simple framing protocol.
- simpleFramingProtocol(int) - Static method in class akka.stream.scaladsl.Framing
-
Returns a BidiFlow that implements a simple framing protocol.
- simpleFramingProtocolDecoder(int) - Method in class akka.stream.scaladsl.Framing$
-
- simpleFramingProtocolDecoder(int) - Static method in class akka.stream.scaladsl.Framing
-
- simpleFramingProtocolEncoder(int) - Method in class akka.stream.scaladsl.Framing$
-
- simpleFramingProtocolEncoder(int) - Static method in class akka.stream.scaladsl.Framing
-
- SimpleLinearGraphStage() - Constructor for class akka.stream.impl.fusing.GraphStages.SimpleLinearGraphStage
-
- simpleName(Object) - Method in class akka.event.Logging$
-
- simpleName(Class<?>) - Method in class akka.event.Logging$
-
- simpleName(Object) - Static method in class akka.event.Logging
-
- simpleName(Class<?>) - Static method in class akka.event.Logging
-
- SimpleOutputs - Class in akka.stream.impl
-
INTERNAL API
- SimpleOutputs(ActorRef, Pump) - Constructor for class akka.stream.impl.SimpleOutputs
-
- 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
-
- single(Object) - Method in class akka.persistence.journal.EventSeq$
-
Java API
- single(Object) - Static method in class akka.persistence.journal.EventSeq
-
Java API
- single(T) - Method in class akka.stream.javadsl.Source$
-
Create a Source
with one element.
- single(T) - Static method in class akka.stream.javadsl.Source
-
Create a Source
with one element.
- single() - Method in class akka.stream.KillSwitches$
-
Creates a new
Graph
of
FlowShape
that materializes to an external switch that allows external completion
of that unique materialization.
- single() - Static method in class akka.stream.KillSwitches
-
Creates a new
Graph
of
FlowShape
that materializes to an external switch that allows external completion
of that unique materialization.
- single(T) - Method in class akka.stream.scaladsl.Source$
-
Create a Source
with one element.
- single(T) - Static method in class akka.stream.scaladsl.Source
-
Create a Source
with one element.
- singleBidi() - Method in class akka.stream.KillSwitches$
-
Creates a new
Graph
of
FlowShape
that materializes to an external switch that allows external completion
of that unique materialization.
- singleBidi() - Static method in class akka.stream.KillSwitches
-
Creates a new
Graph
of
FlowShape
that materializes to an external switch that allows external completion
of that unique materialization.
- SingleConsumerOnlyUnboundedMailbox - Class in akka.dispatch
-
SingleConsumerOnlyUnboundedMailbox is a high-performance, multiple producer—single consumer, unbounded MailboxType,
with the drawback that you can't have multiple consumers,
which rules out using it with BalancingPool (BalancingDispatcher) for instance.
- SingleConsumerOnlyUnboundedMailbox() - 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$
-
- SingleEventSeq - Class in akka.persistence.journal
-
- SingleEventSeq(Object) - Constructor for class akka.persistence.journal.SingleEventSeq
-
- SingleEventSeq$ - Class in akka.persistence.journal
-
- SingleEventSeq$() - Constructor for class akka.persistence.journal.SingleEventSeq$
-
- SingleExpectDefaultTimeout() - Method in class akka.testkit.TestKitSettings
-
- singleNoAttribute() - Method in class akka.stream.impl.fusing.GraphInterpreter$
-
- singleNoAttribute() - Static method in class akka.stream.impl.fusing.GraphInterpreter
-
- SingleSource(T) - Constructor for class akka.stream.impl.fusing.GraphStages.SingleSource
-
- singleSource() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- singleton() - Method in class akka.cluster.singleton.ClusterSingletonManager.Internal$.HandingOverData
-
- singleton() - Method in class akka.cluster.singleton.ClusterSingletonManager.Internal$.OldestData
-
- singleton() - Method in class akka.cluster.singleton.ClusterSingletonManager.Internal$.StoppingData
-
- singleton() - Method in class akka.cluster.singleton.ClusterSingletonManager.Internal$.WasOldestData
-
- singleton() - Method in class akka.cluster.singleton.ClusterSingletonProxy
-
- singletonIdentificationInterval() - Method in class akka.cluster.singleton.ClusterSingletonProxySettings
-
- singletonName() - Method in class akka.cluster.singleton.ClusterSingletonManagerSettings
-
- singletonName() - Method in class akka.cluster.singleton.ClusterSingletonProxySettings
-
- singletonPath() - Method in class akka.cluster.singleton.ClusterSingletonProxy
-
- singletonTerminated() - Method in class akka.cluster.singleton.ClusterSingletonManager.Internal$.OldestData
-
- singletonTerminated() - Method in class akka.cluster.singleton.ClusterSingletonManager.Internal$.WasOldestData
-
- Sink<In,Mat> - Class in akka.stream.javadsl
-
Java API
- Sink(Sink<In, Mat>) - Constructor for class akka.stream.javadsl.Sink
-
- sink(int) - Method in class akka.stream.scaladsl.BroadcastHub$
-
Creates a
Sink
that receives elements from its upstream producer and broadcasts them to a dynamic set
of consumers.
- sink() - Method in class akka.stream.scaladsl.BroadcastHub$
-
Creates a
Sink
that receives elements from its upstream producer and broadcasts them to a dynamic set
of consumers.
- sink(int) - Static method in class akka.stream.scaladsl.BroadcastHub
-
Creates a
Sink
that receives elements from its upstream producer and broadcasts them to a dynamic set
of consumers.
- sink() - Static method in class akka.stream.scaladsl.BroadcastHub
-
Creates a
Sink
that receives elements from its upstream producer and broadcasts them to a dynamic set
of consumers.
- Sink<In,Mat> - Class in akka.stream.scaladsl
-
A Sink
is a set of stream processing steps that has one open input.
- Sink(StreamLayout.Module) - Constructor for class akka.stream.scaladsl.Sink
-
- sink() - Method in class akka.stream.stage.GraphStageLogic.SubSinkInlet
-
- Sink$ - Class in akka.stream.javadsl
-
Java API
- Sink$() - Constructor for class akka.stream.javadsl.Sink$
-
- Sink$ - Class in akka.stream.scaladsl
-
- Sink$() - Constructor for class akka.stream.scaladsl.Sink$
-
- SinkArrow(Graph<SinkShape<T>, ?>) - Constructor for class akka.stream.scaladsl.GraphDSL.Implicits$.SinkArrow
-
- SinkholeSubscriber<T> - Class in akka.stream.impl
-
INTERNAL API
- SinkholeSubscriber(Promise<Done>) - Constructor for class akka.stream.impl.SinkholeSubscriber
-
- SinkModule<In,Mat> - Class in akka.stream.impl
-
INTERNAL API
- SinkModule(SinkShape<In>) - Constructor for class akka.stream.impl.SinkModule
-
- SinkQueue<T> - Interface in akka.stream.javadsl
-
Trait allows to have the queue as a sink for some stream.
- SinkQueue<T> - Interface in akka.stream.scaladsl
-
Trait allows to have the queue as a sink for some stream.
- SinkQueueAdapter<T> - Class in akka.stream.impl
-
- SinkQueueAdapter(SinkQueueWithCancel<T>) - Constructor for class akka.stream.impl.SinkQueueAdapter
-
INTERNAL API
- SinkQueueWithCancel<T> - Interface in akka.stream.javadsl
-
- SinkQueueWithCancel<T> - Interface in akka.stream.scaladsl
-
- SinkShape<T> - Class in akka.stream
-
A Sink
Shape
has exactly one input and no outputs, it models a data sink.
- SinkShape(Inlet<T>) - Constructor for class akka.stream.SinkShape
-
- SinkShape$ - Class in akka.stream
-
- SinkShape$() - Constructor for class akka.stream.SinkShape$
-
- SinkShapeArrow(SinkShape<T>) - Constructor for class akka.stream.scaladsl.GraphDSL.Implicits$.SinkShapeArrow
-
- size() - Method in class akka.cluster.ddata.GSet
-
- size() - Method in class akka.cluster.ddata.LWWMap
-
- size() - Method in class akka.cluster.ddata.ManyVersionVector
-
INTERNAL API
- size() - Method in class akka.cluster.ddata.OneVersionVector
-
INTERNAL API
- size() - Method in class akka.cluster.ddata.ORMap
-
- size() - Method in class akka.cluster.ddata.ORMultiMap
-
- size() - Method in class akka.cluster.ddata.ORSet
-
- size() - Method in class akka.cluster.ddata.PNCounterMap
-
- size() - Method in class akka.cluster.ddata.VersionVector
-
INTERNAL API
- 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.persistence.AtomicWrite
-
- size() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- size() - Static method in class akka.persistence.journal.JournalSpec
-
- size() - Method in class akka.persistence.NonPersistentRepr
-
- size() - Method in interface akka.persistence.PersistentEnvelope
-
- size() - Method in class akka.persistence.PluginSpec
-
- size() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- size() - Method in class akka.remote.artery.compress.CountMinSketch
-
- size() - Method in class akka.remote.artery.ImmutableLongMap
-
- size() - Static method in class akka.remote.security.provider.AkkaProvider
-
- size() - Method in class akka.stream.impl.BatchingInputBuffer
-
- size() - Method in class akka.stream.impl.fusing.Buffer
-
- size() - Method in class akka.stream.impl.ResizableMultiReaderRingBuffer
-
The number of elements currently in the buffer.
- size() - Method in class akka.typed.internal.EarliestFirstSystemMessageList
-
Indicates if the list is empty or not.
- size() - Method in class akka.typed.internal.LatestFirstSystemMessageList
-
Indicates if the list is empty or not.
- size() - Method in class akka.util.BoundedBlockingQueue
-
- size() - Static method in class akka.util.ByteIterator
-
- size() - Static method in class akka.util.ByteString
-
- size() - Method in class akka.util.Collections.PartialImmutableValuesIterable
-
- size() - Static method in class akka.util.CompactByteString
-
- size() - Method in class akka.util.MessageBuffer
-
How many elements are in the message buffer.
- size() - Method in class akka.util.MessageBufferMap
-
How many ids are in the buffer map.
- size() - Method in interface akka.util.PriorityQueueStabilizer
-
- size() - Method in class akka.util.SerializedSuspendableExecutionContext
-
O(N)
- sizeHint(int) - Method in class akka.util.ByteStringBuilder
-
- sizeHintIfCheap() - Static method in class akka.util.ByteIterator
-
- sizeHintIfCheap() - Static method in class akka.util.ByteString
-
- sizeHintIfCheap() - Static method in class akka.util.CompactByteString
-
- sizeInner(SystemMessage, int) - Method in class akka.dispatch.sysmsg.SystemMessageList$
-
- sizeInner(SystemMessage, int) - Static method in class akka.dispatch.sysmsg.SystemMessageList
-
- sizeInner(SystemMessage, int) - Method in class akka.typed.internal.SystemMessageList$
-
- sizeInner(SystemMessage, int) - Static method in class akka.typed.internal.SystemMessageList
-
- skip(int) - Method in class akka.stream.impl.io.ByteStringParser.ByteReader
-
- skipMemberStatus() - Static method in class akka.cluster.AutoDown
-
- skipMemberStatus() - Method in class akka.cluster.AutoDownBase
-
- skipZeroTerminatedString() - Method in class akka.stream.impl.io.ByteStringParser.ByteReader
-
- 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 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.ByteString1
-
- slice(int, int) - Method in class akka.util.ByteString.ByteString1C
-
- slice(int, int) - Method in class akka.util.ByteString.ByteStrings
-
- slice(int, int) - Method in class akka.util.ByteString
-
- slice(int, int) - Static method in class akka.util.CompactByteString
-
- sliceIterator(int, int) - Static method in class akka.util.ByteIterator
-
- sliceWithKnownBound(int, int) - Static method in class akka.util.ByteString
-
- sliceWithKnownBound(int, int) - Static method in class akka.util.CompactByteString
-
- sliceWithKnownDelta(int, int, int) - Static method in class akka.util.ByteString
-
- sliceWithKnownDelta(int, int, int) - Static method in class akka.util.CompactByteString
-
- Sliding<T> - Class in akka.stream.impl.fusing
-
INTERNAL API
- Sliding(int, int) - Constructor for class akka.stream.impl.fusing.Sliding
-
- sliding() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- sliding(int, int) - Static method in class akka.stream.impl.SubFlowImpl
-
- sliding(int, int) - Method in class akka.stream.javadsl.Flow
-
Apply a sliding window over the stream and return the windows as groups of elements, with the last group
possibly smaller than requested due to end-of-stream.
- sliding(int, int) - Method in class akka.stream.javadsl.Source
-
Apply a sliding window over the stream and return the windows as groups of elements, with the last group
possibly smaller than requested due to end-of-stream.
- sliding(int, int) - Method in class akka.stream.javadsl.SubFlow
-
Apply a sliding window over the stream and return the windows as groups of elements, with the last group
possibly smaller than requested due to end-of-stream.
- sliding(int, int) - Method in class akka.stream.javadsl.SubSource
-
- sliding(int, int) - Static method in class akka.stream.scaladsl.Flow
-
- sliding(int, int) - Method in interface akka.stream.scaladsl.FlowOps
-
Apply a sliding window over the stream and return the windows as groups of elements, with the last group
possibly smaller than requested due to end-of-stream.
- sliding(int, int) - Static method in class akka.stream.scaladsl.Source
-
- sliding(int, int) - Static method in class akka.util.ByteIterator
-
- sliding(int) - Static method in class akka.util.ByteString
-
- sliding(int, int) - Static method in class akka.util.ByteString
-
- sliding(int) - Static method in class akka.util.CompactByteString
-
- sliding(int, int) - Static method in class akka.util.CompactByteString
-
- Sliding$ - Class in akka.stream.impl.fusing
-
- Sliding$() - Constructor for class akka.stream.impl.fusing.Sliding$
-
- sliding$default$2() - Static method in class akka.stream.impl.SubFlowImpl
-
- sliding$default$2() - Static method in class akka.stream.scaladsl.Flow
-
- sliding$default$2() - Static method in class akka.stream.scaladsl.Source
-
- sliding$default$2() - Static method in class akka.util.ByteIterator
-
- slot() - Method in class akka.stream.impl.fusing.GraphInterpreter.Connection
-
- smallBackoffCount() - Method in class akka.remote.EndpointWriter
-
- SmallCache(int, FiniteDuration, Function1<A, B>) - Constructor for class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer.SmallCache
-
- 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
-
Deprecated.
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.Eventsourced.RecoveryTick
-
- 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() - Method in class akka.remote.artery.FlightRecorder
-
- Snapshot() - Method in class akka.remote.artery.RollingEventLogSection$
-
- Snapshot() - Static method in class akka.remote.artery.RollingEventLogSection
-
- Snapshot$ - Class in akka.persistence.serialization
-
- Snapshot$() - Constructor for class akka.persistence.serialization.Snapshot$
-
- Snapshot$() - Constructor for class akka.remote.artery.FlightRecorderReader.Snapshot$
-
- snapshotAfter() - Method in class akka.cluster.sharding.ClusterShardingSettings.TuningParameters
-
- snapshotByteSizeLimit() - Method in class akka.persistence.snapshot.SnapshotStoreSpec
-
The limit defines a number of bytes persistence plugin can support to store the snapshot.
- SnapshotCount() - Method in class akka.remote.artery.FlightRecorder$
-
- SnapshotCount() - Static method in class akka.remote.artery.FlightRecorder
-
- snapshotFileForWrite(SnapshotMetadata, String) - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
-
Only by persistenceId and sequenceNr, timestamp is informational - accomodates for 2.13.x series files
- 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$
-
- SnapshotInProgress - Class in akka.remote.artery
-
- SnapshotInProgress(CountDownLatch) - Constructor for class akka.remote.artery.SnapshotInProgress
-
- SnapshotInProgress$ - Class in akka.remote.artery
-
- SnapshotInProgress$() - Constructor for class akka.remote.artery.SnapshotInProgress$
-
- SnapshotMask() - Method in class akka.remote.artery.FlightRecorder$
-
- SnapshotMask() - Static method in class akka.remote.artery.FlightRecorder
-
- 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 class akka.cluster.sharding.ClusterShardingSettings
-
- snapshotPluginId() - Method in class akka.cluster.sharding.PersistentShard
-
- snapshotPluginId() - Method in class akka.cluster.sharding.PersistentShardCoordinator
-
- 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.LoadSnapshotFailed - Class in akka.persistence
-
- SnapshotProtocol.LoadSnapshotFailed$ - 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
-
- snapshots() - Method in class akka.cluster.sharding.RemoveInternalClusterShardingData.RemoveOnePersistenceId$.Removals
-
- SnapshotSelectionCriteria - Class in akka.persistence
-
Selection criteria for loading and deleting snapshots.
- SnapshotSelectionCriteria(long, long, 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
-
Deprecated.
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 class akka.cluster.sharding.PersistentShard
-
- snapshotStore() - Method in class akka.cluster.sharding.PersistentShardCoordinator
-
- snapshotStore() - Method in class akka.cluster.sharding.RemoveInternalClusterShardingData.RemoveOnePersistenceId
-
- snapshotStore() - Method in class akka.persistence.AbstractPersistentActor
-
- snapshotStore() - Method in class akka.persistence.AbstractPersistentView
-
Deprecated.
- snapshotStore() - Method in interface akka.persistence.Eventsourced
-
- snapshotStore() - Method in class akka.persistence.fsm.AbstractPersistentFSM
-
- snapshotStore() - Method in class akka.persistence.fsm.AbstractPersistentLoggingFSM
-
- snapshotStore() - Method in class akka.persistence.journal.JournalPerfSpec.BenchActor
-
- snapshotStore() - Method in interface akka.persistence.PersistentView
-
Deprecated.
- 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.
- snapshotStore() - Method in class akka.persistence.UntypedPersistentActor
-
- snapshotStore() - Method in class akka.persistence.UntypedPersistentView
-
Deprecated.
- SnapshotStoreCapabilityFlags - Interface in akka.persistence
-
- snapshotStoreFor(String) - Method in class akka.persistence.Persistence
-
INTERNAL API
- 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$
-
- 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
-
Deprecated.
Returns viewId
.
- snapshotterId() - Method in interface akka.persistence.Snapshotter
-
Snapshotter id.
- 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$
-
- SoftShutdown - Interface in akka.stream.impl
-
INTERNAL API
- softShutdown() - Method in interface akka.stream.impl.SoftShutdown
-
- 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$
-
- Some$() - Constructor for class akka.util.OptionVal.Some$
-
- SomeMaxFiniteDuration() - Method in class akka.persistence.fsm.PersistentFSM$
-
Used by forMax
to signal "cancel stateTimeout"
- SomeNormalShutdownReason() - Method in class akka.stream.impl.ActorPublisher$
-
- SomeNormalShutdownReason() - Static method in class akka.stream.impl.ActorPublisher
-
- 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).
- sortBy(Function1<A, B>, Ordering<B>) - Static method in class akka.util.ByteString
-
- sortBy(Function1<A, B>, Ordering<B>) - Static method in class akka.util.CompactByteString
-
- sorted() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- sorted() - Static method in class akka.persistence.journal.JournalSpec
-
- sorted() - Method in class akka.persistence.PluginSpec
-
- sorted() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- sorted(Ordering<B>) - Static method in class akka.util.ByteString
-
- sorted(Ordering<B>) - Static method in class akka.util.CompactByteString
-
- sortWith(Function2<A, A, Object>) - Static method in class akka.util.ByteString
-
- sortWith(Function2<A, A, Object>) - Static method in class akka.util.CompactByteString
-
- source() - Method in class akka.stream.extra.Implicits.TimedSourceDsl
-
- Source<Out,Mat> - Class in akka.stream.javadsl
-
Java API
- Source(Source<Out, Mat>) - Constructor for class akka.stream.javadsl.Source
-
- source(int) - Method in class akka.stream.scaladsl.MergeHub$
-
Creates a
Source
that emits elements merged from a dynamic set of producers.
- source() - Method in class akka.stream.scaladsl.MergeHub$
-
Creates a
Source
that emits elements merged from a dynamic set of producers.
- source(int) - Static method in class akka.stream.scaladsl.MergeHub
-
Creates a
Source
that emits elements merged from a dynamic set of producers.
- source() - Static method in class akka.stream.scaladsl.MergeHub
-
Creates a
Source
that emits elements merged from a dynamic set of producers.
- Source<Out,Mat> - Class in akka.stream.scaladsl
-
A Source
is a set of stream processing steps that has one open output.
- Source(StreamLayout.Module) - Constructor for class akka.stream.scaladsl.Source
-
- source() - Method in class akka.stream.stage.GraphStageLogic.SubSourceOutlet
-
Get the Source for this dynamic output port.
- source() - Static method in class akka.testkit.CustomEventFilter
-
- source() - Static method in class akka.testkit.DeadLettersFilter
-
- 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
-
- Source$ - Class in akka.stream.javadsl
-
Java API
- Source$() - Constructor for class akka.stream.javadsl.Source$
-
- Source$ - Class in akka.stream.scaladsl
-
- Source$() - Constructor for class akka.stream.scaladsl.Source$
-
- SourceArrow(Graph<SourceShape<T>, ?>) - Constructor for class akka.stream.scaladsl.GraphDSL.Implicits$.SourceArrow
-
- 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$
-
- SourceModule<Out,Mat> - Class in akka.stream.impl
-
INTERNAL API
- SourceModule(SourceShape<Out>) - Constructor for class akka.stream.impl.SourceModule
-
- SourceQueue<T> - Interface in akka.stream.javadsl
-
This trait allows to have the queue as a data source for some stream.
- SourceQueue<T> - Interface in akka.stream.scaladsl
-
This trait allows to have the queue as a data source for some stream.
- SourceQueueAdapter<T> - Class in akka.stream.impl
-
- SourceQueueAdapter(SourceQueueWithComplete<T>) - Constructor for class akka.stream.impl.SourceQueueAdapter
-
- SourceQueueWithComplete<T> - Interface in akka.stream.javadsl
-
- SourceQueueWithComplete<T> - Interface in akka.stream.scaladsl
-
- SourceShape<T> - Class in akka.stream
-
A Source
Shape
has exactly one output and no inputs, it models a source
of data.
- SourceShape(Outlet<T>) - Constructor for class akka.stream.SourceShape
-
- SourceShape$ - Class in akka.stream
-
- SourceShape$() - Constructor for class akka.stream.SourceShape$
-
- SourceShapeArrow(SourceShape<T>) - Constructor for class akka.stream.scaladsl.GraphDSL.Implicits$.SourceShapeArrow
-
- Space() - Method in class akka.stream.impl.JsonObjectParser$
-
- Space() - Static method in class akka.stream.impl.JsonObjectParser
-
- span(Function1<Object, Object>) - Method in class akka.util.ByteIterator
-
- span(Function1<Object, Object>) - Method in class akka.util.ByteString
-
- span(Function1<Object, Object>) - Static method in class akka.util.CompactByteString
-
- Spawn(Props, Option<String>, Option<SupervisorStrategy>) - Constructor for class akka.testkit.TestActor.Spawn
-
- spawn(Behavior<U>, String, DeploymentConfig) - Method in interface akka.typed.ActorContext
-
Create a child Actor from the given Props
and with the given name.
- spawn(Behavior<U>, String, DeploymentConfig) - Method in class akka.typed.adapter.ActorContextAdapter
-
- spawn(Behavior<U>, String, DeploymentConfig) - Method in class akka.typed.EffectfulActorContext
-
- spawn(Behavior<U>, String, DeploymentConfig) - Method in class akka.typed.internal.ActorCell
-
- spawn(Behavior<U>, String, DeploymentConfig) - Method in class akka.typed.StubbedActorContext
-
- Spawn$() - Constructor for class akka.testkit.TestActor.Spawn$
-
- spawn$default$3() - Static method in class akka.typed.internal.ActorCell
-
- 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.adapter.ActorContextAdapter
-
- spawnAdapter(Function1<U, T>) - Method in class akka.typed.internal.ActorCell
-
- spawnAdapter(Function1<U, T>) - Method in class akka.typed.StubbedActorContext
-
- spawnAnonymous(Behavior<U>, DeploymentConfig) - Method in interface akka.typed.ActorContext
-
Create a child Actor from the given Props
under a randomly chosen name.
- spawnAnonymous(Behavior<U>, DeploymentConfig) - Method in class akka.typed.adapter.ActorContextAdapter
-
- spawnAnonymous(Behavior<U>, DeploymentConfig) - Method in class akka.typed.EffectfulActorContext
-
- spawnAnonymous(Behavior<U>, DeploymentConfig) - Method in class akka.typed.internal.ActorCell
-
- spawnAnonymous(Behavior<U>, DeploymentConfig) - Method in class akka.typed.StubbedActorContext
-
- spawnAnonymous$default$2() - Static method in class akka.typed.internal.ActorCell
-
- 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
-
- specialStackTrace() - Method in exception akka.persistence.scalatest.MayVerb.TestCanceledByFailure
-
- split(String, String) - Static method in class akka.actor.ActorPathExtractor
-
- split(String, String) - Method in interface akka.actor.PathUtils
-
- split(String, String) - Static method in class akka.actor.RelativeActorPath
-
- Split<T> - Class in akka.stream.impl.fusing
-
INTERNAL API
- Split(Split.SplitDecision, Function1<T, Object>, SubstreamCancelStrategy) - Constructor for class akka.stream.impl.fusing.Split
-
- split() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- Split$ - Class in akka.stream.impl.fusing
-
INTERNAL API
- Split$() - Constructor for class akka.stream.impl.fusing.Split$
-
- Split.SplitAfter$ - Class in akka.stream.impl.fusing
-
Splits after the current element.
- Split.SplitBefore$ - Class in akka.stream.impl.fusing
-
Splits before the current element.
- Split.SplitDecision - Class in akka.stream.impl.fusing
-
- splitAfter(SubstreamCancelStrategy, Function1<Out, Object>) - Static method in class akka.stream.impl.SubFlowImpl
-
- splitAfter(Function1<Out, Object>) - Static method in class akka.stream.impl.SubFlowImpl
-
- splitAfter(Predicate<Out>) - Method in class akka.stream.javadsl.Flow
-
This operation applies the given predicate to all incoming elements and
emits them to a stream of output streams.
- splitAfter(SubstreamCancelStrategy, Predicate<Out>) - Method in class akka.stream.javadsl.Flow
-
This operation applies the given predicate to all incoming elements and
emits them to a stream of output streams.
- splitAfter(Predicate<Out>) - Method in class akka.stream.javadsl.Source
-
This operation applies the given predicate to all incoming elements and
emits them to a stream of output streams.
- splitAfter(SubstreamCancelStrategy, Function1<Out, Object>) - Static method in class akka.stream.scaladsl.Flow
-
- splitAfter(Function1<Out, Object>) - Static method in class akka.stream.scaladsl.Flow
-
- splitAfter(SubstreamCancelStrategy, Function1<Out, Object>) - Method in interface akka.stream.scaladsl.FlowOps
-
This operation applies the given predicate to all incoming elements and
emits them to a stream of output streams.
- splitAfter(Function1<Out, Object>) - Method in interface akka.stream.scaladsl.FlowOps
-
This operation applies the given predicate to all incoming elements and
emits them to a stream of output streams.
- splitAfter(SubstreamCancelStrategy, Function1<Out, Object>) - Static method in class akka.stream.scaladsl.Source
-
- splitAfter(Function1<Out, Object>) - Static method in class akka.stream.scaladsl.Source
-
- SplitAfter$() - Constructor for class akka.stream.impl.fusing.Split.SplitAfter$
-
- splitAt(int) - Method in class akka.util.ByteString
-
- splitAt(int) - Static method in class akka.util.CompactByteString
-
- SplitBefore$() - Constructor for class akka.stream.impl.fusing.Split.SplitBefore$
-
- SplitDecision() - Constructor for class akka.stream.impl.fusing.Split.SplitDecision
-
- spliterator() - Static method in class akka.japi.Option
-
- spliterator() - Static method in class akka.remote.transport.netty.ChannelLocalActor
-
- splitNameAndUid(String) - Method in class akka.actor.ActorCell$
-
- splitNameAndUid(String) - Static method in class akka.actor.ActorCell
-
- splitWhen(SubstreamCancelStrategy, Function1<Out, Object>) - Static method in class akka.stream.impl.SubFlowImpl
-
- splitWhen(Function1<Out, Object>) - Static method in class akka.stream.impl.SubFlowImpl
-
- splitWhen(Predicate<Out>) - Method in class akka.stream.javadsl.Flow
-
This operation applies the given predicate to all incoming elements and
emits them to a stream of output streams, always beginning a new one with
the current element if the given predicate returns true for it.
- splitWhen(SubstreamCancelStrategy, Predicate<Out>) - Method in class akka.stream.javadsl.Flow
-
This operation applies the given predicate to all incoming elements and
emits them to a stream of output streams, always beginning a new one with
the current element if the given predicate returns true for it.
- splitWhen(Predicate<Out>) - Method in class akka.stream.javadsl.Source
-
This operation applies the given predicate to all incoming elements and
emits them to a stream of output streams, always beginning a new one with
the current element if the given predicate returns true for it.
- splitWhen(SubstreamCancelStrategy, Function1<Out, Object>) - Static method in class akka.stream.scaladsl.Flow
-
- splitWhen(Function1<Out, Object>) - Static method in class akka.stream.scaladsl.Flow
-
- splitWhen(SubstreamCancelStrategy, Function1<Out, Object>) - Method in interface akka.stream.scaladsl.FlowOps
-
This operation applies the given predicate to all incoming elements and
emits them to a stream of output streams, always beginning a new one with
the current element if the given predicate returns true for it.
- splitWhen(Function1<Out, Object>) - Method in interface akka.stream.scaladsl.FlowOps
-
This operation applies the given predicate to all incoming elements and
emits them to a stream of output streams, always beginning a new one with
the current element if the given predicate returns true for it.
- splitWhen(SubstreamCancelStrategy, Function1<Out, Object>) - Static method in class akka.stream.scaladsl.Source
-
- splitWhen(Function1<Out, Object>) - Static method in class akka.stream.scaladsl.Source
-
- SquareBraceEnd() - Method in class akka.stream.impl.JsonObjectParser$
-
- SquareBraceEnd() - Static method in class akka.stream.impl.JsonObjectParser
-
- SquareBraceStart() - Method in class akka.stream.impl.JsonObjectParser$
-
- SquareBraceStart() - Static method in class akka.stream.impl.JsonObjectParser
-
- squaredIntervalSum() - Method in class akka.remote.HeartbeatHistory
-
- SSLEnabledAlgorithms() - Method in class akka.remote.transport.netty.SSLSettings
-
- sslEngineConfigurator() - Method in class com.typesafe.sslconfig.akka.AkkaSSLConfig
-
- SSLEngineConfigurator - Interface in com.typesafe.sslconfig.akka
-
Gives the chance to configure the SSLContext before it is going to be used.
- 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
-
- sslParameters() - Method in class akka.stream.TLSProtocol.NegotiateNewSession
-
- SSLProtocol() - Method in class akka.remote.transport.netty.SSLSettings
-
- SSLRandomNumberGenerator() - Method in class akka.remote.transport.netty.SSLSettings
-
- SSLRequireMutualAuthentication() - 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
-
- stackDepth() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- stackDepth() - Static method in class akka.persistence.journal.JournalSpec
-
- stackDepth() - Method in class akka.persistence.PluginSpec
-
- stackDepth() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- STACKTRACE_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.Throwable
-
- stackTraceElementBuilder(StackTraceElement) - Method in class akka.remote.serialization.ThrowableSupport
-
- stackTraceFor(Throwable) - Method in class akka.event.Logging$
-
- stackTraceFor(Throwable) - Static method in class akka.event.Logging
-
- stage() - Method in class akka.stream.impl.fusing.GraphStageModule
-
- Stage<In,Out> - Interface in akka.stream.stage
-
- stageActor() - Method in class akka.stream.stage.GraphStageLogic
-
- StageActor(ActorMaterializer, Function1<Function1<Tuple2<ActorRef, Object>, BoxedUnit>, AsyncCallback<Tuple2<ActorRef, Object>>>, Function1<Tuple2<ActorRef, Object>, BoxedUnit>) - Constructor for class akka.stream.stage.GraphStageLogic.StageActor
-
- StageActorRef$() - Constructor for class akka.stream.stage.GraphStageLogic.StageActorRef$
-
- StageActorRefNotInitializedException() - Constructor for exception akka.stream.stage.GraphStageLogic.StageActorRefNotInitializedException
-
- StageActorRefNotInitializedException$() - Constructor for class akka.stream.stage.GraphStageLogic.StageActorRefNotInitializedException$
-
- StageFailure(GraphStageMessages.StageMessage, Throwable) - Constructor for class akka.stream.testkit.GraphStageMessages.StageFailure
-
- StageFailure$() - Constructor for class akka.stream.testkit.GraphStageMessages.StageFailure$
-
- stageId() - Method in class akka.stream.stage.GraphStageLogic
-
INTERNAL API
- StageLogging - Interface in akka.stream.stage
-
Simple way to obtain a LoggingAdapter
when used together with an ActorMaterializer
.
- stageName() - Method in class akka.stream.MaterializationContext
-
- stages() - Method in class akka.stream.impl.fusing.GraphInterpreter.GraphAssembly
-
- stages() - Method in class akka.stream.impl.fusing.IteratorInterpreter
-
- Stages - Class in akka.stream.impl
-
INTERNAL API
- Stages() - Constructor for class akka.stream.impl.Stages
-
- Stages$ - Class in akka.stream.impl
-
INTERNAL API
- Stages$() - Constructor for class akka.stream.impl.Stages$
-
- Stages.DefaultAttributes$ - Class in akka.stream.impl
-
- Stages.SymbolicGraphStage<In,Out,Ext> - Class in akka.stream.impl
-
- Stages.SymbolicGraphStage$ - Class in akka.stream.impl
-
- Stages.SymbolicStage<In,Out> - Interface in akka.stream.impl
-
- StageState<In,Out> - Class in akka.stream.stage
-
The behavior of
StatefulStage
is defined by these two methods, which
has the same semantics as corresponding methods in
PushPullStage
.
- StageState() - Constructor for class akka.stream.stage.StageState
-
- 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
-
- StandardMetrics() - Constructor for class akka.cluster.StandardMetrics
-
Deprecated.
- 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
-
- StandardMetrics$() - Constructor for class akka.cluster.StandardMetrics$
-
Deprecated.
- StandardMetrics.Cpu - Class in akka.cluster.metrics
-
- StandardMetrics.Cpu - Class in akka.cluster
-
Deprecated.
- StandardMetrics.Cpu$ - Class in akka.cluster.metrics
-
- StandardMetrics.Cpu$ - Class in akka.cluster
-
Deprecated.
- StandardMetrics.HeapMemory - Class in akka.cluster.metrics
-
- StandardMetrics.HeapMemory - Class in akka.cluster
-
Deprecated.
- StandardMetrics.HeapMemory$ - Class in akka.cluster.metrics
-
- StandardMetrics.HeapMemory$ - Class in akka.cluster
-
Deprecated.
- StandardOutLogger() - Method in class akka.event.Logging$
-
- StandardOutLogger() - Static method in class akka.event.Logging
-
- StandardOutLogger() - Constructor for class akka.event.Logging.StandardOutLogger
-
- StandardOutLogger() - Constructor for class akka.typed.internal.EventStreamImpl.StandardOutLogger
-
- StandardOutLoggerPath() - Method in class akka.typed.internal.EventStreamImpl$
-
- StandardOutLoggerPath() - Static method in class akka.typed.internal.EventStreamImpl
-
- start() - Static method in class akka.actor.ActorCell
-
- 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() - Static method in class akka.actor.DeadLetterActorRef
-
- 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() - Static method in class akka.actor.Nobody
-
- 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, Props, ClusterShardingSettings, PartialFunction<Object, Tuple2<String, Object>>, Function1<Object, String>, ShardCoordinator.ShardAllocationStrategy, Object) - Method in class akka.cluster.sharding.ClusterSharding
-
Scala API: Register a named entity type by defining the
Props
of the entity actor
and functions to extract entity and shard identifier from messages.
- start(String, Props, ClusterShardingSettings, PartialFunction<Object, Tuple2<String, Object>>, Function1<Object, String>) - Method in class akka.cluster.sharding.ClusterSharding
-
Register a named entity type by defining the
Props
of the entity actor and
functions to extract entity and shard identifier from messages.
- start(String, Props, ClusterShardingSettings, ShardRegion.MessageExtractor, ShardCoordinator.ShardAllocationStrategy, Object) - Method in class akka.cluster.sharding.ClusterSharding
-
Java/Scala API: Register a named entity type by defining the
Props
of the entity actor
and functions to extract entity and shard identifier from messages.
- start(String, Props, ClusterShardingSettings, ShardRegion.MessageExtractor) - Method in class akka.cluster.sharding.ClusterSharding
-
Java/Scala API: Register a named entity type by defining the
Props
of the entity actor
and functions to extract entity and shard identifier from messages.
- Start(String, Props, ClusterShardingSettings, PartialFunction<Object, Tuple2<String, Object>>, Function1<Object, String>, ShardCoordinator.ShardAllocationStrategy, Object) - Constructor for class akka.cluster.sharding.ClusterShardingGuardian.Start
-
- Start() - Constructor for class akka.cluster.singleton.ClusterSingletonManager.Internal$.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() - Static method in class akka.pattern.PromiseActorRef
-
- start(ActorSystem) - Method in class akka.persistence.journal.PersistencePluginProxy$
-
- start(ActorSystem) - Static method in class akka.persistence.journal.PersistencePluginProxy
-
- start() - Method in class akka.remote.artery.ArteryTransport
-
- start() - Method in class akka.remote.artery.TaskRunner
-
- 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.OptimalSizeExploringResizer.UnderUtilizationStreak
-
- start() - Method in class akka.routing.RoutedActorCell
-
- start() - Method in class akka.stream.extra.Timed.TimedFlowContext
-
Deprecated.
- start() - Method in class akka.stream.impl.fusing.Intersperse
-
- start() - Static method in class akka.testkit.TestActorRef
-
- start() - Static method in class akka.testkit.TestFSMRef
-
- Start$() - Constructor for class akka.cluster.sharding.ClusterShardingGuardian.Start$
-
- startChild() - Static method in class akka.pattern.BackoffSupervisor
-
- startChild() - Method in interface akka.pattern.HandleBackoff
-
- StartChild$() - Constructor for class akka.pattern.BackoffSupervisor.StartChild$
-
- 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.
- startDefaultLoggers(ActorSystemImpl) - Static method in class akka.event.EventStream
-
- startDefaultLoggers(ActorSystemImpl) - Method in interface akka.event.LoggingBus
-
Internal Akka use only
- startDefaultLoggers(ActorSystemImpl<Nothing$>) - Method in class akka.typed.internal.EventStreamImpl
-
- 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.
- startingShards() - Method in class akka.cluster.sharding.ShardRegion
-
- 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.
- StartOldestChangedBuffer() - Constructor for class akka.cluster.singleton.ClusterSingletonManager.Internal$.StartOldestChangedBuffer
-
- startProxy(String, Option<String>, PartialFunction<Object, Tuple2<String, Object>>, Function1<Object, String>) - Method in class akka.cluster.sharding.ClusterSharding
-
Scala API: Register a named entity type ShardRegion
on this node that will run in proxy only mode,
i.e.
- startProxy(String, Optional<String>, ShardRegion.MessageExtractor) - Method in class akka.cluster.sharding.ClusterSharding
-
Java/Scala API: Register a named entity type ShardRegion
on this node that will run in proxy only mode,
i.e.
- StartProxy(String, ClusterShardingSettings, PartialFunction<Object, Tuple2<String, Object>>, Function1<Object, String>) - Constructor for class akka.cluster.sharding.ClusterShardingGuardian.StartProxy
-
- StartProxy$() - Constructor for class akka.cluster.sharding.ClusterShardingGuardian.StartProxy$
-
- startRecovery(Recovery) - Method in interface akka.persistence.Eventsourced
-
- startRecovery(Recovery) - Method in interface akka.persistence.PersistentView
-
Deprecated.
- startRedeliverTask() - Method in interface akka.persistence.AtLeastOnceDeliveryLike
-
- startStdoutLogger(ActorSystem.Settings) - Static method in class akka.event.EventStream
-
- startStdoutLogger(ActorSystem.Settings) - Method in interface akka.event.LoggingBus
-
Internal Akka use only
- startStdoutLogger(Settings) - Method in class akka.typed.internal.EventStreamImpl
-
- startsWith(String) - Method in class akka.testkit.JavaTestKit.EventFilter
-
- startsWith(GenSeq<B>) - Static method in class akka.util.ByteString
-
- startsWith(GenSeq<B>, int) - Static method in class akka.util.ByteString
-
- startsWith(GenSeq<B>) - Static method in class akka.util.CompactByteString
-
- startsWith(GenSeq<B>, int) - Static method in class akka.util.CompactByteString
-
- startTick() - Method in class akka.actor.LightArrayRevolverScheduler
-
Replaceable for testing.
- startTime() - Method in class akka.actor.ActorSystem
-
Start-up time in milliseconds since the epoch.
- startTime() - Method in class akka.remote.artery.FlightRecorderReader.Structure
-
- startTime() - Method in interface akka.typed.ActorSystem
-
Start-up time in milliseconds since the epoch.
- startTime() - Method in class akka.typed.adapter.ActorSystemAdapter
-
- startTime() - Method in class akka.typed.internal.ActorSystemImpl
-
- StartTimed(Timed.TimedFlowContext) - Constructor for class akka.stream.extra.Timed.StartTimed
-
Deprecated.
- StartTimeStampOffset() - Method in class akka.remote.artery.FlightRecorder$
-
- StartTimeStampOffset() - Static method in class akka.remote.artery.FlightRecorder
-
- startUnsubscriber() - Method in class akka.event.EventStream
-
''Must'' be called after actor system is "ready".
- startUnsubscriber(ActorSystem<Nothing$>) - Method in class akka.typed.internal.EventStreamImpl
-
''Must'' be called after actor system is "ready".
- startup() - Method in interface akka.kernel.Bootable
-
Deprecated.
Callback run on microkernel startup.
- StartupFinished$() - Constructor for class akka.remote.EndpointManager.StartupFinished$
-
- StartupTimeout() - Method in class akka.remote.RemoteSettings
-
- startUsingNextTable() - Method in class akka.remote.artery.compress.InboundCompression.State
-
- 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(S, D, Option<FiniteDuration>) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- startWith(S, D, Option<FiniteDuration>) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- startWith(S, D, Option<FiniteDuration>) - Static method in class akka.contrib.pattern.ReliableProxy
-
- startWith(S, D, Option<FiniteDuration>) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- startWith(S, D) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
Set initial state.
- startWith(S, D, FiniteDuration) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
Set initial state.
- startWith(S, D, Option<FiniteDuration>) - Method in interface akka.persistence.fsm.PersistentFSMBase
-
Set initial state.
- startWith() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- startWith() - Static method in class akka.persistence.journal.JournalSpec
-
- startWith() - Method in class akka.persistence.PluginSpec
-
- startWith() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- startWith(S, D, Option<FiniteDuration>) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- startWith(S, D, Option<FiniteDuration>) - Static method in class akka.remote.testconductor.ClientFSM
-
- startWith(S, D, Option<FiniteDuration>) - Static method in class akka.remote.testconductor.ServerFSM
-
- startWith(S, D, Option<FiniteDuration>) - Static method in class akka.remote.transport.ProtocolStateActor
-
- startWith(S, D, Option<FiniteDuration>) - Static method in class akka.remote.transport.ThrottledAssociation
-
- startWith(ByteStringParser.ParseStep<T>) - Method in class akka.stream.impl.io.ByteStringParser.ParsingLogic
-
- startWith$default$3() - Static method in class akka.actor.AbstractFSM
-
- startWith$default$3() - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- startWith$default$3() - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- startWith$default$3() - Static method in class akka.contrib.pattern.ReliableProxy
-
- startWith$default$3() - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- startWith$default$3() - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- startWith$default$3() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- startWith$default$3() - Static method in class akka.remote.testconductor.ClientFSM
-
- startWith$default$3() - Static method in class akka.remote.testconductor.ServerFSM
-
- startWith$default$3() - Static method in class akka.remote.transport.ProtocolStateActor
-
- startWith$default$3() - Static method in class akka.remote.transport.ThrottledAssociation
-
- 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.
- stash() - Static method in class akka.event.ActorClassificationUnsubscriber
-
- stash() - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- stash() - Static method in class akka.persistence.journal.PersistencePluginProxy
-
- stash(SystemMessage) - Static method in class akka.routing.RoutedActorCell
-
- stashCapacity(String, String) - Method in class akka.dispatch.Mailboxes
-
INTERNAL API: The capacity of the 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$
-
- stashInternally(Object) - Method in interface akka.persistence.Eventsourced
-
- 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$
-
- StashOverflowStrategy - Interface in akka.persistence
-
This defines how to handle the current received message which failed to stash, when the size of
Stash exceeding the capacity of Stash.
- StashOverflowStrategyConfigurator - Interface in akka.persistence
-
Implement this interface in order to configure the stashOverflowStrategy for
the internal stash of persistent actor.
- StashSupport - Interface in akka.actor
-
- 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.ddata.GCounter
-
- state() - Method in class akka.cluster.sharding.Shard
-
- State(Set<String>) - Constructor for class akka.cluster.sharding.Shard.State
-
- State() - Constructor for class akka.cluster.sharding.ShardCoordinator.Internal$.State
-
- state() - Method in class akka.cluster.sharding.ShardCoordinator
-
- 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() - Method in class akka.persistence.fsm.PersistentFSM.CurrentState
-
- State(S, D, Option<FiniteDuration>, Option<PersistentFSM.Reason>, List<Object>, Seq<E>, Function1<D, BoxedUnit>, boolean) - Constructor for class akka.persistence.fsm.PersistentFSM.State
-
- State(DecompressionTable<T>, DecompressionTable<T>, DecompressionTable<T>, Option<CompressionTable<T>>) - Constructor for class akka.remote.artery.compress.InboundCompression.State
-
- state() - Method in class akka.remote.artery.FlightRecorderReader.Log
-
- State(int, Deadline) - Constructor for class akka.remote.artery.RestartCounter.State
-
- State(Option<Subscriber<Object>>, long, akka.stream.actor.ActorPublisher.Internal.LifecycleState) - Constructor for class akka.stream.actor.ActorPublisherState.State
-
- State(Option<Subscription>, long, boolean) - Constructor for class akka.stream.actor.ActorSubscriberState.State
-
- state() - Method in interface akka.stream.FlowMonitor
-
- state() - Method in class akka.stream.stage.StatefulStage.Become
-
Deprecated.
- State() - Constructor for class akka.stream.stage.StatefulStage.State
-
Deprecated.
- State$() - Constructor for class akka.actor.FSM.State$
-
- State$() - Constructor for class akka.cluster.sharding.Shard.State$
-
- State$() - Constructor for class akka.persistence.fsm.PersistentFSM.State$
-
- State$() - Constructor for class akka.remote.artery.compress.InboundCompression.State$
-
- State$() - Constructor for class akka.remote.artery.RestartCounter.State$
-
- State$() - Constructor for class akka.stream.actor.ActorPublisherState.State$
-
- State$() - Constructor for class akka.stream.actor.ActorSubscriberState.State$
-
- STATE_FIELD_NUMBER - Static variable in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.LWWRegister
-
- stateChange(MessageFormats.PersistentStateChangeEvent) - Method in class akka.persistence.serialization.MessageSerializer
-
- stateChangeBuilder(PersistentFSM.StateChangeEvent) - Method in class akka.persistence.serialization.MessageSerializer
-
- StateChangeEvent(String, Option<FiniteDuration>) - Constructor for class akka.persistence.fsm.PersistentFSM.StateChangeEvent
-
- StateChangeEvent$() - Constructor for class akka.persistence.fsm.PersistentFSM.StateChangeEvent$
-
- stateData() - Static method in class akka.actor.AbstractFSM
-
- 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() - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- stateData() - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- stateData() - Static method in class akka.contrib.pattern.ReliableProxy
-
- stateData() - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- stateData() - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- stateData() - Method in class akka.persistence.fsm.PersistentFSM.Event
-
- stateData() - Method in class akka.persistence.fsm.PersistentFSM.LogEntry
-
- stateData() - Method in class akka.persistence.fsm.PersistentFSM.State
-
- stateData() - Method in class akka.persistence.fsm.PersistentFSM.StopEvent
-
- stateData() - Method in interface akka.persistence.fsm.PersistentFSMBase
-
- stateData() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- stateData() - Static method in class akka.remote.testconductor.ClientFSM
-
- stateData() - Static method in class akka.remote.testconductor.ServerFSM
-
- stateData() - Static method in class akka.remote.transport.ProtocolStateActor
-
- stateData() - Static method in class akka.remote.transport.ThrottledAssociation
-
- stateData() - Method in class akka.testkit.TestFSMRef
-
Get current state data of this FSM.
- StatefulMapConcat<In,Out> - Class in akka.stream.impl.fusing
-
INTERNAL API
- StatefulMapConcat(Function0<Function1<In, Iterable<Out>>>) - Constructor for class akka.stream.impl.fusing.StatefulMapConcat
-
- statefulMapConcat() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- statefulMapConcat(Function0<Function1<Out, Iterable<T>>>) - Static method in class akka.stream.impl.SubFlowImpl
-
- statefulMapConcat(Creator<Function<Out, Iterable<T>>>) - Method in class akka.stream.javadsl.Flow
-
Transform each input element into an Iterable
of output elements that is
then flattened into the output stream.
- statefulMapConcat(Creator<Function<Out, Iterable<T>>>) - Method in class akka.stream.javadsl.Source
-
Transform each input element into an Iterable
of output elements that is
then flattened into the output stream.
- statefulMapConcat(Creator<Function<Out, Iterable<T>>>) - Method in class akka.stream.javadsl.SubFlow
-
Transform each input element into an Iterable
of output elements that is
then flattened into the output stream.
- statefulMapConcat(Creator<Function<Out, Iterable<T>>>) - Method in class akka.stream.javadsl.SubSource
-
Transform each input element into an Iterable
of output elements that is
then flattened into the output stream.
- statefulMapConcat(Function0<Function1<Out, Iterable<T>>>) - Static method in class akka.stream.scaladsl.Flow
-
- statefulMapConcat(Function0<Function1<Out, Iterable<T>>>) - Method in interface akka.stream.scaladsl.FlowOps
-
Transform each input element into an Iterable
of output elements that is
then flattened into the output stream.
- statefulMapConcat(Function0<Function1<Out, Iterable<T>>>) - Static method in class akka.stream.scaladsl.Source
-
- StatefulStage<In,Out> - Class in akka.stream.stage
-
- StatefulStage() - Constructor for class akka.stream.stage.StatefulStage
-
Deprecated.
- StatefulStage$ - Class in akka.stream.stage
-
- StatefulStage$() - Constructor for class akka.stream.stage.StatefulStage$
-
Deprecated.
- StatefulStage.AndThen - Interface in akka.stream.stage
-
Deprecated.
- StatefulStage.Become - Class in akka.stream.stage
-
Deprecated.
- StatefulStage.Become$ - Class in akka.stream.stage
-
Deprecated.
- StatefulStage.Finish$ - Class in akka.stream.stage
-
Deprecated.
- StatefulStage.State - Class in akka.stream.stage
-
Deprecated.
Scala API
- StatefulStage.Stay$ - Class in akka.stream.stage
-
Deprecated.
- stateIdentifier() - Method in class akka.persistence.fsm.PersistentFSM.PersistentFSMSnapshot
-
- stateIdentifier() - Method in class akka.persistence.fsm.PersistentFSM.StateChangeEvent
-
- STATEIDENTIFIER_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentFSMSnapshot
-
- STATEIDENTIFIER_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
-
- StateInitialized() - Constructor for class akka.cluster.sharding.ShardCoordinator.Internal$.StateInitialized
-
- stateInitialized() - Method in class akka.cluster.sharding.ShardCoordinator
-
- stateName() - Static method in class akka.actor.AbstractFSM
-
- stateName() - Method in class akka.actor.FSM.LogEntry
-
- stateName() - Method in class akka.actor.FSM.State
-
- stateName() - Method in interface akka.actor.FSM
-
- stateName() - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- stateName() - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- stateName() - Static method in class akka.contrib.pattern.ReliableProxy
-
- stateName() - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- stateName() - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- stateName() - Method in class akka.persistence.fsm.PersistentFSM.LogEntry
-
- stateName() - Method in class akka.persistence.fsm.PersistentFSM.State
-
- stateName() - Method in interface akka.persistence.fsm.PersistentFSMBase
-
- stateName() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- stateName() - Static method in class akka.remote.testconductor.ClientFSM
-
- stateName() - Static method in class akka.remote.testconductor.ServerFSM
-
- stateName() - Static method in class akka.remote.transport.ProtocolStateActor
-
- stateName() - Static method in class akka.remote.transport.ThrottledAssociation
-
- stateName() - Method in class akka.testkit.TestFSMRef
-
Get current state name of this FSM.
- stateNames() - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- stateNames() - Method in interface akka.persistence.fsm.PersistentFSMBase
-
- stateReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.persistence.Eventsourced.State
-
- stateReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.persistence.PersistentView.State
-
Deprecated.
- statesMap() - Method in class akka.persistence.fsm.AbstractPersistentFSM
-
- statesMap() - Method in class akka.persistence.fsm.AbstractPersistentLoggingFSM
-
- statesMap() - Method in interface akka.persistence.fsm.PersistentFSM
-
Map from state identifier to state instance
- stateStoreMode() - Method in class akka.cluster.sharding.ClusterShardingSettings
-
- StateTimeout() - Method in class akka.actor.AbstractFSM
-
- StateTimeout() - Method in interface akka.actor.FSM
-
This case object is received in case of a state timeout.
- StateTimeout() - Method in class akka.cluster.singleton.ClusterSingletonManager
-
- StateTimeout() - Method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- StateTimeout() - Method in class akka.contrib.pattern.ReliableProxy
-
- StateTimeout() - Method in class akka.contrib.throttle.TimerBasedThrottler
-
- StateTimeout() - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- StateTimeout() - Method in interface akka.persistence.fsm.PersistentFSMBase
-
This case object is received in case of a state timeout.
- StateTimeout() - Method in class akka.remote.testconductor.BarrierCoordinator
-
- StateTimeout() - Method in class akka.remote.testconductor.ClientFSM
-
- StateTimeout() - Method in class akka.remote.testconductor.ServerFSM
-
- StateTimeout() - Method in class akka.remote.transport.ProtocolStateActor
-
- StateTimeout() - Method in class akka.remote.transport.ThrottledAssociation
-
- StateTimeout$() - Constructor for class akka.actor.FSM.StateTimeout$
-
- StateTimeout$() - Constructor for class akka.persistence.fsm.PersistentFSM.StateTimeout$
-
- 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() - Method in class akka.cluster.sharding.ShardRegion.ShardRegionStats
-
- stats() - Method in class akka.remote.artery.LruBoundedCache
-
- 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(Map<String, ByteString>, int, int) - Constructor for class akka.cluster.ddata.Replicator.Internal$.Status
-
- status() - Method in class akka.cluster.Member
-
- Status(Map<Address, Object>, boolean) - 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() - Method in class akka.stream.IOResult
-
- 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
-
- statusCount() - Method in class akka.cluster.ddata.Replicator
-
- statusFuture() - Method in class akka.remote.transport.netty.ClientHandler
-
- StatusManifest() - Method in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer
-
- statusOffset() - Method in class akka.typed.internal.ActorCell$
-
- statusOffset() - Static method in class akka.typed.internal.ActorCell
-
- 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
-
- statusTotChunks() - Method in class akka.cluster.ddata.Replicator
-
- stay() - Static method in class akka.actor.AbstractFSM
-
- stay() - Method in interface akka.actor.FSM
-
Produce "empty" transition descriptor.
- stay() - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- stay() - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- stay() - Static method in class akka.contrib.pattern.ReliableProxy
-
- stay() - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- stay() - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- stay() - Method in interface akka.persistence.fsm.PersistentFSMBase
-
Produce "empty" transition descriptor.
- stay() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- stay() - Static method in class akka.remote.testconductor.ClientFSM
-
- stay() - Static method in class akka.remote.testconductor.ServerFSM
-
- stay() - Static method in class akka.remote.transport.ProtocolStateActor
-
- stay() - Static method in class akka.remote.transport.ThrottledAssociation
-
- Stay$() - Constructor for class akka.stream.stage.StatefulStage.Stay$
-
Deprecated.
- stdDeviation() - Method in class akka.remote.HeartbeatHistory
-
- StdOutLogger$() - Constructor for class akka.event.Logging.StdOutLogger$
-
- StdoutLogLevel() - Method in class akka.actor.ActorSystem.Settings
-
- step() - Method in class akka.stream.impl.fusing.Sliding
-
- stop() - Static method in class akka.actor.AbstractFSM
-
- stop(FSM.Reason) - Static method in class akka.actor.AbstractFSM
-
- stop(FSM.Reason, D) - Static method in class akka.actor.AbstractFSM
-
- stop(ActorRef) - Static method in class akka.actor.ActorCell
-
- stop() - Static method in class akka.actor.ActorCell
-
- 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) - Static method in class akka.actor.ActorSystem
-
- stop(ActorRef) - Method in class akka.actor.ActorSystemImpl
-
- stop() - Method in interface akka.actor.Cell
-
Recursively terminate this actor and all its children.
- stop(Object) - Static method in class akka.actor.ContextualTypedActorFactory
-
- stop() - Static method in class akka.actor.DeadLetterActorRef
-
- 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.FunctionRef
-
- 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() - Static method in class akka.actor.Nobody
-
- 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() - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- stop(FSM.Reason) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- stop(FSM.Reason, D) - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- stop() - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- stop(FSM.Reason) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- stop(FSM.Reason, D) - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- stop() - Static method in class akka.contrib.pattern.ReliableProxy
-
- stop(FSM.Reason) - Static method in class akka.contrib.pattern.ReliableProxy
-
- stop(FSM.Reason, D) - Static method in class akka.contrib.pattern.ReliableProxy
-
- stop() - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- stop(FSM.Reason) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- stop(FSM.Reason, D) - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- 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() - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- stop(PersistentFSM.Reason) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- stop(PersistentFSM.Reason, D) - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- stop(PersistentFSM.Reason, FI.UnitApply2<S, D>) - Method in class akka.persistence.fsm.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.persistence.fsm.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.persistence.fsm.japi.pf.FSMStopBuilder
-
Add a case statement that matches on a reason type and a predicate.
- stop() - Method in interface akka.persistence.fsm.PersistentFSMBase
-
Produce change descriptor to stop this FSM actor with reason "Normal".
- stop(PersistentFSM.Reason) - Method in interface akka.persistence.fsm.PersistentFSMBase
-
Produce change descriptor to stop this FSM actor including specified reason.
- stop(PersistentFSM.Reason, D) - Method in interface akka.persistence.fsm.PersistentFSMBase
-
Produce change descriptor to stop this FSM actor including specified reason.
- stop() - Method in class akka.remote.artery.TaskRunner
-
- stop() - Method in class akka.remote.RemoteActorRef
-
- stop() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- stop(FSM.Reason) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- stop(FSM.Reason, D) - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- stop() - Static method in class akka.remote.testconductor.ClientFSM
-
- stop(FSM.Reason) - Static method in class akka.remote.testconductor.ClientFSM
-
- stop(FSM.Reason, D) - Static method in class akka.remote.testconductor.ClientFSM
-
- stop() - Static method in class akka.remote.testconductor.ServerFSM
-
- stop(FSM.Reason) - Static method in class akka.remote.testconductor.ServerFSM
-
- stop(FSM.Reason, D) - Static method in class akka.remote.testconductor.ServerFSM
-
- stop() - Static method in class akka.remote.transport.ProtocolStateActor
-
- stop(FSM.Reason) - Static method in class akka.remote.transport.ProtocolStateActor
-
- stop(FSM.Reason, D) - Static method in class akka.remote.transport.ProtocolStateActor
-
- stop() - Static method in class akka.remote.transport.ThrottledAssociation
-
- stop(FSM.Reason) - Static method in class akka.remote.transport.ThrottledAssociation
-
- stop(FSM.Reason, D) - Static method in class akka.remote.transport.ThrottledAssociation
-
- stop(ActorRef) - Static method in class akka.routing.RoutedActorCell
-
- stop() - Static method in class akka.routing.RoutedActorCell
-
- stop() - Method in class akka.stream.actor.ActorPublisher.Internal$.ErrorEmitted
-
- stop() - Method in class akka.stream.extra.Timed.TimedFlowContext
-
Deprecated.
- stop() - Method in class akka.stream.stage.GraphStageLogic.StageActor
-
- stop() - Method in class akka.stream.Supervision$
-
Java API: The stream will be completed with failure if application code for processing an element
throws an exception.
- stop() - Static method in class akka.stream.Supervision
-
Java API: The stream will be completed with failure if application code for processing an element
throws an exception.
- stop() - Static method in class akka.testkit.TestActorRef
-
- stop() - Static method in class akka.testkit.TestFSMRef
-
- 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.adapter.ActorContextAdapter
-
- stop(ActorRef<Nothing$>) - Method in class akka.typed.EffectfulActorContext
-
- stop(ActorRef<Nothing$>) - Method in class akka.typed.internal.ActorCell
-
- stop(ActorRef<Nothing$>) - Method in class akka.typed.StubbedActorContext
-
Do not actually stop the child inbox, only simulate the liveness check.
- Stop$() - Constructor for class akka.actor.SupervisorStrategy.Stop$
-
- Stop$() - Constructor for class akka.stream.Supervision.Stop$
-
- Stop$() - Constructor for class akka.typed.Failed.Stop$
-
- stopAll() - Method in class akka.typed.internal.ActorCell
-
- stopAll() - Method in interface akka.typed.internal.SupervisionMechanics
-
- stopCallback(Function1<T, BoxedUnit>) - Method in interface akka.stream.stage.CallbackWrapper
-
- 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$
-
- StopChildren$() - Constructor for class akka.stream.impl.StreamSupervisor.StopChildren$
-
- stopDefaultLoggers(ActorSystem) - Static method in class akka.event.EventStream
-
- stopDefaultLoggers(ActorSystem) - Method in interface akka.event.LoggingBus
-
- stopDefaultLoggers(ActorSystem<Nothing$>) - Method in class akka.typed.internal.EventStreamImpl
-
- StopEvent() - Method in class akka.actor.AbstractFSM
-
- StopEvent() - Method in interface akka.actor.FSM
-
- StopEvent(FSM.Reason, S, D) - Constructor for class akka.actor.FSM.StopEvent
-
- StopEvent() - Method in class akka.cluster.singleton.ClusterSingletonManager
-
- StopEvent() - Method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- StopEvent() - Method in class akka.contrib.pattern.ReliableProxy
-
- StopEvent() - Method in class akka.contrib.throttle.TimerBasedThrottler
-
- StopEvent() - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- StopEvent(PersistentFSM.Reason, S, D) - Constructor for class akka.persistence.fsm.PersistentFSM.StopEvent
-
- StopEvent() - Method in interface akka.persistence.fsm.PersistentFSMBase
-
- StopEvent() - Method in class akka.remote.testconductor.BarrierCoordinator
-
- StopEvent() - Method in class akka.remote.testconductor.ClientFSM
-
- StopEvent() - Method in class akka.remote.testconductor.ServerFSM
-
- StopEvent() - Method in class akka.remote.transport.ProtocolStateActor
-
- StopEvent() - Method in class akka.remote.transport.ThrottledAssociation
-
- StopEvent$() - Constructor for class akka.actor.FSM.StopEvent$
-
- StopEvent$() - Constructor for class akka.persistence.fsm.PersistentFSM.StopEvent$
-
- stopExploring() - Method in class akka.routing.DefaultOptimalSizeExploringResizer
-
Leave package accessible for testing purpose
- stopFunctionRefs() - Static method in class akka.actor.ActorCell
-
- stopFunctionRefs() - Method in interface akka.actor.dungeon.Children
-
- stopFunctionRefs() - Static method in class akka.routing.RoutedActorCell
-
- stopIfAllRouteesRemoved() - Static method in class akka.routing.ResizablePoolActor
-
- stopIfAllRouteesRemoved() - Method in class akka.routing.RouterActor
-
- StopImpliesFailure - Class in akka.pattern
-
- StopImpliesFailure() - Constructor for class akka.pattern.StopImpliesFailure
-
- StopImpliesFailure$ - Class in akka.pattern
-
- StopImpliesFailure$() - Constructor for class akka.pattern.StopImpliesFailure$
-
- stopMessage() - Method in class akka.cluster.sharding.ShardRegion.Passivate
-
- stopped() - Method in interface akka.remote.artery.InboundControlJunction.ControlMessageSubject
-
- Stopped(Function1<T, BoxedUnit>) - Constructor for class akka.stream.stage.CallbackWrapper.Stopped
-
- 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$
-
- StoppedChildren$() - Constructor for class akka.stream.impl.StreamSupervisor.StoppedChildren$
-
- StoppedReading(ActorRef) - Constructor for class akka.remote.EndpointWriter.StoppedReading
-
- StoppedReading$() - Constructor for class akka.remote.EndpointWriter.StoppedReading$
-
- Stopping() - Constructor for class akka.cluster.singleton.ClusterSingletonManager.Internal$.Stopping
-
- StoppingData(ActorRef) - Constructor for class akka.cluster.singleton.ClusterSingletonManager.Internal$.StoppingData
-
- stoppingDecider() - Method in class akka.stream.Supervision$
-
Scala API: Decider
that returns Stop
for all exceptions.
- stoppingDecider() - Static method in class akka.stream.Supervision
-
Scala API: Decider
that returns Stop
for all exceptions.
- 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
-
- StopQuarantinedAfterIdle() - Method in class akka.remote.artery.ArterySettings.Advanced$
-
- 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.persistence.fsm.PersistentFSM.State
-
- stopReason() - Method in class akka.remote.EndpointWriter
-
- stopRouterWhenAllRouteesRemoved() - Static method in class akka.cluster.metrics.AdaptiveLoadBalancingGroup
-
- stopRouterWhenAllRouteesRemoved() - Static method in class akka.cluster.metrics.AdaptiveLoadBalancingPool
-
- stopRouterWhenAllRouteesRemoved() - Static method in class akka.cluster.routing.AdaptiveLoadBalancingGroup
-
Deprecated.
- stopRouterWhenAllRouteesRemoved() - Static method in class akka.cluster.routing.AdaptiveLoadBalancingPool
-
Deprecated.
- stopRouterWhenAllRouteesRemoved() - Method in interface akka.cluster.routing.ClusterRouterConfigBase
-
- stopRouterWhenAllRouteesRemoved() - Static method in class akka.cluster.routing.ClusterRouterGroup
-
- stopRouterWhenAllRouteesRemoved() - Static method in class akka.cluster.routing.ClusterRouterPool
-
- stopRouterWhenAllRouteesRemoved() - Static method in class akka.remote.routing.RemoteRouterConfig
-
- stopRouterWhenAllRouteesRemoved() - Static method in class akka.routing.BalancingPool
-
- stopRouterWhenAllRouteesRemoved() - Static method in class akka.routing.BroadcastGroup
-
- stopRouterWhenAllRouteesRemoved() - Static method in class akka.routing.BroadcastPool
-
- stopRouterWhenAllRouteesRemoved() - Static method in class akka.routing.ConsistentHashingGroup
-
- stopRouterWhenAllRouteesRemoved() - Static method in class akka.routing.ConsistentHashingPool
-
- stopRouterWhenAllRouteesRemoved() - Static method in class akka.routing.FromConfig
-
- stopRouterWhenAllRouteesRemoved() - Static method in class akka.routing.NoRouter
-
- stopRouterWhenAllRouteesRemoved() - Method in interface akka.routing.Pool
-
- stopRouterWhenAllRouteesRemoved() - Static method in class akka.routing.RandomGroup
-
- stopRouterWhenAllRouteesRemoved() - Static method in class akka.routing.RandomPool
-
- stopRouterWhenAllRouteesRemoved() - Static method in class akka.routing.RoundRobinGroup
-
- stopRouterWhenAllRouteesRemoved() - Static method in class akka.routing.RoundRobinPool
-
- stopRouterWhenAllRouteesRemoved() - Method in interface akka.routing.RouterConfig
-
- stopRouterWhenAllRouteesRemoved() - Static method in class akka.routing.ScatterGatherFirstCompletedGroup
-
- stopRouterWhenAllRouteesRemoved() - Static method in class akka.routing.ScatterGatherFirstCompletedPool
-
- stopRouterWhenAllRouteesRemoved() - Static method in class akka.routing.SmallestMailboxPool
-
- stopRouterWhenAllRouteesRemoved() - Static method in class akka.routing.TailChoppingGroup
-
- stopRouterWhenAllRouteesRemoved() - Static method in class akka.routing.TailChoppingPool
-
- stopScheduler() - Method in class akka.actor.ActorSystemImpl
-
- stopSeedNodeProcess() - Method in class akka.cluster.ClusterCoreDaemon
-
- StopTimed(Timed.TimedFlowContext, Function1<FiniteDuration, BoxedUnit>) - Constructor for class akka.stream.extra.Timed.StopTimed
-
Deprecated.
- stopWith(TcpConnection.CloseInformation) - Method in class akka.io.TcpConnection
-
- stopWith(TcpConnection.CloseInformation) - Static method in class akka.io.TcpOutgoingConnection
-
- Store(String, ReplicatedData, Option<DurableStore.StoreReply>) - Constructor for class akka.cluster.ddata.DurableStore.Store
-
- store() - Method in interface akka.persistence.journal.AsyncWriteProxy
-
- store() - Method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- store(Writer, String) - Static method in class akka.remote.security.provider.AkkaProvider
-
- store(OutputStream, String) - Static method in class akka.remote.security.provider.AkkaProvider
-
- Store$() - Constructor for class akka.cluster.ddata.DurableStore.Store$
-
- store_$eq(Option<ActorRef>) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- StoreFailure(Key<A>, Option<Object>) - Constructor for class akka.cluster.ddata.Replicator.StoreFailure
-
- StoreFailure$() - Constructor for class akka.cluster.ddata.Replicator.StoreFailure$
-
- StoreReply(Object, Object, ActorRef) - Constructor for class akka.cluster.ddata.DurableStore.StoreReply
-
- StoreReply$() - Constructor for class akka.cluster.ddata.DurableStore.StoreReply$
-
- storeToXML(OutputStream, String) - Static method in class akka.remote.security.provider.AkkaProvider
-
- storeToXML(OutputStream, String, String) - Static method in class akka.remote.security.provider.AkkaProvider
-
- strategy() - Method in class akka.cluster.metrics.ClusterMetricsExtension
-
INTERNAL API
- strategy() - Method in class akka.stream.impl.fusing.Delay
-
- strategy() - Method in class akka.testkit.TestActor.Spawn
-
- StreamConverters - Class in akka.stream.javadsl
-
Converters for interacting with the blocking java.io
streams APIs and Java 8 Streams
- StreamConverters() - Constructor for class akka.stream.javadsl.StreamConverters
-
- StreamConverters - Class in akka.stream.scaladsl
-
Converters for interacting with the blocking java.io
streams APIs and Java 8 Streams
- StreamConverters() - Constructor for class akka.stream.scaladsl.StreamConverters
-
- StreamConverters$ - Class in akka.stream.javadsl
-
Converters for interacting with the blocking java.io
streams APIs and Java 8 Streams
- StreamConverters$() - Constructor for class akka.stream.javadsl.StreamConverters$
-
- StreamConverters$ - Class in akka.stream.scaladsl
-
Converters for interacting with the blocking java.io
streams APIs and Java 8 Streams
- StreamConverters$() - Constructor for class akka.stream.scaladsl.StreamConverters$
-
- StreamingCache() - Method in class akka.camel.CamelSettings
-
enables or disables streamingCache on the Camel Context
- streamKillSwitch() - Method in class akka.remote.artery.Association.OutboundStreamMatValues
-
- StreamLayout - Class in akka.stream.impl
-
INTERNAL API
- StreamLayout() - Constructor for class akka.stream.impl.StreamLayout
-
- StreamLayout$ - Class in akka.stream.impl
-
INTERNAL API
- StreamLayout$() - Constructor for class akka.stream.impl.StreamLayout$
-
- StreamLayout.Atomic - Class in akka.stream.impl
-
- StreamLayout.Atomic$ - Class in akka.stream.impl
-
- StreamLayout.AtomicModule - Class in akka.stream.impl
-
This is the only extension point for the sealed type hierarchy: composition
(i.e.
- StreamLayout.Combine - Class in akka.stream.impl
-
- StreamLayout.Combine$ - Class in akka.stream.impl
-
- StreamLayout.CompositeModule - Class in akka.stream.impl
-
- StreamLayout.CompositeModule$ - Class in akka.stream.impl
-
- StreamLayout.CopiedModule - Class in akka.stream.impl
-
- StreamLayout.CopiedModule$ - Class in akka.stream.impl
-
- StreamLayout.EmptyModule$ - Class in akka.stream.impl
-
- StreamLayout.FusedModule - Class in akka.stream.impl
-
- StreamLayout.FusedModule$ - Class in akka.stream.impl
-
- StreamLayout.IgnorableMatValComp$ - Class in akka.stream.impl
-
- StreamLayout.Ignore$ - Class in akka.stream.impl
-
- StreamLayout.MaterializedValueNode - Interface in akka.stream.impl
-
- StreamLayout.Module - Interface in akka.stream.impl
-
- StreamLayout.StructuralInfoModule - Class in akka.stream.impl
-
INTERNAL API
- StreamLayout.StructuralInfoModule$ - Class in akka.stream.impl
-
- StreamLayout.Transform - Class in akka.stream.impl
-
- StreamLayout.Transform$ - Class in akka.stream.impl
-
- StreamLimitReachedException - Exception in akka.stream
-
- StreamLimitReachedException(long) - Constructor for exception akka.stream.StreamLimitReachedException
-
- streamsCompleted() - Method in class akka.remote.artery.Association
-
Exposed for orderly shutdown purposes, can not be trusted except for during shutdown as streams may restart.
- StreamSubscriptionTimeoutSettings - Class in akka.stream
-
- StreamSubscriptionTimeoutSettings(StreamSubscriptionTimeoutTerminationMode, FiniteDuration) - Constructor for class akka.stream.StreamSubscriptionTimeoutSettings
-
- StreamSubscriptionTimeoutSettings$ - Class in akka.stream
-
- StreamSubscriptionTimeoutSettings$() - Constructor for class akka.stream.StreamSubscriptionTimeoutSettings$
-
- StreamSubscriptionTimeoutSupport - Interface in akka.stream.impl
-
INTERNAL API
Provides support methods to create Publishers and Subscribers which time-out gracefully,
and are canceled subscribing an CancellingSubscriber
to the publisher, or by calling onError
on the timed-out subscriber.
- StreamSubscriptionTimeoutSupport$ - Class in akka.stream.impl
-
- StreamSubscriptionTimeoutSupport$() - Constructor for class akka.stream.impl.StreamSubscriptionTimeoutSupport$
-
- StreamSubscriptionTimeoutSupport.CancelingSubscriber$ - Class in akka.stream.impl
-
A subscriber who calls cancel
directly from onSubscribe
and ignores all other callbacks.
- StreamSubscriptionTimeoutSupport.NoopSubscriptionTimeout$ - Class in akka.stream.impl
-
INTERNAL API
- StreamSubscriptionTimeoutTerminationMode - Class in akka.stream
-
This mode describes what shall happen when the subscription timeout expires for
substream Publishers created by operations like prefixAndTail
.
- StreamSubscriptionTimeoutTerminationMode() - Constructor for class akka.stream.StreamSubscriptionTimeoutTerminationMode
-
- StreamSubscriptionTimeoutTerminationMode$ - Class in akka.stream
-
- StreamSubscriptionTimeoutTerminationMode$() - Constructor for class akka.stream.StreamSubscriptionTimeoutTerminationMode$
-
- StreamSubscriptionTimeoutTerminationMode.CancelTermination$ - Class in akka.stream
-
- StreamSubscriptionTimeoutTerminationMode.NoopTermination$ - Class in akka.stream
-
- StreamSubscriptionTimeoutTerminationMode.WarnTermination$ - Class in akka.stream
-
- StreamSupervisor - Class in akka.stream.impl
-
- StreamSupervisor(ActorMaterializerSettings, AtomicBoolean) - Constructor for class akka.stream.impl.StreamSupervisor
-
- StreamSupervisor$ - Class in akka.stream.impl
-
INTERNAL API
- StreamSupervisor$() - Constructor for class akka.stream.impl.StreamSupervisor$
-
- StreamSupervisor.Children - Class in akka.stream.impl
-
Testing purpose
- StreamSupervisor.Children$ - Class in akka.stream.impl
-
- StreamSupervisor.GetChildren$ - Class in akka.stream.impl
-
Testing purpose
- StreamSupervisor.Materialize - Class in akka.stream.impl
-
- StreamSupervisor.Materialize$ - Class in akka.stream.impl
-
- StreamSupervisor.PrintDebugDump$ - Class in akka.stream.impl
-
Testing purpose
- StreamSupervisor.StopChildren$ - Class in akka.stream.impl
-
Testing purpose
- StreamSupervisor.StoppedChildren$ - Class in akka.stream.impl
-
Testing purpose
- StreamTcpException - Exception in akka.stream
-
- StreamTcpException(String) - Constructor for exception akka.stream.StreamTcpException
-
- StreamTestKit - Class in akka.stream.testkit
-
INTERNAL API
- StreamTestKit() - Constructor for class akka.stream.testkit.StreamTestKit
-
- StreamTestKit$ - Class in akka.stream.testkit
-
INTERNAL API
- StreamTestKit$() - Constructor for class akka.stream.testkit.StreamTestKit$
-
- StreamTestKit.CompletedSubscription<T> - Class in akka.stream.testkit
-
- StreamTestKit.CompletedSubscription$ - Class in akka.stream.testkit
-
- StreamTestKit.FailedSubscription<T> - Class in akka.stream.testkit
-
- StreamTestKit.FailedSubscription$ - Class in akka.stream.testkit
-
- StreamTestKit.ProbeSink<T> - Class in akka.stream.testkit
-
- StreamTestKit.ProbeSource<T> - Class in akka.stream.testkit
-
- StreamTestKit.PublisherProbeSubscription<I> - Class in akka.stream.testkit
-
- StreamTestKit.PublisherProbeSubscription$ - Class in akka.stream.testkit
-
- STRINGELEMENTS_FIELD_NUMBER - Static variable in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.GSet
-
- STRINGELEMENTS_FIELD_NUMBER - Static variable in class akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSet
-
- 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$
-
- stringPrefix() - Method in class akka.util.ByteString
-
- stringPrefix() - Static method in class akka.util.CompactByteString
-
- stringPropertyNames() - Static method in class akka.remote.security.provider.AkkaProvider
-
- StringSerializer - Class in akka.remote.serialization
-
- StringSerializer(ExtendedActorSystem) - Constructor for class akka.remote.serialization.StringSerializer
-
- StringValueFieldOffset() - Method in class akka.remote.artery.EnvelopeBuffer$
-
- StringValueFieldOffset() - Static method in class akka.remote.artery.EnvelopeBuffer
-
- structuralInfo(Graph<S, M>, Attributes) - Method in class akka.stream.Fusing$
-
Return the StructuralInfo for this Graph without any fusing
- structuralInfo(Graph<S, M>, Attributes) - Static method in class akka.stream.Fusing
-
Return the StructuralInfo for this Graph without any fusing
- structuralInfo(Graph<S, M>, Attributes) - Method in class akka.stream.impl.fusing.Fusing$
-
- structuralInfo(Graph<S, M>, Attributes) - Static method in class akka.stream.impl.fusing.Fusing
-
- StructuralInfoModule(Set<StreamLayout.Module>, Shape, Map<OutPort, InPort>, Map<InPort, OutPort>, Map<InPort, StreamLayout.Module>, Map<OutPort, StreamLayout.Module>, List<Tuple2<StreamLayout.Module, StreamLayout.MaterializedValueNode>>, StreamLayout.MaterializedValueNode, Attributes) - Constructor for class akka.stream.impl.StreamLayout.StructuralInfoModule
-
- StructuralInfoModule$() - Constructor for class akka.stream.impl.StreamLayout.StructuralInfoModule$
-
- structure() - Method in class akka.remote.artery.FlightRecorderReader
-
- Structure(Instant, FlightRecorderReader.RollingLog, FlightRecorderReader.RollingLog, FlightRecorderReader.RollingLog) - Constructor for class akka.remote.artery.FlightRecorderReader.Structure
-
- Structure$() - Constructor for class akka.remote.artery.FlightRecorderReader.Structure$
-
- 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, int, ActorSystem<Nothing$>) - Constructor for class akka.typed.StubbedActorContext
-
- styleName() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- styleName() - Static method in class akka.persistence.journal.JournalSpec
-
- styleName() - Method in class akka.persistence.PluginSpec
-
- styleName() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- 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
-
- subFlow() - Method in class akka.stream.impl.SubFlowImpl
-
- SubFlow<In,Out,Mat> - Class in akka.stream.javadsl
-
A “stream of streams” sub-flow of data elements, e.g.
- SubFlow(SubFlow<Out, Mat, Flow<In, Object, Mat>, Sink<In, Mat>>) - Constructor for class akka.stream.javadsl.SubFlow
-
- SubFlow<Out,Mat,F,C> - Interface in akka.stream.scaladsl
-
A “stream of streams” sub-flow of data elements, e.g.
- SubFlowImpl<In,Out,Mat,F,C> - Class in akka.stream.impl
-
- SubFlowImpl(Flow<In, Out, NotUsed>, SubFlowImpl.MergeBack<In, F>, Function1<Sink<In, NotUsed>, C>) - Constructor for class akka.stream.impl.SubFlowImpl
-
- SubFlowImpl$ - Class in akka.stream.impl
-
- SubFlowImpl$() - Constructor for class akka.stream.impl.SubFlowImpl$
-
- SubFlowImpl.MergeBack<In,F> - Interface in akka.stream.impl
-
- SubFusingActorMaterializerImpl - Class in akka.stream.impl
-
- SubFusingActorMaterializerImpl(ExtendedActorMaterializer, Function1<GraphInterpreterShell, ActorRef>) - Constructor for class akka.stream.impl.SubFusingActorMaterializerImpl
-
- subFusingMaterializer() - Method in class akka.stream.impl.fusing.GraphInterpreter
-
- subFusingMaterializer() - Method in class akka.stream.stage.GraphStageLogic
-
An
Materializer
that may run fusable parts of the graphs
that it materializes within the same actor as the current GraphStage (if
fusing is available).
- subFusingMaterializerImpl() - Method in class akka.stream.impl.fusing.ActorGraphInterpreter
-
- SubInput(ActorRef, int) - Constructor for class akka.stream.impl.FanIn.SubInput
-
- SubInput$() - Constructor for class akka.stream.impl.FanIn.SubInput$
-
- subject() - Method in class akka.cluster.Reachability.Record
-
- SUBJECTREACHABILITY_FIELD_NUMBER - Static variable in class akka.cluster.protobuf.msg.ClusterMessages.ObserverReachability
-
- subjectRegistrationFunction() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- subjectRegistrationFunction() - Static method in class akka.persistence.journal.JournalSpec
-
- subjectRegistrationFunction() - Method in class akka.persistence.PluginSpec
-
- subjectRegistrationFunction() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- subjectWithAfterWordRegistrationFunction() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- subjectWithAfterWordRegistrationFunction() - Static method in class akka.persistence.journal.JournalSpec
-
- subjectWithAfterWordRegistrationFunction() - Method in class akka.persistence.PluginSpec
-
- subjectWithAfterWordRegistrationFunction() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- 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
-
- subModules() - Static method in class akka.stream.impl.fusing.GraphModule
-
- subModules() - Static method in class akka.stream.impl.fusing.GraphStageModule
-
- subModules() - Static method in class akka.stream.impl.io.TlsModule
-
- subModules() - Static method in class akka.stream.impl.ProcessorModule
-
- subModules() - Method in class akka.stream.impl.StreamLayout.AtomicModule
-
- subModules() - Method in class akka.stream.impl.StreamLayout.CompositeModule
-
- subModules() - Method in class akka.stream.impl.StreamLayout.CopiedModule
-
- subModules() - Method in class akka.stream.impl.StreamLayout.EmptyModule$
-
- subModules() - Method in class akka.stream.impl.StreamLayout.FusedModule
-
- subModules() - Method in interface akka.stream.impl.StreamLayout.Module
-
- subModules() - Method in class akka.stream.impl.StreamLayout.StructuralInfoModule
-
- subreceive() - Method in class akka.stream.impl.BatchingInputBuffer
-
- subreceive() - Method in class akka.stream.impl.FanIn.InputBunch
-
- subreceive() - Method in class akka.stream.impl.FanOut.OutputBunch
-
- subreceive() - Method in class akka.stream.impl.FanoutOutputs
-
- subreceive() - Method in interface akka.stream.impl.Inputs
-
- subreceive() - Method in interface akka.stream.impl.Outputs
-
- subreceive() - Method in class akka.stream.impl.SimpleOutputs
-
- SubReceive - Class in akka.stream.impl
-
INTERNAL API
- SubReceive(PartialFunction<Object, BoxedUnit>) - Constructor for class akka.stream.impl.SubReceive
-
- 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(Key<A>, ActorRef) - Constructor for class akka.cluster.ddata.Replicator.Subscribe
-
- 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
-
Deprecated.
- 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
-
Deprecated.
- 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>) - Static method in class akka.persistence.journal.JournalPerfSpec
-
- subscribe(ActorRef, ClassTag<T>) - Static method in class akka.persistence.journal.JournalSpec
-
- subscribe(ActorRef, ClassTag<T>) - Method in class akka.persistence.PluginSpec
-
- subscribe(ActorRef, ClassTag<T>) - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- Subscribe(Subscriber<Object>) - Constructor for class akka.stream.actor.ActorPublisher.Internal$.Subscribe
-
- subscribe(Subscriber<? super T>) - Method in class akka.stream.actor.ActorPublisherImpl
-
- subscribe(Subscriber<? super T>) - Static method in class akka.stream.impl.ActorProcessor
-
- subscribe(Subscriber<? super T>) - Method in class akka.stream.impl.ActorPublisher
-
- subscribe(Subscriber<?>) - Method in class akka.stream.impl.EmptyPublisher$
-
- subscribe(Subscriber<?>) - Static method in class akka.stream.impl.EmptyPublisher
-
- subscribe(Subscriber<?>) - Method in class akka.stream.impl.ErrorPublisher
-
- subscribe(Subscriber<? super T>) - Method in class akka.stream.impl.MaybePublisher
-
- subscribe(Subscriber<?>) - Method in class akka.stream.impl.RejectAdditionalSubscribers$
-
- subscribe(Subscriber<?>) - Static method in class akka.stream.impl.RejectAdditionalSubscribers
-
- subscribe(Subscriber<? super T>) - Method in class akka.stream.impl.VirtualProcessor
-
- subscribe(Subscriber<? super T>) - Method in class akka.stream.impl.VirtualPublisher
-
- subscribe(Subscriber<? super I>) - Method in class akka.stream.testkit.TestPublisher.ManualProbe
-
Subscribes a given Subscriber
to this probe publisher.
- Subscribe(Subscription) - Constructor for class akka.stream.testkit.TestPublisher.Subscribe
-
- subscribe(ActorRef<T>, Class<T>) - Method in class akka.typed.adapter.EventStreamAdapter
-
- subscribe(ActorRef<T>, Class<T>) - Method in interface akka.typed.EventStream
-
Attempts to register the subscriber to the specified Classifier
- subscribe(ActorRef<T>, Class<T>) - Method in class akka.typed.internal.EventStreamImpl
-
- Subscribe$() - Constructor for class akka.cluster.ddata.Replicator.Subscribe$
-
- Subscribe$() - Constructor for class akka.cluster.InternalClusterAction.Subscribe$
-
- Subscribe$() - Constructor for class akka.cluster.pubsub.DistributedPubSubMediator.Subscribe$
-
- Subscribe$() - Constructor for class akka.stream.testkit.TestPublisher.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
-
- subscribeAddressTerminated() - Method in interface akka.typed.internal.DeathWatch
-
- SubscribeAllPersistenceIds$() - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal.SubscribeAllPersistenceIds$
-
- SubscribeClusterClients - Class in akka.cluster.client
-
- SubscribeClusterClients() - Constructor for class akka.cluster.client.SubscribeClusterClients
-
- SubscribeClusterClients$ - Class in akka.cluster.client
-
Subscribe to a cluster receptionist's client interactions where
it is guaranteed that a sender receives the initial state
of contact points prior to any events in relation to them
changing.
- SubscribeClusterClients$() - Constructor for class akka.cluster.client.SubscribeClusterClients$
-
- SubscribeContactPoints - Class in akka.cluster.client
-
- SubscribeContactPoints() - Constructor for class akka.cluster.client.SubscribeContactPoints
-
- SubscribeContactPoints$ - Class in akka.cluster.client
-
Subscribe to a cluster client's contact point changes where
it is guaranteed that a sender receives the initial state
of contact points prior to any events in relation to them
changing.
- SubscribeContactPoints$() - Constructor for class akka.cluster.client.SubscribeContactPoints$
-
- Subscribed(DistributedPubSubMediator.SubscribeAck, ActorRef) - Constructor for class akka.cluster.pubsub.DistributedPubSubMediator.Internal$.Subscribed
-
- SubscribeManifest() - Method in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer
-
- subscribePending() - Method in class akka.stream.impl.fusing.ActorGraphInterpreter.ActorOutputBoundary
-
- SubscribePending(GraphInterpreterShell, int) - Constructor for class akka.stream.impl.fusing.ActorGraphInterpreter.SubscribePending
-
- SubscribePending - Class in akka.stream.impl
-
INTERNAL API
- SubscribePending() - Constructor for class akka.stream.impl.SubscribePending
-
- SubscribePending$() - Constructor for class akka.stream.impl.fusing.ActorGraphInterpreter.SubscribePending$
-
- SubscribePending$ - Class in akka.stream.impl
-
INTERNAL API
- SubscribePending$() - Constructor for class akka.stream.impl.SubscribePending$
-
- SubscribePersistenceId(String) - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal.SubscribePersistenceId
-
- SubscribePersistenceId$() - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal.SubscribePersistenceId$
-
- subscriber() - Method in class akka.cluster.ddata.Replicator.Subscribe
-
- subscriber() - Method in class akka.cluster.ddata.Replicator.Unsubscribe
-
- 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
-
- subscriber() - Method in class akka.stream.actor.ActorPublisher.Internal$.Subscribe
-
- subscriber() - Method in class akka.stream.actor.ActorPublisherState.State
-
- subscriber() - Method in class akka.stream.impl.ActorSubscription
-
- subscriber() - Method in class akka.stream.impl.SimpleOutputs
-
- subscriber() - Method in interface akka.stream.impl.SubscriptionWithCursor
-
- subscriber() - Method in class akka.stream.impl.VirtualProcessor.Both
-
- subscriber() - Method in class akka.stream.impl.VirtualProcessor.Inert$
-
- subscriber() - Method in class akka.stream.testkit.StreamTestKit.CompletedSubscription
-
- subscriber() - Method in class akka.stream.testkit.StreamTestKit.FailedSubscription
-
- subscriber() - Method in class akka.stream.testkit.StreamTestKit.PublisherProbeSubscription
-
- subscriberClosedException() - Method in class akka.stream.impl.io.InputStreamAdapter
-
- SubscriberManagement<T> - Interface in akka.stream.impl
-
INTERNAL API
- SubscriberManagement$ - Class in akka.stream.impl
-
INTERNAL API
- SubscriberManagement$() - Constructor for class akka.stream.impl.SubscriberManagement$
-
- SubscriberManagement.Completed$ - Class in akka.stream.impl
-
- SubscriberManagement.EndOfStream - Interface in akka.stream.impl
-
- SubscriberManagement.ErrorCompleted - Class in akka.stream.impl
-
- SubscriberManagement.ErrorCompleted$ - Class in akka.stream.impl
-
- SubscriberManagement.NotReached$ - Class in akka.stream.impl
-
- subscriberMustNotBeNullException() - Method in class akka.stream.impl.ReactiveStreamsCompliance$
-
- subscriberMustNotBeNullException() - Static method in class akka.stream.impl.ReactiveStreamsCompliance
-
- SubscriberMustNotBeNullMsg() - Method in class akka.stream.impl.ReactiveStreamsCompliance$
-
- SubscriberMustNotBeNullMsg() - Static method in class akka.stream.impl.ReactiveStreamsCompliance
-
- subscribers() - Method in class akka.cluster.client.ClusterClient
-
- subscribers() - Method in class akka.cluster.client.ClusterReceptionist
-
- subscribers() - Method in class akka.cluster.ddata.Replicator
-
- subscribers() - Method in class akka.cluster.pubsub.DistributedPubSubMediator.Internal$.Group
-
- subscribers() - Method in class akka.cluster.pubsub.DistributedPubSubMediator.Internal$.Topic
-
- subscribers() - Method in interface akka.cluster.pubsub.DistributedPubSubMediator.Internal$.TopicLike
-
- subscribers() - Method in interface akka.event.LookupClassification
-
- subscribers() - Method in interface akka.event.ScanningClassification
-
- subscriberSink() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- SubscriberSink<In> - Class in akka.stream.impl
-
INTERNAL API
Attaches a subscriber to this stream.
- SubscriberSink(Subscriber<In>, Attributes, SinkShape<In>) - Constructor for class akka.stream.impl.SubscriberSink
-
- subscriberSource() - Method in class akka.stream.impl.Stages.DefaultAttributes$
-
- SubscriberSource<Out> - Class in akka.stream.impl
-
INTERNAL API
Holds a Subscriber
representing the input side of the flow.
- SubscriberSource(Attributes, SourceShape<Out>) - Constructor for class akka.stream.impl.SubscriberSource
-
- SubscribeTag(String) - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal.SubscribeTag
-
- SubscribeTag$() - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal.SubscribeTag$
-
- SubscribeTransitionCallBack(ActorRef) - Constructor for class akka.actor.FSM.SubscribeTransitionCallBack
-
- SubscribeTransitionCallBack(ActorRef) - Constructor for class akka.persistence.fsm.PersistentFSM.SubscribeTransitionCallBack
-
- SubscribeTransitionCallBack$() - Constructor for class akka.actor.FSM.SubscribeTransitionCallBack$
-
- SubscribeTransitionCallBack$() - Constructor for class akka.persistence.fsm.PersistentFSM.SubscribeTransitionCallBack$
-
- subscription() - Method in class akka.stream.actor.ActorSubscriber.OnSubscribe
-
- subscription() - Method in class akka.stream.actor.ActorSubscriberState.State
-
- subscription() - Method in class akka.stream.impl.Cancel
-
- subscription() - Method in class akka.stream.impl.FanIn.OnSubscribe
-
- subscription() - Method in class akka.stream.impl.fusing.ActorGraphInterpreter.OnSubscribe
-
- subscription() - Method in class akka.stream.impl.RequestMore
-
- subscription() - Method in class akka.stream.testkit.TestPublisher.CancelSubscription
-
- subscription() - Method in class akka.stream.testkit.TestPublisher.RequestMore
-
- subscription() - Method in class akka.stream.testkit.TestPublisher.Subscribe
-
- subscription() - Method in class akka.stream.testkit.TestSubscriber.OnSubscribe
-
- SubscriptionInitialStateMode() - Constructor for class akka.cluster.ClusterEvent.SubscriptionInitialStateMode
-
- subscriptionKeys() - Method in class akka.cluster.ddata.Replicator
-
- subscriptionMustNotBeNullException() - Method in class akka.stream.impl.ReactiveStreamsCompliance$
-
- subscriptionMustNotBeNullException() - Static method in class akka.stream.impl.ReactiveStreamsCompliance
-
- SubscriptionMustNotBeNullMsg() - Method in class akka.stream.impl.ReactiveStreamsCompliance$
-
- SubscriptionMustNotBeNullMsg() - Static method in class akka.stream.impl.ReactiveStreamsCompliance
-
- subscriptionTimedOut(Publisher<?>) - Method in interface akka.stream.impl.StreamSubscriptionTimeoutSupport
-
Called by the actor when a subscription has timed out.
- subscriptionTimeout() - Static method in class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher
-
- subscriptionTimeout() - Static method in class akka.stream.actor.AbstractActorPublisher
-
- subscriptionTimeout() - Method in interface akka.stream.actor.ActorPublisher
-
Subscription timeout after which this actor will become Canceled and reject any incoming "late" subscriber.
- subscriptionTimeout() - Static method in class akka.stream.actor.UntypedActorPublisher
-
- subscriptionTimeout() - Static method in class akka.stream.impl.ActorRefSourceActor
-
- subscriptionTimeout() - Static method in class akka.stream.impl.io.FilePublisher
-
- subscriptionTimeout() - Static method in class akka.stream.impl.io.InputStreamPublisher
-
- SubscriptionTimeoutExceeded() - Constructor for class akka.stream.actor.ActorPublisherMessage.SubscriptionTimeoutExceeded
-
- SubscriptionTimeoutExceeded$() - Constructor for class akka.stream.actor.ActorPublisherMessage.SubscriptionTimeoutExceeded$
-
- subscriptionTimeoutExceededInstance() - Method in class akka.stream.actor.ActorPublisherMessage$
-
Java API: get the singleton instance of the SubscriptionTimeoutExceeded
message
- subscriptionTimeoutExceededInstance() - Static method in class akka.stream.actor.ActorPublisherMessage
-
Java API: get the singleton instance of the SubscriptionTimeoutExceeded
message
- SubscriptionTimeoutException - Exception in akka.stream.impl
-
INTERNAL API
- SubscriptionTimeoutException(String) - Constructor for exception akka.stream.impl.SubscriptionTimeoutException
-
- subscriptionTimeoutSettings() - Method in class akka.stream.ActorMaterializerSettings
-
- subscriptionTimeoutSettings() - Method in interface akka.stream.impl.StreamSubscriptionTimeoutSupport
-
Default settings for subscription timeouts.
- SubscriptionWithCursor<T> - Interface in akka.stream.impl
-
INTERNAL API
- SubSink<T> - Class in akka.stream.impl.fusing
-
INTERNAL API
- SubSink(String, Function1<ActorSubscriberMessage, BoxedUnit>) - Constructor for class akka.stream.impl.fusing.SubSink
-
- SubSink$ - Class in akka.stream.impl.fusing
-
INTERNAL API
- SubSink$() - Constructor for class akka.stream.impl.fusing.SubSink$
-
- SubSink.Cancel$ - Class in akka.stream.impl.fusing
-
- SubSink.CancelScheduledBeforeMaterialization$ - Class in akka.stream.impl.fusing
-
A Cancel command was scheduled before materialization
- SubSink.Command - Interface in akka.stream.impl.fusing
-
Steady state: sink has been materialized, commands can be delivered through the callback
- SubSink.CommandScheduledBeforeMaterialization - Class in akka.stream.impl.fusing
-
A command was scheduled before materialization
- SubSink.RequestOne$ - Class in akka.stream.impl.fusing
-
- SubSink.RequestOneScheduledBeforeMaterialization$ - Class in akka.stream.impl.fusing
-
A RequestOne command was scheduled before materialization
- SubSink.State - Interface in akka.stream.impl.fusing
-
- SubSink.Uninitialized$ - Class in akka.stream.impl.fusing
-
Not yet materialized and no command has been scheduled
- SubSinkInlet(String) - Constructor for class akka.stream.stage.GraphStageLogic.SubSinkInlet
-
- SubSource<T> - Class in akka.stream.impl.fusing
-
INTERNAL API
- SubSource(String, AsyncCallback<SubSink.Command>) - Constructor for class akka.stream.impl.fusing.SubSource
-
- SubSource<Out,Mat> - Class in akka.stream.javadsl
-
A “stream of streams” sub-flow of data elements, e.g.
- SubSource(SubFlow<Out, Mat, Source<Object, Mat>, RunnableGraph<Mat>>) - Constructor for class akka.stream.javadsl.SubSource
-
- SubSource$ - Class in akka.stream.impl.fusing
-
- SubSource$() - Constructor for class akka.stream.impl.fusing.SubSource$
-
- SubSourceOutlet(String) - Constructor for class akka.stream.stage.GraphStageLogic.SubSourceOutlet
-
- SubstreamCancel(int) - Constructor for class akka.stream.impl.FanOut.SubstreamCancel
-
- SubstreamCancel$() - Constructor for class akka.stream.impl.FanOut.SubstreamCancel$
-
- SubstreamCancelStrategies - Class in akka.stream
-
- SubstreamCancelStrategies() - Constructor for class akka.stream.SubstreamCancelStrategies
-
- SubstreamCancelStrategies$ - Class in akka.stream
-
- SubstreamCancelStrategies$() - Constructor for class akka.stream.SubstreamCancelStrategies$
-
- SubstreamCancelStrategies.Drain$ - Class in akka.stream
-
INTERNAL API
- SubstreamCancelStrategies.Propagate$ - Class in akka.stream
-
INTERNAL API
- substreamCancelStrategy() - Method in class akka.stream.impl.fusing.Split
-
- SubstreamCancelStrategy - Class in akka.stream
-
Represents a strategy that decides how to deal with substream events.
- SubstreamCancelStrategy() - Constructor for class akka.stream.SubstreamCancelStrategy
-
- SubstreamCancelStrategy$ - Class in akka.stream
-
- SubstreamCancelStrategy$() - Constructor for class akka.stream.SubstreamCancelStrategy$
-
- SubstreamRequestMore(int, long) - Constructor for class akka.stream.impl.FanOut.SubstreamRequestMore
-
- SubstreamRequestMore$() - Constructor for class akka.stream.impl.FanOut.SubstreamRequestMore$
-
- SubstreamSubscribePending(int) - Constructor for class akka.stream.impl.FanOut.SubstreamSubscribePending
-
- SubstreamSubscribePending$() - Constructor for class akka.stream.impl.FanOut.SubstreamSubscribePending$
-
- SubstreamSubscription(ActorRef, int) - Constructor for class akka.stream.impl.FanOut.SubstreamSubscription
-
- subtractDots(VersionVector, VersionVector) - Method in class akka.cluster.ddata.ORSet$
-
INTERNAL API
Subtract the vvector
from the dot
.
- subtractDots(VersionVector, VersionVector) - Static method in class akka.cluster.ddata.ORSet
-
INTERNAL API
Subtract the vvector
from the dot
.
- succeed() - Method in class akka.pattern.CircuitBreaker
-
Mark a successful call through CircuitBreaker.
- succeed() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- succeed() - Static method in class akka.persistence.journal.JournalSpec
-
- succeed() - Method in class akka.persistence.PluginSpec
-
- succeed() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- 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
- successMsg() - Method in class akka.cluster.ddata.DurableStore.StoreReply
-
- successUnit() - Method in class akka.persistence.journal.AsyncWriteJournal$
-
- suiteId() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- suiteId() - Static method in class akka.persistence.journal.JournalSpec
-
- suiteId() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- suiteName() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- suiteName() - Static method in class akka.persistence.journal.JournalSpec
-
- suiteName() - Static method in class akka.persistence.snapshot.SnapshotStoreSpec
-
- sum(Numeric<B>) - Static method in class akka.util.ByteIterator
-
- sum(Numeric<B>) - Static method in class akka.util.ByteString
-
- sum(Numeric<B>) - Static method in class akka.util.CompactByteString
-
- 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$
-
- SUPERVISE_VALUE - Static variable in enum akka.remote.SystemMessageFormats.SystemMessage.Type
-
SUPERVISE = 5;
- SUPERVISEDATA_FIELD_NUMBER - Static variable in class akka.remote.SystemMessageFormats.SystemMessage
-
- SupervisedGraphStageLogic - Class in akka.stream.impl.fusing
-
INTERNAL API
- SupervisedGraphStageLogic(Attributes, Shape) - Constructor for class akka.stream.impl.fusing.SupervisedGraphStageLogic
-
- superviseWith(SupervisorStrategy) - Method in interface akka.actor.dsl.Creators.Act
-
Set the supervisor strategy of this actor, i.e.
- supervision(Attributes) - Method in interface akka.stream.impl.Stages.SymbolicStage
-
- Supervision - Class in akka.stream
-
- Supervision() - Constructor for class akka.stream.Supervision
-
- Supervision$ - Class in akka.stream
-
- Supervision$() - Constructor for class akka.stream.Supervision$
-
- Supervision.Directive - Interface in akka.stream
-
- Supervision.Restart$ - Class in akka.stream
-
Scala API: The element is dropped and the stream continues after restarting the stage
if application code for processing an element throws an exception.
- Supervision.Resume$ - Class in akka.stream
-
Scala API: The element is dropped and the stream continues if application code for processing
an element throws an exception.
- Supervision.Stop$ - Class in akka.stream
-
Scala API: The stream will be completed with failure if application code for processing an element
throws an exception.
- supervisionDecider() - Method in class akka.stream.ActorMaterializerSettings
-
- SupervisionMechanics<T> - Interface in akka.typed.internal
-
INTERNAL API
- supervisionStrategy(Function1<Throwable, Supervision.Directive>) - Method in class akka.stream.ActorAttributes$
-
Scala API: Decides how exceptions from user are to be handled.
- supervisionStrategy(Function1<Throwable, Supervision.Directive>) - Static method in class akka.stream.ActorAttributes
-
Scala API: Decides how exceptions from user are to be handled.
- SupervisionStrategy(Function1<Throwable, Supervision.Directive>) - Constructor for class akka.stream.ActorAttributes.SupervisionStrategy
-
- SupervisionStrategy$() - Constructor for class akka.stream.ActorAttributes.SupervisionStrategy$
-
- 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() - Method in class akka.stream.ActorMaterializer
-
INTERNAL API
- supervisor() - Method in class akka.stream.impl.ActorMaterializerImpl
-
- supervisor() - Method in class akka.stream.impl.ExtendedActorMaterializer
-
INTERNAL API
- 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() - Static method in class akka.actor.AbstractActor
-
- supervisorStrategy() - Static method in class akka.actor.AbstractFSM
-
- 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() - Static method in class akka.cluster.AutoDown
-
- supervisorStrategy() - Static method in class akka.cluster.client.ClusterClient
-
- supervisorStrategy() - Static method in class akka.cluster.client.ClusterReceptionist
-
- supervisorStrategy() - Method in class akka.cluster.ClusterCoreSupervisor
-
- supervisorStrategy() - Static method in class akka.cluster.ClusterHeartbeatSender
-
- supervisorStrategy() - Static method in class akka.cluster.ClusterRemoteWatcher
-
- supervisorStrategy() - Static method in class akka.cluster.ddata.LmdbDurableStore
-
- supervisorStrategy() - Static method in class akka.cluster.ddata.ReadAggregator
-
- supervisorStrategy() - Static method in class akka.cluster.ddata.ReadWriteAggregator
-
- supervisorStrategy() - Method in class akka.cluster.ddata.Replicator
-
- supervisorStrategy() - Static method in class akka.cluster.ddata.WriteAggregator
-
- supervisorStrategy() - Method in class akka.cluster.metrics.AdaptiveLoadBalancingPool
-
- supervisorStrategy() - Method in class akka.cluster.metrics.ClusterMetricsSupervisor
-
- supervisorStrategy() - Static method in class akka.cluster.pubsub.DistributedPubSubMediator
-
- supervisorStrategy() - Method in class akka.cluster.routing.AdaptiveLoadBalancingPool
-
Deprecated.
- supervisorStrategy() - Method in class akka.cluster.routing.ClusterRouterPool
-
- supervisorStrategy() - Static method in class akka.cluster.sharding.ClusterShardingGuardian
-
- supervisorStrategy() - Static method in class akka.cluster.sharding.RemoveInternalClusterShardingData
-
- supervisorStrategy() - Static method in class akka.cluster.sharding.Shard
-
- supervisorStrategy() - Static method in class akka.cluster.sharding.ShardCoordinator
-
- supervisorStrategy() - Static method in class akka.cluster.sharding.ShardRegion
-
- supervisorStrategy() - Static method in class akka.cluster.singleton.ClusterSingletonManager
-
- supervisorStrategy() - Static method in class akka.cluster.singleton.ClusterSingletonProxy
-
- supervisorStrategy() - Static method in class akka.contrib.circuitbreaker.CircuitBreakerProxy
-
- supervisorStrategy() - Method in class akka.contrib.pattern.ReliableProxy
-
- supervisorStrategy() - Static method in class akka.contrib.throttle.TimerBasedThrottler
-
- supervisorStrategy() - Static method in class akka.event.ActorClassificationUnsubscriber
-
- supervisorStrategy() - Static method in class akka.event.EventStreamUnsubscriber
-
- supervisorStrategy() - Method in class akka.io.SelectionHandler.SelectorBasedManager
-
- supervisorStrategy() - Method in class akka.io.SelectionHandler
-
- supervisorStrategy() - Static method in class akka.io.SimpleDnsManager
-
- supervisorStrategy() - Static method in class akka.io.TcpConnection
-
- supervisorStrategy() - Method in class akka.io.TcpListener
-
- supervisorStrategy() - Static method in class akka.io.TcpOutgoingConnection
-
- supervisorStrategy() - Method in class akka.pattern.BackoffOnRestartSupervisor
-
- supervisorStrategy() - Method in class akka.pattern.BackoffOptionsImpl
-
- supervisorStrategy() - Method in class akka.pattern.BackoffSupervisor
-
- supervisorStrategy() - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
-
- supervisorStrategy() - Static method in class akka.persistence.journal.leveldb.LeveldbJournal
-
- supervisorStrategy() - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
-
- supervisorStrategy() - Static method in class akka.persistence.journal.PersistencePluginProxy
-
- supervisorStrategy() - Static method in class akka.persistence.journal.ReplayFilter
-
- supervisorStrategy() - Static method in class akka.persistence.query.journal.leveldb.AllPersistenceIdsPublisher
-
- supervisorStrategy() - Static method in class akka.persistence.RecoveryPermitter
-
- supervisorStrategy() - Static method in class akka.remote.artery.FlushOnShutdown
-
- supervisorStrategy() - Method in class akka.remote.EndpointManager
-
- supervisorStrategy() - Static method in class akka.remote.EndpointReader
-
- supervisorStrategy() - Method in class akka.remote.EndpointWriter
-
- supervisorStrategy() - Method in class akka.remote.ReliableDeliverySupervisor
-
- supervisorStrategy() - Static method in class akka.remote.RemoteDeploymentWatcher
-
- supervisorStrategy() - Static method in class akka.remote.RemoteWatcher
-
- supervisorStrategy() - Method in class akka.remote.Remoting.TransportSupervisor
-
- supervisorStrategy() - Method in class akka.remote.routing.RemoteRouterConfig
-
- supervisorStrategy() - Static method in class akka.remote.testconductor.BarrierCoordinator
-
- supervisorStrategy() - Static method in class akka.remote.testconductor.ClientFSM
-
- supervisorStrategy() - Method in class akka.remote.testconductor.Controller
-
- supervisorStrategy() - Static method in class akka.remote.testconductor.ServerFSM
-
- supervisorStrategy() - Method in class akka.remote.transport.AkkaProtocolManager
-
- supervisorStrategy() - Static method in class akka.remote.transport.ProtocolStateActor
-
- supervisorStrategy() - Static method in class akka.remote.transport.ThrottledAssociation
-
- supervisorStrategy() - Static method in class akka.remote.transport.ThrottlerManager
-
- 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() - Static method in class akka.routing.ResizablePoolActor
-
- 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() - Static method in class akka.stream.actor.AbstractActorPublisher
-
- supervisorStrategy() - Static method in class akka.stream.actor.AbstractActorSubscriber
-
- supervisorStrategy() - Static method in class akka.stream.actor.UntypedActorPublisher
-
- supervisorStrategy() - Static method in class akka.stream.actor.UntypedActorSubscriber
-
- supervisorStrategy() - Static method in class akka.stream.impl.ActorRefSinkActor
-
- supervisorStrategy() - Static method in class akka.stream.impl.ActorRefSourceActor
-
- supervisorStrategy() - Static method in class akka.stream.impl.FanIn
-
- supervisorStrategy() - Static method in class akka.stream.impl.FanOut
-
- supervisorStrategy() - Static method in class akka.stream.impl.FanoutProcessorImpl
-
- supervisorStrategy() - Static method in class akka.stream.impl.fusing.ActorGraphInterpreter
-
- supervisorStrategy() - Static method in class akka.stream.impl.io.FilePublisher
-
- supervisorStrategy() - Static method in class akka.stream.impl.io.FileSubscriber
-
- supervisorStrategy() - Static method in class akka.stream.impl.io.InputStreamPublisher
-
- supervisorStrategy() - Static method in class akka.stream.impl.io.OutputStreamSubscriber
-
- supervisorStrategy() - Static method in class akka.stream.impl.io.TLSActor
-
- supervisorStrategy() - Method in class akka.stream.impl.StreamSupervisor
-
- supervisorStrategy() - Static method in class akka.stream.impl.Unzip
-
- supervisorStrategy() - Method in class akka.testkit.TestActor
-
- supervisorStrategy() - Method in class akka.typed.adapter.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
-
- supportsAtomicPersistAllOfSeveralEvents() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- supportsAtomicPersistAllOfSeveralEvents() - Method in class akka.persistence.journal.JournalSpec
-
Implementation may override and return false if it does not
support atomic writes of several events, as emitted by persistAll
.
- SupportsOnlyASingleSubscriber() - Method in class akka.stream.impl.ReactiveStreamsCompliance$
-
- SupportsOnlyASingleSubscriber() - Static method in class akka.stream.impl.ReactiveStreamsCompliance
-
- supportsRejectingNonSerializableObjects() - Method in class akka.persistence.japi.journal.JavaJournalPerfSpec
-
- supportsRejectingNonSerializableObjects() - Method in class akka.persistence.japi.journal.JavaJournalSpec
-
- supportsRejectingNonSerializableObjects() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- supportsRejectingNonSerializableObjects() - Static method in class akka.persistence.journal.JournalSpec
-
- supportsRejectingNonSerializableObjects() - Method in interface akka.persistence.JournalCapabilityFlags
-
When true
enables tests which check if the Journal properly rejects
writes of objects which are not java.lang.Serializable
.
- 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() - Static method in class akka.actor.ActorCell
-
- suspend() - Method in interface akka.actor.Cell
-
Recursively suspend this actor and all its children.
- suspend() - Static method in class akka.actor.DeadLetterActorRef
-
- 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() - Static method in class akka.actor.Nobody
-
- 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() - Static method in class akka.pattern.PromiseActorRef
-
- suspend() - Method in class akka.remote.RemoteActorRef
-
- suspend() - Static method in class akka.routing.RoutedActorCell
-
- suspend(ActorCell) - Method in class akka.testkit.CallingThreadDispatcher
-
- suspend() - Static method in class akka.testkit.TestActorRef
-
- suspend() - Static method in class akka.testkit.TestFSMRef
-
- 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$
-
- SUSPEND_VALUE - Static variable in enum akka.remote.SystemMessageFormats.SystemMessage.Type
-
SUSPEND = 2;
- suspendChildren(Set<ActorRef>) - Static method in class akka.actor.ActorCell
-
- suspendChildren(Set<ActorRef>) - Method in interface akka.actor.dungeon.Children
-
- suspendChildren(Set<ActorRef>) - Static method in class akka.routing.RoutedActorCell
-
- suspendChildren$default$1() - Static method in class akka.actor.ActorCell
-
- suspendChildren$default$1() - Static method in class akka.routing.RoutedActorCell
-
- 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
-
- SuspendedState() - Method in class akka.typed.internal.ActorCell$
-
- SuspendedState() - Static method in class akka.typed.internal.ActorCell
-
- SuspendedWaitForChildrenState() - Method in class akka.actor.ActorCell$
-
- SuspendedWaitForChildrenState() - Static method in class akka.actor.ActorCell
-
- SuspendedWaitForChildrenState() - Method in class akka.typed.internal.ActorCell$
-
- SuspendedWaitForChildrenState() - Static method in class akka.typed.internal.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(TcpConnection.ConnectionInfo) - Static method in class akka.io.TcpOutgoingConnection
-
- 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) - Static method in class akka.actor.ActorCell
-
- swapMailbox(Mailbox) - Method in interface akka.actor.dungeon.Dispatch
-
- swapMailbox(Mailbox) - Static method in class akka.routing.RoutedActorCell
-
- 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() - Method in class akka.cluster.ddata.Flag
-
- 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
- SymbolicGraphStage(Stages.SymbolicStage<In, Out>) - Constructor for class akka.stream.impl.Stages.SymbolicGraphStage
-
- SymbolicGraphStage$() - Constructor for class akka.stream.impl.Stages.SymbolicGraphStage$
-
- symbolicStage() - Method in class akka.stream.impl.Stages.SymbolicGraphStage
-
- 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.
- SyncDirective - Interface in akka.stream.stage
-
- SynchronizedEventSink - Class in akka.remote.artery
-
INTERNAL API
- SynchronizedEventSink(EventSink) - Constructor for class akka.remote.artery.SynchronizedEventSink
-
- 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$
-
- syncProcessingLimit() - Method in class akka.stream.ActorMaterializerSettings
-
- SysMsgAckTimeout() - Method in class akka.remote.RemoteSettings
-
- SysMsgBufferSize() - Method in class akka.remote.artery.ArterySettings.Advanced$
-
- SysMsgBufferSize() - Method in class akka.remote.RemoteSettings
-
- SysResendLimit() - 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.client.protobuf.ClusterClientMessageSerializer
-
- system() - Method in class akka.cluster.Cluster
-
- system() - Method in class akka.cluster.ddata.protobuf.ReplicatedDataSerializer
-
- system() - Method in class akka.cluster.ddata.protobuf.ReplicatorMessageSerializer
-
- system() - Method in interface akka.cluster.ddata.protobuf.SerializationSupport
-
- 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
-
Deprecated.
- system() - Method in class akka.cluster.sharding.protobuf.ClusterShardingMessageSerializer
-
- system() - Method in class akka.cluster.singleton.protobuf.ClusterSingletonMessageSerializer
-
- system() - Method in class akka.contrib.mailbox.PeekMailboxExtension
-
- system() - Method in interface akka.event.ManagedActorClassification
-
- system() - Static method in class akka.persistence.journal.JournalPerfSpec
-
- 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() - Static method in class akka.remote.artery.ArteryTransport
-
- system() - Method in class akka.remote.BoundAddressesExtension
-
- system() - Method in class akka.remote.RemoteTransport
-
- system() - Static method in class akka.remote.Remoting
-
- system() - Method in class akka.remote.serialization.ActorRefResolveThreadLocalCache
-
- system() - Method in class akka.remote.serialization.ArteryMessageSerializer
-
- system() - Method in class akka.remote.serialization.ByteStringSerializer
-
- system() - Method in class akka.remote.serialization.DaemonMsgCreateSerializer
-
- system() - Method in class akka.remote.serialization.IntSerializer
-
- system() - Method in class akka.remote.serialization.LongSerializer
-
- system() - Method in class akka.remote.serialization.MessageContainerSerializer
-
- system() - Method in class akka.remote.serialization.MiscMessageSerializer
-
- system() - Method in class akka.remote.serialization.ProtobufSerializer
-
- system() - Method in class akka.remote.serialization.StringSerializer
-
- system() - Method in class akka.remote.serialization.SystemMessageSerializer
-
- system() - Method in class akka.remote.testconductor.TestConductorExt
-
- system() - Static method in class akka.remote.testkit.MultiNodeSpec
-
- system() - Method in class akka.remote.transport.netty.NettyTransport
-
- system() - Method in class akka.routing.ConsistentHashingRoutingLogic
-
- system() - Static method in class akka.routing.RoutedActorCell
-
- 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.DisabledJavaSerializer
-
- 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.stream.ActorMaterializer
-
INTERNAL API
- system() - Method in class akka.stream.impl.ActorMaterializerImpl
-
- system() - Method in class akka.testkit.CallingThreadMailbox
-
- system() - Method in class akka.testkit.TestKit
-
- system() - Method in interface akka.testkit.TestKitBase
-
- system() - Static method in class akka.testkit.TestProbe
-
- system() - Method in interface akka.typed.ActorContext
-
- system() - Method in class akka.typed.adapter.ActorContextAdapter
-
- system() - Method in class akka.typed.internal.ActorCell
-
- system() - Method in interface akka.typed.internal.DeathWatch
-
- system() - Method in interface akka.typed.internal.SupervisionMechanics
-
- 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.ArteryControlFormats.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.
- systemActorOf(Behavior<U>, String, DeploymentConfig, Timeout) - Method in interface akka.typed.ActorSystem
-
Ask the system guardian of this system to create an actor from the given
behavior and deployment and with the given name.
- systemActorOf(Behavior<U>, String, DeploymentConfig, Timeout) - Method in class akka.typed.adapter.ActorSystemAdapter
-
- systemActorOf(Behavior<U>, String, DeploymentConfig, Timeout) - Method in class akka.typed.internal.ActorSystemImpl
-
- systemActorOf$default$3() - Static method in class akka.typed.adapter.ActorSystemAdapter
-
- systemActorOf$default$3() - Static method in class akka.typed.internal.ActorSystemImpl
-
- 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) - Static method in class akka.dispatch.Mailbox
-
- 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) - Static method in class akka.dispatch.Mailbox
-
- 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
-
- systemGuardianBehavior() - Method in class akka.typed.internal.ActorSystemImpl$
-
- systemGuardianBehavior() - Static method in class akka.typed.internal.ActorSystemImpl
-
- 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() - Static method in class akka.actor.ActorSystem
-
- 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
-
- systemImpl() - Static method in class akka.routing.RoutedActorCell
-
- systemInvoke(SystemMessage) - Method in class akka.actor.ActorCell
-
- systemInvoke(SystemMessage) - Static method in class akka.routing.RoutedActorCell
-
- systemLoadAverage() - Method in class akka.cluster.JmxMetricsCollector
-
Deprecated.
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
-
Deprecated.
(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$
-
Deprecated.
- systemLoadAverage() - Method in class akka.cluster.StandardMetrics.Cpu
-
Deprecated.
- SystemLoadAverage() - Static method in class akka.cluster.StandardMetrics
-
Deprecated.
- 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
-
- SystemLoadAverageMetricsSelector() - Constructor for class akka.cluster.routing.SystemLoadAverageMetricsSelector
-
Deprecated.
- 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
-
- SystemLoadAverageMetricsSelector$() - Constructor for class akka.cluster.routing.SystemLoadAverageMetricsSelector$
-
Deprecated.
- systemMaterializer(ActorMaterializerSettings, String, ExtendedActorSystem) - Method in class akka.stream.ActorMaterializer$
-
INTERNAL API: Creates the StreamSupervisor
as a system actor.
- systemMaterializer(ActorMaterializerSettings, String, ExtendedActorSystem) - Static method in class akka.stream.ActorMaterializer
-
INTERNAL API: Creates the StreamSupervisor
as a system actor.
- SystemMessage - Interface in akka.dispatch.sysmsg
-
System messages are handled specially: they form their own queue within
each actor’s mailbox.
- SystemMessage - Interface in akka.typed.internal
-
System messages are handled specially: they form their own queue within
each actor’s mailbox.
- SystemMessageAcker - Class in akka.remote.artery
-
INTERNAL API
- SystemMessageAcker(InboundContext) - Constructor for class akka.remote.artery.SystemMessageAcker
-
- SystemMessageDelivery - Class in akka.remote.artery
-
INTERNAL API
- SystemMessageDelivery(OutboundContext, ActorRef, FiniteDuration, int) - Constructor for class akka.remote.artery.SystemMessageDelivery
-
- SystemMessageDelivery$ - Class in akka.remote.artery
-
INTERNAL API
- SystemMessageDelivery$() - Constructor for class akka.remote.artery.SystemMessageDelivery$
-
- SystemMessageDelivery.Ack - Class in akka.remote.artery
-
- SystemMessageDelivery.Ack$ - Class in akka.remote.artery
-
- SystemMessageDelivery.AckedDeliveryMessage - Interface in akka.remote.artery
-
- SystemMessageDelivery.ClearSystemMessageDelivery$ - Class in akka.remote.artery
-
- SystemMessageDelivery.GaveUpSystemMessageException - Exception in akka.remote.artery
-
- SystemMessageDelivery.Nack - Class in akka.remote.artery
-
- SystemMessageDelivery.Nack$ - Class in akka.remote.artery
-
- SystemMessageDelivery.SystemMessageEnvelope - Class in akka.remote.artery
-
- SystemMessageDelivery.SystemMessageEnvelope$ - Class in akka.remote.artery
-
- SystemMessageEnvelope(Object, long, UniqueAddress) - Constructor for class akka.remote.artery.SystemMessageDelivery.SystemMessageEnvelope
-
- SystemMessageEnvelope$() - Constructor for class akka.remote.artery.SystemMessageDelivery.SystemMessageEnvelope$
-
- SystemMessageFormats - Class in akka.remote
-
- SystemMessageFormats.DeathWatchNotificationData - Class in akka.remote
-
Protobuf type DeathWatchNotificationData
- SystemMessageFormats.DeathWatchNotificationData.Builder - Class in akka.remote
-
Protobuf type DeathWatchNotificationData
- SystemMessageFormats.DeathWatchNotificationDataOrBuilder - Interface in akka.remote
-
- SystemMessageFormats.FailedData - Class in akka.remote
-
Protobuf type FailedData
- SystemMessageFormats.FailedData.Builder - Class in akka.remote
-
Protobuf type FailedData
- SystemMessageFormats.FailedDataOrBuilder - Interface in akka.remote
-
- SystemMessageFormats.SuperviseData - Class in akka.remote
-
Protobuf type SuperviseData
- SystemMessageFormats.SuperviseData.Builder - Class in akka.remote
-
Protobuf type SuperviseData
- SystemMessageFormats.SuperviseDataOrBuilder - Interface in akka.remote
-
- SystemMessageFormats.SystemMessage - Class in akka.remote
-
Protobuf type SystemMessage
- SystemMessageFormats.SystemMessage.Builder - Class in akka.remote
-
Protobuf type SystemMessage
- SystemMessageFormats.SystemMessage.Type - Enum in akka.remote
-
Protobuf enum SystemMessage.Type
- SystemMessageFormats.SystemMessageOrBuilder - Interface in akka.remote
-
- SystemMessageFormats.WatchData - Class in akka.remote
-
Protobuf type WatchData
- SystemMessageFormats.WatchData.Builder - Class in akka.remote
-
Protobuf type WatchData
- SystemMessageFormats.WatchDataOrBuilder - Interface in akka.remote
-
- SystemMessageList - Class in akka.dispatch.sysmsg
-
INTERNAL API
- SystemMessageList() - Constructor for class akka.dispatch.sysmsg.SystemMessageList
-
- SystemMessageList - Class in akka.typed.internal
-
INTERNAL API
- SystemMessageList() - Constructor for class akka.typed.internal.SystemMessageList
-
- SystemMessageList$ - Class in akka.dispatch.sysmsg
-
INTERNAL API
- SystemMessageList$() - Constructor for class akka.dispatch.sysmsg.SystemMessageList$
-
- SystemMessageList$ - Class in akka.typed.internal
-
INTERNAL API
- SystemMessageList$() - Constructor for class akka.typed.internal.SystemMessageList$
-
- SystemMessageQueue - Interface in akka.dispatch
-
INTERNAL API
- SystemMessageResendInterval() - Method in class akka.remote.artery.ArterySettings.Advanced$
-
- SystemMessageSerializer - Class in akka.remote.serialization
-
- SystemMessageSerializer(ExtendedActorSystem) - Constructor for class akka.remote.serialization.SystemMessageSerializer
-
- systemName() - Method in class akka.cluster.ClusterSettings
-
- systemName() - Method in class akka.remote.RemoteActorRefProvider
-
- systemQueueGet() - Method in class akka.dispatch.Mailbox
-
- systemQueueOffset() - Method in class akka.typed.internal.ActorCell$
-
- systemQueueOffset() - Static method in class akka.typed.internal.ActorCell
-
- systemQueuePut(LatestFirstSystemMessageList, LatestFirstSystemMessageList) - Method in class akka.dispatch.Mailbox
-