Skip navigation links
A B C D E F G H I K L M N O P Q R S T U V W _ 

A

AbstractTransportAdapter - Class in akka.remote.transport
An adapter that wraps a transport and provides interception
AbstractTransportAdapter(Transport, ExecutionContext) - Constructor for class akka.remote.transport.AbstractTransportAdapter
 
AbstractTransportAdapterHandle - Class in akka.remote.transport
 
AbstractTransportAdapterHandle(Address, Address, AssociationHandle, String) - Constructor for class akka.remote.transport.AbstractTransportAdapterHandle
 
AbstractTransportAdapterHandle(AssociationHandle, String) - Constructor for class akka.remote.transport.AbstractTransportAdapterHandle
 
acceptableHeartbeatPause() - Method in class akka.remote.DeadlineFailureDetector
 
acceptableHeartbeatPause() - Method in class akka.remote.PhiAccrualFailureDetector
 
accepting() - Method in class akka.remote.EndpointManager
 
Ack - Class in akka.remote
Class representing an acknowledgement with selective negative acknowledgements.
Ack(SeqNo, Set<SeqNo>) - Constructor for class akka.remote.Ack
 
ack() - Method in class akka.remote.EndpointWriter.OutboundAck
 
Ack$ - Class in akka.remote
 
Ack$() - Constructor for class akka.remote.Ack$
 
ACK_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
ackDeadline() - Method in class akka.remote.EndpointWriter
 
AckedReceiveBuffer<T extends HasSequenceNumber> - Class in akka.remote
Implements an immutable receive buffer that buffers incoming messages until they can be safely delivered.
AckedReceiveBuffer(SeqNo, SeqNo, SortedSet<T>, Ordering<T>) - Constructor for class akka.remote.AckedReceiveBuffer
 
ackedReceiveBuffer() - Method in class akka.remote.EndpointReader
 
AckedReceiveBuffer$ - Class in akka.remote
 
AckedReceiveBuffer$() - Constructor for class akka.remote.AckedReceiveBuffer$
 
AckedSendBuffer<T extends HasSequenceNumber> - Class in akka.remote
Implements an immutable resend buffer that buffers messages until they have been acknowledged.
AckedSendBuffer(int, IndexedSeq<T>, IndexedSeq<T>, SeqNo) - Constructor for class akka.remote.AckedSendBuffer
 
AckedSendBuffer$ - Class in akka.remote
 
AckedSendBuffer$() - Constructor for class akka.remote.AckedSendBuffer$
 
AckIdleCheckTimer$() - Constructor for class akka.remote.EndpointWriter.AckIdleCheckTimer$
 
ackIdleTimer() - Method in class akka.remote.EndpointWriter
 
acknowledge(Ack) - Method in class akka.remote.AckedSendBuffer
Processes an incoming acknowledgement and returns a new buffer with only unacknowledged elements remaining.
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
 
ActorAssociationEventListener(ActorRef) - Constructor for class akka.remote.transport.Transport.ActorAssociationEventListener
 
ActorAssociationEventListener$() - Constructor for class akka.remote.transport.Transport.ActorAssociationEventListener$
 
actorFor(ActorPath) - Method in class akka.remote.RemoteActorRefProvider
 
actorFor(InternalActorRef, String) - Method in class akka.remote.RemoteActorRefProvider
 
actorFor(InternalActorRef, Iterable<String>) - Method in class akka.remote.RemoteActorRefProvider
 
ActorHandleEventListener(ActorRef) - Constructor for class akka.remote.transport.AssociationHandle.ActorHandleEventListener
 
ActorHandleEventListener$() - Constructor for class akka.remote.transport.AssociationHandle.ActorHandleEventListener$
 
actorOf(ActorSystemImpl, Props, InternalActorRef, ActorPath, boolean, Option<Deploy>, boolean, boolean) - Method in class akka.remote.RemoteActorRefProvider
 
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
 
Adapters() - Method in class akka.remote.RemoteSettings
 
adaptiveBackoffNanos() - Method in class akka.remote.EndpointWriter
 
addAllArgs(Iterable<? extends ByteString>) - Method in class akka.remote.WireFormats.PropsData.Builder
repeated bytes args = 4;
addAllClasses(Iterable<String>) - Method in class akka.remote.WireFormats.PropsData.Builder
repeated string classes = 5;
addAllNacks(Iterable<? extends Long>) - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
repeated fixed64 nacks = 2;
addAllPattern(Iterable<? extends ContainerFormats.Selection>) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
repeated .Selection pattern = 3;
addArgs(ByteString) - Method in class akka.remote.WireFormats.PropsData.Builder
repeated bytes args = 4;
addClasses(String) - Method in class akka.remote.WireFormats.PropsData.Builder
repeated string classes = 5;
addClassesBytes(ByteString) - Method in class akka.remote.WireFormats.PropsData.Builder
repeated string classes = 5;
addedSchemeIdentifier() - Method in class akka.remote.transport.AbstractTransportAdapterHandle
 
addedSchemeIdentifier() - Method in class akka.remote.transport.AkkaProtocolTransport
 
addedSchemeIdentifier() - Method in class akka.remote.transport.FailureInjectorTransportAdapter
 
addedSchemeIdentifier() - Method in interface akka.remote.transport.SchemeAugmenter
 
addedSchemeIdentifier() - Method in class akka.remote.transport.ThrottlerTransportAdapter
 
addNacks(long) - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
repeated fixed64 nacks = 2;
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;
address() - Method in class akka.remote.QuarantinedEvent
 
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
 
addressChaosTable() - Method in class akka.remote.transport.FailureInjectorTransportAdapter
 
addresses() - Method in class akka.remote.RemoteTransport
Address to be used in RootActorPath of refs generated for this transport.
addresses() - Method in class akka.remote.Remoting
 
addressesPromise() - Method in class akka.remote.EndpointManager.Listen
 
addressesPromise() - Method in class akka.remote.EndpointManager.ListensFailure
 
addressesPromise() - Method in class akka.remote.EndpointManager.ListensResult
 
addressFromSocketAddress(SocketAddress, String, String, Option<String>, Option<Object>) - Method in class akka.remote.transport.netty.NettyTransport$
 
addressFromSocketAddress(SocketAddress, String, String, Option<String>) - Method in class akka.remote.transport.netty.NettyTransport$
 
addressFromSocketAddress(SocketAddress, String, String, Option<String>, Option<Object>) - Static method in class akka.remote.transport.netty.NettyTransport
 
addressFromSocketAddress(SocketAddress, String, String, Option<String>) - Static method in class akka.remote.transport.netty.NettyTransport
 
addressToSocketAddress(Address) - Method in class akka.remote.transport.netty.NettyTransport
 
addressUid() - Method in class akka.remote.AddressUidExtension
 
addressUid() - Method in class akka.remote.RemoteWatcher.HeartbeatRsp
 
AddressUidExtension - Class in akka.remote
 
AddressUidExtension(ExtendedActorSystem) - Constructor for class akka.remote.AddressUidExtension
 
AddressUidExtension$ - Class in akka.remote
Extension that holds a uid that is assigned as a random Int.
AddressUidExtension$() - Constructor for class akka.remote.AddressUidExtension$
 
addressUids() - Method in class akka.remote.RemoteWatcher
 
AddressUrlEncoder - Class in akka.remote
INTERNAL API
AddressUrlEncoder() - Constructor for class akka.remote.AddressUrlEncoder
 
AddressUrlEncoder$ - Class in akka.remote
INTERNAL API
AddressUrlEncoder$() - Constructor for class akka.remote.AddressUrlEncoder$
 
addWatch(InternalActorRef, InternalActorRef) - Method in class akka.remote.RemoteWatcher
 
adjustAdaptiveBackup() - Method in class akka.remote.EndpointWriter
 
AES128CounterInetRNG - Class in akka.remote.security.provider
INTERNAL API This class is a wrapper around the 128-bit AESCounterRNG algorithm provided by http://maths.uncommons.org/ It uses the default seed generator which uses one of the following 3 random seed sources: Depending on availability: random.org, /dev/random, and SecureRandom (provided by Java) The only method used by netty ssl is engineNextBytes(bytes)
AES128CounterInetRNG() - Constructor for class akka.remote.security.provider.AES128CounterInetRNG
 
AES128CounterSecureRNG - Class in akka.remote.security.provider
INTERNAL API This class is a wrapper around the 128-bit AESCounterRNG algorithm provided by http://maths.uncommons.org/ The only method used by netty ssl is engineNextBytes(bytes) This RNG is good to use to prevent startup delay when you don't have Internet access to random.org
AES128CounterSecureRNG() - Constructor for class akka.remote.security.provider.AES128CounterSecureRNG
 
AES256CounterInetRNG - Class in akka.remote.security.provider
INTERNAL API This class is a wrapper around the 256-bit AESCounterRNG algorithm provided by http://maths.uncommons.org/ It uses the default seed generator which uses one of the following 3 random seed sources: Depending on availability: random.org, /dev/random, and SecureRandom (provided by Java) The only method used by netty ssl is engineNextBytes(bytes)
AES256CounterInetRNG() - Constructor for class akka.remote.security.provider.AES256CounterInetRNG
 
AES256CounterSecureRNG - Class in akka.remote.security.provider
INTERNAL API This class is a wrapper around the 256-bit AESCounterRNG algorithm provided by http://maths.uncommons.org/ The only method used by netty ssl is engineNextBytes(bytes) This RNG is good to use to prevent startup delay when you don't have Internet access to random.org
AES256CounterSecureRNG() - Constructor for class akka.remote.security.provider.AES256CounterSecureRNG
 
akka.remote - package akka.remote
 
akka.remote.routing - package akka.remote.routing
 
akka.remote.security.provider - package akka.remote.security.provider
 
akka.remote.serialization - package akka.remote.serialization
 
akka.remote.transport - package akka.remote.transport
 
akka.remote.transport.netty - package akka.remote.transport.netty
 
AkkaOverhead() - Method in class akka.remote.transport.AkkaProtocolTransport$
 
AkkaOverhead() - Static method in class akka.remote.transport.AkkaProtocolTransport
 
AkkaPduCodec - Interface in akka.remote.transport
INTERNAL API
AkkaPduCodec$ - Class in akka.remote.transport
INTERNAL API
AkkaPduCodec$() - Constructor for class akka.remote.transport.AkkaPduCodec$
 
AkkaPduCodec.AkkaPdu - Interface in akka.remote.transport
Trait that represents decoded Akka PDUs (Protocol Data Units)
AkkaPduCodec.Associate - Class in akka.remote.transport
 
AkkaPduCodec.Associate$ - Class in akka.remote.transport
 
AkkaPduCodec.Disassociate - Class in akka.remote.transport
 
AkkaPduCodec.Disassociate$ - Class in akka.remote.transport
 
AkkaPduCodec.Heartbeat$ - Class in akka.remote.transport
 
AkkaPduCodec.Message - Class in akka.remote.transport
 
AkkaPduCodec.Message$ - Class in akka.remote.transport
 
AkkaPduCodec.Payload - Class in akka.remote.transport
 
AkkaPduCodec.Payload$ - Class in akka.remote.transport
 
AkkaPduProtobufCodec - Class in akka.remote.transport
INTERNAL API
AkkaPduProtobufCodec() - Constructor for class akka.remote.transport.AkkaPduProtobufCodec
 
AkkaPduProtobufCodec$ - Class in akka.remote.transport
INTERNAL API
AkkaPduProtobufCodec$() - Constructor for class akka.remote.transport.AkkaPduProtobufCodec$
 
AkkaProtocolException - Exception in akka.remote.transport
 
AkkaProtocolException(String, Throwable) - Constructor for exception akka.remote.transport.AkkaProtocolException
 
AkkaProtocolException(String) - Constructor for exception akka.remote.transport.AkkaProtocolException
 
AkkaProtocolHandle - Class in akka.remote.transport
 
AkkaProtocolHandle(Address, Address, Promise<AssociationHandle.HandleEventListener>, AssociationHandle, HandshakeInfo, ActorRef, AkkaPduCodec) - Constructor for class akka.remote.transport.AkkaProtocolHandle
 
AkkaProtocolManager - Class in akka.remote.transport
 
AkkaProtocolManager(Transport, AkkaProtocolSettings) - Constructor for class akka.remote.transport.AkkaProtocolManager
 
AkkaProtocolSettings - Class in akka.remote.transport
 
AkkaProtocolSettings(Config) - Constructor for class akka.remote.transport.AkkaProtocolSettings
 
AkkaProtocolTransport - Class in akka.remote.transport
Implementation of the Akka protocol as a Transport that wraps an underlying Transport instance.
AkkaProtocolTransport(Transport, ActorSystem, AkkaProtocolSettings, AkkaPduCodec) - Constructor for class akka.remote.transport.AkkaProtocolTransport
 
AkkaProtocolTransport$ - Class in akka.remote.transport
 
AkkaProtocolTransport$() - Constructor for class akka.remote.transport.AkkaProtocolTransport$
 
AkkaProtocolTransport.AssociateUnderlyingRefuseUid - Class in akka.remote.transport
 
AkkaProtocolTransport.AssociateUnderlyingRefuseUid$ - Class in akka.remote.transport
 
AkkaProvider - Class in akka.remote.security.provider
A provider that for AES128CounterRNGFast, a cryptographically secure random number generator through SecureRandom
AkkaProvider() - Constructor for class akka.remote.security.provider.AkkaProvider
 
AkkaProvider$ - Class in akka.remote.security.provider
A provider that for AES128CounterRNGFast, a cryptographically secure random number generator through SecureRandom
AkkaProvider$() - Constructor for class akka.remote.security.provider.AkkaProvider$
 
AkkaScheme() - Method in class akka.remote.transport.AkkaProtocolTransport$
 
AkkaScheme() - Static method in class akka.remote.transport.AkkaProtocolTransport
 
All(FailureInjectorTransportAdapter.GremlinMode) - Constructor for class akka.remote.transport.FailureInjectorTransportAdapter.All
 
All$() - Constructor for class akka.remote.transport.FailureInjectorTransportAdapter.All$
 
allEndpoints() - Method in class akka.remote.EndpointManager.EndpointRegistry
 
apply(Address) - Method in class akka.remote.AddressUrlEncoder$
 
apply(Address) - Static method in class akka.remote.AddressUrlEncoder
 
apply(String, Config, ActorContext) - Method in class akka.remote.FailureDetectorLoader$
Loads and instantiates a given FailureDetector implementation.
apply(String, Config, ActorContext) - Static method in class akka.remote.FailureDetectorLoader
Loads and instantiates a given FailureDetector implementation.
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(ChannelFuture) - Method in class akka.remote.transport.netty.NettyFutureBridge$
 
apply(ChannelGroupFuture) - Method in class akka.remote.transport.netty.NettyFutureBridge$
 
apply(ChannelFuture) - Static method in class akka.remote.transport.netty.NettyFutureBridge
 
apply(ChannelGroupFuture) - Static method in class akka.remote.transport.netty.NettyFutureBridge
 
apply(SSLSettings, LoggingAdapter, boolean) - Method in class akka.remote.transport.netty.NettySSLSupport$
Construct a SSLHandler which can be inserted into a Netty server/client pipeline
apply(SSLSettings, LoggingAdapter, boolean) - Static method in class akka.remote.transport.netty.NettySSLSupport
Construct a SSLHandler which can be inserted into a Netty server/client pipeline
apply(A) - Method in class akka.remote.transport.TestTransport.SwitchableLoggedBehavior
Applies the current behavior, and invokes the callback.
ARGS_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.PropsData
 
ARRAY_OF_BYTE_ARRAY() - Method in class akka.remote.serialization.ProtobufSerializer
 
AskTimeout() - Method in class akka.remote.transport.ActorTransportAdapter$
 
AskTimeout() - Static method in class akka.remote.transport.ActorTransportAdapter
 
associate(Address) - Method in class akka.remote.transport.AbstractTransportAdapter
 
Associate(HandshakeInfo) - Constructor for class akka.remote.transport.AkkaPduCodec.Associate
 
associate(Address, Option<Object>) - Method in class akka.remote.transport.AkkaProtocolTransport
 
associate(Address) - Method in class akka.remote.transport.netty.NettyTransport
 
associate(Address) - Method in class akka.remote.transport.TestTransport
 
associate(Address) - Method in interface akka.remote.transport.Transport
Asynchronously opens a logical duplex link between two Transport Entities over a network.
Associate$() - Constructor for class akka.remote.transport.AkkaPduCodec.Associate$
 
ASSOCIATE_VALUE - Static variable in enum akka.remote.WireFormats.CommandType
ASSOCIATE = 1;
AssociateAttempt(Address, Address) - Constructor for class akka.remote.transport.TestTransport.AssociateAttempt
 
AssociateAttempt$() - Constructor for class akka.remote.transport.TestTransport.AssociateAttempt$
 
associateBehavior() - Method in class akka.remote.transport.TestTransport
The TestTransport.SwitchableLoggedBehavior for the associate() method.
AssociatedEvent - Class in akka.remote
 
AssociatedEvent(Address, Address, boolean) - Constructor for class akka.remote.AssociatedEvent
 
AssociatedEvent$ - Class in akka.remote
 
AssociatedEvent$() - Constructor for class akka.remote.AssociatedEvent$
 
AssociatedWaitHandler(Future<AssociationHandle.HandleEventListener>, AssociationHandle, Queue<ByteString>) - Constructor for class akka.remote.transport.ProtocolStateActor.AssociatedWaitHandler
 
AssociatedWaitHandler$() - Constructor for class akka.remote.transport.ProtocolStateActor.AssociatedWaitHandler$
 
AssociateResult(AssociationHandle, Promise<AssociationHandle>) - Constructor for class akka.remote.transport.ThrottlerManager.AssociateResult
 
AssociateResult$() - Constructor for class akka.remote.transport.ThrottlerManager.AssociateResult$
 
AssociateUnderlying(Address, Promise<AssociationHandle>) - Constructor for class akka.remote.transport.ActorTransportAdapter.AssociateUnderlying
 
AssociateUnderlying$() - Constructor for class akka.remote.transport.ActorTransportAdapter.AssociateUnderlying$
 
AssociateUnderlyingRefuseUid(Address, Promise<AssociationHandle>, Option<Object>) - Constructor for class akka.remote.transport.AkkaProtocolTransport.AssociateUnderlyingRefuseUid
 
AssociateUnderlyingRefuseUid$() - Constructor for class akka.remote.transport.AkkaProtocolTransport.AssociateUnderlyingRefuseUid$
 
association() - Method in class akka.remote.transport.Transport.InboundAssociation
 
AssociationErrorEvent - Class in akka.remote
 
AssociationErrorEvent(Throwable, Address, Address, boolean, Logging.LogLevel) - Constructor for class akka.remote.AssociationErrorEvent
 
AssociationErrorEvent$ - Class in akka.remote
 
AssociationErrorEvent$() - Constructor for class akka.remote.AssociationErrorEvent$
 
AssociationEvent - Interface in akka.remote
 
AssociationHandle - Interface in akka.remote.transport
An SPI layer for abstracting over logical links (associations) created by a Transport.
AssociationHandle$ - Class in akka.remote.transport
 
AssociationHandle$() - Constructor for class akka.remote.transport.AssociationHandle$
 
AssociationHandle.ActorHandleEventListener - Class in akka.remote.transport
Class to convert ordinary ActorRef instances to a HandleEventListener.
AssociationHandle.ActorHandleEventListener$ - Class in akka.remote.transport
 
AssociationHandle.Disassociated - Class in akka.remote.transport
Message sent to the listener registered to an association
AssociationHandle.Disassociated$ - Class in akka.remote.transport
 
AssociationHandle.DisassociateInfo - Interface in akka.remote.transport
Supertype of possible disassociation reasons
AssociationHandle.HandleEvent - Interface in akka.remote.transport
Trait for events that the registered listener for an AssociationHandle might receive.
AssociationHandle.HandleEventListener - Interface in akka.remote.transport
An interface that needs to be implemented by the user of an AssociationHandle to listen to association events.
AssociationHandle.InboundPayload - Class in akka.remote.transport
Message sent to the listener registered to an association (via the Promise returned by AssociationHandle.readHandlerPromise()) when an inbound payload arrives.
AssociationHandle.InboundPayload$ - Class in akka.remote.transport
 
AssociationHandle.Quarantined$ - Class in akka.remote.transport
 
AssociationHandle.Shutdown$ - Class in akka.remote.transport
 
AssociationHandle.Unknown$ - Class in akka.remote.transport
 
associationHandler() - Method in class akka.remote.transport.ThrottledAssociation
 
associationListener() - Method in class akka.remote.transport.ActorTransportAdapterManager
 
associationListener() - Method in class akka.remote.transport.ProtocolStateActor.InboundUnassociated
 
AssociationProblem - Interface in akka.remote
INTERNAL API
AssociationRegistry - Class in akka.remote.transport
 
AssociationRegistry() - Constructor for class akka.remote.transport.AssociationRegistry
 
AssociationRegistry() - Constructor for class akka.remote.transport.TestTransport.AssociationRegistry
 
AssociationRegistry$ - Class in akka.remote.transport
 
AssociationRegistry$() - Constructor for class akka.remote.transport.AssociationRegistry$
 
AttemptSysMsgRedelivery$() - Constructor for class akka.remote.ReliableDeliverySupervisor.AttemptSysMsgRedelivery$
 
augmentScheme(String) - Method in interface akka.remote.transport.SchemeAugmenter
 
augmentScheme(Address) - Method in interface akka.remote.transport.SchemeAugmenter
 
autoResendTimer() - Method in class akka.remote.ReliableDeliverySupervisor
 
availableTokens() - Method in class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket
 

B

Backlog() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
backoffDispatcher() - Method in class akka.remote.EndpointWriter
 
BackoffPeriod() - Method in class akka.remote.RemoteSettings
 
BackoffTimer$() - Constructor for class akka.remote.EndpointWriter.BackoffTimer$
 
bailoutAt() - Method in class akka.remote.ReliableDeliverySupervisor
 
becomeWritingOrSendBufferedMessages() - Method in class akka.remote.EndpointWriter
 
BindHostname() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
BindPortSelector() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
Blackhole$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.Blackhole$
 
Both$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.Direction.Both$
 
boundAddress() - Method in class akka.remote.transport.AbstractTransportAdapter
INTERNAL API
boundAddress() - Method in class akka.remote.transport.netty.NettyTransport
 
boundAddress() - Method in class akka.remote.transport.TestTransport
 
boundAddress() - Method in class akka.remote.transport.TestTransport.ListenAttempt
 
boundAddress() - Method in class akka.remote.transport.TestTransport.ShutdownAttempt
 
boundAddresses() - Method in class akka.remote.BoundAddressesExtension
Returns a mapping from a protocol to a set of bound addresses.
boundAddresses() - Method in class akka.remote.Remoting
 
BoundAddressesExtension - Class in akka.remote
 
BoundAddressesExtension(ExtendedActorSystem) - Constructor for class akka.remote.BoundAddressesExtension
 
BoundAddressesExtension$ - Class in akka.remote
Extension provides access to bound addresses.
BoundAddressesExtension$() - Constructor for class akka.remote.BoundAddressesExtension$
 
buf() - Method in class akka.remote.AckedReceiveBuffer
 
buffer(T) - Method in class akka.remote.AckedSendBuffer
Puts a new message in the buffer.
buffer() - Method in class akka.remote.EndpointManager.ResendState
 
buffer() - Method in class akka.remote.EndpointWriter
 
buffering() - Method in class akka.remote.EndpointWriter
 
build() - Method in class akka.remote.ContainerFormats.Selection.Builder
 
build() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
build() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
build() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
build() - Method in class akka.remote.WireFormats.ActorRefData.Builder
 
build() - Method in class akka.remote.WireFormats.AddressData.Builder
 
build() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
build() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
build() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
build() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
build() - Method in class akka.remote.WireFormats.DeployData.Builder
 
build() - Method in class akka.remote.WireFormats.PropsData.Builder
 
build() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
build() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
buildPartial() - Method in class akka.remote.ContainerFormats.Selection.Builder
 
buildPartial() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
buildPartial() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
buildPartial() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
buildPartial() - Method in class akka.remote.WireFormats.ActorRefData.Builder
 
buildPartial() - Method in class akka.remote.WireFormats.AddressData.Builder
 
buildPartial() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
buildPartial() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
buildPartial() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
buildPartial() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
buildPartial() - Method in class akka.remote.WireFormats.DeployData.Builder
 
buildPartial() - Method in class akka.remote.WireFormats.PropsData.Builder
 
buildPartial() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
buildPartial() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
bytes() - Method in class akka.remote.transport.AkkaPduCodec.Payload
 

C

capacity() - Method in class akka.remote.AckedSendBuffer
 
capacity() - Method in class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket
 
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
 
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 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 interface akka.remote.transport.netty.NettyClientHelpers
 
channelOpen(ChannelHandlerContext, ChannelStateEvent) - Method in interface akka.remote.transport.netty.NettyServerHelpers
 
chaosMode(Address) - Method in class akka.remote.transport.FailureInjectorTransportAdapter
 
Checkin(Address, ThrottlerHandle) - Constructor for class akka.remote.transport.ThrottlerManager.Checkin
 
Checkin$() - Constructor for class akka.remote.transport.ThrottlerManager.Checkin$
 
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;
CLASSES_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.PropsData
 
CLAZZ_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.PropsData
 
