Interface | Description |
---|---|
AbstractMessageHandler.OnHandlerClosed | |
AsyncStreamingInputPlus.Consumer | |
FrameDecoder.FrameProcessor | |
FrameEncoder.PayloadAllocator | |
InboundMessageHandlers.GlobalMetricCallbacks | |
InboundMessageHandlers.MessageConsumer | |
IVerbHandler<T> |
IVerbHandler provides the method that all verb handlers need to implement.
|
LatencyConsumer | |
LatencySubscribers.Subscriber | |
MessagingServiceMBean |
MBean exposing MessagingService metrics plus allowing to enable/disable back-pressure.
|
OutboundSink.Sink | |
RequestCallback<T> |
implementors of
RequestCallback need to make sure that any public methods
are threadsafe with respect to RequestCallback.onResponse(org.apache.cassandra.net.Message<T>) being called from the message
service. |
RequestCallbackWithFailure<T> | |
ResourceLimits.Limit |
Represents permits to utilise a resource and ways to allocate and release them.
|
Class | Description |
---|---|
AbstractMessageHandler |
Core logic for handling inbound message deserialization and execution (in tandem with
FrameDecoder ). |
AbstractMessageHandler.WaitQueue |
A special-purpose wait queue to park inbound message handlers that failed to allocate
reserve capacity for a message in.
|
AsyncChannelOutputPlus |
A
DataOutputStreamPlus that writes ASYNCHRONOUSLY to a Netty Channel. |
AsyncChannelPromise |
See
AsyncPromise and ChannelPromise
This class is all boiler plate, just ensuring we return ourselves and invoke the correct Promise method. |
AsyncMessageOutputPlus |
A
DataOutputStreamPlus that writes ASYNCHRONOUSLY to a Netty Channel. |
AsyncOneResponse<T> |
A callback specialized for returning a value from a single target; that is, this is for messages
that we only send to one recipient.
|
AsyncStreamingInputPlus | |
AsyncStreamingOutputPlus |
A
DataOutputStreamPlus that writes ASYNCHRONOUSLY to a Netty Channel. |
BufferPoolAllocator |
A trivial wrapper around BufferPool for integrating with Netty, but retaining ownership of pooling behaviour
that is integrated into Cassandra's other pooling.
|
BufferPoolAllocator.Wrapped |
A simple extension to UnpooledUnsafeDirectByteBuf that returns buffers to BufferPool on deallocate,
and permits extracting the buffer from it to take ownership and use directly.
|
Crc | |
EndpointMessagingVersions |
Map of hosts to their known current messaging versions.
|
ForwardingInfo |
A container used to store a node -> message_id map for inter-DC write forwarding.
|
FrameDecoder |
A Netty inbound handler that decodes incoming frames and passes them forward to
InboundMessageHandler for processing. |
FrameDecoder.CorruptFrame |
A corrupted frame was encountered; this represents the knowledge we have about this frame,
and whether or not the stream is recoverable.
|
FrameDecoder.Frame | |
FrameDecoder.IntactFrame |
The payload bytes of a complete frame, i.e.
|
FrameDecoderCrc |
Framing format that protects integrity of data in movement with CRCs (of both header and payload).
|
FrameDecoderLZ4 |
Framing format that compresses payloads with LZ4, and protects integrity of data in movement with CRCs
(of both header and payload).
|
FrameEncoder | |
FrameEncoder.Payload |
An abstraction useful for transparently allocating buffers that can be written to upstream
of the
FrameEncoder without knowledge of the encoder's frame layout, while ensuring
enough space to write the remainder of the frame's contents is reserved. |
FrameEncoderCrc |
Please see
FrameDecoderCrc for description of the framing produced by this encoder. |
FrameEncoderLZ4 |
Please see
FrameDecoderLZ4 for description of the framing produced by this encoder. |
FutureDelegate<V> |
A delegating future, that we can extend to provide subtly modified behaviour.
|
FutureResult<V> |
An abstraction for yielding a result performed by an asynchronous task,
for whom we may wish to offer cancellation, but no other access to the underlying task
|
GlobalBufferPoolAllocator | |
HandshakeProtocol |
Messages for the handshake phase of the internode protocol.
|
InboundConnectionInitiator | |
InboundConnectionSettings | |
InboundMessageHandler |
Implementation of
AbstractMessageHandler for processing internode messages from peers. |
InboundMessageHandlers |
An aggregation of
InboundMessageHandler s for all connections from a peer. |
InboundSink |
A message sink that all inbound messages go through.
|
LatencySubscribers |
Callback that
DynamicEndpointSnitch listens to in order
to update host scores. |
Message<T> |
Immutable main unit of internode communication - what used to be
MessageIn and MessageOut fused
in one class. |
Message.Builder<T> | |
Message.Header |
Split into a separate object to allow partial message deserialization without wasting work and allocation
afterwards, if the entire message is necessary and available.
|
Message.Serializer |
Each message contains a header with several fixed fields, an optional key-value params section, and then
the message payload itself.
|
MessagingService |
MessagingService implements all internode communication - with the exception of SSTable streaming (for now).
|
MessagingServiceMBeanImpl | |
NoPayload |
Empty message payload - primarily used for responses.
|
OutboundConnection |
Represents a connection type to a peer, and handles the state transistions on the connection and the netty
Channel . |
OutboundConnectionInitiator<SuccessType extends OutboundConnectionInitiator.Result.Success> |
A
ChannelHandler to execute the send-side of the internode handshake protocol. |
OutboundConnectionInitiator.Result<SuccessType extends OutboundConnectionInitiator.Result.Success> |
The result of the handshake.
|
OutboundConnectionInitiator.Result.MessagingSuccess | |
OutboundConnectionInitiator.Result.StreamingSuccess | |
OutboundConnectionInitiator.Result.Success<SuccessType extends OutboundConnectionInitiator.Result.Success> | |
OutboundConnections |
Groups a set of outbound connections to a given peer, and routes outgoing messages to the appropriate connection
(based upon message's type or size).
|
OutboundConnectionSettings |
A collection of settings to be passed around for outbound connections.
|
OutboundSink |
A message sink that all outbound messages go through.
|
PingRequest |
Indicates to the recipient which
ConnectionType should be used for the response. |
RequestCallbacks |
An expiring map of request callbacks.
|
RequestCallbacks.CallbackInfo | |
ResourceLimits | |
ResourceLimits.Basic |
A cheaper, thread-unsafe permit container to be used for unshared limits.
|
ResourceLimits.Concurrent |
A thread-safe permit container.
|
ResourceLimits.EndpointAndGlobal |
A convenience class that groups a per-endpoint limit with the global one
to allow allocating/releasing permits from/to both limits as one logical operation.
|
ShareableBytes |
A wrapper for possibly sharing portions of a single,
BufferPools.forNetworking() managed, ByteBuffer ;
optimised for the case where no sharing is necessary. |
SharedDefaultFileRegion |
Netty's DefaultFileRegion closes the underlying FileChannel as soon as
the refCnt() for the region drops to zero, this is an implementation of
the DefaultFileRegion that doesn't close the FileChannel.
|
SharedDefaultFileRegion.SharedFileChannel | |
SocketFactory |
A factory for building Netty
Channel s. |
StartupClusterConnectivityChecker |
Enum | Description |
---|---|
ConnectionCategory | |
ConnectionType | |
MessageFlag |
Binary message flags to be passed as
flags field of Message . |
MessagingService.Version | |
OutboundConnectionSettings.Framing | |
ParamType |
Type names and serializers for various parameters that can be put in
Message params map. |
ResourceLimits.Outcome | |
Verb |
Note that priorities except P0 are presently unused.
|
Verb.Kind | |
Verb.Priority |
Exception | Description |
---|---|
AsyncChannelOutputPlus.FlushException | |
Crc.InvalidCrc | |
Message.InvalidLegacyProtocolMagic | |
MessagingService.FailureResponseException |
Copyright © 2009- The Apache Software Foundation