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

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
 
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
 
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.
AUTOCONF() - Constructor for class org.jgroups.protocols.AUTOCONF
 
AUTO_GETSTATE - Static variable in class org.jgroups.Channel
 
AUTO_RECONNECT - Static variable in class org.jgroups.Channel
 
AckCollector - class org.jgroups.util.AckCollector.
 
AckCollector() - Constructor for class org.jgroups.util.AckCollector
 
AckCollector(ViewId, List) - Constructor for class org.jgroups.util.AckCollector
 
AckMcastReceiverWindow - class org.jgroups.stack.AckMcastReceiverWindow.
Keeps track of messages received from various senders.
AckMcastReceiverWindow() - Constructor for class org.jgroups.stack.AckMcastReceiverWindow
 
AckMcastSenderWindow - class org.jgroups.stack.AckMcastSenderWindow.
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 org.jgroups.stack.AckMcastSenderWindow.RetransmitCommand.
Called by retransmitter thread whenever a message needs to be re-sent to a destination.
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.
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.RetransmitCommand - interface org.jgroups.stack.AckSenderWindow.RetransmitCommand.
 
Address - interface org.jgroups.Address.
Abstract address.
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.
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
 
acquire() - Method in class org.jgroups.util.NullSync
 
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.applets.DrawApplet
 
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(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(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, 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
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(List) - Method in class org.jgroups.util.Queue
 
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.Channel
Allows to be notified when a channel event such as connect, disconnect or close occurs.
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.jmx.JChannel
 
addConnectionListener(ConnectionTable.ConnectionListener) - Method in class org.jgroups.blocks.ConnectionTable
 
addDistributedTreeListener(DistributedTree.DistributedTreeListener) - Method in class org.jgroups.blocks.DistributedTree
 
addEntry(String) - Method in class org.jgroups.protocols.PerfHeader
Adds a new entry to both hashtables
addGossipServer(IpAddress) - Method in class org.jgroups.stack.GossipClient
Adds a GossipServer to be accessed.
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
 
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
 
addNotReceived(Address) - Method in class org.jgroups.util.RspList
 
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
 
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
 
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
 
addRsp(Address, Object) - Method in class org.jgroups.util.RspList
 
addStateTransferListener(ReplicatedHashtable.StateTransferListener) - Method in class org.jgroups.blocks.ReplicatedHashtable
 
addSuspect(Address) - Method in class org.jgroups.util.RspList
 
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.
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
 
addr - Variable in class org.jgroups.demos.wb.Node
 
adjustNodes(Vector) - Method in class org.jgroups.demos.wb.GraphPanel
 
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
 
assignTask(Runnable) - Method in class org.jgroups.util.ReusableThread
Assigns a task to the thread.
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.PING
 
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.TCPGOSSIP
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.TCPPING
 
attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.TCP_NIO
 
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
 
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
 
attempt(long) - Method in class org.jgroups.util.NullSync
 
available() - Method in class org.jgroups.util.ReusableThread
 

B

BCAST - Static variable in class org.jgroups.protocols.TOTAL.Header
Broadcast Message
BECOME_SERVER - Static variable in class org.jgroups.Event
 
BELOW - Static variable in class org.jgroups.stack.ProtocolStack
 
BLOCK - Static variable in class org.jgroups.Channel
 
BLOCK - Static variable in class org.jgroups.Event
 
BLOCK_OK - Static variable in class org.jgroups.Event
 
BLOCK_SEND - Static variable in class org.jgroups.Event
 
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.
 
BSH.BshHeader() - Constructor for class org.jgroups.protocols.BSH.BshHeader
 
BSH.BshHeader(int) - Constructor for class org.jgroups.protocols.BSH.BshHeader
 
BYTE_SIZE - Static variable in class org.jgroups.Global
Value is 1.
BlockEvent - class org.jgroups.BlockEvent.
Trivial object that represents a block event.
BlockEvent() - Constructor for class org.jgroups.BlockEvent
 
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
 
Buffer - class org.jgroups.util.Buffer.
Buffer with an offset and length.
Buffer(byte[], int, int) - Constructor for class org.jgroups.util.Buffer
 
bar(int, int) - Method in class org.jgroups.protocols.RpcProtocolEXAMPLE
 
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.
block() - Method in interface org.jgroups.MembershipListener
Called whenever the member needs to stop sending messages.
block() - Method in class org.jgroups.ReceiverAdapter
 
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.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() - Method in class org.jgroups.demos.Chat
 
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
 
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
 
bottom() - Method in class org.jgroups.util.Stack
 
byteBufferToMessageList(byte[], int, int) - Static method in class org.jgroups.util.Util
 

C

CANCEL_MERGE - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
CAUSAL - class org.jgroups.protocols.CAUSAL.
Implements casual ordering layer using vector clocks.
CAUSAL() - Constructor for class org.jgroups.protocols.CAUSAL
default constructor
CAUSAL.CausalHeader - class org.jgroups.protocols.CAUSAL.CausalHeader.
 
CAUSAL.CausalHeader() - Constructor for class org.jgroups.protocols.CAUSAL.CausalHeader
used for externalization
CAUSAL.CausalHeader(TransportedVectorTime) - Constructor for class org.jgroups.protocols.CAUSAL.CausalHeader
 
COMMIT - Static variable in class org.jgroups.blocks.ReplicationData
 
COMPRESS - class org.jgroups.protocols.COMPRESS.
Compresses the payload of a message.
COMPRESS() - Constructor for class org.jgroups.protocols.COMPRESS
 
COMPRESS.CompressHeader - class org.jgroups.protocols.COMPRESS.CompressHeader.
 
COMPRESS.CompressHeader() - Constructor for class org.jgroups.protocols.COMPRESS.CompressHeader
 
COMPRESS.CompressHeader(int) - Constructor for class org.jgroups.protocols.COMPRESS.CompressHeader
 
CONFIG - Static variable in class org.jgroups.Event
 
CONNECT - Static variable in class org.jgroups.Event
 
CONNECT_OK - Static variable in class org.jgroups.Event
 
CREDIT_REQUEST - Static variable in class org.jgroups.protocols.FC.FcHeader
 
CannotConnectException - exception 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 - exception org.jgroups.persistence.CannotCreateSchemaException.
 
CannotCreateSchemaException(Throwable, String) - Constructor for class org.jgroups.persistence.CannotCreateSchemaException
 
CannotPersistException - exception org.jgroups.persistence.CannotPersistException.
 
CannotPersistException(Throwable, String) - Constructor for class org.jgroups.persistence.CannotPersistException
 
CannotRemoveException - exception org.jgroups.persistence.CannotRemoveException.
 
CannotRemoveException(Throwable, String) - Constructor for class org.jgroups.persistence.CannotRemoveException
 
CannotRetrieveException - exception org.jgroups.persistence.CannotRetrieveException.
 
CannotRetrieveException(Throwable, String) - Constructor for class org.jgroups.persistence.CannotRetrieveException
 
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
 
Channel - class org.jgroups.Channel.
A channel represents a group communication endpoint (like BSD datagram sockets).
Channel() - Constructor for class org.jgroups.Channel
 
ChannelClosedException - exception org.jgroups.ChannelClosedException.
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
 
ChannelException - exception org.jgroups.ChannelException.
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.
ChannelNotConnectedException - exception org.jgroups.ChannelNotConnectedException.
Thrown if an operation is attemped on an unconnected channel.
ChannelNotConnectedException() - Constructor for class org.jgroups.ChannelNotConnectedException
 
ChannelNotConnectedException(String) - Constructor for class org.jgroups.ChannelNotConnectedException
 
Chat - class org.jgroups.demos.Chat.
Simple chat demo
Chat(String) - Constructor for class org.jgroups.demos.Chat
 
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 - class org.jgroups.conf.ClassPathEntityResolver.
 
ClassPathEntityResolver() - Constructor for class org.jgroups.conf.ClassPathEntityResolver
 
ClassPathEntityResolver(String) - Constructor for class org.jgroups.conf.ClassPathEntityResolver
 
ClientGmsImpl - class org.jgroups.protocols.ClientGmsImpl.
Client part of GMS.
ClientGmsImpl(GMS) - Constructor for class org.jgroups.protocols.ClientGmsImpl
 
ClientGmsImpl - class org.jgroups.protocols.pbcast.ClientGmsImpl.
Client part of GMS.
ClientGmsImpl(GMS) - Constructor for class org.jgroups.protocols.pbcast.ClientGmsImpl
 
Command - interface org.jgroups.util.Command.
The Command patttern (see Gamma et al.).
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
 
Configurator - class org.jgroups.stack.Configurator.
The task if this class is to setup and configure the protocol stack.
Configurator() - Constructor for class org.jgroups.stack.Configurator
 
Configurator.ProtocolConfiguration - class org.jgroups.stack.Configurator.ProtocolConfiguration.
Parses and encapsulates the specification for 1 protocol of the protocol stack, e.g.
Configurator.ProtocolConfiguration(String) - Constructor for class org.jgroups.stack.Configurator.ProtocolConfiguration
Creates a new ProtocolConfiguration.
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
 
ConnectionTable - class org.jgroups.blocks.ConnectionTable.
Manages incoming and outgoing TCP connections.
ConnectionTable(int) - Constructor for class org.jgroups.blocks.ConnectionTable
Regular ConnectionTable without expiration of idle connections
ConnectionTable(InetAddress, int) - Constructor for class org.jgroups.blocks.ConnectionTable
 
ConnectionTable(int, long, long) - Constructor for class org.jgroups.blocks.ConnectionTable
ConnectionTable including a connection reaper.
ConnectionTable(ConnectionTable.Receiver, InetAddress, InetAddress, int, int) - Constructor for class org.jgroups.blocks.ConnectionTable
Create a ConnectionTable
ConnectionTable(ConnectionTable.Receiver, InetAddress, InetAddress, int, int, long, long) - Constructor for class org.jgroups.blocks.ConnectionTable
ConnectionTable including a connection reaper.
ConnectionTable.ConnectionListener - interface org.jgroups.blocks.ConnectionTable.ConnectionListener.
Used to be notified about connection establishment and teardown.
ConnectionTable.Receiver - interface org.jgroups.blocks.ConnectionTable.Receiver.
Used for message reception.
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
 
ConnectionTableNIO(ConnectionTable.Receiver, InetAddress, InetAddress, int, int) - Constructor for class org.jgroups.blocks.ConnectionTableNIO
 
ConnectionTableNIO(ConnectionTable.Receiver, InetAddress, InetAddress, int, int, long, long) - Constructor for class org.jgroups.blocks.ConnectionTableNIO
 
ConnectionTableNIO.SelectorWriteHandler - class org.jgroups.blocks.ConnectionTableNIO.SelectorWriteHandler.
 
ConnectionTableNIO.WriteRequest - class org.jgroups.blocks.ConnectionTableNIO.WriteRequest.
 
ContextObjectInputStream - class org.jgroups.util.ContextObjectInputStream.
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
CoordGmsImpl - class org.jgroups.protocols.CoordGmsImpl.
 
CoordGmsImpl(GMS) - Constructor for class org.jgroups.protocols.CoordGmsImpl
 
CoordGmsImpl - class org.jgroups.protocols.pbcast.CoordGmsImpl.
Coordinator role of the Group MemberShip (GMS) protocol.
CoordGmsImpl(GMS) - Constructor for class org.jgroups.protocols.pbcast.CoordGmsImpl
 
callRemoteMethod(Address, String, Object[], Class[], int, long) - Method in class org.jgroups.blocks.RpcDispatcher
 
callRemoteMethod(Address, String, Object[], String[], int, long) - Method in class org.jgroups.blocks.RpcDispatcher
 
callRemoteMethod(Address, MethodCall, int, long) - Method in class org.jgroups.blocks.RpcDispatcher
 
callRemoteMethod(Address, String, int, long) - Method in class org.jgroups.stack.RpcProtocol
 
callRemoteMethod(Address, String, Object[], Class[], int, long) - Method in class org.jgroups.stack.RpcProtocol
 
callRemoteMethod(Address, String, Object[], String[], int, long) - Method in class org.jgroups.stack.RpcProtocol
 
callRemoteMethod(Address, MethodCall, int, long) - Method in class org.jgroups.stack.RpcProtocol
 
callRemoteMethods(Vector, String, Object[], Class[], int, long) - Method in class org.jgroups.blocks.RpcDispatcher
 
callRemoteMethods(Vector, String, Object[], String[], int, long) - Method in class org.jgroups.blocks.RpcDispatcher
 
callRemoteMethods(Vector, MethodCall, int, long) - Method in class org.jgroups.blocks.RpcDispatcher
 
callRemoteMethods(Vector, String, Object[], Class[], int, long) - Method in class org.jgroups.stack.RpcProtocol
 
callRemoteMethods(Vector, String, Object[], String[], int, long) - Method in class org.jgroups.stack.RpcProtocol
 
callRemoteMethods(Vector, MethodCall, int, long) - Method in class org.jgroups.stack.RpcProtocol
 
callStack - Variable in class org.jgroups.blocks.RequestCorrelator.Header
Stack
.
call_stack - Variable in class org.jgroups.blocks.RequestCorrelator
This field is used only if deadlock detection is enabled.
cancel() - Method in interface org.jgroups.util.TimeScheduler.CancellableTask
Cancels the task.
cancelled() - Method in interface org.jgroups.util.TimeScheduler.Task
 
castMessage(Vector, Message, int, long) - Method in class org.jgroups.blocks.MessageDispatcher
Cast a message to all members, and wait for mode responses.
castMessage(Vector, long, Message, RspCollector) - Method in class org.jgroups.blocks.MessageDispatcher
Multicast a message request to all members in dests and receive responses via the RspCollector interface.
castMessage(Vector, Message, int, long) - Method in class org.jgroups.blocks.RpcDispatcher
 
castMessage(Vector, Message, int, long) - Method in class org.jgroups.stack.MessageProtocol
Cast a message to all members, and wait for mode responses.
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.
castViewChange(View, Digest) - Method in class org.jgroups.protocols.pbcast.GMS
 
castViewChangeWithDest(View, Digest, List) - Method in class org.jgroups.protocols.pbcast.GMS
Broadcasts the new view and digest, and waits for acks from all members in the list given as argument.
cause - Variable in class org.jgroups.protocols.ring.TokenLostException
 
channel - Variable in class org.jgroups.blocks.DistributedQueue
 
channel - Variable in class org.jgroups.blocks.DistributedTree
 
channel - Variable in class org.jgroups.blocks.MessageDispatcher
 
channelClosed(Channel) - Method in interface org.jgroups.ChannelListener
 
channelClosed(Channel) - Method in class org.jgroups.blocks.PullPushAdapter
 
channelClosed(Channel) - Method in class org.jgroups.blocks.RpcDispatcher
 
channelClosed(Channel) - Method in class org.jgroups.demos.Draw
 
channelClosed(Channel) - Method in class org.jgroups.demos.Gossip
 
channelConnected(Channel) - Method in interface org.jgroups.ChannelListener
 
channelConnected(Channel) - Method in class org.jgroups.blocks.PullPushAdapter
 
channelConnected(Channel) - Method in class org.jgroups.blocks.RpcDispatcher
 
channelConnected(Channel) - Method in class org.jgroups.demos.Draw
 
channelConnected(Channel) - Method in class org.jgroups.demos.Gossip
 
channelDisconnected(Channel) - Method in interface org.jgroups.ChannelListener
 
channelDisconnected(Channel) - Method in class org.jgroups.blocks.PullPushAdapter
 
channelDisconnected(Channel) - Method in class org.jgroups.blocks.RpcDispatcher
 
channelDisconnected(Channel) - Method in class org.jgroups.demos.Draw
 
channelDisconnected(Channel) - Method in class org.jgroups.demos.Gossip
 
channelReconnected(Address) - Method in interface org.jgroups.ChannelListener
 
channelReconnected(Address) - Method in class org.jgroups.blocks.PullPushAdapter
 
channelReconnected(Address) - Method in class org.jgroups.blocks.RpcDispatcher
 
channelReconnected(Address) - Method in class org.jgroups.demos.Draw
 
channelReconnected(Address) - Method in class org.jgroups.demos.Gossip
 
channelShunned() - Method in interface org.jgroups.ChannelListener
 
channelShunned() - Method in class org.jgroups.blocks.PullPushAdapter
 
channelShunned() - Method in class org.jgroups.blocks.RpcDispatcher
 
channelShunned() - Method in class org.jgroups.demos.Draw
 
channelShunned() - Method in class org.jgroups.demos.Gossip
 
channel_listener - Variable in class org.jgroups.Channel
 
channel_listeners - Variable in class org.jgroups.Channel
 
channel_name - Variable in class org.jgroups.protocols.TpHeader
 
channel_name - Variable in class org.jgroups.protocols.TunnelHeader
 
channel_name - Variable in class org.jgroups.protocols.UdpHeader
 
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
 
checkResult(RspList, Object) - Method in class org.jgroups.blocks.DistributedQueue
 
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
clear() - Method in class org.jgroups.Membership
removes all the members from this membership
clear() - Method in class org.jgroups.blocks.DistributedHashtable
Clears this hashtable so that it contains no keys
clear() - Method in class org.jgroups.blocks.ReplicatedHashtable
Clears this hashtable so that it contains no keys
clear() - Method in class org.jgroups.persistence.DBPersistenceManager
Clears the key-cache as well as all entries
clear() - Method in class org.jgroups.persistence.FilePersistenceManager
Clears the complete NV state from the DB
clear() - Method in interface org.jgroups.persistence.PersistenceManager
Clears the complete NV state from the DB
clear() - Method in class org.jgroups.protocols.pbcast.Digest
 
clear() - Method in class org.jgroups.util.Queue
Removes all elements from the queue.
clearPanel() - Method in class org.jgroups.demos.Draw
 
clearPanel() - Method in class org.jgroups.demos.Draw2Channels
 
clearPanel() - Method in class org.jgroups.demos.DrawRepl
 
clearPanel() - Method in class org.jgroups.demos.Gossip
 
clearPanel() - Method in class org.jgroups.demos.applets.DrawApplet
 
clearResponses() - Method in class org.jgroups.protocols.PingWaiter
 
clearStableMessages() - Method in class org.jgroups.stack.AckMcastSenderWindow
 
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.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
clone() - Method in class org.jgroups.blocks.ReplicatedTree.Node
 
clone() - Method in class org.jgroups.protocols.JMS.JMSAddress
Clone the object.
clone() - Method in class org.jgroups.stack.IpAddress
 
clone() - Method in class org.jgroups.stack.LogicalAddress
 
clone() - Method in class org.jgroups.util.List
 
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 interface 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.
closeInputStream(InputStream) - Static method in class org.jgroups.util.Util
 
closeOutputStream(OutputStream) - Static method in class org.jgroups.util.Util
 
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.
closer - Variable 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
 
commit() - Method in class org.jgroups.blocks.DistributedLockManager.LockDecree
 
commit(Object) - Method in class org.jgroups.blocks.DistributedLockManager
Commit phase for the lock acquisition or release.
commit(Xid) - Method in class org.jgroups.blocks.ReplicationManager
Commits all modifications sent to the receivers via ReplicationManager.send(org.jgroups.Address, byte[], boolean, long, org.jgroups.blocks.Xid, byte[], long, long, boolean) and releases all locks associated with this transaction.
commit(Xid) - Method in interface org.jgroups.blocks.ReplicationReceiver
Commit the modifications to the locally replicated data and release all locks.
commit() - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
 
commit(Object) - Method in interface org.jgroups.blocks.TwoPhaseVotingListener
This is voting on the commiting the decree.
commited - Variable in class org.jgroups.blocks.DistributedLockManager.LockDecree
 
compare(Object) - Method in class org.jgroups.ViewId
Old Compare
compare(IpAddress) - Method in class org.jgroups.stack.IpAddress
Establishes an order between 2 addresses.
compare(LogicalAddress) - Method in class org.jgroups.stack.LogicalAddress
Establishes an order between 2 addresses.
compareTo(short) - Static method in class org.jgroups.Version
Compares the specified version number against the current version number.
compareTo(Object) - Method in class org.jgroups.ViewId
Establishes an order between 2 ViewIds.
compareTo(Object) - Method in class org.jgroups.blocks.Xid
 
compareTo(Object) - Method in class org.jgroups.protocols.JMS.JMSAddress
Compare this object to o.
compareTo(Object) - Method in class org.jgroups.protocols.WanPipeAddress
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.stack.LogicalAddress
implements the java.lang.Comparable interface
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
 
computeFragOffsets(int, int, int) - Static method in class org.jgroups.util.Util
Given a buffer and a fragmentation size, compute a list of fragmentation offset/length pairs, and return them in a list.
computeFragOffsets(byte[], int) - Static method in class org.jgroups.util.Util
 
concurrent_processing - Variable in class org.jgroups.blocks.MessageDispatcher
Process items on the queue concurrently (RequestCorrelator).
concurrent_processing - Variable in class org.jgroups.blocks.RequestCorrelator
Process items on the queue concurrently (Scheduler).
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() - Method in class org.jgroups.demos.TotalTokenDemo
 
connect(String) - Method in class org.jgroups.jmx.JChannel
 
connect(String) - Method in interface org.jgroups.jmx.JChannelMBean
 
connect() - Method in class org.jgroups.stack.RouterStub
Establishes a connection to the router.
connectionClosed(Address) - Method in interface org.jgroups.blocks.ConnectionTable.ConnectionListener
 
connectionOpened(Address) - Method in interface org.jgroups.blocks.ConnectionTable.ConnectionListener
 
contains(Address) - Method in class org.jgroups.Membership
Returns true if the provided member belongs to this membership
contains(Address) - Method in class org.jgroups.protocols.pbcast.Digest
 
contains(Object) - Method in class org.jgroups.util.List
 
containsMember(Address) - Method in class org.jgroups.View
returns true, if this view contains a certain member
contentsCleared() - Method in interface org.jgroups.blocks.DistributedHashtable.Notification
 
contentsCleared() - Method in interface org.jgroups.blocks.DistributedQueue.Notification
 
contentsCleared() - Method in class org.jgroups.demos.DistributedHashtableDemo
 
contentsCleared() - Method in class org.jgroups.demos.DistributedQueueDemo
 
contentsSet(Map) - Method in interface org.jgroups.blocks.DistributedHashtable.Notification
 
contentsSet(Collection) - Method in interface org.jgroups.blocks.DistributedQueue.Notification
 
contentsSet(Map) - Method in interface org.jgroups.blocks.ReplicatedHashtable.Notification
 
contentsSet(Map) - Method in class org.jgroups.demos.DistributedHashtableDemo
 
contentsSet(Collection) - Method in class org.jgroups.demos.DistributedQueueDemo
 
coord_addr - Variable in class org.jgroups.protocols.PingRsp
 
coordinatorChosen() - Method in class org.jgroups.demos.Topology
 
copy - Static variable 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.Membership
returns a copy of this membership
copy() - Method in class org.jgroups.Message
 
copy(boolean) - Method in class org.jgroups.Message
Create a copy of the message.
copy() - Method in class org.jgroups.ViewId
Old Copy method, deprecated because it is substituted by clone()
copy() - Method in class org.jgroups.protocols.NakAckHeader
 
copy() - Method in class org.jgroups.protocols.pbcast.Digest
 
copy() - Method in class org.jgroups.protocols.pbcast.Gossip
 
copy() - Method in class org.jgroups.protocols.pbcast.NakAckHeader
 
copy() - Method in class org.jgroups.stack.LogicalAddress
 
copy() - Method in class org.jgroups.util.Buffer
 
copy() - Method in class org.jgroups.util.List
 
copy() - Method in class org.jgroups.util.Stack
 
corr - Variable in class org.jgroups.blocks.GroupRequest
 
corr - Variable in class org.jgroups.blocks.MessageDispatcher
 
corrName - Variable in class org.jgroups.blocks.RequestCorrelator.Header
The unique name of the associated RequestCorrelator
count - Static variable in class org.jgroups.stack.LogicalAddress
 
crash() - Static method in class org.jgroups.util.Util
 
create(Address) - Static method in class org.jgroups.blocks.Xid
 
create(Address, int) - Static method in class org.jgroups.blocks.Xid
 
create() - Method in class org.jgroups.jmx.JChannel
 
create() - Method in interface org.jgroups.jmx.JChannelMBean
 
create() - Method in class org.jgroups.jmx.Protocol
 
create() - Method in interface org.jgroups.jmx.ProtocolMBean
 
create() - Method in class org.jgroups.stack.GossipRouter
JBoss MBean lifecycle operation.
createChannel(Object) - Method in interface org.jgroups.ChannelFactory
Deprecated. Channel factories should pass configuration information related to the protocol stack during construction or via another method before attempting to create any channels.
createChannel() - Method in interface org.jgroups.ChannelFactory
Creates an instance implementing the Channel interface.
createChannel(Object) - Method in class org.jgroups.JChannelFactory
Deprecated. JChannel's conversion to type-specific construction, and the subsequent deprecation of its JChannel(Object) constructor, necessitate the deprecation of this factory method as well. Type-specific protocol stack configuration should be specfied during construction of an instance of this factory.
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.
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, ProtocolStack) - Method in class org.jgroups.stack.Configurator
Creates a new protocol given the protocol specification.
createProtocol(String) - Method in class org.jgroups.stack.ProtocolStack
Creates a new protocol given the protocol specification.
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.
createServerSocket(int) - Static method in class org.jgroups.util.Util
Finds first available port starting at start_port and returns server socket
createServerSocket(InetAddress, int) - Static method in class org.jgroups.util.Util
 
createSocket(InetAddress, InetAddress, int, long) - Method in class org.jgroups.util.TimedWriter
Tries to create a socket to remote_peer:remote_port.
creator - Variable in class org.jgroups.blocks.Xid
 
cummulative - Variable in class org.jgroups.debug.Debugger
 
cvs - Static variable in class org.jgroups.Version
 

D

DATA - Static variable in class org.jgroups.protocols.UNICAST.UnicastHeader
 
DBPersistenceManager - class org.jgroups.persistence.DBPersistenceManager.
Class will be utilized
DBPersistenceManager(String) - Constructor for class org.jgroups.persistence.DBPersistenceManager
Default construct
DBPersistenceManager(InputStream) - Constructor for class org.jgroups.persistence.DBPersistenceManager
Duplicate constructor allowing inputstream
DEADLOCK - class org.jgroups.protocols.DEADLOCK.
Tests the deadlock detection mechanism of RequestCorrelator.
DEADLOCK() - Constructor for class org.jgroups.protocols.DEADLOCK
 
DEFAULT_CONNECTION_FACTORY - Static variable in class org.jgroups.protocols.JMS
 
DEFAULT_PROTOCOL_STACK - Static variable in class org.jgroups.JChannel
The default protocol stack used by the default constructor.
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).
DELAY() - Constructor for class org.jgroups.protocols.DELAY
 
DESTROY_INTERPRETER - Static variable in class org.jgroups.protocols.BSH.BshHeader
 
DEST_PROPERTY - Static variable in class org.jgroups.protocols.JMS
 
DIAG_GROUP - Static variable in class org.jgroups.util.Util
 
DIRTY_READS - Static variable 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.
DISCARD() - Constructor for class org.jgroups.protocols.DISCARD
 
DISCONNECT - Static variable in class org.jgroups.Event
 
DISCONNECT_OK - Static variable in class org.jgroups.Event
 
DROP_NEXT_MSG - Static variable in class org.jgroups.Event
 
DUMMY - class org.jgroups.protocols.DUMMY.
 
DUMMY() - Constructor for 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 variable in class org.jgroups.stack.GossipRouter
 
DUMP - Static variable in class org.jgroups.stack.Router
 
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(JChannel) - Constructor for class org.jgroups.debug.Debugger
 
Debugger(JChannel, String) - Constructor for class org.jgroups.debug.Debugger
 
Debugger(JChannel, boolean) - Constructor for class org.jgroups.debug.Debugger
 
Debugger(JChannel, boolean, String) - Constructor for class org.jgroups.debug.Debugger
 
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(int) - Constructor for class org.jgroups.protocols.Digest
 
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.pbcast.Digest
 
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
Digest.Entry(long, long, long) - Constructor for class org.jgroups.protocols.pbcast.Digest.Entry
 
Digest.Entry(long, long) - Constructor for class org.jgroups.protocols.pbcast.Digest.Entry
 
Digest.Entry(Digest.Entry) - Constructor for class org.jgroups.protocols.pbcast.Digest.Entry
 
Discovery - class org.jgroups.jmx.protocols.Discovery.
 
Discovery() - Constructor for class org.jgroups.jmx.protocols.Discovery
 
Discovery(Protocol) - Constructor for 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.protocols.Discovery
 
DiscoveryMBean - interface org.jgroups.jmx.protocols.DiscoveryMBean.
 
DistributedHashtable - class org.jgroups.blocks.DistributedHashtable.
Provides the abstraction of a java.util.Hashtable that is replicated at several locations.
DistributedHashtable(String, ChannelFactory, String, long) - Constructor for class org.jgroups.blocks.DistributedHashtable
Creates a DistributedHashtable
DistributedHashtable(String, ChannelFactory, String, boolean, long) - Constructor for class org.jgroups.blocks.DistributedHashtable
Creates a DisttributedHashtable.
DistributedHashtable(JChannel, long) - Constructor for class org.jgroups.blocks.DistributedHashtable
 
DistributedHashtable(JChannel, boolean, long) - Constructor for class org.jgroups.blocks.DistributedHashtable
 
DistributedHashtable(PullPushAdapter, Serializable, long) - Constructor for class org.jgroups.blocks.DistributedHashtable
Uses a user-provided PullPushAdapter to create the dispatcher rather than a Channel.
DistributedHashtable(PullPushAdapter, Serializable) - Constructor for class org.jgroups.blocks.DistributedHashtable
 
DistributedHashtable.Notification - interface org.jgroups.blocks.DistributedHashtable.Notification.
 
DistributedHashtableDemo - class org.jgroups.demos.DistributedHashtableDemo.
Uses the DistributedHashtable building block.
DistributedHashtableDemo() - Constructor for class org.jgroups.demos.DistributedHashtableDemo
 
DistributedLockManager - class org.jgroups.blocks.DistributedLockManager.
Distributed lock manager is responsible for maintaining the lock information consistent on all participating nodes.
DistributedLockManager(VotingAdapter, Object) - Constructor for class org.jgroups.blocks.DistributedLockManager
Create instance of this class.
DistributedLockManager(TwoPhaseVotingAdapter, Object) - Constructor for class org.jgroups.blocks.DistributedLockManager
Constructor for the DistributedLockManager_cl object.
DistributedLockManager.AcquireLockDecree - class org.jgroups.blocks.DistributedLockManager.AcquireLockDecree.
This class represents the lock to be released.
DistributedLockManager.LockDecree - class org.jgroups.blocks.DistributedLockManager.LockDecree.
This class represents the lock
DistributedLockManager.MultiLockDecree - class org.jgroups.blocks.DistributedLockManager.MultiLockDecree.
This class represents the lock that has to be marked as multilocked
DistributedLockManager.ReleaseLockDecree - class org.jgroups.blocks.DistributedLockManager.ReleaseLockDecree.
This class represents the lock to be released.
DistributedQueue - class org.jgroups.blocks.DistributedQueue.
Provides the abstraction of a java.util.LinkedList that is replicated at several locations.
DistributedQueue(String, ChannelFactory, String, long) - Constructor for class org.jgroups.blocks.DistributedQueue
Creates a DistributedQueue
DistributedQueue(JChannel) - Constructor for class org.jgroups.blocks.DistributedQueue
 
DistributedQueue(PullPushAdapter, Serializable) - Constructor for class org.jgroups.blocks.DistributedQueue
Uses a user-provided PullPushAdapter to create the dispatcher rather than a Channel.
DistributedQueue.Notification - interface org.jgroups.blocks.DistributedQueue.Notification.
 
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
 
DistributedTree(PullPushAdapter, Serializable, long) - Constructor for class org.jgroups.blocks.DistributedTree
 
DistributedTree.DistributedTreeListener - interface org.jgroups.blocks.DistributedTree.DistributedTreeListener.
 
DistributedTree.ViewListener - interface org.jgroups.blocks.DistributedTree.ViewListener.
 
DistributedTreeDemo - class org.jgroups.demos.DistributedTreeDemo.
Demo showing the DistributedTree class.
DistributedTreeDemo(boolean) - Constructor for class org.jgroups.demos.DistributedTreeDemo
 
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.
 
DrawApplet() - Constructor for class org.jgroups.demos.applets.DrawApplet
 
DrawCommand - class org.jgroups.demos.DrawCommand.
Encapsulates information about a draw command.
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
 
deadlock_detection - Variable in class org.jgroups.blocks.MessageDispatcher
 
deadlock_detection - Variable in class org.jgroups.blocks.RequestCorrelator
Whether or not to perform deadlock detection for synchronous (potentially recursive) group method invocations.
debug - Static variable 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
defragmentBuffer(byte[][]) - Static method in class org.jgroups.util.Util
Concatenates smaller fragments into entire buffers.
description - Static variable in class org.jgroups.Version
 
dest_addr - Variable in class org.jgroups.Message
 
dest_mbrs - Variable in class org.jgroups.blocks.RequestCorrelator.Header
Contains a list of members who should receive the request (others will drop).
destroy() - Method in class org.jgroups.demos.applets.DrawApplet
 
destroy() - Method in class org.jgroups.demos.wb.Whiteboard
 
destroy() - Method in class org.jgroups.jmx.JChannel
 
destroy() - Method in interface org.jgroups.jmx.JChannelMBean
 
destroy() - Method in class org.jgroups.jmx.Protocol
 
destroy() - Method in interface org.jgroups.jmx.ProtocolMBean
 
destroy() - Method in class org.jgroups.protocols.BSH
 
destroy() - Method in class org.jgroups.protocols.COMPRESS
 
destroy() - Method in class org.jgroups.stack.GossipRouter
JBoss MBean lifecycle operation.
destroy() - Method in class org.jgroups.stack.NakReceiverWindow
Stop the retransmitter and reset the nak window
destroy() - Method in class org.jgroups.stack.Protocol
This method is called on a Channel.close().
destroy() - Method in class org.jgroups.stack.ProtocolStack
 
destroy() - Method in class org.jgroups.util.ThreadPool
 
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.
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.demos.TotalTokenDemo
 
disconnect() - Method in class org.jgroups.jmx.JChannel
 
disconnect() - Method in interface org.jgroups.jmx.JChannelMBean
 
disconnect() - Method in class org.jgroups.stack.RouterStub
Closes the socket and the input and output streams associated with it
disp - Variable in class org.jgroups.blocks.DistributedHashtable
 
disp - Variable in class org.jgroups.blocks.DistributedQueue
 
disp - Variable in class org.jgroups.blocks.DistributedTree
 
disp - Variable in class org.jgroups.blocks.ReplicationManager
Used to broadcast updates and receive responses (latter only in synchronous case)
disp - Variable in class org.jgroups.demos.wb.Whiteboard
 
displayMessage(String, String) - Method in class org.jgroups.demos.wb.Whiteboard
 
done - Variable in class org.jgroups.blocks.GroupRequest
 
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.
done() - Method in class org.jgroups.protocols.PERF_TP
 
done() - Method in class org.jgroups.util.ReusableThread
 
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).
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).
down(Event) - Method in class org.jgroups.Channel
Access to event mechanism of channels.
down(Event) - Method in class org.jgroups.JChannel
Sends a message through the protocol stack if the stack is available
down(Event, int) - Method in class org.jgroups.debug.ProtocolView
 
down(Event) - Method in class org.jgroups.jmx.JChannel
 
down(Event) - Method in interface org.jgroups.jmx.JChannelMBean
Deprecated.  
down(Event) - Method in class org.jgroups.protocols.CAUSAL
Processes Event going down in the stack
down(Event) - Method in class org.jgroups.protocols.COMPRESS
We compress the payload if it is larger than min_size.
down(Event) - Method in class org.jgroups.protocols.DELAY
 
down(Event) - Method in class org.jgroups.protocols.DISCARD
 
down(Event) - Method in class org.jgroups.protocols.DUMMY
 
down(Event) - Method in class org.jgroups.protocols.DUMMY_TP
Caller by the layer above this layer.
down(Event) - Method in class org.jgroups.protocols.Discovery
An event is to be sent down the stack.
down(Event) - Method in class org.jgroups.protocols.ENCRYPT
 
down(Event) - Method in class org.jgroups.protocols.ENCRYPT1_4
 
down(Event) - Method in class org.jgroups.protocols.EXAMPLE
 
down(Event) - Method in class org.jgroups.protocols.FC
 
down(Event) - Method in class org.jgroups.protocols.FD
 
down(Event) - Method in class org.jgroups.protocols.FD_PID
 
down(Event) - Method in class org.jgroups.protocols.FD_PROB
 
down(Event) - Method in class org.jgroups.protocols.FD_SIMPLE
 
down(Event) - Method in class org.jgroups.protocols.FD_SOCK
 
down(Event) - Method in class org.jgroups.protocols.FLOWCONTROL
Checs if it can send the message, else puts the message in the queue.
down(Event) - Method in class org.jgroups.protocols.FRAG
Fragment a packet if larger than frag_size (add a header).
down(Event) - Method in class org.jgroups.protocols.FRAG2
Fragment a packet if larger than frag_size (add a header).
down(Event) - Method in class org.jgroups.protocols.HDRS
 
down(Event) - Method in class org.jgroups.protocols.HTOTAL
 
down(Event) - Method in class org.jgroups.protocols.JMS
Called by the protocol above this.
down(Event) - Method in class org.jgroups.protocols.LOOPBACK
Caller by the layer above this layer.
down(Event) - Method in class org.jgroups.protocols.LOSS
 
down(Event) - Method in class org.jgroups.protocols.MERGE
 
down(Event) - Method in class org.jgroups.protocols.MERGE2
 
down(Event) - Method in class org.jgroups.protocols.MERGE3
 
down(Event) - Method in class org.jgroups.protocols.MERGEFAST
 