clear() - Method in class akka.remote.ContainerFormats.Selection.Builder
 
clear() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.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
 
clearAck() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .AcknowledgementInfo ack = 1;
clearArgs() - Method in class akka.remote.WireFormats.PropsData.Builder
repeated bytes args = 4;
clearClasses() - Method in class akka.remote.WireFormats.PropsData.Builder
repeated string classes = 5;
clearClazz() - Method in class akka.remote.WireFormats.PropsData.Builder
required string clazz = 3;
clearCommandType() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
required .CommandType commandType = 1;
clearConfig() - Method in class akka.remote.WireFormats.DeployData.Builder
optional bytes config = 2;
clearCookie() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
optional string cookie = 3;
clearCumulativeAck() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
required fixed64 cumulativeAck = 1;
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;
clearDispatcher() - Method in class akka.remote.WireFormats.DeployData.Builder
optional string dispatcher = 5;
clearEnclosedMessage() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
required bytes enclosedMessage = 1;
clearEnvelope() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .RemoteEnvelope envelope = 2;
clearHandshakeInfo() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
optional .AkkaHandshakeInfo handshakeInfo = 2;
clearHostname() - Method in class akka.remote.WireFormats.AddressData.Builder
required string hostname = 2;
clearInstruction() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
optional .AkkaControlMessage instruction = 2;
clearLog() - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Clears the activity log.
clearMatcher() - Method in class akka.remote.ContainerFormats.Selection.Builder
optional string matcher = 2;
clearMessage() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
required .SerializedMessage message = 2;
clearMessage() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
required bytes message = 1;
clearMessageManifest() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
optional bytes messageManifest = 4;
clearMessageManifest() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
optional bytes messageManifest = 3;
clearNacks() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
repeated fixed64 nacks = 2;
clearOrigin() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
required .AddressData origin = 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.remote.WireFormats.AkkaProtocolMessage.Builder
optional bytes payload = 1;
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.remote.WireFormats.AddressData.Builder
optional string protocol = 4;
clearRecipient() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
required .ActorRefData recipient = 1;
clearRouterConfig() - Method in class akka.remote.WireFormats.DeployData.Builder
optional bytes routerConfig = 3;
clearScope() - Method in class akka.remote.WireFormats.DeployData.Builder
optional bytes scope = 4;
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;
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;
clearSupervisor() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .ActorRefData supervisor = 4;
clearSystem() - Method in class akka.remote.WireFormats.AddressData.Builder
required string system = 1;
clearType() - Method in class akka.remote.ContainerFormats.Selection.Builder
required .PatternType type = 1;
clearUid() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
required fixed64 uid = 2;
clearWildcardFanOut() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
optional bool wildcardFanOut = 5;
ClientHandler - Class in akka.remote.transport.netty
INTERNAL API
ClientHandler(NettyTransport, Address) - Constructor for class akka.remote.transport.netty.ClientHandler
 
ClientSocketWorkerPoolSize() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
Clock() - Constructor for class akka.remote.FailureDetector.Clock
 
clone() - Method in class akka.remote.ContainerFormats.Selection.Builder
 
clone() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.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
 
Closed$() - Constructor for class akka.remote.transport.ProtocolStateActor.Closed$
 
cmd() - Method in class akka.remote.EndpointManager.ManagementCommand
 
codec() - Method in class akka.remote.EndpointActor
 
codec() - Method in class akka.remote.ReliableDeliverySupervisor
 
CommandAckTimeout() - Method in class akka.remote.RemoteSettings
 
COMMANDTYPE_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AkkaControlMessage
 
CommonHandlers - Interface in akka.remote.transport.netty
INTERNAL API
compare(SeqNo) - Method in class akka.remote.SeqNo
 
config() - Method in class akka.remote.RemoteSettings
 
CONFIG_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DeployData
 
configureDispatcher(Props) - Method in class akka.remote.RARP
 
configureDispatcher(Props) - Method in class akka.remote.RemoteSettings
 
ConnectionTimeout() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
constructAssociate(HandshakeInfo) - Method in interface akka.remote.transport.AkkaPduCodec
 
constructAssociate(HandshakeInfo) - Method in class akka.remote.transport.AkkaPduProtobufCodec$
 
constructAssociate(HandshakeInfo) - Static method in class akka.remote.transport.AkkaPduProtobufCodec
 
constructDisassociate(AssociationHandle.DisassociateInfo) - Method in interface akka.remote.transport.AkkaPduCodec
 
constructDisassociate(AssociationHandle.DisassociateInfo) - Method in class akka.remote.transport.AkkaPduProtobufCodec$
 
constructDisassociate(AssociationHandle.DisassociateInfo) - Static method in class akka.remote.transport.AkkaPduProtobufCodec
 
constructHeartbeat() - Method in interface akka.remote.transport.AkkaPduCodec
 
constructHeartbeat() - Method in class akka.remote.transport.AkkaPduProtobufCodec$
 
constructHeartbeat() - Static method in class akka.remote.transport.AkkaPduProtobufCodec
 
constructMessage(Address, ActorRef, WireFormats.SerializedMessage, Option<ActorRef>, Option<SeqNo>, Option<Ack>) - Method in interface akka.remote.transport.AkkaPduCodec
 
constructMessage(Address, ActorRef, WireFormats.SerializedMessage, Option<ActorRef>, Option<SeqNo>, Option<Ack>) - Method in class akka.remote.transport.AkkaPduProtobufCodec$
 
constructMessage(Address, ActorRef, WireFormats.SerializedMessage, Option<ActorRef>, Option<SeqNo>, Option<Ack>) - Static method in class akka.remote.transport.AkkaPduProtobufCodec
 
constructPayload(ByteString) - Method in interface akka.remote.transport.AkkaPduCodec
 
constructPayload(ByteString) - Method in class akka.remote.transport.AkkaPduProtobufCodec$
 
constructPayload(ByteString) - Static method in class akka.remote.transport.AkkaPduProtobufCodec
 
constructPureAck(Ack) - Method in interface akka.remote.transport.AkkaPduCodec
 
constructPureAck(Ack) - Method in class akka.remote.transport.AkkaPduProtobufCodec$
 
constructPureAck(Ack) - Static method in class akka.remote.transport.AkkaPduProtobufCodec
 
ContainerFormats - Class in akka.remote
 
ContainerFormats.PatternType - Enum in akka.remote
Protobuf enum PatternType
ContainerFormats.Selection - Class in akka.remote
Protobuf type Selection
ContainerFormats.Selection.Builder - Class in akka.remote
Protobuf type Selection
ContainerFormats.SelectionEnvelope - Class in akka.remote
Protobuf type SelectionEnvelope
ContainerFormats.SelectionEnvelope.Builder - Class in akka.remote
Protobuf type SelectionEnvelope
ContainerFormats.SelectionEnvelopeOrBuilder - Interface in akka.remote
 
ContainerFormats.SelectionOrBuilder - Interface in akka.remote
 
cookie() - Method in class akka.remote.transport.HandshakeInfo
 
COOKIE_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AkkaHandshakeInfo
 
counts(int, int) - Method in class akka.remote.RemoteWatcher.Stats$
 
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.
createDeployer() - Method in class akka.remote.RemoteActorRefProvider
Factory method to make it possible to override deployer in subclass Creates a new instance every time
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.transport.TransportAdaptersExtension$
 
createExtension(ExtendedActorSystem) - Static method in class akka.remote.transport.TransportAdaptersExtension
 
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
 
createRemoteDeploymentWatcher(ActorSystemImpl) - Method in class akka.remote.RemoteActorRefProvider
 
createRemoteWatcher(ActorSystemImpl) - Method in class akka.remote.RemoteActorRefProvider
 
createRemoteWatcherFailureDetector(ExtendedActorSystem) - Method in class akka.remote.RemoteActorRefProvider
 
createRouter(ActorSystem) - Method in class akka.remote.routing.RemoteRouterConfig
 
createRouterActor() - Method in class akka.remote.routing.RemoteRouterConfig
 
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
 
currentHandle() - Method in class akka.remote.ReliableDeliverySupervisor
 

D

DaemonMsg - Interface in akka.remote
INTERNAL API
DaemonMsgCreate - Class in akka.remote
INTERNAL API
DaemonMsgCreate(Props, Deploy, String, ActorRef) - Constructor for class akka.remote.DaemonMsgCreate
 
DaemonMsgCreate$ - Class in akka.remote
 
DaemonMsgCreate$() - Constructor for class akka.remote.DaemonMsgCreate$
 
DaemonMsgCreateSerializer - Class in akka.remote.serialization
Serializes Akka's internal DaemonMsgCreate using protobuf for the core structure of DaemonMsgCreate, Props and Deploy.
DaemonMsgCreateSerializer(ExtendedActorSystem) - Constructor for class akka.remote.serialization.DaemonMsgCreateSerializer
 
DaemonMsgCreateSerializer() - Constructor for class akka.remote.serialization.DaemonMsgCreateSerializer
 
deadLetters() - Method in class akka.remote.RemoteActorRefProvider
 
DeadlineFailureDetector - Class in akka.remote
Implementation of failure detector using an absolute timeout of missing heartbeats to trigger unavailability.
DeadlineFailureDetector(FiniteDuration, FiniteDuration, FailureDetector.Clock) - Constructor for class akka.remote.DeadlineFailureDetector
 
DeadlineFailureDetector(Config, EventStream) - Constructor for class akka.remote.DeadlineFailureDetector
Constructor that reads parameters from config.
DeadlineFailureDetector(FiniteDuration, FailureDetector.Clock) - Constructor for class akka.remote.DeadlineFailureDetector
 
decodeMessage(ByteString, RemoteActorRefProvider, Address) - Method in interface akka.remote.transport.AkkaPduCodec
 
decodeMessage(ByteString, RemoteActorRefProvider, Address) - Method in class akka.remote.transport.AkkaPduProtobufCodec$
 
decodeMessage(ByteString, RemoteActorRefProvider, Address) - Static method in class akka.remote.transport.AkkaPduProtobufCodec
 
decodePdu(ByteString) - Method in interface akka.remote.transport.AkkaPduCodec
Returns an AkkaPduCodec.AkkaPdu instance that represents the PDU contained in the raw ByteString.
decodePdu(ByteString) - Method in class akka.remote.transport.AkkaPduProtobufCodec$
 
decodePdu(ByteString) - Static method in class akka.remote.transport.AkkaPduProtobufCodec
 
defaultAddress() - Method in class akka.remote.RemoteTransport
The default transport address of the ActorSystem
defaultAddress() - Method in class akka.remote.Remoting
 
defaultClock() - Method in class akka.remote.FailureDetector$
 
DefaultFailureDetectorRegistry<A> - Class in akka.remote
A lock-less thread-safe implementation of FailureDetectorRegistry.
DefaultFailureDetectorRegistry(Function0<FailureDetector>) - Constructor for class akka.remote.DefaultFailureDetectorRegistry
 
DefaultMessageDispatcher - Class in akka.remote
INTERNAL API
DefaultMessageDispatcher(ExtendedActorSystem, RemoteActorRefProvider, LoggingAdapter) - Constructor for class akka.remote.DefaultMessageDispatcher
 
deploy() - Method in class akka.remote.DaemonMsgCreate
 
DEPLOY_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DaemonMsgCreateData
 
DEPLOY_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.PropsData
 
deployer() - Method in class akka.remote.RemoteActorRefProvider
 
Dequeue$() - Constructor for class akka.remote.transport.ThrottledAssociation.Dequeue$
 
deregisterAssociation(Tuple2<Address, Address>) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Removes an association.
deserialize(ExtendedActorSystem, WireFormats.SerializedMessage) - Method in class akka.remote.MessageSerializer$
Uses Akka Serialization for the specified ActorSystem to transform the given MessageProtocol to a message
deserialize(ExtendedActorSystem, WireFormats.SerializedMessage) - Static method in class akka.remote.MessageSerializer
Uses Akka Serialization for the specified ActorSystem to transform the given MessageProtocol to a message
deserialize(Tuple2<ByteString, String>) - Method in class akka.remote.serialization.DaemonMsgCreateSerializer
 
deserialize(ByteString, Class<T>, ClassTag<T>) - Method in class akka.remote.serialization.DaemonMsgCreateSerializer
 
deserializeActorRef(ExtendedActorSystem, WireFormats.ActorRefData) - Method in class akka.remote.serialization.ProtobufSerializer$
Helper to materialize (lookup) an ActorRef from Akka's protobuf representation in the supplied ActorSystem.
deserializeActorRef(ExtendedActorSystem, WireFormats.ActorRefData) - Static method in class akka.remote.serialization.ProtobufSerializer
Helper to materialize (lookup) an ActorRef from Akka's protobuf representation in the supplied ActorSystem.
direction() - Method in class akka.remote.transport.ThrottlerTransportAdapter.SetThrottle
 
Direction$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.Direction$
 
Disassociate(AssociationHandle.DisassociateInfo) - Constructor for class akka.remote.transport.AkkaPduCodec.Disassociate
 
disassociate() - Method in class akka.remote.transport.AkkaProtocolHandle
 
disassociate(AssociationHandle.DisassociateInfo) - Method in class akka.remote.transport.AkkaProtocolHandle
 
disassociate() - Method in interface akka.remote.transport.AssociationHandle
Closes the underlying transport link, if needed.
disassociate() - Method in class akka.remote.transport.FailureInjectorHandle
 
disassociate() - Method in class akka.remote.transport.netty.TcpAssociationHandle
 
disassociate() - Method in class akka.remote.transport.netty.UdpAssociationHandle
 
disassociate() - Method in class akka.remote.transport.TestAssociationHandle
 
disassociate(TestAssociationHandle) - Method in class akka.remote.transport.TestTransport
 
disassociate() - Method in class akka.remote.transport.ThrottlerHandle
 
Disassociate$() - Constructor for class akka.remote.transport.AkkaPduCodec.Disassociate$
 
DISASSOCIATE_QUARANTINED_VALUE - Static variable in enum akka.remote.WireFormats.CommandType
DISASSOCIATE_QUARANTINED = 5;
DISASSOCIATE_SHUTTING_DOWN_VALUE - Static variable in enum akka.remote.WireFormats.CommandType
DISASSOCIATE_SHUTTING_DOWN = 4;
DISASSOCIATE_VALUE - Static variable in enum akka.remote.WireFormats.CommandType
DISASSOCIATE = 2;
DisassociateAttempt(Address, Address) - Constructor for class akka.remote.transport.TestTransport.DisassociateAttempt
 
DisassociateAttempt$() - Constructor for class akka.remote.transport.TestTransport.DisassociateAttempt$
 
disassociateBehavior() - Method in class akka.remote.transport.TestTransport
The TestTransport.SwitchableLoggedBehavior for the disassociate() method on handles.
Disassociated(AssociationHandle.DisassociateInfo) - Constructor for class akka.remote.transport.AssociationHandle.Disassociated
 
Disassociated$() - Constructor for class akka.remote.transport.AssociationHandle.Disassociated$
 
DisassociatedEvent - Class in akka.remote
 
DisassociatedEvent(Address, Address, boolean) - Constructor for class akka.remote.DisassociatedEvent
 
DisassociatedEvent$ - Class in akka.remote
 
DisassociatedEvent$() - Constructor for class akka.remote.DisassociatedEvent$
 
DisassociateUnderlying(AssociationHandle.DisassociateInfo) - Constructor for class akka.remote.transport.ActorTransportAdapter.DisassociateUnderlying
 
DisassociateUnderlying$() - Constructor for class akka.remote.transport.ActorTransportAdapter.DisassociateUnderlying$
 
disassociateWithFailure(AssociationHandle.DisassociateInfo) - Method in class akka.remote.transport.ThrottlerHandle
 
dispatch(InternalActorRef, Address, WireFormats.SerializedMessage, Option<ActorRef>) - Method in class akka.remote.DefaultMessageDispatcher
 
dispatch(InternalActorRef, Address, WireFormats.SerializedMessage, Option<ActorRef>) - Method in interface akka.remote.InboundMessageDispatcher
 
Dispatcher() - Method in class akka.remote.RemoteSettings
 
DISPATCHER_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DeployData
 
Drop(double, double) - Constructor for class akka.remote.transport.FailureInjectorTransportAdapter.Drop
 
Drop$() - Constructor for class akka.remote.transport.FailureInjectorTransportAdapter.Drop$
 
dynamicAccess() - Method in class akka.remote.RemoteActorRefProvider
 

E

ec() - Method in class akka.remote.transport.AbstractTransportAdapter
 
empty() - Method in class akka.remote.RemoteWatcher.Stats$
 
EnableSsl() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
ENCLOSEDMESSAGE_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.SelectionEnvelope
 
encodePdu(AkkaPduCodec.AkkaPdu) - Method in interface akka.remote.transport.AkkaPduCodec
Takes an AkkaPduCodec.AkkaPdu representation of an Akka PDU and returns its encoded form as a ByteString.
endpoint() - Method in class akka.remote.EndpointManager.Pass
 
EndpointActor - Class in akka.remote
INTERNAL API
EndpointActor(Address, Address, Transport, RemoteSettings, AkkaPduCodec) - Constructor for class akka.remote.EndpointActor
 
EndpointAssociationException - Exception in akka.remote
INTERNAL API
EndpointAssociationException(String, Throwable) - Constructor for exception akka.remote.EndpointAssociationException
 
EndpointDisassociatedException - Exception in akka.remote
INTERNAL API
EndpointDisassociatedException(String) - Constructor for exception akka.remote.EndpointDisassociatedException
 
EndpointException - Exception in akka.remote
INTERNAL API
EndpointException(String, Throwable) - Constructor for exception akka.remote.EndpointException
 
EndpointException(String) - Constructor for exception akka.remote.EndpointException
 
endpointId() - Method in class akka.remote.EndpointManager
 
EndpointManager - Class in akka.remote
INTERNAL API
EndpointManager(Config, LoggingAdapter) - Constructor for class akka.remote.EndpointManager
 
EndpointManager$ - Class in akka.remote
INTERNAL API
EndpointManager$() - Constructor for class akka.remote.EndpointManager$
 
EndpointManager.EndpointPolicy - Interface in akka.remote
 
EndpointManager.EndpointRegistry - Class in akka.remote
 
EndpointManager.Gated - Class in akka.remote
 
EndpointManager.Gated$ - Class in akka.remote
 
EndpointManager.Link - Class in akka.remote
 
EndpointManager.Link$ - Class in akka.remote
 
EndpointManager.Listen - Class in akka.remote
 
EndpointManager.Listen$ - Class in akka.remote
 
EndpointManager.ListensFailure - Class in akka.remote
 
EndpointManager.ListensFailure$ - Class in akka.remote
 
EndpointManager.ListensResult - Class in akka.remote
 
EndpointManager.ListensResult$ - Class in akka.remote
 
EndpointManager.ManagementCommand - Class in akka.remote
 
EndpointManager.ManagementCommand$ - Class in akka.remote
 
EndpointManager.ManagementCommandAck - Class in akka.remote
 
EndpointManager.ManagementCommandAck$ - Class in akka.remote
 
EndpointManager.Pass - Class in akka.remote
 
EndpointManager.Pass$ - Class in akka.remote
 
EndpointManager.Prune$ - Class in akka.remote
 
EndpointManager.Quarantine - Class in akka.remote
 
EndpointManager.Quarantine$ - Class in akka.remote
 
EndpointManager.Quarantined - Class in akka.remote
 
EndpointManager.Quarantined$ - Class in akka.remote
 
EndpointManager.RemotingCommand - Interface in akka.remote
 
EndpointManager.ResendState - Class in akka.remote
 
EndpointManager.ResendState$ - Class in akka.remote
 
EndpointManager.Send - Class in akka.remote
 
EndpointManager.Send$ - Class in akka.remote
 
EndpointManager.ShutdownAndFlush$ - Class in akka.remote
 
EndpointManager.StartupFinished$ - Class in akka.remote
 
EndpointManagerName() - Method in class akka.remote.Remoting$
 
EndpointManagerName() - Static method in class akka.remote.Remoting
 
EndpointReader - Class in akka.remote
INTERNAL API
EndpointReader(Address, Address, Transport, RemoteSettings, AkkaPduCodec, InboundMessageDispatcher, boolean, int, Option<ActorRef>, ConcurrentHashMap<EndpointManager.Link, EndpointManager.ResendState>) - Constructor for class akka.remote.EndpointReader
 
EndpointReader$ - Class in akka.remote
INTERNAL API
EndpointReader$() - Constructor for class akka.remote.EndpointReader$
 
EndpointRegistry() - Constructor for class akka.remote.EndpointManager.EndpointRegistry
 
endpoints() - Method in class akka.remote.EndpointManager
 
EndpointWriter - Class in akka.remote
INTERNAL API
EndpointWriter(Option<AkkaProtocolHandle>, Address, Address, Option<Object>, AkkaProtocolTransport, RemoteSettings, AkkaPduCodec, ConcurrentHashMap<EndpointManager.Link, EndpointManager.ResendState>, Option<ActorRef>) - Constructor for class akka.remote.EndpointWriter
 
EndpointWriter$ - Class in akka.remote
INTERNAL API
EndpointWriter$() - Constructor for class akka.remote.EndpointWriter$
 
EndpointWriter.AckIdleCheckTimer$ - Class in akka.remote
 
EndpointWriter.BackoffTimer$ - Class in akka.remote
 
EndpointWriter.FlushAndStop$ - Class in akka.remote
 
EndpointWriter.Handle - Class in akka.remote
 
EndpointWriter.Handle$ - Class in akka.remote
 
EndpointWriter.OutboundAck - Class in akka.remote
 
EndpointWriter.OutboundAck$ - Class in akka.remote
 
EndpointWriter.StoppedReading - Class in akka.remote
 
EndpointWriter.StoppedReading$ - Class in akka.remote
 
EndpointWriter.StopReading - Class in akka.remote
 
EndpointWriter.StopReading$ - Class in akka.remote
 
EndpointWriter.TakeOver - Class in akka.remote
This message signals that the current association maintained by the local EndpointWriter and EndpointReader is to be overridden by a new inbound association.
EndpointWriter.TakeOver$ - Class in akka.remote
 
EndpointWriter.TookOver - Class in akka.remote
 
EndpointWriter.TookOver$ - Class in akka.remote
 
engineGenerateSeed(int) - Method in class akka.remote.security.provider.AES128CounterInetRNG
Unused method Returns the given number of seed bytes.
engineGenerateSeed(int) - Method in class akka.remote.security.provider.AES128CounterSecureRNG
Unused method Returns the given number of seed bytes.
engineGenerateSeed(int) - Method in class akka.remote.security.provider.AES256CounterInetRNG
Unused method Returns the given number of seed bytes.
engineGenerateSeed(int) - Method in class akka.remote.security.provider.AES256CounterSecureRNG
Unused method Returns the given number of seed bytes.
engineNextBytes(byte[]) - Method in class akka.remote.security.provider.AES128CounterInetRNG
Generates a user-specified number of random bytes.
engineNextBytes(byte[]) - Method in class akka.remote.security.provider.AES128CounterSecureRNG
Generates a user-specified number of random bytes.
engineNextBytes(byte[]) - Method in class akka.remote.security.provider.AES256CounterInetRNG
Generates a user-specified number of random bytes.
engineNextBytes(byte[]) - Method in class akka.remote.security.provider.AES256CounterSecureRNG
Generates a user-specified number of random bytes.
engineSetSeed(byte[]) - Method in class akka.remote.security.provider.AES128CounterInetRNG
This is managed internally by AESCounterRNG
engineSetSeed(byte[]) - Method in class akka.remote.security.provider.AES128CounterSecureRNG
This is managed internally by AESCounterRNG
engineSetSeed(byte[]) - Method in class akka.remote.security.provider.AES256CounterInetRNG
This is managed internally by AESCounterRNG
engineSetSeed(byte[]) - Method in class akka.remote.security.provider.AES256CounterSecureRNG
This is managed internally by AESCounterRNG
enqueueInBuffer(Object) - Method in class akka.remote.EndpointWriter
 
ENVELOPE_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
errorMessage() - Method in class akka.remote.transport.ProtocolStateActor.TimeoutReason
 
eventName() - Method in class akka.remote.AssociatedEvent
 
eventName() - Method in class akka.remote.AssociationErrorEvent
 
eventName() - Method in interface akka.remote.AssociationEvent
 
eventName() - Method in class akka.remote.DisassociatedEvent
 
eventPublisher() - Method in class akka.remote.EndpointActor
 
eventPublisher() - Method in class akka.remote.EndpointManager
 
EventPublisher - Class in akka.remote
INTERNAL API
EventPublisher(ActorSystem, LoggingAdapter, Logging.LogLevel) - Constructor for class akka.remote.EventPublisher
 
eventPublisher() - Method in class akka.remote.Remoting
 
eventStream() - Method in class akka.remote.RemoteActorRefProvider
 
exceptionCaught(ChannelHandlerContext, ExceptionEvent) - Method in interface akka.remote.transport.netty.NettyClientHelpers
 
exceptionCaught(ChannelHandlerContext, ExceptionEvent) - Method in interface akka.remote.transport.netty.NettyServerHelpers
 
executionContext() - Method in class akka.remote.transport.netty.NettyTransport
 
existsAssociation(Address, Address) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Tests if an association was registered.
ExpectedFirstHeartbeat(Address) - Constructor for class akka.remote.RemoteWatcher.ExpectedFirstHeartbeat
 
