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

A

abort(Object) - Method in class org.jgroups.blocks.DistributedLockManager
Abort phase for the lock acquisition or release.
abort() - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
 
abort(Object) - Method in interface org.jgroups.blocks.TwoPhaseVotingListener
This is unconditional abort of the previous voting on the decree.
ABORT_FLUSH - Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
 
ABOVE - Static variable in class org.jgroups.stack.ProtocolStack
 
ACK - Static variable in class org.jgroups.protocols.SMACK.SmackHeader
 
ACK - Static variable in class org.jgroups.protocols.UNICAST.UnicastHeader
 
ack(long, Address) - Method in class org.jgroups.stack.AckMcastSenderWindow
An ACK has been received from sender.
ack(long) - Method in class org.jgroups.stack.AckSenderWindow
Removes the message from msgs, removing them also from retransmission.
ack(Object) - Method in class org.jgroups.util.AckCollector
 
AckCollector - Class in org.jgroups.util
 
AckCollector() - Constructor for class org.jgroups.util.AckCollector
 
AckCollector(ViewId, List) - Constructor for class org.jgroups.util.AckCollector
 
AckMcastReceiverWindow - Class in org.jgroups.stack
Keeps track of messages received from various senders.
AckMcastReceiverWindow() - Constructor for class org.jgroups.stack.AckMcastReceiverWindow
 
AckMcastSenderWindow - Class in org.jgroups.stack
Keeps track of ACKs from receivers for each message.
AckMcastSenderWindow(AckMcastSenderWindow.RetransmitCommand, long[], TimeScheduler) - Constructor for class org.jgroups.stack.AckMcastSenderWindow
Create and start the retransmitter
AckMcastSenderWindow(AckMcastSenderWindow.RetransmitCommand, TimeScheduler) - Constructor for class org.jgroups.stack.AckMcastSenderWindow
Create and start the retransmitter
AckMcastSenderWindow(AckMcastSenderWindow.RetransmitCommand, long[]) - Constructor for class org.jgroups.stack.AckMcastSenderWindow
Create and start the retransmitter
AckMcastSenderWindow(AckMcastSenderWindow.RetransmitCommand) - Constructor for class org.jgroups.stack.AckMcastSenderWindow
Create and start the retransmitter
AckMcastSenderWindow.RetransmitCommand - Interface in org.jgroups.stack
Called by retransmitter thread whenever a message needs to be re-sent to a destination.
AckReceiverWindow - Class in org.jgroups.stack
Counterpart of AckSenderWindow.
AckReceiverWindow(long) - Constructor for class org.jgroups.stack.AckReceiverWindow
 
AckSenderWindow - Class in org.jgroups.stack
ACK-based sliding window for a sender.
AckSenderWindow(AckSenderWindow.RetransmitCommand) - Constructor for class org.jgroups.stack.AckSenderWindow
Creates a new instance.
AckSenderWindow(AckSenderWindow.RetransmitCommand, long[]) - Constructor for class org.jgroups.stack.AckSenderWindow
 
AckSenderWindow(AckSenderWindow.RetransmitCommand, long[], TimeScheduler) - Constructor for class org.jgroups.stack.AckSenderWindow
 
AckSenderWindow(AckSenderWindow.RetransmitCommand, long[], TimeScheduler, Address) - Constructor for class org.jgroups.stack.AckSenderWindow
 
AckSenderWindow.RetransmitCommand - Interface in org.jgroups.stack
 
acquire() - Method in class org.jgroups.util.NullSync
 
acquire(Sync) - Static method in class org.jgroups.util.Util
Attempts to acquire the given Sync, suppressing any InterruptedException.
actionPerformed(ActionEvent) - Method in class org.jgroups.demos.applets.DrawApplet
 
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.DrawRepl
 
actionPerformed(ActionEvent) - Method in class org.jgroups.demos.Gossip
 
actionPerformed(ActionEvent) - Method in class org.jgroups.demos.QuoteClient
 
actionPerformed(ActionEvent) - Method in class org.jgroups.demos.wb.MessageDialog
 
actionPerformed(ActionEvent) - Method in class org.jgroups.demos.wb.SendDialog
 
actionPerformed(ActionEvent) - Method in class org.jgroups.demos.wb.UserInfoDialog
 
