Alphabetical Index

_ 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

_

_add(Object) - method in class org.jgroups.blocks.DistributedQueue
_add(String) - method in class org.jgroups.blocks.DistributedTree
_add(String,Serializable) - method in class org.jgroups.blocks.DistributedTree
_addAll(Collection) - method in class org.jgroups.blocks.DistributedQueue
_addAtHead(Object) - method in class org.jgroups.blocks.DistributedQueue
_clear() - method in class org.jgroups.blocks.DistributedHashtable
_corr - field in class org.jgroups.stack.MessageProtocol
_private_reset() - method in class org.jgroups.blocks.DistributedQueue
_put(Object,Object) - method in class org.jgroups.blocks.DistributedHashtable
_put(String,HashMap) - method in class org.jgroups.blocks.ReplicatedTree
_put(String,String,Object) - method in class org.jgroups.blocks.ReplicatedTree
_putAll(Map) - method in class org.jgroups.blocks.DistributedHashtable
_putAll(Map) - method in class org.jgroups.blocks.ReplicatedHashtable
_remove() - method in class org.jgroups.blocks.DistributedQueue
_remove(Object) - method in class org.jgroups.blocks.DistributedHashtable
_remove(String) - method in class org.jgroups.blocks.DistributedTree
_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
_reset() - method in class org.jgroups.blocks.DistributedQueue
_reset(String,Serializable) - method in class org.jgroups.blocks.DistributedTree
similar to set, but does not error if node does not exist, but rather does an add instead
_set(String,Serializable) - method in class org.jgroups.blocks.DistributedTree

A

abort() - method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
abort(Object) - method in class org.jgroups.blocks.DistributedLockManager
Abort phase for the lock acquisition or release.
abort(Object) - method in class org.jgroups.blocks.TwoPhaseVotingListener
This is unconditional abort of the previous voting on the decree.
ABOVE - static field in class org.jgroups.stack.ProtocolStack
ACK - static field in class org.jgroups.protocols.SMACK.SmackHeader
ACK - static field in class org.jgroups.protocols.UNICAST.UnicastHeader
ack(long) - method in class org.jgroups.stack.AckSenderWindow
Removes the message from msgs, removing them also from retransmission.
ack(long,org.jgroups.Address) - method in class org.jgroups.stack.AckMcastSenderWindow
An ACK has been received from sender.
ack(Object) - method in class org.jgroups.util.AckCollector
AckCollector - class org.jgroups.util.AckCollector
AckCollector() - constructor for class org.jgroups.util.AckCollector
AckCollector(org.jgroups.ViewId,java.util.List) - constructor for class org.jgroups.util.AckCollector
Keeps track of messages received from various senders.
AckMcastSenderWindow - class org.jgroups.stack.AckMcastSenderWindow
Keeps track of ACKs from receivers for each message.
Create and start the retransmitter
Create and start the retransmitter
Create and start the retransmitter
Create and start the retransmitter
AckReceiverWindow - class org.jgroups.stack.AckReceiverWindow
Counterpart of AckSenderWindow.
AckReceiverWindow(long) - constructor for class org.jgroups.stack.AckReceiverWindow
AckSenderWindow - class org.jgroups.stack.AckSenderWindow
ACK-based sliding window for a sender.
Creates a new instance.
acquire() - method in class org.jgroups.util.NullSync
This class represents the lock to be released.
actionPerformed(ActionEvent) - method in class org.jgroups.demos.DistributedHashtableDemo
actionPerformed(ActionEvent) - method in class org.jgroups.demos.DistributedQueueDemo
actionPerformed(ActionEvent) - method in class org.jgroups.demos.Draw
actionPerformed(ActionEvent) - method in class org.jgroups.demos.Draw2Channels
actionPerformed(ActionEvent) - method in class org.jgroups.demos.applets.DrawApplet
actionPerformed(ActionEvent) - method in class org.jgroups.demos.DrawRepl
actionPerformed(ActionEvent) - method in class org.jgroups.demos.Gossip
actionPerformed(ActionEvent) - method in class org.jgroups.demos.wb.MessageDialog
actionPerformed(ActionEvent) - method in class org.jgroups.demos.QuoteClient
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
activeThreads() - static method in class org.jgroups.util.Util
adapter - field in class org.jgroups.blocks.MessageDispatcher
add(Collection) - method in class org.jgroups.Membership
Adds a list of members to this membership
add(long,long) - method in class org.jgroups.stack.Retransmitter
Add the given range [first_seqno, last_seqno] in the list of entries eligible for retransmission.
add(long,org.jgroups.Message) - method in class org.jgroups.stack.AckReceiverWindow
Adds a new message.
add(long,org.jgroups.Message) - method in class org.jgroups.stack.AckSenderWindow
Adds a new message to the retransmission table.
add(long,org.jgroups.Message) - method in class org.jgroups.stack.NakReceiverWindow
Adds a message according to its sequence number (ordered).
Adds a new message to the hash table.
add(Object) - method in class org.jgroups.util.BoundedList
Adds an element at the tail.
add(Object) - method in class org.jgroups.blocks.DistributedQueue
Add the speficied element at the bottom of the queue
add(Object) - method in class org.jgroups.util.LinkedListQueue
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(Object) - method in class org.jgroups.util.List
Adds an object at the tail of the list.
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(Object) - method in class org.jgroups.util.Queue2
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(Object,long) - method in class org.jgroups.stack.AckMcastReceiverWindow
Records the sender/seqno pair in the message table
add(org.jgroups.Address) - method in class org.jgroups.Membership
Adds a new member to this membership.
add(org.jgroups.Address,long,long) - method in class org.jgroups.protocols.pbcast.Digest
add(org.jgroups.Address,long,long,long) - method in class org.jgroups.protocols.pbcast.Digest
add(org.jgroups.conf.ProtocolData) - method in class org.jgroups.conf.XmlConfigurator
add(org.jgroups.protocols.pbcast.Digest) - method in class org.jgroups.protocols.pbcast.Digest
add(org.jgroups.util.TimeScheduler.Task) - method in class org.jgroups.util.TimeScheduler
Add a task for execution at adjustable intervals
Add a task for execution at adjustable intervals
add(Runnable) - method in class org.jgroups.util.Scheduler
add(String) - method in class org.jgroups.blocks.DistributedTree
add(String,Serializable) - method in class org.jgroups.blocks.DistributedTree
add(String,Serializable,int) - method in class org.jgroups.blocks.DistributedTree
addAll(Collection) - method in class org.jgroups.blocks.DistributedQueue
Add the speficied collection to the top of the queue.
addAll(Collection) - method in class org.jgroups.util.Queue
addAll(org.jgroups.util.List) - method in class org.jgroups.util.Queue
addAtHead(Object) - method in class org.jgroups.util.BoundedList
Adds an object to the head, removes an element from the tail if capacity has been exceeded
addAtHead(Object) - method in class org.jgroups.blocks.DistributedQueue
Add the speficied element at the top of the queue
addAtHead(Object) - method in class org.jgroups.util.LinkedListQueue
Adds a new object to the head of the queue basically (obj.equals(LinkedListQueue.remove(LinkedListQueue.add(obj)))) returns true If the queue has been closed with close(true) no exception will be thrown if the queue has not been flushed yet.
addAtHead(Object) - method in class org.jgroups.util.List
Adds an object at the head of the list.
addAtHead(Object) - method in class org.jgroups.util.Queue
Adds a new object to the head of the queue basically (obj.equals(queue.remove(queue.add(obj)))) returns true If the queue has been closed with close(true) no exception will be thrown if the queue has not been flushed yet.
addAtHead(Object) - method in class org.jgroups.util.Queue2
Adds a new object to the head of the queue basically (obj.equals(queue.remove(queue.add(obj)))) returns true If the queue has been closed with close(true) no exception will be thrown if the queue has not been flushed yet.
addBacklog(int) - method in class org.jgroups.protocols.ring.RingToken
Allows to be notified when a channel event such as connect, disconnect or close occurs.
Add a new channel listener to be notified on the channel's state change.
addEntry(String) - method in class org.jgroups.protocols.PerfHeader
Adds a new entry to both hashtables
Adds a GossipServer to be accessed.
addingToDownVector(org.jgroups.Event,int) - method in class org.jgroups.protocols.QUEUE.Observer
Called before event is added.
addingToUpVector(org.jgroups.Event,int) - method in class org.jgroups.protocols.QUEUE.Observer
Called before event is added.
additionalChannelListeners - field in class org.jgroups.blocks.RpcDispatcher
addLastRoundBroadcastCount(int) - method in class org.jgroups.protocols.ring.RingToken
addLink(String,int,String,int) - method in class org.jgroups.blocks.LogicalLink
addLink(String,int,String,int,long,long) - method in class org.jgroups.blocks.LogicalLink
Wraps actual listener with the VoteChannelListener and adds to the voteChannel
addMember(org.jgroups.Address) - method in class org.jgroups.debug.Simulator
Add membership listener to this adapter.
Add message listener to this adapter.
addNode(Object) - method in class org.jgroups.demos.Topology
addNode(String,org.jgroups.Address,int,int) - method in class org.jgroups.demos.wb.GraphPanel
addNode(String,org.jgroups.Address,int,int) - method in class org.jgroups.demos.wb.Whiteboard
addNotReceived(org.jgroups.Address) - method in class org.jgroups.util.RspList
addPanel(String,JPanel) - method in class org.jgroups.demos.TotalTokenDemo
addPhysicalAddress(SocketAddress) - method in class org.jgroups.stack.LogicalAddress
For internal use only.
addPrio(Runnable) - method in class org.jgroups.util.Scheduler
addr - field in class org.jgroups.demos.wb.Node
addRecoveredMember(org.jgroups.Address) - method in class org.jgroups.protocols.ring.RingToken
addResponse(org.jgroups.protocols.PingRsp) - method in class org.jgroups.protocols.PingWaiter
Address - interface org.jgroups.Address
Abstract address.
addRsp(org.jgroups.Address,Object) - method in class org.jgroups.util.RspList
addSuspect(org.jgroups.Address) - method in class org.jgroups.util.RspList
addToSeenList(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.Gossip
addVote(boolean) - method in class org.jgroups.blocks.VotingAdapter.VoteResult
Adds voting listener.
adjustNodes(Vector) - method in class org.jgroups.demos.wb.GraphPanel
arg - field in class org.jgroups.protocols.PingHeader
args - field in class org.jgroups.blocks.MethodCall
The arguments of the method.
array2String(boolean[]) - static method in class org.jgroups.util.Util
array2String(int[]) - static method in class org.jgroups.util.Util
array2String(long[]) - static method in class org.jgroups.util.Util
assignTask(Runnable) - method in class org.jgroups.util.ReusableThread
Assigns a task to the thread.
attachProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.jmx.protocols.Discovery
attachProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.jmx.protocols.FC
attachProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.jmx.protocols.FD
attachProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.jmx.protocols.FD_SOCK
attachProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.jmx.protocols.FRAG
attachProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.jmx.protocols.FRAG2
attachProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.jmx.protocols.pbcast.GMS
attachProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.jmx.protocols.MERGE2
attachProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.jmx.protocols.MPING
attachProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.jmx.protocols.pbcast.NAKACK
attachProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.jmx.protocols.PING
attachProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.jmx.Protocol
attachProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.jmx.protocols.pbcast.STABLE
attachProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.jmx.protocols.pbcast.STATE_TRANSFER
attachProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.jmx.protocols.STATS
attachProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.jmx.protocols.TCP
attachProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.jmx.protocols.TCP_NIO
attachProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.jmx.protocols.TCPGOSSIP
attachProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.jmx.protocols.TCPPING
attachProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.jmx.protocols.TP
attachProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.jmx.protocols.UDP
attachProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.jmx.protocols.UNICAST
attachProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.jmx.protocols.VIEW_SYNC
attempt(long) - method in class org.jgroups.util.NullSync
ATTR_INHERIT - static field in class org.jgroups.conf.XmlConfigurator
ATTR_NAME - static field in class org.jgroups.conf.XmlConfigurator
ATTR_VALUE - static field in class org.jgroups.conf.XmlConfigurator
AUTO_GETSTATE - static field in class org.jgroups.Channel
AUTO_RECONNECT - static field in class org.jgroups.Channel
AUTOCONF - class org.jgroups.protocols.AUTOCONF
Senses the network configuration when it is initialized (in init()) and sends a CONFIG event up and down the stack.
available() - method in class org.jgroups.util.ReusableThread

B

bar(int,int) - method in class org.jgroups.protocols.RpcProtocolEXAMPLE
BCAST - static field in class org.jgroups.protocols.TOTAL.Header
Broadcast Message
BECOME_SERVER - static field in class org.jgroups.Event
becomeClient() - method in class org.jgroups.protocols.GMS
becomeClient() - method in class org.jgroups.protocols.pbcast.GMS
becomeCoordinator() - method in class org.jgroups.protocols.GMS
becomeCoordinator() - method in class org.jgroups.protocols.pbcast.GMS
becomeParticipant() - method in class org.jgroups.protocols.GMS
becomeParticipant() - method in class org.jgroups.protocols.pbcast.GMS
begin() - method in class org.jgroups.blocks.ReplicationManager
Create a new transaction.
begin(int) - method in class org.jgroups.blocks.ReplicationManager
Create a new transaction.
BELOW - static field in class org.jgroups.stack.ProtocolStack
BLOCK - static field in class org.jgroups.Channel
BLOCK - static field in class org.jgroups.Event
block() - method in class org.jgroups.demos.Chat
block() - method in class org.jgroups.blocks.DistributedHashtable
Block sending and receiving of messages until ViewAccepted is called
block() - method in class org.jgroups.blocks.DistributedQueue
Block sending and receiving of messages until ViewAccepted is called
block() - method in class org.jgroups.blocks.DistributedTree
Block sending and receiving of messages until ViewAccepted is called
block() - method in class org.jgroups.MembershipListener
Called whenever the member needs to stop sending messages.
block() - method in class org.jgroups.blocks.MembershipListenerAdapter
Notify membership listeners to temporarily stop sending messages into a channel.
block() - method in class org.jgroups.blocks.NotificationBus
Called whenever the member needs to stop sending messages.
block() - method in class org.jgroups.demos.QuoteClient
Called whenever the member needs to stop sending messages.
block() - method in class org.jgroups.demos.QuoteServer
Called whenever the member needs to stop sending messages.
block() - method in class org.jgroups.ReceiverAdapter
Called whenever the member needs to stop sending messages.
block() - method in class org.jgroups.blocks.ReplicatedHashtable
Block sending and receiving of messages until ViewAccepted is called
block() - method in class org.jgroups.blocks.ReplicatedTree
Block sending and receiving of messages until viewAccepted() is called
block() - method in class org.jgroups.demos.Topology
block() - method in class org.jgroups.demos.ViewDemo
Block sending and receiving of messages until ViewAccepted is called
block() - method in class org.jgroups.blocks.VotingAdapter
Blocks the channel until the ViewAccepted is invoked.
block() - method in class org.jgroups.demos.wb.Whiteboard
Called whenever the member needs to stop sending messages.
BLOCK_OK - static field in class org.jgroups.Event
BLOCK_SEND - static field in class org.jgroups.Event
BlockEvent - class org.jgroups.BlockEvent
Trivial object that represents a block event.
blockOk() - method in class org.jgroups.Channel
Called to acknowledge a block() (callback in MembershipListener or BlockEvent received from call to Receive).
blockOk() - method in class org.jgroups.JChannel
Called to acknowledge a block() (callback in MembershipListener or BlockEvent received from call to receive()).
blockOk() - method in class org.jgroups.jmx.JChannel
blockOk() - method in class org.jgroups.jmx.JChannelMBean
bottom() - method in class org.jgroups.util.Stack
BoundedList - class org.jgroups.util.BoundedList
A bounded subclass of List, 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
BSH - class org.jgroups.protocols.BSH
Beanshell (www.beanshell.org) interpreter class.
BSH() - constructor for class org.jgroups.protocols.BSH
BSH.BshHeader - class org.jgroups.protocols.BSH.BshHeader
BshHeader() - constructor for class org.jgroups.protocols.BSH.BshHeader
BshHeader(int) - constructor for class org.jgroups.protocols.BSH.BshHeader
Buffer - class org.jgroups.util.Buffer
Buffer with an offset and length.
Buffer(byte[],int,int) - constructor for class org.jgroups.util.Buffer
BYTE_SIZE - static field in class org.jgroups.Global
Value is .
byteBufferToMessageList(byte[],int,int) - static method in class org.jgroups.util.Util

C

call_stack - field in class org.jgroups.blocks.RequestCorrelator
This field is used only if deadlock detection is enabled.
callStack - field in class org.jgroups.blocks.RequestCorrelator.Header
Stack
.
cancel() - method in class org.jgroups.util.TimeScheduler.CancellableTask
Cancels the task.
CANCEL_MERGE - static field in class org.jgroups.protocols.pbcast.GMS.GmsHeader
cancelled() - method in class org.jgroups.util.TimeScheduler.Task
CannotConnectException - class org.jgroups.persistence.CannotConnectException
CannotConnectException(Exception,String) - constructor for class org.jgroups.persistence.CannotConnectException
CannotConnectException(Throwable,String) - constructor for class org.jgroups.persistence.CannotConnectException
CannotCreateSchemaException(Throwable,String) - constructor for class org.jgroups.persistence.CannotCreateSchemaException
CannotPersistException - class org.jgroups.persistence.CannotPersistException
CannotPersistException(Throwable,String) - constructor for class org.jgroups.persistence.CannotPersistException
CannotRemoveException - class org.jgroups.persistence.CannotRemoveException
CannotRemoveException(Throwable,String) - constructor for class org.jgroups.persistence.CannotRemoveException
CannotRetrieveException - class org.jgroups.persistence.CannotRetrieveException
CannotRetrieveException(Throwable,String) - constructor for class org.jgroups.persistence.CannotRetrieveException
Multicast a message request to all members in dests and receive responses via the RspCollector interface.
Cast a message to all members, and wait for mode responses.
Cast a message to all members, and wait for mode responses.
castViewChange(org.jgroups.View,org.jgroups.protocols.pbcast.Digest) - method in class org.jgroups.protocols.pbcast.GMS
castViewChange(Vector,Vector,Vector) - method in class org.jgroups.protocols.GMS
Compute a new view, given the current view, the new members and the suspected/left members.
castViewChange(Vector,Vector,Vector) - method in class org.jgroups.protocols.pbcast.GMS
Compute a new view, given the current view, the new members and the suspected/left members.
Broadcasts the new view and digest, and waits for acks from all members in the list given as argument.
CAUSAL - class org.jgroups.protocols.CAUSAL
Implements casual ordering layer using vector clocks.
CAUSAL() - constructor for class org.jgroups.protocols.CAUSAL
default constructor
CausalDemo - class org.jgroups.demos.CausalDemo
Simple causal demo where each member bcast a consecutive letter from the alphabet and picks the next member to transmit the next letter.
CausalDemo(boolean) - constructor for class org.jgroups.demos.CausalDemo
CAUSAL.CausalHeader - class org.jgroups.protocols.CAUSAL.CausalHeader
CausalHeader() - constructor for class org.jgroups.protocols.CAUSAL.CausalHeader
used for externalization
cause - field in class org.jgroups.protocols.ring.TokenLostException
channel - field in class org.jgroups.blocks.DistributedQueue
channel - field in class org.jgroups.blocks.DistributedTree
channel - field in class org.jgroups.blocks.MessageDispatcher
Channel - class org.jgroups.Channel
A channel represents a group communication endpoint (like BSD datagram sockets).
channel_listener - field in class org.jgroups.Channel
channel_listeners - field in class org.jgroups.Channel
channel_name - field in class org.jgroups.protocols.TpHeader
channel_name - field in class org.jgroups.protocols.TunnelHeader
channel_name - field in class org.jgroups.protocols.UdpHeader
channelClosed(org.jgroups.Channel) - method in class org.jgroups.demos.Draw
channelClosed(org.jgroups.Channel) - method in class org.jgroups.demos.Gossip
channelClosed(org.jgroups.Channel) - method in class org.jgroups.blocks.PullPushAdapter
channelClosed(org.jgroups.Channel) - method in class org.jgroups.blocks.RpcDispatcher
Thrown if an operation is attemped on a closed channel.
ChannelClosedException() - constructor for class org.jgroups.ChannelClosedException
ChannelClosedException(String) - constructor for class org.jgroups.ChannelClosedException
channelConnected(org.jgroups.Channel) - method in class org.jgroups.demos.Draw
channelConnected(org.jgroups.Channel) - method in class org.jgroups.demos.Gossip
channelConnected(org.jgroups.Channel) - method in class org.jgroups.blocks.PullPushAdapter
channelConnected(org.jgroups.Channel) - method in class org.jgroups.blocks.RpcDispatcher
channelDisconnected(org.jgroups.Channel) - method in class org.jgroups.demos.Draw
channelDisconnected(org.jgroups.Channel) - method in class org.jgroups.demos.Gossip
channelDisconnected(org.jgroups.Channel) - method in class org.jgroups.blocks.PullPushAdapter
channelDisconnected(org.jgroups.Channel) - method in class org.jgroups.blocks.RpcDispatcher
This class represents the super class for all exception types thrown by JGroups.
ChannelException() - constructor for class org.jgroups.ChannelException
ChannelException(String) - constructor for class org.jgroups.ChannelException
ChannelException(String,Throwable) - constructor for class org.jgroups.ChannelException
ChannelFactory - interface org.jgroups.ChannelFactory
A channel factory takes care of creation of channel implementations.
ChannelListener - interface org.jgroups.ChannelListener
Allows a listener to be notified when important channel events occur.
Thrown if an operation is attemped on an unconnected channel.
channelReconnected(org.jgroups.Address) - method in class org.jgroups.demos.Draw
channelReconnected(org.jgroups.Address) - method in class org.jgroups.demos.Gossip
channelReconnected(org.jgroups.Address) - method in class org.jgroups.blocks.PullPushAdapter
channelReconnected(org.jgroups.Address) - method in class org.jgroups.blocks.RpcDispatcher
channelShunned() - method in class org.jgroups.ChannelListener
channelShunned() - method in class org.jgroups.demos.Draw
channelShunned() - method in class org.jgroups.demos.Gossip
channelShunned() - method in class org.jgroups.blocks.PullPushAdapter
channelShunned() - method in class org.jgroups.blocks.RpcDispatcher
Chat - class org.jgroups.demos.Chat
Simple chat demo
Chat(String) - constructor for class org.jgroups.demos.Chat
checkForLinux() - static method in class org.jgroups.util.Util
checkForSolaris() - static method in class org.jgroups.util.Util
checkForWindows() - static method in class org.jgroups.util.Util
checkSelfInclusion(Vector) - method in class org.jgroups.protocols.GMS
Returns true if local_addr is member of mbrs, else false
checkSelfInclusion(Vector) - method in class org.jgroups.protocols.pbcast.GMS
Returns true if local_addr is member of mbrs, else false
ClassConfigurator - class org.jgroups.conf.ClassConfigurator
This class will be replaced with the class that read info from the magic number configurator that reads info from the xml file.
ClassMap - class org.jgroups.conf.ClassMap
Maintains mapping between magic number and class
ClassMap(String,String,boolean,int) - constructor for class org.jgroups.conf.ClassMap
ClassPathEntityResolver() - constructor for class org.jgroups.conf.ClassPathEntityResolver
ClassPathEntityResolver(String) - constructor for class org.jgroups.conf.ClassPathEntityResolver
clear() - method in class org.jgroups.persistence.DBPersistenceManager
Clears the key-cache as well as all entries
clear() - method in class org.jgroups.protocols.pbcast.Digest
clear() - method in class org.jgroups.blocks.DistributedHashtable
Clears this hashtable so that it contains no keys
clear() - method in class org.jgroups.persistence.FilePersistenceManager
Clears the complete NV state from the DB
clear() - method in class org.jgroups.Membership
removes all the members from this membership
clear() - method in class org.jgroups.persistence.PersistenceManager
Clears the complete NV state from the DB
clear() - method in class org.jgroups.util.Queue
Removes all elements from the queue.
clear() - method in class org.jgroups.blocks.ReplicatedHashtable
Clears this hashtable so that it contains no keys
clearPanel() - method in class org.jgroups.demos.Draw
clearPanel() - method in class org.jgroups.demos.Draw2Channels
clearPanel() - method in class org.jgroups.demos.applets.DrawApplet
clearPanel() - method in class org.jgroups.demos.DrawRepl
clearPanel() - method in class org.jgroups.demos.Gossip
clearResponses() - method in class org.jgroups.protocols.PingWaiter
clearStableMessages() - method in class org.jgroups.stack.AckMcastSenderWindow
ClientGmsImpl - class org.jgroups.protocols.ClientGmsImpl
Client part of GMS.
ClientGmsImpl - class org.jgroups.protocols.pbcast.ClientGmsImpl
Client part of GMS.
ClientGmsImpl(org.jgroups.protocols.GMS) - constructor for class org.jgroups.protocols.ClientGmsImpl
ClientGmsImpl(org.jgroups.protocols.pbcast.GMS) - constructor for class org.jgroups.protocols.pbcast.ClientGmsImpl
clone() - method in class org.jgroups.stack.IpAddress
clone() - method in class org.jgroups.protocols.JMS.JMSAddress
Clone the object.
clone() - method in class org.jgroups.util.List
clone() - method in class org.jgroups.stack.LogicalAddress
clone() - method in class org.jgroups.Membership
clone() - method in class org.jgroups.MergeView
creates a copy of this view
clone() - method in class org.jgroups.Message
clone() - method in class org.jgroups.blocks.ReplicatedTree.Node
clone() - method in class org.jgroups.View
creates a copy of this view
clone() - method in class org.jgroups.ViewId
Cloneable interface Returns a new ViewID object containing the same address and lamport timestamp as this view
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
Destroys the channel.
close() - method in class org.jgroups.jmx.JChannel
close() - method in class org.jgroups.jmx.JChannelMBean
close(boolean) - method in class org.jgroups.util.LinkedListQueue
Marks the queues as closed.
close(boolean) - method in class org.jgroups.util.Queue
Marks the queues as closed.
close(boolean) - method in class org.jgroups.util.Queue2
Marks the queues as closed.
closed() - method in class org.jgroups.util.LinkedListQueue
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.
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.
closed() - method in class org.jgroups.util.Queue2
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.
closeInputStream(InputStream) - static method in class org.jgroups.util.Util
closeOutputStream(OutputStream) - static method in class org.jgroups.util.Util
closer - field in class org.jgroups.JChannel
Thread responsible for closing a channel and potentially reconnecting to it (e.g., when shunned).
collectionToByteBuffer(Collection) - static method in class org.jgroups.util.Util
colorPanel(int,int,int) - method in class org.jgroups.demos.Gossip
Command - interface org.jgroups.util.Command
The Command patttern (see Gamma et al.).
COMMIT - static field in class org.jgroups.blocks.ReplicationData
commit() - method in class org.jgroups.blocks.DistributedLockManager.LockDecree
commit() - method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
commit(Object) - method in class org.jgroups.blocks.DistributedLockManager
Commit phase for the lock acquisition or release.
commit(Object) - method in class org.jgroups.blocks.TwoPhaseVotingListener
This is voting on the commiting the decree.
commit(org.jgroups.blocks.Xid) - method in class org.jgroups.blocks.ReplicationManager
Commits all modifications sent to the receivers via send(Address,byte[],boolean,long,Xid,byte[],long,long,boolean) and releases all locks associated with this transaction.
commit(org.jgroups.blocks.Xid) - method in class org.jgroups.blocks.ReplicationReceiver
Commit the modifications to the locally replicated data and release all locks.
commited - field in class org.jgroups.blocks.DistributedLockManager.LockDecree
compare(Object) - method in class org.jgroups.ViewId
Old Compare
compare(org.jgroups.stack.IpAddress) - method in class org.jgroups.stack.IpAddress
Establishes an order between 2 addresses.
compare(org.jgroups.stack.LogicalAddress) - method in class org.jgroups.stack.LogicalAddress
Establishes an order between 2 addresses.
compareTo(Object) - method in class org.jgroups.stack.IpAddress
implements the java.lang.Comparable interface
compareTo(Object) - method in class org.jgroups.protocols.JMS.JMSAddress
Compare this object to o.
compareTo(Object) - method in class org.jgroups.stack.LogicalAddress
implements the java.lang.Comparable interface
compareTo(Object) - method in class org.jgroups.ViewId
Establishes an order between 2 ViewIds.
compareTo(Object) - method in class org.jgroups.protocols.WanPipeAddress
Establishes an order between 2 addresses.
compareTo(Object) - method in class org.jgroups.blocks.Xid
compareTo(short) - static method in class org.jgroups.Version
Compares the specified version number against the current version number.
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
componentShown(ComponentEvent) - method in class org.jgroups.demos.wb.Whiteboard
COMPRESS - class org.jgroups.protocols.COMPRESS
Compresses the payload of a message.
COMPRESS.CompressHeader - class org.jgroups.protocols.COMPRESS.CompressHeader
CompressHeader() - constructor for class org.jgroups.protocols.COMPRESS.CompressHeader
CompressHeader(int) - constructor for class org.jgroups.protocols.COMPRESS.CompressHeader
computeFragOffsets(byte[],int) - static method in class org.jgroups.util.Util
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.
concurrent_processing - field in class org.jgroups.blocks.MessageDispatcher
Process items on the queue concurrently (RequestCorrelator).
concurrent_processing - field in class org.jgroups.blocks.RequestCorrelator
Process items on the queue concurrently (Scheduler).
CondVar - class org.jgroups.util.CondVar
Class that checks on a condition and - if condition doesn't match the expected result - waits until the result matches the expected result, or a timeout occurs.
CondVar(String,Object) - constructor for class org.jgroups.util.CondVar
CondVar(String,Object,Object) - constructor for class org.jgroups.util.CondVar
CONFIG - static field in class org.jgroups.Event
Configurator - class org.jgroups.stack.Configurator
The task if this class is to setup and configure the protocol stack.
ConfiguratorFactory - class org.jgroups.conf.ConfiguratorFactory
The ConfigurationFactory is a factory that returns a protocol stack configurator.
ConfiguratorFactory() - constructor for class org.jgroups.conf.ConfiguratorFactory
CONNECT - static field in class org.jgroups.Event
connect() - method in class org.jgroups.stack.RouterStub
Establishes a connection to the router.
connect() - method in class org.jgroups.demos.TotalTokenDemo
connect(String) - method in class org.jgroups.Channel
Connects the channel to a group.
connect(String) - method in class org.jgroups.JChannel
Connects the channel to a group.
connect(String) - method in class org.jgroups.jmx.JChannel
connect(String) - method in class org.jgroups.jmx.JChannelMBean
CONNECT_OK - static field in class org.jgroups.Event
Used to be notified about connection establishment and teardown.
ConnectionTable - class org.jgroups.blocks.ConnectionTable
Manages incoming and outgoing TCP connections.
ConnectionTable(InetAddress,int) - constructor for class org.jgroups.blocks.ConnectionTable
ConnectionTable(int) - constructor for class org.jgroups.blocks.ConnectionTable
Regular ConnectionTable without expiration of idle connections
ConnectionTable(int,long,long) - constructor for class org.jgroups.blocks.ConnectionTable
ConnectionTable including a connection reaper.
Create a ConnectionTable
ConnectionTable including a connection reaper.
ConnectionTableNIO - class org.jgroups.blocks.ConnectionTableNIO
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
UDP_NIO.Connector - class org.jgroups.protocols.UDP_NIO.Connector
Manages a multicast and unicast socket on a given interface (NIC).
UDP_NIO.ConnectorTable - class org.jgroups.protocols.UDP_NIO.ConnectorTable
Manages a bunch of Connectors
NotificationBus.Consumer - interface org.jgroups.blocks.NotificationBus.Consumer
contains(Object) - method in class org.jgroups.util.List
contains(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.Digest
contains(org.jgroups.Address) - method in class org.jgroups.Membership
Returns true if the provided member belongs to this membership
containsMember(org.jgroups.Address) - method in class org.jgroups.View
returns true, if this view contains a certain member
contentsCleared() - method in class org.jgroups.blocks.DistributedHashtable.Notification
contentsCleared() - method in class org.jgroups.demos.DistributedHashtableDemo
contentsCleared() - method in class org.jgroups.blocks.DistributedQueue.Notification
contentsCleared() - method in class org.jgroups.demos.DistributedQueueDemo
contentsSet(Collection) - method in class org.jgroups.blocks.DistributedQueue.Notification
contentsSet(Collection) - method in class org.jgroups.demos.DistributedQueueDemo
contentsSet(Map) - method in class org.jgroups.blocks.DistributedHashtable.Notification
contentsSet(Map) - method in class org.jgroups.demos.DistributedHashtableDemo
contentsSet(Map) - method in class org.jgroups.blocks.ReplicatedHashtable.Notification
ObjectInputStream which sets a contact classloader for reading bytes into objects.
ContextObjectInputStream(InputStream) - constructor for class org.jgroups.util.ContextObjectInputStream
Creates a new instance of MarshalledValueOutputStream
coord_addr - field in class org.jgroups.protocols.PingRsp
CoordAnnouncement() - constructor for class org.jgroups.protocols.MERGE3.CoordAnnouncement
CoordAnnouncement(org.jgroups.Address) - constructor for class org.jgroups.protocols.MERGE3.CoordAnnouncement
CoordGmsImpl - class org.jgroups.protocols.CoordGmsImpl
CoordGmsImpl - class org.jgroups.protocols.pbcast.CoordGmsImpl
Coordinator role of the Group MemberShip (GMS) protocol.
CoordGmsImpl(org.jgroups.protocols.GMS) - constructor for class org.jgroups.protocols.CoordGmsImpl
CoordGmsImpl(org.jgroups.protocols.pbcast.GMS) - constructor for class org.jgroups.protocols.pbcast.CoordGmsImpl
coordinatorChosen() - method in class org.jgroups.demos.Topology
copy - static field in class org.jgroups.Global
Used to determine whether to copy messages (copy=true) in retransmission tables, or whether to use references (copy=false).
copy() - method in class org.jgroups.util.Buffer
copy() - method in class org.jgroups.protocols.pbcast.Digest
copy() - method in class org.jgroups.protocols.pbcast.Gossip
copy() - method in class org.jgroups.util.List
copy() - method in class org.jgroups.stack.LogicalAddress
copy() - method in class org.jgroups.Membership
returns a copy of this membership
copy() - method in class org.jgroups.Message
copy() - method in class org.jgroups.protocols.NakAckHeader
copy() - method in class org.jgroups.protocols.pbcast.NakAckHeader
copy() - method in class org.jgroups.util.Stack
copy() - method in class org.jgroups.ViewId
Old Copy method, deprecated because it is substituted by clone()
copy(boolean) - method in class org.jgroups.Message
Create a copy of the message.
corr - field in class org.jgroups.blocks.GroupRequest
corr - field in class org.jgroups.blocks.MessageDispatcher
corrName - field in class org.jgroups.blocks.RequestCorrelator.Header
The unique name of the associated RequestCorrelator
count - static field in class org.jgroups.stack.LogicalAddress
crash() - static method in class org.jgroups.util.Util
create() - method in class org.jgroups.stack.GossipRouter
JBoss MBean lifecycle operation.
create() - method in class org.jgroups.jmx.JChannel
create() - method in class org.jgroups.jmx.JChannelMBean
create() - method in class org.jgroups.jmx.Protocol
create() - method in class org.jgroups.jmx.ProtocolMBean
create(org.jgroups.Address) - static method in class org.jgroups.blocks.Xid
create(org.jgroups.Address,int) - static method in class org.jgroups.blocks.Xid
createChannel() - method in class org.jgroups.ChannelFactory
Creates an instance implementing the Channel interface.
createChannel() - method in class org.jgroups.JChannelFactory
Creates a JChannel implementation of the Channel interface using the protocol stack configuration information specfied during construction of an instance of this factory.
createChannel(Object) - method in class org.jgroups.ChannelFactory
Creates an instance implementing the Channel interface.
createChannel(Object) - method in class org.jgroups.JChannelFactory
Creates a JChannel implementation of the Channel interface.
createDatagramSocket(InetAddress,int) - static method in class org.jgroups.util.Util
Creates a DatagramSocket bound to addr.
createManager() - method in class org.jgroups.persistence.PersistenceFactory
Reads the default properties and creates a persistencemanager The default properties are picked up from the $USER_HOME or from the classpath.
createManager(String) - method in class org.jgroups.persistence.PersistenceFactory
Duplicated signature to create PersistenceManager to allow user to provide property path.
createProtocol(String) - method in class org.jgroups.stack.ProtocolStack
Creates a new protocol given the protocol specification.
Creates a new protocol given the protocol specification.
createServerSocket(InetAddress,int) - static method in class org.jgroups.util.Util
createServerSocket(int) - static method in class org.jgroups.util.Util
Finds first available port starting at start_port and returns server socket
createServerSocket(int,int) - method in class org.jgroups.blocks.ConnectionTable
Finds first available port starting at start_port and returns server socket.
createServerSocket(int,int) - method in class org.jgroups.blocks.ConnectionTableNIO
Finds first available port starting at start_port and returns server socket.
Tries to create a socket to remote_peer:remote_port.
creator - field in class org.jgroups.blocks.Xid
CREDIT_REQUEST - static field in class org.jgroups.protocols.FC.FcHeader
cummulative - field in class org.jgroups.debug.Debugger
cvs - static field in class org.jgroups.Version

D

DATA - static field in class org.jgroups.protocols.UNICAST.UnicastHeader
DBPersistenceManager - class org.jgroups.persistence.DBPersistenceManager
Class will be utilized
DBPersistenceManager(InputStream) - constructor for class org.jgroups.persistence.DBPersistenceManager
Duplicate constructor allowing inputstream
DBPersistenceManager(String) - constructor for class org.jgroups.persistence.DBPersistenceManager
Default construct
DEADLOCK - class org.jgroups.protocols.DEADLOCK
Tests the deadlock detection mechanism of RequestCorrelator.
deadlock_detection - field in class org.jgroups.blocks.MessageDispatcher
deadlock_detection - field in class org.jgroups.blocks.RequestCorrelator
Whether or not to perform deadlock detection for synchronous (potentially recursive) group method invocations.
debug - static field in class org.jgroups.Global
Allows for conditional compilation; e.g., if(log.isTraceEnabled()) if(log.isInfoEnabled()) log.info(...) would be removed from the code (if recompiled) when this flag is set to false.
debug() - method in class org.jgroups.util.Queue2
Dumps internal state @remove
Debugger - class org.jgroups.debug.Debugger
The Debugger displays a graphical view of the protocol stack by showing all the protocols and the events in them.
Debugger() - constructor for class org.jgroups.debug.Debugger
Debugger(org.jgroups.JChannel) - constructor for class org.jgroups.debug.Debugger
Debugger(org.jgroups.JChannel,boolean) - constructor for class org.jgroups.debug.Debugger
Debugger(org.jgroups.JChannel,boolean,String) - constructor for class org.jgroups.debug.Debugger
Debugger(org.jgroups.JChannel,String) - constructor for class org.jgroups.debug.Debugger
DEFAULT_CONNECTION_FACTORY - static field in class org.jgroups.protocols.JMS
DEFAULT_PROTOCOL_STACK - static field in class org.jgroups.JChannel
The default protocol stack used by the default constructor.
defragmentBuffer(fragments[][]) - static method in class org.jgroups.util.Util
Concatenates smaller fragments into entire buffers.
DELAY - class org.jgroups.protocols.DELAY
Delays incoming/outgoing messages by a random number of milliseconds (range between 0 and n where n is determined by the user).
description - static field in class org.jgroups.Version
dest_addr - field in class org.jgroups.Message
dest_mbrs - field in class org.jgroups.blocks.RequestCorrelator.Header
Contains a list of members who should receive the request (others will drop).
DEST_PROPERTY - static field in class org.jgroups.protocols.JMS
destroy() - method in class org.jgroups.protocols.BSH
destroy() - method in class org.jgroups.protocols.COMPRESS
This method is called on a Channel.close().
destroy() - method in class org.jgroups.demos.applets.DrawApplet
destroy() - method in class org.jgroups.stack.GossipRouter
JBoss MBean lifecycle operation.
destroy() - method in class org.jgroups.jmx.JChannel
destroy() - method in class org.jgroups.jmx.JChannelMBean
destroy() - method in class org.jgroups.stack.NakReceiverWindow
Stop the retransmitter and reset the nak window
destroy() - method in class org.jgroups.jmx.Protocol
destroy() - method in class org.jgroups.stack.Protocol
This method is called on a Channel.close().
destroy() - method in class org.jgroups.jmx.ProtocolMBean
destroy() - method in class org.jgroups.stack.ProtocolStack
destroy() - method in class org.jgroups.util.ThreadPool
destroy() - method in class org.jgroups.demos.wb.Whiteboard
DESTROY_INTERPRETER - static field in class org.jgroups.protocols.BSH.BshHeader
destroyInterpreter() - method in class org.jgroups.protocols.BSH
determineAllBindInterfaces() - method in class org.jgroups.protocols.UDP_NIO
determineCoordinator() - method in class org.jgroups.protocols.GMS
determineCoordinator() - method in class org.jgroups.protocols.pbcast.GMS
determineDefaultBindInterface() - method in class org.jgroups.protocols.UDP_NIO
Return the first non-loopback interface
determineLeftMembers(Vector,Vector) - static method in class org.jgroups.util.Util
Returns all members that left between 2 views.
DIAG_GROUP - static field in class org.jgroups.util.Util
Digest - class org.jgroups.protocols.Digest
Message digest, collecting the highest sequence number seen so far for each member, plus the messages that have higher seqnos than the ones given.
Digest - class org.jgroups.protocols.pbcast.Digest
A message digest, which is used by the PBCAST layer for gossiping (also used by NAKACK for keeping track of current seqnos for all members).
Digest() - constructor for class org.jgroups.protocols.pbcast.Digest
Digest(int) - constructor for class org.jgroups.protocols.Digest
Digest(int) - constructor for class org.jgroups.protocols.pbcast.Digest
DIRTY_READS - static field in class org.jgroups.blocks.Xid
Writes are serialized, but reads can be dirty; e.g., a data might have been changed while we read it.
DISCARD - class org.jgroups.protocols.DISCARD
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.
DISCONNECT - static field in class org.jgroups.Event
disconnect() - method in class org.jgroups.Channel
Disconnects the channel from the current group (if connected), leaving the group.
disconnect() - method in class org.jgroups.JChannel
Disconnects the channel if it is connected.
disconnect() - method in class org.jgroups.jmx.JChannel
disconnect() - method in class org.jgroups.jmx.JChannelMBean
disconnect() - method in class org.jgroups.stack.RouterStub
Closes the socket and the input and output streams associated with it
disconnect() - method in class org.jgroups.demos.TotalTokenDemo
DISCONNECT_OK - static field in class org.jgroups.Event
Discovery - class org.jgroups.jmx.protocols.Discovery
Discovery - class org.jgroups.protocols.Discovery
The Discovery protocol layer retrieves the initial membership (used by the GMS when started by sending event FIND_INITIAL_MBRS down the stack).
Discovery() - constructor for class org.jgroups.jmx.protocols.Discovery
Discovery(org.jgroups.stack.Protocol) - constructor for class org.jgroups.jmx.protocols.Discovery
DiscoveryMBean - interface org.jgroups.jmx.protocols.DiscoveryMBean
disp - field in class org.jgroups.blocks.DistributedHashtable
disp - field in class org.jgroups.blocks.DistributedQueue
disp - field in class org.jgroups.blocks.DistributedTree
disp - field in class org.jgroups.blocks.ReplicationManager
Used to broadcast updates and receive responses (latter only in synchronous case)
disp - field in class org.jgroups.demos.wb.Whiteboard
displayMessage(String,String) - method in class org.jgroups.demos.wb.Whiteboard
DistributedHashtable - class org.jgroups.blocks.DistributedHashtable
Provides the abstraction of a java.util.Hashtable that is replicated at several locations.
Uses a user-provided PullPushAdapter to create the dispatcher rather than a Channel.
Creates a DisttributedHashtable.
Creates a DistributedHashtable
Uses the DistributedHashtable building block.
DistributedHashtableDemo() - constructor for class org.jgroups.demos.DistributedHashtableDemo
Distributed lock manager is responsible for maintaining the lock information consistent on all participating nodes.
Constructor for the DistributedLockManager_cl object.
Create instance of this class.
DistributedQueue - class org.jgroups.blocks.DistributedQueue
Provides the abstraction of a java.util.LinkedList that is replicated at several locations.
Uses a user-provided PullPushAdapter to create the dispatcher rather than a Channel.
DistributedQueue(org.jgroups.JChannel) - constructor for class org.jgroups.blocks.DistributedQueue
Creates a DistributedQueue
DistributedQueueDemo - class org.jgroups.demos.DistributedQueueDemo
Uses the DistributedQueue building block.
DistributedQueueDemo() - constructor for class org.jgroups.demos.DistributedQueueDemo
DistributedTree - class org.jgroups.blocks.DistributedTree
A tree-like structure that is replicated across several members.
DistributedTree() - constructor for class org.jgroups.blocks.DistributedTree
DistributedTree(String,String) - constructor for class org.jgroups.blocks.DistributedTree
DistributedTreeDemo - class org.jgroups.demos.DistributedTreeDemo
Demo showing the DistributedTree class.
DistributedTreeDemo(boolean) - constructor for class org.jgroups.demos.DistributedTreeDemo
done - field in class org.jgroups.blocks.GroupRequest
done() - method in class org.jgroups.protocols.PERF_TP
done() - method in class org.jgroups.util.ReusableThread
done(long) - method in class org.jgroups.blocks.MessageDispatcher
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.
doubleWrite(byte[],int,int,OutputStream) - static method in class org.jgroups.util.Util
Makes sure that we detect when a peer connection is in the closed state (not closed while we send data, but before we send data).
doubleWrite(byte[],OutputStream) - static method in class org.jgroups.util.Util
Makes sure that we detect when a peer connection is in the closed state (not closed while we send data, but before we send data).
down(org.jgroups.Event) - method in class org.jgroups.protocols.CAUSAL
Processes Event going down in the stack
down(org.jgroups.Event) - method in class org.jgroups.Channel
Access to event mechanism of channels.
down(org.jgroups.Event) - method in class org.jgroups.protocols.COMPRESS
We compress the payload if it is larger than min_size.
down(org.jgroups.Event) - method in class org.jgroups.protocols.DELAY
down(org.jgroups.Event) - method in class org.jgroups.protocols.DISCARD
down(org.jgroups.Event) - method in class org.jgroups.protocols.Discovery
An event is to be sent down the stack.
down(org.jgroups.Event) - method in class org.jgroups.protocols.DUMMY
down(org.jgroups.Event) - method in class org.jgroups.protocols.DUMMY_TP
Caller by the layer above this layer.
down(org.jgroups.Event) - method in class org.jgroups.protocols.ENCRYPT
An event is to be sent down the stack.
down(org.jgroups.Event) - method in class org.jgroups.protocols.ENCRYPT1_4
down(org.jgroups.Event) - method in class org.jgroups.protocols.EXAMPLE
down(org.jgroups.Event) - method in class org.jgroups.protocols.FC
down(org.jgroups.Event) - method in class org.jgroups.protocols.FD
down(org.jgroups.Event) - method in class org.jgroups.protocols.pbcast.FD
An event is to be sent down the stack.
down(org.jgroups.Event) - method in class org.jgroups.protocols.FD_PID
down(org.jgroups.Event) - method in class org.jgroups.protocols.FD_PROB
An event is to be sent down the stack.
down(org.jgroups.Event) - method in class org.jgroups.protocols.FD_SIMPLE
An event is to be sent down the stack.
down(org.jgroups.Event) - method in class org.jgroups.protocols.FD_SOCK
down(org.jgroups.Event) - method in class org.jgroups.protocols.FLOWCONTROL
Checs if it can send the message, else puts the message in the queue.
down(org.jgroups.Event) - method in class org.jgroups.protocols.FRAG
Fragment a packet if larger than frag_size (add a header).
down(org.jgroups.Event) - method in class org.jgroups.protocols.FRAG2
Fragment a packet if larger than frag_size (add a header).
down(org.jgroups.Event) - method in class org.jgroups.protocols.pbcast.GMS
down(org.jgroups.Event) - method in class org.jgroups.protocols.HDRS
down(org.jgroups.Event) - method in class org.jgroups.protocols.HTOTAL
down(org.jgroups.Event) - method in class org.jgroups.JChannel
Sends a message through the protocol stack if the stack is available
down(org.jgroups.Event) - method in class org.jgroups.jmx.JChannel
down(org.jgroups.Event) - method in class org.jgroups.jmx.JChannelMBean
down(org.jgroups.Event) - method in class org.jgroups.protocols.JMS
Called by the protocol above this.
down(org.jgroups.Event) - method in class org.jgroups.protocols.LOOPBACK
Caller by the layer above this layer.
down(org.jgroups.Event) - method in class org.jgroups.protocols.LOSS
An event is to be sent down the stack.
down(org.jgroups.Event) - method in class org.jgroups.protocols.MERGE
An event is to be sent down the stack.
down(org.jgroups.Event) - method in class org.jgroups.protocols.MERGE2
down(org.jgroups.Event) - method in class org.jgroups.protocols.MERGE3
down(org.jgroups.Event) - method in class org.jgroups.protocols.MERGEFAST
down(org.jgroups.Event) - method in class org.jgroups.stack.MessageProtocol
This message is not originated by this layer, therefore we can just pass it down without having to go through the request correlator.
down(org.jgroups.Event) - method in class org.jgroups.protocols.NAKACK
Callback.
down(org.jgroups.Event) - method in class org.jgroups.protocols.pbcast.NAKACK
Callback.
down(org.jgroups.Event) - method in class org.jgroups.protocols.PARTITIONER
Adds to Messages a Header with the local partitin number and if receives a SET_PARTITIONS Event sends a new Message with a PartitionerHeader set to COMMAND that carries the Hashtable
down(org.jgroups.Event) - method in class org.jgroups.protocols.pbcast.PBCAST
down(org.jgroups.Event) - method in class org.jgroups.protocols.PERF
down(org.jgroups.Event) - method in class org.jgroups.protocols.PERF_TP
Caller by the layer above this layer.
down(org.jgroups.Event) - method in class org.jgroups.protocols.PIGGYBACK
down(org.jgroups.Event) - method in class org.jgroups.protocols.PRINTMETHODS
down(org.jgroups.Event) - method in class org.jgroups.protocols.PRINTOBJS
An event is to be sent down the stack.
down(org.jgroups.Event) - method in class org.jgroups.stack.Protocol
An event is to be sent down the stack.
down(org.jgroups.Event) - method in class org.jgroups.stack.ProtocolStack
down(org.jgroups.Event) - method in class org.jgroups.protocols.QUEUE
An event is to be sent down the stack.
down(org.jgroups.Event) - method in class org.jgroups.protocols.SIZE
down(org.jgroups.Event) - method in class org.jgroups.protocols.SMACK
down(org.jgroups.Event) - method in class org.jgroups.protocols.pbcast.STABLE
down(org.jgroups.Event) - method in class org.jgroups.protocols.STATE_TRANSFER
An event is to be sent down the stack.
down(org.jgroups.Event) - method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
down(org.jgroups.Event) - method in class org.jgroups.protocols.STATS
An event is to be sent down the stack.
down(org.jgroups.Event) - method in class org.jgroups.protocols.TOTAL
An event is to be sent down the stack.
down(org.jgroups.Event) - method in class org.jgroups.protocols.TOTAL_OLD
handles an Event coming down the Protocol Stack
down(org.jgroups.Event) - method in class org.jgroups.protocols.TP
Caller by the layer above this layer.
down(org.jgroups.Event) - method in class org.jgroups.protocols.TRACE
down(org.jgroups.Event) - method in class org.jgroups.protocols.TUNNEL
Caller by the layer above this layer.
down(org.jgroups.Event) - method in class org.jgroups.protocols.UDP_NIO
Caller by the layer above this layer.
down(org.jgroups.Event) - method in class org.jgroups.protocols.UNICAST
An event is to be sent down the stack.
down(org.jgroups.Event) - method in class org.jgroups.protocols.VIEW_SYNC
An event is to be sent down the stack.
down(org.jgroups.Event) - method in class org.jgroups.protocols.WANPIPE
Sent to destination(s) using the WAN pipe.
down(org.jgroups.Event,int) - method in class org.jgroups.stack.ProtocolObserver
Called when an event is about to be dispatched to the protocol (before it is dispatched).
down(org.jgroups.Event,int) - method in class org.jgroups.debug.ProtocolView
down_handler - field in class org.jgroups.stack.Protocol
down_prot - field in class org.jgroups.stack.Protocol
down_queue - field in class org.jgroups.stack.Protocol
down_thread - field in class org.jgroups.stack.Protocol
down_thread_prio - field in class org.jgroups.stack.Protocol
downThreadEnabled() - method in class org.jgroups.stack.Protocol
Draw - class org.jgroups.demos.Draw
Shared whiteboard, each new instance joins the same group.
Draw(String,boolean,boolean,boolean,boolean) - constructor for class org.jgroups.demos.Draw
Draw2Channels - class org.jgroups.demos.Draw2Channels
Same as Draw but using 2 channels: one for view changes (control channel) and the other one for drawing (data channel).
Draw2Channels(String,String,boolean) - constructor for class org.jgroups.demos.Draw2Channels
DrawApplet - class org.jgroups.demos.applets.DrawApplet
DrawCommand - class org.jgroups.demos.DrawCommand
Encapsulates information about a draw command.
drawNode(Graphics,int,int,String,int) - method in class org.jgroups.demos.Topology
DrawRepl - class org.jgroups.demos.DrawRepl
Replicates the whiteboard demo by intercepting central AWT event queue and mcasting events to all members.
DrawRepl() - constructor for class org.jgroups.demos.DrawRepl
drawTopology(Graphics) - method in class org.jgroups.demos.Topology
DROP_NEXT_MSG - static field in class org.jgroups.Event
DUMMY - class org.jgroups.protocols.DUMMY
DUMMY_TP - class org.jgroups.protocols.DUMMY_TP
Dummy transport, returns a fake local address and responds to CONNECT with CONNECT_OK.
DUMMY_TP() - constructor for class org.jgroups.protocols.DUMMY_TP
DUMP - static field in class org.jgroups.stack.GossipRouter
DUMP - static field in class org.jgroups.stack.Router
dump() - method in class org.jgroups.util.List
dump() - static method in class org.jgroups.debug.Profiler
dumpGossipTable() - method in class org.jgroups.stack.GossipRouter
dumpHistory() - method in class org.jgroups.jmx.protocols.pbcast.GMS
dumpHistory() - method in class org.jgroups.jmx.protocols.pbcast.GMSMBean
dumpQueue() - method in class org.jgroups.Channel
dumpQueue() - method in class org.jgroups.JChannel
dumpQueue() - method in class org.jgroups.jmx.JChannel
dumpQueue() - method in class org.jgroups.jmx.JChannelMBean
dumpQueue(org.jgroups.util.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() - method in class org.jgroups.stack.GossipRouter
dumpStack(boolean) - static method in class org.jgroups.util.Util
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.protocols.DISCARD
dumpStats() - method in class org.jgroups.protocols.FC
dumpStats() - method in class org.jgroups.JChannel
Returns a map of statistics of the various protocols and of the channel itself.
dumpStats() - method in class org.jgroups.jmx.JChannel
dumpStats() - method in class org.jgroups.jmx.JChannelMBean
dumpStats() - method in class org.jgroups.protocols.pbcast.NAKACK
dumpStats() - method in class org.jgroups.jmx.Protocol
dumpStats() - method in class org.jgroups.stack.Protocol
dumpStats() - method in class org.jgroups.jmx.ProtocolMBean
dumpStats() - method in class org.jgroups.stack.ProtocolStack
dumpStats() - method in class org.jgroups.debug.Simulator
dumpStats() - method in class org.jgroups.protocols.TP
dumpStats() - method in class org.jgroups.protocols.UNICAST
dumpTaskQueue() - method in class org.jgroups.util.TimeScheduler
dumpTimerQueue() - method in class org.jgroups.JChannel
dumpTimerQueue() - method in class org.jgroups.jmx.JChannel
dumpTimerQueue() - method in class org.jgroups.jmx.JChannelMBean
dumpTimerQueue() - method in class org.jgroups.stack.ProtocolStack
dumpViewHandlerHistory() - method in class org.jgroups.protocols.pbcast.GMS
dumpViewHandlerQueue() - method in class org.jgroups.jmx.protocols.pbcast.GMS
dumpViewHandlerQueue() - method in class org.jgroups.protocols.pbcast.GMS
dumpViewHandlerQueue() - method in class org.jgroups.jmx.protocols.pbcast.GMSMBean
dx - field in class org.jgroups.demos.wb.Node
dy - field in class org.jgroups.demos.wb.Node

E

elementAt(int) - method in class org.jgroups.Membership
Returns the component at the specified index
elementAt(int) - method in class org.jgroups.util.RspList
elements() - method in class org.jgroups.util.List
ELMT_CLASS - static field in class org.jgroups.conf.XmlConfigurator
ELMT_DESCRIPTION - static field in class org.jgroups.conf.XmlConfigurator
ELMT_PROT - static field in class org.jgroups.conf.XmlConfigurator
ELMT_PROT_NAME - static field in class org.jgroups.conf.XmlConfigurator
ELMT_PROT_OVERRIDE - static field in class org.jgroups.conf.XmlConfigurator
ELMT_PROT_PARAMS - static field in class org.jgroups.conf.XmlConfigurator
empty() - method in class org.jgroups.util.Stack
ENABLE_UNICASTS_TO - static field in class org.jgroups.Event
enableStats(boolean) - method in class org.jgroups.JChannel
enableStats(boolean) - method in class org.jgroups.stack.Protocol
ENCRYPT - static field in class org.jgroups.protocols.ENCRYPT.EncryptHeader
ENCRYPT - class org.jgroups.protocols.ENCRYPT
ENCRYPT layer.
ENCRYPT() - constructor for class org.jgroups.protocols.ENCRYPT
ENCRYPT1_4 - class org.jgroups.protocols.ENCRYPT1_4
ENCRYPT1_4 layer.
ENCRYPT1_4() - constructor for class org.jgroups.protocols.ENCRYPT1_4
ENCRYPT.EncryptHeader - class org.jgroups.protocols.ENCRYPT.EncryptHeader
EncryptHeader() - constructor for class org.jgroups.protocols.ENCRYPT.EncryptHeader
EncryptHeader() - constructor for class org.jgroups.protocols.ENCRYPT1_4.EncryptHeader
EncryptHeader(int) - constructor for class org.jgroups.protocols.ENCRYPT1_4.EncryptHeader
EncryptHeader(short) - constructor for class org.jgroups.protocols.ENCRYPT.EncryptHeader
EncryptHeader(short,String) - constructor for class org.jgroups.protocols.ENCRYPT.EncryptHeader
Digest.Entry - class org.jgroups.protocols.pbcast.Digest.Entry
Class keeping track of the lowest and highest sequence numbers delivered, and the highest sequence numbers received, per member
Profiler.Entry - class org.jgroups.debug.Profiler.Entry
Entry(long,long) - constructor for class org.jgroups.protocols.pbcast.Digest.Entry
Entry(long,long,long) - constructor for class org.jgroups.protocols.pbcast.Digest.Entry
Entry(org.jgroups.protocols.pbcast.Digest.Entry) - constructor for class org.jgroups.protocols.pbcast.Digest.Entry
entryAdd(Object) - method in class org.jgroups.blocks.DistributedQueue.Notification
entryAdd(Object) - method in class org.jgroups.demos.DistributedQueueDemo
entryRemoved(Object) - method in class org.jgroups.blocks.DistributedHashtable.Notification
entryRemoved(Object) - method in class org.jgroups.demos.DistributedHashtableDemo
entryRemoved(Object) - method in class org.jgroups.blocks.DistributedQueue.Notification
entryRemoved(Object) - method in class org.jgroups.demos.DistributedQueueDemo
entryRemoved(Object) - method in class org.jgroups.blocks.ReplicatedHashtable.Notification
entrySet(Object,Object) - method in class org.jgroups.blocks.DistributedHashtable.Notification
entrySet(Object,Object) - method in class org.jgroups.demos.DistributedHashtableDemo
entrySet(Object,Object) - method in class org.jgroups.blocks.ReplicatedHashtable.Notification
equals(Object) - method in class org.jgroups.conf.ClassMap
equals(Object) - method in class org.jgroups.protocols.pbcast.Digest
equals(Object) - method in class org.jgroups.protocols.pbcast.Digest.Entry
equals(Object) - method in class org.jgroups.blocks.DistributedLockManager.LockDecree
equals(Object) - method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
equals(Object) - method in class org.jgroups.protocols.pbcast.Gossip
equals(Object) - method in class org.jgroups.stack.IpAddress
equals(Object) - method in class org.jgroups.protocols.JMS.JMSAddress
Test is this object is equal to obj.
equals(Object) - method in class org.jgroups.blocks.Link
equals(Object) - method in class org.jgroups.stack.LogicalAddress
equals(Object) - method in class org.jgroups.protocols.pbcast.MergeData
equals(Object) - method in class org.jgroups.protocols.PingRsp
equals(Object) - method in class org.jgroups.conf.ProtocolData
equals(Object) - method in class org.jgroups.conf.ProtocolParameter
equals(Object) - method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
equals(Object) - method in class org.jgroups.protocols.TransportedVectorTime
Checks if this TransportedVectorTimeis equal to the specified TransportedVectorTime.
equals(Object) - method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseVoteWrapper
equals(Object) - method in class org.jgroups.View
equals(Object) - method in class org.jgroups.ViewId
equals(Object) - method in class org.jgroups.protocols.WanPipeAddress
equals(Object) - method in class org.jgroups.blocks.Xid
established() - method in class org.jgroups.blocks.Link
Event - class org.jgroups.Event
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
EXAMPLE - class org.jgroups.protocols.EXAMPLE
Example of a protocol layer.
execute() - method in class org.jgroups.util.Command
execute() - method in class org.jgroups.blocks.GroupRequest
Sends the message.
exists(String) - method in class org.jgroups.blocks.DistributedTree
exists(String) - method in class org.jgroups.blocks.ReplicatedTree
Checks whether a given node exists in the tree
EXIT - static field in class org.jgroups.Event
ExitEvent - class org.jgroups.ExitEvent
Trivial object that represents an exit event.
expected_mbrs - field in class org.jgroups.blocks.GroupRequest
EXPIRY_TIME - static field in class org.jgroups.stack.GossipRouter
Creates a BufferedInputStream and saves its argument, the input stream in, for later use.
Creates a BufferedInputStream with the specified buffer size, and saves its argument, the input stream in, for later use.
Creates a new buffered output stream to write data to the specified underlying output stream.
Creates a new buffered output stream to write data to the specified underlying output stream with the specified buffer size.
ExposedByteArrayInputStream(byte[]) - constructor for class org.jgroups.util.ExposedByteArrayInputStream
Creates a ByteArrayInputStream so that it uses buf as its buffer array.
Creates ByteArrayInputStream that uses buf as its buffer array.
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(OutputStream) - constructor for class org.jgroups.util.ExposedDataOutputStream
Creates a new data output stream to write data to the specified underlying output stream.

F

failed_mbrs - field in class org.jgroups.protocols.FlushRsp
failedNode - field in class org.jgroups.protocols.ring.TokenLostException
Class that represents a result of local voting on the failed node.
FailureVoteResult(String) - constructor for class org.jgroups.blocks.VotingAdapter.FailureVoteResult
FC - class org.jgroups.jmx.protocols.FC
FC - class org.jgroups.protocols.FC
Simple flow control protocol based on a credit system.
FC() - constructor for class org.jgroups.jmx.protocols.FC
FC(org.jgroups.stack.Protocol) - constructor for class org.jgroups.jmx.protocols.FC
FC.FcHeader - class org.jgroups.protocols.FC.FcHeader
FcHeader() - constructor for class org.jgroups.protocols.FC.FcHeader
FcHeader(byte) - constructor for class org.jgroups.protocols.FC.FcHeader
FCMBean - interface org.jgroups.jmx.protocols.FCMBean
FD - class org.jgroups.jmx.protocols.FD
FD - class org.jgroups.protocols.FD
Failure detection based on simple heartbeat protocol.
FD - class org.jgroups.protocols.pbcast.FD
Passive failure detection protocol.
FD() - constructor for class org.jgroups.jmx.protocols.FD
FD(org.jgroups.stack.Protocol) - constructor for class org.jgroups.jmx.protocols.FD
FD_PID - class org.jgroups.protocols.FD_PID
Process-ID based FD protocol.
FD_PROB - class org.jgroups.protocols.FD_PROB
Probabilistic failure detection protocol based on "A Gossip-Style Failure Detection Service" by Renesse, Minsky and Hayden.
FD_SIMPLE - class org.jgroups.protocols.FD_SIMPLE
Simple failure detection protocol.
FD_SOCK - class org.jgroups.jmx.protocols.FD_SOCK
FD_SOCK - class org.jgroups.protocols.FD_SOCK
Failure detection protocol based on sockets.
FD_SOCK() - constructor for class org.jgroups.jmx.protocols.FD_SOCK
FD_SOCK(org.jgroups.stack.Protocol) - constructor for class org.jgroups.jmx.protocols.FD_SOCK
FD_SOCKMBean - interface org.jgroups.jmx.protocols.FD_SOCKMBean
FD.FdHeader - class org.jgroups.protocols.FD.FdHeader
FD_PID.FdHeader - class org.jgroups.protocols.FD_PID.FdHeader
FD_PROB.FdHeader - class org.jgroups.protocols.FD_PROB.FdHeader
FD_SIMPLE.FdHeader - class org.jgroups.protocols.FD_SIMPLE.FdHeader
FD_SOCK.FdHeader - class org.jgroups.protocols.FD_SOCK.FdHeader
FdHeader() - constructor for class org.jgroups.protocols.FD.FdHeader
FdHeader() - constructor for class org.jgroups.protocols.FD_PID.FdHeader
FdHeader() - constructor for class org.jgroups.protocols.FD_PROB.FdHeader
FdHeader() - constructor for class org.jgroups.protocols.FD_SIMPLE.FdHeader
FdHeader() - constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
FdHeader(byte) - constructor for class org.jgroups.protocols.FD.FdHeader
FdHeader(byte) - constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
FdHeader(byte,Hashtable) - constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
FdHeader(byte,org.jgroups.Address) - constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
FdHeader(byte,Vector) - constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
FdHeader(byte,Vector,org.jgroups.Address) - constructor for class org.jgroups.protocols.FD.FdHeader
FDMBean - interface org.jgroups.jmx.protocols.FDMBean
fetchState(long) - method in class org.jgroups.blocks.ReplicatedTree
Fetch the group state from the current coordinator.
fileExists(String) - static method in class org.jgroups.util.Util
FilePersistenceManager - class org.jgroups.persistence.FilePersistenceManager
FilePersistenceManager(String) - constructor for class org.jgroups.persistence.FilePersistenceManager
Default constructor
filterLoadedValues(Map) - method in class org.jgroups.persistence.FilePersistenceManager
Turns the values into Floats to enable DistributedHashtableDemo to work.
FIND_INITIAL_MBRS - static field in class org.jgroups.Event
FIND_INITIAL_MBRS_EVT - static field in class org.jgroups.Event
FIND_INITIAL_MBRS_OK - static field in class org.jgroups.Event
findComponent(Container,String) - method in class org.jgroups.demos.DrawRepl
findInitialMembers() - method in class org.jgroups.jmx.protocols.Discovery
findInitialMembers() - method in class org.jgroups.protocols.Discovery
Finds the initial membership
findInitialMembers() - method in class org.jgroups.jmx.protocols.DiscoveryMBean
findInitialMembers() - method in class org.jgroups.protocols.PingWaiter
findInitialMembersAsString() - method in class org.jgroups.jmx.protocols.Discovery
findInitialMembersAsString() - method in class org.jgroups.protocols.Discovery
findInitialMembersAsString() - method in class org.jgroups.jmx.protocols.DiscoveryMBean
findMethod(short) - method in class org.jgroups.blocks.MethodLookup
findProtocol(org.jgroups.stack.Protocol) - static method in class org.jgroups.jmx.JmxConfigurator
findProtocol(String) - method in class org.jgroups.stack.ProtocolStack
Returns a given protocol or null if not found
first() - method in class org.jgroups.stack.Interval
fixed - field in class org.jgroups.demos.wb.Node
FLOW_CONTROL - class org.jgroups.protocols.FLOW_CONTROL
FLOW_CONTROL provides end-end congestion control and flow control.
FLOW_CONTROL() - constructor for class org.jgroups.protocols.FLOW_CONTROL
FLOWCONTROL - class org.jgroups.protocols.FLOWCONTROL
Title: Flow control layer Description: This layer limits the number of sent messages without a receive of an own message to MAXSENTMSGS, just put this layer above GMS and you will get a more Copyright: Copyright (c) 2000 Company: Computer Network Laboratory
FLOWCONTROL() - constructor for class org.jgroups.protocols.FLOWCONTROL
FLUSH - static field in class org.jgroups.Event
FLUSH - class org.jgroups.protocols.FLUSH
The task of the FLUSH protocol is to flush all pending messages out of the system.
flush(Vector,Vector) - method in class org.jgroups.protocols.GMS
FLUSH protocol.
FLUSH_OK - static field in class org.jgroups.Event
flushEvents() - method in class org.jgroups.stack.ProtocolStack
Not needed anymore, just left in here for backwards compatibility with JBoss AS
FlushRsp - class org.jgroups.protocols.FlushRsp
FlushRsp() - constructor for class org.jgroups.protocols.FlushRsp
FlushRsp(boolean,Vector,Vector) - constructor for class org.jgroups.protocols.FlushRsp
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.protocols.RpcProtocolEXAMPLE
FRAG - class org.jgroups.jmx.protocols.FRAG
FRAG - class org.jgroups.protocols.FRAG
Fragmentation layer.
FRAG() - constructor for class org.jgroups.jmx.protocols.FRAG
FRAG(org.jgroups.stack.Protocol) - constructor for class org.jgroups.jmx.protocols.FRAG
FRAG2 - class org.jgroups.jmx.protocols.FRAG2
FRAG2 - class org.jgroups.protocols.FRAG2
Fragmentation layer.
FRAG2() - constructor for class org.jgroups.jmx.protocols.FRAG2
FRAG2(org.jgroups.stack.Protocol) - constructor for class org.jgroups.jmx.protocols.FRAG2
FRAG2MBean - interface org.jgroups.jmx.protocols.FRAG2MBean
frag_id - field in class org.jgroups.protocols.FragHeader
FragHeader - class org.jgroups.protocols.FragHeader
FragHeader() - constructor for class org.jgroups.protocols.FragHeader
FragHeader(long,int,int) - constructor for class org.jgroups.protocols.FragHeader
FRAGMBean - interface org.jgroups.jmx.protocols.FRAGMBean
fragmentBuffer(byte[],int) - static method in class org.jgroups.util.Util
fragmentBuffer(byte[],int,int) - static method in class org.jgroups.util.Util
Fragments a byte buffer into smaller fragments of (max.) frag_size.

G

generateLocalAddress() - method in class org.jgroups.protocols.JMS
Generate random local address.
GET - static field in class org.jgroups.stack.GossipRouter
GET - static field in class org.jgroups.stack.Router
get() - method in class org.jgroups.util.CondVar
get(int) - method in class org.jgroups.conf.ClassConfigurator
Returns a class for a magic number.
get(long) - method in class org.jgroups.stack.NakReceiverWindow
Returns the message from received_msgs or delivered_msgs.
get(Object) - method in class org.jgroups.blocks.MethodCall
get(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.Digest
get(org.jgroups.Address) - method in class org.jgroups.util.RspList
get(String) - method in class org.jgroups.conf.ClassConfigurator
Loads and returns the class from the class name
get(String) - method in class org.jgroups.blocks.DistributedTree
get(String) - method in class org.jgroups.stack.RouterStub
Retrieves the membership (list of Addresses) for a given group.
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_ABS_MAJORITY - static field in class org.jgroups.blocks.GroupRequest
return majority (of all members, may block)
GET_ALL - static field in class org.jgroups.blocks.GroupRequest
return all responses
GET_APPLSTATE - static field in class org.jgroups.Event
GET_APPLSTATE_OK - static field in class org.jgroups.Event
GET_CACHE - static field in class org.jgroups.protocols.FD_SOCK.FdHeader
GET_CACHE_RSP - static field in class org.jgroups.protocols.FD_SOCK.FdHeader
GET_DIGEST - static field in class org.jgroups.Event
GET_DIGEST_EVT - static field in class org.jgroups.Event
GET_DIGEST_OK - static field in class org.jgroups.Event
GET_DIGEST_STABLE - static field in class org.jgroups.Event
GET_DIGEST_STABLE_OK - static field in class org.jgroups.Event
GET_DIGEST_STATE - static field in class org.jgroups.Event
GET_DIGEST_STATE_OK - static field in class org.jgroups.Event
GET_FIRST - static field in class org.jgroups.blocks.GroupRequest
return only first response
GET_FROM_MANY - static field in class org.jgroups.stack.StateTransferInfo
GET_FROM_SINGLE - static field in class org.jgroups.stack.StateTransferInfo
GET_LOCAL_ADDRESS - static field in class org.jgroups.Event
GET_MAJORITY - static field in class org.jgroups.blocks.GroupRequest
return majority (of all non-faulty members)
GET_MBRS_REQ - static field in class org.jgroups.protocols.PingHeader
GET_MBRS_RSP - static field in class org.jgroups.protocols.PingHeader
GET_MSG_DIGEST - static field in class org.jgroups.Event
GET_MSG_DIGEST_OK - static field in class org.jgroups.Event
GET_MSGS - static field in class org.jgroups.Event
GET_MSGS_OK - static field in class org.jgroups.Event
GET_MSGS_RECEIVED - static field in class org.jgroups.Event
GET_MSGS_RECEIVED_OK - static field in class org.jgroups.Event
GET_N - static field in class org.jgroups.blocks.GroupRequest
return n responses (may block)
GET_NONE - static field in class org.jgroups.blocks.GroupRequest
return no response (async call)
GET_REQ - static field in class org.jgroups.stack.GossipData
GET_RSP - static field in class org.jgroups.stack.GossipData
GET_STATE - static field in class org.jgroups.Event
GET_STATE_EVENTS - static field in class org.jgroups.Channel
GET_STATE_OK - static field in class org.jgroups.Event
getAcksReceived() - method in class org.jgroups.jmx.protocols.UNICAST
getAcksReceived() - method in class org.jgroups.jmx.protocols.UNICASTMBean
getAcksSent() - method in class org.jgroups.jmx.protocols.UNICAST
getAcksSent() - method in class org.jgroups.jmx.protocols.UNICASTMBean
getAdditionalData() - method in class org.jgroups.stack.IpAddress
Returns the additional_data.
getAdditionalData() - method in class org.jgroups.stack.LogicalAddress
Returns the additional_data.
getAddress() - method in class org.jgroups.protocols.JMS.JMSAddress
Get the node address.
getAddress() - method in class org.jgroups.protocols.PingRsp
getAllAvailableInterfaces() - static method in class org.jgroups.util.Util
getAllReceivedUpto() - method in class org.jgroups.protocols.ring.RingToken
getAllReceivedUpTo() - method in class org.jgroups.protocols.TOTAL_TOKEN
getAllStates(Vector,long) - method in class org.jgroups.Channel
Retrieve all states of the group members.
getAllStates(Vector,long) - method in class org.jgroups.JChannel
Retrieves the current group state.
getAllStocks() - method in class org.jgroups.demos.QuoteServer
getArg() - method in class org.jgroups.Event
getArg() - method in class org.jgroups.SetStateEvent
getArgs() - method in class org.jgroups.blocks.MethodCall
returns an ordered list of arguments used for the method invokation
getAruId() - method in class org.jgroups.protocols.ring.RingToken
getAssociatedMessage() - method in class org.jgroups.protocols.TransportedVectorTime
Returns a message associated with this vector timestamp.
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
getAutoGetState() - method in class org.jgroups.jmx.JChannel
getAutoGetState() - method in class org.jgroups.jmx.JChannelMBean
getAutoReconnect() - method in class org.jgroups.jmx.JChannel
getAutoReconnect() - method in class org.jgroups.jmx.JChannelMBean
getAverageSendInterval() - method in class org.jgroups.jmx.protocols.VIEW_SYNC
getAverageSendInterval() - method in class org.jgroups.protocols.VIEW_SYNC
getAverageSendInterval() - method in class org.jgroups.jmx.protocols.VIEW_SYNCMBean
getAverageStateSize() - method in class org.jgroups.jmx.protocols.pbcast.STATE_TRANSFER
getAverageStateSize() - method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
getAverageStateSize() - method in class org.jgroups.jmx.protocols.pbcast.STATE_TRANSFERMBean
getAverageTimeBlocked() - method in class org.jgroups.jmx.protocols.FC
getAverageTimeBlocked() - method in class org.jgroups.protocols.FC
getAverageTimeBlocked() - method in class org.jgroups.jmx.protocols.FCMBean
getBacklog() - method in class org.jgroups.protocols.ring.RingNodeFlowControl
getBacklog() - method in class org.jgroups.protocols.ring.RingToken
getBacklogDifference() - method in class org.jgroups.protocols.ring.RingNodeFlowControl
getBindAddr() - method in class org.jgroups.jmx.protocols.MPING
getBindAddr() - method in class org.jgroups.protocols.MPING
getBindAddr() - method in class org.jgroups.jmx.protocols.MPINGMBean
getBindAddr() - method in class org.jgroups.jmx.protocols.TCP
getBindAddr() - method in class org.jgroups.protocols.TCP
getBindAddr() - method in class org.jgroups.jmx.protocols.TCPMBean
getBindAddress() - method in class org.jgroups.stack.GossipRouter
getBindAddress() - method in class org.jgroups.jmx.protocols.TP
getBindAddress() - method in class org.jgroups.protocols.TP
getBindAddress() - method in class org.jgroups.jmx.protocols.TPMBean
getBindInterface() - method in class org.jgroups.protocols.UDP_NIO.Connector
getBindToAllInterfaces() - method in class org.jgroups.protocols.TP
getBlockings() - method in class org.jgroups.jmx.protocols.FC
getBlockings() - method in class org.jgroups.jmx.protocols.FCMBean
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.
getBytesReceived() - method in class org.jgroups.jmx.protocols.TP
getBytesReceived() - method in class org.jgroups.jmx.protocols.TPMBean
getBytesReceived() - method in class org.jgroups.jmx.protocols.UNICAST
getBytesReceived() - method in class org.jgroups.jmx.protocols.UNICASTMBean
getBytesSent() - method in class org.jgroups.jmx.protocols.TP
getBytesSent() - method in class org.jgroups.jmx.protocols.TPMBean
getBytesSent() - method in class org.jgroups.jmx.protocols.UNICAST
getBytesSent() - method in class org.jgroups.jmx.protocols.UNICASTMBean
getCache() - method in class org.jgroups.blocks.NotificationBus
getCache() - method in class org.jgroups.blocks.NotificationBus.Consumer
Called on the coordinator to obtains its cache
getCache() - method in class org.jgroups.demos.NotificationBusDemo
Called on the coordinator to obtains its cache
getCacheFromCoordinator(long,int) - method in class org.jgroups.blocks.NotificationBus
Determines the coordinator and asks it for its cache.
Determines the coordinator and asks it for its cache.
getCaller() - method in class org.jgroups.blocks.GroupRequest
getCapacity() - method in class org.jgroups.util.ExposedByteArrayOutputStream
getChannel() - method in class org.jgroups.blocks.DistributedHashtable
getChannel() - method in class org.jgroups.blocks.DistributedQueue
getChannel() - method in class org.jgroups.blocks.DistributedTree
Returns the Channel the DistributedTree is connected to
getChannel() - method in class org.jgroups.jmx.JChannel
getChannel() - method in class org.jgroups.jmx.JChannelMBean
getChannel() - method in class org.jgroups.blocks.MessageDispatcher
Offers access to the underlying Channel.
getChannel() - method in class org.jgroups.blocks.NotificationBus
Answers the Channel.
getChannel() - method in class org.jgroups.stack.ProtocolStack
getChannel() - method in class org.jgroups.blocks.ReplicatedHashtable
getChannel() - method in class org.jgroups.blocks.ReplicatedTree
Returns the Channel the DistributedTree is connected to
getChannel() - method in class org.jgroups.demos.TotalTokenDemo
getChannelName() - method in class org.jgroups.Channel
Returns the group address of the group of which the channel is a member.
getChannelName() - method in class org.jgroups.JChannel
returns the name of the channel if the channel is not connected or if it is closed it will return null
getChannelName() - method in class org.jgroups.jmx.protocols.TP
getChannelName() - method in class org.jgroups.protocols.TP
getChannelName() - method in class org.jgroups.jmx.protocols.TPMBean
getChildrenNames(String) - method in class org.jgroups.blocks.DistributedTree
Returns all children of a Node as strings
getChildrenNames(String) - method in class org.jgroups.blocks.ReplicatedTree
Returns all children of a given node
getClassForMap() - method in class org.jgroups.conf.ClassMap
Returns the Class object for this class
getClassName() - method in class org.jgroups.conf.ClassMap
getClassName() - method in class org.jgroups.conf.ProtocolData
getClusterName() - method in class org.jgroups.jmx.JChannel
getClusterName() - method in class org.jgroups.jmx.JChannelMBean
getCombinedResults() - method in class org.jgroups.protocols.DEADLOCK
Mcasts getResult() to all members (including itself).
getConcurrentProcessing() - method in class org.jgroups.util.Scheduler
getConnectorAddresses() - method in class org.jgroups.protocols.UDP_NIO.ConnectorTable
Returns a list of local addresses (one for each Connector)
getConnExpireTime() - method in class org.jgroups.jmx.protocols.TCP
getConnExpireTime() - method in class org.jgroups.protocols.TCP
getConnExpireTime() - method in class org.jgroups.jmx.protocols.TCPMBean
getConsensusStr(int) - static method in class org.jgroups.blocks.VotingAdapter
Convert consensus type into string representation.
getContents() - method in class org.jgroups.blocks.DistributedQueue
getContents() - method in class org.jgroups.util.LinkedListQueue
returns a vector with all the objects currently in the queue
getContents() - method in class org.jgroups.util.List
getContents() - method in class org.jgroups.util.Queue2
returns a vector with all the objects currently in the queue
getCoordAddress() - method in class org.jgroups.protocols.PingRsp
getCoordAddress() - method in class org.jgroups.ViewId
returns the address of the member that issued this view
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.blocks.Xid
getCreditRequestsReceived() - method in class org.jgroups.jmx.protocols.FC
getCreditRequestsReceived() - method in class org.jgroups.jmx.protocols.FCMBean
getCreditRequestsSent() - method in class org.jgroups.jmx.protocols.FC
getCreditRequestsSent() - method in class org.jgroups.jmx.protocols.FCMBean
getCreditResponsesReceived() - method in class org.jgroups.jmx.protocols.FC
getCreditResponsesReceived() - method in class org.jgroups.jmx.protocols.FCMBean
getCreditResponsesSent() - method in class org.jgroups.jmx.protocols.FC
getCreditResponsesSent() - method in class org.jgroups.jmx.protocols.FCMBean
getCurrentNumTries() - method in class org.jgroups.jmx.protocols.FD
getCurrentNumTries() - method in class org.jgroups.protocols.FD
getCurrentNumTries() - method in class org.jgroups.jmx.protocols.FDMBean
getData() - method in class org.jgroups.blocks.ReplicationData
getDecree() - method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
getDescription() - method in class org.jgroups.conf.ClassMap
getDescription() - method in class org.jgroups.conf.ProtocolData
getDesiredAverageGossip() - method in class org.jgroups.jmx.protocols.pbcast.STABLE
getDesiredAverageGossip() - method in class org.jgroups.protocols.pbcast.STABLE
getDesiredAverageGossip() - method in class org.jgroups.jmx.protocols.pbcast.STABLEMBean
getDesKey() - method in class org.jgroups.protocols.ENCRYPT
getDest() - method in class org.jgroups.Message
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.MergeData
getDigest() - method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
getDiscoveryRequestsSent() - method in class org.jgroups.jmx.protocols.Discovery
getDiscoveryRequestsSent() - method in class org.jgroups.jmx.protocols.DiscoveryMBean
getDownProtocol() - method in class org.jgroups.stack.Protocol
getDownQueue() - method in class org.jgroups.stack.Protocol
getDownThread() - method in class org.jgroups.jmx.Protocol
getDownThread() - method in class org.jgroups.jmx.ProtocolMBean
getDownVector() - method in class org.jgroups.protocols.QUEUE
getEndPort() - method in class org.jgroups.jmx.protocols.TCP
getEndPort() - method in class org.jgroups.protocols.TCP
getEndPort() - method in class org.jgroups.jmx.protocols.TCPMBean
getExpiryTime() - method in class org.jgroups.stack.GossipRouter
getFailedNode() - method in class org.jgroups.protocols.ring.TokenLostException
getFailureMode() - method in class org.jgroups.protocols.ring.TokenLostException
getFirst() - method in class org.jgroups.util.Queue
Returns the first element.
getFirst() - method in class org.jgroups.util.Queue2
Returns the first element.
getFirst() - method in class org.jgroups.util.RspList
getFirstNonLoopbackAddress() - static method in class org.jgroups.util.Util
getFirstQueuedSeqID() - method in class org.jgroups.protocols.TOTAL_OLD
Returns the sequence id of the "first" queued message (i.e., the lowest seq id queued).
getFragSize() - method in class org.jgroups.jmx.protocols.FRAG
getFragSize() - method in class org.jgroups.protocols.FRAG
getFragSize() - method in class org.jgroups.jmx.protocols.FRAG2
getFragSize() - method in class org.jgroups.protocols.FRAG2
getFragSize() - method in class org.jgroups.jmx.protocols.FRAG2MBean
getFragSize() - method in class org.jgroups.jmx.protocols.FRAGMBean
getGcLag() - method in class org.jgroups.jmx.protocols.pbcast.NAKACK
getGcLag() - method in class org.jgroups.protocols.pbcast.NAKACK
getGcLag() - method in class org.jgroups.jmx.protocols.pbcast.NAKACKMBean
getGossipMessages() - method in class org.jgroups.jmx.protocols.pbcast.STABLE
getGossipMessages() - method in class org.jgroups.jmx.protocols.pbcast.STABLEMBean
getGossipRequestTimeout() - method in class org.jgroups.stack.GossipRouter
getGroup() - method in class org.jgroups.stack.GossipData
getGroupMembersNumber() - method in class org.jgroups.blocks.DistributedTree
Returns the number of current members joined to the group
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.DistributedHashtable
getGroupName() - method in class org.jgroups.blocks.DistributedTree
Returns the name of the group that the DistributedTree is connected to
getGroupName() - method in class org.jgroups.demos.Draw
getGroupName() - method in class org.jgroups.jmx.JChannel
getGroupName() - method in class org.jgroups.jmx.JChannelMBean
getGroupName() - method in class org.jgroups.blocks.ReplicatedTree
Returns the name of the group that the DistributedTree is connected to
getHeader(String) - method in class org.jgroups.Message
getHeaders() - method in class org.jgroups.Message
getHighestDelivered() - method in class org.jgroups.stack.NakReceiverWindow
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.
getHighestSeen() - method in class org.jgroups.stack.NakReceiverWindow
Returns the highest deliverable seqno; e.g., for 1,2,3,5,6 it would be 3.
getHighestSequence() - method in class org.jgroups.protocols.ring.RingToken
getHost() - method in class org.jgroups.stack.LogicalAddress
getHostname() - static method in class org.jgroups.util.Util
getId() - method in class org.jgroups.stack.LogicalAddress
getId() - method in class org.jgroups.blocks.MethodCall
getId() - method in class org.jgroups.ViewId
returns the lamport time of the view
getId() - method in class org.jgroups.blocks.Xid
getIdentifier() - method in class org.jgroups.blocks.PullPushAdapter.PullHeader
getImpl() - method in class org.jgroups.protocols.pbcast.GMS
getIncomingQueueSize() - method in class org.jgroups.jmx.protocols.TP
getIncomingQueueSize() - method in class org.jgroups.protocols.TP
getIncomingQueueSize() - method in class org.jgroups.jmx.protocols.TPMBean
getInfo() - method in class org.jgroups.protocols.TCP
getInfo() - method in class org.jgroups.protocols.TP
getInfo() - method in class org.jgroups.protocols.UDP
getInitialMembers() - method in class org.jgroups.jmx.protocols.Discovery
getInitialMembers() - method in class org.jgroups.jmx.protocols.DiscoveryMBean
getInputStream(String) - method in class org.jgroups.conf.ClassPathEntityResolver
getInputStream(String) - static method in class org.jgroups.conf.XmlValidator
getInstance() - static method in class org.jgroups.protocols.PERF_TP
getInstance() - static method in class org.jgroups.persistence.PersistenceFactory
Singular public method to get access to any of the Persistence Manager implementations.
getInstance(boolean) - static method in class org.jgroups.conf.ClassConfigurator
getInstance(Element) - static method in class org.jgroups.conf.XmlConfigurator
getInstance(InputStream) - static method in class org.jgroups.conf.XmlConfigurator
getInstance(URL) - static method in class org.jgroups.conf.XmlConfigurator
getInstanceOldFormat(InputStream) - static method in class org.jgroups.conf.XmlConfigurator
getInstanceOldFormat(URL) - static method in class org.jgroups.conf.XmlConfigurator
getInterval() - method in class org.jgroups.stack.Interval
getIpAddress() - method in class org.jgroups.stack.IpAddress
getJavaVersion() - static method in class org.jgroups.util.Util
getJoinRetryTimeout() - method in class org.jgroups.jmx.protocols.pbcast.GMS
getJoinRetryTimeout() - method in class org.jgroups.protocols.pbcast.GMS
getJoinRetryTimeout() - method in class org.jgroups.jmx.protocols.pbcast.GMSMBean
getJoinTimeout() - method in class org.jgroups.jmx.protocols.pbcast.GMS
getJoinTimeout() - method in class org.jgroups.protocols.pbcast.GMS
getJoinTimeout() - method in class org.jgroups.jmx.protocols.pbcast.GMSMBean
getKey() - method in class org.jgroups.blocks.DistributedLockManager.LockDecree
Returns the key that should be used for Map lookup.
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
getLast() - method in class org.jgroups.util.Queue
Returns the last element.
getLast() - method in class org.jgroups.util.Queue2
Returns the last element.
getLastRoundBroadcastCount() - method in class org.jgroups.protocols.ring.RingToken
getLength() - method in class org.jgroups.util.Buffer
getLength() - method in class org.jgroups.Message
Returns the number of bytes in the buffer
getLinks() - method in class org.jgroups.blocks.LogicalLink
getListener() - method in class org.jgroups.blocks.PullPushAdapter
getLocal_addr() - method in class org.jgroups.protocols.ENCRYPT
getLocalAddr() - method in class org.jgroups.protocols.TOTAL_OLD
returns the Address of the local machine returns null if it is not known yet
getLocalAddress() - method in class org.jgroups.Channel
Returns the channel's own address.
getLocalAddress() - method in class org.jgroups.blocks.ConnectionTable
getLocalAddress() - method in class org.jgroups.blocks.DistributedHashtable
getLocalAddress() - method in class org.jgroups.blocks.DistributedQueue
getLocalAddress() - method in class org.jgroups.blocks.DistributedTree
getLocalAddress() - method in class org.jgroups.jmx.protocols.FD
getLocalAddress() - method in class org.jgroups.protocols.FD
getLocalAddress() - method in class org.jgroups.jmx.protocols.FD_SOCK
getLocalAddress() - method in class org.jgroups.protocols.FD_SOCK
getLocalAddress() - method in class org.jgroups.jmx.protocols.FD_SOCKMBean
getLocalAddress() - method in class org.jgroups.jmx.protocols.FDMBean
getLocalAddress() - method in class org.jgroups.jmx.protocols.pbcast.GMS
getLocalAddress() - method in class org.jgroups.protocols.pbcast.GMS
getLocalAddress() - method in class org.jgroups.jmx.protocols.pbcast.GMSMBean
getLocalAddress() - method in class org.jgroups.JChannel
returns the local address of the channel returns null if the channel is closed
getLocalAddress() - method in class org.jgroups.jmx.JChannel
getLocalAddress() - method in class org.jgroups.jmx.JChannelMBean
getLocalAddress() - method in class org.jgroups.blocks.Link
getLocalAddress() - method in class org.jgroups.blocks.NotificationBus
getLocalAddress() - method in class org.jgroups.blocks.ReplicatedHashtable
getLocalAddress() - method in class org.jgroups.blocks.ReplicatedTree
getLocalAddress() - method in class org.jgroups.blocks.RequestCorrelator
getLocalAddress() - method in class org.jgroups.jmx.protocols.TP
getLocalAddress() - method in class org.jgroups.protocols.TP
getLocalAddress() - method in class org.jgroups.jmx.protocols.TPMBean
getLocalAddress() - method in class org.jgroups.protocols.UDP_NIO.Connector
getLocalAddress() - method in class org.jgroups.jmx.protocols.UNICAST
getLocalAddress() - method in class org.jgroups.protocols.UNICAST
getLocalAddress() - method in class org.jgroups.jmx.protocols.UNICASTMBean
getLocalAddressAsString() - method in class org.jgroups.jmx.JChannel
getLocalAddressAsString() - method in class org.jgroups.jmx.JChannelMBean
getLocalPort() - method in class org.jgroups.blocks.Link
getLock() - method in class org.jgroups.util.CondVar
getLockAcquisitionTimeout() - method in class org.jgroups.blocks.ReplicationData
getLockInfo() - method in class org.jgroups.blocks.ReplicationData
getLockLeaseTimeout() - method in class org.jgroups.blocks.ReplicationData
getLog() - method in class org.jgroups.Channel
getLog() - method in class org.jgroups.JChannel
getLowestSeen() - method in class org.jgroups.stack.NakReceiverWindow
getMagicNumber() - method in class org.jgroups.conf.ClassMap
getMagicNumber(Class) - method in class org.jgroups.conf.ClassConfigurator
Returns the magic number for the class.
getMarshaller() - method in class org.jgroups.blocks.RpcDispatcher
getMaxBlockTime() - method in class org.jgroups.jmx.protocols.FC
getMaxBlockTime() - method in class org.jgroups.protocols.FC
getMaxBlockTime() - method in class org.jgroups.jmx.protocols.FCMBean
getMaxBundleSize() - method in class org.jgroups.jmx.protocols.TP
getMaxBundleSize() - method in class org.jgroups.protocols.TP
getMaxBundleSize() - method in class org.jgroups.jmx.protocols.TPMBean
getMaxBundleTimeout() - method in class org.jgroups.jmx.protocols.TP
getMaxBundleTimeout() - method in class org.jgroups.protocols.TP
getMaxBundleTimeout() - method in class org.jgroups.jmx.protocols.TPMBean
getMaxBytes() - method in class org.jgroups.jmx.protocols.pbcast.STABLE
getMaxBytes() - method in class org.jgroups.protocols.pbcast.STABLE
getMaxBytes() - method in class org.jgroups.jmx.protocols.pbcast.STABLEMBean
getMaxCredits() - method in class org.jgroups.jmx.protocols.FC
getMaxCredits() - method in class org.jgroups.protocols.FC
getMaxCredits() - method in class org.jgroups.jmx.protocols.FCMBean
getMaxInterval() - method in class org.jgroups.jmx.protocols.MERGE2
getMaxInterval() - method in class org.jgroups.protocols.MERGE2
getMaxInterval() - method in class org.jgroups.jmx.protocols.MERGE2MBean
getMaxTries() - method in class org.jgroups.jmx.protocols.FD
getMaxTries() - method in class org.jgroups.protocols.FD
getMaxTries() - method in class org.jgroups.jmx.protocols.FDMBean
getMaxXmitBufSize() - method in class org.jgroups.jmx.protocols.pbcast.NAKACK
getMaxXmitBufSize() - method in class org.jgroups.protocols.pbcast.NAKACK
getMaxXmitBufSize() - method in class org.jgroups.jmx.protocols.pbcast.NAKACKMBean
getMaxXmitBufSize() - method in class org.jgroups.stack.NakReceiverWindow
getMaxXmitSize() - method in class org.jgroups.jmx.protocols.pbcast.NAKACK
getMaxXmitSize() - method in class org.jgroups.protocols.pbcast.NAKACK
getMaxXmitSize() - method in class org.jgroups.jmx.protocols.pbcast.NAKACKMBean
getMBeanServerName() - method in class org.jgroups.jmx.JChannel
getMbr() - method in class org.jgroups.stack.GossipData
getMbrs() - method in class org.jgroups.stack.GossipData
getMcastAddr() - method in class org.jgroups.jmx.protocols.MPING
getMcastAddr() - method in class org.jgroups.protocols.MPING
getMcastAddr() - method in class org.jgroups.jmx.protocols.MPINGMBean
getMcastPort() - method in class org.jgroups.jmx.protocols.MPING
getMcastPort() - method in class org.jgroups.protocols.MPING
getMcastPort() - method in class org.jgroups.jmx.protocols.MPINGMBean
getMember() - method in class org.jgroups.SuspectEvent
getMembers() - method in class org.jgroups.jmx.protocols.FD
getMembers() - method in class org.jgroups.protocols.FD
getMembers() - method in class org.jgroups.jmx.protocols.FD_SOCK
getMembers() - method in class org.jgroups.protocols.FD_SOCK
getMembers() - method in class org.jgroups.jmx.protocols.FD_SOCKMBean
getMembers() - method in class org.jgroups.jmx.protocols.FDMBean
getMembers() - method in class org.jgroups.jmx.protocols.pbcast.GMS
getMembers() - method in class org.jgroups.protocols.pbcast.GMS
getMembers() - method in class org.jgroups.jmx.protocols.pbcast.GMSMBean
getMembers() - method in class org.jgroups.Membership
returns a copy (clone) of the members in this membership.
getMembers() - method in class org.jgroups.blocks.ReplicatedTree
getMembers() - method in class org.jgroups.jmx.protocols.UNICAST
getMembers() - method in class org.jgroups.protocols.UNICAST
getMembers() - method in class org.jgroups.jmx.protocols.UNICASTMBean
getMembers() - method in class org.jgroups.protocols.VectorTime
Returns Collection containing addresses of other group members from this Vector clock
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.
getMembers(String) - method in class org.jgroups.stack.GossipClient
Returns all members of a given group
getMembership() - method in class org.jgroups.blocks.NotificationBus
Returns a reference to the real membership: don't modify.
getMemeber() - method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
getMessage() - method in class org.jgroups.demos.wb.SendDialog
getMessageListener() - method in class org.jgroups.blocks.MessageDispatcher
Gives access to the currently configured MessageListener.
getMessagesHigherThan(long) - method in class org.jgroups.stack.NakReceiverWindow
Return messages that are higher than seqno (excluding seqno).
Return a list of all messages for which there is a seqno in missing_msgs.
getMessagesInRange(long,long) - method in class org.jgroups.stack.NakReceiverWindow
Return all messages m for which the following holds: m > lower && m <= upper (excluding lower, including upper).
getMessagesReceived() - method in class org.jgroups.jmx.protocols.TP
getMessagesReceived() - method in class org.jgroups.jmx.protocols.TPMBean
getMessagesReceived() - method in class org.jgroups.jmx.protocols.UNICAST
getMessagesReceived() - method in class org.jgroups.jmx.protocols.UNICASTMBean
getMessagesSent() - method in class org.jgroups.jmx.protocols.TP
getMessagesSent() - method in class org.jgroups.jmx.protocols.TPMBean
getMessagesSent() - method in class org.jgroups.jmx.protocols.UNICAST
getMessagesSent() - method in class org.jgroups.jmx.protocols.UNICASTMBean
getMethod() - method in class org.jgroups.blocks.MethodCall
getMethodLookup() - method in class org.jgroups.blocks.RpcDispatcher
getMinCredits() - method in class org.jgroups.jmx.protocols.FC
getMinCredits() - method in class org.jgroups.protocols.FC
getMinCredits() - method in class org.jgroups.jmx.protocols.FCMBean
getMinInterval() - method in class org.jgroups.jmx.protocols.MERGE2
getMinInterval() - method in class org.jgroups.protocols.MERGE2
getMinInterval() - method in class org.jgroups.jmx.protocols.MERGE2MBean
getMinThreshold() - method in class org.jgroups.jmx.protocols.FC
getMinThreshold() - method in class org.jgroups.protocols.FC
getMinThreshold() - method in class org.jgroups.jmx.protocols.FCMBean
getMissing() - method in class org.jgroups.util.AckCollector
getMissingMessages(long,long) - method in class org.jgroups.stack.NakReceiverWindow
Find all messages between 'low' and 'high' (including 'low' and 'high') that have a null msg.
getMissingMessagesReceived() - method in class org.jgroups.jmx.protocols.pbcast.NAKACK
getMissingMessagesReceived() - method in class org.jgroups.protocols.pbcast.NAKACK
getMissingMessagesReceived() - method in class org.jgroups.jmx.protocols.pbcast.NAKACKMBean
getMode() - method in class org.jgroups.blocks.MethodCall
getMode() - method in class org.jgroups.blocks.Xid
getName() - method in class org.jgroups.protocols.AUTOCONF
getName() - method in class org.jgroups.protocols.BSH
getName() - method in class org.jgroups.protocols.CAUSAL
Returns a name of this stack, each stackhas to have unique name
getName() - method in class org.jgroups.protocols.COMPRESS
getName() - method in class org.jgroups.protocols.DEADLOCK
getName() - method in class org.jgroups.protocols.DELAY
All protocol names have to be unique !
getName() - method in class org.jgroups.protocols.DISCARD
All protocol names have to be unique !
getName() - method in class org.jgroups.protocols.DUMMY
All protocol names have to be unique !
getName() - method in class org.jgroups.protocols.DUMMY_TP
getName() - method in class org.jgroups.protocols.ENCRYPT
getName() - method in class org.jgroups.protocols.ENCRYPT1_4
getName() - method in class org.jgroups.protocols.EXAMPLE
All protocol names have to be unique !
getName() - method in class org.jgroups.protocols.FC
getName() - method in class org.jgroups.protocols.FD
getName() - method in class org.jgroups.protocols.pbcast.FD
getName() - method in class org.jgroups.protocols.FD_PID
getName() - method in class org.jgroups.protocols.FD_PROB
getName() - method in class org.jgroups.protocols.FD_SIMPLE
getName() - method in class org.jgroups.protocols.FD_SOCK
getName() - method in class org.jgroups.protocols.FLOW_CONTROL
getName() - method in class org.jgroups.protocols.FLOWCONTROL
getName() - method in class org.jgroups.protocols.FLUSH
getName() - method in class org.jgroups.protocols.FRAG
getName() - method in class org.jgroups.protocols.FRAG2
getName() - method in class org.jgroups.protocols.GMS
getName() - method in class org.jgroups.protocols.pbcast.GMS
getName() - method in class org.jgroups.protocols.HDRS
getName() - method in class org.jgroups.protocols.HTOTAL
getName() - method in class org.jgroups.protocols.JMS
Get the name of the protocol.
getName() - method in class org.jgroups.protocols.LOOPBACK
getName() - method in class org.jgroups.protocols.LOSS
All protocol names have to be unique !
getName() - method in class org.jgroups.protocols.MERGE
getName() - method in class org.jgroups.protocols.MERGE2
getName() - method in class org.jgroups.protocols.MERGE3
getName() - method in class org.jgroups.protocols.MERGEFAST
getName() - method in class org.jgroups.protocols.MessageProtocolEXAMPLE
getName() - method in class org.jgroups.blocks.MethodCall
returns the name of the method to be invoked using this method call object
getName() - method in class org.jgroups.protocols.MPING
getName() - method in class org.jgroups.protocols.NAKACK
getName() - method in class org.jgroups.protocols.pbcast.NAKACK
getName() - method in class org.jgroups.protocols.PARTITIONER
All protocol names have to be unique !
getName() - method in class org.jgroups.protocols.pbcast.PBCAST
getName() - method in class org.jgroups.protocols.PERF
All protocol names have to be unique !
getName() - method in class org.jgroups.protocols.PERF_TP
getName() - method in class org.jgroups.protocols.PIGGYBACK
All protocol names have to be unique !
getName() - method in class org.jgroups.protocols.PING
getName() - method in class org.jgroups.protocols.PRINTMETHODS
getName() - method in class org.jgroups.protocols.PRINTOBJS
getName() - method in class org.jgroups.jmx.Protocol
getName() - method in class org.jgroups.stack.Protocol
getName() - method in class org.jgroups.jmx.ProtocolMBean
getName() - method in class org.jgroups.conf.ProtocolParameter
getName() - method in class org.jgroups.stack.ProtocolStack
getName() - method in class org.jgroups.protocols.QUEUE
All protocol names have to be unique !
getName() - method in class org.jgroups.blocks.RpcDispatcher
getName() - method in class org.jgroups.stack.RpcProtocol
getName() - method in class org.jgroups.protocols.RpcProtocolEXAMPLE
getName() - method in class org.jgroups.protocols.SHUFFLE
getName() - method in class org.jgroups.protocols.SIZE
All protocol names have to be unique !
getName() - method in class org.jgroups.protocols.SMACK
getName() - method in class org.jgroups.protocols.STABLE
getName() - method in class org.jgroups.protocols.pbcast.STABLE
getName() - method in class org.jgroups.protocols.STATE_TRANSFER
All protocol names have to be unique !
getName() - method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
All protocol names have to be unique !
getName() - method in class org.jgroups.protocols.STATS
getName() - method in class org.jgroups.protocols.TCP
getName() - method in class org.jgroups.protocols.TCP_NIO
getName() - method in class org.jgroups.protocols.TCPGOSSIP
getName() - method in class org.jgroups.protocols.TCPPING
getName() - method in class org.jgroups.protocols.TOTAL
getName() - method in class org.jgroups.protocols.TOTAL_OLD
returns the unique name of this protocol
getName() - method in class org.jgroups.protocols.TOTAL_TOKEN
getName() - method in class org.jgroups.protocols.TRACE
getName() - method in class org.jgroups.protocols.TUNNEL
getName() - method in class org.jgroups.protocols.UDP
getName() - method in class org.jgroups.protocols.UDP_NIO
getName() - method in class org.jgroups.protocols.UNICAST
All protocol names have to be unique !
getName() - method in class org.jgroups.protocols.VERIFY_SUSPECT
getName() - method in class org.jgroups.protocols.VIEW_ENFORCER
All protocol names have to be unique !
getName() - method in class org.jgroups.protocols.VIEW_SYNC
getName() - method in class org.jgroups.protocols.WANPING
getName() - method in class org.jgroups.protocols.WANPIPE
getName() - method in class org.jgroups.conf.XmlConfigurator
getNegativeVotes() - method in class org.jgroups.blocks.VotingAdapter.VoteResult
Lists all network interfaces on a system
getNext(String) - method in class org.jgroups.demos.CausalDemo
getNextSeqID() - method in class org.jgroups.protocols.TOTAL_OLD
getNextView(Vector,Vector,Vector) - method in class org.jgroups.protocols.GMS
Computes the next view.
getNextView(Vector,Vector,Vector) - method in class org.jgroups.protocols.pbcast.GMS
Computes the next view.
getNotSeenList() - method in class org.jgroups.protocols.pbcast.Gossip
getNumAcksReceived() - method in class org.jgroups.protocols.UNICAST
getNumAcksSent() - method in class org.jgroups.protocols.UNICAST
getNumberOfBlockings() - method in class org.jgroups.protocols.FC
getNumberOfCreditRequestsReceived() - method in class org.jgroups.protocols.FC
getNumberOfCreditRequestsSent() - method in class org.jgroups.protocols.FC
getNumberOfCreditResponsesReceived() - method in class org.jgroups.protocols.FC
getNumberOfCreditResponsesSent() - method in class org.jgroups.protocols.FC
getNumberOfDiscoveryRequestsSent() - method in class org.jgroups.protocols.Discovery
getNumberOfGossipMessages() - method in class org.jgroups.protocols.pbcast.STABLE
getNumberOfHeartbeatsSent() - method in class org.jgroups.jmx.protocols.FD
getNumberOfHeartbeatsSent() - method in class org.jgroups.protocols.FD
getNumberOfHeartbeatsSent() - method in class org.jgroups.jmx.protocols.FDMBean
getNumberOfReceivedFragments() - method in class org.jgroups.jmx.protocols.FRAG
getNumberOfReceivedFragments() - method in class org.jgroups.protocols.FRAG
getNumberOfReceivedFragments() - method in class org.jgroups.jmx.protocols.FRAG2
getNumberOfReceivedFragments() - method in class org.jgroups.protocols.FRAG2
getNumberOfReceivedFragments() - method in class org.jgroups.jmx.protocols.FRAG2MBean
getNumberOfReceivedFragments() - method in class org.jgroups.jmx.protocols.FRAGMBean
getNumberOfReceivedMessages() - method in class org.jgroups.jmx.protocols.FRAG
getNumberOfReceivedMessages() - method in class org.jgroups.protocols.FRAG
getNumberOfReceivedMessages() - method in class org.jgroups.jmx.protocols.FRAG2
getNumberOfReceivedMessages() - method in class org.jgroups.protocols.FRAG2
getNumberOfReceivedMessages() - method in class org.jgroups.jmx.protocols.FRAG2MBean
getNumberOfReceivedMessages() - method in class org.jgroups.jmx.protocols.FRAGMBean
getNumberOfResponsesExpected(long) - method in class org.jgroups.stack.AckMcastSenderWindow
Returns the number of members for a given entry for which acks have to be received
getNumberOfResponsesReceived(long) - method in class org.jgroups.stack.AckMcastSenderWindow
Returns the number of members for a given entry for which acks have been received
getNumberOfRetransmitRequestsReceived() - method in class org.jgroups.protocols.UNICAST
getNumberOfSentFragments() - method in class org.jgroups.jmx.protocols.FRAG
getNumberOfSentFragments() - method in class org.jgroups.protocols.FRAG
getNumberOfSentFragments() - method in class org.jgroups.jmx.protocols.FRAG2
getNumberOfSentFragments() - method in class org.jgroups.protocols.FRAG2
getNumberOfSentFragments() - method in class org.jgroups.jmx.protocols.FRAG2MBean
getNumberOfSentFragments() - method in class org.jgroups.jmx.protocols.FRAGMBean
getNumberOfSentMessages() - method in class org.jgroups.jmx.protocols.FRAG
getNumberOfSentMessages() - method in class org.jgroups.protocols.FRAG
getNumberOfSentMessages() - method in class org.jgroups.jmx.protocols.FRAG2
getNumberOfSentMessages() - method in class org.jgroups.protocols.FRAG2
getNumberOfSentMessages() - method in class org.jgroups.jmx.protocols.FRAG2MBean
getNumberOfSentMessages() - method in class org.jgroups.jmx.protocols.FRAGMBean
getNumberOfStateBytesSent() - method in class org.jgroups.jmx.protocols.pbcast.STATE_TRANSFER
getNumberOfStateBytesSent() - method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
getNumberOfStateBytesSent() - method in class org.jgroups.jmx.protocols.pbcast.STATE_TRANSFERMBean
getNumberOfStateRequests() - method in class org.jgroups.jmx.protocols.pbcast.STATE_TRANSFER
getNumberOfStateRequests() - method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
getNumberOfStateRequests() - method in class org.jgroups.jmx.protocols.pbcast.STATE_TRANSFERMBean
getNumberOfTasksInTimer() - method in class org.jgroups.JChannel
getNumberOfTasksInTimer() - method in class org.jgroups.jmx.JChannel
getNumberOfTasksInTimer() - method in class org.jgroups.jmx.JChannelMBean
getNumberOfUnackedMessages() - method in class org.jgroups.protocols.UNICAST
The number of messages in all Entry.sent_msgs tables (haven't received an ACK yet)
getNumberOfViews() - method in class org.jgroups.jmx.protocols.pbcast.GMS
getNumberOfViews() - method in class org.jgroups.protocols.pbcast.GMS
getNumberOfViews() - method in class org.jgroups.jmx.protocols.pbcast.GMSMBean
getNumBytesReceived() - method in class org.jgroups.protocols.TP
getNumBytesReceived() - method in class org.jgroups.protocols.UNICAST
getNumBytesSent() - method in class org.jgroups.protocols.TP
getNumBytesSent() - method in class org.jgroups.protocols.UNICAST
getNumConnections() - method in class org.jgroups.blocks.ConnectionTable
getNumInitialMembers() - method in class org.jgroups.protocols.Discovery
getNumMembers() - method in class org.jgroups.jmx.protocols.pbcast.GMS
getNumMembers() - method in class org.jgroups.protocols.pbcast.GMS
getNumMembers() - method in class org.jgroups.jmx.protocols.pbcast.GMSMBean
getNumMessages() - method in class org.jgroups.Channel
Returns the number of messages that are waiting.
getNumMessages() - method in class org.jgroups.JChannel
getNumMessages() - method in class org.jgroups.jmx.JChannel
getNumMessages() - method in class org.jgroups.jmx.JChannelMBean
getNumMessages() - method in class org.jgroups.protocols.PERF_TP
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
getNumPingRequests() - method in class org.jgroups.protocols.Discovery
getNumSuspectEventsGenerated() - method in class org.jgroups.jmx.protocols.FD
getNumSuspectEventsGenerated() - method in class org.jgroups.protocols.FD
getNumSuspectEventsGenerated() - method in class org.jgroups.jmx.protocols.FD_SOCK
getNumSuspectEventsGenerated() - method in class org.jgroups.protocols.FD_SOCK
getNumSuspectEventsGenerated() - method in class org.jgroups.jmx.protocols.FD_SOCKMBean
getNumSuspectEventsGenerated() - method in class org.jgroups.jmx.protocols.FDMBean
getNumSuspects() - method in class org.jgroups.blocks.GroupRequest
getNumViewsAdjusted() - method in class org.jgroups.jmx.protocols.VIEW_SYNC
getNumViewsAdjusted() - method in class org.jgroups.protocols.VIEW_SYNC
getNumViewsAdjusted() - method in class org.jgroups.jmx.protocols.VIEW_SYNCMBean
getNumViewsSent() - method in class org.jgroups.jmx.protocols.VIEW_SYNC
getNumViewsSent() - method in class org.jgroups.protocols.VIEW_SYNC
getNumViewsSent() - method in class org.jgroups.jmx.protocols.VIEW_SYNCMBean
getObject() - method in class org.jgroups.Message
getObjectName() - method in class org.jgroups.jmx.JChannel
getObjectName() - method in class org.jgroups.jmx.JChannelMBean
getOffset() - method in class org.jgroups.util.Buffer
getOffset() - method in class org.jgroups.Message
Returns the offset into the buffer at which the data starts
getOpenConnections() - method in class org.jgroups.jmx.protocols.TCP
getOpenConnections() - method in class org.jgroups.protocols.TCP
getOpenConnections() - method in class org.jgroups.jmx.protocols.TCPMBean
getOpt(int) - method in class org.jgroups.Channel
Gets an option.
getOpt(int) - method in class org.jgroups.JChannel
returns the value of an option.
getOutgoingQueueMaxSize() - method in class org.jgroups.jmx.protocols.TP
getOutgoingQueueMaxSize() - method in class org.jgroups.protocols.TP
getOutgoingQueueMaxSize() - method in class org.jgroups.jmx.protocols.TPMBean
getOutgoingQueueSize() - method in class org.jgroups.jmx.protocols.TP
getOutgoingQueueSize() - method in class org.jgroups.protocols.TP
getOutgoingQueueSize() - method in class org.jgroups.jmx.protocols.TPMBean
getOverhead() - method in class org.jgroups.jmx.protocols.FRAG2
getOverhead() - method in class org.jgroups.protocols.FRAG2
getOverhead() - method in class org.jgroups.jmx.protocols.FRAG2MBean
getOwnerIndex() - method in class org.jgroups.protocols.VectorTime
Returns owner index in this VectorTime clock
getParameters() - method in class org.jgroups.conf.ProtocolData
getParametersAsArray() - method in class org.jgroups.conf.ProtocolData
getParameterString() - method in class org.jgroups.conf.ProtocolParameter
getParameterStringXml() - method in class org.jgroups.conf.ProtocolParameter
getPendingRetransmissionRequests() - method in class org.jgroups.jmx.protocols.pbcast.NAKACK
getPendingRetransmissionRequests() - method in class org.jgroups.protocols.pbcast.NAKACK
getPendingRetransmissionRequests() - method in class org.jgroups.jmx.protocols.pbcast.NAKACKMBean
getPersistent() - method in class org.jgroups.blocks.DistributedHashtable
getPhysicalAddresses() - method in class org.jgroups.stack.LogicalAddress
Returns a copy of the list of physical addresses.
getPingableMembers() - method in class org.jgroups.jmx.protocols.FD
getPingableMembers() - method in class org.jgroups.protocols.FD
getPingableMembers() - method in class org.jgroups.jmx.protocols.FD_SOCK
getPingableMembers() - method in class org.jgroups.protocols.FD_SOCK
getPingableMembers() - method in class org.jgroups.jmx.protocols.FD_SOCKMBean
getPingableMembers() - method in class org.jgroups.jmx.protocols.FDMBean
getPingDest() - method in class org.jgroups.jmx.protocols.FD
getPingDest() - method in class org.jgroups.protocols.FD
getPingDest() - method in class org.jgroups.jmx.protocols.FD_SOCK
getPingDest() - method in class org.jgroups.protocols.FD_SOCK
getPingDest() - method in class org.jgroups.jmx.protocols.FD_SOCKMBean
getPingDest() - method in class org.jgroups.jmx.protocols.FDMBean
getPingRequests() - method in class org.jgroups.jmx.protocols.Discovery
getPingRequests() - method in class org.jgroups.jmx.protocols.DiscoveryMBean
getPort() - method in class org.jgroups.stack.GossipRouter
getPort() - method in class org.jgroups.stack.IpAddress
getPositiveVotes() - method in class org.jgroups.blocks.VotingAdapter.VoteResult
getPreload() - method in class org.jgroups.conf.ClassMap
getPreviousBacklog() - method in class org.jgroups.protocols.ring.RingNodeFlowControl
getPrimaryPhysicalAddress() - method in class org.jgroups.stack.LogicalAddress
getProcessorKeepAliveTime() - method in class org.jgroups.jmx.protocols.TCP_NIO
getProcessorKeepAliveTime() - method in class org.jgroups.protocols.TCP_NIO
getProcessorKeepAliveTime() - method in class org.jgroups.jmx.protocols.TCP_NIOMBean
getProcessorMaxThreads() - method in class org.jgroups.jmx.protocols.TCP_NIO
getProcessorMaxThreads() - method in class org.jgroups.protocols.TCP_NIO
getProcessorMaxThreads() - method in class org.jgroups.jmx.protocols.TCP_NIOMBean
getProcessorMinThreads() - method in class org.jgroups.jmx.protocols.TCP_NIO
getProcessorMinThreads() - method in class org.jgroups.protocols.TCP_NIO
getProcessorMinThreads() - method in class org.jgroups.jmx.protocols.TCP_NIOMBean
getProcessorQueueSize() - method in class org.jgroups.jmx.protocols.TCP_NIO
getProcessorQueueSize() - method in class org.jgroups.protocols.TCP_NIO
getProcessorQueueSize() - method in class org.jgroups.jmx.protocols.TCP_NIOMBean
getProcessorThreads() - method in class org.jgroups.jmx.protocols.TCP_NIO
getProcessorThreads() - method in class org.jgroups.protocols.TCP_NIO
getProcessorThreads() - method in class org.jgroups.jmx.protocols.TCP_NIOMBean
getProperties() - method in class org.jgroups.stack.Configurator.ProtocolConfiguration
getProperties() - method in class org.jgroups.JChannel
returns the protocol stack configuration in string format.
getProperties() - method in class org.jgroups.jmx.JChannel
getProperties() - method in class org.jgroups.jmx.JChannelMBean
getProperties() - method in class org.jgroups.stack.Protocol
getPropertiesAsString() - method in class org.jgroups.jmx.Protocol
getPropertiesAsString() - method in class org.jgroups.jmx.ProtocolMBean
getProtocolName() - method in class org.jgroups.stack.Configurator.ProtocolConfiguration
getProtocolName() - method in class org.jgroups.conf.ProtocolData
getProtocols() - method in class org.jgroups.stack.ProtocolStack
Returns all protocols in a list, from top to bottom.
getProtocolSpec() - method in class org.jgroups.debug.ProtocolTester
getProtocolStack() - method in class org.jgroups.JChannel
Returns the protocol stack.
getProtocolStack() - method in class org.jgroups.conf.PlainConfigurator
Throws a UnsupportedOperationException all the time.
getProtocolStack() - method in class org.jgroups.conf.ProtocolStackConfigurator
getProtocolStack() - method in class org.jgroups.conf.XmlConfigurator
getProtocolStackString() - method in class org.jgroups.conf.PlainConfigurator
returns the old style protocol string
getProtocolStackString() - method in class org.jgroups.conf.ProtocolStackConfigurator
getProtocolStackString() - method in class org.jgroups.conf.XmlConfigurator
getProtocolStackString(boolean) - method in class org.jgroups.conf.XmlConfigurator
getProtocolString() - method in class org.jgroups.conf.ProtocolData
getProtocolString(boolean) - method in class org.jgroups.conf.ProtocolData
getProtocolStringNewXml() - method in class org.jgroups.conf.ProtocolData
getQueueingDown() - method in class org.jgroups.protocols.QUEUE
getQueueingUp() - method in class org.jgroups.protocols.QUEUE
getQuote(String) - method in class org.jgroups.demos.QuoteServer
getRandomSequence() - method in class org.jgroups.demos.TotalTokenDemo.TotalPayload
getRawBuffer() - method in class org.jgroups.util.ExposedByteArrayOutputStream
getRawBuffer() - method in class org.jgroups.Message
Returns a reference to the payload (byte buffer).
getReaderThreads() - method in class org.jgroups.jmx.protocols.TCP_NIO
getReaderThreads() - method in class org.jgroups.protocols.TCP_NIO
getReaderThreads() - method in class org.jgroups.jmx.protocols.TCP_NIOMBean
getReaperInterval() - method in class org.jgroups.jmx.protocols.TCP
getReaperInterval() - method in class org.jgroups.protocols.TCP
getReaperInterval() - method in class org.jgroups.jmx.protocols.TCPMBean
getReason() - method in class org.jgroups.blocks.VotingAdapter.FailureVoteResult
getReceiveBlockEvents() - method in class org.jgroups.jmx.JChannel
getReceiveBlockEvents() - method in class org.jgroups.jmx.JChannelMBean
getReceiveBufferSize() - method in class org.jgroups.blocks.ConnectionTable
getReceived() - method in class org.jgroups.util.AckCollector
getReceivedBytes() - method in class org.jgroups.JChannel
getReceivedBytes() - method in class org.jgroups.jmx.JChannel
getReceivedBytes() - method in class org.jgroups.jmx.JChannelMBean
getReceivedBytes() - method in class org.jgroups.jmx.protocols.STATS
getReceivedBytes() - method in class org.jgroups.protocols.STATS
getReceivedBytes() - method in class org.jgroups.jmx.protocols.STATSMBean
getReceivedMcastBytes() - method in class org.jgroups.jmx.protocols.STATS
getReceivedMcastBytes() - method in class org.jgroups.protocols.STATS
getReceivedMcastBytes() - method in class org.jgroups.jmx.protocols.STATSMBean
getReceivedMcastMessages() - method in class org.jgroups.jmx.protocols.STATS
getReceivedMcastMessages() - method in class org.jgroups.protocols.STATS
getReceivedMcastMessages() - method in class org.jgroups.jmx.protocols.STATSMBean
getReceivedMessages() - method in class org.jgroups.JChannel
getReceivedMessages() - method in class org.jgroups.jmx.JChannel
getReceivedMessages() - method in class org.jgroups.jmx.JChannelMBean
getReceivedMessages() - method in class org.jgroups.jmx.protocols.STATS
getReceivedMessages() - method in class org.jgroups.protocols.STATS
getReceivedMessages() - method in class org.jgroups.jmx.protocols.STATSMBean
getReceivedTableSize() - method in class org.jgroups.jmx.protocols.pbcast.NAKACK
getReceivedTableSize() - method in class org.jgroups.protocols.pbcast.NAKACK
getReceivedTableSize() - method in class org.jgroups.jmx.protocols.pbcast.NAKACKMBean
getReceivedUnicastBytes() - method in class org.jgroups.jmx.protocols.STATS
getReceivedUnicastBytes() - method in class org.jgroups.protocols.STATS
getReceivedUnicastBytes() - method in class org.jgroups.jmx.protocols.STATSMBean
getReceivedUnicastMessages() - method in class org.jgroups.jmx.protocols.STATS
getReceivedUnicastMessages() - method in class org.jgroups.protocols.STATS
getReceivedUnicastMessages() - method in class org.jgroups.jmx.protocols.STATSMBean
getReceiveInterfaces() - method in class org.jgroups.jmx.protocols.TP
getReceiveInterfaces() - method in class org.jgroups.protocols.TP
getReceiveInterfaces() - method in class org.jgroups.jmx.protocols.TPMBean
getReceiveLocalMessages() - method in class org.jgroups.jmx.JChannel
getReceiveLocalMessages() - method in class org.jgroups.jmx.JChannelMBean
getReceiver() - method in class org.jgroups.protocols.UDP_NIO.ConnectorTable
getReceiveStateEvents() - method in class org.jgroups.jmx.JChannel
getReceiveStateEvents() - method in class org.jgroups.jmx.JChannelMBean
getReceiveSuspectEvents() - method in class org.jgroups.jmx.JChannel
getReceiveSuspectEvents() - method in class org.jgroups.jmx.JChannelMBean
getReceiveViewEvents() - method in class org.jgroups.jmx.JChannel
getReceiveViewEvents() - method in class org.jgroups.jmx.JChannelMBean
getRecoveredMembers() - method in class org.jgroups.protocols.ring.RingToken
getRemoteAddress() - method in class org.jgroups.blocks.Link
getRemotePort() - method in class org.jgroups.blocks.Link
getRequestor() - method in class org.jgroups.GetStateEvent
getResourceAsStream(String,Class) - static method in class org.jgroups.util.Util
getResponses() - method in class org.jgroups.protocols.PingWaiter
getResult() - static method in class org.jgroups.protocols.DEADLOCK
Returns a random integer value between 1 and 10
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.
getResults() - method in class org.jgroups.blocks.GroupRequest
Returns the results as a RspList
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
getRetransmissionRequests() - method in class org.jgroups.protocols.ring.RingToken
getRoutingClientReplyTimeout() - method in class org.jgroups.stack.GossipRouter
getSeenList() - method in class org.jgroups.protocols.pbcast.Gossip
getSendBufferSize() - method in class org.jgroups.blocks.ConnectionTable
getSender() - method in class org.jgroups.protocols.pbcast.MergeData
getSender() - method in class org.jgroups.util.Rsp
getSenderIndex() - method in class org.jgroups.protocols.TransportedVectorTime
Returns sender index
getSendInterfaces() - method in class org.jgroups.jmx.protocols.TP
getSendInterfaces() - method in class org.jgroups.protocols.TP
getSendInterfaces() - method in class org.jgroups.jmx.protocols.TPMBean
getSentBytes() - method in class org.jgroups.JChannel
getSentBytes() - method in class org.jgroups.jmx.JChannel
getSentBytes() - method in class org.jgroups.jmx.JChannelMBean
getSentBytes() - method in class org.jgroups.jmx.protocols.STATS
getSentBytes() - method in class org.jgroups.protocols.STATS
getSentBytes() - method in class org.jgroups.jmx.protocols.STATSMBean
getSentMcastBytes() - method in class org.jgroups.jmx.protocols.STATS
getSentMcastBytes() - method in class org.jgroups.protocols.STATS
getSentMcastBytes() - method in class org.jgroups.jmx.protocols.STATSMBean
getSentMcastMessages() - method in class org.jgroups.jmx.protocols.STATS
getSentMcastMessages() - method in class org.jgroups.protocols.STATS
getSentMcastMessages() - method in class org.jgroups.jmx.protocols.STATSMBean
getSentMessages() - method in class org.jgroups.JChannel
getSentMessages() - method in class org.jgroups.jmx.JChannel
getSentMessages() - method in class org.jgroups.jmx.JChannelMBean
getSentMessages() - method in class org.jgroups.jmx.protocols.STATS
getSentMessages() - method in class org.jgroups.protocols.STATS
getSentMessages() - method in class org.jgroups.jmx.protocols.STATSMBean
getSentTableSize() - method in class org.jgroups.jmx.protocols.pbcast.NAKACK
getSentTableSize() - method in class org.jgroups.protocols.pbcast.NAKACK
getSentTableSize() - method in class org.jgroups.jmx.protocols.pbcast.NAKACKMBean
getSentUnicastBytes() - method in class org.jgroups.jmx.protocols.STATS
getSentUnicastBytes() - method in class org.jgroups.protocols.STATS
getSentUnicastBytes() - method in class org.jgroups.jmx.protocols.STATSMBean
getSentUnicastMessages() - method in class org.jgroups.jmx.protocols.STATS
getSentUnicastMessages() - method in class org.jgroups.protocols.STATS
getSentUnicastMessages() - method in class org.jgroups.jmx.protocols.STATSMBean
getSeq() - method in class org.jgroups.protocols.TOTAL_TOKEN.TotalTokenHeader
Returns sequence number of the message that owns this header
getSeqno() - method in class org.jgroups.protocols.pbcast.PbcastHeader
getSequencer() - method in class org.jgroups.protocols.TOTAL_OLD
returns the address of the current sequencer of the group returns null if the list of members is empty
getServerObject() - method in class org.jgroups.blocks.RpcDispatcher
getServerPubKey() - method in class org.jgroups.protocols.ENCRYPT
getSocketConnectionTimeout() - method in class org.jgroups.blocks.ConnectionTable
getSrc() - method in class org.jgroups.Message
getStableMessages() - method in class org.jgroups.stack.AckMcastSenderWindow
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(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(Object) - static method in class org.jgroups.conf.ConfiguratorFactory
Returns a protocol stack configurator based on the properties passed in.
If the properties parameter is a plain string UDP:FRAG:MERGE:GMS etc, a PlainConfigurator is returned.
If the properties parameter is a string that represents a url for example http://www.filip.net/test.xml or the parameter is a java.net.URL object, an XmlConfigurator is returned
getStackConfigurator(String) - static method in class org.jgroups.conf.ConfiguratorFactory
Returns a protocol stack configurator based on the provided properties string.
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.
getStackTrace(Throwable) - static method in class org.jgroups.util.Util
getStartPort() - method in class org.jgroups.jmx.protocols.TCP
getStartPort() - method in class org.jgroups.protocols.TCP
getStartPort() - method in class org.jgroups.jmx.protocols.TCPMBean
getState() - method in class org.jgroups.demos.Chat
getState() - method in class org.jgroups.blocks.DistributedHashtable
Answers the group state; e.g., when joining.
getState() - method in class org.jgroups.blocks.DistributedQueue
Answers the group state; e.g., when joining.
getState() - method in class org.jgroups.blocks.DistributedTree
Return a copy of the tree
getState() - method in class org.jgroups.demos.wb.GraphPanel
getState() - method in class org.jgroups.MessageListener
Answers the group state; e.g., when joining.
getState() - method in class org.jgroups.blocks.MessageListenerAdapter
Get state from state listener if present.
getState() - method in class org.jgroups.blocks.NotificationBus
Answers the group state; e.g., when joining.
getState() - method in class org.jgroups.demos.QuoteServer
Answers the group state; e.g., when joining.
getState() - method in class org.jgroups.ReceiverAdapter
Answers the group state; e.g., when joining.
getState() - method in class org.jgroups.blocks.ReplicatedHashtable
Answers the group state; e.g., when joining.
getState() - method in class org.jgroups.blocks.ReplicatedTree
Return a copy of the current cache (tree)
getState() - method in class org.jgroups.blocks.VotingAdapter
Get the channel state.
getState() - method in class org.jgroups.demos.wb.Whiteboard
Answers the group state; e.g., when joining.
getState(org.jgroups.Address,long) - method in class org.jgroups.Channel
Retrieve the state of the group.
getState(org.jgroups.Address,long) - method in class org.jgroups.JChannel
Retrieves the current group state.
getState(org.jgroups.Address,long) - method in class org.jgroups.jmx.JChannel
getState(org.jgroups.Address,long) - method in class org.jgroups.jmx.JChannelMBean
GetStateEvent - class org.jgroups.GetStateEvent
Represents a GetState event.
GetStateEvent(Object) - constructor for class org.jgroups.GetStateEvent
getStatsEnabled() - method in class org.jgroups.jmx.JChannel
getStatsEnabled() - method in class org.jgroups.jmx.JChannelMBean
getStatsEnabled() - method in class org.jgroups.jmx.Protocol
getStatsEnabled() - method in class org.jgroups.jmx.ProtocolMBean
getSubgroups() - method in class org.jgroups.MergeView
getSuspectedMembers() - method in class org.jgroups.util.RspList
getSuspects() - method in class org.jgroups.blocks.GroupRequest
getSuspendInterval() - method in class org.jgroups.util.TimeScheduler
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
getThread() - method in class org.jgroups.util.ThreadPool
getTimeout() - method in class org.jgroups.jmx.protocols.Discovery
getTimeout() - method in class org.jgroups.protocols.Discovery
getTimeout() - method in class org.jgroups.jmx.protocols.DiscoveryMBean
getTimeout() - method in class org.jgroups.jmx.protocols.FD
getTimeout() - method in class org.jgroups.protocols.FD
getTimeout() - method in class org.jgroups.jmx.protocols.FDMBean
getTimestamp() - method in class org.jgroups.stack.LogicalAddress
getTokenReceiverAddress() - method in class org.jgroups.protocols.ring.RingNode
getTokenReceiverAddress() - method in class org.jgroups.protocols.ring.TcpRingNode
getTokenReceiverAddress() - method in class org.jgroups.protocols.TOTAL_TOKEN
getTokenReceiverAddress() - method in class org.jgroups.protocols.ring.UdpRingNode
getTokenSequence() - method in class org.jgroups.protocols.ring.RingToken
getTotalTime() - method in class org.jgroups.protocols.PERF_TP
getTotalTimeBlocked() - method in class org.jgroups.jmx.protocols.FC
getTotalTimeBlocked() - method in class org.jgroups.protocols.FC
getTotalTimeBlocked() - method in class org.jgroups.jmx.protocols.FCMBean
getTransaction() - method in class org.jgroups.blocks.ReplicationData
getTransport() - method in class org.jgroups.blocks.PullPushAdapter
getTransportedVectorTime() - method in class org.jgroups.protocols.VectorTime
Returns a minimal lightweight representation of this Vector Time suitable for network transport.
getTTL() - method in class org.jgroups.jmx.protocols.MPING
getTTL() - method in class org.jgroups.protocols.MPING
getTTL() - method in class org.jgroups.jmx.protocols.MPINGMBean
getType() - method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
getType() - method in class org.jgroups.Event
getType() - method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
getType() - method in class org.jgroups.stack.GossipData
getType() - method in class org.jgroups.blocks.ReplicationData
getType() - method in class org.jgroups.protocols.ring.RingToken
getType() - method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
getUnackedMessages() - method in class org.jgroups.jmx.protocols.UNICAST
getUnackedMessages() - method in class org.jgroups.jmx.protocols.UNICASTMBean
getUpProtocol() - method in class org.jgroups.stack.Protocol
getUpQueue() - method in class org.jgroups.stack.Protocol
getUpThread() - method in class org.jgroups.jmx.Protocol
getUpThread() - method in class org.jgroups.jmx.ProtocolMBean
getUpVector() - method in class org.jgroups.protocols.QUEUE
getUserName() - method in class org.jgroups.demos.wb.UserInfoDialog
getUseSendQueues() - method in class org.jgroups.blocks.ConnectionTable
getValue() - method in class org.jgroups.conf.ProtocolParameter
getValue() - method in class org.jgroups.util.Rsp
getValues() - method in class org.jgroups.protocols.TransportedVectorTime
Returns vector values
getValues() - method in class org.jgroups.protocols.VectorTime
Returns Vector clock values of this Vector clock
getVectorTime() - method in class org.jgroups.protocols.CAUSAL.CausalHeader
Returns a vector timestamp carreid by this header
getVectorValues() - method in class org.jgroups.protocols.VectorTime
Returns Vector clock values of this Vector clock
getVersion() - method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
getVersion() - method in class org.jgroups.jmx.JChannel
getVersion() - method in class org.jgroups.jmx.JChannelMBean
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.Channel
Gets the current view.
getView() - method in class org.jgroups.jmx.protocols.pbcast.GMS
getView() - method in class org.jgroups.protocols.pbcast.GMS
getView() - method in class org.jgroups.jmx.protocols.pbcast.GMSMBean
getView() - method in class org.jgroups.JChannel
Returns the current view.
getView() - method in class org.jgroups.jmx.JChannel
getView() - method in class org.jgroups.jmx.JChannelMBean
getView() - method in class org.jgroups.protocols.pbcast.MergeData
getViewAsString() - method in class org.jgroups.jmx.JChannel
getViewAsString() - method in class org.jgroups.jmx.JChannelMBean
getViewHandlerQueue() - method in class org.jgroups.jmx.protocols.pbcast.GMS
getViewHandlerQueue() - method in class org.jgroups.jmx.protocols.pbcast.GMSMBean
getViewId() - method in class org.jgroups.util.AckCollector
getVoteChannel() - method in class org.jgroups.blocks.TwoPhaseVotingAdapter
getWindowSize() - method in class org.jgroups.protocols.ring.RingToken
getWindowThreshold() - method in class org.jgroups.protocols.ring.RingToken
getWriterThreads() - method in class org.jgroups.jmx.protocols.TCP_NIO
getWriterThreads() - method in class org.jgroups.protocols.TCP_NIO
getWriterThreads() - method in class org.jgroups.jmx.protocols.TCP_NIOMBean
getXmitRequestsReceived() - method in class org.jgroups.jmx.protocols.pbcast.NAKACK
getXmitRequestsReceived() - method in class org.jgroups.protocols.pbcast.NAKACK
getXmitRequestsReceived() - method in class org.jgroups.jmx.protocols.pbcast.NAKACKMBean
getXmitRequestsReceived() - method in class org.jgroups.jmx.protocols.UNICAST
getXmitRequestsReceived() - method in class org.jgroups.jmx.protocols.UNICASTMBean
getXmitRequestsSent() - method in class org.jgroups.jmx.protocols.pbcast.NAKACK
getXmitRequestsSent() - method in class org.jgroups.protocols.pbcast.NAKACK
getXmitRequestsSent() - method in class org.jgroups.jmx.protocols.pbcast.NAKACKMBean
getXmitResponsesReceived() - method in class org.jgroups.jmx.protocols.pbcast.NAKACK
getXmitResponsesReceived() - method in class org.jgroups.protocols.pbcast.NAKACK
getXmitResponsesReceived() - method in class org.jgroups.jmx.protocols.pbcast.NAKACKMBean
getXmitResponsesSent() - method in class org.jgroups.jmx.protocols.pbcast.NAKACK
getXmitResponsesSent() - method in class org.jgroups.protocols.pbcast.NAKACK
getXmitResponsesSent() - method in class org.jgroups.jmx.protocols.pbcast.NAKACKMBean
Global - class org.jgroups.Global
Globals used by JGroups packages.
gms - field in class org.jgroups.protocols.GmsImpl
gms - field in class org.jgroups.protocols.pbcast.GmsImpl
GMS - class org.jgroups.jmx.protocols.pbcast.GMS
GMS - class org.jgroups.protocols.GMS
Group membership protocol.
GMS - class org.jgroups.protocols.pbcast.GMS
Group membership protocol.
GMS() - constructor for class org.jgroups.jmx.protocols.pbcast.GMS
GMS() - constructor for class org.jgroups.protocols.GMS
GMS() - constructor for class org.jgroups.protocols.pbcast.GMS
GMS(org.jgroups.stack.Protocol) - constructor for class org.jgroups.jmx.protocols.pbcast.GMS
GMS.GmsHeader - class org.jgroups.protocols.pbcast.GMS.GmsHeader
GmsHeader() - constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
GmsHeader(byte) - constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
GmsHeader(byte,org.jgroups.Address) - constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
Used for JOIN_REQ or LEAVE_REQ header
GmsHeader(byte,org.jgroups.protocols.pbcast.JoinRsp) - constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
Used for JOIN_RSP header
GmsHeader(byte,org.jgroups.View) - constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
Used for VIEW header
GmsImpl - class org.jgroups.protocols.GmsImpl
GmsImpl - class org.jgroups.protocols.pbcast.GmsImpl
GmsImpl() - constructor for class org.jgroups.protocols.pbcast.GmsImpl
GmsImpl(org.jgroups.protocols.pbcast.GMS) - constructor for class org.jgroups.protocols.pbcast.GmsImpl
GMSMBean - interface org.jgroups.jmx.protocols.pbcast.GMSMBean
go() - method in class org.jgroups.demos.Draw
go() - method in class org.jgroups.demos.Draw2Channels
go() - method in class org.jgroups.demos.applets.DrawApplet
go() - method in class org.jgroups.demos.DrawRepl
go() - method in class org.jgroups.demos.Gossip
Gossip - class org.jgroups.demos.Gossip
Demos that tries to graphically illustrating the gossip (or pbcast) protocol: every sender periodically sends a DRAW command to a random subset of the group members.
Gossip - class org.jgroups.protocols.pbcast.Gossip
GOSSIP - static field in class org.jgroups.protocols.pbcast.PbcastHeader
Gossip(org.jgroups.Address,long) - constructor for class org.jgroups.protocols.pbcast.Gossip
Gossip(org.jgroups.Address,long,org.jgroups.protocols.pbcast.Digest,Vector) - constructor for class org.jgroups.protocols.pbcast.Gossip
gossip(org.jgroups.ViewId,long,long[],boolean[],Object) - method in class org.jgroups.protocols.STABLE
Contains the highest sequence numbers as seen by sender
Gossip(String,long) - constructor for class org.jgroups.demos.Gossip
GOSSIP_REQUEST_TIMEOUT - static field in class org.jgroups.stack.GossipRouter
GossipClient - class org.jgroups.stack.GossipClient
Local stub for clients to access one (or more) GossipServers.
GossipClient(org.jgroups.stack.IpAddress,long) - constructor for class org.jgroups.stack.GossipClient
Creates the GossipClient
GossipClient(Vector,long) - constructor for class org.jgroups.stack.GossipClient
Creates the GossipClient
GossipData - class org.jgroups.stack.GossipData
Encapsulates data sent between GossipServer and GossipClient
GossipData() - constructor for class org.jgroups.stack.GossipData
GossipData(int,String,org.jgroups.Address,Vector) - constructor for class org.jgroups.stack.GossipData
GossipRouter - class org.jgroups.stack.GossipRouter
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,long) - constructor for class org.jgroups.stack.GossipRouter
GossipRouter(int,String,long,long,long) - constructor for class org.jgroups.stack.GossipRouter
GossipServer - class org.jgroups.stack.GossipServer
Maintains a cache of member addresses for each group.
GossipServer(int) - constructor for class org.jgroups.stack.GossipServer
GossipServer(int,long) - constructor for class org.jgroups.stack.GossipServer
GossipServer(int,long,InetAddress) - constructor for class org.jgroups.stack.GossipServer
GraphPanel - class org.jgroups.demos.wb.GraphPanel
GraphPanel(org.jgroups.demos.wb.Whiteboard) - constructor for class org.jgroups.demos.wb.GraphPanel
group_addr - field in class org.jgroups.protocols.GMS
group_addr - field in class org.jgroups.protocols.TcpHeader
group_addr - field in class org.jgroups.protocols.WANPIPE.WanPipeHeader
GROUP_NAME_PROPERTY - static field in class org.jgroups.protocols.JMS
groupname - field in class org.jgroups.blocks.DistributedQueue
groupname - static field in class org.jgroups.demos.wb.Whiteboard
GroupRequest - class org.jgroups.blocks.GroupRequest
Sends a message to all members of the group and waits for all responses (or timeout).

H

handle(org.jgroups.Message) - method in class org.jgroups.protocols.FLOW_CONTROL
Called when a request for this protocol layer is received.
handle(org.jgroups.Message) - method in class org.jgroups.blocks.MessageDispatcher
handle(org.jgroups.Message) - method in class org.jgroups.stack.MessageProtocol
Processes a request destined for this layer.
handle(org.jgroups.Message) - method in class org.jgroups.protocols.MessageProtocolEXAMPLE
Callback.
handle(org.jgroups.Message) - method in class org.jgroups.blocks.ReplicationManager
handle(org.jgroups.Message) - method in class org.jgroups.blocks.RequestHandler
handle(org.jgroups.Message) - method in class org.jgroups.blocks.RpcDispatcher
Message contains MethodCall.
handle(org.jgroups.Message) - method in class org.jgroups.stack.RpcProtocol
Message contains MethodCall.
handle(org.jgroups.Message) - method in class org.jgroups.protocols.STATE_TRANSFER
handleCommit(org.jgroups.blocks.Xid) - method in class org.jgroups.blocks.ReplicationManager
handleConfigEvent(HashMap) - method in class org.jgroups.protocols.TP
handleConfigEvent(HashMap) - method in class org.jgroups.protocols.UDP
handleConnect() - method in class org.jgroups.protocols.Discovery
handleConnect() - method in class org.jgroups.protocols.PING
handleConnectOK() - method in class org.jgroups.protocols.Discovery
Called when CONNECT_OK has been received
handleConnectOK() - method in class org.jgroups.protocols.TCPGOSSIP
Called when CONNECT_OK has been received
handleDisconnect() - method in class org.jgroups.protocols.Discovery
handleDisconnect() - method in class org.jgroups.protocols.PING
handleDownEvent(org.jgroups.Event) - method in class org.jgroups.protocols.DEADLOCK
Callback.
handleDownEvent(org.jgroups.Event) - method in class org.jgroups.protocols.FLOW_CONTROL
If Event.MSG type is received count is incremented by one, and message is passed to the down_prot.
handleDownEvent(org.jgroups.Event) - method in class org.jgroups.protocols.FLUSH
Callback.
handleDownEvent(org.jgroups.Event) - method in class org.jgroups.protocols.GMS
Callback.
handleDownEvent(org.jgroups.Event) - method in class org.jgroups.protocols.GmsImpl
handleDownEvent(org.jgroups.Event) - method in class org.jgroups.protocols.pbcast.GmsImpl
handleDownEvent(org.jgroups.Event) - method in class org.jgroups.protocols.JMS
Handle down event, if it is not a Event.MSG type.
handleDownEvent(org.jgroups.Event) - method in class org.jgroups.stack.MessageProtocol
Handle down event.
handleDownEvent(org.jgroups.Event) - method in class org.jgroups.protocols.MessageProtocolEXAMPLE
Callback.
handleDownEvent(org.jgroups.Event) - method in class org.jgroups.stack.RpcProtocol
Handle down event.
handleDownEvent(org.jgroups.Event) - method in class org.jgroups.protocols.RpcProtocolEXAMPLE
Callback.
handleDownEvent(org.jgroups.Event) - method in class org.jgroups.protocols.STABLE
Callback.
handleDownEvent(org.jgroups.Event) - method in class org.jgroups.protocols.TCP
handleDownEvent(org.jgroups.Event) - method in class org.jgroups.protocols.TOTAL_TOKEN
Handle down event.
handleDownEvent(org.jgroups.Event) - method in class org.jgroups.protocols.TP
handleExit() - method in class org.jgroups.protocols.pbcast.CoordGmsImpl
handleExit() - method in class org.jgroups.protocols.pbcast.GmsImpl
handleFlush(Vector,long[]) - method in class org.jgroups.protocols.FLUSH
Called by coordinator running the FLUSH protocol.
handleIncomingMessage(org.jgroups.Message) - method in class org.jgroups.protocols.TUNNEL
handleJoin(org.jgroups.Address) - method in class org.jgroups.protocols.ClientGmsImpl
handleJoin(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.ClientGmsImpl
handleJoin(org.jgroups.Address) - method in class org.jgroups.protocols.CoordGmsImpl
handleJoin(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.CoordGmsImpl
Computes the new view (including the newly joined member) and get the digest from PBCAST.
handleJoin(org.jgroups.Address) - method in class org.jgroups.protocols.GMS
handleJoin(org.jgroups.Address) - method in class org.jgroups.protocols.GmsImpl
handleJoin(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.GmsImpl
handleJoin(org.jgroups.Address) - method in class org.jgroups.protocols.ParticipantGmsImpl
handleJoin(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
handleJoinResponse(org.jgroups.protocols.pbcast.JoinRsp) - method in class org.jgroups.protocols.pbcast.ClientGmsImpl
handleJoinResponse(org.jgroups.protocols.pbcast.JoinRsp) - method in class org.jgroups.protocols.pbcast.CoordGmsImpl
handleJoinResponse(org.jgroups.protocols.pbcast.JoinRsp) - method in class org.jgroups.protocols.pbcast.GmsImpl
handleLeave(org.jgroups.Address,boolean) - method in class org.jgroups.protocols.ClientGmsImpl
Returns false.
handleLeave(org.jgroups.Address,boolean) - method in class org.jgroups.protocols.pbcast.ClientGmsImpl
Returns false.
handleLeave(org.jgroups.Address,boolean) - method in class org.jgroups.protocols.CoordGmsImpl
Exclude mbr from the membership.
handleLeave(org.jgroups.Address,boolean) - method in class org.jgroups.protocols.pbcast.CoordGmsImpl
Exclude mbr from the membership.
handleLeave(org.jgroups.Address,boolean) - method in class org.jgroups.protocols.GMS
handleLeave(org.jgroups.Address,boolean) - method in class org.jgroups.protocols.GmsImpl
handleLeave(org.jgroups.Address,boolean) - method in class org.jgroups.protocols.pbcast.GmsImpl
handleLeave(org.jgroups.Address,boolean) - method in class org.jgroups.protocols.ParticipantGmsImpl
handleLeave(org.jgroups.Address,boolean) - method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
handleLeaveResponse() - method in class org.jgroups.protocols.pbcast.ClientGmsImpl
handleLeaveResponse() - method in class org.jgroups.protocols.pbcast.CoordGmsImpl
handleLeaveResponse() - method in class org.jgroups.protocols.pbcast.GmsImpl
handleLeaveResponse() - method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
handleMerge(org.jgroups.ViewId,Vector) - method in class org.jgroups.protocols.ClientGmsImpl
Returns immediately.
handleMerge(org.jgroups.ViewId,Vector) - method in class org.jgroups.protocols.CoordGmsImpl
Invoked by another coordinator that asks to merge its view with mine.
handleMerge(org.jgroups.ViewId,Vector) - method in class org.jgroups.protocols.GMS
handleMerge(org.jgroups.ViewId,Vector) - method in class org.jgroups.protocols.GmsImpl
handleMerge(org.jgroups.ViewId,Vector) - method in class org.jgroups.protocols.ParticipantGmsImpl
handleMergeCancelled(org.jgroups.ViewId) - method in class org.jgroups.protocols.pbcast.CoordGmsImpl
handleMergeCancelled(org.jgroups.ViewId) - method in class org.jgroups.protocols.pbcast.GmsImpl
handleMergeRequest(org.jgroups.Address,org.jgroups.ViewId) - method in class org.jgroups.protocols.pbcast.CoordGmsImpl
Get the view and digest and send back both (MergeData) in the form of a MERGE_RSP to the sender.
handleMergeRequest(org.jgroups.Address,org.jgroups.ViewId) - method in class org.jgroups.protocols.pbcast.GmsImpl
If merge_id is not equal to this.merge_id then discard.
handleMessage(org.jgroups.Message) - method in class org.jgroups.blocks.PullPushAdapter
Check whether the message has an identifier.
handleNotification(Serializable) - method in class org.jgroups.blocks.NotificationBus.Consumer
handleNotification(Serializable) - method in class org.jgroups.demos.NotificationBusDemo
handleRollback(org.jgroups.blocks.Xid) - method in class org.jgroups.blocks.ReplicationManager
handleSpecialDownEvent(org.jgroups.Event) - method in class org.jgroups.stack.Protocol
These are special internal events that should not be handled by protocols
handleSuspect(org.jgroups.Address) - method in class org.jgroups.protocols.ClientGmsImpl
Returns immediately.
handleSuspect(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.ClientGmsImpl
Returns immediately.
handleSuspect(org.jgroups.Address) - method in class org.jgroups.protocols.CoordGmsImpl
handleSuspect(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.CoordGmsImpl
handleSuspect(org.jgroups.Address) - method in class org.jgroups.protocols.GMS
handleSuspect(org.jgroups.Address) - method in class org.jgroups.protocols.GmsImpl
handleSuspect(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.GmsImpl
handleSuspect(org.jgroups.Address) - method in class org.jgroups.protocols.ParticipantGmsImpl
handleSuspect(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
handleUpEvent(org.jgroups.Event) - method in class org.jgroups.protocols.ClientGmsImpl
handleUpEvent(org.jgroups.Event) - method in class org.jgroups.protocols.pbcast.ClientGmsImpl
handleUpEvent(org.jgroups.Event) - method in class org.jgroups.protocols.DEADLOCK
Callback.
handleUpEvent(org.jgroups.Event) - method in class org.jgroups.protocols.FLOW_CONTROL
If Event.MSG type is received message, number of received messages from the sender is incremented.
handleUpEvent(org.jgroups.Event) - method in class org.jgroups.protocols.FLUSH
Callback.
handleUpEvent(org.jgroups.Event) - method in class org.jgroups.protocols.GMS
Callback.
handleUpEvent(org.jgroups.Event) - method in class org.jgroups.protocols.GmsImpl
handleUpEvent(org.jgroups.Event) - method in class org.jgroups.protocols.pbcast.GmsImpl
handleUpEvent(org.jgroups.Event) - method in class org.jgroups.stack.MessageProtocol
Handle up event.
handleUpEvent(org.jgroups.Event) - method in class org.jgroups.protocols.MessageProtocolEXAMPLE
Callback.
handleUpEvent(org.jgroups.Event) - method in class org.jgroups.stack.RpcProtocol
Handle up event.
handleUpEvent(org.jgroups.Event) - method in class org.jgroups.protocols.RpcProtocolEXAMPLE
Callback.
handleUpEvent(org.jgroups.Event) - method in class org.jgroups.protocols.STABLE
Callback.
handleUpEvent(org.jgroups.Event) - method in class org.jgroups.protocols.TOTAL_TOKEN
Handle up event.
handleView(org.jgroups.View) - method in class org.jgroups.util.AckCollector
Does nothing.
Called by the GMS when a VIEW is received.
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(org.jgroups.ViewId,Vector) - method in class org.jgroups.protocols.ClientGmsImpl
Install the first view in which we are a member.
handleViewChange(org.jgroups.ViewId,Vector) - method in class org.jgroups.protocols.CoordGmsImpl
handleViewChange(org.jgroups.ViewId,Vector) - method in class org.jgroups.protocols.GMS
handleViewChange(org.jgroups.ViewId,Vector) - method in class org.jgroups.protocols.GmsImpl
handleViewChange(org.jgroups.ViewId,Vector) - method in class org.jgroups.protocols.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.
hashCode() - method in class org.jgroups.conf.ClassMap
hashCode() - method in class org.jgroups.blocks.DistributedLockManager.LockDecree
This is hashcode from the java.lang.Long class.
hashCode() - method in class org.jgroups.protocols.pbcast.Gossip
hashCode() - method in class org.jgroups.stack.IpAddress
hashCode() - method in class org.jgroups.protocols.JMS.JMSAddress
Get the hash code of this address.
hashCode() - method in class org.jgroups.blocks.Link
hashCode() - method in class org.jgroups.stack.LogicalAddress
hashCode() - method in class org.jgroups.conf.ProtocolData
hashCode() - method in class org.jgroups.conf.ProtocolParameter
hashCode() - method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
hashCode() - method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseVoteWrapper
hashCode() - method in class org.jgroups.ViewId
hashCode() - method in class org.jgroups.protocols.WanPipeAddress
hashCode() - method in class org.jgroups.blocks.Xid
hasResult() - method in class org.jgroups.util.Promise
Checks whether result is available.
HDR_OVERHEAD - static field in class org.jgroups.Header
HDRS - class org.jgroups.protocols.HDRS
Example of a protocol layer.
head - field in class org.jgroups.util.List
Header - class org.jgroups.Header
Abstract base class for all headers to be added to a Message.
The header for RequestCorrelator messages
TOTAL.Header - class org.jgroups.protocols.TOTAL.Header
The header processed by the TOTAL layer and intended for TOTAL inter-stack communication
Header() - constructor for class org.jgroups.Header
Header() - constructor for class org.jgroups.blocks.RequestCorrelator.Header
Used for externalization
Header() - constructor for class org.jgroups.protocols.TOTAL.Header
used for externalization
Header(byte,long,boolean,String) - constructor for class org.jgroups.blocks.RequestCorrelator.Header
Header(int,long,long) - constructor for class org.jgroups.protocols.TOTAL.Header
Create a header for the TOTAL layer
headers - field in class org.jgroups.Message
Map
HEARD_FROM - static field in class org.jgroups.Event
HEARTBEAT - static field in class org.jgroups.protocols.FD.FdHeader
HEARTBEAT_ACK - static field in class org.jgroups.protocols.FD.FdHeader
height - field in class org.jgroups.demos.wb.Node
HELLO - static field in class org.jgroups.protocols.MERGE.MergeHeader
helvetica_12 - static field in class org.jgroups.debug.Debugger
high - field in class org.jgroups.util.Range
high_seqno - field in class org.jgroups.protocols.pbcast.Digest.Entry
high_seqno_seen - field in class org.jgroups.protocols.pbcast.Digest.Entry
highest_seqnos - field in class org.jgroups.protocols.Digest
highSeqnoAt(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.Digest
highSeqnoSeenAt(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.Digest
host - field in class org.jgroups.stack.LogicalAddress
HTOTAL - class org.jgroups.protocols.HTOTAL
Implementation of UTO-TCP as designed by EPFL.
HTOTAL() - constructor for class org.jgroups.protocols.HTOTAL
HTOTAL.HTotalHeader - class org.jgroups.protocols.HTOTAL.HTotalHeader
HTotalHeader() - constructor for class org.jgroups.protocols.HTOTAL.HTotalHeader

I

I_HAVE_SOCK - static field in class org.jgroups.protocols.FD_SOCK.FdHeader
id - field in class org.jgroups.protocols.FragHeader
id - field in class org.jgroups.stack.LogicalAddress
id - field in class org.jgroups.blocks.MessageDispatcher
ID - static field in class org.jgroups.blocks.MethodCall
Use an ID to map to a method
id - field in class org.jgroups.blocks.RequestCorrelator.Header
The id of this request to distinguish among other requests from the same RequestCorrelator
id - field in class org.jgroups.blocks.Xid
impl_mutex - field in class org.jgroups.protocols.GMS
increment() - method in class org.jgroups.protocols.VectorTime
Incerements owners current vector value by 1
incrementHighSeqno(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.Digest
Increments the sender's high_seqno by 1.
incrementTokenSequence() - method in class org.jgroups.protocols.ring.RingToken
indexOf(org.jgroups.Address) - method in class org.jgroups.protocols.VectorTime
Returns index of the given member represented by it's Address
init() - method in class org.jgroups.protocols.AUTOCONF
Called after instance has been created (null constructor) and before protocol is started.
init() - method in class org.jgroups.protocols.BSH
init() - method in class org.jgroups.conf.ClassConfigurator
init() - method in class org.jgroups.protocols.ClientGmsImpl
init() - method in class org.jgroups.protocols.pbcast.ClientGmsImpl
init() - method in class org.jgroups.protocols.COMPRESS
Called after instance has been created (null constructor) and before protocol is started.
init() - method in class org.jgroups.blocks.ConnectionTable
init() - method in class org.jgroups.blocks.ConnectionTableNIO
init() - method in class org.jgroups.protocols.CoordGmsImpl
init() - method in class org.jgroups.protocols.pbcast.CoordGmsImpl
init() - method in class org.jgroups.blocks.DistributedQueue
init() - method in class org.jgroups.demos.applets.DrawApplet
init() - method in class org.jgroups.protocols.DUMMY_TP
init() - method in class org.jgroups.protocols.ENCRYPT
Called after instance has been created (null constructor) and before protocol is started.
init() - method in class org.jgroups.protocols.ENCRYPT1_4
init() - method in class org.jgroups.protocols.FD
init() - method in class org.jgroups.protocols.FD_SIMPLE
Called after instance has been created (null constructor) and before protocol is started.
init() - method in class org.jgroups.protocols.FD_SOCK
init() - method in class org.jgroups.protocols.pbcast.GMS
init() - method in class org.jgroups.protocols.GmsImpl
init() - method in class org.jgroups.protocols.pbcast.GmsImpl
init() - method in class org.jgroups.protocols.LOOPBACK
init() - method in class org.jgroups.protocols.MERGE3
init() - method in class org.jgroups.protocols.NAKACK
Do some initial tasks
init() - method in class org.jgroups.protocols.pbcast.NAKACK
Called after instance has been created (null constructor) and before protocol is started.
init() - method in class org.jgroups.protocols.ParticipantGmsImpl
init() - method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
init() - method in class org.jgroups.protocols.PERF_TP
Called after instance has been created (null constructor) and before protocol is started.
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.protocols.SIZE
init() - method in class org.jgroups.protocols.STATE_TRANSFER
Called after instance has been created (null constructor) and before protocol is started.
init() - method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
init() - method in class org.jgroups.protocols.TUNNEL
init() - method in class org.jgroups.protocols.UDP_NIO
init() - method in class org.jgroups.demos.wb.Whiteboard
init(InputStream) - method in class org.jgroups.persistence.DBPersistenceManager
used to intitiailize complete DB access.
init(long) - method in class org.jgroups.blocks.DistributedHashtable
init(String,List) - method in class org.jgroups.stack.LogicalAddress
INIT_CONNECTION_FACTORY - static field in class org.jgroups.protocols.JMS
INIT_JNDI_CONTEXT - static field in class org.jgroups.protocols.JMS
INIT_PROVIDER_URL - static field in class org.jgroups.protocols.JMS
INIT_TOPIC_NAME - static field in class org.jgroups.protocols.JMS
initKeyPair() - method in class org.jgroups.protocols.ENCRYPT
Generates the public/private key pair from the init params
initSymKey() - method in class org.jgroups.protocols.ENCRYPT
Used to initialise the symmetric key if none is supplied in a keystore.
initSymKey() - static method in class org.jgroups.demos.KeyStoreGenerator
Inserts an already created (and initialized) protocol into the protocol list.
Inserts an already created (and initialized) protocol into the protocol list.
INSTALL_MERGE_VIEW - static field in class org.jgroups.protocols.pbcast.GMS.GmsHeader
installTransitionalView(Vector) - method in class org.jgroups.protocols.TOTAL_TOKEN
installView(org.jgroups.View) - method in class org.jgroups.protocols.pbcast.GMS
Sets the new view and sends a VIEW_CHANGE event up and down the stack.
installView(org.jgroups.View,org.jgroups.protocols.pbcast.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(org.jgroups.ViewId,Vector) - method in class org.jgroups.protocols.GMS
Assigns the new ltime.
INT_SIZE - static field in class org.jgroups.Global
Value is .
internalQueue - field in class org.jgroups.blocks.DistributedQueue
Interval - class org.jgroups.stack.Interval
Manages retransmission timeouts.
Interval(long[]) - constructor for class org.jgroups.stack.Interval
invalidate() - method in class org.jgroups.protocols.ring.RingNodeFlowControl
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
IpAddress - class org.jgroups.stack.IpAddress
Network-dependent address (Internet).
IpAddress() - 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(String,int) - constructor for class org.jgroups.stack.IpAddress
is_server - field in class org.jgroups.protocols.PingRsp
isAbort() - method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
isAlive() - method in class org.jgroups.util.ReusableThread
isBindAddressPropertyIgnored() - static method in class org.jgroups.util.Util
isBindToAllInterfaces() - method in class org.jgroups.jmx.protocols.MPING
isBindToAllInterfaces() - method in class org.jgroups.protocols.MPING
isBindToAllInterfaces() - method in class org.jgroups.jmx.protocols.MPINGMBean
isBlocked() - method in class org.jgroups.jmx.protocols.FC
isBlocked() - method in class org.jgroups.protocols.FC
isBlocked() - method in class org.jgroups.jmx.protocols.FCMBean
Determines if the vector clock represented by TransportedVectorTime is causally next to this VectorTime
isCommit() - method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
isConnected() - method in class org.jgroups.Channel
Determines whether the channel is connected to a group.
isConnected() - method in class org.jgroups.JChannel
returns true if the Connect operation has been called successfully
isConnected() - method in class org.jgroups.jmx.JChannel
isConnected() - method in class org.jgroups.jmx.JChannelMBean
isConnected() - method in class org.jgroups.stack.RouterStub
isCoord() - method in class org.jgroups.protocols.PingRsp
isCoordinator() - method in class org.jgroups.jmx.protocols.pbcast.GMS
isCoordinator() - method in class org.jgroups.protocols.pbcast.GMS
isCoordinator() - method in class org.jgroups.jmx.protocols.pbcast.GMSMBean
isCoordinator() - method in class org.jgroups.blocks.NotificationBus
isDiscardDeliveredMsgs() - method in class org.jgroups.jmx.protocols.pbcast.NAKACK
isDiscardDeliveredMsgs() - method in class org.jgroups.protocols.pbcast.NAKACK
isDiscardDeliveredMsgs() - method in class org.jgroups.jmx.protocols.pbcast.NAKACKMBean
isDiscardIncompatiblePackets() - method in class org.jgroups.jmx.protocols.TP
isDiscardIncompatiblePackets() - method in class org.jgroups.protocols.TP
isDiscardIncompatiblePackets() - method in class org.jgroups.jmx.protocols.TPMBean
isDone() - method in class org.jgroups.blocks.GroupRequest
isEnableBundling() - method in class org.jgroups.jmx.protocols.TP
isEnableBundling() - method in class org.jgroups.protocols.TP
isEnableBundling() - method in class org.jgroups.jmx.protocols.TPMBean
isLoopback() - method in class org.jgroups.protocols.TCP
isLoopback() - method in class org.jgroups.jmx.protocols.TP
isLoopback() - method in class org.jgroups.protocols.TP
isLoopback() - method in class org.jgroups.jmx.protocols.TPMBean
isMulticastAddress() - method in class org.jgroups.Address
Checks whether this is an address that represents multiple destinations; e.g., a class D address in the Internet.
isMulticastAddress() - method in class org.jgroups.stack.IpAddress
Checks whether this is an address that represents multiple destinations; e.g., a class D address in the Internet.
isMulticastAddress() - method in class org.jgroups.protocols.JMS.JMSAddress
Is the address a multicast address?
isMulticastAddress() - method in class org.jgroups.stack.LogicalAddress
isMulticastAddress() - method in class org.jgroups.protocols.WanPipeAddress
Checks whether this is an address that represents multiple destinations; e.g., a class D address in the Internet.
isMultipleLocked() - method in class org.jgroups.blocks.DistributedLockManager.LockDecree
isOpen() - method in class org.jgroups.Channel
Determines whether the channel is open; i.e., the protocol stack has been created (may not be connected though).
isOpen() - method in class org.jgroups.JChannel
returns true if the Open operation has been called successfully
isOpen() - method in class org.jgroups.jmx.JChannel
isOpen() - method in class org.jgroups.jmx.JChannelMBean
isOverride() - method in class org.jgroups.conf.ProtocolData
isPrepare() - method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
isReceived(org.jgroups.Address) - method in class org.jgroups.util.RspList
isReceiveOnAllInterfaces() - method in class org.jgroups.jmx.protocols.TP
isReceiveOnAllInterfaces() - method in class org.jgroups.protocols.TP
isReceiveOnAllInterfaces() - method in class org.jgroups.jmx.protocols.TPMBean
isRunning() - method in class org.jgroups.protocols.PingSender
isRunning() - method in class org.jgroups.protocols.PingWaiter
isSendOnAllInterfaces() - method in class org.jgroups.jmx.protocols.TP
isSendOnAllInterfaces() - method in class org.jgroups.protocols.TP
isSendOnAllInterfaces() - method in class org.jgroups.jmx.protocols.TPMBean
isServer() - method in class org.jgroups.protocols.PingRsp
isShun() - method in class org.jgroups.jmx.protocols.FD
isShun() - method in class org.jgroups.protocols.FD
isShun() - method in class org.jgroups.jmx.protocols.FDMBean
isShun() - method in class org.jgroups.jmx.protocols.pbcast.GMS
isShun() - method in class org.jgroups.protocols.pbcast.GMS
isShun() - method in class org.jgroups.jmx.protocols.pbcast.GMSMBean
isStarted() - method in class org.jgroups.stack.GossipRouter
isSuspected(org.jgroups.Address) - method in class org.jgroups.util.RspList
isSuspended() - method in class org.jgroups.JChannel
isSuspended() - method in class org.jgroups.jmx.JChannel
isSuspended() - method in class org.jgroups.jmx.JChannelMBean
isTrace() - method in class org.jgroups.jmx.Protocol
isTrace() - method in class org.jgroups.stack.Protocol
isTrace() - method in class org.jgroups.jmx.ProtocolMBean
isUseIncomingPacketHandler() - method in class org.jgroups.jmx.protocols.TP
isUseIncomingPacketHandler() - method in class org.jgroups.protocols.TP
isUseIncomingPacketHandler() - method in class org.jgroups.jmx.protocols.TPMBean
isUseMcastXmit() - method in class org.jgroups.jmx.protocols.pbcast.NAKACK
isUseMcastXmit() - method in class org.jgroups.protocols.pbcast.NAKACK
isUseMcastXmit() - method in class org.jgroups.jmx.protocols.pbcast.NAKACKMBean
isUseOutgoingPacketHandler() - method in class org.jgroups.protocols.TP
isUseOutgoungPacketHandler() - method in class org.jgroups.jmx.protocols.TP
isUseOutgoungPacketHandler() - method in class org.jgroups.jmx.protocols.TPMBean
isValid() - method in class org.jgroups.blocks.DistributedLockManager.AcquireLockDecree
Lock aquire decree is valid for a ACQUIRE_EXPIRATION time after creation and if the lock is still valid (in the future locks will be leased for a predefined period of time).
isValid() - method in class org.jgroups.blocks.DistributedLockManager.LockDecree
This is a place-holder for future lock expiration code.
isViewHandlerSuspended() - method in class org.jgroups.jmx.protocols.pbcast.GMS
isViewHandlerSuspended() - method in class org.jgroups.protocols.pbcast.GMS
isViewHandlerSuspended() - method in class org.jgroups.jmx.protocols.pbcast.GMSMBean
isWarn() - method in class org.jgroups.jmx.Protocol
isWarn() - method in class org.jgroups.stack.Protocol
isWarn() - method in class org.jgroups.jmx.ProtocolMBean
isXmitFromRandomMember() - method in class org.jgroups.jmx.protocols.pbcast.NAKACK
isXmitFromRandomMember() - method in class org.jgroups.protocols.pbcast.NAKACK
isXmitFromRandomMember() - method in class org.jgroups.jmx.protocols.pbcast.NAKACKMBean
iWouldBeCoordinator(Vector) - method in class org.jgroups.protocols.GmsImpl
Returns potential coordinator based on lexicographic ordering of member addresses.
iWouldBeCoordinator(Vector) - method in class org.jgroups.protocols.pbcast.GmsImpl
Returns potential coordinator based on lexicographic ordering of member addresses.

J

JAXP_MISSING_ERROR_MSG - static field in class org.jgroups.conf.ConfiguratorFactory
JChannel - class org.jgroups.JChannel
JChannel is a pure Java implementation of Channel.
JChannel - class org.jgroups.jmx.JChannel
JChannel() - constructor for class org.jgroups.JChannel
Constructs a JChannel instance with the protocol stack specified by the DEFAULT_PROTOCOL_STACK member.
JChannel() - constructor for class org.jgroups.jmx.JChannel
JChannel(Element) - constructor for class org.jgroups.JChannel
Constructs a JChannel instance with the protocol stack configuration contained by the specified XML element.
JChannel(File) - constructor for class org.jgroups.JChannel
Constructs a JChannel instance with the protocol stack configuration contained by the specified file.
JChannel(Object) - constructor for class org.jgroups.JChannel
Creates a new JChannel with the protocol stack as defined in the properties parameter.
Constructs a JChannel instance with the protocol stack configuration contained by the protocol stack configurator parameter.
JChannel(org.jgroups.JChannel) - constructor for class org.jgroups.jmx.JChannel
JChannel(String) - constructor for class org.jgroups.JChannel
Constructs a JChannel instance with the protocol stack configuration based upon the specified properties parameter.
JChannel(URL) - constructor for class org.jgroups.JChannel
Constructs a JChannel instance with the protocol stack configuration indicated by the specified URL.
JChannelFactory - class org.jgroups.JChannelFactory
JChannelFactory creates pure Java implementations of the Channel interface.
JChannelFactory() - constructor for class org.jgroups.JChannelFactory
Constructs a JChannelFactory instance that contains no protocol stack configuration.
JChannelFactory(Element) - constructor for class org.jgroups.JChannelFactory
Constructs a JChannelFactory instance that utilizes the specified file for protocl stack configuration.
JChannelFactory(File) - constructor for class org.jgroups.JChannelFactory
Constructs a JChannelFactory instance that utilizes the specified file for protocl stack configuration.
JChannelFactory(String) - constructor for class org.jgroups.JChannelFactory
Constructs a JChannel instance with the protocol stack configuration based upon the specified properties parameter.
JChannelFactory(URL) - constructor for class org.jgroups.JChannelFactory
Constructs a JChannelFactory instance that utilizes the specified file for protocl stack configuration.
JChannelMBean - interface org.jgroups.jmx.JChannelMBean
JMS - class org.jgroups.protocols.JMS
Implementation of the transport protocol using the Java Message Service (JMS).
JMS() - constructor for class org.jgroups.protocols.JMS
Empty constructor.
JMS.JMSAddress - class org.jgroups.protocols.JMS.JMSAddress
Simple Address representing the JMS node ID or JMS topic group.
JmxConfigurator - class org.jgroups.jmx.JmxConfigurator
join(org.jgroups.Address) - method in class org.jgroups.protocols.ClientGmsImpl
Will generate a CONNECT_OK event.
join(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.ClientGmsImpl
Joins this process to a group.
join(org.jgroups.Address) - method in class org.jgroups.protocols.CoordGmsImpl
join(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.CoordGmsImpl
join(org.jgroups.Address) - method in class org.jgroups.protocols.GMS
join(org.jgroups.Address) - method in class org.jgroups.protocols.GmsImpl
join(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.GmsImpl
join(org.jgroups.Address) - method in class org.jgroups.protocols.ParticipantGmsImpl
join(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
JOIN_ANNOUNCEMENT - static field in class org.jgroups.protocols.SMACK.SmackHeader
JOIN_REQ - static field in class org.jgroups.protocols.pbcast.GMS.GmsHeader
join_retry_timeout - field in class org.jgroups.protocols.GMS
JOIN_RSP - static field in class org.jgroups.protocols.pbcast.GMS.GmsHeader
join_timeout - field in class org.jgroups.protocols.GMS
JoinRsp - class org.jgroups.protocols.pbcast.JoinRsp
JoinRsp() - constructor for class org.jgroups.protocols.pbcast.JoinRsp
JoinRsp(org.jgroups.View,org.jgroups.protocols.pbcast.Digest) - constructor for class org.jgroups.protocols.pbcast.JoinRsp

K

KEY_REQUEST - static field in class org.jgroups.protocols.ENCRYPT.EncryptHeader
KeyStoreGenerator - class org.jgroups.demos.KeyStoreGenerator
Generates a keystore file that has a SecretKey in it.

L

lbl - field in class org.jgroups.demos.wb.Node
leave(org.jgroups.Address) - method in class org.jgroups.protocols.ClientGmsImpl
leave(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.ClientGmsImpl
leave(org.jgroups.Address) - method in class org.jgroups.protocols.CoordGmsImpl
The coordinator itself wants to leave the group
leave(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.CoordGmsImpl
The coordinator itself wants to leave the group
leave(org.jgroups.Address) - method in class org.jgroups.protocols.GMS
leave(org.jgroups.Address) - method in class org.jgroups.protocols.GmsImpl
leave(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.GmsImpl
leave(org.jgroups.Address) - method in class org.jgroups.protocols.ParticipantGmsImpl
Loop: determine coord.
leave(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
Loop: determine coord.
LEAVE_ANNOUNCEMENT - static field in class org.jgroups.protocols.SMACK.SmackHeader
LEAVE_REQ - static field in class org.jgroups.protocols.pbcast.GMS.GmsHeader
LEAVE_RSP - static field in class org.jgroups.protocols.pbcast.GMS.GmsHeader
leave_timeout - field in class org.jgroups.protocols.GMS
length - field in class org.jgroups.Message
The number of bytes in the buffer (usually buf.length is buf not equal to null).
Checks if this TransportedVectorTime is less than or equal to the the specified TransportedVectorTime.
Link - class org.jgroups.blocks.Link
Implements a physical link between 2 parties (point-to-point connection).
Link(String,int,String,int) - constructor for class org.jgroups.blocks.Link
Link(String,int,String,int,org.jgroups.blocks.Link.Receiver) - constructor for class org.jgroups.blocks.Link
linkDown(InetAddress,int,InetAddress,int) - method in class org.jgroups.blocks.Link.Receiver
linkDown(InetAddress,int,InetAddress,int) - method in class org.jgroups.blocks.LogicalLink
One of the physical links went down
linkDown(InetAddress,int,InetAddress,int) - method in class org.jgroups.protocols.WANPIPE
LinkedListQueue - class org.jgroups.util.LinkedListQueue
LinkedListQueue implementation based on java.util.Queue.
LinkedListQueue() - constructor for class org.jgroups.util.LinkedListQueue
creates an empty queue
linkUp(InetAddress,int,InetAddress,int) - method in class org.jgroups.blocks.Link.Receiver
linkUp(InetAddress,int,InetAddress,int) - method in class org.jgroups.blocks.LogicalLink
One of the physical links came up
linkUp(InetAddress,int,InetAddress,int) - method in class org.jgroups.protocols.WANPIPE
List - class org.jgroups.util.List
Doubly-linked list.
List() - constructor for class org.jgroups.util.List
listAlphabet() - method in class org.jgroups.demos.CausalDemo
listener - field in class org.jgroups.blocks.PullPushAdapter
listeners - field in class org.jgroups.blocks.PullPushAdapter
Adds the given interface address to the list of interfaces on which the receiver mcast socket has to listen.
loadClass(String,Class) - static method in class org.jgroups.util.Util
Tries to load the class from the current thread's context class loader.
LOCAL - static field in class org.jgroups.Channel
local_addr - field in class org.jgroups.protocols.GMS
local_addr - field in class org.jgroups.blocks.MessageDispatcher
local_addr - field in class org.jgroups.blocks.RequestCorrelator
The address of this group member
localAddressSet(org.jgroups.Address) - method in class org.jgroups.protocols.Discovery
Called after local_addr was set
localAddressSet(org.jgroups.Address) - method in class org.jgroups.protocols.PING
localAddressSet(org.jgroups.Address) - method in class org.jgroups.protocols.TCPPING
Called after local_addr was set
localSequenceID - field in class org.jgroups.protocols.TOTAL.Header
The ID used by the message source to match replies from the sequencer
localVote(Object) - method in class org.jgroups.blocks.VotingAdapter
This method performs voting on the specific decree between all local voteListeners.
lock() - method in class org.jgroups.util.ReentrantLatch
Lock the latch.
lock(Object,Object,int) - method in class org.jgroups.blocks.DistributedLockManager
Locks an object with lockId on behalf of the specified owner.
lock(Object,Object,int) - method in class org.jgroups.blocks.LockManager
Obtain lock on obj for specified owner.
This class represents the lock
lockId - field in class org.jgroups.blocks.DistributedLockManager.LockDecree
LockingException - class org.jgroups.blocks.LockingException
LockingException(Map) - constructor for class org.jgroups.blocks.LockingException
LockingException(String) - constructor for class org.jgroups.blocks.LockingException
LockManager - interface org.jgroups.blocks.LockManager
LockManager represents generic lock manager that allows obtaining and releasing locks on objects.
Thrown by the DistributedLockManager.unlock(Object,Object,boolean) method if a lock is only locally released, because it is locked by multiple DistributedLockManagers.
LockMultiLockedException() - constructor for class org.jgroups.blocks.LockMultiLockedException
LockMultiLockedException(String) - constructor for class org.jgroups.blocks.LockMultiLockedException
This exception indicated that lock manager refused to give a lock on some resource.
LockNotGrantedException() - constructor for class org.jgroups.blocks.LockNotGrantedException
LockNotGrantedException(String) - constructor for class org.jgroups.blocks.LockNotGrantedException
This exception indicated that lock manager refused to release a lock on some resource.
LockNotReleasedException() - constructor for class org.jgroups.blocks.LockNotReleasedException
LockNotReleasedException(String) - constructor for class org.jgroups.blocks.LockNotReleasedException
log - static field in class org.jgroups.stack.AckMcastReceiverWindow
log - static field in class org.jgroups.stack.AckMcastSenderWindow
log - field in class org.jgroups.conf.ClassConfigurator
log - field in class org.jgroups.stack.Configurator
log - field in class org.jgroups.blocks.ConnectionTable
LOG - static field in class org.jgroups.blocks.ConnectionTableNIO
log - field in class org.jgroups.persistence.DBPersistenceManager
log - static field in class org.jgroups.protocols.pbcast.Digest
log - field in class org.jgroups.blocks.DistributedHashtable
log - field in class org.jgroups.blocks.DistributedLockManager
log - static field in class org.jgroups.blocks.DistributedTree
log - field in class org.jgroups.protocols.GmsImpl
log - field in class org.jgroups.protocols.pbcast.GmsImpl
log - field in class org.jgroups.stack.GossipClient
log - field in class org.jgroups.stack.GossipRouter
log - field in class org.jgroups.stack.GossipServer
log - static field in class org.jgroups.stack.IpAddress
log - field in class org.jgroups.JChannel
log - static field in class org.jgroups.util.LinkedListQueue
log - static field in class org.jgroups.conf.MagicNumberReader
log - static field in class org.jgroups.Membership
log - static field in class org.jgroups.Message
log - field in class org.jgroups.blocks.MessageDispatcher
log - static field in class org.jgroups.blocks.MethodCall
log - static field in class org.jgroups.stack.NakReceiverWindow
log - field in class org.jgroups.blocks.NotificationBus
log - static field in class org.jgroups.persistence.PersistenceFactory
log - field in class org.jgroups.protocols.PingSender
log - field in class org.jgroups.protocols.PingWaiter
log - field in class org.jgroups.stack.Protocol
log - field in class org.jgroups.debug.ProtocolTester
log - field in class org.jgroups.blocks.PullPushAdapter
log - static field in class org.jgroups.util.Queue
log - static field in class org.jgroups.util.Queue2
log - field in class org.jgroups.blocks.ReplicatedHashtable
log - field in class org.jgroups.blocks.ReplicatedTree
log - field in class org.jgroups.blocks.ReplicationManager
log - static field in class org.jgroups.blocks.RequestCorrelator
log - static field in class org.jgroups.stack.Retransmitter
log - static field in class org.jgroups.util.ReusableThread
log - field in class org.jgroups.protocols.ring.RingNodeFlowControl
log - field in class org.jgroups.stack.Router
log - static field in class org.jgroups.stack.RouterStub
log - static field in class org.jgroups.util.Scheduler
log - field in class org.jgroups.protocols.ring.TcpRingNode
log - static field in class org.jgroups.util.ThreadPool
log - static field in class org.jgroups.util.TimeScheduler
log - field in class org.jgroups.blocks.VotingAdapter
log - static field in class org.jgroups.conf.XmlConfigurator
logger - field in class org.jgroups.blocks.DistributedQueue
LogicalAddress - class org.jgroups.stack.LogicalAddress
Logical address that spans the lifetime of a member.
LogicalAddress() - constructor for class org.jgroups.stack.LogicalAddress
LogicalAddress(String,List) - constructor for class org.jgroups.stack.LogicalAddress
Use this constructor to create an instance, not the null-constructor
LogicalLink - class org.jgroups.blocks.LogicalLink
Implements a logical point-to-point link between 2 entities consisting of a number of physical links.
LogicalLink() - constructor for class org.jgroups.blocks.LogicalLink
LogicalLink(org.jgroups.blocks.LogicalLink.Receiver) - constructor for class org.jgroups.blocks.LogicalLink
LONG_SIZE - static field in class org.jgroups.Global
Value is .
LOOPBACK - class org.jgroups.protocols.LOOPBACK
Makes copies of outgoing messages, swaps sender and receiver and sends the message back up the stack.
LOOPBACK() - constructor for class org.jgroups.protocols.LOOPBACK
LOSS - class org.jgroups.protocols.LOSS
Example of a protocol layer.
low - field in class org.jgroups.util.Range
low_seqno - field in class org.jgroups.protocols.pbcast.Digest.Entry
lowSeqnoAt(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.Digest
ltime - field in class org.jgroups.protocols.GMS

M

MAGIC_NUMBER_FILE - static field in class org.jgroups.conf.MagicNumberReader
MagicNumberReader - class org.jgroups.conf.MagicNumberReader
Reads and maintains mapping between magic numbers and classes
Uses magic numbers for class descriptors
MagicObjectInputStream(InputStream) - constructor for class org.jgroups.util.MagicObjectInputStream
Uses magic numbers for class descriptors
MagicObjectOutputStream(OutputStream) - constructor for class org.jgroups.util.MagicObjectOutputStream
main(args[]) - static method in class org.jgroups.demos.CausalDemo
main(args[]) - static method in class org.jgroups.stack.Configurator
main(args[]) - static method in class org.jgroups.demos.DistributedHashtableDemo
main(args[]) - static method in class org.jgroups.demos.DistributedTreeDemo
main(args[]) - static method in class org.jgroups.demos.QuoteClient
main(args[]) - static method in class org.jgroups.demos.QuoteServer
main(args[]) - static method in class org.jgroups.demos.ReplicatedTreeDemo
main(args[]) - static method in class org.jgroups.demos.TotalTokenDemo
main(args[]) - static method in class org.jgroups.util.Util
main(args[]) - static method in class org.jgroups.demos.ViewDemo
main(args[]) - static method in class org.jgroups.protocols.WanPipeAddress
main(String[]) - static method in class org.jgroups.stack.AckMcastReceiverWindow
main(String[]) - static method in class org.jgroups.stack.AckSenderWindow
main(String[]) - static method in class org.jgroups.protocols.AUTOCONF
main(String[]) - static method in class org.jgroups.demos.Chat
main(String[]) - static method in class org.jgroups.conf.ClassConfigurator
main(String[]) - static method in class org.jgroups.debug.Debugger
main(String[]) - static method in class org.jgroups.blocks.DistributedHashtable
main(String[]) - static method in class org.jgroups.blocks.DistributedQueue
main(String[]) - static method in class org.jgroups.demos.DistributedQueueDemo
main(String[]) - static method in class org.jgroups.demos.Draw
main(String[]) - static method in class org.jgroups.demos.Draw2Channels
main(String[]) - static method in class org.jgroups.demos.DrawRepl
main(String[]) - static method in class org.jgroups.util.GetNetworkInterfaces
main(String[]) - static method in class org.jgroups.demos.Gossip
main(String[]) - static method in class org.jgroups.protocols.pbcast.Gossip
main(String[]) - static method in class org.jgroups.stack.GossipClient
main(String[]) - static method in class org.jgroups.stack.GossipRouter
main(String[]) - static method in class org.jgroups.stack.GossipServer
main(String[]) - static method in class org.jgroups.demos.KeyStoreGenerator
main(String[]) - static method in class org.jgroups.blocks.Link
main(String[]) - static method in class org.jgroups.util.List
main(String[]) - static method in class org.jgroups.blocks.LogicalLink
main(String[]) - static method in class org.jgroups.demos.NotificationBusDemo
main(String[]) - static method in class org.jgroups.protocols.PerfHeader
main(String[]) - static method in class org.jgroups.debug.Profiler
main(String[]) - static method in class org.jgroups.debug.ProtocolTester
main(String[]) - static method in class org.jgroups.util.Proxy
main(String[]) - static method in class org.jgroups.blocks.ReplicatedTree
main(String[]) - static method in class org.jgroups.stack.Retransmitter
main(String[]) - static method in class org.jgroups.stack.Router
main(String[]) - static method in class org.jgroups.stack.RouterStub
main(String[]) - static method in class org.jgroups.util.TimedWriter
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.protocols.UDP_NIO
main(String[]) - static method in class org.jgroups.Version
Prints the value of the description and cvs fields to System.out.
main(String[]) - static method in class org.jgroups.demos.wb.Whiteboard
main(String[]) - static method in class org.jgroups.conf.XmlConfigurator
main(String[]) - static method in class org.jgroups.conf.XmlValidator
mainLoop() - method in class org.jgroups.demos.Draw
makeReply() - method in class org.jgroups.Message
makeView(Vector) - method in class org.jgroups.protocols.Discovery
makeView(Vector) - method in class org.jgroups.protocols.GMS
makeView(Vector) - method in class org.jgroups.protocols.pbcast.GMS
makeView(Vector,org.jgroups.ViewId) - static method in class org.jgroups.protocols.GMS
makeView(Vector,org.jgroups.ViewId) - method in class org.jgroups.protocols.pbcast.GMS
managerId - field in class org.jgroups.blocks.DistributedLockManager.LockDecree
Marshaller - class org.jgroups.util.Marshaller
Title: JGroups Communications Description: Contact me at mail@filip.net Copyright: Copyright (c) 2002 Company: www.filip.net
RpcDispatcher.Marshaller - interface org.jgroups.blocks.RpcDispatcher.Marshaller
Marshaller() - constructor for class org.jgroups.util.Marshaller
match(long[],long[]) - static method in class org.jgroups.util.Util
match(Object,Object) - static method in class org.jgroups.util.Util
max(org.jgroups.protocols.TransportedVectorTime) - method in class org.jgroups.protocols.VectorTime
Maxes this VectorTime with the specified TransportedVectorTime.
MAX_PORT - static field in class org.jgroups.util.Util
mbrs - field in class org.jgroups.protocols.GMS
MCAST - static field in class org.jgroups.protocols.SMACK.SmackHeader
MCAST_MSG - static field in class org.jgroups.protocols.pbcast.PbcastHeader
mDefaultJGroupsDTD - field in class org.jgroups.conf.ClassPathEntityResolver
memberJoined(org.jgroups.Address) - method in class org.jgroups.blocks.NotificationBus.Consumer
memberJoined(org.jgroups.Address) - method in class org.jgroups.demos.NotificationBusDemo
memberLeft(org.jgroups.Address) - method in class org.jgroups.blocks.NotificationBus.Consumer
memberLeft(org.jgroups.Address) - method in class org.jgroups.demos.NotificationBusDemo
members - field in class org.jgroups.blocks.DistributedQueue
members - field in class org.jgroups.blocks.MessageDispatcher
members - field in class org.jgroups.stack.MessageProtocol
members - field 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 org.jgroups.Membership
Class to keep track of Addresses.
Membership() - constructor for class org.jgroups.Membership
Public constructor Creates a member ship object with zero members
Membership(Collection) - constructor for class org.jgroups.Membership
Creates a member ship object with the initial members.
membership_listener - field in class org.jgroups.blocks.MessageDispatcher
membership_listeners - field in class org.jgroups.blocks.PullPushAdapter
MembershipListener - interface org.jgroups.MembershipListener
Allows a listener to be notified when group membership changes.
This class provides multiplexing possibilities for MembershipListener instances.
membershipListeners - field in class org.jgroups.blocks.MembershipListenerAdapter
membershipListenersCache - field in class org.jgroups.blocks.MembershipListenerAdapter
memStats(boolean) - static method in class org.jgroups.util.Util
MERGE - static field in class org.jgroups.Event
MERGE - class org.jgroups.protocols.MERGE
Simple and stupid MERGE protocol (does not take into account state transfer).
merge(Collection,Collection) - method in class org.jgroups.Membership
merges membership with the new members and removes suspects The Merge method will remove all the suspects and add in the new members.
merge(org.jgroups.Address,long,long,long) - method in class org.jgroups.protocols.pbcast.Digest
Similar to add(), but if the sender already exists, its seqnos will be modified (no new entry) as follows:
  1. this.low_seqno=min(this.low_seqno, low_seqno)
  2. this.high_seqno=max(this.high_seqno, high_seqno)
  3. this.high_seqno_seen=max(this.high_seqno_seen, high_seqno_seen)
If the sender doesn not exist, a new entry will be added (provided there is enough space)
merge(org.jgroups.protocols.pbcast.Digest) - method in class org.jgroups.protocols.pbcast.Digest
Adds a digest to this digest.
merge(Vector) - method in class org.jgroups.protocols.ClientGmsImpl
merge(Vector) - method in class org.jgroups.protocols.CoordGmsImpl
Invoked upon receiving a MERGE event from the MERGE layer.
merge(Vector) - method in class org.jgroups.protocols.pbcast.CoordGmsImpl
Invoked upon receiving a MERGE event from the MERGE layer.
merge(Vector) - method in class org.jgroups.protocols.GMS
merge(Vector) - method in class org.jgroups.protocols.GmsImpl
merge(Vector) - method in class org.jgroups.protocols.pbcast.GmsImpl
merge(Vector) - method in class org.jgroups.protocols.ParticipantGmsImpl
merge(Vector) - method in class org.jgroups.protocols.VectorTime
Merges this VectorTime with new members of the group VectorTime can possibly either grow or shrink
MERGE2 - class org.jgroups.jmx.protocols.MERGE2
MERGE2 - class org.jgroups.protocols.MERGE2
Protocol to discover subgroups; e.g., existing due to a network partition (that healed).
MERGE2() - constructor for class org.jgroups.jmx.protocols.MERGE2
MERGE2(org.jgroups.stack.Protocol) - constructor for class org.jgroups.jmx.protocols.MERGE2
MERGE2MBean - interface org.jgroups.jmx.protocols.MERGE2MBean
MERGE3 - class org.jgroups.protocols.MERGE3
Protocol to discover subgroups; e.g., existing due to a network partition (that healed).
MERGE_DENIED - static field in class org.jgroups.Event
MERGE_DIGEST - static field in class org.jgroups.Event
MERGE_REQ - static field in class org.jgroups.protocols.pbcast.GMS.GmsHeader
MERGE_RSP - static field in class org.jgroups.protocols.pbcast.GMS.GmsHeader
MergeData - class org.jgroups.protocols.pbcast.MergeData
Encapsulates data sent with a MERGE_RSP (handleMergeResponse()) and INSTALL_MERGE_VIEW (handleMergeView()).
MergeData() - constructor for class org.jgroups.protocols.pbcast.MergeData
Empty constructor needed for externalization
mergeDigest(org.jgroups.protocols.pbcast.Digest) - method in class org.jgroups.protocols.pbcast.GMS
Send down a MERGE_DIGEST event
MERGEFAST - class org.jgroups.protocols.MERGEFAST
The coordinator attaches a small header to each (or every nth) message.
MergefastHeader() - constructor for class org.jgroups.protocols.MERGEFAST.MergefastHeader
MergefastHeader(org.jgroups.Address) - constructor for class org.jgroups.protocols.MERGEFAST.MergefastHeader
MERGE.MergeHeader - class org.jgroups.protocols.MERGE.MergeHeader
MergeHeader() - constructor for class org.jgroups.protocols.MERGE.MergeHeader
MergeHeader(int) - constructor for class org.jgroups.protocols.MERGE.MergeHeader
MergeView - class org.jgroups.MergeView
A view that is sent as a result of a merge.
MergeView() - constructor for class org.jgroups.MergeView
Used by externalization
Creates a new view
MergeView(org.jgroups.ViewId,Vector,Vector) - constructor for class org.jgroups.MergeView
Creates a new view
Message - class org.jgroups.Message
A Message encapsulates data sent to members of a group.
Message() - constructor for class org.jgroups.Message
Message(boolean) - constructor for class org.jgroups.Message
Public constructor
Constructs a message.
Public constructor
MessageDialog - class org.jgroups.demos.wb.MessageDialog
MessageDialog(Frame,String,String) - constructor for class org.jgroups.demos.wb.MessageDialog
MessageDispatcher - class org.jgroups.blocks.MessageDispatcher
Provides synchronous and asynchronous message sending with request-response correlation; i.e., matching responses with the original request.
MessageListener - interface org.jgroups.MessageListener
Allows a listener to be notified when a message arrives.
This class provides multiplexing possibilities for MessageListener instances.
MessageListenerAdapter() - constructor for class org.jgroups.blocks.MessageListenerAdapter
Create default instance of this class.
Create instance of this class.
messageListeners - field in class org.jgroups.blocks.MessageListenerAdapter
messageListenersCache - field in class org.jgroups.blocks.MessageListenerAdapter
MessageProtocol - class org.jgroups.stack.MessageProtocol
Based on Protocol, but incorporates RequestCorrelator and GroupRequest: the latter can be used to mcast messages to all members and receive their reponses.
MessageProtocolEXAMPLE - class org.jgroups.protocols.MessageProtocolEXAMPLE
METHOD - static field in class org.jgroups.blocks.MethodCall
Explicitly ship the method, caller has to determine method himself.
method_id - field in class org.jgroups.blocks.MethodCall
The ID of a method, maps to a java.lang.reflect.Method
method_lookup - field in class org.jgroups.blocks.RpcDispatcher
method_name - field in class org.jgroups.blocks.MethodCall
The name of the method, case sensitive.
MethodCall - class org.jgroups.blocks.MethodCall
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[]) - constructor for class org.jgroups.blocks.MethodCall
MethodCall(String,Object[],Class[]) - constructor for class org.jgroups.blocks.MethodCall
MethodCall(String,Object[],String[]) - constructor for class org.jgroups.blocks.MethodCall
MethodLookup - interface org.jgroups.blocks.MethodLookup
Missed one or more heartbeats.
missedHeartbeat(InetAddress,int,InetAddress,int,int) - method in class org.jgroups.protocols.WANPIPE
missingMessageReceived(long,org.jgroups.Message) - method in class org.jgroups.protocols.pbcast.NAKACK
mMagicNumberFile - field in class org.jgroups.conf.MagicNumberReader
mode - field in class org.jgroups.blocks.MethodCall
Which mode to use.
mode - field in class org.jgroups.protocols.ring.TokenLostException
mode - field in class org.jgroups.blocks.Xid
modeToString(int) - static method in class org.jgroups.blocks.Xid
mouseClicked(MouseEvent) - method in class org.jgroups.demos.Chat
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.DrawRepl
mouseDragged(MouseEvent) - method in class org.jgroups.demos.wb.GraphPanel
mouseEntered(MouseEvent) - method in class org.jgroups.demos.Chat
mouseEntered(MouseEvent) - method in class org.jgroups.demos.wb.GraphPanel
mouseExited(MouseEvent) - method in class org.jgroups.demos.Chat
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.DrawRepl
mouseMoved(MouseEvent) - method in class org.jgroups.demos.Gossip
mouseMoved(MouseEvent) - method in class org.jgroups.demos.wb.GraphPanel
mousePressed(MouseEvent) - method in class org.jgroups.demos.Chat
mousePressed(MouseEvent) - method in class org.jgroups.demos.wb.GraphPanel
mouseReleased(MouseEvent) - method in class org.jgroups.demos.Chat
mouseReleased(MouseEvent) - method in class org.jgroups.demos.wb.GraphPanel
moveNode(org.jgroups.demos.wb.Node) - method in class org.jgroups.demos.wb.GraphPanel
moveNode(org.jgroups.demos.wb.Node) - method in class org.jgroups.demos.wb.Whiteboard
MPING - class org.jgroups.jmx.protocols.MPING
MPING - class org.jgroups.protocols.MPING
Uses its own IP multicast socket to send and receive discovery requests/responses.
MPING() - constructor for class org.jgroups.jmx.protocols.MPING
MPING(org.jgroups.stack.Protocol) - constructor for class org.jgroups.jmx.protocols.MPING
MPINGMBean - interface org.jgroups.jmx.protocols.MPINGMBean
MSG - static field in class org.jgroups.Event
MSG - static field in class org.jgroups.protocols.pbcast.NakAckHeader
msg_listener - field in class org.jgroups.blocks.MessageDispatcher
msgListToByteBuffer(LinkedList) - static method in class org.jgroups.util.Util
Marshalls a list of messages.
msgs - field in class org.jgroups.protocols.Digest
multicast_addr - field in class org.jgroups.stack.LogicalAddress
This class represents the lock that has to be marked as multilocked
mutex - field in class org.jgroups.blocks.DistributedQueue
mutex - field in class org.jgroups.util.List
my_addr - field in class org.jgroups.demos.wb.GraphPanel
UDP_NIO.MyReceiver - class org.jgroups.protocols.UDP_NIO.MyReceiver
MyReceiver() - constructor for class org.jgroups.protocols.UDP_NIO.MyReceiver

N

NAK_ACK_MSG - static field in class org.jgroups.protocols.NakAckHeader
NAK_ACK_RSP - static field in class org.jgroups.protocols.NakAckHeader
NAK_MSG - static field in class org.jgroups.protocols.NakAckHeader
NAKACK - class org.jgroups.jmx.protocols.pbcast.NAKACK
NAKACK - class org.jgroups.protocols.NAKACK
Negative AcKnowledgement layer (NAKs), paired with positive ACKs.
NAKACK - class org.jgroups.protocols.pbcast.NAKACK
Negative AcKnowledgement layer (NAKs).
NAKACK() - constructor for class org.jgroups.jmx.protocols.pbcast.NAKACK
NAKACK() - constructor for class org.jgroups.protocols.pbcast.NAKACK
NAKACK(org.jgroups.stack.Protocol) - constructor for class org.jgroups.jmx.protocols.pbcast.NAKACK
NakAckHeader - class org.jgroups.protocols.NakAckHeader
NakAckHeader - class org.jgroups.protocols.pbcast.NakAckHeader
NakAckHeader() - constructor for class org.jgroups.protocols.NakAckHeader
NakAckHeader() - constructor for class org.jgroups.protocols.pbcast.NakAckHeader
NakAckHeader(byte,long) - constructor for class org.jgroups.protocols.pbcast.NakAckHeader
Constructor for regular messages
NakAckHeader(byte,long,long) - constructor for class org.jgroups.protocols.pbcast.NakAckHeader
Constructor for retransmit requests/responses (low and high define the range of msgs)
NakAckHeader(byte,long,long,org.jgroups.Address) - constructor for class org.jgroups.protocols.pbcast.NakAckHeader
NakAckHeader(int,long,org.jgroups.ViewId) - constructor for class org.jgroups.protocols.NakAckHeader
NAKACKMBean - interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
NakReceiverWindow - class org.jgroups.stack.NakReceiverWindow
Keeps track of messages according to their sequence numbers.
NakReceiverWindow(org.jgroups.Address,long) - constructor for class org.jgroups.stack.NakReceiverWindow
Creates a new instance without a retransmission thread
Creates a new instance with the given retransmit command
Creates a new instance with the given retransmit command
name - static field in class org.jgroups.protocols.GMS
name - static field in class org.jgroups.protocols.PING
name - field in class org.jgroups.blocks.RequestCorrelator
makes the instance unique (together with IDs)
NBMessageForm_NIO - class org.jgroups.blocks.NBMessageForm_NIO
NBMessageForm - Message form for non-blocking message reads.
NBMessageForm_NIO(int,SocketChannel) - constructor for class org.jgroups.blocks.NBMessageForm_NIO
next() - method in class org.jgroups.stack.Interval
next_id - static field in class org.jgroups.blocks.Xid
nextInterval() - method in class org.jgroups.util.TimeScheduler.Task
Node - class org.jgroups.demos.wb.Node
ReplicatedTree.Node - class org.jgroups.blocks.ReplicatedTree.Node
nodeAdded(String) - method in class org.jgroups.blocks.ReplicatedTree.ReplicatedTreeListener
nodeAdded(String,Serializable) - method in class org.jgroups.demos.DistributedTreeDemo
nodeModified(String) - method in class org.jgroups.blocks.ReplicatedTree.ReplicatedTreeListener
nodeRemoved(String) - method in class org.jgroups.demos.DistributedTreeDemo
nodeRemoved(String) - method in class org.jgroups.blocks.ReplicatedTree.ReplicatedTreeListener
normalize(String) - static method in class org.jgroups.util.PrintXMLTree
NOT_MEMBER - static field in class org.jgroups.protocols.FD.FdHeader
NOT_MEMBER - static field in class org.jgroups.protocols.pbcast.PbcastHeader
NotificationBus - class org.jgroups.blocks.NotificationBus
This class provides notification sending and handling capability.
NotificationBus() - constructor for class org.jgroups.blocks.NotificationBus
NotificationBus(String) - constructor for class org.jgroups.blocks.NotificationBus
NotificationBus(String,String) - constructor for class org.jgroups.blocks.NotificationBus
NotificationBusDemo - class org.jgroups.demos.NotificationBusDemo
Demoes the NotificationBus (without caching).
notifs - field in class org.jgroups.blocks.DistributedQueue
notifyBlock() - method in class org.jgroups.blocks.PullPushAdapter
notifyChannelShunned() - method in class org.jgroups.Channel
notifyConsumer(Serializable) - method in class org.jgroups.blocks.NotificationBus
Don't multicast this to all members, just apply it to local consumers.
notifySuspect(org.jgroups.Address) - method in class org.jgroups.blocks.PullPushAdapter
notifyViewChange(org.jgroups.View) - method in class org.jgroups.blocks.PullPushAdapter
NULL_TYPE - static field in class org.jgroups.protocols.TOTAL.Header
Null value for the tag
NullReadWriteLock - class org.jgroups.util.NullReadWriteLock
NullSync - class org.jgroups.util.NullSync
num_frags - field in class org.jgroups.protocols.FragHeader
num_prev_mbrs - field in class org.jgroups.protocols.pbcast.GMS
Max number of old members to keep in history
numberOfEstablishedLinks() - method in class org.jgroups.blocks.LogicalLink
numberOfLinks() - method in class org.jgroups.blocks.LogicalLink
numSuspectedMembers() - method in class org.jgroups.util.RspList

O

objectFromByteBuffer(byte[]) - method in class org.jgroups.blocks.RpcDispatcher.Marshaller
objectFromByteBuffer(byte[]) - static method in class org.jgroups.util.Util
Creates an object from a byte buffer
objectToByteBuffer(Object) - method in class org.jgroups.blocks.RpcDispatcher.Marshaller
objectToByteBuffer(Object) - static method in class org.jgroups.util.Util
Serializes an object into a byte buffer.
observer - field in class org.jgroups.stack.Protocol
QUEUE.Observer - interface org.jgroups.protocols.QUEUE.Observer
offset - field in class org.jgroups.Message
The index into the payload (usually 0)
OLD - static field in class org.jgroups.blocks.MethodCall
Infer the method from the arguments.
onMessage(javax.jms.Message) - method in class org.jgroups.protocols.JMS
Implementation of the javax.jms.MessageListener interface.
open() - method in class org.jgroups.Channel
Re-opens a closed channel.
open() - method in class org.jgroups.JChannel
Opens the channel.
OPERATIONAL - static field in class org.jgroups.protocols.ring.RingToken
option2String(int) - static method in class org.jgroups.Channel
org.jgroups - package
Provides top-level public JGroups classes such as Channel, Message, etc.
Provides building blocks that are layered on top of channels.
Provides ways to configure a protocol stack.
Provides debug support, including testing, profiling, and a graphical view of a protocol stack.
Provides demonstrations of JGroups functionality.
Provides an applet that demonstrates JGroups functionality.
A distributed whiteboard applet implemented using JGroups.
org.jgroups.jmx - package
<!-- Implementation of JGroups using Java Management Extensions.
<!-- Description of package with JMX protocols.
<!-- Description of package that supports JMX probabilistic broadcasts.
Provides features for storing information to a database or file.
Provides implementations of transport protocols which are responsible for sending and receiving messages to/from the network.
Supports probabilistic broadcasts.
Supports protocols in ring networks.
Support for managing protocol stacks.
Provides useful functionality which cannot be assigned to any particular other package.
OUT_OF_BAND_MSG - static field in class org.jgroups.protocols.NakAckHeader
OUT_OF_BAND_RSP - static field in class org.jgroups.protocols.NakAckHeader
override(org.jgroups.conf.ProtocolData) - method in class org.jgroups.conf.XmlConfigurator
own_addr - field in class org.jgroups.protocols.PingRsp

P

paint(Graphics) - method in class org.jgroups.demos.applets.DrawApplet
paint(Graphics) - method in class org.jgroups.demos.Topology
parse(Element) - static method in class org.jgroups.conf.XmlConfigurator
parse(InputStream) - static method in class org.jgroups.conf.MagicNumberReader
parse(InputStream) - static method in class org.jgroups.conf.XmlConfigurator
parseClassData(Node) - static method in class org.jgroups.conf.MagicNumberReader
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.
parseComponentStrings(String,String) - method in class org.jgroups.stack.Configurator
Get a string of the form "P1(config_str1):P2:P3(config_str3)" and return ProtocolConfigurations for it.
parseConfigurations(String) - method in class org.jgroups.stack.Configurator
Return a number of ProtocolConfigurations in a vector
parseOldFormat(InputStream) - static method in class org.jgroups.conf.XmlConfigurator
parseProtocolData(Node) - static method in class org.jgroups.conf.XmlConfigurator
parseProtocolParameters(Element) - static method in class org.jgroups.conf.XmlConfigurator
ParticipantGmsImpl - class org.jgroups.protocols.ParticipantGmsImpl
ParticipantGmsImpl - class org.jgroups.protocols.pbcast.ParticipantGmsImpl
ParticipantGmsImpl(org.jgroups.protocols.GMS) - constructor for class org.jgroups.protocols.ParticipantGmsImpl
ParticipantGmsImpl(org.jgroups.protocols.pbcast.GMS) - constructor for class org.jgroups.protocols.pbcast.ParticipantGmsImpl
PARTITIONER - class org.jgroups.protocols.PARTITIONER
This layer can be put on top of the bottommost layer and is useful to simulate partitions.
The Partitioner header normally (type = NORMAL) contains just the partition number that is checked to discard messages received from other partitions.
PartitionerHeader() - constructor for class org.jgroups.protocols.PARTITIONER.PartitionerHeader
PartitionerHeader(int) - constructor for class org.jgroups.protocols.PARTITIONER.PartitionerHeader
PartitionerHeader(int,int) - constructor for class org.jgroups.protocols.PARTITIONER.PartitionerHeader
passDown(org.jgroups.Event) - method in class org.jgroups.stack.Protocol
Causes the event to be forwarded to the next layer down in the hierarchy.Typically called by the implementation of Down (when done).
passDown(org.jgroups.Event) - method in class org.jgroups.stack.ProtocolObserver
Called when an event is about to be passed down to the next lower protocol.
passDown(org.jgroups.Event) - method in class org.jgroups.debug.ProtocolView
passThrough() - method in class org.jgroups.util.ReentrantLatch
Pass through only when the latch becomes unlocked.
passToken(Object) - method in class org.jgroups.protocols.ring.RingNode
passToken(Object) - method in class org.jgroups.protocols.ring.TcpRingNode
passToken(Object) - method in class org.jgroups.protocols.ring.UdpRingNode
passUp(org.jgroups.Event) - method in class org.jgroups.stack.Protocol
Causes the event to be forwarded to the next layer up in the hierarchy.
passUp(org.jgroups.Event) - method in class org.jgroups.stack.ProtocolObserver
Called when an event is about to be passed up to the next higher protocol.
passUp(org.jgroups.Event) - method in class org.jgroups.debug.ProtocolView
payload - field in class org.jgroups.blocks.MethodCall
To carry arbitrary data with a method call, data needs to be serializable if sent across the wire
PBCAST - class org.jgroups.protocols.pbcast.PBCAST
Implementation of probabilistic broadcast.
PbcastHeader - class org.jgroups.protocols.pbcast.PbcastHeader
PbcastHeader() - constructor for class org.jgroups.protocols.pbcast.PbcastHeader
PbcastHeader(int) - constructor for class org.jgroups.protocols.pbcast.PbcastHeader
PbcastHeader(int,long) - constructor for class org.jgroups.protocols.pbcast.PbcastHeader
PbcastHeader(org.jgroups.protocols.pbcast.Gossip,int) - constructor for class org.jgroups.protocols.pbcast.PbcastHeader
PbcastHeader(org.jgroups.protocols.pbcast.Gossip,int,long) - constructor for class org.jgroups.protocols.pbcast.PbcastHeader
peek() - method in class org.jgroups.blocks.DistributedQueue
returns the first object on the queue, without removing it.
peek() - method in class org.jgroups.util.LinkedListQueue
returns the first object on the queue, without removing it.
peek() - method in class org.jgroups.util.List
Returns element at the tail (if present), but does not remove it from list.
peek() - method in class org.jgroups.util.Queue
returns the first object on the queue, without removing it.
peek() - method in class org.jgroups.util.Queue2
returns the first object on the queue, without removing it.
peek() - method in class org.jgroups.util.Stack
peek(long) - method in class org.jgroups.Channel
Returns the next message, view, block, suspect or other event without removing it from the queue.
peek(long) - method in class org.jgroups.JChannel
Just peeks at the next message, view or block.
peek(long) - method in class org.jgroups.jmx.JChannel
peek(long) - method in class org.jgroups.jmx.JChannelMBean
peek(long) - method in class org.jgroups.util.LinkedListQueue
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.
peek(long) - method in class org.jgroups.util.Queue2
returns the first object on the queue, without removing it.
peekAtHead() - method in class org.jgroups.util.List
Returns element at the head (if present), but does not remove it from list.
PERF - static field in class org.jgroups.Event
PERF - class org.jgroups.protocols.PERF
Measures time taken by each protocol to process a message.
PERF_TP - class org.jgroups.protocols.PERF_TP
Measures the time for a message to travel from the channel to the transport
PERF_TP() - constructor for class org.jgroups.protocols.PERF_TP
PerfHeader - class org.jgroups.protocols.PerfHeader
Inserted by PERF into each message.
PerfHeader() - constructor for class org.jgroups.protocols.PerfHeader
PerfHeader(Object,Object) - constructor for class org.jgroups.protocols.PerfHeader
PersistenceFactory - class org.jgroups.persistence.PersistenceFactory
PersistenceManager - interface org.jgroups.persistence.PersistenceManager
physical_addrs - field in class org.jgroups.stack.LogicalAddress
List of physical addresses
pickRandomElement(Vector) - static method in class org.jgroups.util.Util
pickSubset(Vector,double) - static method in class org.jgroups.util.Util
Selects a random subset of members according to subset_percentage and returns them.
PIGGYBACK - class org.jgroups.protocols.PIGGYBACK
Combines multiple messages into a single large one.
PiggybackHeader() - constructor for class org.jgroups.protocols.PIGGYBACK.PiggybackHeader
PING - class org.jgroups.jmx.protocols.PING
PING - class org.jgroups.protocols.PING
The PING protocol layer retrieves the initial membership (used by the GMS when started by sending event FIND_INITIAL_MBRS down the stack).
PING() - constructor for class org.jgroups.jmx.protocols.PING
PING(org.jgroups.stack.Protocol) - constructor for class org.jgroups.jmx.protocols.PING
PingHeader - class org.jgroups.protocols.PingHeader
PingHeader() - constructor for class org.jgroups.protocols.PingHeader
PingHeader(byte,org.jgroups.protocols.PingRsp) - constructor for class org.jgroups.protocols.PingHeader
PINGMBean - interface org.jgroups.jmx.protocols.PINGMBean
PingRsp - class org.jgroups.protocols.PingRsp
PingRsp() - constructor for class org.jgroups.protocols.PingRsp
PingRsp(org.jgroups.Address,org.jgroups.Address,boolean) - constructor for class org.jgroups.protocols.PingRsp
PingSender - class org.jgroups.protocols.PingSender
Sends num_ping_request GET_MBRS_REQ messages, distributed over timeout ms
PingSender(long,int,org.jgroups.protocols.Discovery) - constructor for class org.jgroups.protocols.PingSender
PingWaiter - class org.jgroups.protocols.PingWaiter
Class that waits for n PingRsp'es, or m milliseconds to return the initial membership
PlainConfigurator - class org.jgroups.conf.PlainConfigurator
A ProtocolStackConfigurator for the old style properties.
PlainConfigurator(String) - constructor for class org.jgroups.conf.PlainConfigurator
Instantiates a PlainConfigurator with old style properties
pop() - method in class org.jgroups.util.Stack
PORT - static field in class org.jgroups.stack.GossipRouter
prepare(Object) - method in class org.jgroups.blocks.DistributedLockManager
Prepare phase for the lock acquisition or release.
prepare(Object) - method in class org.jgroups.blocks.TwoPhaseVotingListener
This is voting if the decree is acceptable to the party.
print() - method in class org.jgroups.blocks.DistributedTree
print(PrintWriter,Element) - static method in class org.jgroups.util.PrintXMLTree
print(String) - method in class org.jgroups.blocks.ReplicatedTree
Prints a representation of the node defined by fqn.
print(String,PrintWriter,Element) - static method in class org.jgroups.util.PrintXMLTree
print(String,PrintWriter,Element,NamedNodeMap) - static method in class org.jgroups.util.PrintXMLTree
Prints the specified element.
print(Throwable) - static method in class org.jgroups.util.Util
printAllStocks() - method in class org.jgroups.demos.QuoteServer
printBytes(long) - static method in class org.jgroups.util.Util
printClassMap() - method in class org.jgroups.conf.ClassConfigurator
printConnections() - method in class org.jgroups.jmx.protocols.TCP
printConnections() - method in class org.jgroups.protocols.TCP
printConnections() - method in class org.jgroups.jmx.protocols.TCPMBean
printConnections() - method in class org.jgroups.jmx.protocols.UNICAST
printConnections() - method in class org.jgroups.protocols.UNICAST
printConnections() - method in class org.jgroups.jmx.protocols.UNICASTMBean
printContents(boolean) - method in class org.jgroups.protocols.PerfHeader
printContents(boolean,Vector) - method in class org.jgroups.protocols.PerfHeader
printCredits() - method in class org.jgroups.jmx.protocols.FC
printCredits() - method in class org.jgroups.protocols.FC
printCredits() - method in class org.jgroups.jmx.protocols.FCMBean
printDescription() - static method in class org.jgroups.Version
Returns the catenation of the description and cvs fields.
printDetails() - method in class org.jgroups.stack.AckReceiverWindow
printDetails() - method in class org.jgroups.stack.AckSenderWindow
printDetails() - method in class org.jgroups.protocols.FD_PROB.FdHeader
printDetails() - method in class org.jgroups.View
debug only
printDetails(long) - method in class org.jgroups.stack.AckMcastSenderWindow
Prints all members plus whether an ack has been received from those members for a given seqno
printEvent(org.jgroups.Event) - static method in class org.jgroups.util.Util
printFragments(frags[][]) - static method in class org.jgroups.util.Util
printHighSeqnos() - method in class org.jgroups.protocols.pbcast.Digest
printHighSeqnosSeen() - method in class org.jgroups.protocols.pbcast.Digest
printMagicMap() - method in class org.jgroups.conf.ClassConfigurator
printMembers(Vector) - static method in class org.jgroups.util.Util
printMessage(org.jgroups.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.jmx.protocols.pbcast.NAKACK
printMessages() - method in class org.jgroups.protocols.pbcast.NAKACK
printMessages() - method in class org.jgroups.jmx.protocols.pbcast.NAKACKMBean
printMethodCall(org.jgroups.Message) - static method in class org.jgroups.util.Util
Tries to read a MethodCall object from the message's buffer and prints it.
PRINTMETHODS - class org.jgroups.protocols.PRINTMETHODS
PRINTMETHODS() - constructor for class org.jgroups.protocols.PRINTMETHODS
printObjectHeaders() - method in class org.jgroups.Message
PRINTOBJS - class org.jgroups.protocols.PRINTOBJS
PRINTOBJS() - constructor for class org.jgroups.protocols.PRINTOBJS
printPreviousMembers() - method in class org.jgroups.jmx.protocols.pbcast.GMS
printPreviousMembers() - method in class org.jgroups.protocols.pbcast.GMS
printPreviousMembers() - method in class org.jgroups.jmx.protocols.pbcast.GMSMBean
printPreviousViews() - method in class org.jgroups.jmx.protocols.pbcast.GMS
printPreviousViews() - method in class org.jgroups.protocols.pbcast.GMS
printPreviousViews() - method in class org.jgroups.jmx.protocols.pbcast.GMSMBean
printProtocolSpec(boolean) - method in class org.jgroups.JChannel
Returns a pretty-printed form of all the protocols.
printProtocolSpec(boolean) - method in class org.jgroups.jmx.JChannel
printProtocolSpec(boolean) - method in class org.jgroups.jmx.JChannelMBean
printProtocolSpec(boolean) - method in class org.jgroups.stack.ProtocolStack
Prints the names of the protocols, from the bottom to top.
printProtocolSpecAsXML() - method in class org.jgroups.stack.ProtocolStack
printReceiverCredits() - method in class org.jgroups.jmx.protocols.FC
printReceiverCredits() - method in class org.jgroups.protocols.FC
printReceiverCredits() - method in class org.jgroups.jmx.protocols.FCMBean
printSenderCredits() - method in class org.jgroups.jmx.protocols.FC
printSenderCredits() - method in class org.jgroups.protocols.FC
printSenderCredits() - method in class org.jgroups.jmx.protocols.FCMBean
printSentMessages() - method in class org.jgroups.jmx.protocols.pbcast.NAKACK
printSentMessages() - method in class org.jgroups.jmx.protocols.pbcast.NAKACKMBean
printSentMsgs() - method in class org.jgroups.protocols.pbcast.NAKACK
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.jmx.Protocol
printStats() - method in class org.jgroups.stack.Protocol
printStats() - method in class org.jgroups.jmx.ProtocolMBean
printStats() - method in class org.jgroups.jmx.protocols.STATS
printStats() - method in class org.jgroups.protocols.STATS
printStats() - method in class org.jgroups.jmx.protocols.STATSMBean
printSuspectHistory() - method in class org.jgroups.jmx.protocols.FD
printSuspectHistory() - method in class org.jgroups.protocols.FD
printSuspectHistory() - method in class org.jgroups.jmx.protocols.FD_SOCK
printSuspectHistory() - method in class org.jgroups.protocols.FD_SOCK
printSuspectHistory() - method in class org.jgroups.jmx.protocols.FD_SOCKMBean
printSuspectHistory() - method in class org.jgroups.jmx.protocols.FDMBean
printThreads() - static method in class org.jgroups.util.Util
printVersion() - static method in class org.jgroups.Version
Returns the version field as a String.
PrintXMLTree - class org.jgroups.util.PrintXMLTree
Title: JGroups Communications Description: Contact me at filip@filip.net Copyright: Copyright (c) 2002 Company: www.filip.net
PrintXMLTree() - constructor for class org.jgroups.util.PrintXMLTree
processEvent(String,AWTEvent) - method in class org.jgroups.demos.DrawRepl
Processes the response list and votes like the default processResponses method with the consensusType VOTE_ALL If the result of the voting is false, but this DistributedLockManager owns the lock, the result is changed to true and the lock is released, but marked as multiple locked.
Processes the responses returned by the other nodes.
Processes the response list and makes a decision according to the type of the consensus for current voting.
Profiler - class org.jgroups.debug.Profiler
Allows to time execution of 'named' statements, counts number of times called and total execution time.
Profiler() - constructor for class org.jgroups.debug.Profiler
Promise - class org.jgroups.util.Promise
Allows a thread to submit an asynchronous request and to wait for the result.
prompt(String) - static method in class org.jgroups.util.Util
props - field in class org.jgroups.stack.Protocol
prot_adapter - field in class org.jgroups.blocks.MessageDispatcher
prot_name - static field in class org.jgroups.protocols.TOTAL_TOKEN
Protocol - class org.jgroups.jmx.Protocol
Protocol - class org.jgroups.stack.Protocol
The Protocol class provides a set of common services for protocol layers.
Protocol() - constructor for class org.jgroups.jmx.Protocol
Protocol(org.jgroups.stack.Protocol) - constructor for class org.jgroups.jmx.Protocol
Parses and encapsulates the specification for 1 protocol of the protocol stack, e.g.
ProtocolConfiguration(String) - constructor for class org.jgroups.stack.Configurator.ProtocolConfiguration
Creates a new ProtocolConfiguration.
ProtocolData - class org.jgroups.conf.ProtocolData
Data holder for protocol
ProtocolMBean - interface org.jgroups.jmx.ProtocolMBean
ProtocolObserver - interface org.jgroups.stack.ProtocolObserver
Interface for the Debugger to receive notifications about a protocol layer.
ProtocolParameter - class org.jgroups.conf.ProtocolParameter
Data holder for protocol data
ProtocolParameter(String,Object) - constructor for class org.jgroups.conf.ProtocolParameter
ProtocolSpecificView - class org.jgroups.debug.ProtocolSpecificView
Abstract class for all protocol-specific views, e.g.
ProtocolSpecificView() - constructor for class org.jgroups.debug.ProtocolSpecificView
ProtocolStack - class org.jgroups.stack.ProtocolStack
A ProtocolStack manages a number of protocols layered above each other.
ProtocolStack() - constructor for class org.jgroups.stack.ProtocolStack
Only used by Simulator; don't use
ProtocolStack(org.jgroups.JChannel,String) - constructor for class org.jgroups.stack.ProtocolStack
ProtocolTester - class org.jgroups.debug.ProtocolTester
Generic class to test one or more protocol layers directly.
ProtocolTester(String,org.jgroups.stack.Protocol) - constructor for class org.jgroups.debug.ProtocolTester
ProtocolView - class org.jgroups.debug.ProtocolView
Graphical view of a protocol instance
providedDownServices() - method in class org.jgroups.protocols.NAKACK
providedDownServices() - method in class org.jgroups.protocols.pbcast.NAKACK
List of events that are provided to layers below (they will be handled when sent down from below).
providedDownServices() - method in class org.jgroups.stack.Protocol
List of events that are provided to layers below (they will be handled when sent down from below).
providedDownServices() - method in class org.jgroups.protocols.QUEUE
List of events that are provided to layers below (they will be handled when sent down from below).
providedUpServices() - method in class org.jgroups.protocols.Discovery
providedUpServices() - method in class org.jgroups.protocols.FLUSH
providedUpServices() - method in class org.jgroups.protocols.NAKACK
providedUpServices() - method in class org.jgroups.protocols.pbcast.NAKACK
List of events that are provided to layers above (they will be handled when sent down from above).
providedUpServices() - method in class org.jgroups.protocols.pbcast.PBCAST
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).
providedUpServices() - method in class org.jgroups.protocols.QUEUE
List of events that are provided to layers above (they will be handled when sent down from above).
providedUpServices() - method in class org.jgroups.protocols.TOTAL_TOKEN
List of events that are provided to layers above (they will be handled when sent down from above).
Proxy - class org.jgroups.util.Proxy
Redirects incoming TCP connections to other hosts/ports.
Proxy(InetAddress,int,InetAddress,int,boolean,boolean) - constructor for class org.jgroups.util.Proxy
PullHeader() - constructor for class org.jgroups.blocks.PullPushAdapter.PullHeader
PullHeader(Serializable) - constructor for class org.jgroups.blocks.PullPushAdapter.PullHeader
PullPushAdapter - class org.jgroups.blocks.PullPushAdapter
Allows a client of Channel to be notified when messages have been received instead of having to actively poll the channel for new messages.
PullPushAdapter(org.jgroups.Transport) - constructor for class org.jgroups.blocks.PullPushAdapter
push(Object) - method in class org.jgroups.util.Stack
put(Object,Object) - method in class org.jgroups.blocks.DistributedHashtable
Maps the specified key to the specified value in the hashtable.
put(Object,Object) - method in class org.jgroups.blocks.MethodCall
put(Object,Object) - method in class org.jgroups.blocks.ReplicatedHashtable
Maps the specified key to the specified value in the hashtable.
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.
putAll(Map) - method in class org.jgroups.blocks.DistributedHashtable
Copies all of the mappings from the specified Map to this Hashtable These mappings will replace any mappings that this Hashtable had for any of the keys currently in the specified Map.
putAll(Map) - method in class org.jgroups.blocks.ReplicatedHashtable
Copies all of the mappings from the specified Map to this Hashtable These mappings will replace any mappings that this Hashtable had for any of the keys currently in the specified Map.
putHeader(String,org.jgroups.Header) - method in class org.jgroups.Message
Puts a header given a key into the hashmap.

Q

QUEUE - class org.jgroups.protocols.QUEUE
Queuing layer.
Queue - class org.jgroups.util.Queue
Elements are added at the tail and removed from the head.
Queue() - constructor for class org.jgroups.util.Queue
creates an empty queue
Queue2 - class org.jgroups.util.Queue2
Elements are added at the tail and removed from the head.
Queue2() - constructor for class org.jgroups.util.Queue2
creates an empty queue
QueueClosedException() - constructor for class org.jgroups.util.QueueClosedException
QueueClosedException(String) - constructor for class org.jgroups.util.QueueClosedException
QUEUEView - class org.jgroups.debug.QUEUEView
Shows the internals of the QUEUE protocol.
QUEUEView() - constructor for class org.jgroups.debug.QUEUEView
QuoteClient - class org.jgroups.demos.QuoteClient
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 org.jgroups.demos.QuoteServer
Example of a replicated quote server.

R

random(long) - static method in class org.jgroups.util.Util
Returns a random value in the range [1 - range]
Range - class org.jgroups.util.Range
Range() - constructor for class org.jgroups.util.Range
For externalization
Range(long,long) - constructor for class org.jgroups.util.Range
read(ObjectInput) - static method in class org.jgroups.util.Marshaller
reads the magic number, instantiates the class (from the configurator) and invokes the readExternal method on the object.
READ_COMMITTED - static field in class org.jgroups.blocks.Xid
Reads are dirty until another transaction actually commits; at that points the modified data will be reflected here.
readAddress(DataInputStream) - static method in class org.jgroups.util.Util
readAddresses(DataInputStream,Class) - static method in class org.jgroups.util.Util
readByteBuffer(DataInputStream) - static method in class org.jgroups.util.Util
readClassDescriptor() - method in class org.jgroups.util.MagicObjectInputStream
readCompleteMsgBuffer() - method in class org.jgroups.blocks.NBMessageForm_NIO
readExternal(java.io.ObjectInput) - method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
readExternal(java.io.ObjectInput) - method in class org.jgroups.protocols.ENCRYPT1_4.EncryptHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.BSH.BshHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.CAUSAL.CausalHeader
Manual deserialization
readExternal(ObjectInput) - method in class org.jgroups.protocols.COMPRESS.CompressHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.pbcast.Digest
readExternal(ObjectInput) - method in class org.jgroups.protocols.FC.FcHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.FD.FdHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.FD_PID.FdHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.FD_PROB.FdHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.FD_SIMPLE.FdHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.FD_SOCK.FdHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.FragHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
readExternal(ObjectInput) - method in class org.jgroups.stack.GossipData
readExternal(ObjectInput) - method in class org.jgroups.protocols.HTOTAL.HTotalHeader
readExternal(ObjectInput) - method in class org.jgroups.stack.IpAddress
readExternal(ObjectInput) - method in class org.jgroups.protocols.JMS.JMSAddress
Read object from external input.
readExternal(ObjectInput) - method in class org.jgroups.util.List
readExternal(ObjectInput) - method in class org.jgroups.stack.LogicalAddress
readExternal(ObjectInput) - method in class org.jgroups.protocols.MERGE.MergeHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.MERGE3.CoordAnnouncement
readExternal(ObjectInput) - method in class org.jgroups.protocols.pbcast.MergeData
readExternal(ObjectInput) - method in class org.jgroups.protocols.MERGEFAST.MergefastHeader
readExternal(ObjectInput) - method in class org.jgroups.MergeView
readExternal(ObjectInput) - method in class org.jgroups.Message
readExternal(ObjectInput) - method in class org.jgroups.blocks.MethodCall
readExternal(ObjectInput) - method in class org.jgroups.protocols.NakAckHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.pbcast.NakAckHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.PARTITIONER.PartitionerHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.pbcast.PbcastHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.PerfHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.PIGGYBACK.PiggybackHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.PingHeader
readExternal(ObjectInput) - method in class org.jgroups.blocks.PullPushAdapter.PullHeader
readExternal(ObjectInput) - method in class org.jgroups.util.Range
readExternal(ObjectInput) - method in class org.jgroups.blocks.ReplicationData
readExternal(ObjectInput) - method in class org.jgroups.blocks.RequestCorrelator.Header
readExternal(ObjectInput) - method in class org.jgroups.protocols.ring.RingToken
readExternal(ObjectInput) - method in class org.jgroups.protocols.SMACK.SmackHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.pbcast.STABLE.StableHeader
readExternal(ObjectInput) - method in class org.jgroups.util.Stack
readExternal(ObjectInput) - method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.TcpHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.TOTAL.Header
Manual deserialization
readExternal(ObjectInput) - method in class org.jgroups.protocols.TOTAL_OLD.TotalHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.TOTAL_TOKEN.RingTokenHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.TOTAL_TOKEN.TotalTokenHeader
Manual deserialization
readExternal(ObjectInput) - method in class org.jgroups.protocols.TpHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.TunnelHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.UdpHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.UNICAST.UnicastHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
readExternal(ObjectInput) - method in class org.jgroups.View
readExternal(ObjectInput) - method in class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
readExternal(ObjectInput) - method in class org.jgroups.ViewId
readExternal(ObjectInput) - method in class org.jgroups.protocols.WANPIPE.WanPipeHeader
readExternal(ObjectInput) - method in class org.jgroups.protocols.WanPipeAddress
readExternal(ObjectInput) - method in class org.jgroups.blocks.Xid
readFrom(DataInputStream) - method in class org.jgroups.protocols.COMPRESS.CompressHeader
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.protocols.pbcast.Digest
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.protocols.FC.FcHeader
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.protocols.FD.FdHeader
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.protocols.FD_SOCK.FdHeader
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.protocols.FragHeader
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.protocols.HTOTAL.HTotalHeader
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.stack.IpAddress
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.protocols.JMS.JMSAddress
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.protocols.pbcast.JoinRsp
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.stack.LogicalAddress
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.MergeView
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.Message
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.protocols.pbcast.NakAckHeader
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.protocols.PingHeader
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.protocols.PingRsp
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.util.Range
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.blocks.RequestCorrelator.Header
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.protocols.pbcast.STABLE.StableHeader
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class 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(DataInputStream) - method in class org.jgroups.protocols.TcpHeader
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.protocols.TpHeader
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.protocols.UdpHeader
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.protocols.UNICAST.UnicastHeader
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.View
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.ViewId
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readFrom(DataInputStream) - method in class org.jgroups.protocols.WanPipeAddress
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
readGenericStreamable(DataInputStream) - static method in class org.jgroups.util.Util
readLock() - method in class org.jgroups.util.NullReadWriteLock
readMagicNumberMapping() - method in class org.jgroups.conf.MagicNumberReader
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)
readObject(DataInputStream) - static method in class org.jgroups.util.Util
readStreamable(Class,DataInputStream) - static method in class org.jgroups.util.Util
readString(DataInputStream) - static method in class org.jgroups.util.Util
reason - field in class org.jgroups.persistence.CannotConnectException
reason - field in class org.jgroups.persistence.CannotRemoveException
REBROADCAST_MSGS - static field in class org.jgroups.Event
REBROADCAST_MSGS_OK - static field in class org.jgroups.Event
receive() - method in class org.jgroups.stack.RouterStub
Receives a message from the router (blocking mode).
receive(byte[]) - method in class org.jgroups.blocks.Link.Receiver
receive(byte[]) - method in class org.jgroups.blocks.LogicalLink
Receive a message from any of the physical links.
receive(byte[]) - method in class org.jgroups.blocks.LogicalLink.Receiver
receive(byte[]) - method in class org.jgroups.protocols.WANPIPE
receive(DatagramPacket) - method in class org.jgroups.protocols.UDP_NIO
receive(DatagramPacket) - method in class org.jgroups.protocols.UDP_NIO.ConnectorTable
receive(DatagramPacket) - method in class org.jgroups.protocols.UDP_NIO.MyReceiver
receive(long) - method in class org.jgroups.Channel
Receives a message, a view change or a block event.
receive(long) - method in class org.jgroups.JChannel
Blocking receive method.
receive(long) - method in class org.jgroups.jmx.JChannel
receive(long) - method in class org.jgroups.jmx.JChannelMBean
receive(long) - method in class org.jgroups.stack.ProtocolStack
receive(long) - method in class org.jgroups.Transport
Calls the receiver callback.
receive(org.jgroups.Address,byte[],int,int) - method in class org.jgroups.protocols.TCP
ConnectionTable.Receiver interface
Subclasses must call this method when a unicast or multicast message has been received.
Receives data sent by a sender to all group members and applies update to locally replicated data.
receive(org.jgroups.Event) - method in class org.jgroups.blocks.RequestCorrelator
Callback.
receive(org.jgroups.Event) - method in class org.jgroups.debug.Simulator
receive(org.jgroups.Event) - method in class org.jgroups.debug.Simulator.Receiver
receive(org.jgroups.Message) - method in class org.jgroups.demos.Chat
receive(org.jgroups.Message) - method in class org.jgroups.blocks.DistributedHashtable
Called when a message is received.
receive(org.jgroups.Message) - method in class org.jgroups.blocks.DistributedQueue
Called when a message is received.
receive(org.jgroups.Message) - method in class org.jgroups.blocks.DistributedTree
Called when a message is received.
receive(org.jgroups.Message) - method in class org.jgroups.MessageListener
Called when a message is received.
receive(org.jgroups.Message) - method in class org.jgroups.blocks.MessageListenerAdapter
Receive message from group.
receive(org.jgroups.Message) - method in class org.jgroups.blocks.NotificationBus
Called when a message is received.
receive(org.jgroups.Message) - method in class org.jgroups.demos.QuoteServer
Called when a message is received.
receive(org.jgroups.Message) - method in class org.jgroups.ReceiverAdapter
Called when a message is received.
receive(org.jgroups.Message) - method in class org.jgroups.blocks.ReplicatedHashtable
Called when a message is received.
receive(org.jgroups.Message) - method in class org.jgroups.blocks.ReplicatedTree
Callback.
receive(org.jgroups.Message) - method in class org.jgroups.blocks.VotingAdapter
Receive the message.
receive(org.jgroups.Message) - method in class org.jgroups.demos.wb.Whiteboard
Called when a message is received.
receive_buffer - field in class org.jgroups.protocols.UDP_NIO.Connector
Buffer for incoming unicast packets
received_bytes - field in class org.jgroups.JChannel
received_msgs - field in class org.jgroups.JChannel
Heartbeat came back again (before link was taken down) after missing some heartbeats
receiveDownEvent(org.jgroups.Event) - method in class org.jgroups.protocols.FC
We need to receive view changes concurrent to messages on the down events: a message might blocks, e.g.
receiveDownEvent(org.jgroups.Event) - method in class org.jgroups.protocols.FLUSH
The default handling adds the event to the down-queue where events are handled in order of addition by a thread.
receiveDownEvent(org.jgroups.Event) - method in class org.jgroups.protocols.GMS
receiveDownEvent(org.jgroups.Event) - method in class org.jgroups.stack.Protocol
Internal method, should not be called by clients.
receiveMessage(org.jgroups.Message) - method in class org.jgroups.blocks.RequestCorrelator
Handles a message coming from a layer below
receiver - field in class org.jgroups.Channel
ConnectionTable.Receiver - interface org.jgroups.blocks.ConnectionTable.Receiver
Used for message reception.
Link.Receiver - interface org.jgroups.blocks.Link.Receiver
LogicalLink.Receiver - interface org.jgroups.blocks.LogicalLink.Receiver
Receiver - interface org.jgroups.Receiver
Defines the callbacks that are invoked when messages, views etc are received on a channel
Simulator.Receiver - interface org.jgroups.debug.Simulator.Receiver
receiver_thread - field in class org.jgroups.blocks.PullPushAdapter
ReceiverAdapter - class org.jgroups.ReceiverAdapter
receiveResponse(org.jgroups.Message) - method in class org.jgroups.blocks.GroupRequest
Callback (called by RequestCorrelator or Transport).
receiveResponse(org.jgroups.Message) - method in class org.jgroups.blocks.RspCollector
receiveSuspect(org.jgroups.Address) - method in class org.jgroups.blocks.RequestCorrelator
Event.SUSPECT event received from a layer below.
receiveToken() - method in class org.jgroups.protocols.ring.RingNode
receiveToken() - method in class org.jgroups.protocols.ring.TcpRingNode
receiveToken() - method in class org.jgroups.protocols.ring.UdpRingNode
receiveToken(int) - method in class org.jgroups.protocols.ring.RingNode
receiveToken(int) - method in class org.jgroups.protocols.ring.TcpRingNode
receiveToken(int) - method in class org.jgroups.protocols.ring.UdpRingNode
receiveUpEvent(org.jgroups.Event) - method in class org.jgroups.protocols.pbcast.GMS
This method is overridden to avoid hanging on getDigest(): when a JOIN is received, the coordinator needs to retrieve the digest from the NAKACK layer.
receiveUpEvent(org.jgroups.Event) - method in class org.jgroups.stack.Protocol
Internal method, should not be called by clients.
receiveUpEvent(org.jgroups.Event) - method in class org.jgroups.stack.ProtocolStack
receiveView(org.jgroups.View) - method in class org.jgroups.blocks.RequestCorrelator
Event.VIEW_CHANGE event received from a layer below.
reconfigure(Vector) - method in class org.jgroups.protocols.ring.RingNode
reconfigure(Vector) - method in class org.jgroups.protocols.ring.TcpRingNode
reconfigure(Vector) - method in class org.jgroups.protocols.ring.UdpRingNode
reconfigureAll(Vector) - method in class org.jgroups.protocols.ring.TcpRingNode
reconnect() - method in class org.jgroups.stack.RouterStub
reconnect(int) - method in class org.jgroups.stack.RouterStub
Tries to establish connection to router.
RECOVERY - static field in class org.jgroups.protocols.ring.RingToken
ReentrantLatch - class org.jgroups.util.ReentrantLatch
Enables safely locking and unlocking a shared resource, without blocking the calling threads.
ReentrantLatch() - constructor for class org.jgroups.util.ReentrantLatch
Create a new unlocked latch.
ReentrantLatch(boolean) - constructor for class org.jgroups.util.ReentrantLatch
Create a reentrant latch
REGISTER - static field in class org.jgroups.stack.GossipRouter
REGISTER - static field in class org.jgroups.stack.Router
register(String) - method in class org.jgroups.stack.RouterStub
Register this process with the router under groupname.
register(String,org.jgroups.Address) - method in class org.jgroups.stack.GossipClient
Adds the member to the given group.
REGISTER_REQ - static field in class org.jgroups.stack.GossipData
Registers an already created channel with the MBeanServer.
Sets a listener to messages with a given identifier.
Register a custom persistence manager as opposed to the FilePersistenceManager or DBPersistenceManager.
Takes all protocols of an existing stack, creates corresponding MBean proxies and registers them with the MBean server
release() - method in class org.jgroups.util.NullSync
This class represents the lock to be released.
remove() - method in class org.jgroups.stack.AckReceiverWindow
Removes a message whose seqno is equal to next_to_remove, increments the latter.
remove() - method in class org.jgroups.blocks.DistributedQueue
Try to return the first objet in the queue.It does not wait for an object.
remove() - method in class org.jgroups.util.LinkedListQueue
Removes 1 element from head or blocks until next element has been added
remove() - method in class org.jgroups.util.List
Removes an object from the tail of the list.
remove() - method in class org.jgroups.stack.NakReceiverWindow
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() - method in class org.jgroups.util.Queue2
Removes 1 element from head or blocks until next element has been added or until queue has been closed
remove(Collection) - method in class org.jgroups.Membership
removes all the members contained in v from this membership
remove(long) - method in class org.jgroups.blocks.DistributedQueue
remove(long) - method in class org.jgroups.util.LinkedListQueue
Removes 1 element from the head.
remove(long) - method in class org.jgroups.util.Queue
Removes 1 element from the head.
remove(long) - method in class org.jgroups.util.Queue2
Removes 1 element from the head.
remove(long) - method in class org.jgroups.stack.Retransmitter
Remove the given sequence number from the list of seqnos eligible for retransmission.
remove(Object) - method in class org.jgroups.blocks.DistributedHashtable
Removes the key (and its corresponding value) from the Hashtable.
remove(Object) - method in class org.jgroups.blocks.ReplicatedHashtable
Removes the key (and its corresponding value) from the Hashtable.
remove(Object,Vector) - method in class org.jgroups.stack.AckMcastReceiverWindow
remove(org.jgroups.Address) - method in class org.jgroups.stack.AckMcastSenderWindow
Remove obj from all receiver sets and wake up retransmission thread.
remove(org.jgroups.Address) - method in class org.jgroups.blocks.ConnectionTable
Remove addrfrom connection table.
remove(org.jgroups.Address) - method in class org.jgroups.Membership
removes an member from the membership.
remove(Serializable) - method in class org.jgroups.persistence.DBPersistenceManager
Removes existing entry.
remove(Serializable) - method in class org.jgroups.persistence.FilePersistenceManager
Remove existing NV from being persisted
remove(Serializable) - method in class org.jgroups.persistence.PersistenceManager
Remove existing NV from being persisted
remove(String) - method in class org.jgroups.blocks.DistributedTree
remove(String) - method in class org.jgroups.blocks.ReplicatedTree
Removes the node from the tree.
remove(String,int) - method in class org.jgroups.blocks.DistributedTree
remove(String,String) - method in class org.jgroups.blocks.ReplicatedTree
Removes key from the node's hashmap
removeAll() - method in class org.jgroups.stack.AckMcastReceiverWindow
removeAll() - method in class org.jgroups.util.List
removeAllLinks() - method in class org.jgroups.blocks.LogicalLink
removeAllPhysicalAddresses() - method in class org.jgroups.stack.LogicalAddress
For internal use only.
removeElement(Object) - method in class org.jgroups.util.LinkedListQueue
removes a specific object from the queue.
removeElement(Object) - method in class org.jgroups.util.List
Removes element obj from the list, checking for equality using the equals operator.
removeElement(Object) - method in class org.jgroups.util.Queue
removes a specific object from the queue.
removeElement(Object) - method in class org.jgroups.util.Queue2
removes a specific object from the queue.
removeFromHead() - method in class org.jgroups.util.List
Removes an object from the head of the list.
removeFromNotSeenList(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.Gossip
Removes obj from not_seen list
removeHeader(String) - method in class org.jgroups.Message
removeHeaders() - method in class org.jgroups.Message
Removes the listener from the voteChannel
Remove membership listener from this adapter.
Remove message listener from this adapter.
removeNode(Object) - method in class org.jgroups.demos.wb.GraphPanel
removeNode(Object) - method in class org.jgroups.demos.Topology
removeNode(Object) - method in class org.jgroups.demos.wb.Whiteboard
removePhysicalAddress(SocketAddress) - method in class org.jgroups.stack.LogicalAddress
For internal use only.
removeProtocol(String) - method in class org.jgroups.stack.Configurator
Removes a protocol from the stack.
removeProtocol(String) - method in class org.jgroups.stack.ProtocolStack
Removes a protocol from the stack.
Removes voting listener.
REP - static field in class org.jgroups.protocols.TOTAL.Header
Reply to broadcast request.
repaint() - method in class org.jgroups.demos.wb.Whiteboard
REPEATABLE_READ - static field in class org.jgroups.blocks.Xid
Each read causes the data read to be copied to the private workspace, so subsequent reads always read the private data.
replace(org.jgroups.protocols.pbcast.Digest) - method in class org.jgroups.protocols.pbcast.Digest
replace(String,String,String) - static method in class org.jgroups.conf.XmlConfigurator
REPLENISH - static field in class org.jgroups.protocols.FC.FcHeader
ReplicatedHashtable - class org.jgroups.blocks.ReplicatedHashtable
Provides the abstraction of a java.util.Hashtable that is replicated at several locations.
ReplicatedHashtable(org.jgroups.JChannel,long) - constructor for class org.jgroups.blocks.ReplicatedHashtable
Creates a ReplicatedHashtable
ReplicatedTree - class org.jgroups.blocks.ReplicatedTree
A tree-like structure that is replicated across several members.
ReplicatedTree() - constructor for class org.jgroups.blocks.ReplicatedTree
ReplicatedTree(org.jgroups.JChannel) - constructor for class org.jgroups.blocks.ReplicatedTree
Expects an already connected channel.
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
ReplicatedTreeDemo - class org.jgroups.demos.ReplicatedTreeDemo
Graphical view of a ReplicatedTree
ReplicationData - class org.jgroups.blocks.ReplicationData
Class used for data exchange by ReplicationManager and ReplicationReceiver.
ReplicationData() - constructor for class org.jgroups.blocks.ReplicationData
ReplicationManager - class org.jgroups.blocks.ReplicationManager
Class to propagate updates to a number of nodes in various ways:
  1. Asynchronous
  2. Synchronous
  3. Synchronous with locking

Note: This class is experimental as of Oct 2002
Creates an instance of ReplicationManager on top of a PullPushAdapter
Creates an instance of ReplicationManager on top of a Channel
ReplicationReceiver - interface org.jgroups.blocks.ReplicationReceiver
Implementation of this interface needs to register with ReplicationManager and will receive updates to be applied to its locally replicated data.
REQ - static field in class org.jgroups.protocols.BSH.BshHeader
REQ - static field in class org.jgroups.blocks.RequestCorrelator.Header
REQ - static field in class org.jgroups.protocols.TOTAL.Header
Request to broadcast by the source
req_handler - field in class org.jgroups.blocks.MessageDispatcher
GMS.Request - class org.jgroups.protocols.pbcast.GMS.Request
request_handler - field in class org.jgroups.blocks.RequestCorrelator
The handler for the incoming requests.
request_msg - field in class org.jgroups.blocks.GroupRequest
RequestCorrelator - class org.jgroups.blocks.RequestCorrelator
Framework to send requests and receive matching responses (matching on request ID).
Constructor.
Constructor.
requester - field in class org.jgroups.blocks.DistributedLockManager.LockDecree
requester - field in class org.jgroups.stack.StateTransferInfo
RequestHandler - interface org.jgroups.blocks.RequestHandler
requests - field in class org.jgroups.blocks.RequestCorrelator
The table of pending requests (keys=Long (request IDs), values=RequestEntry)
requestTypeToString(int) - static method in class org.jgroups.stack.GossipRouter
requiredDownServices() - method in class org.jgroups.protocols.FLUSH
requiredDownServices() - method in class org.jgroups.protocols.GMS
requiredDownServices() - method in class org.jgroups.protocols.pbcast.GMS
requiredDownServices() - method in class org.jgroups.protocols.MERGE2
requiredDownServices() - method in class org.jgroups.stack.Protocol
List of events that are required to be answered by some layer below.
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.TOTAL
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.
requiredUpServices() - method in class org.jgroups.protocols.STABLE
The events expected to be handled from some layer above:
  • GET_MSGS_RECEIVED: NAKACK layer
requiredUpServices() - method in class org.jgroups.protocols.STATE_TRANSFER
List of events that are required to be answered by some layer above.
requiredUpServices() - method in class org.jgroups.protocols.TOTAL
List of events that are required to be answered by some layer above.
reset() - method in class org.jgroups.stack.AckMcastReceiverWindow
reset() - method in class org.jgroups.stack.AckMcastSenderWindow
Remove all pending msgs from the hashtable.
reset() - method in class org.jgroups.stack.AckReceiverWindow
reset() - method in class org.jgroups.stack.AckSenderWindow
reset() - method in class org.jgroups.protocols.pbcast.Digest.Entry
reset() - method in class org.jgroups.blocks.DistributedQueue
reset() - static method in class org.jgroups.protocols.DUMMY
Just remove if you don't need to reset any state
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.ENCRYPT1_4
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.util.ExposedDataOutputStream
reset() - method in class org.jgroups.stack.Interval
reset() - method in class org.jgroups.util.LinkedListQueue
resets the queue.
reset() - method in class org.jgroups.protocols.LOSS
Just remove if you don't need to reset any state
reset() - method in class org.jgroups.Message
Nulls all fields of this message so that the message can be reused.
reset() - method in class org.jgroups.stack.NakReceiverWindow
Reset the retransmitter and the nak window
reset() - method in class org.jgroups.blocks.NBMessageForm_NIO
reset() - method in class org.jgroups.protocols.PARTITIONER
Just remove if you don't need to reset any state
reset() - method in class org.jgroups.protocols.PERF_TP
reset() - method in class org.jgroups.protocols.PRINTOBJS
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.Queue2
resets the queue.
reset() - method in class org.jgroups.stack.Retransmitter
Reset the retransmitter: clear all msgs and cancel all the respective tasks
reset() - method in class org.jgroups.util.RspList
reset() - method in class org.jgroups.protocols.TOTAL_OLD
Just remove if you don't need to reset any state
reset() - method in class org.jgroups.protocols.VectorTime
Resets all the values in this vector clock to 0
reset(int) - method in class org.jgroups.util.ExposedBufferedInputStream
reset(int) - method in class org.jgroups.util.ExposedBufferedOutputStream
reset(org.jgroups.ViewId,java.util.List) - method in class org.jgroups.util.AckCollector
reset(String,Serializable) - method in class org.jgroups.blocks.DistributedTree
resets an existing node, useful after a merge when you want to tell other members of your state, but do not wish to remove and then add as two separate calls
reset(String,Serializable,int) - method in class org.jgroups.blocks.DistributedTree
resets an existing node, useful after a merge when you want to tell other members of your state, but do not wish to remove and then add as two separate calls
reset(Vector) - method in class org.jgroups.blocks.GroupRequest
This method sets the membership variable to the value of members.
resetAt(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.Digest
Resets the seqnos for the sender at 'index' to 0.
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_SOCK
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.JChannel
resetStats() - method in class org.jgroups.jmx.JChannel
resetStats() - method in class org.jgroups.jmx.JChannelMBean
resetStats() - method in class org.jgroups.protocols.pbcast.NAKACK
resetStats() - method in class org.jgroups.jmx.Protocol
resetStats() - method in class org.jgroups.stack.Protocol
resetStats() - method in class org.jgroups.jmx.ProtocolMBean
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.STATS
resetStats() - method in class org.jgroups.protocols.TP
resetStats() - method in class org.jgroups.protocols.UNICAST
resetStats() - method in class org.jgroups.protocols.VIEW_SYNC
resolveEntity(String,String) - method in class org.jgroups.conf.ClassPathEntityResolver
result - field in class org.jgroups.protocols.FlushRsp
resume() - method in class org.jgroups.JChannel
Send() unblocks
resume() - method in class org.jgroups.jmx.JChannel
resume() - method in class org.jgroups.jmx.JChannelMBean
resume() - method in class org.jgroups.util.ReusableThread
Resumes the thread.
RESUME_STABLE - static field in class org.jgroups.Event
resumed(Runnable) - method in class org.jgroups.util.SchedulerListener
resumeViewHandler() - method in class org.jgroups.jmx.protocols.pbcast.GMS
resumeViewHandler() - method in class org.jgroups.protocols.pbcast.GMS
resumeViewHandler() - method in class org.jgroups.jmx.protocols.pbcast.GMSMBean
retransmit(long,long,org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.NAKACK
Implementation of Retransmitter.RetransmitCommand.
Get the missing messages between sequence numbers first_seqno and last_seqno.
retransmit(long,org.jgroups.Message) - method in class org.jgroups.protocols.UNICAST
Called by AckSenderWindow to resend messages for which no ACK has been received yet
Retranmit the given msg
retransmit(long,org.jgroups.Message,org.jgroups.Address) - method in class org.jgroups.protocols.SMACK
Retranmit the given msg
RETRANSMIT_MSG - static field in class org.jgroups.protocols.NakAckHeader
Called by retransmitter thread whenever a message needs to be re-sent to a destination.
Retransmit command (see Gamma et al.) used to retrieve missing messages
Retransmitter - class org.jgroups.stack.Retransmitter
Maintains a pool of sequence numbers of messages that need to be retransmitted.
Create a new Retransmitter associated with the given sender address
Create a new Retransmitter associated with the given sender address
retrieveAll() - method in class org.jgroups.persistence.DBPersistenceManager
Used to retrieve the persisted map back to its last known state
retrieveAll() - method in class org.jgroups.persistence.FilePersistenceManager
Gives back the Map in last known state
retrieveAll() - method in class org.jgroups.persistence.PersistenceManager
Gives back the Map in last known state
returnState(byte[]) - method in class org.jgroups.Channel
Called by the application is response to receiving a getState() object when calling receive().
returnState(byte[]) - method in class org.jgroups.JChannel
Called by the application is response to receiving a getState() object when calling receive().
returnState(byte[]) - method in class org.jgroups.jmx.JChannel
returnState(byte[]) - method in class org.jgroups.jmx.JChannelMBean
ReusableThread - class org.jgroups.util.ReusableThread
Reusable thread class.
ReusableThread() - constructor for class org.jgroups.util.ReusableThread
ReusableThread(String) - constructor for class org.jgroups.util.ReusableThread
RingNode - interface org.jgroups.protocols.ring.RingNode
RingNodeFlowControl - class org.jgroups.protocols.ring.RingNodeFlowControl
RingNodeFlowControl() - constructor for class org.jgroups.protocols.ring.RingNodeFlowControl
RingNodeFlowControl(int,float,int,float) - constructor for class org.jgroups.protocols.ring.RingNodeFlowControl
RingToken - class org.jgroups.protocols.ring.RingToken
RingToken() - constructor for class org.jgroups.protocols.ring.RingToken
RingToken(int) - constructor for class org.jgroups.protocols.ring.RingToken
RingTokenHeader() - constructor for class org.jgroups.protocols.TOTAL_TOKEN.RingTokenHeader
ROLLBACK - static field in class org.jgroups.blocks.ReplicationData
rollback(org.jgroups.blocks.Xid) - method in class org.jgroups.blocks.ReplicationManager
Discards all modifications sent to the receivers via send(Address,byte[],boolean,long,Xid,byte[],long,long,boolean) and releases all locks associated with this transaction.
rollback(org.jgroups.blocks.Xid) - method in class org.jgroups.blocks.ReplicationReceiver
Discard all modifications and release all locks.
Router - class org.jgroups.stack.Router
Router for TCP based group comunication (using layer TCP instead of UDP).
Router(int) - constructor for class org.jgroups.stack.Router
Router(int,InetAddress) - constructor for class org.jgroups.stack.Router
RouterStub - class org.jgroups.stack.RouterStub
RouterStub(String,int) - constructor for class org.jgroups.stack.RouterStub
Creates a stub for a remote Router object.
ROUTING_CLIENT_REPLY_TIMEOUT - static field in class org.jgroups.stack.GossipRouter
RpcDispatcher - class org.jgroups.blocks.RpcDispatcher
This class allows a programmer to invoke remote methods in all (or single) group members and optionally wait for the return value(s).
RpcProtocol - class org.jgroups.stack.RpcProtocol
Base class for group RMC peer protocols.
RpcProtocolEXAMPLE - class org.jgroups.protocols.RpcProtocolEXAMPLE
rrror(String) - method in class org.jgroups.demos.TotalOrder
RSP - static field in class org.jgroups.protocols.BSH.BshHeader
Rsp - class org.jgroups.util.Rsp
class that represents a response from a communication
RSP - static field in class org.jgroups.blocks.RequestCorrelator.Header
Rsp(org.jgroups.Address) - constructor for class org.jgroups.util.Rsp
Rsp(org.jgroups.Address,boolean) - constructor for class org.jgroups.util.Rsp
Rsp(org.jgroups.Address,Object) - constructor for class org.jgroups.util.Rsp
rsp_expected - field in class org.jgroups.blocks.RequestCorrelator.Header
msg is synchronous if true
rsp_mode - field in class org.jgroups.blocks.GroupRequest
RspCollector - interface org.jgroups.blocks.RspCollector
RspList - class org.jgroups.util.RspList
Contains responses from all members.
RspList() - constructor for class org.jgroups.util.RspList
RspList(Collection) - constructor for class org.jgroups.util.RspList
run() - method in class org.jgroups.demos.CausalDemo
run() - method in class org.jgroups.blocks.ConnectionTable
Acceptor thread.
run() - method in class org.jgroups.blocks.ConnectionTableNIO
Acceptor thread.
run() - method in class org.jgroups.demos.applets.DrawApplet
run() - method in class org.jgroups.demos.DrawRepl
run() - method in class org.jgroups.protocols.pbcast.FD
run() - method in class org.jgroups.protocols.FD_PROB
Loop while more than 1 member available.
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.FLOW_CONTROL
FCInfo request must be submitted in a different thread.
run() - method in class org.jgroups.protocols.GMS
run() - method in class org.jgroups.demos.Gossip
run() - method in class org.jgroups.stack.GossipServer
run() - method in class org.jgroups.blocks.Link
Receiver thread main loop.
run() - method in class org.jgroups.protocols.MERGE
If IP multicast: periodically mcast a HELLO message If gossiping: periodically retrieve the membership.
run() - method in class org.jgroups.protocols.MPING
run() - method in class org.jgroups.protocols.pbcast.PBCAST
Gossip thread.
run() - method in class org.jgroups.protocols.PingSender
run() - method in class org.jgroups.protocols.PingWaiter
run() - method in class org.jgroups.blocks.PullPushAdapter
Reentrant run(): message reception is serialized, then the listener is notified of the message reception
run() - method in class org.jgroups.blocks.ReplicatedTree
Request handler thread
run() - method in class org.jgroups.util.ReusableThread
Delicate piece of code (means very important :-)).
run() - method in class org.jgroups.util.Scheduler
run() - method in class org.jgroups.protocols.SHUFFLE
Removes a random chosen message from the messages List<\code> if there are less than 10 messages in the List it waits some time to ensure to chose from a set of messages > 1.
run() - method in class org.jgroups.util.TimeScheduler.Task
Execute the task
run() - method in class org.jgroups.demos.TotalTokenDemo
run() - method in class org.jgroups.protocols.TUNNEL
run() - method in class org.jgroups.protocols.UDP
run() - method in class org.jgroups.protocols.UDP.UcastReceiver
run() - method in class org.jgroups.protocols.UDP_NIO.Connector
run() - method in class org.jgroups.protocols.UDP_NIO.ConnectorTable
run() - method in class org.jgroups.protocols.UDP_NIO.MulticastReceiver
run() - method in class org.jgroups.protocols.VERIFY_SUSPECT
Will be started when a suspect is added to the suspects hashtable.
runMessageGarbageCollection() - method in class org.jgroups.jmx.protocols.pbcast.STABLE
runMessageGarbageCollection() - method in class org.jgroups.protocols.pbcast.STABLE
runMessageGarbageCollection() - method in class org.jgroups.jmx.protocols.pbcast.STABLEMBean

S

sameHost(org.jgroups.Address,org.jgroups.Address) - static method in class org.jgroups.util.Util
Checks whether 2 Addresses are on the same host
sameSenders(org.jgroups.protocols.pbcast.Digest) - method in class org.jgroups.protocols.pbcast.Digest
Compares two digests and returns true if the senders are the same, otherwise false.
sanityCheck(Vector) - method in class org.jgroups.stack.Configurator
Throws an exception if sanity check fails.
save(Serializable,Serializable) - method in class org.jgroups.persistence.DBPersistenceManager
Saves NV pair as serializable object; creates if new, stores new state if already exists.
save(Serializable,Serializable) - method in class org.jgroups.persistence.FilePersistenceManager
Save new NV pair as serializable objects or if already exist; store new state
save(Serializable,Serializable) - method in class org.jgroups.persistence.PersistenceManager
Save new NV pair as serializable objects or if already exist; store new state
saveAll(Map) - method in class org.jgroups.persistence.DBPersistenceManager
Saves all row entries for the map to DB.
saveAll(Map) - method in class org.jgroups.persistence.FilePersistenceManager
Use to store a complete map into persistent state
saveAll(Map) - method in class org.jgroups.persistence.PersistenceManager
Use to store a complete map into persistent state
saveState() - method in class org.jgroups.demos.wb.GraphPanel
Scheduler - class org.jgroups.util.Scheduler
Implementation of a priority scheduler.
scheduler - field in class org.jgroups.blocks.RequestCorrelator
The dispatching thread pool
Scheduler() - constructor for class org.jgroups.util.Scheduler
Scheduler(int) - constructor for class org.jgroups.util.Scheduler
SchedulerListener - interface org.jgroups.util.SchedulerListener
Provides callback for use with a Scheduler.
SECRETKEY - static field in class org.jgroups.protocols.ENCRYPT.EncryptHeader
SECRETKEY_READY - static field in class org.jgroups.protocols.ENCRYPT.EncryptHeader
SEND - static field in class org.jgroups.blocks.ReplicationData
send(byte[]) - method in class org.jgroups.blocks.Link
Tries to send buffer across out socket.
send(byte[]) - method in class org.jgroups.blocks.LogicalLink
Send a message to the other side
send(DatagramPacket) - method in class org.jgroups.protocols.UDP_NIO.Connector
Sends a message using mcast_sock
send(DatagramPacket) - method in class org.jgroups.protocols.UDP_NIO.ConnectorTable
Sends a packet.
Sends a request to all members of the group.
send(org.jgroups.Address,byte[],int,int) - method in class org.jgroups.blocks.ConnectionTable
Helper method.
creates a new message with the destination address, and the source address and the object as the message value
send(org.jgroups.Event) - method in class org.jgroups.debug.Simulator
send(org.jgroups.Message) - method in class org.jgroups.Channel
Sends a message to a (unicast) destination.
send(org.jgroups.Message) - method in class org.jgroups.JChannel
Sends a message through the protocol stack.
send(org.jgroups.Message) - method in class org.jgroups.jmx.JChannel
send(org.jgroups.Message) - method in class org.jgroups.jmx.JChannelMBean
send(org.jgroups.Message) - method in class org.jgroups.blocks.MessageDispatcher
send(org.jgroups.Message) - method in class org.jgroups.stack.ProtocolStack
send(org.jgroups.Message) - method in class org.jgroups.blocks.PullPushAdapter
Sends a message with no identifier; listener member will get this message on the other group members.
send(org.jgroups.Message) - method in class org.jgroups.Transport
send(org.jgroups.Message,String) - method in class org.jgroups.stack.RouterStub
Sends a message to the router.
send(Serializable,org.jgroups.Message) - method in class org.jgroups.blocks.PullPushAdapter
Sends a message to the group - listeners to this identifier will receive the messages.
sendClearPanelMsg() - method in class org.jgroups.demos.Draw
sendClearPanelMsg() - method in class org.jgroups.demos.Draw2Channels
sendClearPanelMsg() - method in class org.jgroups.demos.applets.DrawApplet
sendClearPanelMsg() - method in class org.jgroups.demos.Gossip
SendDialog - class org.jgroups.demos.wb.SendDialog
sender_thread - field in class org.jgroups.protocols.UDP_NIO.Connector
sendGetMembersRequest() - method in class org.jgroups.protocols.Discovery
sendGetMembersRequest() - method in class org.jgroups.protocols.PING
sendGetMembersRequest() - method in class org.jgroups.protocols.TCPGOSSIP
sendGetMembersRequest() - method in class org.jgroups.protocols.TCPPING
sendGetMembersRequest() - method in class org.jgroups.protocols.WANPING
sendMergeRejectedResponse(org.jgroups.Address,org.jgroups.ViewId) - method in class org.jgroups.protocols.pbcast.GmsImpl
sendMessage(org.jgroups.Message) - method in class org.jgroups.protocols.JMS
Publish message in the JMS topic.
Sends a message to a single member (destination = msg.dest) and returns the response.
Sends a message to a single member (destination = msg.dest) and returns the response.
sendMessage(org.jgroups.Message,int,long) - method in class org.jgroups.blocks.RpcDispatcher
sendNotification(Serializable) - method in class org.jgroups.blocks.NotificationBus
Pack the argument in a Info, serialize that one into the message buffer and send the message
Send a request to a group.
sendRequest(org.jgroups.Address) - method in class org.jgroups.protocols.DEADLOCK
sendToAll(String) - method in class org.jgroups.jmx.JChannel
sendToAll(String) - method in class org.jgroups.jmx.JChannelMBean
sendToAllMembers(byte[],int,int) - method in class org.jgroups.protocols.TCP
sendToAllMembers(byte[],int,int) - method in class org.jgroups.protocols.TP
Send to all members in the group.
sendToAllMembers(byte[],int,int) - method in class org.jgroups.protocols.UDP
sendToSingleMember(org.jgroups.Address,byte[],int,int) - method in class org.jgroups.protocols.TCP
sendToSingleMember(org.jgroups.Address,byte[],int,int) - method in class org.jgroups.protocols.TP
Send to all members in the group.
sendToSingleMember(org.jgroups.Address,byte[],int,int) - method in class org.jgroups.protocols.UDP
sendViewRequest() - method in class org.jgroups.jmx.protocols.VIEW_SYNC
sendViewRequest() - method in class org.jgroups.protocols.VIEW_SYNC
Sends a VIEW_SYNC_REQ to all members, every member replies with a VIEW multicast
sendViewRequest() - method in class org.jgroups.jmx.protocols.VIEW_SYNCMBean
senseMaxFragSize() - method in class org.jgroups.protocols.AUTOCONF
Tries to find out the max number of bytes in a DatagramPacket we can send by sending increasingly larger packets, until there is an exception (e.g., java.io.IOException: message too long).
senseMaxFragSizeStatic() - static method in class org.jgroups.protocols.AUTOCONF
sent_bytes - field in class org.jgroups.JChannel
sent_msgs - field in class org.jgroups.JChannel
SEPARATOR - static field in class org.jgroups.blocks.ReplicatedTree
seq_id - field in class org.jgroups.protocols.TOTAL_OLD.TotalHeader
For TOTAL_BCAST messages, seq_id is used to determine the order of messages in the view.
sequenceID - field in class org.jgroups.protocols.TOTAL.Header
The ID imposing the total order of messages
SERIALIZABLE - static field in class org.jgroups.blocks.Xid
Reads and writes require locks.
serializedSize() - method in class org.jgroups.protocols.pbcast.Digest
serializedSize() - method in class org.jgroups.protocols.pbcast.JoinRsp
serializedSize() - method in class org.jgroups.MergeView
serializedSize() - method in class org.jgroups.View
serializedSize() - method in class org.jgroups.ViewId
server_obj - field in class org.jgroups.blocks.RpcDispatcher
SERVER_PUBKEY - static field in class org.jgroups.protocols.ENCRYPT.EncryptHeader
set(Collection) - method in class org.jgroups.Membership
Clear 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(Object) - method in class org.jgroups.util.CondVar
Sets the result
set(org.jgroups.Address,long,long,long) - method in class org.jgroups.protocols.pbcast.Digest
set(org.jgroups.Membership) - method in class org.jgroups.Membership
Clear 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(String,Serializable) - method in class org.jgroups.blocks.DistributedTree
set(String,Serializable,int) - method in class org.jgroups.blocks.DistributedTree
SET_DIGEST - static field in class org.jgroups.Event
SET_LOCAL_ADDRESS - static field in class org.jgroups.Event
SET_PARTITIONS - static field in class org.jgroups.Event
SET_PID - static field in class org.jgroups.Event
setAdditionalData(byte[]) - method in class org.jgroups.stack.IpAddress
Sets the additional_data.
setAdditionalData(byte[]) - method in class org.jgroups.stack.LogicalAddress
Sets the additional_data.
setAddress(String) - method in class org.jgroups.protocols.JMS.JMSAddress
Set the node address.
setAllReceivedUpto(long) - method in class org.jgroups.protocols.ring.RingToken
setArg(Object) - method in class org.jgroups.Event
setArgs(Object[]) - method in class org.jgroups.blocks.MethodCall
setAruId(org.jgroups.Address) - method in class org.jgroups.protocols.ring.RingToken
Sets a message associated with this vector timestamp
setAutoGetState(boolean) - method in class org.jgroups.jmx.JChannel
setAutoGetState(boolean) - method in class org.jgroups.jmx.JChannelMBean
setAutoReconnect(boolean) - method in class org.jgroups.jmx.JChannel
setAutoReconnect(boolean) - method in class org.jgroups.jmx.JChannelMBean
setAverageSendInterval(long) - method in class org.jgroups.jmx.protocols.VIEW_SYNC
setAverageSendInterval(long) - method in class org.jgroups.protocols.VIEW_SYNC
setAverageSendInterval(long) - method in class org.jgroups.jmx.protocols.VIEW_SYNCMBean
setBacklog(int) - method in class org.jgroups.protocols.ring.RingNodeFlowControl
setBindAddr(InetAddress) - method in class org.jgroups.jmx.protocols.MPING
setBindAddr(InetAddress) - method in class org.jgroups.protocols.MPING
setBindAddr(InetAddress) - method in class org.jgroups.jmx.protocols.MPINGMBean
setBindAddr(InetAddress) - method in class org.jgroups.jmx.protocols.TCP
setBindAddr(InetAddress) - method in class org.jgroups.protocols.TCP
setBindAddr(InetAddress) - method in class org.jgroups.jmx.protocols.TCPMBean
setBindAddress(String) - method in class org.jgroups.stack.GossipRouter
setBindAddress(String) - method in class org.jgroups.jmx.protocols.TP
setBindAddress(String) - method in class org.jgroups.protocols.TP
setBindAddress(String) - method in class org.jgroups.jmx.protocols.TPMBean
setBindToAllInterfaces(boolean) - method in class org.jgroups.jmx.protocols.MPING
setBindToAllInterfaces(boolean) - method in class org.jgroups.protocols.MPING
setBindToAllInterfaces(boolean) - method in class org.jgroups.jmx.protocols.MPINGMBean
setBindToAllInterfaces(boolean) - method in class org.jgroups.protocols.TP
setBuf(byte[]) - method in class org.jgroups.util.Buffer
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
setCaller(org.jgroups.Address) - method in class org.jgroups.blocks.GroupRequest
setChannel(org.jgroups.JChannel) - method in class org.jgroups.debug.Debugger
Allows to be notified when a channel event such as connect, disconnect or close occurs.
setClusterConfig(Element) - method in class org.jgroups.jmx.JChannel
To configure via XML file
setClusterConfig(Element) - method in class org.jgroups.jmx.JChannelMBean
To configure via XML file
setClusterName(String) - method in class org.jgroups.jmx.JChannel
setClusterName(String) - method in class org.jgroups.jmx.JChannelMBean
setConcurrentProcessing(boolean) - method in class org.jgroups.blocks.MessageDispatcher
setConcurrentProcessing(boolean) - method in class org.jgroups.blocks.RequestCorrelator
setConcurrentProcessing(boolean) - method in class org.jgroups.util.Scheduler
setConnExpireTime(long) - method in class org.jgroups.jmx.protocols.TCP
setConnExpireTime(long) - method in class org.jgroups.protocols.TCP
setConnExpireTime(long) - method in class org.jgroups.jmx.protocols.TCPMBean
setData(byte[],int,int) - method in class org.jgroups.util.ExposedByteArrayInputStream
setDeadlockDetection(boolean) - method in class org.jgroups.blocks.DistributedTree
setDeadlockDetection(boolean) - method in class org.jgroups.blocks.MessageDispatcher
setDeadlockDetection(boolean) - method in class org.jgroups.blocks.RequestCorrelator
Switch the deadlock detection mechanism on/off
setDecree(Object) - method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
setDesiredAverageGossip(long) - method in class org.jgroups.jmx.protocols.pbcast.STABLE
setDesiredAverageGossip(long) - method in class org.jgroups.protocols.pbcast.STABLE
setDesiredAverageGossip(long) - method in class org.jgroups.jmx.protocols.pbcast.STABLEMBean
setDest(org.jgroups.Address) - method in class org.jgroups.Message
setDigest(org.jgroups.protocols.pbcast.Digest) - method in class org.jgroups.protocols.pbcast.GMS
Send down a SET_DIGEST event
setDigest(org.jgroups.protocols.pbcast.Digest) - method in class org.jgroups.protocols.pbcast.MergeData
setDiscardDeliveredMessages(boolean) - method in class org.jgroups.stack.NakReceiverWindow
setDiscardDeliveredMsgs(boolean) - method in class org.jgroups.jmx.protocols.pbcast.NAKACK
setDiscardDeliveredMsgs(boolean) - method in class org.jgroups.protocols.pbcast.NAKACK
setDiscardDeliveredMsgs(boolean) - method in class org.jgroups.jmx.protocols.pbcast.NAKACKMBean
setDiscardIncompatiblePackets(boolean) - method in class org.jgroups.jmx.protocols.TP
setDiscardIncompatiblePackets(boolean) - method in class org.jgroups.protocols.TP
setDiscardIncompatiblePackets(boolean) - method in class org.jgroups.jmx.protocols.TPMBean
setDone(String,int) - method in class org.jgroups.protocols.PerfHeader
setDownProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.stack.Protocol
setEnableBundling(boolean) - method in class org.jgroups.jmx.protocols.TP
setEnableBundling(boolean) - method in class org.jgroups.protocols.TP
setEnableBundling(boolean) - method in class org.jgroups.jmx.protocols.TPMBean
setEndPort(int) - method in class org.jgroups.jmx.protocols.TCP
setEndPort(int) - method in class org.jgroups.protocols.TCP
setEndPort(int) - method in class org.jgroups.jmx.protocols.TCPMBean
setEndTime() - method in class org.jgroups.protocols.PerfHeader
setExpectedMessages(long) - method in class org.jgroups.protocols.PERF_TP
setExpiryTime(long) - method in class org.jgroups.stack.GossipRouter
setFilename(String) - method in class org.jgroups.conf.MagicNumberReader
setFilename(String) - static method in class org.jgroups.debug.Profiler
setFragSize(int) - method in class org.jgroups.jmx.protocols.FRAG
setFragSize(int) - method in class org.jgroups.protocols.FRAG
setFragSize(int) - method in class org.jgroups.jmx.protocols.FRAG2
setFragSize(int) - method in class org.jgroups.protocols.FRAG2
setFragSize(int) - method in class org.jgroups.jmx.protocols.FRAG2MBean
setFragSize(int) - method in class org.jgroups.jmx.protocols.FRAGMBean
setGcLag(int) - method in class org.jgroups.jmx.protocols.pbcast.NAKACK
setGcLag(int) - method in class org.jgroups.protocols.pbcast.NAKACK
setGcLag(int) - method in class org.jgroups.jmx.protocols.pbcast.NAKACKMBean
setGossipRequestTimeout(long) - method in class org.jgroups.stack.GossipRouter
setGroupName(String) - method in class org.jgroups.demos.Draw
setGroupName(String) - method in class org.jgroups.jmx.JChannel
setGroupName(String) - method in class org.jgroups.jmx.JChannelMBean
setHighestDeliveredAndSeenSeqnos(org.jgroups.Address,long,long) - method in class org.jgroups.protocols.pbcast.Digest
setHighestSequence(long) - method in class org.jgroups.protocols.ring.RingToken
setHighSeqnoAt(org.jgroups.Address,long) - method in class org.jgroups.protocols.pbcast.Digest
setHighSeqnoSeenAt(org.jgroups.Address,long) - method in class org.jgroups.protocols.pbcast.Digest
setId(short) - method in class org.jgroups.blocks.MethodCall
setImpl(org.jgroups.protocols.GmsImpl) - method in class org.jgroups.protocols.GMS
setImpl(org.jgroups.protocols.pbcast.GmsImpl) - method in class org.jgroups.protocols.pbcast.GMS
setInitialMembers(int) - method in class org.jgroups.jmx.protocols.Discovery
setInitialMembers(int) - method in class org.jgroups.jmx.protocols.DiscoveryMBean
setJoinRetryTimeout(long) - method in class org.jgroups.jmx.protocols.pbcast.GMS
setJoinRetryTimeout(long) - method in class org.jgroups.protocols.pbcast.GMS
setJoinRetryTimeout(long) - method in class org.jgroups.jmx.protocols.pbcast.GMSMBean
setJoinTimeout(long) - method in class org.jgroups.jmx.protocols.pbcast.GMS
setJoinTimeout(long) - method in class org.jgroups.protocols.pbcast.GMS
setJoinTimeout(long) - method in class org.jgroups.jmx.protocols.pbcast.GMSMBean
setKeyServerAddr(org.jgroups.Address) - method in class org.jgroups.protocols.ENCRYPT
setLength(int) - method in class org.jgroups.util.Buffer
setListener(org.jgroups.MessageListener) - method in class org.jgroups.blocks.PullPushAdapter
setLocal_addr(org.jgroups.Address) - method in class org.jgroups.protocols.ENCRYPT
setLocalAddress(org.jgroups.Address) - method in class org.jgroups.blocks.RequestCorrelator
setLocalAddress(org.jgroups.Address) - method in class org.jgroups.debug.Simulator
setLoopback(boolean) - method in class org.jgroups.protocols.TCP
setLoopback(boolean) - method in class org.jgroups.jmx.protocols.TP
setLoopback(boolean) - method in class org.jgroups.protocols.TP
setLoopback(boolean) - method in class org.jgroups.jmx.protocols.TPMBean
setMaxBlockTime(long) - method in class org.jgroups.jmx.protocols.FC
setMaxBlockTime(long) - method in class org.jgroups.protocols.FC
setMaxBlockTime(long) - method in class org.jgroups.jmx.protocols.FCMBean
setMaxBundleSize(int) - method in class org.jgroups.jmx.protocols.TP
setMaxBundleSize(int) - method in class org.jgroups.protocols.TP
setMaxBundleSize(int) - method in class org.jgroups.jmx.protocols.TPMBean
setMaxBundleTimeout(long) - method in class org.jgroups.jmx.protocols.TP
setMaxBundleTimeout(long) - method in class org.jgroups.protocols.TP
setMaxBundleTimeout(long) - method in class org.jgroups.jmx.protocols.TPMBean
setMaxBytes(long) - method in class org.jgroups.jmx.protocols.pbcast.STABLE
setMaxBytes(long) - method in class org.jgroups.protocols.pbcast.STABLE
setMaxBytes(long) - method in class org.jgroups.jmx.protocols.pbcast.STABLEMBean
setMaxCredits(long) - method in class org.jgroups.jmx.protocols.FC
setMaxCredits(long) - method in class org.jgroups.protocols.FC
setMaxCredits(long) - method in class org.jgroups.jmx.protocols.FCMBean
setMaxInterval(long) - method in class org.jgroups.jmx.protocols.MERGE2
setMaxInterval(long) - method in class org.jgroups.protocols.MERGE2
setMaxInterval(long) - method in class org.jgroups.jmx.protocols.MERGE2MBean
setMaxTries(int) - method in class org.jgroups.jmx.protocols.FD
setMaxTries(int) - method in class org.jgroups.protocols.FD
setMaxTries(int) - method in class org.jgroups.jmx.protocols.FDMBean
setMaxXmitBufSize(int) - method in class org.jgroups.jmx.protocols.pbcast.NAKACK
setMaxXmitBufSize(int) - method in class org.jgroups.protocols.pbcast.NAKACK
setMaxXmitBufSize(int) - method in class org.jgroups.jmx.protocols.pbcast.NAKACKMBean
setMaxXmitBufSize(int) - method in class org.jgroups.stack.NakReceiverWindow
setMaxXmitSize(long) - method in class org.jgroups.jmx.protocols.pbcast.NAKACK
setMaxXmitSize(long) - method in class org.jgroups.protocols.pbcast.NAKACK
setMaxXmitSize(long) - method in class org.jgroups.jmx.protocols.pbcast.NAKACKMBean
setMBeanServerName(String) - method in class org.jgroups.jmx.JChannel
setMcastAddr(InetAddress) - method in class org.jgroups.jmx.protocols.MPING
setMcastAddr(InetAddress) - method in class org.jgroups.protocols.MPING
setMcastAddr(InetAddress) - method in class org.jgroups.jmx.protocols.MPINGMBean
setMcastPort(int) - method in class org.jgroups.jmx.protocols.MPING
setMcastPort(int) - method in class org.jgroups.protocols.MPING
setMcastPort(int) - method in class org.jgroups.jmx.protocols.MPINGMBean
setMethod(Method) - method in class org.jgroups.blocks.MethodCall
setMinCredits(long) - method in class org.jgroups.jmx.protocols.FC
setMinCredits(long) - method in class org.jgroups.protocols.FC
setMinCredits(long) - method in class org.jgroups.jmx.protocols.FCMBean
setMinInterval(long) - method in class org.jgroups.jmx.protocols.MERGE2
setMinInterval(long) - method in class org.jgroups.protocols.MERGE2
setMinInterval(long) - method in class org.jgroups.jmx.protocols.MERGE2MBean
setMinThreshold(double) - method in class org.jgroups.jmx.protocols.FC
setMinThreshold(double) - method in class org.jgroups.protocols.FC
setMinThreshold(double) - method in class org.jgroups.jmx.protocols.FCMBean
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
setNetworkReceived() - method in class org.jgroups.protocols.PerfHeader
setNetworkSent() - method in class org.jgroups.protocols.PerfHeader
setNumInitialMembers(int) - method in class org.jgroups.protocols.Discovery
setNumPingRequests(int) - method in class org.jgroups.protocols.Discovery
setObject(Serializable) - method in class org.jgroups.Message
setObjectName(String) - method in class org.jgroups.jmx.JChannel
setObjectName(String) - method in class org.jgroups.jmx.JChannelMBean
setObserver(org.jgroups.protocols.QUEUE.Observer) - method in class org.jgroups.protocols.QUEUE
Only 1 observer is allowed.
setObserver(org.jgroups.stack.ProtocolObserver) - method in class org.jgroups.stack.Protocol
setOffset(int) - method in class org.jgroups.util.Buffer
setOpt(int,Object) - method in class org.jgroups.Channel
Sets an option.
setOpt(int,Object) - method in class org.jgroups.JChannel
Sets a channel option.
setOutgoingQueueMaxSize(int) - method in class org.jgroups.jmx.protocols.TP
setOutgoingQueueMaxSize(int) - method in class org.jgroups.protocols.TP
setOutgoingQueueMaxSize(int) - method in class org.jgroups.jmx.protocols.TPMBean
setOverhead(int) - method in class org.jgroups.jmx.protocols.FRAG2
setOverhead(int) - method in class org.jgroups.protocols.FRAG2
setOverhead(int) - method in class org.jgroups.jmx.protocols.FRAG2MBean
setPersistent(boolean) - method in class org.jgroups.blocks.DistributedHashtable
setPingRequests(int) - method in class org.jgroups.jmx.protocols.Discovery
setPingRequests(int) - method in class org.jgroups.jmx.protocols.DiscoveryMBean
setPort(int) - method in class org.jgroups.stack.GossipRouter
setPreviousBacklog() - method in class org.jgroups.protocols.ring.RingNodeFlowControl
setPrimaryPhysicalAddress(SocketAddress) - method in class org.jgroups.stack.LogicalAddress
setProperties(Properties) - method in class org.jgroups.protocols.AUTOCONF
Setup the Protocol instance acording to the configuration string
setProperties(Properties) - method in class org.jgroups.protocols.COMPRESS
Configures the protocol initially.
setProperties(Properties) - method in class org.jgroups.protocols.DELAY
setProperties(Properties) - method in class org.jgroups.protocols.DISCARD
setProperties(Properties) - method in class org.jgroups.protocols.Discovery
sets the properties of the PING protocol.
setProperties(Properties) - method in class org.jgroups.protocols.ENCRYPT
Configures the protocol initially.
setProperties(Properties) - method in class org.jgroups.protocols.ENCRYPT1_4
setProperties(Properties) - method in class org.jgroups.protocols.FC
setProperties(Properties) - method in class org.jgroups.protocols.FD
setProperties(Properties) - method in class org.jgroups.protocols.pbcast.FD
Configures the protocol initially.
setProperties(Properties) - method in class org.jgroups.protocols.FD_PID
setProperties(Properties) - method in class org.jgroups.protocols.FD_PROB
Configures the protocol initially.
setProperties(Properties) - method in class org.jgroups.protocols.FD_SIMPLE
Configures the protocol initially.
setProperties(Properties) - method in class org.jgroups.protocols.FD_SOCK
setProperties(Properties) - method in class org.jgroups.protocols.FLOW_CONTROL
Following parameters can be optionally supplied:
  • window size cap - int Limits the window size to a reasonable value.
setProperties(Properties) - method in class org.jgroups.protocols.FLUSH
setProperties(Properties) - method in class org.jgroups.protocols.FRAG
Setup the Protocol instance acording to the configuration string
setProperties(Properties) - method in class org.jgroups.protocols.FRAG2
Setup the Protocol instance acording to the configuration string
setProperties(Properties) - method in class org.jgroups.protocols.GMS
Setup the Protocol instance acording to the configuration string
setProperties(Properties) - method in class org.jgroups.protocols.pbcast.GMS
Setup the Protocol instance according to the configuration string
setProperties(Properties) - method in class org.jgroups.protocols.HTOTAL
setProperties(Properties) - method in class org.jgroups.protocols.JMS
Set protocol properties.
setProperties(Properties) - method in class org.jgroups.protocols.MERGE
Configures the protocol initially.
setProperties(Properties) - method in class org.jgroups.protocols.MERGE2
setProperties(Properties) - method in class org.jgroups.protocols.MERGE3
setProperties(Properties) - method in class org.jgroups.protocols.MPING
sets the properties of the PING protocol.
setProperties(Properties) - method in class org.jgroups.protocols.NAKACK
setProperties(Properties) - method in class org.jgroups.protocols.pbcast.NAKACK
Configures the protocol initially.
setProperties(Properties) - method in class org.jgroups.protocols.PARTITIONER
setProperties(Properties) - method in class org.jgroups.protocols.pbcast.PBCAST
Setup the Protocol instance acording to the configuration string
setProperties(Properties) - method in class org.jgroups.protocols.PERF
setProperties(Properties) - method in class org.jgroups.protocols.PIGGYBACK
setProperties(Properties) - method in class org.jgroups.protocols.PING
sets the properties of the PING protocol.
setProperties(Properties) - method in class org.jgroups.jmx.Protocol
setProperties(Properties) - method in class org.jgroups.stack.Protocol
Configures the protocol initially.
setProperties(Properties) - method in class org.jgroups.jmx.ProtocolMBean
setProperties(Properties) - method in class org.jgroups.protocols.SHUFFLE
Configures the protocol initially.
setProperties(Properties) - method in class org.jgroups.protocols.SIZE
Setup the Protocol instance acording to the configuration string
setProperties(Properties) - method in class org.jgroups.protocols.SMACK
setProperties(Properties) - method in class org.jgroups.protocols.STABLE
Set the parameters for this layer.
setProperties(Properties) - method in class org.jgroups.protocols.pbcast.STABLE
setProperties(Properties) - method in class org.jgroups.protocols.STATE_TRANSFER
Configures the protocol initially.
setProperties(Properties) - method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
setProperties(Properties) - method in class org.jgroups.protocols.STATS
Configures the protocol initially.
setProperties(Properties) - method in class org.jgroups.protocols.TCP
Setup the Protocol instance acording to the configuration string
setProperties(Properties) - method in class org.jgroups.protocols.TCP_NIO
Setup the Protocol instance acording to the configuration string
setProperties(Properties) - method in class org.jgroups.protocols.TCPGOSSIP
sets the properties of the PING protocol.
setProperties(Properties) - method in class org.jgroups.protocols.TCPPING
sets the properties of the PING protocol.
setProperties(Properties) - method in class org.jgroups.protocols.TOTAL
Configures the protocol initially.
setProperties(Properties) - method in class org.jgroups.protocols.TOTAL_TOKEN
Setup the Protocol instance acording to the configuration string
setProperties(Properties) - method in class org.jgroups.protocols.TP
Setup the Protocol instance according to the configuration string
setProperties(Properties) - method in class org.jgroups.protocols.TUNNEL
Setup the Protocol instance acording to the configuration string
setProperties(Properties) - method in class org.jgroups.protocols.UDP
Setup the Protocol instance acording to the configuration string.
setProperties(Properties) - method in class org.jgroups.protocols.UDP_NIO
Setup the Protocol instance acording to the configuration string.
setProperties(Properties) - method in class org.jgroups.protocols.UNICAST
Configures the protocol initially.
setProperties(Properties) - method in class org.jgroups.protocols.VERIFY_SUSPECT
setProperties(Properties) - method in class org.jgroups.protocols.VIEW_SYNC
Configures the protocol initially.
setProperties(Properties) - method in class org.jgroups.protocols.WANPING
sets the properties of the PING protocol.
setProperties(Properties) - method in class org.jgroups.protocols.WANPIPE
Setup the Protocol instance acording to the configuration string
setProperties(String) - method in class org.jgroups.jmx.JChannel
setProperties(String) - method in class org.jgroups.jmx.JChannelMBean
setPropertiesInternal(Properties) - method in class org.jgroups.stack.Protocol
Called by Configurator.
setProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.stack.ProtocolObserver
Called when a ProtocolObserver is attached to a protcol.
setProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.debug.ProtocolView
setProtocolStack(org.jgroups.stack.Protocol[]) - method in class org.jgroups.debug.Simulator
setQuote(String,Float) - method in class org.jgroups.demos.QuoteServer
setReaperInterval(long) - method in class org.jgroups.jmx.protocols.TCP
setReaperInterval(long) - method in class org.jgroups.protocols.TCP
setReaperInterval(long) - method in class org.jgroups.jmx.protocols.TCPMBean
setReceiveBlockEvents(boolean) - method in class org.jgroups.jmx.JChannel
setReceiveBlockEvents(boolean) - method in class org.jgroups.jmx.JChannelMBean
setReceiveBufferSize(int) - method in class org.jgroups.blocks.ConnectionTable
setReceived(boolean) - method in class org.jgroups.util.Rsp
setReceived(String,int) - method in class org.jgroups.protocols.PerfHeader
setReceiveLocalMessages(boolean) - method in class org.jgroups.jmx.JChannel
setReceiveLocalMessages(boolean) - method in class org.jgroups.jmx.JChannelMBean
setReceiver(org.jgroups.blocks.Link.Receiver) - method in class org.jgroups.blocks.Link
setReceiver(org.jgroups.Receiver) - method in class org.jgroups.Channel
Sets the receiver, which will handle all messages, view changes etc
setReceiver(org.jgroups.Receiver) - method in class org.jgroups.protocols.UDP_NIO.ConnectorTable
setReceiveStateEvents(boolean) - method in class org.jgroups.jmx.JChannel
setReceiveStateEvents(boolean) - method in class org.jgroups.jmx.JChannelMBean
setReceiveSuspectEvents(boolean) - method in class org.jgroups.jmx.JChannel
setReceiveSuspectEvents(boolean) - method in class org.jgroups.jmx.JChannelMBean
setReceiveViewEvents(boolean) - method in class org.jgroups.jmx.JChannel
setReceiveViewEvents(boolean) - method in class org.jgroups.jmx.JChannelMBean
setRemoteCalls(boolean) - method in class org.jgroups.blocks.ReplicatedTree
setResult(Object) - method in class org.jgroups.util.Promise
Sets the result and notifies any threads waiting for it
setRetransmitTimeouts(long[]) - method in class org.jgroups.stack.NakReceiverWindow
setRetransmitTimeouts(long[]) - method in class org.jgroups.stack.Retransmitter
setRoutingClientReplyTimeout(long) - method in class org.jgroups.stack.GossipRouter
setSendBufferSize(int) - method in class org.jgroups.blocks.ConnectionTable
setShun(boolean) - method in class org.jgroups.jmx.protocols.FD
setShun(boolean) - method in class org.jgroups.protocols.FD
setShun(boolean) - method in class org.jgroups.jmx.protocols.FDMBean
setShun(boolean) - method in class org.jgroups.jmx.protocols.pbcast.GMS
setShun(boolean) - method in class org.jgroups.protocols.pbcast.GMS
setShun(boolean) - method in class org.jgroups.jmx.protocols.pbcast.GMSMBean
setSocketConnectionTimeout(int) - method in class org.jgroups.blocks.ConnectionTable
setSrc(org.jgroups.Address) - method in class org.jgroups.Message
setStartPort(int) - method in class org.jgroups.jmx.protocols.TCP
setStartPort(int) - method in class org.jgroups.protocols.TCP
setStartPort(int) - method in class org.jgroups.jmx.protocols.TCPMBean
setState(byte[]) - method in class org.jgroups.demos.Chat
setState(byte[]) - method in class org.jgroups.blocks.DistributedHashtable
Sets the group state; e.g., when joining.
setState(byte[]) - method in class org.jgroups.blocks.DistributedQueue
Sets the group state; e.g., when joining.
setState(byte[]) - method in class org.jgroups.blocks.DistributedTree
Sets the group state; e.g., when joining.
setState(byte[]) - method in class org.jgroups.demos.wb.GraphPanel
setState(byte[]) - method in class org.jgroups.MessageListener
Sets the group state; e.g., when joining.
setState(byte[]) - method in class org.jgroups.blocks.MessageListenerAdapter
Set state of ths group.
setState(byte[]) - method in class org.jgroups.blocks.NotificationBus
Sets the group state; e.g., when joining.
setState(byte[]) - method in class org.jgroups.demos.QuoteServer
Sets the group state; e.g., when joining.
setState(byte[]) - method in class org.jgroups.ReceiverAdapter
Sets the group state; e.g., when joining.
setState(byte[]) - method in class org.jgroups.blocks.ReplicatedHashtable
Sets the group state; e.g., when joining.
setState(byte[]) - method in class org.jgroups.blocks.ReplicatedTree
Set the cache (tree) to this value
setState(byte[]) - method in class org.jgroups.blocks.VotingAdapter
Set the channel state.
setState(byte[]) - method in class org.jgroups.demos.wb.Whiteboard
Sets the group state; e.g., when joining.
setState(Vector) - method in class org.jgroups.demos.Topology
SetStateEvent - class org.jgroups.SetStateEvent
Encapsulates a state returned by Channel.receive(), as requested by Channel.getState(s) previously.
SetStateEvent(byte[]) - constructor for class org.jgroups.SetStateEvent
Register listener for state notification events.
setStatsEnabled(boolean) - method in class org.jgroups.jmx.JChannel
setStatsEnabled(boolean) - method in class org.jgroups.jmx.JChannelMBean
setStatsEnabled(boolean) - method in class org.jgroups.jmx.Protocol
setStatsEnabled(boolean) - method in class org.jgroups.jmx.ProtocolMBean
setSuspected(boolean) - method in class org.jgroups.util.Rsp
setSuspendInterval(long) - method in class org.jgroups.util.TimeScheduler
setTimeout(long) - method in class org.jgroups.jmx.protocols.Discovery
setTimeout(long) - method in class org.jgroups.protocols.Discovery
setTimeout(long) - method in class org.jgroups.jmx.protocols.DiscoveryMBean
setTimeout(long) - method in class org.jgroups.jmx.protocols.FD
setTimeout(long) - method in class org.jgroups.protocols.FD
setTimeout(long) - method in class org.jgroups.jmx.protocols.FDMBean
setTrace(boolean) - method in class org.jgroups.blocks.Link
setTrace(boolean) - method in class org.jgroups.jmx.Protocol
setTrace(boolean) - method in class org.jgroups.stack.Protocol
setTrace(boolean) - method in class org.jgroups.jmx.ProtocolMBean
setTTL(int) - method in class org.jgroups.jmx.protocols.MPING
setTTL(int) - method in class org.jgroups.protocols.MPING
setTTL(int) - method in class org.jgroups.jmx.protocols.MPINGMBean
setType(int) - method in class org.jgroups.Event
setType(int) - method in class org.jgroups.protocols.ring.RingToken
setup() - method in class org.jgroups.stack.ProtocolStack
setUpHandler(org.jgroups.UpHandler) - method in class org.jgroups.Channel
When up_handler is set, all events will be passed to it directly.
setUpProtocol(org.jgroups.stack.Protocol) - method in class org.jgroups.stack.Protocol
The configuration string has a number of entries, separated by a ':' (colon).
setUseMcastXmit(boolean) - method in class org.jgroups.jmx.protocols.pbcast.NAKACK
setUseMcastXmit(boolean) - method in class org.jgroups.protocols.pbcast.NAKACK
setUseMcastXmit(boolean) - method in class org.jgroups.jmx.protocols.pbcast.NAKACKMBean
setUseSendQueues(boolean) - method in class org.jgroups.blocks.ConnectionTable
setValue(Object) - method in class org.jgroups.util.Rsp
setView(org.jgroups.View) - method in class org.jgroups.protocols.pbcast.MergeData
setView(org.jgroups.View) - method in class org.jgroups.debug.Simulator
setVisible(boolean) - method in class org.jgroups.demos.DistributedTreeDemo
setWarn(boolean) - method in class org.jgroups.jmx.Protocol
setWarn(boolean) - method in class org.jgroups.stack.Protocol
setWarn(boolean) - method in class org.jgroups.jmx.ProtocolMBean
setWindowSize(int) - method in class org.jgroups.protocols.ring.RingToken
setWindowThreshold(int) - method in class org.jgroups.protocols.ring.RingToken
setXmitFromRandomMember(boolean) - method in class org.jgroups.jmx.protocols.pbcast.NAKACK
setXmitFromRandomMember(boolean) - method in class org.jgroups.protocols.pbcast.NAKACK
setXmitFromRandomMember(boolean) - method in class org.jgroups.jmx.protocols.pbcast.NAKACKMBean
SHORT_SIZE - static field in class org.jgroups.Global
Value is .
shortForm() - method in class org.jgroups.protocols.pbcast.Gossip
shortName(InetAddress) - static method in class org.jgroups.util.Util
shortName(String) - static method in class org.jgroups.util.Util
showLastBlockingTimes() - method in class org.jgroups.jmx.protocols.FC
showLastBlockingTimes() - method in class org.jgroups.protocols.FC
showLastBlockingTimes() - method in class org.jgroups.jmx.protocols.FCMBean
SHUFFLE - class org.jgroups.protocols.SHUFFLE
This layer shuffles upcoming messages, put it just above your bottom layer.
SHUFFLE() - constructor for class org.jgroups.protocols.SHUFFLE
SHUTDOWN - static field in class org.jgroups.stack.GossipRouter
shutDown() - method in class org.jgroups.persistence.DBPersistenceManager
Shutting down the database cleanly
shutDown() - method in class org.jgroups.persistence.FilePersistenceManager
Used to handle shutdown call the PersistenceManager implementation.
shutdown() - method in class org.jgroups.JChannel
Shuts down the channel without disconnecting
shutdown() - method in class org.jgroups.jmx.JChannel
shutdown() - method in class org.jgroups.jmx.JChannelMBean
shutDown() - method in class org.jgroups.persistence.PersistenceManager
Used to handle shutdown call the PersistenceManager implementation.
SHUTDOWN_OK - static field in class org.jgroups.stack.GossipRouter
SIGNATURE - static field in class org.jgroups.blocks.MethodCall
Provide a signature, similar to JMX.
Simulator - class org.jgroups.debug.Simulator
Tests one or more protocols independently.
size - field in class org.jgroups.util.List
SIZE - class org.jgroups.protocols.SIZE
Protocol which prints out the real size of a message.
size() - method in class org.jgroups.util.AckCollector
size() - method in class org.jgroups.stack.AckMcastReceiverWindow
size() - method in class org.jgroups.stack.AckMcastSenderWindow
size() - method in class org.jgroups.stack.AckReceiverWindow
size() - method in class org.jgroups.stack.AckSenderWindow
size() - method in class org.jgroups.Address
Returns serialized size of this address
size() - method in class org.jgroups.protocols.BSH.BshHeader
To be implemented by subclasses.
size() - method in class org.jgroups.protocols.CAUSAL.CausalHeader
Size of this vector timestamp estimation, used in fragmetation
size() - method in class org.jgroups.protocols.COMPRESS.CompressHeader
size() - method in class org.jgroups.protocols.pbcast.Digest
size() - method in class org.jgroups.blocks.DistributedQueue
size() - method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
size() - method in class org.jgroups.protocols.FC.FcHeader
To be implemented by subclasses.
size() - method in class org.jgroups.protocols.FD.FdHeader
To be implemented by subclasses.
size() - method in class org.jgroups.protocols.FD_SOCK.FdHeader
To be implemented by subclasses.
size() - method in class org.jgroups.protocols.FragHeader
size() - method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
size() - method in class org.jgroups.Header
To be implemented by subclasses.
size() - method in class org.jgroups.stack.IpAddress
Returns serialized size of this address
size() - method in class org.jgroups.protocols.JMS.JMSAddress
size() - method in class org.jgroups.util.LinkedListQueue
returns the number of objects that are currently in the queue
size() - method in class org.jgroups.util.List
size() - method in class org.jgroups.stack.LogicalAddress
size() - method in class org.jgroups.Membership
Returns the number of addresses in this membership
size() - method in class org.jgroups.Message
Returns size of buffer, plus some constant overhead for src and dest, plus number of headers time some estimated size/header.
size() - method in class org.jgroups.protocols.NakAckHeader
size() - method in class org.jgroups.protocols.pbcast.NakAckHeader
size() - method in class org.jgroups.stack.NakReceiverWindow
size() - method in class org.jgroups.protocols.pbcast.PbcastHeader
To be implemented by subclasses.
size() - method in class org.jgroups.protocols.PerfHeader
size() - method in class org.jgroups.protocols.PingHeader
size() - method in class org.jgroups.protocols.PingRsp
size() - method in class org.jgroups.blocks.PullPushAdapter.PullHeader
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.Queue2
returns the number of objects that are currently in the queue
size() - method in class org.jgroups.blocks.RequestCorrelator.Header
size() - method in class org.jgroups.stack.Retransmitter
size() - method in class org.jgroups.util.RspList
size() - method in class org.jgroups.protocols.pbcast.STABLE.StableHeader
size() - method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
To be implemented by subclasses.
size() - method in class org.jgroups.protocols.TcpHeader
To be implemented by subclasses.
size() - method in class org.jgroups.util.TimeScheduler
Answers the number of tasks currently in the queue.
size() - method in class org.jgroups.protocols.TOTAL_TOKEN.RingTokenHeader
size() - method in class org.jgroups.protocols.TOTAL_TOKEN.TotalTokenHeader
Returns size of the header
size() - method in class org.jgroups.protocols.TpHeader
To be implemented by subclasses.
size() - method in class org.jgroups.protocols.TransportedVectorTime
Returns size of this vector timestamp i.e number of process group members
size() - method in class org.jgroups.protocols.TunnelHeader
size() - method in class org.jgroups.protocols.UdpHeader
size() - method in class org.jgroups.protocols.UNICAST.UnicastHeader
size() - method in class org.jgroups.View
returns the number of members in this view
size() - method in class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
To be implemented by subclasses.
size() - method in class org.jgroups.protocols.WANPIPE.WanPipeHeader
size() - method in class org.jgroups.protocols.WanPipeAddress
Returns serialized size of this address
size(Collection) - static method in class org.jgroups.util.Util
Returns the marshalled size of a Collection of Addresses.
size(org.jgroups.Address) - static method in class org.jgroups.util.Util
sizeOf(Object) - static method in class org.jgroups.util.Util
sizeOf(org.jgroups.util.Streamable) - static method in class org.jgroups.util.Util
sizeOf(String) - static method in class org.jgroups.util.Util
sizeOfNotSeenList() - method in class org.jgroups.protocols.pbcast.Gossip
sleep(long) - static method in class org.jgroups.util.Util
Sleep for timeout msecs.
sleep(long,boolean) - static method in class org.jgroups.util.Util
On most UNIX systems, the minimum sleep time is 10-20ms.
sleepRandom(long) - static method in class org.jgroups.util.Util
Sleeps between 1 and timeout milliseconds, chosen randomly.
SMACK - class org.jgroups.protocols.SMACK
Simple Multicast ACK protocol.
SMACK() - constructor for class org.jgroups.protocols.SMACK
SMACK.SmackHeader - class org.jgroups.protocols.SMACK.SmackHeader
SmackHeader() - constructor for class org.jgroups.protocols.SMACK.SmackHeader
SmackHeader(int,long) - constructor for class org.jgroups.protocols.SMACK.SmackHeader
sort() - method in class org.jgroups.Membership
src_addr - field in class org.jgroups.Message
SRC_PROPERTY - static field in class org.jgroups.protocols.JMS
STABILITY - static field in class org.jgroups.protocols.pbcast.STABLE.StableHeader
stability(org.jgroups.ViewId,long,long[],Object) - method in class org.jgroups.protocols.STABLE
Contains the highest message sequence numbers (for each member) that can safely be deleted (because they have been seen by all members).
STABLE - static field in class org.jgroups.Event
STABLE - class org.jgroups.jmx.protocols.pbcast.STABLE
STABLE - class org.jgroups.protocols.STABLE
Computes the broadcast messages that are stable; i.e., that have been received by all members.
STABLE - class org.jgroups.protocols.pbcast.STABLE
Computes the broadcast messages that are stable; i.e., have been received by all members.
STABLE() - constructor for class org.jgroups.jmx.protocols.pbcast.STABLE
stable(long) - method in class org.jgroups.stack.NakReceiverWindow
Delete all messages <= seqno (they are stable, that is, have been received at all members).
STABLE(org.jgroups.stack.Protocol) - constructor for class org.jgroups.jmx.protocols.pbcast.STABLE
STABLE_GOSSIP - static field in class org.jgroups.protocols.pbcast.STABLE.StableHeader
STABLE.StableHeader - class org.jgroups.protocols.pbcast.STABLE.StableHeader
StableHeader() - constructor for class org.jgroups.protocols.pbcast.STABLE.StableHeader
StableHeader(int,org.jgroups.protocols.pbcast.Digest) - constructor for class org.jgroups.protocols.pbcast.STABLE.StableHeader
STABLEMBean - interface org.jgroups.jmx.protocols.pbcast.STABLEMBean
Stack - class org.jgroups.util.Stack
LIFO stack, with better performance than java.util.Stack (based on List).
stack - field in class org.jgroups.stack.Protocol
Stack() - constructor for class org.jgroups.util.Stack
START - static field in class org.jgroups.Event
start() - method in class org.jgroups.stack.AckMcastSenderWindow
Start the retransmitter.
start() - method in class org.jgroups.protocols.AUTOCONF
This method is called on a Channel.connect(String).
start() - method in class org.jgroups.protocols.BSH
start() - method in class org.jgroups.demos.Chat
start() - method in class org.jgroups.blocks.ConnectionTable
start() - method in class org.jgroups.protocols.DEADLOCK
start() - method in class org.jgroups.debug.Debugger
start() - method in class org.jgroups.protocols.Discovery
start() - method in class org.jgroups.blocks.DistributedTree
start() - method in class org.jgroups.demos.applets.DrawApplet
start() - method in class org.jgroups.protocols.DUMMY_TP
start() - method in class org.jgroups.protocols.FC
start() - method in class org.jgroups.protocols.FD_PID
start() - method in class org.jgroups.protocols.FD_PROB
This method is called on a Channel.connect(String).
start() - method in class org.jgroups.protocols.FLUSH
start() - method in class org.jgroups.protocols.GMS
start() - method in class org.jgroups.protocols.pbcast.GMS
start() - method in class org.jgroups.protocols.pbcast.GmsImpl
start() - method in class org.jgroups.stack.GossipRouter
JBoss MBean lifecycle operation.
start() - method in class org.jgroups.jmx.JChannel
start() - method in class org.jgroups.jmx.JChannelMBean
start() - method in class org.jgroups.protocols.JMS
Start the JMS protocol.
start() - method in class org.jgroups.blocks.Link
start() - method in class org.jgroups.blocks.LogicalLink
Start all links
start() - method in class org.jgroups.protocols.LOOPBACK
start() - method in class org.jgroups.protocols.MERGE
This method is called on a Channel.connect(String).
start() - method in class org.jgroups.blocks.MessageDispatcher
start() - method in class org.jgroups.stack.MessageProtocol
start() - method in class org.jgroups.protocols.MPING
This method is called on a Channel.connect(String).
start() - method in class org.jgroups.protocols.pbcast.NAKACK
This method is called on a Channel.connect(String).
start() - method in class org.jgroups.blocks.NotificationBus
start() - method in class org.jgroups.protocols.PERF
start() - method in class org.jgroups.protocols.PERF_TP
This method is called on a Channel.connect(String).
start() - method in class org.jgroups.protocols.PIGGYBACK
start() - method in class org.jgroups.protocols.PingSender
start() - method in class org.jgroups.protocols.PingWaiter
start() - method in class org.jgroups.jmx.Protocol
start() - method in class org.jgroups.stack.Protocol
This method is called on a Channel.connect(String).
start() - method in class org.jgroups.jmx.ProtocolMBean
start() - method in class org.jgroups.util.Proxy
start() - method in class org.jgroups.blocks.PullPushAdapter
start() - method in class org.jgroups.demos.QuoteClient
start() - method in class org.jgroups.demos.QuoteServer
start() - method in class org.jgroups.blocks.ReplicatedTree
start() - method in class org.jgroups.blocks.RequestCorrelator
start() - method in class org.jgroups.util.ReusableThread
Will always be called from synchronized method, no need to do our own synchronization
start() - method in class org.jgroups.stack.Router
start() - method in class org.jgroups.util.Scheduler
start() - method in class org.jgroups.protocols.SHUFFLE
Starts the messagesHandler<\code>
start() - method in class org.jgroups.debug.Simulator
start() - method in class org.jgroups.protocols.STABLE
Start the layer: i.
start() - method in class org.jgroups.protocols.pbcast.STABLE
start() - method in class org.jgroups.protocols.STATE_TRANSFER
This method is called on a Channel.connect(String).
start() - method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
start() - method in class org.jgroups.protocols.TCP
start() - method in class org.jgroups.protocols.TCPGOSSIP
This method is called on a Channel.connect(String).
start() - method in class org.jgroups.util.TimeScheduler
Start the scheduler, if it's suspended or stopped
start() - method in class org.jgroups.demos.Topology
start() - method in class org.jgroups.protocols.TOTAL
Prepare this layer to receive messages from above
start() - method in class org.jgroups.protocols.TOTAL_OLD
start() - method in class org.jgroups.protocols.TOTAL_TOKEN
This method is called on a Channel.connect(String).
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.TUNNEL
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.UDP.UcastReceiver
start() - method in class org.jgroups.protocols.UDP_NIO
Creates the unicast and multicast sockets and starts the unicast and multicast receiver threads
start() - method in class org.jgroups.protocols.UDP_NIO.Connector
start() - method in class org.jgroups.protocols.UDP_NIO.ConnectorTable
Get all interfaces, create one Connector per interface and call start() on it
start() - method in class org.jgroups.protocols.UNICAST
This method is called on a Channel.connect(String).
start() - method in class org.jgroups.protocols.VIEW_SYNC
This method is called on a Channel.connect(String).
start() - method in class org.jgroups.protocols.WANPIPE
This method is called on a Channel.connect(String).
start(long) - method in class org.jgroups.blocks.DistributedHashtable
Fetches the state
start(long) - method in class org.jgroups.blocks.DistributedQueue
start(long) - method in class org.jgroups.blocks.DistributedTree
start(String) - method in class org.jgroups.demos.wb.GraphPanel
start(String) - static method in class org.jgroups.debug.Profiler
start(String,boolean) - method in class org.jgroups.demos.ViewDemo
start(String,String) - method in class org.jgroups.demos.NotificationBusDemo
START_OK - static field in class org.jgroups.Event
START_QUEUEING - static field in class org.jgroups.Event
startDownHandler() - method in class org.jgroups.protocols.AUTOCONF
Leave empty: no down_thread will be created, but the down_thread of the neighbor above us will be used
startDownHandler() - method in class org.jgroups.protocols.BSH
We have no down handler thread
startDownHandler() - method in class org.jgroups.protocols.MERGE2
This prevents the down-handler thread to be created, which is not needed in the protocol.
startDownHandler() - method in class org.jgroups.protocols.MERGE3
This prevents the down-handler thread to be created, which is not needed in the protocol.
startDownHandler() - method in class org.jgroups.stack.Protocol
Used internally.
startDownHandler() - method in class org.jgroups.stack.ProtocolStack
started - field in class org.jgroups.blocks.RequestCorrelator
started(Runnable) - method in class org.jgroups.util.SchedulerListener
startStack() - method in class org.jgroups.stack.ProtocolStack
Start all layers.
startUpHandler() - method in class org.jgroups.protocols.AUTOCONF
Leave empty: no up_thread will be created, but the up_thread of the neighbor below us will be used
startUpHandler() - method in class org.jgroups.protocols.BSH
We have no up handler thread
startUpHandler() - method in class org.jgroups.protocols.MERGE2
This prevents the up-handler thread to be created, which is not needed in the protocol.
startUpHandler() - method in class org.jgroups.protocols.MERGE3
This prevents the up-handler thread to be created, which is not needed in the protocol.
startUpHandler() - method in class org.jgroups.stack.Protocol
Used internally.
startUpHandler() - method in class org.jgroups.stack.ProtocolStack
startUpHandler() - method in class org.jgroups.protocols.TP
This prevents the up-handler thread to be created, which essentially is superfluous: messages are received from the network rather than from a layer below.
startUpHandler() - method in class org.jgroups.protocols.TUNNEL
This prevents the up-handler thread to be created, which essentially is superfluous: messages are received from the network rather than from a layer below.
startUpHandler() - method in class org.jgroups.protocols.UDP_NIO
This prevents the up-handler thread to be created, which essentially is superfluous: messages are received from the network rather than from a layer below.
startWork() - method in class org.jgroups.stack.ProtocolStack
Override with null functionality: we don't need any threads to be started !
state_promise - field in class org.jgroups.blocks.DistributedHashtable
STATE_RECEIVED - static field in class org.jgroups.Event
STATE_REQ - static field in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
STATE_RSP - static field in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
STATE_TRANSFER - class org.jgroups.jmx.protocols.pbcast.STATE_TRANSFER
STATE_TRANSFER - class org.jgroups.protocols.STATE_TRANSFER
State transfer layer.
STATE_TRANSFER - class org.jgroups.protocols.pbcast.STATE_TRANSFER
New STATE_TRANSFER protocol based on PBCAST.
STATE_TRANSFER() - constructor for class org.jgroups.jmx.protocols.pbcast.STATE_TRANSFER
STATE_TRANSFER(org.jgroups.stack.Protocol) - constructor for class org.jgroups.jmx.protocols.pbcast.STATE_TRANSFER
STATE_TRANSFERMBean - interface org.jgroups.jmx.protocols.pbcast.STATE_TRANSFERMBean
STATE_TRANSFER.StateHeader - class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
Wraps data for a state request/response.
StateHeader() - constructor for class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
stateListener - field in class org.jgroups.blocks.MessageListenerAdapter
StateTransferInfo - class org.jgroups.stack.StateTransferInfo
Contains parameters for state transfer.
StateTransferInfo(int,org.jgroups.Address) - constructor for class org.jgroups.stack.StateTransferInfo
StateTransferInfo(int,Vector) - constructor for class org.jgroups.stack.StateTransferInfo
stateTransferRunning() - method in class org.jgroups.blocks.ReplicatedHashtable
stats - field in class org.jgroups.JChannel
Collect statistics
STATS - class org.jgroups.jmx.protocols.STATS
STATS - class org.jgroups.protocols.STATS
Provides various stats
stats - field in class org.jgroups.stack.Protocol
STATS() - constructor for class org.jgroups.jmx.protocols.STATS
STATS(org.jgroups.stack.Protocol) - constructor for class org.jgroups.jmx.protocols.STATS
statsEnabled() - method in class org.jgroups.JChannel
statsEnabled() - method in class org.jgroups.stack.Protocol
STATSMBean - interface org.jgroups.jmx.protocols.STATSMBean
STOP - static field in class org.jgroups.Event
stop() - method in class org.jgroups.stack.AckMcastSenderWindow
Stop the rentransmition and clear all pending msgs.
stop() - method in class org.jgroups.protocols.BSH
stop() - method in class org.jgroups.blocks.ConnectionTable
Closes all open sockets, the server socket and all threads waiting for incoming messages
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.protocols.pbcast.CoordGmsImpl
stop() - method in class org.jgroups.protocols.DEADLOCK
stop() - method in class org.jgroups.debug.Debugger
stop() - method in class org.jgroups.protocols.Discovery
stop() - method in class org.jgroups.blocks.DistributedHashtable
stop() - method in class org.jgroups.blocks.DistributedQueue
stop() - method in class org.jgroups.blocks.DistributedTree
stop() - method in class org.jgroups.protocols.FC
stop() - method in class org.jgroups.protocols.FD
stop() - method in class org.jgroups.protocols.pbcast.FD
This method is called on a Channel.disconnect().
stop() - method in class org.jgroups.protocols.FD_PID
stop() - method in class org.jgroups.protocols.FD_PROB
This method is called on a Channel.disconnect().
stop() - method in class org.jgroups.protocols.FD_SIMPLE
This method is called on a Channel.disconnect().
stop() - method in class org.jgroups.protocols.FD_SOCK
stop() - method in class org.jgroups.protocols.pbcast.GMS
stop() - method in class org.jgroups.protocols.pbcast.GmsImpl
stop() - method in class org.jgroups.stack.GossipClient
stop() - method in class org.jgroups.stack.GossipRouter
JBoss MBean lifecycle operation.
stop() - method in class org.jgroups.demos.wb.GraphPanel
stop() - method in class org.jgroups.jmx.JChannel
stop() - method in class org.jgroups.jmx.JChannelMBean
stop() - method in class org.jgroups.protocols.JMS
Stops the work of the JMS protocol.
stop() - method in class org.jgroups.blocks.Link
stop() - method in class org.jgroups.blocks.LogicalLink
Stop all links
stop() - method in class org.jgroups.protocols.MERGE
This method is called on a Channel.disconnect().
stop() - method in class org.jgroups.protocols.MERGE2
stop() - method in class org.jgroups.blocks.MessageDispatcher
stop() - method in class org.jgroups.stack.MessageProtocol
stop() - method in class org.jgroups.protocols.MPING
This method is called on a Channel.disconnect().
stop() - method in class org.jgroups.protocols.NAKACK
stop() - method in class org.jgroups.protocols.pbcast.NAKACK
This method is called on a Channel.disconnect().
stop() - method in class org.jgroups.blocks.NotificationBus
stop() - method in class org.jgroups.protocols.pbcast.PBCAST
stop() - method in class org.jgroups.protocols.PIGGYBACK
stop() - method in class org.jgroups.protocols.PING
stop() - method in class org.jgroups.protocols.PingSender
stop() - method in class org.jgroups.protocols.PingWaiter
stop() - method in class org.jgroups.jmx.Protocol
stop() - method in class org.jgroups.stack.Protocol
This method is called on a Channel.disconnect().
stop() - method in class org.jgroups.jmx.ProtocolMBean
stop() - method in class org.jgroups.debug.ProtocolTester
stop() - method in class org.jgroups.blocks.PullPushAdapter
stop() - method in class org.jgroups.blocks.ReplicatedTree
stop() - method in class org.jgroups.blocks.ReplicationManager
stop() - method in class org.jgroups.blocks.RequestCorrelator
stop() - method in class org.jgroups.stack.Retransmitter
Stop the rentransmition and clear all pending msgs.
stop() - method in class org.jgroups.util.ReusableThread
Stops the thread by setting thread=null and interrupting it.
stop() - method in class org.jgroups.stack.Router
stop() - method in class org.jgroups.util.Scheduler
Stop the scheduler thread.
stop() - method in class org.jgroups.protocols.SHUFFLE
Stops the messagesHandler
stop() - method in class org.jgroups.debug.Simulator
stop() - method in class org.jgroups.protocols.SMACK
stop() - method in class org.jgroups.protocols.STABLE
Stop scheduling the gossip task
stop() - method in class org.jgroups.protocols.pbcast.STABLE
stop() - method in class org.jgroups.protocols.STATE_TRANSFER
This method is called on a Channel.disconnect().
stop() - method in class org.jgroups.protocols.TCP
stop() - method in class org.jgroups.protocols.TCPGOSSIP
This method is called on a Channel.disconnect().
stop() - method in class org.jgroups.util.TimeScheduler
Stop the scheduler if it's running.
stop() - method in class org.jgroups.protocols.TOTAL
Handle the stop() method travelling down the stack.
stop() - method in class org.jgroups.protocols.TOTAL_OLD
stop() - method in class org.jgroups.protocols.TOTAL_TOKEN
Overrides @org.jgroups.stack.MessageProtocol#stop().
stop() - method in class org.jgroups.protocols.TP
This method is called on a Channel.disconnect().
stop() - method in class org.jgroups.protocols.TUNNEL
stop() - method in class org.jgroups.protocols.UDP
This method is called on a Channel.disconnect().
stop() - method in class org.jgroups.protocols.UDP.UcastReceiver
stop() - method in class org.jgroups.protocols.UDP_NIO
stop() - method in class org.jgroups.protocols.UDP_NIO.Connector
Stops the connector.
stop() - method in class org.jgroups.protocols.UDP_NIO.ConnectorTable
stop() - method in class org.jgroups.protocols.UNICAST
This method is called on a Channel.disconnect().
stop() - method in class org.jgroups.protocols.VERIFY_SUSPECT
stop() - method in class org.jgroups.protocols.VIEW_SYNC
This method is called on a Channel.disconnect().
stop() - method in class org.jgroups.protocols.WANPIPE
This method is called on a Channel.disconnect().
stop(String) - static method in class org.jgroups.debug.Profiler
STOP_OK - static field in class org.jgroups.Event
STOP_QUEUEING - static field in class org.jgroups.Event
stopInternal() - method in class org.jgroups.stack.Protocol
Used internally.
stopInternal() - method in class org.jgroups.stack.ProtocolStack
stopped - field in class org.jgroups.blocks.DistributedQueue
stopped(Runnable) - method in class org.jgroups.util.SchedulerListener
stopStack() - method in class org.jgroups.stack.ProtocolStack
Iterates through all the protocols from top to bottom and does the following:
  1. Waits until all messages in the down queue have been flushed (ie., size is 0)
  2. Calls stop() on the protocol
stopWork() - method in class org.jgroups.stack.ProtocolStack
Override with null functionality: we don't need any threads to be started !
Streamable - interface org.jgroups.util.Streamable
Implementations of Streamable can add their state directly to the output stream, enabling them to bypass costly serialization
streamableFromByteBuffer(Class,byte[]) - static method in class org.jgroups.util.Util
streamableToByteBuffer(org.jgroups.util.Streamable) - static method in class org.jgroups.util.Util
subgroups - field in class org.jgroups.MergeView
SUBVIEW_MERGE - static field in class org.jgroups.Event
SUBVIEWSET_MERGE - static field in class org.jgroups.Event
SUSPECT - static field in class org.jgroups.Channel
SUSPECT - static field in class org.jgroups.Event
SUSPECT - static field in class org.jgroups.protocols.FD.FdHeader
SUSPECT - static field in class org.jgroups.protocols.FD_SOCK.FdHeader
suspect(Object) - method in class org.jgroups.util.AckCollector
suspect(Object) - method in class org.jgroups.stack.AckMcastReceiverWindow
suspect(org.jgroups.Address) - method in class org.jgroups.stack.AckMcastSenderWindow
Process with address suspected is suspected: remove it from all receiver sets.
suspect(org.jgroups.Address) - method in class org.jgroups.demos.Chat
suspect(org.jgroups.Address) - method in class org.jgroups.protocols.ClientGmsImpl
suspect(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.ClientGmsImpl
suspect(org.jgroups.Address) - method in class org.jgroups.protocols.CoordGmsImpl
suspect(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.CoordGmsImpl
suspect(org.jgroups.Address) - method in class org.jgroups.blocks.DistributedHashtable
Called when a member is suspected
suspect(org.jgroups.Address) - method in class org.jgroups.blocks.DistributedQueue
Called when a member is suspected
suspect(org.jgroups.Address) - method in class org.jgroups.blocks.DistributedTree
Called when a member is suspected
suspect(org.jgroups.Address) - method in class org.jgroups.protocols.GMS
suspect(org.jgroups.Address) - method in class org.jgroups.protocols.GmsImpl
suspect(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.GmsImpl
suspect(org.jgroups.Address) - method in class org.jgroups.blocks.GroupRequest
Callback (called by RequestCorrelator or Transport).
suspect(org.jgroups.Address) - method in class org.jgroups.MembershipListener
Called whenever a member is suspected of having crashed, but has not yet been excluded.
suspect(org.jgroups.Address) - method in class org.jgroups.blocks.MembershipListenerAdapter
Notify membership listener that some node was suspected.
suspect(org.jgroups.Address) - method in class org.jgroups.blocks.NotificationBus
Called whenever a member is suspected of having crashed, but has not yet been excluded.
suspect(org.jgroups.Address) - method in class org.jgroups.protocols.ParticipantGmsImpl
suspect(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
suspect(org.jgroups.Address) - method in class org.jgroups.demos.QuoteClient
Called whenever a member is suspected of having crashed, but has not yet been excluded.
suspect(org.jgroups.Address) - method in class org.jgroups.demos.QuoteServer
Called whenever a member is suspected of having crashed, but has not yet been excluded.
suspect(org.jgroups.Address) - method in class org.jgroups.ReceiverAdapter
Called whenever a member is suspected of having crashed, but has not yet been excluded.
suspect(org.jgroups.Address) - method in class org.jgroups.blocks.ReplicatedHashtable
Called when a member is suspected
suspect(org.jgroups.Address) - method in class org.jgroups.blocks.ReplicatedTree
Called when a member is suspected
suspect(org.jgroups.Address) - method in class org.jgroups.blocks.RspCollector
suspect(org.jgroups.Address) - method in class org.jgroups.demos.Topology
suspect(org.jgroups.Address) - method in class org.jgroups.demos.ViewDemo
Called when a member is suspected
suspect(org.jgroups.Address) - method in class org.jgroups.blocks.VotingAdapter
Callback for notification that one node is suspected
suspect(org.jgroups.Address) - method in class org.jgroups.demos.wb.Whiteboard
Called whenever a member is suspected of having crashed, but has not yet been excluded.
Thrown if a message is sent to a suspected member.
SuspectedException() - constructor for class org.jgroups.SuspectedException
SuspectedException(Object) - constructor for class org.jgroups.SuspectedException
SuspectEvent - class org.jgroups.SuspectEvent
Represents a suspect event.
SuspectEvent(Object) - constructor for class org.jgroups.SuspectEvent
suspend() - method in class org.jgroups.JChannel
Send() blocks from now on, until resume() is called
suspend() - method in class org.jgroups.jmx.JChannel
suspend() - method in class org.jgroups.jmx.JChannelMBean
suspend() - method in class org.jgroups.util.ReusableThread
Suspends the thread.
SUSPEND_STABLE - static field in class org.jgroups.Event
suspended(Runnable) - method in class org.jgroups.util.SchedulerListener
suspendViewHandler() - method in class org.jgroups.jmx.protocols.pbcast.GMS
suspendViewHandler() - method in class org.jgroups.protocols.pbcast.GMS
suspendViewHandler() - method in class org.jgroups.jmx.protocols.pbcast.GMSMBean
SWITCH_NAK - static field in class org.jgroups.Event
SWITCH_NAK_ACK - static field in class org.jgroups.Event
SWITCH_OUT_OF_BAND - static field in class org.jgroups.Event

T

t - field in class org.jgroups.persistence.CannotConnectException
members are made available so that the top level user can dump appropriate members on to his stack trace
t - field in class org.jgroups.persistence.CannotRemoveException
members are made available so that the top level user can dump appropriate members on to his stack trace
t - field in class org.jgroups.protocols.UDP_NIO.Connector
tableChanged(TableModelEvent) - method in class org.jgroups.demos.DistributedTreeDemo
tail - field in class org.jgroups.util.List
target - field in class org.jgroups.stack.StateTransferInfo
targets - field in class org.jgroups.stack.StateTransferInfo
Scheduler.Task - class org.jgroups.util.Scheduler.Task
TimeScheduler.Task - interface org.jgroups.util.TimeScheduler.Task
The interface that submitted tasks must implement
TCP - class org.jgroups.jmx.protocols.TCP
TCP - class org.jgroups.protocols.TCP
TCP based protocol.
TCP() - constructor for class org.jgroups.jmx.protocols.TCP
TCP() - constructor for class org.jgroups.protocols.TCP
TCP(org.jgroups.stack.Protocol) - constructor for class org.jgroups.jmx.protocols.TCP
TCP_NIO - class org.jgroups.jmx.protocols.TCP_NIO
TCP_NIO - class org.jgroups.protocols.TCP_NIO
TCP_NIO() - constructor for class org.jgroups.jmx.protocols.TCP_NIO
TCP_NIO(org.jgroups.stack.Protocol) - constructor for class org.jgroups.jmx.protocols.TCP_NIO
TCP_NIOMBean - interface org.jgroups.jmx.protocols.TCP_NIOMBean
TCPGOSSIP - class org.jgroups.jmx.protocols.TCPGOSSIP
TCPGOSSIP - class org.jgroups.protocols.TCPGOSSIP
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.jmx.protocols.TCPGOSSIP
TCPGOSSIP(org.jgroups.stack.Protocol) - constructor for class org.jgroups.jmx.protocols.TCPGOSSIP
TCPGOSSIPMBean - interface org.jgroups.jmx.protocols.TCPGOSSIPMBean
TcpHeader - class org.jgroups.protocols.TcpHeader
TcpHeader() - constructor for class org.jgroups.protocols.TcpHeader
TcpHeader(String) - constructor for class org.jgroups.protocols.TcpHeader
TCPMBean - interface org.jgroups.jmx.protocols.TCPMBean
TCPPING - class org.jgroups.jmx.protocols.TCPPING
TCPPING - class org.jgroups.protocols.TCPPING
The TCPPING protocol layer retrieves the initial membership in answer to the GMS's FIND_INITIAL_MBRS event.
TCPPING() - constructor for class org.jgroups.jmx.protocols.TCPPING
TCPPING(org.jgroups.stack.Protocol) - constructor for class org.jgroups.jmx.protocols.TCPPING
TCPPINGMBean - interface org.jgroups.jmx.protocols.TCPPINGMBean
TcpRingNode - class org.jgroups.protocols.ring.TcpRingNode
TcpRingNode(org.jgroups.stack.RpcProtocol,org.jgroups.Address) - constructor for class org.jgroups.protocols.ring.TcpRingNode
ThreadPool - class org.jgroups.util.ThreadPool
Maintains a set of ReusableThreads.
ThreadPool(int) - constructor for class org.jgroups.util.ThreadPool
TIME_TO_LIVE - static field in class org.jgroups.protocols.JMS
TimedWriter - class org.jgroups.util.TimedWriter
Waits until the buffer has been written to the output stream, or until timeout msecs have elapsed, whichever comes first.
timeout - field in class org.jgroups.blocks.GroupRequest
timeout - field in class org.jgroups.stack.StateTransferInfo
Thrown if members fail to respond in time.
TimeoutException() - constructor for class org.jgroups.TimeoutException
TimeoutException(List) - constructor for class org.jgroups.TimeoutException
TimeoutException(String) - constructor for class org.jgroups.TimeoutException
timer - field in class org.jgroups.stack.ProtocolStack
TimeScheduler - class org.jgroups.util.TimeScheduler
Fixed-delay & fixed-rate single thread scheduler

The scheduler supports varying scheduling intervals by asking the task every time for its next preferred scheduling interval.

TimeScheduler() - constructor for class org.jgroups.util.TimeScheduler
Create a scheduler that executes tasks in dynamically adjustable intervals
TimeScheduler(long) - constructor for class org.jgroups.util.TimeScheduler
Create a scheduler that executes tasks in dynamically adjustable intervals
timestamp - field in class org.jgroups.stack.LogicalAddress
TMP_VIEW - static field in class org.jgroups.Event
tokenArrived(Object) - method in class org.jgroups.protocols.ring.RingNode
tokenArrived(Object) - method in class org.jgroups.protocols.ring.TcpRingNode
tokenArrived(Object) - method in class org.jgroups.protocols.ring.UdpRingNode
TokenLostException - class org.jgroups.protocols.ring.TokenLostException
TokenLostException() - constructor for class org.jgroups.protocols.ring.TokenLostException
TokenLostException(String) - constructor for class org.jgroups.protocols.ring.TokenLostException
TokenLostException(String,Throwable,org.jgroups.Address,int) - constructor for class org.jgroups.protocols.ring.TokenLostException
Topology - class org.jgroups.demos.Topology
Demonstrates the membership service.
Topology() - constructor for class org.jgroups.demos.Topology
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.util.AckCollector
toString() - method in class org.jgroups.stack.AckMcastReceiverWindow
toString() - method in class org.jgroups.stack.AckMcastSenderWindow
toString() - method in class org.jgroups.stack.AckReceiverWindow
toString() - method in class org.jgroups.stack.AckSenderWindow
toString() - method in class org.jgroups.BlockEvent
toString() - method in class org.jgroups.protocols.BSH.BshHeader
toString() - method in class org.jgroups.util.Buffer
toString() - method in class org.jgroups.persistence.CannotConnectException
toString() - method in class org.jgroups.persistence.CannotCreateSchemaException
toString() - method in class org.jgroups.persistence.CannotPersistException
toString() - method in class org.jgroups.persistence.CannotRemoveException
toString() - method in class org.jgroups.persistence.CannotRetrieveException
toString() - method in class org.jgroups.protocols.CAUSAL.CausalHeader
toString() - method in class org.jgroups.ChannelClosedException
toString() - method in class org.jgroups.ChannelNotConnectedException
toString() - method in class org.jgroups.conf.ClassConfigurator
toString() - method in class org.jgroups.util.CondVar
toString() - method in class org.jgroups.stack.Configurator.ProtocolConfiguration
toString() - method in class org.jgroups.blocks.ConnectionTable
toString() - method in class org.jgroups.protocols.Digest
toString() - method in class org.jgroups.protocols.pbcast.Digest
toString() - method in class org.jgroups.protocols.pbcast.Digest.Entry
toString() - method in class org.jgroups.blocks.DistributedQueue
toString() - method in class org.jgroups.demos.DrawCommand
toString() - method in class org.jgroups.protocols.DUMMY_TP
toString() - method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
toString() - method in class org.jgroups.protocols.ENCRYPT1_4.EncryptHeader
toString() - method in class org.jgroups.Event
toString() - method in class org.jgroups.ExitEvent
toString() - method in class org.jgroups.protocols.FC.FcHeader
toString() - method in class org.jgroups.protocols.FD.FdHeader
toString() - method in class org.jgroups.protocols.FD_PID.FdHeader
toString() - method in class org.jgroups.protocols.FD_PROB.FdHeader
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.FlushRsp
toString() - method in class org.jgroups.protocols.FragHeader
toString() - method in class org.jgroups.GetStateEvent
toString() - method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
toString() - method in class org.jgroups.protocols.pbcast.GMS.Request
toString() - method in class org.jgroups.protocols.pbcast.Gossip
toString() - method in class org.jgroups.stack.GossipData
toString() - method in class org.jgroups.blocks.GroupRequest
toString() - method in class org.jgroups.Header
toString() - method in class org.jgroups.protocols.HTOTAL.HTotalHeader
toString() - method in class org.jgroups.stack.IpAddress
toString() - method in class org.jgroups.protocols.JMS
Get the string representation of the protocol.
toString() - method in class org.jgroups.protocols.JMS.JMSAddress
Get the string representation of the address.
toString() - method in class org.jgroups.protocols.pbcast.JoinRsp
toString() - method in class org.jgroups.blocks.Link
toString() - method in class org.jgroups.util.LinkedListQueue
prints the size of the queue
toString() - method in class org.jgroups.util.List
toString() - method in class org.jgroups.blocks.LockingException
toString() - method in class org.jgroups.stack.LogicalAddress
toString() - method in class org.jgroups.blocks.LogicalLink.AllLinksDown
toString() - method in class org.jgroups.blocks.LogicalLink.NoLinksAvailable
toString() - method in class org.jgroups.protocols.LOOPBACK
toString() - method in class org.jgroups.Membership
toString() - method in class org.jgroups.protocols.MERGE.MergeHeader
toString() - method in class org.jgroups.protocols.pbcast.MergeData
toString() - method in class org.jgroups.MergeView
toString() - method in class org.jgroups.Message
toString() - method in class org.jgroups.blocks.MethodCall
toString() - method in class org.jgroups.protocols.NakAckHeader
toString() - method in class org.jgroups.protocols.pbcast.NakAckHeader
toString() - method in class org.jgroups.stack.NakReceiverWindow
toString() - method in class org.jgroups.demos.wb.Node
toString() - method in class org.jgroups.protocols.PARTITIONER.PartitionerHeader
toString() - method in class org.jgroups.protocols.pbcast.PbcastHeader
toString() - method in class org.jgroups.protocols.PERF_TP
toString() - method in class org.jgroups.protocols.PerfHeader
toString() - method in class org.jgroups.protocols.PIGGYBACK.PiggybackHeader
toString() - method in class org.jgroups.protocols.PingHeader
toString() - method in class org.jgroups.protocols.PingRsp
toString() - method in class org.jgroups.protocols.PRINTOBJS
toString() - method in class org.jgroups.util.Promise
toString() - method in class org.jgroups.debug.ProtocolView
toString() - method in class org.jgroups.blocks.PullPushAdapter.PullHeader
toString() - method in class org.jgroups.util.Queue
prints the size of the queue
toString() - method in class org.jgroups.util.Queue2
prints the size of the queue
toString() - method in class org.jgroups.util.QueueClosedException
toString() - method in class org.jgroups.util.Range
toString() - method in class org.jgroups.blocks.ReplicatedTree
toString() - method in class org.jgroups.blocks.ReplicatedTree.Node
toString() - method in class org.jgroups.blocks.ReplicationData
toString() - method in class org.jgroups.blocks.RequestCorrelator.Header
toString() - method in class org.jgroups.stack.Retransmitter
toString() - method in class org.jgroups.util.ReusableThread
toString() - method in class org.jgroups.protocols.ring.RingToken
toString() - method in class org.jgroups.util.Rsp
toString() - method in class org.jgroups.util.RspList
toString() - method in class org.jgroups.util.Scheduler.Task
toString() - method in class org.jgroups.SetStateEvent
toString() - method in class org.jgroups.protocols.SMACK.SmackHeader
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.stack.StateTransferInfo
toString() - method in class org.jgroups.SuspectedException
toString() - method in class org.jgroups.SuspectEvent
toString() - method in class org.jgroups.protocols.TcpHeader
toString() - method in class org.jgroups.util.ThreadPool
toString() - method in class org.jgroups.TimeoutException
toString() - method in class org.jgroups.protocols.ring.TokenLostException
toString() - method in class org.jgroups.protocols.TOTAL.Header
For debugging purposes
toString() - method in class org.jgroups.protocols.TOTAL_OLD.TotalHeader
toString() - method in class org.jgroups.protocols.TOTAL_TOKEN.TotalTokenHeader
toString() - method in class org.jgroups.protocols.TP
debug only
toString() - method in class org.jgroups.protocols.TpHeader
toString() - method in class org.jgroups.protocols.TRACE
toString() - method in class org.jgroups.protocols.TransportedVectorTime
Returns String representation of this vector timestamp
toString() - method in class org.jgroups.protocols.TUNNEL
toString() - method in class org.jgroups.protocols.TunnelHeader
toString() - method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
toString() - method in class org.jgroups.protocols.UDP_NIO
debug only
toString() - method in class org.jgroups.protocols.UDP_NIO.Connector
toString() - method in class org.jgroups.protocols.UDP_NIO.ConnectorTable
toString() - method in class org.jgroups.protocols.UdpHeader
toString() - method in class org.jgroups.protocols.UNICAST.UnicastHeader
toString() - method in class org.jgroups.protocols.VectorTime
return String representation of the VectorTime
toString() - method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
toString() - method in class org.jgroups.View
toString() - method in class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
toString() - method in class org.jgroups.ViewId
toString() - method in class org.jgroups.blocks.VotingAdapter.VoteResult
toString() - method in class org.jgroups.protocols.WANPIPE
toString() - method in class org.jgroups.protocols.WANPIPE.WanPipeHeader
toString() - method in class org.jgroups.protocols.WanPipeAddress
toString() - method in class org.jgroups.blocks.Xid
toString(boolean) - method in class org.jgroups.JChannel
toString(boolean) - method in class org.jgroups.jmx.JChannel
toString(boolean) - method in class org.jgroups.jmx.JChannelMBean
toString(boolean) - method in class org.jgroups.stack.LogicalAddress
toStringAsObject() - method in class org.jgroups.Message
Tries to read an object from the message's buffer and prints it
toStringDetails() - method in class org.jgroups.blocks.MethodCall
TOTAL - class org.jgroups.protocols.TOTAL
Implements the total ordering layer using a message sequencer

The protocol guarantees that all bcast sent messages will be delivered in the same order to all members.

TOTAL() - constructor for class org.jgroups.protocols.TOTAL
Create the TOTAL layer
TOTAL_BCAST - static field in class org.jgroups.protocols.TOTAL_OLD.TotalHeader
TOTAL_CUM_SEQ_ACK - static field in class org.jgroups.protocols.TOTAL_OLD.TotalHeader
total_header_type - field in class org.jgroups.protocols.TOTAL_OLD.TotalHeader
TOTAL_NEW_VIEW - static field in class org.jgroups.protocols.TOTAL_OLD.TotalHeader
TOTAL_NEW_VIEW_ACK - static field in class org.jgroups.protocols.TOTAL_OLD.TotalHeader
TOTAL_OLD - class org.jgroups.protocols.TOTAL_OLD
************************************************************************** class TOTAL_OLD extends Protocol

TODO: (more comments) Sequencer based total ordering protocol layer - requires the following layers "below" it in the stack (or layers with equivalent functionality): GMS, FD, PING, UDP, ...

TOTAL_REQUEST - static field in class org.jgroups.protocols.TOTAL_OLD.TotalHeader
TOTAL_RESEND - static field in class org.jgroups.protocols.TOTAL_OLD.TotalHeader
TOTAL_SEQ_ACK - static field in class org.jgroups.protocols.TOTAL_OLD.TotalHeader
TOTAL_TOKEN - class org.jgroups.protocols.TOTAL_TOKEN
Total order implementation based on The Totem Single-Ring Ordering and Membership Protocol.
TOTAL_UNICAST - static field in class org.jgroups.protocols.TOTAL_OLD.TotalHeader
TOTAL_OLD.TotalHeader - class org.jgroups.protocols.TOTAL_OLD.TotalHeader
class TotalHeader

The header that is prepended to every message passed down through the TOTAL_OLD layer and removed (and processed) from every message passed up through the TOTAL_OLD layer

TotalHeader() - constructor for class org.jgroups.protocols.TOTAL_OLD.TotalHeader
TotalHeader(int,long) - constructor for class org.jgroups.protocols.TOTAL_OLD.TotalHeader
TotalOrder - class org.jgroups.demos.TotalOrder
Originally written to be a demo for TOTAL order (code to be written by a student).
TotalOrder(String,long,int,int,String) - constructor for class org.jgroups.demos.TotalOrder
TotalPayload(int) - constructor for class org.jgroups.demos.TotalTokenDemo.TotalPayload
TotalTokenDemo - class org.jgroups.demos.TotalTokenDemo
Demonstration of TOTAL_TOKEN protocol stack implementing total order.
TotalTokenDemo(String) - constructor for class org.jgroups.demos.TotalTokenDemo
TotalTokenHeader() - constructor for class org.jgroups.protocols.TOTAL_TOKEN.TotalTokenHeader
used for externalization
TotalTokenHeader(Long) - constructor for class org.jgroups.protocols.TOTAL_TOKEN.TotalTokenHeader
TP - class org.jgroups.jmx.protocols.TP
TP - class org.jgroups.protocols.TP
Generic transport - specific implementations should extend this abstract class.
TP() - constructor for class org.jgroups.jmx.protocols.TP
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(org.jgroups.stack.Protocol) - constructor for class org.jgroups.jmx.protocols.TP
TpHeader - class org.jgroups.protocols.TpHeader
Generic transport header, used by TP.
TpHeader() - constructor for class org.jgroups.protocols.TpHeader
TpHeader(String) - constructor for class org.jgroups.protocols.TpHeader
TPMBean - interface org.jgroups.jmx.protocols.TPMBean
TRACE - class org.jgroups.protocols.TRACE
trace - field in class org.jgroups.protocols.PingSender
trace - field in class org.jgroups.stack.Protocol
TRACE() - constructor for class org.jgroups.protocols.TRACE
transport - field in class org.jgroups.blocks.GroupRequest
Transport - interface org.jgroups.Transport
Defines a very small subset of the functionality of a channel, essentially only the methods for sending and receiving messages.
transport - field in class org.jgroups.blocks.PullPushAdapter
transport - field in class org.jgroups.blocks.RequestCorrelator
The protocol layer to use to pass up/down messages.
transport_adapter - field in class org.jgroups.blocks.MessageDispatcher
TransportedVectorTime - class org.jgroups.protocols.TransportedVectorTime
Lighweight representation of the VectorTime clock suitable for network transport
TransportedVectorTime() - constructor for class org.jgroups.protocols.TransportedVectorTime
TransportedVectorTime(int,int[]) - constructor for class org.jgroups.protocols.TransportedVectorTime
Constructs TransportedVectorTime with sender index and vector values
trim(double) - static method in class org.jgroups.debug.Profiler
TUNNEL - class org.jgroups.protocols.TUNNEL
Replacement for UDP.
TUNNEL() - constructor for class org.jgroups.protocols.TUNNEL
TunnelHeader - class org.jgroups.protocols.TunnelHeader
TunnelHeader() - constructor for class org.jgroups.protocols.TunnelHeader
TunnelHeader(String) - constructor for class org.jgroups.protocols.TunnelHeader
TwoPhaseVotingAdapter - class org.jgroups.blocks.TwoPhaseVotingAdapter
This adapter introduces simple two-phase voting on a specified decree.
Creats an instance of the class.
TwoPhaseVotingListener - interface org.jgroups.blocks.TwoPhaseVotingListener
Implementations of this interface can participate in two-phase voting process.
Wrapper of the decree to voting decree.
TwoPhaseWrapper(Object) - constructor for class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
type - field in class org.jgroups.protocols.MERGE.MergeHeader
type - field in class org.jgroups.protocols.PingHeader
type - field in class org.jgroups.blocks.RequestCorrelator.Header
Type of header: request or reply
type - field in class org.jgroups.stack.StateTransferInfo
type - field in class org.jgroups.protocols.TOTAL.Header
The header's type tag
type2Str(byte) - static method in class org.jgroups.protocols.pbcast.NakAckHeader
type2Str(byte) - static method in class org.jgroups.protocols.UNICAST.UnicastHeader
type2Str(int) - static method in class org.jgroups.protocols.NakAckHeader
type2String(byte) - static method in class org.jgroups.protocols.FD_SOCK.FdHeader
type2String(int) - static method in class org.jgroups.Event
type2String(int) - static method in class org.jgroups.protocols.FD_PID.FdHeader
type2String(int) - static method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
type2String(int) - static method in class org.jgroups.stack.GossipData
type2String(int) - static method in class org.jgroups.protocols.pbcast.PbcastHeader
TYPES - static field in class org.jgroups.blocks.MethodCall
Use class information.
typeToString(int) - static method in class org.jgroups.blocks.ReplicationData

U

UCAST - static field in class org.jgroups.protocols.TOTAL.Header
Unicast message
UDP.UcastReceiver - class org.jgroups.protocols.UDP.UcastReceiver
UDP - class org.jgroups.jmx.protocols.UDP
UDP - class org.jgroups.protocols.UDP
IP multicast transport based on UDP.
UDP() - constructor for class org.jgroups.jmx.protocols.UDP
UDP() - constructor for class org.jgroups.protocols.UDP
Creates the UDP protocol, and initializes the state variables, does however not start any sockets or threads.
UDP(org.jgroups.stack.Protocol) - constructor for class org.jgroups.jmx.protocols.UDP
UDP_NIO - class org.jgroups.protocols.UDP_NIO
Multicast transport.
UDP_NIO() - constructor for class org.jgroups.protocols.UDP_NIO
Creates the UDP_NIO protocol, and initializes the state variables, does however not start any sockets or threads.
UdpHeader - class org.jgroups.protocols.UdpHeader
UdpHeader() - constructor for class org.jgroups.protocols.UdpHeader
UdpHeader(String) - constructor for class org.jgroups.protocols.UdpHeader
UDPMBean - interface org.jgroups.jmx.protocols.UDPMBean
UdpRingNode - class org.jgroups.protocols.ring.UdpRingNode
UdpRingNode(org.jgroups.stack.RpcProtocol,org.jgroups.Address) - constructor for class org.jgroups.protocols.ring.UdpRingNode
unblock() - method in class org.jgroups.jmx.protocols.FC
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.jmx.protocols.FCMBean
UNBLOCK_SEND - static field in class org.jgroups.Event
UNDEFINED - static field in class org.jgroups.protocols.ring.TokenLostException
UNICAST - class org.jgroups.jmx.protocols.UNICAST
UNICAST - class org.jgroups.protocols.UNICAST
Reliable unicast layer.
UNICAST() - constructor for class org.jgroups.jmx.protocols.UNICAST
UNICAST(org.jgroups.stack.Protocol) - constructor for class org.jgroups.jmx.protocols.UNICAST
UNICAST.UnicastHeader - class org.jgroups.protocols.UNICAST.UnicastHeader
UnicastHeader() - constructor for class org.jgroups.protocols.UNICAST.UnicastHeader
UnicastHeader(byte,long) - constructor for class org.jgroups.protocols.UNICAST.UnicastHeader
UNICASTMBean - interface org.jgroups.jmx.protocols.UNICASTMBean
unlock() - method in class org.jgroups.util.ReentrantLatch
Unlock the latch.
unlock(Object,Object) - method in class org.jgroups.blocks.DistributedLockManager
Unlocks an object with lockId on behalf of the specified owner.
unlock(Object,Object) - method in class org.jgroups.blocks.LockManager
Release lock on obj owned by specified owner.
unlock(Object,Object,boolean) - method in class org.jgroups.blocks.DistributedLockManager
Unlocks an object with lockId on behalf of the specified owner.
unlock(Object,Object,boolean) - method in class org.jgroups.blocks.LockManager
Release lock on obj owned by specified owner.
UDP_NIO.Unmarshaller - class org.jgroups.protocols.UDP_NIO.Unmarshaller
unregisterChannel(MBeanServer,ObjectName) - static method in class org.jgroups.jmx.JmxConfigurator
unregisterListener(Serializable) - method in class org.jgroups.blocks.PullPushAdapter
Removes a message listener to a given identifier from the message listeners map.
unstable_msgs - field in class org.jgroups.protocols.FlushRsp
UNSUSPECT - static field in class org.jgroups.Event
unsuspect(Object) - method in class org.jgroups.util.AckCollector
unsuspect(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.ClientGmsImpl
unsuspect(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.CoordGmsImpl
unsuspect(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.GmsImpl
unsuspect(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
Removes previously suspected member from list of currently suspected members
up(org.jgroups.Event) - method in class org.jgroups.protocols.BSH
up(org.jgroups.Event) - method in class org.jgroups.protocols.CAUSAL
Processes Event going up through the stack
up(org.jgroups.Event) - method in class org.jgroups.protocols.COMPRESS
If there is no header, we pass the message up.
up(org.jgroups.Event) - method in class org.jgroups.protocols.DELAY
up(org.jgroups.Event) - method in class org.jgroups.protocols.DISCARD
up(org.jgroups.Event) - method in class org.jgroups.protocols.Discovery
An event was received from the layer below.
up(org.jgroups.Event) - method in class org.jgroups.protocols.DUMMY
up(org.jgroups.Event) - method in class org.jgroups.protocols.ENCRYPT
An event was received from the layer below.
up(org.jgroups.Event) - method in class org.jgroups.protocols.ENCRYPT1_4
up(org.jgroups.Event) - method in class org.jgroups.protocols.EXAMPLE
up(org.jgroups.Event) - method in class org.jgroups.protocols.FC
up(org.jgroups.Event) - method in class org.jgroups.protocols.FD
up(org.jgroups.Event) - method in class org.jgroups.protocols.pbcast.FD
An event was received from the layer below.
up(org.jgroups.Event) - method in class org.jgroups.protocols.FD_PID
up(org.jgroups.Event) - method in class org.jgroups.protocols.FD_PROB
An event was received from the layer below.
up(org.jgroups.Event) - method in class org.jgroups.protocols.FD_SIMPLE
An event was received from the layer below.
up(org.jgroups.Event) - method in class org.jgroups.protocols.FD_SOCK
up(org.jgroups.Event) - method in class org.jgroups.protocols.FLOWCONTROL
Checs if up messages are from myaddr and in the case sends down queued messages or decremnts sentMsgs if there are no queued messages
up(org.jgroups.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(org.jgroups.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(org.jgroups.Event) - method in class org.jgroups.protocols.pbcast.GMS
up(org.jgroups.Event) - method in class org.jgroups.protocols.HDRS
up(org.jgroups.Event) - method in class org.jgroups.protocols.HTOTAL
up(org.jgroups.Event) - method in class org.jgroups.JChannel
Callback method
Called by the ProtocolStack when a message is received.
up(org.jgroups.Event) - method in class org.jgroups.protocols.MERGE
An event was received from the layer below.
up(org.jgroups.Event) - method in class org.jgroups.protocols.MERGE2
up(org.jgroups.Event) - method in class org.jgroups.protocols.MERGE3
up(org.jgroups.Event) - method in class org.jgroups.protocols.MERGEFAST
up(org.jgroups.Event) - method in class org.jgroups.stack.MessageProtocol
Handle an event coming from the layer above
up(org.jgroups.Event) - method in class org.jgroups.protocols.NAKACK
Callback.
up(org.jgroups.Event) - method in class org.jgroups.protocols.pbcast.NAKACK
Callback.
up(org.jgroups.Event) - method in class org.jgroups.protocols.PARTITIONER
Discards Messages with the wrong partition number and sets local partition number if it receives a COMMAND Header
up(org.jgroups.Event) - method in class org.jgroups.protocols.pbcast.PBCAST
up(org.jgroups.Event) - method in class org.jgroups.protocols.PERF
up(org.jgroups.Event) - method in class org.jgroups.protocols.PERF_TP
An event was received from the layer below.
up(org.jgroups.Event) - method in class org.jgroups.protocols.PIGGYBACK
up(org.jgroups.Event) - method in class org.jgroups.protocols.PRINTMETHODS
up(org.jgroups.Event) - method in class org.jgroups.protocols.PRINTOBJS
An event was received from the layer below.
up(org.jgroups.Event) - method in class org.jgroups.stack.Protocol
An event was received from the layer below.
up(org.jgroups.Event) - method in class org.jgroups.stack.ProtocolStack
up(org.jgroups.Event) - method in class org.jgroups.protocols.QUEUE
Queues or passes up events.
up(org.jgroups.Event) - method in class org.jgroups.protocols.SHUFFLE
Adds upcoming messages to the messages List<\code> where the messagesHandler<\code> retrieves them.
up(org.jgroups.Event) - method in class org.jgroups.protocols.SIZE
up(org.jgroups.Event) - method in class org.jgroups.protocols.SMACK
up(org.jgroups.Event) - method in class org.jgroups.protocols.pbcast.STABLE
up(org.jgroups.Event) - method in class org.jgroups.protocols.STATE_TRANSFER
An event was received from the layer below.
up(org.jgroups.Event) - method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
up(org.jgroups.Event) - method in class org.jgroups.protocols.STATS
An event was received from the layer below.
up(org.jgroups.Event) - method in class org.jgroups.protocols.TOTAL
An event was received from the layer below.
up(org.jgroups.Event) - method in class org.jgroups.protocols.TOTAL_OLD
handles an Event coming up the Protocol Stack
up(org.jgroups.Event) - method in class org.jgroups.protocols.TP
handle the UP event.
up(org.jgroups.Event) - method in class org.jgroups.protocols.TRACE
up(org.jgroups.Event) - method in class org.jgroups.protocols.UDP_NIO
handle the UP event.
up(org.jgroups.Event) - method in class org.jgroups.protocols.UNICAST
An event was received from the layer below.
up(org.jgroups.Event) - method in class org.jgroups.UpHandler
Invoked for all channel events except connection management and state transfer.
up(org.jgroups.Event) - method in class org.jgroups.protocols.VERIFY_SUSPECT
up(org.jgroups.Event) - method in class org.jgroups.protocols.VIEW_ENFORCER
up(org.jgroups.Event) - method in class org.jgroups.protocols.VIEW_SYNC
An event was received from the layer below.
up(org.jgroups.Event,int) - method in class org.jgroups.stack.ProtocolObserver
Called when an event is about to be dispatched to the protocol (before it is dispatched).
up(org.jgroups.Event,int) - method in class org.jgroups.debug.ProtocolView
up_handler - field in class org.jgroups.Channel
up_handler - field in class org.jgroups.stack.Protocol
up_prot - field in class org.jgroups.stack.Protocol
up_queue - field in class org.jgroups.stack.Protocol
up_thread - field in class org.jgroups.stack.Protocol
up_thread_prio - field in class org.jgroups.stack.Protocol
update(Graphics) - method in class org.jgroups.demos.wb.GraphPanel
UpdateException - class org.jgroups.blocks.UpdateException
UpdateException(String) - constructor for class org.jgroups.blocks.UpdateException
updateView(org.jgroups.View) - method in class org.jgroups.stack.MessageProtocol
updateView(org.jgroups.View) - method in class org.jgroups.protocols.TOTAL_TOKEN
updateWindow(org.jgroups.protocols.ring.RingToken) - method in class org.jgroups.protocols.ring.RingNodeFlowControl
UpHandler - interface org.jgroups.UpHandler
Provides a way of taking over a channel's tasks.
upThreadEnabled() - method in class org.jgroups.stack.Protocol
useLocks() - method in class org.jgroups.blocks.ReplicationData
USER_DEFINED - static field in class org.jgroups.Event
UserInfoDialog - class org.jgroups.demos.wb.UserInfoDialog
UserInfoDialog(Frame) - constructor for class org.jgroups.demos.wb.UserInfoDialog
Util - class org.jgroups.util.Util
Collection of various utility routines that can not be assigned to other classes.

V

validate() - method in class org.jgroups.conf.XmlValidator
valueChanged(TreeSelectionEvent) - method in class org.jgroups.demos.DistributedTreeDemo
values() - method in class org.jgroups.util.Queue
Returns all the elements of the queue
VectorTime - class org.jgroups.protocols.VectorTime
Vector timestamp used in CAUSAL order protocol stack
VectorTime(org.jgroups.Address) - constructor for class org.jgroups.protocols.VectorTime
Constructs VectorTime given an adress of a owning group member
VERIFY_SUSPECT - class org.jgroups.protocols.VERIFY_SUSPECT
Catches SUSPECT events traveling up the stack.
VerifyHeader() - constructor for class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
Version - class org.jgroups.Version
Holds version information for JGroups.
version - static field in class org.jgroups.Version
vid - field in class org.jgroups.View
VIEW - static field in class org.jgroups.Channel
VIEW - static field in class org.jgroups.protocols.pbcast.GMS.GmsHeader
View - class org.jgroups.View
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
View(org.jgroups.Address,long,Vector) - constructor for class org.jgroups.View
Creates a new view
View(org.jgroups.ViewId,Vector) - constructor for class org.jgroups.View
Creates a new view
VIEW_ACK - static field in class org.jgroups.protocols.pbcast.GMS.GmsHeader
VIEW_CHANGE - static field in class org.jgroups.Event
VIEW_ENFORCER - class org.jgroups.protocols.VIEW_ENFORCER
Used by a client until it becomes a member: all up messages are discarded until a VIEW_CHANGE is encountered.
view_handler - field in class org.jgroups.protocols.pbcast.GMS
Class to process JOIN, LEAVE and MERGE requests
view_id - field in class org.jgroups.protocols.GMS
view_mutex - field in class org.jgroups.protocols.GMS
VIEW_SYNC - class org.jgroups.jmx.protocols.VIEW_SYNC
VIEW_SYNC - class org.jgroups.protocols.VIEW_SYNC
Periodically sends the view to the group.
VIEW_SYNC - static field in class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
VIEW_SYNC() - constructor for class org.jgroups.jmx.protocols.VIEW_SYNC
VIEW_SYNC(org.jgroups.stack.Protocol) - constructor for class org.jgroups.jmx.protocols.VIEW_SYNC
VIEW_SYNC_REQ - static field in class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
VIEW_SYNCMBean - interface org.jgroups.jmx.protocols.VIEW_SYNCMBean
viewAccepted(org.jgroups.View) - method in class org.jgroups.demos.Chat
viewAccepted(org.jgroups.View) - method in class org.jgroups.blocks.DistributedHashtable
Called when a change in membership has occurred.
viewAccepted(org.jgroups.View) - method in class org.jgroups.blocks.DistributedQueue
viewAccepted(org.jgroups.View) - method in class org.jgroups.blocks.DistributedTree
Called when a change in membership has occurred.
viewAccepted(org.jgroups.View) - method in class org.jgroups.demos.applets.DrawApplet
Called when a change in membership has occurred.
viewAccepted(org.jgroups.View) - method in class org.jgroups.blocks.MembershipListenerAdapter
Notify membership listener that new view was accepted.
viewAccepted(org.jgroups.View) - method in class org.jgroups.blocks.NotificationBus
Called when a change in membership has occurred.
viewAccepted(org.jgroups.View) - method in class org.jgroups.demos.QuoteClient
Called when a change in membership has occurred.
viewAccepted(org.jgroups.View) - method in class org.jgroups.demos.QuoteServer
Called when a change in membership has occurred.
viewAccepted(org.jgroups.View) - method in class org.jgroups.ReceiverAdapter
Called when a change in membership has occurred.
viewAccepted(org.jgroups.View) - method in class org.jgroups.blocks.ReplicatedHashtable
Called when a change in membership has occurred.
viewAccepted(org.jgroups.View) - method in class org.jgroups.blocks.ReplicatedTree
Called when a change in membership has occurred.
viewAccepted(org.jgroups.View) - method in class org.jgroups.demos.Topology
viewAccepted(org.jgroups.View) - method in class org.jgroups.demos.ViewDemo
Called when a change in membership has occurred.
viewAccepted(org.jgroups.View) - method in class org.jgroups.blocks.VotingAdapter
Callback for notification about the new view of the group.
viewAccepted(org.jgroups.View) - method in class org.jgroups.demos.wb.Whiteboard
Called when a change in membership has occurred.
viewChange(org.jgroups.View) - method in class org.jgroups.blocks.GroupRequest
Any member of 'membership' that is not in the new view is flagged as SUSPECTED.
viewChange(org.jgroups.View) - method in class org.jgroups.blocks.RspCollector
viewChange(Vector,Vector) - method in class org.jgroups.demos.DistributedHashtableDemo
viewChange(Vector,Vector) - method in class org.jgroups.blocks.DistributedQueue.Notification
viewChange(Vector,Vector) - method in class org.jgroups.demos.DistributedQueueDemo
viewChange(Vector,Vector) - method in class org.jgroups.blocks.DistributedTree.ViewListener
viewChange(Vector,Vector) - method in class org.jgroups.blocks.ReplicatedHashtable.Notification
viewChanged(int) - method in class org.jgroups.protocols.ring.RingNodeFlowControl
ViewDemo - class org.jgroups.demos.ViewDemo
Demos the reception of views using a PullPushAdapter.
viewHandlerSize() - method in class org.jgroups.protocols.pbcast.GMS
ViewId - class org.jgroups.ViewId
ViewIds are used for ordering views (each view has a ViewId and a list of members).
ViewId() - constructor for class org.jgroups.ViewId
ViewId(org.jgroups.Address) - constructor for class org.jgroups.ViewId
Creates a ViewID with the coordinator address and a Lamport timestamp of 0.
ViewId(org.jgroups.Address,long) - constructor for class org.jgroups.ViewId
Creates a ViewID with the coordinator address and the given Lamport timestamp.
ViewSyncHeader() - constructor for class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
ViewSyncHeader(int,org.jgroups.View) - constructor for class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
vote(Object) - method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseVoteWrapper
Each member is able to vote with true or false messages.
vote(Object) - method in class org.jgroups.blocks.VotingListener
Each member is able to vote with true or false messages.
vote(Object,int,long) - method in class org.jgroups.blocks.VotingAdapter
Performs actual voting on the VoteChannel using the JGroups facilities for communication.
Performs actual voting on the VoteChannel using the JGroups facilities for communication.
vote(Object,long) - method in class org.jgroups.blocks.TwoPhaseVotingAdapter
Performs the two-phase voting on the decree.
vote(Object,long) - method in class org.jgroups.blocks.VotingAdapter
Vote on the specified decree requiring all nodes to vote.
Performs the two-phase voting on the decree.
Vote on the specified decree requiring all nodes to vote.
VOTE_ALL - static field in class org.jgroups.blocks.VotingAdapter
This consensus type means that at least one positive vote and no negative votes are required for the voting to succeed.
VOTE_ANY - static field in class org.jgroups.blocks.VotingAdapter
This consensus type means that at least one positive vote is required for the voting to succeed.
VOTE_MAJORITY - static field in class org.jgroups.blocks.VotingAdapter
This consensus type means that number of positive votes should be greater than number of negative votes.
VoteException - class org.jgroups.blocks.VoteException
This exception is thrown when voting listener cannot vote on the specified decree.
VoteException(String) - constructor for class org.jgroups.blocks.VoteException
VoteResponseProcessor - interface org.jgroups.blocks.VoteResponseProcessor
VoteResultProcessor Applications that use the VotingAdapter and/or TwoPhaseVotingAdapter can pass an implementation of this down the vote calls, to intercept processing of the VoteResults returned by other nodes.
This class represents the result of local voting.
VotingAdapter - class org.jgroups.blocks.VotingAdapter
Voting adapter provides a voting functionality for an application.
VotingAdapter(org.jgroups.Channel) - constructor for class org.jgroups.blocks.VotingAdapter
Creates an instance of the VoteChannel that uses JGroups for communication between group members.
VotingListener - interface org.jgroups.blocks.VotingListener
Implemetations of this interface are able to participate in voting process.

W

waitForAllAcks() - method in class org.jgroups.util.AckCollector
waitForAllAcks(long) - method in class org.jgroups.util.AckCollector
waitUntil(Object) - method in class org.jgroups.util.CondVar
waitUntil(Object,long) - method in class org.jgroups.util.CondVar
Waits until the condition matches the expected result.
waitUntilAllAcksReceived(long) - method in class org.jgroups.stack.AckMcastSenderWindow
Waits until all outstanding messages have been ACKed by all receivers.
waitUntilClosed(long) - method in class org.jgroups.util.Queue
Waits until the queue has been closed.
waitUntilDone() - method in class org.jgroups.util.ReusableThread
waitUntilEmpty(long) - method in class org.jgroups.util.Queue2
Blocks until the queue has no elements left.
waitUntilWithTimeout(Object,long) - method in class org.jgroups.util.CondVar
Waits until the condition matches the expected result.
WANPING - class org.jgroups.protocols.WANPING
Similar to TCPPING, except that the initial host list is specified as a list of logical pipe names.
WANPIPE - class org.jgroups.protocols.WANPIPE
Logical point-to-point link.
WANPIPE() - constructor for class org.jgroups.protocols.WANPIPE
WanPipeAddress - class org.jgroups.protocols.WanPipeAddress
Logical address for a WAN pipe (logical link)
WanPipeAddress() - constructor for class org.jgroups.protocols.WanPipeAddress
WanPipeAddress(String) - constructor for class org.jgroups.protocols.WanPipeAddress
WANPIPE.WanPipeHeader - class org.jgroups.protocols.WANPIPE.WanPipeHeader
WanPipeHeader() - constructor for class org.jgroups.protocols.WANPIPE.WanPipeHeader
WanPipeHeader(String) - constructor for class org.jgroups.protocols.WANPIPE.WanPipeHeader
warn - field in class org.jgroups.stack.Protocol
wasReceived() - method in class org.jgroups.util.Rsp
wasSuspected() - method in class org.jgroups.util.Rsp
WHILE_RECEIVING - static field in class org.jgroups.protocols.ring.TokenLostException
WHILE_SENDING - static field in class org.jgroups.protocols.ring.TokenLostException
Whiteboard - class org.jgroups.demos.wb.Whiteboard
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_SOCK - static field in class org.jgroups.protocols.FD_SOCK.FdHeader
width - field in class org.jgroups.demos.wb.Node
windowActivated(WindowEvent) - method in class org.jgroups.demos.Chat
windowActivated(WindowEvent) - method in class org.jgroups.demos.DistributedHashtableDemo
windowActivated(WindowEvent) - method in class org.jgroups.demos.DistributedQueueDemo
windowActivated(WindowEvent) - method in class org.jgroups.demos.DistributedTreeDemo
windowActivated(WindowEvent) - method in class org.jgroups.demos.DrawRepl
windowActivated(WindowEvent) - method in class org.jgroups.demos.Gossip
windowActivated(WindowEvent) - method in class org.jgroups.demos.QuoteClient
windowActivated(WindowEvent) - method in class org.jgroups.demos.Topology
windowClosed(WindowEvent) - method in class org.jgroups.demos.Chat
windowClosed(WindowEvent) - method in class org.jgroups.demos.DistributedHashtableDemo
windowClosed(WindowEvent) - method in class org.jgroups.demos.DistributedQueueDemo
windowClosed(WindowEvent) - method in class org.jgroups.demos.DistributedTreeDemo
windowClosed(WindowEvent) - method in class org.jgroups.demos.DrawRepl
windowClosed(WindowEvent) - method in class org.jgroups.demos.Gossip
windowClosed(WindowEvent) - method in class org.jgroups.demos.QuoteClient
windowClosed(WindowEvent) - method in class org.jgroups.demos.Topology
windowClosing(WindowEvent) - method in class org.jgroups.demos.Chat
windowClosing(WindowEvent) - method in class org.jgroups.demos.DistributedHashtableDemo
windowClosing(WindowEvent) - method in class org.jgroups.demos.DistributedQueueDemo
windowClosing(WindowEvent) - method in class org.jgroups.demos.DistributedTreeDemo
windowClosing(WindowEvent) - method in class org.jgroups.demos.DrawRepl
windowClosing(WindowEvent) - method in class org.jgroups.demos.Gossip
windowClosing(WindowEvent) - method in class org.jgroups.demos.QuoteClient
windowClosing(WindowEvent) - method in class org.jgroups.demos.Topology
windowDeactivated(WindowEvent) - method in class org.jgroups.demos.Chat
windowDeactivated(WindowEvent) - method in class org.jgroups.demos.DistributedHashtableDemo
windowDeactivated(WindowEvent) - method in class org.jgroups.demos.DistributedQueueDemo
windowDeactivated(WindowEvent) - method in class org.jgroups.demos.DistributedTreeDemo
windowDeactivated(WindowEvent) - method in class org.jgroups.demos.DrawRepl
windowDeactivated(WindowEvent) - method in class org.jgroups.demos.Gossip
windowDeactivated(WindowEvent) - method in class org.jgroups.demos.QuoteClient
windowDeactivated(WindowEvent) - method in class org.jgroups.demos.Topology
windowDeiconified(WindowEvent) - method in class org.jgroups.demos.Chat
windowDeiconified(WindowEvent) - method in class org.jgroups.demos.DistributedHashtableDemo
windowDeiconified(WindowEvent) - method in class org.jgroups.demos.DistributedQueueDemo
windowDeiconified(WindowEvent) - method in class org.jgroups.demos.DistributedTreeDemo
windowDeiconified(WindowEvent) - method in class org.jgroups.demos.DrawRepl
windowDeiconified(WindowEvent) - method in class org.jgroups.demos.Gossip
windowDeiconified(WindowEvent) - method in class org.jgroups.demos.QuoteClient
windowDeiconified(WindowEvent) - method in class org.jgroups.demos.Topology
windowIconified(WindowEvent) - method in class org.jgroups.demos.Chat
windowIconified(WindowEvent) - method in class org.jgroups.demos.DistributedHashtableDemo
windowIconified(WindowEvent) - method in class org.jgroups.demos.DistributedQueueDemo
windowIconified(WindowEvent) - method in class org.jgroups.demos.DistributedTreeDemo
windowIconified(WindowEvent) - method in class org.jgroups.demos.DrawRepl
windowIconified(WindowEvent) - method in class org.jgroups.demos.Gossip
windowIconified(WindowEvent) - method in class org.jgroups.demos.QuoteClient
windowIconified(WindowEvent) - method in class org.jgroups.demos.Topology
windowOpened(WindowEvent) - method in class org.jgroups.demos.Chat
windowOpened(WindowEvent) - method in class org.jgroups.demos.DistributedHashtableDemo
windowOpened(WindowEvent) - method in class org.jgroups.demos.DistributedQueueDemo
windowOpened(WindowEvent) - method in class org.jgroups.demos.DistributedTreeDemo
windowOpened(WindowEvent) - method in class org.jgroups.demos.DrawRepl
windowOpened(WindowEvent) - method in class org.jgroups.demos.Gossip
windowOpened(WindowEvent) - method in class org.jgroups.demos.QuoteClient
windowOpened(WindowEvent) - method in class org.jgroups.demos.Topology
wouldBeNewCoordinator(org.jgroups.Address) - method in class org.jgroups.protocols.pbcast.GMS
Checks whether the potential_new_coord would be the new coordinator (2nd in line)
WRAPPED_MSG - static field in class org.jgroups.protocols.NakAckHeader
write(Externalizable,ObjectOutput) - static method in class org.jgroups.util.Marshaller
Writes an object to the ObjectOutput stream.
write(OutputStream,byte[],long) - method in class org.jgroups.util.TimedWriter
Writes data to an output stream.
write(OutputStream,int,long) - method in class org.jgroups.util.TimedWriter
writeAddress(org.jgroups.Address,DataOutputStream) - static method in class org.jgroups.util.Util
writeAddresses(Collection,DataOutputStream) - static method in class org.jgroups.util.Util
Writes a Vector of Addresses.
writeByteBuffer(byte[],DataOutputStream) - static method in class org.jgroups.util.Util
writeExternal(java.io.ObjectOutput) - method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
writeExternal(java.io.ObjectOutput) - method in class org.jgroups.protocols.ENCRYPT1_4.EncryptHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.BSH.BshHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.CAUSAL.CausalHeader
Manual serialization
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.COMPRESS.CompressHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.pbcast.Digest
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.FC.FcHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.FD.FdHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.FD_PID.FdHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.FD_PROB.FdHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.FD_SIMPLE.FdHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.FD_SOCK.FdHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.FragHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
writeExternal(ObjectOutput) - method in class org.jgroups.stack.GossipData
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.HTOTAL.HTotalHeader
writeExternal(ObjectOutput) - method in class org.jgroups.stack.IpAddress
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.JMS.JMSAddress
Write the object to external output.
writeExternal(ObjectOutput) - method in class org.jgroups.util.List
writeExternal(ObjectOutput) - method in class org.jgroups.stack.LogicalAddress
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.MERGE.MergeHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.MERGE3.CoordAnnouncement
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.pbcast.MergeData
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.MERGEFAST.MergefastHeader
writeExternal(ObjectOutput) - method in class org.jgroups.MergeView
writeExternal(ObjectOutput) - method in class org.jgroups.Message
writeExternal(ObjectOutput) - method in class org.jgroups.blocks.MethodCall
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.NakAckHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.pbcast.NakAckHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.PARTITIONER.PartitionerHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.pbcast.PbcastHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.PerfHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.PIGGYBACK.PiggybackHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.PingHeader
writeExternal(ObjectOutput) - method in class org.jgroups.blocks.PullPushAdapter.PullHeader
writeExternal(ObjectOutput) - method in class org.jgroups.util.Range
writeExternal(ObjectOutput) - method in class org.jgroups.blocks.ReplicationData
writeExternal(ObjectOutput) - method in class org.jgroups.blocks.RequestCorrelator.Header
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.ring.RingToken
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.SMACK.SmackHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.pbcast.STABLE.StableHeader
writeExternal(ObjectOutput) - method in class org.jgroups.util.Stack
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.TcpHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.TOTAL.Header
Manual serialization
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.TOTAL_OLD.TotalHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.TOTAL_TOKEN.RingTokenHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.TOTAL_TOKEN.TotalTokenHeader
Manual serialization
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.TpHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.TunnelHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.UdpHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.UNICAST.UnicastHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
writeExternal(ObjectOutput) - method in class org.jgroups.View
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
writeExternal(ObjectOutput) - method in class org.jgroups.ViewId
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.WANPIPE.WanPipeHeader
writeExternal(ObjectOutput) - method in class org.jgroups.protocols.WanPipeAddress
writeExternal(ObjectOutput) - method in class org.jgroups.blocks.Xid
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.
writeLock() - method in class org.jgroups.util.NullReadWriteLock
writeObject(Object,DataOutputStream) - static method in class org.jgroups.util.Util
writeString(String,DataOutputStream) - static method in class org.jgroups.util.Util
writeTo(DataOutputStream) - method in class org.jgroups.protocols.COMPRESS.CompressHeader
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.protocols.pbcast.Digest
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.protocols.FC.FcHeader
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.protocols.FD.FdHeader
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.protocols.FD_SOCK.FdHeader
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.protocols.FragHeader
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.protocols.HTOTAL.HTotalHeader
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.stack.IpAddress
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.protocols.JMS.JMSAddress
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.protocols.pbcast.JoinRsp
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.stack.LogicalAddress
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.MergeView
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.Message
Streams all members (dest and src addresses, buffer and headers) to the output stream.
writeTo(DataOutputStream) - method in class org.jgroups.protocols.pbcast.NakAckHeader
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.protocols.PingHeader
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.protocols.PingRsp
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.util.Range
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.blocks.RequestCorrelator.Header
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.protocols.pbcast.STABLE.StableHeader
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.util.Streamable
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.protocols.TcpHeader
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.protocols.TpHeader
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.protocols.UdpHeader
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.protocols.UNICAST.UnicastHeader
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.View
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.ViewId
Write the entire state of the current object (including superclasses) to outstream.
writeTo(DataOutputStream) - method in class org.jgroups.protocols.WanPipeAddress
Write the entire state of the current object (including superclasses) to outstream.
wrongMethod(String) - method in class org.jgroups.protocols.GmsImpl
wrongMethod(String) - method in class org.jgroups.protocols.pbcast.GmsImpl

X

x - field in class org.jgroups.demos.wb.Node
Xid - class org.jgroups.blocks.Xid
Distributed transaction ID modeled after the JTA spec.
XID - static field in class org.jgroups.blocks.Xid
Xid() - constructor for class org.jgroups.blocks.Xid
xloc - field in class org.jgroups.demos.wb.Node
XMIT_REQ - static field in class org.jgroups.protocols.pbcast.NakAckHeader
XMIT_REQ - static field in class org.jgroups.protocols.pbcast.PbcastHeader
XMIT_RSP - static field in class org.jgroups.protocols.pbcast.NakAckHeader
XMIT_RSP - static field in class org.jgroups.protocols.pbcast.PbcastHeader
XmlConfigurator - class org.jgroups.conf.XmlConfigurator
Uses XML to configure a protocol stack
XmlConfigurator(String) - constructor for class org.jgroups.conf.XmlConfigurator
XmlValidator - class org.jgroups.conf.XmlValidator
XmlValidator(String,String) - constructor for class org.jgroups.conf.XmlValidator
XmlValidator(String,String,boolean) - constructor for class org.jgroups.conf.XmlValidator

Y

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

Copyright B) 1998-2005 Bela Ban. All Rights Reserved.