Package org.jgroups.protocols
Class UNICAST3
- java.lang.Object
-
- org.jgroups.stack.Protocol
-
- org.jgroups.protocols.UNICAST3
-
- All Implemented Interfaces:
Lifecycle,AgeOutCache.Handler<Address>
public class UNICAST3 extends Protocol implements AgeOutCache.Handler<Address>
Reliable unicast protocol using a combination of positive and negative acks. See docs/design/UNICAST3.txt for details.- Since:
- 3.3
- Author:
- Bela Ban
-
-
Nested Class Summary
Nested Classes Modifier and Type Class Description protected classUNICAST3.Entryprotected classUNICAST3.ReceiverEntryprotected classUNICAST3.RetransmitTaskRetransmitter task which periodically (every xmit_interval ms): If any of the receiver windows have the ack flag set, clears the flag and sends an ack for the highest delivered seqno to the sender Checks all receiver windows for missing messages and asks senders for retransmission For all sender windows, checks if highest acked (HA) < highest sent (HS).protected classUNICAST3.SenderEntryprotected static classUNICAST3.State
-
Field Summary
Fields Modifier and Type Field Description protected intack_thresholdprotected AverageMinMaxavg_delivery_batch_sizeprotected static java.util.function.BiConsumer<MessageBatch,Message>BATCH_ACCUMULATORprotected AgeOutCache<Address>cacheprotected java.util.Map<Address,MessageBatch>cached_batchesTo cache batches for sending messages up the stack (https://issues.redhat.com/browse/JGRP-2841)protected longconn_close_timeoutprotected longconn_expiry_timeoutprotected static longDEFAULT_FIRST_SEQNOprotected static intDEFAULT_INCREMENTprotected static intDEFAULT_INITIAL_CAPACITYprotected static longDEFAULT_XMIT_INTERVALprotected static java.util.function.Predicate<Message>dont_loopback_filterprotected java.util.function.Predicate<Message>drop_oob_and_dont_loopback_msgs_filterprotected static MessageDUMMY_OOB_MSGprotected booleanis_traceprotected shortlast_conn_idprotected ExpiryCache<Address>last_sync_sentKeep track of when a SEND_FIRST_SEQNO message was sent to a given senderprotected booleanlog_not_found_msgsprotected booleanloopbackprotected intmax_batch_sizeprotected longmax_retransmit_timeprotected intmax_xmit_req_sizeprotected java.util.List<Address>membersprotected MessageCachemsg_cacheprotected java.util.concurrent.atomic.LongAddernum_acks_receivedprotected java.util.concurrent.atomic.LongAddernum_acks_sentprotected java.util.concurrent.atomic.LongAddernum_loopbacksprotected java.util.concurrent.atomic.LongAddernum_msgs_receivedprotected java.util.concurrent.atomic.LongAddernum_msgs_sentprotected java.util.concurrent.atomic.LongAddernum_xmitsprotected java.util.Map<Address,UNICAST3.ReceiverEntry>recv_tableprotected java.util.concurrent.locks.ReentrantLockrecv_table_lockprotected booleanrelay_presentprotected booleanreuse_message_batchesprotected booleanrunningprotected java.util.Map<Address,UNICAST3.SenderEntry>send_tableprotected booleansends_can_blockprotected longsync_min_intervalprotected TimeServicetime_serviceprotected TimeSchedulertimerprotected java.util.concurrent.atomic.AtomicIntegertimestamperprotected longxmit_intervalprotected java.util.concurrent.atomic.LongAdderxmit_reqs_receivedprotected java.util.concurrent.atomic.LongAdderxmit_reqs_sentprotected java.util.concurrent.atomic.LongAdderxmit_rsps_sentprotected longxmit_table_max_compaction_timeprotected intxmit_table_msgs_per_rowprotected intxmit_table_num_rowsprotected doublexmit_table_resize_factorprotected java.util.concurrent.Future<?>xmit_taskRetransmitTask running every xmit_interval msprotected java.util.Map<Address,java.lang.Long>xmit_task_mapUsed by the retransmit task to keep the last retransmitted seqno per member (applicable only for received messages (ReceiverEntry)): https://issues.redhat.com/browse/JGRP-1539protected booleanxmits_enabledDeprecated, for removal: This API element is subject to removal in a future version.-
Fields inherited from class org.jgroups.stack.Protocol
after_creation_hook, down_prot, ergonomics, id, local_addr, log, policies, stack, stats, up_prot
-
-
Constructor Summary
Constructors Constructor Description UNICAST3()
-
Method Summary
All Methods Static Methods Instance Methods Concrete Methods Deprecated Methods Modifier and Type Method Description protected static intaccumulate(java.util.function.ToIntFunction<Table<Message>> func, java.util.Collection<? extends UNICAST3.Entry>... entries)protected voidaddMessage(UNICAST3.ReceiverEntry entry, Address sender, long seqno, Message msg)protected voidaddQueuedMessages(Address sender, UNICAST3.ReceiverEntry entry, java.util.Collection<Message> queued_msgs)UNICAST3clearCachedBatches()voidcloseConnection(Address mbr)Removes and resets from connection table (which is already locked).voidcloseIdleConnections()voidcloseReceiveConnection(Address mbr)voidcloseSendConnection(Address mbr)protected static intcompare(int ts1, int ts2)Compares 2 timestamps, handles numeric overflowprotected UNICAST3.ReceiverEntrycreateReceiverEntry(Address sender, long seqno, short conn_id, Address dest)protected Table<Message>createTable(long seqno)protected voiddeliverBatch(MessageBatch batch)protected voiddeliverMessage(Message msg, Address sender, long seqno)java.lang.Objectdown(Event evt)An event is to be sent down the stack.java.lang.Objectdown(Message msg)A message is sent down the stack.voidexpired(Address key)Called by AgeOutCache, to removed expired connectionsintgetAckThreshold()AgeOutCache<Address>getAgeOutCache()intgetAgeOutCacheSize()longgetConnCloseTimeout()longgetConnExpiryTimeout()longgetMaxRetransmitTime()intgetMaxXmitReqSize()protected shortgetNewConnectionId()longgetNumAcksReceived()longgetNumAcksSent()intgetNumConnections()longgetNumLoopbacks()longgetNumMessagesReceived()Deprecated.longgetNumMessagesSent()Deprecated.intgetNumReceiveConnections()intgetNumSendConnections()intgetNumUnackedMessages()The number of messages in all Entry.sent_msgs tables (haven't received an ACK yet)intgetNumUnackedMessages(Address dest)longgetNumXmits()protected UNICAST3.ReceiverEntrygetReceiverEntry(Address sender, long seqno, boolean first, short conn_id, Address dest)protected UNICAST3.SenderEntrygetSenderEntry(Address dst)Table<Message>getSendWindow(Address target)Used for testing only!longgetSyncMinInterval()protected longgetTimestamp()intgetTimestamper()longgetXmitInterval()intgetXmitTableDeliverableMessages()longgetXmitTableMaxCompactionTime()intgetXmitTableMissingMessages()intgetXmitTableMsgsPerRow()intgetXmitTableNumCompactions()intgetXmitTableNumMoves()intgetXmitTableNumPurges()intgetXmitTableNumResizes()intgetXmitTableNumRows()doublegetXmitTableResizeFactor()intgetXmitTableUndeliveredMessages()protected voidhandleAckReceived(Address sender, long seqno, short conn_id, int timestamp)Add the ACK to hashtable.sender.sent_msgsprotected voidhandleBatchFromSelf(MessageBatch batch, UNICAST3.Entry entry)protected voidhandleBatchReceived(UNICAST3.ReceiverEntry entry, Address sender, java.util.List<LongTuple<Message>> msgs, boolean oob, Address original_dest)protected voidhandleDataReceived(Address sender, long seqno, short conn_id, boolean first, Message msg)Check whether the hashtable contains an entry e forsender(create if not).protected voidhandleDataReceivedFromSelf(Address sender, long seqno, Message msg)Called when the sender of a message is the local member.protected voidhandleResendingOfFirstMessage(Address sender, int timestamp)We need to resend the first message with our conn_idprotected voidhandleUpEvent(Address sender, Message msg, UnicastHeader3 hdr)protected voidhandleXmitRequest(Address sender, SeqnoList missing)booleanhasSendConnectionTo(Address dest)Used for testing onlyvoidinit()Called after a protocol has been created and before the protocol is started.protected booleanisLocal(Address addr)protected booleanisLocalSiteMaster(Address dest)static booleanisXmitsEnabled()booleanisXmitTaskRunning()booleanlogNotFoundMsgs()UNICAST3logNotFoundMsgs(boolean l)booleanloopback()UNICAST3loopback(boolean b)java.lang.StringprintAgeOutCache()java.lang.StringprintCachedBatches()java.lang.StringprintConnections()protected java.lang.StringprintMessageList(java.util.List<LongTuple<Message>> list)java.lang.StringprintReceiveWindowMessages()java.lang.StringprintSendWindowMessages()voidremoveAllConnections()This method is public only so it can be invoked by unit testing, but should not otherwise be used !protected voidremoveAndDeliver(Table<Message> win, Address sender, AsciiString cluster, int min_size)Try to remove as many messages as possible from the table as pass them up.intremoveConnections(boolean remove_send_connections, boolean remove_receive_connections)Removes send- and/or receive-connections whose state is not OPEN (CLOSING or CLOSED).intremoveExpiredConnections()voidremoveReceiveConnection(Address mbr)voidremoveSendConnection(java.util.function.Predicate<Address> pred)voidremoveSendConnection(Address mbr)protected voidresend(Message msg)voidresetStats()protected voidretransmit(Message msg)Called by the sender to resend messages for which no ACK has been received yetprotected voidretransmit(SeqnoList missing, Address sender, Address real_dest)Sends a retransmit request to the given senderbooleanreuseMessageBatches()UNICAST3reuseMessageBatches(boolean b)protected voidsendAck(Address dst, long seqno, short conn_id, Address real_dest)voidsendClose(Address dest, short conn_id)voidsendPendingAcks()protected voidsendRequestForFirstSeqno(Address dest, Address original_dest)booleansendsCanBlock()UNICAST3sendsCanBlock(boolean s)UNICAST3setAckThreshold(int a)UNICAST3setConnCloseTimeout(long c)UNICAST3setConnExpiryTimeout(long c)<T extends Protocol>
TsetLevel(java.lang.String level)Sets the level of a logger.UNICAST3setMaxRetransmitTime(long max_retransmit_time)UNICAST3setMaxXmitReqSize(int m)UNICAST3setSyncMinInterval(long s)UNICAST3setXmitInterval(long i)UNICAST3setXmitsEnabled(boolean b)UNICAST3setXmitTableMaxCompactionTime(long x)UNICAST3setXmitTableMsgsPerRow(int n)UNICAST3setXmitTableNumRows(int n)UNICAST3setXmitTableResizeFactor(double x)voidstart()This method is called on aJChannel.connect(String); starts work.voidstartRetransmitTask()voidstop()Called on aJChannel.disconnect(); stops work (e.g.voidstopRetransmitTask()voidtriggerXmit()UNICAST3trimCachedBatches()java.lang.Objectup(Message msg)A single message was received.voidup(MessageBatch batch)Sends up a multiple messages in aMessageBatch.protected voidupdate(UNICAST3.Entry entry, int num_received)-
Methods inherited from class org.jgroups.stack.Protocol
accept, addPolicy, addr, addr, afterCreationHook, destroy, down, enableStats, getAddress, getComponents, getDownProtocol, getDownServices, getId, getIdsAbove, getLevel, getLog, getName, getPolicies, getProtocolStack, getSocketFactory, getThreadFactory, getTransport, getUpProtocol, getUpServices, getValue, isErgonomics, level, parse, policies, providedDownServices, providedUpServices, removePolicy, requiredDownServices, requiredUpServices, resetStatistics, setAddress, setDownProtocol, setErgonomics, setId, setPolicies, setProtocolStack, setSocketFactory, setUpProtocol, setValue, statsEnabled, toString, up
-
-
-
-
Field Detail
-
DEFAULT_FIRST_SEQNO
protected static final long DEFAULT_FIRST_SEQNO
- See Also:
- Constant Field Values
-
DEFAULT_XMIT_INTERVAL
protected static final long DEFAULT_XMIT_INTERVAL
- See Also:
- Constant Field Values
-
conn_expiry_timeout
protected long conn_expiry_timeout
-
conn_close_timeout
protected long conn_close_timeout
-
xmit_table_num_rows
protected int xmit_table_num_rows
-
xmit_table_msgs_per_row
protected int xmit_table_msgs_per_row
-
xmit_table_resize_factor
protected double xmit_table_resize_factor
-
xmit_table_max_compaction_time
protected long xmit_table_max_compaction_time
-
max_retransmit_time
protected long max_retransmit_time
-
xmit_interval
protected long xmit_interval
-
xmits_enabled
@Deprecated(since="5.4.4", forRemoval=true) protected boolean xmits_enabledDeprecated, for removal: This API element is subject to removal in a future version.
-
log_not_found_msgs
protected boolean log_not_found_msgs
-
ack_threshold
protected int ack_threshold
-
sync_min_interval
protected long sync_min_interval
-
max_xmit_req_size
protected int max_xmit_req_size
-
max_batch_size
protected int max_batch_size
-
reuse_message_batches
protected boolean reuse_message_batches
-
loopback
protected boolean loopback
-
DEFAULT_INITIAL_CAPACITY
protected static final int DEFAULT_INITIAL_CAPACITY
- See Also:
- Constant Field Values
-
DEFAULT_INCREMENT
protected static final int DEFAULT_INCREMENT
- See Also:
- Constant Field Values
-
num_msgs_sent
protected final java.util.concurrent.atomic.LongAdder num_msgs_sent
-
num_msgs_received
protected final java.util.concurrent.atomic.LongAdder num_msgs_received
-
num_acks_sent
protected final java.util.concurrent.atomic.LongAdder num_acks_sent
-
num_acks_received
protected final java.util.concurrent.atomic.LongAdder num_acks_received
-
num_xmits
protected final java.util.concurrent.atomic.LongAdder num_xmits
-
xmit_reqs_received
protected final java.util.concurrent.atomic.LongAdder xmit_reqs_received
-
xmit_reqs_sent
protected final java.util.concurrent.atomic.LongAdder xmit_reqs_sent
-
xmit_rsps_sent
protected final java.util.concurrent.atomic.LongAdder xmit_rsps_sent
-
avg_delivery_batch_size
protected final AverageMinMax avg_delivery_batch_size
-
sends_can_block
protected boolean sends_can_block
-
is_trace
protected boolean is_trace
-
relay_present
protected boolean relay_present
-
send_table
protected final java.util.Map<Address,UNICAST3.SenderEntry> send_table
-
recv_table
protected final java.util.Map<Address,UNICAST3.ReceiverEntry> recv_table
-
cached_batches
protected final java.util.Map<Address,MessageBatch> cached_batches
To cache batches for sending messages up the stack (https://issues.redhat.com/browse/JGRP-2841)
-
recv_table_lock
protected final java.util.concurrent.locks.ReentrantLock recv_table_lock
-
xmit_task_map
protected final java.util.Map<Address,java.lang.Long> xmit_task_map
Used by the retransmit task to keep the last retransmitted seqno per member (applicable only for received messages (ReceiverEntry)): https://issues.redhat.com/browse/JGRP-1539
-
xmit_task
protected java.util.concurrent.Future<?> xmit_task
RetransmitTask running every xmit_interval ms
-
members
protected volatile java.util.List<Address> members
-
timer
protected TimeScheduler timer
-
running
protected volatile boolean running
-
last_conn_id
protected short last_conn_id
-
cache
protected AgeOutCache<Address> cache
-
time_service
protected TimeService time_service
-
timestamper
protected final java.util.concurrent.atomic.AtomicInteger timestamper
-
last_sync_sent
protected ExpiryCache<Address> last_sync_sent
Keep track of when a SEND_FIRST_SEQNO message was sent to a given sender
-
num_loopbacks
protected final java.util.concurrent.atomic.LongAdder num_loopbacks
-
msg_cache
protected final MessageCache msg_cache
-
DUMMY_OOB_MSG
protected static final Message DUMMY_OOB_MSG
-
drop_oob_and_dont_loopback_msgs_filter
protected final java.util.function.Predicate<Message> drop_oob_and_dont_loopback_msgs_filter
-
dont_loopback_filter
protected static final java.util.function.Predicate<Message> dont_loopback_filter
-
BATCH_ACCUMULATOR
protected static final java.util.function.BiConsumer<MessageBatch,Message> BATCH_ACCUMULATOR
-
-
Method Detail
-
getNumLoopbacks
public long getNumLoopbacks()
-
getNumSendConnections
public int getNumSendConnections()
-
getNumReceiveConnections
public int getNumReceiveConnections()
-
getNumConnections
public int getNumConnections()
-
getTimestamper
public int getTimestamper()
-
getAckThreshold
public int getAckThreshold()
-
setAckThreshold
public UNICAST3 setAckThreshold(int a)
-
setLevel
public <T extends Protocol> T setLevel(java.lang.String level)
Description copied from class:ProtocolSets the level of a logger. This method is used to dynamically change the logging level of a running system, e.g. via JMX. The appender of a level needs to exist.
-
getXmitInterval
public long getXmitInterval()
-
setXmitInterval
public UNICAST3 setXmitInterval(long i)
-
isXmitsEnabled
public static boolean isXmitsEnabled()
-
setXmitsEnabled
public UNICAST3 setXmitsEnabled(boolean b)
-
getXmitTableNumRows
public int getXmitTableNumRows()
-
setXmitTableNumRows
public UNICAST3 setXmitTableNumRows(int n)
-
getXmitTableMsgsPerRow
public int getXmitTableMsgsPerRow()
-
setXmitTableMsgsPerRow
public UNICAST3 setXmitTableMsgsPerRow(int n)
-
getConnExpiryTimeout
public long getConnExpiryTimeout()
-
setConnExpiryTimeout
public UNICAST3 setConnExpiryTimeout(long c)
-
getConnCloseTimeout
public long getConnCloseTimeout()
-
setConnCloseTimeout
public UNICAST3 setConnCloseTimeout(long c)
-
getXmitTableResizeFactor
public double getXmitTableResizeFactor()
-
setXmitTableResizeFactor
public UNICAST3 setXmitTableResizeFactor(double x)
-
getXmitTableMaxCompactionTime
public long getXmitTableMaxCompactionTime()
-
setXmitTableMaxCompactionTime
public UNICAST3 setXmitTableMaxCompactionTime(long x)
-
logNotFoundMsgs
public boolean logNotFoundMsgs()
-
logNotFoundMsgs
public UNICAST3 logNotFoundMsgs(boolean l)
-
getSyncMinInterval
public long getSyncMinInterval()
-
setSyncMinInterval
public UNICAST3 setSyncMinInterval(long s)
-
getMaxXmitReqSize
public int getMaxXmitReqSize()
-
setMaxXmitReqSize
public UNICAST3 setMaxXmitReqSize(int m)
-
reuseMessageBatches
public boolean reuseMessageBatches()
-
reuseMessageBatches
public UNICAST3 reuseMessageBatches(boolean b)
-
sendsCanBlock
public boolean sendsCanBlock()
-
sendsCanBlock
public UNICAST3 sendsCanBlock(boolean s)
-
loopback
public boolean loopback()
-
loopback
public UNICAST3 loopback(boolean b)
-
printConnections
public java.lang.String printConnections()
-
printCachedBatches
public java.lang.String printCachedBatches()
-
clearCachedBatches
public UNICAST3 clearCachedBatches()
-
trimCachedBatches
public UNICAST3 trimCachedBatches()
-
getNumMessagesSent
@Deprecated public long getNumMessagesSent()
Deprecated.Don't remove! https://issues.redhat.com/browse/JGRP-2814
-
getNumMessagesReceived
@Deprecated public long getNumMessagesReceived()
Deprecated.Don't remove! https://issues.redhat.com/browse/JGRP-2814
-
getNumAcksSent
public long getNumAcksSent()
-
getNumAcksReceived
public long getNumAcksReceived()
-
getNumXmits
public long getNumXmits()
-
getMaxRetransmitTime
public long getMaxRetransmitTime()
-
setMaxRetransmitTime
public UNICAST3 setMaxRetransmitTime(long max_retransmit_time)
-
isXmitTaskRunning
public boolean isXmitTaskRunning()
-
getAgeOutCacheSize
public int getAgeOutCacheSize()
-
printAgeOutCache
public java.lang.String printAgeOutCache()
-
getAgeOutCache
public AgeOutCache<Address> getAgeOutCache()
-
hasSendConnectionTo
public boolean hasSendConnectionTo(Address dest)
Used for testing only
-
getNumUnackedMessages
public int getNumUnackedMessages()
The number of messages in all Entry.sent_msgs tables (haven't received an ACK yet)
-
getNumUnackedMessages
public int getNumUnackedMessages(Address dest)
-
getXmitTableUndeliveredMessages
public int getXmitTableUndeliveredMessages()
-
getXmitTableMissingMessages
public int getXmitTableMissingMessages()
-
getXmitTableDeliverableMessages
public int getXmitTableDeliverableMessages()
-
getXmitTableNumCompactions
public int getXmitTableNumCompactions()
-
getXmitTableNumMoves
public int getXmitTableNumMoves()
-
getXmitTableNumResizes
public int getXmitTableNumResizes()
-
getXmitTableNumPurges
public int getXmitTableNumPurges()
-
printReceiveWindowMessages
public java.lang.String printReceiveWindowMessages()
-
printSendWindowMessages
public java.lang.String printSendWindowMessages()
-
resetStats
public void resetStats()
- Overrides:
resetStatsin classProtocol
-
init
public void init() throws java.lang.ExceptionDescription copied from class:ProtocolCalled after a protocol has been created and before the protocol is started. Attributes are already set. Other protocols are not yet connected and events cannot yet be sent.
-
start
public void start() throws java.lang.ExceptionDescription copied from class:ProtocolThis method is called on aJChannel.connect(String); starts work. Protocols are connected ready to receive events. Will be called from bottom to top.- Specified by:
startin interfaceLifecycle- Overrides:
startin classProtocol- Throws:
java.lang.Exception- Thrown if protocol cannot be started successfully. This will cause the ProtocolStack to fail, soJChannel.connect(String)will throw an exception
-
stop
public void stop()
Description copied from class:ProtocolCalled on aJChannel.disconnect(); stops work (e.g. by closing multicast socket). Will be called from top to bottom.
-
up
public java.lang.Object up(Message msg)
Description copied from class:ProtocolA single message was received. Protocols may examine the message and do something (e.g. add a header) with it before passing it up.
-
handleUpEvent
protected void handleUpEvent(Address sender, Message msg, UnicastHeader3 hdr)
-
up
public void up(MessageBatch batch)
Description copied from class:ProtocolSends up a multiple messages in aMessageBatch. The sender of the batch is always the same, and so is the destination (null == multicast messages). Messages in a batch can be OOB messages, regular messages, or mixed messages, although the transport itself will create initial MessageBatches that contain only either OOB or regular messages. The default processing below sends messages up the stack individually, based on a matching criteria (callingProtocol.accept(Message)), and - if true - callsProtocol.up(org.jgroups.Event)for that message and removes the message. If the batch is not empty, it is passed up, or else it is dropped. Subclasses should check if there are any messages destined for them (e.g. usingMessageBatch.iterator(Predicate)), then possibly remove and process them and finally pass the batch up to the next protocol. Protocols can also modify messages in place, e.g. ENCRYPT could decrypt all encrypted messages in the batch, not remove them, and pass the batch up when done.
-
handleBatchFromSelf
protected void handleBatchFromSelf(MessageBatch batch, UNICAST3.Entry entry)
-
down
public java.lang.Object down(Event evt)
Description copied from class:ProtocolAn event is to be sent down the stack. A protocol may want to examine its type and perform some action on it, depending on the event's type. If the event is a message MSG, then the protocol may need to add a header to it (or do nothing at all) before sending it down the stack usingdown_prot.down().
-
down
public java.lang.Object down(Message msg)
Description copied from class:ProtocolA message is sent down the stack. Protocols may examine the message and do something (e.g. add a header) with it, before passing it down.
-
isLocalSiteMaster
protected boolean isLocalSiteMaster(Address dest)
-
isLocal
protected boolean isLocal(Address addr)
-
closeConnection
public void closeConnection(Address mbr)
Removes and resets from connection table (which is already locked). Returns true if member was found, otherwise false. This method is public only so it can be invoked by unit testing, but should not be used !
-
closeSendConnection
public void closeSendConnection(Address mbr)
-
closeReceiveConnection
public void closeReceiveConnection(Address mbr)
-
removeSendConnection
public void removeSendConnection(Address mbr)
-
removeSendConnection
public void removeSendConnection(java.util.function.Predicate<Address> pred)
-
removeReceiveConnection
public void removeReceiveConnection(Address mbr)
-
removeAllConnections
public void removeAllConnections()
This method is public only so it can be invoked by unit testing, but should not otherwise be used !
-
retransmit
protected void retransmit(SeqnoList missing, Address sender, Address real_dest)
Sends a retransmit request to the given sender
-
retransmit
protected void retransmit(Message msg)
Called by the sender to resend messages for which no ACK has been received yet
-
expired
public void expired(Address key)
Called by AgeOutCache, to removed expired connections- Specified by:
expiredin interfaceAgeOutCache.Handler<Address>- Parameters:
key-
-
handleDataReceived
protected void handleDataReceived(Address sender, long seqno, short conn_id, boolean first, Message msg)
Check whether the hashtable contains an entry e forsender(create if not). If e.received_msgs is null andfirstis true: create a new AckReceiverWindow(seqno) and add message. Set e.received_msgs to the new window. Else just add the message.
-
addMessage
protected void addMessage(UNICAST3.ReceiverEntry entry, Address sender, long seqno, Message msg)
-
addQueuedMessages
protected void addQueuedMessages(Address sender, UNICAST3.ReceiverEntry entry, java.util.Collection<Message> queued_msgs)
-
handleDataReceivedFromSelf
protected void handleDataReceivedFromSelf(Address sender, long seqno, Message msg)
Called when the sender of a message is the local member. In this case, we don't need to add the message to the table as the sender already did that
-
handleBatchReceived
protected void handleBatchReceived(UNICAST3.ReceiverEntry entry, Address sender, java.util.List<LongTuple<Message>> msgs, boolean oob, Address original_dest)
-
removeAndDeliver
protected void removeAndDeliver(Table<Message> win, Address sender, AsciiString cluster, int min_size)
Try to remove as many messages as possible from the table as pass them up. Prevents concurrent passing up of messages by different threads (https://issues.redhat.com/browse/JGRP-198); lots of threads can come up to this point concurrently, but only 1 is allowed to pass at a time. We *can* deliver messages from *different* senders concurrently, e.g. reception of P1, Q1, P2, Q2 can result in delivery of P1, Q1, Q2, P2: FIFO (implemented by UNICAST) says messages need to be delivered in the order in which they were sent
-
printMessageList
protected java.lang.String printMessageList(java.util.List<LongTuple<Message>> list)
-
getReceiverEntry
protected UNICAST3.ReceiverEntry getReceiverEntry(Address sender, long seqno, boolean first, short conn_id, Address dest)
-
getSenderEntry
protected UNICAST3.SenderEntry getSenderEntry(Address dst)
-
createReceiverEntry
protected UNICAST3.ReceiverEntry createReceiverEntry(Address sender, long seqno, short conn_id, Address dest)
-
handleAckReceived
protected void handleAckReceived(Address sender, long seqno, short conn_id, int timestamp)
Add the ACK to hashtable.sender.sent_msgs
-
handleResendingOfFirstMessage
protected void handleResendingOfFirstMessage(Address sender, int timestamp)
We need to resend the first message with our conn_id- Parameters:
sender-
-
resend
protected void resend(Message msg)
-
deliverBatch
protected void deliverBatch(MessageBatch batch)
-
getTimestamp
protected long getTimestamp()
-
startRetransmitTask
public void startRetransmitTask()
-
stopRetransmitTask
public void stopRetransmitTask()
-
getNewConnectionId
protected short getNewConnectionId()
-
sendRequestForFirstSeqno
protected void sendRequestForFirstSeqno(Address dest, Address original_dest)
-
sendClose
public void sendClose(Address dest, short conn_id)
-
closeIdleConnections
public void closeIdleConnections()
-
removeExpiredConnections
public int removeExpiredConnections()
-
removeConnections
public int removeConnections(boolean remove_send_connections, boolean remove_receive_connections)Removes send- and/or receive-connections whose state is not OPEN (CLOSING or CLOSED).- Parameters:
remove_send_connections- If true, send connections whose state is !OPEN are destroyed and removedremove_receive_connections- If true, receive connections with state !OPEN are destroyed and removed- Returns:
- The number of connections which were removed
-
triggerXmit
public void triggerXmit()
-
sendPendingAcks
public void sendPendingAcks()
-
update
protected void update(UNICAST3.Entry entry, int num_received)
-
compare
protected static int compare(int ts1, int ts2)Compares 2 timestamps, handles numeric overflow
-
accumulate
@SafeVarargs protected static int accumulate(java.util.function.ToIntFunction<Table<Message>> func, java.util.Collection<? extends UNICAST3.Entry>... entries)
-
-