ExpectedFirstHeartbeat$() - Constructor for class akka.remote.RemoteWatcher.ExpectedFirstHeartbeat$
 
ExposedHandle(ThrottlerHandle) - Constructor for class akka.remote.transport.ThrottledAssociation.ExposedHandle
 
ExposedHandle$() - Constructor for class akka.remote.transport.ThrottledAssociation.ExposedHandle$
 
extendedSystem() - Method in class akka.remote.EndpointManager
 
extendedSystem() - Method in class akka.remote.EndpointWriter
 
extendedSystem() - Method in class akka.remote.transport.FailureInjectorTransportAdapter
 
extractDeliverable() - Method in class akka.remote.AckedReceiveBuffer
Extract all messages that could be safely delivered, an updated ack to be sent to the sender(), and an updated buffer that has the messages removed that can be delivered.

F

failureDetector(A) - Method in class akka.remote.DefaultFailureDetectorRegistry
INTERNAL API Get the underlying FailureDetector for a resource.
FailureDetector - Interface in akka.remote
A failure detector must be a thread-safe mutable construct that registers heartbeat events of a resource and is able to decide the availability of that monitored resource.
FailureDetector$ - Class in akka.remote
 
FailureDetector$() - Constructor for class akka.remote.FailureDetector$
 
FailureDetector.Clock - Class in akka.remote
Abstraction of a clock that returns time in milliseconds.
FailureDetectorLoader - Class in akka.remote
INTERNAL API
FailureDetectorLoader() - Constructor for class akka.remote.FailureDetectorLoader
 
FailureDetectorLoader$ - Class in akka.remote
INTERNAL API
FailureDetectorLoader$() - Constructor for class akka.remote.FailureDetectorLoader$
 
failureDetectorReaperTask() - Method in class akka.remote.RemoteWatcher
 
FailureDetectorRegistry<A> - Interface in akka.remote
Interface for a registry of Akka failure detectors.
FailureInjectorException - Exception in akka.remote.transport
 
FailureInjectorException(String) - Constructor for exception akka.remote.transport.FailureInjectorException
 
FailureInjectorException$ - Class in akka.remote.transport
 
FailureInjectorException$() - Constructor for class akka.remote.transport.FailureInjectorException$
 
FailureInjectorHandle - Class in akka.remote.transport
INTERNAL API
FailureInjectorHandle(AssociationHandle, FailureInjectorTransportAdapter) - Constructor for class akka.remote.transport.FailureInjectorHandle
 
FailureInjectorHandle$ - Class in akka.remote.transport
 
FailureInjectorHandle$() - Constructor for class akka.remote.transport.FailureInjectorHandle$
 
FailureInjectorProvider - Class in akka.remote.transport
 
FailureInjectorProvider() - Constructor for class akka.remote.transport.FailureInjectorProvider
 
FailureInjectorSchemeIdentifier() - Method in class akka.remote.transport.FailureInjectorTransportAdapter$
 
FailureInjectorSchemeIdentifier() - Static method in class akka.remote.transport.FailureInjectorTransportAdapter
 
FailureInjectorTransportAdapter - Class in akka.remote.transport
INTERNAL API
FailureInjectorTransportAdapter(Transport, ExtendedActorSystem) - Constructor for class akka.remote.transport.FailureInjectorTransportAdapter
 
FailureInjectorTransportAdapter$ - Class in akka.remote.transport
INTERNAL API
FailureInjectorTransportAdapter$() - Constructor for class akka.remote.transport.FailureInjectorTransportAdapter$
 
FailureInjectorTransportAdapter.All - Class in akka.remote.transport
 
FailureInjectorTransportAdapter.All$ - Class in akka.remote.transport
 
FailureInjectorTransportAdapter.Drop - Class in akka.remote.transport
 
FailureInjectorTransportAdapter.Drop$ - Class in akka.remote.transport
 
FailureInjectorTransportAdapter.FailureInjectorCommand - Interface in akka.remote.transport
 
FailureInjectorTransportAdapter.GremlinMode - Interface in akka.remote.transport
 
FailureInjectorTransportAdapter.One - Class in akka.remote.transport
 
FailureInjectorTransportAdapter.One$ - Class in akka.remote.transport
 
FailureInjectorTransportAdapter.PassThru$ - Class in akka.remote.transport
 
FailWith(AssociationHandle.DisassociateInfo) - Constructor for class akka.remote.transport.ThrottledAssociation.FailWith
 
FailWith$() - Constructor for class akka.remote.transport.ThrottledAssociation.FailWith$
 
Finished$() - Constructor for class akka.remote.RemoteActorRefProvider.Finished$
 
firstHeartbeatEstimate() - Method in class akka.remote.PhiAccrualFailureDetector
 
flushAndStop() - Method in class akka.remote.EndpointWriter
 
FlushAndStop$() - Constructor for class akka.remote.EndpointWriter.FlushAndStop$
 
flushing() - Method in class akka.remote.EndpointManager
 
flushWait() - Method in class akka.remote.ReliableDeliverySupervisor
 
FlushWait() - Method in class akka.remote.RemoteSettings
 
ForbiddenUidReason$() - Constructor for class akka.remote.transport.ProtocolStateActor.ForbiddenUidReason$
 
ForceDisassociate(Address) - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociate
 
ForceDisassociate$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociate$
 
ForceDisassociateAck$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociateAck$
 
ForceDisassociateExplicitly(Address, AssociationHandle.DisassociateInfo) - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociateExplicitly
 
ForceDisassociateExplicitly$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociateExplicitly$
 
forwardOrDelay(ByteString) - Method in class akka.remote.transport.ThrottledAssociation
 
FrameLengthFieldLength() - Method in class akka.remote.transport.netty.NettyTransport$
 
FrameLengthFieldLength() - Static method in class akka.remote.transport.netty.NettyTransport
 
from() - Method in class akka.remote.RemoteWatcher.ExpectedFirstHeartbeat
 
fromBinary(byte[], Option<Class<?>>) - Method in class akka.remote.serialization.DaemonMsgCreateSerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in class akka.remote.serialization.MessageContainerSerializer
 
fromBinary(byte[], Option<Class<?>>) - Method in class akka.remote.serialization.ProtobufSerializer
 
fullBackoff() - Method in class akka.remote.EndpointWriter
 
fullBackoffCount() - Method in class akka.remote.EndpointWriter
 

G

Gated(Deadline) - Constructor for class akka.remote.EndpointManager.Gated
 
gated() - Method in class akka.remote.ReliableDeliverySupervisor
 
Gated$() - Constructor for class akka.remote.EndpointManager.Gated$
 
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.
get(ActorSystem) - Method in class akka.remote.AddressUidExtension$
 
get(ActorSystem) - Static method in class akka.remote.AddressUidExtension
 
get(ActorSystem) - Method in class akka.remote.BoundAddressesExtension$
 
get(ActorSystem) - Static method in class akka.remote.BoundAddressesExtension
 
get(ActorSystem) - Method in class akka.remote.RemoteMetricsExtension$
 
get(ActorSystem) - Static method in class akka.remote.RemoteMetricsExtension
 
get(String) - Method in class akka.remote.transport.AssociationRegistry$
 
get(String) - Static method in class akka.remote.transport.AssociationRegistry
 
get(ActorSystem) - Method in class akka.remote.transport.TransportAdaptersExtension$
 
get(ActorSystem) - Static method in class akka.remote.transport.TransportAdaptersExtension
 
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;
getAdapterProvider(String) - Method in class akka.remote.transport.TransportAdapters
 
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;
getCause() - Method in class akka.remote.AssociationErrorEvent
 
getCause() - Method in class akka.remote.RemotingErrorEvent
 
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).
getClasses(int) - Method in class akka.remote.WireFormats.PropsData.Builder
repeated string classes = 5;
getClasses(int) - Method in class akka.remote.WireFormats.PropsData
repeated string classes = 5;
getClasses(int) - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
repeated string classes = 5;
getClassesBytes(int) - Method in class akka.remote.WireFormats.PropsData.Builder
repeated string classes = 5;
getClassesBytes(int) - Method in class akka.remote.WireFormats.PropsData
repeated string classes = 5;
getClassesBytes(int) - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
repeated string classes = 5;
getClassesCount() - Method in class akka.remote.WireFormats.PropsData.Builder
repeated string classes = 5;
getClassesCount() - Method in class akka.remote.WireFormats.PropsData
repeated string classes = 5;
getClassesCount() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
repeated string classes = 5;
getClassesList() - Method in class akka.remote.WireFormats.PropsData.Builder
repeated string classes = 5;
getClassesList() - Method in class akka.remote.WireFormats.PropsData
repeated string classes = 5;
getClassesList() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
repeated string classes = 5;
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;
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() - 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;
getCookie() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
optional string cookie = 3;
getCookie() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
optional string cookie = 3;
getCookie() - Method in interface akka.remote.WireFormats.AkkaHandshakeInfoOrBuilder
optional string cookie = 3;
getCookieBytes() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
optional string cookie = 3;
getCookieBytes() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
optional string cookie = 3;
getCookieBytes() - Method in interface akka.remote.WireFormats.AkkaHandshakeInfoOrBuilder
optional string cookie = 3;
getCumulativeAck() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
required fixed64 cumulativeAck = 1;
getCumulativeAck() - Method in class akka.remote.WireFormats.AcknowledgementInfo
required fixed64 cumulativeAck = 1;
getCumulativeAck() - Method in interface akka.remote.WireFormats.AcknowledgementInfoOrBuilder
required fixed64 cumulativeAck = 1;
getDefaultAddress() - Method in class akka.remote.RemoteActorRefProvider
 
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.WireFormats.AckAndEnvelopeContainer
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.ActorRefData
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.AddressData
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.DeployData
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.PropsData
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
getDefaultInstance() - Static method in class akka.remote.WireFormats.SerializedMessage
 
getDefaultInstanceForType() - Method in class akka.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.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
 
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.remote.ContainerFormats
 
getDescriptor() - Static method in enum akka.remote.ContainerFormats.PatternType
 
getDescriptor() - Static method in class akka.remote.ContainerFormats.Selection.Builder
 
getDescriptor() - Static method in class akka.remote.ContainerFormats.Selection
 
getDescriptor() - Static method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
getDescriptor() - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
getDescriptor() - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
getDescriptor() - Static method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
getDescriptor() - Static method in class akka.remote.WireFormats.ActorRefData.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.ActorRefData
 
getDescriptor() - Static method in class akka.remote.WireFormats.AddressData.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.AddressData
 
getDescriptor() - Static method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
getDescriptor() - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
getDescriptor() - Static method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
getDescriptor() - Static method in enum akka.remote.WireFormats.CommandType
 
getDescriptor() - Static method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
getDescriptor() - Static method in class akka.remote.WireFormats.DeployData.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.DeployData
 
getDescriptor() - Static method in class akka.remote.WireFormats
 
getDescriptor() - Static method in class akka.remote.WireFormats.PropsData.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.PropsData
 
getDescriptor() - Static method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
getDescriptor() - Static method in class akka.remote.WireFormats.SerializedMessage.Builder
 
getDescriptor() - Static method in class akka.remote.WireFormats.SerializedMessage
 
getDescriptorForType() - Method in enum akka.remote.ContainerFormats.PatternType
 
getDescriptorForType() - Method in class akka.remote.ContainerFormats.Selection.Builder
 
getDescriptorForType() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
getDescriptorForType() - Method in class akka.remote.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
 
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;
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;
getEnvelope() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .RemoteEnvelope envelope = 2;
getEnvelope() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
optional .RemoteEnvelope envelope = 2;
getEnvelope() - Method in interface akka.remote.WireFormats.AckAndEnvelopeContainerOrBuilder
optional .RemoteEnvelope envelope = 2;
getEnvelopeBuilder() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .RemoteEnvelope envelope = 2;
getEnvelopeOrBuilder() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .RemoteEnvelope envelope = 2;
getEnvelopeOrBuilder() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
optional .RemoteEnvelope envelope = 2;
getEnvelopeOrBuilder() - Method in interface akka.remote.WireFormats.AckAndEnvelopeContainerOrBuilder
optional .RemoteEnvelope envelope = 2;
getExternalAddressFor(Address) - Method in class akka.remote.RemoteActorRefProvider
 
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;
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.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;
getInstance() - Method in class akka.remote.security.provider.InternetSeedGenerator$
 
getInstance() - Static method in class akka.remote.security.provider.InternetSeedGenerator
 
getInstance() - Method in class akka.remote.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
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;
getListenAddresses() - Method in class akka.remote.RemotingListenEvent
 
getLocalAddress() - Method in interface akka.remote.AssociationEvent
 
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;
getMessage() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
required .SerializedMessage message = 2;
getMessage() - Method in class akka.remote.WireFormats.RemoteEnvelope
required .SerializedMessage message = 2;
getMessage() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
required .SerializedMessage message = 2;
getMessage() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
required bytes message = 1;
getMessage() - Method in class akka.remote.WireFormats.SerializedMessage
required bytes message = 1;
getMessage() - Method in interface akka.remote.WireFormats.SerializedMessageOrBuilder
required bytes message = 1;
getMessageBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
required .SerializedMessage message = 2;
getMessageManifest() - Method in class akka.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;
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;
getNumber() - Method in enum akka.remote.ContainerFormats.PatternType
 
getNumber() - Method in enum akka.remote.WireFormats.CommandType
 
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;
getParent() - Method in class akka.remote.RemoteActorRef
 
getParserForType() - Method in class akka.remote.ContainerFormats.Selection
 
getParserForType() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
getParserForType() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
getParserForType() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
getParserForType() - Method in class akka.remote.WireFormats.ActorRefData
 
getParserForType() - Method in class akka.remote.WireFormats.AddressData
 
getParserForType() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
getParserForType() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
getParserForType() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
getParserForType() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
getParserForType() - Method in class akka.remote.WireFormats.DeployData
 
getParserForType() - Method in class akka.remote.WireFormats.PropsData
 
getParserForType() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
getParserForType() - Method in class akka.remote.WireFormats.SerializedMessage
 
getPath() - Method in class akka.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.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;
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.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;
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;
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.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.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;
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;
getRemoteAddress() - Method in interface akka.remote.AssociationEvent
 
getRemoteReadHandlerFor(TestAssociationHandle) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Returns the event handler corresponding to the remote endpoint of the given local handle.
getRouterConfig() - Method in class akka.remote.WireFormats.DeployData.Builder
optional bytes routerConfig = 3;
getRouterConfig() - Method in class akka.remote.WireFormats.DeployData
optional bytes routerConfig = 3;
getRouterConfig() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
optional bytes routerConfig = 3;
getScope() - Method in class akka.remote.WireFormats.DeployData.Builder
optional bytes scope = 4;
getScope() - Method in class akka.remote.WireFormats.DeployData
optional bytes scope = 4;
getScope() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
optional bytes scope = 4;
getSender() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
optional .ActorRefData sender = 4;
getSender() - Method in class akka.remote.WireFormats.RemoteEnvelope
optional .ActorRefData sender = 4;
getSender() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
optional .ActorRefData sender = 4;
getSenderBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
optional .ActorRefData sender = 4;
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;
getSerializedSize() - Method in class akka.remote.ContainerFormats.Selection
 
getSerializedSize() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
getSerializedSize() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
getSerializedSize() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
getSerializedSize() - Method in class akka.remote.WireFormats.ActorRefData
 
getSerializedSize() - Method in class akka.remote.WireFormats.AddressData
 
getSerializedSize() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
getSerializedSize() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
getSerializedSize() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
getSerializedSize() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
getSerializedSize() - Method in class akka.remote.WireFormats.DeployData
 
getSerializedSize() - Method in class akka.remote.WireFormats.PropsData
 
getSerializedSize() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
getSerializedSize() - Method in class akka.remote.WireFormats.SerializedMessage
 
getSerializerId() - Method in class akka.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;
getSupervisor() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .ActorRefData supervisor = 4;
getSupervisor() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
required .ActorRefData supervisor = 4;
getSupervisor() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
required .ActorRefData supervisor = 4;
getSupervisorBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .ActorRefData supervisor = 4;
getSupervisorOrBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .ActorRefData supervisor = 4;
getSupervisorOrBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
required .ActorRefData supervisor = 4;
getSupervisorOrBuilder() - Method in interface akka.remote.WireFormats.DaemonMsgCreateDataOrBuilder
required .ActorRefData supervisor = 4;
getSystem() - Method in class akka.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;
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;
getType() - Method in class akka.remote.ContainerFormats.Selection.Builder
required .PatternType type = 1;
getType() - Method in class akka.remote.ContainerFormats.Selection
required .PatternType type = 1;
getType() - Method in interface akka.remote.ContainerFormats.SelectionOrBuilder
required .PatternType type = 1;
getUid() - Method in class akka.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;
getUnknownFields() - Method in class akka.remote.ContainerFormats.Selection
 
getUnknownFields() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
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
 
getValueDescriptor() - Method in enum akka.remote.ContainerFormats.PatternType
 
getValueDescriptor() - Method in enum akka.remote.WireFormats.CommandType
 
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;
GotUid(int, Address) - Constructor for class akka.remote.ReliableDeliverySupervisor.GotUid
 
GotUid$() - Constructor for class akka.remote.ReliableDeliverySupervisor.GotUid$
 
gracefulClose(Channel, ExecutionContext) - Method in class akka.remote.transport.netty.NettyTransport$
 
gracefulClose(Channel, ExecutionContext) - Static method in class akka.remote.transport.netty.NettyTransport
 
guardian() - Method in class akka.remote.RemoteActorRefProvider
 

H

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$
 
handleInboundAssociation(Transport.InboundAssociation, boolean) - Method in class akka.remote.EndpointManager
 
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$
 
handleStashedInbound(ActorRef, boolean) - Method in class akka.remote.EndpointManager
 
handoff() - Method in class akka.remote.EndpointWriter
 
handshakeInfo() - Method in class akka.remote.transport.AkkaProtocolHandle
 
HandshakeInfo - Class in akka.remote.transport
 
HandshakeInfo(Address, int, Option<String>) - Constructor for class akka.remote.transport.HandshakeInfo
 
HandshakeInfo$ - Class in akka.remote.transport
 
HandshakeInfo$() - Constructor for class akka.remote.transport.HandshakeInfo$
 
HANDSHAKEINFO_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AkkaControlMessage
 
hasAck() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .AcknowledgementInfo ack = 1;
hasAck() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
optional .AcknowledgementInfo ack = 1;
hasAck() - Method in interface akka.remote.WireFormats.AckAndEnvelopeContainerOrBuilder
optional .AcknowledgementInfo ack = 1;
hasClazz() - Method in class akka.remote.WireFormats.PropsData.Builder
required string clazz = 3;
hasClazz() - Method in class akka.remote.WireFormats.PropsData
required string clazz = 3;
hasClazz() - Method in interface akka.remote.WireFormats.PropsDataOrBuilder
required string clazz = 3;
hasCommandType() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
required .CommandType commandType = 1;
hasCommandType() - Method in class akka.remote.WireFormats.AkkaControlMessage
required .CommandType commandType = 1;
hasCommandType() - Method in interface akka.remote.WireFormats.AkkaControlMessageOrBuilder
required .CommandType commandType = 1;
hasConfig() - Method in class akka.remote.WireFormats.DeployData.Builder
optional bytes config = 2;
hasConfig() - Method in class akka.remote.WireFormats.DeployData
optional bytes config = 2;
hasConfig() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
optional bytes config = 2;
hasCookie() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
optional string cookie = 3;
hasCookie() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
optional string cookie = 3;
hasCookie() - Method in interface akka.remote.WireFormats.AkkaHandshakeInfoOrBuilder
optional string cookie = 3;
hasCumulativeAck() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
required fixed64 cumulativeAck = 1;
hasCumulativeAck() - Method in class akka.remote.WireFormats.AcknowledgementInfo
required fixed64 cumulativeAck = 1;
hasCumulativeAck() - Method in interface akka.remote.WireFormats.AcknowledgementInfoOrBuilder
required fixed64 cumulativeAck = 1;
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;
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;
hasEnclosedMessage() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
required bytes enclosedMessage = 1;
hasEnclosedMessage() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
required bytes enclosedMessage = 1;
hasEnclosedMessage() - Method in interface akka.remote.ContainerFormats.SelectionEnvelopeOrBuilder
required bytes enclosedMessage = 1;
hasEnvelope() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .RemoteEnvelope envelope = 2;
hasEnvelope() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
optional .RemoteEnvelope envelope = 2;
hasEnvelope() - Method in interface akka.remote.WireFormats.AckAndEnvelopeContainerOrBuilder
optional .RemoteEnvelope envelope = 2;
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;
hasHostname() - Method in class akka.remote.WireFormats.AddressData.Builder
required string hostname = 2;
hasHostname() - Method in class akka.remote.WireFormats.AddressData
required string hostname = 2;
hasHostname() - Method in interface akka.remote.WireFormats.AddressDataOrBuilder
required string hostname = 2;
hasInstruction() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
optional .AkkaControlMessage instruction = 2;
hasInstruction() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
optional .AkkaControlMessage instruction = 2;
hasInstruction() - Method in interface akka.remote.WireFormats.AkkaProtocolMessageOrBuilder
optional .AkkaControlMessage instruction = 2;
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;
hasMessage() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
required .SerializedMessage message = 2;
hasMessage() - Method in class akka.remote.WireFormats.RemoteEnvelope
required .SerializedMessage message = 2;
hasMessage() - Method in interface akka.remote.WireFormats.RemoteEnvelopeOrBuilder
required .SerializedMessage message = 2;
hasMessage() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
required bytes message = 1;
hasMessage() - Method in class akka.remote.WireFormats.SerializedMessage
required bytes message = 1;
hasMessage() - Method in interface akka.remote.WireFormats.SerializedMessageOrBuilder
required bytes message = 1;
hasMessageManifest() - Method in class akka.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;
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;
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;
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;
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.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;
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;
hasRouterConfig() - Method in class akka.remote.WireFormats.DeployData.Builder
optional bytes routerConfig = 3;
hasRouterConfig() - Method in class akka.remote.WireFormats.DeployData
optional bytes routerConfig = 3;
hasRouterConfig() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
optional bytes routerConfig = 3;
hasScope() - Method in class akka.remote.WireFormats.DeployData.Builder
optional bytes scope = 4;
hasScope() - Method in class akka.remote.WireFormats.DeployData
optional bytes scope = 4;
hasScope() - Method in interface akka.remote.WireFormats.DeployDataOrBuilder
optional bytes scope = 4;
hasSender() - Method in class akka.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;
HasSequenceNumber - Interface in akka.remote
Messages that are to be buffered in AckedSendBuffer or AckedReceiveBuffer has to implement this interface to provide the sequence needed by the buffers.
HasSequenceNumber$ - Class in akka.remote
 
HasSequenceNumber$() - Constructor for class akka.remote.HasSequenceNumber$
 
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;
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.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;
hasType() - Method in class akka.remote.ContainerFormats.Selection.Builder
required .PatternType type = 1;
hasType() - Method in class akka.remote.ContainerFormats.Selection
required .PatternType type = 1;
hasType() - Method in interface akka.remote.ContainerFormats.SelectionOrBuilder
required .PatternType type = 1;
hasUid() - Method in class akka.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;
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
 
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.remote.RemoteWatcher.Heartbeat$
 
Heartbeat$() - Constructor for class akka.remote.transport.AkkaPduCodec.Heartbeat$
 
HEARTBEAT_VALUE - Static variable in enum akka.remote.WireFormats.CommandType
HEARTBEAT = 3;
HeartbeatHistory - Class in akka.remote
 
HeartbeatHistory$ - Class in akka.remote
 
HeartbeatHistory$() - Constructor for class akka.remote.HeartbeatHistory$
 
heartbeatInterval() - Method in class akka.remote.DeadlineFailureDetector
 
HeartbeatRsp(int) - Constructor for class akka.remote.RemoteWatcher.HeartbeatRsp
 
HeartbeatRsp$() - Constructor for class akka.remote.RemoteWatcher.HeartbeatRsp$
 
heartbeatTask() - Method in class akka.remote.RemoteWatcher
 
HeartbeatTick$() - Constructor for class akka.remote.RemoteWatcher.HeartbeatTick$
 
HeartbeatTimer$() - Constructor for class akka.remote.transport.ProtocolStateActor.HeartbeatTimer$
 
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$
 
Hostname() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
HOSTNAME_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AddressData
 

I

identifier() - Method in class akka.remote.serialization.DaemonMsgCreateSerializer
 
identifier() - Method in class akka.remote.serialization.MessageContainerSerializer
 
identifier() - Method in class akka.remote.serialization.ProtobufSerializer
 
idle() - Method in class akka.remote.ReliableDeliverySupervisor
 
Idle$() - Constructor for class akka.remote.ReliableDeliverySupervisor.Idle$
 
Idle$() - Constructor for class akka.remote.RemoteActorRefProvider.Idle$
 
inbound() - Method in class akka.remote.AssociatedEvent
 
inbound() - Method in class akka.remote.AssociationErrorEvent
 
inbound() - Method in interface akka.remote.AssociationEvent
 
inbound() - Method in class akka.remote.DisassociatedEvent
 
inbound() - Method in class akka.remote.EndpointActor
 
inbound() - Method in class akka.remote.EndpointReader
 
