Uses of Interface
org.jgroups.Message
-
Packages that use Message Package Description org.jgroups Provides top-level public JGroups classes such as Channel, Message, etc.org.jgroups.auth org.jgroups.blocks Provides building blocks that are layered on top of channels.org.jgroups.demos Provides demonstrations of JGroups functionality.org.jgroups.fork org.jgroups.protocols Provides implementations of transport protocols which are responsible for sending and receiving messages to/from the network.org.jgroups.protocols.dns org.jgroups.protocols.pbcast org.jgroups.protocols.relay org.jgroups.stack Support for managing protocol stacks.org.jgroups.util Provides useful functionality which cannot be assigned to any particular other package. -
-
Uses of Message in org.jgroups
Classes in org.jgroups that implement Message Modifier and Type Class Description class
BaseMessage
A common superclass for allMessage
implementations.class
BatchMessage
A message that contains a batch of messages.class
BytesMessage
AMessage
containing a byte array as payload.class
CompositeMessage
A message composed of multiple messages.class
EmptyMessage
AMessage
without a payload; optimized for sending only headers (e.g.class
FragmentedMessage
A message which refers to another message, but only marshals (Streamable.writeTo(DataOutput)
) a part of the original message, starting at a givenBytesMessage.offset
and marshalling onlyBytesMessage.length
bytes.class
LongMessage
Message with a long as payload.class
NioMessage
AMessage
with a (heap-based or direct)ByteBuffer
as payload.
Note that the payload of an NioMessage must not be modified after sending it (ie.class
ObjectMessage
AMessage
with an object as payload.Fields in org.jgroups declared as Message Modifier and Type Field Description protected Message[]
BatchMessage. msgs
protected Message[]
CompositeMessage. msgs
protected Message
FragmentedMessage. original_msg
Fields in org.jgroups with type parameters of type Message Modifier and Type Field Description protected java.util.Map<java.lang.Short,java.util.function.Supplier<? extends Message>>
DefaultMessageFactory. map
Methods in org.jgroups with type parameters of type Message Modifier and Type Method Description <T extends Message>
TDefaultMessageFactory. create(short type)
<T extends Message>
TMessageFactory. create(short id)
Creates a message based on the given ID<T extends Message>
TBatchMessage. get(int index)
<T extends Message>
TCompositeMessage. get(int index)
Methods in org.jgroups that return Message Modifier and Type Method Description Message
BaseMessage. clearFlag(Message.Flag... flags)
Clears a number of flags in a messageMessage
BaseMessage. clearFlag(Message.TransientFlag... flags)
Message
Message. clearFlag(Message.Flag... flags)
Removes a number of flags from the message.Message
Message. clearFlag(Message.TransientFlag... flags)
Removes a number of transient flags from the message.Message
BaseMessage. clearHeaders()
Removes all headers: use carefully!Message
Message. clearHeaders()
Removes all headers: use carefully!Message
BaseMessage. copy(boolean copy_payload, boolean copy_headers)
Copies the source- and destination addresses, flags and headers (if copy_headers is true).
If copy_payload is set, then methodBaseMessage.copyPayload(Message)
of the subclass will be called, which is responsible for copying the payload specific to that message type.
Note that for headers, only the arrays holding references to the headers are copied, not the headers themselves ! The consequence is that the headers array of the copy hold the *same* references as the original, so do *not* modify the headers ! If you want to change a header, copy it and callputHeader(short,Header)
again.Message
Message. copy(boolean copy_payload, boolean copy_headers)
Copies a messageprotected Message
BaseMessage. copyPayload(Message copy)
Copies the payloadprotected Message
BytesMessage. copyPayload(Message copy)
Copies the byte array.protected Message
FragmentedMessage. copyPayload(Message copy)
protected Message
LongMessage. copyPayload(Message copy)
protected Message
NioMessage. copyPayload(Message copy)
protected Message
ObjectMessage. copyPayload(Message copy)
default Message
Message. dest(Address new_dest)
protected Message
BatchMessage. ensureSameDest(Message msg)
protected Message
CompositeMessage. ensureSameDest(Message msg)
Message[]
BatchMessage. getMessages()
Message
FragmentedMessage. getOriginalMessage()
Message
BaseMessage. headers(Header[] hdrs)
Message
BatchMessage.BatchMessageIterator. next()
Message
CompositeMessage.CompositeMessageIterator. next()
Message
BaseMessage. putHeader(short id, Header hdr)
Puts a header given an ID into the hashmap.protected Message
BaseMessage. putHeader(short id, Header hdr, boolean replace_if_present)
Message
Message. putHeader(short id, Header hdr)
Adds a header to the messageMessage
BaseMessage. putHeaderIfAbsent(short id, Header hdr)
Message
Message. putHeaderIfAbsent(short id, Header hdr)
Adds a header to a message if not presentdefault Message
Message. setArray(byte[] b)
Message
Message. setArray(byte[] b, int offset, int length)
Sets the byte array in a message.
Throws an exception if the message does not have a byte[] array payload (hasArray()
is false).
Note that this is a convenience method, as most messages are of typeBytesMessage
.Message
Message. setArray(ByteArray buf)
Sets the byte array in a message.
Throws an exception if the message does not have a byte[] array payload (hasArray()
is false).
Note that this is a convenience method, as most messages are of typeBytesMessage
.Message
BaseMessage. setDest(Address new_dest)
Message
Message. setDest(Address new_dest)
Sets the destination address to send the message to.Message
BaseMessage. setFlag(short flag, boolean transient_flags, boolean xor)
Message
BaseMessage. setFlag(Message.Flag... flags)
Sets a number of flags in a messageMessage
BaseMessage. setFlag(Message.TransientFlag... flags)
Same asBaseMessage.setFlag(Flag...)
except that transient flags are not marshalleddefault Message
Message. setFlag(short flag, boolean transient_flags)
Sets the flags as a short; this way, multiple flags can be set in one operationMessage
Message. setFlag(short flag, boolean transient_flags, boolean xor)
Sets the flags as a short; this way, multiple flags can be set in one operationMessage
Message. setFlag(Message.Flag... flags)
Sets one or more flags (xor-ing existing flags)Message
Message. setFlag(Message.TransientFlag... flags)
Sets one or more transient flags (xor-ing).Message
Message. setObject(java.lang.Object obj)
Sets an object in a message.Message
BaseMessage. setPayload(java.lang.Object pl)
Message
Message. setPayload(java.lang.Object pl)
Sets the payloadMessage
BaseMessage. setSrc(Address new_src)
Message
Message. setSrc(Address new_src)
Sets the address of the sender of this messagedefault Message
Message. src(Address new_src)
Methods in org.jgroups that return types with arguments of type Message Modifier and Type Method Description java.util.function.Supplier<Message>
BatchMessage. create()
java.util.function.Supplier<Message>
BytesMessage. create()
java.util.function.Supplier<Message>
CompositeMessage. create()
java.util.function.Supplier<Message>
EmptyMessage. create()
java.util.function.Supplier<Message>
FragmentedMessage. create()
java.util.function.Supplier<? extends Message>
LongMessage. create()
java.util.function.Supplier<Message>
NioMessage. create()
java.util.function.Supplier<Message>
ObjectMessage. create()
java.util.Iterator<Message>
BatchMessage. iterator()
java.util.Iterator<Message>
CompositeMessage. iterator()
Methods in org.jgroups with parameters of type Message Modifier and Type Method Description BatchMessage
BatchMessage. add(Message msg)
Adds the message at the end of the array.BatchMessage
BatchMessage. add(Message... messages)
CompositeMessage
CompositeMessage. add(Message msg)
Adds the message at the end of the array.CompositeMessage
CompositeMessage. add(Message... messages)
protected Message
BaseMessage. copyPayload(Message copy)
Copies the payloadprotected Message
BytesMessage. copyPayload(Message copy)
Copies the byte array.protected Message
FragmentedMessage. copyPayload(Message copy)
protected Message
LongMessage. copyPayload(Message copy)
protected Message
NioMessage. copyPayload(Message copy)
protected Message
ObjectMessage. copyPayload(Message copy)
java.lang.Object
JChannel. down(Message msg)
java.util.concurrent.CompletableFuture<java.lang.Object>
JChannel. down(Message msg, boolean async)
Sends a message down asynchronously.protected Message
BatchMessage. ensureSameDest(Message msg)
protected Message
CompositeMessage. ensureSameDest(Message msg)
default void
Receiver. receive(Message msg)
Called when a message is received.JChannel
JChannel. send(Message msg)
Sends a message.java.lang.Object
JChannel. up(Message msg)
java.lang.Object
UpHandler. up(Message msg)
Method parameters in org.jgroups with type arguments of type Message Modifier and Type Method Description <T extends MessageFactory>
TDefaultMessageFactory. register(short type, java.util.function.Supplier<? extends Message> generator)
<M extends MessageFactory>
MMessageFactory. register(short type, java.util.function.Supplier<? extends Message> generator)
Registers a new creator of messagesConstructors in org.jgroups with parameters of type Message Constructor Description BatchMessage(Address dest, Address src, Message[] msgs, int index)
CompositeMessage(Address dest, Message... messages)
FragmentedMessage(Message original_msg, int off, int len)
-
Uses of Message in org.jgroups.auth
Methods in org.jgroups.auth with parameters of type Message Modifier and Type Method Description abstract boolean
AuthToken. authenticate(AuthToken token, Message msg)
This method should be implemented to perform the actual authentication of joining members.boolean
FixedMembershipToken. authenticate(AuthToken token, Message msg)
Check if I'm in memberList, tooboolean
Krb5Token. authenticate(AuthToken token, Message msg)
boolean
RegexMembership. authenticate(AuthToken token, Message msg)
boolean
X509Token. authenticate(AuthToken token, Message msg)
-
Uses of Message in org.jgroups.blocks
Fields in org.jgroups.blocks declared as Message Modifier and Type Field Description protected Message
RequestCorrelator.ResponseImpl. req
Methods in org.jgroups.blocks that return Message Modifier and Type Method Description protected static Message
RequestCorrelator. makeReply(Message msg)
Methods in org.jgroups.blocks with parameters of type Message Modifier and Type Method Description protected <T> UnicastRequest<T>
MessageDispatcher. _sendMessage(Message msg, RequestOptions opts)
protected <T> GroupRequest<T>
MessageDispatcher. cast(java.util.Collection<Address> dests, Message msg, RequestOptions options, boolean block_for_results)
<T> RspList<T>
MessageDispatcher. castMessage(java.util.Collection<Address> dests, Message msg, RequestOptions opts)
Sends a message to all members and expects responses from members in dests (if non-null).<T> java.util.concurrent.CompletableFuture<RspList<T>>
MessageDispatcher. castMessageWithFuture(java.util.Collection<Address> dests, Message msg, RequestOptions opts)
Sends a message to all members and expects responses from members in dests (if non-null).protected void
RequestCorrelator. dispatch(Message msg, RequestCorrelator.Header hdr)
java.lang.Object
MessageDispatcher.ProtocolAdapter. down(Message msg)
T
Request. execute(Message msg, boolean block_for_results)
java.lang.Object
MessageDispatcher. handle(Message msg)
void
MessageDispatcher. handle(Message request, Response response)
java.lang.Object
RequestHandler. handle(Message msg)
Processes a request synchronously, ie.default void
RequestHandler. handle(Message request, Response response)
Processes a request asynchronously.java.lang.Object
RpcDispatcher. handle(Message req)
Message contains MethodCall.protected void
RequestCorrelator. handleRequest(Message req, RequestCorrelator.Header hdr)
Handle a request msg for this correlatorprotected void
RequestCorrelator. handleResponse(Message rsp, RequestCorrelator.Header hdr)
protected static Message
RequestCorrelator. makeReply(Message msg)
void
ReplicatedTree. receive(Message msg)
Callback.boolean
RequestCorrelator. receiveMessage(Message msg)
Handles a message coming from a layer belowvoid
RequestCorrelator.ResponseImpl. send(Message reply, boolean is_exception)
void
Response. send(Message reply, boolean is_exception)
Similar toResponse.send(Object,boolean)
, but passes a message instead of an object.protected void
RequestCorrelator. sendAnycastRequest(Message req, java.util.Collection<Address> dest_mbrs)
<T> T
MessageDispatcher. sendMessage(Message msg, RequestOptions opts)
Sends a unicast message and - depending on the options - returns a result<T> java.util.concurrent.CompletableFuture<T>
MessageDispatcher. sendMessageWithFuture(Message msg, RequestOptions opts)
Sends a unicast message to the target defined by msg.getDest() and returns a future<T> void
RequestCorrelator. sendMulticastRequest(java.util.Collection<Address> dest_mbrs, Message msg, Request<T> req, RequestOptions opts)
Sends a request to a group.protected void
RequestCorrelator. sendReply(Message req, long req_id, java.lang.Object reply, boolean is_exception)
void
GroupRequest. sendRequest(Message msg)
protected void
GroupRequest. sendRequest(Message msg, java.util.Collection<Address> targetMembers)
abstract void
Request. sendRequest(Message req)
void
UnicastRequest. sendRequest(Message msg)
protected void
RequestCorrelator. sendResponse(Message rsp, long req_id, boolean is_exception)
<T> void
RequestCorrelator. sendUnicastRequest(Message msg, Request<T> req, RequestOptions opts)
Sends a request to a single destinationjava.lang.Object
MessageDispatcher.ProtocolAdapter. up(Message msg)
Constructors in org.jgroups.blocks with parameters of type Message Constructor Description ResponseImpl(Message req, long req_id)
-
Uses of Message in org.jgroups.demos
Methods in org.jgroups.demos with parameters of type Message Modifier and Type Method Description void
Chat. receive(Message msg)
void
Draw. receive(Message msg)
void
RelayDemo. receive(Message msg)
-
Uses of Message in org.jgroups.fork
Methods in org.jgroups.fork with parameters of type Message Modifier and Type Method Description java.lang.Object
ForkChannel. down(Message msg)
java.lang.Object
ForkProtocol. down(Message msg)
java.lang.Object
ForkProtocolStack. down(Message msg)
java.lang.Object
UnknownForkHandler. handleUnknownForkChannel(Message message, java.lang.String forkChannelId)
Handle a message that refers to an unknown fork channeljava.lang.Object
UnknownForkHandler. handleUnknownForkStack(Message message, java.lang.String forkStackId)
Handle a message that refers to an unknown fork stackForkChannel
ForkChannel. send(Message msg)
protected void
ForkChannel. setHeader(Message msg)
java.lang.Object
ForkProtocolStack. up(Message msg)
-
Uses of Message in org.jgroups.protocols
Fields in org.jgroups.protocols declared as Message Modifier and Type Field Description protected Message[]
RingBufferBundlerLockless. buf
protected Message[]
RingBufferBundlerLockless2. buf
protected static Message
ReliableMulticast. DUMMY_OOB_MSG
protected static Message
UNICAST3. DUMMY_OOB_MSG
protected Message[]
FRAG2.FragEntry. fragments
protected Message
FRAG3.FragEntry. msg
protected Message[]
SimplifiedTransferQueueBundler. msg_queue
static Message
RingBufferBundlerLockless2. NULL_MSG
protected Message[]
RemoveQueueBundler. remove_queue
Fields in org.jgroups.protocols with type parameters of type Message Modifier and Type Field Description protected static java.util.function.BiConsumer<MessageBatch,Message>
ReliableMulticast. BATCH_ACCUMULATOR
protected static java.util.function.BiConsumer<MessageBatch,Message>
SEQUENCER2. BATCH_ACCUMULATOR
protected static java.util.function.BiConsumer<MessageBatch,Message>
UNICAST3. BATCH_ACCUMULATOR
protected java.util.Queue<Message>
ReliableMulticast. become_server_queue
protected static java.util.function.Predicate<Message>
UNICAST3. dont_loopback_filter
protected java.util.List<java.util.function.Predicate<Message>>
DROP. down_filters
protected java.util.List<Message>
SHUFFLE. down_msgs
protected java.util.concurrent.BlockingQueue<Message>
BATCH2. down_queue
protected java.util.function.Predicate<Message>
UNICAST3. drop_oob_and_dont_loopback_msgs_filter
protected java.util.function.Predicate<Message>
HDRS. filter
protected java.util.function.Predicate<Message>
REVERSE. filter
protected java.util.NavigableMap<java.lang.Long,Message>
SEQUENCER. forward_table
Maintains messages forwarded to the coord which which no ack has been received yet.protected java.util.concurrent.BlockingQueue<Message>
SEQUENCER2. fwd_queue
protected java.util.function.Predicate<Message>
FRAG. HAS_FRAG_HEADER
protected java.util.function.Predicate<Message>
FRAG2. HAS_FRAG_HEADER
protected java.util.function.Predicate<Message>
FRAG3. HAS_FRAG_HEADER
protected java.util.function.Predicate<Message>
FailureDetection. HAS_HEADER
protected java.util.function.Predicate<Message>
ReliableMulticast. HAS_HEADER
protected Buffer<Message>
ReliableMulticast. local_xmit_table
protected java.util.Map<Address,Message>
BARRIER. mcast_queue
protected java.util.Map<Address,java.util.List<Message>>
BaseBundler. msgs
Keys are destinations, values are lists of Messagesprotected FastArray<Message>
PerDestinationBundler.SendBuffer. msgs
protected Table<Message>
UNICAST3.Entry. msgs
protected java.util.function.Predicate<Message>
ReliableMulticast. no_dummy_and_no_oob_delivered_msgs_and_no_dont_loopback_msgs
protected java.util.Map<Address,java.util.List<Message>>
MAKE_BATCH. oob_map_mcast
protected java.util.Map<Address,java.util.List<Message>>
MAKE_BATCH. oob_map_ucast
protected java.util.Deque<Message>
REVERSE. queue
protected java.util.concurrent.BlockingQueue<Message>
TransferQueueBundler. queue
protected java.util.concurrent.BlockingQueue<Message>
TransferQueueBundler2. queue
protected RingBuffer<Message>
RemoveQueueBundler. rb
protected RingBuffer<Message>
RingBufferBundler. rb
protected Table<Message>
SEQUENCER2. received_msgs
protected java.util.Map<Address,java.util.List<Message>>
MAKE_BATCH. reg_map_mcast
protected java.util.Map<Address,java.util.List<Message>>
MAKE_BATCH. reg_map_ucast
protected static java.util.function.Predicate<Message>
ReliableMulticast. remove_filter
protected java.util.List<Message>
BATCH2. remove_queue
protected java.util.List<Message>
TransferQueueBundler. remove_queue
protected java.util.List<Message>
TransferQueueBundler2. remove_queue
protected java.util.function.Consumer<Message>
MFC_NB. send_function
protected java.util.function.Consumer<Message>
UFC_NB. send_function
protected java.util.function.Function<Message,java.lang.Long>
ReliableMulticast. SEQNO_GETTER
protected java.util.List<Message>
AlternatingBundler. target_list
protected java.util.Map<Address,Message>
BARRIER. ucast_queue
protected java.util.List<java.util.function.Predicate<Message>>
DROP. up_filters
protected java.util.List<Message>
SHUFFLE. up_msgs
protected java.util.Map<Address,Buffer<Message>>
ReliableMulticast. xmit_table
Map to store sent and received messages (keyed by sender)Methods in org.jgroups.protocols with type parameters of type Message Modifier and Type Method Description <T extends Buffer<Message>>
TReliableMulticast. getWindow(Address sender)
Returns the receive window for sender; only used for testing.Methods in org.jgroups.protocols that return Message Modifier and Type Method Description protected Message
Encrypt. _decrypt(javax.crypto.Cipher cipher, java.security.Key key, Message msg, EncryptHeader hdr)
protected Message
ASYM_ENCRYPT. addKeysToMessage(Message msg, boolean copy, boolean add_secret_keys, Address serialize_only)
Adds the public and/or encrypted shared keys to the payload of msg.protected Message
FRAG2. assembleMessage(Message[] fragments, boolean needs_deserialization, FragHeader hdr)
Assembles all the message fragments into one message.protected Message
FRAG3.FragEntry. assembleMessage()
Assembles all the fragments into one buffer.protected Message
FRAG4. assembleMessage(Message[] fragments, boolean needs_deserialization, FragHeader hdr)
protected Message
Encrypt. decrypt(javax.crypto.Cipher cipher, Message msg)
Does the actual work for decrypting - if version does not match current cipher then tries the previous cipherprotected Message
SERIALIZE. deserialize(Address sender, byte[] buf, int offset, int length)
protected Message
Encrypt. encrypt(Message msg)
protected static Message
COMPRESS. messageFromByteArray(byte[] uncompressed_payload, MessageFactory msg_factory)
protected Message
ReliableMulticast. msgFromXmitRsp(Message msg, NakAckHeader hdr)
Message
FRAG3.FragEntry. set(Message frag_msg, Frag3Header hdr)
Adds a fragment to the full messageprotected Message
COMPRESS. uncompress(Message msg, int original_size, boolean needs_deserialization)
Returns a new message as a result of uncompressing msg, or null if msg couldn't be uncompressedprotected Message
FRAG2. unfragment(Message msg, FragHeader hdr)
1.protected Message
FRAG3. unfragment(Message msg, Frag3Header hdr)
1.Methods in org.jgroups.protocols that return types with arguments of type Message Modifier and Type Method Description RingBuffer<Message>
RingBufferBundler. buf()
protected Table<Message>
UNICAST3. createTable(long seqno)
protected Buffer<Message>
NAKACK3. createXmitWindow(long initial_seqno)
protected Buffer<Message>
NAKACK4. createXmitWindow(long initial_seqno)
protected abstract Buffer<Message>
ReliableMulticast. createXmitWindow(long initial_seqno)
java.util.function.Predicate<Message>
REVERSE. filter()
Table<Message>
UNICAST3. getSendWindow(Address target)
Used for testing only!protected Buffer<Message>
ReliableMulticast. sendBuf()
Methods in org.jgroups.protocols with parameters of type Message Modifier and Type Method Description protected Message
Encrypt. _decrypt(javax.crypto.Cipher cipher, java.security.Key key, Message msg, EncryptHeader hdr)
protected java.lang.Object
BATCH2. _down(Message msg)
protected java.lang.Object
SimpleTCP. _down(Message msg)
protected void
BatchBundler. _send(Message msg, ByteArrayDataOutputStream out)
protected void
TP. _send(Message msg, Address dest)
protected SHUFFLE
SHUFFLE. add(java.util.List<Message> queue, Message msg, java.util.concurrent.locks.Lock lock, java.util.function.Consumer<Message> send_function)
protected void
PerDestinationBundler.SendBuffer. addAndSendIfSizeExceeded(Message msg)
protected void
TransferQueueBundler. addAndSendIfSizeExceeded(Message msg)
protected void
TransferQueueBundler2. addAndSendIfSizeExceeded(Message msg)
protected Message
ASYM_ENCRYPT. addKeysToMessage(Message msg, boolean copy, boolean add_secret_keys, Address serialize_only)
Adds the public and/or encrypted shared keys to the payload of msg.protected void
AlternatingBundler. addMessage(Message msg, int size)
protected void
BaseBundler. addMessage(Message msg, int size)
protected boolean
BATCH.Buffer. addMessage(Message msg)
protected boolean
BATCH2.Buffer. addMessage(Message msg)
protected boolean
BatchBundler.Buffer. addMessage(Message msg)
protected void
PerDestinationBundler.SendBuffer. addMessage(Message msg, int size)
protected void
SimplifiedTransferQueueBundler. addMessage(Message msg, int size)
protected void
UNICAST3. addMessage(UNICAST3.ReceiverEntry entry, Address sender, long seqno, Message msg)
protected ASYM_ENCRYPT.Processing
ASYM_ENCRYPT. addMetadata(Message msg, boolean add_secret_keys, Address include_secret_key_only_for, boolean attach_fetch_key_header)
protected Message
FRAG2. assembleMessage(Message[] fragments, boolean needs_deserialization, FragHeader hdr)
Assembles all the message fragments into one message.protected Message
FRAG4. assembleMessage(Message[] fragments, boolean needs_deserialization, FragHeader hdr)
protected void
SEQUENCER. broadcast(Message msg, boolean copy, Address original_sender, long seqno, boolean resend)
protected void
SEQUENCER2. broadcast(Message msg, long seqno)
protected Message
Encrypt. decrypt(javax.crypto.Cipher cipher, Message msg)
Does the actual work for decrypting - if version does not match current cipher then tries the previous cipherprotected void
ReliableMulticast. deliver(Message msg, Address sender, long seqno, Buffer<Message> win, java.lang.String error_msg)
protected void
SEQUENCER. deliver(Message msg, SEQUENCER.SequencerHeader hdr)
protected void
SEQUENCER2. deliver(Message msg, SEQUENCER2.SequencerHeader hdr)
protected void
UNICAST3. deliverMessage(Message msg, Address sender, long seqno)
java.lang.Object
ASYM_ENCRYPT. down(Message msg)
java.lang.Object
AUTH. down(Message msg)
java.lang.Object
BATCH. down(Message msg)
java.lang.Object
BATCH2. down(Message msg)
java.lang.Object
CLEAR_FLAGS. down(Message msg)
java.lang.Object
COMPRESS. down(Message msg)
We compress the payload if it is larger thanmin_size
.java.lang.Object
DAISYCHAIN. down(Message msg)
java.lang.Object
DELAY. down(Message msg)
java.lang.Object
DETECT_LOOPBACKS. down(Message msg)
java.lang.Object
DISCARD_PAYLOAD. down(Message msg)
java.lang.Object
DISCARD. down(Message msg)
java.lang.Object
DROP. down(Message msg)
java.lang.Object
DUPL. down(Message msg)
java.lang.Object
Encrypt. down(Message msg)
java.lang.Object
EXAMPLE. down(Message msg)
java.lang.Object
FailureDetection. down(Message msg)
java.lang.Object
FlowControl. down(Message msg)
java.lang.Object
FRAG. down(Message msg)
java.lang.Object
FRAG2. down(Message msg)
java.lang.Object
FRAG3. down(Message msg)
java.lang.Object
HDRS. down(Message msg)
java.lang.Object
NON_BLOCKING_SENDS. down(Message msg)
java.lang.Object
PERF. down(Message msg)
java.lang.Object
RATE_LIMITER. down(Message msg)
java.lang.Object
RATE_LIMITER2. down(Message msg)
java.lang.Object
RATE. down(Message msg)
java.lang.Object
RED. down(Message msg)
java.lang.Object
ReliableMulticast. down(Message msg)
java.lang.Object
RSVP. down(Message msg)
java.lang.Object
SEQUENCER. down(Message msg)
java.lang.Object
SEQUENCER2. down(Message msg)
java.lang.Object
SERIALIZE. down(Message msg)
java.lang.Object
SHUFFLE. down(Message msg)
java.lang.Object
SimpleTCP. down(Message msg)
java.lang.Object
SIZE. down(Message msg)
java.lang.Object
SNIFF. down(Message msg)
java.lang.Object
STATS. down(Message msg)
java.lang.Object
THREAD_COUNT. down(Message msg)
java.lang.Object
TIME. down(Message msg)
java.lang.Object
TP. down(Message msg)
A message needs to be sent to a single member or all membersjava.lang.Object
TRACE. down(Message msg)
java.lang.Object
UNICAST3. down(Message msg)
protected boolean
ASYM_ENCRYPT. dropMulticastMessageFromNonMember(Message msg)
protected void
DROP. dropped(Message m, boolean down)
protected static void
SNIFF. dump(java.lang.String type, Message msg)
protected Message
Encrypt. encrypt(Message msg)
protected void
SEQUENCER. forward(Message msg, long seqno, boolean flush)
protected void
SEQUENCER. forwardToCoord(long seqno, Message msg)
protected void
FRAG2. fragment(Message msg)
Send all fragments as separate messages (with same ID !).protected void
FRAG3. fragment(Message msg)
Send all fragments as separate messages (with same ID !).protected void
FRAG4. fragment(Message msg)
protected static GMS.GmsHeader
AUTH. getGMSHeader(Message msg)
protected byte[]
ASYM_ENCRYPT. getIv(Message msg)
protected static JoinRsp
AUTH. getJoinResponse(Message msg)
protected java.lang.Object
Discovery. handle(PingHeader hdr, Message msg)
protected java.lang.Object
MERGE3. handle(MERGE3.MergeHeader hdr, Message msg)
protected boolean
AUTH. handleAuthHeader(GMS.GmsHeader gms_hdr, AuthHeader auth_hdr, Message msg)
Handles a GMS headerprotected void
UNICAST3. handleDataReceived(Address sender, long seqno, short conn_id, boolean first, Message msg)
Check whether the hashtable contains an entry e forsender
(create if not).protected void
UNICAST3. handleDataReceivedFromSelf(Address sender, long seqno, Message msg)
Called when the sender of a message is the local member.protected abstract java.lang.Object
FlowControl. handleDownMessage(Message msg, int length)
protected java.lang.Object
MFC_NB. handleDownMessage(Message msg, int length)
protected java.lang.Object
MFC. handleDownMessage(Message msg, int length)
protected java.lang.Object
UFC_NB. handleDownMessage(Message msg, int length)
protected java.lang.Object
UFC. handleDownMessage(Message msg, int length)
protected java.lang.Object
Encrypt. handleEncryptedMessage(Message msg)
protected void
ReliableMulticast. handleMessage(Message msg, NakAckHeader hdr)
Finds the corresponding retransmit buffer and adds the message to it (according to seqno).protected void
FlowControl. handleUpEvent(Message msg, FcHeader hdr)
protected void
UNICAST3. handleUpEvent(Address sender, Message msg, UnicastHeader3 hdr)
protected void
ReliableMulticast. handleXmitRsp(Message msg, NakAckHeader hdr)
protected void
TP. loopback(Message msg, boolean multicast)
protected int
RingBufferBundler. marshalMessagesToSameDestination(Address dest, Message[] buf, int start_index, int end_index, int max_bundle_size)
protected int
RingBufferBundlerLockless. marshalMessagesToSameDestination(Address dest, Message[] buf, int start_index, int available_msgs, int max_bundle_size)
protected int
RingBufferBundlerLockless2. marshalMessagesToSameDestination(Address dest, Message[] buf, int start_index, int end_index, int max_bundle_size)
static ByteArray
FD_SOCK2. messageToBuffer(Message msg)
protected static ByteArray
COMPRESS. messageToByteArray(Message msg)
protected Message
ReliableMulticast. msgFromXmitRsp(Message msg, NakAckHeader hdr)
protected boolean
AUTH. needsAuthentication(Message msg, GMS.GmsHeader hdr)
protected static int
SIZE. numHeaders(Message msg)
void
TP. passMessageUp(Message msg, byte[] cluster_name, boolean perform_cluster_name_matching, boolean multicast, boolean discard_own_mcast)
protected static void
SNIFF. printPayload(Message msg, java.lang.StringBuilder sb)
protected boolean
ASYM_ENCRYPT. processEncryptMessage(Message msg, EncryptHeader hdr, boolean retval)
protected void
MAKE_BATCH. queue(Message msg)
protected void
ReliableMulticast. queueMessage(Message msg, long seqno)
MsgStats
MsgStats. received(Message msg)
protected void
STATS. received(Message msg)
protected void
ASYM_ENCRYPT. removeKeysFromMessageAndInstall(Message msg, byte[] version)
Removes the public and/or private keys from the payload of msg and installs them.protected void
ReliableMulticast. resend(Message msg)
protected void
UNICAST3. resend(Message msg)
protected void
UNICAST3. retransmit(Message msg)
Called by the sender to resend messages for which no ACK has been received yetvoid
AsyncNoBundler. send(Message msg)
void
BaseBundler. send(Message msg)
void
BatchBundler. send(Message msg)
void
Bundler. send(Message msg)
protected void
NAKACK4. send(Message msg, Buffer<Message> win)
void
NoBundler. send(Message msg)
void
PerDestinationBundler. send(Message msg)
protected void
PerDestinationBundler.SendBuffer. send(Message msg)
protected void
ReliableMulticast. send(Message msg, Buffer<Message> win)
Adds the message to the sent_msgs table and then passes it down the stack.void
RemoveQueueBundler. send(Message msg)
void
RingBufferBundler. send(Message msg)
void
RingBufferBundlerLockless. send(Message msg)
void
RingBufferBundlerLockless2. send(Message msg)
void
SenderSendsBundler. send(Message msg)
void
TransferQueueBundler. send(Message msg)
void
TransferQueueBundler2. send(Message msg)
void
RingBufferBundler. sendBundledMessages(Message[] buf, int read_index, int available_msgs)
Read and send messages in range [read-index ..protected int
RingBufferBundlerLockless. sendBundledMessages(Message[] buf, int read_index, int available_msgs)
Read and send messages in range [read-index ..protected int
RingBufferBundlerLockless2. sendBundledMessages(Message[] buf, int read_index, int write_index)
Read and send messages in range [read-index+1 ..protected void
TCPPING. sendDiscoveryRequest(Message req)
protected void
BPING. sendMcastDiscoveryRequest(Message msg)
protected void
MPING. sendMcastDiscoveryRequest(Message msg)
protected void
PING. sendMcastDiscoveryRequest(Message msg)
protected void
BatchBundler.Buffer. sendMessageList(Address dest, Address src, Message[] list, int length)
protected void
BaseBundler. sendSingleMessage(Message msg)
protected void
NoBundler. sendSingleMessage(Message msg, ByteArrayDataOutputStream output)
protected void
PerDestinationBundler.SendBuffer. sendSingleMessage(Address dest, Message msg)
protected void
ReliableMulticast. sendXmitRsp(Address dest, Message msg)
Sends a message msg to the requester.MsgStats
MsgStats. sent(Message msg)
protected void
STATS. sent(Message msg)
void
FRAG2.FragEntry. set(int frag_id, Message frag)
adds on fragmentation buffer to the messageMessage
FRAG3.FragEntry. set(Message frag_msg, Frag3Header hdr)
Adds a fragment to the full messageprotected void
TP. setSourceAddress(Message msg)
If the sender is null, set our own address.protected boolean
DISCARD. shouldDropUpMessage(Message msg, Address sender)
Checks if a message should be passed up, or notprotected long
RATE. size(Message msg)
protected ASYM_ENCRYPT.Processing
ASYM_ENCRYPT. skipDownMessage(Message msg)
Processes a message with a GMS header (e.g.protected boolean
ASYM_ENCRYPT. skipUpMessage(Message msg)
Checks if the message contains a public key (and adds it to pub_map if present) or an encrypted group key (and installs it if present)protected Message
COMPRESS. uncompress(Message msg, int original_size, boolean needs_deserialization)
Returns a new message as a result of uncompressing msg, or null if msg couldn't be uncompressedprotected Message
FRAG2. unfragment(Message msg, FragHeader hdr)
1.protected Message
FRAG3. unfragment(Message msg, Frag3Header hdr)
1.protected void
SEQUENCER. unwrapAndDeliver(Message msg, boolean flush_ack)
Unmarshal the original message (in the payload) and then pass it up (unless already delivered)java.lang.Object
ASYM_ENCRYPT. up(Message msg)
java.lang.Object
AUTH. up(Message msg)
An event was received from the layer below.java.lang.Object
BARRIER. up(Message msg)
java.lang.Object
BATCH. up(Message msg)
java.lang.Object
BATCH2. up(Message msg)
java.lang.Object
CLEAR_FLAGS. up(Message msg)
java.lang.Object
COMPRESS. up(Message msg)
If there is no header, we pass the message up.java.lang.Object
COUNTER. up(Message msg)
java.lang.Object
DAISYCHAIN. up(Message msg)
java.lang.Object
DELAY. up(Message msg)
java.lang.Object
DH_KEY_EXCHANGE. up(Message msg)
java.lang.Object
DISCARD. up(Message msg)
java.lang.Object
Discovery. up(Message msg)
java.lang.Object
DROP. up(Message msg)
java.lang.Object
DUPL. up(Message msg)
java.lang.Object
Encrypt. up(Message msg)
java.lang.Object
EXAMPLE. up(Message msg)
java.lang.Object
FailureDetection. up(Message msg)
java.lang.Object
FD_SOCK. up(Message msg)
java.lang.Object
FD_SOCK2. up(Message msg)
java.lang.Object
FlowControl. up(Message msg)
java.lang.Object
FORK. up(Message msg)
java.lang.Object
FRAG. up(Message msg)
java.lang.Object
FRAG2. up(Message msg)
java.lang.Object
FRAG3. up(Message msg)
java.lang.Object
HDRS. up(Message msg)
java.lang.Object
MAKE_BATCH. up(Message msg)
java.lang.Object
MERGE3. up(Message msg)
java.lang.Object
NON_BLOCKING_SENDS. up(Message msg)
java.lang.Object
PERF. up(Message msg)
java.lang.Object
RATE. up(Message msg)
java.lang.Object
ReliableMulticast. up(Message msg)
java.lang.Object
REVERSE. up(Message msg)
java.lang.Object
RSVP. up(Message msg)
java.lang.Object
SEQUENCER. up(Message msg)
java.lang.Object
SEQUENCER2. up(Message msg)
java.lang.Object
SERIALIZE. up(Message msg)
java.lang.Object
SHUFFLE. up(Message msg)
java.lang.Object
SIZE. up(Message msg)
java.lang.Object
SNIFF. up(Message msg)
java.lang.Object
STATS. up(Message msg)
java.lang.Object
STOMP. up(Message msg)
java.lang.Object
THREAD_COUNT. up(Message msg)
java.lang.Object
TIME. up(Message msg)
java.lang.Object
UNICAST3. up(Message msg)
java.lang.Object
VERIFY_SUSPECT. up(Message msg)
java.lang.Object
VERIFY_SUSPECT2. up(Message msg)
Method parameters in org.jgroups.protocols with type arguments of type Message Modifier and Type Method Description protected static int
UNICAST3. accumulate(java.util.function.ToIntFunction<Table<Message>> func, java.util.Collection<? extends UNICAST3.Entry>... entries)
protected SHUFFLE
SHUFFLE. add(java.util.List<Message> queue, Message msg, java.util.concurrent.locks.Lock lock, java.util.function.Consumer<Message> send_function)
protected SHUFFLE
SHUFFLE. add(java.util.List<Message> queue, Message msg, java.util.concurrent.locks.Lock lock, java.util.function.Consumer<Message> send_function)
protected SHUFFLE
SHUFFLE. add(java.util.List<Message> queue, MessageBatch batch, java.util.concurrent.locks.Lock lock, java.util.function.Consumer<Message> send_function)
protected SHUFFLE
SHUFFLE. add(java.util.List<Message> queue, MessageBatch batch, java.util.concurrent.locks.Lock lock, java.util.function.Consumer<Message> send_function)
DROP
DROP. addDownFilter(java.util.function.Predicate<Message> filter)
protected void
UNICAST3. addQueuedMessages(Address sender, UNICAST3.ReceiverEntry entry, java.util.Collection<Message> queued_msgs)
DROP
DROP. addUpFilter(java.util.function.Predicate<Message> filter)
protected void
ReliableMulticast. deliver(Message msg, Address sender, long seqno, Buffer<Message> win, java.lang.String error_msg)
protected void
ReliableMulticast. deliverBatch(MessageBatch batch, Buffer<Message> buf)
HDRS
HDRS. filter(java.util.function.Predicate<Message> f)
REVERSE
REVERSE. filter(java.util.function.Predicate<Message> f)
protected void
BARRIER. flushQueue(java.util.Map<Address,Message> queue)
protected void
UNICAST3. handleBatchReceived(UNICAST3.ReceiverEntry entry, Address sender, java.util.List<LongTuple<Message>> msgs, boolean oob, Address original_dest)
protected java.lang.String
UNICAST3. printMessageList(java.util.List<LongTuple<Message>> list)
protected void
ReliableMulticast. removeAndDeliver(Buffer<Message> win, Address sender, boolean loopback, AsciiString cluster)
Efficient way of checking whether another thread is already processing messages from sender.protected void
SEQUENCER2. removeAndDeliver(Table<Message> win, Address sender)
protected void
UNICAST3. removeAndDeliver(Table<Message> win, Address sender)
Try to remove as many messages as possible from the table as pass them up.DROP
DROP. removeDownFilter(java.util.function.Predicate<Message> filter)
DROP
DROP. removeUpFilter(java.util.function.Predicate<Message> filter)
protected SHUFFLE
SHUFFLE. reorderAndSend(java.util.List<Message> list, java.util.concurrent.locks.Lock lock, java.util.function.Consumer<Message> send_function)
protected SHUFFLE
SHUFFLE. reorderAndSend(java.util.List<Message> list, java.util.concurrent.locks.Lock lock, java.util.function.Consumer<Message> send_function)
protected void
NAKACK4. send(Message msg, Buffer<Message> win)
protected void
ReliableMulticast. send(Message msg, Buffer<Message> win)
Adds the message to the sent_msgs table and then passes it down the stack.protected void
NAKACK4. sendAck(Address to, Buffer<Message> win)
protected void
ReliableMulticast. sendAck(Address to, Buffer<Message> win)
protected void
PerDestinationBundler.SendBuffer. sendBatch(Address destination, FastArray<Message> list)
protected void
BaseBundler. sendMessageList(Address dest, Address src, java.util.List<Message> list)
protected void
PerDestinationBundler.SendBuffer. sendMessageList(Address dest, Address src, FastArray<Message> list)
protected void
RemoveQueueBundler. sendMessageList(Address dest, Address src, java.util.List<Message> list)
protected void
PerDestinationBundler.SendBuffer. sendMessages(Address dest, Address src, FastArray<Message> list)
protected static long
ReliableMulticast. sizeOfAllMessages(Buffer<Message> win, boolean include_headers)
Constructor parameters in org.jgroups.protocols with type arguments of type Message Constructor Description Entry(short conn_id, Table<Message> msgs)
ReceiverEntry(Table<Message> received_msgs, short recv_conn_id, Address real_dest)
RingBufferBundler(RingBuffer<Message> rb)
TransferQueueBundler2(java.util.concurrent.BlockingQueue<Message> queue)
-
Uses of Message in org.jgroups.protocols.dns
Methods in org.jgroups.protocols.dns with parameters of type Message Modifier and Type Method Description protected void
DNS_PING. sendDiscoveryRequest(Message req)
-
Uses of Message in org.jgroups.protocols.pbcast
Fields in org.jgroups.protocols.pbcast declared as Message Modifier and Type Field Description protected static Message
NAKACK2. DUMMY_OOB_MSG
Fields in org.jgroups.protocols.pbcast with type parameters of type Message Modifier and Type Field Description protected static java.util.function.BiConsumer<MessageBatch,Message>
NAKACK2. BATCH_ACCUMULATOR
protected java.util.Queue<Message>
NAKACK2. become_server_queue
protected static java.util.function.Predicate<Message>
NAKACK2. dont_loopback_filter
protected java.util.function.Predicate<Message>
NAKACK2. HAS_HEADER
protected Table<Message>
NAKACK2. local_xmit_table
protected java.util.function.Predicate<Message>
NAKACK2. no_dummy_and_no_oob_delivered_msgs_and_no_dont_loopback_msgs
protected java.util.function.Function<Message,java.lang.Long>
NAKACK2. SEQNO_GETTER
protected java.util.concurrent.ConcurrentMap<Address,Table<Message>>
NAKACK2. xmit_table
Map to store sent and received messages (keyed by sender)Methods in org.jgroups.protocols.pbcast that return Message Modifier and Type Method Description protected Message
NAKACK2. msgFromXmitRsp(Message msg, NakAckHeader2 hdr)
Methods in org.jgroups.protocols.pbcast that return types with arguments of type Message Modifier and Type Method Description protected Table<Message>
NAKACK2. createTable(long initial_seqno)
Table<Message>
NAKACK2. getWindow(Address sender)
Returns the receive window for sender; only used for testing.Methods in org.jgroups.protocols.pbcast with parameters of type Message Modifier and Type Method Description protected void
NAKACK2. deliver(Message msg, Address sender, long seqno, java.lang.String error_msg)
java.lang.Object
NAKACK2. down(Message msg)
java.lang.Object
STABLE. down(Message msg)
protected java.lang.Object
GMS. handle(GMS.GmsHeader hdr, Message msg)
protected java.lang.Object
StreamingStateTransfer. handle(StreamingStateTransfer.StateHeader hdr, Message msg)
protected void
NAKACK2. handleMessage(Message msg, NakAckHeader2 hdr)
Finds the corresponding retransmit buffer and adds the message to it (according to seqno).protected void
STABLE. handleRegularMessage(Message msg)
protected void
NAKACK2. handleXmitRsp(Message msg, NakAckHeader2 hdr)
protected Message
NAKACK2. msgFromXmitRsp(Message msg, NakAckHeader2 hdr)
protected void
NAKACK2. queueMessage(Message msg, long seqno)
protected void
NAKACK2. resend(Message msg)
protected void
NAKACK2. send(Message msg)
Adds the message to the sent_msgs table and then passes it down the stack.protected void
NAKACK2. sendXmitRsp(Address dest, Message msg)
Sends a message msg to the requester.java.lang.Object
GMS. up(Message msg)
java.lang.Object
NAKACK2. up(Message msg)
java.lang.Object
STABLE. up(Message msg)
java.lang.Object
STATE_TRANSFER. up(Message msg)
java.lang.Object
StreamingStateTransfer. up(Message msg)
Method parameters in org.jgroups.protocols.pbcast with type arguments of type Message Modifier and Type Method Description protected void
NAKACK2. removeAndDeliver(Table<Message> buf, Address sender, boolean loopback, AsciiString cluster_name)
Efficient way of checking whether another thread is already processing messages from sender.protected static long
NAKACK2. sizeOfAllMessages(Table<Message> buf, boolean include_headers)
-
Uses of Message in org.jgroups.protocols.relay
Methods in org.jgroups.protocols.relay that return Message Modifier and Type Method Description protected Message
RELAY. copy(Message msg)
Copies the message, but only the headers above the current protocol (RELAY) (or RpcDispatcher related headers)protected Message
Route. createMessage(Address target, Address final_destination, Address original_sender, Message msg, java.util.Collection<java.lang.String> visited_sites)
Methods in org.jgroups.protocols.relay with parameters of type Message Modifier and Type Method Description protected Message
RELAY. copy(Message msg)
Copies the message, but only the headers above the current protocol (RELAY) (or RpcDispatcher related headers)protected Message
Route. createMessage(Address target, Address final_destination, Address original_sender, Message msg, java.util.Collection<java.lang.String> visited_sites)
protected void
RELAY2. deliver(Address dest, Address sender, Message msg)
protected java.lang.Object
RELAY3. deliver(Address next_dest, Message msg, boolean dont_relay)
Sends the message to a local destination.protected java.lang.Object
RELAY3. deliver(Address next_dest, Message msg, boolean dont_relay, boolean dont_loopback, boolean oob)
protected void
RELAY2. deliverLocally(SiteAddress dest, SiteAddress sender, Message msg)
java.lang.Object
RELAY2. down(Message msg)
java.lang.Object
RELAY3. down(Message msg)
protected void
RELAY2. forwardTo(Address next_dest, SiteAddress final_dest, Address original_sender, Message msg, boolean forward_to_current_coord)
protected boolean
RELAY3. handleAdminMessage(RelayHeader hdr, Message msg)
Handles SITES_UP/SITES_DOWN/TOPO_REQ/TOPO_RSP messagesprotected void
RELAY2. handleMessage(RelayHeader hdr, Message msg)
Called to handle a message received by the transportprotected abstract void
RELAY. handleRelayMessage(Message msg)
protected void
RELAY2. handleRelayMessage(Message msg)
Called to handle a message received by the relayerprotected void
RELAY3. handleRelayMessage(Message msg)
Called to handle a message received from a different site (via a bridge channel)protected boolean
RELAY3. mustBeRouted(Message msg)
Determines if a message should be routed.protected java.lang.Object
RELAY3. passUp(Message msg)
Sends a message up the stack.protected java.lang.Object
RELAY3. process(boolean down, Message msg)
This method has all the routing logic, for both site masters and regular membersvoid
Bridge. receive(Message msg)
void
Relayer2.Bridge. receive(Message msg)
protected void
RELAY2. route(SiteAddress dest, SiteAddress sender, Message msg)
Routes the message to the target destination, used by a site master (coordinator)protected java.lang.Object
RELAY3. route(Message msg, java.util.Collection<java.lang.String> sites)
Sends a message to the given sites, or all sites (excluding the local site)protected java.lang.Object
RELAY3. routeThen(Message msg, java.util.List<java.lang.String> sites, java.util.function.Supplier<java.lang.Object> action)
void
Route. send(Address final_destination, Address original_sender, Message msg)
void
Route. send(Address final_destination, Address original_sender, Message msg, java.util.Collection<java.lang.String> visited_sites)
protected void
RELAY2. sendToBridges(Address sender, Message msg, java.lang.String... excluded_sites)
Sends the message via all bridges excluding the excluded_sites bridgesprotected java.lang.Object
RELAY3. sendToLocalSiteMaster(Address sender, Message msg)
java.lang.Object
RELAY2. up(Message msg)
java.lang.Object
RELAY3. up(Message msg)
-
Uses of Message in org.jgroups.stack
Fields in org.jgroups.stack with type parameters of type Message Modifier and Type Field Description protected static java.util.function.BiConsumer<java.lang.Short,Message>
GossipRouter. MSG_CONSUMER
Methods in org.jgroups.stack with parameters of type Message Modifier and Type Method Description protected boolean
Protocol. accept(Message msg)
Called by the default implementation ofProtocol.up(org.jgroups.util.MessageBatch)
for each message to determine if the message should be removed from the message batch (and handled by the current protocol) or not.java.lang.Object
Protocol. down(Message msg)
A message is sent down the stack.java.util.concurrent.CompletableFuture<java.lang.Object>
Protocol. down(Message msg, boolean async)
Passes a message down asynchronously.java.lang.Object
ProtocolStack. down(Message msg)
java.util.concurrent.CompletableFuture<java.lang.Object>
ProtocolStack. down(Message msg, boolean async)
boolean
MessageProcessingPolicy. loopback(Message msg, boolean oob)
Process a message that was not received from the transport but from above (e.g.boolean
MessageProcessingPolicy. process(Message msg, boolean oob)
Process a message received from the transportjava.lang.Object
Protocol. up(Message msg)
A single message was received.java.lang.Object
ProtocolStack. up(Message msg)
-
Uses of Message in org.jgroups.util
Fields in org.jgroups.util declared as Message Modifier and Type Field Description protected Message
SubmitToThreadPool.SingleLoopbackHandler. msg
protected Message
SubmitToThreadPool.SingleMessageHandler. msg
Fields in org.jgroups.util with type parameters of type Message Modifier and Type Field Description protected java.util.Map<Address,java.util.Queue<Message>>
MessageCache. map
protected FastArray<Message>
MessageBatch. messages
The storage of the messages; removed messages have a null elementprotected SizeBoundedQueue<Message>
NonBlockingCredit. msg_queue
protected SizeBoundedQueue<Message>
NonBlockingCreditMap. msg_queue
protected static java.util.function.Consumer<Message>
NonBlockingCredit. NO_OP_SEND_FUNCTION
protected static java.util.function.Consumer<Message>
NonBlockingCreditMap. NO_OP_SEND_FUNCTION
protected java.util.function.Predicate<Message>
Buffer.Options. remove_filter
protected java.util.function.Consumer<Message>
NonBlockingCredit. send_function
protected java.util.function.Consumer<Message>
NonBlockingCreditMap. send_function
Methods in org.jgroups.util with type parameters of type Message Modifier and Type Method Description <T extends Message>
TMessageBatch. first()
<T extends Message>
TMessageBatch. last()
Methods in org.jgroups.util that return Message Modifier and Type Method Description static Message
Util. copy(Message msg, boolean copy_buffer, short starting_id, short... copy_only_ids)
Copies a message.Message
SubmitToThreadPool.SingleMessageHandler. getMessage()
static Message
Util. messageFromBuffer(byte[] buf, int offset, int length, MessageFactory mf)
static Message
Util. messageFromByteBuffer(byte[] buffer, int offset, int length, MessageFactory mf)
static Message
Util. readMessage(java.io.DataInput in, MessageFactory mf)
Methods in org.jgroups.util that return types with arguments of type Message Modifier and Type Method Description FastArray<Message>
MessageBatch. array()
Returns the underlying message array.java.util.Collection<Message>
MessageCache. drain(Address sender)
java.util.Iterator<Message>
MessageBatch. iterator()
Iterator which iterates only over non-null messages, skipping null messagesjava.util.Iterator<Message>
MessageBatch. iterator(java.util.function.Predicate<Message> filter)
Iterates over all non-null message which match filterstatic java.util.List<Message>
Util. readMessageList(java.io.DataInput in, short transport_id, MessageFactory mf)
java.util.function.Predicate<Message>
Buffer.Options. remove_filter()
java.util.stream.Stream<Message>
MessageBatch. stream()
java.util.stream.Stream<Message>
MessageBatch. stream(java.util.function.Predicate<Message> p)
java.util.stream.Stream<Message>
MessageBatch. stream(java.util.function.Predicate<Message> p, boolean parallel)
Methods in org.jgroups.util with parameters of type Message Modifier and Type Method Description MessageBatch
MessageBatch. add(Message msg)
int
MessageBatch. add(Message[] msgs, int num_msgs)
Adds message to this batch from a message arrayint
MessageBatch. add(Message msg, boolean resize)
Adds a message to the tableMessageCache
MessageCache. add(Address sender, Message msg)
protected boolean
NonBlockingCredit. addToQueue(Message msg, int length)
protected boolean
NonBlockingCreditMap. addToQueue(Message msg, int length)
protected boolean
MaxOneThreadPerSender.Entry. allowedToSubmitToThreadPool(Message msg)
Either allows access to submit a task to the thread pool for delivery to the application, or queues the messagestatic Message
Util. copy(Message msg, boolean copy_buffer, short starting_id, short... copy_only_ids)
Copies a message.boolean
CreditMap. decrement(Message msg, int credits, long timeout)
Decrements credits bytes from all.boolean
NonBlockingCreditMap. decrement(Message msg, int credits, long timeout)
boolean
Credit. decrementIfEnoughCredits(Message msg, int credits, long timeout)
boolean
NonBlockingCredit. decrementIfEnoughCredits(Message msg, int credits, long timeout)
Decrements the sender's credits by the size of the message.protected MessageBatch
MessageBatch. determineMode(Message msg)
static java.lang.String
Util. getObject(Message msg)
Tries to return a legible representation of a message's payloadvoid
RTT. handleMessage(Message msg, TpHeader hdr)
Called when a message (request or response) is receivedboolean
MaxOneThreadPerSender. loopback(Message msg, boolean oob)
boolean
PassRegularMessagesUpDirectly. loopback(Message msg, boolean oob)
boolean
SubmitToThreadPool. loopback(Message msg, boolean oob)
static ByteArray
Util. messageToBuffer(Message msg)
static ByteArray
Util. messageToByteBuffer(Message msg)
protected boolean
MaxOneThreadPerSender.Entry. process(Message msg, boolean loopback)
protected boolean
MaxOneThreadPerSender.MessageTable. process(Message msg, boolean loopback)
boolean
MaxOneThreadPerSender. process(Message msg, boolean oob)
boolean
PassRegularMessagesUpDirectly. process(Message msg, boolean oob)
boolean
SubmitToThreadPool. process(Message msg, boolean oob)
void
MyReceiver. receive(Message msg)
MessageBatch
MessageBatch. set(Address dest, Address sender, Message[] msgs)
protected boolean
MaxOneThreadPerSender.Entry. submit(Message msg, boolean loopback)
static void
Util. writeMessage(Message msg, java.io.DataOutput dos, boolean multicast)
static void
Util. writeMessageList(Address dest, Address src, byte[] cluster_name, Message[] msgs, int offset, int length, java.io.DataOutput dos, boolean multicast)
Method parameters in org.jgroups.util with type arguments of type Message Modifier and Type Method Description int
MessageBatch. add(java.util.Collection<Message> msgs)
boolean
MessageBatch. anyMatch(java.util.function.Predicate<Message> pred)
static java.lang.String
Util. getObjects(java.lang.Iterable<Message> it)
java.util.Iterator<Message>
MessageBatch. iterator(java.util.function.Predicate<Message> filter)
Iterates over all non-null message which match filterstatic void
Util. parse(byte[] buf, int offset, int length, java.util.function.BiConsumer<java.lang.Short,Message> msg_consumer, java.util.function.BiConsumer<java.lang.Short,MessageBatch> batch_consumer, java.util.function.Consumer<GossipData> gossip_consumer, boolean tcp, boolean gossip)
static void
Util. parse(java.io.InputStream input, java.util.function.BiConsumer<java.lang.Short,Message> msg_consumer, java.util.function.BiConsumer<java.lang.Short,MessageBatch> batch_consumer, java.util.function.Consumer<GossipData> gossip_consumer, boolean tcp, boolean gossip)
Buffer.Options
Buffer.Options. removeFilter(java.util.function.Predicate<Message> f)
MessageBatch
MessageBatch. removeIf(java.util.function.Predicate<Message> filter, boolean match_all)
java.util.stream.Stream<Message>
MessageBatch. stream(java.util.function.Predicate<Message> p)
java.util.stream.Stream<Message>
MessageBatch. stream(java.util.function.Predicate<Message> p, boolean parallel)
static void
Util. writeMessageList(Address dest, Address src, byte[] cluster_name, java.util.List<Message> msgs, java.io.DataOutput dos, boolean multicast)
Write a list of messages with the *same* destination and src addresses.static void
Util. writeMessageList(Address dest, Address src, byte[] cluster_name, FastArray<Message> msgs, java.io.DataOutput dos, boolean multicast)
Constructors in org.jgroups.util with parameters of type Message Constructor Description SingleLoopbackHandler(Message msg)
SingleMessageHandler(Message msg)
SingleMessageHandlerWithClusterName(Message msg, byte[] cluster_name)
Constructor parameters in org.jgroups.util with type arguments of type Message Constructor Description MessageBatch(java.util.Collection<Message> msgs)
MessageBatch(Address dest, Address sender, AsciiString cluster_name, boolean multicast, java.util.Collection<Message> msgs)
NonBlockingCredit(long credits, int max_size, java.util.concurrent.locks.Lock lock, java.util.function.Consumer<Message> send_function)
NonBlockingCreditMap(long max_credits, int max_size, java.util.concurrent.locks.Lock lock, java.util.function.Consumer<Message> send_function)
-