down(Event) - Method in class org.jgroups.protocols.NAKACK
Callback.
down(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(Event) - Method in class org.jgroups.protocols.PERF
 
down(Event) - Method in class org.jgroups.protocols.PERF_TP
Caller by the layer above this layer.
down(Event) - Method in class org.jgroups.protocols.PIGGYBACK
 
down(Event) - Method in class org.jgroups.protocols.PRINTMETHODS
 
down(Event) - Method in class org.jgroups.protocols.PRINTOBJS
 
down(Event) - Method in class org.jgroups.protocols.QUEUE
 
down(Event) - Method in class org.jgroups.protocols.SIZE
 
down(Event) - Method in class org.jgroups.protocols.SMACK
 
down(Event) - Method in class org.jgroups.protocols.STATE_TRANSFER
 
down(Event) - Method in class org.jgroups.protocols.STATS
 
down(Event) - Method in class org.jgroups.protocols.TOTAL
 
down(Event) - Method in class org.jgroups.protocols.TOTAL_OLD
handles an Event coming down the Protocol Stack
down(Event) - Method in class org.jgroups.protocols.TP
Caller by the layer above this layer.
down(Event) - Method in class org.jgroups.protocols.TRACE
 
down(Event) - Method in class org.jgroups.protocols.TUNNEL
Caller by the layer above this layer.
down(Event) - Method in class org.jgroups.protocols.UDP_NIO
Caller by the layer above this layer.
down(Event) - Method in class org.jgroups.protocols.UNICAST
 
down(Event) - Method in class org.jgroups.protocols.VIEW_SYNC
 
down(Event) - Method in class org.jgroups.protocols.WANPIPE
Sent to destination(s) using the WAN pipe.
down(Event) - Method in class org.jgroups.protocols.pbcast.FD
 
down(Event) - Method in class org.jgroups.protocols.pbcast.GMS
 
down(Event) - Method in class org.jgroups.protocols.pbcast.NAKACK
Callback.
down(Event) - Method in class org.jgroups.protocols.pbcast.PBCAST
 
down(Event) - Method in class org.jgroups.protocols.pbcast.STABLE
 
down(Event) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
down(Event) - Method in class org.jgroups.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(Event) - Method in class org.jgroups.stack.Protocol
An event is to be sent down the stack.
down(Event, int) - Method in interface org.jgroups.stack.ProtocolObserver
Called when an event is about to be dispatched to the protocol (before it is dispatched).
down(Event) - Method in class org.jgroups.stack.ProtocolStack
 
downThreadEnabled() - Method in class org.jgroups.stack.Protocol
 
down_handler - Variable in class org.jgroups.stack.Protocol
 
down_prot - Variable in class org.jgroups.stack.Protocol
 
down_queue - Variable in class org.jgroups.stack.Protocol
 
down_thread - Variable in class org.jgroups.stack.Protocol
 
down_thread_prio - Variable in class org.jgroups.stack.Protocol
 
drawNode(Graphics, int, int, String, int) - Method in class org.jgroups.demos.Topology
 
drawTopology(Graphics) - Method in class org.jgroups.demos.Topology
 
dump() - Static method in class org.jgroups.debug.Profiler
 
dump() - Method in class org.jgroups.util.List
 
dumpGossipTable() - Method in class org.jgroups.stack.GossipRouter
 
dumpHistory() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
 
dumpHistory() - Method in interface 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 interface org.jgroups.jmx.JChannelMBean
 
dumpQueue(Queue) - Static method in class org.jgroups.util.Util
Debugging method used to dump the content of a protocol queue in a condensed form.
dumpRoutingTable() - 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.JChannel
Returns a map of statistics of the various protocols and of the channel itself.
dumpStats() - Method in class org.jgroups.debug.Simulator
 
dumpStats() - Method in class org.jgroups.jmx.JChannel
 
dumpStats() - Method in interface org.jgroups.jmx.JChannelMBean
 
dumpStats() - Method in class org.jgroups.jmx.Protocol
 
dumpStats() - Method in interface org.jgroups.jmx.ProtocolMBean
 
dumpStats() - Method in class org.jgroups.protocols.DISCARD
 
dumpStats() - Method in class org.jgroups.protocols.FC
 
dumpStats() - Method in class org.jgroups.protocols.TP
 
dumpStats() - Method in class org.jgroups.protocols.UNICAST
 
dumpStats() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
dumpStats() - Method in class org.jgroups.stack.Protocol
 
dumpStats() - Method in class org.jgroups.stack.ProtocolStack
 
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 interface 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 interface org.jgroups.jmx.protocols.pbcast.GMSMBean
 
dumpViewHandlerQueue() - Method in class org.jgroups.protocols.pbcast.GMS
 
dx - Variable in class org.jgroups.demos.wb.Node
 
dy - Variable in class org.jgroups.demos.wb.Node
 

E

ELMT_CLASS - Static variable in class org.jgroups.conf.XmlConfigurator
 
ELMT_DESCRIPTION - Static variable in class org.jgroups.conf.XmlConfigurator
 
ELMT_PROT - Static variable in class org.jgroups.conf.XmlConfigurator
 
ELMT_PROT_NAME - Static variable in class org.jgroups.conf.XmlConfigurator
 
ELMT_PROT_OVERRIDE - Static variable in class org.jgroups.conf.XmlConfigurator
 
ELMT_PROT_PARAMS - Static variable in class org.jgroups.conf.XmlConfigurator
 
ENABLE_UNICASTS_TO - Static variable in class org.jgroups.Event
 
ENCRYPT - class org.jgroups.protocols.ENCRYPT.
ENCRYPT layer.
ENCRYPT() - Constructor for class org.jgroups.protocols.ENCRYPT
 
ENCRYPT - Static variable in class org.jgroups.protocols.ENCRYPT.EncryptHeader
 
ENCRYPT.EncryptHeader - class org.jgroups.protocols.ENCRYPT.EncryptHeader.
 
ENCRYPT.EncryptHeader() - Constructor for class org.jgroups.protocols.ENCRYPT.EncryptHeader
 
ENCRYPT.EncryptHeader(short) - Constructor for class org.jgroups.protocols.ENCRYPT.EncryptHeader
 
ENCRYPT.EncryptHeader(short, String) - Constructor for class org.jgroups.protocols.ENCRYPT.EncryptHeader
 
ENCRYPT1_4 - class org.jgroups.protocols.ENCRYPT1_4.
ENCRYPT1_4 layer.
ENCRYPT1_4() - Constructor for class org.jgroups.protocols.ENCRYPT1_4
 
ENCRYPT1_4.EncryptHeader - class org.jgroups.protocols.ENCRYPT1_4.EncryptHeader.
 
ENCRYPT1_4.EncryptHeader() - Constructor for class org.jgroups.protocols.ENCRYPT1_4.EncryptHeader
 
ENCRYPT1_4.EncryptHeader(int) - Constructor for class org.jgroups.protocols.ENCRYPT1_4.EncryptHeader
 
EXAMPLE - class org.jgroups.protocols.EXAMPLE.
Example of a protocol layer.
EXAMPLE() - Constructor for class org.jgroups.protocols.EXAMPLE
 
EXIT - Static variable in class org.jgroups.Event
 
EXPIRY_TIME - Static variable in class org.jgroups.stack.GossipRouter
 
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
 
ExitEvent - class org.jgroups.ExitEvent.
Trivial object that represents an exit event.
ExitEvent() - Constructor for class org.jgroups.ExitEvent
 
ExposedBufferedInputStream - class org.jgroups.util.ExposedBufferedInputStream.
 
ExposedBufferedInputStream(InputStream) - Constructor for class org.jgroups.util.ExposedBufferedInputStream
Creates a BufferedInputStream and saves its argument, the input stream in, for later use.
ExposedBufferedInputStream(InputStream, int) - Constructor for class org.jgroups.util.ExposedBufferedInputStream
Creates a BufferedInputStream with the specified buffer size, and saves its argument, the input stream in, for later use.
ExposedBufferedOutputStream - class org.jgroups.util.ExposedBufferedOutputStream.
 
ExposedBufferedOutputStream(OutputStream) - Constructor for class org.jgroups.util.ExposedBufferedOutputStream
Creates a new buffered output stream to write data to the specified underlying output stream.
ExposedBufferedOutputStream(OutputStream, int) - Constructor for class org.jgroups.util.ExposedBufferedOutputStream
Creates a new buffered output stream to write data to the specified underlying output stream with the specified buffer size.
ExposedByteArrayInputStream - class org.jgroups.util.ExposedByteArrayInputStream.
 
ExposedByteArrayInputStream(byte[]) - Constructor for class org.jgroups.util.ExposedByteArrayInputStream
Creates a ByteArrayInputStream so that it uses buf as its buffer array.
ExposedByteArrayInputStream(byte[], int, int) - Constructor for class org.jgroups.util.ExposedByteArrayInputStream
Creates ByteArrayInputStream that uses buf as its buffer array.
ExposedByteArrayOutputStream - class org.jgroups.util.ExposedByteArrayOutputStream.
Extends ByteArrayOutputStream, but exposes the internal buffer.
ExposedByteArrayOutputStream() - Constructor for class org.jgroups.util.ExposedByteArrayOutputStream
 
ExposedByteArrayOutputStream(int) - Constructor for class org.jgroups.util.ExposedByteArrayOutputStream
 
ExposedDataOutputStream - class org.jgroups.util.ExposedDataOutputStream.
 
ExposedDataOutputStream(OutputStream) - Constructor for class org.jgroups.util.ExposedDataOutputStream
Creates a new data output stream to write data to the specified underlying output stream.
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
 
empty() - Method in class org.jgroups.util.Stack
 
enableStats(boolean) - Method in class org.jgroups.JChannel
 
enableStats(boolean) - Method in class org.jgroups.stack.Protocol
 
entryAdd(Object) - Method in interface org.jgroups.blocks.DistributedQueue.Notification
 
entryAdd(Object) - Method in class org.jgroups.demos.DistributedQueueDemo
 
entryRemoved(Object) - Method in interface org.jgroups.blocks.DistributedHashtable.Notification
 
entryRemoved(Object) - Method in interface org.jgroups.blocks.DistributedQueue.Notification
 
entryRemoved(Object) - Method in interface org.jgroups.blocks.ReplicatedHashtable.Notification
 
entryRemoved(Object) - Method in class org.jgroups.demos.DistributedHashtableDemo
 
entryRemoved(Object) - Method in class org.jgroups.demos.DistributedQueueDemo
 
entrySet(Object, Object) - Method in interface org.jgroups.blocks.DistributedHashtable.Notification
 
entrySet(Object, Object) - Method in interface org.jgroups.blocks.ReplicatedHashtable.Notification
 
entrySet(Object, Object) - Method in class org.jgroups.demos.DistributedHashtableDemo
 
equals(Object) - Method in class org.jgroups.View
 
equals(Object) - Method in class org.jgroups.ViewId
 
equals(Object) - Method in class org.jgroups.blocks.DistributedLockManager.LockDecree
 
equals(Object) - Method in class org.jgroups.blocks.Link
 
equals(Object) - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseVoteWrapper
 
equals(Object) - Method in class org.jgroups.blocks.Xid
 
equals(Object) - Method in class org.jgroups.conf.ClassMap
 
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.ENCRYPT.EncryptHeader
 
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.protocols.PingRsp
 
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.protocols.WanPipeAddress
 
equals(Object) - Method in class org.jgroups.protocols.pbcast.Digest.Entry
 
equals(Object) - Method in class org.jgroups.protocols.pbcast.Digest
 
equals(Object) - Method in class org.jgroups.protocols.pbcast.Gossip
 
equals(Object) - Method in class org.jgroups.protocols.pbcast.MergeData
 
equals(Object) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
equals(Object) - Method in class org.jgroups.stack.IpAddress
 
equals(Object) - Method in class org.jgroups.stack.LogicalAddress
 
established() - Method in class org.jgroups.blocks.Link
 
execute() - Method in class org.jgroups.blocks.GroupRequest
Sends the message.
execute() - Method in interface org.jgroups.util.Command
 
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
expected_mbrs - Variable in class org.jgroups.blocks.GroupRequest
 

F

FC - class org.jgroups.jmx.protocols.FC.
 
FC() - Constructor for class org.jgroups.jmx.protocols.FC
 
FC(Protocol) - Constructor for 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.protocols.FC
 
FC.FcHeader - class org.jgroups.protocols.FC.FcHeader.
 
FC.FcHeader() - Constructor for class org.jgroups.protocols.FC.FcHeader
 
FC.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() - Constructor for class org.jgroups.jmx.protocols.FD
 
FD(Protocol) - Constructor for class org.jgroups.jmx.protocols.FD
 
FD - class org.jgroups.protocols.FD.
Failure detection based on simple heartbeat protocol.
FD() - Constructor for class org.jgroups.protocols.FD
 
FD - class org.jgroups.protocols.pbcast.FD.
Passive failure detection protocol.
FD() - Constructor for class org.jgroups.protocols.pbcast.FD
 
FD.FdHeader - class org.jgroups.protocols.FD.FdHeader.
 
FD.FdHeader() - Constructor for class org.jgroups.protocols.FD.FdHeader
 
FD.FdHeader(byte) - Constructor for class org.jgroups.protocols.FD.FdHeader
 
FD.FdHeader(byte, Vector, Address) - Constructor for class org.jgroups.protocols.FD.FdHeader
 
FDMBean - interface org.jgroups.jmx.protocols.FDMBean.
 
FD_PID - class org.jgroups.protocols.FD_PID.
Process-ID based FD protocol.
FD_PID() - Constructor for class org.jgroups.protocols.FD_PID
 
FD_PID.FdHeader - class org.jgroups.protocols.FD_PID.FdHeader.
 
FD_PID.FdHeader() - Constructor for class org.jgroups.protocols.FD_PID.FdHeader
 
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_PROB() - Constructor for class org.jgroups.protocols.FD_PROB
 
FD_PROB.FdHeader - class org.jgroups.protocols.FD_PROB.FdHeader.
 
FD_PROB.FdHeader() - Constructor for class org.jgroups.protocols.FD_PROB.FdHeader
 
FD_SIMPLE - class org.jgroups.protocols.FD_SIMPLE.
Simple failure detection protocol.
FD_SIMPLE() - Constructor for class org.jgroups.protocols.FD_SIMPLE
 
FD_SIMPLE.FdHeader - class org.jgroups.protocols.FD_SIMPLE.FdHeader.
 
FD_SIMPLE.FdHeader() - Constructor for class org.jgroups.protocols.FD_SIMPLE.FdHeader
 
FD_SOCK - class org.jgroups.jmx.protocols.FD_SOCK.
 
FD_SOCK() - Constructor for class org.jgroups.jmx.protocols.FD_SOCK
 
FD_SOCK(Protocol) - Constructor for 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.protocols.FD_SOCK
 
FD_SOCK.FdHeader - class org.jgroups.protocols.FD_SOCK.FdHeader.
 
FD_SOCK.FdHeader() - Constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
 
FD_SOCK.FdHeader(byte) - Constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
 
FD_SOCK.FdHeader(byte, Address) - Constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
 
FD_SOCK.FdHeader(byte, Vector) - Constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
 
FD_SOCK.FdHeader(byte, Hashtable) - Constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
 
FD_SOCKMBean - interface org.jgroups.jmx.protocols.FD_SOCKMBean.
 
FIND_INITIAL_MBRS - Static variable in class org.jgroups.Event
 
FIND_INITIAL_MBRS_EVT - Static variable in class org.jgroups.Event
 
FIND_INITIAL_MBRS_OK - Static variable in class org.jgroups.Event
 
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
 
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
 
FLUSH - Static variable 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() - Constructor for class org.jgroups.protocols.FLUSH
 
FLUSH_OK - Static variable in class org.jgroups.Event
 
FRAG - class org.jgroups.jmx.protocols.FRAG.
 
FRAG() - Constructor for class org.jgroups.jmx.protocols.FRAG
 
FRAG(Protocol) - Constructor for class org.jgroups.jmx.protocols.FRAG
 
FRAG - class org.jgroups.protocols.FRAG.
Fragmentation layer.
FRAG() - Constructor for class org.jgroups.protocols.FRAG
 
FRAG2 - class org.jgroups.jmx.protocols.FRAG2.
 
FRAG2() - Constructor for class org.jgroups.jmx.protocols.FRAG2
 
FRAG2(Protocol) - Constructor for class org.jgroups.jmx.protocols.FRAG2
 
FRAG2 - class org.jgroups.protocols.FRAG2.
Fragmentation layer.
FRAG2() - Constructor for class org.jgroups.protocols.FRAG2
 
FRAG2MBean - interface org.jgroups.jmx.protocols.FRAG2MBean.
 
FRAGMBean - interface org.jgroups.jmx.protocols.FRAGMBean.
 
FilePersistenceManager - class org.jgroups.persistence.FilePersistenceManager.
 
FilePersistenceManager(String) - Constructor for class org.jgroups.persistence.FilePersistenceManager
Default constructor
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
 
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
 
failedNode - Variable in class org.jgroups.protocols.ring.TokenLostException
 
failed_mbrs - Variable in class org.jgroups.protocols.FlushRsp
 
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
 
filterLoadedValues(Map) - Method in class org.jgroups.persistence.FilePersistenceManager
Turns the values into Floats to enable DistributedHashtableDemo to work.
findComponent(Container, String) - Method in class org.jgroups.demos.DrawRepl
 
findInitialMembers() - Method in class org.jgroups.jmx.protocols.Discovery
 
findInitialMembers() - Method in interface org.jgroups.jmx.protocols.DiscoveryMBean
 
findInitialMembers() - Method in class org.jgroups.protocols.Discovery
Finds the initial membership
findInitialMembers() - Method in class org.jgroups.protocols.PingWaiter
 
findInitialMembersAsString() - Method in class org.jgroups.jmx.protocols.Discovery
 
findInitialMembersAsString() - Method in interface org.jgroups.jmx.protocols.DiscoveryMBean
 
findInitialMembersAsString() - Method in class org.jgroups.protocols.Discovery
 
findMethod(short) - Method in interface org.jgroups.blocks.MethodLookup
 
findProtocol(Protocol) - Static method in class org.jgroups.jmx.JmxConfigurator
 
findProtocol(Protocol, String) - Method in class org.jgroups.stack.Configurator
 
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 - Variable in class org.jgroups.demos.wb.Node
 
flush(Vector, Vector) - Method in class org.jgroups.protocols.GMS
FLUSH protocol.
flushEvents() - Method in class org.jgroups.stack.ProtocolStack
Deprecated.  
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_id - Variable in class org.jgroups.protocols.FragHeader
 
fragmentBuffer(byte[], int, int) - Static method in class org.jgroups.util.Util
Fragments a byte buffer into smaller fragments of (max.) frag_size.
fragmentBuffer(byte[], int) - Static method in class org.jgroups.util.Util
 

G

GET - Static variable in class org.jgroups.stack.GossipRouter
 
GET - Static variable in class org.jgroups.stack.Router
 
GET_ABS_MAJORITY - Static variable in class org.jgroups.blocks.GroupRequest
return majority (of all members, may block)
GET_ALL - Static variable in class org.jgroups.blocks.GroupRequest
return all responses
GET_APPLSTATE - Static variable in class org.jgroups.Event
 
GET_APPLSTATE_OK - Static variable in class org.jgroups.Event
 
GET_CACHE - Static variable in class org.jgroups.protocols.FD_SOCK.FdHeader
 
GET_CACHE_RSP - Static variable in class org.jgroups.protocols.FD_SOCK.FdHeader
 
GET_DIGEST - Static variable in class org.jgroups.Event
 
GET_DIGEST_EVT - Static variable in class org.jgroups.Event
 
GET_DIGEST_OK - Static variable in class org.jgroups.Event
 
GET_DIGEST_STABLE - Static variable in class org.jgroups.Event
 
GET_DIGEST_STABLE_OK - Static variable in class org.jgroups.Event
 
GET_DIGEST_STATE - Static variable in class org.jgroups.Event
 
GET_DIGEST_STATE_OK - Static variable in class org.jgroups.Event
 
GET_FIRST - Static variable in class org.jgroups.blocks.GroupRequest
return only first response
GET_FROM_MANY - Static variable in class org.jgroups.stack.StateTransferInfo
 
GET_FROM_SINGLE - Static variable in class org.jgroups.stack.StateTransferInfo
 
GET_LOCAL_ADDRESS - Static variable in class org.jgroups.Event
 
GET_MAJORITY - Static variable in class org.jgroups.blocks.GroupRequest
return majority (of all non-faulty members)
GET_MBRS_REQ - Static variable in class org.jgroups.protocols.PingHeader
 
GET_MBRS_RSP - Static variable in class org.jgroups.protocols.PingHeader
 
GET_MSGS - Static variable in class org.jgroups.Event
 
GET_MSGS_OK - Static variable in class org.jgroups.Event
 
GET_MSGS_RECEIVED - Static variable in class org.jgroups.Event
 
GET_MSGS_RECEIVED_OK - Static variable in class org.jgroups.Event
 
GET_MSG_DIGEST - Static variable in class org.jgroups.Event
 
GET_MSG_DIGEST_OK - Static variable in class org.jgroups.Event
 
GET_N - Static variable in class org.jgroups.blocks.GroupRequest
return n responses (may block)
GET_NONE - Static variable in class org.jgroups.blocks.GroupRequest
return no response (async call)
GET_REQ - Static variable in class org.jgroups.stack.GossipData
 
GET_RSP - Static variable in class org.jgroups.stack.GossipData
 
GET_STATE - Static variable in class org.jgroups.Event
 
GET_STATE_EVENTS - Static variable in class org.jgroups.Channel
 
GET_STATE_OK - Static variable in class org.jgroups.Event
 
GMS - class org.jgroups.jmx.protocols.pbcast.GMS.
 
GMS() - Constructor for class org.jgroups.jmx.protocols.pbcast.GMS
 
GMS(Protocol) - Constructor for class org.jgroups.jmx.protocols.pbcast.GMS
 
GMS - class org.jgroups.protocols.GMS.
Group membership protocol.
GMS() - Constructor for class org.jgroups.protocols.GMS
 
GMS - class org.jgroups.protocols.pbcast.GMS.
Group membership protocol.
GMS() - Constructor for class org.jgroups.protocols.pbcast.GMS
 
GMS.GmsHeader - class org.jgroups.protocols.pbcast.GMS.GmsHeader.
 
GMS.GmsHeader() - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
GMS.GmsHeader(byte) - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
GMS.GmsHeader(byte, View) - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
Used for VIEW header
GMS.GmsHeader(byte, Address) - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
Used for JOIN_REQ or LEAVE_REQ header
GMS.GmsHeader(byte, JoinRsp) - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
Used for JOIN_RSP header
GMS.Request - class org.jgroups.protocols.pbcast.GMS.Request.
 
GMSMBean - interface org.jgroups.jmx.protocols.pbcast.GMSMBean.
 
GOSSIP - Static variable in class org.jgroups.protocols.pbcast.PbcastHeader
 
GOSSIP_REQUEST_TIMEOUT - Static variable in class org.jgroups.stack.GossipRouter
 
GROUP_NAME_PROPERTY - Static variable in class org.jgroups.protocols.JMS
 
GetNetworkInterfaces - class org.jgroups.util.GetNetworkInterfaces.
Lists all network interfaces on a system
GetNetworkInterfaces() - Constructor for class org.jgroups.util.GetNetworkInterfaces
 
GetStateEvent - class org.jgroups.GetStateEvent.
Represents a GetState event.
GetStateEvent(Object) - Constructor for class org.jgroups.GetStateEvent
 
Global - class org.jgroups.Global.
Globals used by JGroups packages.
Global() - Constructor for class org.jgroups.Global
 
GmsImpl - class org.jgroups.protocols.GmsImpl.
 
GmsImpl() - Constructor for class org.jgroups.protocols.GmsImpl
 
GmsImpl - class org.jgroups.protocols.pbcast.GmsImpl.
 
GmsImpl() - Constructor for class org.jgroups.protocols.pbcast.GmsImpl
 
GmsImpl(GMS) - Constructor for class org.jgroups.protocols.pbcast.GmsImpl
 
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(String, long) - Constructor for class org.jgroups.demos.Gossip
 
Gossip - class org.jgroups.protocols.pbcast.Gossip.
 
Gossip(Address, long) - Constructor for class org.jgroups.protocols.pbcast.Gossip
 
Gossip(Address, long, Digest, Vector) - Constructor for class org.jgroups.protocols.pbcast.Gossip
 
GossipClient - class org.jgroups.stack.GossipClient.
Local stub for clients to access one (or more) GossipServers.
GossipClient(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, 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.
Deprecated. Use GossipRouter instead
GossipServer(int) - Constructor for class org.jgroups.stack.GossipServer
Deprecated.  
GossipServer(int, long) - Constructor for class org.jgroups.stack.GossipServer
Deprecated.  
GossipServer(int, long, InetAddress) - Constructor for class org.jgroups.stack.GossipServer
Deprecated.  
GraphPanel - class org.jgroups.demos.wb.GraphPanel.
 
GraphPanel(Whiteboard) - Constructor for class org.jgroups.demos.wb.GraphPanel
 
GroupRequest - class org.jgroups.blocks.GroupRequest.
Sends a message to all members of the group and waits for all responses (or timeout).
GroupRequest(Message, RequestCorrelator, Vector, int) - Constructor for class org.jgroups.blocks.GroupRequest
 
GroupRequest(Message, RequestCorrelator, Vector, int, long, int) - Constructor for class org.jgroups.blocks.GroupRequest
 
GroupRequest(Message, Transport, Vector, int) - Constructor for class org.jgroups.blocks.GroupRequest
 
GroupRequest(Message, Transport, Vector, int, long, int) - Constructor for class org.jgroups.blocks.GroupRequest
 
generateLocalAddress() - Method in class org.jgroups.protocols.JMS
Generate random local address.
get(String) - Method in class org.jgroups.blocks.DistributedTree
 
get(Object) - Method in class org.jgroups.blocks.MethodCall
 
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(int) - Method in class org.jgroups.conf.ClassConfigurator
Returns a class for a magic number.
get(String) - Method in class org.jgroups.conf.ClassConfigurator
Loads and returns the class from the class name
get(Address) - Method in class org.jgroups.protocols.pbcast.Digest
 
get(long) - Method in class org.jgroups.stack.NakReceiverWindow
Returns the message from received_msgs or delivered_msgs.
get(String) - Method in class org.jgroups.stack.RouterStub
Retrieves the membership (list of Addresses) for a given group.
get() - Method in class org.jgroups.util.CondVar
 
get(Address) - Method in class org.jgroups.util.RspList
 
getAcksReceived() - Method in class org.jgroups.jmx.protocols.UNICAST
 
getAcksReceived() - Method in interface org.jgroups.jmx.protocols.UNICASTMBean
 
getAcksSent() - Method in class org.jgroups.jmx.protocols.UNICAST
 
getAcksSent() - Method in interface 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.TOTAL_TOKEN
 
getAllReceivedUpto() - Method in class org.jgroups.protocols.ring.RingToken
 
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
 
getAllowedToBroadcast(RingToken) - Method in class org.jgroups.protocols.ring.RingNodeFlowControl
 
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 interface org.jgroups.jmx.JChannelMBean
 
getAutoReconnect() - Method in class org.jgroups.jmx.JChannel
 
getAutoReconnect() - Method in interface org.jgroups.jmx.JChannelMBean
 
getAverageSendInterval() - Method in class org.jgroups.jmx.protocols.VIEW_SYNC
 
getAverageSendInterval() - Method in interface org.jgroups.jmx.protocols.VIEW_SYNCMBean
 
getAverageSendInterval() - Method in class org.jgroups.protocols.VIEW_SYNC
 
getAverageStateSize() - Method in class org.jgroups.jmx.protocols.pbcast.STATE_TRANSFER
 
getAverageStateSize() - Method in interface org.jgroups.jmx.protocols.pbcast.STATE_TRANSFERMBean
 
getAverageStateSize() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
getAverageTimeBlocked() - Method in class org.jgroups.jmx.protocols.FC
 
getAverageTimeBlocked() - Method in interface org.jgroups.jmx.protocols.FCMBean
 
getAverageTimeBlocked() - Method in class org.jgroups.protocols.FC
 
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 interface org.jgroups.jmx.protocols.MPINGMBean
 
getBindAddr() - Method in class org.jgroups.jmx.protocols.TCP
 
getBindAddr() - Method in interface org.jgroups.jmx.protocols.TCPMBean
 
getBindAddr() - Method in class org.jgroups.protocols.MPING
 
getBindAddr() - Method in class org.jgroups.protocols.TCP
 
getBindAddress() - Method in class org.jgroups.jmx.protocols.TP
 
getBindAddress() - Method in interface org.jgroups.jmx.protocols.TPMBean
 
getBindAddress() - Method in class org.jgroups.protocols.TP
 
getBindAddress() - Method in class org.jgroups.stack.GossipRouter
 
getBindInterface() - Method in class org.jgroups.protocols.UDP_NIO.Connector
 
getBindToAllInterfaces() - Method in class org.jgroups.protocols.TP
Deprecated. Use TP.isReceiveOnAllInterfaces() instead
getBlockings() - Method in class org.jgroups.jmx.protocols.FC
 
getBlockings() - Method in interface org.jgroups.jmx.protocols.FCMBean
 
getBottommostProtocol(Protocol) - Method in class org.jgroups.stack.Configurator
 
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 interface org.jgroups.jmx.protocols.TPMBean
 
getBytesReceived() - Method in class org.jgroups.jmx.protocols.UNICAST
 
getBytesReceived() - Method in interface org.jgroups.jmx.protocols.UNICASTMBean
 
getBytesSent() - Method in class org.jgroups.jmx.protocols.TP
 
getBytesSent() - Method in interface org.jgroups.jmx.protocols.TPMBean
 
getBytesSent() - Method in class org.jgroups.jmx.protocols.UNICAST
 
getBytesSent() - Method in interface org.jgroups.jmx.protocols.UNICASTMBean
 
getCache() - Method in interface org.jgroups.blocks.NotificationBus.Consumer
Called on the coordinator to obtains its cache
getCache() - Method in class org.jgroups.blocks.NotificationBus
 
getCache() - Method in class org.jgroups.demos.NotificationBusDemo
 
getCacheFromCoordinator(long, int) - Method in class org.jgroups.blocks.NotificationBus
Determines the coordinator and asks it for its cache.
getCacheFromMember(Address, long, int) - Method in class org.jgroups.blocks.NotificationBus
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.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.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
 
getChannel() - Method in class org.jgroups.jmx.JChannel
 
getChannel() - Method in interface org.jgroups.jmx.JChannelMBean
 
getChannel() - Method in class org.jgroups.stack.ProtocolStack
 
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 interface org.jgroups.jmx.protocols.TPMBean
 
getChannelName() - Method in class org.jgroups.protocols.TP
 
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 interface 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
 
getConnExpireTime() - Method in class org.jgroups.jmx.protocols.TCP
 
getConnExpireTime() - Method in interface org.jgroups.jmx.protocols.TCPMBean
 
getConnExpireTime() - Method in class org.jgroups.protocols.TCP
 
getConnectionTable(long, long, InetAddress, InetAddress, int, int) - Method in class org.jgroups.protocols.TCP
 
getConnectionTable(long, long, InetAddress, InetAddress, int, int) - Method in class org.jgroups.protocols.TCP_NIO
 
getConnectorAddresses() - Method in class org.jgroups.protocols.UDP_NIO.ConnectorTable
Returns a list of local addresses (one for each Connector)
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.ViewId
returns the address of the member that issued this view
getCoordAddress() - Method in class org.jgroups.protocols.PingRsp
 
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 interface org.jgroups.jmx.protocols.FCMBean
 
getCreditRequestsSent() - Method in class org.jgroups.jmx.protocols.FC
 
getCreditRequestsSent() - Method in interface org.jgroups.jmx.protocols.FCMBean
 
getCreditResponsesReceived() - Method in class org.jgroups.jmx.protocols.FC
 
getCreditResponsesReceived() - Method in interface org.jgroups.jmx.protocols.FCMBean
 
getCreditResponsesSent() - Method in class org.jgroups.jmx.protocols.FC
 
getCreditResponsesSent() - Method in interface org.jgroups.jmx.protocols.FCMBean
 
getCurrentNumTries() - Method in class org.jgroups.jmx.protocols.FD
 
getCurrentNumTries() - Method in interface org.jgroups.jmx.protocols.FDMBean
 
getCurrentNumTries() - Method in class org.jgroups.protocols.FD
 
getData() - Method in class org.jgroups.blocks.ReplicationData
 
getDecree() - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
 
getDesKey() - Method in class org.jgroups.protocols.ENCRYPT
 
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 interface org.jgroups.jmx.protocols.pbcast.STABLEMBean
 
getDesiredAverageGossip() - Method in class org.jgroups.protocols.pbcast.STABLE
 
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 interface 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 interface org.jgroups.jmx.ProtocolMBean
 
getDownVector() - Method in class org.jgroups.protocols.QUEUE
 
getEndPort() - Method in class org.jgroups.jmx.protocols.TCP
 
getEndPort() - Method in interface org.jgroups.jmx.protocols.TCPMBean
 
getEndPort() - Method in class org.jgroups.protocols.TCP
 
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.jmx.protocols.FRAG2
 
getFragSize() - Method in interface org.jgroups.jmx.protocols.FRAG2MBean
 
getFragSize() - Method in interface org.jgroups.jmx.protocols.FRAGMBean
 
getFragSize() - Method in class org.jgroups.protocols.FRAG
 
getFragSize() - Method in class org.jgroups.protocols.FRAG2
 
getGcLag() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
 
getGcLag() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
 
getGcLag() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
getGossipMessages() - Method in class org.jgroups.jmx.protocols.pbcast.STABLE
 
getGossipMessages() - Method in interface 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.blocks.ReplicatedTree
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 interface org.jgroups.jmx.JChannelMBean
 
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.ViewId
returns the lamport time of the view
getId() - Method in class org.jgroups.blocks.MethodCall
 
getId() - Method in class org.jgroups.blocks.Xid
 
getId() - Method in class org.jgroups.stack.LogicalAddress
 
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 interface org.jgroups.jmx.protocols.TPMBean
 
getIncomingQueueSize() - Method in class org.jgroups.protocols.TP
 
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 interface 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(boolean) - Static method in class org.jgroups.conf.ClassConfigurator
 
getInstance(URL) - Static method in class org.jgroups.conf.XmlConfigurator
 
getInstance(InputStream) - Static method in class org.jgroups.conf.XmlConfigurator
 
getInstance(Element) - Static method in class org.jgroups.conf.XmlConfigurator
 
getInstance() - Static method in class org.jgroups.persistence.PersistenceFactory
Singular public method to get access to any of the Persistence Manager implementations.
getInstance() - Static method in class org.jgroups.protocols.PERF_TP
 
getInstanceOldFormat(URL) - Static method in class org.jgroups.conf.XmlConfigurator
 
getInstanceOldFormat(InputStream) - 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 interface org.jgroups.jmx.protocols.pbcast.GMSMBean
 
getJoinRetryTimeout() - Method in class org.jgroups.protocols.pbcast.GMS
 
getJoinTimeout() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
 
getJoinTimeout() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
 
getJoinTimeout() - Method in class org.jgroups.protocols.pbcast.GMS
 
getKey() - Method in class org.jgroups.blocks.DistributedLockManager.LockDecree
Returns the key that should be used for Map lookup.
getKeyServerAddr() - Method in class org.jgroups.protocols.ENCRYPT
 
getKeyStoreName() - Method in class org.jgroups.protocols.ENCRYPT
 
getKeys(String) - Method in class org.jgroups.blocks.ReplicatedTree
Gets the keys of the data map.
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.Message
Returns the number of bytes in the buffer
getLength() - Method in class org.jgroups.util.Buffer
 
getLinks() - Method in class org.jgroups.blocks.LogicalLink
 
getListener() - Method in class org.jgroups.blocks.PullPushAdapter
 
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.JChannel
returns the local address of the channel returns null if the channel is closed
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.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.JChannel
 
getLocalAddress() - Method in interface org.jgroups.jmx.JChannelMBean
 
getLocalAddress() - Method in class org.jgroups.jmx.protocols.FD
 
getLocalAddress() - Method in interface org.jgroups.jmx.protocols.FDMBean
 
getLocalAddress() - Method in class org.jgroups.jmx.protocols.FD_SOCK
 
getLocalAddress() - Method in interface org.jgroups.jmx.protocols.FD_SOCKMBean
 
getLocalAddress() - Method in class org.jgroups.jmx.protocols.TP
 
getLocalAddress() - Method in interface org.jgroups.jmx.protocols.TPMBean
 
getLocalAddress() - Method in class org.jgroups.jmx.protocols.UNICAST
 
getLocalAddress() - Method in interface org.jgroups.jmx.protocols.UNICASTMBean
 
getLocalAddress() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
 
getLocalAddress() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
 
getLocalAddress() - Method in class org.jgroups.protocols.FD
 
getLocalAddress() - Method in class org.jgroups.protocols.FD_SOCK
 
getLocalAddress() - Method in class org.jgroups.protocols.TP
 
getLocalAddress() - Method in class org.jgroups.protocols.UDP_NIO.Connector
 
getLocalAddress() - Method in class org.jgroups.protocols.UNICAST
 
getLocalAddress() - Method in class org.jgroups.protocols.pbcast.GMS
 
getLocalAddressAsString() - Method in class org.jgroups.jmx.JChannel
 
getLocalAddressAsString() - Method in interface org.jgroups.jmx.JChannelMBean
 
getLocalPort() - Method in class org.jgroups.blocks.Link
 
getLocal_addr() - Method in class org.jgroups.protocols.ENCRYPT
 
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
 
getMBeanServerName() - Method in class org.jgroups.jmx.JChannel
 
getMagicNumber(Class) - Method in class org.jgroups.conf.ClassConfigurator
Returns the magic number for the class.
getMagicNumber() - Method in class org.jgroups.conf.ClassMap
 
getMagicNumberFromObjectStreamClass(ObjectStreamClass) - Method in class org.jgroups.conf.ClassConfigurator
 
getMarshaller() - Method in class org.jgroups.blocks.RpcDispatcher
 
getMaxBlockTime() - Method in class org.jgroups.jmx.protocols.FC
 
getMaxBlockTime() - Method in interface org.jgroups.jmx.protocols.FCMBean
 
getMaxBlockTime() - Method in class org.jgroups.protocols.FC
 
getMaxBundleSize() - Method in class org.jgroups.jmx.protocols.TP
 
getMaxBundleSize() - Method in interface org.jgroups.jmx.protocols.TPMBean
 
getMaxBundleSize() - Method in class org.jgroups.protocols.TP
 
getMaxBundleTimeout() - Method in class org.jgroups.jmx.protocols.TP
 
getMaxBundleTimeout() - Method in interface org.jgroups.jmx.protocols.TPMBean
 
getMaxBundleTimeout() - Method in class org.jgroups.protocols.TP
 
getMaxBytes() - Method in class org.jgroups.jmx.protocols.pbcast.STABLE
 
getMaxBytes() - Method in interface org.jgroups.jmx.protocols.pbcast.STABLEMBean
 
getMaxBytes() - Method in class org.jgroups.protocols.pbcast.STABLE
 
getMaxCredits() - Method in class org.jgroups.jmx.protocols.FC
 
getMaxCredits() - Method in interface org.jgroups.jmx.protocols.FCMBean
 
getMaxCredits() - Method in class org.jgroups.protocols.FC
 
getMaxInterval() - Method in class org.jgroups.jmx.protocols.MERGE2
 
getMaxInterval() - Method in interface org.jgroups.jmx.protocols.MERGE2MBean
 
getMaxInterval() - Method in class org.jgroups.protocols.MERGE2
 
getMaxTries() - Method in class org.jgroups.jmx.protocols.FD
 
getMaxTries() - Method in interface org.jgroups.jmx.protocols.FDMBean
 
getMaxTries() - Method in class org.jgroups.protocols.FD
 
getMaxXmitBufSize() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
 
getMaxXmitBufSize() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
 
getMaxXmitBufSize() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
getMaxXmitBufSize() - Method in class org.jgroups.stack.NakReceiverWindow
 
getMaxXmitSize() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
 
getMaxXmitSize() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
 
getMaxXmitSize() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
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 interface org.jgroups.jmx.protocols.MPINGMBean
 
getMcastAddr() - Method in class org.jgroups.protocols.MPING
 
getMcastPort() - Method in class org.jgroups.jmx.protocols.MPING
 
getMcastPort() - Method in interface org.jgroups.jmx.protocols.MPINGMBean
 
getMcastPort() - Method in class org.jgroups.protocols.MPING
 
getMember() - Method in class org.jgroups.SuspectEvent
 
getMembers() - Method in class org.jgroups.Membership
returns a copy (clone) of the members in this membership.
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() - Method in class org.jgroups.blocks.ReplicatedTree
 
getMembers() - Method in class org.jgroups.jmx.protocols.FD
 
getMembers() - Method in interface org.jgroups.jmx.protocols.FDMBean
 
getMembers() - Method in class org.jgroups.jmx.protocols.FD_SOCK
 
getMembers() - Method in interface org.jgroups.jmx.protocols.FD_SOCKMBean
 
getMembers() - Method in class org.jgroups.jmx.protocols.UNICAST
 
getMembers() - Method in interface org.jgroups.jmx.protocols.UNICASTMBean
 
getMembers() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
 
getMembers() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
 
getMembers() - Method in class org.jgroups.protocols.FD
 
getMembers() - Method in class org.jgroups.protocols.FD_SOCK
 
getMembers() - Method in class org.jgroups.protocols.UNICAST
 
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.protocols.pbcast.GMS
 
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).
getMessagesInList(List) - Method in class org.jgroups.stack.NakReceiverWindow
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 interface org.jgroups.jmx.protocols.TPMBean
 
getMessagesReceived() - Method in class org.jgroups.jmx.protocols.UNICAST
 
getMessagesReceived() - Method in interface org.jgroups.jmx.protocols.UNICASTMBean
 
getMessagesSent() - Method in class org.jgroups.jmx.protocols.TP
 
getMessagesSent() - Method in interface org.jgroups.jmx.protocols.TPMBean
 
getMessagesSent() - Method in class org.jgroups.jmx.protocols.UNICAST
 
getMessagesSent() - Method in interface 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 interface org.jgroups.jmx.protocols.FCMBean
 
getMinCredits() - Method in class org.jgroups.protocols.FC
 
getMinInterval() - Method in class org.jgroups.jmx.protocols.MERGE2
 
getMinInterval() - Method in interface org.jgroups.jmx.protocols.MERGE2MBean
 
getMinInterval() - Method in class org.jgroups.protocols.MERGE2
 
getMinThreshold() - Method in class org.jgroups.jmx.protocols.FC
 
getMinThreshold() - Method in interface org.jgroups.jmx.protocols.FCMBean
 
getMinThreshold() - Method in class org.jgroups.protocols.FC
 
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 interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
 
getMissingMessagesReceived() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
getMode() - Method in class org.jgroups.blocks.MethodCall
 
getMode() - Method in class org.jgroups.blocks.Xid
 
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.blocks.RpcDispatcher
 
getName() - Method in class org.jgroups.conf.ProtocolParameter
 
getName() - Method in class org.jgroups.conf.XmlConfigurator
 
getName() - Method in class org.jgroups.jmx.Protocol
 
getName() - Method in interface org.jgroups.jmx.ProtocolMBean
 
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.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.FLOWCONTROL
 
getName() - Method in class org.jgroups.protocols.FLOW_CONTROL
 
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.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.MPING
 
getName() - Method in class org.jgroups.protocols.MessageProtocolEXAMPLE
 
getName() - Method in class org.jgroups.protocols.NAKACK
 
getName() - Method in class org.jgroups.protocols.PARTITIONER
All protocol names have to be unique !
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.protocols.QUEUE
All protocol names have to be unique !
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.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.TCPGOSSIP
 
getName() - Method in class org.jgroups.protocols.TCPPING
 
getName() - Method in class org.jgroups.protocols.TCP_NIO
 
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.protocols.pbcast.FD
 
getName() - Method in class org.jgroups.protocols.pbcast.GMS
 
getName() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
getName() - Method in class org.jgroups.protocols.pbcast.PBCAST
 
getName() - Method in class org.jgroups.protocols.pbcast.STABLE
 
getName() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
All protocol names have to be unique !
getName() - Method in class org.jgroups.stack.Protocol
 
getName() - Method in class org.jgroups.stack.ProtocolStack
 
getName() - Method in class org.jgroups.stack.RpcProtocol
 
getNegativeVotes() - Method in class org.jgroups.blocks.VotingAdapter.VoteResult
 
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
 
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 interface org.jgroups.jmx.protocols.pbcast.GMSMBean
 
getNumMembers() - Method in class org.jgroups.protocols.pbcast.GMS
 
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 interface 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 interface org.jgroups.jmx.protocols.FDMBean
 
getNumSuspectEventsGenerated() - Method in class org.jgroups.jmx.protocols.FD_SOCK
 
getNumSuspectEventsGenerated() - Method in interface org.jgroups.jmx.protocols.FD_SOCKMBean
 
getNumSuspectEventsGenerated() - Method in class org.jgroups.protocols.FD
 
getNumSuspectEventsGenerated() - Method in class org.jgroups.protocols.FD_SOCK
 
getNumSuspects() - Method in class org.jgroups.blocks.GroupRequest
 
getNumViewsAdjusted() - Method in class org.jgroups.jmx.protocols.VIEW_SYNC
 
getNumViewsAdjusted() - Method in interface org.jgroups.jmx.protocols.VIEW_SYNCMBean
 
getNumViewsAdjusted() - Method in class org.jgroups.protocols.VIEW_SYNC
 
getNumViewsSent() - Method in class org.jgroups.jmx.protocols.VIEW_SYNC
 
getNumViewsSent() - Method in interface org.jgroups.jmx.protocols.VIEW_SYNCMBean
 
getNumViewsSent() - Method in class org.jgroups.protocols.VIEW_SYNC
 
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 interface org.jgroups.jmx.protocols.FDMBean
 
getNumberOfHeartbeatsSent() - Method in class org.jgroups.protocols.FD
 
getNumberOfReceivedFragments() - Method in class org.jgroups.jmx.protocols.FRAG
 
getNumberOfReceivedFragments() - Method in class org.jgroups.jmx.protocols.FRAG2
 
getNumberOfReceivedFragments() - Method in interface org.jgroups.jmx.protocols.FRAG2MBean
 
getNumberOfReceivedFragments() - Method in interface org.jgroups.jmx.protocols.FRAGMBean
 
getNumberOfReceivedFragments() - Method in class org.jgroups.protocols.FRAG
 
getNumberOfReceivedFragments() - Method in class org.jgroups.protocols.FRAG2
 
getNumberOfReceivedMessages() - Method in class org.jgroups.jmx.protocols.FRAG
 
getNumberOfReceivedMessages() - Method in class org.jgroups.jmx.protocols.FRAG2
 
getNumberOfReceivedMessages() - Method in interface org.jgroups.jmx.protocols.FRAG2MBean
 
getNumberOfReceivedMessages() - Method in interface org.jgroups.jmx.protocols.FRAGMBean
 
getNumberOfReceivedMessages() - Method in class org.jgroups.protocols.FRAG
 
getNumberOfReceivedMessages() - Method in class org.jgroups.protocols.FRAG2
 
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.jmx.protocols.FRAG2
 
getNumberOfSentFragments() - Method in interface org.jgroups.jmx.protocols.FRAG2MBean
 
getNumberOfSentFragments() - Method in interface org.jgroups.jmx.protocols.FRAGMBean
 
getNumberOfSentFragments() - Method in class org.jgroups.protocols.FRAG
 
getNumberOfSentFragments() - Method in class org.jgroups.protocols.FRAG2
 
getNumberOfSentMessages() - Method in class org.jgroups.jmx.protocols.FRAG
 
getNumberOfSentMessages() - Method in class org.jgroups.jmx.protocols.FRAG2
 
getNumberOfSentMessages() - Method in interface org.jgroups.jmx.protocols.FRAG2MBean
 
getNumberOfSentMessages() - Method in interface org.jgroups.jmx.protocols.FRAGMBean
 
getNumberOfSentMessages() - Method in class org.jgroups.protocols.FRAG
 
getNumberOfSentMessages() - Method in class org.jgroups.protocols.FRAG2
 
getNumberOfStateBytesSent() - Method in class org.jgroups.jmx.protocols.pbcast.STATE_TRANSFER
 
getNumberOfStateBytesSent() - Method in interface org.jgroups.jmx.protocols.pbcast.STATE_TRANSFERMBean
 
getNumberOfStateBytesSent() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
getNumberOfStateRequests() - Method in class org.jgroups.jmx.protocols.pbcast.STATE_TRANSFER
 
getNumberOfStateRequests() - Method in interface org.jgroups.jmx.protocols.pbcast.STATE_TRANSFERMBean
 
getNumberOfStateRequests() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
getNumberOfTasksInTimer() - Method in class org.jgroups.JChannel
 
getNumberOfTasksInTimer() - Method in class org.jgroups.jmx.JChannel
 
getNumberOfTasksInTimer() - Method in interface 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 interface org.jgroups.jmx.protocols.pbcast.GMSMBean
 
getNumberOfViews() - Method in class org.jgroups.protocols.pbcast.GMS
 
getObject() - Method in class org.jgroups.Message
 
getObjectName() - Method in class org.jgroups.jmx.JChannel
 
getObjectName() - Method in interface org.jgroups.jmx.JChannelMBean
 
getObjectStreamClassFromMagicNumber(int) - Method in class org.jgroups.conf.ClassConfigurator
 
getOffset() - Method in class org.jgroups.Message
Returns the offset into the buffer at which the data starts
getOffset() - Method in class org.jgroups.util.Buffer
 
getOpenConnections() - Method in class org.jgroups.jmx.protocols.TCP
 
getOpenConnections() - Method in interface org.jgroups.jmx.protocols.TCPMBean
 
getOpenConnections() - Method in class org.jgroups.protocols.TCP
 
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 interface org.jgroups.jmx.protocols.TPMBean
 
getOutgoingQueueMaxSize() - Method in class org.jgroups.protocols.TP
 
getOutgoingQueueSize() - Method in class org.jgroups.jmx.protocols.TP
 
getOutgoingQueueSize() - Method in interface org.jgroups.jmx.protocols.TPMBean
 
getOutgoingQueueSize() - Method in class org.jgroups.protocols.TP
 
getOverhead() - Method in class org.jgroups.jmx.protocols.FRAG2
 
getOverhead() - Method in interface org.jgroups.jmx.protocols.FRAG2MBean
 
getOverhead() - Method in class org.jgroups.protocols.FRAG2
 
getOwnerIndex() - Method in class org.jgroups.protocols.VectorTime
Returns owner index in this VectorTime clock
getParameterString() - Method in class org.jgroups.conf.ProtocolParameter
 
getParameterStringXml() - Method in class org.jgroups.conf.ProtocolParameter
 
getParameters() - Method in class org.jgroups.conf.ProtocolData
 
getParametersAsArray() - Method in class org.jgroups.conf.ProtocolData
 
getPendingRetransmissionRequests() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
 
getPendingRetransmissionRequests() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
 
getPendingRetransmissionRequests() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
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.
getPingDest() - Method in class org.jgroups.jmx.protocols.FD
 
getPingDest() - Method in interface org.jgroups.jmx.protocols.FDMBean
 
getPingDest() - Method in class org.jgroups.jmx.protocols.FD_SOCK
 
getPingDest() - Method in interface org.jgroups.jmx.protocols.FD_SOCKMBean
 
getPingDest() - Method in class org.jgroups.protocols.FD
 
getPingDest() - Method in class org.jgroups.protocols.FD_SOCK
 
getPingRequests() - Method in class org.jgroups.jmx.protocols.Discovery
 
getPingRequests() - Method in interface org.jgroups.jmx.protocols.DiscoveryMBean
 
getPingableMembers() - Method in class org.jgroups.jmx.protocols.FD
 
getPingableMembers() - Method in interface org.jgroups.jmx.protocols.FDMBean
 
getPingableMembers() - Method in class org.jgroups.jmx.protocols.FD_SOCK
 
getPingableMembers() - Method in interface org.jgroups.jmx.protocols.FD_SOCKMBean
 
getPingableMembers() - Method in class org.jgroups.protocols.FD
 
getPingableMembers() - Method in class org.jgroups.protocols.FD_SOCK
 
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 interface org.jgroups.jmx.protocols.TCP_NIOMBean
 
getProcessorKeepAliveTime() - Method in class org.jgroups.protocols.TCP_NIO
 
getProcessorMaxThreads() - Method in class org.jgroups.jmx.protocols.TCP_NIO
 
getProcessorMaxThreads() - Method in interface org.jgroups.jmx.protocols.TCP_NIOMBean
 
getProcessorMaxThreads() - Method in class org.jgroups.protocols.TCP_NIO
 
getProcessorMinThreads() - Method in class org.jgroups.jmx.protocols.TCP_NIO
 
getProcessorMinThreads() - Method in interface org.jgroups.jmx.protocols.TCP_NIOMBean
 
getProcessorMinThreads() - Method in class org.jgroups.protocols.TCP_NIO
 
getProcessorQueueSize() - Method in class org.jgroups.jmx.protocols.TCP_NIO
 
getProcessorQueueSize() - Method in interface org.jgroups.jmx.protocols.TCP_NIOMBean
 
getProcessorQueueSize() - Method in class org.jgroups.protocols.TCP_NIO
 
getProcessorThreads() - Method in class org.jgroups.jmx.protocols.TCP_NIO
 
getProcessorThreads() - Method in interface org.jgroups.jmx.protocols.TCP_NIOMBean
 
getProcessorThreads() - Method in class org.jgroups.protocols.TCP_NIO
 
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 interface org.jgroups.jmx.JChannelMBean
 
getProperties() - Method in class org.jgroups.stack.Configurator.ProtocolConfiguration
 
getProperties() - Method in class org.jgroups.stack.Protocol
 
getPropertiesAsString() - Method in class org.jgroups.jmx.Protocol
 
getPropertiesAsString() - Method in interface org.jgroups.jmx.ProtocolMBean
 
getProtocolName() - Method in class org.jgroups.conf.ProtocolData
 
getProtocolName() - Method in class org.jgroups.stack.Configurator.ProtocolConfiguration
 
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 interface 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 interface org.jgroups.conf.ProtocolStackConfigurator
 
getProtocolStackString(boolean) - Method in class org.jgroups.conf.XmlConfigurator
 
getProtocolStackString() - Method in class org.jgroups.conf.XmlConfigurator
 
getProtocolString(boolean) - Method in class org.jgroups.conf.ProtocolData
 
getProtocolString() - Method in class org.jgroups.conf.ProtocolData
 
getProtocolStringNewXml() - 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.
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.Message
Returns a reference to the payload (byte buffer).
getRawBuffer() - Method in class org.jgroups.util.ExposedByteArrayOutputStream
 
getReaderThreads() - Method in class org.jgroups.jmx.protocols.TCP_NIO
 
getReaderThreads() - Method in interface org.jgroups.jmx.protocols.TCP_NIOMBean
 
getReaderThreads() - Method in class org.jgroups.protocols.TCP_NIO
 
getReaperInterval() - Method in class org.jgroups.jmx.protocols.TCP
 
getReaperInterval() - Method in interface org.jgroups.jmx.protocols.TCPMBean
 
getReaperInterval() - Method in class org.jgroups.protocols.TCP
 
getReason() - Method in class org.jgroups.blocks.VotingAdapter.FailureVoteResult
 
getReceiveBlockEvents() - Method in class org.jgroups.jmx.JChannel
 
getReceiveBlockEvents() - Method in interface org.jgroups.jmx.JChannelMBean
 
getReceiveBufferSize() - Method in class org.jgroups.blocks.ConnectionTable
 
getReceiveInterfaces() - Method in class org.jgroups.jmx.protocols.TP
 
getReceiveInterfaces() - Method in interface org.jgroups.jmx.protocols.TPMBean
 
getReceiveInterfaces() - Method in class org.jgroups.protocols.TP
 
getReceiveLocalMessages() - Method in class org.jgroups.jmx.JChannel
 
getReceiveLocalMessages() - Method in interface org.jgroups.jmx.JChannelMBean
 
getReceiveStateEvents() - Method in class org.jgroups.jmx.JChannel
 
getReceiveStateEvents() - Method in interface org.jgroups.jmx.JChannelMBean
 
getReceiveSuspectEvents() - Method in class org.jgroups.jmx.JChannel
 
getReceiveSuspectEvents() - Method in interface org.jgroups.jmx.JChannelMBean
 
getReceiveViewEvents() - Method in class org.jgroups.jmx.JChannel
 
getReceiveViewEvents() - Method in interface org.jgroups.jmx.JChannelMBean
 
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 interface org.jgroups.jmx.JChannelMBean
 
getReceivedBytes() - Method in class org.jgroups.jmx.protocols.STATS
 
getReceivedBytes() - Method in interface org.jgroups.jmx.protocols.STATSMBean
 
getReceivedBytes() - Method in class org.jgroups.protocols.STATS
 
getReceivedMcastBytes() - Method in class org.jgroups.jmx.protocols.STATS
 
getReceivedMcastBytes() - Method in interface org.jgroups.jmx.protocols.STATSMBean
 
getReceivedMcastBytes() - Method in class org.jgroups.protocols.STATS
 
getReceivedMcastMessages() - Method in class org.jgroups.jmx.protocols.STATS
 
getReceivedMcastMessages() - Method in interface org.jgroups.jmx.protocols.STATSMBean
 
getReceivedMcastMessages() - Method in class org.jgroups.protocols.STATS
 
getReceivedMessages() - Method in class org.jgroups.JChannel
 
getReceivedMessages() - Method in class org.jgroups.jmx.JChannel
 
getReceivedMessages() - Method in interface org.jgroups.jmx.JChannelMBean
 
getReceivedMessages() - Method in class org.jgroups.jmx.protocols.STATS
 
getReceivedMessages() - Method in interface org.jgroups.jmx.protocols.STATSMBean
 
getReceivedMessages() - Method in class org.jgroups.protocols.STATS
 
getReceivedTableSize() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
 
getReceivedTableSize() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
 
getReceivedTableSize() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
getReceivedUnicastBytes() - Method in class org.jgroups.jmx.protocols.STATS
 
getReceivedUnicastBytes() - Method in interface org.jgroups.jmx.protocols.STATSMBean
 
getReceivedUnicastBytes() - Method in class org.jgroups.protocols.STATS
 
getReceivedUnicastMessages() - Method in class org.jgroups.jmx.protocols.STATS
 
getReceivedUnicastMessages() - Method in interface org.jgroups.jmx.protocols.STATSMBean
 
getReceivedUnicastMessages() - Method in class org.jgroups.protocols.STATS
 
getReceiver() - Method in class org.jgroups.protocols.UDP_NIO.ConnectorTable
 
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.
getResultWithTimeout(long) - Method in class org.jgroups.util.Promise
Blocks until a result is available, or timeout milliseconds have elapsed
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.
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
 
getSendInterfaces() - Method in class org.jgroups.jmx.protocols.TP
 
getSendInterfaces() - Method in interface org.jgroups.jmx.protocols.TPMBean
 
getSendInterfaces() - Method in class org.jgroups.protocols.TP
 
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
getSentBytes() - Method in class org.jgroups.JChannel
 
getSentBytes() - Method in class org.jgroups.jmx.JChannel
 
getSentBytes() - Method in interface org.jgroups.jmx.JChannelMBean
 
getSentBytes() - Method in class org.jgroups.jmx.protocols.STATS
 
getSentBytes() - Method in interface org.jgroups.jmx.protocols.STATSMBean
 
getSentBytes() - Method in class org.jgroups.protocols.STATS
 
getSentMcastBytes() - Method in class org.jgroups.jmx.protocols.STATS
 
getSentMcastBytes() - Method in interface org.jgroups.jmx.protocols.STATSMBean
 
getSentMcastBytes() - Method in class org.jgroups.protocols.STATS
 
getSentMcastMessages() - Method in class org.jgroups.jmx.protocols.STATS
 
getSentMcastMessages() - Method in interface org.jgroups.jmx.protocols.STATSMBean
 
getSentMcastMessages() - Method in class org.jgroups.protocols.STATS
 
getSentMessages() - Method in class org.jgroups.JChannel
 
getSentMessages() - Method in class org.jgroups.jmx.JChannel
 
getSentMessages() - Method in interface org.jgroups.jmx.JChannelMBean
 
getSentMessages() - Method in class org.jgroups.jmx.protocols.STATS
 
getSentMessages() - Method in interface org.jgroups.jmx.protocols.STATSMBean
 
getSentMessages() - Method in class org.jgroups.protocols.STATS
 
getSentTableSize() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
 
getSentTableSize() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
 
getSentTableSize() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
getSentUnicastBytes() - Method in class org.jgroups.jmx.protocols.STATS
 
getSentUnicastBytes() - Method in interface org.jgroups.jmx.protocols.STATSMBean
 
getSentUnicastBytes() - Method in class org.jgroups.protocols.STATS
 
getSentUnicastMessages() - Method in class org.jgroups.jmx.protocols.STATS
 
getSentUnicastMessages() - Method in interface org.jgroups.jmx.protocols.STATSMBean
 
getSentUnicastMessages() - Method in class org.jgroups.protocols.STATS
 
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(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(URL) - Static method in class org.jgroups.conf.ConfiguratorFactory
Returns a protocol stack configurator based on the XML configuration provided at the specified URL.
getStackConfigurator(Element) - Static method in class org.jgroups.conf.ConfiguratorFactory
Returns a protocol stack configurator based on the XML configuration provided by the specified XML element.
getStackConfigurator(String) - Static method in class org.jgroups.conf.ConfiguratorFactory
Returns a protocol stack configurator based on the provided properties string.
getStackConfigurator(Object) - Static method in class org.jgroups.conf.ConfiguratorFactory
Deprecated. Used by the JChannel(Object) constructor which has been deprecated.
getStackTrace(Throwable) - Static method in class org.jgroups.util.Util
 
getStartPort() - Method in class org.jgroups.jmx.protocols.TCP
 
getStartPort() - Method in interface org.jgroups.jmx.protocols.TCPMBean
 
getStartPort() - Method in class org.jgroups.protocols.TCP
 
getState(Address, long) - Method in class org.jgroups.Channel
Retrieve the state of the group.
getState(Address, long) - Method in class org.jgroups.JChannel
Retrieves the current group state.
getState() - Method in interface org.jgroups.MessageListener
Answers the group state; e.g., when joining.
getState() - Method in class org.jgroups.ReceiverAdapter
 
getState() - Method in class org.jgroups.blocks.DistributedHashtable
 
getState() - Method in class org.jgroups.blocks.DistributedQueue
 
getState() - Method in class org.jgroups.blocks.DistributedTree
Return a copy of the tree
getState() - Method in class org.jgroups.blocks.MessageListenerAdapter
Get state from state listener if present.
getState() - Method in class org.jgroups.blocks.NotificationBus
 
getState() - Method in class org.jgroups.blocks.ReplicatedHashtable
 
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.Chat
 
getState() - Method in class org.jgroups.demos.QuoteServer
 
getState() - Method in class org.jgroups.demos.wb.GraphPanel
 
getState() - Method in class org.jgroups.demos.wb.Whiteboard
 
getState(Address, long) - Method in class org.jgroups.jmx.JChannel
 
getState(Address, long) - Method in interface org.jgroups.jmx.JChannelMBean
 
getStatsEnabled() - Method in class org.jgroups.jmx.JChannel
 
getStatsEnabled() - Method in interface org.jgroups.jmx.JChannelMBean
 
getStatsEnabled() - Method in class org.jgroups.jmx.Protocol
 
getStatsEnabled() - Method in interface 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
 
getTTL() - Method in class org.jgroups.jmx.protocols.MPING
 
getTTL() - Method in interface org.jgroups.jmx.protocols.MPINGMBean
 
getTTL() - Method in class org.jgroups.protocols.MPING
 
getThread() - Method in class org.jgroups.util.ThreadPool
 
getTimeout() - Method in class org.jgroups.jmx.protocols.Discovery
 
getTimeout() - Method in interface org.jgroups.jmx.protocols.DiscoveryMBean
 
getTimeout() - Method in class org.jgroups.jmx.protocols.FD
 
getTimeout() - Method in interface org.jgroups.jmx.protocols.FDMBean
 
getTimeout() - Method in class org.jgroups.protocols.Discovery
 
getTimeout() - Method in class org.jgroups.protocols.FD
 
getTimestamp() - Method in class org.jgroups.stack.LogicalAddress
 
getTokenReceiverAddress() - Method in class org.jgroups.protocols.TOTAL_TOKEN
 
getTokenReceiverAddress() - Method in interface org.jgroups.protocols.ring.RingNode
 
getTokenReceiverAddress() - Method in class org.jgroups.protocols.ring.TcpRingNode
 
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 interface org.jgroups.jmx.protocols.FCMBean
 
getTotalTimeBlocked() - Method in class org.jgroups.protocols.FC
 
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.
getType() - Method in class org.jgroups.Event
 
getType() - Method in class org.jgroups.blocks.ReplicationData
 
getType() - Method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
 
getType() - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
getType() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
getType() - Method in class org.jgroups.protocols.ring.RingToken
 
getType() - Method in class org.jgroups.stack.GossipData
 
getUnackedMessages() - Method in class org.jgroups.jmx.protocols.UNICAST
 
getUnackedMessages() - Method in interface 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 interface org.jgroups.jmx.ProtocolMBean
 
getUpVector() - Method in class org.jgroups.protocols.QUEUE
 
getUseSendQueues() - Method in class org.jgroups.blocks.ConnectionTable
 
getUserName() - Method in class org.jgroups.demos.wb.UserInfoDialog
 
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.jmx.JChannel
 
getVersion() - Method in interface org.jgroups.jmx.JChannelMBean
 
getVersion() - Method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
 
getVid() - Method in class org.jgroups.View
returns the view ID of this view if this view was created with the empty constructur, null will be returned
getView() - Method in class org.jgroups.Channel
Gets the current view.
getView() - Method in class org.jgroups.JChannel
Returns the current view.
getView() - Method in class org.jgroups.jmx.JChannel
 
getView() - Method in interface org.jgroups.jmx.JChannelMBean
 
getView() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
 
getView() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
 
getView() - Method in class org.jgroups.protocols.pbcast.GMS
 
getView() - Method in class org.jgroups.protocols.pbcast.MergeData
 
getViewAsString() - Method in class org.jgroups.jmx.JChannel
 
getViewAsString() - Method in interface org.jgroups.jmx.JChannelMBean
 
getViewHandlerQueue() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
 
getViewHandlerQueue() - Method in interface 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 interface org.jgroups.jmx.protocols.TCP_NIOMBean
 
getWriterThreads() - Method in class org.jgroups.protocols.TCP_NIO
 
getXmitRequestsReceived() - Method in class org.jgroups.jmx.protocols.UNICAST
 
getXmitRequestsReceived() - Method in interface org.jgroups.jmx.protocols.UNICASTMBean
 
getXmitRequestsReceived() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
 
getXmitRequestsReceived() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
 
getXmitRequestsReceived() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
getXmitRequestsSent() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
 
getXmitRequestsSent() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
 
getXmitRequestsSent() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
getXmitResponsesReceived() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
 
getXmitResponsesReceived() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
 
getXmitResponsesReceived() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
getXmitResponsesSent() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
 
getXmitResponsesSent() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
 
getXmitResponsesSent() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
gms - Variable in class org.jgroups.protocols.GmsImpl
 
gms - Variable in class org.jgroups.protocols.pbcast.GmsImpl
 
go() - Method in class org.jgroups.demos.Draw
 
go() - Method in class org.jgroups.demos.Draw2Channels
 
go() - Method in class org.jgroups.demos.DrawRepl
 
go() - Method in class org.jgroups.demos.Gossip
 
go() - Method in class org.jgroups.demos.applets.DrawApplet
 
gossip(ViewId, long, long[], boolean[], Object) - Method in class org.jgroups.protocols.STABLE
Contains the highest sequence numbers as seen by sender
group_addr - Variable in class org.jgroups.protocols.GMS
 
group_addr - Variable in class org.jgroups.protocols.TcpHeader
 
group_addr - Variable in class org.jgroups.protocols.WANPIPE.WanPipeHeader
 
groupname - Variable in class org.jgroups.blocks.DistributedQueue
 
groupname - Static variable in class org.jgroups.demos.wb.Whiteboard
 

H

HDRS - class org.jgroups.protocols.HDRS.
Example of a protocol layer.
HDRS() - Constructor for class org.jgroups.protocols.HDRS
 
HDR_OVERHEAD - Static variable in class org.jgroups.Header
 
HEARD_FROM - Static variable in class org.jgroups.Event
 
HEARTBEAT - Static variable in class org.jgroups.protocols.FD.FdHeader
 
HEARTBEAT_ACK - Static variable in class org.jgroups.protocols.FD.FdHeader
 
HELLO - Static variable in class org.jgroups.protocols.MERGE.MergeHeader
 
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.
 
HTOTAL.HTotalHeader() - Constructor for class org.jgroups.protocols.HTOTAL.HTotalHeader
 
HTOTAL.HTotalHeader(Address, Address) - Constructor for class org.jgroups.protocols.HTOTAL.HTotalHeader
 
Header - class org.jgroups.Header.
Abstract base class for all headers to be added to a Message.
Header() - Constructor for class org.jgroups.Header
 
handle(Message) - Method in class org.jgroups.blocks.MessageDispatcher
 
handle(Message) - Method in class org.jgroups.blocks.ReplicationManager
 
handle(Message) - Method in interface org.jgroups.blocks.RequestHandler
 
handle(Message) - Method in class org.jgroups.blocks.RpcDispatcher
Message contains MethodCall.
handle(Message) - Method in class org.jgroups.protocols.FLOW_CONTROL
Called when a request for this protocol layer is received.
handle(Message) - Method in class org.jgroups.protocols.MessageProtocolEXAMPLE
Callback.
handle(Message) - Method in class org.jgroups.protocols.STATE_TRANSFER
 
handle(Message) - Method in class org.jgroups.stack.MessageProtocol
Processes a request destined for this layer.
handle(Message) - Method in class org.jgroups.stack.RpcProtocol
Message contains MethodCall.
handleCommit(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
 
handleDisconnect() - Method in class org.jgroups.protocols.Discovery
 
handleDisconnect() - Method in class org.jgroups.protocols.PING
 
handleDownEvent(Event) - Method in class org.jgroups.protocols.DEADLOCK
Callback.
handleDownEvent(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(Event) - Method in class org.jgroups.protocols.FLUSH
Callback.
handleDownEvent(Event) - Method in class org.jgroups.protocols.GMS
Callback.
handleDownEvent(Event) - Method in class org.jgroups.protocols.GmsImpl
 
handleDownEvent(Event) - Method in class org.jgroups.protocols.JMS
Handle down event, if it is not a Event.MSG type.
handleDownEvent(Event) - Method in class org.jgroups.protocols.MessageProtocolEXAMPLE
Callback.
handleDownEvent(Event) - Method in class org.jgroups.protocols.RpcProtocolEXAMPLE
Callback.
handleDownEvent(Event) - Method in class org.jgroups.protocols.STABLE
Callback.
handleDownEvent(Event) - Method in class org.jgroups.protocols.TCP
 
handleDownEvent(Event) - Method in class org.jgroups.protocols.TOTAL_TOKEN
 
handleDownEvent(Event) - Method in class org.jgroups.protocols.TP
 
handleDownEvent(Event) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
handleDownEvent(Event) - Method in class org.jgroups.stack.MessageProtocol
Handle down event.
handleDownEvent(Event) - Method in class org.jgroups.stack.RpcProtocol
Handle down event.
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(Message) - Method in class org.jgroups.protocols.TUNNEL
 
handleJoin(Address) - Method in class org.jgroups.protocols.ClientGmsImpl
 
handleJoin(Address) - Method in class org.jgroups.protocols.CoordGmsImpl
 
handleJoin(Address) - Method in class org.jgroups.protocols.GMS
 
handleJoin(Address) - Method in class org.jgroups.protocols.GmsImpl
 
handleJoin(Address) - Method in class org.jgroups.protocols.ParticipantGmsImpl
 
handleJoin(Address) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
 
handleJoin(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(Address) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
handleJoin(Address) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
 
handleJoinResponse(JoinRsp) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
 
handleJoinResponse(JoinRsp) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
 
handleJoinResponse(JoinRsp) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
handleJoinResponse(JoinRsp) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
 
handleLeave(Address, boolean) - Method in class org.jgroups.protocols.ClientGmsImpl
Returns false.
handleLeave(Address, boolean) - Method in class org.jgroups.protocols.CoordGmsImpl
Exclude mbr from the membership.
handleLeave(Address, boolean) - Method in class org.jgroups.protocols.GMS
 
handleLeave(Address, boolean) - Method in class org.jgroups.protocols.GmsImpl
 
handleLeave(Address, boolean) - Method in class org.jgroups.protocols.ParticipantGmsImpl
 
handleLeave(Address, boolean) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
Returns false.
handleLeave(Address, boolean) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
Exclude mbr from the membership.
handleLeave(Address, boolean) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
handleLeave(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(ViewId, Vector) - Method in class org.jgroups.protocols.ClientGmsImpl
Returns immediately.
handleMerge(ViewId, Vector) - Method in class org.jgroups.protocols.CoordGmsImpl
Invoked by another coordinator that asks to merge its view with mine.
handleMerge(ViewId, Vector) - Method in class org.jgroups.protocols.GMS
 
handleMerge(ViewId, Vector) - Method in class org.jgroups.protocols.GmsImpl
 
handleMerge(ViewId, Vector) - Method in class org.jgroups.protocols.ParticipantGmsImpl
 
handleMergeCancelled(ViewId) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
 
handleMergeCancelled(ViewId) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
handleMergeRequest(Address, 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(Address, ViewId) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
handleMergeRequest(Address, ViewId) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
 
handleMergeResponse(MergeData, ViewId) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
 
handleMergeResponse(MergeData, ViewId) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
handleMergeView(MergeData, ViewId) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
If merge_id is not equal to this.merge_id then discard.
handleMergeView(MergeData, ViewId) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
handleMessage(Message) - Method in class org.jgroups.blocks.PullPushAdapter
Check whether the message has an identifier.
handleNotification(Serializable) - Method in interface org.jgroups.blocks.NotificationBus.Consumer
 
handleNotification(Serializable) - Method in class org.jgroups.demos.NotificationBusDemo
 
handleRollback(Xid) - Method in class org.jgroups.blocks.ReplicationManager
 
handleSend(ReplicationData) - Method in class org.jgroups.blocks.ReplicationManager
 
handleSpecialDownEvent(Event) - Method in class org.jgroups.stack.Protocol
These are special internal events that should not be handled by protocols
handleSuspect(Address) - Method in class org.jgroups.protocols.ClientGmsImpl
Returns immediately.
handleSuspect(Address) - Method in class org.jgroups.protocols.CoordGmsImpl
 
handleSuspect(Address) - Method in class org.jgroups.protocols.GMS
 
handleSuspect(Address) - Method in class org.jgroups.protocols.GmsImpl
 
handleSuspect(Address) - Method in class org.jgroups.protocols.ParticipantGmsImpl
 
handleSuspect(Address) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
Returns immediately.
handleSuspect(Address) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
 
handleSuspect(Address) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
handleSuspect(Address) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
 
handleUpEvent(Event) - Method in class org.jgroups.protocols.ClientGmsImpl
 
handleUpEvent(Event) - Method in class org.jgroups.protocols.DEADLOCK
Callback.
handleUpEvent(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(Event) - Method in class org.jgroups.protocols.FLUSH
Callback.
handleUpEvent(Event) - Method in class org.jgroups.protocols.GMS
Callback.
handleUpEvent(Event) - Method in class org.jgroups.protocols.GmsImpl
 
handleUpEvent(Event) - Method in class org.jgroups.protocols.MessageProtocolEXAMPLE
Callback.
handleUpEvent(Event) - Method in class org.jgroups.protocols.RpcProtocolEXAMPLE
Callback.
handleUpEvent(Event) - Method in class org.jgroups.protocols.STABLE
Callback.
handleUpEvent(Event) - Method in class org.jgroups.protocols.TOTAL_TOKEN
 
handleUpEvent(Event) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
 
handleUpEvent(Event) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
handleUpEvent(Event) - Method in class org.jgroups.stack.MessageProtocol
Handle up event.
handleUpEvent(Event) - Method in class org.jgroups.stack.RpcProtocol
Handle up event.
handleView(View) - Method in class org.jgroups.util.AckCollector
 
handleViewChange(ViewId, Vector) - Method in class org.jgroups.protocols.ClientGmsImpl
Install the first view in which we are a member.
handleViewChange(ViewId, Vector) - Method in class org.jgroups.protocols.CoordGmsImpl
 
handleViewChange(ViewId, Vector) - Method in class org.jgroups.protocols.GMS
 
handleViewChange(ViewId, Vector) - Method in class org.jgroups.protocols.GmsImpl
 
handleViewChange(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.
handleViewChange(View, Digest) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
Does nothing.
handleViewChange(View, Digest) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
Called by the GMS when a VIEW is received.
handleViewChange(View, Digest) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
handleViewChange(View, Digest) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
If we are leaving, we have to wait for the view change (last msg in the current view) that excludes us before we can leave.
hasResult() - Method in class org.jgroups.util.Promise
Checks whether result is available.
hashCode() - Method in class org.jgroups.ViewId
 
hashCode() - Method in class org.jgroups.blocks.DistributedLockManager.LockDecree
This is hashcode from the java.lang.Long class.
hashCode() - Method in class org.jgroups.blocks.Link
 
hashCode() - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseVoteWrapper
 
hashCode() - Method in class org.jgroups.blocks.Xid
 
hashCode() - Method in class org.jgroups.conf.ClassMap
 
hashCode() - Method in class org.jgroups.conf.ProtocolData
 
hashCode() - Method in class org.jgroups.conf.ProtocolParameter
 
hashCode() - Method in class org.jgroups.protocols.JMS.JMSAddress
Get the hash code of this address.
hashCode() - Method in class org.jgroups.protocols.WanPipeAddress
 
hashCode() - Method in class org.jgroups.protocols.pbcast.Gossip
 
hashCode() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
hashCode() - Method in class org.jgroups.stack.IpAddress
 
hashCode() - Method in class org.jgroups.stack.LogicalAddress
 
head - Variable in class org.jgroups.util.List
 
headers - Variable in class org.jgroups.Message
Map
height - Variable in class org.jgroups.demos.wb.Node
 
helvetica_12 - Static variable in class org.jgroups.debug.Debugger
 
high - Variable in class org.jgroups.util.Range
 
highSeqnoAt(Address) - Method in class org.jgroups.protocols.pbcast.Digest
 
highSeqnoSeenAt(Address) - Method in class org.jgroups.protocols.pbcast.Digest
 
high_seqno - Variable in class org.jgroups.protocols.pbcast.Digest.Entry
 
high_seqno_seen - Variable in class org.jgroups.protocols.pbcast.Digest.Entry
 
highest_seqnos - Variable in class org.jgroups.protocols.Digest
 
host - Variable in class org.jgroups.stack.LogicalAddress
 

I

ID - Static variable in class org.jgroups.blocks.MethodCall
Use an ID to map to a method
INIT_CONNECTION_FACTORY - Static variable in class org.jgroups.protocols.JMS
 
INIT_JNDI_CONTEXT - Static variable in class org.jgroups.protocols.JMS
 
INIT_PROVIDER_URL - Static variable in class org.jgroups.protocols.JMS
 
INIT_TOPIC_NAME - Static variable in class org.jgroups.protocols.JMS
 
INSTALL_MERGE_VIEW - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
INT_SIZE - Static variable in class org.jgroups.Global
Value is 4.
I_HAVE_SOCK - Static variable in class org.jgroups.protocols.FD_SOCK.FdHeader
 
Interval - class org.jgroups.stack.Interval.
Manages retransmission timeouts.
Interval(long[]) - Constructor for class org.jgroups.stack.Interval
 
IpAddress - class org.jgroups.stack.IpAddress.
Network-dependent address (Internet).
IpAddress() - Constructor for class org.jgroups.stack.IpAddress
 
IpAddress(String, int) - Constructor for class org.jgroups.stack.IpAddress
 
IpAddress(InetAddress, int) - Constructor for class org.jgroups.stack.IpAddress
 
IpAddress(int) - Constructor for class org.jgroups.stack.IpAddress
 
IpAddress(int, boolean) - Constructor for class org.jgroups.stack.IpAddress
 
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.
id - Variable in class org.jgroups.blocks.MessageDispatcher
 
id - Variable in class org.jgroups.blocks.RequestCorrelator.Header
The id of this request to distinguish among other requests from the same RequestCorrelator
id - Variable in class org.jgroups.blocks.Xid
 
id - Variable in class org.jgroups.protocols.FragHeader
 
id - Variable in class org.jgroups.stack.LogicalAddress
 
impl_mutex - Variable in class org.jgroups.protocols.GMS
 
increment() - Method in class org.jgroups.protocols.VectorTime
Incerements owners current vector value by 1
incrementHighSeqno(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(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.blocks.ConnectionTable
 
init() - Method in class org.jgroups.blocks.ConnectionTableNIO
 
init(long) - Method in class org.jgroups.blocks.DistributedHashtable
 
init() - Method in class org.jgroups.blocks.DistributedQueue
 
init() - Method in class org.jgroups.conf.ClassConfigurator
 
init() - Method in class org.jgroups.demos.applets.DrawApplet
 
init() - Method in class org.jgroups.demos.wb.Whiteboard
 
init(InputStream) - Method in class org.jgroups.persistence.DBPersistenceManager
used to intitiailize complete DB access.
init() - Method in class org.jgroups.protocols.AUTOCONF
 
init() - Method in class org.jgroups.protocols.BSH
 
init() - Method in class org.jgroups.protocols.COMPRESS
 
init() - Method in class org.jgroups.protocols.ClientGmsImpl
 
init() - Method in class org.jgroups.protocols.CoordGmsImpl
 
init() - Method in class org.jgroups.protocols.DUMMY_TP
 
init() - Method in class org.jgroups.protocols.ENCRYPT
 
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
 
init() - Method in class org.jgroups.protocols.FD_SOCK
 
init() - Method in class org.jgroups.protocols.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.PERF_TP
 
init() - Method in class org.jgroups.protocols.ParticipantGmsImpl
 
init() - Method in class org.jgroups.protocols.SIZE
 
init() - Method in class org.jgroups.protocols.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.protocols.pbcast.ClientGmsImpl
 
init() - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
 
init() - Method in class org.jgroups.protocols.pbcast.GMS
 
init() - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
init() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
init() - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
 
init() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
init(String, List) - Method in class org.jgroups.stack.LogicalAddress
 
init() - Method in class org.jgroups.stack.Protocol
Called after instance has been created (null constructor) and before protocol is started.
initKeyPair() - Method in class org.jgroups.protocols.ENCRYPT
Generates the public/private key pair from the init params
initSymKey() - Static method in class org.jgroups.demos.KeyStoreGenerator
 
initSymKey() - Method in class org.jgroups.protocols.ENCRYPT
Used to initialise the symmetric key if none is supplied in a keystore.
insertProtocol(Protocol, int, String, ProtocolStack) - Method in class org.jgroups.stack.Configurator
Inserts an already created (and initialized) protocol into the protocol list.
insertProtocol(Protocol, int, String) - Method in class org.jgroups.stack.ProtocolStack
Inserts an already created (and initialized) protocol into the protocol list.
installTransitionalView(Vector) - Method in class org.jgroups.protocols.TOTAL_TOKEN
 
installView(ViewId, Vector) - Method in class org.jgroups.protocols.GMS
Assigns the new ltime.
installView(View, Digest) - Method in class org.jgroups.protocols.pbcast.GMS
Sets the new view and sends a VIEW_CHANGE event up and down the stack.
installView(View) - Method in class org.jgroups.protocols.pbcast.GMS
Sets the new view and sends a VIEW_CHANGE event up and down the stack.
internalQueue - Variable in class org.jgroups.blocks.DistributedQueue
 
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
 
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 interface org.jgroups.jmx.protocols.MPINGMBean
 
isBindToAllInterfaces() - Method in class org.jgroups.protocols.MPING
 
isBlocked() - Method in class org.jgroups.jmx.protocols.FC
 
isBlocked() - Method in interface org.jgroups.jmx.protocols.FCMBean
 
isBlocked() - Method in class org.jgroups.protocols.FC
 
isCausallyNext(TransportedVectorTime) - Method in class org.jgroups.protocols.VectorTime
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 interface 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.blocks.NotificationBus
 
isCoordinator() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
 
isCoordinator() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
 
isCoordinator() - Method in class org.jgroups.protocols.pbcast.GMS
 
isDiscardDeliveredMsgs() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
 
isDiscardDeliveredMsgs() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
 
isDiscardDeliveredMsgs() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
isDiscardIncompatiblePackets() - Method in class org.jgroups.jmx.protocols.TP
 
isDiscardIncompatiblePackets() - Method in interface org.jgroups.jmx.protocols.TPMBean
 
isDiscardIncompatiblePackets() - Method in class org.jgroups.protocols.TP
 
isDone() - Method in class org.jgroups.blocks.GroupRequest
 
isEnableBundling() - Method in class org.jgroups.jmx.protocols.TP
 
isEnableBundling() - Method in interface org.jgroups.jmx.protocols.TPMBean
 
isEnableBundling() - Method in class org.jgroups.protocols.TP
 
isLoopback() - Method in class org.jgroups.jmx.protocols.TP
 
isLoopback() - Method in interface org.jgroups.jmx.protocols.TPMBean
 
isLoopback() - Method in class org.jgroups.protocols.TCP
 
isLoopback() - Method in class org.jgroups.protocols.TP
 
isMulticastAddress() - Method in interface 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.protocols.JMS.JMSAddress
Is the address a multicast address?
isMulticastAddress() - Method in class org.jgroups.protocols.WanPipeAddress
 
isMulticastAddress() - Method in class org.jgroups.stack.IpAddress
 
isMulticastAddress() - Method in class org.jgroups.stack.LogicalAddress
 
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 interface org.jgroups.jmx.JChannelMBean
 
isOverride() - Method in class org.jgroups.conf.ProtocolData
 
isPrepare() - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
 
isReceiveOnAllInterfaces() - Method in class org.jgroups.jmx.protocols.TP
 
isReceiveOnAllInterfaces() - Method in interface org.jgroups.jmx.protocols.TPMBean
 
isReceiveOnAllInterfaces() - Method in class org.jgroups.protocols.TP
 
isReceived(Address) - Method in class org.jgroups.util.RspList
 
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 interface org.jgroups.jmx.protocols.TPMBean
 
isSendOnAllInterfaces() - Method in class org.jgroups.protocols.TP
 
isServer() - Method in class org.jgroups.protocols.PingRsp
 
isShun() - Method in class org.jgroups.jmx.protocols.FD
 
isShun() - Method in interface org.jgroups.jmx.protocols.FDMBean
 
isShun() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
 
isShun() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
 
isShun() - Method in class org.jgroups.protocols.FD
 
isShun() - Method in class org.jgroups.protocols.pbcast.GMS
 
isStarted() - Method in class org.jgroups.stack.GossipRouter
 
isSuspected(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 interface org.jgroups.jmx.JChannelMBean
 
isTrace() - Method in class org.jgroups.jmx.Protocol
 
isTrace() - Method in interface org.jgroups.jmx.ProtocolMBean
 
isTrace() - Method in class org.jgroups.stack.Protocol
 
isUseIncomingPacketHandler() - Method in class org.jgroups.jmx.protocols.TP
 
isUseIncomingPacketHandler() - Method in interface org.jgroups.jmx.protocols.TPMBean
 
isUseIncomingPacketHandler() - Method in class org.jgroups.protocols.TP
 
isUseMcastXmit() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
 
isUseMcastXmit() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
 
isUseMcastXmit() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
isUseOutgoingPacketHandler() - Method in class org.jgroups.protocols.TP
 
isUseOutgoungPacketHandler() - Method in class org.jgroups.jmx.protocols.TP
 
isUseOutgoungPacketHandler() - Method in interface 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 interface org.jgroups.jmx.protocols.pbcast.GMSMBean
 
isViewHandlerSuspended() - Method in class org.jgroups.protocols.pbcast.GMS
 
isWarn() - Method in class org.jgroups.jmx.Protocol
 
isWarn() - Method in interface org.jgroups.jmx.ProtocolMBean
 
isWarn() - Method in class org.jgroups.stack.Protocol
 
isXmitFromRandomMember() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
 
isXmitFromRandomMember() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
 
isXmitFromRandomMember() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
is_server - Variable in class org.jgroups.protocols.PingRsp
 

J

JAXP_MISSING_ERROR_MSG - Static variable in class org.jgroups.conf.ConfiguratorFactory
 
JChannel - class org.jgroups.JChannel.
JChannel is a pure Java implementation of Channel.
JChannel() - Constructor for class org.jgroups.JChannel
Constructs a JChannel instance with the protocol stack specified by the DEFAULT_PROTOCOL_STACK member.
JChannel(File) - Constructor for class org.jgroups.JChannel
Constructs a JChannel instance with the protocol stack configuration contained by the specified file.
JChannel(Element) - Constructor for class org.jgroups.JChannel
Constructs a JChannel instance with the protocol stack configuration contained by the specified XML element.
JChannel(URL) - Constructor for class org.jgroups.JChannel
Constructs a JChannel instance with the protocol stack configuration indicated by the specified URL.
JChannel(String) - Constructor for class org.jgroups.JChannel
Constructs a JChannel instance with the protocol stack configuration based upon the specified properties parameter.
JChannel(ProtocolStackConfigurator) - Constructor for class org.jgroups.JChannel
Constructs a JChannel instance with the protocol stack configuration contained by the protocol stack configurator parameter.
JChannel(Object) - Constructor for class org.jgroups.JChannel
Deprecated. Use the constructors with specific parameter types instead.
JChannel - class org.jgroups.jmx.JChannel.
 
JChannel() - Constructor for class org.jgroups.jmx.JChannel
 
JChannel(JChannel) - Constructor for class org.jgroups.jmx.JChannel
 
JChannelFactory - class org.jgroups.JChannelFactory.
JChannelFactory creates pure Java implementations of the Channel interface.
JChannelFactory() - Constructor for class org.jgroups.JChannelFactory
Deprecated. This constructor should only be used in conjunction with the deprecated getChannel(Object) method of this class.
JChannelFactory(File) - Constructor for class org.jgroups.JChannelFactory
Constructs a JChannelFactory instance that utilizes the specified file for protocl stack configuration.
JChannelFactory(Element) - Constructor for class org.jgroups.JChannelFactory
Constructs a JChannelFactory instance that utilizes the specified file for protocl stack configuration.
JChannelFactory(URL) - 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.
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.
JOIN_ANNOUNCEMENT - Static variable in class org.jgroups.protocols.SMACK.SmackHeader
 
JOIN_REQ - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
JOIN_RSP - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
JmxConfigurator - class org.jgroups.jmx.JmxConfigurator.
 
JmxConfigurator() - Constructor for class org.jgroups.jmx.JmxConfigurator
 
JoinRsp - class org.jgroups.protocols.pbcast.JoinRsp.
 
JoinRsp() - Constructor for class org.jgroups.protocols.pbcast.JoinRsp
 
JoinRsp(View, Digest) - Constructor for class org.jgroups.protocols.pbcast.JoinRsp
 
join(Address) - Method in class org.jgroups.protocols.ClientGmsImpl
Will generate a CONNECT_OK event.
join(Address) - Method in class org.jgroups.protocols.CoordGmsImpl
 
join(Address) - Method in class org.jgroups.protocols.GMS
 
join(Address) - Method in class org.jgroups.protocols.GmsImpl
 
join(Address) - Method in class org.jgroups.protocols.ParticipantGmsImpl
 
join(Address) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
Joins this process to a group.
join(Address) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
 
join(Address) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
join(Address) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
 
join_retry_timeout - Variable in class org.jgroups.protocols.GMS
 
join_timeout - Variable in class org.jgroups.protocols.GMS
 

K

KEY_REQUEST - Static variable in class org.jgroups.protocols.ENCRYPT.EncryptHeader
 
KeyStoreGenerator - class org.jgroups.demos.KeyStoreGenerator.
Generates a keystore file that has a SecretKey in it.
KeyStoreGenerator() - Constructor for class org.jgroups.demos.KeyStoreGenerator
 

L

LEAVE_ANNOUNCEMENT - Static variable in class org.jgroups.protocols.SMACK.SmackHeader
 
LEAVE_REQ - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
LEAVE_RSP - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
LOCAL - Static variable in class org.jgroups.Channel
 
LOG - Static variable in class org.jgroups.blocks.ConnectionTableNIO
 
LONG_SIZE - Static variable in class org.jgroups.Global
Value is 8.
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.
LOSS() - Constructor for class org.jgroups.protocols.LOSS
 
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, Link.Receiver) - Constructor for class org.jgroups.blocks.Link
 
Link(String, int, String, int, long, long, Link.Receiver) - Constructor for class org.jgroups.blocks.Link
 
Link.Receiver - interface org.jgroups.blocks.Link.Receiver.
 
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
List - class org.jgroups.util.List.
Doubly-linked list.
List() - Constructor for class org.jgroups.util.List
 
LockManager - interface org.jgroups.blocks.LockManager.
LockManager represents generic lock manager that allows obtaining and releasing locks on objects.
LockMultiLockedException - exception org.jgroups.blocks.LockMultiLockedException.
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
 
LockNotGrantedException - exception org.jgroups.blocks.LockNotGrantedException.
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
 
LockNotReleasedException - exception org.jgroups.blocks.LockNotReleasedException.
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
 
LockingException - exception org.jgroups.blocks.LockingException.
 
LockingException(String) - Constructor for class org.jgroups.blocks.LockingException
 
LockingException(Map) - Constructor for class org.jgroups.blocks.LockingException
 
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(LogicalLink.Receiver) - Constructor for class org.jgroups.blocks.LogicalLink
 
LogicalLink() - Constructor for class org.jgroups.blocks.LogicalLink
 
LogicalLink.AllLinksDown - exception org.jgroups.blocks.LogicalLink.AllLinksDown.
 
LogicalLink.AllLinksDown() - Constructor for class org.jgroups.blocks.LogicalLink.AllLinksDown
 
LogicalLink.NoLinksAvailable - exception org.jgroups.blocks.LogicalLink.NoLinksAvailable.
 
LogicalLink.NoLinksAvailable() - Constructor for class org.jgroups.blocks.LogicalLink.NoLinksAvailable
 
LogicalLink.Receiver - interface org.jgroups.blocks.LogicalLink.Receiver.
 
lbl - Variable in class org.jgroups.demos.wb.Node
 
leave(Address) - Method in class org.jgroups.protocols.ClientGmsImpl
 
leave(Address) - Method in class org.jgroups.protocols.CoordGmsImpl
The coordinator itself wants to leave the group
leave(Address) - Method in class org.jgroups.protocols.GMS
 
leave(Address) - Method in class org.jgroups.protocols.GmsImpl
 
leave(Address) - Method in class org.jgroups.protocols.ParticipantGmsImpl
Loop: determine coord.
leave(Address) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
 
leave(Address) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
The coordinator itself wants to leave the group
leave(Address) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
leave(Address) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
Loop: determine coord.
leave_timeout - Variable in class org.jgroups.protocols.GMS
 
length - Variable in class org.jgroups.Message
The number of bytes in the buffer (usually buf.length is buf not equal to null).
lessThanOrEqual(TransportedVectorTime) - Method in class org.jgroups.protocols.TransportedVectorTime
Checks if this TransportedVectorTime is less than or equal to the the specified TransportedVectorTime.
linkDown(InetAddress, int, InetAddress, int) - Method in interface org.jgroups.blocks.Link.Receiver
 
linkDown(InetAddress, int, InetAddress, int) - Method in interface org.jgroups.blocks.LogicalLink.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
 
linkUp(InetAddress, int, InetAddress, int) - Method in interface org.jgroups.blocks.Link.Receiver
 
linkUp(InetAddress, int, InetAddress, int) - Method in interface org.jgroups.blocks.LogicalLink.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
 
listAlphabet() - Method in class org.jgroups.demos.CausalDemo
 
listenOn(String, int, int, int, int, int, int, Receiver) - Method in class org.jgroups.protocols.UDP_NIO.ConnectorTable
Adds the given interface address to the list of interfaces on which the receiver mcast socket has to listen.
listener - Variable in class org.jgroups.blocks.PullPushAdapter
 
listeners - Variable in class org.jgroups.blocks.PullPushAdapter
 
loadClass(String, Class) - Static method in class org.jgroups.util.Util
Tries to load the class from the current thread's context class loader.
localAddressSet(Address) - Method in class org.jgroups.protocols.Discovery
Called after local_addr was set
localAddressSet(Address) - Method in class org.jgroups.protocols.PING
 
localAddressSet(Address) - Method in class org.jgroups.protocols.TCPPING
 
localSequenceID - Variable 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.
local_addr - Variable in class org.jgroups.blocks.MessageDispatcher
 
local_addr - Variable in class org.jgroups.blocks.RequestCorrelator
The address of this group member
local_addr - Variable in class org.jgroups.protocols.GMS
 
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 interface org.jgroups.blocks.LockManager
Obtain lock on obj for specified owner.
lock() - Method in class org.jgroups.util.ReentrantLatch
Lock the latch.
lockId - Variable in class org.jgroups.blocks.DistributedLockManager.LockDecree
 
log - Variable in class org.jgroups.JChannel
 
log - Static variable in class org.jgroups.Membership
 
log - Static variable in class org.jgroups.Message
 
log - Variable in class org.jgroups.blocks.ConnectionTable
 
log - Variable in class org.jgroups.blocks.DistributedHashtable
 
log - Variable in class org.jgroups.blocks.DistributedLockManager
 
log - Static variable in class org.jgroups.blocks.DistributedTree
 
log - Variable in class org.jgroups.blocks.MessageDispatcher
 
log - Static variable in class org.jgroups.blocks.MethodCall
 
log - Variable in class org.jgroups.blocks.NotificationBus
 
log - Variable in class org.jgroups.blocks.PullPushAdapter
 
log - Variable in class org.jgroups.blocks.ReplicatedHashtable
 
log - Variable in class org.jgroups.blocks.ReplicatedTree
 
log - Variable in class org.jgroups.blocks.ReplicationManager
 
log - Static variable in class org.jgroups.blocks.RequestCorrelator
 
log - Variable in class org.jgroups.blocks.VotingAdapter
 
log - Variable in class org.jgroups.conf.ClassConfigurator
 
log - Static variable in class org.jgroups.conf.MagicNumberReader
 
log - Static variable in class org.jgroups.conf.XmlConfigurator
 
log - Variable in class org.jgroups.debug.ProtocolTester
 
log - Variable in class org.jgroups.persistence.DBPersistenceManager
 
log - Static variable in class org.jgroups.persistence.PersistenceFactory
 
log - Variable in class org.jgroups.protocols.GmsImpl
 
log - Variable in class org.jgroups.protocols.PingSender
 
log - Variable in class org.jgroups.protocols.PingWaiter
 
log - Static variable in class org.jgroups.protocols.pbcast.Digest
 
log - Variable in class org.jgroups.protocols.pbcast.GmsImpl
 
log - Variable in class org.jgroups.protocols.ring.RingNodeFlowControl
 
log - Variable in class org.jgroups.protocols.ring.TcpRingNode
 
log - Static variable in class org.jgroups.stack.AckMcastReceiverWindow
 
log - Static variable in class org.jgroups.stack.AckMcastSenderWindow
 
log - Variable in class org.jgroups.stack.Configurator
 
log - Variable in class org.jgroups.stack.GossipClient
 
log - Variable in class org.jgroups.stack.GossipRouter
 
log - Variable in class org.jgroups.stack.GossipServer
Deprecated.  
log - Static variable in class org.jgroups.stack.IpAddress
 
log - Static variable in class org.jgroups.stack.NakReceiverWindow
 
log - Variable in class org.jgroups.stack.Protocol
 
log - Static variable in class org.jgroups.stack.Retransmitter
 
log - Variable in class org.jgroups.stack.Router
 
log - Static variable in class org.jgroups.stack.RouterStub
 
log - Static variable in class org.jgroups.util.LinkedListQueue
 
log - Static variable in class org.jgroups.util.Queue
 
log - Static variable in class org.jgroups.util.Queue2
 
log - Static variable in class org.jgroups.util.ReusableThread
 
log - Static variable in class org.jgroups.util.Scheduler
 
log - Static variable in class org.jgroups.util.ThreadPool
 
log - Static variable in class org.jgroups.util.TimeScheduler
 
logger - Variable in class org.jgroups.blocks.DistributedQueue
 
low - Variable in class org.jgroups.util.Range
 
lowSeqnoAt(Address) - Method in class org.jgroups.protocols.pbcast.Digest
 
low_seqno - Variable in class org.jgroups.protocols.pbcast.Digest.Entry
 
ltime - Variable in class org.jgroups.protocols.GMS
 

M

MAGIC_NUMBER_FILE - Static variable in class org.jgroups.conf.MagicNumberReader
 
MAX_PORT - Static variable in class org.jgroups.util.Util
 
MCAST - Static variable in class org.jgroups.protocols.SMACK.SmackHeader
 
MCAST_MSG - Static variable in class org.jgroups.protocols.pbcast.PbcastHeader
 
MERGE - Static variable in class org.jgroups.Event
 
MERGE - class org.jgroups.protocols.MERGE.
Simple and stupid MERGE protocol (does not take into account state transfer).
MERGE() - Constructor for class org.jgroups.protocols.MERGE
 
MERGE.MergeHeader - class org.jgroups.protocols.MERGE.MergeHeader.
 
MERGE.MergeHeader() - Constructor for class org.jgroups.protocols.MERGE.MergeHeader
 
MERGE.MergeHeader(int) - Constructor for class org.jgroups.protocols.MERGE.MergeHeader
 
MERGE2 - class org.jgroups.jmx.protocols.MERGE2.
 
MERGE2() - Constructor for class org.jgroups.jmx.protocols.MERGE2
 
MERGE2(Protocol) - Constructor for 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.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).
MERGE3() - Constructor for class org.jgroups.protocols.MERGE3
 
MERGE3.CoordAnnouncement - class org.jgroups.protocols.MERGE3.CoordAnnouncement.
 
MERGE3.CoordAnnouncement() - Constructor for class org.jgroups.protocols.MERGE3.CoordAnnouncement
 
MERGE3.CoordAnnouncement(Address) - Constructor for class org.jgroups.protocols.MERGE3.CoordAnnouncement
 
MERGEFAST - class org.jgroups.protocols.MERGEFAST.
The coordinator attaches a small header to each (or every nth) message.
MERGEFAST() - Constructor for class org.jgroups.protocols.MERGEFAST
 
MERGEFAST.MergefastHeader - class org.jgroups.protocols.MERGEFAST.MergefastHeader.
 
MERGEFAST.MergefastHeader() - Constructor for class org.jgroups.protocols.MERGEFAST.MergefastHeader
 
MERGEFAST.MergefastHeader(Address) - Constructor for class org.jgroups.protocols.MERGEFAST.MergefastHeader
 
MERGE_DENIED - Static variable in class org.jgroups.Event
 
MERGE_DIGEST - Static variable in class org.jgroups.Event
 
MERGE_REQ - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
MERGE_RSP - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
METHOD - Static variable in class org.jgroups.blocks.MethodCall
Explicitly ship the method, caller has to determine method himself.
MPING - class org.jgroups.jmx.protocols.MPING.
 
MPING() - Constructor for class org.jgroups.jmx.protocols.MPING
 
MPING(Protocol) - Constructor for 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.protocols.MPING
 
MPINGMBean - interface org.jgroups.jmx.protocols.MPINGMBean.
 
MSG - Static variable in class org.jgroups.Event
 
MSG - Static variable in class org.jgroups.protocols.pbcast.NakAckHeader
 
MagicNumberReader - class org.jgroups.conf.MagicNumberReader.
 
MagicNumberReader() - Constructor for class org.jgroups.conf.MagicNumberReader
 
MagicObjectInputStream - class org.jgroups.util.MagicObjectInputStream.
Uses magic numbers for class descriptors
MagicObjectInputStream(InputStream) - Constructor for class org.jgroups.util.MagicObjectInputStream
 
MagicObjectOutputStream - class org.jgroups.util.MagicObjectOutputStream.
Uses magic numbers for class descriptors
MagicObjectOutputStream(OutputStream) - Constructor for class org.jgroups.util.MagicObjectOutputStream
 
Marshaller - class org.jgroups.util.Marshaller.
Title: JGroups Communications Description: Contact me at mail@filip.net Copyright: Copyright (c) 2002 Company: www.filip.net
Marshaller() - Constructor for class org.jgroups.util.Marshaller
 
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.
MembershipListener - interface org.jgroups.MembershipListener.
Allows a listener to be notified when group membership changes.
MembershipListenerAdapter - class org.jgroups.blocks.MembershipListenerAdapter.
This class provides multiplexing possibilities for MembershipListener instances.
MembershipListenerAdapter() - Constructor for class org.jgroups.blocks.MembershipListenerAdapter
 
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
MergeData(Address, View, Digest) - Constructor for class org.jgroups.protocols.pbcast.MergeData
 
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
MergeView(ViewId, Vector, Vector) - Constructor for class org.jgroups.MergeView
Creates a new view
MergeView(Address, long, 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(Address, Address, byte[]) - Constructor for class org.jgroups.Message
Public constructor
Message(Address, Address, byte[], int, int) - Constructor for class org.jgroups.Message
Constructs a message.
Message(Address, Address, Serializable) - Constructor for class org.jgroups.Message
Public constructor
Message() - Constructor for class org.jgroups.Message
 
Message(boolean) - Constructor for class org.jgroups.Message
 
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.
MessageDispatcher(Channel, MessageListener, MembershipListener) - Constructor for class org.jgroups.blocks.MessageDispatcher
 
MessageDispatcher(Channel, MessageListener, MembershipListener, boolean) - Constructor for class org.jgroups.blocks.MessageDispatcher
 
MessageDispatcher(Channel, MessageListener, MembershipListener, boolean, boolean) - Constructor for class org.jgroups.blocks.MessageDispatcher
 
MessageDispatcher(Channel, MessageListener, MembershipListener, RequestHandler) - Constructor for class org.jgroups.blocks.MessageDispatcher
 
MessageDispatcher(Channel, MessageListener, MembershipListener, RequestHandler, boolean) - Constructor for class org.jgroups.blocks.MessageDispatcher
 
MessageDispatcher(Channel, MessageListener, MembershipListener, RequestHandler, boolean, boolean) - Constructor for class org.jgroups.blocks.MessageDispatcher
 
MessageDispatcher(PullPushAdapter, Serializable, MessageListener, MembershipListener) - Constructor for class org.jgroups.blocks.MessageDispatcher
 
MessageDispatcher(PullPushAdapter, Serializable, MessageListener, MembershipListener, RequestHandler) - Constructor for class org.jgroups.blocks.MessageDispatcher
 
MessageDispatcher(PullPushAdapter, Serializable, MessageListener, MembershipListener, RequestHandler, boolean) - Constructor for class org.jgroups.blocks.MessageDispatcher
 
MessageListener - interface org.jgroups.MessageListener.
Allows a listener to be notified when a message arrives.
MessageListenerAdapter - class org.jgroups.blocks.MessageListenerAdapter.
This class provides multiplexing possibilities for MessageListener instances.
MessageListenerAdapter() - Constructor for class org.jgroups.blocks.MessageListenerAdapter
Create default instance of this class.
MessageListenerAdapter(MessageListener) - Constructor for class org.jgroups.blocks.MessageListenerAdapter
Create instance of this class.
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.
MessageProtocol() - Constructor for class org.jgroups.stack.MessageProtocol
 
MessageProtocolEXAMPLE - class org.jgroups.protocols.MessageProtocolEXAMPLE.
 
MessageProtocolEXAMPLE() - Constructor for class org.jgroups.protocols.MessageProtocolEXAMPLE
 
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(String, Object[]) - Constructor for class org.jgroups.blocks.MethodCall
Deprecated. Use one of the constructors that take class types as arguments
MethodCall(short, 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.
 
mDefaultJGroupsDTD - Variable in class org.jgroups.conf.ClassPathEntityResolver
 
mMagicNumberFile - Variable in class org.jgroups.conf.MagicNumberReader
 
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.blocks.DistributedHashtable
 
main(String[]) - Static method in class org.jgroups.blocks.DistributedQueue
 
main(String[]) - Static method in class org.jgroups.blocks.Link
 
main(String[]) - Static method in class org.jgroups.blocks.LogicalLink
 
main(String[]) - Static method in class org.jgroups.blocks.ReplicatedTree
 
main(String[]) - Static method in class org.jgroups.conf.ClassConfigurator
 
main(String[]) - Static method in class org.jgroups.conf.XmlConfigurator
 
main(String[]) - Static method in class org.jgroups.conf.XmlValidator
 
main(String[]) - Static method in class org.jgroups.debug.Debugger
 
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.demos.CausalDemo
 
main(String[]) - Static method in class org.jgroups.demos.Chat
 
main(String[]) - Static method in class org.jgroups.demos.DistributedHashtableDemo
 
main(String[]) - Static method in class org.jgroups.demos.DistributedQueueDemo
 
main(String[]) - Static method in class org.jgroups.demos.DistributedTreeDemo
 
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.demos.Gossip
 
main(String[]) - Static method in class org.jgroups.demos.KeyStoreGenerator
 
main(String[]) - Static method in class org.jgroups.demos.NotificationBusDemo
 
main(String[]) - Static method in class org.jgroups.demos.QuoteClient
 
main(String[]) - Static method in class org.jgroups.demos.QuoteServer
 
main(String[]) - Static method in class org.jgroups.demos.ReplicatedTreeDemo
 
main(String[]) - Static method in class org.jgroups.demos.Topology
 
main(String[]) - Static method in class org.jgroups.demos.TotalOrder
 
main(String[]) - Static method in class org.jgroups.demos.TotalTokenDemo
 
main(String[]) - Static method in class org.jgroups.demos.ViewDemo
 
main(String[]) - Static method in class org.jgroups.demos.wb.Whiteboard
 
main(String[]) - Static method in class org.jgroups.protocols.AUTOCONF
 
main(String[]) - Static method in class org.jgroups.protocols.PerfHeader
 
main(String[]) - Static method in class org.jgroups.protocols.UDP_NIO
 
main(String[]) - Static method in class org.jgroups.protocols.WanPipeAddress
 
main(String[]) - Static method in class org.jgroups.protocols.pbcast.Gossip
 
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.stack.Configurator
 
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
Deprecated.  
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.GetNetworkInterfaces
 
main(String[]) - Static method in class org.jgroups.util.List
 
main(String[]) - Static method in class org.jgroups.util.Proxy
 
main(String[]) - Static method in class org.jgroups.util.TimedWriter
 
main(String[]) - Static method in class org.jgroups.util.Util
 
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, ViewId) - Static method in class org.jgroups.protocols.GMS
 
makeView(Vector) - Method in class org.jgroups.protocols.pbcast.GMS
 
makeView(Vector, ViewId) - Method in class org.jgroups.protocols.pbcast.GMS
 
managerId - Variable in class org.jgroups.blocks.DistributedLockManager.LockDecree
 
marshaller - Variable in class org.jgroups.blocks.RpcDispatcher
 
match(Object, Object) - Static method in class org.jgroups.util.Util
 
match(long[], long[]) - Static method in class org.jgroups.util.Util
 
max(TransportedVectorTime) - Method in class org.jgroups.protocols.VectorTime
Maxes this VectorTime with the specified TransportedVectorTime.
mbrs - Variable in class org.jgroups.protocols.GMS
 
memStats(boolean) - Static method in class org.jgroups.util.Util
 
memberJoined(Address) - Method in interface org.jgroups.blocks.NotificationBus.Consumer
 
memberJoined(Address) - Method in class org.jgroups.demos.NotificationBusDemo
 
memberLeft(Address) - Method in interface org.jgroups.blocks.NotificationBus.Consumer
 
memberLeft(Address) - Method in class org.jgroups.demos.NotificationBusDemo
 
members - Variable in class org.jgroups.View
A list containing all the members of the view This list is always ordered, with the coordinator being the first member.
members - Variable in class org.jgroups.blocks.DistributedQueue
 
members - Variable in class org.jgroups.blocks.MessageDispatcher
 
members - Variable in class org.jgroups.stack.MessageProtocol
 
membershipListeners - Variable in class org.jgroups.blocks.MembershipListenerAdapter
 
membershipListenersCache - Variable in class org.jgroups.blocks.MembershipListenerAdapter
 
membership_listener - Variable in class org.jgroups.blocks.MessageDispatcher
 
membership_listeners - Variable in class org.jgroups.blocks.PullPushAdapter
 
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(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.GMS
 
merge(Vector) - Method in class org.jgroups.protocols.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
merge(Vector) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
Invoked upon receiving a MERGE event from the MERGE layer.
merge(Digest) - Method in class org.jgroups.protocols.pbcast.Digest
Adds a digest to this digest.
merge(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: this.low_seqno=min(this.low_seqno, low_seqno) this.high_seqno=max(this.high_seqno, high_seqno) 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(Vector) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
mergeDigest(Digest) - Method in class org.jgroups.protocols.pbcast.GMS
Send down a MERGE_DIGEST event
messageListeners - Variable in class org.jgroups.blocks.MessageListenerAdapter
 
messageListenersCache - Variable in class org.jgroups.blocks.MessageListenerAdapter
 
method - Variable in class org.jgroups.blocks.MethodCall
The Method of the call.
method_id - Variable in class org.jgroups.blocks.MethodCall
The ID of a method, maps to a java.lang.reflect.Method
method_lookup - Variable in class org.jgroups.blocks.RpcDispatcher
 
method_name - Variable in class org.jgroups.blocks.MethodCall
The name of the method, case sensitive.
missedHeartbeat(InetAddress, int, InetAddress, int, int) - Method in interface org.jgroups.blocks.Link.Receiver
 
missedHeartbeat(InetAddress, int, InetAddress, int, int) - Method in interface org.jgroups.blocks.LogicalLink.Receiver
 
missedHeartbeat(InetAddress, int, InetAddress, int, int) - Method in class org.jgroups.blocks.LogicalLink
Missed one or more heartbeats.
missedHeartbeat(InetAddress, int, InetAddress, int, int) - Method in class org.jgroups.protocols.WANPIPE
 
missingMessageReceived(long, Message) - Method in class org.jgroups.protocols.pbcast.NAKACK
 
missingMessageReceived(long, Message) - Method in interface org.jgroups.stack.NakReceiverWindow.Listener
 
mode - Variable in class org.jgroups.blocks.MethodCall
Which mode to use.
mode - Variable in class org.jgroups.blocks.Xid
 
mode - Variable in class org.jgroups.protocols.ring.TokenLostException
 
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.DrawRepl
 
mouseDragged(MouseEvent) - Method in class org.jgroups.demos.applets.DrawApplet
 
mouseDragged(MouseEvent) - Method in class org.jgroups.demos.wb.GraphPanel
 
mouseEntered(MouseEvent) - Method in class org.jgroups.demos.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.DrawRepl
 
mouseMoved(MouseEvent) - Method in class org.jgroups.demos.Gossip
 
mouseMoved(MouseEvent) - Method in class org.jgroups.demos.applets.DrawApplet
 
mouseMoved(MouseEvent) - Method in class org.jgroups.demos.wb.GraphPanel
 
mousePressed(MouseEvent) - Method in class org.jgroups.demos.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(Node) - Method in class org.jgroups.demos.wb.GraphPanel
 
moveNode(Node) - Method in class org.jgroups.demos.wb.Whiteboard
 
msgListToByteBuffer(LinkedList) - Static method in class org.jgroups.util.Util
Marshalls a list of messages.
msg_listener - Variable in class org.jgroups.blocks.MessageDispatcher
 
msgs - Variable in class org.jgroups.protocols.Digest
 
multicast_addr - Variable in class org.jgroups.stack.LogicalAddress
 
mutex - Variable in class org.jgroups.blocks.DistributedQueue
 
mutex - Variable in class org.jgroups.util.List
 
my_addr - Variable in class org.jgroups.demos.wb.GraphPanel
 

N

NAKACK - class org.jgroups.jmx.protocols.pbcast.NAKACK.
 
NAKACK() - Constructor for class org.jgroups.jmx.protocols.pbcast.NAKACK
 
NAKACK(Protocol) - Constructor for class org.jgroups.jmx.protocols.pbcast.NAKACK
 
NAKACK - class org.jgroups.protocols.NAKACK.
Negative AcKnowledgement layer (NAKs), paired with positive ACKs.
NAKACK() - Constructor for class org.jgroups.protocols.NAKACK
 
NAKACK - class org.jgroups.protocols.pbcast.NAKACK.
Negative AcKnowledgement layer (NAKs).
NAKACK() - Constructor for class org.jgroups.protocols.pbcast.NAKACK
 
NAKACKMBean - interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean.
 
NAK_ACK_MSG - Static variable in class org.jgroups.protocols.NakAckHeader
 
NAK_ACK_RSP - Static variable in class org.jgroups.protocols.NakAckHeader
 
NAK_MSG - Static variable in class org.jgroups.protocols.NakAckHeader
 
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
 
NOT_MEMBER - Static variable in class org.jgroups.protocols.FD.FdHeader
 
NOT_MEMBER - Static variable in class org.jgroups.protocols.pbcast.PbcastHeader
 
NULL_TYPE - Static variable in class org.jgroups.protocols.TOTAL.Header
Null value for the tag
NakAckHeader - class org.jgroups.protocols.NakAckHeader.
 
NakAckHeader() - Constructor for class org.jgroups.protocols.NakAckHeader
 
NakAckHeader(int, long, ViewId) - Constructor for class org.jgroups.protocols.NakAckHeader
 
NakAckHeader - class org.jgroups.protocols.pbcast.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, Address) - Constructor for class org.jgroups.protocols.pbcast.NakAckHeader
 
NakReceiverWindow - class org.jgroups.stack.NakReceiverWindow.
Keeps track of messages according to their sequence numbers.
NakReceiverWindow(Address, Retransmitter.RetransmitCommand, long, TimeScheduler) - Constructor for class org.jgroups.stack.NakReceiverWindow
Creates a new instance with the given retransmit command
NakReceiverWindow(Address, Retransmitter.RetransmitCommand, long) - Constructor for class org.jgroups.stack.NakReceiverWindow
Creates a new instance with the given retransmit command
NakReceiverWindow(Address, long) - Constructor for class org.jgroups.stack.NakReceiverWindow
Creates a new instance without a retransmission thread
NakReceiverWindow.Listener - interface org.jgroups.stack.NakReceiverWindow.Listener.
 
Node - class org.jgroups.demos.wb.Node.
 
Node() - Constructor for class org.jgroups.demos.wb.Node
 
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
 
NotificationBus.Consumer - interface org.jgroups.blocks.NotificationBus.Consumer.
 
NotificationBusDemo - class org.jgroups.demos.NotificationBusDemo.
Demoes the NotificationBus (without caching).
NotificationBusDemo() - Constructor for class org.jgroups.demos.NotificationBusDemo
 
NullReadWriteLock - class org.jgroups.util.NullReadWriteLock.
 
NullReadWriteLock() - Constructor for class org.jgroups.util.NullReadWriteLock
 
NullSync - class org.jgroups.util.NullSync.
 
NullSync() - Constructor for class org.jgroups.util.NullSync
 
name - Variable in class org.jgroups.blocks.RequestCorrelator
makes the instance unique (together with IDs)
name - Static variable in class org.jgroups.protocols.GMS
 
name - Static variable in class org.jgroups.protocols.PING
 
next() - Method in class org.jgroups.stack.Interval
 
nextInterval() - Method in interface org.jgroups.util.TimeScheduler.Task
 
next_id - Static variable in class org.jgroups.blocks.Xid
 
nodeAdded(String, Serializable) - Method in interface org.jgroups.blocks.DistributedTree.DistributedTreeListener
 
nodeAdded(String) - Method in interface org.jgroups.blocks.ReplicatedTree.ReplicatedTreeListener
 
nodeAdded(String, Serializable) - Method in class org.jgroups.demos.DistributedTreeDemo
 
nodeModified(String, Serializable, Serializable) - Method in interface org.jgroups.blocks.DistributedTree.DistributedTreeListener
 
nodeModified(String) - Method in interface org.jgroups.blocks.ReplicatedTree.ReplicatedTreeListener
 
nodeModified(String, Serializable, Serializable) - Method in class org.jgroups.demos.DistributedTreeDemo
 
nodeRemoved(String) - Method in interface org.jgroups.blocks.DistributedTree.DistributedTreeListener
 
nodeRemoved(String) - Method in interface org.jgroups.blocks.ReplicatedTree.ReplicatedTreeListener
 
nodeRemoved(String) - Method in class org.jgroups.demos.DistributedTreeDemo
 
normalize(String) - Static method in class org.jgroups.util.PrintXMLTree
 
notifs - Variable in class org.jgroups.blocks.DistributedQueue
 
notifyBlock() - Method in class org.jgroups.blocks.PullPushAdapter
 
notifyChannelClosed(Channel) - Method in class org.jgroups.Channel
 
notifyChannelConnected(Channel) - Method in class org.jgroups.Channel
 
notifyChannelDisconnected(Channel) - Method in class org.jgroups.Channel
 
notifyChannelReconnected(Address) - Method in class org.jgroups.Channel
 
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(Address) - Method in class org.jgroups.blocks.PullPushAdapter
 
notifyViewChange(View) - Method in class org.jgroups.blocks.PullPushAdapter
 
numSuspectedMembers() - Method in class org.jgroups.util.RspList
 
num_frags - Variable in class org.jgroups.protocols.FragHeader
 
num_prev_mbrs - Variable 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
 

O

OLD - Static variable in class org.jgroups.blocks.MethodCall
Infer the method from the arguments.
OPERATIONAL - Static variable in class org.jgroups.protocols.ring.RingToken
 
OUT_OF_BAND_MSG - Static variable in class org.jgroups.protocols.NakAckHeader
 
OUT_OF_BAND_RSP - Static variable in class org.jgroups.protocols.NakAckHeader
 
objectFromByteBuffer(byte[]) - Method in interface org.jgroups.blocks.RpcDispatcher.Marshaller
 
objectFromByteBuffer(byte[]) - Static method in class org.jgroups.util.Util
Creates an object from a byte buffer
objectToByteBuffer(Object) - Method in interface org.jgroups.blocks.RpcDispatcher.Marshaller
 
objectToByteBuffer(Object) - Static method in class org.jgroups.util.Util
Serializes an object into a byte buffer.
observer - Variable in class org.jgroups.stack.Protocol
 
offset - Variable in class org.jgroups.Message
The index into the payload (usually 0)
onMessage(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.
option2String(int) - Static method in class org.jgroups.Channel
 
org.jgroups - package org.jgroups
Provides top-level public JGroups classes such as Channel, Message, etc.
org.jgroups.blocks - package org.jgroups.blocks
Provides building blocks that are layered on top of channels.
org.jgroups.conf - package org.jgroups.conf
Provides ways to configure a protocol stack.
org.jgroups.debug - package org.jgroups.debug
Provides debug support, including testing, profiling, and a graphical view of a protocol stack.
org.jgroups.demos - package org.jgroups.demos
Provides demonstrations of JGroups functionality.
org.jgroups.demos.applets - package org.jgroups.demos.applets
Provides an applet that demonstrates JGroups functionality.
org.jgroups.demos.wb - package org.jgroups.demos.wb
A distributed whiteboard applet implemented using JGroups.
org.jgroups.jmx - package org.jgroups.jmx
 
org.jgroups.jmx.protocols - package org.jgroups.jmx.protocols
 
org.jgroups.jmx.protocols.pbcast - package org.jgroups.jmx.protocols.pbcast
 
org.jgroups.persistence - package org.jgroups.persistence
Provides features for storing information to a database or file.
org.jgroups.protocols - package org.jgroups.protocols
Provides implementations of transport protocols which are responsible for sending and receiving messages to/from the network.
org.jgroups.protocols.pbcast - package org.jgroups.protocols.pbcast
Supports probabilistic broadcasts.
org.jgroups.protocols.ring - package org.jgroups.protocols.ring
Supports protocols in ring networks.
org.jgroups.stack - package org.jgroups.stack
Support for managing protocol stacks.
org.jgroups.util - package org.jgroups.util
Provides useful functionality which cannot be assigned to any particular other package.
override(ProtocolParameter[]) - Method in class org.jgroups.conf.ProtocolData
 
override(ProtocolData) - Method in class org.jgroups.conf.XmlConfigurator
 
own_addr - Variable in class org.jgroups.protocols.PingRsp
 

P

PARTITIONER - class org.jgroups.protocols.PARTITIONER.
This layer can be put on top of the bottommost layer and is useful to simulate partitions.
PARTITIONER() - Constructor for class org.jgroups.protocols.PARTITIONER
 
PARTITIONER.PartitionerHeader - class org.jgroups.protocols.PARTITIONER.PartitionerHeader.
The Partitioner header normally (type = NORMAL) contains just the partition number that is checked to discard messages received from other partitions.
PARTITIONER.PartitionerHeader() - Constructor for class org.jgroups.protocols.PARTITIONER.PartitionerHeader
 
PARTITIONER.PartitionerHeader(int) - Constructor for class org.jgroups.protocols.PARTITIONER.PartitionerHeader
 
PARTITIONER.PartitionerHeader(int, int) - Constructor for class org.jgroups.protocols.PARTITIONER.PartitionerHeader
 
PBCAST - class org.jgroups.protocols.pbcast.PBCAST.
Implementation of probabilistic broadcast.
PBCAST() - Constructor for class org.jgroups.protocols.pbcast.PBCAST
 
PERF - Static variable in class org.jgroups.Event
 
PERF - class org.jgroups.protocols.PERF.
Measures time taken by each protocol to process a message.
PERF() - Constructor for class org.jgroups.protocols.PERF
 
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
 
PIGGYBACK - class org.jgroups.protocols.PIGGYBACK.
Combines multiple messages into a single large one.
PIGGYBACK() - Constructor for class org.jgroups.protocols.PIGGYBACK
 
PIGGYBACK.PiggybackHeader - class org.jgroups.protocols.PIGGYBACK.PiggybackHeader.
 
PIGGYBACK.PiggybackHeader() - Constructor for class org.jgroups.protocols.PIGGYBACK.PiggybackHeader
 
PING - class org.jgroups.jmx.protocols.PING.
 
PING() - Constructor for class org.jgroups.jmx.protocols.PING
 
PING(Protocol) - Constructor for 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.protocols.PING
 
PINGMBean - interface org.jgroups.jmx.protocols.PINGMBean.
 
PORT - Static variable in class org.jgroups.stack.GossipRouter
 
PRINTMETHODS - class org.jgroups.protocols.PRINTMETHODS.
 
PRINTMETHODS() - Constructor for class org.jgroups.protocols.PRINTMETHODS
 
PRINTOBJS - class org.jgroups.protocols.PRINTOBJS.
 
PRINTOBJS() - Constructor for class org.jgroups.protocols.PRINTOBJS
 
ParticipantGmsImpl - class org.jgroups.protocols.ParticipantGmsImpl.
 
ParticipantGmsImpl(GMS) - Constructor for class org.jgroups.protocols.ParticipantGmsImpl
 
ParticipantGmsImpl - class org.jgroups.protocols.pbcast.ParticipantGmsImpl.
 
ParticipantGmsImpl(GMS) - Constructor for class org.jgroups.protocols.pbcast.ParticipantGmsImpl
 
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(Gossip, int) - Constructor for class org.jgroups.protocols.pbcast.PbcastHeader
 
PbcastHeader(Gossip, int, long) - Constructor for class org.jgroups.protocols.pbcast.PbcastHeader
 
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.
 
PingHeader - class org.jgroups.protocols.PingHeader.
 
PingHeader() - Constructor for class org.jgroups.protocols.PingHeader
 
PingHeader(byte, PingRsp) - Constructor for class org.jgroups.protocols.PingHeader
 
PingRsp - class org.jgroups.protocols.PingRsp.
 
PingRsp() - Constructor for class org.jgroups.protocols.PingRsp
 
PingRsp(Address, 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, 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
PingWaiter(long, int, Protocol, PingSender) - Constructor for class org.jgroups.protocols.PingWaiter
 
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
PrintXMLTree - class org.jgroups.util.PrintXMLTree.
 
PrintXMLTree() - Constructor for class org.jgroups.util.PrintXMLTree
 
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
 
Profiler.Entry - class org.jgroups.debug.Profiler.Entry.
 
Profiler.Entry() - Constructor for class org.jgroups.debug.Profiler.Entry
 
Promise - class org.jgroups.util.Promise.
Allows a thread to submit an asynchronous request and to wait for the result.
Promise() - Constructor for class org.jgroups.util.Promise
 
Protocol - class org.jgroups.jmx.Protocol.
 
Protocol() - Constructor for class org.jgroups.jmx.Protocol
 
Protocol(Protocol) - Constructor for 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.stack.Protocol
 
ProtocolData - class org.jgroups.conf.ProtocolData.
 
ProtocolData(String, String, String, ProtocolParameter[]) - Constructor for class org.jgroups.conf.ProtocolData
 
ProtocolData(String, ProtocolParameter[]) - Constructor for class org.jgroups.conf.ProtocolData
 
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(JChannel, String) - Constructor for class org.jgroups.stack.ProtocolStack
 
ProtocolStack() - Constructor for class org.jgroups.stack.ProtocolStack
Only used by Simulator; don't use
ProtocolStackConfigurator - interface org.jgroups.conf.ProtocolStackConfigurator.
 
ProtocolTester - class org.jgroups.debug.ProtocolTester.
Generic class to test one or more protocol layers directly.
ProtocolTester(String, Protocol) - Constructor for class org.jgroups.debug.ProtocolTester
 
ProtocolView - class org.jgroups.debug.ProtocolView.
Graphical view of a protocol instance
ProtocolView(Protocol, DefaultTableModel, int) - Constructor for class org.jgroups.debug.ProtocolView
 
ProtocolView(Protocol, DefaultTableModel, int, boolean) - Constructor for class org.jgroups.debug.ProtocolView
 
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
 
Proxy(InetAddress, int, InetAddress, int, boolean, boolean, String) - Constructor for class org.jgroups.util.Proxy
 
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(Transport) - Constructor for class org.jgroups.blocks.PullPushAdapter
 
PullPushAdapter(Transport, MessageListener) - Constructor for class org.jgroups.blocks.PullPushAdapter
 
PullPushAdapter(Transport, MembershipListener) - Constructor for class org.jgroups.blocks.PullPushAdapter
 
PullPushAdapter(Transport, MessageListener, MembershipListener) - Constructor for class org.jgroups.blocks.PullPushAdapter
 
PullPushAdapter.PullHeader - class org.jgroups.blocks.PullPushAdapter.PullHeader.
 
PullPushAdapter.PullHeader() - Constructor for class org.jgroups.blocks.PullPushAdapter.PullHeader
 
PullPushAdapter.PullHeader(Serializable) - Constructor for class org.jgroups.blocks.PullPushAdapter.PullHeader
 
paint(Graphics) - Method in class org.jgroups.demos.Topology
 
paint(Graphics) - Method in class org.jgroups.demos.applets.DrawApplet
 
paintNode(Graphics, Node, FontMetrics) - Method in class org.jgroups.demos.wb.GraphPanel
 
parse(InputStream) - Static method in class org.jgroups.conf.MagicNumberReader
 
parse(InputStream) - Static method in class org.jgroups.conf.XmlConfigurator
 
parse(Element) - 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
 
passDown(Event) - Method in class org.jgroups.debug.ProtocolView
 
passDown(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(Event) - Method in interface org.jgroups.stack.ProtocolObserver
Called when an event is about to be passed down to the next lower protocol.
passThrough() - Method in class org.jgroups.util.ReentrantLatch
Pass through only when the latch becomes unlocked.
passToken(Object) - Method in interface 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(Event) - Method in class org.jgroups.debug.ProtocolView
 
passUp(Event) - Method in class org.jgroups.stack.Protocol
Causes the event to be forwarded to the next layer up in the hierarchy.
passUp(Event) - Method in interface org.jgroups.stack.ProtocolObserver
Called when an event is about to be passed up to the next higher protocol.
payload - Variable in class org.jgroups.blocks.MethodCall
To carry arbitrary data with a method call, data needs to be serializable if sent across the wire
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() - Method in class org.jgroups.blocks.DistributedQueue
returns the first object on the queue, without removing it.
peek(long) - Method in class org.jgroups.jmx.JChannel
 
peek(long) - Method in interface org.jgroups.jmx.JChannelMBean
 
peek() - 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.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(long) - 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(long) - 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
 
peekAtHead() - Method in class org.jgroups.util.List
Returns element at the head (if present), but does not remove it from list.
physical_addrs - Variable 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.
pop() - Method in class org.jgroups.util.Stack
 
postUnmarshalling(Message, Address, Address, boolean) - Method in class org.jgroups.protocols.TCP
 
postUnmarshalling(Message, Address, Address, boolean) - Method in class org.jgroups.protocols.TP
 
postUnmarshalling(Message, Address, Address, boolean) - Method in class org.jgroups.protocols.UDP
 
postUnmarshallingList(Message, Address, boolean) - Method in class org.jgroups.protocols.TCP
 
postUnmarshallingList(Message, Address, boolean) - Method in class org.jgroups.protocols.TP
 
postUnmarshallingList(Message, Address, boolean) - Method in class org.jgroups.protocols.UDP
 
prepare(Object) - Method in class org.jgroups.blocks.DistributedLockManager
Prepare phase for the lock acquisition or release.
prepare(Object) - Method in interface org.jgroups.blocks.TwoPhaseVotingListener
This is voting if the decree is acceptable to the party.
print() - Method in class org.jgroups.blocks.DistributedTree
 
print(String) - Method in class org.jgroups.blocks.ReplicatedTree
Prints a representation of the node defined by fqn.
print(PrintWriter, Element) - Static method in class org.jgroups.util.PrintXMLTree
 
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 interface org.jgroups.jmx.protocols.TCPMBean
 
printConnections() - Method in class org.jgroups.jmx.protocols.UNICAST
 
printConnections() - Method in interface org.jgroups.jmx.protocols.UNICASTMBean
 
printConnections() - Method in class org.jgroups.protocols.TCP
 
printConnections() - Method in class org.jgroups.protocols.UNICAST
 
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 interface org.jgroups.jmx.protocols.FCMBean
 
printCredits() - Method in class org.jgroups.protocols.FC
 
printDescription() - Static method in class org.jgroups.Version
Returns the catenation of the description and cvs fields.
printDetails() - Method in class org.jgroups.View
debug only
printDetails() - Method in class org.jgroups.protocols.FD_PROB.FdHeader
 
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
printDetails() - Method in class org.jgroups.stack.AckReceiverWindow
 
printDetails() - Method in class org.jgroups.stack.AckSenderWindow
 
printEvent(Event) - Static method in class org.jgroups.util.Util
 
printFragments(byte[][]) - 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(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 interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
 
printMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
printMethodCall(Message) - Static method in class org.jgroups.util.Util
Tries to read a MethodCall object from the message's buffer and prints it.
printObjectHeaders() - Method in class org.jgroups.Message
 
printPreviousMembers() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
 
printPreviousMembers() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
 
printPreviousMembers() - Method in class org.jgroups.protocols.pbcast.GMS
 
printPreviousViews() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
 
printPreviousViews() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
 
printPreviousViews() - Method in class org.jgroups.protocols.pbcast.GMS
 
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 interface 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 interface org.jgroups.jmx.protocols.FCMBean
 
printReceiverCredits() - Method in class org.jgroups.protocols.FC
 
printSenderCredits() - Method in class org.jgroups.jmx.protocols.FC
 
printSenderCredits() - Method in interface org.jgroups.jmx.protocols.FCMBean
 
printSenderCredits() - Method in class org.jgroups.protocols.FC
 
printSentMessages() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
 
printSentMessages() - Method in interface 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.jmx.Protocol
 
printStats() - Method in interface org.jgroups.jmx.ProtocolMBean
 
printStats() - Method in class org.jgroups.jmx.protocols.STATS
 
printStats() - Method in interface org.jgroups.jmx.protocols.STATSMBean
 
printStats() - Method in class org.jgroups.protocols.STATS
 
printStats() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
printStats() - Method in class org.jgroups.stack.Protocol
 
printSuspectHistory() - Method in class org.jgroups.jmx.protocols.FD
 
printSuspectHistory() - Method in interface org.jgroups.jmx.protocols.FDMBean
 
printSuspectHistory() - Method in class org.jgroups.jmx.protocols.FD_SOCK
 
printSuspectHistory() - Method in interface org.jgroups.jmx.protocols.FD_SOCKMBean
 
printSuspectHistory() - Method in class org.jgroups.protocols.FD
 
printSuspectHistory() - Method in class org.jgroups.protocols.FD_SOCK
 
printThreads() - Static method in class org.jgroups.util.Util
 
printVersion() - Static method in class org.jgroups.Version
Returns the version field as a String.
processEvent(String, AWTEvent) - Method in class org.jgroups.demos.DrawRepl
 
processResponses(RspList, int, Object) - Method in class org.jgroups.blocks.DistributedLockManager
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.
processResponses(RspList, int, Object) - Method in interface org.jgroups.blocks.VoteResponseProcessor
Processes the responses returned by the other nodes.
processResponses(RspList, int, Object) - Method in class org.jgroups.blocks.VotingAdapter
Processes the response list and makes a decision according to the type of the consensus for current voting.
prompt(String) - Static method in class org.jgroups.util.Util
 
props - Variable in class org.jgroups.stack.Protocol
 
prot_adapter - Variable in class org.jgroups.blocks.MessageDispatcher
 
prot_name - Static variable in class org.jgroups.protocols.TOTAL_TOKEN
 
providedDownServices() - Method in class org.jgroups.protocols.NAKACK
 
providedDownServices() - Method in class org.jgroups.protocols.QUEUE
 
providedDownServices() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
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).
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.QUEUE
 
providedUpServices() - Method in class org.jgroups.protocols.TOTAL_TOKEN
 
providedUpServices() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
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).
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, 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() - Constructor for class org.jgroups.protocols.QUEUE
 
QUEUE.Observer - interface org.jgroups.protocols.QUEUE.Observer.
 
QUEUEView - class org.jgroups.debug.QUEUEView.
Shows the internals of the QUEUE protocol.
QUEUEView() - Constructor for class org.jgroups.debug.QUEUEView
 
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 - exception org.jgroups.util.QueueClosedException.
 
QueueClosedException() - Constructor for class org.jgroups.util.QueueClosedException
 
QueueClosedException(String) - Constructor for class org.jgroups.util.QueueClosedException
 
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.
QuoteServer() - Constructor for class org.jgroups.demos.QuoteServer
 

R

READ_COMMITTED - Static variable in class org.jgroups.blocks.Xid
Reads are dirty until another transaction actually commits; at that points the modified data will be reflected here.
REBROADCAST_MSGS - Static variable in class org.jgroups.Event
 
REBROADCAST_MSGS_OK - Static variable in class org.jgroups.Event
 
RECOVERY - Static variable in class org.jgroups.protocols.ring.RingToken
 
REGISTER - Static variable in class org.jgroups.stack.GossipRouter
 
REGISTER - Static variable in class org.jgroups.stack.Router
 
REGISTER_REQ - Static variable in class org.jgroups.stack.GossipData
 
REP - Static variable in class org.jgroups.protocols.TOTAL.Header
Reply to broadcast request.
REPEATABLE_READ - Static variable 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.
REPLENISH - Static variable in class org.jgroups.protocols.FC.FcHeader
 
REQ - Static variable in class org.jgroups.blocks.RequestCorrelator.Header
 
REQ - Static variable in class org.jgroups.protocols.BSH.BshHeader
 
REQ - Static variable in class org.jgroups.protocols.TOTAL.Header
Request to broadcast by the source
RESUME_STABLE - Static variable in class org.jgroups.Event
 
RETRANSMIT_MSG - Static variable in class org.jgroups.protocols.NakAckHeader
 
ROLLBACK - Static variable in class org.jgroups.blocks.ReplicationData
 
ROUTING_CLIENT_REPLY_TIMEOUT - Static variable in class org.jgroups.stack.GossipRouter
 
RSP - Static variable in class org.jgroups.blocks.RequestCorrelator.Header
 
RSP - Static variable in class org.jgroups.protocols.BSH.BshHeader
 
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
 
Receiver - interface org.jgroups.Receiver.
Defines the callbacks that are invoked when messages, views etc are received on a channel
ReceiverAdapter - class org.jgroups.ReceiverAdapter.
 
ReceiverAdapter() - Constructor for class org.jgroups.ReceiverAdapter
 
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
ReplicatedHashtable - class org.jgroups.blocks.ReplicatedHashtable.
Provides the abstraction of a java.util.Hashtable that is replicated at several locations.
ReplicatedHashtable(String, ChannelFactory, ReplicatedHashtable.StateTransferListener, String, long) - Constructor for class org.jgroups.blocks.ReplicatedHashtable
Creates a ReplicatedHashtable
ReplicatedHashtable(String, ChannelFactory, String, long) - Constructor for class org.jgroups.blocks.ReplicatedHashtable
 
ReplicatedHashtable(JChannel, long) - Constructor for class org.jgroups.blocks.ReplicatedHashtable
 
ReplicatedHashtable(JChannel, ReplicatedHashtable.StateTransferListener, long) - Constructor for class org.jgroups.blocks.ReplicatedHashtable
 
ReplicatedHashtable.Notification - interface org.jgroups.blocks.ReplicatedHashtable.Notification.
 
ReplicatedHashtable.StateTransferListener - interface org.jgroups.blocks.ReplicatedHashtable.StateTransferListener.
 
ReplicatedTree - class org.jgroups.blocks.ReplicatedTree.
A tree-like structure that is replicated across several members.
ReplicatedTree(String, String, long) - Constructor for class org.jgroups.blocks.ReplicatedTree
Creates a channel with the given properties.
ReplicatedTree(String, String, long, boolean) - Constructor for class org.jgroups.blocks.ReplicatedTree
 
ReplicatedTree() - Constructor for class org.jgroups.blocks.ReplicatedTree
 
ReplicatedTree(JChannel) - Constructor for class org.jgroups.blocks.ReplicatedTree
Expects an already connected channel.
ReplicatedTree.Node - class org.jgroups.blocks.ReplicatedTree.Node.
 
ReplicatedTree.ReplicatedTreeListener - interface org.jgroups.blocks.ReplicatedTree.ReplicatedTreeListener.
 
ReplicatedTreeDemo - class org.jgroups.demos.ReplicatedTreeDemo.
Graphical view of a ReplicatedTree
ReplicatedTreeDemo() - Constructor for class org.jgroups.demos.ReplicatedTreeDemo
 
ReplicationData - class org.jgroups.blocks.ReplicationData.
Class used for data exchange by ReplicationManager and ReplicationReceiver.
ReplicationData() - Constructor for class org.jgroups.blocks.ReplicationData
 
ReplicationData(int, byte[], Xid, byte[], long, long, boolean) - 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: Asynchronous Synchronous Synchronous with locking
Note: This class is experimental as of Oct 2002
ReplicationManager(Channel, MessageListener, MembershipListener, ReplicationReceiver) - Constructor for class org.jgroups.blocks.ReplicationManager
Creates an instance of ReplicationManager on top of a Channel
ReplicationManager(PullPushAdapter, Serializable, MessageListener, MembershipListener, ReplicationReceiver) - Constructor for class org.jgroups.blocks.ReplicationManager
Creates an instance of ReplicationManager on top of a PullPushAdapter
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.
RequestCorrelator - class org.jgroups.blocks.RequestCorrelator.
Framework to send requests and receive matching responses (matching on request ID).
RequestCorrelator(String, Object, RequestHandler) - Constructor for class org.jgroups.blocks.RequestCorrelator
Constructor.
RequestCorrelator(String, Object, RequestHandler, Address) - Constructor for class org.jgroups.blocks.RequestCorrelator
 
RequestCorrelator(String, Object, RequestHandler, boolean) - Constructor for class org.jgroups.blocks.RequestCorrelator
Constructor.
RequestCorrelator(String, Object, RequestHandler, boolean, boolean) - Constructor for class org.jgroups.blocks.RequestCorrelator
 
RequestCorrelator(String, Object, RequestHandler, boolean, Address) - Constructor for class org.jgroups.blocks.RequestCorrelator
 
RequestCorrelator(String, Object, RequestHandler, boolean, Address, boolean) - Constructor for class org.jgroups.blocks.RequestCorrelator
 
RequestCorrelator.Header - class org.jgroups.blocks.RequestCorrelator.Header.
The header for RequestCorrelator messages
RequestCorrelator.Header() - Constructor for class org.jgroups.blocks.RequestCorrelator.Header
Used for externalization
RequestCorrelator.Header(byte, long, boolean, String) - Constructor for class org.jgroups.blocks.RequestCorrelator.Header
 
RequestHandler - interface org.jgroups.blocks.RequestHandler.
 
Retransmitter - class org.jgroups.stack.Retransmitter.
Maintains a pool of sequence numbers of messages that need to be retransmitted.
Retransmitter(Address, Retransmitter.RetransmitCommand, TimeScheduler) - Constructor for class org.jgroups.stack.Retransmitter
Create a new Retransmitter associated with the given sender address
Retransmitter(Address, Retransmitter.RetransmitCommand) - Constructor for class org.jgroups.stack.Retransmitter
Create a new Retransmitter associated with the given sender address
Retransmitter.RetransmitCommand - interface org.jgroups.stack.Retransmitter.RetransmitCommand.
Retransmit command (see Gamma et al.) used to retrieve missing messages
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(int, float, int, float) - Constructor for class org.jgroups.protocols.ring.RingNodeFlowControl
 
RingNodeFlowControl() - 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
 
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.
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).
RpcDispatcher(Channel, MessageListener, MembershipListener, Object) - Constructor for class org.jgroups.blocks.RpcDispatcher
 
RpcDispatcher(Channel, MessageListener, MembershipListener, Object, boolean) - Constructor for class org.jgroups.blocks.RpcDispatcher
 
RpcDispatcher(Channel, MessageListener, MembershipListener, Object, boolean, boolean) - Constructor for class org.jgroups.blocks.RpcDispatcher
 
RpcDispatcher(PullPushAdapter, Serializable, MessageListener, MembershipListener, Object) - Constructor for class org.jgroups.blocks.RpcDispatcher
 
RpcDispatcher.Marshaller - interface org.jgroups.blocks.RpcDispatcher.Marshaller.
 
RpcProtocol - class org.jgroups.stack.RpcProtocol.
Base class for group RMC peer protocols.
RpcProtocol() - Constructor for class org.jgroups.stack.RpcProtocol
 
RpcProtocolEXAMPLE - class org.jgroups.protocols.RpcProtocolEXAMPLE.
 
RpcProtocolEXAMPLE() - Constructor for class org.jgroups.protocols.RpcProtocolEXAMPLE
 
Rsp - class org.jgroups.util.Rsp.
class that represents a response from a communication
Rsp(Address) - Constructor for class org.jgroups.util.Rsp
 
Rsp(Address, boolean) - Constructor for class org.jgroups.util.Rsp
 
Rsp(Address, Object) - Constructor for class org.jgroups.util.Rsp
 
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
 
random(long) - Static method in class org.jgroups.util.Util
Returns a random value in the range [1 - 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.
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(ObjectInput) - Method in class org.jgroups.MergeView
 
readExternal(ObjectInput) - Method in class org.jgroups.Message
 
readExternal(ObjectInput) - Method in class org.jgroups.View
 
readExternal(ObjectInput) - Method in class org.jgroups.ViewId
 
readExternal(ObjectInput) - Method in class org.jgroups.blocks.MethodCall
 
readExternal(ObjectInput) - Method in class org.jgroups.blocks.PullPushAdapter.PullHeader
 
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.blocks.Xid
 
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.ENCRYPT.EncryptHeader
 
readExternal(ObjectInput) - Method in class org.jgroups.protocols.ENCRYPT1_4.EncryptHeader
 
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.HTOTAL.HTotalHeader
 
readExternal(ObjectInput) - Method in class org.jgroups.protocols.JMS.JMSAddress
Read object from external input.
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.MERGEFAST.MergefastHeader
 
readExternal(ObjectInput) - Method in class org.jgroups.protocols.NakAckHeader
 
readExternal(ObjectInput) - Method in class org.jgroups.protocols.PARTITIONER.PartitionerHeader
 
readExternal(ObjectInput) - Method in class org.jgroups.protocols.PIGGYBACK.PiggybackHeader
 
readExternal(ObjectInput) - Method in class org.jgroups.protocols.PerfHeader
 
readExternal(ObjectInput) - Method in class org.jgroups.protocols.PingHeader
 
readExternal(ObjectInput) - Method in class org.jgroups.protocols.SMACK.SmackHeader
 
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.TcpHeader
 
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.UNICAST.UnicastHeader
 
readExternal(ObjectInput) - Method in class org.jgroups.protocols.UdpHeader
 
readExternal(ObjectInput) - Method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
 
readExternal(ObjectInput) - Method in class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
 
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.protocols.pbcast.Digest
 
readExternal(ObjectInput) - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
readExternal(ObjectInput) - Method in class org.jgroups.protocols.pbcast.MergeData
 
readExternal(ObjectInput) - Method in class org.jgroups.protocols.pbcast.NakAckHeader
 
readExternal(ObjectInput) - Method in class org.jgroups.protocols.pbcast.PbcastHeader
 
readExternal(ObjectInput) - Method in class org.jgroups.protocols.pbcast.STABLE.StableHeader
 
readExternal(ObjectInput) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
readExternal(ObjectInput) - Method in class org.jgroups.protocols.ring.RingToken
 
readExternal(ObjectInput) - Method in class org.jgroups.stack.GossipData
 
readExternal(ObjectInput) - Method in class org.jgroups.stack.IpAddress
 
readExternal(ObjectInput) - Method in class org.jgroups.stack.LogicalAddress
 
readExternal(ObjectInput) - Method in class org.jgroups.util.List
 
readExternal(ObjectInput) - Method in class org.jgroups.util.Range
 
readExternal(ObjectInput) - Method in class org.jgroups.util.Stack
 
readFrom(DataInputStream) - Method in class org.jgroups.MergeView
 
readFrom(DataInputStream) - Method in class org.jgroups.Message
 
readFrom(DataInputStream) - Method in class org.jgroups.View
 
readFrom(DataInputStream) - Method in class org.jgroups.ViewId
 
readFrom(DataInputStream) - Method in class org.jgroups.blocks.RequestCorrelator.Header
 
readFrom(DataInputStream) - Method in class org.jgroups.protocols.COMPRESS.CompressHeader
 
readFrom(DataInputStream) - Method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
 
readFrom(DataInputStream) - Method in class org.jgroups.protocols.FC.FcHeader
 
readFrom(DataInputStream) - Method in class org.jgroups.protocols.FD.FdHeader
 
readFrom(DataInputStream) - Method in class org.jgroups.protocols.FD_SOCK.FdHeader
 
readFrom(DataInputStream) - Method in class org.jgroups.protocols.FragHeader
 
readFrom(DataInputStream) - Method in class org.jgroups.protocols.HTOTAL.HTotalHeader
 
readFrom(DataInputStream) - Method in class org.jgroups.protocols.JMS.JMSAddress
 
readFrom(DataInputStream) - Method in class org.jgroups.protocols.PingHeader
 
readFrom(DataInputStream) - Method in class org.jgroups.protocols.PingRsp
 
readFrom(DataInputStream) - Method in class org.jgroups.protocols.TcpHeader
 
readFrom(DataInputStream) - Method in class org.jgroups.protocols.TpHeader
 
readFrom(DataInputStream) - Method in class org.jgroups.protocols.UNICAST.UnicastHeader
 
readFrom(DataInputStream) - Method in class org.jgroups.protocols.UdpHeader
 
readFrom(DataInputStream) - Method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
 
readFrom(DataInputStream) - Method in class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
 
readFrom(DataInputStream) - Method in class org.jgroups.protocols.WanPipeAddress
 
readFrom(DataInputStream) - Method in class org.jgroups.protocols.pbcast.Digest
 
readFrom(DataInputStream) - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
readFrom(DataInputStream) - Method in class org.jgroups.protocols.pbcast.JoinRsp
 
readFrom(DataInputStream) - Method in class org.jgroups.protocols.pbcast.NakAckHeader
 
readFrom(DataInputStream) - Method in class org.jgroups.protocols.pbcast.STABLE.StableHeader
 
readFrom(DataInputStream) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
readFrom(DataInputStream) - Method in class org.jgroups.stack.IpAddress
 
readFrom(DataInputStream) - Method in class org.jgroups.stack.LogicalAddress
 
readFrom(DataInputStream) - Method in class org.jgroups.util.Range
 
readFrom(DataInputStream) - Method in interface org.jgroups.util.Streamable
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
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 - Variable in class org.jgroups.persistence.CannotConnectException
 
reason - Variable in class org.jgroups.persistence.CannotRemoveException
 
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(Message) - Method in interface org.jgroups.MessageListener
Called when a message is received.
receive(Message) - Method in class org.jgroups.ReceiverAdapter
 
receive(long) - Method in interface org.jgroups.Transport
 
receive(Address, byte[], int, int) - Method in interface org.jgroups.blocks.ConnectionTable.Receiver
 
receive(Address, byte[], int, int) - Method in class org.jgroups.blocks.ConnectionTable
Calls the receiver callback.
receive(Message) - Method in class org.jgroups.blocks.DistributedHashtable
 
receive(Message) - Method in class org.jgroups.blocks.DistributedQueue
 
receive(Message) - Method in class org.jgroups.blocks.DistributedTree
 
receive(byte[]) - Method in interface org.jgroups.blocks.Link.Receiver
 
receive(byte[]) - Method in interface org.jgroups.blocks.LogicalLink.Receiver
 
receive(byte[]) - Method in class org.jgroups.blocks.LogicalLink
Receive a message from any of the physical links.
receive(Message) - Method in class org.jgroups.blocks.MessageListenerAdapter
Receive message from group.
receive(Message) - Method in class org.jgroups.blocks.NotificationBus
 
receive(Message) - Method in class org.jgroups.blocks.ReplicatedHashtable
 
receive(Message) - Method in class org.jgroups.blocks.ReplicatedTree
Callback.
receive(Xid, byte[], byte[], long, long, boolean) - Method in interface org.jgroups.blocks.ReplicationReceiver
Receives data sent by a sender to all group members and applies update to locally replicated data.
receive(Event) - Method in class org.jgroups.blocks.RequestCorrelator
Callback.
receive(Message) - Method in class org.jgroups.blocks.VotingAdapter
Receive the message.
receive(Event) - Method in interface org.jgroups.debug.Simulator.Receiver
 
receive(Event) - Method in class org.jgroups.debug.Simulator
 
receive(Message) - Method in class org.jgroups.demos.Chat
 
receive(Message) - Method in class org.jgroups.demos.QuoteServer
 
receive(Message) - Method in class org.jgroups.demos.wb.Whiteboard
 
receive(long) - Method in class org.jgroups.jmx.JChannel
 
receive(long) - Method in interface org.jgroups.jmx.JChannelMBean
 
receive(Address, byte[], int, int) - Method in class org.jgroups.protocols.TCP
ConnectionTable.Receiver interface
receive(Address, Address, byte[], int, int) - Method in class org.jgroups.protocols.TP
Subclasses must call this method when a unicast or multicast message has been received.
receive(DatagramPacket) - Method in class org.jgroups.protocols.UDP_NIO.ConnectorTable
 
receive(DatagramPacket) - Method in class org.jgroups.protocols.UDP_NIO.MyReceiver
 
receive(DatagramPacket) - Method in class org.jgroups.protocols.UDP_NIO
 
receive(byte[]) - Method in class org.jgroups.protocols.WANPIPE
 
receive(long) - Method in class org.jgroups.stack.ProtocolStack
 
receive() - Method in class org.jgroups.stack.RouterStub
Receives a message from the router (blocking mode).
receiveDownEvent(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(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(Event) - Method in class org.jgroups.protocols.GMS
 
receiveDownEvent(Event) - Method in class org.jgroups.stack.Protocol
Internal method, should not be called by clients.
receiveMessage(Message) - Method in class org.jgroups.blocks.RequestCorrelator
Handles a message coming from a layer below
receivePacket(DatagramPacket, DatagramSocket, Receiver) - Static method in class org.jgroups.protocols.UDP_NIO.ConnectorTable
 
receiveResponse(Message) - Method in class org.jgroups.blocks.GroupRequest
Callback (called by RequestCorrelator or Transport).
receiveResponse(Message) - Method in interface org.jgroups.blocks.RspCollector
 
receiveSuspect(Address) - Method in class org.jgroups.blocks.RequestCorrelator
Event.SUSPECT event received from a layer below.
receiveToken(int) - Method in interface org.jgroups.protocols.ring.RingNode
 
receiveToken() - Method in interface org.jgroups.protocols.ring.RingNode
 
receiveToken(int) - Method in class org.jgroups.protocols.ring.TcpRingNode
 
receiveToken() - Method in class org.jgroups.protocols.ring.TcpRingNode
 
receiveToken(int) - Method in class org.jgroups.protocols.ring.UdpRingNode
 
receiveToken() - Method in class org.jgroups.protocols.ring.UdpRingNode
 
receiveUpEvent(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(Event) - Method in class org.jgroups.stack.Protocol
Internal method, should not be called by clients.
receiveUpEvent(Event) - Method in class org.jgroups.stack.ProtocolStack
 
receiveView(View) - Method in class org.jgroups.blocks.RequestCorrelator
Event.VIEW_CHANGE event received from a layer below.
receive_buffer - Variable in class org.jgroups.protocols.UDP_NIO.Connector
Buffer for incoming unicast packets
receivedHeartbeatAgain(InetAddress, int, InetAddress, int) - Method in interface org.jgroups.blocks.Link.Receiver
 
receivedHeartbeatAgain(InetAddress, int, InetAddress, int) - Method in interface org.jgroups.blocks.LogicalLink.Receiver
 
receivedHeartbeatAgain(InetAddress, int, InetAddress, int) - Method in class org.jgroups.blocks.LogicalLink
Heartbeat came back again (before link was taken down) after missing some heartbeats
receivedHeartbeatAgain(InetAddress, int, InetAddress, int) - Method in class org.jgroups.protocols.WANPIPE
 
received_bytes - Variable in class org.jgroups.JChannel
 
received_msgs - Variable in class org.jgroups.JChannel
 
receiver - Variable in class org.jgroups.Channel
 
receiver_thread - Variable in class org.jgroups.blocks.PullPushAdapter
 
reconfigure(Vector) - Method in interface 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(int) - Method in class org.jgroups.stack.RouterStub
Tries to establish connection to router.
reconnect() - Method in class org.jgroups.stack.RouterStub
 
register(String, Address) - Method in class org.jgroups.stack.GossipClient
Adds the member to the given group.
register(String) - Method in class org.jgroups.stack.RouterStub
Register this process with the router under groupname.
registerChannel(JChannel, MBeanServer, String, boolean) - Static method in class org.jgroups.jmx.JmxConfigurator
Registers an already created channel with the MBeanServer.
registerListener(Serializable, MessageListener) - Method in class org.jgroups.blocks.PullPushAdapter
Sets a listener to messages with a given identifier.
registerManager(PersistenceManager) - Method in class org.jgroups.persistence.PersistenceFactory
Register a custom persistence manager as opposed to the FilePersistenceManager or DBPersistenceManager.
registerProtocols(MBeanServer, JChannel, String) - Static method in class org.jgroups.jmx.JmxConfigurator
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
 
remove(Address) - Method in class org.jgroups.Membership
removes an member from the membership.
remove(Collection) - Method in class org.jgroups.Membership
removes all the members contained in v from this membership
remove(Address) - Method in class org.jgroups.blocks.ConnectionTable
Remove addrfrom connection table.
remove(Object) - Method in class org.jgroups.blocks.DistributedHashtable
Removes the key (and its corresponding value) from the Hashtable.
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(long) - Method in class org.jgroups.blocks.DistributedQueue
 
remove(String) - Method in class org.jgroups.blocks.DistributedTree
 
remove(String, int) - Method in class org.jgroups.blocks.DistributedTree
 
remove(Object) - Method in class org.jgroups.blocks.ReplicatedHashtable
Removes the key (and its corresponding value) from the Hashtable.
remove(String) - Method in class org.jgroups.blocks.ReplicatedTree
Removes the node from the tree.
remove(String, String) - Method in class org.jgroups.blocks.ReplicatedTree
Removes key from the node's hashmap
remove(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 interface org.jgroups.persistence.PersistenceManager
Remove existing NV from being persisted
remove(Object, Vector) - Method in class org.jgroups.stack.AckMcastReceiverWindow
 
remove(Address) - Method in class org.jgroups.stack.AckMcastSenderWindow
Remove obj from all receiver sets and wake up retransmission thread.
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.stack.NakReceiverWindow
 
remove(long) - Method in class org.jgroups.stack.Retransmitter
Remove the given sequence number from the list of seqnos eligible for retransmission.
remove() - Method in class org.jgroups.util.LinkedListQueue
Removes 1 element from head or blocks until next element has been added
remove(long) - Method in class org.jgroups.util.LinkedListQueue
Removes 1 element from the head.
remove() - Method in class org.jgroups.util.List
Removes an object from the tail of the list.
remove() - Method in class org.jgroups.util.Queue
Removes 1 element from head or blocks until next element has been added or until queue has been closed
remove(long) - Method in class org.jgroups.util.Queue
Removes 1 element from the head.
remove() - 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(long) - Method in class org.jgroups.util.Queue2
Removes 1 element from the head.
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.
removeChannelListener(ChannelListener) - Method in class org.jgroups.Channel
 
removeChannelListener(ChannelListener) - Method in class org.jgroups.blocks.RpcDispatcher
 
removeChannelListener(ChannelListener) - Method in class org.jgroups.jmx.JChannel
 
removeConnectionListener(ConnectionTable.ConnectionListener) - Method in class org.jgroups.blocks.ConnectionTable
 
removeDistributedTreeListener(DistributedTree.DistributedTreeListener) - Method in class org.jgroups.blocks.DistributedTree
 
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(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
 
removeListener(TwoPhaseVotingListener) - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter
Removes the listener from the voteChannel
removeMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.MembershipListenerAdapter
Remove membership listener from this adapter.
removeMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.PullPushAdapter
 
removeMessageListener(MessageListener) - Method in class org.jgroups.blocks.MessageListenerAdapter
Remove message listener from this adapter.
removeNode(Object) - Method in class org.jgroups.demos.Topology
 
removeNode(Object) - Method in class org.jgroups.demos.wb.GraphPanel
 
removeNode(Object) - Method in class org.jgroups.demos.wb.Whiteboard
 
removeNotifier(DistributedHashtable.Notification) - Method in class org.jgroups.blocks.DistributedHashtable
 
removeNotifier(DistributedQueue.Notification) - Method in class org.jgroups.blocks.DistributedQueue
 
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.
removeReplicatedTreeListener(ReplicatedTree.ReplicatedTreeListener) - Method in class org.jgroups.blocks.ReplicatedTree
 
removeStateTransferListener(ReplicatedHashtable.StateTransferListener) - Method in class org.jgroups.blocks.ReplicatedHashtable
 
removeViewListener(DistributedTree.ViewListener) - Method in class org.jgroups.blocks.DistributedTree
 
removeVoteListener(VotingListener) - Method in class org.jgroups.blocks.VotingAdapter
Removes voting listener.
repaint() - Method in class org.jgroups.demos.wb.Whiteboard
 
replace(String, String, String) - Static method in class org.jgroups.conf.XmlConfigurator
 
replace(Digest) - Method in class org.jgroups.protocols.pbcast.Digest
 
req_handler - Variable in class org.jgroups.blocks.MessageDispatcher
 
requestTypeToString(int) - Static method in class org.jgroups.stack.GossipRouter
 
request_handler - Variable in class org.jgroups.blocks.RequestCorrelator
The handler for the incoming requests.
request_msg - Variable in class org.jgroups.blocks.GroupRequest
 
requester - Variable in class org.jgroups.blocks.DistributedLockManager.LockDecree
 
requester - Variable in class org.jgroups.stack.StateTransferInfo
 
requests - Variable in class org.jgroups.blocks.RequestCorrelator
The table of pending requests (keys=Long (request IDs), values=RequestEntry)
requiredDownServices() - Method in class org.jgroups.protocols.FLUSH
 
requiredDownServices() - Method in class org.jgroups.protocols.GMS
 
requiredDownServices() - Method in class org.jgroups.protocols.MERGE2
 
requiredDownServices() - Method in class org.jgroups.protocols.TOTAL
 
requiredDownServices() - Method in class org.jgroups.protocols.pbcast.GMS
 
requiredDownServices() - Method in class org.jgroups.protocols.pbcast.STABLE
 
requiredDownServices() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
requiredDownServices() - Method in class org.jgroups.stack.Protocol
List of events that are required to be answered by some layer below.
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
 
requiredUpServices() - Method in class org.jgroups.protocols.TOTAL
 
requiredUpServices() - Method in class org.jgroups.stack.Protocol
List of events that are required to be answered by some layer above.
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.blocks.DistributedQueue
 
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.
reset() - Method in class org.jgroups.blocks.NBMessageForm_NIO
 
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.protocols.LOSS
Just remove if you don't need to reset any state
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.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() - Method in class org.jgroups.protocols.pbcast.Digest.Entry
 
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.stack.Interval
 
reset() - Method in class org.jgroups.stack.NakReceiverWindow
Reset the retransmitter and the nak window
reset() - Method in class org.jgroups.stack.Retransmitter
Reset the retransmitter: clear all msgs and cancel all the respective tasks
reset(ViewId, List) - Method in class org.jgroups.util.AckCollector
 
reset(int) - Method in class org.jgroups.util.ExposedBufferedInputStream
 
reset(int) - Method in class org.jgroups.util.ExposedBufferedOutputStream
 
reset() - Method in class org.jgroups.util.ExposedDataOutputStream
 
reset() - Method in class org.jgroups.util.LinkedListQueue
resets the queue.
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.util.RspList
 
resetAt(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.JChannel
 
resetStats() - Method in class org.jgroups.jmx.JChannel
 
resetStats() - Method in interface org.jgroups.jmx.JChannelMBean
 
resetStats() - Method in class org.jgroups.jmx.Protocol
 
resetStats() - Method in interface org.jgroups.jmx.ProtocolMBean
 
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.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
 
resetStats() - Method in class org.jgroups.protocols.pbcast.GMS
 
resetStats() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
resetStats() - Method in class org.jgroups.protocols.pbcast.STABLE
 
resetStats() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
resetStats() - Method in class org.jgroups.stack.Protocol
 
resolveClass(ObjectStreamClass) - Method in class org.jgroups.util.ContextObjectInputStream
 
resolveEntity(String, String) - Method in class org.jgroups.conf.ClassPathEntityResolver
 
result - Variable 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 interface org.jgroups.jmx.JChannelMBean
 
resume() - Method in class org.jgroups.util.ReusableThread
Resumes the thread.
resumeViewHandler() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
 
resumeViewHandler() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
 
resumeViewHandler() - Method in class org.jgroups.protocols.pbcast.GMS
 
resumed(Runnable) - Method in interface org.jgroups.util.SchedulerListener
 
retransmit(long, Message, Address) - Method in class org.jgroups.protocols.SMACK
 
retransmit(long, Message) - Method in class org.jgroups.protocols.UNICAST
Called by AckSenderWindow to resend messages for which no ACK has been received yet
retransmit(long, long, Address) - Method in class org.jgroups.protocols.pbcast.NAKACK
Implementation of Retransmitter.RetransmitCommand.
retransmit(long, Message, Address) - Method in interface org.jgroups.stack.AckMcastSenderWindow.RetransmitCommand
Retranmit the given msg
retransmit(long, Message) - Method in interface org.jgroups.stack.AckSenderWindow.RetransmitCommand
 
retransmit(long, long, Address) - Method in class org.jgroups.stack.AckSenderWindow
 
retransmit(long, long, Address) - Method in interface org.jgroups.stack.Retransmitter.RetransmitCommand
Get the missing messages between sequence numbers first_seqno and last_seqno.
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 interface 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 interface org.jgroups.jmx.JChannelMBean
 
rollback(Xid) - Method in class org.jgroups.blocks.ReplicationManager
Discards all modifications sent to the receivers via ReplicationManager.send(org.jgroups.Address, byte[], boolean, long, org.jgroups.blocks.Xid, byte[], long, long, boolean) and releases all locks associated with this transaction.
rollback(Xid) - Method in interface org.jgroups.blocks.ReplicationReceiver
Discard all modifications and release all locks.
rrror(String) - Method in class org.jgroups.demos.TotalOrder
 
rsp_expected - Variable in class org.jgroups.blocks.RequestCorrelator.Header
msg is synchronous if true
rsp_mode - Variable in class org.jgroups.blocks.GroupRequest
 
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.blocks.Link
Receiver thread main loop.
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.demos.CausalDemo
 
run() - Method in class org.jgroups.demos.DrawRepl
 
run() - Method in class org.jgroups.demos.Gossip
 
run() - Method in class org.jgroups.demos.TotalTokenDemo
 
run() - Method in class org.jgroups.demos.applets.DrawApplet
 
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.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.PingSender
 
run() - Method in class org.jgroups.protocols.PingWaiter
 
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.protocols.TUNNEL
 
run() - Method in class org.jgroups.protocols.UDP.UcastReceiver
 
run() - Method in class org.jgroups.protocols.UDP
 
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.
run() - Method in class org.jgroups.protocols.pbcast.FD
 
run() - Method in class org.jgroups.protocols.pbcast.PBCAST
Gossip thread.
run() - Method in class org.jgroups.stack.GossipServer
Deprecated.  
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 interface org.jgroups.util.TimeScheduler.Task
Execute the task
runMessageGarbageCollection() - Method in class org.jgroups.jmx.protocols.pbcast.STABLE
 
runMessageGarbageCollection() - Method in interface org.jgroups.jmx.protocols.pbcast.STABLEMBean
 
runMessageGarbageCollection() - Method in class org.jgroups.protocols.pbcast.STABLE
 

S

SECRETKEY - Static variable in class org.jgroups.protocols.ENCRYPT.EncryptHeader
 
SECRETKEY_READY - Static variable in class org.jgroups.protocols.ENCRYPT.EncryptHeader
 
SEND - Static variable in class org.jgroups.blocks.ReplicationData
 
SEPARATOR - Static variable in class org.jgroups.blocks.ReplicatedTree
 
SERIALIZABLE - Static variable in class org.jgroups.blocks.Xid
Reads and writes require locks.
SERVER_PUBKEY - Static variable in class org.jgroups.protocols.ENCRYPT.EncryptHeader
 
SET_DIGEST - Static variable in class org.jgroups.Event
 
SET_LOCAL_ADDRESS - Static variable in class org.jgroups.Event
 
SET_PARTITIONS - Static variable in class org.jgroups.Event
 
SET_PID - Static variable in class org.jgroups.Event
 
SHORT_SIZE - Static variable in class org.jgroups.Global
Value is 2.
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 variable in class org.jgroups.stack.GossipRouter
 
SHUTDOWN_OK - Static variable in class org.jgroups.stack.GossipRouter
 
SIGNATURE - Static variable in class org.jgroups.blocks.MethodCall
Provide a signature, similar to JMX.
SIZE - class org.jgroups.protocols.SIZE.
Protocol which prints out the real size of a message.
SIZE() - Constructor for class org.jgroups.protocols.SIZE
 
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.
 
SMACK.SmackHeader() - Constructor for class org.jgroups.protocols.SMACK.SmackHeader
 
SMACK.SmackHeader(int, long) - Constructor for class org.jgroups.protocols.SMACK.SmackHeader
 
SRC_PROPERTY - Static variable in class org.jgroups.protocols.JMS
 
STABILITY - Static variable in class org.jgroups.protocols.pbcast.STABLE.StableHeader
 
STABLE - Static variable in class org.jgroups.Event
 
STABLE - class org.jgroups.jmx.protocols.pbcast.STABLE.
 
STABLE() - Constructor for class org.jgroups.jmx.protocols.pbcast.STABLE
 
STABLE(Protocol) - Constructor for 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() - Constructor for class org.jgroups.protocols.STABLE
 
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.protocols.pbcast.STABLE
 
STABLE.StableHeader - class org.jgroups.protocols.pbcast.STABLE.StableHeader.
 
STABLE.StableHeader() - Constructor for class org.jgroups.protocols.pbcast.STABLE.StableHeader
 
STABLE.StableHeader(int, Digest) - Constructor for class org.jgroups.protocols.pbcast.STABLE.StableHeader
 
STABLEMBean - interface org.jgroups.jmx.protocols.pbcast.STABLEMBean.
 
STABLE_GOSSIP - Static variable in class org.jgroups.protocols.pbcast.STABLE.StableHeader
 
START - Static variable in class org.jgroups.Event
 
START_OK - Static variable in class org.jgroups.Event
 
START_QUEUEING - Static variable in class org.jgroups.Event
 
STATE_RECEIVED - Static variable in class org.jgroups.Event
 
STATE_REQ - Static variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
STATE_RSP - Static variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
STATE_TRANSFER - class org.jgroups.jmx.protocols.pbcast.STATE_TRANSFER.
 
STATE_TRANSFER() - Constructor for class org.jgroups.jmx.protocols.pbcast.STATE_TRANSFER
 
STATE_TRANSFER(Protocol) - Constructor for class org.jgroups.jmx.protocols.pbcast.STATE_TRANSFER
 
STATE_TRANSFER - class org.jgroups.protocols.STATE_TRANSFER.
State transfer layer.
STATE_TRANSFER() - Constructor for class org.jgroups.protocols.STATE_TRANSFER
 
STATE_TRANSFER - class org.jgroups.protocols.pbcast.STATE_TRANSFER.
New STATE_TRANSFER protocol based on PBCAST.
STATE_TRANSFER() - Constructor for class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
STATE_TRANSFER.StateHeader - class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader.
Wraps data for a state request/response.
STATE_TRANSFER.StateHeader() - Constructor for class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
STATE_TRANSFER.StateHeader(byte, Address, long, Digest) - Constructor for class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
STATE_TRANSFERMBean - interface org.jgroups.jmx.protocols.pbcast.STATE_TRANSFERMBean.
 
STATS - class org.jgroups.jmx.protocols.STATS.
 
STATS() - Constructor for class org.jgroups.jmx.protocols.STATS
 
STATS(Protocol) - Constructor for class org.jgroups.jmx.protocols.STATS
 
STATS - class org.jgroups.protocols.STATS.
Provides various stats
STATS() - Constructor for class org.jgroups.protocols.STATS
 
STATSMBean - interface org.jgroups.jmx.protocols.STATSMBean.
 
STOP - Static variable in class org.jgroups.Event
 
STOP_OK - Static variable in class org.jgroups.Event
 
STOP_QUEUEING - Static variable in class org.jgroups.Event
 
SUBVIEWSET_MERGE - Static variable in class org.jgroups.Event
 
SUBVIEW_MERGE - Static variable in class org.jgroups.Event
 
SUSPECT - Static variable in class org.jgroups.Channel
 
SUSPECT - Static variable in class org.jgroups.Event
 
SUSPECT - Static variable in class org.jgroups.protocols.FD.FdHeader
 
SUSPECT - Static variable in class org.jgroups.protocols.FD_SOCK.FdHeader
 
SUSPEND_STABLE - Static variable in class org.jgroups.Event
 
SWITCH_NAK - Static variable in class org.jgroups.Event
 
SWITCH_NAK_ACK - Static variable in class org.jgroups.Event
 
SWITCH_OUT_OF_BAND - Static variable in class org.jgroups.Event
 
Scheduler - class org.jgroups.util.Scheduler.
Implementation of a priority scheduler.
Scheduler() - Constructor for class org.jgroups.util.Scheduler
 
Scheduler(int) - Constructor for class org.jgroups.util.Scheduler
 
Scheduler.Task - class org.jgroups.util.Scheduler.Task.
 
SchedulerListener - interface org.jgroups.util.SchedulerListener.
Provides callback for use with a Scheduler.
SendDialog - class org.jgroups.demos.wb.SendDialog.
 
SendDialog(Frame, Node, String, RpcDispatcher, String) - Constructor for class org.jgroups.demos.wb.SendDialog
 
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
 
Simulator - class org.jgroups.debug.Simulator.
Tests one or more protocols independently.
Simulator() - Constructor for class org.jgroups.debug.Simulator
 
Simulator.Receiver - interface org.jgroups.debug.Simulator.Receiver.
 
Stack - class org.jgroups.util.Stack.
LIFO stack, with better performance than java.util.Stack (based on List).
Stack() - Constructor for class org.jgroups.util.Stack
 
StateTransferInfo - class org.jgroups.stack.StateTransferInfo.
Contains parameters for state transfer.
StateTransferInfo(Address, int, Address) - Constructor for class org.jgroups.stack.StateTransferInfo
 
StateTransferInfo(int, Address) - Constructor for class org.jgroups.stack.StateTransferInfo
 
StateTransferInfo(int, Vector) - Constructor for class org.jgroups.stack.StateTransferInfo
 
Streamable - interface org.jgroups.util.Streamable.
Implementations of Streamable can add their state directly to the output stream, enabling them to bypass costly serialization
SuspectEvent - class org.jgroups.SuspectEvent.
Represents a suspect event.
SuspectEvent(Object) - Constructor for class org.jgroups.SuspectEvent
 
SuspectedException - exception org.jgroups.SuspectedException.
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
 
sameHost(Address, Address) - Static method in class org.jgroups.util.Util
Checks whether 2 Addresses are on the same host
sameSenders(Digest) - Method in class org.jgroups.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 interface 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 interface org.jgroups.persistence.PersistenceManager
Use to store a complete map into persistent state
saveState() - Method in class org.jgroups.demos.wb.GraphPanel
 
scheduler - Variable in class org.jgroups.blocks.RequestCorrelator
The dispatching thread pool
send(Message) - Method in class org.jgroups.Channel
Sends a message to a (unicast) destination.
send(Address, Address, Serializable) - Method in class org.jgroups.Channel
Helper method.
send(Message) - Method in class org.jgroups.JChannel
Sends a message through the protocol stack.
send(Address, Address, Serializable) - Method in class org.jgroups.JChannel
creates a new message with the destination address, and the source address and the object as the message value
send(Message) - Method in interface org.jgroups.Transport
 
send(Address, byte[], int, int) - Method in class org.jgroups.blocks.ConnectionTable
 
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(Message) - Method in class org.jgroups.blocks.MessageDispatcher
 
send(Serializable, Message) - Method in class org.jgroups.blocks.PullPushAdapter
Sends a message to the group - listeners to this identifier will receive the messages.
send(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(Address, byte[], boolean, long, Xid, byte[], long, long, boolean) - Method in class org.jgroups.blocks.ReplicationManager
Sends a request to all members of the group.
send(Event) - Method in class org.jgroups.debug.Simulator
 
send(Message) - Method in class org.jgroups.jmx.JChannel
 
send(Address, Address, Serializable) - Method in class org.jgroups.jmx.JChannel
 
send(Message) - Method in interface org.jgroups.jmx.JChannelMBean
 
send(Address, Address, Serializable) - Method in interface org.jgroups.jmx.JChannelMBean
 
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.
send(Message) - Method in class org.jgroups.stack.ProtocolStack
 
send(Message, String) - Method in class org.jgroups.stack.RouterStub
Sends a message to the router.
sendClearPanelMsg() - Method in class org.jgroups.demos.Draw
 
sendClearPanelMsg() - Method in class org.jgroups.demos.Draw2Channels
 
sendClearPanelMsg() - Method in class org.jgroups.demos.Gossip
 
sendClearPanelMsg() - Method in class org.jgroups.demos.applets.DrawApplet
 
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(Address, ViewId) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
sendMessage(Message, int, long) - Method in class org.jgroups.blocks.MessageDispatcher
Sends a message to a single member (destination = msg.dest) and returns the response.
sendMessage(Message, int, long) - Method in class org.jgroups.blocks.RpcDispatcher
 
sendMessage(Message) - Method in class org.jgroups.protocols.JMS
Publish message in the JMS topic.
sendMessage(Message, int, long) - Method in class org.jgroups.stack.MessageProtocol
Sends a message to a single member (destination = msg.dest) and returns the response.
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
sendRequest(long, Message, RspCollector) - Method in class org.jgroups.blocks.RequestCorrelator
Helper method for RequestCorrelator.sendRequest(long,List,Message,RspCollector).
sendRequest(long, List, Message, RspCollector) - Method in class org.jgroups.blocks.RequestCorrelator
Send a request to a group.
sendRequest(Address) - Method in class org.jgroups.protocols.DEADLOCK
 
sendToAll(String) - Method in class org.jgroups.jmx.JChannel
 
sendToAll(String) - Method in interface 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(Address, byte[], int, int) - Method in class org.jgroups.protocols.TCP
 
sendToSingleMember(Address, byte[], int, int) - Method in class org.jgroups.protocols.TP
Send to all members in the group.
sendToSingleMember(Address, byte[], int, int) - Method in class org.jgroups.protocols.UDP
 
sendViewRequest() - Method in class org.jgroups.jmx.protocols.VIEW_SYNC
 
sendViewRequest() - Method in interface org.jgroups.jmx.protocols.VIEW_SYNCMBean
 
sendViewRequest() - Method in class org.jgroups.protocols.VIEW_SYNC
Sends a VIEW_SYNC_REQ to all members, every member replies with a VIEW multicast
sender_thread - Variable in class org.jgroups.protocols.UDP_NIO.Connector
 
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 - Variable in class org.jgroups.JChannel
 
sent_msgs - Variable in class org.jgroups.JChannel
 
seq_id - Variable 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 - Variable in class org.jgroups.protocols.TOTAL.Header
The ID imposing the total order of messages
serializedSize() - Method in class org.jgroups.MergeView
 
serializedSize() - Method in class org.jgroups.View
 
serializedSize() - Method in class org.jgroups.ViewId
 
serializedSize() - Method in class org.jgroups.protocols.pbcast.Digest
 
serializedSize() - Method in class org.jgroups.protocols.pbcast.JoinRsp
 
server_obj - Variable in class org.jgroups.blocks.RpcDispatcher
 
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(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(Address, long, long, long) - Method in class org.jgroups.protocols.pbcast.Digest
 
set(Object) - Method in class org.jgroups.util.CondVar
Sets the result
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(Address) - Method in class org.jgroups.protocols.ring.RingToken
 
setAssociatedMessage(Message) - Method in class org.jgroups.protocols.TransportedVectorTime
Sets a message associated with this vector timestamp
setAutoGetState(boolean) - Method in class org.jgroups.jmx.JChannel
 
setAutoGetState(boolean) - Method in interface org.jgroups.jmx.JChannelMBean
 
setAutoReconnect(boolean) - Method in class org.jgroups.jmx.JChannel
 
setAutoReconnect(boolean) - Method in interface org.jgroups.jmx.JChannelMBean
 
setAverageSendInterval(long) - Method in class org.jgroups.jmx.protocols.VIEW_SYNC
 
setAverageSendInterval(long) - Method in interface org.jgroups.jmx.protocols.VIEW_SYNCMBean
 
setAverageSendInterval(long) - Method in class org.jgroups.protocols.VIEW_SYNC
 
setBacklog(int) - Method in class org.jgroups.protocols.ring.RingNodeFlowControl
 
setBindAddr(InetAddress) - Method in class org.jgroups.jmx.protocols.MPING
 
setBindAddr(InetAddress) - Method in interface org.jgroups.jmx.protocols.MPINGMBean
 
setBindAddr(InetAddress) - Method in class org.jgroups.jmx.protocols.TCP
 
setBindAddr(InetAddress) - Method in interface org.jgroups.jmx.protocols.TCPMBean
 
setBindAddr(InetAddress) - Method in class org.jgroups.protocols.MPING
 
setBindAddr(InetAddress) - Method in class org.jgroups.protocols.TCP
 
setBindAddress(String) - Method in class org.jgroups.jmx.protocols.TP
 
setBindAddress(String) - Method in interface org.jgroups.jmx.protocols.TPMBean
 
setBindAddress(String) - Method in class org.jgroups.protocols.TP
 
setBindAddress(String) - Method in class org.jgroups.stack.GossipRouter
 
setBindToAllInterfaces(boolean) - Method in class org.jgroups.jmx.protocols.MPING
 
setBindToAllInterfaces(boolean) - Method in interface org.jgroups.jmx.protocols.MPINGMBean
 
setBindToAllInterfaces(boolean) - Method in class org.jgroups.protocols.MPING
 
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(Address) - Method in class org.jgroups.blocks.GroupRequest
 
setChannel(JChannel) - Method in class org.jgroups.debug.Debugger
 
setChannelListener(ChannelListener) - Method in class org.jgroups.Channel
Deprecated. Use addChannelListener() instead
setChannelListener(ChannelListener) - Method in class org.jgroups.jmx.JChannel
Deprecated. Use addChannelListener() instead
setChannelListener(ChannelListener) - Method in interface org.jgroups.jmx.JChannelMBean
 
setClusterConfig(Element) - Method in class org.jgroups.jmx.JChannel
 
setClusterConfig(Element) - Method in interface org.jgroups.jmx.JChannelMBean
To configure via XML file
setClusterName(String) - Method in class org.jgroups.jmx.JChannel
 
setClusterName(String) - Method in interface 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 interface org.jgroups.jmx.protocols.TCPMBean
 
setConnExpireTime(long) - Method in class org.jgroups.protocols.TCP
 
setConnectorTable(UDP_NIO.ConnectorTable) - Method in class org.jgroups.protocols.UDP_NIO.MyReceiver
 
setConsumer(NotificationBus.Consumer) - Method in class org.jgroups.blocks.NotificationBus
 
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 interface org.jgroups.jmx.protocols.pbcast.STABLEMBean
 
setDesiredAverageGossip(long) - Method in class org.jgroups.protocols.pbcast.STABLE
 
setDest(Address) - Method in class org.jgroups.Message
 
setDigest(Digest) - Method in class org.jgroups.protocols.pbcast.GMS
Send down a SET_DIGEST event
setDigest(Digest) - Method in class org.jgroups.protocols.pbcast.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 interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
 
setDiscardDeliveredMsgs(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK
 
setDiscardIncompatiblePackets(boolean) - Method in class org.jgroups.jmx.protocols.TP
 
setDiscardIncompatiblePackets(boolean) - Method in interface org.jgroups.jmx.protocols.TPMBean
 
setDiscardIncompatiblePackets(boolean) - Method in class org.jgroups.protocols.TP
 
setDone(String, int) - Method in class org.jgroups.protocols.PerfHeader
 
setDownProtocol(Protocol) - Method in class org.jgroups.stack.Protocol
 
setEnableBundling(boolean) - Method in class org.jgroups.jmx.protocols.TP
 
setEnableBundling(boolean) - Method in interface org.jgroups.jmx.protocols.TPMBean
 
setEnableBundling(boolean) - Method in class org.jgroups.protocols.TP
 
setEndPort(int) - Method in class org.jgroups.jmx.protocols.TCP
 
setEndPort(int) - Method in interface org.jgroups.jmx.protocols.TCPMBean
 
setEndPort(int) - Method in class org.jgroups.protocols.TCP
 
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.jmx.protocols.FRAG2
 
setFragSize(int) - Method in interface org.jgroups.jmx.protocols.FRAG2MBean
 
setFragSize(int) - Method in interface org.jgroups.jmx.protocols.FRAGMBean
 
setFragSize(int) - Method in class org.jgroups.protocols.FRAG
 
setFragSize(int) - Method in class org.jgroups.protocols.FRAG2
 
setGcLag(int) - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
 
setGcLag(int) - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
 
setGcLag(int) - Method in class org.jgroups.protocols.pbcast.NAKACK
 
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 interface org.jgroups.jmx.JChannelMBean
 
setHighSeqnoAt(Address, long) - Method in class org.jgroups.protocols.pbcast.Digest
 
setHighSeqnoSeenAt(Address, long) - Method in class org.jgroups.protocols.pbcast.Digest
 
setHighestDeliveredAndSeenSeqnos(Address, long, long) - Method in class org.jgroups.protocols.pbcast.Digest
 
setHighestSequence(long) - Method in class org.jgroups.protocols.ring.RingToken
 
setId(short) - Method in class org.jgroups.blocks.MethodCall
 
setImpl(GmsImpl) - Method in class org.jgroups.protocols.GMS
 
setImpl(GmsImpl) - Method in class org.jgroups.protocols.pbcast.GMS
 
setInitialMembers(int) - Method in class org.jgroups.jmx.protocols.Discovery
 
setInitialMembers(int) - Method in interface org.jgroups.jmx.protocols.DiscoveryMBean
 
setJoinRetryTimeout(long) - Method in class org.jgroups.jmx.protocols.pbcast.GMS
 
setJoinRetryTimeout(long) - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
 
setJoinRetryTimeout(long) - Method in class org.jgroups.protocols.pbcast.GMS
 
setJoinTimeout(long) - Method in class org.jgroups.jmx.protocols.pbcast.GMS
 
setJoinTimeout(long) - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
 
setJoinTimeout(long) - Method in class org.jgroups.protocols.pbcast.GMS
 
setKeyServerAddr(Address) - Method in class org.jgroups.protocols.ENCRYPT
 
setLength(int) - Method in class org.jgroups.util.Buffer
 
setListener(MessageListener) - Method in class org.jgroups.blocks.PullPushAdapter
 
setListener(NakReceiverWindow.Listener) - Method in class org.jgroups.stack.NakReceiverWindow
 
setListener(SchedulerListener) - Method in class org.jgroups.util.Scheduler
 
setLocalAddress(Address) - Method in class org.jgroups.blocks.RequestCorrelator
 
setLocalAddress(Address) - Method in class org.jgroups.debug.Simulator
 
setLocal_addr(Address) - Method in class org.jgroups.protocols.ENCRYPT
 
setLoopback(boolean) - Method in class org.jgroups.jmx.protocols.TP
 
setLoopback(boolean) - Method in interface org.jgroups.jmx.protocols.TPMBean
 
setLoopback(boolean) - Method in class org.jgroups.protocols.TCP
 
setLoopback(boolean) - Method in class org.jgroups.protocols.TP
 
setMBeanServerName(String) - Method in class org.jgroups.jmx.JChannel
 
setMarshaller(RpcDispatcher.Marshaller) - Method in class org.jgroups.blocks.RpcDispatcher
 
setMaxBlockTime(long) - Method in class org.jgroups.jmx.protocols.FC
 
setMaxBlockTime(long) - Method in interface org.jgroups.jmx.protocols.FCMBean
 
setMaxBlockTime(long) - Method in class org.jgroups.protocols.FC
 
setMaxBundleSize(int) - Method in class org.jgroups.jmx.protocols.TP
 
setMaxBundleSize(int) - Method in interface org.jgroups.jmx.protocols.TPMBean
 
setMaxBundleSize(int) - Method in class org.jgroups.protocols.TP
 
setMaxBundleTimeout(long) - Method in class org.jgroups.jmx.protocols.TP
 
setMaxBundleTimeout(long) - Method in interface org.jgroups.jmx.protocols.TPMBean
 
setMaxBundleTimeout(long) - Method in class org.jgroups.protocols.TP
 
setMaxBytes(long) - Method in class org.jgroups.jmx.protocols.pbcast.STABLE
 
setMaxBytes(long) - Method in interface org.jgroups.jmx.protocols.pbcast.STABLEMBean
 
setMaxBytes(long) - Method in class org.jgroups.protocols.pbcast.STABLE
 
setMaxCredits(long) - Method in class org.jgroups.jmx.protocols.FC
 
setMaxCredits(long) - Method in interface org.jgroups.jmx.protocols.FCMBean
 
setMaxCredits(long) - Method in class org.jgroups.protocols.FC
 
setMaxInterval(long) - Method in class org.jgroups.jmx.protocols.MERGE2
 
setMaxInterval(long) - Method in interface org.jgroups.jmx.protocols.MERGE2MBean
 
setMaxInterval(long) - Method in class org.jgroups.protocols.MERGE2
 
setMaxTries(int) - Method in class org.jgroups.jmx.protocols.FD
 
setMaxTries(int) - Method in interface org.jgroups.jmx.protocols.FDMBean
 
setMaxTries(int) - Method in class org.jgroups.protocols.FD
 
setMaxXmitBufSize(int) - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
 
setMaxXmitBufSize(int) - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
 
setMaxXmitBufSize(int) - Method in class org.jgroups.protocols.pbcast.NAKACK
 
setMaxXmitBufSize(int) - Method in class org.jgroups.stack.NakReceiverWindow
 
setMaxXmitSize(long) - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
 
setMaxXmitSize(long) - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
 
setMaxXmitSize(long) - Method in class org.jgroups.protocols.pbcast.NAKACK
 
setMcastAddr(InetAddress) - Method in class org.jgroups.jmx.protocols.MPING
 
setMcastAddr(InetAddress) - Method in interface org.jgroups.jmx.protocols.MPINGMBean
 
setMcastAddr(InetAddress) - Method in class org.jgroups.protocols.MPING
 
setMcastPort(int) - Method in class org.jgroups.jmx.protocols.MPING
 
setMcastPort(int) - Method in interface org.jgroups.jmx.protocols.MPINGMBean
 
setMcastPort(int) - Method in class org.jgroups.protocols.MPING
 
setMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.MessageDispatcher
 
setMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.PullPushAdapter
Deprecated. Use PullPushAdapter.addMembershipListener(org.jgroups.MembershipListener)
setMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.ReplicationManager
 
setMessageListener(MessageListener) - Method in class org.jgroups.blocks.MessageDispatcher
 
setMethod(Method) - Method in class org.jgroups.blocks.MethodCall
 
setMethodLookup(MethodLookup) - Method in class org.jgroups.blocks.RpcDispatcher
 
setMinCredits(long) - Method in class org.jgroups.jmx.protocols.FC
 
setMinCredits(long) - Method in interface org.jgroups.jmx.protocols.FCMBean
 
setMinCredits(long) - Method in class org.jgroups.protocols.FC
 
setMinInterval(long) - Method in class org.jgroups.jmx.protocols.MERGE2
 
setMinInterval(long) - Method in interface org.jgroups.jmx.protocols.MERGE2MBean
 
setMinInterval(long) - Method in class org.jgroups.protocols.MERGE2
 
setMinThreshold(double) - Method in class org.jgroups.jmx.protocols.FC
 
setMinThreshold(double) - Method in interface org.jgroups.jmx.protocols.FCMBean
 
setMinThreshold(double) - Method in class org.jgroups.protocols.FC
 
setMultipleLocked(boolean) - Method in class org.jgroups.blocks.DistributedLockManager.LockDecree
 
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 interface org.jgroups.jmx.JChannelMBean
 
setObserver(ProtocolObserver) - Method in class org.jgroups.jmx.Protocol
 
setObserver(ProtocolObserver) - Method in interface org.jgroups.jmx.ProtocolMBean
 
setObserver(QUEUE.Observer) - Method in class org.jgroups.protocols.QUEUE
Only 1 observer is allowed.
setObserver(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 interface org.jgroups.jmx.protocols.TPMBean
 
setOutgoingQueueMaxSize(int) - Method in class org.jgroups.protocols.TP
 
setOverhead(int) - Method in class org.jgroups.jmx.protocols.FRAG2
 
setOverhead(int) - Method in interface org.jgroups.jmx.protocols.FRAG2MBean
 
setOverhead(int) - Method in class org.jgroups.protocols.FRAG2
 
setPersistent(boolean) - Method in class org.jgroups.blocks.DistributedHashtable
 
setPingRequests(int) - Method in class org.jgroups.jmx.protocols.Discovery
 
setPingRequests(int) - Method in interface 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(String) - Method in class org.jgroups.jmx.JChannel
 
setProperties(String) - Method in interface org.jgroups.jmx.JChannelMBean
 
setProperties(Properties) - Method in class org.jgroups.jmx.Protocol
 
setProperties(Properties) - Method in interface org.jgroups.jmx.ProtocolMBean
 
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
 
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
 
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.FD_PID
 
setProperties(Properties) - Method in class org.jgroups.protocols.FD_PROB
 
setProperties(Properties) - Method in class org.jgroups.protocols.FD_SIMPLE
 
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.HTOTAL
 
setProperties(Properties) - Method in class org.jgroups.protocols.JMS
Set protocol properties.
setProperties(Properties) - Method in class org.jgroups.protocols.MERGE
 
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
 
setProperties(Properties) - Method in class org.jgroups.protocols.NAKACK
 
setProperties(Properties) - Method in class org.jgroups.protocols.PARTITIONER
 
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.protocols.SHUFFLE
 
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.STATE_TRANSFER
 
setProperties(Properties) - Method in class org.jgroups.protocols.STATS
 
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.TCPGOSSIP
 
setProperties(Properties) - Method in class org.jgroups.protocols.TCPPING
 
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.TOTAL
 
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
 
setProperties(Properties) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
 
setProperties(Properties) - Method in class org.jgroups.protocols.VIEW_SYNC
 
setProperties(Properties) - Method in class org.jgroups.protocols.WANPING
 
setProperties(Properties) - Method in class org.jgroups.protocols.WANPIPE
Setup the Protocol instance acording to the configuration string
setProperties(Properties) - Method in class org.jgroups.protocols.pbcast.FD
 
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.pbcast.NAKACK
 
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.pbcast.STABLE
 
setProperties(Properties) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
setProperties(Properties) - Method in class org.jgroups.stack.Protocol
Configures the protocol initially.
setPropertiesInternal(Properties) - Method in class org.jgroups.stack.Protocol
Called by Configurator.
setProtocol(Protocol) - Method in class org.jgroups.debug.ProtocolView
 
setProtocol(Protocol) - Method in interface org.jgroups.stack.ProtocolObserver
Called when a ProtocolObserver is attached to a protcol.
setProtocolStack(Protocol[]) - Method in class org.jgroups.debug.Simulator
 
setProtocolStack(ProtocolStack) - Method in class org.jgroups.stack.Protocol
 
setQuote(String, Float) - Method in class org.jgroups.demos.QuoteServer
 
setReaperInterval(long) - Method in class org.jgroups.jmx.protocols.TCP
 
setReaperInterval(long) - Method in interface org.jgroups.jmx.protocols.TCPMBean
 
setReaperInterval(long) - Method in class org.jgroups.protocols.TCP
 
setReceiveBlockEvents(boolean) - Method in class org.jgroups.jmx.JChannel
 
setReceiveBlockEvents(boolean) - Method in interface org.jgroups.jmx.JChannelMBean
 
setReceiveBufferSize(int) - Method in class org.jgroups.blocks.ConnectionTable
 
setReceiveLocalMessages(boolean) - Method in class org.jgroups.jmx.JChannel
 
setReceiveLocalMessages(boolean) - Method in interface org.jgroups.jmx.JChannelMBean
 
setReceiveStateEvents(boolean) - Method in class org.jgroups.jmx.JChannel
 
setReceiveStateEvents(boolean) - Method in interface org.jgroups.jmx.JChannelMBean
 
setReceiveSuspectEvents(boolean) - Method in class org.jgroups.jmx.JChannel
 
setReceiveSuspectEvents(boolean) - Method in interface org.jgroups.jmx.JChannelMBean
 
setReceiveViewEvents(boolean) - Method in class org.jgroups.jmx.JChannel
 
setReceiveViewEvents(boolean) - Method in interface org.jgroups.jmx.JChannelMBean
 
setReceived(String, int) - Method in class org.jgroups.protocols.PerfHeader
 
setReceived(boolean) - Method in class org.jgroups.util.Rsp
 
setReceiver(Receiver) - Method in class org.jgroups.Channel
Sets the receiver, which will handle all messages, view changes etc
setReceiver(ConnectionTable.Receiver) - Method in class org.jgroups.blocks.ConnectionTable
 
setReceiver(Link.Receiver) - Method in class org.jgroups.blocks.Link
 
setReceiver(LogicalLink.Receiver) - Method in class org.jgroups.blocks.LogicalLink
 
setReceiver(Simulator.Receiver) - Method in class org.jgroups.debug.Simulator
 
setReceiver(Receiver) - Method in class org.jgroups.protocols.UDP_NIO.ConnectorTable
 
setRemoteCalls(boolean) - Method in class org.jgroups.blocks.ReplicatedTree
 
setReplicationReceiver(ReplicationReceiver) - Method in class org.jgroups.blocks.ReplicationManager
 
setRequestHandler(RequestHandler) - Method in class org.jgroups.blocks.MessageDispatcher
 
setRequestHandler(RequestHandler) - Method in class org.jgroups.blocks.RequestCorrelator
 
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
 
setRootNode(ReplicatedTree.Node) - Method in class org.jgroups.blocks.ReplicatedTree
 
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 interface org.jgroups.jmx.protocols.FDMBean
 
setShun(boolean) - Method in class org.jgroups.jmx.protocols.pbcast.GMS
 
setShun(boolean) - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
 
setShun(boolean) - Method in class org.jgroups.protocols.FD
 
setShun(boolean) - Method in class org.jgroups.protocols.pbcast.GMS
 
setSocketConnectionTimeout(int) - Method in class org.jgroups.blocks.ConnectionTable
 
setSrc(Address) - Method in class org.jgroups.Message
 
setStartPort(int) - Method in class org.jgroups.jmx.protocols.TCP
 
setStartPort(int) - Method in interface org.jgroups.jmx.protocols.TCPMBean
 
setStartPort(int) - Method in class org.jgroups.protocols.TCP
 
setState(byte[]) - Method in interface org.jgroups.MessageListener
Sets the group state; e.g., when joining.
setState(byte[]) - Method in class org.jgroups.ReceiverAdapter
 
setState(byte[]) - Method in class org.jgroups.blocks.DistributedHashtable
 
setState(byte[]) - Method in class org.jgroups.blocks.DistributedQueue
 
setState(byte[]) - Method in class org.jgroups.blocks.DistributedTree
 
setState(byte[]) - Method in class org.jgroups.blocks.MessageListenerAdapter
Set state of ths group.
setState(byte[]) - Method in class org.jgroups.blocks.NotificationBus
 
setState(byte[]) - Method in class org.jgroups.blocks.ReplicatedHashtable
 
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.Chat
 
setState(byte[]) - Method in class org.jgroups.demos.QuoteServer
 
setState(Vector) - Method in class org.jgroups.demos.Topology
 
setState(byte[]) - Method in class org.jgroups.demos.wb.GraphPanel
 
setState(byte[]) - Method in class org.jgroups.demos.wb.Whiteboard
 
setStateListener(MessageListener) - Method in class org.jgroups.blocks.MessageListenerAdapter
Register listener for state notification events.
setStatsEnabled(boolean) - Method in class org.jgroups.jmx.JChannel
 
setStatsEnabled(boolean) - Method in interface org.jgroups.jmx.JChannelMBean
 
setStatsEnabled(boolean) - Method in class org.jgroups.jmx.Protocol
 
setStatsEnabled(boolean) - Method in interface org.jgroups.jmx.ProtocolMBean
 
setSuspected(boolean) - Method in class org.jgroups.util.Rsp
 
setSuspendInterval(long) - Method in class org.jgroups.util.TimeScheduler
 
setTTL(int) - Method in class org.jgroups.jmx.protocols.MPING
 
setTTL(int) - Method in interface org.jgroups.jmx.protocols.MPINGMBean
 
setTTL(int) - Method in class org.jgroups.protocols.MPING
 
setTimeout(long) - Method in class org.jgroups.jmx.protocols.Discovery
 
setTimeout(long) - Method in interface org.jgroups.jmx.protocols.DiscoveryMBean
 
setTimeout(long) - Method in class org.jgroups.jmx.protocols.FD
 
setTimeout(long) - Method in interface org.jgroups.jmx.protocols.FDMBean
 
setTimeout(long) - Method in class org.jgroups.protocols.Discovery
 
setTimeout(long) - Method in class org.jgroups.protocols.FD
 
setTrace(boolean) - Method in class org.jgroups.blocks.Link
 
setTrace(boolean) - Method in class org.jgroups.jmx.Protocol
 
setTrace(boolean) - Method in interface org.jgroups.jmx.ProtocolMBean
 
setTrace(boolean) - Method in class org.jgroups.stack.Protocol
 
setType(int) - Method in class org.jgroups.Event
 
setType(int) - Method in class org.jgroups.protocols.ring.RingToken
 
setUpHandler(UpHandler) - Method in class org.jgroups.Channel
When up_handler is set, all events will be passed to it directly.
setUpProtocol(Protocol) - Method in class org.jgroups.stack.Protocol
 
setUseMcastXmit(boolean) - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
 
setUseMcastXmit(boolean) - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
 
setUseMcastXmit(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK
 
setUseSendQueues(boolean) - Method in class org.jgroups.blocks.ConnectionTable
 
setValue(Object) - Method in class org.jgroups.util.Rsp
 
setView(View) - Method in class org.jgroups.debug.Simulator
 
setView(View) - Method in class org.jgroups.protocols.pbcast.MergeData
 
setVisible(boolean) - Method in class org.jgroups.demos.DistributedTreeDemo
 
setWarn(boolean) - Method in class org.jgroups.jmx.Protocol
 
setWarn(boolean) - Method in interface org.jgroups.jmx.ProtocolMBean
 
setWarn(boolean) - Method in class org.jgroups.stack.Protocol
 
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 interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
 
setXmitFromRandomMember(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK
 
setup() - Method in class org.jgroups.stack.ProtocolStack
 
setupProtocolStack(String, ProtocolStack) - Method in class org.jgroups.stack.Configurator
The configuration string has a number of entries, separated by a ':' (colon).
shortForm() - Method in class org.jgroups.protocols.pbcast.Gossip
 
shortName(String) - Static method in class org.jgroups.util.Util
 
shortName(InetAddress) - Static method in class org.jgroups.util.Util
 
showLastBlockingTimes() - Method in class org.jgroups.jmx.protocols.FC
 
showLastBlockingTimes() - Method in interface org.jgroups.jmx.protocols.FCMBean
 
showLastBlockingTimes() - Method in class org.jgroups.protocols.FC
 
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 interface org.jgroups.persistence.PersistenceManager
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 interface org.jgroups.jmx.JChannelMBean
 
signature - Variable in class org.jgroups.blocks.MethodCall
The signature, e.g., new String[]{String.class.getName(), int.class.getName()}.
size() - Method in interface org.jgroups.Address
Returns serialized size of this address
size() - Method in class org.jgroups.Header
To be implemented by subclasses.
size() - Method in class org.jgroups.Membership
Returns the number of addresses in this membership
size() - Method in class org.jgroups.Message
Returns 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.View
returns the number of members in this view
size() - Method in class org.jgroups.blocks.DistributedQueue
 
size() - Method in class org.jgroups.blocks.PullPushAdapter.PullHeader
 
size() - Method in class org.jgroups.blocks.RequestCorrelator.Header
 
size() - Method in class org.jgroups.protocols.BSH.BshHeader
 
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.ENCRYPT.EncryptHeader
 
size() - Method in class org.jgroups.protocols.FC.FcHeader
 
size() - Method in class org.jgroups.protocols.FD.FdHeader
 
size() - Method in class org.jgroups.protocols.FD_SOCK.FdHeader
 
size() - Method in class org.jgroups.protocols.FragHeader
 
size() - Method in class org.jgroups.protocols.JMS.JMSAddress
 
size() - Method in class org.jgroups.protocols.NakAckHeader
 
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.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.TcpHeader
 
size() - Method in class org.jgroups.protocols.TpHeader
 
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.UNICAST.UnicastHeader
 
size() - Method in class org.jgroups.protocols.UdpHeader
 
size() - Method in class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
 
size() - Method in class org.jgroups.protocols.WANPIPE.WanPipeHeader
 
size() - Method in class org.jgroups.protocols.WanPipeAddress
 
size() - Method in class org.jgroups.protocols.pbcast.Digest
 
size() - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
size() - Method in class org.jgroups.protocols.pbcast.NakAckHeader
 
size() - Method in class org.jgroups.protocols.pbcast.PbcastHeader
 
size() - Method in class org.jgroups.protocols.pbcast.STABLE.StableHeader
 
size() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
size() - Method in class org.jgroups.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.stack.IpAddress
 
size() - Method in class org.jgroups.stack.LogicalAddress
 
size() - Method in class org.jgroups.stack.NakReceiverWindow
 
size() - Method in class org.jgroups.stack.Retransmitter
 
size() - Method in class org.jgroups.util.AckCollector
 
size() - Method in class org.jgroups.util.LinkedListQueue
returns the number of objects that are currently in the queue
size - Variable in class org.jgroups.util.List
 
size() - Method in class org.jgroups.util.List
 
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.util.RspList
 
size() - Method in class org.jgroups.util.TimeScheduler
Answers the number of tasks currently in the queue.
size(Address) - Static method in class org.jgroups.util.Util
 
size(Collection) - Static method in class org.jgroups.util.Util
Returns the marshalled size of a Collection of Addresses.
sizeOf(String) - Static method in class org.jgroups.util.Util
 
sizeOf(Object) - Static method in class org.jgroups.util.Util
 
sizeOf(Streamable) - Static method in class org.jgroups.util.Util
 
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.
sort() - Method in class org.jgroups.Membership
 
src_addr - Variable in class org.jgroups.Message
 
stability(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(long) - Method in class org.jgroups.stack.NakReceiverWindow
Delete all messages <= seqno (they are stable, that is, have been received at all members).
stack - Variable in class org.jgroups.stack.Protocol
 
start() - Method in class org.jgroups.blocks.ConnectionTable
 
start(long) - Method in class org.jgroups.blocks.DistributedHashtable
Fetches the state
start(long) - Method in class org.jgroups.blocks.DistributedQueue
 
start() - Method in class org.jgroups.blocks.DistributedTree
 
start(long) - Method in class org.jgroups.blocks.DistributedTree
 
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.blocks.MessageDispatcher
 
start() - Method in class org.jgroups.blocks.NotificationBus
 
start() - Method in class org.jgroups.blocks.PullPushAdapter
 
start() - Method in class org.jgroups.blocks.ReplicatedTree
 
start() - Method in class org.jgroups.blocks.RequestCorrelator
 
start() - Method in class org.jgroups.debug.Debugger
 
start(String) - Static method in class org.jgroups.debug.Profiler
 
start() - Method in class org.jgroups.debug.Simulator
 
start() - Method in class org.jgroups.demos.Chat
 
start(ChannelFactory, String, boolean) - Method in class org.jgroups.demos.DistributedHashtableDemo
 
start(String, ChannelFactory, String) - Method in class org.jgroups.demos.DistributedQueueDemo
 
start(String, String) - Method in class org.jgroups.demos.NotificationBusDemo
 
start() - Method in class org.jgroups.demos.QuoteClient
 
start() - Method in class org.jgroups.demos.QuoteServer
 
start() - Method in class org.jgroups.demos.Topology
 
start(String, boolean) - Method in class org.jgroups.demos.ViewDemo
 
start() - Method in class org.jgroups.demos.applets.DrawApplet
 
start(String) - Method in class org.jgroups.demos.wb.GraphPanel
 
start() - Method in class org.jgroups.jmx.JChannel
 
start() - Method in interface org.jgroups.jmx.JChannelMBean
 
start() - Method in class org.jgroups.jmx.Protocol
 
start() - Method in interface org.jgroups.jmx.ProtocolMBean
 
start() - Method in class org.jgroups.protocols.AUTOCONF
 
start() - Method in class org.jgroups.protocols.BSH
 
start() - Method in class org.jgroups.protocols.DEADLOCK
 
start() - Method in class org.jgroups.protocols.DUMMY_TP
 
start() - Method in class org.jgroups.protocols.Discovery
 
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
 
start() - Method in class org.jgroups.protocols.FLUSH
 
start() - Method in class org.jgroups.protocols.GMS
 
start() - Method in class org.jgroups.protocols.JMS
Start the JMS protocol.
start() - Method in class org.jgroups.protocols.LOOPBACK
 
start() - Method in class org.jgroups.protocols.MERGE
 
start() - Method in class org.jgroups.protocols.MPING
 
start() - Method in class org.jgroups.protocols.PERF
 
start() - Method in class org.jgroups.protocols.PERF_TP
 
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.protocols.SHUFFLE
Starts the messagesHandler<\code>
start() - Method in class org.jgroups.protocols.STABLE
Start the layer: i.
start() - Method in class org.jgroups.protocols.STATE_TRANSFER
 
start() - Method in class org.jgroups.protocols.TCP
 
start() - Method in class org.jgroups.protocols.TCPGOSSIP
 
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
 
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.UcastReceiver
 
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_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.UDP_NIO
Creates the unicast and multicast sockets and starts the unicast and multicast receiver threads
start() - Method in class org.jgroups.protocols.UNICAST
 
start() - Method in class org.jgroups.protocols.VIEW_SYNC
 
start() - Method in class org.jgroups.protocols.WANPIPE
 
start() - Method in class org.jgroups.protocols.pbcast.GMS
 
start() - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
start() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
start() - Method in class org.jgroups.protocols.pbcast.STABLE
 
start() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
start() - Method in class org.jgroups.stack.AckMcastSenderWindow
Start the retransmitter.
start() - Method in class org.jgroups.stack.GossipRouter
JBoss MBean lifecycle operation.
start() - Method in class org.jgroups.stack.MessageProtocol
 
start() - Method in class org.jgroups.stack.Protocol
This method is called on a Channel.connect(String).
start() - Method in class org.jgroups.stack.Router
 
start() - Method in class org.jgroups.util.Proxy
 
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.util.Scheduler
 
start() - Method in class org.jgroups.util.TimeScheduler
Start the scheduler, if it's suspended or stopped
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
 
startProtocolStack(Protocol) - Method in class org.jgroups.stack.Configurator
 
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.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.
startUpHandler() - Method in class org.jgroups.stack.Protocol
Used internally.
startUpHandler() - Method in class org.jgroups.stack.ProtocolStack
 
startWork() - Method in class org.jgroups.stack.ProtocolStack
Override with null functionality: we don't need any threads to be started !
started - Variable in class org.jgroups.blocks.RequestCorrelator
 
started(Runnable) - Method in interface org.jgroups.util.SchedulerListener
 
stateListener - Variable in class org.jgroups.blocks.MessageListenerAdapter
 
stateTransferCompleted(boolean) - Method in interface org.jgroups.blocks.ReplicatedHashtable.StateTransferListener
 
stateTransferRunning() - Method in class org.jgroups.blocks.ReplicatedHashtable
 
stateTransferStarted() - Method in interface org.jgroups.blocks.ReplicatedHashtable.StateTransferListener
 
state_promise - Variable in class org.jgroups.blocks.DistributedHashtable
 
stats - Variable in class org.jgroups.JChannel
Collect statistics
stats - Variable in class org.jgroups.stack.Protocol
 
statsEnabled() - Method in class org.jgroups.JChannel
 
statsEnabled() - Method in class org.jgroups.stack.Protocol
 
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.blocks.DistributedHashtable
 
stop() - Method in class org.jgroups.blocks.DistributedQueue
 
stop() - Method in class org.jgroups.blocks.DistributedTree
 
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.blocks.MessageDispatcher
 
stop() - Method in class org.jgroups.blocks.NotificationBus
 
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.debug.Debugger
 
stop(String) - Static method in class org.jgroups.debug.Profiler
 
stop() - Method in class org.jgroups.debug.ProtocolTester
 
stop() - Method in class org.jgroups.debug.Simulator
 
stop() - Method in class org.jgroups.demos.wb.GraphPanel
 
stop() - Method in class org.jgroups.jmx.JChannel
 
stop() - Method in interface org.jgroups.jmx.JChannelMBean
 
stop() - Method in class org.jgroups.jmx.Protocol
 
stop() - Method in interface org.jgroups.jmx.ProtocolMBean
 
stop() - Method in class org.jgroups.protocols.BSH
 
stop() - Method in class org.jgroups.protocols.DEADLOCK
 
stop() - Method in class org.jgroups.protocols.Discovery
 
stop() - Method in class org.jgroups.protocols.FC
 
stop() - Method in class org.jgroups.protocols.FD
 
stop() - Method in class org.jgroups.protocols.FD_PID
 
stop() - Method in class org.jgroups.protocols.FD_PROB
 
stop() - Method in class org.jgroups.protocols.FD_SIMPLE
 
stop() - Method in class org.jgroups.protocols.FD_SOCK
 
stop() - Method in class org.jgroups.protocols.JMS
Stops the work of the JMS protocol.
stop() - Method in class org.jgroups.protocols.MERGE
 
stop() - Method in class org.jgroups.protocols.MERGE2
 
stop() - Method in class org.jgroups.protocols.MPING
 
stop() - Method in class org.jgroups.protocols.NAKACK
 
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.protocols.SHUFFLE
Stops the messagesHandler
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.STATE_TRANSFER
 
stop() - Method in class org.jgroups.protocols.TCP
 
stop() - Method in class org.jgroups.protocols.TCPGOSSIP
 
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
 
stop() - Method in class org.jgroups.protocols.TUNNEL
 
stop() - Method in class org.jgroups.protocols.UDP.UcastReceiver
 
stop() - Method in class org.jgroups.protocols.UDP
 
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.UDP_NIO
 
stop() - Method in class org.jgroups.protocols.UNICAST
 
stop() - Method in class org.jgroups.protocols.VERIFY_SUSPECT
 
stop() - Method in class org.jgroups.protocols.VIEW_SYNC
 
stop() - Method in class org.jgroups.protocols.WANPIPE
 
stop() - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
 
stop() - Method in class org.jgroups.protocols.pbcast.FD
 
stop() - Method in class org.jgroups.protocols.pbcast.GMS
 
stop() - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
stop() - Method in class org.jgroups.protocols.pbcast.NAKACK
 
stop() - Method in class org.jgroups.protocols.pbcast.PBCAST
 
stop() - Method in class org.jgroups.protocols.pbcast.STABLE
 
stop() - Method in class org.jgroups.stack.AckMcastSenderWindow
Stop the rentransmition and clear all pending msgs.
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.stack.MessageProtocol
 
stop() - Method in class org.jgroups.stack.Protocol
This method is called on a Channel.disconnect().
stop() - Method in class org.jgroups.stack.Retransmitter
Stop the rentransmition and clear all pending msgs.
stop() - Method in class org.jgroups.stack.Router
 
stop() - Method in class org.jgroups.util.ReusableThread
Stops the thread by setting thread=null and interrupting it.
stop() - Method in class org.jgroups.util.Scheduler
Stop the scheduler thread.
stop() - Method in class org.jgroups.util.TimeScheduler
Stop the scheduler if it's running.
stopInternal() - Method in class org.jgroups.stack.Protocol
Used internally.
stopInternal() - Method in class org.jgroups.stack.ProtocolStack
 
stopProtocolStack(Protocol) - Method in class org.jgroups.stack.Configurator
 
stopStack() - Method in class org.jgroups.stack.ProtocolStack
Iterates through all the protocols from top to bottom and does the following: Waits until all messages in the down queue have been flushed (ie., size is 0) Calls stop() on the protocol
stopWork() - Method in class org.jgroups.stack.ProtocolStack
Override with null functionality: we don't need any threads to be started !
stopped - Variable in class org.jgroups.blocks.DistributedQueue
 
stopped(Runnable) - Method in interface org.jgroups.util.SchedulerListener
 
streamableFromByteBuffer(Class, byte[]) - Static method in class org.jgroups.util.Util
 
streamableToByteBuffer(Streamable) - Static method in class org.jgroups.util.Util
 
subgroups - Variable in class org.jgroups.MergeView
 
suspect(Address) - Method in interface org.jgroups.MembershipListener
Called whenever a member is suspected of having crashed, but has not yet been excluded.
suspect(Address) - Method in class org.jgroups.ReceiverAdapter
 
suspect(Address) - Method in class org.jgroups.blocks.DistributedHashtable
Called when a member is suspected
suspect(Address) - Method in class org.jgroups.blocks.DistributedQueue
Called when a member is suspected
suspect(Address) - Method in class org.jgroups.blocks.DistributedTree
Called when a member is suspected
suspect(Address) - Method in class org.jgroups.blocks.GroupRequest
Callback (called by RequestCorrelator or Transport).
suspect(Address) - Method in class org.jgroups.blocks.MembershipListenerAdapter
Notify membership listener that some node was suspected.
suspect(Address) - Method in class org.jgroups.blocks.NotificationBus
 
suspect(Address) - Method in class org.jgroups.blocks.ReplicatedHashtable
Called when a member is suspected
suspect(Address) - Method in class org.jgroups.blocks.ReplicatedTree
Called when a member is suspected
suspect(Address) - Method in interface org.jgroups.blocks.RspCollector
 
suspect(Address) - Method in class org.jgroups.blocks.VotingAdapter
Callback for notification that one node is suspected
suspect(Address) - Method in class org.jgroups.demos.Chat
 
suspect(Address) - Method in class org.jgroups.demos.QuoteClient
 
suspect(Address) - Method in class org.jgroups.demos.QuoteServer
 
suspect(Address) - Method in class org.jgroups.demos.Topology
 
suspect(Address) - Method in class org.jgroups.demos.ViewDemo
Called when a member is suspected
suspect(Address) - Method in class org.jgroups.demos.wb.Whiteboard
 
suspect(Address) - Method in class org.jgroups.protocols.ClientGmsImpl
 
suspect(Address) - Method in class org.jgroups.protocols.CoordGmsImpl
 
suspect(Address) - Method in class org.jgroups.protocols.GMS
 
suspect(Address) - Method in class org.jgroups.protocols.GmsImpl
 
suspect(Address) - Method in class org.jgroups.protocols.ParticipantGmsImpl
 
suspect(Address) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
 
suspect(Address) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
 
suspect(Address) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
suspect(Address) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
 
suspect(Object) - Method in class org.jgroups.stack.AckMcastReceiverWindow
 
suspect(Address) - Method in class org.jgroups.stack.AckMcastSenderWindow
Process with address suspected is suspected: remove it from all receiver sets.
suspect(Object) - Method in class org.jgroups.util.AckCollector
 
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 interface org.jgroups.jmx.JChannelMBean
 
suspend() - Method in class org.jgroups.util.ReusableThread
Suspends the thread.
suspendViewHandler() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
 
suspendViewHandler() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
 
suspendViewHandler() - Method in class org.jgroups.protocols.pbcast.GMS
 
suspended(Runnable) - Method in interface org.jgroups.util.SchedulerListener
 

T

TCP - class org.jgroups.jmx.protocols.TCP.
 
TCP() - Constructor for class org.jgroups.jmx.protocols.TCP
 
TCP(Protocol) - Constructor for class org.jgroups.jmx.protocols.TCP
 
TCP - class org.jgroups.protocols.TCP.
TCP based protocol.
TCP() - Constructor for class org.jgroups.protocols.TCP
 
TCPGOSSIP - class org.jgroups.jmx.protocols.TCPGOSSIP.
 
TCPGOSSIP() - Constructor for class org.jgroups.jmx.protocols.TCPGOSSIP
 
TCPGOSSIP(Protocol) - Constructor for 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.protocols.TCPGOSSIP
 
TCPGOSSIPMBean - interface org.jgroups.jmx.protocols.TCPGOSSIPMBean.
 
TCPMBean - interface org.jgroups.jmx.protocols.TCPMBean.
 
TCPPING - class org.jgroups.jmx.protocols.TCPPING.
 
TCPPING() - Constructor for class org.jgroups.jmx.protocols.TCPPING
 
TCPPING(Protocol) - Constructor for 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.protocols.TCPPING
 
TCPPINGMBean - interface org.jgroups.jmx.protocols.TCPPINGMBean.
 
TCP_NIO - class org.jgroups.jmx.protocols.TCP_NIO.
 
TCP_NIO() - Constructor for class org.jgroups.jmx.protocols.TCP_NIO
 
TCP_NIO(Protocol) - Constructor for class org.jgroups.jmx.protocols.TCP_NIO
 
TCP_NIO - class org.jgroups.protocols.TCP_NIO.
 
TCP_NIO() - Constructor for class org.jgroups.protocols.TCP_NIO
 
TCP_NIOMBean - interface org.jgroups.jmx.protocols.TCP_NIOMBean.
 
TIME_TO_LIVE - Static variable in class org.jgroups.protocols.JMS
 
TMP_VIEW - Static variable in class org.jgroups.Event
 
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.Header - class org.jgroups.protocols.TOTAL.Header.
The header processed by the TOTAL layer and intended for TOTAL inter-stack communication
TOTAL.Header() - Constructor for class org.jgroups.protocols.TOTAL.Header
used for externalization
TOTAL.Header(int, long, long) - Constructor for class org.jgroups.protocols.TOTAL.Header
Create a header for the TOTAL layer
TOTAL_BCAST - Static variable in class org.jgroups.protocols.TOTAL_OLD.TotalHeader
 
TOTAL_CUM_SEQ_ACK - Static variable in class org.jgroups.protocols.TOTAL_OLD.TotalHeader
 
TOTAL_NEW_VIEW - Static variable in class org.jgroups.protocols.TOTAL_OLD.TotalHeader
 
TOTAL_NEW_VIEW_ACK - Static variable 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_OLD() - Constructor for class org.jgroups.protocols.TOTAL_OLD
 
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

TOTAL_OLD.TotalHeader() - Constructor for class org.jgroups.protocols.TOTAL_OLD.TotalHeader
 
TOTAL_OLD.TotalHeader(int, long) - Constructor for class org.jgroups.protocols.TOTAL_OLD.TotalHeader
 
TOTAL_REQUEST - Static variable in class org.jgroups.protocols.TOTAL_OLD.TotalHeader
 
TOTAL_RESEND - Static variable in class org.jgroups.protocols.TOTAL_OLD.TotalHeader
 
TOTAL_SEQ_ACK - Static variable 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_TOKEN() - Constructor for class org.jgroups.protocols.TOTAL_TOKEN
 
TOTAL_TOKEN.RingTokenHeader - class org.jgroups.protocols.TOTAL_TOKEN.RingTokenHeader.
 
TOTAL_TOKEN.RingTokenHeader() - Constructor for class org.jgroups.protocols.TOTAL_TOKEN.RingTokenHeader
 
TOTAL_TOKEN.TotalTokenHeader - class org.jgroups.protocols.TOTAL_TOKEN.TotalTokenHeader.
 
TOTAL_TOKEN.TotalTokenHeader() - Constructor for class org.jgroups.protocols.TOTAL_TOKEN.TotalTokenHeader
used for externalization
TOTAL_TOKEN.TotalTokenHeader(long) - Constructor for class org.jgroups.protocols.TOTAL_TOKEN.TotalTokenHeader
 
TOTAL_TOKEN.TotalTokenHeader(Long) - Constructor for class org.jgroups.protocols.TOTAL_TOKEN.TotalTokenHeader
 
TOTAL_UNICAST - Static variable in class org.jgroups.protocols.TOTAL_OLD.TotalHeader
 
TP - class org.jgroups.jmx.protocols.TP.
 
TP() - Constructor for class org.jgroups.jmx.protocols.TP
 
TP(Protocol) - Constructor for 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.protocols.TP
Creates the TP protocol, and initializes the state variables, does however not start any sockets or threads.
TPMBean - interface org.jgroups.jmx.protocols.TPMBean.
 
TRACE - class org.jgroups.protocols.TRACE.
 
TRACE() - Constructor for class org.jgroups.protocols.TRACE
 
TUNNEL - class org.jgroups.protocols.TUNNEL.
Replacement for UDP.
TUNNEL() - Constructor for class org.jgroups.protocols.TUNNEL
 
TYPES - Static variable in class org.jgroups.blocks.MethodCall
Use class information.
TcpHeader - class org.jgroups.protocols.TcpHeader.
 
TcpHeader() - Constructor for class org.jgroups.protocols.TcpHeader
 
TcpHeader(String) - Constructor for class org.jgroups.protocols.TcpHeader
 
TcpRingNode - class org.jgroups.protocols.ring.TcpRingNode.
 
TcpRingNode(RpcProtocol, 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
 
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(long) - Constructor for class org.jgroups.util.TimeScheduler
Create a scheduler that executes tasks in dynamically adjustable intervals
TimeScheduler() - Constructor for class org.jgroups.util.TimeScheduler
Create a scheduler that executes tasks in dynamically adjustable intervals
TimeScheduler.CancellableTask - interface org.jgroups.util.TimeScheduler.CancellableTask.
 
TimeScheduler.Task - interface org.jgroups.util.TimeScheduler.Task.
The interface that submitted tasks must implement
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.
TimedWriter() - Constructor for class org.jgroups.util.TimedWriter
 
TimeoutException - exception org.jgroups.TimeoutException.
Thrown if members fail to respond in time.
TimeoutException() - Constructor for class org.jgroups.TimeoutException
 
TimeoutException(String) - Constructor for class org.jgroups.TimeoutException
 
TimeoutException(List) - Constructor for class org.jgroups.TimeoutException
 
TokenLostException - exception 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, 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
 
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
 
TotalTokenDemo - class org.jgroups.demos.TotalTokenDemo.
Demonstration of TOTAL_TOKEN protocol stack implementing total order.
TotalTokenDemo(String) - Constructor for class org.jgroups.demos.TotalTokenDemo
 
TotalTokenDemo.TotalPayload - class org.jgroups.demos.TotalTokenDemo.TotalPayload.
 
TotalTokenDemo.TotalPayload(int) - Constructor for class org.jgroups.demos.TotalTokenDemo.TotalPayload
 
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
 
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.
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
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.
TwoPhaseVotingAdapter(VotingAdapter) - Constructor for class org.jgroups.blocks.TwoPhaseVotingAdapter
Creats an instance of the class.
TwoPhaseVotingAdapter.TwoPhaseVoteWrapper - class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseVoteWrapper.
 
TwoPhaseVotingAdapter.TwoPhaseVoteWrapper(TwoPhaseVotingListener) - Constructor for class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseVoteWrapper
 
TwoPhaseVotingAdapter.TwoPhaseWrapper - class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper.
Wrapper of the decree to voting decree.
TwoPhaseVotingAdapter.TwoPhaseWrapper(Object) - Constructor for class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
 
TwoPhaseVotingListener - interface org.jgroups.blocks.TwoPhaseVotingListener.
Implementations of this interface can participate in two-phase voting process.
t - Variable 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 - Variable 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 - Variable in class org.jgroups.protocols.UDP_NIO.Connector
 
tableChanged(TableModelEvent) - Method in class org.jgroups.demos.DistributedTreeDemo
 
tail - Variable in class org.jgroups.util.List
 
target - Variable in class org.jgroups.stack.StateTransferInfo
 
targets - Variable in class org.jgroups.stack.StateTransferInfo
 
timeout - Variable in class org.jgroups.blocks.GroupRequest
 
timeout - Variable in class org.jgroups.stack.StateTransferInfo
 
timer - Variable in class org.jgroups.stack.ProtocolStack
 
timestamp - Variable in class org.jgroups.stack.LogicalAddress
 
toString() - Method in class org.jgroups.BlockEvent
 
toString() - Method in class org.jgroups.ChannelClosedException
 
toString() - Method in class org.jgroups.ChannelNotConnectedException
 
toString() - Method in class org.jgroups.Event
 
toString() - Method in class org.jgroups.ExitEvent
 
toString() - Method in class org.jgroups.GetStateEvent
 
toString() - Method in class org.jgroups.Header
 
toString(boolean) - Method in class org.jgroups.JChannel
 
toString() - Method in class org.jgroups.Membership
 
toString() - Method in class org.jgroups.MergeView
 
toString() - Method in class org.jgroups.Message
 
toString() - Method in class org.jgroups.SetStateEvent
 
toString() - Method in class org.jgroups.SuspectEvent
 
toString() - Method in class org.jgroups.SuspectedException
 
toString() - Method in class org.jgroups.TimeoutException
 
toString() - Method in class org.jgroups.View
 
toString() - Method in class org.jgroups.ViewId
 
toString() - Method in class org.jgroups.blocks.ConnectionTable
 
toString() - Method in class org.jgroups.blocks.DistributedQueue
 
toString() - Method in class org.jgroups.blocks.GroupRequest
 
toString() - Method in class org.jgroups.blocks.Link
 
toString() - Method in class org.jgroups.blocks.LockingException
 
toString() - Method in class org.jgroups.blocks.LogicalLink.AllLinksDown
 
toString() - Method in class org.jgroups.blocks.LogicalLink.NoLinksAvailable
 
toString() - Method in class org.jgroups.blocks.MethodCall
 
toString() - Method in class org.jgroups.blocks.PullPushAdapter.PullHeader
 
toString() - Method in class org.jgroups.blocks.ReplicatedTree.Node
 
toString() - Method in class org.jgroups.blocks.ReplicatedTree
 
toString() - Method in class org.jgroups.blocks.ReplicationData
 
toString() - Method in class org.jgroups.blocks.RequestCorrelator.Header
 
toString() - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
 
toString() - Method in class org.jgroups.blocks.VotingAdapter.VoteResult
 
toString() - Method in class org.jgroups.blocks.Xid
 
toString() - Method in class org.jgroups.conf.ClassConfigurator
 
toString() - Method in class org.jgroups.debug.ProtocolView
 
toString() - Method in class org.jgroups.demos.DrawCommand
 
toString() - Method in class org.jgroups.demos.wb.Node
 
toString(boolean) - Method in class org.jgroups.jmx.JChannel
 
toString(boolean) - Method in interface org.jgroups.jmx.JChannelMBean
 
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.BSH.BshHeader
 
toString() - Method in class org.jgroups.protocols.CAUSAL.CausalHeader
 
toString() - Method in class org.jgroups.protocols.DUMMY_TP
 
toString() - Method in class org.jgroups.protocols.Digest
 
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.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.protocols.HTOTAL.HTotalHeader
 
toString() - Method in class org.jgroups.protocols.JMS.JMSAddress
Get the string representation of the address.
toString() - Method in class org.jgroups.protocols.JMS
Get the string representation of the protocol.
toString() - Method in class org.jgroups.protocols.LOOPBACK
 
toString() - Method in class org.jgroups.protocols.MERGE.MergeHeader
 
toString() - Method in class org.jgroups.protocols.NakAckHeader
 
toString() - Method in class org.jgroups.protocols.PARTITIONER.PartitionerHeader
 
toString() - Method in class org.jgroups.protocols.PERF_TP
 
toString() - Method in class org.jgroups.protocols.PIGGYBACK.PiggybackHeader
 
toString() - Method in class org.jgroups.protocols.PRINTOBJS
 
toString() - Method in class org.jgroups.protocols.PerfHeader
 
toString() - Method in class org.jgroups.protocols.PingHeader
 
toString() - Method in class org.jgroups.protocols.PingRsp
 
toString() - Method in class org.jgroups.protocols.SMACK.SmackHeader
 
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.TRACE
 
toString() - Method in class org.jgroups.protocols.TUNNEL
 
toString() - Method in class org.jgroups.protocols.TcpHeader
 
toString() - Method in class org.jgroups.protocols.TpHeader
 
toString() - Method in class org.jgroups.protocols.TransportedVectorTime
Returns String representation of this vector timestamp
toString() - Method in class org.jgroups.protocols.TunnelHeader
 
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.UDP_NIO
debug only
toString() - Method in class org.jgroups.protocols.UNICAST.UnicastHeader
 
toString() - Method in class org.jgroups.protocols.UdpHeader
 
toString() - Method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
 
toString() - Method in class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
 
toString() - Method in class org.jgroups.protocols.VectorTime
return String representation of the VectorTime
toString() - Method in class org.jgroups.protocols.WANPIPE.WanPipeHeader
 
toString() - Method in class org.jgroups.protocols.WANPIPE
 
toString() - Method in class org.jgroups.protocols.WanPipeAddress
 
toString() - Method in class org.jgroups.protocols.pbcast.Digest.Entry
 
toString() - Method in class org.jgroups.protocols.pbcast.Digest
 
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.protocols.pbcast.JoinRsp
 
toString() - Method in class org.jgroups.protocols.pbcast.MergeData
 
toString() - Method in class org.jgroups.protocols.pbcast.NakAckHeader
 
toString() - Method in class org.jgroups.protocols.pbcast.PbcastHeader
 
toString() - Method in class org.jgroups.protocols.pbcast.STABLE.StableHeader
 
toString() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
toString() - Method in class org.jgroups.protocols.ring.RingToken
 
toString() - Method in class org.jgroups.protocols.ring.TokenLostException
 
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.stack.Configurator.ProtocolConfiguration
 
toString() - Method in class org.jgroups.stack.GossipData
 
toString() - Method in class org.jgroups.stack.IpAddress
 
toString() - Method in class org.jgroups.stack.LogicalAddress
 
toString(boolean) - Method in class org.jgroups.stack.LogicalAddress
 
toString() - Method in class org.jgroups.stack.NakReceiverWindow
 
toString() - Method in class org.jgroups.stack.Retransmitter
 
toString() - Method in class org.jgroups.stack.StateTransferInfo
 
toString() - Method in class org.jgroups.util.AckCollector
 
toString() - Method in class org.jgroups.util.Buffer
 
toString() - Method in class org.jgroups.util.CondVar
 
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.util.Promise
 
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.util.ReusableThread
 
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.util.ThreadPool
 
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
 
tokenArrived(Object) - Method in interface 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
 
tossWeightedCoin(double) - Static method in class org.jgroups.util.Util
Tosses a coin weighted with probability and returns true or false.
total_header_type - Variable in class org.jgroups.protocols.TOTAL_OLD.TotalHeader
 
trace - Variable in class org.jgroups.protocols.PingSender
 
trace - Variable in class org.jgroups.stack.Protocol
 
transport - Variable in class org.jgroups.blocks.GroupRequest
 
transport - Variable in class org.jgroups.blocks.PullPushAdapter
 
transport - Variable in class org.jgroups.blocks.RequestCorrelator
The protocol layer to use to pass up/down messages.
transport_adapter - Variable in class org.jgroups.blocks.MessageDispatcher
 
trim(double) - Static method in class org.jgroups.debug.Profiler
 
type - Variable in class org.jgroups.blocks.RequestCorrelator.Header
Type of header: request or reply
type - Variable in class org.jgroups.protocols.MERGE.MergeHeader
 
type - Variable in class org.jgroups.protocols.PingHeader
 
type - Variable in class org.jgroups.protocols.TOTAL.Header
The header's type tag
type - Variable in class org.jgroups.stack.StateTransferInfo
 
type2Str(int) - Static method in class org.jgroups.protocols.NakAckHeader
 
type2Str(byte) - Static method in class org.jgroups.protocols.UNICAST.UnicastHeader
 
type2Str(byte) - Static method in class org.jgroups.protocols.pbcast.NakAckHeader
 
type2String(int) - Static method in class org.jgroups.Event
 
type2String(int) - Static method in class org.jgroups.protocols.FD_PID.FdHeader
 
type2String(byte) - Static method in class org.jgroups.protocols.FD_SOCK.FdHeader
 
type2String(int) - Static method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
type2String(int) - Static method in class org.jgroups.protocols.pbcast.PbcastHeader
 
type2String(int) - Static method in class org.jgroups.stack.GossipData
 
typeToString(int) - Static method in class org.jgroups.blocks.ReplicationData
 
types - Variable in class org.jgroups.blocks.MethodCall
The class types, e.g., new Class[]{String.class, int.class}.

U

UCAST - Static variable in class org.jgroups.protocols.TOTAL.Header
Unicast message
UDP - class org.jgroups.jmx.protocols.UDP.
 
UDP() - Constructor for class org.jgroups.jmx.protocols.UDP
 
UDP(Protocol) - Constructor for class org.jgroups.jmx.protocols.UDP
 
UDP - class org.jgroups.protocols.UDP.
IP multicast transport based on 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.UcastReceiver - class org.jgroups.protocols.UDP.UcastReceiver.
 
UDP.UcastReceiver() - Constructor for class org.jgroups.protocols.UDP.UcastReceiver
 
UDPMBean - interface org.jgroups.jmx.protocols.UDPMBean.
 
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.
UDP_NIO.Connector - class org.jgroups.protocols.UDP_NIO.Connector.
Manages a multicast and unicast socket on a given interface (NIC).
UDP_NIO.Connector(NetworkInterface, int, int, int, int, int, int, Receiver) - Constructor for class org.jgroups.protocols.UDP_NIO.Connector
 
UDP_NIO.ConnectorTable - class org.jgroups.protocols.UDP_NIO.ConnectorTable.
Manages a bunch of Connectors
UDP_NIO.ConnectorTable(InetSocketAddress, int, int, boolean, Receiver) - Constructor for class org.jgroups.protocols.UDP_NIO.ConnectorTable
 
UDP_NIO.MulticastReceiver - class org.jgroups.protocols.UDP_NIO.MulticastReceiver.
 
UDP_NIO.MulticastReceiver() - Constructor for class org.jgroups.protocols.UDP_NIO.MulticastReceiver
 
UDP_NIO.MyReceiver - class org.jgroups.protocols.UDP_NIO.MyReceiver.
 
UDP_NIO.MyReceiver() - Constructor for class org.jgroups.protocols.UDP_NIO.MyReceiver
 
UDP_NIO.Unmarshaller - class org.jgroups.protocols.UDP_NIO.Unmarshaller.
 
UDP_NIO.Unmarshaller() - Constructor for class org.jgroups.protocols.UDP_NIO.Unmarshaller
 
UNBLOCK_SEND - Static variable in class org.jgroups.Event
 
UNDEFINED - Static variable in class org.jgroups.protocols.ring.TokenLostException
 
UNICAST - class org.jgroups.jmx.protocols.UNICAST.
 
UNICAST() - Constructor for class org.jgroups.jmx.protocols.UNICAST
 
UNICAST(Protocol) - Constructor for class org.jgroups.jmx.protocols.UNICAST
 
UNICAST - class org.jgroups.protocols.UNICAST.
Reliable unicast layer.
UNICAST() - Constructor for class org.jgroups.protocols.UNICAST
 
UNICAST.UnicastHeader - class org.jgroups.protocols.UNICAST.UnicastHeader.
 
UNICAST.UnicastHeader() - Constructor for class org.jgroups.protocols.UNICAST.UnicastHeader
 
UNICAST.UnicastHeader(byte, long) - Constructor for class org.jgroups.protocols.UNICAST.UnicastHeader
 
UNICASTMBean - interface org.jgroups.jmx.protocols.UNICASTMBean.
 
UNSUSPECT - Static variable in class org.jgroups.Event
 
USER_DEFINED - Static variable in class org.jgroups.Event
 
UdpHeader - class org.jgroups.protocols.UdpHeader.
 
UdpHeader() - Constructor for class org.jgroups.protocols.UdpHeader
 
UdpHeader(String) - Constructor for class org.jgroups.protocols.UdpHeader
 
UdpRingNode - class org.jgroups.protocols.ring.UdpRingNode.
 
UdpRingNode(RpcProtocol, Address) - Constructor for class org.jgroups.protocols.ring.UdpRingNode
 
UpHandler - interface org.jgroups.UpHandler.
Provides a way of taking over a channel's tasks.
UpdateException - exception org.jgroups.blocks.UpdateException.
 
UpdateException(String) - Constructor for class org.jgroups.blocks.UpdateException
 
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.
Util() - Constructor for class org.jgroups.util.Util
 
unblock() - Method in class org.jgroups.jmx.protocols.FC
 
unblock() - Method in interface org.jgroups.jmx.protocols.FCMBean
 
unblock() - Method in class org.jgroups.protocols.FC
Allows to unblock a blocked sender from an external program, e.g.
unlock(Object, Object) - 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.DistributedLockManager
Unlocks an object with lockId on behalf of the specified owner.
unlock(Object, Object) - Method in interface org.jgroups.blocks.LockManager
Release lock on obj owned by specified owner.
unlock(Object, Object, boolean) - Method in interface org.jgroups.blocks.LockManager
Release lock on obj owned by specified owner.
unlock() - Method in class org.jgroups.util.ReentrantLatch
Unlock the latch.
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.
unregisterProtocols(MBeanServer, JChannel, String) - Static method in class org.jgroups.jmx.JmxConfigurator
 
unstable_msgs - Variable in class org.jgroups.protocols.FlushRsp
 
unsuspect(Address) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
 
unsuspect(Address) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
 
unsuspect(Address) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
unsuspect(Address) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
Removes previously suspected member from list of currently suspected members
unsuspect(Object) - Method in class org.jgroups.util.AckCollector
 
up(Event) - Method in class org.jgroups.JChannel
Callback method
Called by the ProtocolStack when a message is received.
up(Event) - Method in interface org.jgroups.UpHandler
Invoked for all channel events except connection management and state transfer.
up(Event, int) - Method in class org.jgroups.debug.ProtocolView
 
up(Event) - Method in class org.jgroups.protocols.BSH
 
up(Event) - Method in class org.jgroups.protocols.CAUSAL
Processes Event going up through the stack
up(Event) - Method in class org.jgroups.protocols.COMPRESS
If there is no header, we pass the message up.
up(Event) - Method in class org.jgroups.protocols.DELAY
 
up(Event) - Method in class org.jgroups.protocols.DISCARD
 
up(Event) - Method in class org.jgroups.protocols.DUMMY
 
up(Event) - Method in class org.jgroups.protocols.Discovery
An event was received from the layer below.
up(Event) - Method in class org.jgroups.protocols.ENCRYPT
 
up(Event) - Method in class org.jgroups.protocols.ENCRYPT1_4
 
up(Event) - Method in class org.jgroups.protocols.EXAMPLE
 
up(Event) - Method in class org.jgroups.protocols.FC
 
up(Event) - Method in class org.jgroups.protocols.FD
 
up(Event) - Method in class org.jgroups.protocols.FD_PID
 
up(Event) - Method in class org.jgroups.protocols.FD_PROB
 
up(Event) - Method in class org.jgroups.protocols.FD_SIMPLE
 
up(Event) - Method in class org.jgroups.protocols.FD_SOCK
 
up(Event) - Method in class org.jgroups.protocols.FLOWCONTROL
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(Event) - Method in class org.jgroups.protocols.FRAG
If event is a message, if it is fragmented, re-assemble fragments into big message and pass up the stack.
up(Event) - Method in class org.jgroups.protocols.FRAG2
If event is a message, if it is fragmented, re-assemble fragments into big message and pass up the stack.
up(Event) - Method in class org.jgroups.protocols.HDRS
 
up(Event) - Method in class org.jgroups.protocols.HTOTAL
 
up(Event) - Method in class org.jgroups.protocols.MERGE
 
up(Event) - Method in class org.jgroups.protocols.MERGE2
 
up(Event) - Method in class org.jgroups.protocols.MERGE3
 
up(Event) - Method in class org.jgroups.protocols.MERGEFAST
 
up(Event) - Method in class org.jgroups.protocols.NAKACK
Callback.
up(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(Event) - Method in class org.jgroups.protocols.PERF
 
up(Event) - Method in class org.jgroups.protocols.PERF_TP
 
up(Event) - Method in class org.jgroups.protocols.PIGGYBACK
 
up(Event) - Method in class org.jgroups.protocols.PRINTMETHODS
 
up(Event) - Method in class org.jgroups.protocols.PRINTOBJS
 
up(Event) - Method in class org.jgroups.protocols.QUEUE
Queues or passes up events.
up(Event) - Method in class org.jgroups.protocols.SHUFFLE
Adds upcoming messages to the messages List<\code> where the messagesHandler<\code> retrieves them.
up(Event) - Method in class org.jgroups.protocols.SIZE
 
up(Event) - Method in class org.jgroups.protocols.SMACK
 
up(Event) - Method in class org.jgroups.protocols.STATE_TRANSFER
 
up(Event) - Method in class org.jgroups.protocols.STATS
 
up(Event) - Method in class org.jgroups.protocols.TOTAL
 
up(Event) - Method in class org.jgroups.protocols.TOTAL_OLD
handles an Event coming up the Protocol Stack
up(Event) - Method in class org.jgroups.protocols.TP
handle the UP event.
up(Event) - Method in class org.jgroups.protocols.TRACE
 
up(Event) - Method in class org.jgroups.protocols.UDP_NIO
handle the UP event.
up(Event) - Method in class org.jgroups.protocols.UNICAST
 
up(Event) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
 
up(Event) - Method in class org.jgroups.protocols.VIEW_ENFORCER
 
up(Event) - Method in class org.jgroups.protocols.VIEW_SYNC
 
up(Event) - Method in class org.jgroups.protocols.pbcast.FD
 
up(Event) - Method in class org.jgroups.protocols.pbcast.GMS
 
up(Event) - Method in class org.jgroups.protocols.pbcast.NAKACK
Callback.
up(Event) - Method in class org.jgroups.protocols.pbcast.PBCAST
 
up(Event) - Method in class org.jgroups.protocols.pbcast.STABLE
 
up(Event) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
 
up(Event) - Method in class org.jgroups.stack.MessageProtocol
Handle an event coming from the layer above
up(Event) - Method in class org.jgroups.stack.Protocol
An event was received from the layer below.
up(Event, int) - Method in interface org.jgroups.stack.ProtocolObserver
Called when an event is about to be dispatched to the protocol (before it is dispatched).
up(Event) - Method in class org.jgroups.stack.ProtocolStack
 
upThreadEnabled() - Method in class org.jgroups.stack.Protocol
 
up_handler - Variable in class org.jgroups.Channel
 
up_handler - Variable in class org.jgroups.stack.Protocol
 
up_prot - Variable in class org.jgroups.stack.Protocol
 
up_queue - Variable in class org.jgroups.stack.Protocol
 
up_thread - Variable in class org.jgroups.stack.Protocol
 
up_thread_prio - Variable in class org.jgroups.stack.Protocol
 
update(Graphics) - Method in class org.jgroups.demos.wb.GraphPanel
 
updateView(View) - Method in class org.jgroups.protocols.TOTAL_TOKEN
 
updateView(View) - Method in class org.jgroups.stack.MessageProtocol
 
updateWindow(RingToken) - Method in class org.jgroups.protocols.ring.RingNodeFlowControl
 
useLocks() - Method in class org.jgroups.blocks.ReplicationData
 

V

VERIFY_SUSPECT - class org.jgroups.protocols.VERIFY_SUSPECT.
Catches SUSPECT events traveling up the stack.
VERIFY_SUSPECT() - Constructor for class org.jgroups.protocols.VERIFY_SUSPECT
 
VERIFY_SUSPECT.VerifyHeader - class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader.
 
VERIFY_SUSPECT.VerifyHeader() - Constructor for class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
 
VIEW - Static variable in class org.jgroups.Channel
 
VIEW - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
VIEW_ACK - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
VIEW_CHANGE - Static variable 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_ENFORCER() - Constructor for class org.jgroups.protocols.VIEW_ENFORCER
 
VIEW_SYNC - class org.jgroups.jmx.protocols.VIEW_SYNC.
 
VIEW_SYNC() - Constructor for class org.jgroups.jmx.protocols.VIEW_SYNC
 
VIEW_SYNC(Protocol) - Constructor for class org.jgroups.jmx.protocols.VIEW_SYNC
 
VIEW_SYNC - class org.jgroups.protocols.VIEW_SYNC.
Periodically sends the view to the group.
VIEW_SYNC() - Constructor for class org.jgroups.protocols.VIEW_SYNC
 
VIEW_SYNC - Static variable in class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
 
VIEW_SYNC.ViewSyncHeader - class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader.
 
VIEW_SYNC.ViewSyncHeader() - Constructor for class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
 
VIEW_SYNC.ViewSyncHeader(int, View) - Constructor for class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
 
VIEW_SYNCMBean - interface org.jgroups.jmx.protocols.VIEW_SYNCMBean.
 
VIEW_SYNC_REQ - Static variable in class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
 
VOTE_ALL - Static variable 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 variable 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 variable in class org.jgroups.blocks.VotingAdapter
This consensus type means that number of positive votes should be greater than number of negative votes.
VectorTime - class org.jgroups.protocols.VectorTime.
Vector timestamp used in CAUSAL order protocol stack
VectorTime(Address) - Constructor for class org.jgroups.protocols.VectorTime
Constructs VectorTime given an adress of a owning group member
Version - class org.jgroups.Version.
Holds version information for JGroups.
Version() - Constructor for class org.jgroups.Version
 
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(ViewId, Vector) - Constructor for class org.jgroups.View
Creates a new view
View(Address, long, Vector) - Constructor for class org.jgroups.View
Creates a new view
ViewDemo - class org.jgroups.demos.ViewDemo.
Demos the reception of views using a PullPushAdapter.
ViewDemo() - Constructor for class org.jgroups.demos.ViewDemo
 
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(Address) - Constructor for class org.jgroups.ViewId
Creates a ViewID with the coordinator address and a Lamport timestamp of 0.
ViewId(Address, long) - Constructor for class org.jgroups.ViewId
Creates a ViewID with the coordinator address and the given Lamport timestamp.
VoteException - exception 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.
VotingAdapter - class org.jgroups.blocks.VotingAdapter.
Voting adapter provides a voting functionality for an application.
VotingAdapter(Channel) - Constructor for class org.jgroups.blocks.VotingAdapter
Creates an instance of the VoteChannel that uses JGroups for communication between group members.
VotingAdapter(PullPushAdapter, Serializable) - Constructor for class org.jgroups.blocks.VotingAdapter
 
VotingAdapter.FailureVoteResult - class org.jgroups.blocks.VotingAdapter.FailureVoteResult.
Class that represents a result of local voting on the failed node.
VotingAdapter.FailureVoteResult(String) - Constructor for class org.jgroups.blocks.VotingAdapter.FailureVoteResult
 
VotingAdapter.VoteResult - class org.jgroups.blocks.VotingAdapter.VoteResult.
This class represents the result of local voting.
VotingAdapter.VoteResult() - Constructor for class org.jgroups.blocks.VotingAdapter.VoteResult
 
VotingListener - interface org.jgroups.blocks.VotingListener.
Implemetations of this interface are able to participate in voting process.
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
version - Static variable in class org.jgroups.Version
 
vid - Variable in class org.jgroups.View
 
viewAccepted(View) - Method in interface org.jgroups.MembershipListener
Called when a change in membership has occurred.
viewAccepted(View) - Method in class org.jgroups.ReceiverAdapter
 
viewAccepted(View) - Method in class org.jgroups.blocks.DistributedHashtable
 
viewAccepted(View) - Method in class org.jgroups.blocks.DistributedQueue
 
viewAccepted(View) - Method in class org.jgroups.blocks.DistributedTree
 
viewAccepted(View) - Method in class org.jgroups.blocks.MembershipListenerAdapter
Notify membership listener that new view was accepted.
viewAccepted(View) - Method in class org.jgroups.blocks.NotificationBus
 
viewAccepted(View) - Method in class org.jgroups.blocks.ReplicatedHashtable
 
viewAccepted(View) - Method in class org.jgroups.blocks.ReplicatedTree
 
viewAccepted(View) - Method in class org.jgroups.blocks.VotingAdapter
Callback for notification about the new view of the group.
viewAccepted(View) - Method in class org.jgroups.demos.Chat
 
viewAccepted(View) - Method in class org.jgroups.demos.QuoteClient
 
viewAccepted(View) - Method in class org.jgroups.demos.QuoteServer
 
viewAccepted(View) - Method in class org.jgroups.demos.Topology
 
viewAccepted(View) - Method in class org.jgroups.demos.ViewDemo
 
viewAccepted(View) - Method in class org.jgroups.demos.applets.DrawApplet
 
viewAccepted(View) - Method in class org.jgroups.demos.wb.Whiteboard
 
viewChange(Vector, Vector) - Method in interface org.jgroups.blocks.DistributedHashtable.Notification
 
viewChange(Vector, Vector) - Method in interface org.jgroups.blocks.DistributedQueue.Notification
 
viewChange(Vector, Vector) - Method in interface org.jgroups.blocks.DistributedTree.ViewListener
 
viewChange(View) - Method in class org.jgroups.blocks.GroupRequest
Any member of 'membership' that is not in the new view is flagged as SUSPECTED.
viewChange(Vector, Vector) - Method in interface org.jgroups.blocks.ReplicatedHashtable.Notification
 
viewChange(View) - Method in interface org.jgroups.blocks.ReplicatedTree.ReplicatedTreeListener
 
viewChange(View) - Method in interface org.jgroups.blocks.RspCollector
 
viewChange(Vector, Vector) - Method in class org.jgroups.demos.DistributedHashtableDemo
 
viewChange(Vector, Vector) - Method in class org.jgroups.demos.DistributedQueueDemo
 
viewChanged(int) - Method in class org.jgroups.protocols.ring.RingNodeFlowControl
 
viewHandlerSize() - Method in class org.jgroups.protocols.pbcast.GMS
 
view_handler - Variable in class org.jgroups.protocols.pbcast.GMS
Class to process JOIN, LEAVE and MERGE requests
view_id - Variable in class org.jgroups.protocols.GMS
 
view_mutex - Variable in class org.jgroups.protocols.GMS
 
vote(Object) - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseVoteWrapper
 
vote(Object, long) - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter
Performs the two-phase voting on the decree.
vote(Object, long, VoteResponseProcessor) - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter
Performs the two-phase voting on the decree.
vote(Object, int, long) - Method in class org.jgroups.blocks.VotingAdapter
Performs actual voting on the VoteChannel using the JGroups facilities for communication.
vote(Object, int, long, VoteResponseProcessor) - Method in class org.jgroups.blocks.VotingAdapter
Performs actual voting on the VoteChannel using the JGroups facilities for communication.
vote(Object, long) - Method in class org.jgroups.blocks.VotingAdapter
Vote on the specified decree requiring all nodes to vote.
vote(Object, long, VoteResponseProcessor) - Method in class org.jgroups.blocks.VotingAdapter
Vote on the specified decree requiring all nodes to vote.
vote(Object) - Method in interface org.jgroups.blocks.VotingListener
Each member is able to vote with true or false messages.

W

WANPING - class org.jgroups.protocols.WANPING.
Similar to TCPPING, except that the initial host list is specified as a list of logical pipe names.
WANPING() - Constructor for class org.jgroups.protocols.WANPING
 
WANPIPE - class org.jgroups.protocols.WANPIPE.
Logical point-to-point link.
WANPIPE() - Constructor for class org.jgroups.protocols.WANPIPE
 
WANPIPE.WanPipeHeader - class org.jgroups.protocols.WANPIPE.WanPipeHeader.
 
WANPIPE.WanPipeHeader() - Constructor for class org.jgroups.protocols.WANPIPE.WanPipeHeader
 
WANPIPE.WanPipeHeader(String) - Constructor for class org.jgroups.protocols.WANPIPE.WanPipeHeader
 
WHILE_RECEIVING - Static variable in class org.jgroups.protocols.ring.TokenLostException
 
WHILE_SENDING - Static variable in class org.jgroups.protocols.ring.TokenLostException
 
WHO_HAS_SOCK - Static variable in class org.jgroups.protocols.FD_SOCK.FdHeader
 
WRAPPED_MSG - Static variable in class org.jgroups.protocols.NakAckHeader
 
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
 
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
 
waitForAllAcks() - Method in class org.jgroups.util.AckCollector
 
waitForAllAcks(long) - Method in class org.jgroups.util.AckCollector
 
waitUntil(Object, long) - Method in class org.jgroups.util.CondVar
Waits until the condition matches the expected result.
waitUntil(Object) - Method in class org.jgroups.util.CondVar
 
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.
warn - Variable in class org.jgroups.stack.Protocol
 
wasReceived() - Method in class org.jgroups.util.Rsp
 
wasSuspected() - Method in class org.jgroups.util.Rsp
 
width - Variable 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(Address) - Method in class org.jgroups.protocols.pbcast.GMS
Checks whether the potential_new_coord would be the new coordinator (2nd in line)
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(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
 
writeClassDescriptor(ObjectStreamClass) - Method in class org.jgroups.util.MagicObjectOutputStream
 
writeExternal(ObjectOutput) - Method in class org.jgroups.MergeView
 
writeExternal(ObjectOutput) - Method in class org.jgroups.Message
 
writeExternal(ObjectOutput) - Method in class org.jgroups.View
 
writeExternal(ObjectOutput) - Method in class org.jgroups.ViewId
 
writeExternal(ObjectOutput) - Method in class org.jgroups.blocks.MethodCall
 
writeExternal(ObjectOutput) - Method in class org.jgroups.blocks.PullPushAdapter.PullHeader
 
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.blocks.Xid
 
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.ENCRYPT.EncryptHeader
 
writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.ENCRYPT1_4.EncryptHeader
 
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.HTOTAL.HTotalHeader
 
writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.JMS.JMSAddress
Write the object to external output.
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.MERGEFAST.MergefastHeader
 
writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.NakAckHeader
 
writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.PARTITIONER.PartitionerHeader
 
writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.PIGGYBACK.PiggybackHeader
 
writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.PerfHeader
 
writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.PingHeader
 
writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.SMACK.SmackHeader
 
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.TcpHeader
 
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.UNICAST.UnicastHeader
 
writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.UdpHeader
 
writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
 
writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
 
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.protocols.pbcast.Digest
 
writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.pbcast.MergeData
 
writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.pbcast.NakAckHeader
 
writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.pbcast.PbcastHeader
 
writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.pbcast.STABLE.StableHeader
 
writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.ring.RingToken
 
writeExternal(ObjectOutput) - Method in class org.jgroups.stack.GossipData
 
writeExternal(ObjectOutput) - Method in class org.jgroups.stack.IpAddress
 
writeExternal(ObjectOutput) - Method in class org.jgroups.stack.LogicalAddress
 
writeExternal(ObjectOutput) - Method in class org.jgroups.util.List
 
writeExternal(ObjectOutput) - Method in class org.jgroups.util.Range
 
writeExternal(ObjectOutput) - Method in class org.jgroups.util.Stack
 
writeFully(ByteBuffer, WritableByteChannel) - Static method in class org.jgroups.util.Util
if we were to register for OP_WRITE and send the remaining data on readyOps for this channel we have to either block the caller thread or queue the message buffers that may arrive while waiting for OP_WRITE.
writeGenericStreamable(Streamable, DataOutputStream) - Static method in class org.jgroups.util.Util
 
writeLock() - Method in class org.jgroups.util.NullReadWriteLock
 
writeObject(Object, DataOutputStream) - Static method in class org.jgroups.util.Util
 
writeStreamable(Streamable, 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.MergeView
 
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.View
 
writeTo(DataOutputStream) - Method in class org.jgroups.ViewId
 
writeTo(DataOutputStream) - Method in class org.jgroups.blocks.RequestCorrelator.Header
 
writeTo(DataOutputStream) - Method in class org.jgroups.protocols.COMPRESS.CompressHeader
 
writeTo(DataOutputStream) - Method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
 
writeTo(DataOutputStream) - Method in class org.jgroups.protocols.FC.FcHeader
 
writeTo(DataOutputStream) - Method in class org.jgroups.protocols.FD.FdHeader
 
writeTo(DataOutputStream) - Method in class org.jgroups.protocols.FD_SOCK.FdHeader
 
writeTo(DataOutputStream) - Method in class org.jgroups.protocols.FragHeader
 
writeTo(DataOutputStream) - Method in class org.jgroups.protocols.HTOTAL.HTotalHeader
 
writeTo(DataOutputStream) - Method in class org.jgroups.protocols.JMS.JMSAddress
 
writeTo(DataOutputStream) - Method in class org.jgroups.protocols.PingHeader
 
writeTo(DataOutputStream) - Method in class org.jgroups.protocols.PingRsp
 
writeTo(DataOutputStream) - Method in class org.jgroups.protocols.TcpHeader
 
writeTo(DataOutputStream) - Method in class org.jgroups.protocols.TpHeader
 
writeTo(DataOutputStream) - Method in class org.jgroups.protocols.UNICAST.UnicastHeader
 
writeTo(DataOutputStream) - Method in class org.jgroups.protocols.UdpHeader
 
writeTo(DataOutputStream) - Method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
 
writeTo(DataOutputStream) - Method in class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
 
writeTo(DataOutputStream) - Method in class org.jgroups.protocols.WanPipeAddress
 
writeTo(DataOutputStream) - Method in class org.jgroups.protocols.pbcast.Digest
 
writeTo(DataOutputStream) - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
writeTo(DataOutputStream) - Method in class org.jgroups.protocols.pbcast.JoinRsp
 
writeTo(DataOutputStream) - Method in class org.jgroups.protocols.pbcast.NakAckHeader
 
writeTo(DataOutputStream) - Method in class org.jgroups.protocols.pbcast.STABLE.StableHeader
 
writeTo(DataOutputStream) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
writeTo(DataOutputStream) - Method in class org.jgroups.stack.IpAddress
 
writeTo(DataOutputStream) - Method in class org.jgroups.stack.LogicalAddress
 
writeTo(DataOutputStream) - Method in class org.jgroups.util.Range
 
writeTo(DataOutputStream) - Method in interface org.jgroups.util.Streamable
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

XID - Static variable in class org.jgroups.blocks.Xid
 
XMIT_REQ - Static variable in class org.jgroups.protocols.pbcast.NakAckHeader
 
XMIT_REQ - Static variable in class org.jgroups.protocols.pbcast.PbcastHeader
 
XMIT_RSP - Static variable in class org.jgroups.protocols.pbcast.NakAckHeader
 
XMIT_RSP - Static variable in class org.jgroups.protocols.pbcast.PbcastHeader
 
Xid - class org.jgroups.blocks.Xid.
Distributed transaction ID modeled after the JTA spec.
Xid() - Constructor for class org.jgroups.blocks.Xid
 
XmlConfigurator - class org.jgroups.conf.XmlConfigurator.
 
XmlConfigurator(String, ProtocolData[]) - Constructor for class org.jgroups.conf.XmlConfigurator
 
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
 
x - Variable in class org.jgroups.demos.wb.Node
 
xloc - Variable in class org.jgroups.demos.wb.Node
 

Y

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

_

_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 - Variable 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(Object) - Method in class org.jgroups.blocks.DistributedHashtable
 
_remove() - Method in class org.jgroups.blocks.DistributedQueue
 
_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 B C D E F G H I J K L M N O P Q R S T U V W X Y _

Copyright ? 1998-2005 Bela Ban. All Rights Reserved.