inbound() - Method in class akka.remote.EndpointWriter
 
inbound() - Method in class akka.remote.transport.TestAssociationHandle
 
inbound() - Method in class akka.remote.transport.ThrottledAssociation
 
InboundAssociation(AssociationHandle) - Constructor for class akka.remote.transport.Transport.InboundAssociation
 
InboundAssociation$() - Constructor for class akka.remote.transport.Transport.InboundAssociation$
 
inboundDropP() - Method in class akka.remote.transport.FailureInjectorTransportAdapter.Drop
 
InboundMessageDispatcher - Interface in akka.remote
INTERNAL API
InboundPayload(ByteString) - Constructor for class akka.remote.transport.AssociationHandle.InboundPayload
 
InboundPayload$() - Constructor for class akka.remote.transport.AssociationHandle.InboundPayload$
 
inboundProps(HandshakeInfo, AssociationHandle, Transport.AssociationEventListener, AkkaProtocolSettings, AkkaPduCodec, FailureDetector) - Method in class akka.remote.transport.ProtocolStateActor$
 
inboundProps(HandshakeInfo, AssociationHandle, Transport.AssociationEventListener, AkkaProtocolSettings, AkkaPduCodec, FailureDetector) - Static method in class akka.remote.transport.ProtocolStateActor
 
inboundThrottleMode() - Method in class akka.remote.transport.ThrottledAssociation
 
InboundUnassociated(Transport.AssociationEventListener, AssociationHandle) - Constructor for class akka.remote.transport.ProtocolStateActor.InboundUnassociated
 
InboundUnassociated$() - Constructor for class akka.remote.transport.ProtocolStateActor.InboundUnassociated$
 
inc() - Method in class akka.remote.SeqNo
Increments the sequence number.
includeManifest() - Method in class akka.remote.serialization.DaemonMsgCreateSerializer
 
includeManifest() - Method in class akka.remote.serialization.MessageContainerSerializer
 
includeManifest() - Method in class akka.remote.serialization.ProtobufSerializer
 
includes(ThrottlerTransportAdapter.Direction) - Method in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Both$
 
includes(ThrottlerTransportAdapter.Direction) - Method in interface akka.remote.transport.ThrottlerTransportAdapter.Direction
 
includes(ThrottlerTransportAdapter.Direction) - Method in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Receive$
 
includes(ThrottlerTransportAdapter.Direction) - Method in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Send$
 
info() - Method in class akka.remote.transport.ActorTransportAdapter.DisassociateUnderlying
 
info() - Method in class akka.remote.transport.AkkaPduCodec.Associate
 
info() - Method in class akka.remote.transport.AssociationHandle.Disassociated
 
init(ActorSystemImpl) - Method in class akka.remote.RemoteActorRefProvider
 
init(Channel, SocketAddress, Address, ChannelBuffer, Function1<AssociationHandle, Object>) - Method in interface akka.remote.transport.netty.CommonHandlers
 
initializeClientSSL(SSLSettings, LoggingAdapter) - Method in class akka.remote.transport.netty.NettySSLSupport$
 
initializeClientSSL(SSLSettings, LoggingAdapter) - Static method in class akka.remote.transport.netty.NettySSLSupport
 
initializeCustomSecureRandom(Option<String>, LoggingAdapter) - Method in class akka.remote.transport.netty.NettySSLSupport$
 
initializeCustomSecureRandom(Option<String>, LoggingAdapter) - Static method in class akka.remote.transport.netty.NettySSLSupport
 
initializeServerSSL(SSLSettings, LoggingAdapter) - Method in class akka.remote.transport.netty.NettySSLSupport$
 
initializeServerSSL(SSLSettings, LoggingAdapter) - Static method in class akka.remote.transport.netty.NettySSLSupport
 
initializing() - Method in class akka.remote.EndpointWriter
 
InitialSysMsgDeliveryTimeout() - Method in class akka.remote.RemoteSettings
 
initialValue(Channel) - Method in class akka.remote.transport.netty.ChannelLocalActor$
 
initialValue(Channel) - Static method in class akka.remote.transport.netty.ChannelLocalActor
 
initInbound(Channel, SocketAddress, ChannelBuffer) - Method in class akka.remote.transport.netty.ServerHandler
 
initOutbound(Channel, SocketAddress, ChannelBuffer) - Method in class akka.remote.transport.netty.ClientHandler
 
initUdp(Channel, SocketAddress, ChannelBuffer) - Method in class akka.remote.transport.netty.UdpClientHandler
 
initUdp(Channel, SocketAddress, ChannelBuffer) - Method in interface akka.remote.transport.netty.UdpHandlers
 
initUdp(Channel, SocketAddress, ChannelBuffer) - Method in class akka.remote.transport.netty.UdpServerHandler
 
INSTRUCTION_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AkkaProtocolMessage
 
interceptAssociate(Address, Promise<AssociationHandle>) - Method in class akka.remote.transport.AbstractTransportAdapter
 
interceptAssociate(Address, Promise<AssociationHandle>) - Method in class akka.remote.transport.ActorTransportAdapter
 
interceptAssociate(Address, Promise<AssociationHandle>) - Method in class akka.remote.transport.FailureInjectorTransportAdapter
 
interceptInboundAssociation(Transport.AssociationEvent) - Method in class akka.remote.transport.FailureInjectorTransportAdapter
 
interceptListen(Address, Future<Transport.AssociationEventListener>) - Method in class akka.remote.transport.AbstractTransportAdapter
 
interceptListen(Address, Future<Transport.AssociationEventListener>) - Method in class akka.remote.transport.ActorTransportAdapter
 
interceptListen(Address, Future<Transport.AssociationEventListener>) - Method in class akka.remote.transport.FailureInjectorTransportAdapter
 
internalGetFieldAccessorTable() - Method in class akka.remote.ContainerFormats.Selection.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.ContainerFormats.Selection
 
internalGetFieldAccessorTable() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.ActorRefData.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.ActorRefData
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AddressData.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AddressData
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.DeployData.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.DeployData
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.PropsData.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.PropsData
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
internalGetFieldAccessorTable() - Method in class akka.remote.WireFormats.SerializedMessage
 
internalGetValueMap() - Static method in enum akka.remote.ContainerFormats.PatternType
 
internalGetValueMap() - Static method in enum akka.remote.WireFormats.CommandType
 
InternetSeedGenerator - Class in akka.remote.security.provider
 
InternetSeedGenerator() - Constructor for class akka.remote.security.provider.InternetSeedGenerator
 
InternetSeedGenerator$ - Class in akka.remote.security.provider
INTERNAL API Seed generator that maintains multiple strategies for seed generation and will delegate to the best one available for the current operating environment.
InternetSeedGenerator$() - Constructor for class akka.remote.security.provider.InternetSeedGenerator$
 
intervals() - Method in class akka.remote.HeartbeatHistory
 
intervalSum() - Method in class akka.remote.HeartbeatHistory
 
InvalidAssociation - Exception in akka.remote
INTERNAL API
InvalidAssociation(Address, Address, Throwable) - Constructor for exception akka.remote.InvalidAssociation
 
InvalidAssociation$ - Class in akka.remote
 
InvalidAssociation$() - Constructor for class akka.remote.InvalidAssociation$
 
InvalidAssociationException(String, Throwable) - Constructor for exception akka.remote.transport.Transport.InvalidAssociationException
 
InvalidAssociationException$() - Constructor for class akka.remote.transport.Transport.InvalidAssociationException$
 
isAvailable() - Method in class akka.remote.DeadlineFailureDetector
 
isAvailable(A) - Method in class akka.remote.DefaultFailureDetectorRegistry
 
isAvailable() - Method in interface akka.remote.FailureDetector
Returns true if the resource is considered to be up and healthy and returns false otherwise.
isAvailable(A) - Method in interface akka.remote.FailureDetectorRegistry
Returns true if the resource is considered to be up and healthy and returns false otherwise.
isAvailable() - Method in class akka.remote.PhiAccrualFailureDetector
 
IsIdle$() - Constructor for class akka.remote.ReliableDeliverySupervisor.IsIdle$
 
isInbound() - Method in interface akka.remote.AssociationEvent
 
isInitialized() - Method in class akka.remote.ContainerFormats.Selection.Builder
 
isInitialized() - Method in class akka.remote.ContainerFormats.Selection
 
isInitialized() - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
isInitialized() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
isInitialized() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
isInitialized() - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
isInitialized() - Method in class akka.remote.WireFormats.ActorRefData.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.ActorRefData
 
isInitialized() - Method in class akka.remote.WireFormats.AddressData.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.AddressData
 
isInitialized() - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
isInitialized() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
isInitialized() - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
isInitialized() - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
isInitialized() - Method in class akka.remote.WireFormats.DeployData.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.DeployData
 
isInitialized() - Method in class akka.remote.WireFormats.PropsData.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.PropsData
 
isInitialized() - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
isInitialized() - Method in class akka.remote.WireFormats.SerializedMessage.Builder
 
isInitialized() - Method in class akka.remote.WireFormats.SerializedMessage
 
isLocal() - Method in interface akka.remote.RemoteRef
 
isMonitoring() - Method in class akka.remote.DeadlineFailureDetector
 
isMonitoring(A) - Method in class akka.remote.DefaultFailureDetectorRegistry
 
isMonitoring() - Method in interface akka.remote.FailureDetector
Returns true if the failure detector has received any heartbeats and started monitoring of the resource.
isMonitoring(A) - Method in interface akka.remote.FailureDetectorRegistry
Returns true if the failure detector has received any heartbeats and started monitoring of the resource.
isMonitoring() - Method in class akka.remote.PhiAccrualFailureDetector
 
isQuarantined(Address, int) - Method in class akka.remote.EndpointManager.EndpointRegistry
 
isReadOnly(ActorRef) - Method in class akka.remote.EndpointManager.EndpointRegistry
 
isResponsibleFor(Address) - Method in class akka.remote.transport.AbstractTransportAdapter
 
isResponsibleFor(Address) - Method in class akka.remote.transport.netty.NettyTransport
 
isResponsibleFor(Address) - Method in class akka.remote.transport.TestTransport
 
isResponsibleFor(Address) - Method in interface akka.remote.transport.Transport
A function that decides whether the specific transport instance is responsible for delivering to a given address.
isSuccessor(SeqNo) - Method in class akka.remote.SeqNo
Checks if this sequence number is an immediate successor of the provided one.
isTerminated() - Method in class akka.remote.RemoteActorRef
 
isTombstone() - Method in interface akka.remote.EndpointManager.EndpointPolicy
Indicates that the policy does not contain an active endpoint, but it is a tombstone of a previous failure
isTombstone() - Method in class akka.remote.EndpointManager.Gated
 
isTombstone() - Method in class akka.remote.EndpointManager.Pass
 
isTombstone() - Method in class akka.remote.EndpointManager.Quarantined
 
isWatchIntercepted(ActorRef, ActorRef) - Method in class akka.remote.RemoteActorRef
Determine if a watch/unwatch message must be handled by the remoteWatcher actor, or sent to this remote ref
isWritable(ActorRef) - Method in class akka.remote.EndpointManager.EndpointRegistry
 

K

keepQuarantinedOr(Address, Function0<BoxedUnit>) - Method in class akka.remote.EndpointManager
 
key() - Method in class akka.remote.transport.TestAssociationHandle
Key used in TestTransport.AssociationRegistry to identify associations.

L

largeBufferLogTimestamp() - Method in class akka.remote.EndpointWriter
 
lastAck() - Method in class akka.remote.EndpointWriter
 
lastDelivered() - Method in class akka.remote.AckedReceiveBuffer
 
Link(Address, Address) - Constructor for class akka.remote.EndpointManager.Link
 
Link$() - Constructor for class akka.remote.EndpointManager.Link$
 
Listen(Promise<Seq<Tuple2<AkkaProtocolTransport, Address>>>) - Constructor for class akka.remote.EndpointManager.Listen
 
listen() - Method in class akka.remote.transport.AbstractTransportAdapter
 
listen() - Method in class akka.remote.transport.netty.NettyTransport
 
listen() - Method in class akka.remote.transport.TestTransport
 
listen() - Method in interface akka.remote.transport.Transport
Asynchronously attempts to setup the transport layer to listen and accept incoming associations.
Listen$() - Constructor for class akka.remote.EndpointManager.Listen$
 
listenAddress() - Method in class akka.remote.transport.ActorTransportAdapter.ListenUnderlying
 
listenAddresses() - Method in class akka.remote.RemotingListenEvent
 
ListenAttempt(Address) - Constructor for class akka.remote.transport.TestTransport.ListenAttempt
 
ListenAttempt$() - Constructor for class akka.remote.transport.TestTransport.ListenAttempt$
 
listenBehavior() - Method in class akka.remote.transport.TestTransport
The TestTransport.SwitchableLoggedBehavior for the listen() method.
listener() - Method in class akka.remote.transport.ActorTransportAdapter.ListenerRegistered
 
listener() - Method in class akka.remote.transport.ProtocolStateActor.HandleListenerRegistered
 
listener() - Method in class akka.remote.transport.ProtocolStateActor.ListenerReady
 
Listener(AssociationHandle.HandleEventListener) - Constructor for class akka.remote.transport.ThrottlerManager.Listener
 
listener() - Method in class akka.remote.transport.ThrottlerManager.Listener
 
listener() - Method in class akka.remote.transport.ThrottlerManager.ListenerAndMode
 
Listener$() - Constructor for class akka.remote.transport.ThrottlerManager.Listener$
 
ListenerAndMode(AssociationHandle.HandleEventListener, ThrottlerTransportAdapter.ThrottleMode) - Constructor for class akka.remote.transport.ThrottlerManager.ListenerAndMode
 
ListenerAndMode$() - Constructor for class akka.remote.transport.ThrottlerManager.ListenerAndMode$
 
ListenerReady(AssociationHandle.HandleEventListener, AssociationHandle) - Constructor for class akka.remote.transport.ProtocolStateActor.ListenerReady
 
ListenerReady$() - Constructor for class akka.remote.transport.ProtocolStateActor.ListenerReady$
 
ListenerRegistered(Transport.AssociationEventListener) - Constructor for class akka.remote.transport.ActorTransportAdapter.ListenerRegistered
 
ListenerRegistered$() - Constructor for class akka.remote.transport.ActorTransportAdapter.ListenerRegistered$
 
ListensFailure(Promise<Seq<Tuple2<AkkaProtocolTransport, Address>>>, Throwable) - Constructor for class akka.remote.EndpointManager.ListensFailure
 
ListensFailure$() - Constructor for class akka.remote.EndpointManager.ListensFailure$
 
ListensResult(Promise<Seq<Tuple2<AkkaProtocolTransport, Address>>>, Seq<Tuple3<AkkaProtocolTransport, Address, Promise<Transport.AssociationEventListener>>>) - Constructor for class akka.remote.EndpointManager.ListensResult
 
ListensResult$() - Constructor for class akka.remote.EndpointManager.ListensResult$
 
ListenUnderlying(Address, Future<Transport.AssociationEventListener>) - Constructor for class akka.remote.transport.ActorTransportAdapter.ListenUnderlying
 
ListenUnderlying$() - Constructor for class akka.remote.transport.ActorTransportAdapter.ListenUnderlying$
 
load(String, Config, ActorSystem) - Method in class akka.remote.FailureDetectorLoader$
Loads and instantiates a given FailureDetector implementation.
load(String, Config, ActorSystem) - Static method in class akka.remote.FailureDetectorLoader
Loads and instantiates a given FailureDetector implementation.
local() - Method in class akka.remote.routing.RemoteRouterConfig
 
localAddress() - Method in class akka.remote.AssociatedEvent
 
localAddress() - Method in class akka.remote.AssociationErrorEvent
 
localAddress() - Method in interface akka.remote.AssociationEvent
 
localAddress() - Method in class akka.remote.DisassociatedEvent
 
localAddress() - Method in class akka.remote.EndpointActor
 
localAddress() - Method in class akka.remote.EndpointManager.Link
 
localAddress() - Method in exception akka.remote.HopelessAssociation
 
localAddress() - Method in exception akka.remote.InvalidAssociation
 
localAddress() - Method in class akka.remote.ReliableDeliverySupervisor
 
localAddress() - Method in exception akka.remote.ShutDownAssociation
 
localAddress() - Method in class akka.remote.transport.AbstractTransportAdapterHandle
 
localAddress() - Method in class akka.remote.transport.ActorTransportAdapterManager
 
localAddress() - Method in interface akka.remote.transport.AssociationHandle
Address of the local endpoint.
localAddress() - Method in class akka.remote.transport.netty.TcpAssociationHandle
 
localAddress() - Method in class akka.remote.transport.netty.UdpAssociationHandle
 
localAddress() - Method in class akka.remote.transport.ProtocolStateActor
 
localAddress() - Method in class akka.remote.transport.TestAssociationHandle
 
localAddress() - Method in class akka.remote.transport.TestTransport.AssociateAttempt
 
localAddress() - Method in class akka.remote.transport.TestTransport
 
localAddressForRemote(Address) - Method in class akka.remote.RemoteTransport
Resolves the correct local address to be used for contacting the given remote address
localAddressForRemote(Map<String, Set<Tuple2<AkkaProtocolTransport, Address>>>, Address) - Method in class akka.remote.Remoting$
 
localAddressForRemote(Address) - Method in class akka.remote.Remoting
 
localAddressToUse() - Method in class akka.remote.RemoteActorRef
 
log() - Method in class akka.remote.RemoteActorRefProvider
 
log() - Method in class akka.remote.RemoteTransport
A Logger that can be used to log issues that may occur
log() - Method in class akka.remote.Remoting
 
logActivity(TestTransport.Activity) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Logs a transport activity.
LogBufferSizeExceeding() - Method in class akka.remote.RemoteSettings
 
logLevel() - Method in class akka.remote.AssociatedEvent
 
logLevel() - Method in class akka.remote.AssociationErrorEvent
 
logLevel() - Method in class akka.remote.DisassociatedEvent
 
logLevel() - Method in class akka.remote.QuarantinedEvent
 
logLevel() - Method in class akka.remote.RemotingErrorEvent
 
logLevel() - Method in interface akka.remote.RemotingLifecycleEvent
 
logLevel() - Method in class akka.remote.RemotingListenEvent
 
logLevel() - Method in class akka.remote.RemotingShutdownEvent$
 
logLevel() - Static method in class akka.remote.RemotingShutdownEvent
 
logPayloadBytes(Object, int) - Method in interface akka.remote.RemoteMetrics
Logging of the size of different message types.
logPayloadBytes(Object, int) - Method in class akka.remote.RemoteMetricsOff
 
logPayloadBytes(Object, int) - Method in class akka.remote.RemoteMetricsOn
 
LogReceive() - Method in class akka.remote.RemoteSettings
 
LogSend() - Method in class akka.remote.RemoteSettings
 
logSnapshot() - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Takes a thread-safe snapshot of the current state of the activity log.
logTermination(FSM.Reason) - Method in class akka.remote.transport.ProtocolStateActor
 
lookup() - Method in class akka.remote.AddressUidExtension$
 
lookup() - Static method in class akka.remote.AddressUidExtension
 
lookup() - Method in class akka.remote.BoundAddressesExtension$
 
lookup() - Static method in class akka.remote.BoundAddressesExtension
 
lookup() - Method in class akka.remote.RARP$
 
lookup() - Static method in class akka.remote.RARP
 
lookup() - Method in class akka.remote.RemoteMetricsExtension$
 
lookup() - Static method in class akka.remote.RemoteMetricsExtension
 
lookup() - Method in class akka.remote.transport.TransportAdaptersExtension$
 
lookup() - Static method in class akka.remote.transport.TransportAdaptersExtension
 

M

ManagementCommand(Object) - Constructor for class akka.remote.EndpointManager.ManagementCommand
 
managementCommand(Object) - Method in class akka.remote.RemoteTransport
Sends a management command to the underlying transport stack.
managementCommand(Object) - Method in class akka.remote.Remoting
 
managementCommand(Object) - Method in class akka.remote.transport.AkkaProtocolTransport
 
managementCommand(Object) - Method in class akka.remote.transport.FailureInjectorTransportAdapter
 
managementCommand(Object) - Method in class akka.remote.transport.ThrottlerTransportAdapter
 
managementCommand(Object) - Method in interface akka.remote.transport.Transport
This method allows upper layers to send management commands to the transport.
ManagementCommand$() - Constructor for class akka.remote.EndpointManager.ManagementCommand$
 
ManagementCommandAck(boolean) - Constructor for class akka.remote.EndpointManager.ManagementCommandAck
 
ManagementCommandAck$() - Constructor for class akka.remote.EndpointManager.ManagementCommandAck$
 
manager() - Method in class akka.remote.transport.ActorTransportAdapter
 
manager() - Method in class akka.remote.transport.ThrottledAssociation
 
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
 
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
 
MATCHER_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.Selection
 
MaxFrameSize() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
maximumOverhead() - Method in class akka.remote.transport.AbstractTransportAdapter
 
maximumOverhead() - Method in class akka.remote.transport.AkkaProtocolTransport
 
maximumOverhead() - Method in class akka.remote.transport.FailureInjectorTransportAdapter
 
maximumOverhead() - Method in class akka.remote.transport.ThrottlerTransportAdapter
 
maximumPayloadBytes() - Method in class akka.remote.transport.AbstractTransportAdapter
 
maximumPayloadBytes() - Method in class akka.remote.transport.netty.NettyTransport
 
maximumPayloadBytes() - Method in class akka.remote.transport.TestTransport
 
maximumPayloadBytes() - Method in interface akka.remote.transport.Transport
Defines the maximum size of payload this transport is able to deliver.
maxSampleSize() - Method in class akka.remote.HeartbeatHistory
 
maxSampleSize() - Method in class akka.remote.PhiAccrualFailureDetector
 
maxSeq() - Method in class akka.remote.AckedSendBuffer
 
maxWriteCount() - Method in class akka.remote.EndpointWriter
 
mean() - Method in class akka.remote.HeartbeatHistory
 
mergeAck(WireFormats.AcknowledgementInfo) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .AcknowledgementInfo ack = 1;
mergeDeploy(WireFormats.DeployData) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .DeployData deploy = 2;
mergeDeploy(WireFormats.DeployData) - Method in class akka.remote.WireFormats.PropsData.Builder
required .DeployData deploy = 2;
mergeEnvelope(WireFormats.RemoteEnvelope) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .RemoteEnvelope envelope = 2;
mergeFrom(AckedReceiveBuffer<T>) - Method in class akka.remote.AckedReceiveBuffer
Merges two receive buffers.
mergeFrom(Message) - Method in class akka.remote.ContainerFormats.Selection.Builder
 
mergeFrom(ContainerFormats.Selection) - Method in class akka.remote.ContainerFormats.Selection.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.ContainerFormats.Selection.Builder
 
mergeFrom(Message) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
mergeFrom(ContainerFormats.SelectionEnvelope) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
 
mergeFrom(Message) - Method in class akka.remote.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
 
mergeHandshakeInfo(WireFormats.AkkaHandshakeInfo) - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
optional .AkkaHandshakeInfo handshakeInfo = 2;
mergeInstruction(WireFormats.AkkaControlMessage) - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
optional .AkkaControlMessage instruction = 2;
mergeMessage(WireFormats.SerializedMessage) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
required .SerializedMessage message = 2;
mergeOrigin(WireFormats.AddressData) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
required .AddressData origin = 1;
mergeProps(WireFormats.PropsData) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .PropsData props = 1;
mergeRecipient(WireFormats.ActorRefData) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
required .ActorRefData recipient = 1;
mergeSender(WireFormats.ActorRefData) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
optional .ActorRefData sender = 4;
mergeSupervisor(WireFormats.ActorRefData) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .ActorRefData supervisor = 4;
message() - Method in class akka.remote.EndpointManager.Send
 
Message(InternalActorRef, Address, WireFormats.SerializedMessage, Option<ActorRef>, Option<SeqNo>) - Constructor for class akka.remote.transport.AkkaPduCodec.Message
 
Message$() - Constructor for class akka.remote.transport.AkkaPduCodec.Message$
 
MESSAGE_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.RemoteEnvelope
 
MESSAGE_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.SerializedMessage
 
MessageContainerSerializer - Class in akka.remote.serialization
 
MessageContainerSerializer(ExtendedActorSystem) - Constructor for class akka.remote.serialization.MessageContainerSerializer
 
MessageContainerSerializer() - Constructor for class akka.remote.serialization.MessageContainerSerializer
 
MESSAGEMANIFEST_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.SelectionEnvelope
 
MESSAGEMANIFEST_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.SerializedMessage
 
messageReceived(ChannelHandlerContext, MessageEvent) - Method in interface akka.remote.transport.netty.NettyClientHelpers
 
messageReceived(ChannelHandlerContext, MessageEvent) - Method in interface akka.remote.transport.netty.NettyServerHelpers
 
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$
 
minStdDeviation() - Method in class akka.remote.PhiAccrualFailureDetector
 
mode() - Method in class akka.remote.transport.FailureInjectorTransportAdapter.All
 
mode() - Method in class akka.remote.transport.FailureInjectorTransportAdapter.One
 
mode() - Method in class akka.remote.transport.ThrottlerManager.ListenerAndMode
 
mode() - Method in class akka.remote.transport.ThrottlerTransportAdapter.SetThrottle
 
