Package | Description |
---|---|
org.jgroups |
Provides top-level public JGroups classes such as Channel, Message, etc.
|
org.jgroups.auth | |
org.jgroups.auth.sasl | |
org.jgroups.blocks |
Provides building blocks that are layered on top of channels.
|
org.jgroups.blocks.mux | |
org.jgroups.demos |
Provides demonstrations of JGroups functionality.
|
org.jgroups.demos.wb |
A distributed whiteboard applet implemented using JGroups.
|
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.pbcast |
Supports probabilistic broadcasts.
|
org.jgroups.protocols.relay | |
org.jgroups.protocols.tom | |
org.jgroups.stack |
Support for managing protocol stacks.
|
org.jgroups.util |
Provides useful functionality which cannot be assigned to any particular other package.
|
Modifier and Type | Method and Description |
---|---|
Message |
Message.clearFlag(Message.Flag... flags)
Clears a number of flags in a message
|
Message |
Message.clearTransientFlag(Message.TransientFlag... flags) |
Message |
Message.copy() |
Message |
Message.copy(boolean copy_buffer)
Create a copy of the message.
|
Message |
Message.copy(boolean copy_buffer,
boolean copy_headers)
Create a copy of the message.
|
Message |
Message.copy(boolean copy_buffer,
short starting_id)
Doesn't copy any headers except for those with ID >= copy_headers_above
|
Message |
Message.copy(boolean copy_buffer,
short starting_id,
short... copy_only_ids)
Copies a message.
|
Message |
Message.dest(Address new_dest) |
Message |
Message.makeReply() |
Message |
Message.putHeader(short id,
Header hdr)
Puts a header given an ID into the hashmap.
|
Message |
Message.putHeaderIfAbsent(short id,
Header hdr)
Puts a header given a key into the map, only if the key doesn't exist yet
|
Message |
Message.setBuffer(Buffer buf)
Note that the byte[] buffer passed as argument must not be modified.
|
Message |
Message.setBuffer(byte[] b)
Note that the byte[] buffer passed as argument must not be modified.
|
Message |
Message.setBuffer(byte[] b,
int offset,
int length)
Sets the internal buffer to point to a subset of a given buffer.
Note that the byte[] buffer passed as argument must not be modified.
|
Message |
Message.setFlag(Message.Flag... flags)
Sets a number of flags in a message
|
Message |
Message.setFlag(short flag)
Sets the flags from a short.
|
Message |
Message.setObject(java.lang.Object obj)
Takes an object and uses Java serialization to generate the byte[] buffer which is set in the
message.
|
Message |
Message.setScope(short scope) |
Message |
Message.setTransientFlag(Message.TransientFlag... flags)
Same as
setFlag(Flag...) except that transient flags are not marshalled |
Message |
Message.setTransientFlag(short flag) |
Message |
Message.src(Address new_src) |
Modifier and Type | Method and Description |
---|---|
void |
ReceiverAdapter.receive(Message msg)
Called when a message is received.
|
void |
MessageListener.receive(Message msg)
Called when a message is received.
|
void |
JChannel.send(Message msg) |
abstract void |
Channel.send(Message msg)
Sends a message.
|
Modifier and Type | Method and Description |
---|---|
boolean |
RegexMembership.authenticate(AuthToken token,
Message msg) |
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, too
|
boolean |
X509Token.authenticate(AuthToken token,
Message msg) |
boolean |
DemoToken.authenticate(AuthToken token,
Message msg) |
boolean |
Krb5Token.authenticate(AuthToken token,
Message msg) |
boolean |
SimpleToken.authenticate(AuthToken token,
Message msg) |
boolean |
MD5Token.authenticate(AuthToken token,
Message msg) |
Modifier and Type | Method and Description |
---|---|
Message |
SaslClientContext.addHeader(Message msg,
byte[] payload) |
Message |
SaslClientContext.nextMessage(Address address,
SaslHeader header) |
Message |
SaslServerContext.nextMessage(Address address,
SaslHeader header) |
Message |
SaslContext.nextMessage(Address address,
SaslHeader saslHeader) |
Modifier and Type | Method and Description |
---|---|
Message |
SaslClientContext.addHeader(Message msg,
byte[] payload) |
Modifier and Type | Field and Description |
---|---|
protected Message |
RequestCorrelator.ResponseImpl.req |
Modifier and Type | Method and Description |
---|---|
protected <T> GroupRequest<T> |
MessageDispatcher.cast(java.util.Collection<Address> dests,
Message msg,
RequestOptions options,
boolean block_for_results) |
protected <T> GroupRequest<T> |
MessageDispatcher.cast(java.util.Collection<Address> dests,
Message msg,
RequestOptions options,
boolean block_for_results,
FutureListener<RspList<T>> listener) |
<T> RspList<T> |
MessageDispatcher.castMessage(java.util.Collection<Address> dests,
Message msg,
RequestOptions options)
Sends a message to all members and expects responses from members in dests (if non-null).
|
<T> NotifyingFuture<RspList<T>> |
MessageDispatcher.castMessageWithFuture(java.util.Collection<Address> dests,
Message msg,
RequestOptions options)
Sends a message to all members and expects responses from members in dests (if non-null).
|
<T> NotifyingFuture<RspList<T>> |
MessageDispatcher.castMessageWithFuture(java.util.Collection<Address> dests,
Message msg,
RequestOptions options,
FutureListener<RspList<T>> listener)
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) |
boolean |
Request.execute(Message req,
boolean block_for_results) |
java.lang.Object |
RequestHandler.handle(Message msg) |
java.lang.Object |
MessageDispatcher.handle(Message msg) |
java.lang.Object |
RpcDispatcher.handle(Message req)
Message contains MethodCall.
|
void |
MessageDispatcher.handle(Message request,
Response response) |
void |
AsyncRequestHandler.handle(Message request,
Response response)
Invokes a request.
|
protected void |
RequestCorrelator.handleRequest(Message req,
RequestCorrelator.Header hdr)
Handle a request msg for this correlator
|
protected void |
RequestCorrelator.prepareResponse(Message rsp) |
void |
ReplicatedHashMap.receive(Message msg) |
void |
ReplicatedTree.receive(Message msg)
Callback.
|
boolean |
RequestCorrelator.receiveMessage(Message msg)
Handles a message coming from a layer below
|
void |
RequestCorrelator.ResponseImpl.send(Message reply,
boolean is_exception) |
void |
Response.send(Message reply,
boolean is_exception)
Similar to
Response.send(Object,boolean) , but passes a message instead of an object. |
<T> T |
MessageDispatcher.sendMessage(Message msg,
RequestOptions opts)
Sends a unicast message and - depending on the options - returns a result
|
<T> NotifyingFuture<T> |
MessageDispatcher.sendMessageWithFuture(Message msg,
RequestOptions options)
Sends a unicast message to the target defined by msg.getDest() and returns a future
|
<T> NotifyingFuture<T> |
MessageDispatcher.sendMessageWithFuture(Message msg,
RequestOptions options,
FutureListener<T> listener)
Sends a unicast message to the target defined by msg.getDest() and returns a future
|
protected void |
RequestCorrelator.sendReply(Message req,
long req_id,
java.lang.Object reply,
boolean is_exception) |
void |
RequestCorrelator.sendRequest(java.util.Collection<Address> dest_mbrs,
Message msg,
Request req,
RequestOptions options)
Sends a request to a group.
|
void |
RequestCorrelator.sendRequest(java.util.List<Address> dest_mbrs,
Message msg,
Request req) |
protected abstract void |
Request.sendRequest(Message request_msg) |
protected void |
UnicastRequest.sendRequest(Message request_msg) |
void |
GroupRequest.sendRequest(Message req) |
protected void |
RequestCorrelator.sendResponse(Message rsp,
long req_id,
boolean is_exception) |
void |
RequestCorrelator.sendUnicastRequest(Address target,
Message msg,
Request req)
Sends a request to a single destination
|
Constructor and Description |
---|
ResponseImpl(Message req,
long req_id) |
Modifier and Type | Method and Description |
---|---|
protected <T> GroupRequest<T> |
MuxMessageDispatcher.cast(java.util.Collection<Address> dests,
Message msg,
RequestOptions options,
boolean blockForResults,
FutureListener<RspList<T>> listener) |
protected <T> GroupRequest<T> |
MuxRpcDispatcher.cast(java.util.Collection<Address> dests,
Message msg,
RequestOptions options,
boolean blockForResults,
FutureListener<RspList<T>> listener) |
protected void |
MuxRequestCorrelator.prepareResponse(Message rsp) |
void |
MuxRequestCorrelator.sendRequest(java.util.Collection<Address> dest_mbrs,
Message msg,
Request req,
RequestOptions options) |
void |
MuxRequestCorrelator.sendUnicastRequest(Address target,
Message msg,
Request req) |
Modifier and Type | Method and Description |
---|---|
void |
Draw.receive(Message msg) |
void |
Chat.receive(Message msg) |
Modifier and Type | Method and Description |
---|---|
void |
Whiteboard.receive(Message m) |
Modifier and Type | Method and Description |
---|---|
java.lang.Object |
UnknownForkHandler.handleUnknownForkChannel(Message message,
java.lang.String forkChannelId)
Handle a message that refers to an unknown fork channel
|
java.lang.Object |
UnknownForkHandler.handleUnknownForkStack(Message message,
java.lang.String forkStackId)
Handle a message that refers to an unknown fork stack
|
void |
ForkChannel.send(Message msg) |
protected void |
ForkChannel.setHeader(Message msg) |
Modifier and Type | Field and Description |
---|---|
protected Message[] |
RingBufferBundlerLockless2.buf |
protected Message[] |
RingBufferBundlerLockless.buf |
protected static Message |
UNICAST3.DUMMY_OOB_MSG |
protected Message |
TP.SingleMessageHandler.msg |
protected Message[] |
SimplifiedTransferQueueBundler.msg_queue |
static Message |
RingBufferBundlerLockless2.NULL_MSG |
Modifier and Type | Field and Description |
---|---|
protected static Filter<Message> |
UNICAST3.dont_loopback_filter |
protected static Filter<Message> |
UNICAST2.dont_loopback_filter
Deprecated.
|
protected java.util.List<Message> |
SHUFFLE.down_msgs |
protected Filter<Message> |
UNICAST3.drop_oob_and_dont_loopback_msgs_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.Map<Address,Message> |
BARRIER.mcast_queue |
protected Table<Message> |
UNICAST3.Entry.msgs |
protected java.util.Map<SingletonAddress,java.util.List<Message>> |
BaseBundler.msgs
Keys are destinations, values are lists of Messages
|
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.concurrent.BlockingQueue<Message> |
TransferQueueBundler.queue |
protected RingBuffer<Message> |
RingBufferBundler.rb |
protected Table<Message> |
UNICAST.ReceiverEntry.received_msgs |
protected Table<Message> |
SEQUENCER2.received_msgs |
protected Table<Message> |
UNICAST2.ReceiverEntry.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 java.util.List<Message> |
TransferQueueBundler.remove_queue |
protected java.util.concurrent.BlockingQueue<Message> |
ABP.Entry.send_queue |
protected java.util.Map<Address,Message> |
BARRIER.ucast_queue |
protected java.util.List<Message> |
SHUFFLE.up_msgs |
protected java.util.concurrent.BlockingQueue<Message> |
ASYM_ENCRYPT.up_queue |
Modifier and Type | Method and Description |
---|---|
protected Message |
EncryptBase._decrypt(javax.crypto.Cipher cipher,
Message msg,
EncryptHeader hdr) |
protected Message |
FRAG2.FragEntry.assembleMessage()
Assembles all the fragments into one buffer.
|
protected Message |
EncryptBase.decryptMessage(javax.crypto.Cipher cipher,
Message msg)
Does the actual work for decrypting - if version does not match current cipher then tries the previous cipher
|
protected Message |
UNICAST2.SenderEntry.getFirstMessage() |
static Message |
TP.readMessage(java.io.DataInput instream) |
Message |
SCOPE.MessageQueue.remove() |
protected Message |
COMPRESS.uncompress(Message msg,
int original_size)
Returns a new message as a result of uncompressing msg, or null if msg couldn't be uncompressed
|
protected Message |
FRAG2.unfragment(Message msg,
FragHeader hdr)
1.
|
Message |
ENCRYPT.Decrypter.visit(Message msg,
MessageBatch batch) |
Message |
EncryptBase.Decrypter.visit(Message msg,
MessageBatch batch) |
Modifier and Type | Method and Description |
---|---|
RingBuffer<Message> |
RingBufferBundler.buf() |
static java.util.List<Message> |
TP.readMessageList(java.io.DataInput in,
short transport_id) |
Modifier and Type | Method and Description |
---|---|
protected Message |
EncryptBase._decrypt(javax.crypto.Cipher cipher,
Message msg,
EncryptHeader hdr) |
protected void |
TP._send(Message msg,
Address dest) |
void |
SCOPE.MessageQueue.add(Message msg) |
protected void |
SimplifiedTransferQueueBundler.addMessage(Message msg,
long size) |
protected void |
BaseBundler.addMessage(Message msg,
long size) |
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 |
EncryptBase.decryptMessage(javax.crypto.Cipher cipher,
Message msg)
Does the actual work for decrypting - if version does not match current cipher then tries the previous cipher
|
protected void |
SEQUENCER.deliver(Message msg,
Event evt,
SEQUENCER.SequencerHeader hdr) |
protected void |
SEQUENCER2.deliver(Message msg,
Event evt,
SEQUENCER2.SequencerHeader hdr) |
protected void |
EncryptBase.encryptAndSend(Message msg) |
protected boolean |
ASYM_ENCRYPT.enqueue(Message msg) |
protected void |
SEQUENCER.forward(Message msg,
long seqno,
boolean flush) |
protected void |
SEQUENCER.forwardToCoord(long seqno,
Message msg) |
protected void |
RELAY.forwardToCoord(Message msg)
Wraps the message annd sends it to the current coordinator
|
protected void |
FRAG2.fragment(Message msg)
Send all fragments as separate messages (with same ID !).
|
protected AsciiString |
TP.getClusterName(Message msg) |
protected Address |
ASYM_ENCRYPT.getCoordinator(Message msg,
GMS.GmsHeader hdr)
Tries to find out if this is a JOIN_RSP or INSTALL_MERGE_VIEW message and returns the coordinator of the view
|
protected static GMS.GmsHeader |
AUTH.getGMSHeader(Message msg) |
protected boolean |
AUTH.handleAuthHeader(GMS.GmsHeader gms_hdr,
AuthHeader auth_hdr,
Message msg)
Handles a GMS header
|
protected void |
UNICAST.handleDataReceived(Address sender,
long seqno,
short conn_id,
boolean first,
Message msg,
Event evt)
Deprecated.
Check whether the hashtable contains an entry e for
sender (create if not). |
protected void |
UNICAST3.handleDataReceived(Address sender,
long seqno,
short conn_id,
boolean first,
Message msg,
Event evt)
Check whether the hashtable contains an entry e for
sender (create if not). |
protected boolean |
UNICAST2.handleDataReceived(Address sender,
long seqno,
short conn_id,
boolean first,
Message msg,
Event evt)
Deprecated.
Check whether the hashmap contains an entry e for
sender (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 java.lang.Object |
MFC.handleDownMessage(Event evt,
Message msg,
Address dest,
int length) |
protected abstract java.lang.Object |
FlowControl.handleDownMessage(Event evt,
Message msg,
Address dest,
int length) |
protected java.lang.Object |
UFC.handleDownMessage(Event evt,
Message msg,
Address dest,
int length) |
protected java.lang.Object |
EncryptBase.handleEncryptedMessage(Message msg) |
protected java.lang.Object |
ENCRYPT.handleEncryptedMessage(Message msg,
Event evt,
ENCRYPT.EncryptHeader hdr)
Deprecated.
|
protected void |
ASYM_ENCRYPT.handleSecretKeyRequest(Message msg) |
protected void |
ASYM_ENCRYPT.handleSecretKeyResponse(Message msg,
byte[] key_version) |
protected void |
UNICAST3.handleUpEvent(Address sender,
Message msg,
UNICAST3.Header hdr) |
protected void |
FC.handleUpEvent(FcHeader hdr,
Message msg)
Deprecated.
|
protected void |
ENCRYPT.handleUpEvent(Message msg,
ENCRYPT.EncryptHeader hdr)
Deprecated.
|
protected java.lang.Object |
ASYM_ENCRYPT.handleUpEvent(Message msg,
EncryptHeader hdr) |
protected java.lang.Object |
EncryptBase.handleUpEvent(Message msg,
EncryptHeader hdr) |
protected void |
FlowControl.handleUpEvent(Message msg,
FcHeader hdr) |
protected java.lang.Object |
RELAY.handleUpEvent(Message msg,
RELAY.RelayHeader hdr) |
protected java.lang.Object |
EncryptBase.handleUpMessage(Message msg) |
protected void |
TP.loopback(Message msg,
boolean multicast) |
protected int |
RingBufferBundlerLockless2.marshalMessagesToSameDestination(Address dest,
Message[] buf,
int start_index,
int end_index,
int max_bundle_size) |
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 static int |
SIZE.numHeaders(Message msg) |
protected void |
TP.passMessageUp(Message msg,
AsciiString cluster_name,
boolean perform_cluster_name_matching,
boolean multicast,
boolean discard_own_mcast) |
protected boolean |
ASYM_ENCRYPT.process(Message msg) |
protected boolean |
EncryptBase.process(Message msg)
Whether or not to process this received message
|
protected void |
MAKE_BATCH.queue(Message msg) |
protected void |
ENCRYPT.Decrypter.queueUpMessage(Message msg,
MessageBatch batch) |
void |
RELAY.Receiver.receive(Message msg) |
void |
UNICAST.retransmit(Message msg)
Deprecated.
Called by AckSenderWindow to resend messages for which no ACK has been received yet
|
protected void |
UNICAST3.retransmit(Message msg)
Called by the sender to resend messages for which no ACK has been received yet
|
void |
RingBufferBundlerLockless2.send(Message msg) |
void |
SenderSendsBundler.send(Message msg) |
void |
RingBufferBundler.send(Message msg) |
protected void |
ABP.Entry.send(Message msg) |
void |
SenderSendsWithTimerBundler.send(Message msg)
Deprecated.
|
void |
Bundler.send(Message msg) |
void |
TransferQueueBundler.send(Message msg) |
void |
RingBufferBundlerLockless.send(Message msg) |
void |
BaseBundler.send(Message msg) |
void |
NoBundler.send(Message msg) |
protected void |
TUNNEL.send(Message msg,
Address dest) |
protected void |
TP.send(Message msg,
Address dest)
Serializes and sends a message.
|
protected int |
RingBufferBundlerLockless2.sendBundledMessages(Message[] buf,
int read_index,
int write_index)
Read and send messages in range [read-index+1 ..
|
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 void |
MPING.sendMcastDiscoveryRequest(Message msg) |
protected void |
PING.sendMcastDiscoveryRequest(Message msg) |
protected void |
BPING.sendMcastDiscoveryRequest(Message msg) |
protected void |
BaseBundler.sendSingleMessage(Message msg) |
protected void |
SimplifiedTransferQueueBundler.sendSingleMessage(Message msg,
ByteArrayDataOutputStream output) |
protected void |
NoBundler.sendSingleMessage(Message msg,
ByteArrayDataOutputStream output) |
protected boolean |
SASL.serverChallenge(GMS.GmsHeader gmsHeader,
SaslHeader saslHeader,
Message msg) |
void |
FRAG2.FragEntry.set(int frag_id,
Message frag)
adds on fragmentation buffer to the message
|
protected 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 not
|
protected static boolean |
ASYM_ENCRYPT.skip(Message msg)
Checks if a message needs to be encrypted/decrypted.
|
protected Message |
COMPRESS.uncompress(Message msg,
int original_size)
Returns a new message as a result of uncompressing msg, or null if msg couldn't be uncompressed
|
protected Message |
FRAG2.unfragment(Message msg,
FragHeader 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)
|
Message |
ENCRYPT.Decrypter.visit(Message msg,
MessageBatch batch) |
Message |
EncryptBase.Decrypter.visit(Message msg,
MessageBatch batch) |
protected static void |
TP.writeMessage(Message msg,
java.io.DataOutput dos,
boolean multicast)
This method needs to be synchronized on out_stream when it is called
|
Modifier and Type | Method and Description |
---|---|
protected void |
BARRIER.flushQueue(java.util.Map<Address,Message> queue) |
protected void |
UNICAST.handleBatchReceived(Address sender,
java.util.Map<java.lang.Short,java.util.List<Message>> map)
Deprecated.
|
protected void |
UNICAST2.handleBatchReceived(Address sender,
java.util.Map<java.lang.Short,java.util.List<Message>> map)
Deprecated.
|
protected void |
UNICAST3.handleBatchReceived(UNICAST3.ReceiverEntry entry,
Address sender,
java.util.List<Tuple<java.lang.Long,Message>> msgs,
boolean oob) |
protected java.lang.String |
UNICAST.printMessageList(java.util.List<Message> list)
Deprecated.
|
protected java.lang.String |
UNICAST2.printMessageList(java.util.List<Message> list)
Deprecated.
|
protected java.lang.String |
UNICAST3.printMessageList(java.util.List<Tuple<java.lang.Long,Message>> list) |
protected void |
UNICAST3.processInternalMessage(Table<Message> win,
Address sender) |
protected int |
UNICAST.removeAndDeliver(java.util.concurrent.atomic.AtomicBoolean processing,
Table<Message> win,
Address sender)
Deprecated.
Try to remove as many messages as possible from the table as pass them up.
|
protected void |
SEQUENCER2.removeAndDeliver(java.util.concurrent.atomic.AtomicBoolean processing,
Table<Message> win,
Address sender) |
protected void |
UNICAST3.removeAndDeliver(java.util.concurrent.atomic.AtomicBoolean processing,
Table<Message> win,
Address sender)
Try to remove as many messages as possible from the table as pass them up.
|
protected void |
UNICAST2.removeAndPassUp(Table<Message> win,
Address sender)
Deprecated.
Try to remove as many messages as possible and pass them up.
|
protected void |
BaseBundler.sendMessageList(Address dest,
Address src,
byte[] cluster_name,
java.util.List<Message> list) |
static void |
TP.writeMessageList(Address dest,
Address src,
byte[] cluster_name,
java.util.List<Message> msgs,
java.io.DataOutput dos,
boolean multicast,
short transport_id)
Write a list of messages with the *same* destination and src addresses.
|
Constructor and Description |
---|
SingleMessageHandler(Message msg) |
SingleMessageHandlerWithClusterName(Message msg,
AsciiString cluster_name) |
Constructor and Description |
---|
Entry(short conn_id,
Table<Message> msgs) |
ReceiverEntry(Table<Message> received_msgs,
short recv_conn_id) |
ReceiverEntry(Table<Message> received_msgs,
short recv_conn_id) |
ReceiverEntry(Table<Message> received_msgs,
short recv_conn_id) |
RingBufferBundler(RingBuffer<Message> rb) |
TransferQueueBundler(java.util.concurrent.BlockingQueue<Message> queue) |
Modifier and Type | Field and Description |
---|---|
protected static Message |
NAKACK2.DUMMY_OOB_MSG |
Modifier and Type | Field and Description |
---|---|
protected BoundedList<Message> |
NAKACK.become_server_queue
Deprecated.
|
protected BoundedList<Message> |
NAKACK2.become_server_queue |
protected static Filter<Message> |
NAKACK2.dont_loopback_filter |
protected Filter<Message> |
NAKACK2.no_dummy_and_no_oob_delivered_msgs_and_no_dont_loopback_msgs |
protected java.util.concurrent.ConcurrentMap<Address,Table<Message>> |
NAKACK2.xmit_table
Map to store sent and received messages (keyed by sender)
|
Modifier and Type | Method and Description |
---|---|
protected Message |
NAKACK2.msgFromXmitRsp(Message msg,
NakAckHeader2 hdr) |
Modifier and Type | Method and 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.
|
Modifier and Type | Method and Description |
---|---|
protected void |
NAKACK2.deliver(Message msg,
Address sender,
long seqno,
java.lang.String error_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 |
NAKACK.send(Event evt,
Message msg)
Deprecated.
Adds the message to the sent_msgs table and then passes it down the stack.
|
protected void |
NAKACK2.send(Event evt,
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.
|
boolean |
NAKACK2.Counter.visit(long seqno,
Message element,
int row,
int column) |
Modifier and Type | Method and Description |
---|---|
protected void |
NAKACK2.handleMessages(Address dest,
Address sender,
java.util.List<Tuple<java.lang.Long,Message>> msgs,
boolean oob,
AsciiString cluster_name) |
protected void |
NAKACK2.removeAndPassUp(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) |
Modifier and Type | Method and Description |
---|---|
protected Message |
RELAY2.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) |
Modifier and Type | Method and Description |
---|---|
protected Message |
RELAY2.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) |
protected void |
RELAY2.deliver(Address dest,
Address sender,
Message msg) |
protected void |
RELAY2.deliverLocally(SiteAddress dest,
SiteAddress sender,
Message msg) |
protected void |
RELAY2.forwardTo(Address next_dest,
SiteAddress final_dest,
Address original_sender,
Message msg,
boolean forward_to_current_coord) |
protected void |
RELAY2.handleMessage(RELAY2.Relay2Header hdr,
Message msg)
Called to handle a message received by the transport
|
protected void |
RELAY2.handleRelayMessage(RELAY2.Relay2Header hdr,
Message msg)
Called to handle a message received by the relayer
|
void |
Relayer.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)
|
void |
Route.send(Address final_destination,
Address original_sender,
Message msg) |
protected void |
RELAY2.sendToBridges(Address sender,
Message msg,
java.lang.String... excluded_sites)
Sends the message via all bridges excluding the excluded_sites bridges
|
Modifier and Type | Method and Description |
---|---|
java.util.List<Message> |
DeliveryManager.getNextMessagesToDeliver()
returns an ordered list with the messages to be deliver.
|
java.util.List<Message> |
DeliveryManagerImpl.getNextMessagesToDeliver() |
Modifier and Type | Method and Description |
---|---|
long |
DeliveryManagerImpl.addLocalMessageToDeliver(MessageID messageID,
Message message,
ToaHeader header) |
long |
DeliveryManagerImpl.addRemoteMessageToDeliver(MessageID messageID,
Message message,
long remoteSequenceNumber) |
void |
DeliveryProtocol.deliver(Message message)
deliver a message
|
void |
TOA.deliver(Message message) |
void |
DeliveryManagerImpl.deliverSingleDestinationMessage(Message msg,
MessageID messageID)
delivers a message that has only as destination member this node
|
Modifier and Type | Method and Description |
---|---|
Message |
NakReceiverWindow.get(long seqno)
Deprecated.
Returns the message from xmit_table
|
Message |
NakReceiverWindow.remove()
Deprecated.
|
Message |
NakReceiverWindow.remove(boolean acquire_lock,
boolean remove_msg)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
java.util.List<Message> |
NakReceiverWindow.get(long from,
long to)
Deprecated.
Returns a list of messages in the range [from ..
|
java.util.List<Message> |
NakReceiverWindow.removeMany(java.util.concurrent.atomic.AtomicBoolean processing)
Deprecated.
Removes as many messages as possible
|
java.util.List<Message> |
NakReceiverWindow.removeMany(java.util.concurrent.atomic.AtomicBoolean processing,
boolean remove_msgs,
int max_results)
Deprecated.
Removes as many messages as possible
|
Modifier and Type | Method and Description |
---|---|
protected boolean |
Protocol.accept(Message msg)
Called by the default implementation of
Protocol.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. |
boolean |
NakReceiverWindow.add(long seqno,
Message msg)
Deprecated.
Adds a message according to its seqno (sequence number).
|
Modifier and Type | Field and Description |
---|---|
protected Message[][] |
RetransmitTable.matrix
Deprecated.
|
protected Message[] |
MessageBatch.messages
The storage of the messages; removed messages have a null element
|
Modifier and Type | Field and Description |
---|---|
protected java.util.NavigableMap<java.lang.Long,Message> |
ForwardQueue.forward_table
Maintains messages forwarded to the target which which no ack has been received yet.
|
Modifier and Type | Method and Description |
---|---|
Message[] |
MessageBatch.array()
Returns the underlying message array.
|
static Message |
Util.byteBufferToMessage(byte[] buffer,
int offset,
int length) |
Message |
MessageBatch.first() |
Message |
RetransmitTable.get(long seqno)
Deprecated.
|
protected Message[] |
RetransmitTable.getRow(int index)
Deprecated.
Returns a row.
|
Message |
MessageBatch.last() |
Message |
MessageBatch.BatchIterator.next() |
Message |
RetransmitTable.putIfAbsent(long seqno,
Message msg)
Deprecated.
Adds a message if the element at the given index is null.
|
static Message |
Util.readMessage(java.io.DataInput instream) |
Message |
RetransmitTable.remove(long seqno)
Deprecated.
Removes the message with seqno from the table, nulls the index
|
Modifier and Type | Method and Description |
---|---|
java.util.List<Message> |
RetransmitTable.get(long from,
long to)
Deprecated.
|
java.util.Collection<Message> |
MessageBatch.getMatchingMessages(short id,
boolean remove)
Removes and returns all messages which have a header with ID == id
|
java.util.Iterator<Message> |
MessageBatch.iterator()
Iterator which iterates only over non-null messages, skipping null messages
|
static java.util.List<Message> |
Util.readMessageList(java.io.DataInput in,
short transport_id) |
Modifier and Type | Method and Description |
---|---|
MessageBatch |
MessageBatch.add(Message msg) |
static short |
Util.getScope(Message msg) |
static Buffer |
Util.messageToByteBuffer(Message msg) |
boolean |
RetransmitTable.put(long seqno,
Message msg)
Deprecated.
Adds a new message to the index computed as a function of seqno
|
Message |
RetransmitTable.putIfAbsent(long seqno,
Message msg)
Deprecated.
Adds a message if the element at the given index is null.
|
void |
ForwardQueue.receive(long id,
Message msg) |
void |
MyReceiver.receive(Message msg) |
MessageBatch |
MessageBatch.remove(Message msg)
Removes the current message (found by indentity (==)) by nulling it in the message array
|
MessageBatch |
MessageBatch.replace(Filter<Message> filter,
Message replacement,
boolean match_all)
Replaces all messages which match a given filter with a replacement message
|
MessageBatch |
MessageBatch.replace(Message existing_msg,
Message new_msg)
Replaces a message in the batch with another one
|
void |
ForwardQueue.send(long id,
Message msg) |
static void |
Util.setScope(Message msg,
short scope) |
T |
MessageBatch.Visitor.visit(Message msg,
MessageBatch batch)
Called when iterating over the message batch
|
static void |
Util.writeMessage(Message msg,
java.io.DataOutput dos,
boolean multicast)
This method needs to be synchronized on out_stream when it is called
|
Modifier and Type | Method and Description |
---|---|
MessageBatch |
MessageBatch.remove(Filter<Message> filter)
Removes all messages which match filter
|
MessageBatch |
MessageBatch.replace(Filter<Message> filter,
Message replacement,
boolean match_all)
Replaces all messages which match a given filter with a replacement message
|
static void |
Util.writeMessageList(Address dest,
Address src,
byte[] cluster_name,
java.util.List<Message> msgs,
java.io.DataOutput dos,
boolean multicast,
short transport_id)
Write a list of messages with the *same* destination and src addresses.
|
Constructor and Description |
---|
MessageBatch(Address dest,
Address sender,
AsciiString cluster_name,
boolean multicast,
java.util.Collection<Message> msgs) |
MessageBatch(Address dest,
Address sender,
AsciiString cluster_name,
boolean multicast,
java.util.Collection<Message> msgs,
Filter<Message> filter) |
MessageBatch(Address dest,
Address sender,
AsciiString cluster_name,
boolean multicast,
java.util.Collection<Message> msgs,
Filter<Message> filter) |
MessageBatch(java.util.Collection<Message> msgs) |
Copyright © 1998-2020 Red Hat. All Rights Reserved.