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.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 |
Supports probabilistic broadcasts.
|
org.jgroups.protocols.relay | |
org.jgroups.protocols.rules | |
org.jgroups.protocols.tom | |
org.jgroups.stack |
Support for managing protocol stacks.
|
org.jgroups.tests | |
org.jgroups.tests.perf | |
org.jgroups.tests.rt.transports | |
org.jgroups.util |
Provides useful functionality which cannot be assigned to any particular other package.
|
Modifier and Type | Method and Description |
---|---|
Message |
Message.buffer(Buffer b) |
Message |
Message.buffer(byte[] b) |
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.setBuffer(Buffer buf)
Sets the buffer
Note that the byte[] buffer passed as argument must not be modified.
|
Message |
Message.setBuffer(byte[] b)
Sets the buffer.
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.setDest(Address new_dest) |
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(Object obj)
Takes an object and uses Java serialization to generate the byte[] buffer which is set in the
message.
|
Message |
Message.setSrc(Address new_src) |
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 |
---|---|
Supplier<? extends Message> |
Message.create() |
Modifier and Type | Method and Description |
---|---|
Object |
JChannel.down(Message msg) |
void |
ReceiverAdapter.receive(Message msg) |
void |
MessageListener.receive(Message msg)
Called when a message is received.
|
void |
Channel.send(Message msg)
Deprecated.
Sends a message.
|
JChannel |
JChannel.send(Message msg)
Sends a message.
|
Object |
JChannel.up(Message msg) |
Object |
UpHandler.up(Message msg) |
Modifier and Type | Field and Description |
---|---|
protected static BiPredicate<Message,Boolean> |
ChallengeResponseToken.BYPASSER_FUNCTION |
Modifier and Type | Method and Description |
---|---|
boolean |
MD5Token.authenticate(AuthToken token,
Message msg) |
boolean |
ChallengeResponseToken.authenticate(AuthToken token,
Message msg) |
boolean |
X509Token.authenticate(AuthToken token,
Message msg) |
boolean |
SimpleToken.authenticate(AuthToken token,
Message msg) |
boolean |
FixedMembershipToken.authenticate(AuthToken token,
Message msg)
Check if I'm in memberList, too
|
boolean |
RegexMembership.authenticate(AuthToken token,
Message msg) |
boolean |
Krb5Token.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 |
ChallengeResponseToken.handleUpMessage(Message msg) |
Modifier and Type | Method and Description |
---|---|
Message |
SaslClientContext.addHeader(Message msg,
byte[] payload) |
Message |
SaslContext.nextMessage(Address address,
SaslHeader saslHeader) |
Message |
SaslClientContext.nextMessage(Address address,
SaslHeader header) |
Message |
SaslServerContext.nextMessage(Address address,
SaslHeader header) |
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 void |
RequestCorrelator.dispatch(Message msg,
RequestCorrelator.Header hdr) |
Object |
RequestHandler.handle(Message msg)
Processes a request synchronously, ie.
|
Object |
MessageDispatcher.handle(Message msg) |
Object |
RpcDispatcher.handle(Message req)
Message contains MethodCall.
|
default void |
RequestHandler.handle(Message request,
Response response)
Processes a request asynchronously.
|
void |
MessageDispatcher.handle(Message request,
Response response) |
protected void |
RequestCorrelator.handleRequest(Message req,
RequestCorrelator.Header hdr)
Handle a request msg for this correlator
|
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. |
protected void |
RequestCorrelator.sendReply(Message req,
long req_id,
Object reply,
boolean is_exception) |
protected void |
RequestCorrelator.sendResponse(Message rsp,
long req_id,
boolean is_exception) |
Constructor and Description |
---|
ResponseImpl(Message req,
long req_id) |
Modifier and Type | Method and Description |
---|---|
void |
Chat.receive(Message msg) |
void |
Draw.receive(Message msg) |
Modifier and Type | Method and Description |
---|---|
Object |
ForkProtocolStack.down(Message msg) |
Object |
ForkProtocol.down(Message msg) |
Object |
ForkChannel.down(Message msg) |
Object |
UnknownForkHandler.handleUnknownForkChannel(Message message,
String forkChannelId)
Handle a message that refers to an unknown fork channel
|
Object |
UnknownForkHandler.handleUnknownForkStack(Message message,
String forkStackId)
Handle a message that refers to an unknown fork stack
|
ForkChannel |
ForkChannel.send(Message msg) |
protected void |
ForkChannel.setHeader(Message msg) |
Object |
ForkProtocolStack.up(Message msg) |
Modifier and Type | Field and Description |
---|---|
protected Message[] |
RingBufferBundlerLockless.buf |
protected Message[] |
RingBufferBundlerLockless2.buf |
protected static Message |
UNICAST3.DUMMY_OOB_MSG |
protected Message |
FRAG3.FragEntry.msg |
protected Message[] |
SimplifiedTransferQueueBundler.msg_queue |
static Message |
RingBufferBundlerLockless2.NULL_MSG |
protected Message[] |
RemoveQueueBundler.remove_queue |
Modifier and Type | Field and Description |
---|---|
protected static BiConsumer<MessageBatch,Message> |
UNICAST3.BATCH_ACCUMULATOR |
protected static BiConsumer<MessageBatch,Message> |
SEQUENCER2.BATCH_ACCUMULATOR |
protected List<BiPredicate<Message,Boolean>> |
ASYM_ENCRYPT.bypassers |
protected static Predicate<Message> |
UNICAST3.dont_loopback_filter |
protected List<Predicate<Message>> |
DROP.down_filters |
protected List<Message> |
SHUFFLE.down_msgs |
protected Predicate<Message> |
UNICAST3.drop_oob_and_dont_loopback_msgs_filter |
protected NavigableMap<Long,Message> |
SEQUENCER.forward_table
Maintains messages forwarded to the coord which which no ack has been received yet.
|
protected BlockingQueue<Message> |
SEQUENCER2.fwd_queue |
protected Predicate<Message> |
FD_ALL2.HAS_HEADER |
protected Predicate<Message> |
FD_ALL.HAS_HEADER |
protected Map<Address,Message> |
BARRIER.mcast_queue |
protected Table<Message> |
UNICAST3.Entry.msgs |
protected Map<Address,List<Message>> |
BaseBundler.msgs
Keys are destinations, values are lists of Messages
|
protected Map<Address,List<Message>> |
MAKE_BATCH.oob_map_mcast |
protected Map<Address,List<Message>> |
MAKE_BATCH.oob_map_ucast |
protected BlockingQueue<Message> |
TransferQueueBundler.queue |
protected RingBuffer<Message> |
RemoveQueueBundler.rb |
protected RingBuffer<Message> |
RingBufferBundler.rb |
protected Table<Message> |
SEQUENCER2.received_msgs |
protected Map<Address,List<Message>> |
MAKE_BATCH.reg_map_mcast |
protected Map<Address,List<Message>> |
MAKE_BATCH.reg_map_ucast |
protected List<Message> |
TransferQueueBundler.remove_queue |
protected Consumer<Message> |
MFC_NB.send_function |
protected Consumer<Message> |
UFC_NB.send_function |
protected BlockingQueue<Message> |
ABP.Entry.send_queue |
protected List<Message> |
AlternatingBundler.target_list |
protected Map<Address,Message> |
BARRIER.ucast_queue |
protected List<Predicate<Message>> |
DROP.up_filters |
protected List<Message> |
SHUFFLE.up_msgs |
protected BlockingQueue<Message> |
ASYM_ENCRYPT.up_queue |
Modifier and Type | Method and Description |
---|---|
protected Message |
Encrypt._decrypt(Cipher cipher,
Message msg,
EncryptHeader hdr) |
protected Message |
FRAG3.FragEntry.assembleMessage()
Assembles all the fragments into one buffer.
|
protected Message |
FRAG2.FragEntry.assembleMessage()
Assembles all the fragments into one buffer.
|
protected Message |
Encrypt.decryptMessage(Cipher cipher,
Message msg)
Does the actual work for decrypting - if version does not match current cipher then tries the previous cipher
|
Message |
FRAG3.FragEntry.set(Message frag_msg,
Frag3Header hdr)
Adds a fragment to the full message
|
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 |
FRAG3.unfragment(Message msg,
Frag3Header hdr)
1.
|
protected Message |
FRAG2.unfragment(Message msg,
FragHeader hdr)
1.
|
Modifier and Type | Method and Description |
---|---|
RingBuffer<Message> |
RingBufferBundler.buf() |
Modifier and Type | Method and Description |
---|---|
protected void |
TransferQueueBundler._addMessage(Message msg,
long size) |
protected void |
AlternatingBundler._addMessage(Message msg,
long size) |
protected Message |
Encrypt._decrypt(Cipher cipher,
Message msg,
EncryptHeader hdr) |
protected Object |
SimpleTCP._down(Message msg) |
protected void |
TP._send(Message msg,
Address dest) |
void |
Encrypt.Decrypter.accept(Message msg,
MessageBatch batch) |
protected SHUFFLE |
SHUFFLE.add(List<Message> queue,
Message msg,
Lock lock,
Consumer<Message> send_function) |
protected void |
BaseBundler.addMessage(Message msg,
long size) |
protected void |
SimplifiedTransferQueueBundler.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 boolean |
ASYM_ENCRYPT.bypass(Message msg,
boolean up) |
protected boolean |
AUTH.callUpHandlers(Message msg) |
protected Message |
Encrypt.decryptMessage(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,
SEQUENCER.SequencerHeader hdr) |
protected void |
SEQUENCER2.deliver(Message msg,
SEQUENCER2.SequencerHeader hdr) |
protected void |
UNICAST3.deliverMessage(Message msg,
Address sender,
long seqno) |
Object |
FRAG3.down(Message msg) |
Object |
DISCARD_PAYLOAD.down(Message msg) |
Object |
UNICAST3.down(Message msg) |
Object |
DUPL.down(Message msg) |
Object |
TRACE.down(Message msg) |
Object |
AUTH.down(Message msg) |
Object |
ASYM_ENCRYPT.down(Message msg) |
Object |
SIZE.down(Message msg) |
Object |
FlowControl.down(Message msg) |
Object |
PERF.down(Message msg) |
Object |
Encrypt.down(Message msg) |
Object |
RELAY.down(Message msg) |
Object |
SNIFF.down(Message msg) |
Object |
SASL.down(Message msg) |
Object |
DELAY.down(Message msg) |
Object |
HDRS.down(Message msg) |
Object |
COMPRESS.down(Message msg)
We compress the payload if it is larger than
min_size . |
Object |
TP.down(Message msg)
A message needs to be sent to a single member or all members
|
Object |
DISCARD.down(Message msg) |
Object |
ABP.down(Message msg) |
Object |
SimpleTCP.down(Message msg) |
Object |
STATS.down(Message msg) |
Object |
DROP.down(Message msg) |
Object |
DAISYCHAIN.down(Message msg) |
Object |
FRAG2.down(Message msg) |
Object |
CLEAR_FLAGS.down(Message msg) |
Object |
SEQUENCER2.down(Message msg) |
Object |
SHUFFLE.down(Message msg) |
Object |
EXAMPLE.down(Message msg) |
Object |
SEQUENCER.down(Message msg) |
Object |
FRAG.down(Message msg) |
Object |
RATE_LIMITER.down(Message msg) |
Object |
RSVP.down(Message msg) |
protected void |
DROP.dropped(Message msg,
boolean down) |
protected static void |
SNIFF.dump(String type,
Message msg) |
protected void |
Encrypt.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 |
FRAG3.fragment(Message msg)
Send all fragments as separate messages (with same ID !).
|
protected void |
FRAG2.fragment(Message msg)
Send all fragments as separate messages (with same ID !).
|
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 |
NAMING.handleCacheResponse(Message msg) |
protected void |
UNICAST3.handleDataReceived(Address sender,
long seqno,
short conn_id,
boolean first,
Message msg)
Check whether the hashtable 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 Object |
MFC_NB.handleDownMessage(Message msg) |
protected Object |
UFC_NB.handleDownMessage(Message msg) |
protected abstract Object |
FlowControl.handleDownMessage(Message msg) |
protected Object |
UFC.handleDownMessage(Message msg) |
protected Object |
MFC.handleDownMessage(Message msg) |
protected Object |
Encrypt.handleEncryptedMessage(Message msg) |
protected Object |
NAMING.handleMessage(Message msg,
NAMING.Header hdr) |
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,
UnicastHeader3 hdr) |
protected Object |
ASYM_ENCRYPT.handleUpEvent(Message msg,
EncryptHeader hdr) |
protected Object |
Encrypt.handleUpEvent(Message msg,
EncryptHeader hdr) |
protected void |
FlowControl.handleUpEvent(Message msg,
FcHeader hdr) |
protected Object |
RELAY.handleUpEvent(Message msg,
RELAY.RelayHeader hdr) |
boolean |
AUTH.UpHandler.handleUpMessage(Message msg)
Called when a message has been received
|
protected Object |
Encrypt.handleUpMessage(Message msg) |
protected void |
TP.loopback(Message msg,
boolean multicast) |
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) |
protected int |
RingBufferBundler.marshalMessagesToSameDestination(Address dest,
Message[] buf,
int start_index,
int end_index,
int max_bundle_size) |
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 String |
SNIFF.printPayload(Message msg,
StringBuilder sb) |
protected boolean |
ASYM_ENCRYPT.process(Message msg) |
protected boolean |
Encrypt.process(Message msg)
Whether or not to process this received message
|
protected void |
MAKE_BATCH.queue(Message msg) |
void |
RELAY.Receiver.receive(Message msg) |
protected void |
UNICAST3.retransmit(Message msg)
Called by the sender to resend messages for which no ACK has been received yet
|
void |
RingBufferBundlerLockless.send(Message msg) |
void |
TransferQueueBundler.send(Message msg) |
void |
AsyncNoBundler.send(Message msg) |
void |
SenderSendsBundler.send(Message msg) |
void |
RemoveQueueBundler.send(Message msg) |
void |
Bundler.send(Message msg) |
void |
BaseBundler.send(Message msg) |
void |
NoBundler.send(Message msg) |
protected void |
ABP.Entry.send(Message msg) |
void |
RingBufferBundlerLockless2.send(Message msg) |
void |
RingBufferBundler.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 |
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 ..
|
void |
RingBufferBundler.sendBundledMessages(Message[] buf,
int read_index,
int available_msgs)
Read and send messages in range [read-index ..
|
protected void |
TCPPING.sendDiscoveryRequest(Message req) |
protected void |
MPING.sendMcastDiscoveryRequest(Message msg) |
protected void |
BPING.sendMcastDiscoveryRequest(Message msg) |
protected void |
PING.sendMcastDiscoveryRequest(Message msg) |
protected void |
BaseBundler.sendSingleMessage(Message msg) |
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
|
Message |
FRAG3.FragEntry.set(Message frag_msg,
Frag3Header hdr)
Adds a fragment to the full 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 |
FRAG3.unfragment(Message msg,
Frag3Header hdr)
1.
|
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)
|
Object |
FORK.up(Message msg) |
Object |
FD_SOCK.up(Message msg) |
Object |
FRAG3.up(Message msg) |
Object |
STOMP.up(Message msg) |
Object |
UNICAST3.up(Message msg) |
Object |
DUPL.up(Message msg) |
Object |
BARRIER.up(Message msg) |
Object |
Locking.up(Message msg) |
Object |
AUTH.up(Message msg)
An event was received from the layer below.
|
Object |
ASYM_ENCRYPT.up(Message msg) |
Object |
SIZE.up(Message msg) |
Object |
FD.up(Message msg) |
Object |
COUNTER.up(Message msg) |
Object |
Executing.up(Message msg) |
Object |
FlowControl.up(Message msg) |
Object |
PERF.up(Message msg) |
Object |
Encrypt.up(Message msg) |
Object |
NAMING.up(Message msg) |
Object |
RELAY.up(Message msg) |
Object |
SNIFF.up(Message msg) |
Object |
DELIVERY_TIME.up(Message msg) |
Object |
SASL.up(Message msg) |
Object |
DELAY.up(Message msg) |
Object |
HDRS.up(Message msg) |
Object |
COMPRESS.up(Message msg)
If there is no header, we pass the message up.
|
Object |
Discovery.up(Message msg) |
Object |
VERIFY_SUSPECT.up(Message msg) |
Object |
FORWARD_TO_COORD.up(Message msg) |
Object |
FD_ALL2.up(Message msg) |
Object |
DISCARD.up(Message msg) |
Object |
ABP.up(Message msg) |
Object |
MERGE3.up(Message msg) |
Object |
STATS.up(Message msg) |
Object |
DROP.up(Message msg) |
Object |
DAISYCHAIN.up(Message msg) |
Object |
MAKE_BATCH.up(Message msg) |
Object |
FRAG2.up(Message msg) |
Object |
SEQUENCER2.up(Message msg) |
Object |
SHUFFLE.up(Message msg) |
Object |
EXAMPLE.up(Message msg) |
Object |
SEQUENCER.up(Message msg) |
Object |
FD_ALL.up(Message msg) |
Object |
DH_KEY_EXCHANGE.up(Message msg) |
Object |
FRAG.up(Message msg) |
Object |
RSVP.up(Message msg) |
Modifier and Type | Method and Description |
---|---|
protected SHUFFLE |
SHUFFLE.add(List<Message> queue,
MessageBatch batch,
Lock lock,
Consumer<Message> send_function) |
protected SHUFFLE |
SHUFFLE.add(List<Message> queue,
MessageBatch batch,
Lock lock,
Consumer<Message> send_function) |
protected SHUFFLE |
SHUFFLE.add(List<Message> queue,
Message msg,
Lock lock,
Consumer<Message> send_function) |
protected SHUFFLE |
SHUFFLE.add(List<Message> queue,
Message msg,
Lock lock,
Consumer<Message> send_function) |
DROP |
DROP.addDownFilter(Predicate<Message> filter) |
DROP |
DROP.addUpFilter(Predicate<Message> filter) |
protected void |
BARRIER.flushQueue(Map<Address,Message> queue) |
protected void |
UNICAST3.handleBatchReceived(UNICAST3.ReceiverEntry entry,
Address sender,
List<LongTuple<Message>> msgs,
boolean oob) |
protected String |
UNICAST3.printMessageList(List<LongTuple<Message>> list) |
protected void |
UNICAST3.processInternalMessage(Table<Message> win,
Address sender) |
ASYM_ENCRYPT |
ASYM_ENCRYPT.registerBypasser(BiPredicate<Message,Boolean> bypasser) |
protected void |
UNICAST3.removeAndDeliver(Table<Message> win,
Address sender)
Try to remove as many messages as possible from the table as pass them up.
|
protected void |
SEQUENCER2.removeAndDeliver(Table<Message> win,
Address sender) |
DROP |
DROP.removeDownFilter(Predicate<Message> filter) |
DROP |
DROP.removeUpFilter(Predicate<Message> filter) |
protected SHUFFLE |
SHUFFLE.reorderAndSend(List<Message> list,
Lock lock,
Consumer<Message> send_function) |
protected SHUFFLE |
SHUFFLE.reorderAndSend(List<Message> list,
Lock lock,
Consumer<Message> send_function) |
protected void |
RemoveQueueBundler.sendMessageList(Address dest,
Address src,
List<Message> list) |
protected void |
BaseBundler.sendMessageList(Address dest,
Address src,
List<Message> list) |
ASYM_ENCRYPT |
ASYM_ENCRYPT.unregisterBypasser(BiPredicate<Message,Boolean> bypasser) |
Constructor and Description |
---|
Entry(short conn_id,
Table<Message> msgs) |
ReceiverEntry(Table<Message> received_msgs,
short recv_conn_id) |
RingBufferBundler(RingBuffer<Message> rb) |
TransferQueueBundler(BlockingQueue<Message> queue) |
Modifier and Type | Method and Description |
---|---|
protected void |
DNS_PING.sendDiscoveryRequest(Message req) |
Modifier and Type | Field and Description |
---|---|
protected static Message |
NAKACK2.DUMMY_OOB_MSG |
Modifier and Type | Field and Description |
---|---|
protected static BiConsumer<MessageBatch,Message> |
NAKACK2.BATCH_ACCUMULATOR |
protected BoundedList<Message> |
NAKACK2.become_server_queue |
protected static Predicate<Message> |
NAKACK2.dont_loopback_filter |
protected Predicate<Message> |
NAKACK2.no_dummy_and_no_oob_delivered_msgs_and_no_dont_loopback_msgs |
protected 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,
String error_msg) |
Object |
NAKACK2.down(Message msg) |
Object |
FLUSH.down(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.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.
|
Object |
STABLE.up(Message msg) |
Object |
STATE_TRANSFER.up(Message msg) |
Object |
StreamingStateTransfer.up(Message msg) |
Object |
GMS.up(Message msg) |
Object |
NAKACK2.up(Message msg) |
Object |
FLUSH.up(Message msg) |
Modifier and Type | Method and Description |
---|---|
protected void |
NAKACK2.handleMessages(Address dest,
Address sender,
List<LongTuple<Message>> msgs,
boolean oob,
AsciiString cluster_name) |
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) |
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) |
Object |
RELAY2.down(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,
String... excluded_sites)
Sends the message via all bridges excluding the excluded_sites bridges
|
Object |
RELAY2.up(Message msg) |
Modifier and Type | Method and Description |
---|---|
Object |
SUPERVISOR.down(Message msg) |
Object |
EventHandler.down(Message msg) |
Object |
EventHandler.up(Message msg) |
Modifier and Type | Method and Description |
---|---|
List<Message> |
DeliveryManager.getNextMessagesToDeliver()
returns an ordered list with the messages to be deliver.
|
List<Message> |
DeliveryManagerImpl.getNextMessagesToDeliver() |
Modifier and Type | Method and Description |
---|---|
void |
DeliveryProtocol.deliver(Message message)
deliver a message
|
void |
TOA.deliver(Message message) |
Object |
TOA.down(Message message) |
Object |
TOA.up(Message message) |
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. |
Object |
ProtocolStack.down(Message msg) |
Object |
Protocol.down(Message msg)
A message is sent down the stack.
|
void |
MessageProcessingPolicy.loopback(Message msg,
boolean oob,
boolean internal)
Process a message that was not received from the transport but from above (e.g.
|
void |
MessageProcessingPolicy.process(Message msg,
boolean oob,
boolean internal)
Process a message received from the transport
|
Object |
ProtocolStack.up(Message msg) |
Object |
Protocol.up(Message msg)
A single message was received.
|
Modifier and Type | Method and Description |
---|---|
protected static Message |
UnicastTestTcpSlow.readMessage(byte[] buf,
int offset,
int length) |
protected static Message |
UnicastTestTcp.readMessage(DataInput in) |
Modifier and Type | Method and Description |
---|---|
static List<Message> |
ParseMessages.parse(byte[] buf,
int offset,
int length) |
static List<Message> |
ParseMessages.parse(String filename) |
Modifier and Type | Method and Description |
---|---|
Object |
MessageDispatcherSpeedTest.handle(Message msg) |
void |
UnicastTest.MyReceiver.receive(Message msg) |
void |
UnicastTestTcp.receive(Message msg) |
void |
UnicastTestTcpSlow.receive(Message msg) |
void |
LargeState.receive(Message msg) |
void |
PingPong.receive(Message msg) |
void |
FlowControlTest.receive(Message msg) |
protected static void |
UnicastTestTcp.writeMessage(Message msg,
DataOutputStream out) |
Modifier and Type | Method and Description |
---|---|
void |
MPerf.receive(Message msg) |
Modifier and Type | Method and Description |
---|---|
void |
JGroupsTransport.receive(Message msg) |
Modifier and Type | Field and Description |
---|---|
protected Message[] |
MessageBatch.messages
The storage of the messages; removed messages have a null element
|
protected Message |
SubmitToThreadPool.SingleMessageHandler.msg |
Modifier and Type | Field and Description |
---|---|
protected NavigableMap<Long,Message> |
ForwardQueue.forward_table
Maintains messages forwarded to the target which which no ack has been received yet.
|
protected static ToIntBiFunction<Message,MessageBatch> |
MessageBatch.length_visitor |
protected SizeBoundedQueue<Message> |
NonBlockingCredit.msg_queue |
protected SizeBoundedQueue<Message> |
NonBlockingCreditMap.msg_queue |
protected static Consumer<Message> |
NonBlockingCredit.NO_OP_SEND_FUNCTION |
protected static Consumer<Message> |
NonBlockingCreditMap.NO_OP_SEND_FUNCTION |
protected Consumer<Message> |
NonBlockingCredit.send_function |
protected Consumer<Message> |
NonBlockingCreditMap.send_function |
protected static ToLongBiFunction<Message,MessageBatch> |
MessageBatch.total_size_visitor |
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 |
MessageBatch.last() |
Message |
MessageBatch.BatchIterator.next() |
static Message |
Util.readMessage(DataInput instream) |
Modifier and Type | Method and Description |
---|---|
Collection<Message> |
MessageBatch.getMatchingMessages(short id,
boolean remove)
Removes and returns all messages which have a header with ID == id
|
Iterator<Message> |
MessageBatch.iterator()
Iterator which iterates only over non-null messages, skipping null messages
|
static List<Message> |
Util.parse(byte[] buf,
int offset,
int length) |
static List<Message> |
Util.parse(InputStream input) |
static List<Message> |
Util.parse(String filename) |
static List<Message> |
Util.readMessageList(DataInput in,
short transport_id) |
Stream<Message> |
MessageBatch.stream() |
Modifier and Type | Method and Description |
---|---|
MessageBatch |
MessageBatch.add(Message msg) |
int |
MessageBatch.add(Message msg,
boolean resize)
Adds a message to the table
|
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
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 |
NonBlockingCredit.decrementIfEnoughCredits(Message msg,
int credits,
long timeout)
Decrements the sender's credits by the size of the message.
|
boolean |
Credit.decrementIfEnoughCredits(Message msg,
int credits,
long timeout) |
void |
MaxOneThreadPerSender.loopback(Message msg,
boolean oob,
boolean internal) |
void |
SubmitToThreadPool.loopback(Message msg,
boolean oob,
boolean internal) |
static Buffer |
Util.messageToByteBuffer(Message msg) |
protected void |
MaxOneThreadPerSender.MessageTable.process(Message msg,
boolean loopback) |
protected void |
MaxOneThreadPerSender.Entry.process(Message msg,
boolean loopback) |
void |
MaxOneThreadPerSender.process(Message msg,
boolean oob,
boolean internal) |
void |
SubmitToThreadPool.process(Message msg,
boolean oob,
boolean internal) |
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(Message existing_msg,
Message new_msg)
Replaces a message in the batch with another one
|
MessageBatch |
MessageBatch.replace(Predicate<Message> filter,
Message replacement,
boolean match_all)
Replaces all messages which match a given filter with a replacement message
|
int |
MessageBatch.replaceIf(Predicate<Message> filter,
Message replacement,
boolean match_all)
Replaces all messages that match a given filter with a replacement message
|
void |
ForwardQueue.send(long id,
Message msg) |
protected void |
MaxOneThreadPerSender.Entry.submit(Message msg,
boolean loopback) |
static void |
Util.writeMessage(Message msg,
DataOutput dos,
boolean multicast)
This method needs to be synchronized on out_stream when it is called
|
Modifier and Type | Method and Description |
---|---|
void |
MessageBatch.forEach(BiConsumer<Message,MessageBatch> consumer) |
<T> Collection<T> |
MessageBatch.map(BiFunction<Message,MessageBatch,T> visitor)
Applies a function to all messages and returns a list of the function results
|
MessageBatch |
MessageBatch.remove(Predicate<Message> filter)
Removes all messages which match filter
|
MessageBatch |
MessageBatch.replace(Predicate<Message> filter,
Message replacement,
boolean match_all)
Replaces all messages which match a given filter with a replacement message
|
int |
MessageBatch.replaceIf(Predicate<Message> filter,
Message replacement,
boolean match_all)
Replaces all messages that match a given filter with a replacement message
|
static void |
Util.writeMessageList(Address dest,
Address src,
byte[] cluster_name,
List<Message> msgs,
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,
byte[] cluster_name) |
Constructor and Description |
---|
MessageBatch(Address dest,
Address sender,
AsciiString cluster_name,
boolean multicast,
Collection<Message> msgs) |
MessageBatch(Address dest,
Address sender,
AsciiString cluster_name,
boolean multicast,
Collection<Message> msgs,
Predicate<Message> filter) |
MessageBatch(Address dest,
Address sender,
AsciiString cluster_name,
boolean multicast,
Collection<Message> msgs,
Predicate<Message> filter) |
MessageBatch(Collection<Message> msgs) |
NonBlockingCredit(long credits,
int max_size,
Lock lock,
Consumer<Message> send_function) |
NonBlockingCreditMap(long max_credits,
int max_size,
Lock lock,
Consumer<Message> send_function) |
Copyright © 2018 JBoss, a division of Red Hat. All rights reserved.