MODULE$ - Static variable in class akka.remote.Ack$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.AckedReceiveBuffer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.AckedSendBuffer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.AddressUidExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.AddressUrlEncoder$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.AssociatedEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.AssociationErrorEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.BoundAddressesExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.DaemonMsgCreate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.DisassociatedEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.Gated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.Link$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.Listen$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.ListensFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.ListensResult$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.ManagementCommand$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.ManagementCommandAck$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.Pass$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.Prune$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.Quarantine$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.Quarantined$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.ResendState$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.Send$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.ShutdownAndFlush$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointManager.StartupFinished$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointReader$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointWriter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointWriter.AckIdleCheckTimer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointWriter.BackoffTimer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointWriter.FlushAndStop$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointWriter.Handle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointWriter.OutboundAck$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointWriter.StoppedReading$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointWriter.StopReading$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointWriter.TakeOver$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.EndpointWriter.TookOver$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.FailureDetector$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.FailureDetectorLoader$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.HasSequenceNumber$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.HeartbeatHistory$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.HopelessAssociation$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.InvalidAssociation$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.MessageSerializer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.QuarantinedEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RARP$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.ReliableDeliverySupervisor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.ReliableDeliverySupervisor.AttemptSysMsgRedelivery$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.ReliableDeliverySupervisor.GotUid$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.ReliableDeliverySupervisor.Idle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.ReliableDeliverySupervisor.IsIdle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.ReliableDeliverySupervisor.Ungate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteActorRefProvider$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteActorRefProvider.Finished$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteActorRefProvider.Idle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteActorRefProvider.Uninitialized$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteActorRefProvider.WaitDaemonShutdown$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteActorRefProvider.WaitTransportShutdown$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteDeploymentWatcher$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteDeploymentWatcher.WatchRemote$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteMetricsExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteScope$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteWatcher$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteWatcher.ExpectedFirstHeartbeat$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteWatcher.Heartbeat$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteWatcher.HeartbeatRsp$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteWatcher.HeartbeatTick$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteWatcher.ReapUnreachableTick$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteWatcher.Stats$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteWatcher.UnwatchRemote$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemoteWatcher.WatchRemote$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.Remoting$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.Remoting.RegisterTransportActor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemotingErrorEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemotingListenEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.RemotingShutdownEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.routing.RemoteRouterConfig$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.security.provider.AkkaProvider$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.security.provider.InternetSeedGenerator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.security.provider.SeedSize$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.SeqNo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.serialization.ProtobufSerializer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.ShutDownAssociation$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ActorTransportAdapter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ActorTransportAdapter.AssociateUnderlying$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ActorTransportAdapter.DisassociateUnderlying$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ActorTransportAdapter.ListenerRegistered$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ActorTransportAdapter.ListenUnderlying$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AkkaPduCodec$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AkkaPduCodec.Associate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AkkaPduCodec.Disassociate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AkkaPduCodec.Heartbeat$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AkkaPduCodec.Message$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AkkaPduCodec.Payload$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AkkaPduProtobufCodec$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AkkaProtocolTransport$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AkkaProtocolTransport.AssociateUnderlyingRefuseUid$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AssociationHandle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AssociationHandle.ActorHandleEventListener$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AssociationHandle.Disassociated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AssociationHandle.InboundPayload$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AssociationHandle.Quarantined$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AssociationHandle.Shutdown$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AssociationHandle.Unknown$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.AssociationRegistry$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.FailureInjectorException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.FailureInjectorHandle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.FailureInjectorTransportAdapter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.FailureInjectorTransportAdapter.All$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.FailureInjectorTransportAdapter.Drop$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.FailureInjectorTransportAdapter.One$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.FailureInjectorTransportAdapter.PassThru$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.HandshakeInfo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.netty.ChannelLocalActor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.netty.NettyFutureBridge$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.netty.NettySSLSupport$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.netty.NettyTransport$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.netty.NettyTransportSettings$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.netty.NettyTransportSettings.Tcp$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.netty.NettyTransportSettings.Udp$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.AssociatedWaitHandler$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.Closed$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.ForbiddenUidReason$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.Handle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.HandleListenerRegistered$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.HeartbeatTimer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.InboundUnassociated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.ListenerReady$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.Open$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.OutboundUnassociated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.OutboundUnderlyingAssociated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.TimeoutReason$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ProtocolStateActor.WaitHandshake$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.TestAssociationHandle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.TestTransport$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.TestTransport.AssociateAttempt$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.TestTransport.DisassociateAttempt$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.TestTransport.ListenAttempt$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.TestTransport.ShutdownAttempt$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.TestTransport.WriteAttempt$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.Dequeue$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.ExposedHandle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.FailWith$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.Throttling$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.Uninitialized$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.WaitExposedHandle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.WaitMode$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.WaitModeAndUpstreamListener$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.WaitOrigin$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottledAssociation.WaitUpstreamListener$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerHandle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerManager$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerManager.AssociateResult$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerManager.Checkin$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerManager.Handle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerManager.Listener$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerManager.ListenerAndMode$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.Blackhole$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.Direction$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Both$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Receive$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.Direction.Send$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociateAck$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociateExplicitly$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.SetThrottle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.SetThrottleAck$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.ThrottlerTransportAdapter.Unthrottled$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.Transport$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.Transport.ActorAssociationEventListener$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.Transport.InboundAssociation$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.Transport.InvalidAssociationException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.remote.transport.TransportAdaptersExtension$
Static reference to the singleton instance of this Scala object.
msg() - Method in exception akka.remote.transport.FailureInjectorException
 
msg() - Method in exception akka.remote.transport.Transport.InvalidAssociationException
 
msgDispatch() - Method in class akka.remote.EndpointWriter
 

N

nacked() - Method in class akka.remote.AckedSendBuffer
 
nacks() - Method in class akka.remote.Ack
 
NACKS_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AcknowledgementInfo
 
name() - Method in class akka.remote.Remoting.RegisterTransportActor
 
nanoTimeOfLastSend() - Method in class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket
 
NettyClientHelpers - Interface in akka.remote.transport.netty
INTERNAL API
NettyFutureBridge - Class in akka.remote.transport.netty
 
NettyFutureBridge() - Constructor for class akka.remote.transport.netty.NettyFutureBridge
 
NettyFutureBridge$ - Class in akka.remote.transport.netty
 
NettyFutureBridge$() - Constructor for class akka.remote.transport.netty.NettyFutureBridge$
 
NettyHelpers - Interface in akka.remote.transport.netty
INTERNAL API
NettyServerHelpers - Interface in akka.remote.transport.netty
INTERNAL API
NettySSLSupport - Class in akka.remote.transport.netty
INTERNAL API
NettySSLSupport() - Constructor for class akka.remote.transport.netty.NettySSLSupport
 
NettySSLSupport$ - Class in akka.remote.transport.netty
INTERNAL API
NettySSLSupport$() - Constructor for class akka.remote.transport.netty.NettySSLSupport$
 
NettyTransport - Class in akka.remote.transport.netty
 
NettyTransport(NettyTransportSettings, ExtendedActorSystem) - Constructor for class akka.remote.transport.netty.NettyTransport
 
NettyTransport(ExtendedActorSystem, Config) - Constructor for class akka.remote.transport.netty.NettyTransport
 
NettyTransport$ - Class in akka.remote.transport.netty
INTERNAL API
NettyTransport$() - Constructor for class akka.remote.transport.netty.NettyTransport$
 
NettyTransportException - Exception in akka.remote.transport.netty
 
NettyTransportException(String, Throwable) - Constructor for exception akka.remote.transport.netty.NettyTransportException
 
NettyTransportException(String) - Constructor for exception akka.remote.transport.netty.NettyTransportException
 
NettyTransportSettings - Class in akka.remote.transport.netty
 
NettyTransportSettings(Config) - Constructor for class akka.remote.transport.netty.NettyTransportSettings
 
NettyTransportSettings$ - Class in akka.remote.transport.netty
 
NettyTransportSettings$() - Constructor for class akka.remote.transport.netty.NettyTransportSettings$
 
NettyTransportSettings.Mode - Interface in akka.remote.transport.netty
 
NettyTransportSettings.Tcp$ - Class in akka.remote.transport.netty
 
NettyTransportSettings.Udp$ - Class in akka.remote.transport.netty
 
newAckDeadline() - Method in class akka.remote.EndpointWriter
 
newBuilder() - Static method in class akka.remote.ContainerFormats.Selection
 
newBuilder(ContainerFormats.Selection) - Static method in class akka.remote.ContainerFormats.Selection
 
newBuilder() - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
newBuilder(ContainerFormats.SelectionEnvelope) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
newBuilder() - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
newBuilder(WireFormats.AckAndEnvelopeContainer) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
newBuilder() - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
newBuilder(WireFormats.AcknowledgementInfo) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
newBuilder() - Static method in class akka.remote.WireFormats.ActorRefData
 
newBuilder(WireFormats.ActorRefData) - Static method in class akka.remote.WireFormats.ActorRefData
 
newBuilder() - Static method in class akka.remote.WireFormats.AddressData
 
newBuilder(WireFormats.AddressData) - Static method in class akka.remote.WireFormats.AddressData
 
newBuilder() - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
newBuilder(WireFormats.AkkaControlMessage) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
newBuilder() - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
newBuilder(WireFormats.AkkaHandshakeInfo) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
newBuilder() - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
newBuilder(WireFormats.AkkaProtocolMessage) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
newBuilder() - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
newBuilder(WireFormats.DaemonMsgCreateData) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
newBuilder() - Static method in class akka.remote.WireFormats.DeployData
 
newBuilder(WireFormats.DeployData) - Static method in class akka.remote.WireFormats.DeployData
 
newBuilder() - Static method in class akka.remote.WireFormats.PropsData
 
newBuilder(WireFormats.PropsData) - Static method in class akka.remote.WireFormats.PropsData
 
newBuilder() - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
newBuilder(WireFormats.RemoteEnvelope) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
newBuilder() - Static method in class akka.remote.WireFormats.SerializedMessage
 
newBuilder(WireFormats.SerializedMessage) - Static method in class akka.remote.WireFormats.SerializedMessage
 
newBuilderForType() - Method in class akka.remote.ContainerFormats.Selection
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class akka.remote.ContainerFormats.Selection
 
newBuilderForType() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
newBuilderForType() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
newBuilderForType() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
newBuilderForType() - Method in class akka.remote.WireFormats.ActorRefData
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.ActorRefData
 
newBuilderForType() - Method in class akka.remote.WireFormats.AddressData
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.AddressData
 
newBuilderForType() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.AkkaControlMessage
 
newBuilderForType() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
newBuilderForType() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
newBuilderForType() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
newBuilderForType() - Method in class akka.remote.WireFormats.DeployData
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.DeployData
 
newBuilderForType() - Method in class akka.remote.WireFormats.PropsData
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.PropsData
 
newBuilderForType() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.RemoteEnvelope
 
newBuilderForType() - Method in class akka.remote.WireFormats.SerializedMessage
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class akka.remote.WireFormats.SerializedMessage
 
newRoutee(Props, ActorContext) - Method in class akka.remote.routing.RemoteRouterConfig
 
nextId() - Method in class akka.remote.transport.ActorTransportAdapterManager
 
nextSeq() - Method in class akka.remote.ReliableDeliverySupervisor
 
noBackoffCount() - Method in class akka.remote.EndpointWriter
 
node() - Method in class akka.remote.RemoteScope
 
nodes() - Method in class akka.remote.routing.RemoteRouterConfig
 
nonAcked() - Method in class akka.remote.AckedSendBuffer
 
notify(AssociationHandle.HandleEvent) - Method in class akka.remote.transport.AssociationHandle.ActorHandleEventListener
 
notify(AssociationHandle.HandleEvent) - Method in interface akka.remote.transport.AssociationHandle.HandleEventListener
Called by the transport to notify the listener about a HandleEvent
notify(AssociationHandle.HandleEvent) - Method in class akka.remote.transport.FailureInjectorHandle
 
notify(Transport.AssociationEvent) - Method in class akka.remote.transport.FailureInjectorTransportAdapter
 
notify(Transport.AssociationEvent) - Method in class akka.remote.transport.Transport.ActorAssociationEventListener
 
notify(Transport.AssociationEvent) - Method in interface akka.remote.transport.Transport.AssociationEventListener
Called by the transport to notify the listener about an AssociationEvent
notifyListener(Channel, AssociationHandle.HandleEvent) - Method in class akka.remote.transport.netty.ChannelLocalActor$
 
notifyListener(Channel, AssociationHandle.HandleEvent) - Static method in class akka.remote.transport.netty.ChannelLocalActor
 
notifyListeners(RemotingLifecycleEvent) - Method in class akka.remote.EventPublisher
 
notReading() - Method in class akka.remote.EndpointReader
 
nrOfInstances(ActorSystem) - Method in class akka.remote.routing.RemoteRouterConfig
 

O

onConnect(ChannelHandlerContext, ChannelStateEvent) - Method in interface akka.remote.transport.netty.NettyHelpers
 
onConnect(ChannelHandlerContext, ChannelStateEvent) - Method in class akka.remote.transport.netty.TcpClientHandler
 
onConnect(ChannelHandlerContext, ChannelStateEvent) - Method in class akka.remote.transport.netty.TcpServerHandler
 
onDisconnect(ChannelHandlerContext, ChannelStateEvent) - Method in interface akka.remote.transport.netty.NettyHelpers
 
onDisconnect(ChannelHandlerContext, ChannelStateEvent) - Method in interface akka.remote.transport.netty.TcpHandlers
 
One(Address, FailureInjectorTransportAdapter.GremlinMode) - Constructor for class akka.remote.transport.FailureInjectorTransportAdapter.One
 
One$() - Constructor for class akka.remote.transport.FailureInjectorTransportAdapter.One$
 
onException(ChannelHandlerContext, ExceptionEvent) - Method in interface akka.remote.transport.netty.NettyHelpers
 
onException(ChannelHandlerContext, ExceptionEvent) - Method in interface akka.remote.transport.netty.TcpHandlers
 
onMessage(ChannelHandlerContext, MessageEvent) - Method in interface akka.remote.transport.netty.NettyHelpers
 
onMessage(ChannelHandlerContext, MessageEvent) - Method in interface akka.remote.transport.netty.TcpHandlers
 
onMessage(ChannelHandlerContext, MessageEvent) - Method in interface akka.remote.transport.netty.UdpHandlers
 
onOpen(ChannelHandlerContext, ChannelStateEvent) - Method in interface akka.remote.transport.netty.CommonHandlers
 
onOpen(ChannelHandlerContext, ChannelStateEvent) - Method in interface akka.remote.transport.netty.NettyHelpers
 
Open$() - Constructor for class akka.remote.transport.ProtocolStateActor.Open$
 
ord() - Method in class akka.remote.SeqNo$
 
ord() - Static method in class akka.remote.SeqNo
 
origin() - Method in class akka.remote.transport.HandshakeInfo
 
origin() - Method in class akka.remote.transport.ThrottlerManager.Checkin
 
ORIGIN_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AkkaHandshakeInfo
 
originalHandle() - Method in class akka.remote.transport.ThrottledAssociation
 
originalLocalAddress() - Method in class akka.remote.transport.AbstractTransportAdapterHandle
 
originalRemoteAddress() - Method in class akka.remote.transport.AbstractTransportAdapterHandle
 
OutboundAck(Ack) - Constructor for class akka.remote.EndpointWriter.OutboundAck
 
OutboundAck$() - Constructor for class akka.remote.EndpointWriter.OutboundAck$
 
outboundDropP() - Method in class akka.remote.transport.FailureInjectorTransportAdapter.Drop
 
outboundProps(HandshakeInfo, Address, Promise<AssociationHandle>, Transport, AkkaProtocolSettings, AkkaPduCodec, FailureDetector, Option<Object>) - Method in class akka.remote.transport.ProtocolStateActor$
 
outboundProps(HandshakeInfo, Address, Promise<AssociationHandle>, Transport, AkkaProtocolSettings, AkkaPduCodec, FailureDetector, Option<Object>) - Static method in class akka.remote.transport.ProtocolStateActor
 
outboundThrottleMode() - Method in class akka.remote.transport.ThrottlerHandle
 
OutboundUnassociated(Address, Promise<AssociationHandle>, Transport) - Constructor for class akka.remote.transport.ProtocolStateActor.OutboundUnassociated
 
OutboundUnassociated$() - Constructor for class akka.remote.transport.ProtocolStateActor.OutboundUnassociated$
 
OutboundUnderlyingAssociated(Promise<AssociationHandle>, AssociationHandle) - Constructor for class akka.remote.transport.ProtocolStateActor.OutboundUnderlyingAssociated
 
OutboundUnderlyingAssociated$() - Constructor for class akka.remote.transport.ProtocolStateActor.OutboundUnderlyingAssociated$
 
OversizedPayloadException - Exception in akka.remote
INTERNAL API
OversizedPayloadException(String) - Constructor for exception akka.remote.OversizedPayloadException
 

P

PARENT_VALUE - Static variable in enum akka.remote.ContainerFormats.PatternType
PARENT = 0;
parseConfig(String, Config) - Method in class akka.remote.RemoteDeployer
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.ContainerFormats.Selection
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.Selection
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.ActorRefData
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.ActorRefData
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.AddressData
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AddressData
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.DeployData
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DeployData
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.PropsData
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.PropsData
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
parseDelimitedFrom(InputStream) - Static method in class akka.remote.WireFormats.SerializedMessage
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.SerializedMessage
 
parseFrom(ByteString) - Static method in class akka.remote.ContainerFormats.Selection
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.Selection
 
parseFrom(byte[]) - Static method in class akka.remote.ContainerFormats.Selection
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.Selection
 
parseFrom(InputStream) - Static method in class akka.remote.ContainerFormats.Selection
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.Selection
 
parseFrom(CodedInputStream) - Static method in class akka.remote.ContainerFormats.Selection
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.Selection
 
parseFrom(ByteString) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
parseFrom(byte[]) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
parseFrom(InputStream) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
parseFrom(CodedInputStream) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class akka.remote.ContainerFormats.SelectionEnvelope
 
parseFrom(ByteString) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
parseFrom(byte[]) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
parseFrom(InputStream) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
parseFrom(CodedInputStream) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
parseFrom(ByteString) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
parseFrom(byte[]) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
parseFrom(InputStream) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
parseFrom(CodedInputStream) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AcknowledgementInfo
 
parseFrom(ByteString) - Static method in class akka.remote.WireFormats.ActorRefData
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.ActorRefData
 
parseFrom(byte[]) - Static method in class akka.remote.WireFormats.ActorRefData
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.ActorRefData
 
parseFrom(InputStream) - Static method in class akka.remote.WireFormats.ActorRefData
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.ActorRefData
 
parseFrom(CodedInputStream) - Static method in class akka.remote.WireFormats.ActorRefData
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.ActorRefData
 
parseFrom(ByteString) - Static method in class akka.remote.WireFormats.AddressData
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AddressData
 
parseFrom(byte[]) - Static method in class akka.remote.WireFormats.AddressData
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AddressData
 
parseFrom(InputStream) - Static method in class akka.remote.WireFormats.AddressData
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AddressData
 
parseFrom(CodedInputStream) - Static method in class akka.remote.WireFormats.AddressData
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AddressData
 
parseFrom(ByteString) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
parseFrom(byte[]) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
parseFrom(InputStream) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
parseFrom(CodedInputStream) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaControlMessage
 
parseFrom(ByteString) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
parseFrom(byte[]) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
parseFrom(InputStream) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
parseFrom(CodedInputStream) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
parseFrom(ByteString) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
parseFrom(byte[]) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
parseFrom(InputStream) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
parseFrom(CodedInputStream) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.AkkaProtocolMessage
 
parseFrom(ByteString) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
parseFrom(byte[]) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
parseFrom(InputStream) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
parseFrom(CodedInputStream) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DaemonMsgCreateData
 
parseFrom(ByteString) - Static method in class akka.remote.WireFormats.DeployData
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DeployData
 
parseFrom(byte[]) - Static method in class akka.remote.WireFormats.DeployData
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DeployData
 
parseFrom(InputStream) - Static method in class akka.remote.WireFormats.DeployData
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DeployData
 
parseFrom(CodedInputStream) - Static method in class akka.remote.WireFormats.DeployData
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.DeployData
 
parseFrom(ByteString) - Static method in class akka.remote.WireFormats.PropsData
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.PropsData
 
parseFrom(byte[]) - Static method in class akka.remote.WireFormats.PropsData
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.PropsData
 
parseFrom(InputStream) - Static method in class akka.remote.WireFormats.PropsData
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.PropsData
 
parseFrom(CodedInputStream) - Static method in class akka.remote.WireFormats.PropsData
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.PropsData
 
parseFrom(ByteString) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
parseFrom(byte[]) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
parseFrom(InputStream) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
parseFrom(CodedInputStream) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.RemoteEnvelope
 
parseFrom(ByteString) - Static method in class akka.remote.WireFormats.SerializedMessage
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.SerializedMessage
 
parseFrom(byte[]) - Static method in class akka.remote.WireFormats.SerializedMessage
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.SerializedMessage
 
parseFrom(InputStream) - Static method in class akka.remote.WireFormats.SerializedMessage
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.SerializedMessage
 
parseFrom(CodedInputStream) - Static method in class akka.remote.WireFormats.SerializedMessage
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class akka.remote.WireFormats.SerializedMessage
 
PARSER - Static variable in class akka.remote.ContainerFormats.Selection
 
PARSER - Static variable in class akka.remote.ContainerFormats.SelectionEnvelope
 
PARSER - Static variable in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
PARSER - Static variable in class akka.remote.WireFormats.AcknowledgementInfo
 
PARSER - Static variable in class akka.remote.WireFormats.ActorRefData
 
PARSER - Static variable in class akka.remote.WireFormats.AddressData
 
PARSER - Static variable in class akka.remote.WireFormats.AkkaControlMessage
 
PARSER - Static variable in class akka.remote.WireFormats.AkkaHandshakeInfo
 
PARSER - Static variable in class akka.remote.WireFormats.AkkaProtocolMessage
 
PARSER - Static variable in class akka.remote.WireFormats.DaemonMsgCreateData
 
PARSER - Static variable in class akka.remote.WireFormats.DeployData
 
PARSER - Static variable in class akka.remote.WireFormats.PropsData
 
PARSER - Static variable in class akka.remote.WireFormats.RemoteEnvelope
 
PARSER - Static variable in class akka.remote.WireFormats.SerializedMessage
 
Pass(ActorRef, Option<Object>, Option<Object>) - Constructor for class akka.remote.EndpointManager.Pass
 
Pass$() - Constructor for class akka.remote.EndpointManager.Pass$
 
PassThru$() - Constructor for class akka.remote.transport.FailureInjectorTransportAdapter.PassThru$
 
path() - Method in class akka.remote.DaemonMsgCreate
 
path() - Method in class akka.remote.RemoteActorRef
 
PATH_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.ActorRefData
 
PATH_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DaemonMsgCreateData
 
PATH_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DeployData
 
PATTERN_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.SelectionEnvelope
 
Payload(ByteString) - Constructor for class akka.remote.transport.AkkaPduCodec.Payload
 
payload() - Method in class akka.remote.transport.AssociationHandle.InboundPayload
 
payload() - Method in class akka.remote.transport.TestTransport.WriteAttempt
 
Payload$() - Constructor for class akka.remote.transport.AkkaPduCodec.Payload$
 
PAYLOAD_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AkkaProtocolMessage
 
PduCodecException - Exception in akka.remote.transport
INTERNAL API
PduCodecException(String, Throwable) - Constructor for exception akka.remote.transport.PduCodecException
 
pendingReadHandoffs() - Method in class akka.remote.EndpointManager
 
phi() - Method in class akka.remote.PhiAccrualFailureDetector
The suspicion level of the accrual failure detector.
phi(long, double, double) - Method in class akka.remote.PhiAccrualFailureDetector
Calculation of phi, derived from the Cumulative distribution function for N(mean, stdDeviation) normal distribution, given by 1.0 / (1.0 + math.exp(-y * (1.5976 + 0.070566 * y * y))) where y = (x - mean) / standard_deviation This is an approximation defined in β Mathematics Handbook (Logistic approximation).
PhiAccrualFailureDetector - Class in akka.remote
Implementation of 'The Phi Accrual Failure Detector' by Hayashibara et al.
PhiAccrualFailureDetector(double, int, FiniteDuration, FiniteDuration, FiniteDuration, FailureDetector.Clock) - Constructor for class akka.remote.PhiAccrualFailureDetector
 
PhiAccrualFailureDetector(Config, EventStream) - Constructor for class akka.remote.PhiAccrualFailureDetector
Constructor that reads parameters from config.
pop() - Method in class akka.remote.transport.TestTransport.SwitchableLoggedBehavior
Restores the previous behavior.
PORT_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AddressData
 
PortSelector() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
postRestart(Throwable) - Method in class akka.remote.EndpointWriter
 
postRestart(Throwable) - Method in class akka.remote.ReliableDeliverySupervisor
 
postStop() - Method in class akka.remote.EndpointManager
 
postStop() - Method in class akka.remote.EndpointReader
 
postStop() - Method in class akka.remote.EndpointWriter
 
postStop() - Method in class akka.remote.ReliableDeliverySupervisor
 
postStop() - Method in class akka.remote.RemoteWatcher
 
postStop() - Method in class akka.remote.transport.ProtocolStateActor
 