actionPerformed(ActionEvent) - Method in class org.jgroups.demos.wb.Whiteboard
 
activeThreads() - Static method in class org.jgroups.util.Util
 
adapter - Variable in class org.jgroups.blocks.MessageDispatcher
 
add(Object) - Method in class org.jgroups.blocks.DistributedQueue
Add the speficied element at the bottom of the queue
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
 
add(ProtocolData) - Method in class org.jgroups.conf.XmlConfigurator
 
add(Address) - Method in class org.jgroups.Membership
Adds a new member to this membership.
add(Collection) - Method in class org.jgroups.Membership
Adds a list of members to this membership
add(Address, long, long) - Method in class org.jgroups.protocols.pbcast.Digest
 
add(Address, long, long, long) - Method in class org.jgroups.protocols.pbcast.Digest
 
add(Digest) - Method in class org.jgroups.protocols.pbcast.Digest
 
add(Object, long) - Method in class org.jgroups.stack.AckMcastReceiverWindow
Records the sender/seqno pair in the message table
add(long, Message, Vector) - Method in class org.jgroups.stack.AckMcastSenderWindow
Adds a new message to the hash table.
add(long, Message) - Method in class org.jgroups.stack.AckReceiverWindow
Adds a new message.
add(long, Message) - Method in class org.jgroups.stack.AckSenderWindow
Adds a new message to the retransmission table.
add(long, Message) - Method in class org.jgroups.stack.NakReceiverWindow
Adds a message according to its sequence number (ordered).
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(Object) - Method in class org.jgroups.util.BoundedList
Adds an element at the tail.
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(Runnable) - Method in class org.jgroups.util.Scheduler
 
add(TimeScheduler.Task, boolean) - Method in class org.jgroups.util.TimeScheduler
Add a task for execution at adjustable intervals
add(TimeScheduler.Task) - Method in class org.jgroups.util.TimeScheduler
Add a task for execution at adjustable intervals
add(Object) - Method in class org.jgroups.util.UnmodifiableVector
 
add(int, Object) - Method in class org.jgroups.util.UnmodifiableVector
 
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.List
 
addAll(Collection) - Method in class org.jgroups.util.Queue
 
addAll(List) - Method in class org.jgroups.util.Queue
 
addAll(Collection) - Method in class org.jgroups.util.UnmodifiableVector
 
addAll(int, Collection) - Method in class org.jgroups.util.UnmodifiableVector
 
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.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.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
 
addChannelListener(ChannelListener) - Method in class org.jgroups.blocks.RpcDispatcher
Add a new channel listener to be notified on the channel's state change.
addChannelListener(ChannelListener) - Method in class org.jgroups.Channel
Allows to be notified when a channel event such as connect, disconnect or close occurs.
addChannelListener(ChannelListener) - Method in class org.jgroups.jmx.JChannel
 
addConnectionListener(BasicConnectionTable.ConnectionListener) - Method in class org.jgroups.blocks.BasicConnectionTable
 
addDistributedTreeListener(DistributedTree.DistributedTreeListener) - Method in class org.jgroups.blocks.DistributedTree
 
addElement(Object) - Method in class org.jgroups.util.UnmodifiableVector
 
addEntry(String) - Method in class org.jgroups.protocols.PerfHeader
Adds a new entry to both hashtables
addGossipRouter(IpAddress) - Method in class org.jgroups.stack.GossipClient
Adds a GossipRouter to be accessed.
addingToDownVector(Event, int) - Method in interface org.jgroups.protocols.QUEUE.Observer
Called before event is added.
addingToUpVector(Event, int) - Method in interface org.jgroups.protocols.QUEUE.Observer
Called before event is added.
additionalChannelListeners - Variable 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
 
addListener(TwoPhaseVotingListener) - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter
Wraps actual listener with the VoteChannelListener and adds to the voteChannel
addMember(Address) - Method in class org.jgroups.debug.Simulator
 
addMember(Address, Simulator) - Method in class org.jgroups.debug.Simulator
 
addMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.MembershipListenerAdapter
Add membership listener to this adapter.
addMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.PullPushAdapter
 
addMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.VotingAdapter
 
addMessageListener(MessageListener) - Method in class org.jgroups.blocks.MessageListenerAdapter
Add message listener to this adapter.
addNode(Object) - Method in class org.jgroups.demos.Topology
 
