A B C D E F G H I J K L M N O P Q R S T U V W X Y _

A

ABORT_FLUSH - Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
 
ABOVE - Static variable in class org.jgroups.stack.ProtocolStack
 
AbstractConnectionMap<V extends Connection> - Class in org.jgroups.blocks
 
AbstractConnectionMap(ThreadFactory) - Constructor for class org.jgroups.blocks.AbstractConnectionMap
 
AbstractConnectionMap(ThreadFactory, long) - Constructor for class org.jgroups.blocks.AbstractConnectionMap
 
AbstractConnectionMap.ConnectionMapListener<V> - Interface in org.jgroups.blocks
 
acceptor - Variable in class org.jgroups.blocks.TCPConnectionMap
 
acceptor - Variable in class org.jgroups.protocols.BSH
 
acceptor - Variable in class org.jgroups.protocols.STOMP
 
access_key - Variable in class org.jgroups.protocols.S3_PING
 
accumulated_credits - Variable in class org.jgroups.util.CreditMap
 
ACK - Static variable in class org.jgroups.protocols.FORWARD_TO_COORD.ForwardHeader
 
ack(Address) - Method in class org.jgroups.protocols.RSVP.Entry
 
ACK - Static variable in class org.jgroups.protocols.UNICAST.UnicastHeader
 
ack(Address) - Method in class org.jgroups.util.AckCollector
 
ack(long) - Method in class org.jgroups.util.ForwardQueue
 
ack_collector - Variable in class org.jgroups.protocols.pbcast.GMS
To collect VIEW_ACKs from all members
ack_collector - Variable in class org.jgroups.protocols.RSVP.Entry
 
ack_mode - Variable in class org.jgroups.protocols.SEQUENCER
When ack_mode is set, we need to wait for an ack for each forwarded message until we can send the next one
ack_on_delivery - Variable in class org.jgroups.protocols.RSVP
 
ack_promise - Variable in class org.jgroups.protocols.SEQUENCER
Used for each resent message to wait until the message has been received
ack_promise - Variable in class org.jgroups.util.ForwardQueue
Used for each resent message to wait until the message has been received
AckCollector - Class in org.jgroups.util
Collects acks from a number of nodes, waits for all acks.
AckCollector() - Constructor for class org.jgroups.util.AckCollector
 
AckCollector(Collection<Address>) - Constructor for class org.jgroups.util.AckCollector
 
AckCollector(Address...) - Constructor for class org.jgroups.util.AckCollector
 
acquire(boolean) - Method in class org.jgroups.protocols.Locking.ClientLock
 
acquire() - Method in class org.jgroups.protocols.SCOPE.MessageQueue
 
acquired - Variable in class org.jgroups.protocols.Locking.ClientLock
 
acquireTryLock(long, boolean) - Method in class org.jgroups.protocols.Locking.ClientLock
 
actionPerformed(ActionEvent) - Method in class org.jgroups.demos.applets.DrawApplet
 
actionPerformed(ActionEvent) - Method in class org.jgroups.demos.Draw
 
actionPerformed(ActionEvent) - Method in class org.jgroups.demos.QuoteClient
 
actionPerformed(ActionEvent) - Method in class org.jgroups.demos.ReplCacheDemo
 
actionPerformed(ActionEvent) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
 
actionPerformed(ActionEvent) - Method in class org.jgroups.demos.StompDraw
 
actionPerformed(ActionEvent) - Method in class org.jgroups.demos.wb.MessageDialog
 
actionPerformed(ActionEvent) - Method in class org.jgroups.demos.wb.SendDialog
 
actionPerformed(ActionEvent) - Method in class org.jgroups.demos.wb.UserInfoDialog
 
actionPerformed(ActionEvent) - Method in class org.jgroups.demos.wb.Whiteboard
 
active - Variable in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
 
activeThreads() - Static method in class org.jgroups.util.Util
 
add(Address...) - Method in class org.jgroups.AnycastAddress
 
add(K, V) - Method in class org.jgroups.blocks.LazyRemovalCache
 
add(short, T) - Method in interface org.jgroups.blocks.mux.Muxer
Registers the specified handler to handle messages containing a mux header with the specified mux identifier.
add(short, UpHandler) - Method in class org.jgroups.blocks.mux.MuxUpHandler
Registers the specified handler to handle messages containing a mux header with the specified mux identifier.
add(short, Class) - Static method in class org.jgroups.conf.ClassConfigurator
Method to register a user-defined header with jg-magic-map at runtime
add(int, int) - Method in class org.jgroups.demos.JmxDemo
 
add(Address) - Method in class org.jgroups.Membership
Adds a new member to this membership.
add(Address...) - Method in class org.jgroups.Membership
 
add(Collection<Address>) - Method in class org.jgroups.Membership
Adds a list of members to this membership
add(COUNTER.ReconcileResponse, Address) - Method in class org.jgroups.protocols.COUNTER.ReconciliationTask
 
add(Message) - Method in class org.jgroups.protocols.SCOPE.MessageQueue
 
add(long, long) - Method in class org.jgroups.stack.DefaultRetransmitter
Add the given range [first_seqno, last_seqno] in the list of entries eligible for retransmission.
add(long, Message) - Method in class org.jgroups.stack.NakReceiverWindow
Adds a message according to its seqno (sequence number).
add(long, long) - Method in class org.jgroups.stack.RangeBasedRetransmitter
Add the given range [first_seqno, last_seqno] in the list of entries eligible for retransmission.
add(long, long) - Method in class org.jgroups.stack.Retransmitter
Add messages from first_seqno to last_seqno for retransmission
add(K) - Method in class org.jgroups.util.AgeOutCache
 
add(T) - Method in class org.jgroups.util.BoundedList
Adds an element at the tail.
add(Address, long, long) - Method in class org.jgroups.util.MutableDigest
 
add(Address, long, long, boolean) - Method in class org.jgroups.util.MutableDigest
 
add(Digest) - Method in class org.jgroups.util.MutableDigest
 
add(Digest, boolean) - Method in class org.jgroups.util.MutableDigest
 
add(Object) - Method in class org.jgroups.util.Queue
adds an object to the tail of this queue If the queue has been closed with close(true) no exception will be thrown if the queue has not been flushed yet.
add(Address, T) - Method in class org.jgroups.util.ResponseCollector
 
add(long, T) - Method in class org.jgroups.util.RingBuffer
 
add(long, T, boolean) - Method in class org.jgroups.util.RingBuffer
Adds a new element to the buffer
add(long, T) - Method in class org.jgroups.util.RingBufferLockless
 
add(long, T, boolean) - Method in class org.jgroups.util.RingBufferLockless
Adds a new element to the buffer
add(long) - Method in class org.jgroups.util.SeqnoList
Adds a single seqno
add(long...) - Method in class org.jgroups.util.SeqnoList
 
add(long, long) - Method in class org.jgroups.util.SeqnoList
Adds a seqno range
add(long, T) - Method in class org.jgroups.util.Table
Adds an element if the element at the given index is null.
add(TimeScheduler3.Task) - Method in class org.jgroups.util.TimeScheduler3
 
add(Address, String) - Static method in class org.jgroups.util.UUID
 
add(Map<Address, String>) - Static method in class org.jgroups.util.UUID
 
addAll(Collection<Address>) - Method in class org.jgroups.AnycastAddress
 
addAll(Address...) - Method in class org.jgroups.util.AckCollector
 
addAll(Collection<Address>) - Method in class org.jgroups.util.AckCollector
 
addAll(Collection) - Method in class org.jgroups.util.Queue
 
addAll(List<Object>) - Method in class org.jgroups.util.Queue
 
addAndGet(long) - Method in interface org.jgroups.blocks.atomic.Counter
Atomically adds the given value to the current value.
addAndGet(long) - Method in class org.jgroups.protocols.COUNTER.CounterImpl
 
addAndGet(long) - Method in class org.jgroups.protocols.COUNTER.VersionedValue
num == 0 --> GET
addAnycastSentDuration(long, int) - Method in class org.jgroups.protocols.tom.StatsCollector
 
addBridge(RelayConfig.BridgeConfig) - Method in class org.jgroups.protocols.relay.config.RelayConfig.SiteConfig
 
addChangeListener(Cache.ChangeListener) - Method in class org.jgroups.blocks.Cache
 
addChangeListener(ReplCache.ChangeListener) - Method in class org.jgroups.blocks.ReplCache
 
addChannelListener(ChannelListener) - Method in class org.jgroups.blocks.MessageDispatcher
Adds a new channel listener to be notified on the channel's state change.
addChannelListener(ChannelListener) - Method in class org.jgroups.Channel
Adds a ChannelListener instance that will be notified when a channel event such as connect, disconnect or close occurs.
addCondition(String) - Method in class org.jgroups.protocols.rules.SUPERVISOR
 
addConnection(Address, V) - Method in class org.jgroups.blocks.AbstractConnectionMap
 
addConnectionListener(BasicConnectionTable.ConnectionListener) - Method in class org.jgroups.blocks.BasicConnectionTable
 
addConnectionMapListener(AbstractConnectionMap.ConnectionMapListener<V>) - Method in class org.jgroups.blocks.AbstractConnectionMap
 
addConnectionMapListener(AbstractConnectionMap.ConnectionMapListener<TCPConnectionMap.TCPConnection>) - Method in class org.jgroups.blocks.TCPConnectionMap
 
addDataMessageDuration(long) - Method in class org.jgroups.protocols.tom.StatsCollector
 
addDestinations(Collection<Address>) - Method in class org.jgroups.protocols.tom.ToaHeader
 
addDigest(Digest) - Method in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
 
addExecutorListener(Future<?>, ExecutorNotification) - Method in class org.jgroups.protocols.Executing
 
addFinalSequenceNumberDuration(long) - Method in class org.jgroups.protocols.tom.StatsCollector
 
addFlush(Channel, FLUSH) - Static method in class org.jgroups.util.Util
 
addForward(RelayConfig.ForwardConfig) - Method in class org.jgroups.protocols.relay.config.RelayConfig.SiteConfig
 
addIfAbsent(T) - Method in class org.jgroups.util.BoundedList
 
addIfAbsentOrExpired(K) - Method in class org.jgroups.util.ExpiryCache
 
addIgnoreMember(Address) - Method in class org.jgroups.protocols.DISCARD
Messages from this sender will get dropped
addInitialHost(String, int) - Method in class org.jgroups.protocols.TCPGOSSIP
 
AdditionalDataUUID - Class in org.jgroups.util
Subclass of UUID which adds a string as payload.
AdditionalDataUUID() - Constructor for class org.jgroups.util.AdditionalDataUUID
 
AdditionalDataUUID(byte[], byte[]) - Constructor for class org.jgroups.util.AdditionalDataUUID
 
addListener(StompConnection.Listener) - Method in class org.jgroups.client.StompConnection
 
addLockListener(LockNotification) - Method in class org.jgroups.blocks.locking.LockService
 
addLockListener(LockNotification) - Method in class org.jgroups.protocols.Locking
 
addMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.PartitionedHashMap
 
addMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.ReplCache
 
addNewMessageToDeliver(MessageID, Message, long) - Method in class org.jgroups.protocols.tom.DeliveryManagerImpl
Add a new group message to be deliver
addNewMessageToSend(MessageID, Collection<Address>, long, boolean) - Method in class org.jgroups.protocols.tom.SenderManager
Add a new message sent
addNode(Object) - Method in class org.jgroups.demos.Topology
 
addNode(String, Address, int, int) - Method in class org.jgroups.demos.wb.GraphPanel
 
addNode(String, Address, int, int) - Method in class org.jgroups.demos.wb.Whiteboard
 
addNotifier(ReplicatedHashMap.Notification) - Method in class org.jgroups.blocks.ReplicatedHashMap
 
addNotReceived(Address) - Method in class org.jgroups.util.RspList
 
addPhysicalAddressToCache(Address, PhysicalAddress) - Method in class org.jgroups.protocols.TP
 
addPropose(MessageID, Address, long) - Method in class org.jgroups.protocols.tom.SenderManager
Add a propose from a member in destination set
addProposeSequenceNumberDuration(long, boolean) - Method in class org.jgroups.protocols.tom.StatsCollector
 
addProtocol(short, Class) - Static method in class org.jgroups.conf.ClassConfigurator
 
addProtocol(Protocol) - Method in class org.jgroups.stack.ProtocolStack
Adds a protocol at the tail of the protocol list
addProtocols(Protocol...) - Method in class org.jgroups.stack.ProtocolStack
Adds a list of protocols
addProtocols(List<Protocol>) - Method in class org.jgroups.stack.ProtocolStack
Adds a list of protocols
addr - Variable in class org.jgroups.demos.wb.Node
 
addr - Variable in class org.jgroups.util.SingletonAddress
 
addReplicatedTreeListener(ReplicatedTree.ReplicatedTreeListener) - Method in class org.jgroups.blocks.ReplicatedTree
 
addResponse(PingData) - Method in class org.jgroups.protocols.Discovery.Responses
 
addResponse(PingData, boolean) - Method in class org.jgroups.protocols.Discovery.Responses
 
Address - Interface in org.jgroups
Address identifies cluster member.
address - Variable in class org.jgroups.protocols.Executing.Owner
 
address - Variable in class org.jgroups.protocols.pbcast.STATE_SOCK.StateProviderAcceptor
 
address - Variable in class org.jgroups.util.DefaultThreadFactory
 
address - Variable in class org.jgroups.util.Owner
 
address_generator - Variable in class org.jgroups.JChannel
 
addressAsString(Address) - Static method in class org.jgroups.protocols.FILE_PING
 
addressAsString(Address) - Static method in class org.jgroups.protocols.PDC
 
AddressGenerator - Interface in org.jgroups.stack
Callback to provide custom addresses.
addRsp(Address, T) - Method in class org.jgroups.util.RspList
 
addSite(String, RelayConfig.SiteConfig) - Method in class org.jgroups.protocols.relay.RELAY2
 
addSuspect(Address) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
 
addSuspectedMember(Address) - Method in class org.jgroups.protocols.FD.Broadcaster
Adds a suspected member.
addSuspectedMember(Address) - Method in class org.jgroups.protocols.FD.BroadcastTask
 
addToCache(short, String) - Static method in class org.jgroups.protocols.relay.SiteUUID
 
addToQueue(byte[]) - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection.Sender
 
addToQueue(Locking.Request) - Method in class org.jgroups.protocols.Locking.ServerLock
 
addToRelayedTime(long) - Method in class org.jgroups.protocols.relay.RELAY2
 
addWaiter(Owner) - Method in class org.jgroups.protocols.Locking.ServerCondition
 
adjustCredit(Map<Address, FlowControl.Credit>, Address, int) - Method in class org.jgroups.protocols.FlowControl
Check whether sender has enough credits left.
adjustNodes(List<Address>) - Method in class org.jgroups.demos.wb.GraphPanel
 
adjustReceivers(List<Address>) - Method in class org.jgroups.protocols.pbcast.NAKACK2
Remove old members from the retransmission buffers.
adjustSuspectedMembers(List<Address>) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
Removes all elements from suspects that are not in the new membership
age() - Method in class org.jgroups.util.SuppressCache.Value
 
AgeOutCache<K> - Class in org.jgroups.util
Cache which removes its elements after a certain time
AgeOutCache(TimeScheduler, long) - Constructor for class org.jgroups.util.AgeOutCache
 
AgeOutCache(TimeScheduler, long, AgeOutCache.Handler) - Constructor for class org.jgroups.util.AgeOutCache
 
AgeOutCache.Handler<K> - Interface in org.jgroups.util
 
all - Variable in class org.jgroups.blocks.locking.AwaitInfo
 
all(Collection, Object) - Static method in class org.jgroups.util.Util
Returns true if all elements of c match obj
all_acks_received - Variable in class org.jgroups.util.AckCollector
 
ALL_TASK_CANCEL - Static variable in class org.jgroups.blocks.executor.ExecutorEvent
 
AnycastAddress - Class in org.jgroups
This type of address represents a subset of the cluster members in which the total order properties must be applied, e.g.
AnycastAddress() - Constructor for class org.jgroups.AnycastAddress
 
AnycastAddress(Collection<Address>) - Constructor for class org.jgroups.AnycastAddress
 
AnycastAddress(Address...) - Constructor for class org.jgroups.AnycastAddress
 
apiKey - Variable in class org.jgroups.protocols.RACKSPACE_PING
 
args - Variable in class org.jgroups.blocks.MethodCall
The arguments of the method.
array2String(long[]) - Static method in class org.jgroups.util.Util
 
array2String(short[]) - Static method in class org.jgroups.util.Util
 
array2String(int[]) - Static method in class org.jgroups.util.Util
 
array2String(boolean[]) - Static method in class org.jgroups.util.Util
 
array2String(Object[]) - Static method in class org.jgroups.util.Util
 
assertEquals(String, Object, Object) - Static method in class org.jgroups.util.Util
 
assertEquals(Object, Object) - Static method in class org.jgroups.util.Util
 
assertFalse(boolean) - Static method in class org.jgroups.util.Util
 
assertFalse(String, boolean) - Static method in class org.jgroups.util.Util
 
assertNotNull(String, Object) - Static method in class org.jgroups.util.Util
 
assertNotNull(Object) - Static method in class org.jgroups.util.Util
 
assertNull(String, Object) - Static method in class org.jgroups.util.Util
 
assertTrue(boolean) - Static method in class org.jgroups.util.Util
 
assertTrue(String, boolean) - Static method in class org.jgroups.util.Util
 
ASYNC() - Static method in class org.jgroups.blocks.RequestOptions
 
async_anycasts - Variable in class org.jgroups.blocks.MessageDispatcher
 
async_multicasts - Variable in class org.jgroups.blocks.MessageDispatcher
 
async_relay_creation - Variable in class org.jgroups.protocols.relay.RELAY2
 
async_unicasts - Variable in class org.jgroups.blocks.MessageDispatcher
 
asyncRelayCreation(boolean) - Method in class org.jgroups.protocols.relay.RELAY2
 
asyncRelayCreation() - Method in class org.jgroups.protocols.relay.RELAY2
 
attemptSchemaInitialization() - Method in class org.jgroups.protocols.JDBC_PING
 
attributeNameToMethodName(String) - Static method in class org.jgroups.util.Util
 
auth - Variable in class org.jgroups.auth.AuthToken
A reference to AUTH
AUTH - Class in org.jgroups.protocols
The AUTH protocol adds a layer of authentication to JGroups
AUTH() - Constructor for class org.jgroups.protocols.AUTH
 
AUTH.UpHandler - Interface in org.jgroups.protocols
Interface to provide callbacks for handling up events
auth_token - Variable in class org.jgroups.protocols.AUTH
Used on the coordinator to authentication joining member requests against
auth_type - Variable in class org.jgroups.protocols.SWIFT_PING
 
auth_url - Variable in class org.jgroups.protocols.SWIFT_PING
 
authenticate(AuthToken, Message) - Method in class org.jgroups.auth.AuthToken
This method should be implemented to perform the actual authentication of joining members.
authenticate(AuthToken, Message) - Method in class org.jgroups.auth.DemoToken
 
authenticate(AuthToken, Message) - Method in class org.jgroups.auth.FixedMembershipToken
 
authenticate(AuthToken, Message) - Method in class org.jgroups.auth.MD5Token
 
authenticate(AuthToken, Message) - Method in class org.jgroups.auth.RegexMembership
 
authenticate(AuthToken, Message) - Method in class org.jgroups.auth.SimpleToken
 
authenticate(AuthToken, Message) - Method in class org.jgroups.auth.X509Token
 
authenticate() - Method in class org.jgroups.protocols.SWIFT_PING.SwiftClient
Authenticate
AuthHeader - Class in org.jgroups.protocols
AuthHeader is a holder object for the token that is passed from the joiner to the coordinator
AuthHeader() - Constructor for class org.jgroups.protocols.AuthHeader
 
AuthHeader(AuthToken) - Constructor for class org.jgroups.protocols.AuthHeader
 
authorizeProbeRequest(DatagramPacket) - Method in class org.jgroups.stack.DiagnosticsHandler
Performs authorization on given DatagramPacket.
AuthToken - Class in org.jgroups.auth
Abstract AuthToken class used by implementations of AUTH, e.g.
AuthToken() - Constructor for class org.jgroups.auth.AuthToken
 
automatic_purging - Variable in class org.jgroups.util.RetransmitTable
By default, rows are only nulled and highest_seqno_purged is adjusted when RetransmitTable.purge(long) is called.
available() - Method in class org.jgroups.blocks.GridInputStream
 
available() - Method in class org.jgroups.util.BlockingInputStream
 
available() - Method in class org.jgroups.util.ExposedByteArrayInputStream
 
avg_state_size - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
await() - Method in class org.jgroups.protocols.Locking.ClientCondition
 
await(long, TimeUnit) - Method in class org.jgroups.protocols.Locking.ClientCondition
Note this wait will only work correctly if the converted value is less than 292 years.
await(boolean) - Method in class org.jgroups.protocols.Locking.ClientCondition
 
await(long) - Method in class org.jgroups.protocols.Locking.ClientCondition
 
awaited(String, Owner) - Method in interface org.jgroups.blocks.locking.LockNotification
 
awaited(String, Owner) - Method in class org.jgroups.demos.LockServiceDemo
 
awaited(String, Owner) - Method in class org.jgroups.protocols.CENTRAL_LOCK
 
AwaitInfo - Class in org.jgroups.blocks.locking
 
AwaitInfo(String, boolean) - Constructor for class org.jgroups.blocks.locking.AwaitInfo
 
awaiting(String, Owner) - Method in interface org.jgroups.blocks.locking.LockNotification
 
awaiting(String, Owner) - Method in class org.jgroups.demos.LockServiceDemo
 
awaiting(String, Owner) - Method in class org.jgroups.protocols.CENTRAL_LOCK
 
awaitNanos(long) - Method in class org.jgroups.protocols.Locking.ClientCondition
 
awaitTermination(long, TimeUnit) - Method in class org.jgroups.blocks.executor.ExecutionService
 
awaitUninterruptibly() - Method in class org.jgroups.protocols.Locking.ClientCondition
 
awaitUntil(Date) - Method in class org.jgroups.protocols.Locking.ClientCondition
 

B

backup_coords - Variable in class org.jgroups.protocols.COUNTER
Backup coordinators.
backups - Variable in class org.jgroups.protocols.CENTRAL_EXECUTOR
 
backups - Variable in class org.jgroups.protocols.CENTRAL_LOCK
 
BARRIER - Class in org.jgroups.protocols
All messages up the stack have to go through a barrier (read lock, RL).
BARRIER() - Constructor for class org.jgroups.protocols.BARRIER
 
barrier_closed - Variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER
Used to prevent spurious open and close barrier calls
barrier_closed - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
Used to prevent spurious open and close barrier calls
baseName - Variable in class org.jgroups.util.DefaultThreadFactory
 
BasicConnectionTable - Class in org.jgroups.blocks
Shared class for TCP connection tables.
BasicConnectionTable() - Constructor for class org.jgroups.blocks.BasicConnectionTable
 
BasicConnectionTable.ConnectionListener - Interface in org.jgroups.blocks
Used to be notified about connection establishment and teardown.
BasicConnectionTable.Receiver - Interface in org.jgroups.blocks
Used for message reception.
BasicTCP - Class in org.jgroups.protocols
Shared base class for TCP protocols
BasicTCP() - Constructor for class org.jgroups.protocols.BasicTCP
 
BCAST - Static variable in class org.jgroups.protocols.SEQUENCER.SequencerHeader
 
bcast_future - Variable in class org.jgroups.protocols.FD.Broadcaster
 
bcast_lock - Variable in class org.jgroups.protocols.FD.Broadcaster
 
bcast_msgs - Variable in class org.jgroups.protocols.SEQUENCER
 
bcast_task - Variable in class org.jgroups.protocols.FD
Transmits SUSPECT message until view change or UNSUSPECT is received
BECOME_SERVER - Static variable in class org.jgroups.Event
 
become_server_queue - Variable in class org.jgroups.protocols.pbcast.NAKACK
 
become_server_queue - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
become_server_queue_size - Variable in class org.jgroups.protocols.pbcast.NAKACK
 
become_server_queue_size - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
becomeClient() - Method in class org.jgroups.protocols.pbcast.GMS
 
becomeCoordinator() - Method in class org.jgroups.protocols.pbcast.GMS
 
becomeParticipant() - Method in class org.jgroups.protocols.pbcast.GMS
 
BELOW - Static variable in class org.jgroups.stack.ProtocolStack
 
bind_addr - Variable in class org.jgroups.blocks.TCPConnectionMap
 
BIND_ADDR - Static variable in class org.jgroups.Global
 
bind_addr - Variable in class org.jgroups.protocols.pbcast.STATE_SOCK
 
bind_addr - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
 
bind_addr - Variable in class org.jgroups.protocols.STOMP
 
bind_addr - Variable in class org.jgroups.protocols.TP
 
bind_addr - Variable in class org.jgroups.stack.RouterStub
 
BIND_INTERFACE - Static variable in class org.jgroups.Global
 
bind_interface_str - Variable in class org.jgroups.protocols.FD_ICMP
 
bind_interface_str - Variable in class org.jgroups.protocols.FD_SOCK
 
bind_interface_str - Variable in class org.jgroups.protocols.MPING
 
bind_interface_str - Variable in class org.jgroups.protocols.pbcast.STATE_SOCK
 
bind_interface_str - Variable in class org.jgroups.protocols.TP
 
bind_interface_str - Variable in class org.jgroups.protocols.VERIFY_SUSPECT
 
bind_interfaces - Variable in class org.jgroups.stack.DiagnosticsHandler
 
bind_port - Variable in class org.jgroups.protocols.BPING
 
bind_port - Variable in class org.jgroups.protocols.pbcast.STATE_SOCK
 
bind_port - Variable in class org.jgroups.protocols.TP
The port to which the transport binds.
bindToInterfaces(List<NetworkInterface>, MulticastSocket, InetAddress) - Method in class org.jgroups.protocols.UDP
 
bindToInterfaces(List<NetworkInterface>, MulticastSocket) - Method in class org.jgroups.stack.DiagnosticsHandler
 
block() - Method in class org.jgroups.blocks.PartitionedHashMap
 
block() - Method in class org.jgroups.blocks.PartitionedHashMap.ConsistentHashFunction
 
block() - Method in class org.jgroups.blocks.ReplCache
 
block() - Method in class org.jgroups.blocks.ReplicatedHashMap
Block sending and receiving of messages until ViewAccepted is called
block() - Method in class org.jgroups.demos.QuoteClient
 
block() - Method in class org.jgroups.demos.wb.Whiteboard
 
BLOCK - Static variable in class org.jgroups.Event
 
block() - Method in interface org.jgroups.MembershipListener
Called (usually by the FLUSH protocol), as an indication that the member should stop sending messages.
block(long) - Method in class org.jgroups.protocols.RSVP.Entry
 
block() - Method in class org.jgroups.protocols.SEQUENCER
 
block() - Method in class org.jgroups.ReceiverAdapter
Called (usually by the FLUSH protocol), as an indication that the member should stop sending messages.
block() - Method in class org.jgroups.util.ForwardQueue
 
block(long) - Method in class org.jgroups.util.RingBuffer
 
block(long) - Method in class org.jgroups.util.RingBufferLockless
 
block_for_results - Variable in class org.jgroups.blocks.Request
 
block_time - Variable in class org.jgroups.auth.DemoToken
 
BlockingInputStream - Class in org.jgroups.util
Bounded input stream.
BlockingInputStream() - Constructor for class org.jgroups.util.BlockingInputStream
 
BlockingInputStream(int) - Constructor for class org.jgroups.util.BlockingInputStream
 
BLOCKS_START_ID - Static variable in class org.jgroups.Global
First ID assigned for building blocks (defined in jg-protocols.xml)
bold(String) - Static method in class org.jgroups.util.Util
 
BoundedList<T> - Class in org.jgroups.util
A bounded subclass of LinkedList, oldest elements are removed once max capacity is exceeded.
BoundedList() - Constructor for class org.jgroups.util.BoundedList
 
BoundedList(int) - Constructor for class org.jgroups.util.BoundedList
 
BPING - Class in org.jgroups.protocols
Broadcast PING.
BPING() - Constructor for class org.jgroups.protocols.BPING
 
BPING_BIND_PORT - Static variable in class org.jgroups.Global
 
break_on_coord_rsp - Variable in class org.jgroups.protocols.Discovery
 
bridge - Variable in class org.jgroups.protocols.RELAY
The bridge between the two local clusters, usually based on a TCP config
BRIDGE - Static variable in class org.jgroups.protocols.relay.config.RelayConfig
 
bridge() - Method in class org.jgroups.protocols.relay.Relayer.Route
 
bridge(JChannel) - Method in class org.jgroups.protocols.relay.Relayer.Route
 
bridge_name - Variable in class org.jgroups.protocols.RELAY
 
bridge_props - Variable in class org.jgroups.protocols.RELAY
 
bridge_view - Variable in class org.jgroups.protocols.RELAY
The view of the bridge cluster, usually consists of max 2 nodes
BRIDGES - Static variable in class org.jgroups.protocols.relay.config.RelayConfig
 
bridges - Variable in class org.jgroups.protocols.relay.config.RelayConfig.SiteConfig
 
bridges - Variable in class org.jgroups.protocols.relay.Relayer
The bridges which are used to connect to different sites
broadcast(Message, boolean, Address, long, boolean) - Method in class org.jgroups.protocols.SEQUENCER
 
broadcastEndpoint() - Method in class org.jgroups.protocols.STOMP
 
BSH - Class in org.jgroups.protocols
Beanshell (www.beanshell.org) interpreter class.
BSH() - Constructor for class org.jgroups.protocols.BSH
 
buf - Variable in class org.jgroups.Message
The payload
buf - Variable in class org.jgroups.util.BlockingInputStream
The transfer buffer
buf - Variable in class org.jgroups.util.RingBuffer
Atomic ref array so that elements can be checked for null and set atomically
buf - Variable in class org.jgroups.util.RingBufferLockless
Atomic ref array so that elements can be checked for null and set atomically
buffer - Variable in class org.jgroups.demos.ExecutionServiceDemo.ByteBufferStreamable
 
buffer - Variable in class org.jgroups.demos.ExecutionServiceDemo.SortingByteCallable
 
Buffer - Class in org.jgroups.util
Buffer with an offset and length.
Buffer(byte[], int, int) - Constructor for class org.jgroups.util.Buffer
 
Buffer(byte[]) - Constructor for class org.jgroups.util.Buffer
 
buffer - Variable in class org.jgroups.util.RingBuffer.RingBufferIterator
 
buffer - Variable in class org.jgroups.util.RingBufferLockless.RingBufferIterator
 
buffer - Variable in class org.jgroups.util.StateTransferResult
 
buffer_full - Variable in class org.jgroups.util.RingBuffer
 
buffer_full - Variable in class org.jgroups.util.RingBufferLockless
 
buffer_size - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
bundler - Variable in class org.jgroups.protocols.TP
 
bundler_capacity - Variable in class org.jgroups.protocols.TP
 
bundler_type - Variable in class org.jgroups.protocols.TP
 
bypass - Variable in class org.jgroups.protocols.pbcast.FLUSH
 
bypass_bundling - Variable in class org.jgroups.protocols.COUNTER
 
bypass_bundling - Variable in class org.jgroups.protocols.Executing
 
bypass_bundling - Variable in class org.jgroups.protocols.Locking
 
BYTE_SIZE - Static variable in class org.jgroups.Global
 
byteArrayToHexString(byte[]) - Static method in class org.jgroups.protocols.ENCRYPT
 
byteBufferToMessage(byte[], int, int) - Static method in class org.jgroups.util.Util
 
BYTEMAN - Static variable in class org.jgroups.Global
 
bytes1 - Variable in class org.jgroups.demos.ExecutionServiceDemo.SortingTwoByteCallable
 
bytes2 - Variable in class org.jgroups.demos.ExecutionServiceDemo.SortingTwoByteCallable
 
bytesWrittenCounter - Variable in class org.jgroups.protocols.pbcast.STATE.StateOutputStream
 

C

Cache<K,V> - Class in org.jgroups.blocks
Simple cache which maintains keys and value.
Cache() - Constructor for class org.jgroups.blocks.Cache
 
cache - Variable in class org.jgroups.protocols.PDC
 
cache - Variable in class org.jgroups.protocols.UNICAST
 
cache - Variable in class org.jgroups.protocols.UNICAST2
 
cache - Variable in class org.jgroups.util.SuppressLog
 
cache - Static variable in class org.jgroups.util.UUID
Keeps track of associations between logical addresses (UUIDs) and logical names
Cache.ChangeListener - Interface in org.jgroups.blocks
 
Cache.Value<V> - Class in org.jgroups.blocks
 
Cache.Value(V, long) - Constructor for class org.jgroups.blocks.Cache.Value
 
Cache.Value() - Constructor for class org.jgroups.blocks.Cache.Value
 
cache_dir - Variable in class org.jgroups.protocols.PDC
 
cacheValues() - Static method in class org.jgroups.protocols.relay.SiteUUID
 
call() - Method in class org.jgroups.blocks.executor.Executions.StreamableCallable
 
call() - Method in class org.jgroups.blocks.executor.ExecutionService.RunnableAdapter
 
call() - Method in class org.jgroups.demos.ExecutionServiceDemo.SortingByteCallable
 
call() - Method in class org.jgroups.demos.ExecutionServiceDemo.SortingTwoByteCallable
 
call_options - Variable in class org.jgroups.blocks.ReplicatedHashMap
 
callable - Variable in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture.Sync
The underlying callable
callRemoteMethod(Address, String, Object[], Class[], RequestOptions) - Method in class org.jgroups.blocks.RpcDispatcher
Invokes a method in a cluster member and - if blocking - returns the result
callRemoteMethod(Address, MethodCall, RequestOptions) - Method in class org.jgroups.blocks.RpcDispatcher
Invokes a method in a cluster member and - if blocking - returns the result
callRemoteMethods(Collection<Address>, String, Object[], Class[], RequestOptions) - Method in class org.jgroups.blocks.RpcDispatcher
Invokes a method in all members and expects responses from members contained in dests (or all members if dests is null).
callRemoteMethods(Collection<Address>, MethodCall, RequestOptions) - Method in class org.jgroups.blocks.RpcDispatcher
Invokes a method in all members and expects responses from members contained in dests (or all members if dests is null).
callRemoteMethodsWithFuture(Collection<Address>, MethodCall, RequestOptions) - Method in class org.jgroups.blocks.RpcDispatcher
Invokes a method in all members and expects responses from members contained in dests (or all members if dests is null).
callRemoteMethodWithFuture(Address, MethodCall, RequestOptions) - Method in class org.jgroups.blocks.RpcDispatcher
Invokes a method in a cluster member and - if blocking - returns the result
callRetransmissionCommand() - Method in class org.jgroups.stack.DefaultRetransmitter.SeqnoTask
 
callRetransmissionCommand() - Method in class org.jgroups.stack.RangeBasedRetransmitter.RangeTask
 
callRetransmissionCommand() - Method in class org.jgroups.stack.Retransmitter.Task
 
callUpHandlers(Event) - Method in class org.jgroups.protocols.AUTH
 
can_become_site_master - Variable in class org.jgroups.protocols.relay.CanBeSiteMaster
 
can_become_site_master - Variable in class org.jgroups.protocols.relay.CanBeSiteMasterTopology
 
can_become_site_master - Variable in class org.jgroups.protocols.relay.RELAY2
 
can_bind_to_mcast_addr - Static variable in class org.jgroups.protocols.TP
 
canBecomeSiteMaster() - Method in class org.jgroups.protocols.relay.CanBeSiteMaster
 
canBecomeSiteMaster() - Method in class org.jgroups.protocols.relay.CanBeSiteMasterTopology
 
canBecomeSiteMaster(boolean) - Method in class org.jgroups.protocols.relay.RELAY2
 
canBecomeSiteMaster() - Method in class org.jgroups.protocols.relay.RELAY2
 
canBeProcessedTogether(GmsImpl.Request) - Method in class org.jgroups.protocols.pbcast.GmsImpl.Request
Specifies whether this request can be processed with other request simultaneously
CanBeSiteMaster - Class in org.jgroups.protocols.relay
Subclass of UUID which adds a boolean as payload.
CanBeSiteMaster() - Constructor for class org.jgroups.protocols.relay.CanBeSiteMaster
 
CanBeSiteMaster(byte[], boolean) - Constructor for class org.jgroups.protocols.relay.CanBeSiteMaster
 
CanBeSiteMaster(UUID, boolean) - Constructor for class org.jgroups.protocols.relay.CanBeSiteMaster
 
CanBeSiteMasterTopology - Class in org.jgroups.protocols.relay
Subclass of TopologyUUID which adds a boolean as payload.
CanBeSiteMasterTopology() - Constructor for class org.jgroups.protocols.relay.CanBeSiteMasterTopology
 
CanBeSiteMasterTopology(TopologyUUID, boolean) - Constructor for class org.jgroups.protocols.relay.CanBeSiteMasterTopology
 
cancel(boolean) - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
 
cancel(boolean) - Method in class org.jgroups.blocks.Request
 
cancel() - Method in class org.jgroups.protocols.COUNTER.ReconciliationTask
 
cancel() - Method in class org.jgroups.stack.Retransmitter.Task
 
cancel(boolean) - Method in class org.jgroups.util.DefaultTimeScheduler.TaskWrapper
 
cancel(boolean) - Method in class org.jgroups.util.HashedTimingWheel.MyTask
 
cancel(boolean) - Method in class org.jgroups.util.NullFuture
 
cancel(boolean) - Method in class org.jgroups.util.TimeScheduler2.MyTask
 
cancel(boolean) - Method in class org.jgroups.util.TimeScheduler3.Task
 
CANCEL_MERGE - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
CANCELLED - Static variable in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture.Sync
State value representing that task was cancelled
cancelled - Variable in class org.jgroups.stack.Retransmitter.Task
 
cancelled - Variable in class org.jgroups.util.HashedTimingWheel.MyTask
 
cancelled - Variable in class org.jgroups.util.TimeScheduler2.MyTask
 
cancelled - Variable in class org.jgroups.util.TimeScheduler3.Task
 
cancelMerge() - Method in class org.jgroups.protocols.pbcast.GMS
 
cancelRebroadcasting() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
cancelTask(short) - Method in class org.jgroups.protocols.relay.Relayer.Bridge
 
cancelTask() - Method in class org.jgroups.protocols.RSVP.Entry
 
canDeliver(Address, long) - Method in class org.jgroups.protocols.SEQUENCER
Checks if seqno has already been received from sender.
canDeliver(Address, long) - Method in class org.jgroups.util.ForwardQueue
Checks if seqno has already been received from sender.
canRun() - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection.ConnectionPeerReceiver
 
canRun() - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection.Sender
 
cap - Variable in class org.jgroups.protocols.pbcast.STABLE
 
capacity() - Method in class org.jgroups.util.BlockingInputStream
 
capacity() - Method in class org.jgroups.util.Headers
 
capacity() - Method in class org.jgroups.util.RetransmitTable
Returns the total capacity in the matrix
capacity() - Method in class org.jgroups.util.RingBuffer
 
capacity() - Method in class org.jgroups.util.RingBufferLockless
 
capacity() - Method in class org.jgroups.util.Table
Returns the total capacity in the matrix
cardinality() - Method in class org.jgroups.util.FixedSizeBitSet
Returns the number of bits set to true in this bit set
cast(Collection<Address>, Message, RequestOptions, boolean) - Method in class org.jgroups.blocks.MessageDispatcher
 
cast(Collection<Address>, Message, RequestOptions, boolean) - Method in class org.jgroups.blocks.mux.MuxMessageDispatcher
 
cast(Collection<Address>, Message, RequestOptions, boolean) - Method in class org.jgroups.blocks.mux.MuxRpcDispatcher
 
castMessage(Collection<Address>, Message, RequestOptions) - Method in class org.jgroups.blocks.MessageDispatcher
Sends a message to all members and expects responses from members in dests (if non-null).
castMessageWithFuture(Collection<Address>, Message, RequestOptions) - Method in class org.jgroups.blocks.MessageDispatcher
Sends a message to all members and expects responses from members in dests (if non-null).
castViewChange(View, Digest, JoinRsp, Collection<Address>) - Method in class org.jgroups.protocols.pbcast.GMS
Broadcasts the new view and digest, and waits for acks from all members in the list given as argument.
CCHM_CONCURRENCY_LEVEL - Static variable in class org.jgroups.Global
 
CCHM_CONCURRENCY_LEVEL - Static variable in class org.jgroups.util.Util
 
CCHM_INITIAL_CAPACITY - Static variable in class org.jgroups.Global
 
CCHM_INITIAL_CAPACITY - Static variable in class org.jgroups.util.Util
 
CCHM_LOAD_FACTOR - Static variable in class org.jgroups.Global
 
CCHM_LOAD_FACTOR - Static variable in class org.jgroups.util.Util
 
CENTRAL_EXECUTOR - Class in org.jgroups.protocols
This is a central executor service where each request is sent to the coordinator for either a task or a current waiting thread.
CENTRAL_EXECUTOR() - Constructor for class org.jgroups.protocols.CENTRAL_EXECUTOR
 
CENTRAL_LOCK - Class in org.jgroups.protocols
Implementation of a locking protocol which acquires locks by contacting the coordinator.
CENTRAL_LOCK() - Constructor for class org.jgroups.protocols.CENTRAL_LOCK
 
CERT_ALIAS - Static variable in class org.jgroups.auth.X509Token
 
CERT_PASSWORD - Static variable in class org.jgroups.auth.X509Token
 
ch - Variable in class org.jgroups.blocks.atomic.CounterService
 
ch - Variable in class org.jgroups.blocks.executor.ExecutionRunner
 
ch - Variable in class org.jgroups.blocks.executor.ExecutionService
 
ch - Variable in class org.jgroups.blocks.locking.LockService
 
ch - Variable in class org.jgroups.demos.ExecutionServiceDemo
 
ch - Variable in class org.jgroups.demos.LockServiceDemo
 
ch - Variable in class org.jgroups.demos.RelayDemoRpc
 
CHALLENGE - Static variable in class org.jgroups.auth.DemoToken.DemoHeader
 
challenge - Variable in class org.jgroups.auth.DemoToken.Entry
 
changed() - Method in interface org.jgroups.blocks.Cache.ChangeListener
 
changed() - Method in class org.jgroups.blocks.ReplCache
 
changed() - Method in interface org.jgroups.blocks.ReplCache.ChangeListener
 
changeStatusToDown(short) - Method in class org.jgroups.protocols.relay.Relayer.Bridge
 
changeStatusToUnknown(short) - Method in class org.jgroups.protocols.relay.Relayer.Bridge
 
changeStatusToUp(short, JChannel, Address) - Method in class org.jgroups.protocols.relay.Relayer.Bridge
 
channel - Variable in class org.jgroups.blocks.MessageDispatcher
 
Channel - Class in org.jgroups
A channel represents a group communication endpoint (like BSD datagram sockets).
Channel() - Constructor for class org.jgroups.Channel
 
channel - Variable in class org.jgroups.protocols.relay.Relayer.Bridge
 
Channel.State - Enum in org.jgroups
 
channel_listeners - Variable in class org.jgroups.blocks.MessageDispatcher
 
channel_listeners - Variable in class org.jgroups.Channel
 
channel_name - Variable in class org.jgroups.protocols.TP
The name of the group to which this member is connected.
channel_name - Variable in class org.jgroups.protocols.TpHeader
 
channelClosed(Channel) - Method in class org.jgroups.blocks.MessageDispatcher
 
channelClosed(Channel) - Method in interface org.jgroups.ChannelListener
Channel has been closed notification callback
channelClosed(Channel) - Method in class org.jgroups.demos.Draw
 
channelConnected(Channel) - Method in class org.jgroups.blocks.MessageDispatcher
 
channelConnected(Channel) - Method in interface org.jgroups.ChannelListener
Channel has been connected notification callback
channelConnected(Channel) - Method in class org.jgroups.demos.Draw
 
channelDisconnected(Channel) - Method in class org.jgroups.blocks.MessageDispatcher
 
channelDisconnected(Channel) - Method in interface org.jgroups.ChannelListener
Channel has been disconnected notification callback
channelDisconnected(Channel) - Method in class org.jgroups.demos.Draw
 
ChannelListener - Interface in org.jgroups
Allows a listener to be notified when an important channel lifecycle event occurs.
Chat - Class in org.jgroups.demos
 
Chat() - Constructor for class org.jgroups.demos.Chat
 
check_interval - Variable in class org.jgroups.protocols.MERGE3
 
checkClosed() - Method in class org.jgroups.JChannel
health check
throws a ChannelClosed exception if the channel is closed
checkClosedOrNotConnected() - Method in class org.jgroups.JChannel
 
checkCompletion(Future) - Method in class org.jgroups.blocks.Request
 
checkConnection() - Method in class org.jgroups.stack.RouterStub
Checks whether the connection is open
CheckFDMonitor - Class in org.jgroups.protocols.rules
Rule which checks if the FD monitor is running when we have more than 1 member.
CheckFDMonitor() - Constructor for class org.jgroups.protocols.rules.CheckFDMonitor
 
checkForHp() - Static method in class org.jgroups.util.Util
 
checkForLinux() - Static method in class org.jgroups.util.Util
 
checkForMac() - Static method in class org.jgroups.util.Util
 
checkForRebroadcasts() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
checkForRebroadcasts() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
checkForSolaris() - Static method in class org.jgroups.util.Util
 
checkForWindows() - Static method in class org.jgroups.util.Util
 
checkIfValidAddress(InetAddress, String) - Static method in class org.jgroups.util.Util
 
checkParentDirs(String, boolean) - Method in class org.jgroups.blocks.GridFile
Checks whether the parent directories are present (and are directories).
checkSealed() - Method in class org.jgroups.util.MutableDigest
 
CIPHER_TYPE - Static variable in class org.jgroups.auth.X509Token
 
CLASS - Static variable in class org.jgroups.protocols.rules.SUPERVISOR
 
ClassConfigurator - Class in org.jgroups.conf
This class will be replaced with the class that read info from the magic number configurator that reads info from the xml file.
ClassConfigurator() - Constructor for class org.jgroups.conf.ClassConfigurator
 
clear() - Method in class org.jgroups.blocks.AbstractConnectionMap
 
clear(boolean) - Method in class org.jgroups.blocks.LazyRemovalCache
 
clear() - Method in class org.jgroups.blocks.ReplCache
Removes all keys and values in the L2 and L1 caches
clear() - Method in class org.jgroups.blocks.ReplicatedHashMap
Removes all of the mappings from this map.
clear() - Method in class org.jgroups.Membership
Removes all the members from this membership
clear() - Method in class org.jgroups.protocols.SCOPE.MessageQueue
 
clear() - Method in class org.jgroups.protocols.tom.DeliveryManagerImpl
remove all the pending messages
clear() - Method in class org.jgroups.protocols.tom.SenderManager
removes all pending messages
clear() - Method in class org.jgroups.stack.GossipRouter
 
clear() - Method in class org.jgroups.util.AgeOutCache
 
clear() - Method in class org.jgroups.util.CreditMap
 
clear() - Method in class org.jgroups.util.ExpiryCache
 
clear(int) - Method in class org.jgroups.util.FixedSizeBitSet
Sets the bit specified by the index to false.
clear() - Method in class org.jgroups.util.MutableDigest
 
clear() - Method in class org.jgroups.util.Queue
Removes all elements from the queue.
clear() - Method in class org.jgroups.util.RetransmitTable
Removes all elements.
clear() - Method in class org.jgroups.util.RspList
 
clear(long) - Method in class org.jgroups.util.Seqno
 
clear(long) - Method in class org.jgroups.util.SeqnoRange
 
clear(long...) - Method in class org.jgroups.util.SeqnoRange
 
clear() - Method in class org.jgroups.util.SuppressCache
 
clearAllFragments() - Method in class org.jgroups.protocols.FRAG2
 
clearCache() - Static method in class org.jgroups.protocols.relay.SiteUUID
 
clearChannelListeners() - Method in class org.jgroups.Channel
Clears all installed ChannelListener instances
clearDifferentClusterCache() - Method in class org.jgroups.protocols.TP
 
clearDifferentVersionCache() - Method in class org.jgroups.protocols.TP
 
clearDynamicHostList() - Method in class org.jgroups.protocols.TCPPING
 
clearFlag(Message.Flag...) - Method in class org.jgroups.Message
Clears a number of flags in a message
clearFlags(Message.Flag...) - Method in class org.jgroups.blocks.RequestOptions
 
clearFlags(byte, byte) - Static method in class org.jgroups.util.Util
 
clearFragmentsFor(Address) - Method in class org.jgroups.protocols.FRAG2
 
clearLogicalAddressCache() - Method in class org.jgroups.protocols.TP
Clears the cache.
clearNonMemberCache() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
clearNonMemberCache() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
clearPanel() - Method in class org.jgroups.demos.applets.DrawApplet
 
clearPanel() - Method in class org.jgroups.demos.Draw
 
clearPanel() - Method in class org.jgroups.demos.StompDraw
 
clearQueue(Address) - Method in class org.jgroups.protocols.SCOPE
 
clearStats() - Method in class org.jgroups.protocols.tom.StatsCollector
 
clearTransientFlag(Message.TransientFlag...) - Method in class org.jgroups.Message
 
clearViews() - Method in class org.jgroups.protocols.MERGE3
 
CLIENT - Static variable in class org.jgroups.demos.StompChat
 
client_bind_addr - Variable in class org.jgroups.blocks.TCPConnectionMap
 
client_bind_addr - Variable in class org.jgroups.protocols.BasicTCP
 
client_bind_port - Variable in class org.jgroups.blocks.TCPConnectionMap
 
client_bind_port - Variable in class org.jgroups.protocols.BasicTCP
 
CLIENT_JOINED - Static variable in class org.jgroups.demos.StompChat
 
CLIENT_LEFT - Static variable in class org.jgroups.demos.StompChat
 
client_locks - Variable in class org.jgroups.protocols.Locking
 
clientBindAddress() - Method in class org.jgroups.blocks.TCPConnectionMap
 
clientBindAddress(InetAddress) - Method in class org.jgroups.blocks.TCPConnectionMap
 
clientBindPort() - Method in class org.jgroups.blocks.TCPConnectionMap
 
clientBindPort(int) - Method in class org.jgroups.blocks.TCPConnectionMap
 
ClientGmsImpl - Class in org.jgroups.protocols.pbcast
Client part of GMS.
ClientGmsImpl(GMS) - Constructor for class org.jgroups.protocols.pbcast.ClientGmsImpl
 
CLIENTS - Static variable in class org.jgroups.demos.StompChat
 
clients_dest - Static variable in class org.jgroups.demos.StompDraw
 
CLIENTS_KW - Static variable in class org.jgroups.demos.StompChat
 
clone() - Method in class org.jgroups.blocks.ReplicatedTree.Node
 
clone() - Method in class org.jgroups.protocols.tom.MessageID
 
close() - Method in interface org.jgroups.blocks.Connection
 
close() - Method in class org.jgroups.blocks.GridInputStream
 
close() - Method in class org.jgroups.blocks.GridOutputStream
 
close() - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
 
close() - Method in class org.jgroups.Channel
Destroys the channel and its associated resources (e.g., the protocol stack).
close() - Method in class org.jgroups.JChannel
 
close() - Method in class org.jgroups.protocols.pbcast.STATE.StateOutputStream
 
CLOSE - Static variable in class org.jgroups.stack.GossipRouter
 
close() - Method in class org.jgroups.util.BlockingInputStream
Closes the stream.
close(Socket) - Method in class org.jgroups.util.DefaultSocketFactory
 
close(ServerSocket) - Method in class org.jgroups.util.DefaultSocketFactory
 
close(DatagramSocket) - Method in class org.jgroups.util.DefaultSocketFactory
 
close() - Method in class org.jgroups.util.ExposedByteArrayInputStream
 
close(boolean) - Method in class org.jgroups.util.Queue
Marks the queues as closed.
close(Socket) - Method in interface org.jgroups.util.SocketFactory
 
close(ServerSocket) - Method in interface org.jgroups.util.SocketFactory
 
close(DatagramSocket) - Method in interface org.jgroups.util.SocketFactory
 
close(InputStream) - Static method in class org.jgroups.util.Util
 
close(OutputStream) - Static method in class org.jgroups.util.Util
 
close(Socket) - Static method in class org.jgroups.util.Util
 
close(ServerSocket) - Static method in class org.jgroups.util.Util
 
close(DatagramSocket) - Static method in class org.jgroups.util.Util
 
close(Channel) - Static method in class org.jgroups.util.Util
 
close(Channel...) - Static method in class org.jgroups.util.Util
 
close(Connection) - Static method in class org.jgroups.util.Util
 
CLOSE_BARRIER - Static variable in class org.jgroups.Event
 
closeBarrierAndSuspendStable() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
closeBarrierAndSuspendStable() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
closeConnection(Connection) - Method in class org.jgroups.protocols.JDBC_PING
 
closeConnections() - Method in class org.jgroups.client.StompConnection
 
closed - Variable in class org.jgroups.protocols.pbcast.STATE.StateOutputStream
 
closed - Variable in class org.jgroups.util.BlockingInputStream
Set to true when BlockingInputStream.close() is called
closed() - Method in class org.jgroups.util.Queue
returns true if the Queue has been closed however, this method will return false if the queue has been closed using the close(true) method and the last element has yet not been received.
closeUnicastSocket() - Method in class org.jgroups.protocols.UDP
 
cluster_name - Variable in class org.jgroups.JChannel
 
cluster_name - Variable in class org.jgroups.protocols.MERGE3
 
cluster_name - Variable in class org.jgroups.protocols.PingHeader
 
cluster_name - Variable in class org.jgroups.protocols.relay.config.RelayConfig.BridgeConfig
 
cluster_name - Variable in class org.jgroups.protocols.relay.Relayer.Bridge
 
cluster_name - Variable in class org.jgroups.protocols.SCOPE
 
cluster_name - Variable in class org.jgroups.util.SingletonAddress
 
clusterName - Variable in class org.jgroups.util.DefaultThreadFactory
 
cmd - Variable in class org.jgroups.stack.Retransmitter
 
collectionToByteBuffer(Collection<Address>) - Static method in class org.jgroups.util.Util
 
command - Variable in class org.jgroups.stack.Retransmitter.Task
 
compact() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
compact() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
compact() - Method in class org.jgroups.stack.NakReceiverWindow
 
compact() - Method in class org.jgroups.util.BlockingInputStream
Moves the bytes between [read_pos and write_pos] read_pos bytes to the left, such that the new read_pos is 0 and the write_pos is write_pos - read_pos.
compact() - Method in class org.jgroups.util.RetransmitTable
Moves the contents of matrix down by the number of purged rows and resizes the matrix accordingly.
compact() - Method in class org.jgroups.util.Table
 
compare(Seqno, Seqno) - Method in class org.jgroups.util.SeqnoComparator
 
compareAndSet(long, long) - Method in interface org.jgroups.blocks.atomic.Counter
Atomically updates the counter using a CAS operation
compareAndSet(long, long) - Method in class org.jgroups.protocols.COUNTER.CounterImpl
 
compareAndSet(long, long) - Method in class org.jgroups.protocols.COUNTER.VersionedValue
 
compareTo(Address) - Method in class org.jgroups.AnycastAddress
 
compareTo(Address) - Method in class org.jgroups.protocols.relay.SiteMaster
 
compareTo(MessageID) - Method in class org.jgroups.protocols.tom.MessageID
 
compareTo(Delayed) - Method in class org.jgroups.protocols.VERIFY_SUSPECT.Entry
 
compareTo(Address) - Method in class org.jgroups.stack.IpAddress
implements the java.lang.Comparable interface
compareTo(Range) - Method in class org.jgroups.util.Range
 
compareTo(Address) - Method in class org.jgroups.util.SingletonAddress
 
compareTo(Delayed) - Method in class org.jgroups.util.TimeScheduler3.Task
 
compareTo(Address) - Method in class org.jgroups.util.UUID
Compares this UUID with the specified UUID.
compareTo(View) - Method in class org.jgroups.View
 
compareTo(ViewId) - Method in class org.jgroups.ViewId
Establishes an order between 2 ViewIds.
compareToIDs(ViewId) - Method in class org.jgroups.ViewId
Establishes an order between 2 ViewIds.
completed - Variable in class org.jgroups.blocks.Request
Is set as soon as the request has received all required responses
completionQueue - Variable in class org.jgroups.blocks.executor.ExecutionCompletionService
 
componentHidden(ComponentEvent) - Method in class org.jgroups.demos.wb.Whiteboard
 
componentMoved(ComponentEvent) - Method in class org.jgroups.demos.wb.Whiteboard
 
componentResized(ComponentEvent) - Method in class org.jgroups.demos.wb.Whiteboard
 
components(String, String) - Static method in class org.jgroups.util.Util
 
componentShown(ComponentEvent) - Method in class org.jgroups.demos.wb.Whiteboard
 
COMPRESS - Class in org.jgroups.protocols
Compresses the payload of a message.
COMPRESS() - Constructor for class org.jgroups.protocols.COMPRESS
 
COMPRESS.CompressHeader - Class in org.jgroups.protocols
 
COMPRESS.CompressHeader() - Constructor for class org.jgroups.protocols.COMPRESS.CompressHeader
 
COMPRESS.CompressHeader(int) - Constructor for class org.jgroups.protocols.COMPRESS.CompressHeader
 
computeCheckInterval() - Method in class org.jgroups.protocols.MERGE3
 
computeFragOffsets(int, int, int) - Static method in class org.jgroups.util.Util
Given a buffer and a fragmentation size, compute a list of fragmentation offset/length pairs, and return them in a list.
computeFragOffsets(byte[], int) - Static method in class org.jgroups.util.Util
 
computeIndex(long) - Method in class org.jgroups.util.RetransmitTable
Computes and returns the index within a row for seqno
computeIndex(long) - Method in class org.jgroups.util.Table
Computes and returns the index within a row for seqno
computeInterval() - Method in class org.jgroups.protocols.MERGE2.FindSubgroupsTask
Returns a random value within [min_interval - max_interval]
computeLowestCredit() - Method in class org.jgroups.util.CreditMap
Needs to be called with lock held
computeLowestCreditWithAccumulated() - Method in class org.jgroups.util.CreditMap
 
computePingDest(Address) - Method in class org.jgroups.protocols.FD
Computes pingable_mbrs (based on the current membership and the suspected members) and ping_dest
computeRow(long) - Method in class org.jgroups.util.RetransmitTable
Computes and returns the row index for seqno
computeRow(long) - Method in class org.jgroups.util.Table
Computes and returns the row index for seqno.
computeSize() - Method in class org.jgroups.util.RetransmitTable
Iterate from highest_seqno_purged to highest_seqno and add up non-null values
computeSize() - Method in class org.jgroups.util.Table
Iterate from low to hr and add up non-null values.
ConcurrentLinkedBlockingQueue<T> - Class in org.jgroups.util
Attempt at writing a fast transfer queue, which is bounded.
ConcurrentLinkedBlockingQueue(int) - Constructor for class org.jgroups.util.ConcurrentLinkedBlockingQueue
 
condition - Variable in class org.jgroups.protocols.Locking.ClientLock
 
condition - Variable in class org.jgroups.protocols.Locking.ServerLock
 
condition() - Method in class org.jgroups.protocols.rules.CheckFDMonitor
 
condition() - Method in class org.jgroups.protocols.rules.Rule
Returns a description of the condition that led to Rule.eval() returning true
condition() - Method in class org.jgroups.protocols.rules.SampleRule
 
CONFIG - Static variable in class org.jgroups.Event
 
config - Variable in class org.jgroups.JChannel
 
config - Variable in class org.jgroups.protocols.relay.config.RelayConfig.PropertiesBridgeConfig
 
config - Variable in class org.jgroups.protocols.relay.RELAY2
 
config(String) - Method in class org.jgroups.protocols.relay.RELAY2
 
config() - Method in class org.jgroups.protocols.relay.RELAY2
 
config - Variable in class org.jgroups.protocols.rules.SUPERVISOR
 
Configurator - Class in org.jgroups.stack
The task if this class is to setup and configure the protocol stack.
Configurator() - Constructor for class org.jgroups.stack.Configurator
 
Configurator(ProtocolStack) - Constructor for class org.jgroups.stack.Configurator
 
Configurator.InetAddressInfo - Class in org.jgroups.stack
 
ConfiguratorFactory - Class in org.jgroups.conf
The ConfigurationFactory is a factory that returns a protocol stack configurator.
ConfiguratorFactory() - Constructor for class org.jgroups.conf.ConfiguratorFactory
 
conn - Variable in class org.jgroups.protocols.S3_PING
 
conn_expire_time - Variable in class org.jgroups.blocks.TCPConnectionMap
 
conn_expire_time - Variable in class org.jgroups.protocols.BasicTCP
 
conn_expiry_timeout - Variable in class org.jgroups.protocols.UNICAST
 
conn_expiry_timeout - Variable in class org.jgroups.protocols.UNICAST2
 
conn_listener - Variable in class org.jgroups.stack.RouterStub
 
conn_listeners - Variable in class org.jgroups.blocks.AbstractConnectionMap
 
connect(String) - Method in class org.jgroups.Channel
Connects the channel to a group.
connect(String, Address, long) - Method in class org.jgroups.Channel
Connects this channel to a group and gets a state from a specified state provider.
connect() - Method in class org.jgroups.client.StompConnection
 
connect() - Method in class org.jgroups.demos.StompChat
 
CONNECT - Static variable in class org.jgroups.Event
 
connect(String) - Method in class org.jgroups.JChannel
 
connect(String, boolean) - Method in class org.jgroups.JChannel
Connects the channel to a group.
connect(String, Address, long) - Method in class org.jgroups.JChannel
 
connect(String, Address, long, boolean) - Method in class org.jgroups.JChannel
Connects this channel to a group and gets a state from a specified state provider.

This method invokes connect() and then getState.

If the FLUSH protocol is in the channel's stack definition, only one flush round is executed for both connecting and fetching the state rather than two flushes if we invoke connect and getState in succession.

connect(RouterStub, String, Address) - Method in class org.jgroups.protocols.TCPGOSSIP
 
connect(List<RouterStub>, String, Address, String, List<PhysicalAddress>) - Method in interface org.jgroups.protocols.TUNNEL.TUNNELPolicy
 
CONNECT - Static variable in class org.jgroups.stack.GossipRouter
 
connect(String, Address, String, List<PhysicalAddress>) - Method in class org.jgroups.stack.RouterStub
Register this process with the router under group.
connect(Socket, SocketAddress, int) - Static method in class org.jgroups.util.Util
Utility method.
connect_count - Variable in class org.jgroups.protocols.TP
Keeps track of connects and disconnects, in order to start and stop threads
CONNECT_OK - Static variable in class org.jgroups.stack.GossipRouter
 
CONNECT_USE_FLUSH - Static variable in class org.jgroups.Event
 
CONNECT_WITH_STATE_TRANSFER - Static variable in class org.jgroups.Event
 
CONNECT_WITH_STATE_TRANSFER_USE_FLUSH - Static variable in class org.jgroups.Event
 
connectAllStubs(String, Address) - Method in class org.jgroups.protocols.TCPGOSSIP
 
Connection - Interface in org.jgroups.blocks
 
connection_driver - Variable in class org.jgroups.protocols.JDBC_PING
 
connection_password - Variable in class org.jgroups.protocols.JDBC_PING
 
connection_reaper - Variable in class org.jgroups.protocols.UNICAST
 
connection_reaper - Variable in class org.jgroups.protocols.UNICAST2
 
connection_url - Variable in class org.jgroups.protocols.JDBC_PING
 
connection_username - Variable in class org.jgroups.protocols.JDBC_PING
 
connectionClosed(Address) - Method in interface org.jgroups.blocks.AbstractConnectionMap.ConnectionMapListener
 
connectionClosed(Address) - Method in interface org.jgroups.blocks.BasicConnectionTable.ConnectionListener
 
connectionEstablishedTo(Address) - Method in class org.jgroups.blocks.TCPConnectionMap
 
connectionEstablishedTo(Address) - Method in class org.jgroups.blocks.TCPConnectionMap.Mapper
 
ConnectionMap<V extends Connection> - Interface in org.jgroups.blocks
 
connectionOpened(Address, V) - Method in interface org.jgroups.blocks.AbstractConnectionMap.ConnectionMapListener
 
connectionOpened(Address) - Method in interface org.jgroups.blocks.BasicConnectionTable.ConnectionListener
 
connectionPeerReceiver - Variable in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
 
connections - Variable in class org.jgroups.protocols.STOMP
 
connectionState - Variable in class org.jgroups.stack.RouterStub
 
connectionStateChanged(RouterStub.ConnectionStatus) - Method in class org.jgroups.stack.RouterStub
 
connectionStatusChange(RouterStub, RouterStub.ConnectionStatus) - Method in interface org.jgroups.stack.RouterStub.ConnectionListener
 
connectionStatusChange(RouterStub, RouterStub.ConnectionStatus) - Method in class org.jgroups.stack.RouterStubManager
 
ConnectionTableNIO - Class in org.jgroups.blocks
Manages incoming and outgoing TCP connections.
ConnectionTableNIO(int) - Constructor for class org.jgroups.blocks.ConnectionTableNIO
 
ConnectionTableNIO(int, long, long) - Constructor for class org.jgroups.blocks.ConnectionTableNIO
 
ConnectionTableNIO(BasicConnectionTable.Receiver, InetAddress, InetAddress, int, int, int) - Constructor for class org.jgroups.blocks.ConnectionTableNIO
 
ConnectionTableNIO(BasicConnectionTable.Receiver, InetAddress, InetAddress, int, int, int, boolean) - Constructor for class org.jgroups.blocks.ConnectionTableNIO
 
ConnectionTableNIO(BasicConnectionTable.Receiver, InetAddress, InetAddress, int, int, int, long, long) - Constructor for class org.jgroups.blocks.ConnectionTableNIO
 
ConnectionTableNIO(BasicConnectionTable.Receiver, InetAddress, InetAddress, int, int, int, long, long, boolean) - Constructor for class org.jgroups.blocks.ConnectionTableNIO
 
ConnectionTableNIO.MyFuture - Class in org.jgroups.blocks
 
ConnectionTableNIO.MyFuture() - Constructor for class org.jgroups.blocks.ConnectionTableNIO.MyFuture
 
ConnectionTableNIO.SelectorWriteHandler - Class in org.jgroups.blocks
 
ConnectionTableNIO.WriteRequest - Class in org.jgroups.blocks
 
connectionTearListeners - Variable in class org.jgroups.stack.GossipRouter
 
connectionTorn(GossipRouter.ConnectionHandler, Exception) - Method in interface org.jgroups.stack.GossipRouter.ConnectionTearListener
 
connectLock - Variable in class org.jgroups.protocols.TP
 
connectProtocols(List<Protocol>) - Static method in class org.jgroups.stack.Configurator
Creates a protocol stack by iterating through the protocol list and connecting adjacent layers.
connectToDestination(String) - Method in class org.jgroups.client.StompConnection
 
conns - Variable in class org.jgroups.blocks.AbstractConnectionMap
 
CONSUMER_READY - Static variable in class org.jgroups.blocks.executor.ExecutorEvent
 
container - Variable in class org.jgroups.protocols.RACKSPACE_PING
 
container - Variable in class org.jgroups.protocols.SWIFT_PING
 
contains(Address) - Method in class org.jgroups.Membership
Returns true if the provided member belongs to this membership
contains(K) - Method in class org.jgroups.util.AgeOutCache
 
contains(Address) - Method in class org.jgroups.util.Digest
 
contains(K) - Method in class org.jgroups.util.ExpiryCache
 
contains(long) - Method in class org.jgroups.util.Seqno
 
contains(long) - Method in class org.jgroups.util.SeqnoRange
 
contains(T, T[]) - Static method in class org.jgroups.util.Util
 
containsAll(Digest) - Method in class org.jgroups.util.Digest
Returns true if our 'members' array contains all of the elements in other.members
containsId(short, short[]) - Static method in class org.jgroups.Message
 
containsKey(K) - Method in class org.jgroups.blocks.LazyRemovalCache
 
containsKey(Object) - Method in class org.jgroups.blocks.ReplicatedHashMap
 
containsKey(Object) - Method in class org.jgroups.util.RspList
 
containsKeys(Collection<K>) - Method in class org.jgroups.blocks.LazyRemovalCache
Returns true if all of the keys in keys are present.
containsMember(Address) - Method in class org.jgroups.View
Returns true, if this view contains a certain member
containsValue(Object) - Method in class org.jgroups.blocks.ReplicatedHashMap
 
containsValue(Object) - Method in class org.jgroups.util.RspList
 
containsViewId(Collection<View>, ViewId) - Static method in class org.jgroups.util.Util
 
contents() - Method in class org.jgroups.blocks.LazyRemovalCache
 
contentsCleared() - Method in interface org.jgroups.blocks.ReplicatedHashMap.Notification
 
contentsCleared() - Method in class org.jgroups.demos.ReplicatedHashMapDemo
 
contentsSet(Map<K, V>) - Method in interface org.jgroups.blocks.ReplicatedHashMap.Notification
 
contentsSet(Map<Object, Object>) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
 
convert(String, Class<?>) - Static method in class org.jgroups.blocks.MethodCall
 
convert(Object, Class<?>, String, String, boolean) - Method in interface org.jgroups.conf.PropertyConverter
 
convert(Object, Class<?>, String, String, boolean) - Method in class org.jgroups.conf.PropertyConverters.BindInterface
 
convert(Object, Class<?>, String, String, boolean) - Method in class org.jgroups.conf.PropertyConverters.Default
 
convert(Object, Class<?>, String, String, boolean) - Method in class org.jgroups.conf.PropertyConverters.FlushInvoker
 
convert(Object, Class<?>, String, String, boolean) - Method in class org.jgroups.conf.PropertyConverters.InitialHosts
 
convert(Object, Class<?>, String, String, boolean) - Method in class org.jgroups.conf.PropertyConverters.InitialHosts2
 
convert(Object, Class<?>, String, String, boolean) - Method in class org.jgroups.conf.PropertyConverters.IntegerArray
 
convert(Object, Class<?>, String, String, boolean) - Method in class org.jgroups.conf.PropertyConverters.LongArray
 
convert(Object, Class<?>, String, String, boolean) - Method in class org.jgroups.conf.PropertyConverters.NetworkInterfaceList
 
cookie - Variable in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
 
coord - Variable in class org.jgroups.protocols.CENTRAL_EXECUTOR
 
coord - Variable in class org.jgroups.protocols.CENTRAL_LOCK
 
coord - Variable in class org.jgroups.protocols.COUNTER
The address of the cluster coordinator.
coord - Variable in class org.jgroups.protocols.FORWARD_TO_COORD
the address of the current coordinator, all msgs are forwarded to it
coord - Variable in class org.jgroups.protocols.RELAY
 
coord - Variable in class org.jgroups.protocols.relay.RELAY2
 
coord - Variable in class org.jgroups.protocols.SEQUENCER
 
CoordGmsImpl - Class in org.jgroups.protocols.pbcast
Coordinator role of the Group MemberShip (GMS) protocol.
CoordGmsImpl(GMS) - Constructor for class org.jgroups.protocols.pbcast.CoordGmsImpl
 
coordinatorChosen() - Method in class org.jgroups.demos.Topology
 
copy() - Method in class org.jgroups.Membership
Returns a copy of this membership
copy() - Method in class org.jgroups.MergeView
 
copy() - Method in class org.jgroups.Message
 
copy(boolean) - Method in class org.jgroups.Message
Create a copy of the message.
copy(boolean, boolean) - Method in class org.jgroups.Message
Create a copy of the message.
copy(boolean, short) - Method in class org.jgroups.Message
Doesn't copy any headers except for those with ID >= copy_headers_above
copy(boolean, short, short...) - Method in class org.jgroups.Message
Copies a message.
copy() - Method in class org.jgroups.protocols.pbcast.NakAckHeader
 
copy() - Method in class org.jgroups.protocols.pbcast.NakAckHeader2
 
copy(Message) - Method in class org.jgroups.protocols.relay.RELAY2
Copies the message, but only the headers above the current protocol (RELAY) (or RpcDispatcher related headers)
copy() - Method in class org.jgroups.protocols.relay.SiteMaster
 
copy() - Method in class org.jgroups.protocols.relay.SiteUUID
 
copy() - Method in class org.jgroups.protocols.tom.MessageID
 
copy() - Method in class org.jgroups.protocols.UNICAST.UnicastHeader
 
copy() - Method in class org.jgroups.protocols.UNICAST2.Unicast2Header
 
copy() - Method in class org.jgroups.stack.ExponentialInterval
We don't need to copy as we don't have any state
copy() - Method in interface org.jgroups.stack.Interval
Returns a copy of the state.
copy() - Method in class org.jgroups.stack.IpAddress
 
copy() - Method in class org.jgroups.stack.StateTransferInfo
 
copy() - Method in class org.jgroups.stack.StaticInterval
 
copy() - Method in class org.jgroups.util.Buffer
 
copy() - Method in class org.jgroups.util.Digest
 
copy() - Method in class org.jgroups.util.Headers
 
copy() - Method in class org.jgroups.util.MutableDigest
 
copy(Reader, Writer) - Static method in class org.jgroups.util.PropertiesToXML
 
copy() - Method in class org.jgroups.util.UUID
 
copy() - Method in class org.jgroups.View
 
copy() - Method in class org.jgroups.ViewId
 
copy_multicast_msgs - Variable in class org.jgroups.protocols.DUPL
 
copy_unicast_msgs - Variable in class org.jgroups.protocols.DUPL
 
copyLocksTo(List<Address>) - Method in class org.jgroups.protocols.CENTRAL_LOCK
 
copyProtocols(ProtocolStack) - Method in class org.jgroups.stack.ProtocolStack
 
copyQueueTo(List<Address>) - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
 
corr - Variable in class org.jgroups.blocks.MessageDispatcher
 
corr - Variable in class org.jgroups.blocks.Request
 
correlatorStarted() - Method in class org.jgroups.blocks.MessageDispatcher
 
correlatorStarted() - Method in class org.jgroups.blocks.RpcDispatcher
 
corrId - Variable in class org.jgroups.blocks.RequestCorrelator.Header
The unique ID of the associated RequestCorrelator
count(boolean) - Method in class org.jgroups.util.RingBuffer
 
count(boolean) - Method in class org.jgroups.util.RingBufferLockless
 
count - Variable in class org.jgroups.util.SuppressCache.Value
 
count() - Method in class org.jgroups.util.SuppressCache.Value
 
count_size - Variable in class org.jgroups.protocols.pbcast.NAKACK2.Counter
 
Counter - Interface in org.jgroups.blocks.atomic
 
COUNTER - Class in org.jgroups.protocols
Protocol which is used by CounterService to provide a distributed atomic counter
COUNTER() - Constructor for class org.jgroups.protocols.COUNTER
 
counter - Static variable in class org.jgroups.protocols.Executing
This keeps track of all the requests we send.
counter - Variable in class org.jgroups.util.DefaultThreadFactory
 
COUNTER.AddAndGetRequest - Class in org.jgroups.protocols
 
COUNTER.AddAndGetRequest() - Constructor for class org.jgroups.protocols.COUNTER.AddAndGetRequest
 
COUNTER.AddAndGetRequest(Owner, String, long) - Constructor for class org.jgroups.protocols.COUNTER.AddAndGetRequest
 
COUNTER.BooleanResponse - Class in org.jgroups.protocols
 
COUNTER.BooleanResponse() - Constructor for class org.jgroups.protocols.COUNTER.BooleanResponse
 
COUNTER.BooleanResponse(Owner, long, boolean) - Constructor for class org.jgroups.protocols.COUNTER.BooleanResponse
 
COUNTER.CompareAndSetRequest - Class in org.jgroups.protocols
 
COUNTER.CompareAndSetRequest() - Constructor for class org.jgroups.protocols.COUNTER.CompareAndSetRequest
 
COUNTER.CompareAndSetRequest(Owner, String, long, long) - Constructor for class org.jgroups.protocols.COUNTER.CompareAndSetRequest
 
COUNTER.CounterHeader - Class in org.jgroups.protocols
 
COUNTER.CounterHeader() - Constructor for class org.jgroups.protocols.COUNTER.CounterHeader
 
COUNTER.CounterImpl - Class in org.jgroups.protocols
 
COUNTER.CounterImpl(String) - Constructor for class org.jgroups.protocols.COUNTER.CounterImpl
 
COUNTER.DeleteRequest - Class in org.jgroups.protocols
 
COUNTER.DeleteRequest() - Constructor for class org.jgroups.protocols.COUNTER.DeleteRequest
 
COUNTER.DeleteRequest(Owner, String) - Constructor for class org.jgroups.protocols.COUNTER.DeleteRequest
 
COUNTER.ExceptionResponse - Class in org.jgroups.protocols
 
COUNTER.ExceptionResponse() - Constructor for class org.jgroups.protocols.COUNTER.ExceptionResponse
 
COUNTER.ExceptionResponse(Owner, String) - Constructor for class org.jgroups.protocols.COUNTER.ExceptionResponse
 
COUNTER.GetOrCreateRequest - Class in org.jgroups.protocols
 
COUNTER.GetOrCreateRequest() - Constructor for class org.jgroups.protocols.COUNTER.GetOrCreateRequest
 
COUNTER.GetOrCreateResponse - Class in org.jgroups.protocols
 
COUNTER.GetOrCreateResponse() - Constructor for class org.jgroups.protocols.COUNTER.GetOrCreateResponse
 
COUNTER.GetOrCreateResponse(Owner, long, long) - Constructor for class org.jgroups.protocols.COUNTER.GetOrCreateResponse
 
COUNTER.ReconcileRequest - Class in org.jgroups.protocols
 
COUNTER.ReconcileRequest() - Constructor for class org.jgroups.protocols.COUNTER.ReconcileRequest
 
COUNTER.ReconcileRequest(String[], long[], long[]) - Constructor for class org.jgroups.protocols.COUNTER.ReconcileRequest
 
COUNTER.ReconcileResponse - Class in org.jgroups.protocols
 
COUNTER.ReconcileResponse() - Constructor for class org.jgroups.protocols.COUNTER.ReconcileResponse
 
COUNTER.ReconcileResponse(String[], long[], long[]) - Constructor for class org.jgroups.protocols.COUNTER.ReconcileResponse
 
COUNTER.ReconciliationTask - Class in org.jgroups.protocols
 
COUNTER.ReconciliationTask() - Constructor for class org.jgroups.protocols.COUNTER.ReconciliationTask
 
COUNTER.Request - Class in org.jgroups.protocols
 
COUNTER.Request() - Constructor for class org.jgroups.protocols.COUNTER.Request
 
COUNTER.RequestType - Enum in org.jgroups.protocols
 
COUNTER.ResendPendingRequests - Class in org.jgroups.protocols
 
COUNTER.ResendPendingRequests() - Constructor for class org.jgroups.protocols.COUNTER.ResendPendingRequests
 
COUNTER.Response - Class in org.jgroups.protocols
 
COUNTER.Response() - Constructor for class org.jgroups.protocols.COUNTER.Response
 
COUNTER.ResponseType - Enum in org.jgroups.protocols
 
COUNTER.SetRequest - Class in org.jgroups.protocols
 
COUNTER.SetRequest() - Constructor for class org.jgroups.protocols.COUNTER.SetRequest
 
COUNTER.SetRequest(Owner, String, long) - Constructor for class org.jgroups.protocols.COUNTER.SetRequest
 
COUNTER.SimpleRequest - Class in org.jgroups.protocols
 
COUNTER.SimpleRequest() - Constructor for class org.jgroups.protocols.COUNTER.SimpleRequest
 
COUNTER.SimpleRequest(Owner, String) - Constructor for class org.jgroups.protocols.COUNTER.SimpleRequest
 
COUNTER.SimpleResponse - Class in org.jgroups.protocols
Response without data
COUNTER.SimpleResponse() - Constructor for class org.jgroups.protocols.COUNTER.SimpleResponse
 
COUNTER.SimpleResponse(Owner, long) - Constructor for class org.jgroups.protocols.COUNTER.SimpleResponse
 
COUNTER.UpdateRequest - Class in org.jgroups.protocols
 
COUNTER.UpdateRequest() - Constructor for class org.jgroups.protocols.COUNTER.UpdateRequest
 
COUNTER.UpdateRequest(String, long, long) - Constructor for class org.jgroups.protocols.COUNTER.UpdateRequest
 
COUNTER.ValueResponse - Class in org.jgroups.protocols
 
COUNTER.ValueResponse() - Constructor for class org.jgroups.protocols.COUNTER.ValueResponse
 
COUNTER.ValueResponse(Owner, long, long) - Constructor for class org.jgroups.protocols.COUNTER.ValueResponse
 
COUNTER.VersionedValue - Class in org.jgroups.protocols
 
COUNTER.VersionedValue(long) - Constructor for class org.jgroups.protocols.COUNTER.VersionedValue
 
COUNTER.VersionedValue(long, long) - Constructor for class org.jgroups.protocols.COUNTER.VersionedValue
 
counter_prot - Variable in class org.jgroups.blocks.atomic.CounterService
 
counters - Variable in class org.jgroups.protocols.COUNTER
 
CounterService - Class in org.jgroups.blocks.atomic
Provides a distributed counter (similar to AtomicLong) which can be atomically updated across a cluster.
CounterService(JChannel) - Constructor for class org.jgroups.blocks.atomic.CounterService
 
CounterServiceDemo - Class in org.jgroups.demos
 
CounterServiceDemo() - Constructor for class org.jgroups.demos.CounterServiceDemo
 
crash() - Static method in class org.jgroups.util.Util
 
create() - Method in interface org.jgroups.blocks.ReplCache.HashFunctionFactory
 
create(RELAY.RelayHeader.Type) - Static method in class org.jgroups.protocols.RELAY.RelayHeader
 
create(View, View) - Static method in class org.jgroups.protocols.RELAY.ViewData
 
create(Address) - Static method in class org.jgroups.util.MergeId
 
createAcceptor() - Method in class org.jgroups.protocols.pbcast.STATE_SOCK
 
createAckHeader(long) - Static method in class org.jgroups.protocols.UNICAST.UnicastHeader
 
createAndRegisterStub(String, int, InetAddress) - Method in class org.jgroups.stack.RouterStubManager
 
createArrays(int) - Method in class org.jgroups.util.Digest
 
createArrays(Map<Address, long[]>) - Method in class org.jgroups.util.Digest
 
createAuthenticationDigest(String, long, double) - Static method in class org.jgroups.util.Util
 
createBridge() - Method in class org.jgroups.protocols.RELAY
 
createChannel() - Method in class org.jgroups.protocols.relay.config.RelayConfig.BridgeConfig
 
createChannel() - Method in class org.jgroups.protocols.relay.config.RelayConfig.ProgrammaticBridgeConfig
 
createChannel() - Method in class org.jgroups.protocols.relay.config.RelayConfig.PropertiesBridgeConfig
 
createChannel(Protocol...) - Static method in class org.jgroups.util.Util
 
createConcurrentMap(int, float, int) - Static method in class org.jgroups.util.Util
 
createConcurrentMap(int) - Static method in class org.jgroups.util.Util
 
createConcurrentMap() - Static method in class org.jgroups.util.Util
 
createConnectionMap(long, long, InetAddress, InetAddress, int, int, int) - Method in class org.jgroups.protocols.TCP
 
createContainer(String) - Method in class org.jgroups.protocols.SWIFT_PING.SwiftClient
Create a container, which is equivalent to a bucket
createDaemons - Variable in class org.jgroups.util.DefaultThreadFactory
 
createDatagramSocket(String) - Method in class org.jgroups.util.DefaultSocketFactory
 
createDatagramSocket(String, SocketAddress) - Method in class org.jgroups.util.DefaultSocketFactory
 
createDatagramSocket(String, int) - Method in class org.jgroups.util.DefaultSocketFactory
 
createDatagramSocket(String, int, InetAddress) - Method in class org.jgroups.util.DefaultSocketFactory
 
createDatagramSocket(String) - Method in interface org.jgroups.util.SocketFactory
 
createDatagramSocket(String, SocketAddress) - Method in interface org.jgroups.util.SocketFactory
 
createDatagramSocket(String, int) - Method in interface org.jgroups.util.SocketFactory
 
createDatagramSocket(String, int, InetAddress) - Method in interface org.jgroups.util.SocketFactory
 
createDatagramSocket(SocketFactory, String, InetAddress, int) - Static method in class org.jgroups.util.Util
Creates a DatagramSocket bound to addr.
createDatagramSocketWithBindPort() - Method in class org.jgroups.protocols.UDP
Creates a DatagramSocket when bind_port > 0.
createDataHeader(long, short, boolean) - Static method in class org.jgroups.protocols.UNICAST.UnicastHeader
 
createDataHeader(long, short, boolean) - Static method in class org.jgroups.protocols.UNICAST2.Unicast2Header
 
createDigest(String, long, double) - Static method in class org.jgroups.util.Util
 
createDiskCacheFile() - Method in class org.jgroups.protocols.PDC
 
createDisseminateHeader(Address) - Static method in class org.jgroups.protocols.RELAY.RelayHeader
 
createEphemeralDatagramSocket() - Method in class org.jgroups.protocols.UDP
Creates a DatagramSocket with a random port.
createExpireHeader(short) - Static method in class org.jgroups.protocols.SCOPE.ScopeHeader
 
createHashMap() - Static method in class org.jgroups.util.Util
 
createHeader(STOMP.StompHeader.Type, String...) - Static method in class org.jgroups.protocols.STOMP.StompHeader
Creates a new header
createHeader(STOMP.StompHeader.Type, Map<String, String>) - Static method in class org.jgroups.protocols.STOMP.StompHeader
 
createHeaders(int) - Static method in class org.jgroups.Message
 
createHeaders(Headers) - Static method in class org.jgroups.Message
 
createInetAddressMap(List<ProtocolConfiguration>, List<Protocol>) - Static method in class org.jgroups.stack.Configurator
 
createInfo(ViewId, String, Collection<PhysicalAddress>) - Static method in class org.jgroups.protocols.MERGE3.MergeHeader
 
createInstance(RspFilter) - Static method in class org.jgroups.blocks.mux.NoMuxHandlerRspFilter
 
createLayer(ProtocolStack, ProtocolConfiguration) - Static method in class org.jgroups.stack.Configurator
 
createLocalAddress() - Method in class org.jgroups.protocols.UDP
 
createLock(String) - Method in class org.jgroups.protocols.Locking
 
createLock(String) - Method in class org.jgroups.protocols.PEER_LOCK
 
createMessage(Address, Address, Address, Message) - Method in class org.jgroups.protocols.relay.Relayer.Route
 
createMessageHeader(long) - Static method in class org.jgroups.protocols.pbcast.NakAckHeader
 
createMessageHeader(long) - Static method in class org.jgroups.protocols.pbcast.NakAckHeader2
 
createMessageHeader(short) - Static method in class org.jgroups.protocols.SCOPE.ScopeHeader
 
createMonitor() - Method in class org.jgroups.protocols.FD_ICMP
 
createMonitor() - Method in class org.jgroups.protocols.FD_PING
 
createMulticastSocket(String) - Method in class org.jgroups.util.DefaultSocketFactory
 
createMulticastSocket(String, int) - Method in class org.jgroups.util.DefaultSocketFactory
 
createMulticastSocket(String, SocketAddress) - Method in class org.jgroups.util.DefaultSocketFactory
 
createMulticastSocket(String) - Method in interface org.jgroups.util.SocketFactory
 
createMulticastSocket(String, int) - Method in interface org.jgroups.util.SocketFactory
 
createMulticastSocket(String, SocketAddress) - Method in interface org.jgroups.util.SocketFactory
 
createMulticastSocket(SocketFactory, String, InetAddress, int, Log) - Static method in class org.jgroups.util.Util
 
createNewFile() - Method in class org.jgroups.blocks.GridFile
 
createNewHeader(byte, MessageID) - Static method in class org.jgroups.protocols.tom.ToaHeader
 
createObject(String, String, byte[]) - Method in class org.jgroups.protocols.SWIFT_PING.SwiftClient
Create an object (=file)
createProtocol(String, ProtocolStack) - Static method in class org.jgroups.stack.Configurator
Creates a new protocol given the protocol specification.
createProtocol(String) - Method in class org.jgroups.stack.ProtocolStack
 
createRandomAddress() - Static method in class org.jgroups.util.Util
 
createRandomAddress(String) - Static method in class org.jgroups.util.Util
 
createRequest(COUNTER.RequestType) - Static method in class org.jgroups.protocols.COUNTER
 
createRequestCorrelator(Protocol, RequestHandler, Address) - Method in class org.jgroups.blocks.MessageDispatcher
 
createRequestCorrelator(Protocol, RequestHandler, Address) - Method in class org.jgroups.blocks.mux.MuxMessageDispatcher
 
createRequestCorrelator(Protocol, RequestHandler, Address) - Method in class org.jgroups.blocks.mux.MuxRpcDispatcher
 
createResponse(COUNTER.ResponseType) - Static method in class org.jgroups.protocols.COUNTER
 
createRootDir() - Method in class org.jgroups.protocols.FILE_PING
 
createRootDir() - Method in class org.jgroups.protocols.JDBC_PING
 
createRootDir() - Method in class org.jgroups.protocols.RACKSPACE_PING
 
createRootDir() - Method in class org.jgroups.protocols.S3_PING
 
createRootDir() - Method in class org.jgroups.protocols.SWIFT_PING
 
createSendFirstSeqnoHeader(long) - Static method in class org.jgroups.protocols.UNICAST.UnicastHeader
 
createSendFirstSeqnoHeader(long) - Static method in class org.jgroups.protocols.UNICAST2.Unicast2Header
 
createServerSocket(int, int) - Method in class org.jgroups.blocks.ConnectionTableNIO
Finds first available port starting at start_port and returns server socket.
createServerSocket(String) - Method in class org.jgroups.util.DefaultSocketFactory
 
createServerSocket(String, int) - Method in class org.jgroups.util.DefaultSocketFactory
 
createServerSocket(String, int, int) - Method in class org.jgroups.util.DefaultSocketFactory
 
createServerSocket(String, int, int, InetAddress) - Method in class org.jgroups.util.DefaultSocketFactory
 
createServerSocket(String) - Method in interface org.jgroups.util.SocketFactory
 
createServerSocket(String, int) - Method in interface org.jgroups.util.SocketFactory
 
createServerSocket(String, int, int) - Method in interface org.jgroups.util.SocketFactory
 
createServerSocket(String, int, int, InetAddress) - Method in interface org.jgroups.util.SocketFactory
 
createServerSocket(SocketFactory, String, InetAddress, int) - Static method in class org.jgroups.util.Util
 
createServerSocket(SocketFactory, String, InetAddress, int, int) - Static method in class org.jgroups.util.Util
Finds first available port starting at start_port and returns server socket.
createSingleDestinationHeader() - Static method in class org.jgroups.protocols.tom.ToaHeader
 
createSocket(String) - Method in class org.jgroups.util.DefaultSocketFactory
 
createSocket(String, String, int) - Method in class org.jgroups.util.DefaultSocketFactory
 
createSocket(String, InetAddress, int) - Method in class org.jgroups.util.DefaultSocketFactory
 
createSocket(String, String, int, InetAddress, int) - Method in class org.jgroups.util.DefaultSocketFactory
 
createSocket(String, InetAddress, int, InetAddress, int) - Method in class org.jgroups.util.DefaultSocketFactory
 
createSocket(String) - Method in interface org.jgroups.util.SocketFactory
 
createSocket(String, String, int) - Method in interface org.jgroups.util.SocketFactory
 
createSocket(String, InetAddress, int) - Method in interface org.jgroups.util.SocketFactory
 
createSocket(String, String, int, InetAddress, int) - Method in interface org.jgroups.util.SocketFactory
 
createSocket(String, InetAddress, int, InetAddress, int) - Method in interface org.jgroups.util.SocketFactory
 
createSockets() - Method in class org.jgroups.protocols.UDP
Create UDP sender and receiver sockets.
createStableHeader(short, long, long) - Static method in class org.jgroups.protocols.UNICAST2.Unicast2Header
 
createStreamToProvider(Address, StreamingStateTransfer.StateHeader) - Method in class org.jgroups.protocols.pbcast.STATE
 
createStreamToProvider(Address, StreamingStateTransfer.StateHeader) - Method in class org.jgroups.protocols.pbcast.STATE_SOCK
 
createStreamToProvider(Address, StreamingStateTransfer.StateHeader) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
Creates an InputStream to the state provider to read the state
createStreamToRequester(Address) - Method in class org.jgroups.protocols.pbcast.STATE
 
createStreamToRequester(Address) - Method in class org.jgroups.protocols.pbcast.STATE_SOCK
 
createStreamToRequester(Address) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
Creates an OutputStream to the state requester to write the state
createTable(long) - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
createThreadPool() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
createThreadPool(int, int, long, ThreadFactory) - Static method in class org.jgroups.protocols.SCOPE
 
createThreadPool(int, int, long, String, BlockingQueue<Runnable>, ThreadFactory) - Static method in class org.jgroups.protocols.TP
 
createTimer() - Static method in class org.jgroups.util.Util
 
createView(Address, long, Address...) - Static method in class org.jgroups.util.Util
 
createViewRequest() - Static method in class org.jgroups.protocols.MERGE3.MergeHeader
 
createViewResponse(View) - Static method in class org.jgroups.protocols.MERGE3.MergeHeader
 
createXmitReqHeader() - Static method in class org.jgroups.protocols.UNICAST2.Unicast2Header
 
createXmitRequestHeader(long, long, Address) - Static method in class org.jgroups.protocols.pbcast.NakAckHeader
 
createXmitRequestHeader(Address) - Static method in class org.jgroups.protocols.pbcast.NakAckHeader2
 
createXmitResponseHeader() - Static method in class org.jgroups.protocols.pbcast.NakAckHeader
 
createXmitResponseHeader() - Static method in class org.jgroups.protocols.pbcast.NakAckHeader2
 
creator - Variable in class org.jgroups.ViewId
 
CREDIT_REQUEST - Static variable in class org.jgroups.protocols.FcHeader
 
CREDIT_REQUEST_HDR - Static variable in class org.jgroups.protocols.FlowControl
 
CreditMap - Class in org.jgroups.util
Maintains credits for senders, when credits fall below 0, a sender blocks until new credits have been received.
CreditMap(long) - Constructor for class org.jgroups.util.CreditMap
 
credits - Variable in class org.jgroups.protocols.MFC
Maintains credits per member
credits - Variable in class org.jgroups.util.CreditMap
 
credits_available - Variable in class org.jgroups.util.CreditMap
 
credits_left - Variable in class org.jgroups.protocols.FlowControl.Credit
 
current - Variable in class org.jgroups.util.RingBuffer.RingBufferIterator
 
current - Variable in class org.jgroups.util.RingBufferLockless.RingBufferIterator
 
current_coord - Variable in class org.jgroups.protocols.Discovery
 
current_id - Variable in class org.jgroups.protocols.FORWARD_TO_COORD
ID to be used to identify forwarded messages.
current_id - Variable in class org.jgroups.protocols.RSVP
ID to be used to identify messages.
current_index - Variable in class org.jgroups.util.MutableDigest
 
current_owner - Variable in class org.jgroups.protocols.Locking.ServerLock
 
CUSTOM_LOG_FACTORY - Static variable in class org.jgroups.Global
 
CustomLogFactory - Interface in org.jgroups.logging
An extension interface allowing to plug in a custom log provider.

D

DAISYCHAIN - Class in org.jgroups.protocols
Implementation of daisy chaining.
DAISYCHAIN() - Constructor for class org.jgroups.protocols.DAISYCHAIN
 
DAISYCHAIN.DaisyHeader - Class in org.jgroups.protocols
 
DAISYCHAIN.DaisyHeader() - Constructor for class org.jgroups.protocols.DAISYCHAIN.DaisyHeader
 
DAISYCHAIN.DaisyHeader(short) - Constructor for class org.jgroups.protocols.DAISYCHAIN.DaisyHeader
 
data - Variable in class org.jgroups.blocks.GridFilesystem
 
data - Variable in class org.jgroups.protocols.PingHeader
 
DATA - Static variable in class org.jgroups.protocols.relay.RELAY2.Relay2Header
 
DATA - Static variable in class org.jgroups.protocols.UNICAST.UnicastHeader
 
DATA - Static variable in class org.jgroups.protocols.UNICAST2.Unicast2Header
 
DATA_MESSAGE - Static variable in class org.jgroups.protocols.tom.ToaHeader
 
datasource_jndi_name - Variable in class org.jgroups.protocols.JDBC_PING
 
debug(String) - Method in class org.jgroups.logging.JDKLogImpl
 
debug(String, Throwable) - Method in class org.jgroups.logging.JDKLogImpl
 
debug(String) - Method in interface org.jgroups.logging.Log
 
debug(String, Throwable) - Method in interface org.jgroups.logging.Log
 
debug(String) - Method in class org.jgroups.logging.Log4JLogImpl
 
debug(String, Throwable) - Method in class org.jgroups.logging.Log4JLogImpl
 
decode(byte[]) - Static method in class org.jgroups.util.Util
 
decode(short) - Static method in class org.jgroups.Version
 
decodeLength(byte) - Static method in class org.jgroups.util.Util
 
decodeLongSequence(byte[]) - Static method in class org.jgroups.util.Util
 
decrement(long) - Method in class org.jgroups.protocols.FlowControl.Credit
 
decrement(long, long) - Method in class org.jgroups.util.CreditMap
Decrements credits bytes from all.
decrement(long) - Method in class org.jgroups.util.CreditMap
 
decrementAndAdd(Address, long) - Method in class org.jgroups.util.CreditMap
Decrements credits bytes from all elements and add new_credits to member (if non null).
decrementAndGet() - Method in interface org.jgroups.blocks.atomic.Counter
Atomically decrements the counter and returns the new value
decrementAndGet() - Method in class org.jgroups.protocols.COUNTER.CounterImpl
 
decrementAndGet(long) - Method in class org.jgroups.protocols.FlowControl.Credit
 
decrementIfEnoughCredits(long, long) - Method in class org.jgroups.protocols.FlowControl.Credit
 
decrementInitCount() - Method in class org.jgroups.stack.ProtocolStack.RefCounter
 
decrementStartCount() - Method in class org.jgroups.stack.ProtocolStack.RefCounter
 
decrypt_lock - Variable in class org.jgroups.protocols.ENCRYPT
To synchronize access to symDecodingCipher
default_chunk_size - Variable in class org.jgroups.blocks.GridFilesystem
 
DEFAULT_FIRST_SEQNO - Static variable in class org.jgroups.protocols.UNICAST
 
DEFAULT_FIRST_SEQNO - Static variable in class org.jgroups.protocols.UNICAST2
 
DEFAULT_FIRST_UNICAST_SEQNO - Static variable in class org.jgroups.Global
 
DEFAULT_MAX_COMPACTION_TIME - Static variable in class org.jgroups.util.RetransmitTable
 
DEFAULT_MAX_COMPACTION_TIME - Static variable in class org.jgroups.util.Table
 
default_pool - Variable in class org.jgroups.protocols.DAISYCHAIN
 
DEFAULT_PROTOCOL_STACK - Static variable in class org.jgroups.JChannel
The default protocol stack used by the default constructor
default_repl_count - Variable in class org.jgroups.blocks.GridFilesystem
 
DEFAULT_RESIZE_FACTOR - Static variable in class org.jgroups.util.RetransmitTable
 
DEFAULT_RESIZE_FACTOR - Static variable in class org.jgroups.util.Table
 
default_thread_factory - Variable in class org.jgroups.protocols.TP
Factory which is used by oob_thread_pool
default_thread_factory - Variable in class org.jgroups.stack.GossipRouter
 
DefaultRetransmitter - Class in org.jgroups.stack
Maintains a pool of sequence numbers of messages that need to be retransmitted.
DefaultRetransmitter(Address, Retransmitter.RetransmitCommand, TimeScheduler) - Constructor for class org.jgroups.stack.DefaultRetransmitter
Create a new Retransmitter associated with the given sender address
DefaultRetransmitter.SeqnoTask - Class in org.jgroups.stack
 
DefaultRetransmitter.SeqnoTask(long, Interval, Retransmitter.RetransmitCommand, Address) - Constructor for class org.jgroups.stack.DefaultRetransmitter.SeqnoTask
 
DefaultSocketFactory - Class in org.jgroups.util
Default implementation, ignores service names
DefaultSocketFactory() - Constructor for class org.jgroups.util.DefaultSocketFactory
 
DefaultThreadFactory - Class in org.jgroups.util
Thread factory mainly responsible for naming of threads.
DefaultThreadFactory(String, boolean) - Constructor for class org.jgroups.util.DefaultThreadFactory
 
DefaultThreadFactory(String, boolean, boolean) - Constructor for class org.jgroups.util.DefaultThreadFactory
 
DefaultTimeScheduler - Class in org.jgroups.util
Implementation of TimeScheduler by extending ScheduledThreadPoolExecutor to keep tasks sorted.
DefaultTimeScheduler() - Constructor for class org.jgroups.util.DefaultTimeScheduler
Create a scheduler that executes tasks in dynamically adjustable intervals
DefaultTimeScheduler(ThreadFactory) - Constructor for class org.jgroups.util.DefaultTimeScheduler
 
DefaultTimeScheduler(ThreadFactory, int) - Constructor for class org.jgroups.util.DefaultTimeScheduler
 
DefaultTimeScheduler(int) - Constructor for class org.jgroups.util.DefaultTimeScheduler
 
DefaultTimeScheduler.RobustRunnable - Class in org.jgroups.util
Class which catches exceptions in run() - https://jira.jboss.org/jira/browse/JGRP-1062
DefaultTimeScheduler.RobustRunnable(Runnable) - Constructor for class org.jgroups.util.DefaultTimeScheduler.RobustRunnable
 
DefaultTimeScheduler.TaskWrapper<V> - Class in org.jgroups.util
 
DefaultTimeScheduler.TaskWrapper(TimeScheduler.Task) - Constructor for class org.jgroups.util.DefaultTimeScheduler.TaskWrapper
 
defer_client_bind_addr - Variable in class org.jgroups.protocols.BasicTCP
 
defer_client_binding - Variable in class org.jgroups.blocks.TCPConnectionMap
 
deferClientBinding() - Method in class org.jgroups.blocks.TCPConnectionMap
 
deferClientBinding(boolean) - Method in class org.jgroups.blocks.TCPConnectionMap
 
defragmentBuffer(byte[][]) - Static method in class org.jgroups.util.Util
Concatenates smaller fragments into entire buffers.
DELAY - Class in org.jgroups.protocols
Delays incoming/outgoing messages by a random number of milliseconds (range between 0 and n where n is determined by the user).
DELAY() - Constructor for class org.jgroups.protocols.DELAY
 
delay - Variable in class org.jgroups.util.TimeScheduler3.RecurringTask
 
DELAY_JOIN_REQ - Class in org.jgroups.protocols
Discards 2 JOIN-REQs then accepts 1, then discards 2 more and so on
DELAY_JOIN_REQ() - Constructor for class org.jgroups.protocols.DELAY_JOIN_REQ
 
delete() - Method in class org.jgroups.blocks.GridFile
 
delete(boolean) - Method in class org.jgroups.blocks.GridFile
 
delete(Connection, String, String) - Method in class org.jgroups.protocols.JDBC_PING
 
delete(String, String) - Method in class org.jgroups.protocols.JDBC_PING
 
delete_single_sql - Variable in class org.jgroups.protocols.JDBC_PING
 
deleteCounter(String) - Method in class org.jgroups.blocks.atomic.CounterService
Deletes a counter instance (on the coordinator)
deleteCounter(String) - Method in class org.jgroups.protocols.COUNTER
Sent asynchronously - we don't wait for an ack
deleteFile(File) - Method in class org.jgroups.protocols.PDC
Attempts to delete the provided file.
Logging is performed on the result
deleteObject(String, String) - Method in class org.jgroups.protocols.SWIFT_PING.SwiftClient
Delete a object (=file) from the storage
deleteSelf() - Method in class org.jgroups.protocols.JDBC_PING
 
deliver(Address, Address, Message) - Method in class org.jgroups.protocols.relay.RELAY2
 
deliver(Message, Event, SEQUENCER.SequencerHeader) - Method in class org.jgroups.protocols.SEQUENCER
 
deliver(Message) - Method in interface org.jgroups.protocols.tom.DeliveryProtocol
deliver a message
deliver(Message) - Method in class org.jgroups.protocols.tom.TOA
 
delivered_bcasts - Variable in class org.jgroups.protocols.SEQUENCER
 
deliverLocally(SiteAddress, SiteAddress, Message) - Method in class org.jgroups.protocols.relay.RELAY2
 
deliverSingleDestinationMessage(Message) - Method in class org.jgroups.protocols.tom.DeliveryManagerImpl
delivers a message that has only as destination member this node
delivery_table - Variable in class org.jgroups.protocols.SEQUENCER
 
delivery_table - Variable in class org.jgroups.util.ForwardQueue
 
delivery_table_max_size - Variable in class org.jgroups.protocols.SEQUENCER
 
delivery_table_max_size - Variable in class org.jgroups.util.ForwardQueue
Size of the set to store received seqnos (for duplicate checking)
DeliveryManager - Interface in org.jgroups.protocols.tom
The interface that a delivery manager must implement.
DeliveryManagerImpl - Class in org.jgroups.protocols.tom
The implementation of the Delivery Manager
DeliveryManagerImpl() - Constructor for class org.jgroups.protocols.tom.DeliveryManagerImpl
 
DeliveryProtocol - Interface in org.jgroups.protocols.tom
The interface that the Total Order Anycast protocol must implement.
deliveryTableSize() - Method in class org.jgroups.util.ForwardQueue
Total size of all queues of the delivery table
DeliveryThread - Class in org.jgroups.protocols.tom
The delivery thread.
DeliveryThread(DeliveryProtocol) - Constructor for class org.jgroups.protocols.tom.DeliveryThread
 
DemoToken - Class in org.jgroups.auth
AuthToken implementation which shows how to send messages back and forth in order to perform authentication.
DemoToken() - Constructor for class org.jgroups.auth.DemoToken
 
DemoToken.DemoHeader - Class in org.jgroups.auth
 
DemoToken.DemoHeader() - Constructor for class org.jgroups.auth.DemoToken.DemoHeader
 
DemoToken.DemoHeader(byte[]) - Constructor for class org.jgroups.auth.DemoToken.DemoHeader
 
DemoToken.DemoHeader(long) - Constructor for class org.jgroups.auth.DemoToken.DemoHeader
 
DemoToken.Entry - Class in org.jgroups.auth
 
DemoToken.Entry(byte[]) - Constructor for class org.jgroups.auth.DemoToken.Entry
 
denied - Variable in class org.jgroups.protocols.Locking.ClientLock
 
DeprecatedProperty - Annotation Type in org.jgroups.annotations
Represents an array of deprecated Protocol properties
description() - Method in class org.jgroups.protocols.rules.CheckFDMonitor
 
description() - Method in class org.jgroups.protocols.rules.Rule
Describes what the rules does
description() - Method in class org.jgroups.protocols.rules.SampleRule
 
description - Static variable in class org.jgroups.Version
 
deserialize(byte[]) - Method in class org.jgroups.protocols.Discovery
 
dest() - Method in class org.jgroups.Message
 
dest(Address) - Method in class org.jgroups.Message
 
dest - Variable in class org.jgroups.protocols.BPING
 
dest_addr - Variable in class org.jgroups.Message
 
dest_addr - Variable in class org.jgroups.protocols.BPING
 
DESTINATION - Static variable in class org.jgroups.demos.StompChat
 
destinations - Variable in class org.jgroups.AnycastAddress
 
destroy() - Method in class org.jgroups.demos.applets.DrawApplet
 
destroy() - Method in class org.jgroups.demos.wb.Whiteboard
 
destroy() - Method in class org.jgroups.protocols.BARRIER
 
destroy() - Method in class org.jgroups.protocols.COMPRESS
 
destroy() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
destroy() - Method in class org.jgroups.protocols.RSVP.Entry
 
destroy() - Method in class org.jgroups.protocols.rules.Rule
Called when rule is uninstalled
destroy() - Method in class org.jgroups.protocols.rules.SUPERVISOR
 
destroy() - Method in class org.jgroups.protocols.SHARED_LOOPBACK
 
destroy() - Method in class org.jgroups.protocols.TCPGOSSIP
 
destroy() - Method in class org.jgroups.protocols.TP
 
destroy() - Method in class org.jgroups.protocols.TUNNEL
 
destroy() - Method in class org.jgroups.protocols.UDP
 
destroy() - Method in class org.jgroups.stack.GossipRouter
 
destroy() - Method in class org.jgroups.stack.NakReceiverWindow
Destroys the NakReceiverWindow.
destroy() - Method in class org.jgroups.stack.Protocol
This method is called on a Channel.close().
destroy() - Method in class org.jgroups.stack.ProtocolStack
 
destroy() - Method in class org.jgroups.stack.RouterStub
 
destroy() - Method in class org.jgroups.util.AckCollector
 
destroy() - Method in class org.jgroups.util.RingBuffer
 
destroy() - Method in class org.jgroups.util.RingBufferLockless
 
destroySockets() - Method in class org.jgroups.protocols.UDP
 
destroyStubs() - Method in class org.jgroups.stack.RouterStubManager
 
detectDifferentViews(Map<Address, View>) - Static method in class org.jgroups.protocols.MERGE3
 
detectDifferentViews(Map<Address, View>) - Static method in class org.jgroups.util.Util
 
determineActualMergeCoords(Map<Address, View>) - Static method in class org.jgroups.util.Util
Similar to Util.determineMergeCoords(java.util.Map) but only actual coordinators are counted: an actual coord is when the sender of a view is the first member of that view
determineCoordinator() - Method in class org.jgroups.protocols.FD_SOCK
 
determineCoordinator() - Method in class org.jgroups.protocols.pbcast.GMS
 
determineCoordinator() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
determineIpVersionFromAddresses(Collection<InetAddress>) - Static method in class org.jgroups.stack.Configurator
This method takes a set of InetAddresses, represented by an inetAddressmap, and: - if the resulting set is non-empty, goes through to see if all InetAddress-related user settings have a consistent IP version: v4 or v6, and throws an exception if not - if the resulting set is empty, sets the default IP version based on available stacks and if a dual stack, stack preferences - sets the IP version to be used in the JGroups session
determineLeftMembers(List<Address>, List<Address>) - Static method in class org.jgroups.util.Util
Returns all members that left between 2 views.
determineMergeCoords(Map<Address, View>) - Static method in class org.jgroups.util.Util
This is the same or a subset of Util.determineMergeParticipants(java.util.Map) and contains only members which are currently sub-partition coordinators.
determineMergeParticipants(Map<Address, View>) - Static method in class org.jgroups.util.Util
Determines the members which take part in a merge.
determineSiteMaster(View) - Static method in class org.jgroups.protocols.relay.RELAY2
Gets the site master from view.
diag_handler - Variable in class org.jgroups.protocols.TP
 
diag_sock - Variable in class org.jgroups.stack.DiagnosticsHandler
 
diagnostics_addr - Variable in class org.jgroups.protocols.TP
 
diagnostics_addr - Variable in class org.jgroups.stack.DiagnosticsHandler
 
diagnostics_bind_interfaces - Variable in class org.jgroups.protocols.TP
 
diagnostics_passcode - Variable in class org.jgroups.protocols.TP
 
diagnostics_port - Variable in class org.jgroups.protocols.TP
 
diagnostics_port - Variable in class org.jgroups.stack.DiagnosticsHandler
 
diagnostics_ttl - Variable in class org.jgroups.protocols.TP
 
DiagnosticsHandler - Class in org.jgroups.stack
 
DiagnosticsHandler(InetAddress, int, Log, SocketFactory, ThreadFactory) - Constructor for class org.jgroups.stack.DiagnosticsHandler
 
DiagnosticsHandler(InetAddress, int, Log, SocketFactory, ThreadFactory, String) - Constructor for class org.jgroups.stack.DiagnosticsHandler
 
DiagnosticsHandler(InetAddress, int, List<NetworkInterface>, int, Log, SocketFactory, ThreadFactory, String) - Constructor for class org.jgroups.stack.DiagnosticsHandler
 
DiagnosticsHandler.ProbeHandler - Interface in org.jgroups.stack
 
difference(Digest) - Method in class org.jgroups.util.Digest
 
different(T, T) - Static method in class org.jgroups.util.Util
 
digest - Variable in class org.jgroups.protocols.pbcast.MergeData
 
Digest - Class in org.jgroups.util
A message digest, containing senders and ranges of seqnos, where each sender is associated with its highest delivered and received seqno seen so far.

Digest(Address[], long[]) - Constructor for class org.jgroups.util.Digest
 
Digest() - Constructor for class org.jgroups.util.Digest
Used for serialization
Digest(Map<Address, long[]>) - Constructor for class org.jgroups.util.Digest
Creates a new digest from an existing map by copying the keys and values from map
Digest(Digest) - Constructor for class org.jgroups.util.Digest
 
Digest(Address, long, long) - Constructor for class org.jgroups.util.Digest
 
Digest(Address, long) - Constructor for class org.jgroups.util.Digest
 
Digest.DigestEntry - Class in org.jgroups.util
Keeps track of one members plus its highest delivered and received seqnos
Digest.DigestEntry(Address, long, long) - Constructor for class org.jgroups.util.Digest.DigestEntry
 
Digest.MyIterator - Class in org.jgroups.util
 
Digest.MyIterator() - Constructor for class org.jgroups.util.Digest.MyIterator
 
digest_history - Variable in class org.jgroups.protocols.pbcast.NAKACK
Keeps a bounded list of the last N digest sets
digest_history - Variable in class org.jgroups.protocols.pbcast.NAKACK2
Keeps a bounded list of the last N digest sets
DIGEST_PRESENT - Static variable in class org.jgroups.protocols.pbcast.JoinRsp
 
digits(long, int) - Static method in class org.jgroups.util.UUID
Returns val represented by the specified number of hex digits.
DIR - Static variable in class org.jgroups.blocks.GridFile.Metadata
 
DirectExecutor - Class in org.jgroups.util
 
DirectExecutor() - Constructor for class org.jgroups.util.DirectExecutor
 
disable_loopback - Variable in class org.jgroups.protocols.UDP
 
disableReaping() - Method in class org.jgroups.blocks.Cache
 
DISCARD - Class in org.jgroups.protocols
Discards up or down messages based on a percentage; e.g., setting property 'up' to 0.1 causes 10% of all up messages to be discarded.
DISCARD() - Constructor for class org.jgroups.protocols.DISCARD
 
DISCARD.DiscardHeader - Class in org.jgroups.protocols
 
DISCARD.DiscardHeader() - Constructor for class org.jgroups.protocols.DISCARD.DiscardHeader
 
DISCARD.DiscardHeader(Set<Address>) - Constructor for class org.jgroups.protocols.DISCARD.DiscardHeader
 
discard_delivered_msgs - Variable in class org.jgroups.protocols.pbcast.NAKACK2
Messages that have been received in order are sent up the stack (= delivered to the application).
discard_incompatible_packets - Variable in class org.jgroups.protocols.TP
Deprecated. 
discard_own_messages - Variable in class org.jgroups.Channel
 
DISCARD_PAYLOAD - Class in org.jgroups.protocols
Discards a message whose sequence number (in the payload, as a Long) matches seqno 2 times, before passing it down.
DISCARD_PAYLOAD() - Constructor for class org.jgroups.protocols.DISCARD_PAYLOAD
 
discard_requests - Variable in class org.jgroups.protocols.COUNTER
Set to true during reconciliation process, will cause all requests to be discarded
discardUntilNewLine(InputStream) - Static method in class org.jgroups.util.Util
Reads and discards all characters from the input stream until a \r\n or EOF is encountered
disconnect() - Method in class org.jgroups.Channel
Disconnects the channel if it is connected.
disconnect() - Method in class org.jgroups.client.StompConnection
 
DISCONNECT - Static variable in class org.jgroups.Event
 
disconnect() - Method in class org.jgroups.JChannel
 
DISCONNECT - Static variable in class org.jgroups.stack.GossipRouter
 
disconnect(String, Address) - Method in class org.jgroups.stack.RouterStub
 
DISCONNECT_OK - Static variable in class org.jgroups.stack.GossipRouter
 
disconnectStubs() - Method in class org.jgroups.stack.RouterStubManager
 
Discovery - Class in org.jgroups.protocols
The Discovery protocol retrieves the initial membership (used by GMS and MERGE2) by sending discovery requests.
Discovery() - Constructor for class org.jgroups.protocols.Discovery
 
Discovery.Responses - Class in org.jgroups.protocols
 
Discovery.Responses(int, boolean, Promise<JoinRsp>) - Constructor for class org.jgroups.protocols.Discovery.Responses
 
discoveryRequestReceived(Address, String, Collection<PhysicalAddress>) - Method in class org.jgroups.protocols.Discovery
 
discoveryRequestReceived(Address, String, Collection<PhysicalAddress>) - Method in class org.jgroups.protocols.TCPPING
 
disp - Variable in class org.jgroups.blocks.ReplicatedHashMap
 
disp - Variable in class org.jgroups.demos.RelayDemoRpc
 
disp - Variable in class org.jgroups.demos.wb.Whiteboard
 
dispatchToThreadPool(Executor, Address, byte[], int, int) - Method in class org.jgroups.protocols.TP
 
displayMessage(String, String) - Method in class org.jgroups.demos.wb.Whiteboard
 
doConnect() - Method in class org.jgroups.stack.RouterStub
 
doFlush(Address) - Method in class org.jgroups.util.ForwardQueue
 
done() - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
Protected method invoked when this task transitions to state isDone (whether normally or via cancellation).
done(long) - Method in class org.jgroups.blocks.MessageDispatcher
 
done - Variable in class org.jgroups.blocks.Request
 
done(long) - Method in class org.jgroups.blocks.RequestCorrelator
Used to signal that a certain request may be garbage collected as all responses have been received.
done - Variable in class org.jgroups.protocols.relay.Relayer
Flag set when stop() is called.
done() - Method in class org.jgroups.protocols.relay.Relayer
 
done - Variable in class org.jgroups.util.HashedTimingWheel.MyTask
 
done - Variable in class org.jgroups.util.TimeScheduler2.MyTask
 
done - Variable in class org.jgroups.util.TimeScheduler3.Task
 
DONT_BUNDLE - Static variable in class org.jgroups.Message
 
doSchedule() - Method in class org.jgroups.stack.Retransmitter.Task
 
doSchedule() - Method in class org.jgroups.util.DefaultTimeScheduler.TaskWrapper
 
doSchedule(TimeScheduler3.Task, long) - Method in class org.jgroups.util.TimeScheduler3
 
doSend(byte[], int, int) - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
 
doSend(Buffer, Address, boolean) - Method in class org.jgroups.protocols.TP
 
DOUBLE_SIZE - Static variable in class org.jgroups.Global
 
down(Event) - Method in class org.jgroups.Channel
Enables access to event mechanism of a channel and is normally not used by clients directly.
down(Event) - Method in class org.jgroups.JChannel
Sends an event down the protocol stack.
down(Event) - Method in class org.jgroups.protocols.AUTH
An event is to be sent down the stack.
down(Event) - Method in class org.jgroups.protocols.BARRIER
 
down(Event) - Method in class org.jgroups.protocols.COMPRESS
We compress the payload if it is larger than min_size.
down(Event) - Method in class org.jgroups.protocols.COUNTER
 
down(Event) - Method in class org.jgroups.protocols.DAISYCHAIN
 
down(Event) - Method in class org.jgroups.protocols.DELAY
 
down(Event) - Method in class org.jgroups.protocols.DISCARD
 
down(Event) - Method in class org.jgroups.protocols.DISCARD_PAYLOAD
 
down(Event) - Method in class org.jgroups.protocols.Discovery
An event is to be sent down the stack.
down(Event) - Method in class org.jgroups.protocols.DUPL
 
down(Event) - Method in class org.jgroups.protocols.ENCRYPT
 
down(Event) - Method in class org.jgroups.protocols.EXAMPLE
 
down(Event) - Method in class org.jgroups.protocols.Executing
 
down(Event) - Method in class org.jgroups.protocols.FC
 
down(Event) - Method in class org.jgroups.protocols.FD
 
down(Event) - Method in class org.jgroups.protocols.FD_ALL
 
down(Event) - Method in class org.jgroups.protocols.FD_SIMPLE
 
down(Event) - Method in class org.jgroups.protocols.FD_SOCK
 
down(Event) - Method in class org.jgroups.protocols.FILE_PING
 
down(Event) - Method in class org.jgroups.protocols.FlowControl
 
down(Event) - Method in class org.jgroups.protocols.FORWARD_TO_COORD
 
down(Event) - Method in class org.jgroups.protocols.FRAG
Fragment a packet if larger than frag_size (add a header).
down(Event) - Method in class org.jgroups.protocols.FRAG2
Fragment a packet if larger than frag_size (add a header).
down(Event) - Method in class org.jgroups.protocols.HDRS
 
down(Event) - Method in class org.jgroups.protocols.HTOTAL
 
down(Event) - Method in class org.jgroups.protocols.Locking
 
down(Event) - Method in class org.jgroups.protocols.MERGE2
 
down(Event) - Method in class org.jgroups.protocols.MERGE3
 
down(Event) - Method in class org.jgroups.protocols.pbcast.FLUSH
 
down(Event) - Method in class org.jgroups.protocols.pbcast.GMS
 
down(Event) - Method in class org.jgroups.protocols.pbcast.NAKACK
Callback.
down(Event) - Method in class org.jgroups.protocols.pbcast.NAKACK2
Callback.
down(Event) - Method in class org.jgroups.protocols.pbcast.STABLE
 
down(Event) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
down(Event) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
down(Event) - Method in class org.jgroups.protocols.PDC
 
down(Event) - Method in class org.jgroups.protocols.PRIO
An event is to be sent down the stack.
down(Event) - Method in class org.jgroups.protocols.RATE_LIMITER
 
down(Event) - Method in class org.jgroups.protocols.RELAY
 
down(Event) - Method in class org.jgroups.protocols.relay.RELAY2
 
down(Event) - Method in class org.jgroups.protocols.RSVP
 
down(Event) - Method in interface org.jgroups.protocols.rules.EventHandler
Called when a down event is received
down(Event) - Method in class org.jgroups.protocols.rules.SUPERVISOR
 
down(Event) - Method in class org.jgroups.protocols.SCOPE
 
down(Event) - Method in class org.jgroups.protocols.SEQUENCER
 
down(Event) - Method in class org.jgroups.protocols.SHARED_LOOPBACK
 
down - Variable in class org.jgroups.protocols.SHUFFLE
 
down(Event) - Method in class org.jgroups.protocols.SHUFFLE
 
down(Event) - Method in class org.jgroups.protocols.SIZE
 
down(Event) - Method in class org.jgroups.protocols.STATS
 
down(Event) - Method in class org.jgroups.protocols.STOMP
 
down(Event) - Method in class org.jgroups.protocols.TCPPING
 
down(Event) - Method in class org.jgroups.protocols.tom.TOA
 
down(Event) - Method in class org.jgroups.protocols.TP
Caller by the layer above this layer.
down(Event) - Method in class org.jgroups.protocols.TP.ProtocolAdapter
 
down(Event) - Method in class org.jgroups.protocols.TRACE
 
down(Event) - Method in class org.jgroups.protocols.UNICAST
 
down(Event) - Method in class org.jgroups.protocols.UNICAST2
 
down(Event) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
 
down(Event) - Method in class org.jgroups.stack.Protocol
An event is to be sent down the stack.
down(Event) - Method in class org.jgroups.stack.ProtocolStack
 
down_msgs - Variable in class org.jgroups.protocols.SHUFFLE
 
down_prot - Variable in class org.jgroups.stack.Protocol
 
down_prot - Variable in class org.jgroups.util.ForwardQueue
 
down_tasks - Variable in class org.jgroups.protocols.relay.Relayer
Map to store tasks which set the status of a site from UNKNOWN to DOWN.
drainTo(Collection<? super T>) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
 
drainTo(Collection<? super T>, int) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
 
Draw - Class in org.jgroups.demos
Shared whiteboard, each new instance joins the same group.
Draw(String, boolean, boolean, boolean, long, boolean, String) - Constructor for class org.jgroups.demos.Draw
 
Draw(Channel) - Constructor for class org.jgroups.demos.Draw
 
Draw(Channel, boolean, long) - Constructor for class org.jgroups.demos.Draw
 
draw_dest - Static variable in class org.jgroups.demos.StompDraw
 
DrawApplet - Class in org.jgroups.demos.applets
 
DrawApplet() - Constructor for class org.jgroups.demos.applets.DrawApplet
 
DrawCommand - Class in org.jgroups.demos
Encapsulates information about a draw command.
DrawCommand() - Constructor for class org.jgroups.demos.DrawCommand
 
drawNode(Graphics, int, int, String, int) - Method in class org.jgroups.demos.Topology
 
drawTopology(Graphics) - Method in class org.jgroups.demos.Topology
 
DUMMY - Static variable in class org.jgroups.Global
 
DUMMY - Static variable in class org.jgroups.util.Seqno
 
dump() - Method in class org.jgroups.blocks.Cache
 
dump() - Method in class org.jgroups.blocks.PartitionedHashMap
 
dump() - Method in class org.jgroups.blocks.ReplCache
 
dump(String[], long[], long[]) - Static method in class org.jgroups.protocols.COUNTER
 
dump() - Method in class org.jgroups.util.RetransmitTable
Dumps the seqnos in the table as a list
dump() - Method in class org.jgroups.util.Table
Dumps the seqnos in the table as a list
dumpAddresssMappings() - Method in class org.jgroups.stack.GossipRouter
 
dumpChannelStats() - Method in class org.jgroups.JChannel
 
dumpMatrix() - Method in class org.jgroups.util.RetransmitTable
Dumps the non-null in the table in a pseudo graphic way
dumpPendingRequests() - Method in class org.jgroups.blocks.atomic.CounterService
 
dumpPendingRequests() - Method in class org.jgroups.protocols.COUNTER
 
dumpQueue(Queue) - Static method in class org.jgroups.util.Util
Debugging method used to dump the content of a protocol queue in a condensed form.
dumpRoutingTable() - Static method in class org.jgroups.protocols.SHARED_LOOPBACK
 
dumpRoutingTable() - Method in class org.jgroups.stack.GossipRouter
 
dumpRoutingTableDetailed() - Method in class org.jgroups.stack.GossipRouter
 
dumpRules() - Method in class org.jgroups.protocols.rules.SUPERVISOR
 
dumpScopes() - Method in class org.jgroups.protocols.SCOPE
 
dumpSocketInfo() - Method in class org.jgroups.protocols.UDP
 
dumpStats() - Method in class org.jgroups.Channel
Returns a map of statistics of the various protocols and of the channel itself.
dumpStats() - Method in class org.jgroups.JChannel
 
dumpStats(String, List<String>) - Method in class org.jgroups.JChannel
 
dumpStats(String) - Method in class org.jgroups.JChannel
 
dumpStats() - Method in class org.jgroups.protocols.FC
 
dumpStats() - Method in class org.jgroups.protocols.FlowControl
 
dumpStats() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
dumpStats() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
dumpStats() - Method in class org.jgroups.protocols.SEQUENCER
 
dumpStats() - Method in class org.jgroups.protocols.UFC
 
dumpStats() - Method in class org.jgroups.protocols.UNICAST
 
dumpStats() - Method in class org.jgroups.stack.Protocol
 
dumpStats() - Method in class org.jgroups.stack.ProtocolStack
 
dumpStats(String) - Method in class org.jgroups.stack.ProtocolStack
 
dumpStats(String, List<String>) - Method in class org.jgroups.stack.ProtocolStack
 
dumpThreads() - Static method in class org.jgroups.util.Util
 
dumpTimerQueue() - Method in class org.jgroups.JChannel
 
dumpTimerTasks() - Method in class org.jgroups.protocols.TP
 
dumpTimerTasks() - Method in class org.jgroups.util.DefaultTimeScheduler
 
dumpTimerTasks() - Method in class org.jgroups.util.HashedTimingWheel
 
dumpTimerTasks() - Method in class org.jgroups.util.MockTimeScheduler
 
dumpTimerTasks() - Method in interface org.jgroups.util.TimeScheduler
Returns a list of tasks currently waiting for execution.
dumpTimerTasks() - Method in class org.jgroups.util.TimeScheduler2
 
dumpTimerTasks() - Method in class org.jgroups.util.TimeScheduler3
 
dumpViewHandlerHistory() - Method in class org.jgroups.protocols.pbcast.GMS
 
dumpViewHandlerQueue() - Method in class org.jgroups.protocols.pbcast.GMS
 
dumpViews() - Method in class org.jgroups.protocols.MERGE3
 
dumpXmitTablesNumCurrentRows() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
DUPL - Class in org.jgroups.protocols
Duplicates outgoing or incoming messages by copying them
DUPL() - Constructor for class org.jgroups.protocols.DUPL
 
DUPL(boolean, boolean, int, int) - Constructor for class org.jgroups.protocols.DUPL
 
dx - Variable in class org.jgroups.demos.wb.Node
 
dy - Variable in class org.jgroups.demos.wb.Node
 
dynamic_hosts - Variable in class org.jgroups.protocols.TCPPING
https://jira.jboss.org/jira/browse/JGRP-989

E

elementAt(int) - Method in class org.jgroups.Membership
Returns the component at the specified index
elements_per_row - Variable in class org.jgroups.util.Table
 
emptyGossipClientStubManager(Protocol) - Static method in class org.jgroups.stack.RouterStubManager
 
enable_address_tagging - Variable in class org.jgroups.protocols.relay.RELAY2
 
enable_bundling - Variable in class org.jgroups.protocols.TP
 
enable_diagnostics - Variable in class org.jgroups.protocols.TP
 
enable_unicast_bundling - Variable in class org.jgroups.protocols.TP
Enable bundling for unicast messages.
enableAddressTagging(boolean) - Method in class org.jgroups.protocols.relay.RELAY2
 
enableAddressTagging() - Method in class org.jgroups.protocols.relay.RELAY2
 
enableReaping(long) - Method in class org.jgroups.blocks.Cache
Runs the reaper every interval ms, evicts expired items
enableStats(boolean) - Method in class org.jgroups.JChannel
 
enableStats(boolean) - Method in class org.jgroups.protocols.tom.TOA
 
enableStats(boolean) - Method in class org.jgroups.stack.Protocol
 
encode(long) - Static method in class org.jgroups.util.Util
 
encode(int, int, int) - Static method in class org.jgroups.Version
Method copied from http://www.jboss.com/index.html?module=bb&op=viewtopic&t=77231
encodeLength(byte, byte) - Static method in class org.jgroups.util.Util
Encodes the number of bytes needed into a single byte.
encodeLongSequence(long, long) - Static method in class org.jgroups.util.Util
Encode the highest delivered and received seqnos.
encrypt(byte[]) - Static method in class org.jgroups.auth.DemoToken
 
ENCRYPT - Class in org.jgroups.protocols
ENCRYPT layer.
ENCRYPT() - Constructor for class org.jgroups.protocols.ENCRYPT
 
ENCRYPT - Static variable in class org.jgroups.protocols.ENCRYPT.EncryptHeader
 
ENCRYPT.EncryptHeader - Class in org.jgroups.protocols
 
ENCRYPT.EncryptHeader() - Constructor for class org.jgroups.protocols.ENCRYPT.EncryptHeader
 
ENCRYPT.EncryptHeader(short) - Constructor for class org.jgroups.protocols.ENCRYPT.EncryptHeader
 
ENCRYPT.EncryptHeader(short, String) - Constructor for class org.jgroups.protocols.ENCRYPT.EncryptHeader
 
encryptedToken(byte[]) - Method in class org.jgroups.auth.X509Token
To be used for testing only
end_of_current_period - Variable in class org.jgroups.protocols.RATE_LIMITER
 
endpoint - Variable in class org.jgroups.protocols.STOMP
 
endpoint_addr - Variable in class org.jgroups.protocols.STOMP
 
ENDPOINTS - Static variable in class org.jgroups.demos.StompChat
 
endpoints - Variable in class org.jgroups.protocols.STOMP
 
ensureValidBindAddresses(List<Protocol>) - Static method in class org.jgroups.stack.Configurator
Makes sure that all fields annotated with @LocalAddress is (1) an InetAddress and (2) a valid address on any local network interface
entryRemoved(K) - Method in interface org.jgroups.blocks.ReplicatedHashMap.Notification
 
entryRemoved(Object) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
 
entrySet() - Method in class org.jgroups.blocks.Cache
 
entrySet() - Method in class org.jgroups.blocks.ReplicatedHashMap
 
entrySet(K, V) - Method in interface org.jgroups.blocks.ReplicatedHashMap.Notification
 
entrySet(Object, Object) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
 
entrySet() - Method in class org.jgroups.util.RspList
 
equals(Object) - Method in class org.jgroups.AnycastAddress
 
equals(Object) - Method in class org.jgroups.blocks.mux.NoMuxHandler
 
equals(Object) - Method in class org.jgroups.protocols.Executing.Owner
 
equals(Object) - Method in class org.jgroups.protocols.PingData
 
equals(Object) - Method in class org.jgroups.protocols.relay.SiteMaster
 
equals(Object) - Method in class org.jgroups.protocols.tom.MessageID
 
equals(Object) - Method in class org.jgroups.stack.IpAddress
 
equals(Object) - Method in class org.jgroups.util.Digest
Not really used, other than in unit tests and by FLUSH (reconciliation phase), so it doesn't need to be super efficient
equals(Object) - Method in class org.jgroups.util.MergeId
 
equals(Object) - Method in class org.jgroups.util.Owner
 
equals(Object) - Method in class org.jgroups.util.Range
 
equals(Object) - Method in class org.jgroups.util.Rsp
 
equals(Object) - Method in class org.jgroups.util.Seqno
 
equals(Object) - Method in class org.jgroups.util.SingletonAddress
 
equals(Object) - Method in class org.jgroups.util.UUID
Compares this object to the specified object.
equals(Object) - Method in class org.jgroups.View
 
equals(Object) - Method in class org.jgroups.ViewId
 
ergonomics - Variable in class org.jgroups.stack.Protocol
 
error(String) - Method in class org.jgroups.logging.JDKLogImpl
 
error(String, Throwable) - Method in class org.jgroups.logging.JDKLogImpl
 
error(String) - Method in interface org.jgroups.logging.Log
 
error(String, Throwable) - Method in interface org.jgroups.logging.Log
 
error(String) - Method in class org.jgroups.logging.Log4JLogImpl
 
error(String, Throwable) - Method in class org.jgroups.logging.Log4JLogImpl
 
error_message - Variable in class org.jgroups.protocols.COUNTER.ExceptionResponse
 
eval() - Method in class org.jgroups.protocols.rules.CheckFDMonitor
 
eval() - Method in class org.jgroups.protocols.rules.Rule
Evaluates the condition.
eval() - Method in class org.jgroups.protocols.rules.SampleRule
 
Event - Class in org.jgroups
Event is a JGroups internal class used for inter-stack and intra-stack communication.
Event(int) - Constructor for class org.jgroups.Event
 
Event(int, Object) - Constructor for class org.jgroups.Event
 
event_handlers - Variable in class org.jgroups.protocols.rules.SUPERVISOR
 
EventHandler - Interface in org.jgroups.protocols.rules
Interface which defines 2 callbacks: up() and down().
evictLogicalAddressCache() - Method in class org.jgroups.protocols.TP
 
evictLogicalAddressCache(boolean) - Method in class org.jgroups.protocols.TP
 
exact_destination_match - Variable in class org.jgroups.protocols.STOMP
 
EXAMPLE - Class in org.jgroups.protocols
Example of a protocol layer.
EXAMPLE() - Constructor for class org.jgroups.protocols.EXAMPLE
 
EXAMPLE.ExampleHeader - Class in org.jgroups.protocols
 
EXAMPLE.ExampleHeader() - Constructor for class org.jgroups.protocols.EXAMPLE.ExampleHeader
 
EXC_RSP - Static variable in class org.jgroups.blocks.RequestCorrelator.Header
 
exception - Variable in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture.Sync
The exception to throw from get()
exception - Variable in class org.jgroups.util.Rsp
If there was an exception, this field will contain it
exception - Variable in class org.jgroups.util.StateTransferResult
 
exclusion_list - Variable in class org.jgroups.blocks.RequestCorrelator.MultiDestinationHeader
Contains a list of members who should not receive the request (others will drop).
exclusion_list - Variable in class org.jgroups.blocks.RequestOptions
A list of members which should be excluded from a call
execute(Runnable) - Method in class org.jgroups.blocks.executor.ExecutionService
 
execute() - Method in class org.jgroups.blocks.Request
 
execute(Runnable) - Method in class org.jgroups.util.DirectExecutor
 
execute(Runnable) - Method in class org.jgroups.util.HashedTimingWheel
 
execute(Runnable) - Method in class org.jgroups.util.MockTimeScheduler
 
execute(Runnable) - Method in interface org.jgroups.util.TimeScheduler
Executes command with zero required delay.
execute(Runnable) - Method in class org.jgroups.util.TimeScheduler2
 
execute(Runnable) - Method in class org.jgroups.util.TimeScheduler3
 
Executing - Class in org.jgroups.protocols
This is the base protocol used for executions.
Executing() - Constructor for class org.jgroups.protocols.Executing
 
Executing.ExecutorHeader - Class in org.jgroups.protocols
 
Executing.ExecutorHeader() - Constructor for class org.jgroups.protocols.Executing.ExecutorHeader
 
Executing.Owner - Class in org.jgroups.protocols
 
Executing.Owner(Address, long) - Constructor for class org.jgroups.protocols.Executing.Owner
 
Executing.Request - Class in org.jgroups.protocols
 
Executing.Request() - Constructor for class org.jgroups.protocols.Executing.Request
 
Executing.Request(Executing.Type, Object, long) - Constructor for class org.jgroups.protocols.Executing.Request
 
Executing.RequestWithThread - Class in org.jgroups.protocols
 
Executing.RequestWithThread() - Constructor for class org.jgroups.protocols.Executing.RequestWithThread
 
Executing.RequestWithThread(Executing.Type, Object, long, long) - Constructor for class org.jgroups.protocols.Executing.RequestWithThread
 
Executing.Type - Enum in org.jgroups.protocols
 
execution_service - Variable in class org.jgroups.demos.ExecutionServiceDemo
 
execution_time - Variable in class org.jgroups.util.TimeScheduler3.Task
 
ExecutionCompletionService<V> - Class in org.jgroups.blocks.executor
A CompletionService that uses a supplied ExecutionService to execute tasks.
ExecutionCompletionService(ExecutionService) - Constructor for class org.jgroups.blocks.executor.ExecutionCompletionService
Creates an ExecutorCompletionService using the supplied executor for base task execution and a LinkedBlockingQueue as a completion queue.
ExecutionCompletionService(ExecutionService, BlockingQueue<NotifyingFuture<V>>) - Constructor for class org.jgroups.blocks.executor.ExecutionCompletionService
Creates an ExecutorCompletionService using the supplied executor for base task execution and the supplied queue as its completion queue.
ExecutionCompletionService(ExecutionService, BlockingQueue<NotifyingFuture<V>>, ExecutionCompletionService<V>.QueueingListener) - Constructor for class org.jgroups.blocks.executor.ExecutionCompletionService
This constructor is here if someone wants to override this class and provide their own QueueingListener to possibly listen in on futures being finished
ExecutionCompletionService.QueueingListener - Class in org.jgroups.blocks.executor
 
ExecutionCompletionService.QueueingListener() - Constructor for class org.jgroups.blocks.executor.ExecutionCompletionService.QueueingListener
 
ExecutionRunner - Class in org.jgroups.blocks.executor
This class is to be used to pick up execution requests and actually run them.
ExecutionRunner(JChannel) - Constructor for class org.jgroups.blocks.executor.ExecutionRunner
 
ExecutionRunner.Holder<T> - Class in org.jgroups.blocks.executor
 
ExecutionRunner.Holder(T) - Constructor for class org.jgroups.blocks.executor.ExecutionRunner.Holder
 
Executions - Class in org.jgroups.blocks.executor
 
Executions() - Constructor for class org.jgroups.blocks.executor.Executions
 
executions - Variable in class org.jgroups.protocols.rules.SUPERVISOR
 
executions() - Method in class org.jgroups.protocols.rules.SUPERVISOR
 
Executions.StreamableCallable - Class in org.jgroups.blocks.executor
 
Executions.StreamableCallable() - Constructor for class org.jgroups.blocks.executor.Executions.StreamableCallable
 
Executions.StreamableCallable(Class<? extends Callable<?>>, byte, Object...) - Constructor for class org.jgroups.blocks.executor.Executions.StreamableCallable
 
ExecutionService - Class in org.jgroups.blocks.executor
This is a jgroups implementation of an ExecutorService, where the consumers are running on any number of nodes.
ExecutionService() - Constructor for class org.jgroups.blocks.executor.ExecutionService
 
ExecutionService(JChannel) - Constructor for class org.jgroups.blocks.executor.ExecutionService
 
ExecutionService.DistributedFuture<V> - Class in org.jgroups.blocks.executor
This is basically a copy of the FutureTask in java.util.concurrent but added serializable to it.
ExecutionService.DistributedFuture(JChannel, Lock, Condition, Set<Future<?>>, Callable<V>) - Constructor for class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
Creates a FutureTask that will upon running, execute the given Callable.
ExecutionService.DistributedFuture(JChannel, Lock, Condition, Set<Future<?>>, Runnable, V) - Constructor for class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
Creates a FutureTask that will upon running, execute the given Runnable, and arrange that get will return the given result on successful completion.
ExecutionService.DistributedFuture.Sync<V> - Class in org.jgroups.blocks.executor
Synchronization control for FutureTask.
ExecutionService.DistributedFuture.Sync(ExecutionService.DistributedFuture<V>, Callable<V>) - Constructor for class org.jgroups.blocks.executor.ExecutionService.DistributedFuture.Sync
 
ExecutionService.RunnableAdapter<T> - Class in org.jgroups.blocks.executor
This is copied from Executors class which contains RunnableAdapter.
ExecutionService.RunnableAdapter() - Constructor for class org.jgroups.blocks.executor.ExecutionService.RunnableAdapter
 
ExecutionService.RunnableAdapter(Runnable, T) - Constructor for class org.jgroups.blocks.executor.ExecutionService.RunnableAdapter
 
ExecutionServiceDemo - Class in org.jgroups.demos
 
ExecutionServiceDemo(String, String, int) - Constructor for class org.jgroups.demos.ExecutionServiceDemo
 
ExecutionServiceDemo.ByteBufferStreamable - Class in org.jgroups.demos
 
ExecutionServiceDemo.ByteBufferStreamable() - Constructor for class org.jgroups.demos.ExecutionServiceDemo.ByteBufferStreamable
 
ExecutionServiceDemo.ByteBufferStreamable(ByteBuffer) - Constructor for class org.jgroups.demos.ExecutionServiceDemo.ByteBufferStreamable
 
ExecutionServiceDemo.SortingByteCallable - Class in org.jgroups.demos
 
ExecutionServiceDemo.SortingByteCallable() - Constructor for class org.jgroups.demos.ExecutionServiceDemo.SortingByteCallable
 
ExecutionServiceDemo.SortingByteCallable(byte[], int, int) - Constructor for class org.jgroups.demos.ExecutionServiceDemo.SortingByteCallable
 
ExecutionServiceDemo.SortingTwoByteCallable - Class in org.jgroups.demos
Sorts 2 byte arrys into a larger byte array
ExecutionServiceDemo.SortingTwoByteCallable() - Constructor for class org.jgroups.demos.ExecutionServiceDemo.SortingTwoByteCallable
 
ExecutionServiceDemo.SortingTwoByteCallable(ExecutionServiceDemo.ByteBufferStreamable, ExecutionServiceDemo.ByteBufferStreamable) - Constructor for class org.jgroups.demos.ExecutionServiceDemo.SortingTwoByteCallable
 
executor - Variable in class org.jgroups.blocks.executor.ExecutionCompletionService
 
executor - Variable in class org.jgroups.demos.ExecutionServiceDemo
 
ExecutorEvent - Class in org.jgroups.blocks.executor
Defines an event class for the execution of an entity.
ExecutorEvent(int, Object) - Constructor for class org.jgroups.blocks.executor.ExecutorEvent
 
ExecutorNotification - Interface in org.jgroups.blocks.executor
 
exists() - Method in class org.jgroups.blocks.GridFile
 
exists(String) - Method in class org.jgroups.blocks.ReplicatedTree
Checks whether a given node exists in the tree
expected - Variable in class org.jgroups.protocols.COUNTER.CompareAndSetRequest
 
expected_acks - Variable in class org.jgroups.util.AckCollector
 
expectedAcks() - Method in class org.jgroups.util.AckCollector
 
Experimental - Annotation Type in org.jgroups.annotations
Elements annotated with this annotation are experimental and may get removed from the distribution at any time
expiration_interval - Variable in class org.jgroups.protocols.SCOPE
 
expiration_time - Variable in class org.jgroups.protocols.SCOPE
 
expire(short) - Method in class org.jgroups.protocols.SCOPE
Multicasts an EXPIRE message to all members, and - on reception - each member removes the scope locally
EXPIRE - Static variable in class org.jgroups.protocols.SCOPE.ScopeHeader
 
expired(Address) - Method in class org.jgroups.protocols.UNICAST
Called by AgeOutCache, to removed expired connections
expired(Address) - Method in class org.jgroups.protocols.UNICAST2
Called by AgeOutCache, to removed expired connections
expired(K) - Method in interface org.jgroups.util.AgeOutCache.Handler
 
expiry_task - Variable in class org.jgroups.protocols.SCOPE
 
ExpiryCache<K> - Class in org.jgroups.util
Cache which maintains timestamps for keys, and methods to remove/replace expired keys.
ExpiryCache(long) - Constructor for class org.jgroups.util.ExpiryCache
Creates a new instance
exponential_backoff - Variable in class org.jgroups.protocols.UNICAST2
Deprecated. 
ExponentialInterval - Class in org.jgroups.stack
 
ExponentialInterval() - Constructor for class org.jgroups.stack.ExponentialInterval
 
ExponentialInterval(int) - Constructor for class org.jgroups.stack.ExponentialInterval
 
ExposedByteArrayInputStream - Class in org.jgroups.util
 
ExposedByteArrayInputStream(byte[]) - Constructor for class org.jgroups.util.ExposedByteArrayInputStream
Creates a ByteArrayInputStream so that it uses buf as its buffer array.
ExposedByteArrayInputStream(byte[], int, int) - Constructor for class org.jgroups.util.ExposedByteArrayInputStream
Creates ByteArrayInputStream that uses buf as its buffer array.
ExposedByteArrayOutputStream - Class in org.jgroups.util
Extends ByteArrayOutputStream, but exposes the internal buffer.
ExposedByteArrayOutputStream() - Constructor for class org.jgroups.util.ExposedByteArrayOutputStream
 
ExposedByteArrayOutputStream(int) - Constructor for class org.jgroups.util.ExposedByteArrayOutputStream
 
ExposedDataOutputStream - Class in org.jgroups.util
 
ExposedDataOutputStream(OutputStream) - Constructor for class org.jgroups.util.ExposedDataOutputStream
Creates a new data output stream to write data to the specified underlying output stream.
EXTERNAL_ADDR - Static variable in class org.jgroups.Global
 
external_addr - Variable in class org.jgroups.protocols.FD_SOCK
 
external_addr - Variable in class org.jgroups.protocols.pbcast.STATE_SOCK
 
external_addr - Variable in class org.jgroups.protocols.TP
 
EXTERNAL_PORT - Static variable in class org.jgroups.Global
 
external_port - Variable in class org.jgroups.protocols.FD_SOCK
 
external_port - Variable in class org.jgroups.protocols.pbcast.STATE_SOCK
 
external_port - Variable in class org.jgroups.protocols.TP
 

F

f - Static variable in class org.jgroups.protocols.TP
 
factory - Variable in class org.jgroups.blocks.AbstractConnectionMap
 
FAIL_REASON_PRESENT - Static variable in class org.jgroups.protocols.pbcast.JoinRsp
 
fatal(String) - Method in class org.jgroups.logging.JDKLogImpl
 
fatal(String, Throwable) - Method in class org.jgroups.logging.JDKLogImpl
 
fatal(String) - Method in interface org.jgroups.logging.Log
 
fatal(String, Throwable) - Method in interface org.jgroups.logging.Log
 
fatal(String) - Method in class org.jgroups.logging.Log4JLogImpl
 
fatal(String, Throwable) - Method in class org.jgroups.logging.Log4JLogImpl
 
FC - Class in org.jgroups.protocols
Simple flow control protocol based on a credit system.
FC() - Constructor for class org.jgroups.protocols.FC
 
FcHeader - Class in org.jgroups.protocols
Header used by various flow control protocols
FcHeader() - Constructor for class org.jgroups.protocols.FcHeader
 
FcHeader(byte) - Constructor for class org.jgroups.protocols.FcHeader
 
FD - Class in org.jgroups.protocols
Failure detection based on simple heartbeat protocol.
FD() - Constructor for class org.jgroups.protocols.FD
 
fd - Variable in class org.jgroups.protocols.rules.CheckFDMonitor
 
FD.Broadcaster - Class in org.jgroups.protocols
Task that periodically broadcasts a list of suspected members to the group.
FD.Broadcaster() - Constructor for class org.jgroups.protocols.FD.Broadcaster
 
FD.BroadcastTask - Class in org.jgroups.protocols
 
FD.FdHeader - Class in org.jgroups.protocols
 
FD.FdHeader() - Constructor for class org.jgroups.protocols.FD.FdHeader
 
FD.FdHeader(byte) - Constructor for class org.jgroups.protocols.FD.FdHeader
 
FD.FdHeader(byte, Collection<Address>, Address) - Constructor for class org.jgroups.protocols.FD.FdHeader
 
FD.Monitor - Class in org.jgroups.protocols
Task which periodically checks of the last_ack from ping_dest exceeded timeout and - if yes - broadcasts a SUSPECT message
FD.Monitor() - Constructor for class org.jgroups.protocols.FD.Monitor
 
FD_ALL - Class in org.jgroups.protocols
Failure detection based on simple heartbeat protocol.
FD_ALL() - Constructor for class org.jgroups.protocols.FD_ALL
 
FD_ALL.HeartbeatHeader - Class in org.jgroups.protocols
 
FD_ALL.HeartbeatHeader() - Constructor for class org.jgroups.protocols.FD_ALL.HeartbeatHeader
 
FD_ICMP - Class in org.jgroups.protocols
Protocol which uses InetAddress.isReachable() to check whether a given host is up or not, taking 1 argument; the host name of the host to be pinged.
FD_ICMP() - Constructor for class org.jgroups.protocols.FD_ICMP
 
FD_ICMP.PingMonitor - Class in org.jgroups.protocols
Runs InetAddress.isReachable().
FD_ICMP.PingMonitor() - Constructor for class org.jgroups.protocols.FD_ICMP.PingMonitor
 
FD_PING - Class in org.jgroups.protocols
Protocol which uses an executable (e.g.
FD_PING() - Constructor for class org.jgroups.protocols.FD_PING
 
FD_PING.Pinger - Class in org.jgroups.protocols
 
FD_PING.Pinger() - Constructor for class org.jgroups.protocols.FD_PING.Pinger
 
FD_PING.PingMonitor - Class in org.jgroups.protocols
Executes the ping command.
FD_PING.PingMonitor() - Constructor for class org.jgroups.protocols.FD_PING.PingMonitor
 
FD_SIMPLE - Class in org.jgroups.protocols
Simple failure detection protocol.
FD_SIMPLE() - Constructor for class org.jgroups.protocols.FD_SIMPLE
 
FD_SIMPLE.FdHeader - Class in org.jgroups.protocols
 
FD_SIMPLE.FdHeader() - Constructor for class org.jgroups.protocols.FD_SIMPLE.FdHeader
 
FD_SOCK - Class in org.jgroups.protocols
Failure detection protocol based on sockets.
FD_SOCK() - Constructor for class org.jgroups.protocols.FD_SOCK
 
FD_SOCK.FdHeader - Class in org.jgroups.protocols
 
FD_SOCK.FdHeader() - Constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
 
FD_SOCK.FdHeader(byte) - Constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
 
FD_SOCK.FdHeader(byte, Address) - Constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
 
FD_SOCK.FdHeader(byte, Address, IpAddress) - Constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
 
FD_SOCK.FdHeader(byte, Set<Address>) - Constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
 
FD_SOCK.FdHeader(byte, Map<Address, IpAddress>) - Constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
 
fetchClusterMembers(String) - Method in class org.jgroups.protocols.Discovery
Grab all current cluster members
fetchClusterMembers(String) - Method in class org.jgroups.protocols.FILE_PING
 
fetchClusterMembers(String) - Method in class org.jgroups.protocols.PING
 
fetchClusterMembers(String) - Method in class org.jgroups.protocols.TCPGOSSIP
 
fetchClusterMembers(String) - Method in class org.jgroups.protocols.TCPPING
 
fetchLocalAddresses() - Method in class org.jgroups.protocols.TP
Grabs the local address (or addresses in the shared transport case) and registers them with the physical address in the transport's cache
fetchState(long) - Method in class org.jgroups.blocks.ReplicatedTree
Fetch the group state from the current coordinator.
FILE - Static variable in class org.jgroups.blocks.GridFile.Metadata
 
file - Variable in class org.jgroups.blocks.GridInputStream
 
file - Variable in class org.jgroups.blocks.GridOutputStream
 
FILE_PING - Class in org.jgroups.protocols
Simple discovery protocol which uses a file on shared storage such as an SMB share, NFS mount or S3.
FILE_PING() - Constructor for class org.jgroups.protocols.FILE_PING
 
FILE_PING.WriterTask - Class in org.jgroups.protocols
 
FILE_PING.WriterTask() - Constructor for class org.jgroups.protocols.FILE_PING.WriterTask
 
fileExists(String) - Static method in class org.jgroups.util.Util
 
filename(String) - Static method in class org.jgroups.blocks.GridFile
 
filter - Variable in class org.jgroups.protocols.FILE_PING
 
filter - Variable in class org.jgroups.protocols.PDC
 
final_dest - Variable in class org.jgroups.protocols.relay.RELAY2.Relay2Header
 
FINAL_MESSAGE - Static variable in class org.jgroups.protocols.tom.ToaHeader
 
find(Address) - Method in class org.jgroups.util.Digest
 
FIND_ALL_VIEWS - Static variable in class org.jgroups.Event
 
FIND_INITIAL_MBRS - Static variable in class org.jgroups.Event
 
findAllViews(Promise<JoinRsp>) - Method in class org.jgroups.protocols.Discovery
 
findAllViews() - Method in class org.jgroups.protocols.MERGE2.FindSubgroupsTask
Returns a list of PingData with only the view from members around the cluster
findAllViewsAsString() - Method in class org.jgroups.protocols.Discovery
 
findAndNotify() - Method in class org.jgroups.protocols.MERGE2.FindSubgroupsTask
 
findClassesAnnotatedWith(String, Class<? extends Annotation>) - Static method in class org.jgroups.util.Util
 
findClassesAssignableFrom(String, Class<T>) - Static method in class org.jgroups.util.Util
 
findGetter(Class, String) - Static method in class org.jgroups.jmx.ResourceDMBean
 
findInitialMembers(Promise<JoinRsp>) - Method in class org.jgroups.protocols.Discovery
Finds initial members
findInitialMembersAsString() - Method in class org.jgroups.protocols.Discovery
 
findMembers(Promise<JoinRsp>, int, boolean, ViewId) - Method in class org.jgroups.protocols.Discovery
 
findMethod(Class, String, Object[]) - Static method in class org.jgroups.blocks.MethodCall
Called by the ProbeHandler impl.
findMethod(short) - Method in interface org.jgroups.blocks.MethodLookup
 
findProtocol(String) - Method in class org.jgroups.stack.ProtocolStack
Returns a given protocol or null if not found
findProtocol(Class<?>) - Method in class org.jgroups.stack.ProtocolStack
 
findProtocol(Class<?>...) - Method in class org.jgroups.stack.ProtocolStack
Finds the first protocol of a list and returns it.
findSetter(Class, String) - Static method in class org.jgroups.jmx.ResourceDMBean
 
first - Variable in class org.jgroups.protocols.SCOPE.QueueThread
 
first - Variable in class org.jgroups.util.Table.Dump
 
fixDigests() - Method in class org.jgroups.protocols.pbcast.GMS
 
fixed - Variable in class org.jgroups.demos.wb.Node
 
FixedMembershipToken - Class in org.jgroups.auth
The FixedMemberShipToken object predefines a list of IP addresses and ports that can join the group.
FixedMembershipToken() - Constructor for class org.jgroups.auth.FixedMembershipToken
 
FixedMembershipToken(String) - Constructor for class org.jgroups.auth.FixedMembershipToken
 
FixedSizeBitSet - Class in org.jgroups.util
Class copied from BitSet.
FixedSizeBitSet(int) - Constructor for class org.jgroups.util.FixedSizeBitSet
Creates a bit set whose initial size is the range 0 through size-1.
flags - Variable in class org.jgroups.blocks.RequestOptions
The flags set in the message in which a request is sent
flags - Variable in class org.jgroups.Message
 
flagsToString(short) - Static method in class org.jgroups.Message
 
flip() - Method in class org.jgroups.util.FixedSizeBitSet
Flips all bits: 1 --> 0 and 0 --> 1
FLOAT_SIZE - Static variable in class org.jgroups.Global
 
FlowControl - Class in org.jgroups.protocols
Simple flow control protocol based on a credit system.
FlowControl() - Constructor for class org.jgroups.protocols.FlowControl
 
FlowControl.Credit - Class in org.jgroups.protocols
 
FlowControl.Credit(long) - Constructor for class org.jgroups.protocols.FlowControl.Credit
 
flush() - Method in class org.jgroups.blocks.GridOutputStream
 
FLUSH - Static variable in class org.jgroups.Global
 
FLUSH - Class in org.jgroups.protocols.pbcast
Flush, as it name implies, forces group members to flush their pending messages while blocking them to send any additional messages.
FLUSH() - Constructor for class org.jgroups.protocols.pbcast.FLUSH
 
flush(Address) - Method in class org.jgroups.protocols.SEQUENCER
 
FLUSH - Static variable in class org.jgroups.protocols.SEQUENCER.SequencerHeader
 
flush(Address, List<Address>) - Method in class org.jgroups.util.ForwardQueue
 
FLUSH.FlushHeader - Class in org.jgroups.protocols.pbcast
 
FLUSH.FlushHeader() - Constructor for class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
 
FLUSH.FlushHeader(byte) - Constructor for class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
 
FLUSH.FlushHeader(byte, long) - Constructor for class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
 
FLUSH.FlushHeader(byte, long, Collection<? extends Address>) - Constructor for class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
 
flush_ack - Variable in class org.jgroups.protocols.SEQUENCER.SequencerHeader
 
FLUSH_BYPASS - Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
 
FLUSH_COMPLETED - Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
 
FLUSH_NOT_COMPLETED - Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
 
FLUSH_RECONCILE - Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
 
FLUSH_RECONCILE_OK - Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
 
flush_supported - Variable in class org.jgroups.JChannel
True if a flush protocol is available, false otherwise (set by CONFIG event from FLUSH protocol)
flushAccumulatedCredits() - Method in class org.jgroups.util.CreditMap
 
flushBecomeServerQueue() - Method in class org.jgroups.protocols.pbcast.NAKACK
Flushes the queue.
flushBecomeServerQueue() - Method in class org.jgroups.protocols.pbcast.NAKACK2
Flushes the queue.
flusher - Variable in class org.jgroups.protocols.SEQUENCER
 
flusher - Variable in class org.jgroups.util.ForwardQueue
 
flushing - Variable in class org.jgroups.protocols.SEQUENCER
Set when we block all sending threads to resend all messages from forward_table
flushing - Variable in class org.jgroups.util.ForwardQueue
Set when we block all sending threads to resend all messages from forward_table
flushInvokerClass - Variable in class org.jgroups.protocols.pbcast.GMS
 
flushMessagesInForwardTable() - Method in class org.jgroups.protocols.SEQUENCER
Sends all messages currently in forward_table to the new coordinator (changing the dest field).
flushMessagesInForwardTable(Address) - Method in class org.jgroups.util.ForwardQueue
Sends all messages currently in forward_table to the new target (changing the dest field).
flushProtocolInStack - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
flushQueue(short, Relayer.Route) - Method in class org.jgroups.protocols.relay.Relayer.Bridge
 
flushSupported() - Method in class org.jgroups.Channel
 
flushSupported() - Method in class org.jgroups.JChannel
 
focusGained(FocusEvent) - Method in class org.jgroups.demos.wb.Whiteboard
 
focusLost(FocusEvent) - Method in class org.jgroups.demos.wb.Whiteboard
 
foo() - Method in class org.jgroups.demos.JmxDemo
 
foobar() - Method in class org.jgroups.demos.JmxDemo
 
force_sending_discovery_rsps - Variable in class org.jgroups.protocols.Discovery
 
forEach(long, long, Table.Visitor<T>) - Method in class org.jgroups.util.Table
Iterates over the matrix with range [from ..
format(double) - Static method in class org.jgroups.util.Util
 
FORWARD - Static variable in class org.jgroups.protocols.relay.config.RelayConfig
 
forward(byte[], int, int) - Method in class org.jgroups.protocols.RELAY
Forwards the message across the TCP link to the other local cluster
forward(byte[], long, boolean) - Method in class org.jgroups.protocols.SEQUENCER
 
FORWARD - Static variable in class org.jgroups.protocols.SEQUENCER.SequencerHeader
 
forward_non_client_generated_msgs - Variable in class org.jgroups.protocols.STOMP
 
forward_sleep - Variable in class org.jgroups.protocols.relay.RELAY2
Deprecated. 
forward_sm_time - Variable in class org.jgroups.protocols.relay.RELAY2
 
forward_table - Variable in class org.jgroups.protocols.SEQUENCER
Maintains messages forwarded to the coord which which no ack has been received yet.
forward_table - Variable in class org.jgroups.util.ForwardQueue
Maintains messages forwarded to the target which which no ack has been received yet.
FORWARD_TO_COORD - Static variable in class org.jgroups.Event
 
FORWARD_TO_COORD - Class in org.jgroups.protocols
Forwards a message to the current coordinator.
FORWARD_TO_COORD() - Constructor for class org.jgroups.protocols.FORWARD_TO_COORD
 
FORWARD_TO_COORD.ForwardHeader - Class in org.jgroups.protocols
 
FORWARD_TO_COORD.ForwardHeader() - Constructor for class org.jgroups.protocols.FORWARD_TO_COORD.ForwardHeader
 
FORWARD_TO_COORD.ForwardHeader(byte, long) - Constructor for class org.jgroups.protocols.FORWARD_TO_COORD.ForwardHeader
 
forward_to_local_mbr - Variable in class org.jgroups.protocols.relay.RELAY2
Number of messages (received from a remote Sitemaster and) delivered by the local SiteMaster to a local node
forward_to_local_mbr_time - Variable in class org.jgroups.protocols.relay.RELAY2
 
forward_to_site_master - Variable in class org.jgroups.protocols.relay.RELAY2
Number of messages forwarded to the local SiteMaster
forwarded_msgs - Variable in class org.jgroups.protocols.SEQUENCER
 
forwarding_protocol_present - Variable in class org.jgroups.protocols.relay.RELAY2
Whether or not FORWARD_TO_COORD is on the stack
ForwardQueue - Class in org.jgroups.util
Forwards messages in FIFO order to a destination.
ForwardQueue(Log) - Constructor for class org.jgroups.util.ForwardQueue
 
ForwardQueue.Flusher - Class in org.jgroups.util
 
ForwardQueue.Flusher(Address) - Constructor for class org.jgroups.util.ForwardQueue.Flusher
 
forwardQueueMaxSize(int) - Method in class org.jgroups.protocols.relay.RELAY2
 
forwardQueueMaxSize() - Method in class org.jgroups.protocols.relay.RELAY2
 
FORWARDS - Static variable in class org.jgroups.protocols.relay.config.RelayConfig
 
forwards - Variable in class org.jgroups.protocols.relay.config.RelayConfig.SiteConfig
 
forwardSleep(long) - Method in class org.jgroups.protocols.relay.RELAY2
Deprecated. 
forwardTo(Address, SiteAddress, Address, Message, boolean) - Method in class org.jgroups.protocols.relay.RELAY2
 
forwardToCoord(Message) - Method in class org.jgroups.protocols.RELAY
Wraps the message annd sends it to the current coordinator
forwardToCoord(byte[], long) - Method in class org.jgroups.protocols.SEQUENCER
 
FRAG - Class in org.jgroups.protocols
Fragmentation layer.
FRAG() - Constructor for class org.jgroups.protocols.FRAG
 
FRAG2 - Class in org.jgroups.protocols
Fragmentation layer.
FRAG2() - Constructor for class org.jgroups.protocols.FRAG2
 
frag_id - Variable in class org.jgroups.protocols.FragHeader
 
frag_size - Variable in class org.jgroups.protocols.RATE_LIMITER
 
frag_size_received - Variable in class org.jgroups.protocols.FlowControl
 
FragHeader - Class in org.jgroups.protocols
 
FragHeader() - Constructor for class org.jgroups.protocols.FragHeader
 
FragHeader(long, int, int) - Constructor for class org.jgroups.protocols.FragHeader
 
fragmentBuffer(byte[], int, int) - Static method in class org.jgroups.util.Util
Fragments a byte buffer into smaller fragments of (max.) frag_size.
fragmentBuffer(byte[], int) - Static method in class org.jgroups.util.Util
 
from - Variable in class org.jgroups.protocols.FD.FdHeader
 
from - Variable in class org.jgroups.util.SeqnoList.Seqno
 
FUNCTIONAL - Static variable in class org.jgroups.Global
 
future - Variable in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture.Sync
The containing future
future - Variable in class org.jgroups.stack.Retransmitter.Task
 
futureDone(Future<V>) - Method in class org.jgroups.blocks.executor.ExecutionCompletionService.QueueingListener
 
futureDone(Future<T>) - Method in interface org.jgroups.util.FutureListener
 
FutureListener<T> - Interface in org.jgroups.util
A listener that is called back when a future is done.
fwd_queue - Variable in class org.jgroups.protocols.FORWARD_TO_COORD
 
fwd_queue - Variable in class org.jgroups.protocols.relay.Relayer
 
fwd_queue_max_size - Variable in class org.jgroups.protocols.relay.RELAY2
 

G

gateway - Variable in class org.jgroups.protocols.relay.config.RelayConfig.ForwardConfig
 
gc() - Method in class org.jgroups.protocols.pbcast.STABLE
 
generateAddress() - Method in interface org.jgroups.stack.AddressGenerator
 
generateGlobalView(View, View) - Method in class org.jgroups.protocols.RELAY
 
generateGlobalView(View, View, boolean) - Method in class org.jgroups.protocols.RELAY
 
generateList(Collection, String) - Static method in class org.jgroups.util.Util
 
generateLocalName() - Static method in class org.jgroups.util.Util
 
generatePreSignedUrl(String, String, String, String, String, long) - Static method in class org.jgroups.protocols.S3_PING
Use this helper method to generate pre-signed S3 urls for use with S3_PING.
generateRandomBytes() - Static method in class org.jgroups.auth.DemoToken
 
generateRandomBytes() - Static method in class org.jgroups.protocols.relay.CanBeSiteMaster
 
generateRandomBytes() - Static method in class org.jgroups.util.AdditionalDataUUID
 
generateRandomBytes() - Static method in class org.jgroups.util.PayloadUUID
 
generateRandomBytes() - Static method in class org.jgroups.util.TopologyUUID
 
get() - Method in interface org.jgroups.blocks.atomic.Counter
Gets the current value of the counter
get(K) - Method in class org.jgroups.blocks.Cache
 
get() - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
 
get(long, TimeUnit) - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
 
get() - Method in class org.jgroups.blocks.GroupRequest
 
get(long, TimeUnit) - Method in class org.jgroups.blocks.GroupRequest
 
get(K) - Method in class org.jgroups.blocks.LazyRemovalCache
 
get(short) - Method in interface org.jgroups.blocks.mux.Muxer
Gets the handler registered under the specified id
get(short) - Method in class org.jgroups.blocks.mux.MuxUpHandler
Gets the handler registered under the specified id
get(K) - Method in class org.jgroups.blocks.PartitionedHashMap
 
get(K) - Method in class org.jgroups.blocks.ReplCache
Returns the value associated with key
get(Object) - Method in class org.jgroups.blocks.ReplicatedHashMap
 
get(String, String) - Method in class org.jgroups.blocks.ReplicatedTree
Finds a node given its name and returns the value associated with a given key in its data map.
get() - Method in class org.jgroups.blocks.UnicastRequest
 
get(long, TimeUnit) - Method in class org.jgroups.blocks.UnicastRequest
 
get(short) - Static method in class org.jgroups.conf.ClassConfigurator
Returns a class for a magic number.
get(String) - Static method in class org.jgroups.conf.ClassConfigurator
Loads and returns the class from the class name
get() - Method in class org.jgroups.protocols.COUNTER.CounterImpl
 
get(long) - Method in class org.jgroups.protocols.Discovery.Responses
 
get() - Method in class org.jgroups.protocols.FlowControl.Credit
 
get(long) - Method in class org.jgroups.stack.NakReceiverWindow
Returns the message from xmit_table
get(long, long) - Method in class org.jgroups.stack.NakReceiverWindow
Returns a list of messages in the range [from ..
get(Address) - Method in class org.jgroups.util.CreditMap
 
get() - Method in class org.jgroups.util.DefaultTimeScheduler.TaskWrapper
 
get(long, TimeUnit) - Method in class org.jgroups.util.DefaultTimeScheduler.TaskWrapper
 
get(Address) - Method in class org.jgroups.util.Digest
Returns the highest delivered and received seqnos associated with a member.
get(int) - Method in class org.jgroups.util.FixedSizeBitSet
Returns the value of the bit with the specified index.
get() - Method in class org.jgroups.util.HashedTimingWheel.MyTask
 
get(long, TimeUnit) - Method in class org.jgroups.util.HashedTimingWheel.MyTask
 
get() - Method in class org.jgroups.util.ImmutableReference
Gets the wrapped object, if there is one.
get() - Method in class org.jgroups.util.NullFuture
 
get(long, TimeUnit) - Method in class org.jgroups.util.NullFuture
 
get(long) - Method in class org.jgroups.util.RetransmitTable
 
get(long, long) - Method in class org.jgroups.util.RetransmitTable
 
get(long) - Method in class org.jgroups.util.RingBuffer
 
get(long, long) - Method in class org.jgroups.util.RingBuffer
Returns a list of messages in the range [from ..
get(long) - Method in class org.jgroups.util.RingBufferLockless
 
get(long, long) - Method in class org.jgroups.util.RingBufferLockless
Returns a list of messages in the range [from ..
get(Object) - Method in class org.jgroups.util.RspList
Returns the Rsp associated with address key
get(long) - Method in class org.jgroups.util.Seqno
 
get(long) - Method in class org.jgroups.util.SeqnoRange
 
get(long) - Method in class org.jgroups.util.Table
Returns an element at seqno
get(long, long) - Method in class org.jgroups.util.Table
 
get() - Method in class org.jgroups.util.TimeScheduler2.MyTask
 
get(long, TimeUnit) - Method in class org.jgroups.util.TimeScheduler2.MyTask
 
get() - Method in class org.jgroups.util.TimeScheduler3.Task
 
get(long, TimeUnit) - Method in class org.jgroups.util.TimeScheduler3.Task
 
get(Address) - Static method in class org.jgroups.util.UUID
 
GET_APPLSTATE - Static variable in class org.jgroups.Event
 
GET_CACHE - Static variable in class org.jgroups.protocols.FD_SOCK.FdHeader
 
GET_CACHE_RSP - Static variable in class org.jgroups.protocols.FD_SOCK.FdHeader
 
GET_DIGEST - Static variable in class org.jgroups.Event
 
GET_DIGEST_EVT - Static variable in class org.jgroups.Event
 
GET_DIGEST_REQ - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
GET_DIGEST_RSP - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
GET_LOCAL_ADDRESS - Static variable in class org.jgroups.Event
 
GET_LOGICAL_PHYSICAL_MAPPINGS - Static variable in class org.jgroups.Event
 
GET_MBRS_REQ - Static variable in class org.jgroups.protocols.PingHeader
 
GET_MBRS_RSP - Static variable in class org.jgroups.protocols.PingHeader
 
GET_PHYSICAL_ADDRESS - Static variable in class org.jgroups.Event
 
GET_PHYSICAL_ADDRESSES - Static variable in class org.jgroups.Event
 
GET_STATE - Static variable in class org.jgroups.Event
 
GET_STATE_OK - Static variable in class org.jgroups.Event
 
GET_USERS - Static variable in class org.jgroups.demos.StompChat
 
getAccountNumber() - Method in class org.jgroups.demos.JmxDemo
 
getAccumulatedCredits() - Method in class org.jgroups.util.CreditMap
 
getAddress() - Method in class org.jgroups.Channel
Returns the channel's own address.
getAddress() - Method in class org.jgroups.JChannel
 
getAddress() - Method in class org.jgroups.protocols.AUTH
 
getAddress() - Method in class org.jgroups.protocols.COUNTER
 
getAddress() - Method in class org.jgroups.protocols.Executing
 
getAddress() - Method in class org.jgroups.protocols.Executing.Owner
 
getAddress() - Method in class org.jgroups.protocols.Locking
 
getAddress() - Method in class org.jgroups.protocols.PingData
 
getAddress() - Method in class org.jgroups.protocols.tom.MessageID
 
getAddress() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
 
getAddress() - Method in class org.jgroups.stack.GossipData
 
getAddress() - Method in class org.jgroups.util.Owner
 
getAddress() - Method in class org.jgroups.util.SingletonAddress
 
getAddress(Util.AddressScope) - Static method in class org.jgroups.util.Util
Returns the first address on any interface of the current host, which satisfies scope
getAddress(NetworkInterface, Util.AddressScope) - Static method in class org.jgroups.util.Util
Returns the first address on the given interface on the current host, which satisfies scope
getAddressAsString() - Method in class org.jgroups.JChannel
 
getAddressAsString() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
 
getAddressAsUUID() - Method in class org.jgroups.JChannel
 
getAddressAsUUID() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
 
getAddresses() - Method in class org.jgroups.AnycastAddress
 
getAddresses(Map<String, Map<String, Configurator.InetAddressInfo>>) - Static method in class org.jgroups.stack.Configurator
Returns all inet addresses found
getAddressGenerator() - Method in class org.jgroups.JChannel
Returns the current AddressGenerator, or null if none is set
getAgeOutCache() - Method in class org.jgroups.protocols.UNICAST
 
getAgeOutCache() - Method in class org.jgroups.protocols.UNICAST2
 
getAgeOutCacheSize() - Method in class org.jgroups.protocols.UNICAST
 
getAgeOutCacheSize() - Method in class org.jgroups.protocols.UNICAST2
 
getAllAvailableAddresses() - Static method in class org.jgroups.util.Util
 
getAllAvailableInterfaces() - Static method in class org.jgroups.util.Util
 
getAllDeclaredFields(Class) - Static method in class org.jgroups.util.Util
 
getAllDeclaredFieldsWithAnnotations(Class, Class<? extends Annotation>...) - Static method in class org.jgroups.util.Util
 
getAllDeclaredMethods(Class) - Static method in class org.jgroups.util.Util
 
getAllDeclaredMethodsWithAnnotations(Class, Class<? extends Annotation>...) - Static method in class org.jgroups.util.Util
 
getAllEndpoints() - Method in class org.jgroups.protocols.STOMP
 
getAllPhysicalAddressesFromCache() - Method in class org.jgroups.protocols.TP
 
getAllStocks() - Method in class org.jgroups.demos.QuoteServer
 
getAndDecrementRound() - Method in class org.jgroups.util.HashedTimingWheel.MyTask
 
getAndIncrement() - Method in class org.jgroups.protocols.tom.SequenceNumberManager
 
getAnycastDelivered() - Method in class org.jgroups.protocols.tom.StatsCollector
 
getAnycasting() - Method in class org.jgroups.blocks.GroupRequest
 
getAnycasting() - Method in class org.jgroups.blocks.RequestOptions
 
getArg() - Method in class org.jgroups.Event
 
getArgs() - Method in class org.jgroups.blocks.MethodCall
returns an ordered list of arguments used for the method invokation
getAsymAlgorithm() - Method in class org.jgroups.protocols.ENCRYPT
 
getAsymCipher() - Method in class org.jgroups.protocols.ENCRYPT
 
getAsymInit() - Method in class org.jgroups.protocols.ENCRYPT
 
getAsymProvider() - Method in class org.jgroups.protocols.ENCRYPT
 
getAttribute(String) - Method in class org.jgroups.jmx.ResourceDMBean
 
getAttributes(String[]) - Method in class org.jgroups.jmx.ResourceDMBean
 
getAuthClass() - Method in class org.jgroups.protocols.AUTH
 
getAuthToken() - Method in class org.jgroups.protocols.AUTH
 
getAuthValue() - Method in class org.jgroups.auth.MD5Token
 
getAuthValue() - Method in class org.jgroups.auth.SimpleToken
 
getAverageBlockTime() - Method in class org.jgroups.protocols.RATE_LIMITER
 
getAverageFlushDuration() - Method in class org.jgroups.protocols.pbcast.FLUSH
 
getAverageStateSize() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
getAverageStateSize() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
getAverageTimeBlocked() - Method in class org.jgroups.protocols.FC
 
getAverageTimeBlocked() - Method in class org.jgroups.protocols.FlowControl
 
getAvgAnycastSentDuration() - Method in class org.jgroups.protocols.tom.StatsCollector
 
getAvgDataMessageReceivedDuration() - Method in class org.jgroups.protocols.tom.StatsCollector
 
getAvgDataMessageReceivedDuration() - Method in class org.jgroups.protocols.tom.TOA
 
getAvgFinalMessageReceivedDuration() - Method in class org.jgroups.protocols.tom.StatsCollector
 
getAvgFinalMessageReceivedDuration() - Method in class org.jgroups.protocols.tom.TOA
 
getAvgLastProposeMessageReceivedDuration() - Method in class org.jgroups.protocols.tom.StatsCollector
 
getAvgLastProposeMessageReceivedDuration() - Method in class org.jgroups.protocols.tom.TOA
 
getAvgMsgsDeliveringLocally() - Method in class org.jgroups.protocols.relay.RELAY2
 
getAvgMsgsForwardingToLocalMbr() - Method in class org.jgroups.protocols.relay.RELAY2
 
getAvgMsgsForwardingToSM() - Method in class org.jgroups.protocols.relay.RELAY2
 
getAvgMsgsRelaying() - Method in class org.jgroups.protocols.relay.RELAY2
 
getAvgNumberOfUnicastSentPerAnycast() - Method in class org.jgroups.protocols.tom.StatsCollector
 
getAvgNumberOfUnicastSentPerAnycast() - Method in class org.jgroups.protocols.tom.TOA
 
getAvgProposeMesageReceivedDuration() - Method in class org.jgroups.protocols.tom.StatsCollector
 
getAvgProposeMessageReceivedDuration() - Method in class org.jgroups.protocols.tom.TOA
 
getAvgToaSendDuration() - Method in class org.jgroups.protocols.tom.TOA
 
getBacklog() - Method in class org.jgroups.stack.GossipRouter
 
getBackupCoords() - Method in class org.jgroups.protocols.COUNTER
 
getBackups() - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
 
getBackups() - Method in class org.jgroups.protocols.CENTRAL_LOCK
 
getBecomeServerQueueSizeActual() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
getBindAddr() - Method in class org.jgroups.protocols.MPING
 
getBindAddress() - Method in class org.jgroups.blocks.MemcachedConnector
 
getBindAddress() - Method in class org.jgroups.protocols.TP
 
getBindAddress() - Method in class org.jgroups.stack.GossipRouter
 
getBindAddress(Properties) - Static method in class org.jgroups.util.Util
Returns the address of the interface to use defined by bind_addr and bind_interface
getBindPort() - Method in class org.jgroups.protocols.BPING
 
getBindPort() - Method in class org.jgroups.protocols.TP
 
getBits(boolean) - Method in class org.jgroups.util.SeqnoRange
Returns ranges of all bit set to value
getBlockForResults() - Method in class org.jgroups.blocks.Request
 
getBody() - Method in class org.jgroups.protocols.STOMP.Frame
 
getBottomProtocol() - Method in class org.jgroups.stack.ProtocolStack
 
getBridge(String) - Method in class org.jgroups.protocols.relay.RELAY2
Returns the bridge channel to a given site
getBridges() - Method in class org.jgroups.protocols.relay.config.RelayConfig.SiteConfig
 
getBridgeView() - Method in class org.jgroups.protocols.RELAY
 
getBridgeView(String) - Method in class org.jgroups.protocols.relay.RELAY2
 
getBridgeView(String) - Method in class org.jgroups.protocols.relay.Relayer
 
getBroadcast() - Method in class org.jgroups.protocols.SEQUENCER
 
getBuf() - Method in class org.jgroups.util.Buffer
 
getBuffer() - Method in class org.jgroups.Message
Returns a copy of the buffer if offset and length are used, otherwise a reference.
getBuffer() - Method in class org.jgroups.stack.GossipData
 
getBuffer() - Method in class org.jgroups.util.ExposedByteArrayOutputStream
 
getBuffer() - Method in class org.jgroups.util.StateTransferResult
 
getBufferSize() - Method in class org.jgroups.protocols.TP.TransferQueueBundler
 
getBufferSize() - Method in class org.jgroups.protocols.TP.TransferQueueBundler2
 
getBundlerBufferSize() - Method in class org.jgroups.protocols.TP
 
getBypassBundling() - Method in class org.jgroups.protocols.COUNTER
 
getBypassBundling() - Method in class org.jgroups.protocols.Executing
 
getBypassBundling() - Method in class org.jgroups.protocols.Locking
 
getByteAt(long, int) - Static method in class org.jgroups.util.Util
 
getBytes() - Method in class org.jgroups.protocols.pbcast.STABLE
 
getByValue(V) - Method in class org.jgroups.blocks.LazyRemovalCache
 
getCache() - Method in class org.jgroups.blocks.MemcachedConnector
 
getCache() - Method in class org.jgroups.util.SuppressLog
 
getCachingTime() - Method in class org.jgroups.blocks.PartitionedHashMap
 
getCachingTime() - Method in class org.jgroups.blocks.ReplCache
 
getCallable() - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
 
getCallTimeout() - Method in class org.jgroups.blocks.PartitionedHashMap
 
getCallTimeout() - Method in class org.jgroups.blocks.ReplCache
 
getCapacity() - Method in class org.jgroups.util.ExposedByteArrayOutputStream
 
getChannel() - Method in class org.jgroups.blocks.MessageDispatcher
 
getChannel() - Method in class org.jgroups.blocks.ReplicatedHashMap
 
getChannel() - Method in class org.jgroups.blocks.ReplicatedTree
Returns the Channel the DistributedTree is connected to
getChannel() - Method in class org.jgroups.stack.ProtocolStack
 
getChildrenNames(String) - Method in class org.jgroups.blocks.ReplicatedTree
Returns all children of a given node
getChunkSize() - Method in class org.jgroups.blocks.GridFile
 
getChunkSize() - Method in class org.jgroups.blocks.GridFile.Metadata
 
getClassForName(String) - Static method in class org.jgroups.jmx.ResourceDMBean
 
getClusterName() - Method in class org.jgroups.blocks.PartitionedHashMap
 
getClusterName() - Method in class org.jgroups.blocks.ReplCache
 
getClusterName() - Method in class org.jgroups.blocks.ReplicatedHashMap
 
getClusterName() - Method in class org.jgroups.Channel
Returns the cluster name of the group of which the channel is a member.
getClusterName() - Method in class org.jgroups.JChannel
 
getClusterName() - Method in class org.jgroups.protocols.relay.config.RelayConfig.BridgeConfig
 
getClusterName() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
 
getClusterName() - Method in class org.jgroups.util.SingletonAddress
 
getClusterSize() - Method in class org.jgroups.blocks.ReplCache
 
getCond() - Method in class org.jgroups.util.Promise
 
getConfigStream(File) - Static method in class org.jgroups.conf.ConfiguratorFactory
 
getConfigStream(URL) - Static method in class org.jgroups.conf.ConfiguratorFactory
 
getConfigStream(String) - Static method in class org.jgroups.conf.ConfiguratorFactory
Returns a JGroups XML configuration InputStream based on the provided properties string.
getConfigStream(Object) - Static method in class org.jgroups.conf.ConfiguratorFactory
 
getConfigurableObjects() - Method in class org.jgroups.protocols.AUTH
 
getConfigurableObjects() - Method in class org.jgroups.stack.Protocol
After configuring the protocol itself from the properties defined in the XML config, a protocol might have additional objects which need to be configured.
getConnection(Address) - Method in interface org.jgroups.blocks.ConnectionMap
 
getConnection(Address) - Method in class org.jgroups.blocks.TCPConnectionMap.Mapper
 
getConnection() - Method in class org.jgroups.protocols.JDBC_PING
 
getConnectionExpiryTimeout() - Method in class org.jgroups.blocks.TCPConnectionMap
 
getConnectionStatus() - Method in class org.jgroups.stack.RouterStub
 
getConnectionTable(long, long, InetAddress, InetAddress, int, int, int) - Method in class org.jgroups.protocols.TCP_NIO
 
getConnectionUnderLock(Address) - Method in class org.jgroups.blocks.TCPConnectionMap.Mapper
 
getConnExpireTime() - Method in class org.jgroups.protocols.BasicTCP
 
getConnId() - Method in class org.jgroups.protocols.UNICAST2.Unicast2Header
 
getContents() - Static method in class org.jgroups.util.UUID
Returns a copy of the cache's contents
getConvertedValue(Object, Field, Map<String, String>, String, boolean) - Static method in class org.jgroups.conf.PropertyHelper
 
getConvertedValue(Object, Field, String, boolean) - Static method in class org.jgroups.conf.PropertyHelper
 
getConvertedValue(Object, Method, Map<String, String>, String, boolean) - Static method in class org.jgroups.conf.PropertyHelper
 
getCoord() - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
 
getCoord() - Method in class org.jgroups.protocols.CENTRAL_LOCK
 
getCoordAddress() - Method in class org.jgroups.protocols.PingData
 
getCoordinator() - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
 
getCoordinator() - Method in class org.jgroups.protocols.CENTRAL_LOCK
 
getCoordinator() - Method in class org.jgroups.protocols.SEQUENCER
 
getCoordinator(View) - Static method in class org.jgroups.util.Util
 
getCounter(String) - Method in class org.jgroups.protocols.COUNTER
 
getCreator() - Method in class org.jgroups.View
Returns the creator of this view if this view was created with the empty constructur, null will be returned
getCreator() - Method in class org.jgroups.ViewId
Returns the address of the member that issued this view
getCurrentCoord() - Method in class org.jgroups.protocols.Discovery
 
getCurrentNumTries() - Method in class org.jgroups.protocols.FD
 
getCurrentPort() - Method in class org.jgroups.protocols.BSH
 
getCurrentRunningTasks() - Method in class org.jgroups.blocks.executor.ExecutionRunner
Returns a copy of the runners being used with the runner and what threads.
getCurrentSeqno() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
getCurrentSeqno() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
getCurrentThreads() - Method in class org.jgroups.util.DefaultTimeScheduler
 
getCurrentThreads() - Method in class org.jgroups.util.HashedTimingWheel
 
getCurrentThreads() - Method in class org.jgroups.util.MockTimeScheduler
 
getCurrentThreads() - Method in interface org.jgroups.util.TimeScheduler
Returns the current threads in the pool, or -1 if not applicable
getCurrentThreads() - Method in class org.jgroups.util.TimeScheduler2
 
getCurrentThreads() - Method in class org.jgroups.util.TimeScheduler3
 
getDataSourceFromJNDI(String) - Method in class org.jgroups.protocols.JDBC_PING
 
getDefaultHandler() - Method in interface org.jgroups.blocks.mux.Muxer
Gets the handler for messages that have no mux header.
getDefaultHandler() - Method in class org.jgroups.blocks.mux.MuxUpHandler
 
getDefaultReplicationCount() - Method in class org.jgroups.blocks.ReplCache
 
getDefaultThreadPool() - Method in class org.jgroups.protocols.TP
 
getDefaultThreadPoolThreadFactory() - Method in class org.jgroups.protocols.TP
 
getDefaultThreadPoolThreadFactory() - Method in class org.jgroups.stack.GossipRouter
 
getDelay() - Method in class org.jgroups.protocols.DELAY_JOIN_REQ
 
getDelay(TimeUnit) - Method in class org.jgroups.protocols.VERIFY_SUSPECT.Entry
 
getDelay(TimeUnit) - Method in class org.jgroups.util.TimeScheduler3.Task
 
getDeliveryTableMaxSize() - Method in class org.jgroups.util.ForwardQueue
 
getDeliveryTableSize() - Method in class org.jgroups.protocols.FORWARD_TO_COORD
 
getDesiredAverageGossip() - Method in class org.jgroups.protocols.pbcast.STABLE
 
getDesKey() - Method in class org.jgroups.protocols.ENCRYPT
 
getDest() - Method in class org.jgroups.Message
 
getDestination(MessageID) - Method in class org.jgroups.protocols.tom.SenderManager
obtains the destination set of a message
getDestinations() - Method in class org.jgroups.protocols.tom.ToaHeader
 
getDifferentClusterMessages() - Method in class org.jgroups.protocols.TP
 
getDifferentVersionMessages() - Method in class org.jgroups.protocols.TP
 
getDigest() - Method in class org.jgroups.protocols.pbcast.GMS
Sends down a GET_DIGEST event and waits for the GET_DIGEST_OK response, or timeout, whichever occurs first
getDigest() - Method in class org.jgroups.protocols.pbcast.JoinRsp
 
getDigest() - Method in class org.jgroups.protocols.pbcast.MergeData
 
getDigest() - Method in class org.jgroups.protocols.pbcast.NAKACK
Returns a message digest: for each member P the highest delivered and received seqno is added
getDigest(Address) - Method in class org.jgroups.protocols.pbcast.NAKACK
 
getDigest() - Method in class org.jgroups.protocols.pbcast.NAKACK2
Returns a message digest: for each member P the highest delivered and received seqno is added
getDigest(Address) - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
getDigest() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
getDigest() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
 
getDigest() - Method in class org.jgroups.stack.NakReceiverWindow
Returns the lowest, highest delivered and highest received seqnos
getDigest() - Method in class org.jgroups.util.RingBuffer
 
getDigest() - Method in class org.jgroups.util.RingBufferLockless
 
getDigest() - Method in class org.jgroups.util.Table
 
getDiscardOwnMessages() - Method in class org.jgroups.Channel
Returns true if this channel will discard its own messages, false otherwise
getDownDiscardRate() - Method in class org.jgroups.protocols.DISCARD
 
getDownProt() - Method in class org.jgroups.util.ForwardQueue
 
getDownProtocol() - Method in class org.jgroups.stack.Protocol
 
getDownServices() - Method in class org.jgroups.stack.Protocol
Returns all services provided by protocols below the current protocol
getDropDownMulticasts() - Method in class org.jgroups.protocols.DISCARD
 
getDropDownUnicasts() - Method in class org.jgroups.protocols.DISCARD
 
getDynamicHostList() - Method in class org.jgroups.protocols.TCPPING
 
getEndpoints() - Method in class org.jgroups.protocols.STOMP
 
getEntry(K) - Method in class org.jgroups.blocks.Cache
 
getException() - Method in class org.jgroups.util.Rsp
 
getException() - Method in class org.jgroups.util.StateTransferResult
 
getExclusionList() - Method in class org.jgroups.blocks.RequestOptions
 
getExpiryTime() - Method in class org.jgroups.stack.GossipRouter
 
getFailReason() - Method in class org.jgroups.protocols.pbcast.JoinRsp
 
getField(Class, String) - Static method in class org.jgroups.util.Util
 
getField(Field, Object) - Static method in class org.jgroups.util.Util
 
getFile(String) - Method in class org.jgroups.blocks.GridFilesystem
 
getFile(String, int) - Method in class org.jgroups.blocks.GridFilesystem
 
getFile(String, String) - Method in class org.jgroups.blocks.GridFilesystem
 
getFile(String, String, int) - Method in class org.jgroups.blocks.GridFilesystem
 
getFile(File, String) - Method in class org.jgroups.blocks.GridFilesystem
 
getFile(File, String, int) - Method in class org.jgroups.blocks.GridFilesystem
 
getFillFactor() - Method in class org.jgroups.util.RetransmitTable
Returns the ratio between size and capacity, as a percentage
getFilter() - Method in class org.jgroups.blocks.mux.NoMuxHandlerRspFilter
 
getFirst() - Method in class org.jgroups.util.Queue
Returns the first element.
getFirst() - Method in class org.jgroups.util.RspList
Returns the first value in the response set.
getFlags() - Method in class org.jgroups.blocks.RequestOptions
 
getFlags() - Method in class org.jgroups.Message
Returns the internal representation of flags.
getForwarded() - Method in class org.jgroups.protocols.SEQUENCER
 
getForwards() - Method in class org.jgroups.protocols.relay.config.RelayConfig.SiteConfig
 
getForwardTableSize() - Method in class org.jgroups.protocols.FORWARD_TO_COORD
 
getForwardTableSize() - Method in class org.jgroups.protocols.SEQUENCER
 
getFragSize() - Method in class org.jgroups.protocols.FRAG
 
getFragSize() - Method in class org.jgroups.protocols.FRAG2
 
getFuture() - Method in class org.jgroups.util.DefaultTimeScheduler.TaskWrapper
 
getGateway() - Method in class org.jgroups.protocols.relay.config.RelayConfig.ForwardConfig
 
getGlobalView() - Method in class org.jgroups.protocols.RELAY
 
getGMSHeader(Event) - Static method in class org.jgroups.protocols.AUTH
Get the header from a GMS message
getGossipRouterAddress() - Method in class org.jgroups.stack.RouterStub
 
getGroup() - Method in class org.jgroups.stack.GossipData
 
getGroupMembersNumber() - Method in class org.jgroups.blocks.ReplicatedTree
Returns the number of current members joined to the group
getGroupName() - Method in class org.jgroups.blocks.ReplicatedTree
Returns the name of the group that the DistributedTree is connected to
getGroupName() - Method in class org.jgroups.demos.Draw
 
getHandler() - Method in class org.jgroups.util.AgeOutCache
 
getHashFunction() - Method in class org.jgroups.blocks.PartitionedHashMap
 
getHashFunction() - Method in class org.jgroups.blocks.ReplCache
 
getHashFunctionFactory() - Method in class org.jgroups.blocks.ReplCache
 
getHashType() - Method in class org.jgroups.auth.MD5Token
 
getHeader(short) - Method in class org.jgroups.Message
 
getHeader(short) - Method in class org.jgroups.util.Headers
Returns the header associated with an ID
getHeaders() - Method in class org.jgroups.Message
Returns a reference to the headers hashmap, which is immutable.
getHeaders() - Method in class org.jgroups.protocols.STOMP.Frame
 
getHeaders() - Method in class org.jgroups.util.Headers
 
getHeartbeatsReceived() - Method in class org.jgroups.protocols.FD_ALL
 
getHeartbeatsSent() - Method in class org.jgroups.protocols.FD_ALL
 
getHigh() - Method in class org.jgroups.util.SeqnoRange
 
getHighest() - Method in class org.jgroups.util.Digest.DigestEntry
 
getHighest() - Method in class org.jgroups.util.RetransmitTable
 
getHighestDelivered() - Method in class org.jgroups.stack.NakReceiverWindow
Returns the highest sequence number of a message consumed by the application (by remove()).
getHighestDelivered() - Method in class org.jgroups.util.RingBuffer
 
getHighestDelivered() - Method in class org.jgroups.util.RingBufferLockless
 
getHighestDelivered() - Method in class org.jgroups.util.Table
 
getHighestDeliveredSeqno() - Method in class org.jgroups.util.Digest.DigestEntry
 
getHighestPurged() - Method in class org.jgroups.util.RetransmitTable
 
getHighestReceived() - Method in class org.jgroups.stack.NakReceiverWindow
Returns the highest sequence number received so far (which may be higher than the highest seqno delivered so far; e.g., for 1,2,3,5,6 it would be 6.
getHighestReceived() - Method in class org.jgroups.util.RingBuffer
 
getHighestReceived() - Method in class org.jgroups.util.RingBufferLockless
 
getHighestReceived() - Method in class org.jgroups.util.Table
 
getHighestReceivedSeqno() - Method in class org.jgroups.util.Digest.DigestEntry
 
getHighSeqno() - Method in class org.jgroups.protocols.UNICAST2.Unicast2Header
 
getId() - Method in class org.jgroups.blocks.MethodCall
 
getId() - Method in class org.jgroups.blocks.mux.MuxHeader
 
getId() - Method in class org.jgroups.blocks.mux.NoMuxHandler
 
getId() - Method in class org.jgroups.protocols.FORWARD_TO_COORD.ForwardHeader
 
getId() - Method in class org.jgroups.protocols.relay.config.RelayConfig.SiteConfig
 
getId() - Method in class org.jgroups.protocols.tom.MessageID
 
getId() - Method in class org.jgroups.stack.Protocol
 
getId() - Method in class org.jgroups.ViewId
returns the lamport time of the view
getIdsAbove() - Method in class org.jgroups.stack.Protocol
Returns the protocol IDs of all protocols above this one (excluding the current protocol)
getImpl() - Method in class org.jgroups.protocols.pbcast.GMS
 
getIncomingCopies() - Method in class org.jgroups.protocols.DUPL
 
getInDelay() - Method in class org.jgroups.protocols.DELAY
 
getIndex(int) - Method in class org.jgroups.util.SeqnoRange
 
getInetAddresses(List<Protocol>) - Static method in class org.jgroups.stack.Configurator
 
getInetAddresses() - Method in class org.jgroups.stack.Configurator.InetAddressInfo
 
getInFlightThreadsCount() - Method in class org.jgroups.protocols.BARRIER
 
getInfo() - Method in class org.jgroups.protocols.BasicTCP
 
getInfo() - Method in class org.jgroups.protocols.SHARED_LOOPBACK
 
getInfo() - Method in class org.jgroups.protocols.TP
 
getInfo() - Method in class org.jgroups.protocols.TUNNEL
 
getInfo() - Method in class org.jgroups.protocols.UDP
 
getInitCount() - Method in class org.jgroups.stack.ProtocolStack.RefCounter
 
getInitialHosts() - Method in class org.jgroups.protocols.TCPGOSSIP
 
getInitialHosts() - Method in class org.jgroups.protocols.TCPPING
Returns the list of initial hosts as configured by the user via XML.
getInitialHostsList() - Method in class org.jgroups.protocols.TCPPING
 
getInput(String) - Method in class org.jgroups.blocks.GridFilesystem
 
getInput(File) - Method in class org.jgroups.blocks.GridFilesystem
 
getInputStream() - Method in class org.jgroups.stack.RouterStub
 
getInsertionTime() - Method in class org.jgroups.blocks.Cache.Value
 
getInstance(URL) - Static method in class org.jgroups.conf.XmlConfigurator
 
getInstance(InputStream) - Static method in class org.jgroups.conf.XmlConfigurator
 
getInstance(Element) - Static method in class org.jgroups.conf.XmlConfigurator
 
getInstance(URL, Boolean) - Static method in class org.jgroups.conf.XmlConfigurator
 
getInstance(InputStream, Boolean) - Static method in class org.jgroups.conf.XmlConfigurator
 
getInternalMap() - Method in class org.jgroups.blocks.Cache
This method should not be used to add or remove elements ! It was just added because ReplCacheDemo requires it for its data model
getInterval() - Method in class org.jgroups.protocols.FD_ALL
 
getIpAddress() - Method in class org.jgroups.stack.IpAddress
 
getIpStackType() - Static method in class org.jgroups.util.Util
 
getJoinTimeout() - Method in class org.jgroups.protocols.pbcast.GMS
 
getKeepAliveTime() - Method in class org.jgroups.util.DefaultTimeScheduler
 
getKeepAliveTime() - Method in class org.jgroups.util.HashedTimingWheel
 
getKeepAliveTime() - Method in class org.jgroups.util.MockTimeScheduler
 
getKeepAliveTime() - Method in interface org.jgroups.util.TimeScheduler
Returns the keep alive time (in ms) of the thread pool, or -1 if not applicable
getKeepAliveTime() - Method in class org.jgroups.util.TimeScheduler2
 
getKeepAliveTime() - Method in class org.jgroups.util.TimeScheduler3
 
getKeys(String) - Method in class org.jgroups.blocks.ReplicatedTree
Gets the keys of the data map.
getKeyServerAddr() - Method in class org.jgroups.protocols.ENCRYPT
 
getKeyStoreName() - Method in class org.jgroups.protocols.ENCRYPT
 
getKpair() - Method in class org.jgroups.protocols.ENCRYPT
 
getL1Cache() - Method in class org.jgroups.blocks.PartitionedHashMap
 
getL1Cache() - Method in class org.jgroups.blocks.ReplCache
 
getL2Cache() - Method in class org.jgroups.blocks.PartitionedHashMap
 
getL2Cache() - Method in class org.jgroups.blocks.ReplCache
 
getLast() - Method in class org.jgroups.util.Queue
Returns the last element.
getLast() - Method in class org.jgroups.util.SeqnoList
Returns the last seqno, this should also be the highest seqno in the list as we're supposed to add seqnos in order
getLastUpdate() - Method in class org.jgroups.protocols.SCOPE.MessageQueue
 
getLeastSignificantBits() - Method in class org.jgroups.util.UUID
 
getLength() - Method in class org.jgroups.blocks.GridFile.Metadata
 
getLength() - Method in class org.jgroups.Message
Returns the number of bytes in the buffer
getLength() - Method in class org.jgroups.util.Buffer
 
getLevel() - Method in class org.jgroups.logging.JDKLogImpl
 
getLevel() - Method in interface org.jgroups.logging.Log
 
getLevel() - Method in class org.jgroups.logging.Log4JLogImpl
 
getLevel() - Method in class org.jgroups.stack.Protocol
 
getLinger() - Method in class org.jgroups.blocks.BasicConnectionTable
 
getLingerTimeout() - Method in class org.jgroups.stack.GossipRouter
 
getList() - Method in class org.jgroups.util.Table.Getter
 
getList() - Method in class org.jgroups.util.Table.Remover
 
getLocal_addr() - Method in class org.jgroups.protocols.ENCRYPT
 
getLocalAddr() - Method in class org.jgroups.util.ForwardQueue
 
getLocalAddress() - Method in class org.jgroups.blocks.BasicConnectionTable
 
getLocalAddress() - Method in class org.jgroups.blocks.PartitionedHashMap
 
getLocalAddress() - Method in class org.jgroups.blocks.ReplCache
 
getLocalAddress() - Method in class org.jgroups.blocks.ReplicatedHashMap
 
getLocalAddress() - Method in class org.jgroups.blocks.ReplicatedTree
 
getLocalAddress() - Method in class org.jgroups.blocks.RequestCorrelator
 
getLocalAddress() - Method in class org.jgroups.blocks.TCPConnectionMap
 
getLocalAddress() - Method in class org.jgroups.protocols.FD
 
getLocalAddress() - Method in class org.jgroups.protocols.FD_ALL
 
getLocalAddress() - Method in class org.jgroups.protocols.FD_SOCK
 
getLocalAddress() - Method in class org.jgroups.protocols.pbcast.GMS
 
getLocalAddress() - Method in class org.jgroups.protocols.relay.RELAY2
 
getLocalAddress() - Method in class org.jgroups.protocols.rules.SUPERVISOR
 
getLocalAddress() - Method in class org.jgroups.protocols.SEQUENCER
 
getLocalAddress() - Method in class org.jgroups.protocols.UNICAST
 
getLocalAddress() - Method in class org.jgroups.protocols.UNICAST2
 
getLocalAddressAsString() - Method in class org.jgroups.blocks.PartitionedHashMap
 
getLocalAddressAsString() - Method in class org.jgroups.blocks.ReplCache
 
getLocalhost(StackType) - Static method in class org.jgroups.util.Util
IP related utilities
getLocalView() - Method in class org.jgroups.protocols.RELAY
 
getLock() - Method in class org.jgroups.blocks.AbstractConnectionMap
 
getLock(String) - Method in class org.jgroups.blocks.locking.LockService
 
getLock(String) - Method in class org.jgroups.protocols.Locking
 
getLock(String, boolean) - Method in class org.jgroups.protocols.Locking
 
getLock(String, Owner, boolean) - Method in class org.jgroups.protocols.Locking
 
getLock() - Method in class org.jgroups.util.Promise
 
getLog() - Method in class org.jgroups.Channel
 
getLog() - Method in class org.jgroups.JChannel
 
getLog(Class) - Method in interface org.jgroups.logging.CustomLogFactory
 
getLog(String) - Method in interface org.jgroups.logging.CustomLogFactory
 
getLog(Class) - Static method in class org.jgroups.logging.LogFactory
 
getLog(String) - Static method in class org.jgroups.logging.LogFactory
 
getLogCollectMessages() - Method in class org.jgroups.protocols.pbcast.GMS
 
getLogDiscardMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
getLogDiscardMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
getLogDiscardMessages() - Method in class org.jgroups.protocols.TP
 
getLogDiscardMessagesVersion() - Method in class org.jgroups.protocols.TP
 
getLogicalAddr() - Method in class org.jgroups.protocols.PDC.Mapping
 
getLogicalName() - Method in class org.jgroups.protocols.PDC.Mapping
 
getLogicalName() - Method in class org.jgroups.protocols.PingData
 
getLogicalName() - Method in class org.jgroups.stack.GossipData
 
getLow() - Method in class org.jgroups.util.RingBuffer
 
getLow() - Method in class org.jgroups.util.RingBufferLockless
 
getLow() - Method in class org.jgroups.util.Seqno
 
getLow() - Method in class org.jgroups.util.Table
 
getMachineId() - Method in class org.jgroups.util.TopologyUUID
 
getMagicNumber(Class) - Static method in class org.jgroups.conf.ClassConfigurator
Returns the magic number for the class.
getMarshaller() - Method in class org.jgroups.blocks.RequestCorrelator
 
getMarshaller() - Method in class org.jgroups.blocks.RpcDispatcher
 
getMaxAge() - Method in class org.jgroups.demos.JmxDemo
 
getMaxBlockTime() - Method in class org.jgroups.protocols.FC
 
getMaxBlockTime() - Method in class org.jgroups.protocols.FlowControl
 
getMaxBlockTime(long) - Method in class org.jgroups.protocols.FlowControl
 
getMaxBlockTimes() - Method in class org.jgroups.protocols.FC
 
getMaxBlockTimes() - Method in class org.jgroups.protocols.FlowControl
 
getMaxBundleSize() - Method in class org.jgroups.protocols.TP
 
getMaxBundleTimeout() - Method in class org.jgroups.protocols.TP
 
getMaxBundlingTime() - Method in class org.jgroups.protocols.pbcast.GMS
 
getMaxBytes() - Method in class org.jgroups.protocols.pbcast.STABLE
 
getMaxBytes() - Method in class org.jgroups.protocols.RATE_LIMITER
 
getMaxCompactionTime() - Method in class org.jgroups.util.RetransmitTable
 
getMaxCompactionTime() - Method in class org.jgroups.util.Table
 
getMaxCredits() - Method in class org.jgroups.protocols.FC
 
getMaxCredits() - Method in class org.jgroups.protocols.FlowControl
 
getMaxInterval() - Method in class org.jgroups.protocols.MERGE2
 
getMaxInterval() - Method in class org.jgroups.protocols.MERGE3
 
getMaxJoinAttempts() - Method in class org.jgroups.protocols.pbcast.GMS
 
getMaxNumberOfEntries() - Method in class org.jgroups.blocks.Cache
 
getMaxRetransmitTime() - Method in class org.jgroups.protocols.UNICAST
 
getMaxRetransmitTime() - Method in class org.jgroups.protocols.UNICAST2
 
getMaxSize() - Method in class org.jgroups.protocols.SHUFFLE
 
getMaxThreads() - Method in class org.jgroups.util.DefaultTimeScheduler
 
getMaxThreads() - Method in class org.jgroups.util.HashedTimingWheel
 
getMaxThreads() - Method in class org.jgroups.util.MockTimeScheduler
 
getMaxThreads() - Method in interface org.jgroups.util.TimeScheduler
Returns the configured max threads, or -1 if not applicable
getMaxThreads() - Method in class org.jgroups.util.TimeScheduler2
 
getMaxThreads() - Method in class org.jgroups.util.TimeScheduler3
 
getMaxTime() - Method in class org.jgroups.protocols.SHUFFLE
 
getMaxTries() - Method in class org.jgroups.protocols.FD
 
getMBeanInfo() - Method in class org.jgroups.jmx.ResourceDMBean
 
getMBeanServer() - Static method in class org.jgroups.util.Util
 
getMcastAddr() - Method in class org.jgroups.protocols.MPING
 
getMcastPort() - Method in class org.jgroups.protocols.MPING
 
getMember() - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
getMember() - Method in class org.jgroups.util.Digest.DigestEntry
 
getMembers() - Method in class org.jgroups.blocks.ReplicatedTree
 
getMembers() - Method in class org.jgroups.Membership
Returns a copy (clone) of the members in this membership.
getMembers() - Method in class org.jgroups.protocols.FD
 
getMembers() - Method in class org.jgroups.protocols.FD_ALL
 
getMembers() - Method in class org.jgroups.protocols.FD_SOCK
 
getMembers() - Method in class org.jgroups.protocols.pbcast.GMS
 
getMembers() - Method in class org.jgroups.protocols.PingData
 
getMembers() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
 
getMembers() - Method in class org.jgroups.protocols.UNICAST
 
getMembers() - Method in class org.jgroups.protocols.UNICAST2
 
getMembers() - Method in class org.jgroups.stack.GossipData
 
getMembers(String) - Method in class org.jgroups.stack.RouterStub
 
getMembers() - Method in class org.jgroups.util.Digest
 
getMembers() - Method in class org.jgroups.View
Returns a reference to the List of members (ordered) Do NOT change this list, hence your will invalidate the view Make a copy if you have to modify it.
getMembersWithCreditsLessThan(long) - Method in class org.jgroups.util.CreditMap
 
getMembersWithInsufficientCredits(long) - Method in class org.jgroups.util.CreditMap
 
getMergeId() - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
 
getMergeId() - Method in class org.jgroups.protocols.pbcast.GMS
 
getMergeId() - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
getMergeId() - Method in class org.jgroups.protocols.pbcast.Merger
Only used for testing, might get removed any time.
getMergeIdAsString() - Method in class org.jgroups.protocols.pbcast.Merger
 
getMergeIdHistory() - Method in class org.jgroups.protocols.pbcast.Merger
 
getMerger() - Method in class org.jgroups.protocols.pbcast.GMS
Only used for internal testing, don't use this method !
getMergeTimeout() - Method in class org.jgroups.protocols.pbcast.GMS
 
getMessage() - Method in class org.jgroups.demos.wb.SendDialog
 
getMessage(String) - Static method in class org.jgroups.util.Util
 
getMessage(String, Object...) - Static method in class org.jgroups.util.Util
 
getMessageID() - Method in class org.jgroups.protocols.tom.ToaHeader
 
getMessageList() - Method in class org.jgroups.protocols.tom.TOA
 
getMessageListener() - Method in class org.jgroups.blocks.MessageDispatcher
 
getMessageSet() - Method in class org.jgroups.protocols.tom.DeliveryManagerImpl
It is used for testing (see the messages in JMX)
getMessagesToRetransmit() - Method in class org.jgroups.util.Seqno
 
getMessagesToRetransmit() - Method in class org.jgroups.util.SeqnoRange
 
getMethod() - Method in class org.jgroups.blocks.MethodCall
 
getMethodLookup() - Method in class org.jgroups.blocks.RpcDispatcher
 
getMinCredits() - Method in class org.jgroups.protocols.FC
 
getMinCredits() - Method in class org.jgroups.protocols.FlowControl
 
getMinCredits() - Method in class org.jgroups.util.CreditMap
 
getMinInterval() - Method in class org.jgroups.protocols.MERGE2
 
getMinInterval() - Method in class org.jgroups.protocols.MERGE3
 
getMinThreads() - Method in class org.jgroups.util.DefaultTimeScheduler
 
getMinThreads() - Method in class org.jgroups.util.HashedTimingWheel
 
getMinThreads() - Method in class org.jgroups.util.MockTimeScheduler
 
getMinThreads() - Method in interface org.jgroups.util.TimeScheduler
Returns the configured core threads, or -1 if not applicable
getMinThreads() - Method in class org.jgroups.util.TimeScheduler2
 
getMinThreads() - Method in class org.jgroups.util.TimeScheduler3
 
getMinThreshold() - Method in class org.jgroups.protocols.FC
 
getMinThreshold() - Method in class org.jgroups.protocols.FlowControl
 
getMissing() - Method in class org.jgroups.util.ResponseCollector
Returns a list of members which didn't send a valid response
getMissing() - Method in class org.jgroups.util.RingBuffer
 
getMissing() - Method in class org.jgroups.util.RingBufferLockless
 
getMissing() - Method in class org.jgroups.util.Table
Returns a list of missing (= null) messages
getMissingElements() - Method in class org.jgroups.util.Table.Missing
 
getMissingMessages() - Method in class org.jgroups.stack.NakReceiverWindow
 
getMode() - Method in class org.jgroups.blocks.MethodCall
 
getMode() - Method in class org.jgroups.blocks.RequestOptions
 
getModificationTime() - Method in class org.jgroups.blocks.GridFile.Metadata
 
getMostSignificantBits() - Method in class org.jgroups.util.UUID
Returns the most significant 64 bits of this UUID's 128 bit value.
getMulticastAddress() - Method in class org.jgroups.protocols.UDP
 
getMulticastPort() - Method in class org.jgroups.protocols.UDP
 
getMulticastTTL() - Method in class org.jgroups.protocols.UDP
Getter for current multicast TTL
getMyFoo() - Static method in class org.jgroups.demos.JmxDemo
 
getName() - Method in class org.jgroups.auth.AuthToken
Used to return the full package and class name of the implementation.
getName() - Method in class org.jgroups.auth.DemoToken
 
getName() - Method in class org.jgroups.auth.FixedMembershipToken
 
getName() - Method in class org.jgroups.auth.MD5Token
 
getName() - Method in class org.jgroups.auth.RegexMembership
 
getName() - Method in class org.jgroups.auth.SimpleToken
 
getName() - Method in class org.jgroups.auth.X509Token
 
getName() - Method in interface org.jgroups.blocks.atomic.Counter
 
getName() - Method in class org.jgroups.blocks.GridFile
 
getName() - Method in class org.jgroups.blocks.locking.AwaitInfo
 
getName() - Method in class org.jgroups.blocks.locking.LockInfo
 
getName() - Method in class org.jgroups.blocks.MethodCall
returns the name of the method to be invoked using this method call object
getName() - Static method in class org.jgroups.blocks.RpcDispatcher
 
getName() - Method in class org.jgroups.Channel
Returns the logical name of this channel if set.
getName(Address) - Method in class org.jgroups.Channel
Returns the logical name of a given member.
getName() - Method in class org.jgroups.demos.JmxDemo.MyNotification
 
getName() - Method in class org.jgroups.JChannel
 
getName(Address) - Method in class org.jgroups.JChannel
 
getName() - Method in class org.jgroups.protocols.COUNTER.CounterImpl
 
getName() - Method in class org.jgroups.protocols.relay.config.RelayConfig.SiteConfig
 
getName() - Method in class org.jgroups.protocols.relay.SiteUUID
 
getName() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
 
getName() - Method in class org.jgroups.stack.Protocol
 
getName() - Method in class org.jgroups.stack.ProtocolStack
 
GetNetworkInterfaces - Class in org.jgroups.util
Lists all network interfaces on a system
GetNetworkInterfaces() - Constructor for class org.jgroups.util.GetNetworkInterfaces
 
getNewConnectionId() - Method in class org.jgroups.protocols.UNICAST
 
getNewConnectionId() - Method in class org.jgroups.protocols.UNICAST2
 
getNextId() - Method in class org.jgroups.protocols.FORWARD_TO_COORD
 
getNextId() - Method in class org.jgroups.protocols.RSVP
 
getNextMessagesToDeliver() - Method in interface org.jgroups.protocols.tom.DeliveryManager
returns an ordered list with the messages to be deliver.
getNextMessagesToDeliver() - Method in class org.jgroups.protocols.tom.DeliveryManagerImpl
 
getNextMulticastAddress() - Static method in class org.jgroups.util.ResourceManager
Returns the next available multicast address, e.g.
getNextMulticastPort(InetAddress) - Static method in class org.jgroups.util.ResourceManager
 
getNextTcpPort(InetAddress) - Static method in class org.jgroups.util.ResourceManager
 
getNextTcpPorts(InetAddress, int) - Static method in class org.jgroups.util.ResourceManager
 
getNextView(Collection<Address>, Collection<Address>, Collection<Address>) - Method in class org.jgroups.protocols.pbcast.GMS
Computes the next view.
getNonLoopbackAddress() - Static method in class org.jgroups.util.Util
Returns the first non-loopback address on any interface on the current host.
getNonMemberMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
getNonMemberMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
getNullMessages(long, long) - Method in class org.jgroups.util.RetransmitTable
Returns the number of null elements in the range [from ..
getNumAcksReceived() - Method in class org.jgroups.protocols.UNICAST
 
getNumAcksSent() - Method in class org.jgroups.protocols.UNICAST
 
getNumActiveThreads() - Method in class org.jgroups.protocols.SCOPE
 
getNumberAsString() - Method in class org.jgroups.demos.JmxDemo
 
getNumberOfAnycastMessagesDelivered() - Method in class org.jgroups.protocols.tom.TOA
 
getNumberOfAnycastMessagesSent() - Method in class org.jgroups.protocols.tom.StatsCollector
 
getNumberOfAnycastMessagesSent() - Method in class org.jgroups.protocols.tom.TOA
 
getNumberOfBackups() - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
 
getNumberOfBackups() - Method in class org.jgroups.protocols.CENTRAL_LOCK
 
getNumberOfBlockings() - Method in class org.jgroups.protocols.FC
 
getNumberOfBlockings() - Method in class org.jgroups.protocols.FlowControl
 
getNumberOfBlockings() - Method in class org.jgroups.protocols.MFC
 
getNumberOfBlockings() - Method in class org.jgroups.protocols.UFC
 
getNumberOfConnectionCreations() - Static method in class org.jgroups.blocks.BasicConnectionTable
 
getNumberOfCreditRequestsReceived() - Method in class org.jgroups.protocols.FC
 
getNumberOfCreditRequestsReceived() - Method in class org.jgroups.protocols.FlowControl
 
getNumberOfCreditRequestsSent() - Method in class org.jgroups.protocols.FC
 
getNumberOfCreditRequestsSent() - Method in class org.jgroups.protocols.FlowControl
 
getNumberOfCreditResponsesReceived() - Method in class org.jgroups.protocols.FC
 
getNumberOfCreditResponsesReceived() - Method in class org.jgroups.protocols.FlowControl
 
getNumberOfCreditResponsesSent() - Method in class org.jgroups.protocols.FC
 
getNumberOfCreditResponsesSent() - Method in class org.jgroups.protocols.FlowControl
 
getNumberOfDataMessagesDelivered() - Method in class org.jgroups.protocols.tom.TOA
 
getNumberOfDiscoveryRequestsSent() - Method in class org.jgroups.protocols.Discovery
 
getNumberOfFinalAnycastSent() - Method in class org.jgroups.protocols.tom.TOA
 
getNumberOfFinalAnycastsSent() - Method in class org.jgroups.protocols.tom.StatsCollector
 
getNumberOfFinalMessagesDelivered() - Method in class org.jgroups.protocols.tom.StatsCollector
 
getNumberOfFinalMessagesDelivered() - Method in class org.jgroups.protocols.tom.TOA
 
getNumberOfFlushes() - Method in class org.jgroups.protocols.pbcast.FLUSH
 
getNumberOfHeartbeatsSent() - Method in class org.jgroups.protocols.FD
 
getNumberOfInFlightThreads() - Method in class org.jgroups.protocols.BARRIER
 
getNumberOfMessages() - Method in class org.jgroups.protocols.SCOPE
 
getNumberOfMessagesInReceiveWindows() - Method in class org.jgroups.protocols.UNICAST
 
getNumberOfMissingMessages() - Method in class org.jgroups.util.Seqno
 
getNumberOfMissingMessages() - Method in class org.jgroups.util.SeqnoRange
 
getNumberOfProposeMessageReceived() - Method in class org.jgroups.protocols.tom.TOA
 
getNumberOfProposeMessageSent() - Method in class org.jgroups.protocols.tom.TOA
 
getNumberOfProposeMessagesReceived() - Method in class org.jgroups.protocols.tom.StatsCollector
 
getNumberOfProposeMessagesSent() - Method in class org.jgroups.protocols.tom.StatsCollector
 
getNumberOfReceivedFragments() - Method in class org.jgroups.protocols.FRAG
 
getNumberOfReceivedFragments() - Method in class org.jgroups.protocols.FRAG2
 
getNumberOfReceivedMessages() - Method in class org.jgroups.protocols.FRAG
 
getNumberOfReceivedMessages() - Method in class org.jgroups.protocols.FRAG2
 
getNumberOfReceivedMessages() - Method in class org.jgroups.util.Seqno
 
getNumberOfReceivedMessages() - Method in class org.jgroups.util.SeqnoRange
 
getNumberOfReceiverScopes() - Method in class org.jgroups.protocols.SCOPE
 
getNumberOfSentFragments() - Method in class org.jgroups.protocols.FRAG
 
getNumberOfSentFragments() - Method in class org.jgroups.protocols.FRAG2
 
getNumberOfSentMessages() - Method in class org.jgroups.protocols.FRAG
 
getNumberOfSentMessages() - Method in class org.jgroups.protocols.FRAG2
 
getNumberOfStateBytesSent() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
getNumberOfStateBytesSent() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
getNumberOfStateRequests() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
getNumberOfStateRequests() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
getNumberOfTasksInTimer() - Method in class org.jgroups.JChannel
 
getNumberOfViews() - Method in class org.jgroups.protocols.pbcast.GMS
 
getNumBlockings() - Method in class org.jgroups.protocols.FlowControl.Credit
 
getNumBlockings() - Method in class org.jgroups.util.CreditMap
 
getNumBytesReceived() - Method in class org.jgroups.protocols.TP
 
getNumBytesSent() - Method in class org.jgroups.protocols.TP
 
getNumCompactions() - Method in class org.jgroups.util.Table
 
getNumConnections() - Method in class org.jgroups.blocks.AbstractConnectionMap
 
getNumConnections() - Method in class org.jgroups.blocks.BasicConnectionTable
 
getNumConnections() - Method in class org.jgroups.blocks.TCPConnectionMap
 
getNumConnections() - Method in class org.jgroups.protocols.STOMP
 
getNumConnections() - Method in class org.jgroups.protocols.UNICAST
 
getNumConnections() - Method in class org.jgroups.protocols.UNICAST2
 
getNumForwardedToLocalMbr() - Method in class org.jgroups.protocols.relay.RELAY2
 
getNumForwardedToSiteMaster() - Method in class org.jgroups.protocols.relay.RELAY2
 
getNumHeaders() - Method in class org.jgroups.Message
 
getNumInitialMembers() - Method in class org.jgroups.protocols.Discovery
 
getNumLocalDeliveries() - Method in class org.jgroups.protocols.relay.RELAY2
 
getNumMembers() - Method in class org.jgroups.protocols.pbcast.GMS
 
getNumMessagesReceived() - Method in class org.jgroups.protocols.TP
 
getNumMessagesReceived() - Method in class org.jgroups.protocols.UNICAST
 
getNumMessagesSent() - Method in class org.jgroups.protocols.TP
 
getNumMessagesSent() - Method in class org.jgroups.protocols.UNICAST
 
getNumMissing() - Method in class org.jgroups.util.Table
Returns the number of null elements in the range [hd+1 ..
getNumMoves() - Method in class org.jgroups.util.Table
 
getNumPurges() - Method in class org.jgroups.util.Table
 
getNumReceiveConnections() - Method in class org.jgroups.protocols.UNICAST
 
getNumReceiveConnections() - Method in class org.jgroups.protocols.UNICAST2
 
getNumRelayed() - Method in class org.jgroups.protocols.relay.RELAY2
 
getNumResizes() - Method in class org.jgroups.util.Table
 
getNumRows() - Method in class org.jgroups.util.Table
 
getNumRules() - Method in class org.jgroups.protocols.rules.SUPERVISOR
 
getNumSendConnections() - Method in class org.jgroups.protocols.UNICAST
 
getNumSendConnections() - Method in class org.jgroups.protocols.UNICAST2
 
getNumSubscriptions() - Method in class org.jgroups.protocols.STOMP
 
getNumSuspectEventsGenerated() - Method in class org.jgroups.protocols.FD
 
getNumSuspectEventsGenerated() - Method in class org.jgroups.protocols.FD_SOCK
 
getNumThreads() - Static method in class org.jgroups.protocols.TP
 
getNumTimerTasks() - Method in class org.jgroups.protocols.TP
 
getNumUnackedMessages() - Method in class org.jgroups.protocols.UNICAST
The number of messages in all Entry.sent_msgs tables (haven't received an ACK yet)
getNumXmits() - Method in class org.jgroups.protocols.UNICAST
 
getObject() - Method in class org.jgroups.Message
Uses custom serialization to create an object from the buffer of the message.
getOffset() - Method in class org.jgroups.Message
Returns the offset into the buffer at which the data starts
getOffset() - Method in class org.jgroups.util.Buffer
 
getOffset() - Method in class org.jgroups.util.RetransmitTable
 
getOffset() - Method in class org.jgroups.util.Table
 
getOOBMaxQueueSize() - Method in class org.jgroups.protocols.TP
 
getOOBMessages() - Method in class org.jgroups.protocols.TP
 
getOOBPoolSize() - Method in class org.jgroups.protocols.TP
 
getOOBQueueSize() - Method in class org.jgroups.protocols.TP
 
getOOBThreadPool() - Method in class org.jgroups.protocols.TP
 
getOOBThreadPoolKeepAliveTime() - Method in class org.jgroups.protocols.TP
 
getOOBThreadPoolMaxThreads() - Method in class org.jgroups.protocols.TP
 
getOOBThreadPoolMinThreads() - Method in class org.jgroups.protocols.TP
 
getOOBThreadPoolThreadFactory() - Method in class org.jgroups.protocols.TP
 
getOpenConnections() - Method in class org.jgroups.protocols.TCP
 
getOpenConnections() - Method in class org.jgroups.protocols.TCP_NIO
 
getOrCreateCounter(String, long) - Method in class org.jgroups.blocks.atomic.CounterService
Returns an existing counter, or creates a new one if none exists
getOrCreateCounter(String, long) - Method in class org.jgroups.protocols.COUNTER
 
getOrCreateQueue(Address, short) - Method in class org.jgroups.protocols.SCOPE
 
getOrCreateReceiverEntry(Address, long, short) - Method in class org.jgroups.protocols.UNICAST
 
getOrCreateReceiverEntry(Address, long, short) - Method in class org.jgroups.protocols.UNICAST2
 
getOrigin() - Method in class org.jgroups.protocols.tom.ToaHeader
 
getOriginalProperties() - Method in class org.jgroups.conf.ProtocolConfiguration
 
getOutDelay() - Method in class org.jgroups.protocols.DELAY
 
getOutgoingCopies() - Method in class org.jgroups.protocols.DUPL
 
getOutput(String) - Method in class org.jgroups.blocks.GridFilesystem
 
getOutput(String, boolean) - Method in class org.jgroups.blocks.GridFilesystem
 
getOutput(String, boolean, short, int) - Method in class org.jgroups.blocks.GridFilesystem
 
getOutput(GridFile) - Method in class org.jgroups.blocks.GridFilesystem
 
getOutputStream() - Method in class org.jgroups.util.ExposedDataOutputStream
 
getOwner() - Method in class org.jgroups.protocols.COUNTER
 
getOwner() - Method in class org.jgroups.protocols.Locking
 
getParameterString(String, String) - Static method in class org.jgroups.conf.ProtocolConfiguration
 
getParameterStringXml(String, String) - Static method in class org.jgroups.conf.ProtocolConfiguration
 
getPath() - Method in class org.jgroups.blocks.GridFile
 
getPayload() - Method in class org.jgroups.util.PayloadUUID
 
getPeerAddress() - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
 
getPeerAddressReadTimeout() - Method in class org.jgroups.blocks.BasicConnectionTable
 
getPendingRsvpRequests() - Method in class org.jgroups.protocols.RSVP
 
getPendingXmitRequests() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
getPendingXmits() - Method in class org.jgroups.stack.NakReceiverWindow
 
getPhysicalAddr() - Method in class org.jgroups.protocols.PDC.Mapping
 
getPhysicalAddress() - Method in class org.jgroups.protocols.SHARED_LOOPBACK
 
getPhysicalAddress() - Method in class org.jgroups.protocols.TCP
 
getPhysicalAddress() - Method in class org.jgroups.protocols.TCP_NIO
 
getPhysicalAddress() - Method in class org.jgroups.protocols.TP
 
getPhysicalAddress() - Method in class org.jgroups.protocols.TUNNEL
 
getPhysicalAddress() - Method in class org.jgroups.protocols.UDP
 
getPhysicalAddresses() - Method in class org.jgroups.stack.GossipData
 
getPhysicalAddressFromCache(Address) - Method in class org.jgroups.protocols.TP
 
getPhysicalAddrs() - Method in class org.jgroups.protocols.PingData
 
getPingableMembers() - Method in class org.jgroups.protocols.FD
 
getPingableMembers() - Method in class org.jgroups.protocols.FD_SOCK
 
getPingDest() - Method in class org.jgroups.protocols.FD
 
getPingDest(List<Address>) - Method in class org.jgroups.protocols.FD
 
getPingDest() - Method in class org.jgroups.protocols.FD_SOCK
 
getPort() - Method in class org.jgroups.blocks.MemcachedConnector
 
getPort() - Method in class org.jgroups.stack.GossipRouter
 
getPort() - Method in class org.jgroups.stack.IpAddress
 
getPortRange() - Method in class org.jgroups.protocols.TCPPING
 
getPortRange() - Method in class org.jgroups.protocols.TP
 
getPriority() - Method in class org.jgroups.protocols.PrioHeader
 
getProbeHandlers() - Method in class org.jgroups.stack.DiagnosticsHandler
 
getProcessing() - Method in class org.jgroups.stack.NakReceiverWindow
 
getProcessing() - Method in class org.jgroups.util.RingBuffer
 
getProcessing() - Method in class org.jgroups.util.RingBufferLockless
 
getProcessing() - Method in class org.jgroups.util.Table
 
getProcessorKeepAliveTime() - Method in class org.jgroups.blocks.ConnectionTableNIO
 
getProcessorKeepAliveTime() - Method in class org.jgroups.protocols.TCP_NIO
 
getProcessorMaxThreads() - Method in class org.jgroups.blocks.ConnectionTableNIO
 
getProcessorMaxThreads() - Method in class org.jgroups.protocols.TCP_NIO
 
getProcessorMinThreads() - Method in class org.jgroups.blocks.ConnectionTableNIO
 
getProcessorMinThreads() - Method in class org.jgroups.protocols.TCP_NIO
 
getProcessorQueueSize() - Method in class org.jgroups.blocks.ConnectionTableNIO
 
getProcessorQueueSize() - Method in class org.jgroups.protocols.TCP_NIO
 
getProcessorThreads() - Method in class org.jgroups.blocks.ConnectionTableNIO
 
getProcessorThreads() - Method in class org.jgroups.protocols.TCP_NIO
 
getProperties() - Method in class org.jgroups.Channel
 
getProperties() - Method in class org.jgroups.conf.ProtocolConfiguration
 
getProperties() - Method in class org.jgroups.JChannel
Returns the protocol stack configuration in string format.
getPropertiesString() - Method in class org.jgroups.conf.ProtocolConfiguration
 
getProperty(String[], Properties, String, boolean, String) - Static method in class org.jgroups.util.Util
Returns a value associated wither with one or more system properties, or found in the props map
getProperty(String) - Static method in class org.jgroups.util.Util
 
getPropertyAsBoolean(String, boolean) - Static method in class org.jgroups.Global
 
getPropertyAsInteger(String, int) - Static method in class org.jgroups.Global
 
getPropertyAsLong(String, long) - Static method in class org.jgroups.Global
 
getPropertyName(Field, Map<String, String>) - Static method in class org.jgroups.conf.PropertyHelper
 
getPropertyName(Method) - Static method in class org.jgroups.conf.PropertyHelper
 
getProps() - Method in class org.jgroups.blocks.PartitionedHashMap
 
getProps() - Method in class org.jgroups.blocks.ReplCache
 
getProtocol(short) - Static method in class org.jgroups.conf.ClassConfigurator
 
getProtocolAdapter() - Method in class org.jgroups.blocks.MessageDispatcher
 
getProtocolId(Class) - Static method in class org.jgroups.conf.ClassConfigurator
 
getProtocolName() - Method in class org.jgroups.conf.ProtocolConfiguration
 
getProtocols() - Method in class org.jgroups.stack.ProtocolStack
Returns all protocols in a list, from top to bottom.
getProtocolStack() - Method in class org.jgroups.Channel
 
getProtocolStack() - Method in class org.jgroups.conf.PlainConfigurator
 
getProtocolStack() - Method in interface org.jgroups.conf.ProtocolStackConfigurator
 
getProtocolStack() - Method in class org.jgroups.conf.XmlConfigurator
 
getProtocolStack() - Method in class org.jgroups.JChannel
Returns the protocol stack
getProtocolStack() - Method in class org.jgroups.stack.Protocol
 
getProtocolStackString() - Method in class org.jgroups.conf.PlainConfigurator
returns the old style protocol string
getProtocolStackString() - Method in interface org.jgroups.conf.ProtocolStackConfigurator
 
getProtocolStackString(boolean) - Method in class org.jgroups.conf.XmlConfigurator
 
getProtocolStackString() - Method in class org.jgroups.conf.XmlConfigurator
 
getProtocolString(boolean) - Method in class org.jgroups.conf.ProtocolConfiguration
 
getProtocolString() - Method in class org.jgroups.conf.ProtocolConfiguration
 
getProtocolStringNewXml() - Method in class org.jgroups.conf.ProtocolConfiguration
 
getQueueSize() - Method in class org.jgroups.util.HashedTimingWheel
 
getQueueSize() - Method in class org.jgroups.util.TimeScheduler2
 
getQueueSize() - Method in class org.jgroups.util.TimeScheduler3
 
getQuote(String) - Method in class org.jgroups.demos.QuoteServer
 
getRackId() - Method in class org.jgroups.util.TopologyUUID
 
getRange() - Method in class org.jgroups.protocols.pbcast.NakAckHeader
 
getRank(View, Address) - Static method in class org.jgroups.util.Util
Returns the rank of a member in a given view
getRank(Collection<Address>, Address) - Static method in class org.jgroups.util.Util
 
getRawBuffer() - Method in class org.jgroups.Message
Returns a reference to the payload (byte buffer).
getRawBuffer() - Method in class org.jgroups.util.ExposedByteArrayOutputStream
 
getRawHeaders() - Method in class org.jgroups.util.Headers
 
getRawIDs() - Method in class org.jgroups.util.Headers
 
getReaderThreads() - Method in class org.jgroups.blocks.ConnectionTableNIO
 
getReaderThreads() - Method in class org.jgroups.protocols.TCP_NIO
 
getReaperInterval() - Method in class org.jgroups.protocols.BasicTCP
 
getReceiveBufferSize() - Method in class org.jgroups.blocks.BasicConnectionTable
 
getReceivedBroadcasts() - Method in class org.jgroups.protocols.SEQUENCER
 
getReceivedBytes() - Method in class org.jgroups.JChannel
 
getReceivedBytes() - Method in class org.jgroups.protocols.STATS
 
getReceivedForwards() - Method in class org.jgroups.protocols.SEQUENCER
 
getReceivedMcastBytes() - Method in class org.jgroups.protocols.STATS
 
getReceivedMcastMessages() - Method in class org.jgroups.protocols.STATS
 
getReceivedMessages() - Method in class org.jgroups.JChannel
 
getReceivedMessages() - Method in class org.jgroups.protocols.STATS
 
getReceivedUnicastBytes() - Method in class org.jgroups.protocols.STATS
 
getReceivedUnicastMessages() - Method in class org.jgroups.protocols.STATS
 
getReceiveInterfaces() - Method in class org.jgroups.protocols.MPING
 
getReceiveInterfaces() - Method in class org.jgroups.protocols.TP
 
getReceiver() - Method in class org.jgroups.blocks.TCPConnectionMap
 
getReceiver() - Method in class org.jgroups.Channel
Returns a receiver for this channel if it has been installed using Channel.setReceiver(Receiver) , null otherwise
getReceiver() - Method in class org.jgroups.stack.RouterStub
 
getReceiverEntry(Address, long, boolean, short) - Method in class org.jgroups.protocols.UNICAST
 
getReceiverEntry(Address, long, boolean, short) - Method in class org.jgroups.protocols.UNICAST2
 
getReconnectInterval() - Method in class org.jgroups.protocols.TUNNEL
 
getRegularMaxQueueSize() - Method in class org.jgroups.protocols.TP
 
getRegularMessages() - Method in class org.jgroups.protocols.TP
 
getRegularPoolSize() - Method in class org.jgroups.protocols.TP
 
getRegularQueueSize() - Method in class org.jgroups.protocols.TP
 
getRemoteView() - Method in class org.jgroups.protocols.RELAY
 
getReplicationCount() - Method in class org.jgroups.blocks.ReplCache.Value
 
getRequestId() - Static method in class org.jgroups.blocks.Request
Generates a new unique request ID
getRequestId() - Method in class org.jgroups.protocols.Executing.Owner
 
getRequestMarshaller() - Method in class org.jgroups.blocks.RpcDispatcher
 
getResourceAsStream(String, Class) - Static method in class org.jgroups.util.Util
 
getResponseMarshaller() - Method in class org.jgroups.blocks.RpcDispatcher
 
getResponsesComplete() - Method in class org.jgroups.blocks.Request
 
getResult() - Method in class org.jgroups.blocks.UnicastRequest
 
getResult() - Method in class org.jgroups.protocols.pbcast.NAKACK2.Counter
 
getResult() - Method in class org.jgroups.util.Promise
 
getResult(long) - Method in class org.jgroups.util.Promise
Returns the result, but never throws a TimeoutException; returns null instead.
getResult() - Method in class org.jgroups.util.Table.Counter
 
getResult() - Method in class org.jgroups.util.Table.Dump
 
getResults() - Method in class org.jgroups.blocks.GroupRequest
Returns the results as a RspList
getResults() - Method in class org.jgroups.util.ResponseCollector
 
getResults() - Method in class org.jgroups.util.RspList
Returns the results from non-suspected members that are not null.
getResultWithTimeout(long) - Method in class org.jgroups.util.Promise
Blocks until a result is available, or timeout milliseconds have elapsed
getRetransmitTableCapacity() - Method in class org.jgroups.stack.NakReceiverWindow
 
getRetransmitTableFillFactor() - Method in class org.jgroups.stack.NakReceiverWindow
 
getRetransmitTableOffset() - Method in class org.jgroups.stack.NakReceiverWindow
 
getRetransmitTableSize() - Method in class org.jgroups.stack.NakReceiverWindow
 
getRetryTimeout() - Method in class org.jgroups.protocols.pbcast.FLUSH
 
getRound() - Method in class org.jgroups.util.HashedTimingWheel.MyTask
 
getRoute(String) - Method in class org.jgroups.protocols.relay.RELAY2
Returns the route to a given site
getRoute(short) - Method in class org.jgroups.protocols.relay.Relayer
 
getRoutes(short...) - Method in class org.jgroups.protocols.relay.Relayer
 
getRow(int) - Method in class org.jgroups.util.RetransmitTable
Returns a row.
getRow(int) - Method in class org.jgroups.util.Table
Returns a row.
getRspFilter() - Method in class org.jgroups.blocks.RequestOptions
 
getRunnable() - Method in class org.jgroups.util.TimeScheduler3.Task
 
getScope() - Method in class org.jgroups.blocks.RequestOptions
 
getScope() - Method in class org.jgroups.Message
 
getScope() - Method in class org.jgroups.protocols.SCOPE.ScopeHeader
 
getScope(Message) - Static method in class org.jgroups.util.Util
 
getScopedInetAddress(Inet6Address) - Static method in class org.jgroups.conf.PropertyConverters.Default
 
getSendBufferSize() - Method in class org.jgroups.blocks.BasicConnectionTable
 
getSender() - Method in class org.jgroups.protocols.pbcast.MergeData
 
getSender() - Method in class org.jgroups.protocols.pbcast.NakAckHeader
 
getSender() - Method in class org.jgroups.protocols.pbcast.NakAckHeader2
 
getSender() - Method in class org.jgroups.util.Rsp
 
getSenderQueueSize() - Method in class org.jgroups.blocks.TCPConnectionMap
 
getSendInterfaces() - Method in class org.jgroups.protocols.MPING
 
getSendQueueSize() - Method in class org.jgroups.blocks.BasicConnectionTable
 
getSentBytes() - Method in class org.jgroups.JChannel
 
getSentBytes() - Method in class org.jgroups.protocols.STATS
 
getSentMcastBytes() - Method in class org.jgroups.protocols.STATS
 
getSentMcastMessages() - Method in class org.jgroups.protocols.STATS
 
getSentMessages() - Method in class org.jgroups.JChannel
 
getSentMessages() - Method in class org.jgroups.protocols.STATS
 
getSentUnicastBytes() - Method in class org.jgroups.protocols.STATS
 
getSentUnicastMessages() - Method in class org.jgroups.protocols.STATS
 
getSeqno() - Method in class org.jgroups.protocols.pbcast.NakAckHeader
 
getSeqno() - Method in class org.jgroups.protocols.pbcast.NakAckHeader2
 
getSeqno() - Method in class org.jgroups.protocols.SEQUENCER.SequencerHeader
 
getSeqno() - Method in class org.jgroups.protocols.UNICAST.UnicastHeader
 
getSeqno() - Method in class org.jgroups.protocols.UNICAST2.Unicast2Header
 
getSequencerNumber() - Method in class org.jgroups.protocols.tom.ToaHeader
 
getServerObject() - Method in class org.jgroups.blocks.RpcDispatcher
 
getServerPubKey() - Method in class org.jgroups.protocols.ENCRYPT
 
getServerSocketAddress() - Method in class org.jgroups.protocols.pbcast.STATE_SOCK.StateProviderAcceptor
 
getSessionId() - Method in class org.jgroups.client.StompConnection
 
getSingletonName() - Method in class org.jgroups.protocols.TP
 
getSingletonTransports() - Static method in class org.jgroups.stack.ProtocolStack
 
getSite() - Method in interface org.jgroups.protocols.relay.SiteAddress
Returns the ID of the site (all sites need to have a unique site ID)
getSite() - Method in class org.jgroups.protocols.relay.SiteUUID
 
getSite(String) - Static method in class org.jgroups.protocols.relay.SiteUUID
 
getSiteId() - Method in class org.jgroups.util.TopologyUUID
 
getSiteName(short) - Static method in class org.jgroups.protocols.relay.SiteUUID
 
getSize() - Method in class org.jgroups.blocks.Cache
 
getSizeOfAllMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
getSizeOfAllMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
getSizeOfAllMessagesInclHeaders() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
getSizeOfAllMessagesInclHeaders() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
getSockAddress() - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
 
getSocket() - Method in class org.jgroups.stack.RouterStub
 
getSocketConnectionTimeout() - Method in class org.jgroups.blocks.BasicConnectionTable
 
getSocketConnectionTimeout() - Method in class org.jgroups.stack.RouterStub
 
getSocketFactory() - Method in class org.jgroups.blocks.BasicConnectionTable
 
getSocketFactory() - Method in class org.jgroups.blocks.TCPConnectionMap
 
getSocketFactory() - Method in class org.jgroups.Channel
 
getSocketFactory() - Method in class org.jgroups.protocols.TP
 
getSocketFactory() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
 
getSocketFactory() - Method in class org.jgroups.stack.Protocol
Returns the SocketFactory associated with this protocol, if overridden in a subclass, or passes the call down
getSocketReadTimeout() - Method in class org.jgroups.stack.GossipRouter
 
getSocketReadTimeout() - Method in class org.jgroups.stack.RouterStub
 
getSockets() - Method in class org.jgroups.util.DefaultSocketFactory
 
getSockets() - Method in interface org.jgroups.util.SocketFactory
Returns all open sockets.
getSrc() - Method in class org.jgroups.Message
 
getStabilityReceived() - Method in class org.jgroups.protocols.pbcast.STABLE
 
getStabilitySent() - Method in class org.jgroups.protocols.pbcast.STABLE
 
getStableReceived() - Method in class org.jgroups.protocols.pbcast.STABLE
 
getStableSent() - Method in class org.jgroups.protocols.pbcast.STABLE
 
getStableTaskRunning() - Method in class org.jgroups.protocols.pbcast.STABLE
 
getStackConfigurator(File) - Static method in class org.jgroups.conf.ConfiguratorFactory
Returns a protocol stack configurator based on the XML configuration provided by the specified File.
getStackConfigurator(InputStream) - Static method in class org.jgroups.conf.ConfiguratorFactory
 
getStackConfigurator(URL) - Static method in class org.jgroups.conf.ConfiguratorFactory
Returns a protocol stack configurator based on the XML configuration provided at the specified URL.
getStackConfigurator(Element) - Static method in class org.jgroups.conf.ConfiguratorFactory
Returns a protocol stack configurator based on the XML configuration provided by the specified XML element.
getStackConfigurator(String) - Static method in class org.jgroups.conf.ConfiguratorFactory
Returns a protocol stack configurator based on the provided properties string.
getStackTrace(Throwable) - Static method in class org.jgroups.util.Util
 
getStartCount() - Method in class org.jgroups.stack.ProtocolStack.RefCounter
 
getStartFlushTimeout() - Method in class org.jgroups.protocols.pbcast.FLUSH
 
getState(OutputStream) - Method in class org.jgroups.blocks.ReplicatedHashMap
 
getState(OutputStream) - Method in class org.jgroups.blocks.ReplicatedTree
 
getState() - Method in class org.jgroups.Channel
 
getState(Address, long) - Method in class org.jgroups.Channel
Retrieves the full state from the target member.
getState(OutputStream) - Method in class org.jgroups.demos.Draw
 
getState(OutputStream) - Method in class org.jgroups.demos.QuoteServer
 
getState(OutputStream) - Method in class org.jgroups.demos.wb.GraphPanel
 
getState(OutputStream) - Method in class org.jgroups.demos.wb.Whiteboard
 
getState(Address, long) - Method in class org.jgroups.JChannel
 
getState(Address, long, boolean) - Method in class org.jgroups.JChannel
Retrieves state from the target member.
getState(Address, long, Callable<Boolean>) - Method in class org.jgroups.JChannel
 
getState(OutputStream) - Method in interface org.jgroups.MessageListener
Allows an application to write a state through a provided OutputStream.
getState(OutputStream) - Method in class org.jgroups.ReceiverAdapter
Allows an application to write a state through a provided OutputStream.
getStateFromApplication(Address, Digest) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
getStateFromApplication(Address, OutputStream, boolean) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
getStats() - Method in class org.jgroups.blocks.MemcachedConnector
 
getStubs() - Method in class org.jgroups.stack.RouterStubManager
 
getSubgroups() - Method in class org.jgroups.MergeView
 
getSubscriptions() - Method in class org.jgroups.protocols.STOMP
 
getSuspectedMembers() - Method in class org.jgroups.protocols.FD.Broadcaster
 
getSuspectedMembers() - Method in class org.jgroups.protocols.FD_ALL
 
getSuspectedMembers() - Method in class org.jgroups.util.RspList
 
getSuspectEventsSent() - Method in class org.jgroups.protocols.FD_ALL
 
getSymAlgorithm() - Method in class org.jgroups.protocols.ENCRYPT
 
getSymDecodingCipher() - Method in class org.jgroups.protocols.ENCRYPT
 
getSymEncodingCipher() - Method in class org.jgroups.protocols.ENCRYPT
 
getSymInit() - Method in class org.jgroups.protocols.ENCRYPT
 
getSymProvider() - Method in class org.jgroups.protocols.ENCRYPT
 
getTcpNodelay() - Method in class org.jgroups.blocks.BasicConnectionTable
 
getThread() - Method in class org.jgroups.protocols.TP.TransferQueueBundler
 
getThread() - Method in class org.jgroups.protocols.TP.TransferQueueBundler2
 
getThread() - Method in class org.jgroups.protocols.TUNNEL.StubReceiver
 
getThread() - Method in class org.jgroups.stack.DiagnosticsHandler
 
getThreadFactory() - Method in class org.jgroups.blocks.AbstractConnectionMap
 
getThreadFactory() - Method in class org.jgroups.blocks.BasicConnectionTable
 
getThreadFactory() - Method in class org.jgroups.protocols.TP
 
getThreadFactory() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
 
getThreadFactory() - Method in class org.jgroups.stack.Protocol
Supposed to be overwritten by subclasses.
getThreadId() - Method in class org.jgroups.util.Owner
 
getThreadNamingPattern() - Method in class org.jgroups.protocols.TP
Names the current thread.
getThreadPool() - Method in class org.jgroups.blocks.MemcachedConnector
 
getThreadPoolCompletedTasks() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
getThreadPoolCoreThreads() - Method in class org.jgroups.blocks.MemcachedConnector
 
getThreadPoolIdleTime() - Method in class org.jgroups.blocks.MemcachedConnector
 
getThreadPoolKeepAliveTime() - Method in class org.jgroups.protocols.SCOPE
 
getThreadPoolKeepAliveTime() - Method in class org.jgroups.protocols.TP
 
getThreadPoolMaxThreads() - Method in class org.jgroups.blocks.MemcachedConnector
 
getThreadPoolMaxThreads() - Method in class org.jgroups.protocols.SCOPE
 
getThreadPoolMaxThreads() - Method in class org.jgroups.protocols.TP
 
getThreadPoolMinThreads() - Method in class org.jgroups.protocols.SCOPE
 
getThreadPoolMinThreads() - Method in class org.jgroups.protocols.TP
 
getThreadPoolSize() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
getTimeDeliveringLocally() - Method in class org.jgroups.protocols.relay.RELAY2
 
getTimeForwardingToLocalMbr() - Method in class org.jgroups.protocols.relay.RELAY2
 
getTimeForwardingToSM() - Method in class org.jgroups.protocols.relay.RELAY2
 
getTimeout() - Method in class org.jgroups.blocks.Cache.Value
 
getTimeout() - Method in class org.jgroups.blocks.locking.LockInfo
 
getTimeout() - Method in class org.jgroups.blocks.ReplicatedHashMap
The timeout (in milliseconds) for blocking updates
getTimeout() - Method in class org.jgroups.blocks.RequestOptions
 
getTimeout() - Method in class org.jgroups.protocols.Discovery
 
getTimeout() - Method in class org.jgroups.protocols.FD
 
getTimeout() - Method in class org.jgroups.protocols.FD_ALL
 
getTimeout() - Method in class org.jgroups.protocols.UNICAST
 
getTimeout() - Method in class org.jgroups.protocols.UNICAST2
Deprecated. 
getTimeout() - Method in class org.jgroups.util.AgeOutCache
 
getTimeout() - Method in class org.jgroups.util.ExpiryCache
 
getTimeoutCheckInterval() - Method in class org.jgroups.protocols.FD_ALL
 
getTimePeriod() - Method in class org.jgroups.protocols.RATE_LIMITER
 
getTimer() - Method in class org.jgroups.JChannel
 
getTimer() - Method in class org.jgroups.protocols.relay.RELAY2
 
getTimer() - Method in class org.jgroups.protocols.TP
 
getTimer() - Method in class org.jgroups.protocols.UNICAST2
 
getTimerClass() - Method in class org.jgroups.protocols.TP
 
getTimeRelaying() - Method in class org.jgroups.protocols.relay.RELAY2
 
getTimerKeepAliveTime() - Method in class org.jgroups.protocols.TP
 
getTimerMaxThreads() - Method in class org.jgroups.protocols.TP
 
getTimerMinThreads() - Method in class org.jgroups.protocols.TP
 
getTimerQueueSize() - Method in class org.jgroups.protocols.TP
 
getTimerThreadFactory() - Method in class org.jgroups.protocols.TP
 
getTimerThreads() - Method in class org.jgroups.JChannel
 
getTimerThreads() - Method in class org.jgroups.protocols.TP
 
getTimeUnit() - Method in class org.jgroups.blocks.locking.LockInfo
 
getTo() - Method in class org.jgroups.protocols.relay.config.RelayConfig.ForwardConfig
 
getToken() - Method in class org.jgroups.protocols.AuthHeader
 
getTopProtocol() - Method in class org.jgroups.stack.ProtocolStack
 
getTotalBlockingTime() - Method in class org.jgroups.protocols.FlowControl.Credit
 
getTotalBlockTime() - Method in class org.jgroups.protocols.RATE_LIMITER
 
getTotalBlockTime() - Method in class org.jgroups.util.CreditMap
 
getTotalTimeBlocked() - Method in class org.jgroups.protocols.FC
 
getTotalTimeBlocked() - Method in class org.jgroups.protocols.FlowControl
 
getTotalTimeBlocked() - Method in class org.jgroups.protocols.MFC
 
getTotalTimeBlocked() - Method in class org.jgroups.protocols.UFC
 
getTotalTimeInFlush() - Method in class org.jgroups.protocols.pbcast.FLUSH
 
getTransientFlags() - Method in class org.jgroups.Message
 
getTransport() - Method in class org.jgroups.stack.Protocol
 
getTransport() - Method in class org.jgroups.stack.ProtocolStack
Returns the bottom most protocol
getTransportName() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
 
getTTL() - Method in class org.jgroups.protocols.DAISYCHAIN.DaisyHeader
 
getTTL() - Method in class org.jgroups.protocols.MPING
 
getType() - Method in class org.jgroups.Event
 
getType() - Method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
 
getType() - Method in class org.jgroups.protocols.FORWARD_TO_COORD.ForwardHeader
 
getType() - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
getType() - Method in class org.jgroups.protocols.pbcast.GmsImpl.Request
 
getType() - Method in class org.jgroups.protocols.pbcast.NakAckHeader
 
getType() - Method in class org.jgroups.protocols.pbcast.NakAckHeader2
 
getType() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
getType() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
 
getType() - Method in class org.jgroups.protocols.tom.ToaHeader
 
getType() - Method in class org.jgroups.protocols.UNICAST2.Unicast2Header
 
getType() - Method in class org.jgroups.stack.GossipData
 
getUniqueClusterName(String) - Static method in class org.jgroups.util.ResourceManager
 
getUniqueClusterName() - Static method in class org.jgroups.util.ResourceManager
 
getUpDiscardRate() - Method in class org.jgroups.protocols.DISCARD
 
getUpHandler() - Method in class org.jgroups.Channel
Returns UpHandler installed for this channel
getUpProt() - Method in class org.jgroups.util.ForwardQueue
 
getUpProtocol() - Method in class org.jgroups.stack.Protocol
 
getUpProtocols() - Method in class org.jgroups.protocols.TP
 
getUpServices() - Method in class org.jgroups.stack.Protocol
Returns all services provided by the protocols above the current protocol
getUserName() - Method in class org.jgroups.demos.wb.UserInfoDialog
 
getUseSendQueues() - Method in class org.jgroups.blocks.BasicConnectionTable
 
getVal() - Method in class org.jgroups.blocks.ReplCache.Value
 
getVal1() - Method in class org.jgroups.util.Triple
 
getVal1() - Method in class org.jgroups.util.Tuple
 
getVal2() - Method in class org.jgroups.util.Triple
 
getVal2() - Method in class org.jgroups.util.Tuple
 
getVal3() - Method in class org.jgroups.util.Triple
 
getValidResults() - Method in class org.jgroups.util.ResponseCollector
 
getValue() - Method in class org.jgroups.blocks.Cache.Value
 
getValue() - Method in class org.jgroups.blocks.UnicastRequest
 
getValue(String) - Method in class org.jgroups.stack.Protocol
 
getValue() - Method in class org.jgroups.util.Rsp
 
getValue(Object) - Method in class org.jgroups.util.RspList
Returns the value associated with address key
getValueFromProtocol(Protocol, Field) - Static method in class org.jgroups.stack.Configurator
 
getValueFromProtocol(Protocol, String) - Static method in class org.jgroups.stack.Configurator
 
getVerb() - Method in class org.jgroups.protocols.STOMP.Frame
 
getVersion() - Static method in class org.jgroups.JChannel
 
getVersion() - Method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
 
getVid() - Method in class org.jgroups.View
Returns the view ID of this view if this view was created with the empty constructur, null will be returned
getView() - Method in class org.jgroups.blocks.PartitionedHashMap
 
getView() - Method in class org.jgroups.blocks.ReplCache
 
getView() - Method in class org.jgroups.Channel
Gets the current view.
getView() - Method in class org.jgroups.JChannel
 
getView() - Method in class org.jgroups.protocols.COUNTER
 
getView() - Method in class org.jgroups.protocols.Discovery
 
getView() - Method in class org.jgroups.protocols.Executing
 
getView() - Method in class org.jgroups.protocols.Locking
 
getView() - Method in class org.jgroups.protocols.pbcast.GMS
 
getView() - Method in class org.jgroups.protocols.pbcast.JoinRsp
 
getView() - Method in class org.jgroups.protocols.pbcast.MergeData
 
getView() - Method in class org.jgroups.protocols.PingData
 
getView() - Method in class org.jgroups.protocols.rules.SUPERVISOR
 
getViewAckCollectionTimeout() - Method in class org.jgroups.protocols.pbcast.GMS
 
getViewAndDigest() - Method in class org.jgroups.protocols.pbcast.GMS
Returns the current view and digest
getViewAsString() - Method in class org.jgroups.JChannel
 
getViewHandlerSize() - Method in class org.jgroups.protocols.pbcast.GMS
 
getViewId() - Method in class org.jgroups.protocols.Discovery
 
getViewId() - Method in class org.jgroups.protocols.pbcast.GMS
 
getViewId() - Method in class org.jgroups.protocols.PingData
 
getViewId() - Method in class org.jgroups.View
 
getViews(List<PingData>) - Method in class org.jgroups.protocols.MERGE2.FindSubgroupsTask
 
getViews() - Method in class org.jgroups.protocols.MERGE3
 
getWindow(Address) - Method in class org.jgroups.protocols.pbcast.NAKACK
Please don't use this method; it is only provided for unit testing !
getWindow(Address) - Method in class org.jgroups.protocols.pbcast.NAKACK2
Returns the receive window for sender; only used for testing.
getWriterThreads() - Method in class org.jgroups.blocks.ConnectionTableNIO
 
getWriterThreads() - Method in class org.jgroups.protocols.TCP_NIO
 
getXmitRequestsReceived() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
getXmitRequestsReceived() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
getXmitRequestsSent() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
getXmitRequestsSent() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
getXmitResponsesReceived() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
getXmitResponsesReceived() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
getXmitResponsesSent() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
getXmitResponsesSent() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
getXmitStaggerTimeout() - Method in class org.jgroups.stack.Retransmitter
 
getXmitTableCapacity() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
getXmitTableMissingMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
getXmitTableMissingMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
getXmitTableMissingMessages() - Method in class org.jgroups.protocols.UNICAST
 
getXmitTableMissingMessages() - Method in class org.jgroups.protocols.UNICAST2
 
getXmitTableNumCompactions() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
getXmitTableNumCompactions() - Method in class org.jgroups.protocols.UNICAST
 
getXmitTableNumCompactions() - Method in class org.jgroups.protocols.UNICAST2
 
getXmitTableNumCurrentRows() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
getXmitTableNumMoves() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
getXmitTableNumMoves() - Method in class org.jgroups.protocols.UNICAST
 
getXmitTableNumMoves() - Method in class org.jgroups.protocols.UNICAST2
 
getXmitTableNumPurges() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
getXmitTableNumPurges() - Method in class org.jgroups.protocols.UNICAST
 
getXmitTableNumPurges() - Method in class org.jgroups.protocols.UNICAST2
 
getXmitTableNumResizes() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
getXmitTableNumResizes() - Method in class org.jgroups.protocols.UNICAST
 
getXmitTableNumResizes() - Method in class org.jgroups.protocols.UNICAST2
 
getXmitTableSize() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
getXmitTableUndeliveredMessages() - Method in class org.jgroups.protocols.UNICAST
 
getXmitTableUndeliveredMessages() - Method in class org.jgroups.protocols.UNICAST2
 
getXmitTableUndeliveredMsgs() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
Global - Class in org.jgroups
Global is a JGroups internal class defining global variables.
Global() - Constructor for class org.jgroups.Global
 
global_thread_factory - Variable in class org.jgroups.protocols.TP
Used by all threads created by JGroups outside of the thread pools
global_view - Variable in class org.jgroups.protocols.RELAY
The combined view of local and remote cluster
global_view - Variable in class org.jgroups.protocols.RELAY.ViewData
 
global_view_id - Variable in class org.jgroups.protocols.RELAY
To generate new global views
GMS - Class in org.jgroups.protocols.pbcast
Group membership protocol.
GMS() - Constructor for class org.jgroups.protocols.pbcast.GMS
 
gms - Variable in class org.jgroups.protocols.pbcast.GmsImpl
 
GMS.GmsHeader - Class in org.jgroups.protocols.pbcast
 
GMS.GmsHeader() - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
GMS.GmsHeader(byte) - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
GMS.GmsHeader(byte, View) - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
Used for VIEW header
GMS.GmsHeader(byte, Address, boolean) - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
Used for JOIN_REQ or LEAVE_REQ header
GMS.GmsHeader(byte, Address) - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
GMS.GmsHeader(byte, Collection<Address>) - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
GMS.GmsHeader(byte, JoinRsp) - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
Used for JOIN_RSP header
gms_id - Static variable in class org.jgroups.protocols.AUTH
 
GmsImpl - Class in org.jgroups.protocols.pbcast
 
GmsImpl(GMS) - Constructor for class org.jgroups.protocols.pbcast.GmsImpl
 
GmsImpl.Request - Class in org.jgroups.protocols.pbcast
 
go() - Method in class org.jgroups.demos.applets.DrawApplet
 
go() - Method in class org.jgroups.demos.Draw
 
go() - Method in class org.jgroups.demos.StompDraw
 
GOSSIP_GET - Static variable in class org.jgroups.stack.GossipRouter
 
GOSSIP_ROUTER - Static variable in class org.jgroups.Global
 
GossipData - Class in org.jgroups.stack
Encapsulates data sent between GossipRouter and GossipClient
GossipData() - Constructor for class org.jgroups.stack.GossipData
 
GossipData(byte) - Constructor for class org.jgroups.stack.GossipData
 
GossipData(byte, String, Address) - Constructor for class org.jgroups.stack.GossipData
 
GossipData(byte, String, Address, List<Address>) - Constructor for class org.jgroups.stack.GossipData
 
GossipData(byte, String, Address, List<Address>, List<PhysicalAddress>) - Constructor for class org.jgroups.stack.GossipData
 
GossipData(byte, String, Address, String, List<PhysicalAddress>) - Constructor for class org.jgroups.stack.GossipData
 
GossipData(byte, String, Address, byte[]) - Constructor for class org.jgroups.stack.GossipData
 
GossipData(byte, String, Address, byte[], int, int) - Constructor for class org.jgroups.stack.GossipData
 
GossipRouter - Class in org.jgroups.stack
Router for TCP based group comunication (using layer TCP instead of UDP).
GossipRouter() - Constructor for class org.jgroups.stack.GossipRouter
 
GossipRouter(int) - Constructor for class org.jgroups.stack.GossipRouter
 
GossipRouter(int, String) - Constructor for class org.jgroups.stack.GossipRouter
 
GossipRouter(int, String, boolean) - Constructor for class org.jgroups.stack.GossipRouter
 
GossipRouter(int, String, boolean, long) - Constructor for class org.jgroups.stack.GossipRouter
 
GossipRouter.ConnectionTearListener - Interface in org.jgroups.stack
 
grants - Variable in class org.jgroups.protocols.PEER_LOCK.PeerLock
 
GraphPanel - Class in org.jgroups.demos.wb
 
GraphPanel(Whiteboard) - Constructor for class org.jgroups.demos.wb.GraphPanel
 
GridFile - Class in org.jgroups.blocks
Subclass of File to iterate through directories and files in a grid
GridFile.Metadata - Class in org.jgroups.blocks
 
GridFile.Metadata() - Constructor for class org.jgroups.blocks.GridFile.Metadata
 
GridFile.Metadata(int, long, int, byte) - Constructor for class org.jgroups.blocks.GridFile.Metadata
 
GridFilesystem - Class in org.jgroups.blocks
Entry point for GridFile and GridInputStream / GridOutputStream
GridFilesystem(ReplCache<String, byte[]>, ReplCache<String, GridFile.Metadata>, short, int) - Constructor for class org.jgroups.blocks.GridFilesystem
Creates an instance.
GridFilesystem(ReplCache<String, byte[]>, ReplCache<String, GridFile.Metadata>) - Constructor for class org.jgroups.blocks.GridFilesystem
 
GridInputStream - Class in org.jgroups.blocks
 
GridOutputStream - Class in org.jgroups.blocks
 
group_addr - Variable in class org.jgroups.protocols.Discovery
 
groupname - Static variable in class org.jgroups.demos.wb.Whiteboard
 
GroupRequest<T> - Class in org.jgroups.blocks
Sends a message to all members of the group and waits for all responses (or timeout).
GroupRequest(Message, RequestCorrelator, Collection<Address>, RequestOptions) - Constructor for class org.jgroups.blocks.GroupRequest
 
GroupRequest(Message, RequestCorrelator, Address, RequestOptions) - Constructor for class org.jgroups.blocks.GroupRequest
 
GuardedBy - Annotation Type in org.jgroups.annotations
Copyright (c) 2005 Brian Goetz and Tim Peierls Released under the Creative Commons Attribution License (http://creativecommons.org/licenses/by/2.5) Official home: http://www.jcip.net Adopted from Java Concurrency in Practice.

H

handle(Message) - Method in class org.jgroups.blocks.MessageDispatcher
 
handle(Message) - Method in interface org.jgroups.blocks.RequestHandler
 
handle(Message) - Method in class org.jgroups.blocks.RpcDispatcher
Message contains MethodCall.
handleAckReceived(Address, long) - Method in class org.jgroups.protocols.UNICAST
Add the ACK to hashtable.sender.sent_msgs
handleAuthHeader(GMS.GmsHeader, AuthHeader, Message) - Method in class org.jgroups.protocols.AUTH
Handles a GMS header
handleAwaitRequest(String, Owner) - Method in class org.jgroups.protocols.Locking
 
handleConfig(Map<String, Object>) - Method in class org.jgroups.protocols.pbcast.STATE_SOCK
 
handleConfig(Map<String, Object>) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
handleConfigEvent(Map<String, Object>) - Method in class org.jgroups.protocols.FlowControl
 
handleConfigEvent(Map<String, Object>) - Method in class org.jgroups.protocols.UDP
 
handleConnect() - Method in class org.jgroups.protocols.Discovery
 
handleConnect() - Method in class org.jgroups.protocols.TCP
 
handleConnect() - Method in class org.jgroups.protocols.TCPGOSSIP
 
handleConnect() - Method in class org.jgroups.protocols.TP
 
handleConnect() - Method in class org.jgroups.protocols.UDP
 
handleConsumerFoundResponse(long, Address) - Method in class org.jgroups.protocols.Executing
 
handleConsumerReadyRequest(long, Address) - Method in class org.jgroups.protocols.Executing
 
handleConsumerUnreadyRequest(long, Address) - Method in class org.jgroups.protocols.Executing
 
handleCreateAwaitingRequest(String, Owner) - Method in class org.jgroups.protocols.Locking
 
handleCreateLockRequest(String, Owner) - Method in class org.jgroups.protocols.Locking
 
handleCredit(Address, long) - Method in class org.jgroups.protocols.FlowControl
 
handleCredit(Address, long) - Method in class org.jgroups.protocols.MFC
 
handleCredit(Address, long) - Method in class org.jgroups.protocols.UFC
 
handleCreditRequest(Map<Address, FlowControl.Credit>, Address, long) - Method in class org.jgroups.protocols.FlowControl
 
handleDataReceived(Address, long, short, boolean, Message, Event) - Method in class org.jgroups.protocols.UNICAST
Check whether the hashtable contains an entry e for sender (create if not).
handleDataReceived(Address, long, short, boolean, Message, Event) - Method in class org.jgroups.protocols.UNICAST2
Check whether the hashmap contains an entry e for sender (create if not).
handleDeleteAwaitingRequest(String, Owner) - Method in class org.jgroups.protocols.Locking
 
handleDeleteAwaitRequest(String, Owner) - Method in class org.jgroups.protocols.Locking
 
handleDeleteLockRequest(String) - Method in class org.jgroups.protocols.Locking
 
handleDiagnosticProbe(SocketAddress, DatagramSocket, String) - Method in class org.jgroups.stack.DiagnosticsHandler
 
handleDigestResponse(Address, Digest) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
handleDigestResponse(Address, Digest) - Method in class org.jgroups.protocols.pbcast.Merger
 
handleDigestResponse(Address, Digest) - Method in class org.jgroups.protocols.pbcast.ServerGmsImpl
 
handleDisconnect() - Method in class org.jgroups.protocols.Discovery
 
handleDisconnect() - Method in class org.jgroups.protocols.TCP
 
handleDisconnect() - Method in class org.jgroups.protocols.TCPGOSSIP
 
handleDisconnect() - Method in class org.jgroups.protocols.TP
 
handleDisconnect() - Method in class org.jgroups.protocols.UDP
 
handleDownEvent(Event) - Method in class org.jgroups.protocols.BasicTCP
 
handleDownEvent(Event) - Method in class org.jgroups.protocols.TP
 
handleDownEvent(Event) - Method in class org.jgroups.protocols.TUNNEL
 
handleDownMessage(Event, Message, Address, int) - Method in class org.jgroups.protocols.FlowControl
 
handleDownMessage(Event, Message, Address, int) - Method in class org.jgroups.protocols.MFC
 
handleDownMessage(Event, Message, Address, int) - Method in class org.jgroups.protocols.UFC
 
handleEOF(Address) - Method in class org.jgroups.protocols.pbcast.STATE
 
handleEOF(Address) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
handleException(Throwable) - Method in class org.jgroups.protocols.pbcast.STATE
 
handleException(Throwable) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
handleException(Throwable) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
handleExceptionResponse(Address, long, Throwable) - Method in class org.jgroups.protocols.Executing
 
handleFrame(STOMP.Frame) - Method in class org.jgroups.protocols.STOMP.Connection
 
handleInterruptRequest(Address, long) - Method in class org.jgroups.protocols.Executing
 
handleJoinResponse(JoinRsp) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
 
handleJoinResponse(JoinRsp) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
handleJoinResponse(JoinRsp) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
In case we get a different JOIN_RSP from a previous JOIN_REQ sent by us (as a client), we simply apply the new view if it is greater than ours
handleLeaveResponse() - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
handleLeaveResponse() - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
 
handleLockDeniedResponse(String, Owner) - Method in class org.jgroups.protocols.Locking
 
handleLockGrantedResponse(Owner, Address) - Method in class org.jgroups.protocols.Locking.ClientLock
 
handleLockGrantedResponse(String, Owner, Address) - Method in class org.jgroups.protocols.Locking
 
handleLockGrantedResponse(Owner, Address) - Method in class org.jgroups.protocols.PEER_LOCK.PeerLock
 
handleLockRequest(Locking.Request) - Method in class org.jgroups.protocols.Locking
 
handleMembershipChange(Collection<GmsImpl.Request>) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
 
handleMembershipChange(Collection<GmsImpl.Request>) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
handleMembershipChange(Collection<GmsImpl.Request>) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
 
handleMergeCancelled(MergeId) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
 
handleMergeCancelled(MergeId) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
handleMergeCancelled(MergeId) - Method in class org.jgroups.protocols.pbcast.Merger
 
handleMergeRequest(Address, MergeId, Collection<? extends Address>) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
handleMergeRequest(Address, MergeId, Collection<? extends Address>) - Method in class org.jgroups.protocols.pbcast.Merger
Get the view and digest and send back both (MergeData) in the form of a MERGE_RSP to the sender.
handleMergeRequest(Address, MergeId, Collection<? extends Address>) - Method in class org.jgroups.protocols.pbcast.ServerGmsImpl
Get the view and digest and send back both (MergeData) in the form of a MERGE_RSP to the sender.
handleMergeResponse(MergeData, MergeId) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
 
handleMergeResponse(MergeData, MergeId) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
handleMergeResponse(MergeData, MergeId) - Method in class org.jgroups.protocols.pbcast.Merger
 
handleMergeView(MergeData, MergeId) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
handleMergeView(MergeData, MergeId) - Method in class org.jgroups.protocols.pbcast.Merger
If merge_id is not equal to this.merge_id then discard.
handleMergeView(MergeData, MergeId) - Method in class org.jgroups.protocols.pbcast.ServerGmsImpl
If merge_id is not equal to this.merge_id then discard.
handleMessage(String, String) - Static method in class org.jgroups.demos.RelayDemoRpc
 
handleMessage(Message, NakAckHeader2) - Method in class org.jgroups.protocols.pbcast.NAKACK2
Finds the corresponding retransmit buffer and adds the message to it (according to seqno).
handleMessage(RELAY2.Relay2Header, Message) - Method in class org.jgroups.protocols.relay.RELAY2
Called to handle a message received by the transport
handleMulticastMessage() - Method in class org.jgroups.protocols.FlowControl
Whether the protocol handles message with dest == null || dest.isMulticastAddress()
handleMulticastMessage() - Method in class org.jgroups.protocols.MFC
 
handleMulticastMessage() - Method in class org.jgroups.protocols.UFC
 
handleNewConsumer(Executing.Owner) - Method in class org.jgroups.protocols.Executing
 
handleNewRunRequest(Executing.Owner) - Method in class org.jgroups.protocols.Executing
 
handleProbe(String...) - Method in class org.jgroups.protocols.pbcast.GMS
 
handleProbe(String...) - Method in class org.jgroups.protocols.pbcast.NAKACK
 
handleProbe(String...) - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
handleProbe(String...) - Method in class org.jgroups.protocols.TP.ProtocolAdapter
 
handleProbe(String...) - Method in interface org.jgroups.stack.DiagnosticsHandler.ProbeHandler
Handles a probe.
handleRelayMessage(RELAY2.Relay2Header, Message) - Method in class org.jgroups.protocols.relay.RELAY2
Called to handle a message received by the relayer
handleRemoveConsumer(Executing.Owner) - Method in class org.jgroups.protocols.Executing
 
handleRemoveRunRequest(Executing.Owner) - Method in class org.jgroups.protocols.Executing
 
handleRequest(Message, RequestCorrelator.Header) - Method in class org.jgroups.blocks.RequestCorrelator
Handle a request msg for this correlator
handleRequest(COUNTER.Request, Address) - Method in class org.jgroups.protocols.COUNTER
 
handleRequest(Locking.Request) - Method in class org.jgroups.protocols.Locking.ServerLock
 
handleResendingOfFirstMessage(Address, long) - Method in class org.jgroups.protocols.UNICAST
We need to resend our first message with our conn_id
handleResendingOfFirstMessage(Address, long) - Method in class org.jgroups.protocols.UNICAST2
We need to resend our first message with our conn_id
handleResponse(COUNTER.Response, Address) - Method in class org.jgroups.protocols.COUNTER
 
handleResponse(Address, short) - Method in class org.jgroups.protocols.RSVP
 
handlers - Variable in class org.jgroups.stack.DiagnosticsHandler
 
handleSignalRequest(Locking.Request) - Method in class org.jgroups.protocols.Locking
 
handleSignalResponse(String, Owner) - Method in class org.jgroups.protocols.Locking
 
handleStateChunk(Address, byte[], int, int) - Method in class org.jgroups.protocols.pbcast.STATE
 
handleStateChunk(Address, byte[], int, int) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
handleStateReq(Address) - Method in class org.jgroups.protocols.pbcast.STATE_SOCK
 
handleStateReq(Address) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
handleStateTransferEvent(Event) - Method in class org.jgroups.blocks.mux.MuxUpHandler
Extension point for subclasses called by up() when an event related to state transfer is received, allowing the subclass to override the default behavior of passing the event to the default up handler.
handleTaskRejectedResponse(Address, long) - Method in class org.jgroups.protocols.Executing
 
handleTaskRequest(long, Address) - Method in class org.jgroups.protocols.Executing
 
handleTaskSubmittedRequest(Runnable, Address, long, long) - Method in class org.jgroups.protocols.Executing
 
handleUpEvent(Event) - Method in class org.jgroups.auth.DemoToken
 
handleUpEvent(Event) - Method in class org.jgroups.blocks.MessageDispatcher
 
handleUpEvent(Event) - Method in interface org.jgroups.protocols.AUTH.UpHandler
Called when an up event has been received
handleValueResponse(Address, long, Object) - Method in class org.jgroups.protocols.Executing
 
handleView(View) - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
 
handleView(View) - Method in class org.jgroups.protocols.CENTRAL_LOCK
 
handleView(View) - Method in class org.jgroups.protocols.COUNTER
 
handleView(View) - Method in class org.jgroups.protocols.DAISYCHAIN
 
handleView(View) - Method in class org.jgroups.protocols.Executing
 
handleView(View) - Method in class org.jgroups.protocols.FILE_PING
 
handleView(View) - Method in class org.jgroups.protocols.Locking
 
handleView(List<Address>) - Method in class org.jgroups.protocols.Locking.ServerLock
 
handleView(View) - Method in class org.jgroups.protocols.PEER_LOCK
 
handleView(View) - Method in class org.jgroups.protocols.RELAY
 
handleView(View) - Method in class org.jgroups.protocols.relay.RELAY2
 
handleView(View) - Method in class org.jgroups.protocols.RSVP
 
handleView(View) - Method in class org.jgroups.protocols.rules.SUPERVISOR
 
handleView(View) - Method in class org.jgroups.protocols.STOMP
 
handleViewChange(List<Address>) - Method in class org.jgroups.protocols.FlowControl
 
handleViewChange(View) - Method in class org.jgroups.protocols.FORWARD_TO_COORD
 
handleViewChange(List<Address>) - Method in class org.jgroups.protocols.MFC
 
handleViewChange(View, Digest) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
Called by the GMS when a VIEW is received.
handleViewChange(View, Digest) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
handleViewChange(View, Digest) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
If we are leaving, we have to wait for the view change (last msg in the current view) that excludes us before we can leave.
handleViewChange(View) - Method in class org.jgroups.protocols.pbcast.STATE
 
handleViewChange(View) - Method in class org.jgroups.protocols.pbcast.STATE_SOCK
 
handleViewChange(View) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
handleViewChange(View) - Method in class org.jgroups.protocols.SEQUENCER
 
handleViewChange(List<Address>) - Method in class org.jgroups.protocols.UFC
 
handleXmitReq(Address, SeqnoList, Address) - Method in class org.jgroups.protocols.pbcast.NAKACK2
Retransmits messsages first_seqno to last_seqno from original_sender from xmit_table to xmit_requester, called when XMIT_REQ is received.
handleXmitRequest(Address, SeqnoList) - Method in class org.jgroups.protocols.UNICAST2
 
handleXmitRsp(Message, NakAckHeader2) - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
hardware_multicast_supported - Variable in class org.jgroups.blocks.MessageDispatcher
 
has_suspected_mbrs - Variable in class org.jgroups.protocols.FD_ALL
 
hasAllResponses() - Method in class org.jgroups.util.ResponseCollector
 
hasBuffer() - Method in class org.jgroups.util.StateTransferResult
 
hasCacheValues() - Static method in class org.jgroups.protocols.relay.SiteUUID
 
hasConnection(Address) - Method in class org.jgroups.blocks.AbstractConnectionMap
 
hasCoord() - Method in class org.jgroups.protocols.PingData
 
hasException() - Method in class org.jgroups.util.Rsp
 
hasException() - Method in class org.jgroups.util.StateTransferResult
 
hasExclusionList() - Method in class org.jgroups.blocks.RequestOptions
 
hasExpired(K) - Method in class org.jgroups.util.ExpiryCache
 
hasExpired(long) - Static method in class org.jgroups.util.ExpiryCache
 
hash - Variable in class org.jgroups.auth.DemoToken.DemoHeader
 
hash - Variable in class org.jgroups.auth.DemoToken.Entry
 
hash(byte[]) - Static method in class org.jgroups.auth.DemoToken
 
hash(K, List<Address>) - Method in class org.jgroups.blocks.PartitionedHashMap.ConsistentHashFunction
 
hash(K, List<Address>) - Method in interface org.jgroups.blocks.PartitionedHashMap.HashFunction
Defines a hash function to pick the right node from the list of cluster nodes.
hash(K, short) - Method in class org.jgroups.blocks.ReplCache.ConsistentHashFunction
 
hash(K, short) - Method in interface org.jgroups.blocks.ReplCache.HashFunction
Function that, given a key and a replication count, returns replication_count number of different addresses of nodes.
hashCode() - Method in class org.jgroups.AnycastAddress
 
hashCode() - Method in class org.jgroups.blocks.mux.NoMuxHandler
 
hashCode() - Method in class org.jgroups.protocols.Executing.Owner
 
hashCode() - Method in class org.jgroups.protocols.PingData
 
hashCode() - Method in class org.jgroups.protocols.relay.SiteMaster
 
hashCode() - Method in class org.jgroups.protocols.tom.MessageID
 
hashCode() - Method in class org.jgroups.stack.IpAddress
 
hashCode() - Method in class org.jgroups.util.MergeId
 
hashCode() - Method in class org.jgroups.util.Owner
 
hashCode() - Method in class org.jgroups.util.Range
 
hashCode() - Method in class org.jgroups.util.Rsp
 
hashCode() - Method in class org.jgroups.util.Seqno
 
hashCode() - Method in class org.jgroups.util.SingletonAddress
 
hashCode() - Method in class org.jgroups.util.UUID
Returns a hash code for this UUID.
hashCode() - Method in class org.jgroups.View
 
hashCode() - Method in class org.jgroups.ViewId
 
HashedTimingWheel - Class in org.jgroups.util
Implementation of TimeScheduler.
HashedTimingWheel() - Constructor for class org.jgroups.util.HashedTimingWheel
Create a scheduler that executes tasks in dynamically adjustable intervals
HashedTimingWheel(ThreadFactory, int, int, long, int, int, long) - Constructor for class org.jgroups.util.HashedTimingWheel
 
HashedTimingWheel(int) - Constructor for class org.jgroups.util.HashedTimingWheel
 
HashedTimingWheel.MyTask - Class in org.jgroups.util
Simple task wrapper, always executed by at most 1 thread.
HashedTimingWheel.MyTask(Runnable, int) - Constructor for class org.jgroups.util.HashedTimingWheel.MyTask
 
hasNext() - Method in class org.jgroups.util.Digest.MyIterator
 
hasNext() - Method in class org.jgroups.util.RingBuffer.RingBufferIterator
 
hasNext() - Method in class org.jgroups.util.RingBufferLockless.RingBufferIterator
 
hasNext() - Method in class org.jgroups.util.SeqnoList.SeqnoListIterator
 
hasOpenConnection(Address) - Method in class org.jgroups.blocks.AbstractConnectionMap
 
hasResult() - Method in class org.jgroups.util.Promise
Checks whether result is available.
hd - Variable in class org.jgroups.util.RingBuffer
The highest delivered seqno.
hd - Variable in class org.jgroups.util.RingBufferLockless
The highest delivered seqno.
hd - Variable in class org.jgroups.util.Table
The highest delivered (= removed) seqno
HDRS - Class in org.jgroups.protocols
Example of a protocol layer.
HDRS() - Constructor for class org.jgroups.protocols.HDRS
 
Header - Class in org.jgroups
Header is a JGroups internal base class for all JGroups headers.
Header() - Constructor for class org.jgroups.Header
 
header - Variable in class org.jgroups.protocols.TP
The header including the cluster name, sent with each message.
headers - Variable in class org.jgroups.Message
All headers are placed here
headers - Variable in class org.jgroups.protocols.STOMP.StompHeader
 
Headers - Class in org.jgroups.util
Open addressing based implementation of a hashmap (not supporting the Map interface though) for message headers.
Headers(int) - Constructor for class org.jgroups.util.Headers
 
Headers(Headers) - Constructor for class org.jgroups.util.Headers
 
HEARTBEAT - Static variable in class org.jgroups.protocols.FD.FdHeader
 
HEARTBEAT_ACK - Static variable in class org.jgroups.protocols.FD.FdHeader
 
height - Variable in class org.jgroups.demos.wb.Node
 
help() - Static method in class org.jgroups.demos.Chat
 
help() - Static method in class org.jgroups.demos.ExecutionServiceDemo
 
help() - Static method in class org.jgroups.demos.LockServiceDemo
 
help() - Static method in class org.jgroups.demos.PubSub
 
high - Variable in class org.jgroups.util.Range
 
highest_delivered - Variable in class org.jgroups.util.Digest.DigestEntry
 
highest_received - Variable in class org.jgroups.util.Digest.DigestEntry
 
highest_seqno - Variable in class org.jgroups.util.RetransmitTable
The highest seqno in the table
highest_seqno_purged - Variable in class org.jgroups.util.RetransmitTable
The highest seqno purged
highestDeliveredSeqnoAt(Address) - Method in class org.jgroups.util.Digest
 
highestReceivedSeqnoAt(Address) - Method in class org.jgroups.util.Digest
 
highestSequence(Digest) - Method in class org.jgroups.util.Digest
 
holder - Variable in class org.jgroups.blocks.locking.LockService.LockImpl
 
HOST_UNREACHABLE - Static variable in class org.jgroups.protocols.relay.RELAY2.Relay2Header
 
hr - Variable in class org.jgroups.util.RingBuffer
The highest received seqno.
hr - Variable in class org.jgroups.util.RingBufferLockless
The highest received seqno.
hr - Variable in class org.jgroups.util.Table
The highest received seqno
HTOTAL - Class in org.jgroups.protocols
Implementation of UTO-TCP as designed by EPFL.
HTOTAL() - Constructor for class org.jgroups.protocols.HTOTAL
 
HTOTAL.HTotalHeader - Class in org.jgroups.protocols
 
HTOTAL.HTotalHeader() - Constructor for class org.jgroups.protocols.HTOTAL.HTotalHeader
 
HTOTAL.HTotalHeader(Address, Address) - Constructor for class org.jgroups.protocols.HTOTAL.HTotalHeader
 

I

I_HAVE_SOCK - Static variable in class org.jgroups.protocols.FD_SOCK.FdHeader
 
ID - Static variable in class org.jgroups.auth.DemoToken
 
ID - Static variable in class org.jgroups.blocks.MethodCall
Use an ID to map to a method
id - Variable in class org.jgroups.blocks.RequestCorrelator.Header
The id of this request to distinguish among other requests from the same RequestCorrelator
id - Variable in class org.jgroups.blocks.RequestCorrelator
makes the instance unique (together with IDs)
id - Variable in class org.jgroups.protocols.FORWARD_TO_COORD.ForwardHeader
 
id - Variable in class org.jgroups.protocols.FragHeader
 
id - Variable in class org.jgroups.protocols.relay.config.RelayConfig.SiteConfig
 
id - Variable in class org.jgroups.protocols.RSVP.RsvpHeader
 
id - Variable in class org.jgroups.stack.Protocol
 
id - Variable in class org.jgroups.ViewId
 
ids - Variable in class org.jgroups.protocols.RSVP
Used to store IDs and their acks
IGNORE_BIND_ADDRESS_PROPERTY - Static variable in class org.jgroups.Global
 
ignore_synchronous_response - Variable in class org.jgroups.protocols.FlowControl
Whether an up thread that comes back down should be allowed to bypass blocking if all credits are exhausted.
ignore_thread - Variable in class org.jgroups.protocols.FlowControl
Thread that carries messages through up() and shouldn't be blocked in down() if ignore_synchronous_response==true.
Immutable - Annotation Type in org.jgroups.annotations
Copyright (c) 2005 Brian Goetz and Tim Peierls Released under the Creative Commons Attribution License (http://creativecommons.org/licenses/by/2.5) Official home: http://www.jcip.net Adopted from Java Concurrency in Practice.
ImmutableReference<T> - Class in org.jgroups.util
Simple class that holds an immutable reference to another object (or to null).
ImmutableReference(T) - Constructor for class org.jgroups.util.ImmutableReference
Create a new ImmutableReference.
in - Variable in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
 
in - Variable in class org.jgroups.client.StompConnection
 
in - Variable in class org.jgroups.protocols.STOMP.Connection
 
in_flight_sends - Variable in class org.jgroups.protocols.SEQUENCER
Keeps track of the threads sending messages
in_flight_sends - Variable in class org.jgroups.util.ForwardQueue
Keeps track of the threads sending messages
includeClusterName - Variable in class org.jgroups.util.DefaultThreadFactory
 
includeLocalAddress - Variable in class org.jgroups.util.DefaultThreadFactory
 
incoming_copies - Variable in class org.jgroups.protocols.DUPL
 
inconsistent_view_threshold - Variable in class org.jgroups.protocols.MERGE2
 
incrCounter() - Static method in class org.jgroups.util.Util
 
increment(long) - Method in class org.jgroups.protocols.FlowControl.Credit
 
incrementAndGet() - Method in interface org.jgroups.blocks.atomic.Counter
Atomically increments the counter and returns the new value
incrementAndGet() - Method in class org.jgroups.protocols.COUNTER.CounterImpl
 
incrementHighestDeliveredSeqno(Address) - Method in class org.jgroups.util.MutableDigest
Increments the sender's highest delivered seqno by 1
incrementInitCount() - Method in class org.jgroups.stack.ProtocolStack.RefCounter
Increments init_count, returns the old value before incr
incrementMessageDeliver() - Method in class org.jgroups.protocols.tom.StatsCollector
 
incrementRelayed() - Method in class org.jgroups.protocols.relay.RELAY2
 
incrementStartCount() - Method in class org.jgroups.stack.ProtocolStack.RefCounter
 
index(long) - Method in class org.jgroups.util.RingBuffer
 
index(long) - Method in class org.jgroups.util.RingBufferLockless
 
index - Variable in class org.jgroups.util.SeqnoList.SeqnoListIterator
 
info(String) - Method in class org.jgroups.logging.JDKLogImpl
 
info(String) - Method in interface org.jgroups.logging.Log
 
info(String) - Method in class org.jgroups.logging.Log4JLogImpl
 
info_sender - Variable in class org.jgroups.protocols.MERGE3
 
init() - Method in class org.jgroups.auth.AuthToken
 
init() - Method in class org.jgroups.auth.DemoToken
 
init() - Method in class org.jgroups.auth.RegexMembership
 
init() - Method in class org.jgroups.blocks.ConnectionTableNIO
 
init() - Method in class org.jgroups.blocks.ReplicatedHashMap
 
init() - Static method in class org.jgroups.conf.ClassConfigurator
 
init() - Method in class org.jgroups.demos.applets.DrawApplet
 
init() - Method in class org.jgroups.demos.wb.Whiteboard
 
init(ProtocolStackConfigurator) - Method in class org.jgroups.JChannel
 
init(JChannel) - Method in class org.jgroups.JChannel
 
init() - Method in class org.jgroups.JChannel
Initializes all variables.
init() - Method in class org.jgroups.protocols.AUTH
 
init() - Method in class org.jgroups.protocols.BARRIER
 
init() - Method in class org.jgroups.protocols.BasicTCP
 
init() - Method in class org.jgroups.protocols.BPING
 
init() - Method in class org.jgroups.protocols.COMPRESS
 
init() - Method in class org.jgroups.protocols.DAISYCHAIN
 
init() - Method in class org.jgroups.protocols.Discovery
 
init() - Method in class org.jgroups.protocols.ENCRYPT
 
init() - Method in class org.jgroups.protocols.FC
 
init() - Method in class org.jgroups.protocols.FD
 
init() - Method in class org.jgroups.protocols.FD_ALL
 
init() - Method in class org.jgroups.protocols.FD_ICMP
 
init() - Method in class org.jgroups.protocols.FD_SIMPLE
 
init() - Method in class org.jgroups.protocols.FD_SOCK
 
init() - Method in class org.jgroups.protocols.FILE_PING
 
init() - Method in class org.jgroups.protocols.FlowControl
 
init() - Method in class org.jgroups.protocols.FRAG
 
init() - Method in class org.jgroups.protocols.FRAG2
 
init() - Method in class org.jgroups.protocols.JDBC_PING
 
init() - Method in class org.jgroups.protocols.MERGE2
 
init() - Method in class org.jgroups.protocols.MERGE3
 
init() - Method in class org.jgroups.protocols.MFC
 
init() - Method in class org.jgroups.protocols.MPING
 
init() - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
 
init() - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
 
init() - Method in class org.jgroups.protocols.pbcast.GMS
 
init() - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
init() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
init() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
init() - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
 
init() - Method in class org.jgroups.protocols.pbcast.STABLE
 
init() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
init() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
init() - Method in class org.jgroups.protocols.PDC
 
init() - Method in class org.jgroups.protocols.RACKSPACE_PING
 
init() - Method in class org.jgroups.protocols.RATE_LIMITER
 
init() - Method in class org.jgroups.protocols.RELAY
 
init() - Method in class org.jgroups.protocols.relay.RELAY2
 
init(int) - Method in class org.jgroups.protocols.relay.Relayer
 
init() - Method in class org.jgroups.protocols.RSVP
 
init() - Method in class org.jgroups.protocols.rules.CheckFDMonitor
 
init() - Method in class org.jgroups.protocols.rules.Rule
Called when rule is installed
init() - Method in class org.jgroups.protocols.rules.SUPERVISOR
 
init() - Method in class org.jgroups.protocols.S3_PING
 
init() - Method in class org.jgroups.protocols.SCOPE
 
init() - Method in class org.jgroups.protocols.SHUFFLE
 
init() - Method in class org.jgroups.protocols.SIZE
 
init() - Method in class org.jgroups.protocols.SWIFT_PING
 
init() - Method in class org.jgroups.protocols.TCPGOSSIP
 
init() - Method in class org.jgroups.protocols.TP
 
init() - Method in class org.jgroups.protocols.TUNNEL
 
init() - Method in class org.jgroups.protocols.UFC
 
init() - Method in class org.jgroups.protocols.UNICAST2
 
init() - Method in class org.jgroups.protocols.VERIFY_SUSPECT
 
init() - Method in class org.jgroups.stack.Protocol
Called after instance has been created (null constructor) and before protocol is started.
init() - Method in class org.jgroups.stack.ProtocolStack
 
init() - Method in class org.jgroups.util.HashedTimingWheel
 
init() - Method in class org.jgroups.util.TimeScheduler2
 
INITIAL_MCAST_ADDR - Static variable in class org.jgroups.Global
 
INITIAL_MCAST_PORT - Static variable in class org.jgroups.Global
 
INITIAL_TCP_PORT - Static variable in class org.jgroups.Global
 
initial_value - Variable in class org.jgroups.protocols.COUNTER.GetOrCreateRequest
 
initialize_sql - Variable in class org.jgroups.protocols.JDBC_PING
 
initKeyPair() - Method in class org.jgroups.protocols.ENCRYPT
Generates the public/private key pair from the init params
initMetadata() - Method in class org.jgroups.blocks.GridFile
 
initProtocolStack() - Method in class org.jgroups.stack.ProtocolStack
 
initSymKey() - Static method in class org.jgroups.demos.KeyStoreGenerator
 
initSymKey() - Method in class org.jgroups.protocols.ENCRYPT
Used to initialise the symmetric key if none is supplied in a keystore.
input - Variable in class org.jgroups.stack.RouterStub
 
input_stream - Variable in class org.jgroups.protocols.pbcast.STATE
If use_default_transport is true, we consume bytes off of this blocking queue.
insert(Connection, PingData, String, String) - Method in class org.jgroups.protocols.JDBC_PING
 
insert_single_sql - Variable in class org.jgroups.protocols.JDBC_PING
 
insertProtocol(Protocol, int, String) - Method in class org.jgroups.stack.ProtocolStack
Inserts an already created (and initialized) protocol into the protocol list.
insertProtocol(Protocol, int, Class<? extends Protocol>) - Method in class org.jgroups.stack.ProtocolStack
 
insertProtocol(Protocol, int, Class<? extends Protocol>...) - Method in class org.jgroups.stack.ProtocolStack
 
insertProtocolAtTop(Protocol) - Method in class org.jgroups.stack.ProtocolStack
 
insertProtocolInStack(Protocol, Protocol, int) - Method in class org.jgroups.stack.ProtocolStack
 
INSTALL_DIGEST - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
INSTALL_MERGE_VIEW - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
INSTALL_MERGE_VIEW_OK - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
installNodes(List<Address>) - Method in class org.jgroups.blocks.ReplCache.ConsistentHashFunction
 
installNodes(List<Address>) - Method in interface org.jgroups.blocks.ReplCache.HashFunction
When the topology changes, this method will be called.
installRule(long, Rule) - Method in class org.jgroups.protocols.rules.SUPERVISOR
Installs a new rule
installRule(String, long, Rule) - Method in class org.jgroups.protocols.rules.SUPERVISOR
Installs a new rule
installRule(String, long, String) - Method in class org.jgroups.protocols.rules.SUPERVISOR
 
installRule(long, String) - Method in class org.jgroups.protocols.rules.SUPERVISOR
 
installUpHandler(UpHandler, boolean) - Method in class org.jgroups.blocks.MessageDispatcher
Sets the given UpHandler as the UpHandler for the channel, or, if the channel already has a Muxer installed as it's UpHandler, sets the given handler as the Muxer's default handler.
installView(View) - Method in class org.jgroups.protocols.pbcast.GMS
 
installView(View, Digest) - Method in class org.jgroups.protocols.pbcast.GMS
Sets the new view and sends a VIEW_CHANGE event up and down the stack.
installView(byte[], int, int) - Method in class org.jgroups.protocols.RELAY
 
INT_SIZE - Static variable in class org.jgroups.Global
 
interfaceHasIPAddresses(NetworkInterface, StackType) - Static method in class org.jgroups.util.Util
A function to check if an interface supports an IP version (i.e has addresses defined for that IP version).
interpreter - Variable in class org.jgroups.protocols.BSH
 
interrupt() - Method in class org.jgroups.protocols.tom.DeliveryThread
 
interrupt() - Method in class org.jgroups.stack.RouterStub
 
interruptAndWaitToDie(Thread) - Static method in class org.jgroups.util.Util
 
interruptAndWaitToDie(Thread, long) - Static method in class org.jgroups.util.Util
 
interrupted(Runnable) - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
 
interrupted(Runnable) - Method in interface org.jgroups.blocks.executor.ExecutorNotification
 
interrupted(int) - Method in class org.jgroups.protocols.pbcast.STATE.StateOutputStream
 
interval - Variable in class org.jgroups.protocols.FILE_PING
 
INTERVAL - Static variable in class org.jgroups.protocols.rules.SUPERVISOR
 
Interval - Interface in org.jgroups.stack
Interface which returns a time series, one value at a time calling next()
intervals - Variable in class org.jgroups.stack.Retransmitter.Task
 
intf - Variable in class org.jgroups.protocols.VERIFY_SUSPECT
network interface to be used to send the ICMP packets
invoke(Object) - Method in class org.jgroups.blocks.MethodCall
Invokes the method with the supplied arguments against the target object.
invoke(Object, Object[]) - Method in class org.jgroups.blocks.MethodCall
 
invoke(String, Object[], String[]) - Method in class org.jgroups.jmx.ResourceDMBean
 
invokeAny(Collection<? extends Callable<T>>) - Method in class org.jgroups.blocks.executor.ExecutionService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.jgroups.blocks.executor.ExecutionService
 
invokeCallback(int, Object) - Method in class org.jgroups.JChannel
 
IP_ADDR - Static variable in interface org.jgroups.Address
 
ip_mcast - Variable in class org.jgroups.protocols.UDP
 
ip_ttl - Variable in class org.jgroups.protocols.UDP
 
IpAddress - Class in org.jgroups.stack
Network-dependent address (Internet).
IpAddress() - Constructor for class org.jgroups.stack.IpAddress
 
IpAddress(String, int) - Constructor for class org.jgroups.stack.IpAddress
 
IpAddress(InetAddress, int) - Constructor for class org.jgroups.stack.IpAddress
 
IpAddress(int) - Constructor for class org.jgroups.stack.IpAddress
 
IpAddress(int, boolean) - Constructor for class org.jgroups.stack.IpAddress
 
IpAddress(InetSocketAddress) - Constructor for class org.jgroups.stack.IpAddress
 
IPv4 - Static variable in class org.jgroups.Global
 
IPV4_SIZE - Static variable in class org.jgroups.Global
 
IPv6 - Static variable in class org.jgroups.Global
 
IPV6_MCAST_PREFIX - Static variable in class org.jgroups.Global
 
IPV6_SIZE - Static variable in class org.jgroups.Global
 
is_coord - Variable in class org.jgroups.protocols.CENTRAL_EXECUTOR
 
is_coord - Variable in class org.jgroups.protocols.CENTRAL_LOCK
 
is_coord - Variable in class org.jgroups.protocols.Discovery
 
is_coord - Variable in class org.jgroups.protocols.MERGE2
 
is_coord - Variable in class org.jgroups.protocols.MERGE3
 
is_coord - Variable in class org.jgroups.protocols.RELAY
 
is_coord - Variable in class org.jgroups.protocols.relay.RELAY2
 
is_coord - Variable in class org.jgroups.protocols.SEQUENCER
 
is_leaving - Variable in class org.jgroups.protocols.Discovery
 
IS_LOG4J_AVAILABLE - Static variable in class org.jgroups.logging.LogFactory
 
IS_MERGE_IN_PROGRESS - Static variable in class org.jgroups.Event
 
is_server - Variable in class org.jgroups.protocols.Discovery
 
is_server - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
is_server - Variable in class org.jgroups.protocols.PingData
 
is_trylock - Variable in class org.jgroups.blocks.locking.LockInfo
 
is_trylock - Variable in class org.jgroups.protocols.Locking.ClientLock
 
is_trylock - Variable in class org.jgroups.protocols.Locking.Request
 
isAcceptable(Object, Address) - Method in class org.jgroups.blocks.mux.NoMuxHandlerRspFilter
 
isAcceptable(Object, Address) - Method in interface org.jgroups.blocks.RspFilter
Determines whether a response from a given sender should be added to the response list of the request
isAll() - Method in class org.jgroups.blocks.locking.AwaitInfo
 
isAuthorizationRequired() - Method in class org.jgroups.stack.DiagnosticsHandler
 
isAutomaticPurging() - Method in class org.jgroups.util.RetransmitTable
 
isBinaryCompatible(short) - Static method in class org.jgroups.Version
Checks whether ver is binary compatible with the current version.
isBinaryCompatible(short, short) - Static method in class org.jgroups.Version
 
isBindAddressPropertyIgnored() - Static method in class org.jgroups.util.Util
 
isBlockingUpdates() - Method in class org.jgroups.blocks.ReplicatedHashMap
 
isCancelled() - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
 
isCancelled() - Method in class org.jgroups.blocks.Request
 
isCancelled() - Method in class org.jgroups.util.DefaultTimeScheduler.TaskWrapper
 
isCancelled() - Method in class org.jgroups.util.HashedTimingWheel.MyTask
 
isCancelled() - Method in class org.jgroups.util.NullFuture
 
isCancelled() - Method in class org.jgroups.util.TimeScheduler2.MyTask
 
isCancelled() - Method in class org.jgroups.util.TimeScheduler3.Task
 
isChildOf(String, String) - Static method in class org.jgroups.blocks.GridFile
Verifies whether child is a child (dir or file) of parent
isClosed() - Method in class org.jgroups.Channel
Determines whether the channel is in the closed state.
isClosed() - Method in class org.jgroups.protocols.BARRIER
 
isClosed() - Method in class org.jgroups.util.BlockingInputStream
 
isConnected() - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
 
isConnected() - Method in class org.jgroups.Channel
Determines whether the channel is connected to a group.
isConnected() - Method in class org.jgroups.client.StompConnection
 
isConnected() - Method in class org.jgroups.JChannel
Deprecated. 
isConnected() - Method in class org.jgroups.stack.RouterStub
 
isConnecting() - Method in class org.jgroups.Channel
Determines whether the channel is in the connecting state; this means Channel.connect(String) has been called, but hasn't returned yet
isConnectionReaperRunning() - Method in class org.jgroups.protocols.UNICAST
 
isConnectionReaperRunning() - Method in class org.jgroups.protocols.UNICAST2
 
isCoord() - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
 
isCoord() - Method in class org.jgroups.protocols.CENTRAL_LOCK
 
isCoord() - Method in class org.jgroups.protocols.PingData
 
isCoordinator() - Method in class org.jgroups.protocols.pbcast.GMS
 
isCoordinator() - Method in class org.jgroups.protocols.SEQUENCER
 
isCoordinator(JChannel) - Static method in class org.jgroups.util.Util
 
isCoordinator(View, Address) - Static method in class org.jgroups.util.Util
 
isCopyMulticastMsgs() - Method in class org.jgroups.protocols.DUPL
 
isCopyUnicastMsgs() - Method in class org.jgroups.protocols.DUPL
 
isDebugEnabled() - Method in class org.jgroups.logging.JDKLogImpl
 
isDebugEnabled() - Method in interface org.jgroups.logging.Log
 
isDebugEnabled() - Method in class org.jgroups.logging.Log4JLogImpl
 
isDefaulThreadPoolEnabled() - Method in class org.jgroups.protocols.TP
 
isDigestNeeded() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
When FLUSH is used we do not need to pass digests between members (see JGroups/doc/design/FLUSH.txt)
isDirectory() - Method in class org.jgroups.blocks.GridFile
 
isDirectory() - Method in class org.jgroups.blocks.GridFile.Metadata
 
isDiscardAll() - Method in class org.jgroups.protocols.DISCARD
 
isDiscardDeliveredMsgs() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
isDiscardDeliveredMsgs() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
isDiscardIncompatiblePackets() - Static method in class org.jgroups.protocols.TP
 
isDiscardLoopbacks() - Method in class org.jgroups.stack.GossipRouter
 
isDone() - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
 
isDone() - Method in class org.jgroups.blocks.Request
 
isDone() - Method in class org.jgroups.util.DefaultTimeScheduler.TaskWrapper
 
isDone() - Method in class org.jgroups.util.HashedTimingWheel.MyTask
 
isDone() - Method in class org.jgroups.util.NullFuture
 
isDone() - Method in class org.jgroups.util.TimeScheduler2.MyTask
 
isDone() - Method in class org.jgroups.util.TimeScheduler3.Task
 
isDown() - Method in class org.jgroups.protocols.SHUFFLE
 
isDummy() - Method in class org.jgroups.util.Seqno
 
isDynamic() - Method in class org.jgroups.protocols.Discovery
 
isDynamic() - Method in class org.jgroups.protocols.FILE_PING
 
isDynamic() - Method in class org.jgroups.protocols.PING
 
isDynamic() - Method in class org.jgroups.protocols.TCPGOSSIP
 
isDynamic() - Method in class org.jgroups.protocols.TCPPING
 
isEmpty() - Method in class org.jgroups.protocols.Locking.ServerLock
 
isEmpty() - Method in class org.jgroups.util.RetransmitTable
 
isEmpty() - Method in class org.jgroups.util.RspList
 
isEmpty() - Method in class org.jgroups.util.Table
 
isEnableBundling() - Method in class org.jgroups.protocols.TP
 
isEnableUnicastBundling() - Method in class org.jgroups.protocols.TP
 
isErgonomics() - Method in class org.jgroups.stack.Protocol
 
isErrorEnabled() - Method in class org.jgroups.logging.JDKLogImpl
 
isErrorEnabled() - Method in interface org.jgroups.logging.Log
 
isErrorEnabled() - Method in class org.jgroups.logging.Log4JLogImpl
 
isExcluded(Relayer.Route, short...) - Static method in class org.jgroups.protocols.relay.Relayer
 
isExcludeItself() - Method in class org.jgroups.protocols.DISCARD
 
isExpired(long) - Method in interface org.jgroups.blocks.Connection
 
isExpired(long) - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
 
isFatalEnabled() - Method in class org.jgroups.logging.JDKLogImpl
 
isFatalEnabled() - Method in interface org.jgroups.logging.Log
 
isFatalEnabled() - Method in class org.jgroups.logging.Log4JLogImpl
 
isFile() - Method in class org.jgroups.blocks.GridFile
 
isFile() - Method in class org.jgroups.blocks.GridFile.Metadata
 
isFirst() - Method in class org.jgroups.protocols.UNICAST2.Unicast2Header
 
isFlag() - Static method in class org.jgroups.demos.JmxDemo
 
isFlagSet(Message.Flag) - Method in class org.jgroups.blocks.RequestOptions
 
isFlagSet(short, Message.Flag) - Static method in class org.jgroups.Message
 
isFlagSet(Message.Flag) - Method in class org.jgroups.Message
Checks if a given flag is set
isFlagSet(byte, byte) - Static method in class org.jgroups.util.Util
 
isGreaterThanOrEqual(Digest) - Method in class org.jgroups.util.Digest
Returns true if all senders of the current digest have their seqnos >= the ones from other
isInfoEnabled() - Method in class org.jgroups.logging.JDKLogImpl
 
isInfoEnabled() - Method in interface org.jgroups.logging.Log
 
isInfoEnabled() - Method in class org.jgroups.logging.Log4JLogImpl
 
isInfoSenderRunning() - Method in class org.jgroups.protocols.MERGE3
 
isL1CacheEnabled() - Method in class org.jgroups.blocks.PartitionedHashMap
 
isL1CacheEnabled() - Method in class org.jgroups.blocks.ReplCache
 
isLocal(Address) - Method in class org.jgroups.protocols.RELAY
Does the payload match the 'site' ID.
isLockInterruptibly() - Method in class org.jgroups.blocks.locking.LockInfo
 
isLogSuspectedMessages() - Method in class org.jgroups.protocols.FD_SOCK
 
isLoopback() - Method in class org.jgroups.protocols.TP
 
isMergeInProgress() - Method in class org.jgroups.protocols.pbcast.GMS
 
isMergeInProgress() - Method in class org.jgroups.protocols.pbcast.Merger
 
isMergeKillerRunning() - Method in class org.jgroups.protocols.pbcast.GMS
 
isMergeRejected() - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
isMergeRunning() - Method in class org.jgroups.protocols.Discovery
 
isMergeRunning() - Method in class org.jgroups.protocols.MERGE2
 
isMergeRunning() - Method in class org.jgroups.protocols.MERGE3
 
isMergeTaskRunning() - Method in class org.jgroups.protocols.MERGE2
 
isMergeTaskRunning() - Method in class org.jgroups.protocols.MERGE3
 
isMergeTaskRunning() - Method in class org.jgroups.protocols.pbcast.GMS
 
isMigrateData() - Method in class org.jgroups.blocks.PartitionedHashMap
 
isMigrateData() - Method in class org.jgroups.blocks.ReplCache
 
isMonitorRunning() - Method in class org.jgroups.protocols.FD
 
isMulticastCapable() - Method in class org.jgroups.protocols.TP
 
isOOBThreadPoolEnabled() - Method in class org.jgroups.protocols.TP
 
isOpen() - Method in interface org.jgroups.blocks.Connection
 
isOpen() - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
 
isOpen() - Method in class org.jgroups.Channel
Determines whether the channel is open; ie.
isOpen() - Method in class org.jgroups.JChannel
Deprecated. 
isOpenerScheduled() - Method in class org.jgroups.protocols.BARRIER
 
isPrimitiveType(Class<?>) - Static method in class org.jgroups.blocks.MethodCall
 
isReapingEnabled() - Method in class org.jgroups.blocks.Cache
 
isReceived(Address) - Method in class org.jgroups.util.RspList
 
isReceiveOnAllInterfaces() - Method in class org.jgroups.protocols.MPING
 
isReceiveOnAllInterfaces() - Method in class org.jgroups.protocols.TP
 
isRequestPresent(Locking.Type, Owner) - Method in class org.jgroups.protocols.Locking.ServerLock
Checks if a certain request from a given owner is already in the queue
isRunning() - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection.ConnectionPeerReceiver
 
isRunning() - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection.Sender
 
isRunning() - Method in class org.jgroups.protocols.FD_ALL
 
isRunning() - Method in class org.jgroups.protocols.MERGE2.FindSubgroupsTask
 
isRunning() - Method in class org.jgroups.protocols.pbcast.STATE_SOCK.StateProviderAcceptor
 
isRunning() - Method in class org.jgroups.stack.GossipRouter
 
isSame(short) - Static method in class org.jgroups.Version
Compares the specified version number against the current version number.
isSameMachine(TopologyUUID) - Method in class org.jgroups.util.TopologyUUID
 
isSameRack(TopologyUUID) - Method in class org.jgroups.util.TopologyUUID
 
isSameSite(TopologyUUID) - Method in class org.jgroups.util.TopologyUUID
 
isSenderUsed() - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
 
isSendOnAllInterfaces() - Method in class org.jgroups.protocols.MPING
 
isServer() - Method in class org.jgroups.protocols.PingData
 
isSetPropertyMethod(Method) - Static method in class org.jgroups.stack.Configurator
 
isShutdown() - Method in class org.jgroups.blocks.executor.ExecutionService
 
isShutdown() - Method in class org.jgroups.util.HashedTimingWheel
 
isShutdown() - Method in class org.jgroups.util.MockTimeScheduler
 
isShutdown() - Method in interface org.jgroups.util.TimeScheduler
Returns true if stop() has been called, false otherwise
isShutdown() - Method in class org.jgroups.util.TimeScheduler2
 
isShutdown() - Method in class org.jgroups.util.TimeScheduler3
 
isSingleton() - Method in class org.jgroups.protocols.TP
 
isStackAvailable(boolean) - Static method in class org.jgroups.util.Util
 
isStarted() - Method in class org.jgroups.stack.GossipRouter
 
isSuspected(Address) - Method in class org.jgroups.util.RspList
 
isTcpNoDelay() - Method in class org.jgroups.stack.RouterStub
 
isTerminated() - Method in class org.jgroups.blocks.executor.ExecutionService
 
isTraceEnabled() - Method in class org.jgroups.logging.JDKLogImpl
 
isTraceEnabled() - Method in interface org.jgroups.logging.Log
 
isTraceEnabled() - Method in class org.jgroups.logging.Log4JLogImpl
 
isTransientFlagSet(Message.TransientFlag) - Method in class org.jgroups.Message
 
isTrylock() - Method in class org.jgroups.blocks.locking.LockInfo
 
isUp() - Method in class org.jgroups.protocols.SHUFFLE
 
isUseMcastXmit() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
isUseMcastXmit() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
isUseTimeout() - Method in class org.jgroups.blocks.locking.LockInfo
 
isViewBundling() - Method in class org.jgroups.protocols.pbcast.GMS
 
isViewConsistencyCheckerRunning() - Method in class org.jgroups.protocols.MERGE3
 
isViewHandlerSuspended() - Method in class org.jgroups.protocols.pbcast.GMS
 
isWarnEnabled() - Method in class org.jgroups.logging.JDKLogImpl
 
isWarnEnabled() - Method in interface org.jgroups.logging.Log
 
isWarnEnabled() - Method in class org.jgroups.logging.Log4JLogImpl
 
isXmitFromRandomMember() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
isXmitFromRandomMember() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
isXmitTaskRunning() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
isXmitTaskRunning() - Method in class org.jgroups.protocols.UNICAST
 
isXmitTaskRunning() - Method in class org.jgroups.protocols.UNICAST2
 
iterator() - Method in class org.jgroups.util.Digest
 
iterator() - Method in class org.jgroups.util.RingBuffer
Returns an iterator over the elements of the ring buffer in the range [HD+1 ..
iterator() - Method in class org.jgroups.util.RingBufferLockless
Returns an iterator over the elements of the ring buffer in the range [HD+1 ..
iterator() - Method in class org.jgroups.util.RspList
 
iterator() - Method in class org.jgroups.util.SeqnoList
 
iterator() - Method in class org.jgroups.View
 

J

JAXP_MISSING_ERROR_MSG - Static variable in class org.jgroups.conf.ConfiguratorFactory
 
JChannel - Class in org.jgroups
JChannel is a default implementation of a Channel abstraction.
JChannel(boolean) - Constructor for class org.jgroups.JChannel
Creates a JChannel without a protocol stack; used for programmatic creation of channel and protocol stack
JChannel() - Constructor for class org.jgroups.JChannel
Constructs a JChannel instance with the protocol stack specified by the DEFAULT_PROTOCOL_STACK member.
JChannel(File) - Constructor for class org.jgroups.JChannel
Constructs a JChannel instance with the protocol stack configuration contained by the specified file.
JChannel(Element) - Constructor for class org.jgroups.JChannel
Constructs a JChannel instance with the protocol stack configuration contained by the specified XML element.
JChannel(URL) - Constructor for class org.jgroups.JChannel
Constructs a JChannel instance with the protocol stack configuration indicated by the specified URL.
JChannel(String) - Constructor for class org.jgroups.JChannel
Constructs a JChannel instance with the protocol stack configuration based upon the specified properties parameter.
JChannel(InputStream) - Constructor for class org.jgroups.JChannel
Creates a channel with a configuration based on an input stream.
JChannel(ProtocolStackConfigurator) - Constructor for class org.jgroups.JChannel
Constructs a JChannel with the protocol stack configuration contained by the protocol stack configurator parameter.
JChannel(Protocol...) - Constructor for class org.jgroups.JChannel
Creates a channel from an array of protocols.
JChannel(Collection<Protocol>) - Constructor for class org.jgroups.JChannel
Creates a channel from an array of protocols.
JChannel(JChannel) - Constructor for class org.jgroups.JChannel
Creates a channel with the same configuration as the channel passed to this constructor.
JDBC_PING - Class in org.jgroups.protocols
Discovery protocol using a JDBC connection to a shared database.
JDBC_PING() - Constructor for class org.jgroups.protocols.JDBC_PING
 
JDKLogImpl - Class in org.jgroups.logging
Logger that delivers messages to a JDK logger
JDKLogImpl(String) - Constructor for class org.jgroups.logging.JDKLogImpl
 
JDKLogImpl(Class) - Constructor for class org.jgroups.logging.JDKLogImpl
 
JmxConfigurator - Class in org.jgroups.jmx
 
JmxConfigurator() - Constructor for class org.jgroups.jmx.JmxConfigurator
 
JmxDemo - Class in org.jgroups.demos
Shows how annotations can be used to expose attributes and operations
JmxDemo() - Constructor for class org.jgroups.demos.JmxDemo
 
JmxDemo.MyNotification - Class in org.jgroups.demos
 
JmxDemo.MyNotification(String, Object, long) - Constructor for class org.jgroups.demos.JmxDemo.MyNotification
 
JmxDemo.MyNotification(String, Object, long, String) - Constructor for class org.jgroups.demos.JmxDemo.MyNotification
 
JmxDemo.MyNotification(String, Object, long, long) - Constructor for class org.jgroups.demos.JmxDemo.MyNotification
 
JmxDemo.MyNotification(String, Object, long, long, String) - Constructor for class org.jgroups.demos.JmxDemo.MyNotification
 
join(Address, boolean) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
 
join(Address, boolean) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
 
join(Address, boolean) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
join(Address, boolean) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
 
join(long) - Method in class org.jgroups.stack.RouterStub
 
JOIN_REQ - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
JOIN_REQ_WITH_STATE_TRANSFER - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
JOIN_RSP - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
JoinRsp - Class in org.jgroups.protocols.pbcast
Result of a JOIN request (sent by the GMS client).
JoinRsp() - Constructor for class org.jgroups.protocols.pbcast.JoinRsp
 
JoinRsp(View, Digest) - Constructor for class org.jgroups.protocols.pbcast.JoinRsp
 
JoinRsp(String) - Constructor for class org.jgroups.protocols.pbcast.JoinRsp
 
joinWithStateTransfer(Address, boolean) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
 
joinWithStateTransfer(Address, boolean) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
 
joinWithStateTransfer(Address, boolean) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
joinWithStateTransfer(Address, boolean) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
 

K

KEY_REQUEST - Static variable in class org.jgroups.protocols.ENCRYPT.EncryptHeader
 
keyPress(String) - Static method in class org.jgroups.util.Util
 
keys() - Method in class org.jgroups.util.CreditMap
 
keySet() - Method in class org.jgroups.blocks.ReplicatedHashMap
 
keySet() - Method in class org.jgroups.util.RspList
 
KEYSTORE_PASSWORD - Static variable in class org.jgroups.auth.X509Token
 
KEYSTORE_PATH - Static variable in class org.jgroups.auth.X509Token
 
KEYSTORE_TYPE - Static variable in class org.jgroups.auth.X509Token
 
KeyStoreGenerator - Class in org.jgroups.demos
Generates a keystore file that has a SecretKey in it.
KeyStoreGenerator() - Constructor for class org.jgroups.demos.KeyStoreGenerator
 

L

last_access - Variable in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
 
last_ack - Variable in class org.jgroups.protocols.FD
 
last_compaction_timestamp - Variable in class org.jgroups.util.RetransmitTable
The time when the last compaction took place.
last_compaction_timestamp - Variable in class org.jgroups.util.Table
The time when the last compaction took place.
last_conn_id - Variable in class org.jgroups.protocols.UNICAST
 
last_conn_id - Variable in class org.jgroups.protocols.UNICAST2
 
last_credit_request - Variable in class org.jgroups.protocols.FlowControl.Credit
 
last_credit_request - Variable in class org.jgroups.protocols.MFC
Last time a credit request was sent.
last_discovery_request - Variable in class org.jgroups.protocols.TP
 
last_highest - Variable in class org.jgroups.protocols.UNICAST2.ReceiverEntry
 
last_missing - Variable in class org.jgroups.util.Table.Missing
 
latch - Variable in class org.jgroups.auth.DemoToken.Entry
 
LazyRemovalCache<K,V> - Class in org.jgroups.blocks
Cache which doesn't remove elements on remove(), removeAll() or retainAll(), but only removes elements when a configurable size limit has been exceeded.
LazyRemovalCache() - Constructor for class org.jgroups.blocks.LazyRemovalCache
 
LazyRemovalCache(int, long) - Constructor for class org.jgroups.blocks.LazyRemovalCache
 
LazyRemovalCache.Printable<K,V> - Interface in org.jgroups.blocks
 
LazyThreadFactory - Class in org.jgroups.util
Lazily names threads: whenever the address or cluster name is changed, all threads are renamed
LazyThreadFactory(String, boolean, boolean) - Constructor for class org.jgroups.util.LazyThreadFactory
 
lbl - Variable in class org.jgroups.demos.wb.Node
 
leastSigBits - Variable in class org.jgroups.util.UUID
 
leave(Address) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
 
leave(Address) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
The coordinator itself wants to leave the group
leave(Address) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
leave(Address) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
Loop: determine coord.
LEAVE_REQ - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
LEAVE_RSP - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
leaving - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
leftMembers(View, View) - Static method in class org.jgroups.util.Util
Returns a list of members which left from view one to two
leftMembers(Collection<Address>, Collection<Address>) - Static method in class org.jgroups.util.Util
 
length() - Method in class org.jgroups.blocks.GridFile
 
length - Variable in class org.jgroups.Message
The number of bytes in the buffer (usually buf.length is buf not equal to null).
linger - Variable in class org.jgroups.blocks.TCPConnectionMap
 
linger - Variable in class org.jgroups.protocols.BasicTCP
 
list() - Method in class org.jgroups.blocks.GridFile
 
list(FilenameFilter) - Method in class org.jgroups.blocks.GridFile
 
LIST - Static variable in class org.jgroups.protocols.TP
 
list - Variable in class org.jgroups.util.Table.Getter
 
list - Variable in class org.jgroups.util.Table.Remover
 
listener - Variable in class org.jgroups.blocks.executor.ExecutionCompletionService
 
listener - Variable in class org.jgroups.blocks.Request
 
listeners - Variable in class org.jgroups.client.StompConnection
 
listFiles() - Method in class org.jgroups.blocks.GridFile
 
listFiles(FilenameFilter) - Method in class org.jgroups.blocks.GridFile
 
listFiles(FileFilter) - Method in class org.jgroups.blocks.GridFile
 
listObjects(String) - Method in class org.jgroups.protocols.SWIFT_PING.SwiftClient
List files in a folder
loadClass(String, Class) - Static method in class org.jgroups.util.Util
Tries to load the class from the current thread's context class loader.
loadDriver() - Method in class org.jgroups.protocols.JDBC_PING
 
local_addr - Variable in class org.jgroups.blocks.MessageDispatcher
 
local_addr - Variable in class org.jgroups.blocks.RequestCorrelator
The address of this group member
local_addr - Variable in class org.jgroups.blocks.TCPConnectionMap
 
local_addr - Variable in class org.jgroups.demos.RelayDemoRpc
 
local_addr - Variable in class org.jgroups.JChannel
 
local_addr - Variable in class org.jgroups.protocols.AUTH
 
local_addr - Variable in class org.jgroups.protocols.COUNTER
 
local_addr - Variable in class org.jgroups.protocols.DAISYCHAIN
 
local_addr - Variable in class org.jgroups.protocols.Discovery
 
local_addr - Variable in class org.jgroups.protocols.Executing
 
local_addr - Variable in class org.jgroups.protocols.FD
 
local_addr - Variable in class org.jgroups.protocols.FORWARD_TO_COORD
 
local_addr - Variable in class org.jgroups.protocols.Locking
 
local_addr - Variable in class org.jgroups.protocols.MERGE2
 
local_addr - Variable in class org.jgroups.protocols.MERGE3
 
local_addr - Variable in class org.jgroups.protocols.pbcast.GMS
 
local_addr - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
local_addr - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
local_addr - Variable in class org.jgroups.protocols.PDC
 
local_addr - Variable in class org.jgroups.protocols.RELAY
 
local_addr - Variable in class org.jgroups.protocols.relay.RELAY2
 
local_addr - Variable in class org.jgroups.protocols.RSVP
 
local_addr - Variable in class org.jgroups.protocols.rules.SUPERVISOR
 
local_addr - Variable in class org.jgroups.protocols.SCOPE
 
local_addr - Variable in class org.jgroups.protocols.SEQUENCER
 
local_addr - Variable in class org.jgroups.protocols.STOMP
 
local_addr - Variable in class org.jgroups.protocols.TP
The address (host and port) of this member.
local_addr - Variable in class org.jgroups.protocols.UNICAST
 
local_addr - Variable in class org.jgroups.protocols.UNICAST2
 
local_addr - Variable in class org.jgroups.protocols.VERIFY_SUSPECT
 
local_addr - Variable in class org.jgroups.util.ForwardQueue
 
local_deliveries - Variable in class org.jgroups.protocols.relay.RELAY2
Number of messages delivered locally, e.g.
local_delivery_time - Variable in class org.jgroups.protocols.relay.RELAY2
Total time (ms) for received messages that are delivered locally
local_view - Variable in class org.jgroups.protocols.RELAY
The view of the local cluster
LocalAddress - Annotation Type in org.jgroups.annotations
This is an assertion, checked at startup time.
location - Variable in class org.jgroups.protocols.FILE_PING
 
lock - Variable in class org.jgroups.blocks.AbstractConnectionMap
 
lock() - Method in class org.jgroups.blocks.locking.LockService.LockImpl
 
lock - Variable in class org.jgroups.blocks.Request
 
LOCK - Static variable in class org.jgroups.Event
 
lock - Variable in class org.jgroups.protocols.FD
 
lock - Variable in class org.jgroups.protocols.Locking.ClientCondition
 
lock() - Method in class org.jgroups.protocols.Locking.ClientLock
 
lock - Variable in class org.jgroups.protocols.Locking.ServerCondition
 
lock - Variable in class org.jgroups.protocols.RATE_LIMITER
 
lock - Variable in class org.jgroups.protocols.UNICAST2.ReceiverEntry
 
lock - Variable in class org.jgroups.stack.RouterStub
 
lock - Variable in class org.jgroups.util.BlockingInputStream
 
lock - Variable in class org.jgroups.util.CreditMap
 
lock - Variable in class org.jgroups.util.RingBuffer
Lock for adders to block on when the buffer is full
lock - Variable in class org.jgroups.util.RingBufferLockless
Lock for adders to block on when the buffer is full
lock - Variable in class org.jgroups.util.Table
 
LOCK_AWAIT - Static variable in class org.jgroups.Event
 
lock_interruptibly - Variable in class org.jgroups.blocks.locking.LockInfo
 
lock_listeners - Variable in class org.jgroups.protocols.Locking
 
lock_name - Variable in class org.jgroups.protocols.Locking.Request
 
lock_name - Variable in class org.jgroups.protocols.Locking.ServerLock
 
lock_prot - Variable in class org.jgroups.blocks.locking.LockService
 
lock_service - Variable in class org.jgroups.demos.LockServiceDemo
 
LOCK_SIGNAL - Static variable in class org.jgroups.Event
 
lockCreated(String) - Method in interface org.jgroups.blocks.locking.LockNotification
 
lockCreated(String) - Method in class org.jgroups.demos.LockServiceDemo
 
lockCreated(String) - Method in class org.jgroups.protocols.CENTRAL_LOCK
 
lockDeleted(String) - Method in interface org.jgroups.blocks.locking.LockNotification
 
lockDeleted(String) - Method in class org.jgroups.demos.LockServiceDemo
 
lockDeleted(String) - Method in class org.jgroups.protocols.CENTRAL_LOCK
 
lockDenied() - Method in class org.jgroups.protocols.Locking.ClientLock
 
locked(String, Owner) - Method in interface org.jgroups.blocks.locking.LockNotification
 
locked(String, Owner) - Method in class org.jgroups.demos.LockServiceDemo
 
locked(String, Owner) - Method in class org.jgroups.protocols.CENTRAL_LOCK
 
lockGranted() - Method in class org.jgroups.protocols.Locking.ClientLock
 
LockInfo - Class in org.jgroups.blocks.locking
 
LockInfo(String, boolean, boolean, boolean, long, TimeUnit) - Constructor for class org.jgroups.blocks.locking.LockInfo
 
Locking - Class in org.jgroups.protocols
Base locking protocol, handling most of the protocol communication with other instances.
Locking() - Constructor for class org.jgroups.protocols.Locking
 
Locking.ClientCondition - Class in org.jgroups.protocols
 
Locking.ClientCondition(Locking.ClientLock) - Constructor for class org.jgroups.protocols.Locking.ClientCondition
 
Locking.ClientLock - Class in org.jgroups.protocols
 
Locking.ClientLock(String) - Constructor for class org.jgroups.protocols.Locking.ClientLock
 
Locking.LockingHeader - Class in org.jgroups.protocols
 
Locking.LockingHeader() - Constructor for class org.jgroups.protocols.Locking.LockingHeader
 
Locking.Request - Class in org.jgroups.protocols
 
Locking.Request() - Constructor for class org.jgroups.protocols.Locking.Request
 
Locking.Request(Locking.Type, String, Owner, long) - Constructor for class org.jgroups.protocols.Locking.Request
 
Locking.Request(Locking.Type, String, Owner, long, boolean) - Constructor for class org.jgroups.protocols.Locking.Request
 
Locking.ServerCondition - Class in org.jgroups.protocols
 
Locking.ServerCondition(Locking.ServerLock) - Constructor for class org.jgroups.protocols.Locking.ServerCondition
 
Locking.ServerLock - Class in org.jgroups.protocols
Server side queue for handling of lock requests (lock, release).
Locking.ServerLock(String) - Constructor for class org.jgroups.protocols.Locking.ServerLock
 
Locking.ServerLock(String, Owner) - Constructor for class org.jgroups.protocols.Locking.ServerLock
 
Locking.Type - Enum in org.jgroups.protocols
 
lockInterruptibly() - Method in class org.jgroups.blocks.locking.LockService.LockImpl
 
lockInterruptibly() - Method in class org.jgroups.protocols.Locking.ClientLock
 
LockNotification - Interface in org.jgroups.blocks.locking
 
LockService - Class in org.jgroups.blocks.locking
LockService is the main class for to use for distributed locking functionality.
LockService() - Constructor for class org.jgroups.blocks.locking.LockService
 
LockService(JChannel) - Constructor for class org.jgroups.blocks.locking.LockService
 
LockService.LockImpl - Class in org.jgroups.blocks.locking
 
LockService.LockImpl(String) - Constructor for class org.jgroups.blocks.locking.LockService.LockImpl
 
LockServiceDemo - Class in org.jgroups.demos
Demos the LockService
LockServiceDemo(String, String) - Constructor for class org.jgroups.demos.LockServiceDemo
 
log - Variable in class org.jgroups.auth.AuthToken
 
log - Variable in class org.jgroups.blocks.AbstractConnectionMap
 
log - Variable in class org.jgroups.blocks.BasicConnectionTable
 
log - Variable in class org.jgroups.blocks.MessageDispatcher
 
log - Static variable in class org.jgroups.blocks.MethodCall
 
log - Variable in class org.jgroups.blocks.mux.MuxUpHandler
 
log - Variable in class org.jgroups.blocks.ReplicatedHashMap
 
log - Variable in class org.jgroups.blocks.ReplicatedTree
 
log - Static variable in class org.jgroups.blocks.Request
 
log - Static variable in class org.jgroups.blocks.RequestCorrelator
 
log - Variable in class org.jgroups.blocks.TCPConnectionMap
 
log - Variable in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
 
log - Variable in class org.jgroups.client.StompConnection
 
log - Static variable in class org.jgroups.conf.ClassConfigurator
 
log - Static variable in class org.jgroups.conf.PropertyHelper
 
log - Static variable in class org.jgroups.conf.ProtocolConfiguration
 
log - Static variable in class org.jgroups.conf.XmlConfigurator
 
log - Variable in class org.jgroups.JChannel
 
Log - Interface in org.jgroups.logging
Simple logging wrapper for log4j or JDK logging.
log - Static variable in class org.jgroups.Message
 
log - Variable in class org.jgroups.protocols.pbcast.GmsImpl
 
log - Static variable in class org.jgroups.protocols.RACKSPACE_PING
 
log - Variable in class org.jgroups.protocols.relay.Relayer
 
log - Variable in class org.jgroups.protocols.rules.Rule
 
log(Log) - Method in class org.jgroups.protocols.rules.Rule
 
log - Static variable in class org.jgroups.stack.Configurator
 
log - Variable in class org.jgroups.stack.DiagnosticsHandler
 
log - Variable in class org.jgroups.stack.GossipRouter
 
log - Static variable in class org.jgroups.stack.IpAddress
 
log - Static variable in class org.jgroups.stack.NakReceiverWindow
 
log - Variable in class org.jgroups.stack.Protocol
 
log - Static variable in class org.jgroups.stack.Retransmitter
 
log - Static variable in class org.jgroups.stack.RouterStub
 
log - Variable in class org.jgroups.stack.RouterStubManager
 
log - Static variable in class org.jgroups.util.DefaultTimeScheduler
 
log - Variable in class org.jgroups.util.ForwardQueue
 
log - Static variable in class org.jgroups.util.HashedTimingWheel
 
log - Static variable in class org.jgroups.util.PropertiesToXML
 
log - Static variable in class org.jgroups.util.Queue
 
log - Static variable in class org.jgroups.util.RetransmitTable
 
log - Variable in class org.jgroups.util.SuppressLog
 
log(SuppressLog.Level, T, long, Object...) - Method in class org.jgroups.util.SuppressLog
Logs a message from a given member if is hasn't been logged for timeout ms
log - Static variable in class org.jgroups.util.TimeScheduler2
 
log - Static variable in class org.jgroups.util.TimeScheduler3
 
Log4JLogImpl - Class in org.jgroups.logging
Logger that delivers messages to a Log4J logger
Log4JLogImpl(String) - Constructor for class org.jgroups.logging.Log4JLogImpl
 
Log4JLogImpl(Class<?>) - Constructor for class org.jgroups.logging.Log4JLogImpl
 
log_discard_msgs - Variable in class org.jgroups.protocols.pbcast.NAKACK2
If true, logs messages discarded because received from other members
log_discard_msgs - Variable in class org.jgroups.protocols.TP
Whether or not warnings about messages from different groups are logged - private flag, not for common use
log_discard_msgs_version - Variable in class org.jgroups.protocols.TP
 
log_not_found_msgs - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
log_not_found_msgs - Variable in class org.jgroups.protocols.UNICAST2
 
LogFactory - Class in org.jgroups.logging
Factory that creates Log instances.
LogFactory() - Constructor for class org.jgroups.logging.LogFactory
 
logical_addr - Variable in class org.jgroups.protocols.PDC.Mapping
 
logical_addr_cache - Variable in class org.jgroups.protocols.TP
Cache which maintains mappings between logical and physical addresses.
logical_addr_cache_expiration - Variable in class org.jgroups.protocols.TP
 
logical_addr_cache_max_size - Variable in class org.jgroups.protocols.TP
 
logical_name - Variable in class org.jgroups.protocols.MERGE3.MergeHeader
 
logical_name - Variable in class org.jgroups.protocols.PDC.Mapping
 
logical_name - Variable in class org.jgroups.protocols.PingData
 
LONG_SIZE - Static variable in class org.jgroups.Global
 
loop() - Method in class org.jgroups.demos.ExecutionServiceDemo
 
loop() - Method in class org.jgroups.demos.LockServiceDemo
 
loopback - Variable in class org.jgroups.protocols.TP
If true, messages sent to self are treated specially: unicast messages are looped back immediately, multicast messages get a local copy first and - when the real copy arrives - it will be discarded.
low - Variable in class org.jgroups.util.Range
 
low - Variable in class org.jgroups.util.RingBuffer
The lowest seqno.
low - Variable in class org.jgroups.util.RingBufferLockless
The lowest seqno.
low - Variable in class org.jgroups.util.Table
The highest seqno purged
ltime - Variable in class org.jgroups.protocols.pbcast.GMS
 

M

machine_id - Variable in class org.jgroups.util.TopologyUUID
 
MAGIC_NUMBER_FILE - Static variable in class org.jgroups.conf.ClassConfigurator
 
MAGIC_NUMBER_FILE - Static variable in class org.jgroups.Global
 
main(String[]) - Static method in class org.jgroups.blocks.ReplicatedTree
 
main(String[]) - Static method in class org.jgroups.client.StompConnection
 
main(String[]) - Static method in class org.jgroups.conf.XmlConfigurator
 
main(String[]) - Static method in class org.jgroups.demos.Chat
 
main(String[]) - Static method in class org.jgroups.demos.CounterServiceDemo
 
main(String[]) - Static method in class org.jgroups.demos.Draw
 
main(String[]) - Static method in class org.jgroups.demos.ExecutionServiceDemo
 
main(String[]) - Static method in class org.jgroups.demos.JmxDemo
 
main(String[]) - Static method in class org.jgroups.demos.KeyStoreGenerator
 
main(String[]) - Static method in class org.jgroups.demos.LockServiceDemo
 
main(String[]) - Static method in class org.jgroups.demos.MemcachedServer
 
main(String[]) - Static method in class org.jgroups.demos.PartitionedHashMapDemo
 
main(String[]) - Static method in class org.jgroups.demos.ProgrammaticChat
 
main(String[]) - Static method in class org.jgroups.demos.PubSub
 
main(String[]) - Static method in class org.jgroups.demos.QuoteClient
 
main(String[]) - Static method in class org.jgroups.demos.QuoteServer
 
main(String[]) - Static method in class org.jgroups.demos.RelayDemo
 
main(String[]) - Static method in class org.jgroups.demos.RelayDemoRpc
 
main(String[]) - Static method in class org.jgroups.demos.ReplCacheDemo
 
main(String[]) - Static method in class org.jgroups.demos.ReplicatedHashMapDemo
 
main(String[]) - Static method in class org.jgroups.demos.StompChat
 
main(String[]) - Static method in class org.jgroups.demos.StompDraw
 
main(String[]) - Static method in class org.jgroups.demos.Topology
 
main(String[]) - Static method in class org.jgroups.demos.TotalOrder
 
main(String[]) - Static method in class org.jgroups.demos.ViewDemo
 
main(String[]) - Static method in class org.jgroups.demos.wb.Whiteboard
 
main(String[]) - Static method in class org.jgroups.protocols.relay.config.RelayConfig
 
main(String[]) - Static method in class org.jgroups.stack.GossipRouter
 
main(String[]) - Static method in class org.jgroups.util.GetNetworkInterfaces
 
main(String[]) - Static method in class org.jgroups.util.PropertiesToXML
 
main(String[]) - Static method in class org.jgroups.util.ResourceManager
 
main(String[]) - Static method in class org.jgroups.util.XMLSchemaGenerator
 
main(String[]) - Static method in class org.jgroups.Version
Prints the value of the description and cvs fields to System.out.
major - Static variable in class org.jgroups.Version
 
makeReply() - Method in class org.jgroups.Message
 
ManagedAttribute - Annotation Type in org.jgroups.annotations
Indicates that a public method or a field (any visibility) in an MBean class defines an MBean attribute.
ManagedOperation - Annotation Type in org.jgroups.annotations
Indicates that a method in an MBean class defines an MBean operation.
map - Variable in class org.jgroups.blocks.ReplicatedHashMap
wrapped map instance
map - Variable in class org.jgroups.util.ExpiryCache
 
map - Variable in class org.jgroups.util.SuppressCache
 
mapper - Variable in class org.jgroups.blocks.TCPConnectionMap
 
mapToString(Map<? extends Object, ? extends Object>) - Static method in class org.jgroups.util.Util
 
markReadyToDeliver(MessageID, long) - Method in class org.jgroups.protocols.tom.DeliveryManagerImpl
marks the message as ready to deliver and set the final sequence number (to be ordered)
markSent(MessageID) - Method in class org.jgroups.protocols.tom.SenderManager
Mark the message as sent
marshalledSize() - Method in class org.jgroups.util.Headers
 
marshaller - Variable in class org.jgroups.blocks.RequestCorrelator
Possibility for an external marshaller to marshal/unmarshal responses
match(String, String, boolean) - Static method in class org.jgroups.protocols.relay.config.RelayConfig
 
match(String, String, boolean) - Static method in class org.jgroups.protocols.rules.SUPERVISOR
 
match(T, T) - Static method in class org.jgroups.util.Util
 
match(long[], long[]) - Static method in class org.jgroups.util.Util
 
match_ip_address - Variable in class org.jgroups.auth.RegexMembership
 
match_logical_name - Variable in class org.jgroups.auth.RegexMembership
 
match_string - Variable in class org.jgroups.auth.RegexMembership
 
matchCookie(byte[]) - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
 
matchMergeId(MergeId) - Method in class org.jgroups.protocols.pbcast.Merger
 
matrix - Variable in class org.jgroups.util.RetransmitTable
 
matrix - Variable in class org.jgroups.util.Table
 
max_block_time - Variable in class org.jgroups.protocols.FlowControl
Max time (in milliseconds) to block.
max_block_times - Variable in class org.jgroups.protocols.FlowControl
Defines the max number of milliseconds for a message to block before being sent, based on the length of the message.
max_bundle_size - Variable in class org.jgroups.protocols.TP
Maximum number of bytes for messages to be queued until they are sent.
max_bundle_timeout - Variable in class org.jgroups.protocols.TP
Max number of milliseconds until queued messages are sent.
max_bytes - Variable in class org.jgroups.protocols.pbcast.STABLE
Total amount of bytes from incoming messages (default = 0 = disabled).
max_bytes - Variable in class org.jgroups.protocols.RATE_LIMITER
 
max_bytes - Variable in class org.jgroups.protocols.UNICAST2
 
max_compaction_time - Variable in class org.jgroups.util.RetransmitTable
Time (in ms) after which a compaction should take place.
max_compaction_time - Variable in class org.jgroups.util.Table
Time (in nanoseconds) after which a compaction should take place.
max_credits - Variable in class org.jgroups.protocols.FlowControl
Max number of bytes to send per receiver until an ack must be received before continuing sending
max_credits - Variable in class org.jgroups.util.CreditMap
 
MAX_DATAGRAM_PACKET_SIZE - Static variable in class org.jgroups.Global
 
max_dynamic_hosts - Variable in class org.jgroups.protocols.TCPPING
 
max_forward_attempts - Variable in class org.jgroups.protocols.relay.RELAY2
 
max_interval - Variable in class org.jgroups.protocols.MERGE2
 
max_interval - Variable in class org.jgroups.protocols.MERGE3
 
MAX_LIST_PRINT_SIZE - Static variable in class org.jgroups.Global
 
MAX_LIST_PRINT_SIZE - Static variable in class org.jgroups.util.Util
The max size of an address list, e.g.
max_msg_batch_size - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
max_msg_batch_size - Variable in class org.jgroups.protocols.UNICAST
 
max_msg_batch_size - Variable in class org.jgroups.protocols.UNICAST2
 
max_participants_in_merge - Variable in class org.jgroups.protocols.MERGE3
 
max_pool - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
MAX_PORT - Static variable in class org.jgroups.util.Util
 
max_rebroadcast_timeout - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
max_results - Variable in class org.jgroups.util.Table.Remover
 
max_retransmit_time - Variable in class org.jgroups.protocols.UNICAST
 
max_retransmit_time - Variable in class org.jgroups.protocols.UNICAST2
 
max_size - Variable in class org.jgroups.protocols.SHUFFLE
 
max_stable_msgs - Variable in class org.jgroups.protocols.UNICAST2
 
max_time - Variable in class org.jgroups.protocols.SHUFFLE
 
max_tries - Variable in class org.jgroups.protocols.FD
 
maxForwardAttempts(int) - Method in class org.jgroups.protocols.relay.RELAY2
Deprecated. 
MBean - Annotation Type in org.jgroups.annotations
Optional annotation that exposes all public methods in the class hierarchy (excluding Object) as MBean operations.
mbrs - Variable in class org.jgroups.protocols.FD.FdHeader
 
mcast_addr - Variable in class org.jgroups.protocols.UDP
The multicast address (mcast address and port) this member uses
mcast_group_addr - Variable in class org.jgroups.protocols.UDP
 
mcast_port - Variable in class org.jgroups.protocols.UDP
 
mcast_receiver - Variable in class org.jgroups.protocols.UDP
Runnable to receive multicast packets
mcast_recv_buf_size - Variable in class org.jgroups.protocols.UDP
 
mcast_send_buf_size - Variable in class org.jgroups.protocols.UDP
 
mcast_sock - Variable in class org.jgroups.protocols.UDP
IP multicast socket for receiving multicast packets
mcastEntries() - Method in class org.jgroups.blocks.ReplCache
 
md5(String) - Static method in class org.jgroups.util.Util
Converts a java.lang.String in to a MD5 hashed String
MD5Token - Class in org.jgroups.auth
This is an example of using a preshared token that is encrypted using an MD5/SHA hash for authentication purposes.
MD5Token() - Constructor for class org.jgroups.auth.MD5Token
 
MD5Token(String) - Constructor for class org.jgroups.auth.MD5Token
 
MD5Token(String, String) - Constructor for class org.jgroups.auth.MD5Token
 
member - Variable in exception org.jgroups.UnreachableException
 
member - Variable in class org.jgroups.util.Digest.DigestEntry
 
members - Variable in class org.jgroups.blocks.MessageDispatcher
 
members - Variable in class org.jgroups.protocols.Discovery
 
members - Variable in class org.jgroups.protocols.FD
 
members - Variable in class org.jgroups.protocols.MERGE2
 
members - Variable in class org.jgroups.protocols.pbcast.GMS
 
members - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
members - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
members - Variable in class org.jgroups.protocols.RSVP
 
members - Variable in class org.jgroups.protocols.TP
The members of this group (updated when a member joins or leaves).
members - Variable in class org.jgroups.protocols.UNICAST
 
members - Variable in class org.jgroups.protocols.UNICAST2
 
members - Variable in class org.jgroups.util.Digest
 
members - Variable in class org.jgroups.View
A list containing all the members of the view.This list is always ordered, with the coordinator being the first member.
Membership - Class in org.jgroups
Represents a membership of a cluster group.
Membership() - Constructor for class org.jgroups.Membership
Creates a member ship object with zero members
Membership(Collection<Address>) - Constructor for class org.jgroups.Membership
Creates a Membership with a given initial members.
membership_listener - Variable in class org.jgroups.blocks.MessageDispatcher
 
MembershipListener - Interface in org.jgroups
Allows a listener to be notified when group membership changes.
MemcachedConnector - Class in org.jgroups.blocks
Class which listens on a server socket for memcached clients, reads the requests, forwards them to an instance of PartitionedHashMap and sends the response.
MemcachedConnector(InetAddress, int, PartitionedHashMap<String, byte[]>) - Constructor for class org.jgroups.blocks.MemcachedConnector
 
MemcachedConnector.Request - Class in org.jgroups.blocks
 
MemcachedConnector.Request() - Constructor for class org.jgroups.blocks.MemcachedConnector.Request
 
MemcachedConnector.Request.Type - Enum in org.jgroups.blocks
 
MemcachedServer - Class in org.jgroups.demos
Server process which listens for memcached requests and forwards them to an instance of PartitionedHashMap.
MemcachedServer() - Constructor for class org.jgroups.demos.MemcachedServer
 
MERGE - Static variable in class org.jgroups.Event
 
merge(Collection<Address>, Collection<Address>) - Method in class org.jgroups.Membership
Merges membership with the new members and removes suspects.
merge(Map<Address, View>) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
Invoked upon receiving a MERGE event from the MERGE layer.
merge(Map<Address, View>) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
merge(Map<Address, View>) - Method in class org.jgroups.protocols.pbcast.Merger
Invoked upon receiving a MERGE event from the MERGE layer.
merge(Digest) - Method in class org.jgroups.util.MutableDigest
Adds a digest to this digest.
merge(Address, long, long) - Method in class org.jgroups.util.MutableDigest
Similar to add(), but if the sender already exists, its seqnos will be modified (no new entry) as follows: this.highest_delivered_seqno=max(this.highest_delivered_seqno, highest_delivered_seqno) this.highest_received_seqno=max(this.highest_received_seqno, highest_received_seqno) If the member doesn not exist, a new entry will be added (provided there is enough space)
MERGE2 - Class in org.jgroups.protocols
Protocol to discover subgroups; e.g., existing due to a network partition (that healed).
MERGE2() - Constructor for class org.jgroups.protocols.MERGE2
 
MERGE2.FindSubgroupsTask - Class in org.jgroups.protocols
Task periodically executing (if role is coordinator).
MERGE2.FindSubgroupsTask() - Constructor for class org.jgroups.protocols.MERGE2.FindSubgroupsTask
 
MERGE3 - Class in org.jgroups.protocols
Protocol to discover subgroups; e.g., existing due to a network partition (that healed).
MERGE3() - Constructor for class org.jgroups.protocols.MERGE3
 
MERGE3.InfoSender - Class in org.jgroups.protocols
 
MERGE3.InfoSender() - Constructor for class org.jgroups.protocols.MERGE3.InfoSender
 
MERGE3.MergeHeader - Class in org.jgroups.protocols
 
MERGE3.MergeHeader() - Constructor for class org.jgroups.protocols.MERGE3.MergeHeader
 
MERGE3.MergeHeader(MERGE3.MergeHeader.Type, ViewId, View, String, Collection<PhysicalAddress>) - Constructor for class org.jgroups.protocols.MERGE3.MergeHeader
 
MERGE3.MergeHeader.Type - Enum in org.jgroups.protocols
 
MERGE3.ViewConsistencyChecker - Class in org.jgroups.protocols
 
MERGE3.ViewConsistencyChecker() - Constructor for class org.jgroups.protocols.MERGE3.ViewConsistencyChecker
 
merge_ack_collector - Variable in class org.jgroups.protocols.pbcast.GMS
 
merge_candidates - Variable in class org.jgroups.protocols.MERGE2
 
MERGE_DIGEST - Static variable in class org.jgroups.Event
 
merge_fast - Variable in class org.jgroups.protocols.MERGE2
 
merge_fast_delay - Variable in class org.jgroups.protocols.MERGE2
 
merge_id_history - Variable in class org.jgroups.protocols.pbcast.Merger
 
merge_rejected - Variable in class org.jgroups.protocols.pbcast.MergeData
 
MERGE_REQ - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
MERGE_RSP - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
MergeData - Class in org.jgroups.protocols.pbcast
Encapsulates data sent with a MERGE_RSP (handleMergeResponse()) and INSTALL_MERGE_VIEW (handleMergeView()).

Note that since MergeData is never sent across the network, it doesn't need to be Streamable.

MergeData(Address, View, Digest, boolean) - Constructor for class org.jgroups.protocols.pbcast.MergeData
 
MergeData(Address, View, Digest) - Constructor for class org.jgroups.protocols.pbcast.MergeData
 
mergeDigest(Digest) - Method in class org.jgroups.protocols.pbcast.GMS
Send down a MERGE_DIGEST event
mergeDigest(Digest) - Method in class org.jgroups.protocols.pbcast.NAKACK2
For all members of the digest, adjust the retransmit buffers in xmit_table.
MergeId - Class in org.jgroups.util
ID to uniquely identify a merge
MergeId() - Constructor for class org.jgroups.util.MergeId
 
merger - Variable in class org.jgroups.protocols.pbcast.GmsImpl
 
Merger - Class in org.jgroups.protocols.pbcast
Handles merging.
Merger(GMS) - Constructor for class org.jgroups.protocols.pbcast.Merger
 
MergeView - Class in org.jgroups
A view that is sent as a result of a cluster merge.
MergeView() - Constructor for class org.jgroups.MergeView
Used by externalization
MergeView(ViewId, List<Address>, List<View>) - Constructor for class org.jgroups.MergeView
Creates a new view
MergeView(Address, long, List<Address>, List<View>) - Constructor for class org.jgroups.MergeView
Creates a new view
Message - Class in org.jgroups
A Message encapsulates data sent to members of a group.
Message(Address) - Constructor for class org.jgroups.Message
Constructs a Message given a destination Address
Message(Address, Address, byte[]) - Constructor for class org.jgroups.Message
Constructs a Message given a destination Address, a source Address and the payload byte buffer
Message(Address, byte[]) - Constructor for class org.jgroups.Message
 
Message(Address, Address, byte[], int, int) - Constructor for class org.jgroups.Message
Constructs a message.
Message(Address, byte[], int, int) - Constructor for class org.jgroups.Message
 
Message(Address, Address, Object) - Constructor for class org.jgroups.Message
Constructs a Message given a destination Address, a source Address and the payload Object
Message(Address, Object) - Constructor for class org.jgroups.Message
 
Message() - Constructor for class org.jgroups.Message
 
Message(boolean) - Constructor for class org.jgroups.Message
 
MESSAGE - Static variable in class org.jgroups.stack.GossipRouter
 
Message.Flag - Enum in org.jgroups
 
Message.TransientFlag - Enum in org.jgroups
 
message_format - Variable in class org.jgroups.util.SuppressLog
 
MessageDialog - Class in org.jgroups.demos.wb
 
MessageDialog(Frame, String, String) - Constructor for class org.jgroups.demos.wb.MessageDialog
 
MessageDispatcher - Class in org.jgroups.blocks
Provides synchronous and asynchronous message sending with request-response correlation; i.e., matching responses with the original request.
MessageDispatcher() - Constructor for class org.jgroups.blocks.MessageDispatcher
 
MessageDispatcher(Channel, MessageListener, MembershipListener) - Constructor for class org.jgroups.blocks.MessageDispatcher
 
MessageDispatcher(Channel, MessageListener, MembershipListener, RequestHandler) - Constructor for class org.jgroups.blocks.MessageDispatcher
 
messageGapDetected(long, long, Address) - Method in interface org.jgroups.stack.NakReceiverWindow.Listener
 
MessageID - Class in org.jgroups.protocols.tom
The represents an unique identifier for the messages processed by the Total Order Anycast protocol Note: it is similar to the ViewId (address + counter)
MessageID() - Constructor for class org.jgroups.protocols.tom.MessageID
 
MessageID(Address, long) - Constructor for class org.jgroups.protocols.tom.MessageID
 
MessageID(Address) - Constructor for class org.jgroups.protocols.tom.MessageID
 
MessageListener - Interface in org.jgroups
MessageListener allows a listener to be notified when a Message or a state transfer events arrives to a node.
MESSAGES - Static variable in class org.jgroups.demos.StompChat
 
messageToByteBuffer(Message) - Static method in class org.jgroups.util.Util
 
metadata - Variable in class org.jgroups.blocks.GridFilesystem
 
method - Variable in class org.jgroups.blocks.MethodCall
The Method of the call.
METHOD - Static variable in class org.jgroups.blocks.MethodCall
Explicitly ship the method, caller has to determine method himself.
method_id - Variable in class org.jgroups.blocks.MethodCall
The ID of a method, maps to a java.lang.reflect.Method
method_lookup - Variable in class org.jgroups.blocks.RpcDispatcher
 
method_name - Variable in class org.jgroups.blocks.MethodCall
The name of the method, case sensitive.
MethodCall - Class in org.jgroups.blocks
A method call is the JGroups representation of a remote method.
MethodCall() - Constructor for class org.jgroups.blocks.MethodCall
Creates an empty method call, this is always invalid, until setName() has been called.
MethodCall(Method) - Constructor for class org.jgroups.blocks.MethodCall
 
MethodCall(Method, Object...) - Constructor for class org.jgroups.blocks.MethodCall
 
MethodCall(short, Object...) - Constructor for class org.jgroups.blocks.MethodCall
 
MethodCall(String, Object[], Class[]) - Constructor for class org.jgroups.blocks.MethodCall
 
MethodLookup - Interface in org.jgroups.blocks
 
methodNameToAttributeName(String) - Static method in class org.jgroups.util.Util
 
methods - Static variable in class org.jgroups.blocks.PartitionedHashMap
 
methods - Static variable in class org.jgroups.blocks.ReplCache
 
methods - Static variable in class org.jgroups.blocks.ReplicatedHashMap
 
MFC - Class in org.jgroups.protocols
Simple flow control protocol based on a credit system.
MFC() - Constructor for class org.jgroups.protocols.MFC
 
micro - Static variable in class org.jgroups.Version
 
min_credits - Variable in class org.jgroups.protocols.FlowControl
Computed as max_credits times min_theshold.
min_credits - Variable in class org.jgroups.util.CreditMap
 
min_interval - Variable in class org.jgroups.protocols.MERGE2
 
min_interval - Variable in class org.jgroups.protocols.MERGE3
 
min_threshold - Variable in class org.jgroups.protocols.FlowControl
If we're down to (min_threshold * max_credits) bytes for P, we send more credits to P.
minor - Static variable in class org.jgroups.Version
 
missing() - Method in class org.jgroups.util.RingBuffer
 
missing() - Method in class org.jgroups.util.RingBufferLockless
 
missing_acks - Variable in class org.jgroups.util.AckCollector
List of members from whom we haven't received an ACK yet
missing_elements - Variable in class org.jgroups.util.Table.Missing
 
missingMessageReceived(long, Address) - Method in interface org.jgroups.stack.NakReceiverWindow.Listener
 
mkdir() - Method in class org.jgroups.blocks.GridFile
 
mkdirs() - Method in class org.jgroups.blocks.GridFile
 
MockTimeScheduler - Class in org.jgroups.util
Mock implementation of TimeScheduler, used by unit tests
MockTimeScheduler() - Constructor for class org.jgroups.util.MockTimeScheduler
 
mode - Variable in class org.jgroups.blocks.MethodCall
Which mode to use.
mode - Variable in class org.jgroups.blocks.RequestOptions
The mode of a request.
modifyStateResponseHeader(StreamingStateTransfer.StateHeader) - Method in class org.jgroups.protocols.pbcast.STATE_SOCK
 
modifyStateResponseHeader(StreamingStateTransfer.StateHeader) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
monitor_future - Variable in class org.jgroups.protocols.FD
 
mostSigBits - Variable in class org.jgroups.util.UUID
 
mouseClicked(MouseEvent) - Method in class org.jgroups.demos.wb.GraphPanel
 
mouseDragged(MouseEvent) - Method in class org.jgroups.demos.applets.DrawApplet
 
mouseDragged(MouseEvent) - Method in class org.jgroups.demos.wb.GraphPanel
 
mouseEntered(MouseEvent) - Method in class org.jgroups.demos.wb.GraphPanel
 
mouseExited(MouseEvent) - Method in class org.jgroups.demos.wb.GraphPanel
 
mouseMoved(MouseEvent) - Method in class org.jgroups.demos.applets.DrawApplet
 
mouseMoved(MouseEvent) - Method in class org.jgroups.demos.wb.GraphPanel
 
mousePressed(MouseEvent) - Method in class org.jgroups.demos.wb.GraphPanel
 
mouseReleased(MouseEvent) - Method in class org.jgroups.demos.wb.GraphPanel
 
move(int) - Method in class org.jgroups.util.RetransmitTable
Moves contents of matrix num_rows down.
move(int) - Method in class org.jgroups.util.Table
Moves contents of matrix num_rows down.
moveNode(Node) - Method in class org.jgroups.demos.wb.GraphPanel
 
moveNode(Node) - Method in class org.jgroups.demos.wb.Whiteboard
 
MPING - Class in org.jgroups.protocols
Uses its own IP multicast socket to send and receive discovery requests/responses.
MPING() - Constructor for class org.jgroups.protocols.MPING
 
MPING_IP_TTL - Static variable in class org.jgroups.Global
 
MPING_MCAST_ADDR - Static variable in class org.jgroups.Global
 
MPING_MCAST_PORT - Static variable in class org.jgroups.Global
 
MSG - Static variable in class org.jgroups.Event
 
MSG - Static variable in class org.jgroups.protocols.FORWARD_TO_COORD.ForwardHeader
 
MSG - Static variable in class org.jgroups.protocols.pbcast.NakAckHeader
 
MSG - Static variable in class org.jgroups.protocols.pbcast.NakAckHeader2
 
MSG - Static variable in class org.jgroups.protocols.SCOPE.ScopeHeader
 
msg_listener - Variable in class org.jgroups.blocks.MessageDispatcher
 
msg_sender - Variable in class org.jgroups.stack.Retransmitter.Task
 
msgListToByteBuffer(List<Message>) - Static method in class org.jgroups.util.Util
Marshalls a list of messages.
msgs_forwarded - Variable in class org.jgroups.protocols.DAISYCHAIN
 
msgs_per_row - Variable in class org.jgroups.util.RetransmitTable
 
msgs_sent - Variable in class org.jgroups.protocols.DAISYCHAIN
 
MULTICAST - Static variable in class org.jgroups.protocols.TP
 
MutableDigest - Class in org.jgroups.util
A mutable version of Digest.
MutableDigest(Address[], long[], int) - Constructor for class org.jgroups.util.MutableDigest
 
MutableDigest() - Constructor for class org.jgroups.util.MutableDigest
Used for externalization
MutableDigest(int) - Constructor for class org.jgroups.util.MutableDigest
 
MutableDigest(Map<Address, long[]>) - Constructor for class org.jgroups.util.MutableDigest
 
MutableDigest(Digest) - Constructor for class org.jgroups.util.MutableDigest
 
MUX_ID - Static variable in class org.jgroups.blocks.mux.MuxRequestCorrelator
 
Muxer<T> - Interface in org.jgroups.blocks.mux
Allows registration/deregistrator of multiplexed handlers by mux id.
MuxHeader - Class in org.jgroups.blocks.mux
Header that identifies the target handler for multiplexed dispatches.
MuxHeader() - Constructor for class org.jgroups.blocks.mux.MuxHeader
 
MuxHeader(short) - Constructor for class org.jgroups.blocks.mux.MuxHeader
 
MuxMessageDispatcher - Class in org.jgroups.blocks.mux
A multiplexed message dispatcher.
MuxMessageDispatcher(short) - Constructor for class org.jgroups.blocks.mux.MuxMessageDispatcher
 
MuxMessageDispatcher(short, Channel, MessageListener, MembershipListener, RequestHandler) - Constructor for class org.jgroups.blocks.mux.MuxMessageDispatcher
 
MuxRequestCorrelator - Class in org.jgroups.blocks.mux
A request correlator that adds a mux header to incoming and outgoing messages.
MuxRequestCorrelator(short, Protocol, RequestHandler, Address) - Constructor for class org.jgroups.blocks.mux.MuxRequestCorrelator
 
MuxRpcDispatcher - Class in org.jgroups.blocks.mux
A multiplexed message dispatcher.
MuxRpcDispatcher(short) - Constructor for class org.jgroups.blocks.mux.MuxRpcDispatcher
 
MuxRpcDispatcher(short, Channel, MessageListener, MembershipListener, Object) - Constructor for class org.jgroups.blocks.mux.MuxRpcDispatcher
 
MuxRpcDispatcher(short, Channel, MessageListener, MembershipListener, Object, MethodLookup) - Constructor for class org.jgroups.blocks.mux.MuxRpcDispatcher
 
MuxUpHandler - Class in org.jgroups.blocks.mux
Allows up handler multiplexing.
MuxUpHandler() - Constructor for class org.jgroups.blocks.mux.MuxUpHandler
Creates a multiplexing up handler, with no default handler.
MuxUpHandler(UpHandler) - Constructor for class org.jgroups.blocks.mux.MuxUpHandler
Creates a multiplexing up handler using the specified default handler.
my_addr - Variable in class org.jgroups.demos.wb.GraphPanel
 
my_digest - Variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
my_digest - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
 
my_view - Variable in class org.jgroups.JChannel
 

N

NAKACK - Class in org.jgroups.protocols.pbcast
Negative AcKnowledgement layer (NAKs).
NAKACK() - Constructor for class org.jgroups.protocols.pbcast.NAKACK
 
NAKACK2 - Class in org.jgroups.protocols.pbcast
Negative AcKnowledgement layer (NAKs).
NAKACK2() - Constructor for class org.jgroups.protocols.pbcast.NAKACK2
 
NAKACK2.Counter - Class in org.jgroups.protocols.pbcast
 
NAKACK2.Counter(boolean) - Constructor for class org.jgroups.protocols.pbcast.NAKACK2.Counter
 
NAKACK2.RetransmitTask - Class in org.jgroups.protocols.pbcast
Retransmitter task which periodically (every xmit_interval ms) looks at all the retransmit tables and sends retransmit request to all members from which we have missing messages
NAKACK2.RetransmitTask() - Constructor for class org.jgroups.protocols.pbcast.NAKACK2.RetransmitTask
 
NakAckHeader - Class in org.jgroups.protocols.pbcast
 
NakAckHeader() - Constructor for class org.jgroups.protocols.pbcast.NakAckHeader
 
NakAckHeader2 - Class in org.jgroups.protocols.pbcast
 
NakAckHeader2() - Constructor for class org.jgroups.protocols.pbcast.NakAckHeader2
 
NakReceiverWindow - Class in org.jgroups.stack
Keeps track of messages according to their sequence numbers.
NakReceiverWindow(Address, Retransmitter.RetransmitCommand, long, TimeScheduler) - Constructor for class org.jgroups.stack.NakReceiverWindow
Creates a new instance with the given retransmit command
NakReceiverWindow(Address, Retransmitter.RetransmitCommand, long, TimeScheduler, boolean) - Constructor for class org.jgroups.stack.NakReceiverWindow
 
NakReceiverWindow(Address, Retransmitter.RetransmitCommand, long, TimeScheduler, boolean, int, int, double, long, boolean) - Constructor for class org.jgroups.stack.NakReceiverWindow
 
NakReceiverWindow.Listener - Interface in org.jgroups.stack
 
name - Variable in class org.jgroups.blocks.locking.AwaitInfo
 
name - Variable in class org.jgroups.blocks.locking.LockInfo
 
name - Variable in class org.jgroups.blocks.locking.LockService.LockImpl
 
name - Variable in class org.jgroups.demos.ExecutionServiceDemo
 
name - Variable in class org.jgroups.demos.JmxDemo.MyNotification
 
name - Variable in class org.jgroups.demos.LockServiceDemo
 
name - Variable in class org.jgroups.JChannel
 
name - Variable in class org.jgroups.protocols.COUNTER.CounterImpl
 
name - Variable in class org.jgroups.protocols.COUNTER.SimpleRequest
 
name - Variable in class org.jgroups.protocols.COUNTER.UpdateRequest
 
name - Variable in class org.jgroups.protocols.Locking.ClientLock
 
name - Variable in class org.jgroups.protocols.relay.config.RelayConfig.SiteConfig
 
name - Variable in class org.jgroups.protocols.relay.SiteUUID
 
name() - Method in class org.jgroups.protocols.rules.CheckFDMonitor
 
name() - Method in class org.jgroups.protocols.rules.Rule
Returns the name of the rule.
name() - Method in class org.jgroups.protocols.rules.SampleRule
 
NAME - Static variable in class org.jgroups.protocols.rules.SUPERVISOR
 
name - Variable in class org.jgroups.stack.Protocol
The name of the protocol.
names - Variable in class org.jgroups.protocols.COUNTER.ReconcileRequest
 
names - Variable in class org.jgroups.protocols.COUNTER.ReconcileResponse
 
needMoreResponses() - Method in class org.jgroups.blocks.mux.NoMuxHandlerRspFilter
 
needMoreResponses() - Method in interface org.jgroups.blocks.RspFilter
Right after calling RspFilter.isAcceptable(Object, org.jgroups.Address), this method is called to see whether we are done with the request and can unblock the caller
needToSendCreditRequest() - Method in class org.jgroups.protocols.FlowControl.Credit
 
needToSendCreditRequest() - Method in class org.jgroups.protocols.MFC
 
new_coord - Variable in class org.jgroups.protocols.SEQUENCER.Flusher
 
new_coord - Variable in class org.jgroups.util.ForwardQueue.Flusher
 
newCondition() - Method in class org.jgroups.blocks.locking.LockService.LockImpl
This condition object is only allowed to work 1 for each lock.
newCondition() - Method in class org.jgroups.protocols.Locking.ClientLock
 
newElements(List<T>, List<T>) - Static method in class org.jgroups.util.Util
 
newMembers(List<Address>, List<Address>) - Static method in class org.jgroups.util.Util
 
newTaskFor(Runnable, T) - Method in class org.jgroups.blocks.executor.ExecutionService
 
newTaskFor(Callable<T>) - Method in class org.jgroups.blocks.executor.ExecutionService
 
newThread(Runnable, String) - Method in class org.jgroups.util.DefaultThreadFactory
 
newThread(Runnable) - Method in class org.jgroups.util.DefaultThreadFactory
 
newThread(ThreadGroup, Runnable, String) - Method in class org.jgroups.util.DefaultThreadFactory
 
newThread(Runnable, String, String, String) - Method in class org.jgroups.util.DefaultThreadFactory
 
newThread(Runnable, String) - Method in class org.jgroups.util.LazyThreadFactory
 
newThread(Runnable) - Method in class org.jgroups.util.LazyThreadFactory
 
newThread(ThreadGroup, Runnable, String) - Method in class org.jgroups.util.LazyThreadFactory
 
newThread(Runnable, String) - Method in interface org.jgroups.util.ThreadFactory
 
newThread(ThreadGroup, Runnable, String) - Method in interface org.jgroups.util.ThreadFactory
Deprecated. 
next - Variable in class org.jgroups.protocols.DAISYCHAIN
 
next() - Method in class org.jgroups.stack.ExponentialInterval
 
next() - Method in interface org.jgroups.stack.Interval
 
next() - Method in class org.jgroups.stack.StaticInterval
 
next() - Method in class org.jgroups.util.Digest.MyIterator
 
next - Variable in class org.jgroups.util.HashedTimingWheel.MyTask
 
next() - Method in class org.jgroups.util.RingBuffer.RingBufferIterator
 
next() - Method in class org.jgroups.util.RingBufferLockless.RingBufferIterator
 
next() - Method in class org.jgroups.util.SeqnoList.SeqnoListIterator
 
next - Variable in class org.jgroups.util.TimeScheduler2.MyTask
 
nextAddress() - Method in interface org.jgroups.util.ResourceManager.IpAddressRep
 
nextClearBit(int) - Method in class org.jgroups.util.FixedSizeBitSet
Returns the index of the first bit that is set to false that occurs on or after the specified starting index.
nextInterval() - Method in class org.jgroups.protocols.MERGE3.InfoSender
 
nextInterval() - Method in class org.jgroups.protocols.MERGE3.ViewConsistencyChecker
 
nextInterval() - Method in class org.jgroups.stack.Retransmitter.Task
 
nextInterval() - Method in interface org.jgroups.util.TimeScheduler.Task
 
nextSetBit(int) - Method in class org.jgroups.util.FixedSizeBitSet
Returns the index of the first bit that is set to true that occurs on or after the specified starting index.
NO_FC - Static variable in class org.jgroups.Message
 
NO_RELAY - Static variable in class org.jgroups.Message
 
NO_RELIABILITY - Static variable in class org.jgroups.Message
 
no_tasks - Variable in class org.jgroups.util.TimeScheduler2
Needed to signal going from 0 tasks to non-zero (we cannot use tasks.isEmpty() here ...)
NO_TOTAL_ORDER - Static variable in class org.jgroups.Message
 
Node - Class in org.jgroups.demos.wb
 
Node() - Constructor for class org.jgroups.demos.wb.Node
 
nodeAdded(String) - Method in interface org.jgroups.blocks.ReplicatedTree.ReplicatedTreeListener
 
nodeModified(String) - Method in interface org.jgroups.blocks.ReplicatedTree.ReplicatedTreeListener
 
nodeRemoved(String) - Method in interface org.jgroups.blocks.ReplicatedTree.ReplicatedTreeListener
 
NoMuxHandler - Class in org.jgroups.blocks.mux
Returned by MuxUpHandler when a message is received with a specific MuxHeader, but no corresponding handler is registered.
NoMuxHandler(short) - Constructor for class org.jgroups.blocks.mux.NoMuxHandler
 
NoMuxHandlerRspFilter - Class in org.jgroups.blocks.mux
Response filter that reject any NoMuxHandler responses.
NoMuxHandlerRspFilter() - Constructor for class org.jgroups.blocks.mux.NoMuxHandlerRspFilter
 
NoMuxHandlerRspFilter(RspFilter) - Constructor for class org.jgroups.blocks.mux.NoMuxHandlerRspFilter
 
NON_LOOPBACK_ADDRESS - Static variable in class org.jgroups.Global
 
nonRemovedValues() - Method in class org.jgroups.blocks.LazyRemovalCache
Adds all value which have not been marked as removable to the returned set
NOT_COORD - Static variable in class org.jgroups.protocols.FORWARD_TO_COORD.ForwardHeader
 
not_empty - Variable in class org.jgroups.util.BlockingInputStream
Signalled when the buf becomes 'readable'; ie.
not_full - Variable in class org.jgroups.util.BlockingInputStream
Signalled when the buf becomes 'writeable'; ie.
NOT_READY - Static variable in class org.jgroups.protocols.tom.SenderManager
 
notifiers - Variable in class org.jgroups.protocols.Executing
 
notifyAwaited(String, Owner) - Method in class org.jgroups.protocols.Locking
 
notifyAwaiting(String, Owner) - Method in class org.jgroups.protocols.Locking
 
notifyChannelClosed(Channel) - Method in class org.jgroups.Channel
 
notifyChannelConnected(Channel) - Method in class org.jgroups.Channel
 
notifyChannelDisconnected(Channel) - Method in class org.jgroups.Channel
 
notifyConnectionClosed(Address) - Method in class org.jgroups.blocks.AbstractConnectionMap
 
notifyConnectionOpened(Address, V) - Method in class org.jgroups.blocks.AbstractConnectionMap
 
NotifyingFuture<T> - Interface in org.jgroups.util
A sub-interface of a Future, that allows for listeners to be attached so that observers can be notified when the future completes.
notifyListeners(Map<String, String>, byte[], int, int) - Method in class org.jgroups.client.StompConnection
 
notifyListeners(Map<String, String>) - Method in class org.jgroups.client.StompConnection
 
notifyLockCreated(String) - Method in class org.jgroups.protocols.Locking
 
notifyLockDeleted(String) - Method in class org.jgroups.protocols.Locking
 
notifyLocked(String, Owner) - Method in class org.jgroups.protocols.Locking
 
notifyUnlocked(String, Owner) - Method in class org.jgroups.protocols.Locking
 
now() - Method in class org.jgroups.protocols.tom.StatsCollector
 
NULL - Static variable in interface org.jgroups.Address
 
NULL_BYTE - Static variable in class org.jgroups.protocols.STOMP
 
NullFuture<T> - Class in org.jgroups.util
 
NullFuture(T) - Constructor for class org.jgroups.util.NullFuture
 
nullify - Variable in class org.jgroups.util.Table.Remover
 
num_acks - Variable in class org.jgroups.protocols.SEQUENCER
 
num_acks_received - Variable in class org.jgroups.protocols.UNICAST
 
num_acks_sent - Variable in class org.jgroups.protocols.UNICAST
 
num_backups - Variable in class org.jgroups.protocols.CENTRAL_EXECUTOR
 
num_backups - Variable in class org.jgroups.protocols.CENTRAL_LOCK
 
num_backups - Variable in class org.jgroups.protocols.COUNTER
 
num_blockings - Variable in class org.jgroups.protocols.FlowControl.Credit
 
num_blockings - Variable in class org.jgroups.protocols.RATE_LIMITER
 
num_blockings - Variable in class org.jgroups.util.CreditMap
 
num_bytes_received - Variable in class org.jgroups.protocols.TP
 
num_bytes_sent - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
num_bytes_sent - Variable in class org.jgroups.protocols.TP
 
num_bytes_sent_in_period - Variable in class org.jgroups.protocols.RATE_LIMITER
Keeps track of the number of bytes sent in the current time period
num_compactions - Variable in class org.jgroups.util.Table
 
num_credit_requests_received - Variable in class org.jgroups.protocols.FlowControl
 
num_credit_requests_sent - Variable in class org.jgroups.protocols.FlowControl
 
num_credit_responses_received - Variable in class org.jgroups.protocols.FlowControl
 
num_credit_responses_sent - Variable in class org.jgroups.protocols.FlowControl
 
num_discovery_requests - Variable in class org.jgroups.protocols.Discovery
 
num_event_handlers - Variable in class org.jgroups.protocols.rules.SUPERVISOR
 
num_frags - Variable in class org.jgroups.protocols.FragHeader
 
num_heartbeats - Variable in class org.jgroups.protocols.FD
 
num_heartbeats_received - Variable in class org.jgroups.protocols.FD_ALL
 
num_heartbeats_sent - Variable in class org.jgroups.protocols.FD_ALL
 
num_incoming_msgs_received - Variable in class org.jgroups.protocols.TP
 
num_inconsistent_views - Variable in class org.jgroups.protocols.MERGE2
 
num_initial_members - Variable in class org.jgroups.protocols.Discovery
 
num_initial_srv_members - Variable in class org.jgroups.protocols.Discovery
Deprecated. 
num_merge_events - Variable in class org.jgroups.protocols.MERGE2
 
num_merge_events - Variable in class org.jgroups.protocols.MERGE3
 
num_messages_received - Variable in class org.jgroups.protocols.pbcast.NAKACK
 
num_messages_received - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
num_messages_received - Variable in class org.jgroups.protocols.UNICAST2
 
num_messages_sent - Variable in class org.jgroups.protocols.pbcast.NAKACK
 
num_messages_sent - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
num_messages_sent - Variable in class org.jgroups.protocols.UNICAST2
 
num_moves - Variable in class org.jgroups.util.Table
 
num_msgs_received - Variable in class org.jgroups.protocols.TP
 
num_msgs_received - Variable in class org.jgroups.protocols.UNICAST
 
num_msgs_sent - Variable in class org.jgroups.protocols.TP
 
num_msgs_sent - Variable in class org.jgroups.protocols.UNICAST
 
num_oob_msgs_received - Variable in class org.jgroups.protocols.TP
 
num_prev_mbrs - Variable in class org.jgroups.protocols.pbcast.GMS
 
num_purges - Variable in class org.jgroups.util.Table
 
NUM_REBROADCAST_MSGS - Static variable in class org.jgroups.protocols.pbcast.NAKACK2
 
num_received - Variable in class org.jgroups.blocks.UnicastRequest
 
num_resizes - Variable in class org.jgroups.util.Table
 
num_results - Variable in class org.jgroups.util.Table.Remover
 
num_rows - Variable in class org.jgroups.util.RetransmitTable
 
num_rows - Variable in class org.jgroups.util.Table
 
num_stable_msgs - Variable in class org.jgroups.protocols.UNICAST2.ReceiverEntry
 
num_state_reqs - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
num_suspect_events - Variable in class org.jgroups.protocols.FD
 
num_suspect_events - Variable in class org.jgroups.protocols.FD_ALL
 
num_tries - Variable in class org.jgroups.protocols.FD
 
num_xmits - Variable in class org.jgroups.protocols.UNICAST
 
numberGenerator - Static variable in class org.jgroups.util.UUID
The random number generator used by this class to create random based UUIDs
numberOfValidResponses() - Method in class org.jgroups.util.ResponseCollector
 
numReceived() - Method in class org.jgroups.util.RspList
 
numSuspectedMembers() - Method in class org.jgroups.util.RspList
 

O

object - Variable in class org.jgroups.protocols.Executing.Request
 
objectFromBuffer(byte[], int, int) - Method in interface org.jgroups.blocks.RpcDispatcher.Marshaller
 
objectFromByteBuffer(byte[]) - Static method in class org.jgroups.util.Util
Creates an object from a byte buffer
objectFromByteBuffer(byte[], int, int) - Static method in class org.jgroups.util.Util
 
objectFromStream(DataInput) - Static method in class org.jgroups.util.Util
 
objectToBuffer(Object) - Method in interface org.jgroups.blocks.RpcDispatcher.Marshaller
Marshals the object into a byte[] buffer and returns a Buffer with a ref to the underlying byte[] buffer, offset and length.
Note that the underlying byte[] buffer must not be changed as this would change the buffer of a message which potentially can get retransmitted, and such a retransmission would then carry a ref to a changed byte[] buffer !
objectToByteBuffer(Object) - Static method in class org.jgroups.util.Util
Serializes/Streams an object into a byte buffer.
objectToStream(Object, DataOutput) - Static method in class org.jgroups.util.Util
 
offer(T) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
Drops elements if capacity has been reached.
offer(T, long, TimeUnit) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
 
offset - Variable in class org.jgroups.Message
The index into the payload (usually 0)
offset - Variable in class org.jgroups.util.RetransmitTable
The first seqno, at matrix[0][0]
offset - Variable in class org.jgroups.util.RingBuffer
 
offset - Variable in class org.jgroups.util.RingBufferLockless
 
offset - Variable in class org.jgroups.util.Table
The first seqno, at matrix[0][0]
OLD - Static variable in class org.jgroups.blocks.MethodCall
Infer the method from the arguments.
onInfo(Map<String, String>) - Method in interface org.jgroups.client.StompConnection.Listener
 
onInfo(Map<String, String>) - Method in class org.jgroups.demos.StompChat
 
onInfo(Map<String, String>) - Method in class org.jgroups.demos.StompDraw
 
onMessage(Map<String, String>, byte[], int, int) - Method in interface org.jgroups.client.StompConnection.Listener
 
onMessage(Map<String, String>, byte[], int, int) - Method in class org.jgroups.demos.StompChat
 
onMessage(Map<String, String>, byte[], int, int) - Method in class org.jgroups.demos.StompDraw
 
OOB - Static variable in class org.jgroups.Message
 
OOB - Static variable in class org.jgroups.protocols.TP
 
OOB_DELIVERED - Static variable in class org.jgroups.Message
 
oob_pool - Variable in class org.jgroups.protocols.DAISYCHAIN
 
oob_thread_factory - Variable in class org.jgroups.protocols.TP
Factory which is used by oob_thread_pool
oob_thread_pool - Variable in class org.jgroups.protocols.TP
 
oob_thread_pool_enabled - Variable in class org.jgroups.protocols.TP
 
oob_thread_pool_keep_alive_time - Variable in class org.jgroups.protocols.TP
 
oob_thread_pool_max_threads - Variable in class org.jgroups.protocols.TP
 
oob_thread_pool_min_threads - Variable in class org.jgroups.protocols.TP
 
oob_thread_pool_queue - Variable in class org.jgroups.protocols.TP
Used if oob_thread_pool is a ThreadPoolExecutor and oob_thread_pool_queue_enabled is true
oob_thread_pool_queue_enabled - Variable in class org.jgroups.protocols.TP
 
oob_thread_pool_queue_max_size - Variable in class org.jgroups.protocols.TP
 
OP_FAIL - Static variable in class org.jgroups.stack.GossipRouter
 
OPEN_BARRIER - Static variable in class org.jgroups.Event
 
openBarrier() - Method in class org.jgroups.protocols.BARRIER
 
openBarrierAndResumeStable() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
openBarrierAndResumeStable() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
options - Variable in class org.jgroups.blocks.Request
 
org.jgroups - package org.jgroups
Provides top-level public JGroups classes such as Channel, Message, etc.
org.jgroups.annotations - package org.jgroups.annotations
 
org.jgroups.auth - package org.jgroups.auth
 
org.jgroups.blocks - package org.jgroups.blocks
Provides building blocks that are layered on top of channels.
org.jgroups.blocks.atomic - package org.jgroups.blocks.atomic
 
org.jgroups.blocks.executor - package org.jgroups.blocks.executor
 
org.jgroups.blocks.locking - package org.jgroups.blocks.locking
 
org.jgroups.blocks.mux - package org.jgroups.blocks.mux
 
org.jgroups.client - package org.jgroups.client
 
org.jgroups.conf - package org.jgroups.conf
Provides ways to configure a protocol stack.
org.jgroups.demos - package org.jgroups.demos
Provides demonstrations of JGroups functionality.
org.jgroups.demos.applets - package org.jgroups.demos.applets
Provides an applet that demonstrates JGroups functionality.
org.jgroups.demos.wb - package org.jgroups.demos.wb
A distributed whiteboard applet implemented using JGroups.
org.jgroups.jmx - package org.jgroups.jmx
 
org.jgroups.logging - package org.jgroups.logging
 
org.jgroups.protocols - package org.jgroups.protocols
Provides implementations of transport protocols which are responsible for sending and receiving messages to/from the network.
org.jgroups.protocols.pbcast - package org.jgroups.protocols.pbcast
Supports probabilistic broadcasts.
org.jgroups.protocols.relay - package org.jgroups.protocols.relay
 
org.jgroups.protocols.relay.config - package org.jgroups.protocols.relay.config
 
org.jgroups.protocols.rules - package org.jgroups.protocols.rules
 
org.jgroups.protocols.tom - package org.jgroups.protocols.tom
 
org.jgroups.stack - package org.jgroups.stack
Support for managing protocol stacks.
org.jgroups.util - package org.jgroups.util
Provides useful functionality which cannot be assigned to any particular other package.
original_max_bytes - Variable in class org.jgroups.protocols.pbcast.STABLE
 
original_sender - Variable in class org.jgroups.protocols.relay.RELAY2.Relay2Header
 
original_sender - Variable in class org.jgroups.protocols.RELAY.RelayHeader
 
out - Variable in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
 
out - Variable in class org.jgroups.client.StompConnection
 
out - Variable in class org.jgroups.protocols.STOMP.Connection
 
outgoing_copies - Variable in class org.jgroups.protocols.DUPL
 
output - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateGetter
 
output - Variable in class org.jgroups.stack.RouterStub
 
OVERWRITE_DIGEST - Static variable in class org.jgroups.Event
 
overwriteDigest(Digest) - Method in class org.jgroups.protocols.pbcast.NAKACK2
Overwrites existing entries, but does NOT remove entries not found in the digest
owner - Variable in class org.jgroups.protocols.COUNTER.SimpleRequest
 
owner - Variable in class org.jgroups.protocols.COUNTER.SimpleResponse
 
owner - Variable in class org.jgroups.protocols.Locking.ClientLock
 
owner - Variable in class org.jgroups.protocols.Locking.Request
 
Owner - Class in org.jgroups.util
Represents an 'owner', which is an address and thread ID
Owner() - Constructor for class org.jgroups.util.Owner
 
Owner(Address, long) - Constructor for class org.jgroups.util.Owner
 

P

paint(Graphics) - Method in class org.jgroups.demos.applets.DrawApplet
 
paint(Graphics) - Method in class org.jgroups.demos.Topology
 
paintNode(Graphics, Node, FontMetrics) - Method in class org.jgroups.demos.wb.GraphPanel
 
parker - Variable in class org.jgroups.protocols.Locking.ClientCondition
This is okay only having 1 since a client condition is 1 per lock_name, thread id combination.
parse(InputStream) - Static method in class org.jgroups.conf.ClassConfigurator
 
parse(InputStream, Boolean) - Static method in class org.jgroups.conf.XmlConfigurator
 
parse(Element) - Static method in class org.jgroups.conf.XmlConfigurator
 
parse(InputStream, Map<String, RelayConfig.SiteConfig>) - Static method in class org.jgroups.protocols.relay.config.RelayConfig
Parses site names and their configuration (e.g.
parseBridges(RelayConfig.SiteConfig, Node) - Static method in class org.jgroups.protocols.relay.config.RelayConfig
 
parseBridgesAndForwards(RelayConfig.SiteConfig, Node) - Static method in class org.jgroups.protocols.relay.config.RelayConfig
 
parseClassData(Node) - Static method in class org.jgroups.conf.ClassConfigurator
 
parseCommaDelimitedHosts(String, int) - Static method in class org.jgroups.util.Util
Input is "daddy[8880],sindhu[8880],camille[5555].
parseCommaDelimitedHosts2(String, int) - Static method in class org.jgroups.util.Util
Input is "daddy[8880],sindhu[8880],camille[5555].
parseCommaDelimitedInts(String) - Static method in class org.jgroups.util.Util
Parses comma-delimited longs; e.g., 2000,4000,8000.
parseCommaDelimitedLongs(String) - Static method in class org.jgroups.util.Util
Parses comma-delimited longs; e.g., 2000,4000,8000.
parseCommaDelimitedStrings(String) - Static method in class org.jgroups.util.Util
e.g.
parseConfig(String) - Method in class org.jgroups.protocols.rules.SUPERVISOR
 
parseConfigurations(String) - Static method in class org.jgroups.stack.Configurator
Return a number of ProtocolConfigurations in a vector
parseForwards(RelayConfig.SiteConfig, Node) - Static method in class org.jgroups.protocols.relay.config.RelayConfig
 
parseInterfaceList(String) - Static method in class org.jgroups.util.Util
 
parseLockNames(String) - Static method in class org.jgroups.demos.LockServiceDemo
 
parsePropertiesString(Map<String, String>) - Method in class org.jgroups.conf.ProtocolConfiguration
 
parseRejectionPolicy(String) - Static method in class org.jgroups.util.Util
 
parseRule(Node) - Method in class org.jgroups.protocols.rules.SUPERVISOR
 
parseRules(InputStream) - Method in class org.jgroups.protocols.rules.SUPERVISOR
 
parseSiteConfiguration(Map<String, RelayConfig.SiteConfig>) - Method in class org.jgroups.protocols.relay.RELAY2
Parses the configuration by reading the config file.
parseSiteMasters(String) - Static method in class org.jgroups.demos.RelayDemoRpc
 
parseSites(Map<String, RelayConfig.SiteConfig>, Node) - Static method in class org.jgroups.protocols.relay.config.RelayConfig
 
parseString(DataInput) - Static method in class org.jgroups.util.Util
 
parseString(ByteBuffer) - Static method in class org.jgroups.util.Util
 
parseString(ByteBuffer, boolean) - Static method in class org.jgroups.util.Util
 
parseStringList(String, String) - Static method in class org.jgroups.util.Util
 
ParticipantGmsImpl - Class in org.jgroups.protocols.pbcast
 
ParticipantGmsImpl(GMS) - Constructor for class org.jgroups.protocols.pbcast.ParticipantGmsImpl
 
PartitionedHashMap<K,V> - Class in org.jgroups.blocks
Hashmap which distributes its keys and values across the cluster.
PartitionedHashMap(String, String) - Constructor for class org.jgroups.blocks.PartitionedHashMap
 
PartitionedHashMap.ConsistentHashFunction<K> - Class in org.jgroups.blocks
 
PartitionedHashMap.ConsistentHashFunction() - Constructor for class org.jgroups.blocks.PartitionedHashMap.ConsistentHashFunction
 
PartitionedHashMap.HashFunction<K> - Interface in org.jgroups.blocks
 
PartitionedHashMapDemo - Class in org.jgroups.demos
 
PartitionedHashMapDemo() - Constructor for class org.jgroups.demos.PartitionedHashMapDemo
 
passcode - Variable in class org.jgroups.stack.DiagnosticsHandler
 
passItDown(Event) - Method in class org.jgroups.protocols.ENCRYPT
 
passItUp(Event) - Method in class org.jgroups.protocols.ENCRYPT
 
passMessageUp(Message, boolean, boolean, boolean) - Method in class org.jgroups.protocols.TP
 
passToAllUpProtocols(Event) - Method in class org.jgroups.protocols.TP
 
password - Variable in class org.jgroups.client.StompConnection
 
password - Variable in class org.jgroups.protocols.SWIFT_PING
 
pattern - Variable in class org.jgroups.auth.RegexMembership
 
payload - Variable in class org.jgroups.auth.DemoToken.DemoHeader
 
payload - Variable in class org.jgroups.util.AdditionalDataUUID
 
payload - Variable in class org.jgroups.util.PayloadUUID
 
PayloadUUID - Class in org.jgroups.util
Subclass of UUID which adds a string as payload.
PayloadUUID() - Constructor for class org.jgroups.util.PayloadUUID
 
PayloadUUID(byte[], String) - Constructor for class org.jgroups.util.PayloadUUID
 
PDC - Class in org.jgroups.protocols
Persistent Discovery Cache.
PDC() - Constructor for class org.jgroups.protocols.PDC
 
PDC.Mapping - Class in org.jgroups.protocols
 
PDC.Mapping() - Constructor for class org.jgroups.protocols.PDC.Mapping
 
PDC.Mapping(Address, PhysicalAddress, String) - Constructor for class org.jgroups.protocols.PDC.Mapping
 
peek() - Method in class org.jgroups.util.Queue
returns the first object on the queue, without removing it.
peek(long) - Method in class org.jgroups.util.Queue
returns the first object on the queue, without removing it.
peer_addr - Variable in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
 
peer_addr_read_timeout - Variable in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
 
peer_addr_read_timeout - Variable in class org.jgroups.protocols.BasicTCP
 
PEER_LOCK - Class in org.jgroups.protocols
Implementation of a locking protocol which acquires locks by contacting all of the nodes of a cluster.
PEER_LOCK() - Constructor for class org.jgroups.protocols.PEER_LOCK
 
PEER_LOCK.PeerLock - Class in org.jgroups.protocols
Lock implementation which grants a lock when all non faulty cluster members OK it.
PEER_LOCK.PeerLock(String) - Constructor for class org.jgroups.protocols.PEER_LOCK.PeerLock
 
pending_requests - Variable in class org.jgroups.auth.DemoToken
 
pending_requests - Variable in class org.jgroups.protocols.COUNTER
 
pending_state_transfers - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
Whenever we get a state transfer request, we create an OutputStream and add the state requester's address and the OutputStream to this map.
physical_addr - Variable in class org.jgroups.protocols.PDC.Mapping
 
physical_addr_max_fetch_attempts - Variable in class org.jgroups.protocols.TP
 
physical_addrs - Variable in class org.jgroups.protocols.MERGE3.MergeHeader
 
physical_addrs - Variable in class org.jgroups.protocols.PingData
 
PhysicalAddress - Interface in org.jgroups
Represents a physical (as opposed to logical) address
pickNext(List<T>, T) - Static method in class org.jgroups.util.Util
Returns the object next to element in list
pickNext(List<T>, T, int) - Static method in class org.jgroups.util.Util
Returns the next min(N,list.size()) elements after obj
pickRandomElement(List) - Static method in class org.jgroups.util.Util
 
pickRandomElement(Object[]) - Static method in class org.jgroups.util.Util
 
pickSubset(List<Address>, double) - Static method in class org.jgroups.util.Util
Selects a random subset of members according to subset_percentage and returns them.
PING - Class in org.jgroups.protocols
The PING protocol retrieves the initial membership by mcasting a discovery request (via the multicast capable transport) to all current cluster members

The responses should allow us to determine the coordinator which we have to contact, e.g.

PING() - Constructor for class org.jgroups.protocols.PING
 
PING - Static variable in class org.jgroups.stack.GossipRouter
 
ping_dest - Variable in class org.jgroups.protocols.FD
 
ping_responses - Variable in class org.jgroups.protocols.Discovery
 
pingable_mbrs - Variable in class org.jgroups.protocols.FD
Members from which we select ping_dest.
PingData - Class in org.jgroups.protocols
Encapsulates information about a cluster node, e.g.
PingData() - Constructor for class org.jgroups.protocols.PingData
 
PingData(Address, View, boolean) - Constructor for class org.jgroups.protocols.PingData
 
PingData(Address, View, boolean, String, Collection<PhysicalAddress>) - Constructor for class org.jgroups.protocols.PingData
 
PingData(Address, View, ViewId, boolean, String, Collection<PhysicalAddress>) - Constructor for class org.jgroups.protocols.PingData
 
PingHeader - Class in org.jgroups.protocols
 
PingHeader() - Constructor for class org.jgroups.protocols.PingHeader
 
PingHeader(byte, String) - Constructor for class org.jgroups.protocols.PingHeader
 
PingHeader(byte, PingData) - Constructor for class org.jgroups.protocols.PingHeader
 
PingHeader(byte, PingData, String) - Constructor for class org.jgroups.protocols.PingHeader
 
PlainConfigurator - Class in org.jgroups.conf
A ProtocolStackConfigurator for the old style properties.
PlainConfigurator(String) - Constructor for class org.jgroups.conf.PlainConfigurator
Instantiates a PlainConfigurator with old style properties
poll() - Method in class org.jgroups.blocks.executor.ExecutionCompletionService
poll(long, TimeUnit) - Method in class org.jgroups.blocks.executor.ExecutionCompletionService
poll() - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
 
poll(long, TimeUnit) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
 
pool - Variable in class org.jgroups.protocols.pbcast.STATE_SOCK.StateProviderAcceptor
 
pool - Variable in class org.jgroups.util.TimeScheduler3
Thread pool used to execute the tasks
pool_thread_keep_alive - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
port - Variable in class org.jgroups.protocols.STOMP
 
PORT - Static variable in class org.jgroups.stack.GossipRouter
 
port_range - Variable in class org.jgroups.protocols.BPING
 
port_range - Variable in class org.jgroups.protocols.TP
 
pre_signed_delete_url - Variable in class org.jgroups.protocols.S3_PING
 
pre_signed_put_url - Variable in class org.jgroups.protocols.S3_PING
 
PREFIX - Static variable in class org.jgroups.Global
 
prefix - Variable in class org.jgroups.protocols.S3_PING
 
prepareResponse(Message) - Method in class org.jgroups.blocks.mux.MuxRequestCorrelator
 
prepareResponse(Message) - Method in class org.jgroups.blocks.RequestCorrelator
 
preregistered_probe_handlers - Variable in class org.jgroups.protocols.TP
 
PRESENT - Static variable in class org.jgroups.protocols.Executing
This is a placeholder for a key value to make a concurrent hash map a concurrent hash set
present_global_views - Variable in class org.jgroups.protocols.RELAY
 
print(K, V) - Method in interface org.jgroups.blocks.LazyRemovalCache.Printable
 
print(String) - Method in class org.jgroups.blocks.ReplicatedTree
Prints a representation of the node defined by fqn.
print(List<PingData>) - Static method in class org.jgroups.protocols.pbcast.ClientGmsImpl
 
print() - Method in class org.jgroups.util.Seqno
 
print() - Method in class org.jgroups.util.SeqnoRange
 
print(Throwable) - Static method in class org.jgroups.util.Util
 
print(Collection<T>) - Static method in class org.jgroups.util.Util
 
print(Map<T, T>) - Static method in class org.jgroups.util.Util
 
print(List<NetworkInterface>) - Static method in class org.jgroups.util.Util
 
print(short) - Static method in class org.jgroups.Version
Method copied from http://www.jboss.com/index.html?module=bb&op=viewtopic&t=77231
print_function - Static variable in class org.jgroups.protocols.TP
 
print_function - Static variable in class org.jgroups.util.UUID
 
print_stability_history_on_failed_xmit - Variable in class org.jgroups.protocols.pbcast.NAKACK
When not finding a message on an XMIT request, include the last N stability messages in the error message
print_stability_history_on_failed_xmit - Variable in class org.jgroups.protocols.pbcast.NAKACK2
When not finding a message on an XMIT request, include the last N stability messages in the error message
PRINT_UUIDS - Static variable in class org.jgroups.Global
 
print_uuids - Static variable in class org.jgroups.util.UUID
 
printAgeOutCache() - Method in class org.jgroups.protocols.UNICAST
 
printAgeOutCache() - Method in class org.jgroups.protocols.UNICAST2
 
printAllStocks() - Method in class org.jgroups.demos.QuoteClient
 
printAllStocks() - Method in class org.jgroups.demos.QuoteServer
 
printBits(boolean) - Method in class org.jgroups.util.SeqnoRange
 
printBytes(long) - Static method in class org.jgroups.util.Util
MByte nowadays doesn't mean 1024 * 1024 bytes, but 1 million bytes, see http://en.wikipedia.org/wiki/Megabyte
printBytes(double) - Static method in class org.jgroups.util.Util
 
printCache() - Method in class org.jgroups.blocks.LazyRemovalCache
 
printCache(LazyRemovalCache.Printable) - Method in class org.jgroups.blocks.LazyRemovalCache
 
printCache() - Method in class org.jgroups.protocols.FD_SOCK
 
printCache() - Method in class org.jgroups.protocols.PDC
 
printCache() - Static method in class org.jgroups.util.UUID
 
printClassMap() - Static method in class org.jgroups.conf.ClassConfigurator
 
printConfigurations(Collection<ProtocolConfiguration>) - Static method in class org.jgroups.stack.Configurator
 
printConnections() - Method in class org.jgroups.blocks.AbstractConnectionMap
 
printConnections() - Method in class org.jgroups.blocks.TCPConnectionMap
 
printConnections() - Method in class org.jgroups.protocols.BasicTCP
 
printConnections() - Method in class org.jgroups.protocols.TCP
 
printConnections() - Method in class org.jgroups.protocols.TCP_NIO
 
printConnections() - Method in class org.jgroups.protocols.UNICAST
 
printConnections() - Method in class org.jgroups.protocols.UNICAST2
 
printCounters() - Method in class org.jgroups.blocks.atomic.CounterService
 
printCounters() - Method in class org.jgroups.protocols.COUNTER
 
printCreditors() - Method in class org.jgroups.protocols.FC
 
printCredits() - Method in class org.jgroups.protocols.FC
 
printCredits() - Method in class org.jgroups.protocols.FlowControl
 
printCredits() - Method in class org.jgroups.protocols.MFC
 
printCredits() - Method in class org.jgroups.protocols.UFC
 
printDescription() - Static method in class org.jgroups.Version
Returns the catenation of the description and cvs fields.
printDetails() - Method in class org.jgroups.util.TopologyUUID
 
printDigestHistory() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
printDigestHistory() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
printEvent(Event) - Static method in class org.jgroups.util.Util
 
printEvents(List<Integer>) - Static method in class org.jgroups.stack.Configurator
 
printFragments(byte[][]) - Static method in class org.jgroups.util.Util
 
printHeaders() - Method in class org.jgroups.Message
 
printHeaders() - Method in class org.jgroups.util.Headers
 
printHighestDeliveredSeqnos() - Method in class org.jgroups.util.Digest
 
printListWithDelimiter(Collection<T>, String) - Static method in class org.jgroups.util.Util
 
printListWithDelimiter(Collection<T>, String, int) - Static method in class org.jgroups.util.Util
 
printLocks() - Method in class org.jgroups.blocks.locking.LockService
 
printLocks() - Method in class org.jgroups.demos.LockServiceDemo
 
printLocks() - Method in class org.jgroups.protocols.Locking
 
printLogicalAddressCache() - Method in class org.jgroups.protocols.TP
 
printLossRate() - Method in class org.jgroups.stack.NakReceiverWindow
 
printLossRates() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
printMagicMap() - Static method in class org.jgroups.conf.ClassConfigurator
 
printMap(Map<Address, FlowControl.Credit>) - Static method in class org.jgroups.protocols.FlowControl
 
printMapWithDelimiter(Map<T, T>, String) - Static method in class org.jgroups.util.Util
 
printMergeIdHistory() - Method in class org.jgroups.protocols.pbcast.GMS
 
printMessage(Message) - Static method in class org.jgroups.util.Util
Tries to read an object from the message's buffer and prints it
printMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
printMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
printMessages() - Method in class org.jgroups.stack.NakReceiverWindow
Prints xmit_table.
printMissing() - Method in class org.jgroups.util.AckCollector
 
printObjectHeaders() - Method in class org.jgroups.Message
 
printObjectHeaders() - Method in class org.jgroups.util.Headers
 
printPingData(List<PingData>) - Static method in class org.jgroups.util.Util
 
printPreviousMembers() - Method in class org.jgroups.protocols.pbcast.GMS
 
printPreviousViews() - Method in class org.jgroups.protocols.pbcast.GMS
 
printProtocols(Protocol[]) - Static method in class org.jgroups.protocols.relay.config.RelayConfig.ProgrammaticBridgeConfig
 
printProtocolSpec(boolean) - Method in class org.jgroups.JChannel
Returns a pretty-printed form of all the protocols.
printProtocolSpec(boolean) - Method in class org.jgroups.stack.ProtocolStack
Prints the names of the protocols, from the bottom to top.
printProtocolSpecAsPlainString() - Method in class org.jgroups.stack.ProtocolStack
 
printProtocolSpecAsXML() - Method in class org.jgroups.stack.ProtocolStack
 
printReceiverCredits() - Method in class org.jgroups.protocols.FC
 
printReceiverCredits() - Method in class org.jgroups.protocols.FlowControl
 
printReceiveWindowMessages() - Method in class org.jgroups.protocols.UNICAST
 
printReceiveWindowMessages() - Method in class org.jgroups.protocols.UNICAST2
 
printRetransmitStats() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
printRetransmitStats() - Method in class org.jgroups.stack.NakReceiverWindow
 
printRetransmitTableSizes() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
printRoutes() - Method in class org.jgroups.protocols.relay.RELAY2
 
printRoutes() - Method in class org.jgroups.protocols.relay.Relayer
 
printSenderCredits() - Method in class org.jgroups.protocols.FC
 
printSenderCredits() - Method in class org.jgroups.protocols.FlowControl
 
printSenderCredits() - Method in class org.jgroups.protocols.MFC
 
printSenderCredits() - Method in class org.jgroups.protocols.UFC
 
printSendWindowMessages() - Method in class org.jgroups.protocols.UNICAST
 
printSendWindowMessages() - Method in class org.jgroups.protocols.UNICAST2
 
printStabilityHistory() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
printStabilityHistory() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
printStabilityMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
printStabilityMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
printStackTrace(Throwable) - Static method in class org.jgroups.util.Util
Use with caution: lots of overhead
printStats() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
printStats() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
printStats() - Method in class org.jgroups.protocols.SEQUENCER
 
printStats() - Method in class org.jgroups.protocols.STATS
 
printStats() - Method in class org.jgroups.stack.Protocol
 
printStats() - Method in class org.jgroups.stack.RangeBasedRetransmitter
 
printSuspected() - Method in class org.jgroups.util.AckCollector
 
printSuspectHistory() - Method in class org.jgroups.protocols.FD
 
printSuspectHistory() - Method in class org.jgroups.protocols.FD_ALL
 
printSuspectHistory() - Method in class org.jgroups.protocols.FD_SOCK
 
printThreads() - Static method in class org.jgroups.util.Util
 
printTime(long, TimeUnit) - Static method in class org.jgroups.util.Util
 
printTimestamps() - Method in class org.jgroups.protocols.FD_ALL
 
printType() - Method in class org.jgroups.protocols.SEQUENCER.SequencerHeader
 
printValues - Variable in class org.jgroups.demos.ExecutionServiceDemo
 
printVersion() - Static method in class org.jgroups.Version
Returns the version field as a String.
printViewId() - Method in class org.jgroups.protocols.PingData
 
printViews(Collection<View>) - Static method in class org.jgroups.util.Util
 
printWhoHasCache() - Method in class org.jgroups.protocols.TP
 
PRIO - Class in org.jgroups.protocols
This protocol will provide message sending and receiving prioritization.
PRIO() - Constructor for class org.jgroups.protocols.PRIO
 
PrioHeader - Class in org.jgroups.protocols
This Header class is used in conjunction with the PRIO protocol to prioritize message sending/receiving Priority values are from 0 to 255 where 0 is the highest priority Example of setting a message priority: // Create a message to send to everyone Message message = new Message( null, null, messagePayload ); // Add the priority protocol header PrioHeader header = new PrioHeader( 1 ); short protocolId = ClassConfigurator.getProtocolId(PRIO.class); message.putHeader( protocolId, header);
PrioHeader() - Constructor for class org.jgroups.protocols.PrioHeader
 
PrioHeader(byte) - Constructor for class org.jgroups.protocols.PrioHeader
 
probe_handler - Variable in class org.jgroups.blocks.MessageDispatcher
 
probe_handler - Variable in class org.jgroups.JChannel
 
process(Socket) - Method in class org.jgroups.protocols.pbcast.STATE_SOCK.StateProviderAcceptor
 
processing - Variable in class org.jgroups.util.RingBuffer
 
processing - Variable in class org.jgroups.util.RingBufferLockless
 
processing - Variable in class org.jgroups.util.Table
 
processQueue() - Method in class org.jgroups.protocols.Locking.ServerLock
 
ProgrammaticChat - Class in org.jgroups.demos
 
ProgrammaticChat() - Constructor for class org.jgroups.demos.ProgrammaticChat
 
Promise<T> - Class in org.jgroups.util
Allows a thread to submit an asynchronous request and to wait for the result.
Promise() - Constructor for class org.jgroups.util.Promise
 
prompt(String) - Static method in class org.jgroups.util.Util
 
propertiesToString() - Method in class org.jgroups.conf.ProtocolConfiguration
 
PropertiesToXML - Class in org.jgroups.util
Iterates over all concrete Protocol classes and creates tables with Protocol's properties.
PropertiesToXML() - Constructor for class org.jgroups.util.PropertiesToXML
 
Property - Annotation Type in org.jgroups.annotations
Represents a Protocol property assigned from corresponding field in JGroups properties file.
PropertyConverter - Interface in org.jgroups.conf
Represents a property converter that takes an input from corresponding field in JGroups properties file as a String and converts it to a matching Java type.
PropertyConverters - Class in org.jgroups.conf
Groups a set of standard PropertyConverter(s) supplied by JGroups.
PropertyConverters() - Constructor for class org.jgroups.conf.PropertyConverters
 
PropertyConverters.BindInterface - Class in org.jgroups.conf
 
PropertyConverters.BindInterface() - Constructor for class org.jgroups.conf.PropertyConverters.BindInterface
 
PropertyConverters.Default - Class in org.jgroups.conf
 
PropertyConverters.Default() - Constructor for class org.jgroups.conf.PropertyConverters.Default
 
PropertyConverters.FlushInvoker - Class in org.jgroups.conf
 
PropertyConverters.FlushInvoker() - Constructor for class org.jgroups.conf.PropertyConverters.FlushInvoker
 
PropertyConverters.InitialHosts - Class in org.jgroups.conf
 
PropertyConverters.InitialHosts() - Constructor for class org.jgroups.conf.PropertyConverters.InitialHosts
 
PropertyConverters.InitialHosts2 - Class in org.jgroups.conf
 
PropertyConverters.InitialHosts2() - Constructor for class org.jgroups.conf.PropertyConverters.InitialHosts2
 
PropertyConverters.IntegerArray - Class in org.jgroups.conf
 
PropertyConverters.IntegerArray() - Constructor for class org.jgroups.conf.PropertyConverters.IntegerArray
 
PropertyConverters.LongArray - Class in org.jgroups.conf
 
PropertyConverters.LongArray() - Constructor for class org.jgroups.conf.PropertyConverters.LongArray
 
PropertyConverters.NetworkInterfaceList - Class in org.jgroups.conf
 
PropertyConverters.NetworkInterfaceList() - Constructor for class org.jgroups.conf.PropertyConverters.NetworkInterfaceList
 
PropertyHelper - Class in org.jgroups.conf
 
PropertyHelper() - Constructor for class org.jgroups.conf.PropertyHelper
 
PROPOSE_MESSAGE - Static variable in class org.jgroups.protocols.tom.ToaHeader
 
props - Variable in class org.jgroups.demos.ExecutionServiceDemo
 
props - Variable in class org.jgroups.demos.LockServiceDemo
 
prot_adapter - Variable in class org.jgroups.blocks.MessageDispatcher
 
prot_stack - Variable in class org.jgroups.JChannel
 
Protocol - Class in org.jgroups.stack
The Protocol class provides a set of common services for protocol layers.
Protocol() - Constructor for class org.jgroups.stack.Protocol
 
PROTOCOL_ID_FILE - Static variable in class org.jgroups.conf.ClassConfigurator
 
PROTOCOL_ID_FILE - Static variable in class org.jgroups.Global
 
protocol_prefix - Static variable in class org.jgroups.conf.ProtocolConfiguration
 
ProtocolConfiguration - Class in org.jgroups.conf
Parses and encapsulates the specification for 1 protocol of the protocol stack, e.g.
ProtocolConfiguration(String) - Constructor for class org.jgroups.conf.ProtocolConfiguration
Creates a new ProtocolConfiguration.
ProtocolConfiguration(String, Map<String, String>) - Constructor for class org.jgroups.conf.ProtocolConfiguration
 
protocols - Variable in class org.jgroups.protocols.relay.config.RelayConfig.ProgrammaticBridgeConfig
 
ProtocolStack - Class in org.jgroups.stack
A ProtocolStack manages a number of protocols layered above each other.
ProtocolStack(JChannel) - Constructor for class org.jgroups.stack.ProtocolStack
 
ProtocolStack() - Constructor for class org.jgroups.stack.ProtocolStack
Used for programmatic creation of ProtocolStack
ProtocolStack.RefCounter - Class in org.jgroups.stack
Keeps track of the number os times init()/destroy() and start()/stop have been called.
ProtocolStack.RefCounter(short, short) - Constructor for class org.jgroups.stack.ProtocolStack.RefCounter
 
ProtocolStackConfigurator - Interface in org.jgroups.conf
 
prots_above - Variable in class org.jgroups.protocols.relay.RELAY2
 
providedDownServices() - Method in class org.jgroups.protocols.pbcast.FLUSH
 
providedDownServices() - Method in class org.jgroups.protocols.pbcast.GMS
 
providedDownServices() - Method in class org.jgroups.stack.Protocol
List of events that are provided to layers below (they will be handled when sent down below)
providedUpServices() - Method in class org.jgroups.protocols.Discovery
 
providedUpServices() - Method in class org.jgroups.protocols.FORWARD_TO_COORD
 
providedUpServices() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
providedUpServices() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
providedUpServices() - Method in class org.jgroups.stack.Protocol
List of events that are provided to layers above (they will be handled when sent down from above)
PubSub - Class in org.jgroups.demos
Simple pub-sub program using a shared transport: every topic creates a new channel
PubSub() - Constructor for class org.jgroups.demos.PubSub
 
purge(long) - Method in class org.jgroups.util.RetransmitTable
Removes all messages less than or equal to seqno from the table.
purge(long) - Method in class org.jgroups.util.Table
Removes all elements less than or equal to seqno from the table.
purge(long, boolean) - Method in class org.jgroups.util.Table
Removes all elements less than or equal to seqno from the table.
put(K, V, long) - Method in class org.jgroups.blocks.Cache
 
put(K, V) - Method in class org.jgroups.blocks.PartitionedHashMap
 
put(K, V, long) - Method in class org.jgroups.blocks.PartitionedHashMap
Adds a key/value to the cache, replacing a previous item if there was one
put(K, V, short, long, boolean) - Method in class org.jgroups.blocks.ReplCache
Places a key/value pair into one or several nodes in the cluster.
put(K, V, short, long) - Method in class org.jgroups.blocks.ReplCache
Places a key/value pair into one or several nodes in the cluster.
put(K, V) - Method in class org.jgroups.blocks.ReplCache
 
put(K, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
Maps the specified key to the specified value in this table.
put(String, HashMap) - Method in class org.jgroups.blocks.ReplicatedTree
Adds a new node to the tree and sets its data.
put(String, String, Object) - Method in class org.jgroups.blocks.ReplicatedTree
Adds a key and value to a given node.
put(T) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
 
put(long, Message) - Method in class org.jgroups.util.RetransmitTable
Adds a new message to the index computed as a function of seqno
put(Address, Rsp<T>) - Method in class org.jgroups.util.RspList
 
putAll(Map<? extends K, ? extends V>) - Method in class org.jgroups.blocks.ReplicatedHashMap
Copies all of the mappings from the specified map to this one.
putAll(Map<? extends Address, ? extends Rsp<T>>) - Method in class org.jgroups.util.RspList
 
putHeader(short, Header) - Method in class org.jgroups.Message
Puts a header given an ID into the hashmap.
putHeader(short, Header) - Method in class org.jgroups.util.Headers
Puts a header given a key into the hashmap.
putHeaderIfAbsent(short, Header) - Method in class org.jgroups.Message
Puts a header given a key into the map, only if the key doesn't exist yet
putHeaderIfAbsent(short, Header) - Method in class org.jgroups.util.Headers
Puts a header given a key into the map, only if the key doesn't exist yet
putIfAbsent(K, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
putIfAbsent(Address) - Method in class org.jgroups.util.CreditMap
 
putIfAbsent(long, Message) - Method in class org.jgroups.util.RetransmitTable
Adds a message if the element at the given index is null.
putIfAbsent(T, long) - Method in class org.jgroups.util.SuppressCache
Adds a new key to the hashmap, or updates the Value associated with the existing key if present.

Q

queue - Variable in class org.jgroups.demos.ExecutionServiceDemo
 
queue - Variable in class org.jgroups.protocols.Locking.ServerCondition
 
queue - Variable in class org.jgroups.protocols.Locking.ServerLock
 
queue - Variable in class org.jgroups.protocols.SCOPE.QueueThread
 
Queue - Class in org.jgroups.util
Elements are added at the tail and removed from the head.
Queue() - Constructor for class org.jgroups.util.Queue
creates an empty queue
queue - Variable in class org.jgroups.util.TimeScheduler3
DelayQueue with tasks being sorted according to execution times (next execution first)
QueueClosedException - Exception in org.jgroups.util
 
QueueClosedException() - Constructor for exception org.jgroups.util.QueueClosedException
 
QueueClosedException(String) - Constructor for exception org.jgroups.util.QueueClosedException
 
queues - Variable in class org.jgroups.protocols.SCOPE
Used to find the correct AckReceiverWindow on message reception and deliver it in the right order
QuoteClient - Class in org.jgroups.demos
Used in conjunction with QuoteServer: a client is member of a group of quote servers which replicate stock quotes among themselves.
QuoteClient() - Constructor for class org.jgroups.demos.QuoteClient
 
QuoteServer - Class in org.jgroups.demos
Example of a replicated quote server.
QuoteServer() - Constructor for class org.jgroups.demos.QuoteServer
 

R

rack_id - Variable in class org.jgroups.util.TopologyUUID
 
RACKSPACE_PING - Class in org.jgroups.protocols
Discovery protocol based on Rackspace Cloud Files storage solution
RACKSPACE_PING() - Constructor for class org.jgroups.protocols.RACKSPACE_PING
 
rackspaceClient - Variable in class org.jgroups.protocols.RACKSPACE_PING
 
RAN - Static variable in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture.Sync
State value representing that task ran
random - Variable in class org.jgroups.demos.ExecutionServiceDemo
 
random(long) - Static method in class org.jgroups.util.Util
Returns a random value in the range [1 - range]
randomUUID(boolean) - Static method in class org.jgroups.protocols.relay.CanBeSiteMaster
 
randomUUID(String, boolean) - Static method in class org.jgroups.protocols.relay.CanBeSiteMaster
 
randomUUID(byte[]) - Static method in class org.jgroups.util.AdditionalDataUUID
 
randomUUID(String, byte[]) - Static method in class org.jgroups.util.AdditionalDataUUID
 
randomUUID(String) - Static method in class org.jgroups.util.PayloadUUID
 
randomUUID(String, String) - Static method in class org.jgroups.util.PayloadUUID
 
randomUUID(String, String, String) - Static method in class org.jgroups.util.TopologyUUID
 
randomUUID(String, String, String, String) - Static method in class org.jgroups.util.TopologyUUID
 
randomUUID() - Static method in class org.jgroups.util.UUID
Static factory to retrieve a type 4 (pseudo randomly generated) UUID.
range - Variable in class org.jgroups.stack.RangeBasedRetransmitter.RangeTask
 
Range - Class in org.jgroups.util
 
Range() - Constructor for class org.jgroups.util.Range
For externalization
Range(long, long) - Constructor for class org.jgroups.util.Range
 
range - Variable in class org.jgroups.util.SeqnoList.SeqnoListIterator
 
range_index - Variable in class org.jgroups.util.SeqnoList.SeqnoListIterator
 
RangeBasedRetransmitter - Class in org.jgroups.stack
This retransmitter is specialized in maintaining ranges of seqnos, e.g.
RangeBasedRetransmitter(Address, Retransmitter.RetransmitCommand, TimeScheduler) - Constructor for class org.jgroups.stack.RangeBasedRetransmitter
Create a new Retransmitter associated with the given sender address
RangeBasedRetransmitter.RangeTask - Class in org.jgroups.stack
 
RangeBasedRetransmitter.RangeTask(Seqno, Interval, Retransmitter.RetransmitCommand, Address) - Constructor for class org.jgroups.stack.RangeBasedRetransmitter.RangeTask
 
RATE_LIMITER - Class in org.jgroups.protocols
Protocol which sends at most max_bytes in time_period milliseconds.
RATE_LIMITER() - Constructor for class org.jgroups.protocols.RATE_LIMITER
 
read() - Method in class org.jgroups.blocks.GridInputStream
 
read(byte[]) - Method in class org.jgroups.blocks.GridInputStream
 
read(byte[], int, int) - Method in class org.jgroups.blocks.GridInputStream
 
read() - Method in class org.jgroups.util.BlockingInputStream
 
read(byte[]) - Method in class org.jgroups.util.BlockingInputStream
 
read(byte[], int, int) - Method in class org.jgroups.util.BlockingInputStream
 
read() - Method in class org.jgroups.util.ExposedByteArrayInputStream
 
read(byte[], int, int) - Method in class org.jgroups.util.ExposedByteArrayInputStream
 
read_pos - Variable in class org.jgroups.util.BlockingInputStream
Index into buf at which the next bytes will be read.
readAddress(DataInput) - Static method in class org.jgroups.util.Util
 
readAddresses(DataInput, Class) - Static method in class org.jgroups.util.Util
 
readAll(String) - Method in class org.jgroups.protocols.FILE_PING
Reads all information from the given directory under clustername
readAll(String) - Method in class org.jgroups.protocols.JDBC_PING
 
readAll(Connection, String) - Method in class org.jgroups.protocols.JDBC_PING
 
readAll(String) - Method in class org.jgroups.protocols.RACKSPACE_PING
 
readAll(String) - Method in class org.jgroups.protocols.S3_PING
 
readAll(String) - Method in class org.jgroups.protocols.SWIFT_PING
 
readAuthToken(DataInput) - Static method in class org.jgroups.protocols.AuthHeader
 
readAuthToken(DataInput) - Static method in class org.jgroups.util.Util
 
readByteBuffer(DataInput) - Static method in class org.jgroups.util.Util
 
readBytesDouble(String) - Static method in class org.jgroups.util.Util
 
readBytesInteger(String) - Static method in class org.jgroups.util.Util
 
readBytesLong(String) - Static method in class org.jgroups.util.Util
 
readCacheFromDisk() - Method in class org.jgroups.protocols.PDC
Reads all mappings from disk
readClass(DataInput) - Static method in class org.jgroups.util.Util
 
readContents(InputStream) - Static method in class org.jgroups.util.Util
 
readDoubleFromStdin(String) - Static method in class org.jgroups.util.Util
 
readExternal(ObjectInput) - Method in class org.jgroups.AnycastAddress
 
readExternal(ObjectInput) - Method in class org.jgroups.blocks.Cache.Value
 
readExternal(ObjectInput) - Method in class org.jgroups.blocks.MethodCall
 
readExternal(ObjectInput) - Method in class org.jgroups.protocols.relay.CanBeSiteMaster
 
readExternal(ObjectInput) - Method in class org.jgroups.protocols.relay.CanBeSiteMasterTopology
 
readExternal(ObjectInput) - Method in class org.jgroups.protocols.relay.SiteUUID
 
readExternal(ObjectInput) - Method in class org.jgroups.protocols.tom.MessageID
 
readExternal(ObjectInput) - Method in class org.jgroups.stack.IpAddress
 
readExternal(ObjectInput) - Method in class org.jgroups.util.AdditionalDataUUID
 
readExternal(ObjectInput) - Method in class org.jgroups.util.PayloadUUID
 
readExternal(ObjectInput) - Method in class org.jgroups.util.SingletonAddress
 
readExternal(ObjectInput) - Method in class org.jgroups.util.TopologyUUID
 
readExternal(ObjectInput) - Method in class org.jgroups.util.UUID
 
readFile(String) - Static method in class org.jgroups.util.Util
 
readFileContents(String) - Static method in class org.jgroups.util.Util
 
readFileContents(InputStream) - Static method in class org.jgroups.util.Util
 
readFrame(DataInputStream) - Static method in class org.jgroups.protocols.STOMP
 
readFrom(DataInput) - Method in class org.jgroups.AnycastAddress
 
readFrom(DataInput) - Method in class org.jgroups.auth.DemoToken.DemoHeader
 
readFrom(DataInput) - Method in class org.jgroups.auth.DemoToken
 
readFrom(DataInput) - Method in class org.jgroups.auth.FixedMembershipToken
Required to deserialize the object when read in from the wire
readFrom(DataInput) - Method in class org.jgroups.auth.MD5Token
 
readFrom(DataInput) - Method in class org.jgroups.auth.RegexMembership
Required to deserialize the object when read in from the wire
readFrom(DataInput) - Method in class org.jgroups.auth.SimpleToken
Required to deserialize the object when read in from the wire
readFrom(DataInput) - Method in class org.jgroups.auth.X509Token
 
readFrom(DataInput) - Method in class org.jgroups.blocks.executor.Executions.StreamableCallable
 
readFrom(DataInput) - Method in class org.jgroups.blocks.executor.ExecutionService.RunnableAdapter
 
readFrom(DataInput) - Method in class org.jgroups.blocks.GridFile.Metadata
 
readFrom(DataInput) - Method in class org.jgroups.blocks.mux.MuxHeader
 
readFrom(DataInput) - Method in class org.jgroups.blocks.RequestCorrelator.Header
 
readFrom(DataInput) - Method in class org.jgroups.blocks.RequestCorrelator.MultiDestinationHeader
 
readFrom(DataInput) - Method in class org.jgroups.demos.DrawCommand
 
readFrom(DataInput) - Method in class org.jgroups.demos.ExecutionServiceDemo.ByteBufferStreamable
 
readFrom(DataInput) - Method in class org.jgroups.demos.ExecutionServiceDemo.SortingByteCallable
 
readFrom(DataInput) - Method in class org.jgroups.demos.ExecutionServiceDemo.SortingTwoByteCallable
 
readFrom(DataInput) - Method in class org.jgroups.MergeView
 
readFrom(DataInput) - Method in class org.jgroups.Message
 
readFrom(DataInput) - Method in class org.jgroups.protocols.AuthHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.COMPRESS.CompressHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.COUNTER.BooleanResponse
 
readFrom(DataInput) - Method in class org.jgroups.protocols.COUNTER.CompareAndSetRequest
 
readFrom(DataInput) - Method in class org.jgroups.protocols.COUNTER.CounterHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.COUNTER.ExceptionResponse
 
readFrom(DataInput) - Method in class org.jgroups.protocols.COUNTER.GetOrCreateRequest
 
readFrom(DataInput) - Method in class org.jgroups.protocols.COUNTER.ReconcileRequest
 
readFrom(DataInput) - Method in class org.jgroups.protocols.COUNTER.ReconcileResponse
 
readFrom(DataInput) - Method in class org.jgroups.protocols.COUNTER.ResendPendingRequests
 
readFrom(DataInput) - Method in class org.jgroups.protocols.COUNTER.SetRequest
 
readFrom(DataInput) - Method in class org.jgroups.protocols.COUNTER.SimpleRequest
 
readFrom(DataInput) - Method in class org.jgroups.protocols.COUNTER.SimpleResponse
 
readFrom(DataInput) - Method in class org.jgroups.protocols.COUNTER.UpdateRequest
 
readFrom(DataInput) - Method in class org.jgroups.protocols.COUNTER.ValueResponse
 
readFrom(DataInput) - Method in class org.jgroups.protocols.DAISYCHAIN.DaisyHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.DISCARD.DiscardHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.EXAMPLE.ExampleHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.Executing.ExecutorHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.Executing.Request
 
readFrom(DataInput) - Method in class org.jgroups.protocols.Executing.RequestWithThread
 
readFrom(DataInput) - Method in class org.jgroups.protocols.FcHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.FD.FdHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.FD_ALL.HeartbeatHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.FD_SIMPLE.FdHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.FD_SOCK.FdHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.FORWARD_TO_COORD.ForwardHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.FragHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.HTOTAL.HTotalHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.Locking.LockingHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.Locking.Request
 
readFrom(DataInput) - Method in class org.jgroups.protocols.MERGE3.MergeHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.pbcast.JoinRsp
 
readFrom(DataInput) - Method in class org.jgroups.protocols.pbcast.NakAckHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.pbcast.NakAckHeader2
 
readFrom(DataInput) - Method in class org.jgroups.protocols.pbcast.STABLE.StableHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.PDC.Mapping
 
readFrom(DataInput) - Method in class org.jgroups.protocols.PingData
 
readFrom(DataInput) - Method in class org.jgroups.protocols.PingHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.PrioHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.relay.CanBeSiteMaster
 
readFrom(DataInput) - Method in class org.jgroups.protocols.relay.CanBeSiteMasterTopology
 
readFrom(DataInput) - Method in class org.jgroups.protocols.relay.RELAY2.Relay2Header
 
readFrom(DataInput) - Method in class org.jgroups.protocols.RELAY.RelayHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.relay.SiteUUID
 
readFrom(DataInput) - Method in class org.jgroups.protocols.RELAY.ViewData
 
readFrom(DataInput) - Method in class org.jgroups.protocols.RSVP.RsvpHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.SCOPE.ScopeHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.SEQUENCER.SequencerHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.STOMP.StompHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.tom.MessageID
 
readFrom(DataInput) - Method in class org.jgroups.protocols.tom.ToaHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.TpHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.UNICAST.UnicastHeader
 
readFrom(DataInput) - Method in class org.jgroups.protocols.UNICAST2.Unicast2Header
 
readFrom(DataInput) - Method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
 
readFrom(DataInput) - Method in class org.jgroups.stack.GossipData
 
readFrom(DataInput) - Method in class org.jgroups.stack.IpAddress
 
readFrom(DataInput) - Method in class org.jgroups.util.AdditionalDataUUID
 
readFrom(DataInput) - Method in class org.jgroups.util.Digest
 
readFrom(DataInput) - Method in class org.jgroups.util.MergeId
 
readFrom(DataInput) - Method in class org.jgroups.util.Owner
 
readFrom(DataInput) - Method in class org.jgroups.util.PayloadUUID
 
readFrom(DataInput) - Method in class org.jgroups.util.Range
 
readFrom(DataInput) - Method in class org.jgroups.util.SeqnoList
 
readFrom(DataInput) - Method in class org.jgroups.util.SingletonAddress
 
readFrom(DataInput) - Method in interface org.jgroups.util.Streamable
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInput) - Method in class org.jgroups.util.TopologyUUID
 
readFrom(DataInput) - Method in class org.jgroups.util.UUID
 
readFrom(DataInput) - Method in class org.jgroups.View
 
readFrom(DataInput) - Method in class org.jgroups.ViewId
 
readGenericStreamable(DataInput) - Static method in class org.jgroups.util.Util
 
readHeader(DataInput) - Static method in class org.jgroups.Message
 
readIntFromStdin(String) - Static method in class org.jgroups.util.Util
 
readLine(InputStream) - Static method in class org.jgroups.util.Util
Reads a line of text.
readLong(DataInput) - Static method in class org.jgroups.util.Util
 
readLongFromStdin(String) - Static method in class org.jgroups.util.Util
 
readLongSequence(DataInput) - Static method in class org.jgroups.util.Util
 
readMappings(String) - Static method in class org.jgroups.conf.ClassConfigurator
try to read the magic number configuration file as a Resource form the classpath using getResourceAsStream if this fails this method tries to read the configuration file from mMagicNumberFile using a FileInputStream (not in classpath but somewhere else in the disk)
readMessage(DataInputStream) - Static method in class org.jgroups.protocols.TP
 
readMessageList(DataInputStream) - Static method in class org.jgroups.protocols.TP
 
readNewLine(ByteBuffer) - Static method in class org.jgroups.util.Util
 
readObject(String, String) - Method in class org.jgroups.protocols.SWIFT_PING.SwiftClient
Read the content of a file
readObject(DataInput) - Static method in class org.jgroups.util.Util
 
readPeerAddress(Socket) - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
Reads the peer's address.
readReconciliationLongs(DataInput, int) - Static method in class org.jgroups.protocols.COUNTER
 
readReconciliationNames(DataInput, int) - Static method in class org.jgroups.protocols.COUNTER
 
readStreamable(Class, DataInput) - Static method in class org.jgroups.util.Util
 
readString(DataInput) - Static method in class org.jgroups.util.Util
 
readStringFromStdin(String) - Static method in class org.jgroups.util.Util
 
readView(DataInput) - Static method in class org.jgroups.util.Util
 
readViewId(DataInput) - Static method in class org.jgroups.util.Util
 
reaper - Variable in class org.jgroups.blocks.AbstractConnectionMap
 
reaper_interval - Variable in class org.jgroups.protocols.BasicTCP
 
reaperInterval - Variable in class org.jgroups.blocks.AbstractConnectionMap
 
reapIdleConnections() - Method in class org.jgroups.protocols.UNICAST
 
reapIdleConnections() - Method in class org.jgroups.protocols.UNICAST2
 
REBROADCAST - Static variable in class org.jgroups.Event
 
rebroadcast_digest - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
rebroadcast_digest_lock - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
rebroadcast_done - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
rebroadcast_lock - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
rebroadcasting - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
rebroadcastMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK2
Takes the argument highest_seqnos and compares it to the current digest.
receive(Address, byte[], int, int) - Method in class org.jgroups.blocks.BasicConnectionTable
Calls the receiver callback.
receive(Address, byte[], int, int) - Method in interface org.jgroups.blocks.BasicConnectionTable.Receiver
 
receive(Message) - Method in class org.jgroups.blocks.ReplicatedHashMap
 
receive(Message) - Method in class org.jgroups.blocks.ReplicatedTree
Callback.
receive(Event) - Method in class org.jgroups.blocks.RequestCorrelator
Callback.
receive(Address, byte[], int, int) - Method in class org.jgroups.blocks.TCPConnectionMap
Calls the receiver callback.
receive(Address, byte[], int, int) - Method in interface org.jgroups.blocks.TCPConnectionMap.Receiver
 
receive(Message) - Method in class org.jgroups.demos.Chat
 
receive(Message) - Method in class org.jgroups.demos.Draw
 
receive(Message) - Method in class org.jgroups.demos.wb.Whiteboard
 
receive(Message) - Method in interface org.jgroups.MessageListener
Called when a message is received.
receive(Address, byte[], int, int) - Method in class org.jgroups.protocols.BasicTCP
ConnectionMap.Receiver interface
receive(Message) - Method in class org.jgroups.protocols.RELAY.Receiver
 
receive(Message) - Method in class org.jgroups.protocols.relay.Relayer.Bridge
 
receive(Address, byte[], int, int) - Method in class org.jgroups.protocols.TP
Subclasses must call this method when a unicast or multicast message has been received.
receive(Message) - Method in class org.jgroups.ReceiverAdapter
Called when a message is received.
receive(long, Message) - Method in class org.jgroups.util.ForwardQueue
 
receive_interfaces - Variable in class org.jgroups.protocols.TP
List of interfaces to receive multicasts on.
receive_on_all_interfaces - Variable in class org.jgroups.protocols.TP
 
received - Variable in class org.jgroups.protocols.FlowControl
Keeps track of credits per member at the receiver.
received - Variable in class org.jgroups.util.Rsp
Flag that represents whether the response was received
RECEIVED - Static variable in class org.jgroups.util.Seqno
 
received() - Method in class org.jgroups.util.Seqno
 
received_bcasts - Variable in class org.jgroups.protocols.SEQUENCER
 
received_bytes - Variable in class org.jgroups.JChannel
 
received_bytes - Variable in class org.jgroups.protocols.UNICAST2.ReceiverEntry
 
received_forwards - Variable in class org.jgroups.protocols.SEQUENCER
 
received_msgs - Variable in class org.jgroups.JChannel
 
received_msgs - Variable in class org.jgroups.protocols.UNICAST.ReceiverEntry
 
received_msgs - Variable in class org.jgroups.protocols.UNICAST2.ReceiverEntry
 
received_not_coord - Variable in class org.jgroups.protocols.FORWARD_TO_COORD
Set when NOT_COORD message has been received.
receiveMessage(Message) - Method in class org.jgroups.blocks.RequestCorrelator
Handles a message coming from a layer below
receiver - Variable in class org.jgroups.blocks.TCPConnectionMap
 
receiver - Variable in class org.jgroups.Channel
 
receiver - Variable in class org.jgroups.protocols.BPING
 
Receiver - Interface in org.jgroups
Defines the callbacks that are invoked when messages, views etc are received on a channel
receiver - Variable in class org.jgroups.stack.RouterStub
 
ReceiverAdapter - Class in org.jgroups
An adapter implementing the Receiver interface with no-op implementations.
ReceiverAdapter() - Constructor for class org.jgroups.ReceiverAdapter
 
receiveResponse(Object, Address, boolean) - Method in class org.jgroups.blocks.GroupRequest
Callback (called by RequestCorrelator or Transport).
receiveResponse(Object, Address, boolean) - Method in class org.jgroups.blocks.Request
 
receiveResponse(Object, Address, boolean) - Method in interface org.jgroups.blocks.RspCollector
 
receiveResponse(Object, Address, boolean) - Method in class org.jgroups.blocks.UnicastRequest
Callback (called by RequestCorrelator or Transport).
receiveSuspect(Address) - Method in class org.jgroups.blocks.RequestCorrelator
Event.SUSPECT event received from a layer below.
receiveView(View) - Method in class org.jgroups.blocks.RequestCorrelator
Event.VIEW_CHANGE event received from a layer below.
receiving - Variable in class org.jgroups.blocks.TCPConnectionMap.TCPConnection.ConnectionPeerReceiver
 
reconciliation_task - Variable in class org.jgroups.protocols.COUNTER
 
reconciliation_task_future - Variable in class org.jgroups.protocols.COUNTER
 
reconciliation_timeout - Variable in class org.jgroups.protocols.COUNTER
 
reconnect - Variable in class org.jgroups.client.StompConnection
 
recv - Variable in class org.jgroups.blocks.TCPConnectionMap.TCPConnection.ConnectionPeerReceiver
 
recv_buf_size - Variable in class org.jgroups.blocks.TCPConnectionMap
 
recv_buf_size - Variable in class org.jgroups.protocols.BasicTCP
 
recv_conn_id - Variable in class org.jgroups.protocols.UNICAST.ReceiverEntry
 
recv_conn_id - Variable in class org.jgroups.protocols.UNICAST2.ReceiverEntry
 
recv_table - Variable in class org.jgroups.protocols.UNICAST
 
recv_table - Variable in class org.jgroups.protocols.UNICAST2
 
recv_table_lock - Variable in class org.jgroups.protocols.UNICAST
 
recv_table_lock - Variable in class org.jgroups.protocols.UNICAST2
 
RegexMembership - Class in org.jgroups.auth
Matches the IP address or logical name of a joiner against a regular expression and accepts or rejects based on pattern matching
RegexMembership() - Constructor for class org.jgroups.auth.RegexMembership
 
region - Variable in class org.jgroups.protocols.RACKSPACE_PING
 
register(Object, MBeanServer, String) - Static method in class org.jgroups.jmx.JmxConfigurator
 
register(AUTH.UpHandler) - Method in class org.jgroups.protocols.AUTH
 
register(EventHandler) - Method in class org.jgroups.protocols.rules.SUPERVISOR
 
register(String, Address, SHARED_LOOPBACK) - Static method in class org.jgroups.protocols.SHARED_LOOPBACK
 
registerChannel(JChannel, MBeanServer, String, String, boolean) - Static method in class org.jgroups.jmx.JmxConfigurator
Registers an already created channel with the given MBeanServer.
registerChannel(JChannel, MBeanServer, String) - Static method in class org.jgroups.jmx.JmxConfigurator
Registers an already created channel with the given MBeanServer.
registerChannel(JChannel, String) - Static method in class org.jgroups.util.Util
 
registerLocalAddress(Address) - Method in class org.jgroups.protocols.TP
Associates the address with the physical address fetched from the cache
registerProbeHandler(TP) - Method in class org.jgroups.blocks.RequestCorrelator
 
registerProbeHandler(DiagnosticsHandler.ProbeHandler) - Method in class org.jgroups.protocols.TP
 
registerProbeHandler(DiagnosticsHandler.ProbeHandler) - Method in class org.jgroups.stack.DiagnosticsHandler
 
registerStub(RouterStub) - Method in class org.jgroups.stack.RouterStubManager
 
rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class org.jgroups.util.ShutdownRejectedExecutionHandler
 
RELAY - Class in org.jgroups.protocols
Simple relaying protocol: RELAY is added to the top of the stack, creates a channel to a bridge cluster, and - if coordinator - relays all multicast messages via the bridge cluster to the remote cluster.

This is not a big virtual cluster, e.g.

RELAY() - Constructor for class org.jgroups.protocols.RELAY
 
relay - Variable in class org.jgroups.protocols.RELAY
 
relay - Variable in class org.jgroups.protocols.relay.Relayer
 
RELAY.Receiver - Class in org.jgroups.protocols
 
RELAY.Receiver() - Constructor for class org.jgroups.protocols.RELAY.Receiver
 
RELAY.RelayHeader - Class in org.jgroups.protocols
 
RELAY.RelayHeader() - Constructor for class org.jgroups.protocols.RELAY.RelayHeader
 
RELAY.RelayHeader.Type - Enum in org.jgroups.protocols
 
RELAY.RemoteViewFetcher - Class in org.jgroups.protocols
 
RELAY.RemoteViewFetcher() - Constructor for class org.jgroups.protocols.RELAY.RemoteViewFetcher
 
RELAY.ViewData - Class in org.jgroups.protocols
Contains local and remote views, and UUID information
RELAY.ViewData() - Constructor for class org.jgroups.protocols.RELAY.ViewData
 
RELAY2 - Class in org.jgroups.protocols.relay
Design: ./doc/design/RELAY2.txt and at https://github.com/belaban/JGroups/blob/master/doc/design/RELAY2.txt.

JIRA: https://issues.jboss.org/browse/JGRP-1433

RELAY2() - Constructor for class org.jgroups.protocols.relay.RELAY2
 
RELAY2.Relay2Header - Class in org.jgroups.protocols.relay
 
RELAY2.Relay2Header() - Constructor for class org.jgroups.protocols.relay.RELAY2.Relay2Header
 
RELAY2.Relay2Header(byte, Address, Address) - Constructor for class org.jgroups.protocols.relay.RELAY2.Relay2Header
 
RELAY2.RouteStatus - Enum in org.jgroups.protocols.relay
 
RELAY_CONFIG - Static variable in class org.jgroups.protocols.relay.config.RelayConfig
 
relay_multicasts - Variable in class org.jgroups.protocols.relay.RELAY2
 
RelayConfig - Class in org.jgroups.protocols.relay.config
Parses and maintains the RELAY2 configuration (in memory)
RelayConfig() - Constructor for class org.jgroups.protocols.relay.config.RelayConfig
 
RelayConfig.BridgeConfig - Class in org.jgroups.protocols.relay.config
 
RelayConfig.BridgeConfig(String) - Constructor for class org.jgroups.protocols.relay.config.RelayConfig.BridgeConfig
 
RelayConfig.ForwardConfig - Class in org.jgroups.protocols.relay.config
 
RelayConfig.ForwardConfig(String, String) - Constructor for class org.jgroups.protocols.relay.config.RelayConfig.ForwardConfig
 
RelayConfig.ProgrammaticBridgeConfig - Class in org.jgroups.protocols.relay.config
 
RelayConfig.ProgrammaticBridgeConfig(String, Protocol[]) - Constructor for class org.jgroups.protocols.relay.config.RelayConfig.ProgrammaticBridgeConfig
 
RelayConfig.PropertiesBridgeConfig - Class in org.jgroups.protocols.relay.config
 
RelayConfig.PropertiesBridgeConfig(String, String) - Constructor for class org.jgroups.protocols.relay.config.RelayConfig.PropertiesBridgeConfig
 
RelayConfig.SiteConfig - Class in org.jgroups.protocols.relay.config
 
RelayConfig.SiteConfig(String, short) - Constructor for class org.jgroups.protocols.relay.config.RelayConfig.SiteConfig
 
RelayDemo - Class in org.jgroups.demos
Demos RELAY.
RelayDemo() - Constructor for class org.jgroups.demos.RelayDemo
 
RelayDemoRpc - Class in org.jgroups.demos
Demos RELAY.
RelayDemoRpc() - Constructor for class org.jgroups.demos.RelayDemoRpc
 
relayed - Variable in class org.jgroups.protocols.relay.RELAY2
Number of messages relayed by the local SiteMaster to a remote SiteMaster
relayed_time - Variable in class org.jgroups.protocols.relay.RELAY2
Total time spent relaying messages from the local SiteMaster to remote SiteMasters (in ns)
relayer - Variable in class org.jgroups.protocols.relay.RELAY2
 
Relayer - Class in org.jgroups.protocols.relay
Maintains bridges and routing table.
Relayer(RELAY2, Log, int) - Constructor for class org.jgroups.protocols.relay.Relayer
 
Relayer.Bridge - Class in org.jgroups.protocols.relay
 
Relayer.Bridge(JChannel, String, String, AddressGenerator) - Constructor for class org.jgroups.protocols.relay.Relayer.Bridge
 
Relayer.Route - Class in org.jgroups.protocols.relay
Includes information about the site master of the route and the channel to be used
Relayer.Route(Address, JChannel) - Constructor for class org.jgroups.protocols.relay.Relayer.Route
 
Relayer.Route(Address, JChannel, RELAY2.RouteStatus) - Constructor for class org.jgroups.protocols.relay.Relayer.Route
 
relayMulticasts(boolean) - Method in class org.jgroups.protocols.relay.RELAY2
 
relayMulticasts() - Method in class org.jgroups.protocols.relay.RELAY2
 
release() - Method in class org.jgroups.protocols.SCOPE.MessageQueue
 
remaining() - Method in class org.jgroups.util.BlockingInputStream
 
remainingCapacity() - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
 
remote_view - Variable in class org.jgroups.protocols.RELAY
The view of the remote cluster
remote_view - Variable in class org.jgroups.protocols.RELAY.ViewData
 
remote_view_fetcher_future - Variable in class org.jgroups.protocols.RELAY
 
remove(K) - Method in class org.jgroups.blocks.Cache
 
remove(String, boolean) - Method in class org.jgroups.blocks.GridFilesystem
 
remove(K) - Method in class org.jgroups.blocks.LazyRemovalCache
 
remove(K, boolean) - Method in class org.jgroups.blocks.LazyRemovalCache
 
remove(short) - Method in interface org.jgroups.blocks.mux.Muxer
Unregisters the handler associated with the specifed mux identifier
remove(short) - Method in class org.jgroups.blocks.mux.MuxUpHandler
Unregisters the handler associated with the specifed mux identifier
remove(K) - Method in class org.jgroups.blocks.PartitionedHashMap
 
remove(K) - Method in class org.jgroups.blocks.ReplCache
Removes key in all nodes in the cluster, both from their local hashmaps and L1 caches
remove(K, boolean) - Method in class org.jgroups.blocks.ReplCache
Removes key in all nodes in the cluster, both from their local hashmaps and L1 caches
remove(Object) - Method in class org.jgroups.blocks.ReplicatedHashMap
Removes the key (and its corresponding value) from this map.
remove(Object, Object) - Method in class org.jgroups.blocks.ReplicatedHashMap
remove(String) - Method in class org.jgroups.blocks.ReplicatedTree
Removes the node from the tree.
remove(String, String) - Method in class org.jgroups.blocks.ReplicatedTree
Removes key from the node's hashmap
remove(Address) - Method in class org.jgroups.Membership
Removes an member from the membership.
remove(Collection<Address>) - Method in class org.jgroups.Membership
Removes all the members contained in v from this membership
remove(String, Address) - Method in class org.jgroups.protocols.FILE_PING
 
remove(String, Address) - Method in class org.jgroups.protocols.JDBC_PING
 
remove(String, Address) - Method in class org.jgroups.protocols.RACKSPACE_PING
 
remove(String, Address) - Method in class org.jgroups.protocols.S3_PING
 
remove() - Method in class org.jgroups.protocols.SCOPE.MessageQueue
 
remove() - Method in class org.jgroups.protocols.STOMP.Connection
 
remove(String, Address) - Method in class org.jgroups.protocols.SWIFT_PING
 
remove(long) - Method in class org.jgroups.stack.DefaultRetransmitter
Remove the given sequence number from the list of seqnos eligible for retransmission.
remove(long, boolean) - Method in class org.jgroups.stack.DefaultRetransmitter
Removes the given seqno and all seqnos lower than it
remove() - Method in class org.jgroups.stack.NakReceiverWindow
 
remove(boolean, boolean) - Method in class org.jgroups.stack.NakReceiverWindow
 
remove(long) - Method in class org.jgroups.stack.RangeBasedRetransmitter
Remove the given sequence number from the list of seqnos eligible for retransmission.
remove(long) - Method in class org.jgroups.stack.Retransmitter
Remove the given sequence number from retransmission
remove(K) - Method in class org.jgroups.util.AgeOutCache
 
remove(Object) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
 
remove(Address) - Method in class org.jgroups.util.CreditMap
 
remove() - Method in class org.jgroups.util.Digest.MyIterator
 
remove(K) - Method in class org.jgroups.util.ExpiryCache
 
remove() - Method in class org.jgroups.util.Queue
Removes 1 element from head or blocks until next element has been added or until queue has been closed
remove(long) - Method in class org.jgroups.util.Queue
Removes 1 element from the head.
remove(Address) - Method in class org.jgroups.util.ResponseCollector
 
remove(List<Address>) - Method in class org.jgroups.util.ResponseCollector
 
remove(long) - Method in class org.jgroups.util.RetransmitTable
Removes the message with seqno from the table, nulls the index
remove(boolean) - Method in class org.jgroups.util.RingBuffer
Removes the next element (at hd +1).
remove() - Method in class org.jgroups.util.RingBuffer
Removes the next element (at hd +1).
remove() - Method in class org.jgroups.util.RingBuffer.RingBufferIterator
 
remove(boolean) - Method in class org.jgroups.util.RingBufferLockless
Removes the next element (at hd +1).
remove() - Method in class org.jgroups.util.RingBufferLockless
Removes the next element (at hd +1).
remove() - Method in class org.jgroups.util.RingBufferLockless.RingBufferIterator
 
remove(Object) - Method in class org.jgroups.util.RspList
 
remove(long) - Method in class org.jgroups.util.SeqnoList
Removes all seqnos <= seqno
remove() - Method in class org.jgroups.util.SeqnoList.SeqnoListIterator
 
remove() - Method in class org.jgroups.util.Table
 
remove(boolean) - Method in class org.jgroups.util.Table
Removes the next non-null element and nulls the index if nullify=true
remove(Address) - Static method in class org.jgroups.util.UUID
 
REMOVE_ADDRESS - Static variable in class org.jgroups.Event
 
removeAll(Collection<K>) - Method in class org.jgroups.blocks.LazyRemovalCache
 
removeAll(Collection<K>, boolean) - Method in class org.jgroups.blocks.LazyRemovalCache
 
removeAll(Collection<K>) - Method in class org.jgroups.util.AgeOutCache
 
removeAll(Collection<K>) - Method in class org.jgroups.util.ExpiryCache
 
removeAll(Collection<T>) - Method in class org.jgroups.util.SuppressCache
 
removeAll(Collection<Address>) - Static method in class org.jgroups.util.UUID
 
removeAllConnections() - Method in class org.jgroups.protocols.UNICAST
This method is public only so it can be invoked by unit testing, but should not otherwise be used !
removeAllConnections() - Method in class org.jgroups.protocols.UNICAST2
This method is public only so it can be invoked by unit testing, but should not otherwise be used !
removeAllQueues() - Method in class org.jgroups.protocols.SCOPE
 
removeAndDeliver(AtomicBoolean, Table<Message>) - Method in class org.jgroups.protocols.UNICAST
 
removeChangeListener(Cache.ChangeListener) - Method in class org.jgroups.blocks.Cache
 
removeChangeListener(ReplCache.ChangeListener) - Method in class org.jgroups.blocks.ReplCache
 
removeChannelListener(ChannelListener) - Method in class org.jgroups.blocks.MessageDispatcher
 
removeChannelListener(ChannelListener) - Method in class org.jgroups.Channel
Removes a ChannelListener previously installed
removeClientLock(String, Owner) - Method in class org.jgroups.protocols.Locking
 
removeConnection(Address) - Method in class org.jgroups.blocks.AbstractConnectionMap
 
removeConnection(Address) - Method in class org.jgroups.blocks.BasicConnectionTable
Remove addrfrom connection table.
removeConnection(Address) - Method in class org.jgroups.protocols.UNICAST
Removes and resets from connection table (which is already locked).
removeConnection(Address) - Method in class org.jgroups.protocols.UNICAST2
Removes and resets from connection table (which is already locked).
removeConnectionListener(BasicConnectionTable.ConnectionListener) - Method in class org.jgroups.blocks.BasicConnectionTable
 
removeConnectionMapListener(AbstractConnectionMap.ConnectionMapListener<V>) - Method in class org.jgroups.blocks.AbstractConnectionMap
 
removeConnectionMapListener(AbstractConnectionMap.ConnectionMapListener<TCPConnectionMap.TCPConnection>) - Method in class org.jgroups.blocks.TCPConnectionMap
 
removeDeprecatedProperties(Object, Map<String, String>) - Static method in class org.jgroups.stack.Configurator
 
removeElement(Object) - Method in class org.jgroups.util.Queue
removes a specific object from the queue.
removeExpired(long) - Method in class org.jgroups.util.SuppressCache
 
removeExpired(long) - Method in class org.jgroups.util.SuppressLog
 
removeExpiredElements() - Method in class org.jgroups.util.ExpiryCache
 
removeFromHead() - Method in class org.jgroups.util.BoundedList
 
removeGroupIfEmpty(String) - Method in class org.jgroups.stack.GossipRouter
 
removeHigherThan(long) - Method in class org.jgroups.util.SeqnoList
Removes all seqnos > seqno
removeIgnoredMember(Address) - Method in class org.jgroups.protocols.DISCARD
 
removeInitialHost(String, int) - Method in class org.jgroups.protocols.TCPGOSSIP
 
removeKeyForValue(Map<V, K>, K) - Static method in class org.jgroups.protocols.Executing
 
removeListener(StompConnection.Listener) - Method in class org.jgroups.client.StompConnection
 
removeLockListener(LockNotification) - Method in class org.jgroups.blocks.locking.LockService
 
removeLockListener(LockNotification) - Method in class org.jgroups.protocols.Locking
 
removeLogicalAddressFromCache(Address) - Method in class org.jgroups.protocols.TP
 
removeMany(AtomicBoolean) - Method in class org.jgroups.stack.NakReceiverWindow
Removes as many messages as possible
removeMany(AtomicBoolean, boolean, int) - Method in class org.jgroups.stack.NakReceiverWindow
Removes as many messages as possible
removeMany(boolean, int) - Method in class org.jgroups.util.RingBuffer
 
removeMany(AtomicBoolean, boolean, int) - Method in class org.jgroups.util.RingBuffer
 
removeMany(boolean, int) - Method in class org.jgroups.util.RingBufferLockless
 
removeMany(AtomicBoolean, boolean, int) - Method in class org.jgroups.util.RingBufferLockless
 
removeMany(boolean, int) - Method in class org.jgroups.util.Table
 
removeMany(AtomicBoolean, boolean, int) - Method in class org.jgroups.util.Table
 
removeMarkedElements(boolean) - Method in class org.jgroups.blocks.LazyRemovalCache
Removes elements marked as removable
removeMarkedElements() - Method in class org.jgroups.blocks.LazyRemovalCache
Removes elements marked as removable
removeMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.PartitionedHashMap
 
removeMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.ReplCache
 
removeNode(Object) - Method in class org.jgroups.demos.Topology
 
removeNode(Object) - Method in class org.jgroups.demos.wb.GraphPanel
 
removeNode(Object) - Method in class org.jgroups.demos.wb.Whiteboard
 
removeNodeFromDisk(Address) - Method in class org.jgroups.protocols.PDC
 
removeNotifier(ReplicatedHashMap.Notification) - Method in class org.jgroups.blocks.ReplicatedHashMap
 
removeProtocol(String) - Method in class org.jgroups.stack.ProtocolStack
Removes a protocol from the stack.
removeProtocol(Class...) - Method in class org.jgroups.stack.ProtocolStack
 
removeProtocol(Class) - Method in class org.jgroups.stack.ProtocolStack
 
removeProtocols(String...) - Method in class org.jgroups.stack.ProtocolStack
 
removeProvidedDownServices(Protocol, List<Integer>) - Static method in class org.jgroups.stack.Configurator
Removes all events provided by the protocol above protocol from events
removeProvidedUpServices(Protocol, List<Integer>) - Static method in class org.jgroups.stack.Configurator
Removes all events provided by the protocol below protocol from events
removeReceiveConnection(Address) - Method in class org.jgroups.protocols.UNICAST
 
removeReceiveConnection(Address) - Method in class org.jgroups.protocols.UNICAST2
 
removeReplicatedTreeListener(ReplicatedTree.ReplicatedTreeListener) - Method in class org.jgroups.blocks.ReplicatedTree
 
removeRequest(Locking.Type, Owner) - Method in class org.jgroups.protocols.Locking.ServerLock
 
removeRequester(Address) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
removeScope(Address, short) - Method in class org.jgroups.protocols.SCOPE
 
removeSendConnection(Address) - Method in class org.jgroups.protocols.UNICAST
 
removeSendConnection(Address) - Method in class org.jgroups.protocols.UNICAST2
 
removeSuspect(Address) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
 
removeWait(long) - Method in class org.jgroups.util.Queue
 
removeWaiter(Owner) - Method in class org.jgroups.protocols.Locking.ServerCondition
 
renameThread(String, Thread) - Method in class org.jgroups.util.DefaultThreadFactory
 
renameThread(String, Thread, String, String) - Method in class org.jgroups.util.DefaultThreadFactory
Names a thread according to base_name, cluster name and local address.
renameThread(Thread, String, String) - Method in class org.jgroups.util.DefaultThreadFactory
 
renameThread(Thread) - Method in class org.jgroups.util.DefaultThreadFactory
 
renameThread(String, Thread) - Method in interface org.jgroups.util.ThreadFactory
 
renameThreads() - Method in class org.jgroups.util.LazyThreadFactory
 
repaint() - Method in class org.jgroups.demos.wb.Whiteboard
 
replace(K, V, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
replace(K, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
replace(String, String, String) - Static method in class org.jgroups.conf.XmlConfigurator
 
replace(Digest) - Method in class org.jgroups.util.MutableDigest
 
replaceInCache(short, String) - Static method in class org.jgroups.protocols.relay.SiteUUID
 
replaceProperties(String, Properties) - Static method in class org.jgroups.util.Util
Go through the input string and replace any occurance of ${p} with the props.getProperty(p) value.
replaceProtocol(Protocol, Protocol) - Method in class org.jgroups.stack.ProtocolStack
Replaces one protocol instance with another.
ReplCache<K,V> - Class in org.jgroups.blocks
Cache which allows for replication factors per data items; the factor determines how many replicas of a key/value we create across the cluster.
See doc/design/ReplCache.txt for details.
ReplCache(String, String) - Constructor for class org.jgroups.blocks.ReplCache
 
ReplCache.ChangeListener - Interface in org.jgroups.blocks
 
ReplCache.ConsistentHashFunction<K> - Class in org.jgroups.blocks
 
ReplCache.ConsistentHashFunction() - Constructor for class org.jgroups.blocks.ReplCache.ConsistentHashFunction
 
ReplCache.HashFunction<K> - Interface in org.jgroups.blocks
 
ReplCache.HashFunctionFactory<K> - Interface in org.jgroups.blocks
 
ReplCache.Value<V> - Class in org.jgroups.blocks
 
ReplCache.Value(V, short) - Constructor for class org.jgroups.blocks.ReplCache.Value
 
ReplCacheDemo - Class in org.jgroups.demos
GUI demo of ReplCache
ReplCacheDemo() - Constructor for class org.jgroups.demos.ReplCacheDemo
 
REPLENISH - Static variable in class org.jgroups.protocols.FcHeader
 
replenish(Address, long) - Method in class org.jgroups.util.CreditMap
 
REPLENISH_HDR - Static variable in class org.jgroups.protocols.FlowControl
 
replenishAll() - Method in class org.jgroups.util.CreditMap
 
ReplicatedHashMap<K,V> - Class in org.jgroups.blocks
Implementation of a ConcurrentMap with replication of the contents across a cluster.
ReplicatedHashMap(Channel) - Constructor for class org.jgroups.blocks.ReplicatedHashMap
Constructs a new ReplicatedHashMap with channel.
ReplicatedHashMap(ConcurrentMap<K, V>, Channel) - Constructor for class org.jgroups.blocks.ReplicatedHashMap
Constructs a new ReplicatedHashMap using provided map instance.
ReplicatedHashMap.Notification<K,V> - Interface in org.jgroups.blocks
 
ReplicatedHashMapDemo - Class in org.jgroups.demos
Uses the ReplicatedHashMap building block, which subclasses java.util.HashMap and overrides the methods that modify the hashmap (e.g.
ReplicatedHashMapDemo() - Constructor for class org.jgroups.demos.ReplicatedHashMapDemo
 
ReplicatedMap<K,V> - Interface in org.jgroups.blocks
 
ReplicatedTree - Class in org.jgroups.blocks
A tree-like structure that is replicated across several members.
ReplicatedTree(String, String, long) - Constructor for class org.jgroups.blocks.ReplicatedTree
Creates a channel with the given properties.
ReplicatedTree(String, String, long, boolean) - Constructor for class org.jgroups.blocks.ReplicatedTree
 
ReplicatedTree() - Constructor for class org.jgroups.blocks.ReplicatedTree
 
ReplicatedTree(JChannel) - Constructor for class org.jgroups.blocks.ReplicatedTree
Expects an already connected channel.
ReplicatedTree.Node - Class in org.jgroups.blocks
 
ReplicatedTree.ReplicatedTreeListener - Interface in org.jgroups.blocks
 
REQ - Static variable in class org.jgroups.blocks.RequestCorrelator.Header
 
REQ - Static variable in class org.jgroups.protocols.RSVP.RsvpHeader
 
req_handler - Variable in class org.jgroups.blocks.MessageDispatcher
 
req_id - Variable in class org.jgroups.blocks.Request
 
req_marshaller - Variable in class org.jgroups.blocks.RpcDispatcher
Marshaller to marshall requests at the caller and unmarshal requests at the receiver(s)
REQ_ONLY - Static variable in class org.jgroups.protocols.RSVP.RsvpHeader
 
Request - Class in org.jgroups.blocks
Abstract class for a unicast or multicast request
Request(Message, RequestCorrelator, RequestOptions) - Constructor for class org.jgroups.blocks.Request
 
REQUEST - Static variable in class org.jgroups.protocols.COUNTER
 
request - Variable in class org.jgroups.protocols.Executing.Request
 
request_handler - Variable in class org.jgroups.blocks.RequestCorrelator
The handler for the incoming requests.
REQUEST_ID - Static variable in class org.jgroups.blocks.Request
To generate unique request IDs (see getRequestId())
request_msg - Variable in class org.jgroups.blocks.Request
 
RequestCorrelator - Class in org.jgroups.blocks
Framework to send requests and receive matching responses (matching on request ID).
RequestCorrelator(short, Protocol, RequestHandler, Address) - Constructor for class org.jgroups.blocks.RequestCorrelator
Constructor.
RequestCorrelator(Protocol, RequestHandler, Address) - Constructor for class org.jgroups.blocks.RequestCorrelator
 
RequestCorrelator.Header - Class in org.jgroups.blocks
The header for RequestCorrelator messages
RequestCorrelator.Header() - Constructor for class org.jgroups.blocks.RequestCorrelator.Header
Used for externalization
RequestCorrelator.Header(byte, long, boolean, short) - Constructor for class org.jgroups.blocks.RequestCorrelator.Header
 
RequestCorrelator.MultiDestinationHeader - Class in org.jgroups.blocks
 
RequestCorrelator.MultiDestinationHeader() - Constructor for class org.jgroups.blocks.RequestCorrelator.MultiDestinationHeader
 
RequestCorrelator.MultiDestinationHeader(byte, long, boolean, short, Collection<Address>) - Constructor for class org.jgroups.blocks.RequestCorrelator.MultiDestinationHeader
 
requester - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateGetter
 
requestFromBuffer(byte[], int, int) - Static method in class org.jgroups.protocols.COUNTER
 
RequestHandler - Interface in org.jgroups.blocks
 
requestId - Variable in class org.jgroups.protocols.Executing.Owner
 
RequestOptions - Class in org.jgroups.blocks
Class which captures a bunch of options relevant to remote method invocation or message sending
RequestOptions() - Constructor for class org.jgroups.blocks.RequestOptions
 
RequestOptions(ResponseMode, long, boolean, RspFilter, Message.Flag...) - Constructor for class org.jgroups.blocks.RequestOptions
 
RequestOptions(ResponseMode, long, boolean, RspFilter, short) - Constructor for class org.jgroups.blocks.RequestOptions
 
RequestOptions(ResponseMode, long, boolean, RspFilter) - Constructor for class org.jgroups.blocks.RequestOptions
 
RequestOptions(ResponseMode, long) - Constructor for class org.jgroups.blocks.RequestOptions
 
RequestOptions(ResponseMode, long, boolean) - Constructor for class org.jgroups.blocks.RequestOptions
 
RequestOptions(RequestOptions) - Constructor for class org.jgroups.blocks.RequestOptions
 
requests - Variable in class org.jgroups.blocks.RequestCorrelator
The table of pending requests (keys=Long (request IDs), values=RequestEntry)
requestToBuffer(COUNTER.Request) - Static method in class org.jgroups.protocols.COUNTER
 
requestToRequestType(COUNTER.Request) - Static method in class org.jgroups.protocols.COUNTER
 
requiredDownServices() - Method in class org.jgroups.protocols.MERGE2
 
requiredDownServices() - Method in class org.jgroups.protocols.pbcast.GMS
 
requiredDownServices() - Method in class org.jgroups.protocols.pbcast.STABLE
 
requiredDownServices() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
requiredDownServices() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
requiredDownServices() - Method in class org.jgroups.stack.Protocol
List of events that are required to be answered by some layer below
requiredUpServices() - Method in class org.jgroups.stack.Protocol
List of events that are required to be answered by some layer above
resend_delay - Variable in class org.jgroups.protocols.FORWARD_TO_COORD
Deprecated. 
resend_interval - Variable in class org.jgroups.protocols.RSVP
 
resend_task - Variable in class org.jgroups.protocols.RSVP.Entry
 
reset() - Method in class org.jgroups.protocols.ENCRYPT
Just remove if you don't need to reset any state
reset() - Static method in class org.jgroups.protocols.EXAMPLE
Just remove if you don't need to reset any state
reset() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
reset() - Method in class org.jgroups.protocols.relay.Relayer.Route
 
reset() - Method in class org.jgroups.stack.DefaultRetransmitter
Reset the retransmitter: clear all msgs and cancel all the respective tasks
reset() - Method in class org.jgroups.stack.RangeBasedRetransmitter
Reset the retransmitter: clear all msgs and cancel all the respective tasks
reset() - Method in class org.jgroups.stack.Retransmitter
Reset the retransmitter: clear all msgs and cancel all the respective tasks
reset(Collection<Address>) - Method in class org.jgroups.util.AckCollector
 
reset() - Method in class org.jgroups.util.ExposedByteArrayInputStream
 
reset(int) - Method in class org.jgroups.util.ExposedByteArrayOutputStream
Resets count and creates a new buf if the current buf is > max_size.
reset() - Method in class org.jgroups.util.ExposedByteArrayOutputStream
Resets the count field of this byte array output stream to zero, so that all currently accumulated output in the output stream is discarded.
reset() - Method in class org.jgroups.util.ExposedDataOutputStream
 
reset() - Method in class org.jgroups.util.Promise
Causes all waiting threads to return
reset() - Method in class org.jgroups.util.Queue
resets the queue.
reset() - Method in class org.jgroups.util.ResponseCollector
 
reset(Collection<Address>) - Method in class org.jgroups.util.ResponseCollector
 
reset(Address...) - Method in class org.jgroups.util.ResponseCollector
 
resetIgnoredMembers() - Method in class org.jgroups.protocols.DISCARD
 
resetStatistics() - Method in class org.jgroups.stack.Protocol
 
resetStats() - Method in class org.jgroups.JChannel
 
resetStats() - Method in class org.jgroups.protocols.DAISYCHAIN
 
resetStats() - Method in class org.jgroups.protocols.DISCARD
 
resetStats() - Method in class org.jgroups.protocols.Discovery
 
resetStats() - Method in class org.jgroups.protocols.FC
 
resetStats() - Method in class org.jgroups.protocols.FD
 
resetStats() - Method in class org.jgroups.protocols.FD_ALL
 
resetStats() - Method in class org.jgroups.protocols.FD_SOCK
 
resetStats() - Method in class org.jgroups.protocols.FlowControl
 
resetStats() - Method in class org.jgroups.protocols.FRAG
 
resetStats() - Method in class org.jgroups.protocols.FRAG2
 
resetStats() - Method in class org.jgroups.protocols.pbcast.GMS
 
resetStats() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
resetStats() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
resetStats() - Method in class org.jgroups.protocols.pbcast.STABLE
 
resetStats() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
resetStats() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
resetStats() - Method in class org.jgroups.protocols.RATE_LIMITER
 
resetStats() - Method in class org.jgroups.protocols.relay.RELAY2
 
resetStats() - Method in class org.jgroups.protocols.SEQUENCER
 
resetStats() - Method in class org.jgroups.protocols.STATS
 
resetStats() - Method in class org.jgroups.protocols.tom.TOA
 
resetStats() - Method in class org.jgroups.protocols.TP
 
resetStats() - Method in class org.jgroups.protocols.UNICAST
 
resetStats() - Method in class org.jgroups.protocols.UNICAST2
 
resetStats() - Method in class org.jgroups.stack.Protocol
 
resetStats() - Method in class org.jgroups.util.Table
 
resize() - Method in class org.jgroups.util.MutableDigest
 
resize(long) - Method in class org.jgroups.util.RetransmitTable
Moves rows down the matrix, by removing purged rows.
resize(long) - Method in class org.jgroups.util.Table
Moves rows down the matrix, by removing purged rows.
RESIZE_FACTOR - Static variable in class org.jgroups.util.MutableDigest
 
resize_factor - Variable in class org.jgroups.util.RetransmitTable
 
resize_factor - Variable in class org.jgroups.util.Table
 
RESOLVE_DNS - Static variable in class org.jgroups.Global
 
resolveAndAssignField(Object, Field, Map<String, String>) - Static method in class org.jgroups.stack.Configurator
 
resolveAndAssignFields(Object, Map<String, String>) - Static method in class org.jgroups.stack.Configurator
 
resolveAndInvokePropertyMethod(Object, Method, Map<String, String>) - Static method in class org.jgroups.stack.Configurator
 
resolveAndInvokePropertyMethods(Object, Map<String, String>) - Static method in class org.jgroups.stack.Configurator
 
resource_bundle - Static variable in class org.jgroups.util.Util
 
ResourceDMBean - Class in org.jgroups.jmx
A DynamicMBean wrapping an annotated object instance.
ResourceDMBean(Object) - Constructor for class org.jgroups.jmx.ResourceDMBean
 
ResourceManager - Class in org.jgroups.util
Manages resources such as multicast addresses and multicast ports, and TCP ports.
ResourceManager.IpAddressRep - Interface in org.jgroups.util
 
RESPONSE - Static variable in class org.jgroups.auth.DemoToken.DemoHeader
 
RESPONSE - Static variable in class org.jgroups.protocols.COUNTER
 
ResponseCollector<T> - Class in org.jgroups.util
Similar to AckCollector, but collects responses, not just acks.
ResponseCollector(Collection<Address>) - Constructor for class org.jgroups.util.ResponseCollector
 
ResponseCollector(Address...) - Constructor for class org.jgroups.util.ResponseCollector
 
ResponseCollector() - Constructor for class org.jgroups.util.ResponseCollector
 
responseFromBuffer(byte[], int, int) - Static method in class org.jgroups.protocols.COUNTER
 
ResponseMode - Enum in org.jgroups.blocks
Enum capturing the various response modes for RPCs
responseReceived() - Method in class org.jgroups.blocks.UnicastRequest
 
responses - Variable in class org.jgroups.protocols.COUNTER.ReconciliationTask
 
responsesComplete() - Method in class org.jgroups.blocks.GroupRequest
 
responsesComplete() - Method in class org.jgroups.blocks.Request
 
responsesComplete(long) - Method in class org.jgroups.blocks.Request
This method runs with lock locked (called by execute()).
responsesComplete() - Method in class org.jgroups.blocks.UnicastRequest
 
responseToBuffer(COUNTER.Response) - Static method in class org.jgroups.protocols.COUNTER
 
responseToResponseType(COUNTER.Response) - Static method in class org.jgroups.protocols.COUNTER
 
result - Variable in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture.Sync
The result to return from get()
result - Variable in class org.jgroups.blocks.executor.ExecutionService.RunnableAdapter
 
result - Variable in class org.jgroups.blocks.UnicastRequest
 
result - Variable in class org.jgroups.protocols.COUNTER.BooleanResponse
 
result - Variable in class org.jgroups.protocols.COUNTER.ValueResponse
 
result - Variable in class org.jgroups.protocols.pbcast.NAKACK2.Counter
 
result - Variable in class org.jgroups.util.Table.Counter
 
resultReturned(Object) - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
 
resultReturned(Object) - Method in interface org.jgroups.blocks.executor.ExecutorNotification
 
RESUME - Static variable in class org.jgroups.Event
 
RESUME_STABLE - Static variable in class org.jgroups.Event
 
resumeViewHandler() - Method in class org.jgroups.protocols.pbcast.GMS
 
retainAll(Collection<Address>) - Method in class org.jgroups.blocks.AbstractConnectionMap
Removes all connections which are not in current_mbrs
retainAll(Collection<Address>) - Method in class org.jgroups.blocks.BasicConnectionTable
Removes all connections from ConnectionTable which are not in current_mbrs
retainAll(Collection<K>) - Method in class org.jgroups.blocks.LazyRemovalCache
 
retainAll(Collection<K>, boolean) - Method in class org.jgroups.blocks.LazyRemovalCache
 
retainAll(Collection<Address>) - Method in class org.jgroups.blocks.TCPConnectionMap
 
retainAll(Collection<Address>) - Method in class org.jgroups.Membership
 
retainAll(Collection<Address>) - Method in class org.jgroups.protocols.BasicTCP
 
retainAll(List<Address>) - Method in class org.jgroups.protocols.PEER_LOCK.PeerLock
 
retainAll(Collection<Address>) - Method in class org.jgroups.protocols.RSVP.Entry
 
retainAll(Collection<Address>) - Method in class org.jgroups.protocols.TCP
 
retainAll(Collection<Address>) - Method in class org.jgroups.protocols.TCP_NIO
 
retainAll(Collection<Address>) - Method in class org.jgroups.util.AckCollector
 
retainAll(List<Address>) - Method in class org.jgroups.util.ResponseCollector
 
retainAll(Collection<T>) - Method in class org.jgroups.util.SuppressCache
 
retainAll(Collection<Address>) - Static method in class org.jgroups.util.UUID
 
retransmit(long, long, Address) - Method in class org.jgroups.protocols.pbcast.NAKACK
Implementation of Retransmitter.RetransmitCommand.
retransmit(long, long, Address, boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK
 
retransmit(long, long, Address) - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
retransmit(long, long, Address, boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
retransmit(SeqnoList, Address, boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
retransmit(Message) - Method in class org.jgroups.protocols.UNICAST
Called by AckSenderWindow to resend messages for which no ACK has been received yet
retransmit(SeqnoList, Address) - Method in class org.jgroups.protocols.UNICAST2
 
retransmit(long, long, Address) - Method in interface org.jgroups.stack.Retransmitter.RetransmitCommand
Get the missing messages between sequence numbers first_seqno and last_seqno.
retransmit_timeouts - Variable in class org.jgroups.stack.Retransmitter
Default retransmit intervals (ms) - exponential approx.
RetransmitTable - Class in org.jgroups.util
A store for messages to be retransmitted or delivered.
RetransmitTable() - Constructor for class org.jgroups.util.RetransmitTable
 
RetransmitTable(int, int, long) - Constructor for class org.jgroups.util.RetransmitTable
 
RetransmitTable(int, int, long, double) - Constructor for class org.jgroups.util.RetransmitTable
 
RetransmitTable(int, int, long, double, long, boolean) - Constructor for class org.jgroups.util.RetransmitTable
 
Retransmitter - Class in org.jgroups.stack
Abstract class of a retransmitter.
Retransmitter(Address, Retransmitter.RetransmitCommand, TimeScheduler) - Constructor for class org.jgroups.stack.Retransmitter
Create a new Retransmitter associated with the given sender address
Retransmitter.RetransmitCommand - Interface in org.jgroups.stack
Retransmit command (see Gamma et al.) used to retrieve missing messages
Retransmitter.Task - Class in org.jgroups.stack
 
Retransmitter.Task(Interval, Retransmitter.RetransmitCommand, Address) - Constructor for class org.jgroups.stack.Retransmitter.Task
 
return_entire_cache - Variable in class org.jgroups.protocols.Discovery
 
retval - Variable in class org.jgroups.util.Rsp
The value from the response
RingBuffer<T> - Class in org.jgroups.util
Ring buffer, implemented with a circular array.
RingBuffer(int, long) - Constructor for class org.jgroups.util.RingBuffer
Creates a RingBuffer
RingBuffer.RingBufferIterator<T> - Class in org.jgroups.util
 
RingBuffer.RingBufferIterator(T[]) - Constructor for class org.jgroups.util.RingBuffer.RingBufferIterator
 
RingBufferLockless<T> - Class in org.jgroups.util
Ring buffer, implemented with a circular array.
RingBufferLockless(int, long) - Constructor for class org.jgroups.util.RingBufferLockless
Creates a RingBuffer
RingBufferLockless.RingBufferIterator<T> - Class in org.jgroups.util
 
RingBufferLockless.RingBufferIterator(AtomicReferenceArray<T>) - Constructor for class org.jgroups.util.RingBufferLockless.RingBufferIterator
 
root_dir - Variable in class org.jgroups.protocols.FILE_PING
 
root_dir - Variable in class org.jgroups.protocols.PDC
 
ROTATION_TIME - Variable in class org.jgroups.util.HashedTimingWheel
 
round - Variable in class org.jgroups.util.HashedTimingWheel.MyTask
 
route(SiteAddress, SiteAddress, Message) - Method in class org.jgroups.protocols.relay.RELAY2
Routes the message to the target destination, used by a site master (coordinator)
router_host - Variable in class org.jgroups.stack.RouterStub
 
router_port - Variable in class org.jgroups.stack.RouterStub
 
RouterStub - Class in org.jgroups.stack
Client stub that talks to a remote GossipRouter
RouterStub(String, int, InetAddress, RouterStub.ConnectionListener) - Constructor for class org.jgroups.stack.RouterStub
Creates a stub for a remote Router object.
RouterStub.ConnectionListener - Interface in org.jgroups.stack
 
RouterStub.ConnectionStatus - Enum in org.jgroups.stack
 
RouterStubManager - Class in org.jgroups.stack
 
RouterStubManager(Protocol, String, Address, long) - Constructor for class org.jgroups.stack.RouterStubManager
 
routes - Variable in class org.jgroups.protocols.relay.Relayer
The routing table.
RPC_TIMEOUT - Static variable in class org.jgroups.demos.RelayDemoRpc
 
RpcDispatcher - Class in org.jgroups.blocks
This class allows a programmer to invoke remote methods in all (or single) group members and optionally wait for the return value(s).
RpcDispatcher() - Constructor for class org.jgroups.blocks.RpcDispatcher
 
RpcDispatcher(Channel, MessageListener, MembershipListener, Object) - Constructor for class org.jgroups.blocks.RpcDispatcher
 
RpcDispatcher(Channel, Object) - Constructor for class org.jgroups.blocks.RpcDispatcher
 
RpcDispatcher.Marshaller - Interface in org.jgroups.blocks
 
RSP - Static variable in class org.jgroups.blocks.RequestCorrelator.Header
 
RSP - Static variable in class org.jgroups.protocols.RSVP.RsvpHeader
 
Rsp<T> - Class in org.jgroups.util
Class that represents a response from a communication
Rsp(Address) - Constructor for class org.jgroups.util.Rsp
 
Rsp(Address, T) - Constructor for class org.jgroups.util.Rsp
 
Rsp(Address, Throwable) - Constructor for class org.jgroups.util.Rsp
 
rsp_expected - Variable in class org.jgroups.blocks.RequestCorrelator.Header
msg is synchronous if true
rsp_filter - Variable in class org.jgroups.blocks.RequestOptions
Allows for filtering of responses
rsp_marshaller - Variable in class org.jgroups.blocks.RpcDispatcher
Marshaller to marshal responses at the receiver(s) and unmarshal responses at the caller
RspCollector - Interface in org.jgroups.blocks
 
RspFilter - Interface in org.jgroups.blocks
Interface defining when a group request is done.
RspList<T> - Class in org.jgroups.util
Contains responses from all members.
RspList() - Constructor for class org.jgroups.util.RspList
 
RspList(Collection<Rsp<T>>) - Constructor for class org.jgroups.util.RspList
Adds a list of responses
RSVP - Static variable in class org.jgroups.Message
 
RSVP - Class in org.jgroups.protocols
Protocol which implements synchronous messages (https://issues.jboss.org/browse/JGRP-1389).
RSVP() - Constructor for class org.jgroups.protocols.RSVP
 
RSVP.Entry - Class in org.jgroups.protocols
 
RSVP.Entry(Address) - Constructor for class org.jgroups.protocols.RSVP.Entry
Unicast entry
RSVP.Entry(Collection<Address>) - Constructor for class org.jgroups.protocols.RSVP.Entry
Multicast entry
RSVP.RsvpHeader - Class in org.jgroups.protocols
 
RSVP.RsvpHeader() - Constructor for class org.jgroups.protocols.RSVP.RsvpHeader
 
RSVP.RsvpHeader(byte, short) - Constructor for class org.jgroups.protocols.RSVP.RsvpHeader
 
Rule - Class in org.jgroups.protocols.rules
A rule with a condition and (optional) action.
Rule() - Constructor for class org.jgroups.protocols.rules.Rule
 
RULE - Static variable in class org.jgroups.protocols.rules.SUPERVISOR
 
rules - Variable in class org.jgroups.protocols.rules.SUPERVISOR
 
RULES - Static variable in class org.jgroups.protocols.rules.SUPERVISOR
 
run() - Method in class org.jgroups.blocks.ConnectionTableNIO
Acceptor thread.
run() - Method in class org.jgroups.blocks.executor.ExecutionRunner
 
run() - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
Sets this Future to the result of its computation unless it has been cancelled.
run() - Method in class org.jgroups.blocks.MemcachedConnector
 
run() - Method in class org.jgroups.blocks.TCPConnectionMap.ConnectionAcceptor
Acceptor thread.
run() - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection.ConnectionPeerReceiver
 
run() - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection.Sender
 
run() - Method in class org.jgroups.client.StompConnection
 
run() - Method in class org.jgroups.protocols.BPING
 
run() - Method in class org.jgroups.protocols.BSH
 
run() - Method in class org.jgroups.protocols.COUNTER.ReconciliationTask
 
run() - Method in class org.jgroups.protocols.FD.BroadcastTask
 
run() - Method in class org.jgroups.protocols.FD.Monitor
 
run() - Method in class org.jgroups.protocols.FD_ICMP.PingMonitor
 
run() - Method in class org.jgroups.protocols.FD_PING.PingMonitor
 
run() - Method in class org.jgroups.protocols.FD_SOCK
Runs as long as there are 2 members and more.
run() - Method in class org.jgroups.protocols.FILE_PING.WriterTask
 
run() - Method in class org.jgroups.protocols.MERGE3.InfoSender
 
run() - Method in class org.jgroups.protocols.MERGE3.ViewConsistencyChecker
 
run() - Method in class org.jgroups.protocols.MPING
 
run() - Method in class org.jgroups.protocols.pbcast.NAKACK2.RetransmitTask
 
run() - Method in class org.jgroups.protocols.pbcast.STABLE.ResumeTask
 
run() - Method in class org.jgroups.protocols.pbcast.STATE_SOCK.StateProviderAcceptor
 
run() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateGetter
 
run() - Method in class org.jgroups.protocols.RELAY.RemoteViewFetcher
 
run() - Method in class org.jgroups.protocols.rules.Rule
 
run() - Method in class org.jgroups.protocols.SCOPE.ExpiryTask
 
run() - Method in class org.jgroups.protocols.SCOPE.QueueThread
Try to remove as many messages as possible from the queue and pass them up.
run() - Method in class org.jgroups.protocols.SEQUENCER.Flusher
 
run() - Method in class org.jgroups.protocols.STOMP.Connection
 
run() - Method in class org.jgroups.protocols.STOMP
 
run() - Method in class org.jgroups.protocols.tom.DeliveryThread
 
run() - Method in class org.jgroups.protocols.TP.TransferQueueBundler
 
run() - Method in class org.jgroups.protocols.TP.TransferQueueBundler2
 
run() - Method in class org.jgroups.protocols.TUNNEL.StubReceiver
 
run() - Method in class org.jgroups.protocols.UDP.PacketReceiver
 
run() - Method in class org.jgroups.protocols.UNICAST.ConnectionReaper
 
run() - Method in class org.jgroups.protocols.UNICAST.RetransmitTask
 
run() - Method in class org.jgroups.protocols.UNICAST2.ConnectionReaper
 
run() - Method in class org.jgroups.protocols.UNICAST2.RetransmitTask
 
run() - Method in class org.jgroups.protocols.VERIFY_SUSPECT
Started when a suspected member is added to suspects.
run() - Method in class org.jgroups.stack.DiagnosticsHandler
 
run() - Method in class org.jgroups.stack.Retransmitter.Task
 
run() - Method in class org.jgroups.util.DefaultTimeScheduler.RobustRunnable
 
run() - Method in class org.jgroups.util.DefaultTimeScheduler.TaskWrapper
 
run() - Method in class org.jgroups.util.ForwardQueue.Flusher
 
run() - Method in class org.jgroups.util.HashedTimingWheel.MyTask
 
run() - Method in class org.jgroups.util.HashedTimingWheel
 
run() - Method in class org.jgroups.util.TimeScheduler2.MyTask
 
run() - Method in class org.jgroups.util.TimeScheduler2
 
run() - Method in class org.jgroups.util.TimeScheduler3.RecurringTask
 
run() - Method in class org.jgroups.util.TimeScheduler3
 
run() - Method in class org.jgroups.util.TimeScheduler3.Task
 
runAsync(Runnable, ThreadFactory, String) - Static method in class org.jgroups.util.Util
Runs a task on a separate thread
runMessageGarbageCollection() - Method in class org.jgroups.protocols.pbcast.STABLE
 
runnable - Variable in class org.jgroups.util.TimeScheduler3.Task
 
runner - Variable in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture.Sync
The thread running task.
runner - Variable in class org.jgroups.client.StompConnection
 
runner - Variable in class org.jgroups.demos.ExecutionServiceDemo
 
runner - Variable in class org.jgroups.util.TimeScheduler3
Thread which removes tasks ready to be executed from the queue and submits them to the pool for execution
RUNNING - Static variable in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture.Sync
State value representing that task is running
running - Variable in class org.jgroups.blocks.TCPConnectionMap
 
running - Variable in class org.jgroups.blocks.TCPConnectionMap.TCPConnection.Sender
 
running - Variable in class org.jgroups.client.StompConnection
 
running - Variable in class org.jgroups.protocols.DAISYCHAIN
 
running - Variable in class org.jgroups.protocols.FlowControl
Whether FlowControl is still running, this is set to false when the protocol terminates (on stop())
running - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
running - Variable in class org.jgroups.protocols.pbcast.STATE_SOCK.StateProviderAcceptor
 
running - Variable in class org.jgroups.protocols.RATE_LIMITER
 
running - Variable in class org.jgroups.protocols.SEQUENCER
 
running - Variable in class org.jgroups.protocols.UNICAST
 
running - Variable in class org.jgroups.protocols.UNICAST2
 
running - Variable in class org.jgroups.util.ForwardQueue
 
running - Variable in class org.jgroups.util.HashedTimingWheel
 
running - Variable in class org.jgroups.util.RingBuffer
 
running - Variable in class org.jgroups.util.RingBufferLockless
 
running - Variable in class org.jgroups.util.TimeScheduler2
 
running - Variable in class org.jgroups.util.TimeScheduler3
 
runRequest(Address, ByteBuffer) - Method in class org.jgroups.blocks.ConnectionTableNIO
 

S

S3_PING - Class in org.jgroups.protocols
Discovery protocol using Amazon's S3 storage.
S3_PING() - Constructor for class org.jgroups.protocols.S3_PING
 
sameHost(Address, Address) - Static method in class org.jgroups.util.Util
Checks whether 2 Addresses are on the same host
sameSenders(Digest) - Method in class org.jgroups.util.Digest
Compares two digests and returns true if the senders are the same, otherwise false.
SampleRule - Class in org.jgroups.protocols.rules
 
SampleRule() - Constructor for class org.jgroups.protocols.rules.SampleRule
 
sanitize(String) - Static method in class org.jgroups.protocols.S3_PING
Sanitizes bucket and folder names according to AWS guidelines
sanitizeViews(Map<Address, View>) - Static method in class org.jgroups.protocols.pbcast.Merger
Removes all members from a given view which don't have us in their view (https://jira.jboss.org/browse/JGRP-1061).
sanityCheck(List<Protocol>) - Static method in class org.jgroups.stack.Configurator
Throws an exception if sanity check fails.
sanityCheck(byte[], int, int) - Static method in class org.jgroups.util.BlockingInputStream
Verifies that length doesn't exceed a buffer's length
saturation() - Method in class org.jgroups.util.RingBuffer
 
saturation() - Method in class org.jgroups.util.RingBufferLockless
 
sayName() - Method in class org.jgroups.demos.JmxDemo
 
sb - Variable in class org.jgroups.util.Table.Dump
 
schedule(Runnable, long, TimeUnit) - Method in class org.jgroups.util.HashedTimingWheel
 
schedule(Runnable, long, TimeUnit) - Method in class org.jgroups.util.MockTimeScheduler
 
schedule(Runnable, long, TimeUnit) - Method in interface org.jgroups.util.TimeScheduler
Creates and executes a one-shot action that becomes enabled after the given delay.
schedule(Runnable, long, TimeUnit) - Method in class org.jgroups.util.TimeScheduler2
 
schedule(Runnable, long, TimeUnit) - Method in class org.jgroups.util.TimeScheduler3
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.jgroups.util.HashedTimingWheel
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.jgroups.util.MockTimeScheduler
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface org.jgroups.util.TimeScheduler
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period; that is executions will commence after initialDelay then initialDelay+period, then initialDelay + 2 * period, and so on.
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.jgroups.util.TimeScheduler2
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.jgroups.util.TimeScheduler3
 
scheduleRecurring(Runnable, TimeScheduler3.TaskType, long, long, TimeUnit) - Method in class org.jgroups.util.TimeScheduler3
 
scheduleWithDynamicInterval(TimeScheduler.Task) - Method in class org.jgroups.util.DefaultTimeScheduler
Schedule a task for execution at varying intervals.
scheduleWithDynamicInterval(TimeScheduler.Task) - Method in class org.jgroups.util.HashedTimingWheel
Schedule a task for execution at varying intervals.
scheduleWithDynamicInterval(TimeScheduler.Task) - Method in class org.jgroups.util.MockTimeScheduler
 
scheduleWithDynamicInterval(TimeScheduler.Task) - Method in interface org.jgroups.util.TimeScheduler
Schedule a task for execution at varying intervals.
scheduleWithDynamicInterval(TimeScheduler.Task) - Method in class org.jgroups.util.TimeScheduler2
Schedule a task for execution at varying intervals.
scheduleWithDynamicInterval(TimeScheduler.Task) - Method in class org.jgroups.util.TimeScheduler3
Schedule a task for execution at varying intervals.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.jgroups.util.DefaultTimeScheduler
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.jgroups.util.HashedTimingWheel
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.jgroups.util.MockTimeScheduler
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in interface org.jgroups.util.TimeScheduler
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given delay between the termination of one execution and the commencement of the next.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.jgroups.util.TimeScheduler2
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.jgroups.util.TimeScheduler3
 
scope - Variable in class org.jgroups.blocks.RequestOptions
The scope of a message, allows for concurrent delivery of messages from the same sender
SCOPE - Class in org.jgroups.protocols
Implements https://jira.jboss.org/jira/browse/JGRP-822, which allows for concurrent delivery of messages from the same sender based on scopes.
SCOPE() - Constructor for class org.jgroups.protocols.SCOPE
 
SCOPE.ExpiryTask - Class in org.jgroups.protocols
 
SCOPE.ExpiryTask() - Constructor for class org.jgroups.protocols.SCOPE.ExpiryTask
 
SCOPE.MessageQueue - Class in org.jgroups.protocols
 
SCOPE.MessageQueue() - Constructor for class org.jgroups.protocols.SCOPE.MessageQueue
 
SCOPE.QueueThread - Class in org.jgroups.protocols
 
SCOPE.QueueThread(SCOPE.MessageQueue) - Constructor for class org.jgroups.protocols.SCOPE.QueueThread
 
SCOPE.ScopeHeader - Class in org.jgroups.protocols
 
SCOPE.ScopeHeader() - Constructor for class org.jgroups.protocols.SCOPE.ScopeHeader
 
SCOPE_ID - Static variable in class org.jgroups.Global
 
SCOPED - Static variable in class org.jgroups.Message
 
seal() - Method in class org.jgroups.util.MutableDigest
Seals the instance against modifications
sealed - Variable in class org.jgroups.util.MutableDigest
 
secret_access_key - Variable in class org.jgroups.protocols.S3_PING
 
SECRETKEY - Static variable in class org.jgroups.protocols.ENCRYPT.EncryptHeader
 
SECRETKEY_READY - Static variable in class org.jgroups.protocols.ENCRYPT.EncryptHeader
 
segment_capacity - Variable in class org.jgroups.protocols.UNICAST
Deprecated. 
select_all_pingdata_sql - Variable in class org.jgroups.protocols.JDBC_PING
 
send(Address, byte[], int, int) - Method in class org.jgroups.blocks.BasicConnectionTable
 
send(Address, byte[], int, int) - Method in class org.jgroups.blocks.TCPConnectionMap
 
send(byte[], int, int) - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
 
send(Message) - Method in class org.jgroups.Channel
Sends a message.
send(Address, Object) - Method in class org.jgroups.Channel
Helper method to create a Message with given parameters and invoke Channel.send(Message).
send(Address, byte[]) - Method in class org.jgroups.Channel
Sends a message.
send(Address, byte[], int, int) - Method in class org.jgroups.Channel
Sends a message to a destination.
send(String, byte[], int, int, String...) - Method in class org.jgroups.client.StompConnection
 
send(String, String...) - Method in class org.jgroups.client.StompConnection
Sends an INFO without body
send(String, byte[], int, int) - Method in class org.jgroups.client.StompConnection
 
send(String, byte[]) - Method in class org.jgroups.client.StompConnection
 
send(String) - Method in class org.jgroups.demos.StompChat
 
send(Message) - Method in class org.jgroups.JChannel
 
send(Address, Object) - Method in class org.jgroups.JChannel
 
send(Address, byte[]) - Method in class org.jgroups.JChannel
 
send(Address, byte[], int, int) - Method in class org.jgroups.JChannel
 
send(Address, byte[], int, int) - Method in class org.jgroups.protocols.BasicTCP
 
send(Address, Buffer) - Method in class org.jgroups.protocols.COUNTER
 
send(Address, long, byte) - Method in class org.jgroups.protocols.FORWARD_TO_COORD
 
send(Event, Message) - Method in class org.jgroups.protocols.pbcast.NAKACK
Adds the message to the sent_msgs table and then passes it down the stack.
send(Event, Message) - Method in class org.jgroups.protocols.pbcast.NAKACK2
Adds the message to the sent_msgs table and then passes it down the stack.
send(short, Address, Address, Message) - Method in class org.jgroups.protocols.relay.Relayer.Route
 
send(Address, byte[], int, int) - Method in class org.jgroups.protocols.TCP
 
send(Address, byte[], int, int) - Method in class org.jgroups.protocols.TCP_NIO
 
send(Message) - Method in interface org.jgroups.protocols.TP.Bundler
 
send(Message) - Method in class org.jgroups.protocols.TP.DefaultBundler
 
send(Message) - Method in class org.jgroups.protocols.TP.DefaultBundler2
 
send(Message, Address, boolean) - Method in class org.jgroups.protocols.TP
Serializes and sends a message.
send(Message) - Method in class org.jgroups.protocols.TP.TransferQueueBundler
 
send(Message) - Method in class org.jgroups.protocols.TP.TransferQueueBundler2
 
send(Message, Address, boolean) - Method in class org.jgroups.protocols.TUNNEL
 
send(Message, Event) - Method in class org.jgroups.protocols.UNICAST
 
send(long, Message) - Method in class org.jgroups.util.ForwardQueue
 
send_buf_size - Variable in class org.jgroups.blocks.TCPConnectionMap
 
send_buf_size - Variable in class org.jgroups.protocols.BasicTCP
 
send_cond - Variable in class org.jgroups.protocols.SEQUENCER
 
send_cond - Variable in class org.jgroups.util.ForwardQueue
 
SEND_FIRST_SEQNO - Static variable in class org.jgroups.protocols.UNICAST.UnicastHeader
 
SEND_FIRST_SEQNO - Static variable in class org.jgroups.protocols.UNICAST2.Unicast2Header
 
send_info - Variable in class org.jgroups.protocols.STOMP
 
send_lock - Variable in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
 
send_lock - Variable in class org.jgroups.protocols.SEQUENCER
 
send_lock - Variable in class org.jgroups.util.ForwardQueue
 
send_queue_size - Variable in class org.jgroups.blocks.TCPConnectionMap
 
send_queue_size - Variable in class org.jgroups.protocols.BasicTCP
 
send_table - Variable in class org.jgroups.protocols.UNICAST
 
send_table - Variable in class org.jgroups.protocols.UNICAST2
 
sendAck(Address, long) - Method in class org.jgroups.protocols.FORWARD_TO_COORD
 
sendAck(Address, long) - Method in class org.jgroups.protocols.UNICAST
 
sendAwaitConditionRequest(String, Owner) - Method in class org.jgroups.protocols.CENTRAL_LOCK
 
sendAwaitConditionRequest(String, Owner) - Method in class org.jgroups.protocols.Locking
 
sendAwaitConditionRequest(String, Owner) - Method in class org.jgroups.protocols.PEER_LOCK
 
sendClearPanelMsg() - Method in class org.jgroups.demos.applets.DrawApplet
 
sendClearPanelMsg() - Method in class org.jgroups.demos.Draw
 
sendClearPanelMsg() - Method in class org.jgroups.demos.StompDraw
 
sendConnect() - Method in class org.jgroups.client.StompConnection
 
sendCounterNotFoundExceptionResponse(Address, Owner, String) - Method in class org.jgroups.protocols.COUNTER
 
sendCreateLockRequest(Address, String, Owner) - Method in class org.jgroups.protocols.CENTRAL_LOCK
 
sendCredit(Address, long) - Method in class org.jgroups.protocols.FlowControl
 
sendCreditRequest(Address, Long) - Method in class org.jgroups.protocols.FlowControl
We cannot send this request as OOB messages, as the credit request needs to queue up behind the regular messages; if a receiver cannot process the regular messages, that is a sign that the sender should be throttled !
sendDeleteAwaitConditionRequest(String, Owner) - Method in class org.jgroups.protocols.CENTRAL_LOCK
 
sendDeleteAwaitConditionRequest(String, Owner) - Method in class org.jgroups.protocols.Locking
 
sendDeleteAwaitConditionRequest(String, Owner) - Method in class org.jgroups.protocols.PEER_LOCK
 
sendDeleteLockRequest(Address, String) - Method in class org.jgroups.protocols.CENTRAL_LOCK
 
SendDialog - Class in org.jgroups.demos.wb
 
SendDialog(Frame, Node, String, RpcDispatcher) - Constructor for class org.jgroups.demos.wb.SendDialog
 
sendDiscoveryRequest(String, Promise, ViewId) - Method in class org.jgroups.protocols.Discovery
 
sendDiscoveryRequestsInParallel() - Method in class org.jgroups.protocols.Discovery
Whether or not to send each discovery request on a separate (timer) thread.
sendDiscoveryRequestsInParallel() - Method in class org.jgroups.protocols.FILE_PING
 
sendDiscoveryRequestsInParallel() - Method in class org.jgroups.protocols.PING
 
sendDiscoveryRequestsInParallel() - Method in class org.jgroups.protocols.TCPGOSSIP
 
sendDiscoveryRequestsInParallel() - Method in class org.jgroups.protocols.TCPPING
 
sendDiscoveryResponse(Address, List<PhysicalAddress>, boolean, boolean, String, Address) - Method in class org.jgroups.protocols.Discovery
 
sendEof(Address) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
sender - Variable in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
 
sender - Variable in class org.jgroups.protocols.pbcast.MergeData
 
sender - Variable in class org.jgroups.protocols.PingData
 
sender - Variable in class org.jgroups.stack.Retransmitter
 
sender - Variable in class org.jgroups.util.Rsp
The sender of this response
SenderManager - Class in org.jgroups.protocols.tom
Keeps track of all sent messages, until the final sequence number is known
SenderManager() - Constructor for class org.jgroups.protocols.tom.SenderManager
 
sendException(Address, Throwable) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
sendException(Address, Throwable) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
sendGetUsers() - Method in class org.jgroups.demos.StompChat
 
sendGrantLockRequest(String, Owner, long, boolean) - Method in class org.jgroups.protocols.CENTRAL_LOCK
 
sendGrantLockRequest(String, Owner, long, boolean) - Method in class org.jgroups.protocols.Locking
 
sendGrantLockRequest(String, Owner, long, boolean) - Method in class org.jgroups.protocols.PEER_LOCK
 
sendHeartbeatResponse(Address) - Method in class org.jgroups.protocols.FD
 
sendInfo() - Method in class org.jgroups.protocols.STOMP.Connection
 
sendJoinRejectionMessage(Address, String) - Method in class org.jgroups.protocols.AUTH
 
sendJoinResponse(JoinRsp, Address) - Method in class org.jgroups.protocols.pbcast.GMS
 
sendLocalAddress(Address) - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
Send the cookie first, then the our port number.
sendLockResponse(Locking.Type, Owner, String) - Method in class org.jgroups.protocols.Locking
 
sendMcastDiscoveryRequest(Message) - Method in class org.jgroups.protocols.BPING
 
sendMcastDiscoveryRequest(Message) - Method in class org.jgroups.protocols.Discovery
 
sendMcastDiscoveryRequest(Message) - Method in class org.jgroups.protocols.MPING
 
sendMergeRejectedResponse(Address, MergeId) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
sendMergeRejectedResponse(Address, MergeId) - Method in class org.jgroups.protocols.pbcast.Merger
 
sendMergeRejectionMessage(Address) - Method in class org.jgroups.protocols.AUTH
 
sendMergeSolicitation() - Method in class org.jgroups.protocols.MERGE2
Discovers members and detects whether we have multiple coordinator.
sendMessage(Message, RequestOptions) - Method in class org.jgroups.blocks.MessageDispatcher
Sends a unicast message and - depending on the options - returns a result
sendMessage(byte[], int, int) - Method in class org.jgroups.protocols.pbcast.STATE.StateOutputStream
 
sendMessageWithFuture(Message, RequestOptions) - Method in class org.jgroups.blocks.MessageDispatcher
Sends a unicast message to the target defined by msg.getDest() and returns a future
sendMulticast(byte[], int, int) - Method in class org.jgroups.protocols.BasicTCP
 
sendMulticast(byte[], int, int) - Method in class org.jgroups.protocols.SHARED_LOOPBACK
 
sendMulticast(byte[], int, int) - Method in class org.jgroups.protocols.TP
Send to all members in the group.
sendMulticast(byte[], int, int) - Method in class org.jgroups.protocols.TUNNEL
 
sendMulticast(byte[], int, int) - Method in class org.jgroups.protocols.UDP
 
sendNewConsumerRequest(Executing.Owner) - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
 
sendNewConsumerRequest(Executing.Owner) - Method in class org.jgroups.protocols.Executing
 
sendNewRunRequest(Executing.Owner) - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
 
sendNewRunRequest(Executing.Owner) - Method in class org.jgroups.protocols.Executing
 
sendNotCoord(Address, long) - Method in class org.jgroups.protocols.FORWARD_TO_COORD
 
sendOnLocalCluster(byte[], int, int) - Method in class org.jgroups.protocols.RELAY
 
sendRejectionMessage(byte, Address, String) - Method in class org.jgroups.protocols.AUTH
 
sendReleaseLockRequest(String, Owner) - Method in class org.jgroups.protocols.CENTRAL_LOCK
 
sendReleaseLockRequest(String, Owner) - Method in class org.jgroups.protocols.Locking
 
sendReleaseLockRequest(String, Owner) - Method in class org.jgroups.protocols.PEER_LOCK
 
sendRemoveConsumerRequest(Executing.Owner) - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
 
sendRemoveConsumerRequest(Executing.Owner) - Method in class org.jgroups.protocols.Executing
 
sendRemoveRunRequest(Executing.Owner) - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
 
sendRemoveRunRequest(Executing.Owner) - Method in class org.jgroups.protocols.Executing
 
sendRequest() - Method in class org.jgroups.blocks.GroupRequest
 
sendRequest(long, Collection<Address>, Message, RspCollector, RequestOptions) - Method in class org.jgroups.blocks.mux.MuxRequestCorrelator
 
sendRequest() - Method in class org.jgroups.blocks.Request
 
sendRequest(long, List<Address>, Message, RspCollector) - Method in class org.jgroups.blocks.RequestCorrelator
 
sendRequest(long, Collection<Address>, Message, RspCollector, RequestOptions) - Method in class org.jgroups.blocks.RequestCorrelator
Sends a request to a group.
sendRequest() - Method in class org.jgroups.blocks.UnicastRequest
 
sendRequest(Address, COUNTER.Request) - Method in class org.jgroups.protocols.COUNTER
 
sendRequest(Address, Executing.Type, long, Object) - Method in class org.jgroups.protocols.Executing
 
sendRequest(Address, Locking.Type, String, Owner, long, boolean) - Method in class org.jgroups.protocols.Locking
 
sendRequestForFirstSeqno(Address, long) - Method in class org.jgroups.protocols.UNICAST
 
sendRequestForFirstSeqno(Address, long) - Method in class org.jgroups.protocols.UNICAST2
 
sendResponse(Address, COUNTER.Response) - Method in class org.jgroups.protocols.COUNTER
 
sendResponse(Address, short) - Method in class org.jgroups.protocols.RSVP
 
sendResponse(DatagramSocket, SocketAddress, byte[]) - Static method in class org.jgroups.stack.DiagnosticsHandler
 
sendSignalConditionRequest(String, boolean) - Method in class org.jgroups.protocols.CENTRAL_LOCK
 
sendSignalConditionRequest(String, boolean) - Method in class org.jgroups.protocols.Locking
 
sendSignalConditionRequest(String, boolean) - Method in class org.jgroups.protocols.PEER_LOCK
 
sendSignalResponse(Owner, String) - Method in class org.jgroups.protocols.Locking
 
sendSiteUnreachableTo(Address, short) - Method in class org.jgroups.protocols.relay.RELAY2
Sends a SITE-UNREACHABLE message to the sender of the message.
sendStableMessage(Address, short, long, long) - Method in class org.jgroups.protocols.UNICAST2
 
sendStableMessages() - Method in class org.jgroups.protocols.UNICAST2
 
sendSubscribe(String) - Method in class org.jgroups.client.StompConnection
 
sendThreadRequest(Address, long, Executing.Type, long, Object) - Method in class org.jgroups.protocols.Executing
 
sendToAllMembers(List<RouterStub>, String, byte[], int, int) - Method in interface org.jgroups.protocols.TUNNEL.TUNNELPolicy
 
sendToAllMembers(String, byte[], int, int) - Method in class org.jgroups.stack.RouterStub
 
sendToAllPhysicalAddresses(byte[], int, int) - Method in class org.jgroups.protocols.TP
 
sendToBridges(Address, Message, short...) - Method in class org.jgroups.protocols.relay.RELAY2
Sends the message via all bridges excluding the excluded_sites bridges
sendToCoordinator(Executing.Type, long, Address) - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
 
sendToCoordinator(Executing.Type, long, Address) - Method in class org.jgroups.protocols.Executing
 
sendToMember(String, Address, byte[], int, int) - Method in class org.jgroups.stack.RouterStub
 
sendToSingleMember(Address, byte[], int, int) - Method in class org.jgroups.protocols.SHARED_LOOPBACK
 
sendToSingleMember(Address, byte[], int, int) - Method in class org.jgroups.protocols.TP
 
sendToSingleMember(List<RouterStub>, String, Address, byte[], int, int) - Method in interface org.jgroups.protocols.TUNNEL.TUNNELPolicy
 
sendUnicast(PhysicalAddress, byte[], int, int) - Method in class org.jgroups.protocols.BasicTCP
 
sendUnicast(PhysicalAddress, byte[], int, int) - Method in class org.jgroups.protocols.SHARED_LOOPBACK
 
sendUnicast(PhysicalAddress, byte[], int, int) - Method in class org.jgroups.protocols.TP
Send a unicast to 1 member.
sendUnicast(PhysicalAddress, byte[], int, int) - Method in class org.jgroups.protocols.TUNNEL
 
sendUnicast(PhysicalAddress, byte[], int, int) - Method in class org.jgroups.protocols.UDP
 
sendUnicastRequest(long, Address, Message, RspCollector) - Method in class org.jgroups.blocks.mux.MuxRequestCorrelator
 
sendUnicastRequest(long, Address, Message, RspCollector) - Method in class org.jgroups.blocks.RequestCorrelator
Sends a request to a single destination
sendUnsubscribe(String) - Method in class org.jgroups.client.StompConnection
 
sendViewOnLocalCluster(View, View, boolean, List<Address>) - Method in class org.jgroups.protocols.RELAY
 
sendViewOnLocalCluster(RELAY.ViewData, boolean, List<Address>) - Method in class org.jgroups.protocols.RELAY
 
sendViewOnLocalCluster(List<Address>, byte[]) - Method in class org.jgroups.protocols.RELAY
 
sendViewToRemote(RELAY.ViewData, boolean) - Method in class org.jgroups.protocols.RELAY
 
sendXmitRsp(Address, Message) - Method in class org.jgroups.protocols.pbcast.NAKACK2
Sends a message msg to the requester.
sent - Variable in class org.jgroups.protocols.UFC
Map: keys are members, values are credits left.
sent_bytes - Variable in class org.jgroups.JChannel
 
sent_msgs - Variable in class org.jgroups.JChannel
 
SEPARATOR - Static variable in class org.jgroups.blocks.ReplicatedTree
 
seqno - Variable in class org.jgroups.protocols.SEQUENCER
 
seqno - Variable in class org.jgroups.protocols.SEQUENCER.SequencerHeader
 
Seqno - Class in org.jgroups.util
Keeps track of a single message to retransmit
Seqno(long) - Constructor for class org.jgroups.util.Seqno
 
Seqno(long, boolean) - Constructor for class org.jgroups.util.Seqno
Only used to compare a long against a range in a TreeSet / TreeMap.
SeqnoComparator - Class in org.jgroups.util
 
SeqnoComparator() - Constructor for class org.jgroups.util.SeqnoComparator
 
SeqnoList - Class in org.jgroups.util
A list of sequence numbers (seqnos).
SeqnoList() - Constructor for class org.jgroups.util.SeqnoList
 
SeqnoList(long) - Constructor for class org.jgroups.util.SeqnoList
 
SeqnoList(long, long) - Constructor for class org.jgroups.util.SeqnoList
 
SeqnoList.Seqno - Class in org.jgroups.util
 
SeqnoList.Seqno(long) - Constructor for class org.jgroups.util.SeqnoList.Seqno
 
SeqnoList.SeqnoListIterator - Class in org.jgroups.util
 
SeqnoList.SeqnoListIterator() - Constructor for class org.jgroups.util.SeqnoList.SeqnoListIterator
 
SeqnoList.SeqnoRange - Class in org.jgroups.util
 
SeqnoList.SeqnoRange(long, long) - Constructor for class org.jgroups.util.SeqnoList.SeqnoRange
 
SeqnoRange - Class in org.jgroups.util
Keeps track of a range of messages to be retransmitted.
SeqnoRange(long, long) - Constructor for class org.jgroups.util.SeqnoRange
 
seqnos - Variable in class org.jgroups.util.Digest
 
seqnos - Variable in class org.jgroups.util.SeqnoList
 
SequenceNumberManager - Class in org.jgroups.protocols.tom
Manages the messages sequence number (keeps it up-to-date)
SequenceNumberManager() - Constructor for class org.jgroups.protocols.tom.SequenceNumberManager
 
SEQUENCER - Class in org.jgroups.protocols
Implementation of total order protocol using a sequencer.
SEQUENCER() - Constructor for class org.jgroups.protocols.SEQUENCER
 
SEQUENCER.Flusher - Class in org.jgroups.protocols
 
SEQUENCER.Flusher(Address) - Constructor for class org.jgroups.protocols.SEQUENCER.Flusher
 
SEQUENCER.SequencerHeader - Class in org.jgroups.protocols
 
SEQUENCER.SequencerHeader() - Constructor for class org.jgroups.protocols.SEQUENCER.SequencerHeader
 
SEQUENCER.SequencerHeader(byte) - Constructor for class org.jgroups.protocols.SEQUENCER.SequencerHeader
 
SEQUENCER.SequencerHeader(byte, long) - Constructor for class org.jgroups.protocols.SEQUENCER.SequencerHeader
 
serializableCallable(Constructor<? extends Callable>, Object...) - Static method in class org.jgroups.blocks.executor.Executions
This method should be used to convert a callable that would not normally be serializable, externalizable or streamable but has serializable, externalizable or streamable arguments to a constructor to construct it.
serializedSize() - Method in class org.jgroups.MergeView
 
serializedSize() - Method in class org.jgroups.protocols.pbcast.JoinRsp
 
serializedSize() - Method in class org.jgroups.protocols.tom.MessageID
 
serializedSize() - Method in class org.jgroups.util.Digest
 
serializedSize() - Method in class org.jgroups.util.Range
 
serializedSize() - Method in class org.jgroups.util.SeqnoList
 
serializedSize() - Method in class org.jgroups.View
 
serializedSize() - Method in class org.jgroups.ViewId
 
serializeWithoutView(PingData) - Method in class org.jgroups.protocols.Discovery
Creates a byte[] representation of the PingData, but DISCARDING the view it contains.
server_destinations - Variable in class org.jgroups.client.StompConnection
 
server_locks - Variable in class org.jgroups.protocols.Locking
 
server_obj - Variable in class org.jgroups.blocks.RpcDispatcher
 
SERVER_PUBKEY - Static variable in class org.jgroups.protocols.ENCRYPT.EncryptHeader
 
ServerGmsImpl - Class in org.jgroups.protocols.pbcast
Common super class for CoordGmsImpl and ParticipantGmsImpl
ServerGmsImpl(GMS) - Constructor for class org.jgroups.protocols.pbcast.ServerGmsImpl
 
serverSocket - Variable in class org.jgroups.protocols.pbcast.STATE_SOCK.StateProviderAcceptor
 
session_id - Variable in class org.jgroups.client.StompConnection
 
session_id - Variable in class org.jgroups.protocols.STOMP.Connection
 
set(long) - Method in interface org.jgroups.blocks.atomic.Counter
Sets the counter to a new value
set(Object) - Method in class org.jgroups.blocks.ConnectionTableNIO.MyFuture
 
set(V) - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
Sets the result of this Future to the given value unless this future has already been set or has been cancelled.
set(Collection<Address>) - Method in class org.jgroups.Membership
Clears the membership and adds all members of v This method will clear out all the old members of this membership by invoking the Clear method.
set(Membership) - Method in class org.jgroups.Membership
Clears the membership and adds all members of a given membership parameter.
set(long) - Method in class org.jgroups.protocols.COUNTER.CounterImpl
 
set(long) - Method in class org.jgroups.protocols.COUNTER.VersionedValue
 
set(long) - Method in class org.jgroups.protocols.FlowControl.Credit
 
set(int) - Method in class org.jgroups.util.FixedSizeBitSet
Sets the bit at the specified index to true.
set(long) - Method in class org.jgroups.util.Seqno
 
set(long) - Method in class org.jgroups.util.SeqnoRange
 
set(long...) - Method in class org.jgroups.util.SeqnoRange
 
SET_DIGEST - Static variable in class org.jgroups.Event
 
SET_LOCAL_ADDRESS - Static variable in class org.jgroups.Event
 
SET_PHYSICAL_ADDRESS - Static variable in class org.jgroups.Event
 
setAccountNumber(int) - Method in class org.jgroups.demos.JmxDemo
 
setAddress() - Method in class org.jgroups.JChannel
Generates new UUID and sets local address.
setAddress(String) - Method in class org.jgroups.util.DefaultThreadFactory
 
setAddress(String) - Method in class org.jgroups.util.LazyThreadFactory
 
setAddress(String) - Method in interface org.jgroups.util.ThreadFactory
 
setAddressGenerator(AddressGenerator) - Method in class org.jgroups.JChannel
Sets the new AddressGenerator.
setAnycasting(boolean) - Method in class org.jgroups.blocks.GroupRequest
 
setAnycasting(boolean) - Method in class org.jgroups.blocks.RequestOptions
 
setArgs(Object...) - Method in class org.jgroups.blocks.MethodCall
 
setAttribute(Attribute) - Method in class org.jgroups.jmx.ResourceDMBean
 
setAttributes(AttributeList) - Method in class org.jgroups.jmx.ResourceDMBean
 
setAuth(AUTH) - Method in class org.jgroups.auth.AuthToken
 
setAuthClass(String) - Method in class org.jgroups.protocols.AUTH
 
setAuthToken(AuthToken) - Method in class org.jgroups.protocols.AUTH
 
setAuthValue(String) - Method in class org.jgroups.auth.MD5Token
 
setAuthValue(String) - Method in class org.jgroups.auth.SimpleToken
 
setAutomaticPurging(boolean) - Method in class org.jgroups.util.RetransmitTable
 
setBacklog(int) - Method in class org.jgroups.stack.GossipRouter
 
setBindAddr(InetAddress) - Method in class org.jgroups.protocols.MPING
 
setBindAddress(InetAddress) - Method in class org.jgroups.blocks.MemcachedConnector
 
setBindAddress(InetAddress) - Method in class org.jgroups.protocols.TP
 
setBindAddress(String) - Method in class org.jgroups.stack.GossipRouter
 
setBindPort(int) - Method in class org.jgroups.protocols.BPING
 
setBindPort(int) - Method in class org.jgroups.protocols.TP
 
setBindToAllInterfaces(boolean) - Method in class org.jgroups.protocols.TP
 
setBlockForResults(boolean) - Method in class org.jgroups.blocks.Request
 
setBlockingUpdates(boolean) - Method in class org.jgroups.blocks.ReplicatedHashMap
Whether updates across the cluster should be asynchronous (default) or synchronous)
setBuffer(byte[]) - Method in class org.jgroups.Message
 
setBuffer(byte[], int, int) - Method in class org.jgroups.Message
Set the internal buffer to point to a subset of a given buffer
setBuffer(Buffer) - Method in class org.jgroups.Message
Note that the byte[] buffer passed as argument must not be modified.
setBufferSize(DatagramSocket, int, int) - Method in class org.jgroups.protocols.UDP
 
setBypass(boolean) - Method in class org.jgroups.protocols.pbcast.FLUSH
 
setBypassBundling(boolean) - Method in class org.jgroups.protocols.COUNTER
 
setBypassBundling(boolean) - Method in class org.jgroups.protocols.Executing
 
setBypassBundling(boolean) - Method in class org.jgroups.protocols.Locking
 
setCache(PartitionedHashMap<String, byte[]>) - Method in class org.jgroups.blocks.MemcachedConnector
 
setCachingTime(long) - Method in class org.jgroups.blocks.PartitionedHashMap
 
setCachingTime(long) - Method in class org.jgroups.blocks.ReplCache
 
setCallTimeout(long) - Method in class org.jgroups.blocks.PartitionedHashMap
 
setCallTimeout(long) - Method in class org.jgroups.blocks.ReplCache
 
setCertificate() - Method in class org.jgroups.auth.X509Token
Used during setup to get the certification from the keystore and encrypt the auth_value with the private key
setCertPassword(String) - Method in class org.jgroups.auth.X509Token
 
setChannel(JChannel) - Method in class org.jgroups.blocks.atomic.CounterService
 
setChannel(JChannel) - Method in class org.jgroups.blocks.executor.ExecutionRunner
 
setChannel(JChannel) - Method in class org.jgroups.blocks.executor.ExecutionService
 
setChannel(JChannel) - Method in class org.jgroups.blocks.locking.LockService
 
setChannel(Channel) - Method in class org.jgroups.blocks.MessageDispatcher
 
setChannel(JChannel) - Method in class org.jgroups.stack.ProtocolStack
 
setClusterName(String) - Method in class org.jgroups.blocks.PartitionedHashMap
 
setClusterName(String) - Method in class org.jgroups.blocks.ReplCache
 
setClusterName(String) - Method in class org.jgroups.util.DefaultThreadFactory
 
setClusterName(String) - Method in class org.jgroups.util.LazyThreadFactory
 
setClusterName(String) - Method in interface org.jgroups.util.ThreadFactory
 
setConnExpireTime(long) - Method in class org.jgroups.protocols.BasicTCP
 
setCopyMulticastMsgs(boolean) - Method in class org.jgroups.protocols.DUPL
 
setCopyUnicastMsgs(boolean) - Method in class org.jgroups.protocols.DUPL
 
setData(byte[], int, int) - Method in class org.jgroups.util.ExposedByteArrayInputStream
 
setDefaultHandler(T) - Method in interface org.jgroups.blocks.mux.Muxer
Sets the handler for messages that have no mux header.
setDefaultHandler(UpHandler) - Method in class org.jgroups.blocks.mux.MuxUpHandler
 
setDefaultReplicationCount(short) - Method in class org.jgroups.blocks.ReplCache
 
setDefaultThreadPool(Executor) - Method in class org.jgroups.protocols.TP
 
setDefaultThreadPoolThreadFactory(ThreadFactory) - Method in class org.jgroups.protocols.TP
 
setDefaultValues(List<Protocol>) - Static method in class org.jgroups.stack.Configurator
 
setDefaultValues(List<ProtocolConfiguration>, List<Protocol>, StackType) - Static method in class org.jgroups.stack.Configurator
 
setDefaultValues(List<Protocol>, StackType) - Static method in class org.jgroups.stack.Configurator
 
setDelay(long) - Method in class org.jgroups.protocols.DELAY_JOIN_REQ
 
setDeliveryTableMaxSize(int) - Method in class org.jgroups.protocols.SEQUENCER
 
setDeliveryTableMaxSize(int) - Method in class org.jgroups.util.ForwardQueue
 
setDesiredAverageGossip(long) - Method in class org.jgroups.protocols.pbcast.STABLE
 
setDest(Address) - Method in class org.jgroups.Message
 
setDiagnosticsHandler(DiagnosticsHandler) - Method in class org.jgroups.protocols.TP
Sets a DiagnosticsHandler.
setDigest(Digest) - Method in class org.jgroups.protocols.pbcast.GMS
Send down a SET_DIGEST event
setDigest(Digest) - Method in class org.jgroups.protocols.pbcast.NAKACK2
Creates a retransmit buffer for each sender in the digest according to the sender's seqno.
setDigest(Digest, boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
Sets or merges the digest.
setDiscardAll(boolean) - Method in class org.jgroups.protocols.DISCARD
 
setDiscardDeliveredMsgs(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK
 
setDiscardDeliveredMsgs(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
setDiscardIncompatiblePackets(boolean) - Static method in class org.jgroups.protocols.TP
 
setDiscardLoopbacks(boolean) - Method in class org.jgroups.stack.GossipRouter
 
setDiscardOwnMessages(boolean) - Method in class org.jgroups.Channel
When set to true, all messages sent by a member A will be discarded by A.
setDown(boolean) - Method in class org.jgroups.protocols.SHUFFLE
 
setDownDiscardRate(double) - Method in class org.jgroups.protocols.DISCARD
 
setDownProt(Protocol) - Method in class org.jgroups.util.ForwardQueue
 
setDownProtocol(Protocol) - Method in class org.jgroups.stack.Protocol
 
setDropDownMulticasts(int) - Method in class org.jgroups.protocols.DISCARD
 
setDropDownUnicasts(int) - Method in class org.jgroups.protocols.DISCARD
Drop the next N unicasts down the stack
setEnableBundling(boolean) - Method in class org.jgroups.protocols.TP
 
setEnableUnicastBundling(boolean) - Method in class org.jgroups.protocols.TP
 
setErgonomics(boolean) - Method in class org.jgroups.stack.Protocol
 
setException(Throwable) - Method in class org.jgroups.blocks.ConnectionTableNIO.MyFuture
 
setException(Throwable) - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
Causes this future to report an ExecutionException with the given throwable as its cause, unless this Future has already been set or has been cancelled.
setException(Throwable) - Method in class org.jgroups.util.Rsp
 
setExcludeItself(boolean) - Method in class org.jgroups.protocols.DISCARD
 
setExclusionList(Address...) - Method in class org.jgroups.blocks.RequestOptions
 
setExpiryTime(long) - Method in class org.jgroups.stack.GossipRouter
 
setFailReason(String) - Method in class org.jgroups.protocols.pbcast.JoinRsp
 
setField(Field, Object, Object) - Static method in class org.jgroups.util.Util
 
setFixedMembersSeparator(String) - Method in class org.jgroups.auth.FixedMembershipToken
 
setFlag(Message.Flag...) - Method in class org.jgroups.Message
Sets a number of flags in a message
setFlag(short) - Method in class org.jgroups.Message
Sets the flags from a short.
setFlag(byte, byte) - Static method in class org.jgroups.util.Util
 
setFlags(Message.Flag...) - Method in class org.jgroups.blocks.RequestOptions
 
setForceSendingDiscoveryRsps(boolean) - Method in class org.jgroups.protocols.Discovery
 
setFragSize(int) - Method in class org.jgroups.protocols.FRAG
 
setFragSize(int) - Method in class org.jgroups.protocols.FRAG2
 
setGossipRouterHosts(String) - Method in class org.jgroups.protocols.TUNNEL
 
setGroupName(String) - Method in class org.jgroups.demos.Draw
 
setHandler(AgeOutCache.Handler) - Method in class org.jgroups.util.AgeOutCache
 
setHashFunction(PartitionedHashMap.HashFunction<K>) - Method in class org.jgroups.blocks.PartitionedHashMap
 
setHashFunction(ReplCache.HashFunction<K>) - Method in class org.jgroups.blocks.ReplCache
 
setHashFunctionFactory(ReplCache.HashFunctionFactory<K>) - Method in class org.jgroups.blocks.ReplCache
 
setHashType(String) - Method in class org.jgroups.auth.MD5Token
 
setHighestDelivered(long) - Method in class org.jgroups.stack.NakReceiverWindow
 
setHighestDelivered(long) - Method in class org.jgroups.util.RingBuffer
 
setHighestDelivered(long) - Method in class org.jgroups.util.RingBufferLockless
 
setHighestDelivered(long) - Method in class org.jgroups.util.Table
Only used internally by JGroups on a state transfer.
setHighestDeliveredAndSeenSeqnos(Address, long, long) - Method in class org.jgroups.util.MutableDigest
 
setId(short) - Method in class org.jgroups.blocks.MethodCall
 
setID(long) - Method in class org.jgroups.protocols.tom.MessageID
 
setId(short) - Method in class org.jgroups.stack.Protocol
 
setImpl(GmsImpl) - Method in class org.jgroups.protocols.pbcast.GMS
 
setInAllThreadFactories(String, Address, String) - Method in class org.jgroups.protocols.TP
 
setIncludeClusterName(boolean) - Method in class org.jgroups.util.DefaultThreadFactory
 
setIncludeClusterName(boolean) - Method in interface org.jgroups.util.ThreadFactory
 
setIncomingCopies(int) - Method in class org.jgroups.protocols.DUPL
 
setInDelay(int) - Method in class org.jgroups.protocols.DELAY
 
setInitialHosts(List<InetSocketAddress>) - Method in class org.jgroups.protocols.TCPGOSSIP
 
setInitialHosts(List<IpAddress>) - Method in class org.jgroups.protocols.TCPPING
 
setInterval(long) - Method in class org.jgroups.protocols.FD_ALL
 
setJoinTimeout(long) - Method in class org.jgroups.protocols.pbcast.GMS
 
setKeepAliveTime(long) - Method in class org.jgroups.util.DefaultTimeScheduler
 
setKeepAliveTime(long) - Method in class org.jgroups.util.HashedTimingWheel
 
setKeepAliveTime(long) - Method in class org.jgroups.util.MockTimeScheduler
 
setKeepAliveTime(long) - Method in interface org.jgroups.util.TimeScheduler
Sets the keep alive time (in ms) of the thread pool.
setKeepAliveTime(long) - Method in class org.jgroups.util.TimeScheduler2
 
setKeepAliveTime(long) - Method in class org.jgroups.util.TimeScheduler3
 
setKeyServerAddr(Address) - Method in class org.jgroups.protocols.ENCRYPT
 
setKeyStorePassword(String) - Method in class org.jgroups.auth.X509Token
 
setL1Cache(Cache<K, V>) - Method in class org.jgroups.blocks.PartitionedHashMap
 
setL1Cache(Cache<K, V>) - Method in class org.jgroups.blocks.ReplCache
 
setL2Cache(Cache<K, V>) - Method in class org.jgroups.blocks.PartitionedHashMap
 
setL2Cache(Cache<K, ReplCache.Value<V>>) - Method in class org.jgroups.blocks.ReplCache
 
setLength(int) - Method in class org.jgroups.blocks.GridFile.Metadata
 
setLevel(String) - Method in class org.jgroups.logging.JDKLogImpl
 
setLevel(String) - Method in interface org.jgroups.logging.Log
Sets the level of a logger.
setLevel(String) - Method in class org.jgroups.logging.Log4JLogImpl
 
setLevel(String) - Method in class org.jgroups.stack.Protocol
Sets the level of a logger.
setLinger(int) - Method in class org.jgroups.blocks.BasicConnectionTable
 
setLinger(int) - Method in class org.jgroups.blocks.TCPConnectionMap
 
setLingerTimeout(long) - Method in class org.jgroups.stack.GossipRouter
 
setListener(FutureListener<V>) - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
 
setListener(FutureListener) - Method in class org.jgroups.blocks.Request
 
setListener(NakReceiverWindow.Listener) - Method in class org.jgroups.stack.NakReceiverWindow
 
setListener(FutureListener<T>) - Method in interface org.jgroups.util.NotifyingFuture
Attaches a listener and returns the same future instance, to allow for 'building' futures.
setListener(FutureListener<T>) - Method in class org.jgroups.util.NullFuture
 
setLocal_addr(Address) - Method in class org.jgroups.protocols.ENCRYPT
 
setLocalAddr(Address) - Method in class org.jgroups.util.ForwardQueue
 
setLocalAddress(Address) - Method in class org.jgroups.blocks.RequestCorrelator
 
setLocalAddress(Address) - Method in class org.jgroups.protocols.DISCARD
 
setLogCollectMessages(boolean) - Method in class org.jgroups.protocols.pbcast.GMS
 
setLogDiscardMessages(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK
 
setLogDiscardMessages(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
setLogDiscardMessages(boolean) - Method in class org.jgroups.protocols.TP
 
setLogDiscardMessagesVersion(boolean) - Method in class org.jgroups.protocols.TP
 
setLogDiscardMsgs(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK
 
setLogSuspectedMessages(boolean) - Method in class org.jgroups.protocols.FD_SOCK
 
setLoopback(boolean) - Method in class org.jgroups.protocols.TP
 
setMachineId(String) - Method in class org.jgroups.util.TopologyUUID
 
setMarshaller(RpcDispatcher.Marshaller) - Method in class org.jgroups.blocks.RequestCorrelator
 
setMarshaller(RpcDispatcher.Marshaller) - Method in class org.jgroups.blocks.RpcDispatcher
 
setMaxAge(int) - Method in class org.jgroups.demos.JmxDemo
 
setMaxBlockTime(long) - Method in class org.jgroups.protocols.FC
 
setMaxBlockTime(long) - Method in class org.jgroups.protocols.FlowControl
 
setMaxBlockTimes(String) - Method in class org.jgroups.protocols.FC
 
setMaxBlockTimes(String) - Method in class org.jgroups.protocols.FlowControl
 
setMaxBundleSize(int) - Method in class org.jgroups.protocols.TP
 
setMaxBundleSize(int) - Method in class org.jgroups.protocols.UDP
 
setMaxBundleTimeout(long) - Method in class org.jgroups.protocols.TP
 
setMaxBundlingTime(long) - Method in class org.jgroups.protocols.pbcast.GMS
 
setMaxBytes(long) - Method in class org.jgroups.protocols.pbcast.STABLE
 
setMaxBytes(long) - Method in class org.jgroups.protocols.RATE_LIMITER
 
setMaxCompactionTime(long) - Method in class org.jgroups.util.RetransmitTable
 
setMaxCompactionTime(long) - Method in class org.jgroups.util.Table
 
setMaxCredits(long) - Method in class org.jgroups.protocols.FC
 
setMaxCredits(long) - Method in class org.jgroups.protocols.FlowControl
 
setMaxInterval(long) - Method in class org.jgroups.protocols.MERGE2
 
setMaxInterval(long) - Method in class org.jgroups.protocols.MERGE3
 
setMaxJoinAttempts(long) - Method in class org.jgroups.protocols.pbcast.GMS
 
setMaxMessageBatchSize(int) - Method in class org.jgroups.protocols.UNICAST
 
setMaxMessageBatchSize(int) - Method in class org.jgroups.protocols.UNICAST2
 
setMaxNumberOfEntries(int) - Method in class org.jgroups.blocks.Cache
 
setMaxRetransmitTime(long) - Method in class org.jgroups.protocols.UNICAST
 
setMaxRetransmitTime(long) - Method in class org.jgroups.protocols.UNICAST2
 
setMaxSize(int) - Method in class org.jgroups.protocols.SHUFFLE
 
setMaxThreads(int) - Method in class org.jgroups.util.DefaultTimeScheduler
 
setMaxThreads(int) - Method in class org.jgroups.util.HashedTimingWheel
 
setMaxThreads(int) - Method in class org.jgroups.util.MockTimeScheduler
 
setMaxThreads(int) - Method in interface org.jgroups.util.TimeScheduler
Sets the max pool size.
setMaxThreads(int) - Method in class org.jgroups.util.TimeScheduler2
 
setMaxThreads(int) - Method in class org.jgroups.util.TimeScheduler3
 
setMaxTime(long) - Method in class org.jgroups.protocols.SHUFFLE
 
setMaxTries(int) - Method in class org.jgroups.protocols.FD
 
setMcastAddr(InetAddress) - Method in class org.jgroups.protocols.MPING
 
setMcastPort(int) - Method in class org.jgroups.protocols.MPING
 
setMcastPort(int) - Method in class org.jgroups.protocols.UDP
 
setMemberList(String) - Method in class org.jgroups.auth.FixedMembershipToken
 
setMembers(List<Address>) - Method in class org.jgroups.blocks.MessageDispatcher
If this dispatcher is using a user-provided PullPushAdapter, then need to set the members from the adapter initially since viewChange has most likely already been called in PullPushAdapter.
setMembers(List<Address>) - Method in class org.jgroups.stack.GossipData
 
setMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.MessageDispatcher
 
setMergeId(MergeId) - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
setMergeId(MergeId, MergeId) - Method in class org.jgroups.protocols.pbcast.Merger
 
setMergeRejected(boolean) - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
setMergeTimeout(long) - Method in class org.jgroups.protocols.pbcast.GMS
 
setMessageListener(MessageListener) - Method in class org.jgroups.blocks.MessageDispatcher
 
setMethod(Method) - Method in class org.jgroups.blocks.MethodCall
 
setMethodLookup(MethodLookup) - Method in class org.jgroups.blocks.RpcDispatcher
 
setMigrateData(boolean) - Method in class org.jgroups.blocks.PartitionedHashMap
 
setMigrateData(boolean) - Method in class org.jgroups.blocks.ReplCache
 
setMinCredits(long) - Method in class org.jgroups.protocols.FC
 
setMinCredits(long) - Method in class org.jgroups.protocols.FlowControl
 
setMinInterval(long) - Method in class org.jgroups.protocols.MERGE2
 
setMinInterval(long) - Method in class org.jgroups.protocols.MERGE3
 
setMinThreads(int) - Method in class org.jgroups.util.DefaultTimeScheduler
 
setMinThreads(int) - Method in class org.jgroups.util.HashedTimingWheel
 
setMinThreads(int) - Method in class org.jgroups.util.MockTimeScheduler
 
setMinThreads(int) - Method in interface org.jgroups.util.TimeScheduler
Sets the core pool size.
setMinThreads(int) - Method in class org.jgroups.util.TimeScheduler2
 
setMinThreads(int) - Method in class org.jgroups.util.TimeScheduler3
 
setMinThreshold(double) - Method in class org.jgroups.protocols.FC
 
setMinThreshold(double) - Method in class org.jgroups.protocols.FlowControl
 
setMode(ResponseMode) - Method in class org.jgroups.blocks.RequestOptions
 
setModificationTime(long) - Method in class org.jgroups.blocks.GridFile.Metadata
 
setMulticastAddress(String) - Method in class org.jgroups.protocols.MPING
 
setMulticastAddress(InetAddress) - Method in class org.jgroups.protocols.UDP
 
setMulticastPort(int) - Method in class org.jgroups.protocols.UDP
 
setMulticastTTL(int) - Method in class org.jgroups.protocols.UDP
Set the ttl for multicast socket
setMyNumber(long) - Method in class org.jgroups.demos.JmxDemo
 
setName(String) - Method in class org.jgroups.blocks.MethodCall
sets the name for this MethodCall and allowing you to reuse the same object for a different method invokation of a different method
setName(String) - Method in class org.jgroups.Channel
Sets the logical name for the channel.
setName(String) - Method in class org.jgroups.demos.JmxDemo.MyNotification
 
setName(String) - Method in class org.jgroups.JChannel
 
setNumber(int) - Method in class org.jgroups.demos.JmxDemo
 
setNumberOfBackups(int) - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
 
setNumberOfBackups(int) - Method in class org.jgroups.protocols.CENTRAL_LOCK
 
setNumInitialMembers(int) - Method in class org.jgroups.protocols.Discovery
 
setObject(Object) - Method in class org.jgroups.Message
Takes an object and uses Java serialization to generate the byte[] buffer which is set in the message.
setObserver(ENCRYPT.Observer) - Method in class org.jgroups.protocols.ENCRYPT
 
setOOBRejectionPolicy(String) - Method in class org.jgroups.protocols.TP
 
setOOBThreadPool(Executor) - Method in class org.jgroups.protocols.TP
 
setOOBThreadPoolKeepAliveTime(long) - Method in class org.jgroups.protocols.TP
 
setOOBThreadPoolMaxThreads(int) - Method in class org.jgroups.protocols.TP
 
setOOBThreadPoolMinThreads(int) - Method in class org.jgroups.protocols.TP
 
setOOBThreadPoolThreadFactory(ThreadFactory) - Method in class org.jgroups.protocols.TP
 
setOtherNumber(int) - Method in class org.jgroups.demos.JmxDemo
 
setOutDelay(int) - Method in class org.jgroups.protocols.DELAY
 
setOutgoingCopies(int) - Method in class org.jgroups.protocols.DUPL
 
setOwner(Owner) - Method in class org.jgroups.protocols.Locking.ServerLock
 
setPattern(String) - Method in class org.jgroups.util.DefaultThreadFactory
 
setPattern(String) - Method in interface org.jgroups.util.ThreadFactory
 
setPayload(String) - Method in class org.jgroups.util.PayloadUUID
 
setPeerAddressReadTimeout(int) - Method in class org.jgroups.blocks.BasicConnectionTable
 
setPort(int) - Method in class org.jgroups.blocks.MemcachedConnector
 
setPort(int) - Method in class org.jgroups.stack.GossipRouter
 
setPortRange(int) - Method in class org.jgroups.protocols.TCPPING
 
setPortRange(int) - Method in class org.jgroups.protocols.TP
 
setPrintLocalAddr(boolean) - Method in class org.jgroups.protocols.pbcast.GMS
 
setPrintLocalAddress(boolean) - Method in class org.jgroups.protocols.pbcast.GMS
 
setPriority(byte) - Method in class org.jgroups.protocols.PrioHeader
 
setProcessorKeepAliveTime(long) - Method in class org.jgroups.blocks.ConnectionTableNIO
 
setProcessorMaxThreads(int) - Method in class org.jgroups.blocks.ConnectionTableNIO
 
setProcessorMinThreads(int) - Method in class org.jgroups.blocks.ConnectionTableNIO
 
setProcessorQueueSize(int) - Method in class org.jgroups.blocks.ConnectionTableNIO
 
setProcessorThreads(int) - Method in class org.jgroups.blocks.ConnectionTableNIO
 
setProps(String) - Method in class org.jgroups.blocks.PartitionedHashMap
 
setProps(String) - Method in class org.jgroups.blocks.ReplCache
 
setProtocolStack(ProtocolStack) - Method in class org.jgroups.JChannel
 
setProtocolStack(ProtocolStack) - Method in class org.jgroups.stack.Protocol
 
setQuote(String, Float) - Method in class org.jgroups.demos.QuoteClient
 
setQuote(String, Float) - Method in class org.jgroups.demos.QuoteServer
 
setRackId(String) - Method in class org.jgroups.util.TopologyUUID
 
setReaderThreads(int) - Method in class org.jgroups.blocks.ConnectionTableNIO
 
setReaperInterval(long) - Method in class org.jgroups.protocols.BasicTCP
 
setReceiveBufferSize(int) - Method in class org.jgroups.blocks.BasicConnectionTable
 
setReceiveBufferSize(int) - Method in class org.jgroups.blocks.TCPConnectionMap
 
setReceived() - Method in class org.jgroups.util.Rsp
 
setReceiver(BasicConnectionTable.Receiver) - Method in class org.jgroups.blocks.BasicConnectionTable
 
setReceiver(TCPConnectionMap.Receiver) - Method in class org.jgroups.blocks.TCPConnectionMap
 
setReceiver(Receiver) - Method in class org.jgroups.Channel
Sets the receiver for this channel.
setReceiver(TUNNEL.StubReceiver) - Method in class org.jgroups.stack.RouterStub
 
setReconnectInterval(long) - Method in class org.jgroups.protocols.TUNNEL
 
setRegularRejectionPolicy(String) - Method in class org.jgroups.protocols.TP
 
setRelay(boolean) - Method in class org.jgroups.protocols.RELAY
 
setRemoteCalls(boolean) - Method in class org.jgroups.blocks.ReplicatedTree
 
setRequestHandler(RequestHandler) - Method in class org.jgroups.blocks.MessageDispatcher
 
setRequestHandler(RequestHandler) - Method in class org.jgroups.blocks.RequestCorrelator
 
setRequestMarshaller(RpcDispatcher.Marshaller) - Method in class org.jgroups.blocks.RpcDispatcher
 
setResponse(long) - Method in class org.jgroups.auth.DemoToken.Entry
 
setResponseFilter(RspFilter) - Method in class org.jgroups.blocks.Request
 
setResponseMarshaller(RpcDispatcher.Marshaller) - Method in class org.jgroups.blocks.RpcDispatcher
 
setResult(T) - Method in class org.jgroups.util.Promise
Sets the result and notifies any threads waiting for it
setRetransmitTimeouts(Interval) - Method in class org.jgroups.stack.NakReceiverWindow
 
setRetransmitTimeouts(Interval) - Method in class org.jgroups.stack.Retransmitter
 
setRetryTimeout(long) - Method in class org.jgroups.protocols.pbcast.FLUSH
 
setRootNode(ReplicatedTree.Node) - Method in class org.jgroups.blocks.ReplicatedTree
 
setRound(int) - Method in class org.jgroups.util.HashedTimingWheel.MyTask
 
setRoute(short, JChannel, SiteMaster, RELAY2.RouteStatus) - Method in class org.jgroups.protocols.relay.Relayer
 
setRspFilter(RspFilter) - Method in class org.jgroups.blocks.RequestOptions
 
setScope(short) - Method in class org.jgroups.blocks.RequestOptions
 
setScope(short) - Method in class org.jgroups.Message
 
setScope(Message, short) - Static method in class org.jgroups.util.Util
 
setSendBufferSize(int) - Method in class org.jgroups.blocks.BasicConnectionTable
 
setSendBufferSize(int) - Method in class org.jgroups.blocks.TCPConnectionMap
 
setSendQueueSize(int) - Method in class org.jgroups.blocks.BasicConnectionTable
 
setSendQueueSize(int) - Method in class org.jgroups.blocks.TCPConnectionMap
 
setSequencerNumber(long) - Method in class org.jgroups.protocols.tom.ToaHeader
 
setServerObject(Object) - Method in class org.jgroups.blocks.RpcDispatcher
 
setSiteId(String) - Method in class org.jgroups.util.TopologyUUID
 
setSiteUnreachable(short) - Method in class org.jgroups.blocks.RequestCorrelator
An entire site is down; mark all requests that point to that site as unreachable (used by RELAY2)
setSocketConnectionTimeout(int) - Method in class org.jgroups.blocks.BasicConnectionTable
 
setSocketConnectionTimeout(int) - Method in class org.jgroups.blocks.TCPConnectionMap
 
setSocketConnectionTimeout(int) - Method in class org.jgroups.stack.RouterStub
 
setSocketFactory(SocketFactory) - Method in class org.jgroups.blocks.BasicConnectionTable
 
setSocketFactory(SocketFactory) - Method in class org.jgroups.blocks.TCPConnectionMap
 
setSocketFactory(SocketFactory) - Method in class org.jgroups.Channel
 
setSocketFactory(SocketFactory) - Method in class org.jgroups.protocols.TCP
 
setSocketFactory(SocketFactory) - Method in class org.jgroups.protocols.TP.ProtocolAdapter
 
setSocketFactory(SocketFactory) - Method in class org.jgroups.protocols.TP
 
setSocketFactory(SocketFactory) - Method in class org.jgroups.stack.Protocol
Sets a SocketFactory.
setSocketParameters(Socket) - Method in class org.jgroups.blocks.TCPConnectionMap
 
setSocketReadTimeout(long) - Method in class org.jgroups.stack.GossipRouter
 
setSocketReadTimeout(int) - Method in class org.jgroups.stack.RouterStub
 
setSourceAddress(Message) - Method in class org.jgroups.protocols.TP
If the sender is null, set our own address.
setSrc(Address) - Method in class org.jgroups.Message
 
setStartFlushTimeout(long) - Method in class org.jgroups.protocols.pbcast.FLUSH
 
setState(InputStream) - Method in class org.jgroups.blocks.ReplicatedHashMap
 
setState(InputStream) - Method in class org.jgroups.blocks.ReplicatedTree
 
setState(InputStream) - Method in class org.jgroups.demos.Draw
 
setState(InputStream) - Method in class org.jgroups.demos.QuoteServer
 
setState(InputStream) - Method in class org.jgroups.demos.wb.GraphPanel
 
setState(InputStream) - Method in class org.jgroups.demos.wb.Whiteboard
 
setState(InputStream) - Method in interface org.jgroups.MessageListener
Allows an application to read a state through a provided InputStream.
setState(InputStream) - Method in class org.jgroups.ReceiverAdapter
Allows an application to read a state through a provided InputStream.
setStateInApplication(Address, InputStream, Digest) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
setStatsEnabled(boolean) - Method in class org.jgroups.protocols.tom.StatsCollector
 
setSuspected() - Method in class org.jgroups.util.Rsp
 
setTcpNodelay(boolean) - Method in class org.jgroups.blocks.BasicConnectionTable
 
setTcpNodelay(boolean) - Method in class org.jgroups.blocks.TCPConnectionMap
 
setTcpNoDelay(boolean) - Method in class org.jgroups.stack.RouterStub
 
setThread(Thread) - Method in class org.jgroups.protocols.TUNNEL.StubReceiver
 
setThreadFactory(ThreadFactory) - Method in class org.jgroups.blocks.BasicConnectionTable
 
setThreadFactory(ThreadFactory) - Method in class org.jgroups.protocols.TP
 
setThreadFactory(ThreadFactory) - Method in class org.jgroups.util.DefaultTimeScheduler
 
setThreadFactory(ThreadFactory) - Method in class org.jgroups.util.HashedTimingWheel
 
setThreadFactory(ThreadFactory) - Method in class org.jgroups.util.MockTimeScheduler
 
setThreadFactory(ThreadFactory) - Method in interface org.jgroups.util.TimeScheduler
 
setThreadFactory(ThreadFactory) - Method in class org.jgroups.util.TimeScheduler2
 
setThreadFactory(ThreadFactory) - Method in class org.jgroups.util.TimeScheduler3
 
setThreadNames() - Method in class org.jgroups.protocols.TP
 
setThreadPool(Executor) - Method in class org.jgroups.blocks.MemcachedConnector
 
setThreadPoolCoreThreads(int) - Method in class org.jgroups.blocks.MemcachedConnector
 
setThreadPoolIdleTime(long) - Method in class org.jgroups.blocks.MemcachedConnector
 
setThreadPoolKeepAliveTime(long) - Method in class org.jgroups.protocols.SCOPE
 
setThreadPoolKeepAliveTime(long) - Method in class org.jgroups.protocols.TP
 
setThreadPoolMaxThreads(int) - Method in class org.jgroups.blocks.MemcachedConnector
 
setThreadPoolMaxThreads(int) - Method in class org.jgroups.protocols.SCOPE
 
setThreadPoolMaxThreads(int) - Method in class org.jgroups.protocols.TP
 
setThreadPoolMinThreads(int) - Method in class org.jgroups.protocols.SCOPE
 
setThreadPoolMinThreads(int) - Method in class org.jgroups.protocols.TP
 
setThreadPoolQueueEnabled(boolean) - Method in class org.jgroups.protocols.TP
 
setThreshold(int) - Method in class org.jgroups.protocols.SEQUENCER
 
setTimeout(long) - Method in class org.jgroups.blocks.ReplicatedHashMap
Sets the cluster call timeout (until all acks have been received)
setTimeout(long) - Method in class org.jgroups.blocks.RequestOptions
 
setTimeout(long) - Method in class org.jgroups.protocols.Discovery
 
setTimeout(long) - Method in class org.jgroups.protocols.FD
 
setTimeout(long) - Method in class org.jgroups.protocols.FD_ALL
 
setTimeout(int[]) - Method in class org.jgroups.protocols.UNICAST
Deprecated. 
setTimeout(int[]) - Method in class org.jgroups.protocols.UNICAST2
Deprecated. 
setTimeout(long) - Method in class org.jgroups.util.AgeOutCache
 
setTimeout(long) - Method in class org.jgroups.util.ExpiryCache
 
setTimeoutCheckInterval(long) - Method in class org.jgroups.protocols.FD_ALL
 
setTimePeriod(long) - Method in class org.jgroups.protocols.RATE_LIMITER
 
setTimer(TimeScheduler) - Method in class org.jgroups.protocols.pbcast.NAKACK
Only used for unit tests, don't use !
setTimer(TimeScheduler) - Method in class org.jgroups.protocols.pbcast.NAKACK2
Only used for unit tests, don't use !
setTimer(TimeScheduler) - Method in class org.jgroups.protocols.TP
Sets a new timer.
setTimer(TimeScheduler) - Method in class org.jgroups.protocols.UNICAST2
Only used for unit tests, don't use !
setTimerKeepAliveTime(long) - Method in class org.jgroups.protocols.TP
 
setTimerMaxThreads(int) - Method in class org.jgroups.protocols.TP
 
setTimerMinThreads(int) - Method in class org.jgroups.protocols.TP
 
setTimerThreadFactory(ThreadFactory) - Method in class org.jgroups.protocols.TP
 
setToken(AuthToken) - Method in class org.jgroups.protocols.AuthHeader
 
setTransientFlag(Message.TransientFlag...) - Method in class org.jgroups.Message
Same as Message.setFlag(Flag...) except that transient flags are not marshalled
setTransientFlagIfAbsent(Message.TransientFlag) - Method in class org.jgroups.Message
Atomically checks if a given flag is set and - if not - sets it.
setTTL(short) - Method in class org.jgroups.protocols.DAISYCHAIN.DaisyHeader
 
setTTL(int) - Method in class org.jgroups.protocols.MPING
 
setTUNNELPolicy(TUNNEL.TUNNELPolicy) - Method in class org.jgroups.protocols.TUNNEL
 
setUnreachable() - Method in class org.jgroups.util.Rsp
 
setUp(boolean) - Method in class org.jgroups.protocols.SHUFFLE
 
setup(List<ProtocolConfiguration>) - Method in class org.jgroups.stack.ProtocolStack
 
setup(ProtocolStack) - Method in class org.jgroups.stack.ProtocolStack
 
setUpDiscardRate(double) - Method in class org.jgroups.protocols.DISCARD
 
setUpHandler(UpHandler) - Method in class org.jgroups.Channel
Sets this channel event handler to be a recipient off all events .
setUpProt(Protocol) - Method in class org.jgroups.util.ForwardQueue
 
setUpProtocol(Protocol) - Method in class org.jgroups.stack.Protocol
 
setupProtocolStack(List<ProtocolConfiguration>) - Method in class org.jgroups.stack.Configurator
 
setupProtocolStack(ProtocolStack) - Method in class org.jgroups.stack.Configurator
 
setUseMcastXmit(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK
 
setUseMcastXmit(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
setUseMcastXmitReq(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
setUseSendQueues(boolean) - Method in class org.jgroups.blocks.BasicConnectionTable
 
setUseSendQueues(boolean) - Method in class org.jgroups.blocks.TCPConnectionMap
 
setVal1(V1) - Method in class org.jgroups.util.Triple
 
setVal1(V1) - Method in class org.jgroups.util.Tuple
 
setVal2(V2) - Method in class org.jgroups.util.Triple
 
setVal2(V2) - Method in class org.jgroups.util.Tuple
 
setVal3(V3) - Method in class org.jgroups.util.Triple
 
setValue(String, Object) - Method in class org.jgroups.stack.Protocol
 
setValue(T) - Method in class org.jgroups.util.Rsp
 
setValues(Map<String, Object>) - Method in class org.jgroups.stack.Protocol
 
setView(View) - Method in class org.jgroups.protocols.PingData
 
setViewAckCollectionTimeout(long) - Method in class org.jgroups.protocols.pbcast.GMS
 
setViewBundling(boolean) - Method in class org.jgroups.protocols.pbcast.GMS
 
setViewId(ViewId) - Method in class org.jgroups.protocols.PingData
 
setWriterThreads(int) - Method in class org.jgroups.blocks.ConnectionTableNIO
 
setXmitFromRandomMember(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK
 
setXmitFromRandomMember(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
setXmitStaggerTimeout(long) - Method in class org.jgroups.stack.NakReceiverWindow
 
setXmitStaggerTimeout(long) - Method in class org.jgroups.stack.Retransmitter
 
sha(String) - Static method in class org.jgroups.util.Util
Converts a java.lang.String in to a SHA hashed String
SHARED_LOOPBACK - Class in org.jgroups.protocols
Loopback transport shared by all channels within the same VM.
SHARED_LOOPBACK() - Constructor for class org.jgroups.protocols.SHARED_LOOPBACK
 
SHORT_SIZE - Static variable in class org.jgroups.Global
 
shortName(String) - Static method in class org.jgroups.util.Util
 
shortName(InetAddress) - Static method in class org.jgroups.util.Util
 
showLastBlockingTimes() - Method in class org.jgroups.protocols.FC
 
showStatus(String) - Method in class org.jgroups.demos.StompChat
 
SHUFFLE - Class in org.jgroups.protocols
Reorders messages by buffering them and shuffling the result after TIMEOUT ms.
SHUFFLE() - Constructor for class org.jgroups.protocols.SHUFFLE
 
shutdown() - Method in class org.jgroups.blocks.executor.ExecutionService
 
shutdown(Channel) - Static method in class org.jgroups.util.Util
Drops messages to/from other members and then closes the channel.
shutdownNow() - Method in class org.jgroups.blocks.executor.ExecutionService
 
ShutdownRejectedExecutionHandler - Class in org.jgroups.util
ShutdownRejectedExecutionHandler is a decorator RejectedExecutionHandler used in all JGroups ThreadPoolExecutor(s).
ShutdownRejectedExecutionHandler(RejectedExecutionHandler) - Constructor for class org.jgroups.util.ShutdownRejectedExecutionHandler
 
shutdownThreadPool(Executor) - Static method in class org.jgroups.protocols.SCOPE
 
shutdownThreadPool(Executor) - Static method in class org.jgroups.protocols.TP
 
signal() - Method in class org.jgroups.protocols.Locking.ClientCondition
 
signal(boolean) - Method in class org.jgroups.protocols.Locking.ServerCondition
 
signalAll() - Method in class org.jgroups.protocols.Locking.ClientCondition
 
signaled - Variable in class org.jgroups.protocols.Locking.ClientCondition
 
signaled() - Method in class org.jgroups.protocols.Locking.ClientCondition
 
SimpleToken - Class in org.jgroups.auth
This is an example of using a preshared token for authentication purposes.
SimpleToken() - Constructor for class org.jgroups.auth.SimpleToken
 
SimpleToken(String) - Constructor for class org.jgroups.auth.SimpleToken
 
SINGLE_DESTINATION_MESSAGE - Static variable in class org.jgroups.protocols.tom.ToaHeader
 
SINGLETON_NAME - Static variable in class org.jgroups.Global
 
singleton_name - Variable in class org.jgroups.protocols.TP
 
SingletonAddress - Class in org.jgroups.util
Address with a cluster name.
SingletonAddress(String, Address) - Constructor for class org.jgroups.util.SingletonAddress
 
SingletonAddress() - Constructor for class org.jgroups.util.SingletonAddress
 
SITE - Static variable in class org.jgroups.protocols.relay.config.RelayConfig
 
site - Variable in class org.jgroups.protocols.relay.RELAY2
 
site(String) - Method in class org.jgroups.protocols.relay.RELAY2
 
site() - Method in class org.jgroups.protocols.relay.RELAY2
 
site - Variable in class org.jgroups.protocols.RELAY
 
site - Variable in class org.jgroups.protocols.relay.SiteUUID
 
site_cache - Static variable in class org.jgroups.protocols.relay.SiteUUID
 
site_config - Variable in class org.jgroups.protocols.relay.RELAY2
 
site_down_timeout - Variable in class org.jgroups.protocols.relay.RELAY2
 
site_id - Variable in class org.jgroups.protocols.relay.RELAY2
 
site_id - Variable in class org.jgroups.util.TopologyUUID
 
SITE_MASTER - Static variable in interface org.jgroups.Address
 
SITE_UNREACHABLE - Static variable in class org.jgroups.Event
 
SITE_UNREACHABLE - Static variable in class org.jgroups.protocols.relay.RELAY2.Relay2Header
 
SITE_UUID - Static variable in interface org.jgroups.Address
 
SiteAddress - Interface in org.jgroups.protocols.relay
Address with a site suffix
siteDownTimeout(long) - Method in class org.jgroups.protocols.relay.RELAY2
 
siteDownTimeout() - Method in class org.jgroups.protocols.relay.RELAY2
 
siteMaster() - Method in class org.jgroups.protocols.relay.Relayer.Route
 
siteMaster(Address) - Method in class org.jgroups.protocols.relay.Relayer.Route
 
SiteMaster - Class in org.jgroups.protocols.relay
Special address with the UUID part being 0: identifies the current (relay) coordinator of a given site.
SiteMaster() - Constructor for class org.jgroups.protocols.relay.SiteMaster
 
SiteMaster(short) - Constructor for class org.jgroups.protocols.relay.SiteMaster
 
SiteMaster(String) - Constructor for class org.jgroups.protocols.relay.SiteMaster
 
SITES - Static variable in class org.jgroups.protocols.relay.config.RelayConfig
 
sites - Variable in class org.jgroups.protocols.relay.RELAY2
A map containing site names (e.g.
siteUnreachable(short) - Method in class org.jgroups.blocks.GroupRequest
 
siteUnreachable(short) - Method in class org.jgroups.blocks.Request
 
siteUnreachable(short) - Method in interface org.jgroups.blocks.RspCollector
 
siteUnreachable(short) - Method in class org.jgroups.blocks.UnicastRequest
 
SiteUUID - Class in org.jgroups.protocols.relay
Implementation of SiteAddress
SiteUUID() - Constructor for class org.jgroups.protocols.relay.SiteUUID
 
SiteUUID(long, long, String, short) - Constructor for class org.jgroups.protocols.relay.SiteUUID
 
SiteUUID(UUID, String, short) - Constructor for class org.jgroups.protocols.relay.SiteUUID
 
size() - Method in interface org.jgroups.Address
Returns serialized size of this address
size() - Method in class org.jgroups.AnycastAddress
 
size() - Method in class org.jgroups.auth.AuthToken
The size of the marshalled AuthToken
size() - Method in class org.jgroups.auth.DemoToken.DemoHeader
 
size() - Method in class org.jgroups.auth.DemoToken
 
size() - Method in class org.jgroups.auth.FixedMembershipToken
 
size() - Method in class org.jgroups.auth.MD5Token
 
size() - Method in class org.jgroups.auth.RegexMembership
 
size() - Method in class org.jgroups.auth.SimpleToken
 
size() - Method in class org.jgroups.auth.X509Token
 
size() - Method in class org.jgroups.blocks.LazyRemovalCache
 
size() - Method in class org.jgroups.blocks.mux.MuxHeader
 
size() - Method in class org.jgroups.blocks.ReplicatedHashMap
 
size() - Method in class org.jgroups.blocks.RequestCorrelator.Header
 
size() - Method in class org.jgroups.blocks.RequestCorrelator.MultiDestinationHeader
 
size() - Method in class org.jgroups.blocks.TCPConnectionMap.Mapper
 
size - Variable in class org.jgroups.demos.ExecutionServiceDemo
 
size() - Method in class org.jgroups.Header
To be implemented by subclasses.
size() - Method in class org.jgroups.Membership
Returns the number of addresses in this membership
size() - Method in class org.jgroups.Message
Returns the exact size of the marshalled message.
size() - Method in class org.jgroups.protocols.AuthHeader
 
size() - Method in class org.jgroups.protocols.COMPRESS.CompressHeader
 
size() - Method in class org.jgroups.protocols.COUNTER.CounterHeader
 
size() - Method in class org.jgroups.protocols.DAISYCHAIN.DaisyHeader
 
size() - Method in class org.jgroups.protocols.DISCARD.DiscardHeader
 
size() - Method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
 
size() - Method in class org.jgroups.protocols.EXAMPLE.ExampleHeader
 
size() - Method in class org.jgroups.protocols.Executing.ExecutorHeader
 
size() - Method in class org.jgroups.protocols.FcHeader
 
size() - Method in class org.jgroups.protocols.FD.FdHeader
 
size() - Method in class org.jgroups.protocols.FD_ALL.HeartbeatHeader
 
size() - Method in class org.jgroups.protocols.FD_SIMPLE.FdHeader
 
size() - Method in class org.jgroups.protocols.FD_SOCK.FdHeader
 
size() - Method in class org.jgroups.protocols.FORWARD_TO_COORD.ForwardHeader
 
size() - Method in class org.jgroups.protocols.FragHeader
 
size() - Method in class org.jgroups.protocols.HTOTAL.HTotalHeader
 
size() - Method in class org.jgroups.protocols.Locking.LockingHeader
 
size() - Method in class org.jgroups.protocols.MERGE3.MergeHeader
 
size() - Method in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
 
size() - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
size() - Method in class org.jgroups.protocols.pbcast.NakAckHeader
 
size() - Method in class org.jgroups.protocols.pbcast.NakAckHeader2
 
size() - Method in class org.jgroups.protocols.pbcast.STABLE.StableHeader
 
size() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
size() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
 
size() - Method in class org.jgroups.protocols.PingData
 
size() - Method in class org.jgroups.protocols.PingHeader
 
size() - Method in class org.jgroups.protocols.PrioHeader
 
size() - Method in class org.jgroups.protocols.relay.CanBeSiteMaster
 
size() - Method in class org.jgroups.protocols.relay.CanBeSiteMasterTopology
 
size() - Method in class org.jgroups.protocols.relay.RELAY2.Relay2Header
 
size() - Method in class org.jgroups.protocols.RELAY.RelayHeader
 
size() - Method in class org.jgroups.protocols.relay.SiteUUID
 
size() - Method in class org.jgroups.protocols.RSVP.Entry
 
size() - Method in class org.jgroups.protocols.RSVP.RsvpHeader
 
size() - Method in class org.jgroups.protocols.SCOPE.MessageQueue
 
size() - Method in class org.jgroups.protocols.SCOPE.ScopeHeader
 
size() - Method in class org.jgroups.protocols.SEQUENCER.SequencerHeader
 
SIZE - Class in org.jgroups.protocols
Protocol which prints out the real size of a message.
SIZE() - Constructor for class org.jgroups.protocols.SIZE
 
size() - Method in class org.jgroups.protocols.STOMP.StompHeader
 
size() - Method in class org.jgroups.protocols.tom.ToaHeader
 
size() - Method in class org.jgroups.protocols.TpHeader
 
size() - Method in class org.jgroups.protocols.UNICAST.UnicastHeader
 
size() - Method in class org.jgroups.protocols.UNICAST2.Unicast2Header
 
size() - Method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
 
size() - Method in class org.jgroups.stack.DefaultRetransmitter
 
size() - Method in class org.jgroups.stack.GossipData
 
size - Variable in class org.jgroups.stack.IpAddress
 
size() - Method in class org.jgroups.stack.IpAddress
 
size() - Method in class org.jgroups.stack.NakReceiverWindow
 
size() - Method in class org.jgroups.stack.RangeBasedRetransmitter
 
size() - Method in class org.jgroups.stack.Retransmitter
 
size() - Method in class org.jgroups.util.AckCollector
 
size() - Method in class org.jgroups.util.AdditionalDataUUID
 
size() - Method in class org.jgroups.util.AgeOutCache
 
size() - Method in class org.jgroups.util.BlockingInputStream
 
size() - Method in class org.jgroups.util.DefaultTimeScheduler
Answers the number of tasks currently in the queue.
size() - Method in class org.jgroups.util.Digest
 
size() - Method in class org.jgroups.util.ExpiryCache
 
size() - Method in class org.jgroups.util.ExposedByteArrayOutputStream
Returns the current size of the buffer.
size() - Method in class org.jgroups.util.FixedSizeBitSet
 
size() - Method in class org.jgroups.util.ForwardQueue
 
size() - Method in class org.jgroups.util.HashedTimingWheel
Returns the number of tasks currently in the timer
size() - Method in class org.jgroups.util.Headers
 
size() - Method in class org.jgroups.util.MergeId
 
size() - Method in class org.jgroups.util.MockTimeScheduler
 
size() - Method in class org.jgroups.util.MutableDigest
 
size() - Method in class org.jgroups.util.PayloadUUID
 
size() - Method in class org.jgroups.util.Queue
returns the number of objects that are currently in the queue
size() - Method in class org.jgroups.util.ResponseCollector
 
size - Variable in class org.jgroups.util.RetransmitTable
 
size() - Method in class org.jgroups.util.RetransmitTable
Returns the numbers of messages in the table
size() - Method in class org.jgroups.util.RingBuffer
 
size() - Method in class org.jgroups.util.RingBufferLockless
 
size() - Method in class org.jgroups.util.RspList
 
size() - Method in class org.jgroups.util.Seqno
 
size() - Method in class org.jgroups.util.SeqnoList
 
size() - Method in class org.jgroups.util.SeqnoRange
 
size() - Method in class org.jgroups.util.SingletonAddress
 
size() - Method in interface org.jgroups.util.SizeStreamable
Returns the size (in bytes) of the marshalled object
size() - Method in class org.jgroups.util.SuppressCache
Returns the total count of all values
size - Variable in class org.jgroups.util.Table
 
size() - Method in class org.jgroups.util.Table
Returns the numbers of elements in the table
size() - Method in interface org.jgroups.util.TimeScheduler
Returns the number of tasks currently in the queue.
size() - Method in class org.jgroups.util.TimeScheduler2
Returns the number of tasks currently in the timer
size() - Method in class org.jgroups.util.TimeScheduler3
 
size() - Method in class org.jgroups.util.TopologyUUID
 
size(Address) - Static method in class org.jgroups.util.Util
 
size(View) - Static method in class org.jgroups.util.Util
 
size(ViewId) - Static method in class org.jgroups.util.Util
 
size(String) - Static method in class org.jgroups.util.Util
 
size(byte[]) - Static method in class org.jgroups.util.Util
 
size(Collection<? extends Address>) - Static method in class org.jgroups.util.Util
Returns the marshalled size of a Collection of Addresses.
size(long) - Static method in class org.jgroups.util.Util
 
size(long, long) - Static method in class org.jgroups.util.Util
Writes 2 longs, where the second long needs to be >= the first (we only write the delta !)
SIZE - Static variable in class org.jgroups.util.UUID
 
size() - Method in class org.jgroups.util.UUID
 
size() - Method in class org.jgroups.View
Returns the number of members in this view
sizeOf(AuthToken) - Static method in class org.jgroups.protocols.AuthHeader
 
sizeOf(String) - Static method in class org.jgroups.util.Util
 
sizeOf(Object) - Static method in class org.jgroups.util.Util
 
sizeOf(Streamable) - Static method in class org.jgroups.util.Util
 
sizeOfAllMessages(Table<Message>, boolean) - Static method in class org.jgroups.protocols.pbcast.NAKACK2
 
sizeOfAllMessages(boolean) - Method in class org.jgroups.stack.NakReceiverWindow
Returns the number of bytes taken up by all of the messages in the RetransmitTable
sizeOfAllMessages(boolean) - Method in class org.jgroups.util.RetransmitTable
Computes the size of all messages currently in the table.
SizeStreamable - Interface in org.jgroups.util
Interface implementing Streamable and returning the size of the marshalled object.
skip(long) - Method in class org.jgroups.blocks.GridInputStream
 
skip(long) - Method in class org.jgroups.util.BlockingInputStream
 
skip(long) - Method in class org.jgroups.util.ExposedByteArrayInputStream
 
sleep(long) - Static method in class org.jgroups.util.Util
Sleep for timeout msecs.
sleep(long, int) - Static method in class org.jgroups.util.Util
 
sleep(long, boolean) - Static method in class org.jgroups.util.Util
On most UNIX systems, the minimum sleep time is 10-20ms.
SLEEP_TIME - Static variable in class org.jgroups.util.TimeScheduler2
 
sleepRandom(long, long) - Static method in class org.jgroups.util.Util
Sleeps between floor and ceiling milliseconds, chosen randomly
sock - Variable in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
 
sock - Variable in class org.jgroups.client.StompConnection
 
sock - Variable in class org.jgroups.protocols.BPING
 
sock - Variable in class org.jgroups.protocols.STOMP.Connection
 
sock - Variable in class org.jgroups.protocols.UDP
Socket used for sending unicast and multicast packets and receiving unicast packets The address of this socket will be our local address (local_addr)
sock - Variable in class org.jgroups.stack.RouterStub
 
sock_conn_timeout - Variable in class org.jgroups.blocks.TCPConnectionMap
 
sock_conn_timeout - Variable in class org.jgroups.protocols.BasicTCP
 
sock_conn_timeout - Variable in class org.jgroups.stack.RouterStub
 
sock_creation_lock - Variable in class org.jgroups.blocks.AbstractConnectionMap
 
sock_read_timeout - Variable in class org.jgroups.stack.RouterStub
 
socket_factory - Variable in class org.jgroups.blocks.BasicConnectionTable
 
socket_factory - Variable in class org.jgroups.blocks.TCPConnectionMap
 
socket_factory - Variable in class org.jgroups.Channel
 
socket_factory - Variable in class org.jgroups.client.StompConnection
 
socket_factory - Variable in class org.jgroups.protocols.TP.ProtocolAdapter
 
socket_factory - Variable in class org.jgroups.protocols.TP
 
socket_factory - Variable in class org.jgroups.stack.DiagnosticsHandler
 
SocketFactory - Interface in org.jgroups.util
Factory to create various types of sockets.
sockets - Variable in class org.jgroups.protocols.BSH
 
sort() - Method in class org.jgroups.Membership
 
spaceUsed() - Method in class org.jgroups.util.RingBuffer
 
spaceUsed() - Method in class org.jgroups.util.RingBufferLockless
 
spawner - Variable in class org.jgroups.protocols.pbcast.STATE_SOCK
Runnable that listens for state requests and spawns threads to serve those requests if socket transport is used
split(String, int) - Static method in class org.jgroups.util.Util
 
src() - Method in class org.jgroups.Message
 
src(Address) - Method in class org.jgroups.Message
 
src_addr - Variable in class org.jgroups.Message
 
srv_sock - Variable in class org.jgroups.blocks.TCPConnectionMap
 
srv_sock - Variable in class org.jgroups.protocols.BSH
 
srv_sock - Variable in class org.jgroups.protocols.STOMP
 
STABILITY - Static variable in class org.jgroups.protocols.pbcast.STABLE.StableHeader
 
stability_msgs - Variable in class org.jgroups.protocols.pbcast.NAKACK
BoundedList, keeps the last 10 stability messages
stability_msgs - Variable in class org.jgroups.protocols.pbcast.NAKACK2
BoundedList, keeps the last 10 stability messages
STABLE - Static variable in class org.jgroups.Event
 
stable(Digest) - Method in class org.jgroups.protocols.pbcast.NAKACK2
Garbage collect messages that have been seen by all members.
STABLE - Class in org.jgroups.protocols.pbcast
Computes the broadcast messages that are stable; i.e., have been received by all members.
STABLE() - Constructor for class org.jgroups.protocols.pbcast.STABLE
 
stable(Address, short, long, long) - Method in class org.jgroups.protocols.UNICAST2
Purge all messages in window for local_addr, which are <= low.
STABLE - Static variable in class org.jgroups.protocols.UNICAST2.Unicast2Header
 
stable(long) - Method in class org.jgroups.stack.NakReceiverWindow
Delete all messages <= seqno (they are stable, that is, have been delivered by all members).
stable(long) - Method in class org.jgroups.util.RingBuffer
Nulls elements between low and seqno and forwards low
stable(long) - Method in class org.jgroups.util.RingBufferLockless
Nulls elements between low and seqno and forwards low
STABLE.ResumeTask - Class in org.jgroups.protocols.pbcast
 
STABLE.ResumeTask() - Constructor for class org.jgroups.protocols.pbcast.STABLE.ResumeTask
 
STABLE.StableHeader - Class in org.jgroups.protocols.pbcast
 
STABLE.StableHeader() - Constructor for class org.jgroups.protocols.pbcast.STABLE.StableHeader
 
STABLE.StableHeader(int, Digest) - Constructor for class org.jgroups.protocols.pbcast.STABLE.StableHeader
 
STABLE_GOSSIP - Static variable in class org.jgroups.protocols.pbcast.STABLE.StableHeader
 
stable_interval - Variable in class org.jgroups.protocols.UNICAST2
 
stable_task_future - Variable in class org.jgroups.protocols.UNICAST2
 
stack - Variable in class org.jgroups.stack.Protocol
 
STACK_DEPENDENT - Static variable in class org.jgroups.Global
 
STACK_INDEPENDENT - Static variable in class org.jgroups.Global
 
StackType - Enum in org.jgroups.util
 
stagger_timeout - Variable in class org.jgroups.protocols.Discovery
 
start() - Method in class org.jgroups.blocks.AbstractConnectionMap
 
start() - Method in class org.jgroups.blocks.BasicConnectionTable
 
start() - Method in class org.jgroups.blocks.Cache
 
start() - Method in class org.jgroups.blocks.ConnectionTableNIO
 
start() - Method in class org.jgroups.blocks.MemcachedConnector
 
start() - Method in class org.jgroups.blocks.MessageDispatcher
 
start() - Method in class org.jgroups.blocks.mux.MuxMessageDispatcher
 
start() - Method in class org.jgroups.blocks.mux.MuxRpcDispatcher
 
start() - Method in class org.jgroups.blocks.PartitionedHashMap
 
start() - Method in class org.jgroups.blocks.ReplCache
 
start(long) - Method in class org.jgroups.blocks.ReplicatedHashMap
Fetches the state
start() - Method in class org.jgroups.blocks.ReplicatedTree
 
start() - Method in class org.jgroups.blocks.RequestCorrelator
 
start() - Method in class org.jgroups.blocks.TCPConnectionMap
 
start() - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection.ConnectionPeerReceiver
 
start() - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection.Sender
 
start(ThreadFactory) - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
 
start() - Method in class org.jgroups.demos.applets.DrawApplet
 
start() - Method in class org.jgroups.demos.ExecutionServiceDemo
 
start() - Method in class org.jgroups.demos.LockServiceDemo
 
start() - Method in class org.jgroups.demos.QuoteClient
 
start() - Method in class org.jgroups.demos.QuoteServer
 
start(String, String) - Method in class org.jgroups.demos.RelayDemoRpc
 
start(JChannel) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
 
start() - Method in class org.jgroups.demos.StompChat
 
start() - Method in class org.jgroups.demos.Topology
 
start(String) - Method in class org.jgroups.demos.ViewDemo
 
start(String) - Method in class org.jgroups.demos.wb.GraphPanel
 
start() - Method in class org.jgroups.protocols.BPING
 
start() - Method in class org.jgroups.protocols.BSH
 
start() - Method in class org.jgroups.protocols.DAISYCHAIN
 
start() - Method in class org.jgroups.protocols.DISCARD
 
start() - Method in class org.jgroups.protocols.Discovery
 
start() - Method in class org.jgroups.protocols.FC
 
start() - Method in class org.jgroups.protocols.FD_SOCK
 
start() - Method in class org.jgroups.protocols.FILE_PING
 
start() - Method in class org.jgroups.protocols.FlowControl
 
start() - Method in class org.jgroups.protocols.FORWARD_TO_COORD
 
start() - Method in class org.jgroups.protocols.MERGE2.FindSubgroupsTask
 
start() - Method in class org.jgroups.protocols.MPING
 
start() - Method in class org.jgroups.protocols.pbcast.FLUSH
 
start() - Method in class org.jgroups.protocols.pbcast.GMS
 
start() - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
start() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
start() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
start() - Method in class org.jgroups.protocols.pbcast.STABLE
 
start() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
start() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
start() - Method in class org.jgroups.protocols.PRIO
This method is called on a Channel.connect(String).
start() - Method in class org.jgroups.protocols.RATE_LIMITER
 
start() - Method in class org.jgroups.protocols.relay.Relayer.Bridge
 
start(List<RelayConfig.BridgeConfig>, String, short) - Method in class org.jgroups.protocols.relay.Relayer
Creates all bridges from site_config and connects them (joining the bridge clusters)
start() - Method in class org.jgroups.protocols.SCOPE
 
start() - Method in class org.jgroups.protocols.SEQUENCER
 
start() - Method in class org.jgroups.protocols.STOMP
 
start() - Method in class org.jgroups.protocols.TCP
 
start() - Method in class org.jgroups.protocols.TCP_NIO
 
start() - Method in class org.jgroups.protocols.TCPGOSSIP
 
start(DeliveryManager) - Method in class org.jgroups.protocols.tom.DeliveryThread
 
start() - Method in class org.jgroups.protocols.tom.DeliveryThread
 
start() - Method in class org.jgroups.protocols.tom.TOA
 
start() - Method in interface org.jgroups.protocols.TP.Bundler
 
start() - Method in class org.jgroups.protocols.TP.DefaultBundler
 
start() - Method in class org.jgroups.protocols.TP.DefaultBundler2
 
start() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
 
start() - Method in class org.jgroups.protocols.TP
Creates the unicast and multicast sockets and starts the unicast and multicast receiver threads
start() - Method in class org.jgroups.protocols.TP.TransferQueueBundler
 
start() - Method in class org.jgroups.protocols.TP.TransferQueueBundler2
 
start() - Method in class org.jgroups.protocols.UDP.PacketReceiver
 
start() - Method in class org.jgroups.protocols.UDP
Creates the unicast and multicast sockets and starts the unicast and multicast receiver threads
start() - Method in class org.jgroups.protocols.UNICAST
 
start() - Method in class org.jgroups.protocols.UNICAST2
 
start() - Method in class org.jgroups.stack.DiagnosticsHandler
 
start() - Method in class org.jgroups.stack.GossipRouter
Lifecycle operation.
start() - Method in class org.jgroups.stack.Protocol
This method is called on a Channel.connect(String).
start() - Method in class org.jgroups.util.ForwardQueue
 
start() - Method in class org.jgroups.util.TimeScheduler3
 
START_FLUSH - Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
 
startBroadcastTask(Address) - Method in class org.jgroups.protocols.FD.Broadcaster
Starts a new task, or - if already running - adds the argument to the running task.
startConnectionReaper() - Method in class org.jgroups.protocols.UNICAST
 
startConnectionReaper() - Method in class org.jgroups.protocols.UNICAST2
 
started - Variable in class org.jgroups.blocks.RequestCorrelator
 
startExpiryTask() - Method in class org.jgroups.protocols.SCOPE
 
startFailureDetection() - Method in class org.jgroups.protocols.FD
 
startFailureDetection() - Method in class org.jgroups.protocols.FD_ALL
 
startFlush(List<Address>, boolean) - Method in class org.jgroups.Channel
Performs a partial flush in a cluster for flush participants.
startFlush(boolean) - Method in class org.jgroups.Channel
Will perform a flush of the system, ie.
startFlush(boolean) - Method in class org.jgroups.JChannel
 
startFlush(List<Address>, boolean) - Method in class org.jgroups.JChannel
 
startFlush() - Method in class org.jgroups.protocols.pbcast.FLUSH
 
startFlush(Channel, List<Address>, int, long, long) - Static method in class org.jgroups.util.Util
 
startFlush(Channel, List<Address>) - Static method in class org.jgroups.util.Util
 
startFlush(Channel, int, long, long) - Static method in class org.jgroups.util.Util
 
startFlush(Channel) - Static method in class org.jgroups.util.Util
 
startFlusher(Address) - Method in class org.jgroups.protocols.SEQUENCER
 
startFlusher(Address) - Method in class org.jgroups.util.ForwardQueue
 
startGui() - Method in class org.jgroups.protocols.DISCARD
 
startInfoSender() - Method in class org.jgroups.protocols.MERGE3
 
startMergeTask() - Method in class org.jgroups.protocols.MERGE2
 
startMonitor() - Method in class org.jgroups.protocols.FD
Requires lock to held by caller
startReconciliationTask() - Method in class org.jgroups.protocols.COUNTER
 
startReconnecting(RouterStub) - Method in class org.jgroups.stack.RouterStubManager
 
startReconnectingClient() - Method in class org.jgroups.client.StompConnection
 
startRelayer(Relayer, String) - Method in class org.jgroups.protocols.relay.RELAY2
 
startRemoteViewFetcher() - Method in class org.jgroups.protocols.RELAY
 
startRetransmitTask() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
startRetransmitTask() - Method in class org.jgroups.protocols.UNICAST
 
startRetransmitTask() - Method in class org.jgroups.protocols.UNICAST2
 
startRunner() - Method in class org.jgroups.client.StompConnection
 
startRunner() - Method in class org.jgroups.util.HashedTimingWheel
 
startRunner() - Method in class org.jgroups.util.TimeScheduler2
 
startRunner() - Method in class org.jgroups.util.TimeScheduler3
 
startStableTask() - Method in class org.jgroups.protocols.UNICAST2
 
startStack(String) - Method in class org.jgroups.JChannel
 
startStack(String, Address) - Method in class org.jgroups.stack.ProtocolStack
Start all layers.
startTask(short) - Method in class org.jgroups.protocols.RSVP.Entry
 
startTask() - Method in class org.jgroups.protocols.SHUFFLE
 
startViewConsistencyChecker() - Method in class org.jgroups.protocols.MERGE3
 
state - Variable in class org.jgroups.Channel
The current state of the channel
STATE - Class in org.jgroups.protocols.pbcast
STATE streams the state (written to an OutputStream) to the state requester in chunks (defined by chunk_size).
STATE() - Constructor for class org.jgroups.protocols.pbcast.STATE
 
state - Variable in class org.jgroups.stack.StateTransferInfo
 
STATE.StateOutputStream - Class in org.jgroups.protocols.pbcast
 
STATE.StateOutputStream(Address) - Constructor for class org.jgroups.protocols.pbcast.STATE.StateOutputStream
 
STATE_EOF - Static variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
 
STATE_EX - Static variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
STATE_EX - Static variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
 
state_lock - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
Used to synchronize all state requests and responses
STATE_PART - Static variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
 
state_promise - Variable in class org.jgroups.JChannel
 
state_provider - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
STATE_REQ - Static variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
STATE_REQ - Static variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
 
STATE_RSP - Static variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
STATE_RSP - Static variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
 
STATE_SOCK - Class in org.jgroups.protocols.pbcast
STATE_SOCK has the state provider create a server socket to which the state requester connects and from which the latter reads the state.
STATE_SOCK() - Constructor for class org.jgroups.protocols.pbcast.STATE_SOCK
 
STATE_SOCK.StateProviderAcceptor - Class in org.jgroups.protocols.pbcast
 
STATE_SOCK.StateProviderAcceptor(ExecutorService, ServerSocket) - Constructor for class org.jgroups.protocols.pbcast.STATE_SOCK.StateProviderAcceptor
 
STATE_TRANSFER - Class in org.jgroups.protocols.pbcast
STATE_TRANSFER protocol based on byte array transfer.
STATE_TRANSFER() - Constructor for class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
STATE_TRANSFER.StateHeader - Class in org.jgroups.protocols.pbcast
Wraps data for a state request/response.
STATE_TRANSFER.StateHeader() - Constructor for class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
STATE_TRANSFER.StateHeader(byte) - Constructor for class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
STATE_TRANSFER.StateHeader(byte, Digest) - Constructor for class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
STATE_TRANSFER_INPUTSTREAM - Static variable in class org.jgroups.Event
 
STATE_TRANSFER_INPUTSTREAM_CLOSED - Static variable in class org.jgroups.Event
 
STATE_TRANSFER_OUTPUTSTREAM - Static variable in class org.jgroups.Event
 
state_transfer_supported - Variable in class org.jgroups.JChannel
True if a state transfer protocol is available, false otherwise (set by CONFIG event from STATE_TRANSFER protocol)
stateRequester - Variable in class org.jgroups.protocols.pbcast.STATE.StateOutputStream
 
StateTransferException - Exception in org.jgroups
StateTransferException is thrown to indicate a failure of a state transfer between cluster members.
StateTransferException() - Constructor for exception org.jgroups.StateTransferException
 
StateTransferException(String) - Constructor for exception org.jgroups.StateTransferException
 
StateTransferException(String, Throwable) - Constructor for exception org.jgroups.StateTransferException
 
StateTransferInfo - Class in org.jgroups.stack
Contains parameters for state transfer.
StateTransferInfo() - Constructor for class org.jgroups.stack.StateTransferInfo
 
StateTransferInfo(Address) - Constructor for class org.jgroups.stack.StateTransferInfo
 
StateTransferInfo(Address, long) - Constructor for class org.jgroups.stack.StateTransferInfo
 
StateTransferInfo(Address, long, byte[]) - Constructor for class org.jgroups.stack.StateTransferInfo
 
StateTransferResult - Class in org.jgroups.util
Encapsulates the result of a state transfer.
StateTransferResult() - Constructor for class org.jgroups.util.StateTransferResult
 
StateTransferResult(byte[]) - Constructor for class org.jgroups.util.StateTransferResult
 
StateTransferResult(Throwable) - Constructor for class org.jgroups.util.StateTransferResult
 
StaticInterval - Class in org.jgroups.stack
Manages retransmission timeouts.
StaticInterval(int...) - Constructor for class org.jgroups.stack.StaticInterval
 
stats - Variable in class org.jgroups.JChannel
Collect statistics
stats - Variable in class org.jgroups.protocols.relay.Relayer
 
STATS - Class in org.jgroups.protocols
Provides various stats
STATS() - Constructor for class org.jgroups.protocols.STATS
 
stats - Variable in class org.jgroups.stack.Protocol
 
StatsCollector - Class in org.jgroups.protocols.tom
This collects the stats and some profiling information
StatsCollector() - Constructor for class org.jgroups.protocols.tom.StatsCollector
 
statsEnabled() - Method in class org.jgroups.JChannel
 
statsEnabled() - Method in class org.jgroups.stack.Protocol
 
status() - Method in class org.jgroups.protocols.relay.Relayer.Route
 
status(RELAY2.RouteStatus) - Method in class org.jgroups.protocols.relay.Relayer.Route
 
STOMP - Class in org.jgroups.protocols
Protocol which provides STOMP (http://stomp.codehaus.org/) support.
STOMP() - Constructor for class org.jgroups.protocols.STOMP
 
STOMP.ClientVerb - Enum in org.jgroups.protocols
 
STOMP.Connection - Class in org.jgroups.protocols
Class which handles a connection to a client
STOMP.Connection(Socket) - Constructor for class org.jgroups.protocols.STOMP.Connection
 
STOMP.Frame - Class in org.jgroups.protocols
 
STOMP.Frame(String, Map<String, String>, byte[]) - Constructor for class org.jgroups.protocols.STOMP.Frame
 
STOMP.ServerVerb - Enum in org.jgroups.protocols
 
STOMP.StompHeader - Class in org.jgroups.protocols
 
STOMP.StompHeader() - Constructor for class org.jgroups.protocols.STOMP.StompHeader
 
STOMP.StompHeader.Type - Enum in org.jgroups.protocols
 
STOMP_BIND_ADDR - Static variable in class org.jgroups.Global
 
stomp_client - Variable in class org.jgroups.demos.StompChat
 
stomp_client - Variable in class org.jgroups.demos.StompDraw
 
STOMP_ENDPOINT_ADDR - Static variable in class org.jgroups.Global
 
StompChat - Class in org.jgroups.demos
Chat client using STOMP to talk to other clients
StompChat(String, int, String) - Constructor for class org.jgroups.demos.StompChat
 
StompConnection - Class in org.jgroups.client
STOMP client to access the STOMP [1] protocol.
StompConnection(String) - Constructor for class org.jgroups.client.StompConnection
 
StompConnection(String, boolean, boolean) - Constructor for class org.jgroups.client.StompConnection
 
StompConnection(String, String, String, boolean, boolean) - Constructor for class org.jgroups.client.StompConnection
 
StompConnection.Listener - Interface in org.jgroups.client
 
StompDraw - Class in org.jgroups.demos
Simple STOMP demo client.
StompDraw(String, String) - Constructor for class org.jgroups.demos.StompDraw
 
stop() - Method in class org.jgroups.blocks.AbstractConnectionMap
 
stop() - Method in class org.jgroups.blocks.BasicConnectionTable
 
stop() - Method in class org.jgroups.blocks.Cache
 
stop() - Method in class org.jgroups.blocks.ConnectionTableNIO
Closes all open sockets, the server socket and all threads waiting for incoming messages
stop() - Method in class org.jgroups.blocks.MemcachedConnector
 
stop() - Method in class org.jgroups.blocks.MessageDispatcher
 
stop() - Method in class org.jgroups.blocks.mux.MuxMessageDispatcher
 
stop() - Method in class org.jgroups.blocks.mux.MuxRpcDispatcher
 
stop() - Method in class org.jgroups.blocks.PartitionedHashMap
 
stop() - Method in class org.jgroups.blocks.ReplCache
 
stop() - Method in class org.jgroups.blocks.ReplicatedHashMap
 
stop() - Method in class org.jgroups.blocks.ReplicatedTree
 
stop() - Method in class org.jgroups.blocks.RequestCorrelator
 
stop() - Method in class org.jgroups.blocks.TCPConnectionMap
 
stop() - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection.ConnectionPeerReceiver
 
stop() - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection.Sender
 
stop() - Method in class org.jgroups.demos.Draw
 
stop() - Method in class org.jgroups.demos.StompDraw
 
stop() - Method in class org.jgroups.demos.wb.GraphPanel
 
stop() - Method in class org.jgroups.protocols.BARRIER
 
stop() - Method in class org.jgroups.protocols.BPING
 
stop() - Method in class org.jgroups.protocols.BSH
 
stop() - Method in class org.jgroups.protocols.DAISYCHAIN
 
stop() - Method in class org.jgroups.protocols.DISCARD
 
stop() - Method in class org.jgroups.protocols.Discovery
 
stop() - Method in class org.jgroups.protocols.FC
 
stop() - Method in class org.jgroups.protocols.FD.BroadcastTask
 
stop() - Method in class org.jgroups.protocols.FD
 
stop() - Method in class org.jgroups.protocols.FD_ALL
 
stop() - Method in class org.jgroups.protocols.FD_SIMPLE
 
stop() - Method in class org.jgroups.protocols.FD_SOCK
 
stop() - Method in class org.jgroups.protocols.FILE_PING
 
stop() - Method in class org.jgroups.protocols.FlowControl
 
stop() - Method in class org.jgroups.protocols.FORWARD_TO_COORD
 
stop() - Method in class org.jgroups.protocols.JDBC_PING
 
stop() - Method in class org.jgroups.protocols.MERGE2.FindSubgroupsTask
 
stop() - Method in class org.jgroups.protocols.MERGE2
 
stop() - Method in class org.jgroups.protocols.MERGE3
 
stop() - Method in class org.jgroups.protocols.MFC
 
stop() - Method in class org.jgroups.protocols.MPING
 
stop() - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
 
stop() - Method in class org.jgroups.protocols.pbcast.FLUSH
 
stop() - Method in class org.jgroups.protocols.pbcast.GMS
 
stop() - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
stop() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
stop() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
stop() - Method in class org.jgroups.protocols.pbcast.STABLE
 
stop() - Method in class org.jgroups.protocols.pbcast.STATE_SOCK.StateProviderAcceptor
 
stop() - Method in class org.jgroups.protocols.pbcast.STATE_SOCK
 
stop() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
stop() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
stop() - Method in class org.jgroups.protocols.PRIO
This method is called on a Channel.disconnect().
stop() - Method in class org.jgroups.protocols.RATE_LIMITER
 
stop() - Method in class org.jgroups.protocols.relay.RELAY2
 
stop() - Method in class org.jgroups.protocols.relay.Relayer.Bridge
 
stop() - Method in class org.jgroups.protocols.relay.Relayer
Disconnects and destroys all bridges
stop() - Method in class org.jgroups.protocols.RELAY
 
stop() - Method in class org.jgroups.protocols.RSVP
 
stop() - Method in class org.jgroups.protocols.SCOPE
 
stop() - Method in class org.jgroups.protocols.SEQUENCER
 
stop() - Method in class org.jgroups.protocols.STOMP.Connection
 
stop() - Method in class org.jgroups.protocols.STOMP
 
stop() - Method in class org.jgroups.protocols.TCP
 
stop() - Method in class org.jgroups.protocols.TCP_NIO
 
stop() - Method in class org.jgroups.protocols.TCPGOSSIP
 
stop() - Method in class org.jgroups.protocols.tom.TOA
 
stop() - Method in interface org.jgroups.protocols.TP.Bundler
 
stop() - Method in class org.jgroups.protocols.TP.DefaultBundler
 
stop() - Method in class org.jgroups.protocols.TP.DefaultBundler2
 
stop() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
 
stop() - Method in class org.jgroups.protocols.TP
 
stop() - Method in class org.jgroups.protocols.TP.TransferQueueBundler
 
stop() - Method in class org.jgroups.protocols.TP.TransferQueueBundler2
 
stop() - Method in class org.jgroups.protocols.UDP.PacketReceiver
 
stop() - Method in class org.jgroups.protocols.UDP
 
stop() - Method in class org.jgroups.protocols.UFC
 
stop() - Method in class org.jgroups.protocols.UNICAST
 
stop() - Method in class org.jgroups.protocols.UNICAST2
 
stop() - Method in class org.jgroups.protocols.VERIFY_SUSPECT
 
stop() - Method in class org.jgroups.stack.DiagnosticsHandler
 
stop() - Method in class org.jgroups.stack.GossipRouter
Always called before destroy().
stop() - Method in class org.jgroups.stack.Protocol
This method is called on a Channel.disconnect().
stop() - Method in class org.jgroups.util.DefaultTimeScheduler
Stop the scheduler if it's running.
stop() - Method in class org.jgroups.util.ForwardQueue
 
stop() - Method in class org.jgroups.util.HashedTimingWheel
Stops the timer, cancelling all tasks
stop() - Method in class org.jgroups.util.MockTimeScheduler
 
stop() - Method in interface org.jgroups.util.TimeScheduler
Stops the scheduler if running, cancelling all pending tasks
stop() - Method in class org.jgroups.util.TimeScheduler2
Stops the timer, cancelling all tasks
stop() - Method in class org.jgroups.util.TimeScheduler3
Stops the timer, cancelling all tasks
STOP_FLUSH - Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
 
stopBroadcastTask() - Method in class org.jgroups.protocols.FD.Broadcaster
 
stopConnectionReaper() - Method in class org.jgroups.protocols.UNICAST
 
stopConnectionReaper() - Method in class org.jgroups.protocols.UNICAST2
 
stopExpiryTask() - Method in class org.jgroups.protocols.SCOPE
 
stopFailureDetection() - Method in class org.jgroups.protocols.FD
 
stopFailureDetection() - Method in class org.jgroups.protocols.FD_ALL
 
stopFlush() - Method in class org.jgroups.Channel
 
stopFlush(List<Address>) - Method in class org.jgroups.Channel
 
stopFlush() - Method in class org.jgroups.JChannel
 
stopFlush(List<Address>) - Method in class org.jgroups.JChannel
 
stopFlush() - Method in class org.jgroups.protocols.pbcast.FLUSH
 
stopFlusher() - Method in class org.jgroups.protocols.SEQUENCER
 
stopFlusher() - Method in class org.jgroups.util.ForwardQueue
 
stopGui() - Method in class org.jgroups.protocols.DISCARD
 
stopInfoSender() - Method in class org.jgroups.protocols.MERGE3
 
stopMergeTask() - Method in class org.jgroups.protocols.MERGE2
 
stopMonitor() - Method in class org.jgroups.protocols.FD
Requires lock to be held by caller
stopReconciliationTask() - Method in class org.jgroups.protocols.COUNTER
 
stopReconnecting(RouterStub) - Method in class org.jgroups.stack.RouterStubManager
 
stopRemoteViewFetcher() - Method in class org.jgroups.protocols.RELAY
 
stopRetransmitTask() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
stopRetransmitTask() - Method in class org.jgroups.protocols.UNICAST
 
stopRetransmitTask() - Method in class org.jgroups.protocols.UNICAST2
 
stopRunner() - Method in class org.jgroups.util.HashedTimingWheel
 
stopRunner() - Method in class org.jgroups.util.TimeScheduler2
 
stopRunner() - Method in class org.jgroups.util.TimeScheduler3
 
stopServerSocket(boolean) - Method in class org.jgroups.protocols.FD_SOCK
 
stopStableTask() - Method in class org.jgroups.protocols.UNICAST2
 
stopStack(boolean, boolean) - Method in class org.jgroups.JChannel
 
stopStack(String) - Method in class org.jgroups.stack.ProtocolStack
Iterates through all the protocols from top to bottom and does the following: Waits until all messages in the down queue have been flushed (ie., size is 0) Calls stop() on the protocol
stopTask() - Method in class org.jgroups.protocols.SHUFFLE
 
stopViewConsistencyChecker() - Method in class org.jgroups.protocols.MERGE3
 
Streamable - Interface in org.jgroups.util
Implementations of Streamable can add their state directly to the output stream, enabling them to bypass costly serialization
streamableFromBuffer(byte[], int, int) - Static method in class org.jgroups.protocols.COUNTER
 
streamableFromByteBuffer(Class<? extends Streamable>, byte[]) - Static method in class org.jgroups.util.Util
 
streamableFromByteBuffer(Class<? extends Streamable>, byte[], int, int) - Static method in class org.jgroups.util.Util
 
streamableToBuffer(byte, byte, Streamable) - Static method in class org.jgroups.protocols.COUNTER
 
streamableToByteBuffer(Streamable) - Static method in class org.jgroups.util.Util
 
StreamingStateTransfer - Class in org.jgroups.protocols.pbcast
Base class for state transfer protocols which use streaming (or chunking) to transfer state between two members.
StreamingStateTransfer() - Constructor for class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
StreamingStateTransfer.StateGetter - Class in org.jgroups.protocols.pbcast
Thread which invokes MessageListener.getState(java.io.OutputStream) in the application
StreamingStateTransfer.StateGetter(Address, OutputStream) - Constructor for class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateGetter
 
StreamingStateTransfer.StateHeader - Class in org.jgroups.protocols.pbcast
 
StreamingStateTransfer.StateHeader() - Constructor for class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
 
StreamingStateTransfer.StateHeader(byte) - Constructor for class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
 
StreamingStateTransfer.StateHeader(byte, Digest) - Constructor for class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
 
StreamingStateTransfer.StateHeader(byte, IpAddress, Digest) - Constructor for class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
 
string_version - Static variable in class org.jgroups.Version
 
subgroups - Variable in class org.jgroups.MergeView
 
submit(Callable<V>) - Method in class org.jgroups.blocks.executor.ExecutionCompletionService
submit(Runnable, V) - Method in class org.jgroups.blocks.executor.ExecutionCompletionService
submit(Runnable, T) - Method in class org.jgroups.blocks.executor.ExecutionService
 
submit(Callable<T>) - Method in class org.jgroups.blocks.executor.ExecutionService
 
submitToPool(TimeScheduler3.Task) - Method in class org.jgroups.util.TimeScheduler3
 
subscribe(String) - Method in class org.jgroups.client.StompConnection
 
subscriptions - Variable in class org.jgroups.client.StompConnection
 
subscriptions - Variable in class org.jgroups.protocols.STOMP
 
substituteVariable(String) - Static method in class org.jgroups.util.Util
Replaces variables of ${var:default} with System.getProperty(var, default).
substituteVariables(ProtocolStackConfigurator) - Static method in class org.jgroups.conf.ConfiguratorFactory
Replace variables of the form ${var:default} with the getProperty(var, default)
substituteVariables() - Method in class org.jgroups.conf.ProtocolConfiguration
 
SUFFIX - Static variable in class org.jgroups.protocols.FILE_PING
 
SUFFIX - Static variable in class org.jgroups.protocols.PDC
 
supervisor(SUPERVISOR) - Method in class org.jgroups.protocols.rules.Rule
 
SUPERVISOR - Class in org.jgroups.protocols.rules
Protocol which supervises other protocols.
SUPERVISOR() - Constructor for class org.jgroups.protocols.rules.SUPERVISOR
 
supportedKeys() - Method in class org.jgroups.protocols.pbcast.GMS
 
supportedKeys() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
supportedKeys() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
supportedKeys() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
 
supportedKeys() - Method in interface org.jgroups.stack.DiagnosticsHandler.ProbeHandler
Returns a list of supported keys
supportsMulticasting() - Method in class org.jgroups.protocols.BasicTCP
 
supportsMulticasting() - Method in class org.jgroups.protocols.SHARED_LOOPBACK
 
supportsMulticasting() - Method in class org.jgroups.protocols.TP
Whether or not hardware multicasting is supported
supportsMulticasting() - Method in class org.jgroups.protocols.TUNNEL
 
supportsMulticasting() - Method in class org.jgroups.protocols.UDP
Usually, src addresses are nulled, and the receiver simply sets them to the address of the sender.
suppress_format - Variable in class org.jgroups.util.SuppressLog
 
suppress_log_different_cluster - Variable in class org.jgroups.protocols.TP
Log to suppress identical warnings for messages from members in different clusters
suppress_log_different_version - Variable in class org.jgroups.protocols.TP
Log to suppress identical warnings for messages from members with different (incompatible) versions
suppress_log_non_member - Variable in class org.jgroups.protocols.pbcast.NAKACK
Log to suppress identical warnings for messages from non-members
suppress_log_non_member - Variable in class org.jgroups.protocols.pbcast.NAKACK2
Log to suppress identical warnings for messages from non-members
suppress_time_different_cluster_warnings - Variable in class org.jgroups.protocols.TP
 
suppress_time_different_version_warnings - Variable in class org.jgroups.protocols.TP
 
suppress_time_non_member_warnings - Variable in class org.jgroups.protocols.pbcast.NAKACK
 
suppress_time_non_member_warnings - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
SuppressCache<T> - Class in org.jgroups.util
Cache which keeps a timestamp and counter for every key.
SuppressCache() - Constructor for class org.jgroups.util.SuppressCache
 
SuppressCache.Value - Class in org.jgroups.util
 
SuppressCache.Value() - Constructor for class org.jgroups.util.SuppressCache.Value
 
SuppressLog<T> - Class in org.jgroups.util
Log (using SuppressCache) which suppresses (certain) messages from the same member for a given time
SuppressLog(Log, String, String) - Constructor for class org.jgroups.util.SuppressLog
 
SuppressLog.Level - Enum in org.jgroups.util
 
suspect(Address) - Method in class org.jgroups.blocks.GroupRequest
Callback (called by RequestCorrelator or Transport).
suspect(Address) - Method in class org.jgroups.blocks.PartitionedHashMap.ConsistentHashFunction
 
suspect(Address) - Method in class org.jgroups.blocks.PartitionedHashMap
 
suspect(Address) - Method in class org.jgroups.blocks.ReplCache
 
suspect(Address) - Method in class org.jgroups.blocks.ReplicatedHashMap
Called when a member is suspected
suspect(Address) - Method in class org.jgroups.blocks.Request
 
suspect(Address) - Method in interface org.jgroups.blocks.RspCollector
 
suspect(Address) - Method in class org.jgroups.blocks.UnicastRequest
Callback (called by RequestCorrelator or Transport).
suspect(Address) - Method in class org.jgroups.demos.QuoteClient
 
suspect(Address) - Method in class org.jgroups.demos.ViewDemo
Called when a member is suspected
suspect(Address) - Method in class org.jgroups.demos.wb.Whiteboard
 
SUSPECT - Static variable in class org.jgroups.Event
 
suspect(Address) - Method in interface org.jgroups.MembershipListener
Called whenever a member is suspected of having crashed, but has not yet been excluded.
SUSPECT - Static variable in class org.jgroups.protocols.FD.FdHeader
 
suspect(List<Address>) - Method in class org.jgroups.protocols.FD_ALL
 
SUSPECT - Static variable in class org.jgroups.protocols.FD_SOCK.FdHeader
 
suspect(Address) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
 
suspect(String) - Method in class org.jgroups.protocols.pbcast.GMS
 
suspect(Address) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
suspect(Address) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
 
suspect - Variable in class org.jgroups.protocols.VERIFY_SUSPECT.Entry
 
suspect(Address) - Method in class org.jgroups.ReceiverAdapter
Called whenever a member is suspected of having crashed, but has not yet been excluded.
SUSPECT - Static variable in class org.jgroups.stack.GossipRouter
 
suspect(Address) - Method in class org.jgroups.util.AckCollector
 
suspect(Address) - Method in class org.jgroups.util.ResponseCollector
 
suspect_history - Variable in class org.jgroups.protocols.FD
 
suspected - Variable in class org.jgroups.util.Rsp
Flag that represents whether the sender of the response was suspected
suspected_mbrs - Variable in class org.jgroups.protocols.FD.Broadcaster
 
suspected_mbrs - Variable in class org.jgroups.protocols.FD_ALL
 
suspected_mbrs - Variable in class org.jgroups.protocols.FD_SOCK
 
suspected_mbrs - Variable in class org.jgroups.util.AckCollector
 
suspected_members - Variable in class org.jgroups.protocols.FD.BroadcastTask
 
SuspectedException - Exception in org.jgroups
Thrown if a message is sent to a suspected member.
SuspectedException() - Constructor for exception org.jgroups.SuspectedException
 
SuspectedException(Object) - Constructor for exception org.jgroups.SuspectedException
 
suspects - Variable in class org.jgroups.protocols.VERIFY_SUSPECT
 
SUSPEND - Static variable in class org.jgroups.Event
 
SUSPEND_BUT_FAIL - Static variable in class org.jgroups.Event
 
SUSPEND_STABLE - Static variable in class org.jgroups.Event
 
suspended - Variable in class org.jgroups.protocols.pbcast.STABLE
When true, don't take part in garbage collection: neither send STABLE messages nor handle STABILITY messages
suspendViewHandler() - Method in class org.jgroups.protocols.pbcast.GMS
 
sv - Variable in class org.jgroups.protocols.rules.Rule
 
SWIFT_PING - Class in org.jgroups.protocols
Discovery protocol based on Openstack Swift (object storage).
SWIFT_PING() - Constructor for class org.jgroups.protocols.SWIFT_PING
 
SWIFT_PING.SwiftClient - Class in org.jgroups.protocols
A thread safe Swift client
SWIFT_PING.SwiftClient(SWIFT_PING.Authenticator) - Constructor for class org.jgroups.protocols.SWIFT_PING.SwiftClient
Constructor
swiftClient - Variable in class org.jgroups.protocols.SWIFT_PING
 
sync - Variable in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
Synchronization control for FutureTask
SYNC() - Static method in class org.jgroups.blocks.RequestOptions
 
sync_anycasts - Variable in class org.jgroups.blocks.MessageDispatcher
 
sync_multicasts - Variable in class org.jgroups.blocks.MessageDispatcher
 
sync_unicasts - Variable in class org.jgroups.blocks.MessageDispatcher
 
synchronizedMap(ReplicatedMap<K, V>) - Static method in class org.jgroups.blocks.ReplicatedHashMap
Creates a synchronized facade for a ReplicatedMap.

T

Table<T> - Class in org.jgroups.util
A store for elements (typically messages) to be retransmitted or delivered.
Table() - Constructor for class org.jgroups.util.Table
 
Table(long) - Constructor for class org.jgroups.util.Table
 
Table(int, int, long) - Constructor for class org.jgroups.util.Table
 
Table(int, int, long, double) - Constructor for class org.jgroups.util.Table
 
Table(int, int, long, double, long) - Constructor for class org.jgroups.util.Table
Creates a new table
Table.Counter - Class in org.jgroups.util
 
Table.Counter() - Constructor for class org.jgroups.util.Table.Counter
 
Table.Dump - Class in org.jgroups.util
 
Table.Dump() - Constructor for class org.jgroups.util.Table.Dump
 
Table.Getter - Class in org.jgroups.util
 
Table.Getter() - Constructor for class org.jgroups.util.Table.Getter
 
Table.Missing - Class in org.jgroups.util
 
Table.Missing() - Constructor for class org.jgroups.util.Table.Missing
 
Table.Remover - Class in org.jgroups.util
 
Table.Remover(boolean, int) - Constructor for class org.jgroups.util.Table.Remover
 
Table.Visitor<T> - Interface in org.jgroups.util
 
take() - Method in class org.jgroups.blocks.executor.ExecutionCompletionService
take() - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
 
target - Variable in class org.jgroups.blocks.UnicastRequest
 
target - Variable in class org.jgroups.protocols.RSVP.Entry
 
target - Variable in class org.jgroups.stack.StateTransferInfo
 
target_time - Variable in class org.jgroups.protocols.VERIFY_SUSPECT.Entry
 
task - Variable in class org.jgroups.blocks.executor.ExecutionService.RunnableAdapter
 
task - Variable in class org.jgroups.protocols.FD.Broadcaster
 
task - Variable in class org.jgroups.protocols.MERGE2
 
task - Variable in class org.jgroups.protocols.SHUFFLE
 
task - Variable in class org.jgroups.util.HashedTimingWheel.MyTask
 
task - Variable in class org.jgroups.util.TimeScheduler2.MyTask
 
TASK_CANCEL - Static variable in class org.jgroups.blocks.executor.ExecutorEvent
 
TASK_COMPLETE - Static variable in class org.jgroups.blocks.executor.ExecutorEvent
 
TASK_SUBMIT - Static variable in class org.jgroups.blocks.executor.ExecutorEvent
 
taskReady(long) - Method in class org.jgroups.util.TimeScheduler2
Signals that a task with a lower execution time than next_execution_time is ready
TCP - Class in org.jgroups.protocols
TCP based protocol.
TCP() - Constructor for class org.jgroups.protocols.TCP
 
TCP_CLIENT_BIND_ADDR - Static variable in class org.jgroups.Global
 
TCP_NIO - Class in org.jgroups.protocols
Transport using NIO
TCP_NIO() - Constructor for class org.jgroups.protocols.TCP_NIO
 
tcp_nodelay - Variable in class org.jgroups.blocks.TCPConnectionMap
 
tcp_nodelay - Variable in class org.jgroups.protocols.BasicTCP
 
tcp_nodelay - Variable in class org.jgroups.stack.RouterStub
 
TCPConnectionMap - Class in org.jgroups.blocks
 
TCPConnectionMap(String, ThreadFactory, SocketFactory, TCPConnectionMap.Receiver, InetAddress, InetAddress, int, int, int) - Constructor for class org.jgroups.blocks.TCPConnectionMap
 
TCPConnectionMap(String, ThreadFactory, TCPConnectionMap.Receiver, InetAddress, InetAddress, int, int, int, long, long) - Constructor for class org.jgroups.blocks.TCPConnectionMap
 
TCPConnectionMap(String, ThreadFactory, SocketFactory, TCPConnectionMap.Receiver, InetAddress, InetAddress, int, int, int, long, long) - Constructor for class org.jgroups.blocks.TCPConnectionMap
 
TCPConnectionMap.ConnectionAcceptor - Class in org.jgroups.blocks
 
TCPConnectionMap.ConnectionAcceptor() - Constructor for class org.jgroups.blocks.TCPConnectionMap.ConnectionAcceptor
 
TCPConnectionMap.Mapper - Class in org.jgroups.blocks
 
TCPConnectionMap.Mapper(ThreadFactory) - Constructor for class org.jgroups.blocks.TCPConnectionMap.Mapper
 
TCPConnectionMap.Mapper(ThreadFactory, long) - Constructor for class org.jgroups.blocks.TCPConnectionMap.Mapper
 
TCPConnectionMap.Receiver - Interface in org.jgroups.blocks
Used for message reception.
TCPConnectionMap.TCPConnection - Class in org.jgroups.blocks
 
TCPConnectionMap.TCPConnection.ConnectionPeerReceiver - Class in org.jgroups.blocks
 
TCPConnectionMap.TCPConnection.ConnectionPeerReceiver(ThreadFactory) - Constructor for class org.jgroups.blocks.TCPConnectionMap.TCPConnection.ConnectionPeerReceiver
 
TCPConnectionMap.TCPConnection.Sender - Class in org.jgroups.blocks
 
TCPConnectionMap.TCPConnection.Sender(ThreadFactory, int) - Constructor for class org.jgroups.blocks.TCPConnectionMap.TCPConnection.Sender
 
TCPGOSSIP - Class in org.jgroups.protocols
The TCPGOSSIP protocol layer retrieves the initial membership (used by the GMS when started by sending event FIND_INITIAL_MBRS down the stack).
TCPGOSSIP() - Constructor for class org.jgroups.protocols.TCPGOSSIP
 
TCPPING - Class in org.jgroups.protocols
The TCPPING protocol defines a static cluster membership.
TCPPING() - Constructor for class org.jgroups.protocols.TCPPING
 
TCPPING_INITIAL_HOSTS - Static variable in class org.jgroups.Global
 
tenant - Variable in class org.jgroups.protocols.SWIFT_PING
 
thread - Variable in class org.jgroups.stack.DiagnosticsHandler
 
thread_cnt - Variable in class org.jgroups.protocols.TP.DefaultBundler2
 
thread_factory - Variable in class org.jgroups.protocols.SCOPE
 
thread_factory - Variable in class org.jgroups.stack.DiagnosticsHandler
 
thread_id - Variable in class org.jgroups.util.Owner
 
THREAD_NAME - Static variable in class org.jgroups.protocols.TP.TransferQueueBundler
 
THREAD_NAME - Static variable in class org.jgroups.protocols.TP.TransferQueueBundler2
 
THREAD_NAME - Static variable in class org.jgroups.stack.DiagnosticsHandler
 
thread_naming_pattern - Variable in class org.jgroups.protocols.SCOPE
 
thread_naming_pattern - Variable in class org.jgroups.protocols.TP
 
thread_pool - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
Thread pool (configured with StreamingStateTransfer.max_pool and StreamingStateTransfer.pool_thread_keep_alive) to run StreamingStateTransfer.StateGetter threads on
thread_pool - Variable in class org.jgroups.protocols.SCOPE
 
thread_pool - Variable in class org.jgroups.protocols.TP
The thread pool which handles unmarshalling, version checks and dispatching of regular messages
thread_pool_enabled - Variable in class org.jgroups.protocols.TP
 
thread_pool_keep_alive_time - Variable in class org.jgroups.protocols.SCOPE
 
thread_pool_keep_alive_time - Variable in class org.jgroups.protocols.TP
 
thread_pool_max_threads - Variable in class org.jgroups.protocols.SCOPE
 
thread_pool_max_threads - Variable in class org.jgroups.protocols.TP
 
thread_pool_min_threads - Variable in class org.jgroups.protocols.SCOPE
 
thread_pool_min_threads - Variable in class org.jgroups.protocols.TP
 
thread_pool_queue - Variable in class org.jgroups.protocols.TP
Used if thread_pool is a ThreadPoolExecutor and thread_pool_queue_enabled is true
thread_pool_queue_enabled - Variable in class org.jgroups.protocols.TP
 
thread_pool_queue_max_size - Variable in class org.jgroups.protocols.TP
 
thread_pool_rejection_policy - Variable in class org.jgroups.protocols.TP
 
THREAD_SHUTDOWN_WAIT_TIME - Static variable in class org.jgroups.Global
 
ThreadFactory - Interface in org.jgroups.util
 
threadId - Variable in class org.jgroups.protocols.Executing.RequestWithThread
 
THREADPOOL_SHUTDOWN_WAIT_TIME - Static variable in class org.jgroups.Global
 
threshold - Variable in class org.jgroups.protocols.SEQUENCER
 
throw_exception_on_timeout - Variable in class org.jgroups.protocols.RSVP
 
throwableEncountered(Throwable) - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
 
throwableEncountered(Throwable) - Method in interface org.jgroups.blocks.executor.ExecutorNotification
 
tick_time - Variable in class org.jgroups.protocols.TP
 
tick_time - Variable in class org.jgroups.util.HashedTimingWheel
 
time_period - Variable in class org.jgroups.protocols.RATE_LIMITER
 
time_period_ns - Variable in class org.jgroups.protocols.RATE_LIMITER
 
TIME_SENSITIVE - Static variable in class org.jgroups.Global
 
time_unit - Variable in class org.jgroups.blocks.locking.LockInfo
 
timeout - Variable in class org.jgroups.blocks.locking.LockInfo
 
timeout - Variable in class org.jgroups.blocks.RequestOptions
The max time (in ms) for a blocking call.
timeout - Variable in class org.jgroups.protocols.COUNTER
 
timeout - Variable in class org.jgroups.protocols.Discovery
 
timeout - Variable in class org.jgroups.protocols.FD
 
timeout - Variable in class org.jgroups.protocols.Locking.ClientLock
 
timeout - Variable in class org.jgroups.protocols.Locking.Request
 
timeout - Variable in class org.jgroups.protocols.RSVP
 
timeout - Variable in class org.jgroups.protocols.UNICAST
Deprecated. 
timeout - Variable in class org.jgroups.protocols.UNICAST2
Deprecated. 
timeout - Variable in class org.jgroups.stack.StateTransferInfo
 
timeout - Variable in class org.jgroups.util.ExpiryCache
 
TimeoutException - Exception in org.jgroups
Thrown if members fail to respond in time.
TimeoutException() - Constructor for exception org.jgroups.TimeoutException
 
TimeoutException(String) - Constructor for exception org.jgroups.TimeoutException
 
timer - Variable in class org.jgroups.protocols.Discovery
 
timer - Variable in class org.jgroups.protocols.FD
 
timer - Variable in class org.jgroups.protocols.MERGE2
 
timer - Variable in class org.jgroups.protocols.MERGE3
 
timer - Variable in class org.jgroups.protocols.pbcast.GMS
 
timer - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
timer - Variable in class org.jgroups.protocols.relay.RELAY2
 
timer - Variable in class org.jgroups.protocols.RELAY
 
timer - Variable in class org.jgroups.protocols.RSVP
 
timer - Variable in class org.jgroups.protocols.rules.SUPERVISOR
 
timer - Variable in class org.jgroups.protocols.SCOPE
 
timer - Variable in class org.jgroups.protocols.SHUFFLE
 
timer - Variable in class org.jgroups.protocols.TP
 
timer - Variable in class org.jgroups.protocols.UNICAST
 
timer - Variable in class org.jgroups.protocols.UNICAST2
 
timer - Variable in class org.jgroups.protocols.VERIFY_SUSPECT
 
timer - Variable in class org.jgroups.stack.GossipRouter
 
timer - Variable in class org.jgroups.stack.Retransmitter
 
timer_keep_alive_time - Variable in class org.jgroups.protocols.TP
 
timer_max_threads - Variable in class org.jgroups.protocols.TP
 
timer_min_threads - Variable in class org.jgroups.protocols.TP
 
TIMER_NUM_THREADS - Static variable in class org.jgroups.Global
 
timer_queue_max_size - Variable in class org.jgroups.protocols.TP
 
timer_rejection_policy - Variable in class org.jgroups.protocols.TP
 
timer_thread_factory - Variable in class org.jgroups.protocols.TP
 
timer_thread_factory - Variable in class org.jgroups.util.HashedTimingWheel
 
timer_thread_factory - Variable in class org.jgroups.util.TimeScheduler2
 
timer_thread_factory - Variable in class org.jgroups.util.TimeScheduler3
 
timer_type - Variable in class org.jgroups.protocols.TP
 
TimeScheduler - Interface in org.jgroups.util
Timer-like interface which allows for execution of tasks.
TimeScheduler.Task - Interface in org.jgroups.util
The interface that dynamic tasks (TimeScheduler.scheduleWithDynamicInterval(org.jgroups.util.TimeScheduler.Task)) must implement
TimeScheduler2 - Class in org.jgroups.util
Implementation of TimeScheduler.
TimeScheduler2() - Constructor for class org.jgroups.util.TimeScheduler2
Create a scheduler that executes tasks in dynamically adjustable intervals
TimeScheduler2(ThreadFactory, int, int, long, int, String) - Constructor for class org.jgroups.util.TimeScheduler2
 
TimeScheduler2(int) - Constructor for class org.jgroups.util.TimeScheduler2
 
TimeScheduler2.MyTask - Class in org.jgroups.util
Simple task wrapper, always executed by at most 1 thread.
TimeScheduler2.MyTask(Runnable) - Constructor for class org.jgroups.util.TimeScheduler2.MyTask
 
TimeScheduler3 - Class in org.jgroups.util
Implementation of TimeScheduler.
TimeScheduler3() - Constructor for class org.jgroups.util.TimeScheduler3
Create a scheduler that executes tasks in dynamically adjustable intervals
TimeScheduler3(ThreadFactory, int, int, long, int, String) - Constructor for class org.jgroups.util.TimeScheduler3
 
TimeScheduler3.RecurringTask - Class in org.jgroups.util
Tasks which runs more than once, either dynamic, fixed-rate or fixed-delay, until cancelled
TimeScheduler3.RecurringTask(Runnable, TimeScheduler3.TaskType, long, long, TimeUnit) - Constructor for class org.jgroups.util.TimeScheduler3.RecurringTask
 
TimeScheduler3.Task - Class in org.jgroups.util
 
TimeScheduler3.Task(Runnable) - Constructor for class org.jgroups.util.TimeScheduler3.Task
 
TimeScheduler3.Task(Runnable, long, TimeUnit) - Constructor for class org.jgroups.util.TimeScheduler3.Task
 
TimeScheduler3.TaskType - Enum in org.jgroups.util
 
timestamp - Variable in class org.jgroups.protocols.UNICAST.ReceiverEntry
 
timestamp - Variable in class org.jgroups.protocols.UNICAST.SenderEntry
 
timestamp - Variable in class org.jgroups.protocols.UNICAST2.ReceiverEntry
 
timestamp - Variable in class org.jgroups.protocols.UNICAST2.SenderEntry
 
timestamp - Variable in class org.jgroups.util.SuppressCache.Value
 
TMP_VIEW - Static variable in class org.jgroups.Event
 
to - Variable in class org.jgroups.protocols.relay.config.RelayConfig.ForwardConfig
 
to - Variable in class org.jgroups.util.SeqnoList.SeqnoRange
 
TOA - Class in org.jgroups.protocols.tom
Total Order Anycast with three communication steps (based on Skeen's Algorithm).
TOA() - Constructor for class org.jgroups.protocols.tom.TOA
 
ToaHeader - Class in org.jgroups.protocols.tom
The header for the Total Order Anycast (TOA) protocol
ToaHeader() - Constructor for class org.jgroups.protocols.tom.ToaHeader
 
toByteArray() - Method in class org.jgroups.util.ExposedByteArrayOutputStream
Creates a newly allocated byte array.
token - Variable in class org.jgroups.protocols.AuthHeader
 
token(AuthToken) - Method in class org.jgroups.protocols.AuthHeader
 
token() - Method in class org.jgroups.protocols.AuthHeader
 
TOKEN_ATTR - Static variable in class org.jgroups.auth.X509Token
 
Topology - Class in org.jgroups.demos
Demonstrates the membership service.
Topology() - Constructor for class org.jgroups.demos.Topology
 
TopologyUUID - Class in org.jgroups.util
Subclass of UUID which adds 3 strings (siteId, rackId and machineId)as payload.
TopologyUUID() - Constructor for class org.jgroups.util.TopologyUUID
 
TopologyUUID(byte[], String, String, String) - Constructor for class org.jgroups.util.TopologyUUID
 
TopologyUUID(long, long, String, String, String) - Constructor for class org.jgroups.util.TopologyUUID
 
tos - Variable in class org.jgroups.protocols.UDP
Traffic class for sending unicast and multicast datagrams.
tossWeightedCoin(double) - Static method in class org.jgroups.util.Util
Tosses a coin weighted with probability and returns true or false.
toString() - Method in class org.jgroups.AnycastAddress
 
toString() - Method in class org.jgroups.auth.DemoToken.DemoHeader
 
toString() - Method in class org.jgroups.auth.SimpleToken
 
toString() - Method in class org.jgroups.blocks.BasicConnectionTable
 
toString() - Method in class org.jgroups.blocks.Cache
 
toString() - Method in class org.jgroups.blocks.executor.Executions.StreamableCallable
 
toString() - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
 
toString() - Method in class org.jgroups.blocks.GridFile.Metadata
 
toString() - Method in class org.jgroups.blocks.GroupRequest
 
toString() - Method in class org.jgroups.blocks.LazyRemovalCache
 
toString() - Method in class org.jgroups.blocks.locking.AwaitInfo
 
toString() - Method in class org.jgroups.blocks.locking.LockInfo
 
toString() - Method in class org.jgroups.blocks.MemcachedConnector.Request
 
toString() - Method in class org.jgroups.blocks.MethodCall
 
toString() - Method in class org.jgroups.blocks.mux.MuxHeader
 
toString() - Method in class org.jgroups.blocks.PartitionedHashMap
 
toString() - Method in class org.jgroups.blocks.ReplCache
 
toString() - Method in class org.jgroups.blocks.ReplCache.Value
 
toString() - Method in class org.jgroups.blocks.ReplicatedTree.Node
 
toString() - Method in class org.jgroups.blocks.ReplicatedTree
 
toString() - Method in class org.jgroups.blocks.Request
 
toString() - Method in class org.jgroups.blocks.RequestCorrelator.Header
 
toString() - Method in class org.jgroups.blocks.RequestCorrelator.MultiDestinationHeader
 
toString() - Method in class org.jgroups.blocks.RequestOptions
 
toString() - Method in class org.jgroups.blocks.TCPConnectionMap.Mapper
 
toString() - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
 
toString() - Method in class org.jgroups.blocks.TCPConnectionMap
 
toString() - Method in class org.jgroups.blocks.UnicastRequest
 
toString() - Method in class org.jgroups.conf.ClassConfigurator
 
toString(Object) - Method in interface org.jgroups.conf.PropertyConverter
Converts the value to a string.
toString(Object) - Method in class org.jgroups.conf.PropertyConverters.BindInterface
 
toString(Object) - Method in class org.jgroups.conf.PropertyConverters.Default
 
toString(Object) - Method in class org.jgroups.conf.PropertyConverters.FlushInvoker
 
toString(Object) - Method in class org.jgroups.conf.PropertyConverters.InitialHosts
 
toString(Object) - Method in class org.jgroups.conf.PropertyConverters.InitialHosts2
 
toString(Object) - Method in class org.jgroups.conf.PropertyConverters.IntegerArray
 
toString(Object) - Method in class org.jgroups.conf.PropertyConverters.LongArray
 
toString(Object) - Method in class org.jgroups.conf.PropertyConverters.NetworkInterfaceList
 
toString() - Method in class org.jgroups.conf.ProtocolConfiguration
 
toString() - Method in class org.jgroups.demos.DrawCommand
 
toString() - Method in class org.jgroups.demos.JmxDemo.MyNotification
 
toString() - Method in class org.jgroups.demos.wb.Node
 
toString() - Method in class org.jgroups.Event
 
toString() - Method in class org.jgroups.Header
 
toString(boolean) - Method in class org.jgroups.JChannel
 
toString() - Method in class org.jgroups.Membership
 
toString() - Method in class org.jgroups.MergeView
 
toString() - Method in class org.jgroups.Message
 
toString() - Method in class org.jgroups.protocols.AuthHeader
 
toString() - Method in class org.jgroups.protocols.COUNTER.AddAndGetRequest
 
toString() - Method in class org.jgroups.protocols.COUNTER.BooleanResponse
 
toString() - Method in class org.jgroups.protocols.COUNTER.CompareAndSetRequest
 
toString() - Method in class org.jgroups.protocols.COUNTER.CounterImpl
 
toString() - Method in class org.jgroups.protocols.COUNTER.DeleteRequest
 
toString() - Method in class org.jgroups.protocols.COUNTER.ExceptionResponse
 
toString() - Method in class org.jgroups.protocols.COUNTER.GetOrCreateResponse
 
toString() - Method in class org.jgroups.protocols.COUNTER.ReconcileRequest
 
toString() - Method in class org.jgroups.protocols.COUNTER.ReconcileResponse
 
toString() - Method in class org.jgroups.protocols.COUNTER.ReconciliationTask
 
toString() - Method in class org.jgroups.protocols.COUNTER.ResendPendingRequests
 
toString() - Method in class org.jgroups.protocols.COUNTER.SetRequest
 
toString() - Method in class org.jgroups.protocols.COUNTER.SimpleRequest
 
toString() - Method in class org.jgroups.protocols.COUNTER.SimpleResponse
 
toString() - Method in class org.jgroups.protocols.COUNTER.UpdateRequest
 
toString() - Method in class org.jgroups.protocols.COUNTER.ValueResponse
 
toString() - Method in class org.jgroups.protocols.COUNTER.VersionedValue
 
toString() - Method in class org.jgroups.protocols.DAISYCHAIN.DaisyHeader
 
toString() - Method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
 
toString() - Method in class org.jgroups.protocols.EXAMPLE.ExampleHeader
 
toString() - Method in class org.jgroups.protocols.Executing.Owner
 
toString() - Method in class org.jgroups.protocols.Executing.Request
 
toString() - Method in class org.jgroups.protocols.Executing.RequestWithThread
 
toString() - Method in class org.jgroups.protocols.FcHeader
 
toString() - Method in class org.jgroups.protocols.FD.BroadcastTask
 
toString() - Method in class org.jgroups.protocols.FD.FdHeader
 
toString() - Method in class org.jgroups.protocols.FD.Monitor
 
toString() - Method in class org.jgroups.protocols.FD_ALL.HeartbeatHeader
 
toString() - Method in class org.jgroups.protocols.FD_SIMPLE.FdHeader
 
toString() - Method in class org.jgroups.protocols.FD_SOCK.FdHeader
 
toString() - Method in class org.jgroups.protocols.FlowControl.Credit
 
toString() - Method in class org.jgroups.protocols.FORWARD_TO_COORD.ForwardHeader
 
toString() - Method in class org.jgroups.protocols.FragHeader
 
toString() - Method in class org.jgroups.protocols.HTOTAL.HTotalHeader
 
toString() - Method in class org.jgroups.protocols.Locking.ClientLock
 
toString() - Method in class org.jgroups.protocols.Locking.Request
 
toString() - Method in class org.jgroups.protocols.Locking.ServerLock
 
toString() - Method in class org.jgroups.protocols.MERGE3.InfoSender
 
toString() - Method in class org.jgroups.protocols.MERGE3.MergeHeader
 
toString() - Method in class org.jgroups.protocols.MERGE3.ViewConsistencyChecker
 
toString() - Method in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
 
toString() - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
toString() - Method in class org.jgroups.protocols.pbcast.GmsImpl.Request
 
toString() - Method in class org.jgroups.protocols.pbcast.JoinRsp
 
toString() - Method in class org.jgroups.protocols.pbcast.MergeData
 
toString() - Method in class org.jgroups.protocols.pbcast.NAKACK2.RetransmitTask
 
toString() - Method in class org.jgroups.protocols.pbcast.NakAckHeader
 
toString() - Method in class org.jgroups.protocols.pbcast.NakAckHeader2
 
toString() - Method in class org.jgroups.protocols.pbcast.STABLE.ResumeTask
 
toString() - Method in class org.jgroups.protocols.pbcast.STABLE.StableHeader
 
toString() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
toString() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
 
toString() - Method in class org.jgroups.protocols.PDC.Mapping
 
toString() - Method in class org.jgroups.protocols.PingData
 
toString() - Method in class org.jgroups.protocols.PingHeader
 
toString() - Method in class org.jgroups.protocols.PrioHeader
 
toString() - Method in class org.jgroups.protocols.relay.CanBeSiteMaster
 
toString() - Method in class org.jgroups.protocols.relay.CanBeSiteMasterTopology
 
toString() - Method in class org.jgroups.protocols.relay.config.RelayConfig.BridgeConfig
 
toString() - Method in class org.jgroups.protocols.relay.config.RelayConfig.ForwardConfig
 
toString() - Method in class org.jgroups.protocols.relay.config.RelayConfig.ProgrammaticBridgeConfig
 
toString() - Method in class org.jgroups.protocols.relay.config.RelayConfig.PropertiesBridgeConfig
 
toString() - Method in class org.jgroups.protocols.relay.config.RelayConfig.SiteConfig
 
toString() - Method in class org.jgroups.protocols.relay.RELAY2.Relay2Header
 
toString() - Method in class org.jgroups.protocols.relay.Relayer.Route
 
toString() - Method in class org.jgroups.protocols.RELAY.RelayHeader
 
toString() - Method in class org.jgroups.protocols.relay.SiteMaster
 
toString() - Method in class org.jgroups.protocols.relay.SiteUUID
 
toString() - Method in class org.jgroups.protocols.RELAY.ViewData
 
toString() - Method in class org.jgroups.protocols.RSVP.Entry
 
toString() - Method in class org.jgroups.protocols.RSVP.RsvpHeader
 
toString() - Method in class org.jgroups.protocols.rules.CheckFDMonitor
 
toString() - Method in class org.jgroups.protocols.SCOPE.ScopeHeader
 
toString() - Method in class org.jgroups.protocols.SEQUENCER.SequencerHeader
 
toString() - Method in class org.jgroups.protocols.SHARED_LOOPBACK
 
toString() - Method in class org.jgroups.protocols.STOMP.Frame
 
toString() - Method in class org.jgroups.protocols.STOMP.StompHeader
 
toString() - Method in class org.jgroups.protocols.tom.MessageID
 
toString() - Method in class org.jgroups.protocols.tom.ToaHeader
 
toString() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
 
toString() - Method in class org.jgroups.protocols.TP
 
toString() - Method in class org.jgroups.protocols.TpHeader
 
toString() - Method in class org.jgroups.protocols.TRACE
 
toString() - Method in class org.jgroups.protocols.TUNNEL
 
toString() - Method in class org.jgroups.protocols.UDP.PacketReceiver
 
toString() - Method in class org.jgroups.protocols.UNICAST.ConnectionReaper
 
toString() - Method in class org.jgroups.protocols.UNICAST.ReceiverEntry
 
toString() - Method in class org.jgroups.protocols.UNICAST.RetransmitTask
 
toString() - Method in class org.jgroups.protocols.UNICAST.SenderEntry
 
toString() - Method in class org.jgroups.protocols.UNICAST.UnicastHeader
 
toString() - Method in class org.jgroups.protocols.UNICAST2.ConnectionReaper
 
toString() - Method in class org.jgroups.protocols.UNICAST2.ReceiverEntry
 
toString() - Method in class org.jgroups.protocols.UNICAST2.RetransmitTask
 
toString() - Method in class org.jgroups.protocols.UNICAST2.SenderEntry
 
toString() - Method in class org.jgroups.protocols.UNICAST2.Unicast2Header
 
toString() - Method in class org.jgroups.protocols.VERIFY_SUSPECT.Entry
 
toString() - Method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
 
toString() - Method in class org.jgroups.stack.Configurator.InetAddressInfo
 
toString() - Method in class org.jgroups.stack.DefaultRetransmitter.SeqnoTask
 
toString() - Method in class org.jgroups.stack.DefaultRetransmitter
 
toString() - Method in class org.jgroups.stack.ExponentialInterval
 
toString() - Method in class org.jgroups.stack.GossipData
 
toString() - Method in class org.jgroups.stack.IpAddress
 
toString() - Method in class org.jgroups.stack.NakReceiverWindow
 
toString() - Method in class org.jgroups.stack.ProtocolStack.RefCounter
 
toString() - Method in class org.jgroups.stack.RangeBasedRetransmitter.RangeTask
 
toString() - Method in class org.jgroups.stack.RangeBasedRetransmitter
 
toString() - Method in class org.jgroups.stack.RouterStub
 
toString() - Method in class org.jgroups.stack.StateTransferInfo
 
toString() - Method in exception org.jgroups.SuspectedException
 
toString() - Method in exception org.jgroups.TimeoutException
 
toString() - Method in exception org.jgroups.UnreachableException
 
toString() - Method in class org.jgroups.util.AckCollector
 
toString() - Method in class org.jgroups.util.AdditionalDataUUID
 
toString() - Method in class org.jgroups.util.AgeOutCache
 
toString() - Method in class org.jgroups.util.BlockingInputStream
 
toString() - Method in class org.jgroups.util.Buffer
 
toString() - Method in class org.jgroups.util.CreditMap
 
toString() - Method in class org.jgroups.util.DefaultTimeScheduler.RobustRunnable
 
toString() - Method in class org.jgroups.util.DefaultTimeScheduler
 
toString() - Method in class org.jgroups.util.Digest.DigestEntry
 
toString() - Method in class org.jgroups.util.Digest
 
toString() - Method in class org.jgroups.util.ExpiryCache
 
toString() - Method in class org.jgroups.util.ExposedByteArrayOutputStream
Converts the buffer's contents into a string decoding bytes using the platform's default character set.
toString(String) - Method in class org.jgroups.util.ExposedByteArrayOutputStream
Converts the buffer's contents into a string by decoding the bytes using the specified charsetName.
toString() - Method in class org.jgroups.util.FixedSizeBitSet
Returns a string representation of this bit set.
toString() - Method in class org.jgroups.util.HashedTimingWheel.MyTask
 
toString() - Method in class org.jgroups.util.HashedTimingWheel
 
toString() - Method in class org.jgroups.util.Headers
 
toString() - Method in class org.jgroups.util.MergeId
 
toString() - Method in class org.jgroups.util.Owner
 
toString() - Method in class org.jgroups.util.PayloadUUID
 
toString() - Method in class org.jgroups.util.Promise
 
toString() - Method in class org.jgroups.util.Queue
prints the size of the queue
toString() - Method in exception org.jgroups.util.QueueClosedException
 
toString() - Method in class org.jgroups.util.Range
 
toString() - Method in class org.jgroups.util.ResponseCollector
 
toString() - Method in class org.jgroups.util.RetransmitTable
 
toString() - Method in class org.jgroups.util.RingBuffer
 
toString() - Method in class org.jgroups.util.RingBufferLockless
 
toString() - Method in class org.jgroups.util.Rsp
 
toString() - Method in class org.jgroups.util.RspList
 
toString() - Method in class org.jgroups.util.Seqno
 
toString() - Method in class org.jgroups.util.SeqnoList.Seqno
 
toString() - Method in class org.jgroups.util.SeqnoList.SeqnoRange
 
toString() - Method in class org.jgroups.util.SeqnoList
 
toString() - Method in class org.jgroups.util.SeqnoRange
 
toString() - Method in class org.jgroups.util.SingletonAddress
 
toString() - Method in class org.jgroups.util.StateTransferResult
 
toString() - Method in class org.jgroups.util.SuppressCache
 
toString() - Method in class org.jgroups.util.SuppressCache.Value
 
toString() - Method in class org.jgroups.util.Table
 
toString() - Method in class org.jgroups.util.TimeScheduler2.MyTask
 
toString() - Method in class org.jgroups.util.TimeScheduler2
 
toString() - Method in class org.jgroups.util.TimeScheduler3.Task
 
toString() - Method in class org.jgroups.util.TimeScheduler3
 
toString() - Method in class org.jgroups.util.TopologyUUID
 
toString() - Method in class org.jgroups.util.Triple
 
toString() - Method in class org.jgroups.util.Tuple
 
toString() - Method in class org.jgroups.util.UUID
 
toString() - Method in class org.jgroups.View
 
toString() - Method in class org.jgroups.ViewId
 
toStringAsObject() - Method in class org.jgroups.Message
Tries to read an object from the message's buffer and prints it
toStringDetailed() - Method in class org.jgroups.util.TopologyUUID
 
toStringDetails() - Method in class org.jgroups.blocks.MethodCall
 
toStringLong() - Method in class org.jgroups.util.UUID
Returns a String object representing this UUID.
toStringShort() - Method in class org.jgroups.protocols.Locking.Request
 
toStringSorted() - Method in class org.jgroups.util.Digest
 
toStringSorted(boolean) - Method in class org.jgroups.util.Digest
 
total_block_time - Variable in class org.jgroups.protocols.RATE_LIMITER
 
total_block_time - Variable in class org.jgroups.util.CreditMap
 
total_blocking_time - Variable in class org.jgroups.protocols.FlowControl.Credit
 
TotalOrder - Class in org.jgroups.demos
Originally written to be a demo for TOTAL order (code to be written by a student).
TotalOrder(String, long, int, int, String, int) - Constructor for class org.jgroups.demos.TotalOrder
 
TP - Class in org.jgroups.protocols
Generic transport - specific implementations should extend this abstract class.
TP() - Constructor for class org.jgroups.protocols.TP
Creates the TP protocol, and initializes the state variables, does however not start any sockets or threads.
TP.Bundler - Interface in org.jgroups.protocols
 
TP.DefaultBundler - Class in org.jgroups.protocols
The sender's thread adds a message to the hashmap and - if the accumulated size has been exceeded - sends all bundled messages.
TP.DefaultBundler() - Constructor for class org.jgroups.protocols.TP.DefaultBundler
 
TP.DefaultBundler2 - Class in org.jgroups.protocols
Similarly to DefaultBundler, this bundler type uses the sender's thread to send accumulated messages.
TP.DefaultBundler2() - Constructor for class org.jgroups.protocols.TP.DefaultBundler2
 
TP.ProtocolAdapter - Class in org.jgroups.protocols
Used when the transport is shared (singleton_name is not null).
TP.ProtocolAdapter(String, Address, short, Protocol, Protocol, String) - Constructor for class org.jgroups.protocols.TP.ProtocolAdapter
 
TP.TransferQueueBundler - Class in org.jgroups.protocols
Uses a queue to transfer messages between the sender's thread and a single bundler thread.
TP.TransferQueueBundler2 - Class in org.jgroups.protocols
Similarly to DefaultBundler2, this bundler accumulates messages until max size or time have been exceeded, but does send individual messages immediately when no other messages are available.
TpHeader - Class in org.jgroups.protocols
Generic transport header, used by TP.
TpHeader() - Constructor for class org.jgroups.protocols.TpHeader
 
TpHeader(String) - Constructor for class org.jgroups.protocols.TpHeader
 
trace(String) - Method in class org.jgroups.logging.JDKLogImpl
 
trace(Object) - Method in class org.jgroups.logging.JDKLogImpl
 
trace(String, Throwable) - Method in class org.jgroups.logging.JDKLogImpl
 
trace(Object) - Method in interface org.jgroups.logging.Log
 
trace(String) - Method in interface org.jgroups.logging.Log
 
trace(String, Throwable) - Method in interface org.jgroups.logging.Log
 
trace(Object) - Method in class org.jgroups.logging.Log4JLogImpl
 
trace(String) - Method in class org.jgroups.logging.Log4JLogImpl
 
trace(String, Throwable) - Method in class org.jgroups.logging.Log4JLogImpl
 
TRACE - Class in org.jgroups.protocols
 
TRACE() - Constructor for class org.jgroups.protocols.TRACE
 
transient_flags - Variable in class org.jgroups.Message
 
transientFlagsToString() - Method in class org.jgroups.Message
 
transport - Variable in class org.jgroups.blocks.RequestCorrelator
The protocol layer to use to pass up/down messages.
transport_supports_multicasting - Variable in class org.jgroups.protocols.MERGE3
 
transportClosed() - Method in class org.jgroups.blocks.GroupRequest
Marks all responses with an exception (unless a response was already marked as done)
transportClosed() - Method in interface org.jgroups.blocks.RspCollector
 
transportClosed() - Method in class org.jgroups.blocks.UnicastRequest
 
trigger() - Method in class org.jgroups.protocols.rules.CheckFDMonitor
 
trigger() - Method in class org.jgroups.protocols.rules.Rule
The action of the rule.
trigger() - Method in class org.jgroups.protocols.rules.SampleRule
 
triggerXmit() - Method in class org.jgroups.protocols.pbcast.NAKACK2
 
triggerXmit() - Method in class org.jgroups.protocols.UNICAST2
 
trim(String) - Static method in class org.jgroups.blocks.GridFile
 
Triple<V1,V2,V3> - Class in org.jgroups.util
Holds 3 values, useful when we have a map with a key, but more than 1 value and we don't want to create a separate holder object for the values, and don't want to pass the values as a list or array.
Triple(V1, V2, V3) - Constructor for class org.jgroups.util.Triple
 
tryAcquireShared(int) - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture.Sync
Implements AQS base acquire to succeed if ran or cancelled
tryLock() - Method in class org.jgroups.blocks.locking.LockService.LockImpl
 
tryLock(long, TimeUnit) - Method in class org.jgroups.blocks.locking.LockService.LockImpl
 
tryLock() - Method in class org.jgroups.protocols.Locking.ClientLock
 
tryLock(long, TimeUnit) - Method in class org.jgroups.protocols.Locking.ClientLock
 
tryReleaseShared(int) - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture.Sync
Implements AQS base release to always signal after setting final done status by nulling runner thread.
ttl - Variable in class org.jgroups.protocols.FD_ICMP
Time-to-live for InetAddress.isReachable()
ttl - Variable in class org.jgroups.stack.DiagnosticsHandler
 
TUNNEL - Class in org.jgroups.protocols
Replacement for UDP.
TUNNEL() - Constructor for class org.jgroups.protocols.TUNNEL
 
TUNNEL.StubReceiver - Class in org.jgroups.protocols
 
TUNNEL.StubReceiver(RouterStub) - Constructor for class org.jgroups.protocols.TUNNEL.StubReceiver
 
TUNNEL.TUNNELPolicy - Interface in org.jgroups.protocols
 
Tuple<V1,V2> - Class in org.jgroups.util
Holds 2 values, useful when we have a map with a key, but more than 1 value and we don't want to create a separate holder object for the values, and don't want to pass the values as a list or array.
Tuple(V1, V2) - Constructor for class org.jgroups.util.Tuple
 
type - Variable in class org.jgroups.auth.DemoToken.DemoHeader
 
type - Variable in class org.jgroups.blocks.RequestCorrelator.Header
Type of header: request or reply
type - Variable in class org.jgroups.protocols.Executing.Request
 
type - Variable in class org.jgroups.protocols.FD.FdHeader
 
type - Variable in class org.jgroups.protocols.FORWARD_TO_COORD.ForwardHeader
 
type - Variable in class org.jgroups.protocols.Locking.Request
 
type - Variable in class org.jgroups.protocols.MERGE3.MergeHeader
 
type - Variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
type - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
 
type - Variable in class org.jgroups.protocols.PingHeader
 
type - Variable in class org.jgroups.protocols.relay.RELAY2.Relay2Header
 
type - Variable in class org.jgroups.protocols.RELAY.RelayHeader
 
type - Variable in class org.jgroups.protocols.RSVP.RsvpHeader
 
type - Variable in class org.jgroups.protocols.SEQUENCER.SequencerHeader
 
type - Variable in class org.jgroups.protocols.STOMP.StompHeader
 
type - Variable in class org.jgroups.util.TimeScheduler3.RecurringTask
 
type2Str(byte) - Static method in class org.jgroups.protocols.pbcast.NakAckHeader
 
type2Str(byte) - Static method in class org.jgroups.protocols.pbcast.NakAckHeader2
 
type2Str(byte) - Static method in class org.jgroups.protocols.UNICAST.UnicastHeader
 
type2Str(byte) - Static method in class org.jgroups.protocols.UNICAST2.Unicast2Header
 
type2String(int) - Static method in class org.jgroups.Event
 
type2String(byte) - Static method in class org.jgroups.protocols.FD_SOCK.FdHeader
 
type2String(int) - Static method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
type2String(byte) - Static method in class org.jgroups.protocols.tom.ToaHeader
 
type2String(int) - Static method in class org.jgroups.stack.GossipRouter
 
types - Variable in class org.jgroups.blocks.MethodCall
The class types, e.g., new Class[]{String.class, int.class}.
TYPES - Static variable in class org.jgroups.blocks.MethodCall
Use class information.
typeToString(byte) - Static method in class org.jgroups.protocols.FORWARD_TO_COORD.ForwardHeader
 
typeToString(byte) - Static method in class org.jgroups.protocols.relay.RELAY2.Relay2Header
 
typeToString() - Method in class org.jgroups.protocols.RSVP.RsvpHeader
 
typeToString(byte) - Static method in class org.jgroups.protocols.SCOPE.ScopeHeader
 

U

ucast_receiver - Variable in class org.jgroups.protocols.UDP
Runnable to receive unicast packets
ucast_recv_buf_size - Variable in class org.jgroups.protocols.UDP
 
ucast_send_buf_size - Variable in class org.jgroups.protocols.UDP
 
UDP - Class in org.jgroups.protocols
IP multicast transport based on UDP.
UDP() - Constructor for class org.jgroups.protocols.UDP
 
UDP.PacketReceiver - Class in org.jgroups.protocols
 
UDP.PacketReceiver(DatagramSocket, String, Runnable) - Constructor for class org.jgroups.protocols.UDP.PacketReceiver
 
UDP_IP_TTL - Static variable in class org.jgroups.Global
 
UDP_MCAST_ADDR - Static variable in class org.jgroups.Global
 
UDP_MCAST_PORT - Static variable in class org.jgroups.Global
 
UFC - Class in org.jgroups.protocols
Simple flow control protocol based on a credit system.
UFC() - Constructor for class org.jgroups.protocols.UFC
 
unblock() - Method in class org.jgroups.blocks.PartitionedHashMap.ConsistentHashFunction
 
unblock() - Method in class org.jgroups.blocks.PartitionedHashMap
 
unblock() - Method in class org.jgroups.blocks.ReplCache
 
unblock() - Method in class org.jgroups.blocks.ReplicatedHashMap
 
unblock() - Method in class org.jgroups.demos.QuoteClient
 
unblock() - Method in class org.jgroups.demos.wb.Whiteboard
 
UNBLOCK - Static variable in class org.jgroups.Event
 
unblock() - Method in interface org.jgroups.MembershipListener
Called after the FLUSH protocol has unblocked previously blocked senders, and messages can be sent again.
unblock() - Method in class org.jgroups.protocols.FC
Allows to unblock a blocked sender from an external program, e.g.
unblock() - Method in class org.jgroups.protocols.FlowControl
Allows to unblock all blocked senders from an external program, e.g.
unblock() - Method in class org.jgroups.protocols.MFC
Allows to unblock a blocked sender from an external program, e.g.
unblock() - Method in class org.jgroups.protocols.UFC
 
unblock() - Method in class org.jgroups.ReceiverAdapter
Called after the FLUSH protocol has unblocked previously blocked senders, and messages can be sent again.
unblockAll() - Method in class org.jgroups.protocols.SEQUENCER
 
unblockAll() - Method in class org.jgroups.util.ForwardQueue
 
UNICAST - Class in org.jgroups.protocols
Reliable unicast layer.
UNICAST() - Constructor for class org.jgroups.protocols.UNICAST
 
UNICAST.ConnectionReaper - Class in org.jgroups.protocols
 
UNICAST.ConnectionReaper() - Constructor for class org.jgroups.protocols.UNICAST.ConnectionReaper
 
UNICAST.ReceiverEntry - Class in org.jgroups.protocols
 
UNICAST.ReceiverEntry(Table<Message>, long) - Constructor for class org.jgroups.protocols.UNICAST.ReceiverEntry
 
UNICAST.RetransmitTask - Class in org.jgroups.protocols
Retransmitter task which periodically (every xmit_interval ms) looks at all the retransmit (send) tables and re-sends messages for which we haven't received an ack yet
UNICAST.RetransmitTask() - Constructor for class org.jgroups.protocols.UNICAST.RetransmitTask
 
UNICAST.SenderEntry - Class in org.jgroups.protocols
 
UNICAST.SenderEntry(short) - Constructor for class org.jgroups.protocols.UNICAST.SenderEntry
 
UNICAST.UnicastHeader - Class in org.jgroups.protocols
The following types and fields are serialized:
UNICAST.UnicastHeader() - Constructor for class org.jgroups.protocols.UNICAST.UnicastHeader
 
UNICAST.UnicastHeader(byte, long) - Constructor for class org.jgroups.protocols.UNICAST.UnicastHeader
 
UNICAST.UnicastHeader(byte, long, short, boolean) - Constructor for class org.jgroups.protocols.UNICAST.UnicastHeader
 
UNICAST2 - Class in org.jgroups.protocols
Reliable unicast layer.
UNICAST2() - Constructor for class org.jgroups.protocols.UNICAST2
 
UNICAST2.ConnectionReaper - Class in org.jgroups.protocols
 
UNICAST2.ConnectionReaper() - Constructor for class org.jgroups.protocols.UNICAST2.ConnectionReaper
 
UNICAST2.ReceiverEntry - Class in org.jgroups.protocols
 
UNICAST2.ReceiverEntry(Table<Message>, short) - Constructor for class org.jgroups.protocols.UNICAST2.ReceiverEntry
 
UNICAST2.RetransmitTask - Class in org.jgroups.protocols
Retransmitter task which periodically (every xmit_interval ms) looks at all the retransmit tables and sends retransmit request to all members from which we have missing messages
UNICAST2.RetransmitTask() - Constructor for class org.jgroups.protocols.UNICAST2.RetransmitTask
 
UNICAST2.SenderEntry - Class in org.jgroups.protocols
 
UNICAST2.SenderEntry(short) - Constructor for class org.jgroups.protocols.UNICAST2.SenderEntry
 
UNICAST2.Unicast2Header - Class in org.jgroups.protocols
The following types and fields are serialized:
UNICAST2.Unicast2Header() - Constructor for class org.jgroups.protocols.UNICAST2.Unicast2Header
 
UNICAST2.Unicast2Header(byte) - Constructor for class org.jgroups.protocols.UNICAST2.Unicast2Header
 
UNICAST2.Unicast2Header(byte, long) - Constructor for class org.jgroups.protocols.UNICAST2.Unicast2Header
 
UNICAST2.Unicast2Header(byte, long, long, short, boolean) - Constructor for class org.jgroups.protocols.UNICAST2.Unicast2Header
 
UnicastRequest<T> - Class in org.jgroups.blocks
Sends a request to a single target destination
UnicastRequest(Message, RequestCorrelator, Address, RequestOptions) - Constructor for class org.jgroups.blocks.UnicastRequest
 
UnicastRequest(Message, Address, RequestOptions) - Constructor for class org.jgroups.blocks.UnicastRequest
 
uninstallRule(String) - Method in class org.jgroups.protocols.rules.SUPERVISOR
 
unlock() - Method in class org.jgroups.blocks.locking.LockService.LockImpl
 
UNLOCK - Static variable in class org.jgroups.Event
 
unlock() - Method in class org.jgroups.protocols.Locking.ClientLock
 
UNLOCK_ALL - Static variable in class org.jgroups.Event
 
unlockAll() - Method in class org.jgroups.blocks.locking.LockService
 
unlockAll() - Method in class org.jgroups.protocols.Locking
 
unlocked(String, Owner) - Method in interface org.jgroups.blocks.locking.LockNotification
 
unlocked(String, Owner) - Method in class org.jgroups.demos.LockServiceDemo
 
unlocked(String, Owner) - Method in class org.jgroups.protocols.CENTRAL_LOCK
 
unreachable - Variable in class org.jgroups.util.Rsp
If true, the sender (below) could not be reached, e.g.
UnreachableException - Exception in org.jgroups
Thrown if member in different site cannot be contacted; used by RELAY2
UnreachableException(Address) - Constructor for exception org.jgroups.UnreachableException
 
UnreachableException(String, Address) - Constructor for exception org.jgroups.UnreachableException
 
unregister(Object, MBeanServer, String) - Static method in class org.jgroups.jmx.JmxConfigurator
 
unregister(MBeanServer, String) - Static method in class org.jgroups.jmx.JmxConfigurator
Unregisters object_name and everything under it
unregister(AUTH.UpHandler) - Method in class org.jgroups.protocols.AUTH
 
unregister(EventHandler) - Method in class org.jgroups.protocols.rules.SUPERVISOR
 
unregister(String, Address) - Static method in class org.jgroups.protocols.SHARED_LOOPBACK
 
unregisterAndDestroyStub(InetSocketAddress) - Method in class org.jgroups.stack.RouterStubManager
 
unregisterChannel(MBeanServer, ObjectName) - Static method in class org.jgroups.jmx.JmxConfigurator
 
unregisterChannel(MBeanServer, String) - Static method in class org.jgroups.jmx.JmxConfigurator
 
unregisterChannel(JChannel, MBeanServer, String) - Static method in class org.jgroups.jmx.JmxConfigurator
 
unregisterChannel(JChannel, MBeanServer, String, String) - Static method in class org.jgroups.jmx.JmxConfigurator
 
unregisterProbeHandler(TP) - Method in class org.jgroups.blocks.RequestCorrelator
 
unregisterProbeHandler(DiagnosticsHandler.ProbeHandler) - Method in class org.jgroups.protocols.TP
 
unregisterProbeHandler(DiagnosticsHandler.ProbeHandler) - Method in class org.jgroups.stack.DiagnosticsHandler
 
unregisterStub(RouterStub) - Method in class org.jgroups.stack.RouterStubManager
 
unregisterStub(InetSocketAddress) - Method in class org.jgroups.stack.RouterStubManager
 
unsetThreadNames() - Method in class org.jgroups.protocols.TP
 
unsubscribe(String) - Method in class org.jgroups.client.StompConnection
 
Unsupported - Annotation Type in org.jgroups.annotations
Elements annotated with this annotation are unsupported and may get removed from the distribution at any time
UNSUSPECT - Static variable in class org.jgroups.Event
 
unsuspect(Address) - Method in class org.jgroups.protocols.FD
 
unsuspect(Address) - Method in class org.jgroups.protocols.FD_ALL
Removes mbr from suspected_mbrs and sends a UNSUSPECT event up and down the stack
unsuspect(Address) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
unsuspect(Address) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
Removes previously suspected member from list of currently suspected members
unsuspect(Address) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
 
unwrapAndDeliver(Message, boolean) - Method in class org.jgroups.protocols.SEQUENCER
Unmarshal the original message (in the payload) and then pass it up (unless already delivered)
up(Event) - Method in class org.jgroups.blocks.mux.MuxUpHandler
Invoked for all channel events except connection management and state transfer.
up(Event) - Method in class org.jgroups.JChannel
Callback method
Called by the ProtocolStack when a message is received.
up(Event) - Method in class org.jgroups.protocols.AUTH
An event was received from the layer below.
up(Event) - Method in class org.jgroups.protocols.BARRIER
 
up(Event) - Method in class org.jgroups.protocols.COMPRESS
If there is no header, we pass the message up.
up(Event) - Method in class org.jgroups.protocols.COUNTER
 
up(Event) - Method in class org.jgroups.protocols.DAISYCHAIN
 
up(Event) - Method in class org.jgroups.protocols.DELAY
 
up(Event) - Method in class org.jgroups.protocols.DELAY_JOIN_REQ
 
up(Event) - Method in class org.jgroups.protocols.DISCARD
 
up(Event) - Method in class org.jgroups.protocols.Discovery
An event was received from the layer below.
up(Event) - Method in class org.jgroups.protocols.DUPL
 
up(Event) - Method in class org.jgroups.protocols.ENCRYPT
 
up(Event) - Method in class org.jgroups.protocols.EXAMPLE
 
up(Event) - Method in class org.jgroups.protocols.Executing
 
up(Event) - Method in class org.jgroups.protocols.FC
 
up(Event) - Method in class org.jgroups.protocols.FD
 
up(Event) - Method in class org.jgroups.protocols.FD_ALL
 
up(Event) - Method in class org.jgroups.protocols.FD_ICMP
 
up(Event) - Method in class org.jgroups.protocols.FD_SIMPLE
 
up(Event) - Method in class org.jgroups.protocols.FD_SOCK
 
up(Event) - Method in class org.jgroups.protocols.FlowControl
 
up(Event) - Method in class org.jgroups.protocols.FORWARD_TO_COORD
 
up(Event) - Method in class org.jgroups.protocols.FRAG
If event is a message, if it is fragmented, re-assemble fragments into big message and pass up the stack.
up(Event) - Method in class org.jgroups.protocols.FRAG2
If event is a message, if it is fragmented, re-assemble fragments into big message and pass up the stack.
up(Event) - Method in class org.jgroups.protocols.HDRS
 
up(Event) - Method in class org.jgroups.protocols.HTOTAL
 
up(Event) - Method in class org.jgroups.protocols.Locking
 
up(Event) - Method in class org.jgroups.protocols.MERGE2
 
up(Event) - Method in class org.jgroups.protocols.MERGE3
 
up(Event) - Method in class org.jgroups.protocols.MPING
 
up(Event) - Method in class org.jgroups.protocols.pbcast.FLUSH
 
up(Event) - Method in class org.jgroups.protocols.pbcast.GMS
 
up(Event) - Method in class org.jgroups.protocols.pbcast.NAKACK
Callback.
up(Event) - Method in class org.jgroups.protocols.pbcast.NAKACK2
Callback.
up(Event) - Method in class org.jgroups.protocols.pbcast.STABLE
 
up(Event) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
up(Event) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
 
up(Event) - Method in class org.jgroups.protocols.PRIO
An event was received from the layer below.
up(Event) - Method in class org.jgroups.protocols.relay.RELAY2
 
up(Event) - Method in class org.jgroups.protocols.RELAY
 
up(Event) - Method in class org.jgroups.protocols.RSVP
 
up(Event) - Method in interface org.jgroups.protocols.rules.EventHandler
Called when an up event is received
up(Event) - Method in class org.jgroups.protocols.rules.SUPERVISOR
 
up(Event) - Method in class org.jgroups.protocols.SCOPE
 
up(Event) - Method in class org.jgroups.protocols.SEQUENCER
 
up - Variable in class org.jgroups.protocols.SHUFFLE
 
up(Event) - Method in class org.jgroups.protocols.SHUFFLE
 
up(Event) - Method in class org.jgroups.protocols.SIZE
 
up(Event) - Method in class org.jgroups.protocols.STATS
 
up(Event) - Method in class org.jgroups.protocols.STOMP
 
up(Event) - Method in class org.jgroups.protocols.tom.TOA
 
up(Event) - Method in class org.jgroups.protocols.TP.ProtocolAdapter
 
up(Event) - Method in class org.jgroups.protocols.TP
handle the UP event.
up(Event) - Method in class org.jgroups.protocols.TRACE
 
up(Event) - Method in class org.jgroups.protocols.UNICAST
 
up(Event) - Method in class org.jgroups.protocols.UNICAST2
 
up(Event) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
 
up(Event) - Method in class org.jgroups.stack.Protocol
An event was received from the layer below.
up(Event) - Method in class org.jgroups.stack.ProtocolStack
 
up(Event) - Method in interface org.jgroups.UpHandler
Invoked for all channel events except connection management and state transfer.
up_handler - Variable in class org.jgroups.Channel
 
up_handlers - Variable in class org.jgroups.protocols.AUTH
List of UpHandler which are called when an up event has been received.
up_msgs - Variable in class org.jgroups.protocols.SHUFFLE
 
up_prot - Variable in class org.jgroups.stack.Protocol
 
up_prot - Variable in class org.jgroups.util.ForwardQueue
 
up_prots - Variable in class org.jgroups.protocols.TP
If singleton_name is enabled, this map is used to de-multiplex incoming messages according to their cluster names (attached to the message by the transport anyway).
update(Graphics) - Method in class org.jgroups.demos.wb.GraphPanel
 
update - Variable in class org.jgroups.protocols.COUNTER.CompareAndSetRequest
 
update(long) - Method in class org.jgroups.protocols.tom.SequenceNumberManager
updates the sequence number to the maximum between them
update() - Method in class org.jgroups.util.SuppressCache.Value
 
updateAndGet(long) - Method in class org.jgroups.protocols.tom.SequenceNumberManager
updates the sequence number and returns the next, that will be used a propose sequence number
updateBackups(Executing.Type, Executing.Owner) - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
 
updateBackups(Locking.Type, String, Owner) - Method in class org.jgroups.protocols.CENTRAL_LOCK
 
updateBackups(String, long, long) - Method in class org.jgroups.protocols.COUNTER
 
updateIfBigger(long, long) - Method in class org.jgroups.protocols.COUNTER.VersionedValue
Sets the value only if the version argument is greater than the own version
updateLastAccessed() - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
 
updateTimestamp(Address) - Method in class org.jgroups.protocols.FD
 
UpHandler - Interface in org.jgroups
Provides a hook to hijack over all events received by a certain channel which has installed this UpHandler.
use_anycast_addresses - Variable in class org.jgroups.blocks.RequestOptions
If use_anycasting is true: do we want to use an AnycastAddress [B,C] or a unicast to B and another unicast to C to send an anycast to {B,C} ? Only used if use_anycasting is true
use_anycasting - Variable in class org.jgroups.blocks.RequestOptions
Turns on anycasting; this results in multiple unicasts rather than a multicast for group calls
use_disk_cache - Variable in class org.jgroups.protocols.Discovery
 
use_gui - Variable in class org.jgroups.protocols.DISCARD
 
USE_JDK_LOGGER - Static variable in class org.jgroups.Global
 
use_mcast_xmit - Variable in class org.jgroups.protocols.pbcast.NAKACK2
Retransmit messages using multicast rather than unicast.
use_mcast_xmit_req - Variable in class org.jgroups.protocols.pbcast.NAKACK2
Use a multicast to request retransmission of missing messages.
use_numbering - Variable in class org.jgroups.util.DefaultThreadFactory
 
use_range_based_retransmitter - Variable in class org.jgroups.protocols.UNICAST2
 
use_send_queues - Variable in class org.jgroups.blocks.TCPConnectionMap
 
use_send_queues - Variable in class org.jgroups.protocols.BasicTCP
 
use_timeout - Variable in class org.jgroups.blocks.locking.LockInfo
 
useAnycastAddresses() - Method in class org.jgroups.blocks.RequestOptions
 
useAnycastAddresses(boolean) - Method in class org.jgroups.blocks.RequestOptions
 
USER - Static variable in class org.jgroups.demos.StompChat
 
USER_DEFINED - Static variable in class org.jgroups.Event
 
USER_JOINED - Static variable in class org.jgroups.demos.StompChat
 
USER_LEFT - Static variable in class org.jgroups.demos.StompChat
 
userid - Variable in class org.jgroups.client.StompConnection
 
UserInfoDialog - Class in org.jgroups.demos.wb
 
UserInfoDialog(Frame) - Constructor for class org.jgroups.demos.wb.UserInfoDialog
 
username - Variable in class org.jgroups.demos.StompChat
 
username - Variable in class org.jgroups.protocols.RACKSPACE_PING
 
username - Variable in class org.jgroups.protocols.SWIFT_PING
 
users - Variable in class org.jgroups.demos.StompChat
 
USERS - Static variable in class org.jgroups.demos.StompChat
 
USERS_KW - Static variable in class org.jgroups.demos.StompChat
 
usesDefaultConverter(Field) - Static method in class org.jgroups.conf.PropertyHelper
 
usingPreSignedUrls() - Method in class org.jgroups.protocols.S3_PING
 
Util - Class in org.jgroups.util
Collection of various utility routines that can not be assigned to other classes.
Util() - Constructor for class org.jgroups.util.Util
 
Util.AddressScope - Enum in org.jgroups.util
 
UUID - Class in org.jgroups.util
Logical address which is unique over space and time.
UUID() - Constructor for class org.jgroups.util.UUID
 
UUID(long, long) - Constructor for class org.jgroups.util.UUID
 
UUID(byte[]) - Constructor for class org.jgroups.util.UUID
Private constructor which uses a byte array to construct the new UUID
UUID_ADDR - Static variable in interface org.jgroups.Address
 
UUID_CACHE_MAX_AGE - Static variable in class org.jgroups.Global
 
UUID_CACHE_MAX_ELEMENTS - Static variable in class org.jgroups.Global
 
uuids - Variable in class org.jgroups.protocols.RELAY.ViewData
 

V

validate(long) - Static method in class org.jgroups.util.RingBufferLockless
 
validateBindAddressFromInterface(InetAddress, String) - Static method in class org.jgroups.util.Util
Method used by PropertyConverters.BindInterface to check that a bind_address is consistent with a specified interface Idea: 1.
validateProperties() - Method in class org.jgroups.protocols.S3_PING
 
value - Variable in class org.jgroups.blocks.executor.ExecutionRunner.Holder
 
value() - Method in enum org.jgroups.Message.Flag
 
value() - Method in enum org.jgroups.Message.TransientFlag
 
value - Variable in class org.jgroups.protocols.COUNTER.SetRequest
 
value - Variable in class org.jgroups.protocols.COUNTER.UpdateRequest
 
value - Variable in class org.jgroups.protocols.COUNTER.VersionedValue
 
valueOf(String) - Static method in enum org.jgroups.blocks.MemcachedConnector.Request.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jgroups.blocks.ResponseMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jgroups.Channel.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jgroups.Message.Flag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jgroups.Message.TransientFlag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jgroups.protocols.COUNTER.RequestType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jgroups.protocols.COUNTER.ResponseType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jgroups.protocols.Executing.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jgroups.protocols.Locking.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jgroups.protocols.MERGE3.MergeHeader.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jgroups.protocols.relay.RELAY2.RouteStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jgroups.protocols.RELAY.RelayHeader.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jgroups.protocols.STOMP.ClientVerb
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jgroups.protocols.STOMP.ServerVerb
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jgroups.protocols.STOMP.StompHeader.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jgroups.stack.RouterStub.ConnectionStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jgroups.util.StackType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jgroups.util.SuppressLog.Level
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jgroups.util.TimeScheduler3.TaskType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jgroups.util.Util.AddressScope
Returns the enum constant of this type with the specified name.
values() - Method in class org.jgroups.blocks.LazyRemovalCache
 
values() - Static method in enum org.jgroups.blocks.MemcachedConnector.Request.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.jgroups.blocks.ReplicatedHashMap
 
values() - Static method in enum org.jgroups.blocks.ResponseMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.jgroups.Channel.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.jgroups.Message.Flag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.jgroups.Message.TransientFlag
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class org.jgroups.protocols.COUNTER.ReconcileRequest
 
values - Variable in class org.jgroups.protocols.COUNTER.ReconcileResponse
 
values() - Static method in enum org.jgroups.protocols.COUNTER.RequestType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.jgroups.protocols.COUNTER.ResponseType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.jgroups.protocols.Executing.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.jgroups.protocols.Locking.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.jgroups.protocols.MERGE3.MergeHeader.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.jgroups.protocols.relay.RELAY2.RouteStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.jgroups.protocols.RELAY.RelayHeader.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.jgroups.protocols.STOMP.ClientVerb
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.jgroups.protocols.STOMP.ServerVerb
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.jgroups.protocols.STOMP.StompHeader.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.jgroups.stack.RouterStub.ConnectionStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.jgroups.util.Queue
Returns all the elements of the queue
values() - Method in class org.jgroups.util.RspList
 
values() - Static method in enum org.jgroups.util.StackType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.jgroups.util.SuppressLog.Level
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.jgroups.util.TimeScheduler3.TaskType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.jgroups.util.Util.AddressScope
Returns an array containing the constants of this enum type, in the order they are declared.
VERIFY_SUSPECT - Class in org.jgroups.protocols
Catches SUSPECT events traveling up the stack.
VERIFY_SUSPECT() - Constructor for class org.jgroups.protocols.VERIFY_SUSPECT
 
VERIFY_SUSPECT.Entry - Class in org.jgroups.protocols
 
VERIFY_SUSPECT.Entry(Address, long) - Constructor for class org.jgroups.protocols.VERIFY_SUSPECT.Entry
 
VERIFY_SUSPECT.VerifyHeader - Class in org.jgroups.protocols
 
VERIFY_SUSPECT.VerifyHeader() - Constructor for class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
 
verifyconfigurationParameters() - Method in class org.jgroups.protocols.JDBC_PING
 
verifyRejectionPolicy(String) - Static method in class org.jgroups.util.Util
 
version - Variable in class org.jgroups.protocols.COUNTER.SimpleResponse
 
version - Variable in class org.jgroups.protocols.COUNTER.UpdateRequest
 
version - Variable in class org.jgroups.protocols.COUNTER.VersionedValue
 
Version - Class in org.jgroups
We're using the scheme described at http://www.jboss.com/index.html?module=bb&op=viewtopic&t=77231 for major, minor and micro version numbers.
Version() - Constructor for class org.jgroups.Version
 
version - Static variable in class org.jgroups.Version
 
versions - Variable in class org.jgroups.protocols.COUNTER.ReconcileRequest
 
versions - Variable in class org.jgroups.protocols.COUNTER.ReconcileResponse
 
vid - Variable in class org.jgroups.View
A view is uniquely identified by its ViewID.
view - Variable in class org.jgroups.blocks.RequestCorrelator
 
view - Variable in class org.jgroups.demos.RelayDemoRpc
 
VIEW - Static variable in class org.jgroups.demos.StompChat
 
view - Variable in class org.jgroups.protocols.COUNTER
 
view - Variable in class org.jgroups.protocols.Discovery
 
view - Variable in class org.jgroups.protocols.Executing
 
view - Variable in class org.jgroups.protocols.Locking
 
view - Variable in class org.jgroups.protocols.MERGE2
 
view - Variable in class org.jgroups.protocols.MERGE3.MergeHeader
 
view - Variable in class org.jgroups.protocols.MERGE3
 
VIEW - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
view - Variable in class org.jgroups.protocols.pbcast.GMS
 
view - Variable in class org.jgroups.protocols.pbcast.MergeData
 
view - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
view - Variable in class org.jgroups.protocols.PingData
 
view - Variable in class org.jgroups.protocols.relay.Relayer.Bridge
 
view - Variable in class org.jgroups.protocols.rules.SUPERVISOR
 
view - Variable in class org.jgroups.protocols.SEQUENCER
 
view - Variable in class org.jgroups.protocols.STOMP
 
View - Class in org.jgroups
A view is a local representation of the current membership of a group.
View() - Constructor for class org.jgroups.View
Creates an empty view, should not be used, only used by (de-)serialization
View(ViewId, List<Address>) - Constructor for class org.jgroups.View
Creates a new view
View(Address, long, List<Address>) - Constructor for class org.jgroups.View
Creates a new view
VIEW_ACK - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
VIEW_CHANGE - Static variable in class org.jgroups.Event
 
view_consistency_checker - Variable in class org.jgroups.protocols.MERGE3
 
view_id - Variable in class org.jgroups.protocols.MERGE3.MergeHeader
 
view_id - Variable in class org.jgroups.protocols.PingData
 
view_id - Variable in class org.jgroups.protocols.PingHeader
 
VIEW_PRESENT - Static variable in class org.jgroups.protocols.pbcast.JoinRsp
 
view_rsps - Variable in class org.jgroups.protocols.MERGE3
 
view_size - Variable in class org.jgroups.protocols.DAISYCHAIN
 
viewAccepted(View) - Method in class org.jgroups.blocks.PartitionedHashMap.ConsistentHashFunction
 
viewAccepted(View) - Method in class org.jgroups.blocks.PartitionedHashMap
 
viewAccepted(View) - Method in class org.jgroups.blocks.ReplCache
 
viewAccepted(View) - Method in class org.jgroups.blocks.ReplicatedHashMap
 
viewAccepted(View) - Method in class org.jgroups.blocks.ReplicatedTree
 
viewAccepted(View) - Method in class org.jgroups.demos.Chat
 
viewAccepted(View) - Method in class org.jgroups.demos.Draw
 
viewAccepted(View) - Method in class org.jgroups.demos.QuoteClient
 
viewAccepted(View) - Method in class org.jgroups.demos.QuoteServer
 
viewAccepted(View) - Method in class org.jgroups.demos.RelayDemoRpc
 
viewAccepted(View) - Method in class org.jgroups.demos.ViewDemo
 
viewAccepted(View) - Method in class org.jgroups.demos.wb.Whiteboard
 
viewAccepted(View) - Method in interface org.jgroups.MembershipListener
Called when a change in membership has occurred.
viewAccepted(View) - Method in class org.jgroups.protocols.RELAY.Receiver
 
viewAccepted(View) - Method in class org.jgroups.protocols.relay.Relayer.Bridge
 
viewAccepted(View) - Method in class org.jgroups.ReceiverAdapter
Called when a change in membership has occurred.
viewChange(View) - Method in class org.jgroups.blocks.GroupRequest
Any member of 'membership' that is not in the new view is flagged as SUSPECTED.
viewChange(View, List<Address>, List<Address>) - Method in interface org.jgroups.blocks.ReplicatedHashMap.Notification
 
viewChange(View) - Method in interface org.jgroups.blocks.ReplicatedTree.ReplicatedTreeListener
 
viewChange(View) - Method in class org.jgroups.blocks.Request
 
viewChange(View) - Method in interface org.jgroups.blocks.RspCollector
 
viewChange(View) - Method in class org.jgroups.blocks.UnicastRequest
If the target address is not a member of the new view, we'll mark the response as not received and unblock the caller of execute()
viewChange(View, List<Address>, List<Address>) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
 
ViewDemo - Class in org.jgroups.demos
Demos the reception of views using a PullPushAdapter.
ViewDemo() - Constructor for class org.jgroups.demos.ViewDemo
 
ViewId - Class in org.jgroups
ViewIds are used for ordering views (each view has a ViewId and a list of members).
ViewId() - Constructor for class org.jgroups.ViewId
 
ViewId(Address) - Constructor for class org.jgroups.ViewId
Creates a ViewID with the coordinator address and a Lamport timestamp of 0.
ViewId(Address, long) - Constructor for class org.jgroups.ViewId
Creates a ViewID with the coordinator address and the given Lamport timestamp.
views - Variable in class org.jgroups.protocols.MERGE3
 
visit(long, Message, int, int) - Method in class org.jgroups.protocols.pbcast.NAKACK2.Counter
 
visit(long, T, int, int) - Method in class org.jgroups.util.Table.Counter
 
visit(long, T, int, int) - Method in class org.jgroups.util.Table.Dump
 
visit(long, T, int, int) - Method in class org.jgroups.util.Table.Getter
 
visit(long, T, int, int) - Method in class org.jgroups.util.Table.Missing
 
visit(long, T, int, int) - Method in class org.jgroups.util.Table.Remover
 
visit(long, T, int, int) - Method in interface org.jgroups.util.Table.Visitor
Iteration over the table, used by Table.forEach(long,long,org.jgroups.util.Table.Visitor).

W

waitFor() - Method in class org.jgroups.util.TimeScheduler2
 
waitForAllAcks() - Method in class org.jgroups.util.AckCollector
 
waitForAllAcks(long) - Method in class org.jgroups.util.AckCollector
 
waitForAllResponses(long) - Method in class org.jgroups.util.ResponseCollector
Waits until all responses have been received, or until a timeout has elapsed.
waitForResults(long) - Method in class org.jgroups.blocks.Request
 
waitUntilAllChannelsHaveSameSize(long, long, Channel...) - Static method in class org.jgroups.util.Util
Blocks until all channels have the same view
waitUntilClosed(long) - Method in class org.jgroups.util.Queue
Waits until the queue has been closed.
waitUntilNextExecution() - Method in class org.jgroups.util.TimeScheduler2
Sleeps until the next task in line is ready to be executed
warn(String) - Method in class org.jgroups.logging.JDKLogImpl
 
warn(String, Throwable) - Method in class org.jgroups.logging.JDKLogImpl
 
warn(String) - Method in interface org.jgroups.logging.Log
 
warn(String, Throwable) - Method in interface org.jgroups.logging.Log
 
warn(String) - Method in class org.jgroups.logging.Log4JLogImpl
 
warn(String, Throwable) - Method in class org.jgroups.logging.Log4JLogImpl
 
warn_when_ftc_missing - Variable in class org.jgroups.protocols.relay.RELAY2
 
wasReceived() - Method in class org.jgroups.util.Rsp
 
wasSuspected() - Method in class org.jgroups.util.Rsp
 
wasUnreachable() - Method in class org.jgroups.util.Rsp
 
wheel - Variable in class org.jgroups.util.HashedTimingWheel
 
wheel_position - Variable in class org.jgroups.util.HashedTimingWheel
 
wheel_size - Variable in class org.jgroups.protocols.TP
 
wheel_size - Variable in class org.jgroups.util.HashedTimingWheel
 
Whiteboard - Class in org.jgroups.demos.wb
Shared whiteboard: members are represented by rectangles that contain their names and the OS/arch of the machine they are working on.
Whiteboard() - Constructor for class org.jgroups.demos.wb.Whiteboard
 
Whiteboard(String) - Constructor for class org.jgroups.demos.wb.Whiteboard
 
who_has_cache - Variable in class org.jgroups.protocols.TP
Cache keeping track of WHO_HAS requests for physical addresses (given a logical address) and expiring them after who_has_cache_timeoout ms
who_has_cache_timeout - Variable in class org.jgroups.protocols.TP
 
WHO_HAS_SOCK - Static variable in class org.jgroups.protocols.FD_SOCK.FdHeader
 
width - Variable in class org.jgroups.demos.wb.Node
 
windowActivated(WindowEvent) - Method in class org.jgroups.demos.QuoteClient
 
windowActivated(WindowEvent) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
 
windowActivated(WindowEvent) - Method in class org.jgroups.demos.Topology
 
windowClosed(WindowEvent) - Method in class org.jgroups.demos.QuoteClient
 
windowClosed(WindowEvent) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
 
windowClosed(WindowEvent) - Method in class org.jgroups.demos.Topology
 
windowClosing(WindowEvent) - Method in class org.jgroups.demos.QuoteClient
 
windowClosing(WindowEvent) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
 
windowClosing(WindowEvent) - Method in class org.jgroups.demos.Topology
 
windowDeactivated(WindowEvent) - Method in class org.jgroups.demos.QuoteClient
 
windowDeactivated(WindowEvent) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
 
windowDeactivated(WindowEvent) - Method in class org.jgroups.demos.Topology
 
windowDeiconified(WindowEvent) - Method in class org.jgroups.demos.QuoteClient
 
windowDeiconified(WindowEvent) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
 
windowDeiconified(WindowEvent) - Method in class org.jgroups.demos.Topology
 
windowIconified(WindowEvent) - Method in class org.jgroups.demos.QuoteClient
 
windowIconified(WindowEvent) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
 
windowIconified(WindowEvent) - Method in class org.jgroups.demos.Topology
 
windowOpened(WindowEvent) - Method in class org.jgroups.demos.QuoteClient
 
windowOpened(WindowEvent) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
 
windowOpened(WindowEvent) - Method in class org.jgroups.demos.Topology
 
wouldBeNewCoordinator(Address) - Method in class org.jgroups.protocols.pbcast.GMS
Checks whether the potential_new_coord would be the new coordinator (2nd in line)
wrap(JChannel) - Static method in class org.jgroups.jmx.JmxConfigurator
Wrap JChannel with DynamicMBean interface.
wrap(Protocol) - Static method in class org.jgroups.jmx.JmxConfigurator
Wrap Protocol with DynamicMBean interface.
WRAPPED_BCAST - Static variable in class org.jgroups.protocols.SEQUENCER.SequencerHeader
 
write(int) - Method in class org.jgroups.blocks.GridOutputStream
 
write(byte[]) - Method in class org.jgroups.blocks.GridOutputStream
 
write(byte[], int, int) - Method in class org.jgroups.blocks.GridOutputStream
 
write(byte[], int, int) - Method in class org.jgroups.protocols.pbcast.STATE.StateOutputStream
 
write(byte[]) - Method in class org.jgroups.protocols.pbcast.STATE.StateOutputStream
 
write(int) - Method in class org.jgroups.protocols.pbcast.STATE.StateOutputStream
 
write(byte[]) - Method in class org.jgroups.util.BlockingInputStream
Appends bytes to the end of the stream
write(byte[], int, int) - Method in class org.jgroups.util.BlockingInputStream
Appends bytes to the end of the stream.
write(int) - Method in class org.jgroups.util.ExposedByteArrayOutputStream
 
write(byte[], int, int) - Method in class org.jgroups.util.ExposedByteArrayOutputStream
Writes len bytes from the specified byte array starting at offset off to this byte array output stream.
write(int) - Method in class org.jgroups.util.ExposedDataOutputStream
 
write(byte[], int, int) - Method in class org.jgroups.util.ExposedDataOutputStream
Writes len bytes from the specified byte array starting at offset off to the underlying output stream.
write_pos - Variable in class org.jgroups.util.BlockingInputStream
Index into buf at which bytes will be written.
writeAddress(Address, DataOutput) - Static method in class org.jgroups.util.Util
 
writeAddresses(Collection<? extends Address>, DataOutput) - Static method in class org.jgroups.util.Util
Writes a Vector of Addresses.
writeAuthToken(DataOutput, AuthToken) - Static method in class org.jgroups.protocols.AuthHeader
 
writeAuthToken(AuthToken, DataOutput) - Static method in class org.jgroups.util.Util
 
writeByteBuffer(byte[], DataOutput) - Static method in class org.jgroups.util.Util
 
writeByteBuffer(byte[], int, int, DataOutput) - Static method in class org.jgroups.util.Util
 
writeClass(Class<?>, DataOutput) - Static method in class org.jgroups.util.Util
 
writeExternal(ObjectOutput) - Method in class org.jgroups.AnycastAddress
 
writeExternal(ObjectOutput) - Method in class org.jgroups.blocks.Cache.Value
 
writeExternal(ObjectOutput) - Method in class org.jgroups.blocks.MethodCall
 
writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.relay.CanBeSiteMaster
 
writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.relay.CanBeSiteMasterTopology
 
writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.relay.SiteUUID
 
writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.tom.MessageID
 
writeExternal(ObjectOutput) - Method in class org.jgroups.stack.IpAddress
 
writeExternal(ObjectOutput) - Method in class org.jgroups.util.AdditionalDataUUID
 
writeExternal(ObjectOutput) - Method in class org.jgroups.util.PayloadUUID
 
writeExternal(ObjectOutput) - Method in class org.jgroups.util.SingletonAddress
 
writeExternal(ObjectOutput) - Method in class org.jgroups.util.TopologyUUID
 
writeExternal(ObjectOutput) - Method in class org.jgroups.util.UUID
 
writeFully(ByteBuffer, WritableByteChannel) - Static method in class org.jgroups.util.Util
if we were to register for OP_WRITE and send the remaining data on readyOps for this channel we have to either block the caller thread or queue the message buffers that may arrive while waiting for OP_WRITE.
writeGenericStreamable(Streamable, DataOutput) - Static method in class org.jgroups.util.Util
 
writeHeader(Header, DataOutput) - Static method in class org.jgroups.Message
 
writeLong(long, DataOutput) - Static method in class org.jgroups.util.Util
 
writeLongSequence(long, long, DataOutput) - Static method in class org.jgroups.util.Util
 
writeMessage(Message, DataOutputStream, boolean) - Static method in class org.jgroups.protocols.TP
This method needs to be synchronized on out_stream when it is called
writeMessageList(Address, Address, List<Message>, DataOutputStream, boolean) - Static method in class org.jgroups.protocols.TP
Write a lits of messages with the same destination and *mostly* the same src addresses.
writeNodeToDisk(Address, PhysicalAddress) - Method in class org.jgroups.protocols.PDC
 
writeObject(Object, DataOutput) - Static method in class org.jgroups.util.Util
 
writeReconciliation(DataOutput, String[], long[], long[]) - Static method in class org.jgroups.protocols.COUNTER
 
writeStreamable(Streamable, DataOutput) - Static method in class org.jgroups.util.Util
 
writeString(String, DataOutput) - Static method in class org.jgroups.util.Util
 
writeString(ByteBuffer, String) - Static method in class org.jgroups.util.Util
 
writeTo(DataOutput) - Method in class org.jgroups.AnycastAddress
 
writeTo(DataOutput) - Method in class org.jgroups.auth.DemoToken.DemoHeader
 
writeTo(DataOutput) - Method in class org.jgroups.auth.DemoToken
 
writeTo(DataOutput) - Method in class org.jgroups.auth.FixedMembershipToken
Required to serialize the object to pass across the wire
writeTo(DataOutput) - Method in class org.jgroups.auth.MD5Token
 
writeTo(DataOutput) - Method in class org.jgroups.auth.RegexMembership
 
writeTo(DataOutput) - Method in class org.jgroups.auth.SimpleToken
Required to serialize the object to pass across the wire
writeTo(DataOutput) - Method in class org.jgroups.auth.X509Token
 
writeTo(DataOutput) - Method in class org.jgroups.blocks.executor.Executions.StreamableCallable
 
writeTo(DataOutput) - Method in class org.jgroups.blocks.executor.ExecutionService.RunnableAdapter
 
writeTo(DataOutput) - Method in class org.jgroups.blocks.GridFile.Metadata
 
writeTo(DataOutput) - Method in class org.jgroups.blocks.mux.MuxHeader
 
writeTo(DataOutput) - Method in class org.jgroups.blocks.RequestCorrelator.Header
 
writeTo(DataOutput) - Method in class org.jgroups.blocks.RequestCorrelator.MultiDestinationHeader
 
writeTo(DataOutput) - Method in class org.jgroups.demos.DrawCommand
 
writeTo(DataOutput) - Method in class org.jgroups.demos.ExecutionServiceDemo.ByteBufferStreamable
 
writeTo(DataOutput) - Method in class org.jgroups.demos.ExecutionServiceDemo.SortingByteCallable
 
writeTo(DataOutput) - Method in class org.jgroups.demos.ExecutionServiceDemo.SortingTwoByteCallable
 
writeTo(DataOutput) - Method in class org.jgroups.MergeView
 
writeTo(DataOutput) - Method in class org.jgroups.Message
Streams all members (dest and src addresses, buffer and headers) to the output stream.
writeTo(DataOutput) - Method in class org.jgroups.protocols.AuthHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.COMPRESS.CompressHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.COUNTER.BooleanResponse
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.COUNTER.CompareAndSetRequest
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.COUNTER.CounterHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.COUNTER.ExceptionResponse
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.COUNTER.GetOrCreateRequest
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.COUNTER.ReconcileRequest
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.COUNTER.ReconcileResponse
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.COUNTER.ResendPendingRequests
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.COUNTER.SetRequest
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.COUNTER.SimpleRequest
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.COUNTER.SimpleResponse
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.COUNTER.UpdateRequest
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.COUNTER.ValueResponse
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.DAISYCHAIN.DaisyHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.DISCARD.DiscardHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.EXAMPLE.ExampleHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.Executing.ExecutorHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.Executing.Request
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.Executing.RequestWithThread
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.FcHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.FD.FdHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.FD_ALL.HeartbeatHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.FD_SIMPLE.FdHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.FD_SOCK.FdHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.FORWARD_TO_COORD.ForwardHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.FragHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.HTOTAL.HTotalHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.Locking.LockingHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.Locking.Request
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.MERGE3.MergeHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.pbcast.JoinRsp
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.pbcast.NakAckHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.pbcast.NakAckHeader2
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.pbcast.STABLE.StableHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.PDC.Mapping
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.PingData
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.PingHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.PrioHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.relay.CanBeSiteMaster
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.relay.CanBeSiteMasterTopology
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.relay.RELAY2.Relay2Header
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.RELAY.RelayHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.relay.SiteUUID
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.RELAY.ViewData
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.RSVP.RsvpHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.SCOPE.ScopeHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.SEQUENCER.SequencerHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.STOMP.StompHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.tom.MessageID
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.tom.ToaHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.TpHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.UNICAST.UnicastHeader
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.UNICAST2.Unicast2Header
 
writeTo(DataOutput) - Method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
 
writeTo(DataOutput) - Method in class org.jgroups.stack.GossipData
 
writeTo(DataOutput) - Method in class org.jgroups.stack.IpAddress
 
writeTo(DataOutput) - Method in class org.jgroups.util.AdditionalDataUUID
 
writeTo(DataOutput) - Method in class org.jgroups.util.Digest
 
writeTo(OutputStream) - Method in class org.jgroups.util.ExposedByteArrayOutputStream
Writes the complete contents of this byte array output stream to the specified output stream argument, as if by calling the output stream's write method using out.write(buf, 0, count).
writeTo(DataOutput) - Method in class org.jgroups.util.MergeId
 
writeTo(DataOutput) - Method in class org.jgroups.util.Owner
 
writeTo(DataOutput) - Method in class org.jgroups.util.PayloadUUID
 
writeTo(DataOutput) - Method in class org.jgroups.util.Range
 
writeTo(DataOutput) - Method in class org.jgroups.util.SeqnoList
 
writeTo(DataOutput) - Method in class org.jgroups.util.SingletonAddress
 
writeTo(DataOutput) - Method in interface org.jgroups.util.Streamable
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutput) - Method in class org.jgroups.util.TopologyUUID
 
writeTo(DataOutput) - Method in class org.jgroups.util.UUID
 
writeTo(DataOutput) - Method in class org.jgroups.View
 
writeTo(DataOutput) - Method in class org.jgroups.ViewId
 
writeToFile(PingData, String) - Method in class org.jgroups.protocols.FILE_PING
 
writeToFile(PingData, String) - Method in class org.jgroups.protocols.JDBC_PING
 
writeToFile(PingData, String) - Method in class org.jgroups.protocols.RACKSPACE_PING
 
writeToFile(PingData, String) - Method in class org.jgroups.protocols.S3_PING
 
writeToFile(PingData, String) - Method in class org.jgroups.protocols.SWIFT_PING
 
writeToNoAddrs(Address, DataOutputStream) - Method in class org.jgroups.Message
Writes the message to the output stream, but excludes the dest and src addresses unless the src address given as argument is different from the message's src address
writeToTempFile(File, Address, Address, String) - Method in class org.jgroups.protocols.PDC
Writes the data to a temporary file.
The file is stored in the same directory as the other cluster files but is given the .tmp suffix
writeView(View, DataOutput) - Static method in class org.jgroups.util.Util
 
writeViewId(ViewId, DataOutput) - Static method in class org.jgroups.util.Util
 
wrongMethod(String) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 

X

x - Variable in class org.jgroups.demos.wb.Node
 
X509Token - Class in org.jgroups.auth
This is an example of using a preshared token that is encrypted using an X509 certificate for authentication purposes.
X509Token() - Constructor for class org.jgroups.auth.X509Token
 
xloc - Variable in class org.jgroups.demos.wb.Node
 
xmit_from_random_member - Variable in class org.jgroups.protocols.pbcast.NAKACK2
Ask a random member for retransmission of a missing message.
xmit_interval - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
xmit_interval - Variable in class org.jgroups.protocols.UNICAST
 
xmit_interval - Variable in class org.jgroups.protocols.UNICAST2
 
XMIT_REQ - Static variable in class org.jgroups.protocols.pbcast.NakAckHeader
 
XMIT_REQ - Static variable in class org.jgroups.protocols.pbcast.NakAckHeader2
 
XMIT_REQ - Static variable in class org.jgroups.protocols.UNICAST2.Unicast2Header
 
xmit_reqs_received - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
xmit_reqs_received - Variable in class org.jgroups.protocols.UNICAST2
 
xmit_reqs_sent - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
xmit_reqs_sent - Variable in class org.jgroups.protocols.UNICAST2
 
XMIT_RSP - Static variable in class org.jgroups.protocols.pbcast.NakAckHeader
 
XMIT_RSP - Static variable in class org.jgroups.protocols.pbcast.NakAckHeader2
 
xmit_rsps_received - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
xmit_rsps_sent - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
xmit_rsps_sent - Variable in class org.jgroups.protocols.UNICAST2
 
xmit_stagger_timeout - Variable in class org.jgroups.protocols.pbcast.NAKACK
 
xmit_stagger_timeout - Variable in class org.jgroups.stack.Retransmitter
 
xmit_table - Variable in class org.jgroups.protocols.pbcast.NAKACK2
Map to store sent and received messages (keyed by sender)
xmit_table_automatic_purging - Variable in class org.jgroups.protocols.UNICAST2
Deprecated. 
xmit_table_max_compaction_time - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
xmit_table_max_compaction_time - Variable in class org.jgroups.protocols.UNICAST
 
xmit_table_max_compaction_time - Variable in class org.jgroups.protocols.UNICAST2
 
xmit_table_msgs_per_row - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
xmit_table_msgs_per_row - Variable in class org.jgroups.protocols.UNICAST
 
xmit_table_msgs_per_row - Variable in class org.jgroups.protocols.UNICAST2
 
xmit_table_num_rows - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
xmit_table_num_rows - Variable in class org.jgroups.protocols.UNICAST
 
xmit_table_num_rows - Variable in class org.jgroups.protocols.UNICAST2
 
xmit_table_resize_factor - Variable in class org.jgroups.protocols.pbcast.NAKACK2
 
xmit_table_resize_factor - Variable in class org.jgroups.protocols.UNICAST
 
xmit_table_resize_factor - Variable in class org.jgroups.protocols.UNICAST2
 
xmit_task - Variable in class org.jgroups.protocols.pbcast.NAKACK2
RetransmitTask running every xmit_interval ms
xmit_task - Variable in class org.jgroups.protocols.UNICAST
RetransmitTask running every xmit_interval ms
xmit_task - Variable in class org.jgroups.protocols.UNICAST2
RetransmitTask running every xmit_interval ms
xmit_task_map - Variable in class org.jgroups.protocols.pbcast.NAKACK2
Used by the retransmit task to keep the last retransmitted seqno per sender (https://issues.jboss.org/browse/JGRP-1539)
xmit_task_map - Variable in class org.jgroups.protocols.UNICAST2
Used by the retransmit task to keep the last retransmitted seqno per sender (https://issues.jboss.org/browse/JGRP-1539)
XML_VALIDATION - Static variable in class org.jgroups.Global
 
XmlConfigurator - Class in org.jgroups.conf
 
XmlConfigurator(List<ProtocolConfiguration>) - Constructor for class org.jgroups.conf.XmlConfigurator
 
XMLSchemaGenerator - Class in org.jgroups.util
Iterates over all concrete Protocol classes and creates XML schema used for validation of configuration files.
XMLSchemaGenerator() - Constructor for class org.jgroups.util.XMLSchemaGenerator
 

Y

y - Variable in class org.jgroups.demos.wb.Node
 
yloc - Variable in class org.jgroups.demos.wb.Node
 

_

_add(Address) - Method in class org.jgroups.AnycastAddress
 
_args - Variable in class org.jgroups.blocks.executor.Executions.StreamableCallable
 
_awaitingConsumer - Variable in class org.jgroups.protocols.Executing
This is a queue on the client side that holds all of the tasks that are awaiting a consumer to pick them up
_awaitingReturn - Variable in class org.jgroups.protocols.Executing
This is a map on the client side that shows for which owner(consumer, request) the runnable they are currently using.
_classCallable - Variable in class org.jgroups.blocks.executor.Executions.StreamableCallable
 
_clear() - Method in class org.jgroups.blocks.ReplicatedHashMap
 
_clear() - Method in interface org.jgroups.blocks.ReplicatedMap
 
_close(boolean) - Method in class org.jgroups.JChannel
Disconnects and closes the channel.
_compact() - Method in class org.jgroups.util.Table
Moves the contents of matrix down by the number of purged rows and resizes the matrix accordingly.
_connect(Event) - Method in class org.jgroups.JChannel
 
_constructorNumber - Variable in class org.jgroups.blocks.executor.Executions.StreamableCallable
 
_consumerId - Variable in class org.jgroups.protocols.Executing
This is essentially a set on the consumer side of id's of all the threads currently running as consumers.
_consumerLock - Variable in class org.jgroups.protocols.Executing
This lock is to protect the incoming run requests and the incoming consumer queues
_consumersAvailable - Variable in class org.jgroups.protocols.Executing
This is stored on the coordinator side.
_doConnect() - Method in class org.jgroups.stack.RouterStub
 
_execProt - Variable in class org.jgroups.blocks.executor.ExecutionRunner
 
_execProt - Variable in class org.jgroups.blocks.executor.ExecutionService
 
_findAndNotify() - Method in class org.jgroups.protocols.MERGE2.FindSubgroupsTask
 
_get(K) - Method in class org.jgroups.blocks.PartitionedHashMap
 
_get(K) - Method in class org.jgroups.blocks.ReplCache
 
_get(long) - Method in class org.jgroups.util.RingBuffer
Only used for testing !!
_get(long) - Method in class org.jgroups.util.RingBufferLockless
Only used for testing !!
_get(long) - Method in class org.jgroups.util.Table
To be used only for testing; doesn't do any index or sanity checks
_getMergeId() - Method in class org.jgroups.protocols.pbcast.GMS
 
_getResultWithTimeout(long) - Method in class org.jgroups.util.Promise
Blocks until a result is available, or timeout milliseconds have elapsed.
_handleMergeRequest(Address, MergeId, Collection<? extends Address>) - Method in class org.jgroups.protocols.pbcast.Merger
 
_list(Object) - Method in class org.jgroups.blocks.GridFile
 
_listFiles(Object) - Method in class org.jgroups.blocks.GridFile
 
_logger - Static variable in class org.jgroups.blocks.executor.ExecutionRunner
 
_preConnect(String) - Method in class org.jgroups.JChannel
 
_printThreads(ThreadMXBean, long[], StringBuilder) - Static method in class org.jgroups.util.Util
 
_put(K, V, long) - Method in class org.jgroups.blocks.PartitionedHashMap
 
_put(K, V, short, long) - Method in class org.jgroups.blocks.ReplCache
 
_put(K, V, short, long, boolean) - Method in class org.jgroups.blocks.ReplCache
 
_put(K, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
 
_put(K, V) - Method in interface org.jgroups.blocks.ReplicatedMap
 
_put(String, HashMap) - Method in class org.jgroups.blocks.ReplicatedTree
 
_put(String, String, Object) - Method in class org.jgroups.blocks.ReplicatedTree
 
_putAll(Map<? extends K, ? extends V>) - Method in class org.jgroups.blocks.ReplicatedHashMap
 
_putAll(Map<? extends K, ? extends V>) - Method in interface org.jgroups.blocks.ReplicatedMap
 
_putIfAbsent(K, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
 
_putIfAbsent(K, V) - Method in interface org.jgroups.blocks.ReplicatedMap
 
_remove(K) - Method in class org.jgroups.blocks.PartitionedHashMap
 
_remove(K) - Method in class org.jgroups.blocks.ReplCache
 
_remove(Object) - Method in class org.jgroups.blocks.ReplicatedHashMap
 
_remove(Object, Object) - Method in class org.jgroups.blocks.ReplicatedHashMap
 
_remove(Object) - Method in interface org.jgroups.blocks.ReplicatedMap
 
_remove(Object, Object) - Method in interface org.jgroups.blocks.ReplicatedMap
 
_remove(String) - Method in class org.jgroups.blocks.ReplicatedTree
 
_remove(String, String) - Method in class org.jgroups.blocks.ReplicatedTree
 
_removeData(String) - Method in class org.jgroups.blocks.ReplicatedTree
 
_removeMany(Set<K>) - Method in class org.jgroups.blocks.ReplCache
 
_replace(K, V, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
 
_replace(K, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
 
_replace(K, V, V) - Method in interface org.jgroups.blocks.ReplicatedMap
 
_replace(K, V) - Method in interface org.jgroups.blocks.ReplicatedMap
 
_requestId - Variable in class org.jgroups.protocols.Executing
This is a map on the client side showing for all of the current pending requests
_run() - Method in class org.jgroups.protocols.COUNTER.ReconciliationTask
 
_run() - Method in class org.jgroups.protocols.MERGE3.ViewConsistencyChecker
 
_run() - Method in class org.jgroups.protocols.SCOPE.ExpiryTask
 
_run() - Method in class org.jgroups.util.HashedTimingWheel
 
_run() - Method in class org.jgroups.util.TimeScheduler2
 
_runnableThreads - Variable in class org.jgroups.protocols.Executing
This is a server side map to show which threads are running for a given runnable.
_running - Variable in class org.jgroups.protocols.Executing
This is a map on the server side that shows which owner is currently tied to the runnable so we can return to them the results
_runRequests - Variable in class org.jgroups.protocols.Executing
This is stored on the coordinator side.
_send(byte[], int, int, boolean) - Method in class org.jgroups.blocks.TCPConnectionMap.TCPConnection
Sends data using the 'out' output stream of the socket
_send(InetAddress, int, boolean, byte[], int, int) - Method in class org.jgroups.protocols.UDP
 
_shutdown - Variable in class org.jgroups.blocks.executor.ExecutionService
 
_startFlush(View, int, boolean, long, long) - Method in class org.jgroups.protocols.pbcast.GMS
 
_taskBarriers - Variable in class org.jgroups.protocols.Executing
This is a server side store of all the barriers for respective tasks requests.
_tasks - Variable in class org.jgroups.protocols.Executing
This is a server side store of all the tasks that want to be ran on a given thread.
_unfinishedCondition - Variable in class org.jgroups.blocks.executor.ExecutionService
 
_unfinishedFutures - Variable in class org.jgroups.blocks.executor.ExecutionService
 
_unfinishedLock - Variable in class org.jgroups.blocks.executor.ExecutionService
 
_unlock(boolean) - Method in class org.jgroups.protocols.Locking.ClientLock
 

A B C D E F G H I J K L M N O P Q R S T U V W X Y _

Copyright © 1998-2012 Bela Ban / Red Hat. All Rights Reserved.