postStop() - Method in class akka.remote.transport.ThrottledAssociation
 
preStart() - Method in class akka.remote.EndpointReader
 
preStart() - Method in class akka.remote.EndpointWriter
 
prioBuffer() - Method in class akka.remote.EndpointWriter
 
PriorityMessage - Interface in akka.remote
INTERNAL API Messages marked with this trait will be sent before other messages when buffering is active.
props() - Method in class akka.remote.DaemonMsgCreate
 
props(Address, Address, Transport, RemoteSettings, AkkaPduCodec, InboundMessageDispatcher, boolean, int, Option<ActorRef>, ConcurrentHashMap<EndpointManager.Link, EndpointManager.ResendState>) - Method in class akka.remote.EndpointReader$
 
props(Address, Address, Transport, RemoteSettings, AkkaPduCodec, InboundMessageDispatcher, boolean, int, Option<ActorRef>, ConcurrentHashMap<EndpointManager.Link, EndpointManager.ResendState>) - Static method in class akka.remote.EndpointReader
 
props(Option<AkkaProtocolHandle>, Address, Address, Option<Object>, AkkaProtocolTransport, RemoteSettings, AkkaPduCodec, ConcurrentHashMap<EndpointManager.Link, EndpointManager.ResendState>, Option<ActorRef>) - Method in class akka.remote.EndpointWriter$
 
props(Option<AkkaProtocolHandle>, Address, Address, Option<Object>, AkkaProtocolTransport, RemoteSettings, AkkaPduCodec, ConcurrentHashMap<EndpointManager.Link, EndpointManager.ResendState>, Option<ActorRef>) - Static method in class akka.remote.EndpointWriter
 
props(Option<AkkaProtocolHandle>, Address, Address, Option<Object>, AkkaProtocolTransport, RemoteSettings, AkkaPduCodec, ConcurrentHashMap<EndpointManager.Link, EndpointManager.ResendState>) - Method in class akka.remote.ReliableDeliverySupervisor$
 
props(Option<AkkaProtocolHandle>, Address, Address, Option<Object>, AkkaProtocolTransport, RemoteSettings, AkkaPduCodec, ConcurrentHashMap<EndpointManager.Link, EndpointManager.ResendState>) - Static method in class akka.remote.ReliableDeliverySupervisor
 
props(FailureDetectorRegistry<Address>, FiniteDuration, FiniteDuration, FiniteDuration) - Method in class akka.remote.RemoteWatcher$
Factory method for RemoteWatcher Props.
props(FailureDetectorRegistry<Address>, FiniteDuration, FiniteDuration, FiniteDuration) - Static method in class akka.remote.RemoteWatcher
Factory method for RemoteWatcher Props.
props() - Method in class akka.remote.Remoting.RegisterTransportActor
 
PROPS_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DaemonMsgCreateData
 
ProtobufSerializer - Class in akka.remote.serialization
This Serializer serializes akka.protobuf.Message and com.google.protobuf.Message It is using reflection to find the parseFrom and toByteArray methods to avoid dependency to com.google.protobuf.
ProtobufSerializer(ExtendedActorSystem) - Constructor for class akka.remote.serialization.ProtobufSerializer
 
ProtobufSerializer() - Constructor for class akka.remote.serialization.ProtobufSerializer
 
ProtobufSerializer$ - Class in akka.remote.serialization
 
ProtobufSerializer$() - Constructor for class akka.remote.serialization.ProtobufSerializer$
 
PROTOCOL_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AddressData
 
ProtocolStateActor - Class in akka.remote.transport
 
ProtocolStateActor(ProtocolStateActor.InitialProtocolStateData, HandshakeInfo, Option<Object>, AkkaProtocolSettings, AkkaPduCodec, FailureDetector) - Constructor for class akka.remote.transport.ProtocolStateActor
 
ProtocolStateActor(HandshakeInfo, Address, Promise<AssociationHandle>, Transport, AkkaProtocolSettings, AkkaPduCodec, FailureDetector, Option<Object>) - Constructor for class akka.remote.transport.ProtocolStateActor
 
ProtocolStateActor(HandshakeInfo, AssociationHandle, Transport.AssociationEventListener, AkkaProtocolSettings, AkkaPduCodec, FailureDetector) - Constructor for class akka.remote.transport.ProtocolStateActor
 
ProtocolStateActor$ - Class in akka.remote.transport
 
ProtocolStateActor$() - Constructor for class akka.remote.transport.ProtocolStateActor$
 
ProtocolStateActor.AssociatedWaitHandler - Class in akka.remote.transport
 
ProtocolStateActor.AssociatedWaitHandler$ - Class in akka.remote.transport
 
ProtocolStateActor.AssociationState - Interface in akka.remote.transport
 
ProtocolStateActor.Closed$ - Class in akka.remote.transport
 
ProtocolStateActor.ForbiddenUidReason$ - Class in akka.remote.transport
 
ProtocolStateActor.Handle - Class in akka.remote.transport
 
ProtocolStateActor.Handle$ - Class in akka.remote.transport
 
ProtocolStateActor.HandleListenerRegistered - Class in akka.remote.transport
 
ProtocolStateActor.HandleListenerRegistered$ - Class in akka.remote.transport
 
ProtocolStateActor.HeartbeatTimer$ - Class in akka.remote.transport
 
ProtocolStateActor.InboundUnassociated - Class in akka.remote.transport
 
ProtocolStateActor.InboundUnassociated$ - Class in akka.remote.transport
 
ProtocolStateActor.InitialProtocolStateData - Interface in akka.remote.transport
 
ProtocolStateActor.ListenerReady - Class in akka.remote.transport
 
ProtocolStateActor.ListenerReady$ - Class in akka.remote.transport
 
ProtocolStateActor.Open$ - Class in akka.remote.transport
 
ProtocolStateActor.OutboundUnassociated - Class in akka.remote.transport
 
ProtocolStateActor.OutboundUnassociated$ - Class in akka.remote.transport
 
ProtocolStateActor.OutboundUnderlyingAssociated - Class in akka.remote.transport
 
ProtocolStateActor.OutboundUnderlyingAssociated$ - Class in akka.remote.transport
 
ProtocolStateActor.ProtocolStateData - Interface in akka.remote.transport
 
ProtocolStateActor.TimeoutReason - Class in akka.remote.transport
 
ProtocolStateActor.TimeoutReason$ - Class in akka.remote.transport
 
ProtocolStateActor.WaitHandshake$ - Class in akka.remote.transport
 
provider() - Method in class akka.remote.EndpointReader
 
provider() - Method in class akka.remote.EndpointWriter
 
provider() - Method in class akka.remote.RARP
 
provider() - Method in class akka.remote.RemoteActorRef
 
provider() - Method in class akka.remote.RemoteTransport
 
prune() - Method in class akka.remote.EndpointManager.EndpointRegistry
 
Prune$() - Constructor for class akka.remote.EndpointManager.Prune$
 
pruneInterval() - Method in class akka.remote.EndpointManager
 
pruneTimerCancellable() - Method in class akka.remote.EndpointManager
 
publishAddressTerminated(Address) - Method in class akka.remote.RemoteWatcher
 
publishDisassociated() - Method in class akka.remote.EndpointActor
 
publishError(Throwable, Logging.LogLevel) - Method in class akka.remote.EndpointActor
 
push(Function1<A, Future<B>>) - Method in class akka.remote.transport.TestTransport.SwitchableLoggedBehavior
Changes the current behavior to the provided one.
pushConstant(B) - Method in class akka.remote.transport.TestTransport.SwitchableLoggedBehavior
Changes the behavior to return a completed future with the given constant value.
pushDelayed() - Method in class akka.remote.transport.TestTransport.SwitchableLoggedBehavior
Enables control of the completion of the previously active behavior.
pushError(Throwable) - Method in class akka.remote.transport.TestTransport.SwitchableLoggedBehavior
Changes the current behavior to return a failed future containing the given Throwable.

Q

Quarantine(Address, Option<Object>) - Constructor for class akka.remote.EndpointManager.Quarantine
 
quarantine(Address, Option<Object>) - Method in class akka.remote.RemoteActorRefProvider
Marks a remote system as out of sync and prevents reconnects until the quarantine timeout elapses.
quarantine(Address, Option<Object>) - Method in class akka.remote.RemoteTransport
Marks a remote system as out of sync and prevents reconnects until the quarantine timeout elapses.
quarantine(Address, Option<Object>) - Method in class akka.remote.RemoteWatcher
 
quarantine(Address, Option<Object>) - Method in class akka.remote.Remoting
 
Quarantine$() - Constructor for class akka.remote.EndpointManager.Quarantine$
 
Quarantined(int, Deadline) - Constructor for class akka.remote.EndpointManager.Quarantined
 
Quarantined$() - Constructor for class akka.remote.EndpointManager.Quarantined$
 
Quarantined$() - Constructor for class akka.remote.transport.AssociationHandle.Quarantined$
 
QuarantinedEvent - Class in akka.remote
 
QuarantinedEvent(Address, int) - Constructor for class akka.remote.QuarantinedEvent
 
QuarantinedEvent$ - Class in akka.remote
 
QuarantinedEvent$() - Constructor for class akka.remote.QuarantinedEvent$
 
QuarantineDuration() - Method in class akka.remote.RemoteSettings
 
queue() - Method in class akka.remote.transport.ProtocolStateActor.AssociatedWaitHandler
 

R

RARP - Class in akka.remote
INTERNAL API
RARP(RemoteActorRefProvider) - Constructor for class akka.remote.RARP
 
RARP$ - Class in akka.remote
INTERNAL API
RARP$() - Constructor for class akka.remote.RARP$
 
rawValue() - Method in class akka.remote.SeqNo
 
reader() - Method in class akka.remote.EndpointWriter
 
readerId() - Method in class akka.remote.EndpointWriter
 
readHandlerPromise() - Method in class akka.remote.transport.AkkaProtocolHandle
 
readHandlerPromise() - Method in interface akka.remote.transport.AssociationHandle
The Promise returned by this call must be completed with an AssociationHandle.HandleEventListener to register a listener responsible for handling incoming payload.
readHandlerPromise() - Method in class akka.remote.transport.FailureInjectorHandle
 
readHandlerPromise() - Method in class akka.remote.transport.netty.TcpAssociationHandle
 
readHandlerPromise() - Method in class akka.remote.transport.netty.UdpAssociationHandle
 
readHandlerPromise() - Method in class akka.remote.transport.TestAssociationHandle
 
readHandlerPromise() - Method in class akka.remote.transport.ThrottlerHandle
 
readOnlyEndpointFor(Address) - Method in class akka.remote.EndpointManager.EndpointRegistry
 
ready() - Method in class akka.remote.transport.ActorTransportAdapterManager
 
ready() - Method in class akka.remote.transport.AkkaProtocolManager
 
ready() - Method in class akka.remote.transport.ThrottlerManager
 
reapUnreachable() - Method in class akka.remote.RemoteWatcher
 
ReapUnreachableTick$() - Constructor for class akka.remote.RemoteWatcher.ReapUnreachableTick$
 
reason() - Method in class akka.remote.transport.AkkaPduCodec.Disassociate
 
reason() - Method in class akka.remote.transport.ThrottledAssociation.FailWith
 
reason() - Method in class akka.remote.transport.ThrottlerTransportAdapter.ForceDisassociateExplicitly
 
receive(T) - Method in class akka.remote.AckedReceiveBuffer
Puts a sequenced message in the receive buffer returning a new buffer.
receive() - Method in class akka.remote.EndpointManager
 
receive() - Method in class akka.remote.EndpointReader
 
receive() - Method in class akka.remote.EndpointWriter
 
receive() - Method in class akka.remote.ReliableDeliverySupervisor
 
receive() - Method in class akka.remote.RemoteDeploymentWatcher
 
receive() - Method in class akka.remote.RemoteWatcher
 
receive() - Method in class akka.remote.Remoting.TransportSupervisor
 
receive() - Method in class akka.remote.transport.ActorTransportAdapterManager
 
Receive$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.Direction.Receive$
 
receiveBuffers() - Method in class akka.remote.EndpointManager
 
receiveBuffers() - Method in class akka.remote.EndpointReader
 
receiveBuffers() - Method in class akka.remote.EndpointWriter
 
receiveBuffers() - Method in class akka.remote.ReliableDeliverySupervisor
 
ReceiveBufferSize() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
receiveHeartbeat() - Method in class akka.remote.RemoteWatcher
 
receiveHeartbeatRsp(int) - Method in class akka.remote.RemoteWatcher
 
recipient() - Method in class akka.remote.EndpointManager.Send
 
recipient() - Method in class akka.remote.transport.AkkaPduCodec.Message
 
recipient() - Method in class akka.remote.transport.TestTransport.WriteAttempt
 
RECIPIENT_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.RemoteEnvelope
 
recipientAddress() - Method in class akka.remote.transport.AkkaPduCodec.Message
 
refuseUid(Address) - Method in class akka.remote.EndpointManager.EndpointRegistry
 
refuseUid() - Method in class akka.remote.EndpointManager.Pass
 
refuseUid() - Method in class akka.remote.ReliableDeliverySupervisor
 
refuseUid() - Method in class akka.remote.transport.AkkaProtocolTransport.AssociateUnderlyingRefuseUid
 
registerAllExtensions(ExtensionRegistry) - Static method in class akka.remote.ContainerFormats
 
registerAllExtensions(ExtensionRegistry) - Static method in class akka.remote.WireFormats
 
registerListener(Channel, AssociationHandle.HandleEventListener, ChannelBuffer, InetSocketAddress) - Method in interface akka.remote.transport.netty.CommonHandlers
 
registerListener(Channel, AssociationHandle.HandleEventListener, ChannelBuffer, InetSocketAddress) - Method in interface akka.remote.transport.netty.TcpHandlers
 
registerListener(Channel, AssociationHandle.HandleEventListener, ChannelBuffer, InetSocketAddress) - Method in interface akka.remote.transport.netty.UdpHandlers
 
registerListenerPair(Tuple2<Address, Address>, Tuple2<AssociationHandle.HandleEventListener, AssociationHandle.HandleEventListener>) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Registers a Future of two handle event listeners corresponding to the two endpoints of an association.
registerReadOnlyEndpoint(Address, ActorRef, int) - Method in class akka.remote.EndpointManager.EndpointRegistry
 
registerTempActor(InternalActorRef, ActorPath) - Method in class akka.remote.RemoteActorRefProvider
 
registerTransport(TestTransport, Future<Transport.AssociationEventListener>) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Records a mapping between an address and the corresponding (transport, associationEventListener) pair.
RegisterTransportActor(Props, String) - Constructor for class akka.remote.Remoting.RegisterTransportActor
 
RegisterTransportActor$() - Constructor for class akka.remote.Remoting.RegisterTransportActor$
 
registerWritableEndpoint(Address, Option<Object>, Option<Object>, ActorRef) - Method in class akka.remote.EndpointManager.EndpointRegistry
 
registerWritableEndpointUid(Address, int) - Method in class akka.remote.EndpointManager.EndpointRegistry
 
registry() - Method in class akka.remote.transport.TestTransport
 
reliableDeliveryEnabled() - Method in class akka.remote.transport.AkkaPduCodec.Message
 
reliableDeliverySupervisor() - Method in class akka.remote.EndpointReader
 
reliableDeliverySupervisor() - Method in class akka.remote.EndpointWriter
 
ReliableDeliverySupervisor - Class in akka.remote
INTERNAL API
ReliableDeliverySupervisor(Option<AkkaProtocolHandle>, Address, Address, Option<Object>, AkkaProtocolTransport, RemoteSettings, AkkaPduCodec, ConcurrentHashMap<EndpointManager.Link, EndpointManager.ResendState>) - Constructor for class akka.remote.ReliableDeliverySupervisor
 
ReliableDeliverySupervisor$ - Class in akka.remote
INTERNAL API
ReliableDeliverySupervisor$() - Constructor for class akka.remote.ReliableDeliverySupervisor$
 
ReliableDeliverySupervisor.AttemptSysMsgRedelivery$ - Class in akka.remote
 
ReliableDeliverySupervisor.GotUid - Class in akka.remote
 
ReliableDeliverySupervisor.GotUid$ - Class in akka.remote
 
ReliableDeliverySupervisor.Idle$ - Class in akka.remote
 
ReliableDeliverySupervisor.IsIdle$ - Class in akka.remote
 
ReliableDeliverySupervisor.Ungate$ - Class in akka.remote
 
remote() - Method in class akka.remote.transport.TestTransport.DisassociateAttempt
 
RemoteActorRef - Class in akka.remote
INTERNAL API Remote ActorRef that is used when referencing the Actor on a different node than its "home" node.
RemoteActorRef(RemoteTransport, Address, ActorPath, InternalActorRef, Option<Props>, Option<Deploy>) - Constructor for class akka.remote.RemoteActorRef
 
RemoteActorRefProvider - Class in akka.remote
INTERNAL API Depending on this class is not supported, only the ActorRefProvider interface is supported.
RemoteActorRefProvider(String, ActorSystem.Settings, EventStream, DynamicAccess) - Constructor for class akka.remote.RemoteActorRefProvider
 
RemoteActorRefProvider$ - Class in akka.remote
INTERNAL API
RemoteActorRefProvider$() - Constructor for class akka.remote.RemoteActorRefProvider$
 
RemoteActorRefProvider.Finished$ - Class in akka.remote
 
RemoteActorRefProvider.Idle$ - Class in akka.remote
 
RemoteActorRefProvider.TerminatorState - Interface in akka.remote
 
RemoteActorRefProvider.Uninitialized$ - Class in akka.remote
 
RemoteActorRefProvider.WaitDaemonShutdown$ - Class in akka.remote
 
RemoteActorRefProvider.WaitTransportShutdown$ - Class in akka.remote
 
remoteAddres() - Method in class akka.remote.ReliableDeliverySupervisor.GotUid
 
remoteAddress() - Method in class akka.remote.AssociatedEvent
 
remoteAddress() - Method in class akka.remote.AssociationErrorEvent
 
remoteAddress() - Method in interface akka.remote.AssociationEvent
 
remoteAddress() - Method in class akka.remote.DisassociatedEvent
 
remoteAddress() - Method in class akka.remote.EndpointActor
 
remoteAddress() - Method in class akka.remote.EndpointManager.Link
 
remoteAddress() - Method in class akka.remote.EndpointManager.Quarantine
 
remoteAddress() - Method in exception akka.remote.HopelessAssociation
 
remoteAddress() - Method in exception akka.remote.InvalidAssociation
 
remoteAddress() - Method in class akka.remote.ReliableDeliverySupervisor
 
remoteAddress() - Method in exception akka.remote.ShutDownAssociation
 
remoteAddress() - Method in class akka.remote.transport.AbstractTransportAdapterHandle
 
remoteAddress() - Method in class akka.remote.transport.ActorTransportAdapter.AssociateUnderlying
 
remoteAddress() - Method in class akka.remote.transport.AkkaProtocolTransport.AssociateUnderlyingRefuseUid
 
remoteAddress() - Method in interface akka.remote.transport.AssociationHandle
Address of the remote endpoint.
remoteAddress() - Method in class akka.remote.transport.FailureInjectorTransportAdapter.One
 
remoteAddress() - Method in class akka.remote.transport.netty.TcpAssociationHandle
 
remoteAddress() - Method in class akka.remote.transport.netty.UdpAssociationHandle
 
remoteAddress() - Method in class akka.remote.transport.ProtocolStateActor.OutboundUnassociated
 
remoteAddress() - Method in class akka.remote.transport.TestAssociationHandle
 
remoteAddress() - Method in class akka.remote.transport.TestTransport.AssociateAttempt
 
remoteDaemon() - Method in class akka.remote.RemoteActorRefProvider
 
RemoteDeployer - Class in akka.remote
INTERNAL API
RemoteDeployer(ActorSystem.Settings, DynamicAccess) - Constructor for class akka.remote.RemoteDeployer
 
RemoteDeploymentWatcher - Class in akka.remote
INTERNAL API
RemoteDeploymentWatcher() - Constructor for class akka.remote.RemoteDeploymentWatcher
 
RemoteDeploymentWatcher$ - Class in akka.remote
INTERNAL API
RemoteDeploymentWatcher$() - Constructor for class akka.remote.RemoteDeploymentWatcher$
 
RemoteDeploymentWatcher.WatchRemote - Class in akka.remote
 
RemoteDeploymentWatcher.WatchRemote$ - Class in akka.remote
 
RemoteLifecycleEventsLogLevel() - Method in class akka.remote.RemoteSettings
 
remoteListenerRelativeTo(TestAssociationHandle, Tuple2<AssociationHandle.HandleEventListener, AssociationHandle.HandleEventListener>) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Returns the remote endpoint for a pair of endpoints relative to the owner of the supplied handle.
remoteMetrics() - Method in class akka.remote.EndpointWriter
 
RemoteMetrics - Interface in akka.remote
INTERNAL API
RemoteMetricsExtension - Class in akka.remote
INTERNAL API Extension that keeps track of remote metrics, such as max size of different message types.
RemoteMetricsExtension() - Constructor for class akka.remote.RemoteMetricsExtension
 
RemoteMetricsExtension$ - Class in akka.remote
INTERNAL API Extension that keeps track of remote metrics, such as max size of different message types.
RemoteMetricsExtension$() - Constructor for class akka.remote.RemoteMetricsExtension$
 
RemoteMetricsOff - Class in akka.remote
INTERNAL API
RemoteMetricsOff() - Constructor for class akka.remote.RemoteMetricsOff
 
RemoteMetricsOn - Class in akka.remote
INTERNAL API
RemoteMetricsOn(ExtendedActorSystem) - Constructor for class akka.remote.RemoteMetricsOn
 
remoteProvider() - Method in class akka.remote.RemoteWatcher
 
RemoteRef - Interface in akka.remote
 
RemoteRouterConfig - Class in akka.remote.routing
RouterConfig implementation for remote deployment on defined target nodes.
RemoteRouterConfig(Pool, Iterable<Address>) - Constructor for class akka.remote.routing.RemoteRouterConfig
 
RemoteRouterConfig(Pool, Iterable<Address>) - Constructor for class akka.remote.routing.RemoteRouterConfig
 
RemoteRouterConfig(Pool, Address[]) - Constructor for class akka.remote.routing.RemoteRouterConfig
 
RemoteRouterConfig$ - Class in akka.remote.routing
 
RemoteRouterConfig$() - Constructor for class akka.remote.routing.RemoteRouterConfig$
 
RemoteScope - Class in akka.remote
 
RemoteScope(Address) - Constructor for class akka.remote.RemoteScope
 
RemoteScope$ - Class in akka.remote
 
RemoteScope$() - Constructor for class akka.remote.RemoteScope$
 
remoteSettings() - Method in class akka.remote.RemoteActorRefProvider
 
RemoteSettings - Class in akka.remote
 
RemoteSettings(Config) - Constructor for class akka.remote.RemoteSettings
 
RemoteSystemDaemon - Class in akka.remote
INTERNAL API
RemoteSystemDaemon(ActorSystemImpl, ActorPath, InternalActorRef, ActorRef, LoggingAdapter, boolean) - Constructor for class akka.remote.RemoteSystemDaemon
 
RemoteTransport - Class in akka.remote
INTERNAL API
RemoteTransport(ExtendedActorSystem, RemoteActorRefProvider) - Constructor for class akka.remote.RemoteTransport
 
RemoteTransportException - Exception in akka.remote
RemoteTransportException represents a general failure within a RemoteTransport, such as inability to start, wrong configuration etc.
RemoteTransportException(String, Throwable) - Constructor for exception akka.remote.RemoteTransportException
 
RemoteTransportExceptionNoStackTrace - Exception in akka.remote
RemoteTransportException without stack trace.
RemoteTransportExceptionNoStackTrace(String, Throwable) - Constructor for exception akka.remote.RemoteTransportExceptionNoStackTrace
 
remoteWatcher() - Method in class akka.remote.RemoteActorRefProvider
 
RemoteWatcher - Class in akka.remote
INTERNAL API
RemoteWatcher(FailureDetectorRegistry<Address>, FiniteDuration, FiniteDuration, FiniteDuration) - Constructor for class akka.remote.RemoteWatcher
 
RemoteWatcher$ - Class in akka.remote
INTERNAL API
RemoteWatcher$() - Constructor for class akka.remote.RemoteWatcher$
 
RemoteWatcher.ExpectedFirstHeartbeat - Class in akka.remote
 
RemoteWatcher.ExpectedFirstHeartbeat$ - Class in akka.remote
 
RemoteWatcher.Heartbeat$ - Class in akka.remote
 
RemoteWatcher.HeartbeatRsp - Class in akka.remote
 
RemoteWatcher.HeartbeatRsp$ - Class in akka.remote
 
RemoteWatcher.HeartbeatTick$ - Class in akka.remote
 
RemoteWatcher.ReapUnreachableTick$ - Class in akka.remote
 
RemoteWatcher.Stats - Class in akka.remote
 
RemoteWatcher.Stats$ - Class in akka.remote
 
RemoteWatcher.UnwatchRemote - Class in akka.remote
 
RemoteWatcher.UnwatchRemote$ - Class in akka.remote
 
RemoteWatcher.WatchRemote - Class in akka.remote
 
RemoteWatcher.WatchRemote$ - Class in akka.remote
 
