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.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.tests | |
org.jgroups.tests.perf | |
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.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(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.src(Address new_src) |
Modifier and Type | Method and Description |
---|---|
void |
MessageListener.receive(Message msg)
Called when a message is received.
|
void |
ReceiverAdapter.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 |
MD5Token.authenticate(AuthToken token,
Message msg) |
boolean |
Krb5Token.authenticate(AuthToken token,
Message msg) |
boolean |
X509Token.authenticate(AuthToken token,
Message msg) |
boolean |
FixedMembershipToken.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 |
DemoToken.authenticate(AuthToken token,
Message msg) |
boolean |
SimpleToken.authenticate(AuthToken token,
Message msg) |
boolean |
RegexMembership.authenticate(AuthToken token,
Message msg) |
Modifier and Type | Field and Description |
---|---|
protected Message |
RequestCorrelator.ResponseImpl.req |
protected Message |
Request.request_msg |
Modifier and Type | Method and Description |
---|---|
protected <T> GroupRequest<T> |
MessageDispatcher.cast(Collection<Address> dests,
Message msg,
RequestOptions options,
boolean block_for_results) |
protected <T> GroupRequest<T> |
MessageDispatcher.cast(Collection<Address> dests,
Message msg,
RequestOptions options,
boolean block_for_results,
FutureListener<T> listener) |
<T> RspList<T> |
MessageDispatcher.castMessage(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(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(Collection<Address> dests,
Message msg,
RequestOptions options,
FutureListener<T> listener)
Sends a message to all members and expects responses from members in dests (if non-null).
|
Object |
RpcDispatcher.handle(Message req)
Message contains MethodCall.
|
Object |
RequestHandler.handle(Message msg) |
Object |
MessageDispatcher.handle(Message msg) |
void |
AsyncRequestHandler.handle(Message request,
Response response)
Invokes a request.
|
void |
MessageDispatcher.handle(Message request,
Response response) |
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,
Object reply,
boolean is_exception) |
void |
RequestCorrelator.sendRequest(long id,
Collection<Address> dest_mbrs,
Message msg,
RspCollector coll,
RequestOptions options)
Sends a request to a group.
|
void |
RequestCorrelator.sendRequest(long id,
List<Address> dest_mbrs,
Message msg,
RspCollector coll) |
protected void |
RequestCorrelator.sendResponse(Message rsp,
long req_id,
boolean is_exception) |
void |
RequestCorrelator.sendUnicastRequest(long id,
Address target,
Message msg,
RspCollector coll)
Sends a request to a single destination
|
Constructor and Description |
---|
GroupRequest(Message msg,
RequestCorrelator corr,
Address target,
RequestOptions options) |
GroupRequest(Message msg,
RequestCorrelator corr,
Collection<Address> targets,
RequestOptions options) |
Request(Message request,
RequestCorrelator corr,
RequestOptions options) |
ResponseImpl(Message req,
long req_id) |
UnicastRequest(Message msg,
Address target,
RequestOptions options) |
UnicastRequest(Message msg,
RequestCorrelator corr,
Address target,
RequestOptions options) |
Modifier and Type | Method and Description |
---|---|
protected <T> GroupRequest<T> |
MuxRpcDispatcher.cast(Collection<Address> dests,
Message msg,
RequestOptions options,
boolean blockForResults,
FutureListener<T> listener) |
protected <T> GroupRequest<T> |
MuxMessageDispatcher.cast(Collection<Address> dests,
Message msg,
RequestOptions options,
boolean blockForResults,
FutureListener<T> listener) |
protected void |
MuxRequestCorrelator.prepareResponse(Message rsp) |
void |
MuxRequestCorrelator.sendRequest(long requestId,
Collection<Address> dest_mbrs,
Message msg,
RspCollector coll,
RequestOptions options) |
void |
MuxRequestCorrelator.sendUnicastRequest(long id,
Address target,
Message msg,
RspCollector coll) |
Modifier and Type | Method and Description |
---|---|
void |
Chat.receive(Message msg) |
void |
Draw.receive(Message msg) |
Modifier and Type | Method and Description |
---|---|
void |
Whiteboard.receive(Message m) |
Modifier and Type | Method and Description |
---|---|
void |
ForkChannel.send(Message msg) |
protected void |
ForkChannel.setHeader(Message msg) |
Modifier and Type | Field and Description |
---|---|
protected List<Message> |
SHUFFLE.down_msgs |
protected NavigableMap<Long,Message> |
SEQUENCER.forward_table
Maintains messages forwarded to the coord which which no ack has been received yet.
|
protected Table<Message> |
UNICAST.ReceiverEntry.received_msgs |
protected Table<Message> |
UNICAST2.ReceiverEntry.received_msgs |
protected Table<Message> |
UNICAST3.ReceiverEntry.received_msgs |
protected List<Message> |
SHUFFLE.up_msgs |
Modifier and Type | Method and Description |
---|---|
protected Message |
FRAG2.FragEntry.assembleMessage()
Assembles all the fragments into one buffer.
|
protected Message |
UNICAST2.SenderEntry.getFirstMessage() |
static Message |
TP.readMessage(DataInputStream 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.
|
Modifier and Type | Method and Description |
---|---|
static List<Message> |
TP.readMessageList(DataInputStream in,
short transport_id) |
Modifier and Type | Method and Description |
---|---|
void |
SCOPE.MessageQueue.add(Message msg) |
protected void |
TP.TransferQueueBundler.addMessage(Message msg) |
protected void |
SEQUENCER.broadcast(Message msg,
boolean copy,
Address original_sender,
long seqno,
boolean resend) |
protected void |
SEQUENCER.deliver(Message msg,
Event evt,
SEQUENCER.SequencerHeader hdr) |
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 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)
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)
Check whether the hashmap 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 Object |
UFC.handleDownMessage(Event evt,
Message msg,
Address dest,
int length) |
protected Object |
MFC.handleDownMessage(Event evt,
Message msg,
Address dest,
int length) |
protected abstract Object |
FlowControl.handleDownMessage(Event evt,
Message msg,
Address dest,
int length) |
protected void |
ENCRYPT.handleEncryptedMessage(Message msg,
Event evt,
ENCRYPT.EncryptHeader hdr) |
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) |
protected void |
FlowControl.handleUpEvent(Message msg,
FcHeader hdr) |
protected Object |
RELAY.handleUpEvent(Message msg,
RELAY.RelayHeader hdr) |
protected static int |
SIZE.numHeaders(Message msg) |
protected void |
TP.passMessageUp(Message msg,
String cluster_name,
boolean perform_cluster_name_matching,
boolean multicast,
boolean discard_own_mcast) |
void |
RELAY.Receiver.receive(Message msg) |
void |
UNICAST.retransmit(Message msg)
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 |
TP.Bundler.send(Message msg) |
void |
TP.DefaultBundler.send(Message msg) |
void |
TP.TransferQueueBundler.send(Message msg) |
protected void |
TP.send(Message msg,
Address dest,
boolean multicast)
Serializes and sends a message.
|
protected void |
TUNNEL.send(Message msg,
Address dest,
boolean multicast) |
protected void |
BPING.sendMcastDiscoveryRequest(Message msg) |
protected void |
Discovery.sendMcastDiscoveryRequest(Message discovery_request) |
protected void |
MPING.sendMcastDiscoveryRequest(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 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)
|
protected static void |
TP.writeMessage(Message msg,
DataOutputStream dos,
boolean multicast)
This method needs to be synchronized on out_stream when it is called
|
Modifier and Type | Method and Description |
---|---|
protected void |
UNICAST.handleBatchReceived(Address sender,
Map<Short,List<Message>> map) |
protected void |
UNICAST2.handleBatchReceived(Address sender,
Map<Short,List<Message>> map) |
protected void |
UNICAST3.handleBatchReceived(UNICAST3.ReceiverEntry entry,
Address sender,
List<Tuple<Long,Message>> msgs,
boolean oob) |
protected String |
UNICAST.printMessageList(List<Message> list) |
protected String |
UNICAST2.printMessageList(List<Message> list) |
protected String |
UNICAST3.printMessageList(List<Tuple<Long,Message>> list) |
protected int |
UNICAST.removeAndDeliver(AtomicBoolean processing,
Table<Message> win,
Address sender)
Try to remove as many messages as possible from the table as pass them up.
|
protected int |
UNICAST3.removeAndDeliver(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)
Try to remove as many messages as possible and pass them up.
|
protected void |
TP.TransferQueueBundler.sendBundledMessages(Map<SingletonAddress,List<Message>> msgs)
Sends all messages from the map, all messages for the same destination are bundled into 1 message.
|
static void |
TP.writeMessageList(Address dest,
Address src,
String cluster_name,
List<Message> msgs,
DataOutputStream dos,
boolean multicast,
short transport_id)
Write a list of messages with the *same* destination and src addresses.
|
Constructor and Description |
---|
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) |
Modifier and Type | Field and Description |
---|---|
protected BoundedList<Message> |
NAKACK.become_server_queue |
protected BoundedList<Message> |
NAKACK2.become_server_queue |
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.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 |
NAKACK.send(Event evt,
Message msg)
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 sender,
List<Tuple<Long,Message>> msgs,
boolean oob,
String cluster_name) |
protected void |
NAKACK2.removeAndPassUp(Table<Message> buf,
Address sender,
boolean loopback,
String 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 |
Relayer.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 |
Relayer.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 |
Relayer.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
|
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 |
DeliveryManagerImpl.addNewMessageToDeliver(MessageID messageID,
Message message,
long sequenceNumber)
Add a new group message to be deliver
|
void |
TOA.deliver(Message message) |
void |
DeliveryProtocol.deliver(Message message)
deliver a message
|
void |
DeliveryManagerImpl.deliverSingleDestinationMessage(Message msg)
delivers a message that has only as destination member this node
|
Modifier and Type | Method and Description |
---|---|
Message |
NakReceiverWindow.get(long seqno)
Returns the message from xmit_table
|
Message |
NakReceiverWindow.remove() |
Message |
NakReceiverWindow.remove(boolean acquire_lock,
boolean remove_msg) |
Modifier and Type | Method and Description |
---|---|
List<Message> |
NakReceiverWindow.get(long from,
long to)
Returns a list of messages in the range [from ..
|
List<Message> |
NakReceiverWindow.removeMany(AtomicBoolean processing)
Removes as many messages as possible
|
List<Message> |
NakReceiverWindow.removeMany(AtomicBoolean processing,
boolean remove_msgs,
int max_results)
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)
Adds a message according to its seqno (sequence number).
|
Modifier and Type | Method and Description |
---|---|
Object |
MessageDispatcherSpeedTest.handle(Message msg) |
void |
LargeState.receive(Message msg) |
void |
PingPong.receive(Message msg) |
void |
FlowControlTest.receive(Message msg) |
void |
RoundTrip.receive(Message msg)
On the server: receive a request, send a response.
|
Modifier and Type | Method and Description |
---|---|
void |
MPerf.receive(Message msg) |
Modifier and Type | Field and Description |
---|---|
protected Message[][] |
RetransmitTable.matrix |
protected Message[] |
MessageBatch.messages
The storage of the messages; removed messages have a null element
|
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.
|
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) |
protected Message[] |
RetransmitTable.getRow(int index)
Returns a row.
|
Message |
MessageBatch.last() |
Message |
MessageBatch.BatchIterator.next() |
Message |
RetransmitTable.putIfAbsent(long seqno,
Message msg)
Adds a message if the element at the given index is null.
|
Message |
RetransmitTable.remove(long seqno)
Removes the message with seqno from the table, nulls the index
|
Modifier and Type | Method and Description |
---|---|
List<Message> |
RetransmitTable.get(long from,
long to) |
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
|
Modifier and Type | Method and Description |
---|---|
MessageBatch |
MessageBatch.add(Message msg) |
static short |
Util.getScope(Message msg) |
static Buffer |
Util.messageToByteBuffer(Message msg) |
static String |
Util.printMessage(Message msg)
Tries to read an object from the message's buffer and prints it
|
boolean |
RetransmitTable.put(long seqno,
Message msg)
Adds a new message to the index computed as a function of seqno
|
Message |
RetransmitTable.putIfAbsent(long seqno,
Message msg)
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(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
|
Modifier and Type | Method and Description |
---|---|
static Buffer |
Util.msgListToByteBuffer(List<Message> xmit_list)
Marshalls a list of messages.
|
Constructor and Description |
---|
MessageBatch(Address dest,
Address sender,
String cluster_name,
boolean multicast,
Collection<Message> msgs) |
MessageBatch(Collection<Message> msgs) |
Copyright © 2014 JBoss, a division of Red Hat. All rights reserved.