Uses of Class
org.apache.cassandra.net.Message
-
-
Uses of Message in org.apache.cassandra.batchlog
Methods in org.apache.cassandra.batchlog with parameters of type Message Modifier and Type Method Description void
BatchRemoveVerbHandler. doVerb(Message<TimeUUID> message)
void
BatchStoreVerbHandler. doVerb(Message<Batch> message)
-
Uses of Message in org.apache.cassandra.db
Methods in org.apache.cassandra.db that return Message Modifier and Type Method Description static <T> Message<T>
MessageParams. addToMessage(Message<T> message)
Message<ReadCommand>
ReadCommand. createMessage(boolean trackRepairedData)
Creates a message for this command.Methods in org.apache.cassandra.db with parameters of type Message Modifier and Type Method Description static <T> Message<T>
MessageParams. addToMessage(Message<T> message)
void
CounterMutationVerbHandler. doVerb(Message<CounterMutation> message)
void
MutationVerbHandler. doVerb(Message<Mutation> message)
void
ReadCommandVerbHandler. doVerb(Message<ReadCommand> message)
void
ReadRepairVerbHandler. doVerb(Message<Mutation> message)
void
TruncateVerbHandler. doVerb(Message<TruncateRequest> message)
-
Uses of Message in org.apache.cassandra.gms
Methods in org.apache.cassandra.gms with parameters of type Message Modifier and Type Method Description void
GossipDigestAck2VerbHandler. doVerb(Message<GossipDigestAck2> message)
void
GossipDigestAckVerbHandler. doVerb(Message<GossipDigestAck> message)
void
GossipDigestSynVerbHandler. doVerb(Message<GossipDigestSyn> message)
void
GossipShutdownVerbHandler. doVerb(Message<GossipShutdown> message)
void
GossipVerbHandler. doVerb(Message<T> message)
-
Uses of Message in org.apache.cassandra.hints
Methods in org.apache.cassandra.hints with parameters of type Message Modifier and Type Method Description void
HintVerbHandler. doVerb(Message<HintMessage> message)
-
Uses of Message in org.apache.cassandra.metrics
Methods in org.apache.cassandra.metrics with parameters of type Message Modifier and Type Method Description void
MessagingMetrics. recordDroppedMessage(Message<?> message, long timeElapsed, java.util.concurrent.TimeUnit timeUnit)
-
Uses of Message in org.apache.cassandra.net
Methods in org.apache.cassandra.net that return Message Modifier and Type Method Description Message<T>
Message.Builder. build()
<T> Message<T>
Message.Serializer. deserialize(DataInputPlus in, InetAddressAndPort peer, int version)
<T> Message<T>
Message.Serializer. deserialize(DataInputPlus in, Message.Header header, int version)
A partial variant of deserialize, taking in a previously deserializedMessage.Header
as an argument.Message<NoPayload>
Message. emptyResponse()
Builds a response Message with no payload, and all the right fields inferred from request MessageMessage<RequestFailureReason>
Message. failureResponse(RequestFailureReason reason)
Builds a failure response Message with an explicit reason, and fields inferred from request Messagestatic <T> Message<T>
Message. internalResponse(Verb verb, T payload)
static <T> Message<T>
Message. out(Verb verb, T payload)
Make a requestMessage
with supplied verb and payload.static <T> Message<T>
Message. out(Verb verb, T payload, long expiresAtNanos)
static <T> Message<T>
Message. outWithFlag(Verb verb, T payload, MessageFlag flag)
static <T> Message<T>
Message. outWithFlags(Verb verb, T payload, MessageFlag flag1, MessageFlag flag2)
static <T> Message<T>
Message. remoteResponse(InetAddressAndPort from, Verb verb, T payload)
Used by theMultiRangeReadCommand
to split multi-range responses from a replica into single-range responses.<T> Message<T>
Message. responseWith(T payload)
Builds a response Message with provided payload, and all the right fields inferred from request Messagestatic <T> Message<T>
Message. synthetic(InetAddressAndPort from, Verb verb, T payload)
Message<T>
Message. withFlag(MessageFlag flag)
Message<T>
Message. withForwardTo(ForwardingInfo peers)
Message<T>
Message. withFrom(InetAddressAndPort from)
Message<T>
Message. withParam(ParamType type, java.lang.Object value)
Message<T>
Message. withParams(java.util.Map<ParamType,java.lang.Object> values)
<V> Message<V>
Message. withPayload(V newPayload)
Methods in org.apache.cassandra.net that return types with arguments of type Message Modifier and Type Method Description <REQ,RSP>
Future<Message<RSP>>MessageDelivery. sendWithResult(Message<REQ> message, InetAddressAndPort to)
<REQ,RSP>
Future<Message<RSP>>MessagingService. sendWithResult(Message<REQ> message, InetAddressAndPort to)
Methods in org.apache.cassandra.net with parameters of type Message Modifier and Type Method Description void
InboundSink. accept(Message<?> message)
void
OutboundSink. accept(Message<?> message, InetAddressAndPort to, ConnectionType connectionType)
void
OutboundSink.Sink. accept(Message<?> message, InetAddressAndPort to, ConnectionType connectionType)
void
RequestCallbacks. addWithExpiration(RequestCallback<?> cb, Message<?> message, InetAddressAndPort to)
Register the providedRequestCallback
, inferring expiry and id from the providedMessage
.void
RequestCallbacks. addWithExpiration(AbstractWriteResponseHandler<?> cb, Message<?> message, Replica to)
boolean
InboundSink. allow(Message<?> message)
Deprecated.See CASSANDRA-15066static <T> Message.Builder<T>
Message. builder(Message<T> message)
void
IVerbHandler. doVerb(Message<T> message)
This method delivers a message to the implementing class (if the implementing class was registered by a call to MessagingService.registerVerbHandlers).void
OutboundConnection. enqueue(Message message)
This is the main entry point for enqueuing a message to be sent to the remote peer.void
OutboundConnections. enqueue(Message msg, ConnectionType type)
Select the appropriate connection for the provided message and use it to send the message.void
RequestCallbacks. onDiscardOnClose(Message<?> message, InetAddressAndPort peer)
void
RequestCallbacks. onExpired(Message<?> message, InetAddressAndPort peer)
void
RequestCallbacks. onFailedSerialize(Message<?> message, InetAddressAndPort peer, int messagingVersion, int bytesWrittenToNetwork, java.lang.Throwable failure)
void
RequestCallbacks. onOverloaded(Message<?> message, InetAddressAndPort peer)
void
AsyncOneResponse. onResponse(Message<T> response)
void
RequestCallback. onResponse(Message<T> msg)
void
RequestCallbacks. removeAndRespond(long id, InetAddressAndPort peer, Message message)
<V> void
MessageDelivery. respond(V response, Message<?> message)
<V> void
MessagingService. respond(V response, Message<?> message)
Send a message to a given endpoint.<V> void
MessagingService. respondWithFailure(RequestFailureReason reason, Message<?> message)
<REQ> void
MessageDelivery. send(Message<REQ> message, InetAddressAndPort to)
void
MessagingService. send(Message message, InetAddressAndPort to)
Send a message to a given endpoint.void
MessagingService. send(Message message, InetAddressAndPort to, ConnectionType specifyConnection)
<REQ,RSP>
voidMessageDelivery. sendWithCallback(Message<REQ> message, InetAddressAndPort to, RequestCallback<RSP> cb)
<REQ,RSP>
voidMessageDelivery. sendWithCallback(Message<REQ> message, InetAddressAndPort to, RequestCallback<RSP> cb, ConnectionType specifyConnection)
void
MessagingService. sendWithCallback(Message message, InetAddressAndPort to, RequestCallback cb)
Send a non-mutation message to a given endpoint.void
MessagingService. sendWithCallback(Message message, InetAddressAndPort to, RequestCallback cb, ConnectionType specifyConnection)
<REQ,RSP>
Future<Message<RSP>>MessageDelivery. sendWithResult(Message<REQ> message, InetAddressAndPort to)
<REQ,RSP>
Future<Message<RSP>>MessagingService. sendWithResult(Message<REQ> message, InetAddressAndPort to)
void
MessagingService. sendWriteWithCallback(Message message, Replica to, AbstractWriteResponseHandler<?> handler)
Send a mutation message or a Paxos Commit to a given endpoint.<T> void
Message.Serializer. serialize(Message<T> message, DataOutputPlus out, int version)
Method parameters in org.apache.cassandra.net with type arguments of type Message Modifier and Type Method Description void
InboundSink. add(java.util.function.Predicate<Message<?>> allow)
void
OutboundSink. add(java.util.function.BiPredicate<Message<?>,InetAddressAndPort> allow)
void
InboundSink. remove(java.util.function.Predicate<Message<?>> allow)
void
OutboundSink. remove(java.util.function.BiPredicate<Message<?>,InetAddressAndPort> allow)
-
Uses of Message in org.apache.cassandra.repair
Methods in org.apache.cassandra.repair with parameters of type Message Modifier and Type Method Description void
RepairMessageVerbHandler. doVerb(Message<RepairMessage> message)
void
RepairSession. syncComplete(RepairJobDesc desc, Message<SyncResponse> message)
Notify this session that sync completed/failed with givenSyncNodePair
.void
RepairSession. validationComplete(RepairJobDesc desc, Message<ValidationResponse> message)
Receive merkle tree response or failed response fromendpoint
for current repair job. -
Uses of Message in org.apache.cassandra.repair.consistent
Methods in org.apache.cassandra.repair.consistent with parameters of type Message Modifier and Type Method Description void
LocalSessions. handleFinalizeCommitMessage(Message<? extends RepairMessage> message)
Finalizes the repair session, completing it as successful.void
CoordinatorSession. handleFinalizePromise(Message<FinalizePromise> message)
void
CoordinatorSessions. handleFinalizePromiseMessage(Message<? extends RepairMessage> message)
void
LocalSessions. handleFinalizeProposeMessage(Message<? extends RepairMessage> message)
void
LocalSessions. handlePrepareMessage(Message<? extends RepairMessage> message)
The PrepareConsistentRequest promotes the parent repair session to a consistent incremental session, and isolates the data to be repaired from the rest of the table's data No response is sent to the repair coordinator until the data preparation / isolation has completed successfully.void
CoordinatorSession. handlePrepareResponse(Message<PrepareConsistentResponse> msg)
void
CoordinatorSessions. handlePrepareResponse(Message<? extends RepairMessage> msg)
protected void
LocalSessions. sendMessage(InetAddressAndPort destination, Message<? extends RepairMessage> message)
-
Uses of Message in org.apache.cassandra.repair.messages
Methods in org.apache.cassandra.repair.messages with parameters of type Message Modifier and Type Method Description static void
RepairMessage. sendAck(SharedContext ctx, Message<? extends RepairMessage> message)
static void
RepairMessage. sendFailureResponse(SharedContext ctx, Message<?> respondTo)
-
Uses of Message in org.apache.cassandra.schema
Methods in org.apache.cassandra.schema with parameters of type Message Modifier and Type Method Description void
SchemaPullVerbHandler. doVerb(Message<NoPayload> message)
void
SchemaPushVerbHandler. doVerb(Message<java.util.Collection<Mutation>> message)
void
SchemaVersionVerbHandler. doVerb(Message<NoPayload> message)
Method parameters in org.apache.cassandra.schema with type arguments of type Message Modifier and Type Method Description void
SchemaPullVerbHandler. register(java.util.function.Consumer<Message<NoPayload>> handler)
void
SchemaPushVerbHandler. register(java.util.function.Consumer<Message<java.util.Collection<Mutation>>> handler)
-
Uses of Message in org.apache.cassandra.service
Methods in org.apache.cassandra.service with parameters of type Message Modifier and Type Method Description void
EchoVerbHandler. doVerb(Message<NoPayload> message)
void
SnapshotVerbHandler. doVerb(Message<SnapshotCommand> message)
void
ActiveRepairService. handleMessage(Message<? extends RepairMessage> message)
protected void
AbstractWriteResponseHandler. logResponseToIdealCLDelegate(Message<T> m)
This logs the response but doesn't do any further processing related to this write response handler on whether the CL was achieved.abstract void
AbstractWriteResponseHandler. onResponse(Message<T> msg)
null message means "response from local write"void
BatchlogResponseHandler. onResponse(Message<T> msg)
void
DatacenterSyncWriteResponseHandler. onResponse(Message<T> message)
void
DatacenterWriteResponseHandler. onResponse(Message<T> message)
void
TruncateResponseHandler. onResponse(Message<TruncateResponse> message)
void
WriteResponseHandler. onResponse(Message<T> m)
-
Uses of Message in org.apache.cassandra.service.paxos
Methods in org.apache.cassandra.service.paxos with parameters of type Message Modifier and Type Method Description void
PaxosCommit.RequestHandler. doVerb(Message<Commit.Agreed> message)
void
PaxosCommitAndPrepare.RequestHandler. doVerb(Message<org.apache.cassandra.service.paxos.PaxosCommitAndPrepare.Request> message)
void
PaxosPrepare.RequestHandler. doVerb(Message<org.apache.cassandra.service.paxos.PaxosPrepare.Request> message)
void
PaxosPrepareRefresh.RequestHandler. doVerb(Message<org.apache.cassandra.service.paxos.PaxosPrepareRefresh.Request> message)
void
PaxosPropose.RequestHandler. doVerb(Message<org.apache.cassandra.service.paxos.PaxosPropose.Request> message)
void
PaxosRepair.RequestHandler. doVerb(Message<org.apache.cassandra.service.paxos.PaxosRepair.Request> message)
void
PaxosCommit. onResponse(Message<NoPayload> response)
Record a success responsevoid
PaxosPrepareRefresh. onResponse(Message<org.apache.cassandra.service.paxos.PaxosPrepareRefresh.Response> message)
void
PaxosRequestCallback. onResponse(Message<T> message)
-
Uses of Message in org.apache.cassandra.service.paxos.cleanup
Methods in org.apache.cassandra.service.paxos.cleanup with parameters of type Message Modifier and Type Method Description void
PaxosCleanupComplete. onResponse(Message<java.lang.Void> msg)
void
PaxosCleanupSession. onResponse(Message<java.lang.Void> msg)
void
PaxosFinishPrepareCleanup. onResponse(Message<java.lang.Void> msg)
void
PaxosStartPrepareCleanup. onResponse(Message<PaxosCleanupHistory> msg)
-
Uses of Message in org.apache.cassandra.service.paxos.v1
Methods in org.apache.cassandra.service.paxos.v1 with parameters of type Message Modifier and Type Method Description void
PrepareVerbHandler. doVerb(Message<Commit> message)
void
ProposeVerbHandler. doVerb(Message<Commit> message)
void
PrepareCallback. onResponse(Message<PrepareResponse> message)
void
ProposeCallback. onResponse(Message<java.lang.Boolean> msg)
-
Uses of Message in org.apache.cassandra.service.reads
Fields in org.apache.cassandra.service.reads with type parameters of type Message Modifier and Type Field Description protected Accumulator<Message<ReadResponse>>
ResponseResolver. responses
Methods in org.apache.cassandra.service.reads that return types with arguments of type Message Modifier and Type Method Description Accumulator<Message<ReadResponse>>
ResponseResolver. getMessages()
Methods in org.apache.cassandra.service.reads with parameters of type Message Modifier and Type Method Description void
ReadCallback. onResponse(Message<ReadResponse> message)
void
DigestResolver. preprocess(Message<ReadResponse> message)
void
ResponseResolver. preprocess(Message<ReadResponse> message)
-
Uses of Message in org.apache.cassandra.service.reads.repair
Methods in org.apache.cassandra.service.reads.repair with parameters of type Message Modifier and Type Method Description void
BlockingPartitionRepair. onResponse(Message<java.lang.Object> msg)
protected void
BlockingPartitionRepair. sendRR(Message<Mutation> message, InetAddressAndPort endpoint)
-
Uses of Message in org.apache.cassandra.streaming
Methods in org.apache.cassandra.streaming with parameters of type Message Modifier and Type Method Description void
ReplicationDoneVerbHandler. doVerb(Message msg)
-
Uses of Message in org.apache.cassandra.tracing
Methods in org.apache.cassandra.tracing with parameters of type Message Modifier and Type Method Description void
Tracing. traceOutgoingMessage(Message<?> message, int serializedSize, InetAddressAndPort sendTo)
Record any tracing data, if enabled on this message.
-