Remoting - Class in akka.remote
INTERNAL API
Remoting(ExtendedActorSystem, RemoteActorRefProvider) - Constructor for class akka.remote.Remoting
 
Remoting$ - Class in akka.remote
INTERNAL API
Remoting$() - Constructor for class akka.remote.Remoting$
 
Remoting.RegisterTransportActor - Class in akka.remote
 
Remoting.RegisterTransportActor$ - Class in akka.remote
 
Remoting.TransportSupervisor - Class in akka.remote
 
RemotingErrorEvent - Class in akka.remote
 
RemotingErrorEvent(Throwable) - Constructor for class akka.remote.RemotingErrorEvent
 
RemotingErrorEvent$ - Class in akka.remote
 
RemotingErrorEvent$() - Constructor for class akka.remote.RemotingErrorEvent$
 
RemotingLifecycleEvent - Interface in akka.remote
 
RemotingListenEvent - Class in akka.remote
 
RemotingListenEvent(Set<Address>) - Constructor for class akka.remote.RemotingListenEvent
 
RemotingListenEvent$ - Class in akka.remote
 
RemotingListenEvent$() - Constructor for class akka.remote.RemotingListenEvent$
 
RemotingShutdownEvent - Class in akka.remote
 
RemotingShutdownEvent() - Constructor for class akka.remote.RemotingShutdownEvent
 
RemotingShutdownEvent$ - Class in akka.remote
 
RemotingShutdownEvent$() - Constructor for class akka.remote.RemotingShutdownEvent$
 
remove(A) - Method in class akka.remote.DefaultFailureDetectorRegistry
 
remove(A) - Method in interface akka.remote.FailureDetectorRegistry
Removes the heartbeat management for a resource.
removePattern(int) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
repeated .Selection pattern = 3;
removePolicy(Address) - Method in class akka.remote.EndpointManager.EndpointRegistry
 
removeScheme(String) - Method in interface akka.remote.transport.SchemeAugmenter
 
removeScheme(Address) - Method in interface akka.remote.transport.SchemeAugmenter
 
removeWatch(InternalActorRef, InternalActorRef) - Method in class akka.remote.RemoteWatcher
 
removeWatchee(InternalActorRef) - Method in class akka.remote.RemoteWatcher
 
replyTo() - Method in class akka.remote.EndpointWriter.StopReading
 
replyTo() - Method in class akka.remote.EndpointWriter.TakeOver
 
requester() - Method in class akka.remote.transport.TestTransport.DisassociateAttempt
 
RequireCookie() - Method in class akka.remote.transport.AkkaProtocolSettings
 
resendBuffer() - Method in class akka.remote.ReliableDeliverySupervisor
 
ResendBufferCapacityReachedException - Exception in akka.remote
 
ResendBufferCapacityReachedException(int) - Constructor for exception akka.remote.ResendBufferCapacityReachedException
 
ResendState(int, AckedReceiveBuffer<AkkaPduCodec.Message>) - Constructor for class akka.remote.EndpointManager.ResendState
 
ResendState$() - Constructor for class akka.remote.EndpointManager.ResendState$
 
ResendUnfulfillableException - Exception in akka.remote
 
ResendUnfulfillableException() - Constructor for exception akka.remote.ResendUnfulfillableException
 
reset() - Method in class akka.remote.DefaultFailureDetectorRegistry
 
reset() - Method in interface akka.remote.FailureDetectorRegistry
Removes all resources and any associated failure detector state.
reset() - Method in class akka.remote.ReliableDeliverySupervisor
 
reset() - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Resets the state of the registry.
resizer() - Method in class akka.remote.routing.RemoteRouterConfig
 
resolveActorRef(String) - Method in class akka.remote.RemoteActorRefProvider
 
resolveActorRef(ActorPath) - Method in class akka.remote.RemoteActorRefProvider
 
resolveActorRefWithLocalAddress(String, Address) - Method in class akka.remote.RemoteActorRefProvider
INTERNAL API Called in deserialization of incoming remote messages where the correct local address is known.
restart(Throwable) - Method in class akka.remote.RemoteActorRef
 
results() - Method in class akka.remote.EndpointManager.ListensResult
 
resume(Throwable) - Method in class akka.remote.RemoteActorRef
 
RetryGateClosedFor() - Method in class akka.remote.RemoteSettings
 
retryGateEnabled() - Method in class akka.remote.EndpointManager
 
reWatch(Address) - Method in class akka.remote.RemoteWatcher
To ensure that we receive heartbeat messages from the right actor system incarnation we send Watch again for the first HeartbeatRsp (containing the system UID) and if HeartbeatRsp contains a new system UID.
rootGuardian() - Method in class akka.remote.RemoteActorRefProvider
 
rootGuardianAt(Address) - Method in class akka.remote.RemoteActorRefProvider
 
rootPath() - Method in class akka.remote.RemoteActorRefProvider
 
ROUTERCONFIG_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DeployData
 
routerDispatcher() - Method in class akka.remote.routing.RemoteRouterConfig
 

S

saveState() - Method in class akka.remote.EndpointReader
 
scheduleBackoffTimer() - Method in class akka.remote.EndpointWriter
 
scheduleDequeue(FiniteDuration) - Method in class akka.remote.transport.ThrottledAssociation
 
scheduler() - Method in class akka.remote.RemoteWatcher
 
SchemeAugmenter - Interface in akka.remote.transport
 
schemeIdentifier() - Method in class akka.remote.transport.AbstractTransportAdapter
 
schemeIdentifier() - Method in class akka.remote.transport.netty.NettyTransport
 
schemeIdentifier() - Method in class akka.remote.transport.TestTransport
 
SchemeIdentifier() - Method in class akka.remote.transport.ThrottlerTransportAdapter$
 
SchemeIdentifier() - Static method in class akka.remote.transport.ThrottlerTransportAdapter
 
schemeIdentifier() - Method in interface akka.remote.transport.Transport
Returns a string that will be used as the scheme part of the URLs corresponding to this transport
SCOPE_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DeployData
 
SecureCookie() - Method in class akka.remote.transport.AkkaProtocolSettings
 
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
 
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$
 
selfHeartbeatRspMsg() - Method in class akka.remote.RemoteWatcher
 
Send(Object, Option<ActorRef>, RemoteActorRef, Option<SeqNo>) - Constructor for class akka.remote.EndpointManager.Send
 
send(Object, Option<ActorRef>, RemoteActorRef) - Method in class akka.remote.RemoteTransport
Sends the given message to the recipient supplying the sender() if any
send(Object, Option<ActorRef>, RemoteActorRef) - Method in class akka.remote.Remoting
 
Send$() - Constructor for class akka.remote.EndpointManager.Send$
 
Send$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.Direction.Send$
 
sendBufferedMessages() - Method in class akka.remote.EndpointWriter
 
SendBufferSize() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
sender() - Method in class akka.remote.transport.TestTransport.WriteAttempt
 
SENDER_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.RemoteEnvelope
 
senderOption() - Method in class akka.remote.EndpointManager.Send
 
senderOption() - Method in class akka.remote.transport.AkkaPduCodec.Message
 
sendHeartbeat() - Method in class akka.remote.RemoteWatcher
 
sendSystemMessage(SystemMessage) - Method in class akka.remote.RemoteActorRef
 
sendSystemMessage(SystemMessage) - Method in class akka.remote.RemoteSystemDaemon
 
seq() - Method in class akka.remote.EndpointManager.Send
 
seq() - Method in interface akka.remote.HasSequenceNumber
Sequence number of the message
seq() - Method in class akka.remote.transport.AkkaPduCodec.Message
 
SEQ_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.RemoteEnvelope
 
seqCounter() - Method in class akka.remote.ReliableDeliverySupervisor
 
SeqNo - Class in akka.remote
 
SeqNo(long) - Constructor for class akka.remote.SeqNo
 
SeqNo$ - Class in akka.remote
 
SeqNo$() - Constructor for class akka.remote.SeqNo$
 
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$
 
serialization() - Method in class akka.remote.RemoteActorRefProvider
 
serialization() - Method in class akka.remote.serialization.DaemonMsgCreateSerializer
 
serialize(ExtendedActorSystem, Object) - Method in class akka.remote.MessageSerializer$
Uses Akka Serialization for the specified ActorSystem to transform the given message to a MessageProtocol
serialize(ExtendedActorSystem, Object) - Static method in class akka.remote.MessageSerializer
Uses Akka Serialization for the specified ActorSystem to transform the given message to a MessageProtocol
serialize(Object) - Method in class akka.remote.serialization.DaemonMsgCreateSerializer
 
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.
serializedMessage() - Method in class akka.remote.transport.AkkaPduCodec.Message
 
SERIALIZERID_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.SelectionEnvelope
 
SERIALIZERID_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.SerializedMessage
 
ServerHandler - Class in akka.remote.transport.netty
INTERNAL API
ServerHandler(NettyTransport, Future<Transport.AssociationEventListener>) - Constructor for class akka.remote.transport.netty.ServerHandler
 
ServerSocketWorkerPoolSize() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
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;
setArgs(int, ByteString) - Method in class akka.remote.WireFormats.PropsData.Builder
repeated bytes args = 4;
setClasses(int, String) - Method in class akka.remote.WireFormats.PropsData.Builder
repeated string classes = 5;
setClazz(String) - Method in class akka.remote.WireFormats.PropsData.Builder
required string clazz = 3;
setClazzBytes(ByteString) - Method in class akka.remote.WireFormats.PropsData.Builder
required string clazz = 3;
setCommandType(WireFormats.CommandType) - Method in class akka.remote.WireFormats.AkkaControlMessage.Builder
required .CommandType commandType = 1;
setConfig(ByteString) - Method in class akka.remote.WireFormats.DeployData.Builder
optional bytes config = 2;
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;
setCumulativeAck(long) - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
required fixed64 cumulativeAck = 1;
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;
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;
setEnclosedMessage(ByteString) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
required bytes enclosedMessage = 1;
setEnvelope(WireFormats.RemoteEnvelope) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .RemoteEnvelope envelope = 2;
setEnvelope(WireFormats.RemoteEnvelope.Builder) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer.Builder
optional .RemoteEnvelope envelope = 2;
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;
setHostname(String) - Method in class akka.remote.WireFormats.AddressData.Builder
required string hostname = 2;
setHostnameBytes(ByteString) - Method in class akka.remote.WireFormats.AddressData.Builder
required string hostname = 2;
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;
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;
setMessage(WireFormats.SerializedMessage) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
required .SerializedMessage message = 2;
setMessage(WireFormats.SerializedMessage.Builder) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
required .SerializedMessage message = 2;
setMessage(ByteString) - Method in class akka.remote.WireFormats.SerializedMessage.Builder
required bytes message = 1;
setMessageManifest(ByteString) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
optional bytes messageManifest = 4;
setMessageManifest(ByteString) - Method in class akka.remote.WireFormats.SerializedMessage.Builder
optional bytes messageManifest = 3;
setNacks(int, long) - Method in class akka.remote.WireFormats.AcknowledgementInfo.Builder
repeated fixed64 nacks = 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;
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.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(ByteString) - Method in class akka.remote.WireFormats.AkkaProtocolMessage.Builder
optional bytes payload = 1;
setPort(int) - Method in class akka.remote.WireFormats.AddressData.Builder
required uint32 port = 3;
setProps(WireFormats.PropsData) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .PropsData props = 1;
setProps(WireFormats.PropsData.Builder) - Method in class akka.remote.WireFormats.DaemonMsgCreateData.Builder
required .PropsData props = 1;
setProtocol(String) - Method in class akka.remote.WireFormats.AddressData.Builder
optional string protocol = 4;
setProtocolBytes(ByteString) - Method in class akka.remote.WireFormats.AddressData.Builder
optional string protocol = 4;
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;
setRouterConfig(ByteString) - Method in class akka.remote.WireFormats.DeployData.Builder
optional bytes routerConfig = 3;
setScope(ByteString) - Method in class akka.remote.WireFormats.DeployData.Builder
optional bytes scope = 4;
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;
setSeq(long) - Method in class akka.remote.WireFormats.RemoteEnvelope.Builder
optional fixed64 seq = 5;
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;
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.remote.WireFormats.AddressData.Builder
required string system = 1;
setSystemBytes(ByteString) - Method in class akka.remote.WireFormats.AddressData.Builder
required string system = 1;
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$
 
settings() - Method in class akka.remote.EndpointActor
 
settings() - Method in class akka.remote.EndpointManager
 
settings() - Method in class akka.remote.ReliableDeliverySupervisor
 
settings() - Method in class akka.remote.RemoteActorRefProvider
 
settings() - Method in class akka.remote.transport.netty.NettyTransport
 
settings() - Method in class akka.remote.transport.TransportAdapters
 
setType(ContainerFormats.PatternType) - Method in class akka.remote.ContainerFormats.Selection.Builder
required .PatternType type = 1;
setUid(long) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo.Builder
required fixed64 uid = 2;
setWildcardFanOut(boolean) - Method in class akka.remote.ContainerFormats.SelectionEnvelope.Builder
optional bool wildcardFanOut = 5;
shouldDropInbound(Address, Object, String) - Method in class akka.remote.transport.FailureInjectorTransportAdapter
 
shouldDropOutbound(Address, Object, String) - Method in class akka.remote.transport.FailureInjectorTransportAdapter
 
shutdown() - Method in class akka.remote.RemoteTransport
Shuts down the remoting
shutdown() - Method in class akka.remote.Remoting
 
shutdown() - Method in class akka.remote.transport.AbstractTransportAdapter
 
shutdown() - Method in class akka.remote.transport.ActorTransportAdapter
 
shutdown() - Method in class akka.remote.transport.netty.NettyTransport
 
shutdown() - Method in class akka.remote.transport.TestTransport
 
shutdown() - Method in interface akka.remote.transport.Transport
Shuts down the transport layer and releases all the corresponding resources.
Shutdown$() - Constructor for class akka.remote.transport.AssociationHandle.Shutdown$
 
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
The TestTransport.SwitchableLoggedBehavior for the shutdown() method.
ShutdownTimeout() - Method in class akka.remote.RemoteSettings
 
smallBackoffCount() - Method in class akka.remote.EndpointWriter
 
squaredIntervalSum() - Method in class akka.remote.HeartbeatHistory
 
SSLEnabledAlgorithms() - Method in class akka.remote.transport.netty.SSLSettings
 
SSLKeyPassword() - Method in class akka.remote.transport.netty.SSLSettings
 
SSLKeyStore() - Method in class akka.remote.transport.netty.SSLSettings
 
SSLKeyStorePassword() - Method in class akka.remote.transport.netty.SSLSettings
 
SSLProtocol() - Method in class akka.remote.transport.netty.SSLSettings
 
SSLRandomNumberGenerator() - Method in class akka.remote.transport.netty.SSLSettings
 
SslSettings() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
SSLSettings - Class in akka.remote.transport.netty
INTERNAL API
SSLSettings(Config) - Constructor for class akka.remote.transport.netty.SSLSettings
 
SSLTrustStore() - Method in class akka.remote.transport.netty.SSLSettings
 
SSLTrustStorePassword() - Method in class akka.remote.transport.netty.SSLSettings
 
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
 
StartupFinished$() - Constructor for class akka.remote.EndpointManager.StartupFinished$
 
StartupTimeout() - Method in class akka.remote.RemoteSettings
 
stashedInbound() - Method in class akka.remote.EndpointManager
 
Stats(int, int, Set<Tuple2<ActorRef, ActorRef>>, Set<Address>) - Constructor for class akka.remote.RemoteWatcher.Stats
 
Stats$() - Constructor for class akka.remote.RemoteWatcher.Stats$
 
status() - Method in class akka.remote.EndpointManager.ManagementCommandAck
 
statusFuture() - Method in class akka.remote.transport.netty.ClientHandler
 
statusPromise() - Method in class akka.remote.transport.ActorTransportAdapter.AssociateUnderlying
 
statusPromise() - Method in class akka.remote.transport.AkkaProtocolTransport.AssociateUnderlyingRefuseUid
 
statusPromise() - Method in class akka.remote.transport.netty.ClientHandler
 
statusPromise() - Method in class akka.remote.transport.ProtocolStateActor.OutboundUnassociated
 
statusPromise() - Method in class akka.remote.transport.ProtocolStateActor.OutboundUnderlyingAssociated
 
statusPromise() - Method in class akka.remote.transport.ThrottlerManager.AssociateResult
 
stdDeviation() - Method in class akka.remote.HeartbeatHistory
 
stop() - Method in class akka.remote.RemoteActorRef
 
StoppedReading(ActorRef) - Constructor for class akka.remote.EndpointWriter.StoppedReading
 
StoppedReading$() - Constructor for class akka.remote.EndpointWriter.StoppedReading$
 
StopReading(ActorRef, ActorRef) - Constructor for class akka.remote.EndpointWriter.StopReading
 
StopReading$() - Constructor for class akka.remote.EndpointWriter.StopReading$
 
stopReason() - Method in class akka.remote.EndpointWriter
 
supervisor() - Method in class akka.remote.DaemonMsgCreate
 
supervisor() - Method in class akka.remote.RemoteDeploymentWatcher.WatchRemote
 
SUPERVISOR_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.DaemonMsgCreateData
 
supervisors() - Method in class akka.remote.RemoteDeploymentWatcher
 
supervisorStrategy() - Method in class akka.remote.EndpointManager
 
supervisorStrategy() - Method in class akka.remote.EndpointWriter
 
supervisorStrategy() - Method in class akka.remote.ReliableDeliverySupervisor
 
supervisorStrategy() - Method in class akka.remote.Remoting.TransportSupervisor
 
supervisorStrategy() - Method in class akka.remote.routing.RemoteRouterConfig
 
supervisorStrategy() - Method in class akka.remote.transport.AkkaProtocolManager
 
suspend() - Method in class akka.remote.RemoteActorRef
 
SwitchableLoggedBehavior(Function1<A, Future<B>>, Function1<A, BoxedUnit>) - Constructor for class akka.remote.transport.TestTransport.SwitchableLoggedBehavior
 
SysMsgAckTimeout() - Method in class akka.remote.RemoteSettings
 
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.remote.AddressUidExtension
 
system() - Method in class akka.remote.BoundAddressesExtension
 
system() - Method in class akka.remote.RemoteTransport
 
system() - Method in class akka.remote.serialization.DaemonMsgCreateSerializer
 
system() - Method in class akka.remote.serialization.MessageContainerSerializer
 
system() - Method in class akka.remote.serialization.ProtobufSerializer
 
system() - Method in class akka.remote.transport.netty.NettyTransport
 
SYSTEM_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AddressData
 
systemGuardian() - Method in class akka.remote.RemoteActorRefProvider
 
systemName() - Method in class akka.remote.RemoteActorRefProvider
 

T

TakeOver(AkkaProtocolHandle, ActorRef) - Constructor for class akka.remote.EndpointWriter.TakeOver
 
TakeOver$() - Constructor for class akka.remote.EndpointWriter.TakeOver$
 
Tcp$() - Constructor for class akka.remote.transport.netty.NettyTransportSettings.Tcp$
 
TcpAssociationHandle - Class in akka.remote.transport.netty
INTERNAL API
TcpAssociationHandle(Address, Address, NettyTransport, Channel) - Constructor for class akka.remote.transport.netty.TcpAssociationHandle
 
TcpClientHandler - Class in akka.remote.transport.netty
INTERNAL API
TcpClientHandler(NettyTransport, Address) - Constructor for class akka.remote.transport.netty.TcpClientHandler
 
TcpHandlers - Interface in akka.remote.transport.netty
INTERNAL API
TcpKeepalive() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
TcpNodelay() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
TcpReuseAddr() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
TcpServerHandler - Class in akka.remote.transport.netty
INTERNAL API
TcpServerHandler(NettyTransport, Future<Transport.AssociationEventListener>) - Constructor for class akka.remote.transport.netty.TcpServerHandler
 
tempContainer() - Method in class akka.remote.RemoteActorRefProvider
 
tempPath() - Method in class akka.remote.RemoteActorRefProvider
 
terminated(InternalActorRef, boolean, boolean) - Method in class akka.remote.RemoteWatcher
 
terminationFuture() - Method in class akka.remote.RemoteActorRefProvider
 
terminationHookDoneWhenNoChildren() - Method in class akka.remote.RemoteSystemDaemon
 
TestAssociationHandle - Class in akka.remote.transport
 
TestAssociationHandle(Address, Address, TestTransport, boolean) - Constructor for class akka.remote.transport.TestAssociationHandle
 
TestAssociationHandle$ - Class in akka.remote.transport
 
TestAssociationHandle$() - Constructor for class akka.remote.transport.TestAssociationHandle$
 
TestTransport - Class in akka.remote.transport
Transport implementation to be used for testing.
TestTransport(Address, TestTransport.AssociationRegistry, int, String) - Constructor for class akka.remote.transport.TestTransport
 
TestTransport(ExtendedActorSystem, Config) - Constructor for class akka.remote.transport.TestTransport
 
TestTransport$ - Class in akka.remote.transport
 
TestTransport$() - Constructor for class akka.remote.transport.TestTransport$
 
TestTransport.Activity - Interface in akka.remote.transport
Base trait for activities that are logged by TestTransport.
TestTransport.AssociateAttempt - Class in akka.remote.transport
 
TestTransport.AssociateAttempt$ - Class in akka.remote.transport
 
TestTransport.AssociationRegistry - Class in akka.remote.transport
Shared state among TestTransport instances.
TestTransport.DisassociateAttempt - Class in akka.remote.transport
 
TestTransport.DisassociateAttempt$ - Class in akka.remote.transport
 
TestTransport.ListenAttempt - Class in akka.remote.transport
 
TestTransport.ListenAttempt$ - Class in akka.remote.transport
 
TestTransport.ShutdownAttempt - Class in akka.remote.transport
 
TestTransport.ShutdownAttempt$ - Class in akka.remote.transport
 
TestTransport.SwitchableLoggedBehavior<A,B> - Class in akka.remote.transport
Test utility to make behavior of functions that return some Future[B] controllable from tests.
TestTransport.WriteAttempt - Class in akka.remote.transport
 
TestTransport.WriteAttempt$ - Class in akka.remote.transport
 
threshold() - Method in class akka.remote.PhiAccrualFailureDetector
 
ThrottledAssociation - Class in akka.remote.transport
INTERNAL API
ThrottledAssociation(ActorRef, Transport.AssociationEventListener, AssociationHandle, boolean) - Constructor for class akka.remote.transport.ThrottledAssociation
 
ThrottledAssociation$ - Class in akka.remote.transport
INTERNAL API
ThrottledAssociation$() - Constructor for class akka.remote.transport.ThrottledAssociation$
 
ThrottledAssociation.Dequeue$ - Class in akka.remote.transport
 
ThrottledAssociation.ExposedHandle - Class in akka.remote.transport
 
ThrottledAssociation.ExposedHandle$ - Class in akka.remote.transport
 
ThrottledAssociation.FailWith - Class in akka.remote.transport
 
ThrottledAssociation.FailWith$ - Class in akka.remote.transport
 
ThrottledAssociation.ThrottlerData - Interface in akka.remote.transport
 
ThrottledAssociation.ThrottlerState - Interface in akka.remote.transport
 
ThrottledAssociation.Throttling$ - Class in akka.remote.transport
 
ThrottledAssociation.Uninitialized$ - Class in akka.remote.transport
 
ThrottledAssociation.WaitExposedHandle$ - Class in akka.remote.transport
 
ThrottledAssociation.WaitMode$ - Class in akka.remote.transport
 
ThrottledAssociation.WaitModeAndUpstreamListener$ - Class in akka.remote.transport
 
ThrottledAssociation.WaitOrigin$ - Class in akka.remote.transport
 
ThrottledAssociation.WaitUpstreamListener$ - Class in akka.remote.transport
 
throttledMessages() - Method in class akka.remote.transport.ThrottledAssociation
 
throttlerActor() - Method in class akka.remote.transport.ThrottlerHandle
 
ThrottlerHandle - Class in akka.remote.transport
INTERNAL API
ThrottlerHandle(AssociationHandle, ActorRef) - Constructor for class akka.remote.transport.ThrottlerHandle
 
ThrottlerHandle$ - Class in akka.remote.transport
 
ThrottlerHandle$() - Constructor for class akka.remote.transport.ThrottlerHandle$
 
ThrottlerManager - Class in akka.remote.transport
INTERNAL API
ThrottlerManager(Transport) - Constructor for class akka.remote.transport.ThrottlerManager
 
ThrottlerManager$ - Class in akka.remote.transport
INTERNAL API
ThrottlerManager$() - Constructor for class akka.remote.transport.ThrottlerManager$
 
ThrottlerManager.AssociateResult - Class in akka.remote.transport
 
ThrottlerManager.AssociateResult$ - Class in akka.remote.transport
 
ThrottlerManager.Checkin - Class in akka.remote.transport
 
ThrottlerManager.Checkin$ - Class in akka.remote.transport
 
ThrottlerManager.Handle - Class in akka.remote.transport
 
ThrottlerManager.Handle$ - Class in akka.remote.transport
 
ThrottlerManager.Listener - Class in akka.remote.transport
 
ThrottlerManager.Listener$ - Class in akka.remote.transport
 
ThrottlerManager.ListenerAndMode - Class in akka.remote.transport
 
ThrottlerManager.ListenerAndMode$ - Class in akka.remote.transport
 