addNode(String, Address, int, int) - Method in class org.jgroups.demos.wb.GraphPanel
 
addNode(String, Address, int, int) - Method in class org.jgroups.demos.wb.Whiteboard
 
addNotifier(DistributedHashtable.Notification) - Method in class org.jgroups.blocks.DistributedHashtable
 
addNotifier(DistributedQueue.Notification) - Method in class org.jgroups.blocks.DistributedQueue
 
addNotifier(ReplicatedHashtable.Notification) - Method in class org.jgroups.blocks.ReplicatedHashtable
 
addNotReceived(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 - Variable in class org.jgroups.demos.wb.Node
 
addRecoveredMember(Address) - Method in class org.jgroups.protocols.ring.RingToken
 
addReplicatedTreeListener(ReplicatedTree.ReplicatedTreeListener) - Method in class org.jgroups.blocks.ReplicatedTree
 
addResponse(PingRsp) - Method in class org.jgroups.protocols.PingWaiter
 
Address - Interface in org.jgroups
Abstract address.
addRsp(Address, Object) - Method in class org.jgroups.util.RspList
 
addServiceIfNotPresent(String, MuxChannel) - Method in class org.jgroups.mux.Multiplexer
 
addStateTransferListener(ReplicatedHashtable.StateTransferListener) - Method in class org.jgroups.blocks.ReplicatedHashtable
 
addSuspect(Address) - Method in class org.jgroups.util.RspList
 
addSuspectedMember(Address) - Method in class org.jgroups.protocols.FD.Broadcaster
Adds a suspected member.
addSuspectedMember(Address) - Method in class org.jgroups.protocols.FD.BroadcastTask
 
addToSeenList(Address) - Method in class org.jgroups.protocols.pbcast.Gossip
 
addViewListener(DistributedTree.ViewListener) - Method in class org.jgroups.blocks.DistributedTree
 
addVote(boolean) - Method in class org.jgroups.blocks.VotingAdapter.VoteResult
 
addVoteListener(VotingListener) - Method in class org.jgroups.blocks.VotingAdapter
Adds voting listener.
adjustNodes(Vector) - Method in class org.jgroups.demos.wb.GraphPanel
 
all(Collection, Object) - Static method in class org.jgroups.util.Util
Returns true if all elements of c match obj
arg - Variable in class org.jgroups.protocols.PingHeader
 
args - Variable in class org.jgroups.blocks.MethodCall
The arguments of the method.
array2String(long[]) - Static method in class org.jgroups.util.Util
 
array2String(int[]) - Static method in class org.jgroups.util.Util
 
array2String(boolean[]) - Static method in class org.jgroups.util.Util
 
array2String(Object[]) - Static method in class org.jgroups.util.Util
 
assignTask(Runnable) - Method in class org.jgroups.util.ReusableThread
Assigns a task to the thread.
assignThreadLocalListener(ThreadLocalListener) - Method in class org.jgroups.util.ReusableThread
Assigns a ThreadLocalListener to the current ReusableThread.
attachProtocol(Protocol) - Method in class org.jgroups.jmx.Protocol
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.Discovery
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.FC
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.FD
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.FD_SOCK
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.FRAG
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.FRAG2
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.MERGE2
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.MPING
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.pbcast.FLUSH
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.pbcast.GMS
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.pbcast.STABLE
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.pbcast.STATE_TRANSFER
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.pbcast.STREAMING_STATE_TRANSFER
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.PING
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.SEQUENCER
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.STATS
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.TCP
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.TCP_NIO
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.TCPGOSSIP
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.TCPPING
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.TP
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.UDP
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.UNICAST
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.VIEW_SYNC
 
attempt(long) - Method in class org.jgroups.util.NullSync
 
ATTR_INHERIT - Static variable in class org.jgroups.conf.XmlConfigurator
 
ATTR_NAME - Static variable in class org.jgroups.conf.XmlConfigurator
 
ATTR_VALUE - Static variable in class org.jgroups.conf.XmlConfigurator
 
AUTH - Class in org.jgroups.protocols
The AUTH protocol adds a layer of authentication to JGroups
AUTH() - Constructor for class org.jgroups.protocols.AUTH
 
authenticate(AuthToken, Message) - Method in class org.jgroups.auth.AuthToken
This method should be implemented to perform the actual authentication of joining members.
authenticate(AuthToken, Message) - Method in class org.jgroups.auth.FixedMembershipToken
 
authenticate(AuthToken, Message) - Method in class org.jgroups.auth.MD5Token
 
authenticate(AuthToken, Message) - Method in class org.jgroups.auth.SimpleToken
 
authenticate(AuthToken, Message) - Method in class org.jgroups.auth.X509Token1_5
 
AuthHeader - Class in org.jgroups.protocols
AuthHeader is a holder object for the token that is passed from the joiner to the coordinator
AuthHeader() - Constructor for class org.jgroups.protocols.AuthHeader
 
AuthToken - Class in org.jgroups.auth
Abstract AuthToken class used by implementations of AUTH, e.g.
AuthToken() - Constructor for class org.jgroups.auth.AuthToken
 
AUTO_GETSTATE - Static variable in class org.jgroups.Channel
 
AUTO_RECONNECT - Static variable in class org.jgroups.Channel
 
AUTOCONF - Class in org.jgroups.protocols
Senses the network configuration when it is initialized (in init()) and sends a CONFIG event up and down the stack.
AUTOCONF() - Constructor for class org.jgroups.protocols.AUTOCONF
 
available() - Method in class org.jgroups.util.ReusableThread
 

B

bar(int, int) - Method in class org.jgroups.protocols.RpcProtocolEXAMPLE
 
BasicConnectionTable - Class in org.jgroups.blocks
Shared class for TCP connection tables.
BasicConnectionTable() - Constructor for class org.jgroups.blocks.BasicConnectionTable
 
BasicConnectionTable.ConnectionListener - Interface in org.jgroups.blocks
Used to be notified about connection establishment and teardown.
BasicConnectionTable.Receiver - Interface in org.jgroups.blocks
Used for message reception.
BasicTCP - Class in org.jgroups.protocols
Shared base class for tcpip protocols
BasicTCP() - Constructor for class org.jgroups.protocols.BasicTCP
 
BCAST - Static variable in class org.jgroups.protocols.TOTAL.Header
Broadcast Message
bcast_task - Variable in class org.jgroups.protocols.FD
Transmits SUSPECT message until view change or UNSUSPECT is received
BECOME_SERVER - Static variable in class org.jgroups.Event
 
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 variable in class org.jgroups.stack.ProtocolStack
 
BIND_ADDR - Static variable in class org.jgroups.Global
 
bind_addr - Variable in class org.jgroups.protocols.TP
The interface (NIC) which should be used by this transport
BIND_ADDR_OLD - Static variable in class org.jgroups.Global
 
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.DistributedLockManager
 
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.blocks.MembershipListenerAdapter
Notify membership listeners to temporarily stop sending messages into a channel.
block() - Method in class org.jgroups.blocks.NotificationBus
 
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.blocks.VotingAdapter
Blocks the channel until the ViewAccepted is invoked.
BLOCK - Static variable in class org.jgroups.Channel
 
block() - Method in class org.jgroups.demos.Chat
 
block() - Method in class org.jgroups.demos.Draw
 
block() - Method in class org.jgroups.demos.QuoteClient
 
block() - Method in class org.jgroups.demos.QuoteServer
 
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.demos.wb.Whiteboard
 
BLOCK - Static variable in class org.jgroups.Event
 
block() - Method in class org.jgroups.ExtendedReceiverAdapter
 
block() - Method in interface org.jgroups.MembershipListener
Called (usually by the FLUSH protocol), as an indication that the member should stop sending messages.
block() - Method in class org.jgroups.ReceiverAdapter
 
BLOCK_OK - Static variable in class org.jgroups.Event
 
BlockEvent - Class in org.jgroups
Trivial object that represents a block event.
BlockEvent() - Constructor for class org.jgroups.BlockEvent
 
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 interface org.jgroups.jmx.JChannelMBean
 
blockOk() - Method in class org.jgroups.mux.Multiplexer
Called by a MuxChannel when BLOCK_OK is sent down
bottom() - Method in class org.jgroups.util.Stack
 
BoundedList - Class in org.jgroups.util
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 in org.jgroups.protocols
Beanshell (www.beanshell.org) interpreter class.
BSH() - Constructor for class org.jgroups.protocols.BSH
 
BSH.BshHeader - Class in org.jgroups.protocols
&nbs