ThrottlerProvider - Class in akka.remote.transport
 
ThrottlerProvider() - Constructor for class akka.remote.transport.ThrottlerProvider
 
ThrottlerTransportAdapter - Class in akka.remote.transport
 
ThrottlerTransportAdapter(Transport, ExtendedActorSystem) - Constructor for class akka.remote.transport.ThrottlerTransportAdapter
 
ThrottlerTransportAdapter$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter$
 
ThrottlerTransportAdapter.Blackhole$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.Direction - Interface in akka.remote.transport
 
ThrottlerTransportAdapter.Direction$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.Direction.Both$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.Direction.Receive$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.Direction.Send$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.ForceDisassociate - Class in akka.remote.transport
Management Command to force disassociation of an address.
ThrottlerTransportAdapter.ForceDisassociate$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.ForceDisassociateAck$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.ForceDisassociateExplicitly - Class in akka.remote.transport
Management Command to force disassociation of an address with an explicit error.
ThrottlerTransportAdapter.ForceDisassociateExplicitly$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.SetThrottle - Class in akka.remote.transport
 
ThrottlerTransportAdapter.SetThrottle$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.SetThrottleAck$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.ThrottleMode - Interface in akka.remote.transport
 
ThrottlerTransportAdapter.TokenBucket - Class in akka.remote.transport
 
ThrottlerTransportAdapter.TokenBucket$ - Class in akka.remote.transport
 
ThrottlerTransportAdapter.Unthrottled$ - Class in akka.remote.transport
 
Throttling$() - Constructor for class akka.remote.transport.ThrottledAssociation.Throttling$
 
timeOfRelease() - Method in class akka.remote.EndpointManager.Gated
 
timeOfRelease() - Method in class akka.remote.EndpointManager.Quarantined
 
TimeoutReason(String) - Constructor for class akka.remote.transport.ProtocolStateActor.TimeoutReason
 
TimeoutReason$() - Constructor for class akka.remote.transport.ProtocolStateActor.TimeoutReason$
 
timeToAvailable(long, int) - Method in class akka.remote.transport.ThrottlerTransportAdapter.Blackhole$
 
timeToAvailable(long, int) - Method in interface akka.remote.transport.ThrottlerTransportAdapter.ThrottleMode
 
timeToAvailable(long, int) - Method in class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket
 
timeToAvailable(long, int) - Method in class akka.remote.transport.ThrottlerTransportAdapter.Unthrottled$
 
toBinary(Object) - Method in class akka.remote.serialization.DaemonMsgCreateSerializer
 
toBinary(Object) - Method in class akka.remote.serialization.MessageContainerSerializer
 
toBinary(Object) - Method in class akka.remote.serialization.ProtobufSerializer
 
toBuilder() - Method in class akka.remote.ContainerFormats.Selection
 
toBuilder() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
toBuilder() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
toBuilder() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
toBuilder() - Method in class akka.remote.WireFormats.ActorRefData
 
toBuilder() - Method in class akka.remote.WireFormats.AddressData
 
toBuilder() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
toBuilder() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
toBuilder() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
toBuilder() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
toBuilder() - Method in class akka.remote.WireFormats.DeployData
 
toBuilder() - Method in class akka.remote.WireFormats.PropsData
 
toBuilder() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
toBuilder() - Method in class akka.remote.WireFormats.SerializedMessage
 
TokenBucket(int, double, long, int) - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket
 
TokenBucket$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket$
 
tokensPerSecond() - Method in class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket
 
TookOver(ActorRef, AkkaProtocolHandle) - Constructor for class akka.remote.EndpointWriter.TookOver
 
TookOver$() - Constructor for class akka.remote.EndpointWriter.TookOver$
 
toString() - Method in class akka.remote.Ack
 
toString() - Method in class akka.remote.AckedReceiveBuffer
 
toString() - Method in class akka.remote.AckedSendBuffer
 
toString() - Method in class akka.remote.AssociationErrorEvent
 
toString() - Method in interface akka.remote.AssociationEvent
 
toString() - Method in class akka.remote.EndpointManager.Send
 
toString() - Method in class akka.remote.QuarantinedEvent
 
toString() - Method in class akka.remote.RemoteWatcher.Stats
 
toString() - Method in class akka.remote.RemotingErrorEvent
 
toString() - Method in class akka.remote.RemotingListenEvent
 
toString() - Method in class akka.remote.RemotingShutdownEvent$
 
toString() - Static method in class akka.remote.RemotingShutdownEvent
 
toString() - Method in class akka.remote.SeqNo
 
toString() - Method in class akka.remote.transport.AssociationHandle.InboundPayload
 
toString() - Method in class akka.remote.transport.netty.NettyTransportSettings.Tcp$
 
toString() - Method in class akka.remote.transport.netty.NettyTransportSettings.Udp$
 
toString() - Method in class akka.remote.transport.TestTransport
 
transformException(ChannelHandlerContext, ExceptionEvent) - Method in interface akka.remote.transport.netty.NettyHelpers
 
transport() - Method in class akka.remote.EndpointActor
 
transport() - Method in class akka.remote.ReliableDeliverySupervisor
 
transport() - Method in class akka.remote.RemoteActorRefProvider
 
transport() - Method in class akka.remote.transport.netty.ClientHandler
 
transport() - Method in interface akka.remote.transport.netty.CommonHandlers
 
transport() - Method in class akka.remote.transport.netty.ServerHandler
 
transport() - Method in class akka.remote.transport.netty.TcpAssociationHandle
 
transport() - Method in class akka.remote.transport.ProtocolStateActor.OutboundUnassociated
 
transport() - Method in class akka.remote.transport.TestAssociationHandle
 
Transport - Interface in akka.remote.transport
An SPI layer for implementing asynchronous transport mechanisms.
Transport$ - Class in akka.remote.transport
 
Transport$() - Constructor for class akka.remote.transport.Transport$
 
Transport.ActorAssociationEventListener - Class in akka.remote.transport
Class to convert ordinary ActorRef instances to an AssociationEventListener.
Transport.ActorAssociationEventListener$ - Class in akka.remote.transport
 
Transport.AssociationEvent - Interface in akka.remote.transport
 
Transport.AssociationEventListener - Interface in akka.remote.transport
An interface that needs to be implemented by the user of a transport to listen to association events
Transport.InboundAssociation - Class in akka.remote.transport
Message sent to a Transport.AssociationEventListener registered to a transport (via the Promise returned by Transport.listen()) when an inbound association request arrives.
Transport.InboundAssociation$ - Class in akka.remote.transport
 
Transport.InvalidAssociationException - Exception in akka.remote.transport
Indicates that the association setup request is invalid, and it is impossible to recover (malformed IP address, hostname, etc.).
Transport.InvalidAssociationException$ - Class in akka.remote.transport
 
TransportAdapterProvider - Interface in akka.remote.transport
 
TransportAdapters - Class in akka.remote.transport
 
TransportAdapters(ExtendedActorSystem) - Constructor for class akka.remote.transport.TransportAdapters
 
TransportAdaptersExtension - Class in akka.remote.transport
 
TransportAdaptersExtension() - Constructor for class akka.remote.transport.TransportAdaptersExtension
 
TransportAdaptersExtension$ - Class in akka.remote.transport
 
TransportAdaptersExtension$() - Constructor for class akka.remote.transport.TransportAdaptersExtension$
 
TransportFailureDetectorConfig() - Method in class akka.remote.transport.AkkaProtocolSettings
 
TransportFailureDetectorImplementationClass() - Method in class akka.remote.transport.AkkaProtocolSettings
 
transportFor(Address) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Returns the Transport bound to the given address.
TransportHeartBeatInterval() - Method in class akka.remote.transport.AkkaProtocolSettings
 
transportMapping() - Method in class akka.remote.EndpointManager
 
TransportMode() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
Transports() - Method in class akka.remote.RemoteSettings
 
transportsReady(Seq<Address>) - Method in class akka.remote.transport.TestTransport.AssociationRegistry
Indicates if all given transports were successfully registered.
transportSupervisor() - Method in class akka.remote.Remoting
 
TransportSupervisor() - Constructor for class akka.remote.Remoting.TransportSupervisor
 
triggerFirstHeartbeat(Address) - Method in class akka.remote.RemoteWatcher
 
TrustedSelectionPaths() - Method in class akka.remote.RemoteSettings
 
tryConsumeTokens(long, int) - Method in class akka.remote.transport.ThrottlerTransportAdapter.Blackhole$
 
tryConsumeTokens(long, int) - Method in interface akka.remote.transport.ThrottlerTransportAdapter.ThrottleMode
 
tryConsumeTokens(long, int) - Method in class akka.remote.transport.ThrottlerTransportAdapter.TokenBucket
 
tryConsumeTokens(long, int) - Method in class akka.remote.transport.ThrottlerTransportAdapter.Unthrottled$
 
TYPE_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.Selection
 

U

Udp$() - Constructor for class akka.remote.transport.netty.NettyTransportSettings.Udp$
 
UdpAssociationHandle - Class in akka.remote.transport.netty
INTERNAL API
UdpAssociationHandle(Address, Address, Channel, NettyTransport) - Constructor for class akka.remote.transport.netty.UdpAssociationHandle
 
UdpClientHandler - Class in akka.remote.transport.netty
INTERNAL API
UdpClientHandler(NettyTransport, Address) - Constructor for class akka.remote.transport.netty.UdpClientHandler
 
udpConnectionTable() - Method in class akka.remote.transport.netty.NettyTransport
INTERNAL API
UdpHandlers - Interface in akka.remote.transport.netty
INTERNAL API
UdpServerHandler - Class in akka.remote.transport.netty
INTERNAL API
UdpServerHandler(NettyTransport, Future<Transport.AssociationEventListener>) - Constructor for class akka.remote.transport.netty.UdpServerHandler
 
uid() - Method in class akka.remote.EndpointManager.Pass
 
uid() - Method in class akka.remote.EndpointManager.Quarantine
 
uid() - Method in class akka.remote.EndpointManager.Quarantined
 
uid() - Method in class akka.remote.EndpointManager.ResendState
 
uid() - Method in class akka.remote.EndpointReader
 
uid() - Method in exception akka.remote.HopelessAssociation
 
uid() - Method in class akka.remote.QuarantinedEvent
 
uid() - Method in class akka.remote.ReliableDeliverySupervisor.GotUid
 
uid() - Method in class akka.remote.ReliableDeliverySupervisor
 
uid() - Method in class akka.remote.transport.HandshakeInfo
 
UID_FIELD_NUMBER - Static variable in class akka.remote.WireFormats.AkkaHandshakeInfo
 
uidConfirmed() - Method in class akka.remote.ReliableDeliverySupervisor
 
Ungate$() - Constructor for class akka.remote.ReliableDeliverySupervisor.Ungate$
 
unhandled(Object) - Method in class akka.remote.EndpointWriter
 
Uninitialized$() - Constructor for class akka.remote.RemoteActorRefProvider.Uninitialized$
 
Uninitialized$() - Constructor for class akka.remote.transport.ThrottledAssociation.Uninitialized$
 
UniqueId() - Method in class akka.remote.transport.AkkaProtocolTransport$
 
UniqueId() - Static method in class akka.remote.transport.AkkaProtocolTransport
 
UniqueId() - Method in class akka.remote.transport.ThrottlerTransportAdapter$
 
UniqueId() - Static method in class akka.remote.transport.ThrottlerTransportAdapter
 
uniqueIdCounter() - Method in class akka.remote.transport.netty.NettyTransport$
 
uniqueIdCounter() - Static method in class akka.remote.transport.netty.NettyTransport
 
Unknown$() - Constructor for class akka.remote.transport.AssociationHandle.Unknown$
 
unreachable() - Method in class akka.remote.RemoteWatcher
 
unregisterEndpoint(ActorRef) - Method in class akka.remote.EndpointManager.EndpointRegistry
 
unregisterTempActor(ActorPath) - Method in class akka.remote.RemoteActorRefProvider
 
Unthrottled$() - Constructor for class akka.remote.transport.ThrottlerTransportAdapter.Unthrottled$
 
UntrustedMode() - Method in class akka.remote.RemoteSettings
 
untrustedMode() - Method in class akka.remote.RemoteSystemDaemon
 
unwatchNode(Address) - Method in class akka.remote.RemoteWatcher
 
UnwatchRemote(InternalActorRef, InternalActorRef) - Constructor for class akka.remote.RemoteWatcher.UnwatchRemote
 
UnwatchRemote$() - Constructor for class akka.remote.RemoteWatcher.UnwatchRemote$
 
upstreamListener() - Method in class akka.remote.transport.ActorTransportAdapter.ListenUnderlying
 
upstreamListener() - Method in class akka.remote.transport.ThrottledAssociation
 
useActorOnNode(ActorRef, Props, Deploy, ActorRef) - Method in class akka.remote.RemoteActorRefProvider
Using (checking out) actor on a specific node.
UseDispatcherForIo() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
UsePassiveConnections() - Method in class akka.remote.RemoteSettings
 
useUntrustedMode() - Method in class akka.remote.RemoteTransport
When this method returns true, some functionality will be turned off for security purposes.
useUntrustedMode() - Method in class akka.remote.Remoting
 

V

valueOf(String) - Static method in enum akka.remote.ContainerFormats.PatternType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum akka.remote.ContainerFormats.PatternType
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum akka.remote.ContainerFormats.PatternType
 
valueOf(String) - Static method in enum akka.remote.WireFormats.CommandType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum akka.remote.WireFormats.CommandType
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum akka.remote.WireFormats.CommandType
 
values() - Static method in enum akka.remote.ContainerFormats.PatternType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum akka.remote.WireFormats.CommandType
Returns an array containing the constants of this enum type, in the order they are declared.
variance() - Method in class akka.remote.HeartbeatHistory
 

W

WaitDaemonShutdown$() - Constructor for class akka.remote.RemoteActorRefProvider.WaitDaemonShutdown$
 
WaitExposedHandle$() - Constructor for class akka.remote.transport.ThrottledAssociation.WaitExposedHandle$
 
WaitHandshake$() - Constructor for class akka.remote.transport.ProtocolStateActor.WaitHandshake$
 
WaitMode$() - Constructor for class akka.remote.transport.ThrottledAssociation.WaitMode$
 
WaitModeAndUpstreamListener$() - Constructor for class akka.remote.transport.ThrottledAssociation.WaitModeAndUpstreamListener$
 
WaitOrigin$() - Constructor for class akka.remote.transport.ThrottledAssociation.WaitOrigin$
 
WaitTransportShutdown$() - Constructor for class akka.remote.RemoteActorRefProvider.WaitTransportShutdown$
 
WaitUpstreamListener$() - Constructor for class akka.remote.transport.ThrottledAssociation.WaitUpstreamListener$
 
watchee() - Method in class akka.remote.RemoteWatcher.UnwatchRemote
 
watchee() - Method in class akka.remote.RemoteWatcher.WatchRemote
 
watcheeByNodes() - Method in class akka.remote.RemoteWatcher
 
watcher() - Method in class akka.remote.RemoteWatcher.UnwatchRemote
 
watcher() - Method in class akka.remote.RemoteWatcher.WatchRemote
 
WatchFailureDetectorConfig() - Method in class akka.remote.RemoteSettings
 
WatchFailureDetectorImplementationClass() - Method in class akka.remote.RemoteSettings
 
WatchHeartbeatExpectedResponseAfter() - Method in class akka.remote.RemoteSettings
 
WatchHeartBeatInterval() - Method in class akka.remote.RemoteSettings
 
watching() - Method in class akka.remote.RemoteWatcher.Stats
 
watching() - Method in class akka.remote.RemoteWatcher
 
watchingAddresses() - Method in class akka.remote.RemoteWatcher.Stats
 
watchingNodes() - Method in class akka.remote.RemoteWatcher.Stats
 
watchingNodes() - Method in class akka.remote.RemoteWatcher
 
watchingRefs() - Method in class akka.remote.RemoteWatcher.Stats
 
watchNode(InternalActorRef) - Method in class akka.remote.RemoteWatcher
 
WatchRemote(ActorRef, ActorRef) - Constructor for class akka.remote.RemoteDeploymentWatcher.WatchRemote
 
WatchRemote(InternalActorRef, InternalActorRef) - Constructor for class akka.remote.RemoteWatcher.WatchRemote
 
WatchRemote$() - Constructor for class akka.remote.RemoteDeploymentWatcher.WatchRemote$
 
WatchRemote$() - Constructor for class akka.remote.RemoteWatcher.WatchRemote$
 
WatchUnreachableReaperInterval() - Method in class akka.remote.RemoteSettings
 
WILDCARDFANOUT_FIELD_NUMBER - Static variable in class akka.remote.ContainerFormats.SelectionEnvelope
 
WireFormats - Class in akka.remote
 
WireFormats.AckAndEnvelopeContainer - Class in akka.remote
Protobuf type AckAndEnvelopeContainer
WireFormats.AckAndEnvelopeContainer.Builder - Class in akka.remote
Protobuf type AckAndEnvelopeContainer
WireFormats.AckAndEnvelopeContainerOrBuilder - Interface in akka.remote
 
WireFormats.AcknowledgementInfo - Class in akka.remote
Protobuf type AcknowledgementInfo
WireFormats.AcknowledgementInfo.Builder - Class in akka.remote
Protobuf type AcknowledgementInfo
WireFormats.AcknowledgementInfoOrBuilder - Interface in akka.remote
 
WireFormats.ActorRefData - Class in akka.remote
Protobuf type ActorRefData
WireFormats.ActorRefData.Builder - Class in akka.remote
Protobuf type ActorRefData
WireFormats.ActorRefDataOrBuilder - Interface in akka.remote
 
WireFormats.AddressData - Class in akka.remote
Protobuf type AddressData
WireFormats.AddressData.Builder - Class in akka.remote
Protobuf type AddressData
WireFormats.AddressDataOrBuilder - Interface in akka.remote
 
WireFormats.AkkaControlMessage - Class in akka.remote
Protobuf type AkkaControlMessage
WireFormats.AkkaControlMessage.Builder - Class in akka.remote
Protobuf type AkkaControlMessage
WireFormats.AkkaControlMessageOrBuilder - Interface in akka.remote
 
WireFormats.AkkaHandshakeInfo - Class in akka.remote
Protobuf type AkkaHandshakeInfo
WireFormats.AkkaHandshakeInfo.Builder - Class in akka.remote
Protobuf type AkkaHandshakeInfo
WireFormats.AkkaHandshakeInfoOrBuilder - Interface in akka.remote
 
WireFormats.AkkaProtocolMessage - Class in akka.remote
Protobuf type AkkaProtocolMessage
WireFormats.AkkaProtocolMessage.Builder - Class in akka.remote
Protobuf type AkkaProtocolMessage
WireFormats.AkkaProtocolMessageOrBuilder - Interface in akka.remote
 
WireFormats.CommandType - Enum in akka.remote
Protobuf enum CommandType
WireFormats.DaemonMsgCreateData - Class in akka.remote
Protobuf type DaemonMsgCreateData
WireFormats.DaemonMsgCreateData.Builder - Class in akka.remote
Protobuf type DaemonMsgCreateData
WireFormats.DaemonMsgCreateDataOrBuilder - Interface in akka.remote
 
WireFormats.DeployData - Class in akka.remote
Protobuf type DeployData
WireFormats.DeployData.Builder - Class in akka.remote
Protobuf type DeployData
WireFormats.DeployDataOrBuilder - Interface in akka.remote
 
WireFormats.PropsData - Class in akka.remote
Protobuf type PropsData
WireFormats.PropsData.Builder - Class in akka.remote
Protobuf type PropsData
WireFormats.PropsDataOrBuilder - Interface in akka.remote
 
WireFormats.RemoteEnvelope - Class in akka.remote
Protobuf type RemoteEnvelope
WireFormats.RemoteEnvelope.Builder - Class in akka.remote
Protobuf type RemoteEnvelope
WireFormats.RemoteEnvelopeOrBuilder - Interface in akka.remote
 
WireFormats.SerializedMessage - Class in akka.remote
Protobuf type SerializedMessage
WireFormats.SerializedMessage.Builder - Class in akka.remote
Protobuf type SerializedMessage
WireFormats.SerializedMessageOrBuilder - Interface in akka.remote
 
withFallback(Scope) - Method in class akka.remote.RemoteScope
 
withFallback(RouterConfig) - Method in class akka.remote.routing.RemoteRouterConfig
 
wrappedHandle() - Method in class akka.remote.transport.AbstractTransportAdapterHandle
 
wrappedHandle() - Method in class akka.remote.transport.ProtocolStateActor.AssociatedWaitHandler
 
wrappedHandle() - Method in class akka.remote.transport.ProtocolStateActor.InboundUnassociated
 
wrappedHandle() - Method in class akka.remote.transport.ProtocolStateActor.ListenerReady
 
wrappedHandle() - Method in class akka.remote.transport.ProtocolStateActor.OutboundUnderlyingAssociated
 
wrappedTransport() - Method in class akka.remote.transport.AbstractTransportAdapter
 
writable() - Method in class akka.remote.transport.TestAssociationHandle
 
writableEndpointWithPolicyFor(Address) - Method in class akka.remote.EndpointManager.EndpointRegistry
 
write(ByteString) - Method in class akka.remote.transport.AkkaProtocolHandle
 
write(ByteString) - Method in interface akka.remote.transport.AssociationHandle
Asynchronously sends the specified payload to the remote endpoint.
write(ByteString) - Method in class akka.remote.transport.FailureInjectorHandle
 
write(ByteString) - Method in class akka.remote.transport.netty.TcpAssociationHandle
 
write(ByteString) - Method in class akka.remote.transport.netty.UdpAssociationHandle
 
write(ByteString) - Method in class akka.remote.transport.TestAssociationHandle
 
write(TestAssociationHandle, ByteString) - Method in class akka.remote.transport.TestTransport
 
write(ByteString) - Method in class akka.remote.transport.ThrottlerHandle
 
WriteAttempt(Address, Address, ByteString) - Constructor for class akka.remote.transport.TestTransport.WriteAttempt
 
WriteAttempt$() - Constructor for class akka.remote.transport.TestTransport.WriteAttempt$
 
writeBehavior() - Method in class akka.remote.transport.TestTransport
The TestTransport.SwitchableLoggedBehavior for the write() method on handles.
WriteBufferHighWaterMark() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
WriteBufferLowWaterMark() - Method in class akka.remote.transport.netty.NettyTransportSettings
 
writeCount() - Method in class akka.remote.EndpointWriter
 
writer() - Method in class akka.remote.EndpointWriter.StoppedReading
 
writer() - Method in class akka.remote.EndpointWriter.StopReading
 
writer() - Method in class akka.remote.EndpointWriter.TookOver
 
writer() - Method in class akka.remote.ReliableDeliverySupervisor
 
writeReplace() - Method in class akka.remote.ContainerFormats.Selection
 
writeReplace() - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
writeReplace() - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
writeReplace() - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
writeReplace() - Method in class akka.remote.WireFormats.ActorRefData
 
writeReplace() - Method in class akka.remote.WireFormats.AddressData
 
writeReplace() - Method in class akka.remote.WireFormats.AkkaControlMessage
 
writeReplace() - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
writeReplace() - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
writeReplace() - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
writeReplace() - Method in class akka.remote.WireFormats.DeployData
 
writeReplace() - Method in class akka.remote.WireFormats.PropsData
 
writeReplace() - Method in class akka.remote.WireFormats.RemoteEnvelope
 
writeReplace() - Method in class akka.remote.WireFormats.SerializedMessage
 
writeSend(EndpointManager.Send) - Method in class akka.remote.EndpointWriter
 
writeTo(CodedOutputStream) - Method in class akka.remote.ContainerFormats.Selection
 
writeTo(CodedOutputStream) - Method in class akka.remote.ContainerFormats.SelectionEnvelope
 
writeTo(CodedOutputStream) - Method in class akka.remote.WireFormats.AckAndEnvelopeContainer
 
writeTo(CodedOutputStream) - Method in class akka.remote.WireFormats.AcknowledgementInfo
 
writeTo(CodedOutputStream) - Method in class akka.remote.WireFormats.ActorRefData
 
writeTo(CodedOutputStream) - Method in class akka.remote.WireFormats.AddressData
 
writeTo(CodedOutputStream) - Method in class akka.remote.WireFormats.AkkaControlMessage
 
writeTo(CodedOutputStream) - Method in class akka.remote.WireFormats.AkkaHandshakeInfo
 
writeTo(CodedOutputStream) - Method in class akka.remote.WireFormats.AkkaProtocolMessage
 
writeTo(CodedOutputStream) - Method in class akka.remote.WireFormats.DaemonMsgCreateData
 
writeTo(CodedOutputStream) - Method in class akka.remote.WireFormats.DeployData
 
writeTo(CodedOutputStream) - Method in class akka.remote.WireFormats.PropsData
 
writeTo(CodedOutputStream) - Method in class akka.remote.WireFormats.RemoteEnvelope
 
writeTo(CodedOutputStream) - Method in class akka.remote.WireFormats.SerializedMessage
 
writing() - Method in class akka.remote.EndpointWriter
 

_

_wrappedHandle() - Method in class akka.remote.transport.FailureInjectorHandle
 
_wrappedHandle() - Method in class akka.remote.transport.ThrottlerHandle
 
A B C D E F G H I K L M N O P Q R S T U V W _ 
Skip navigation links