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.Event
 
ACK - Static variable in class org.jgroups.protocols.SMACK.SmackHeader
 
ACK_OK - Static variable in class org.jgroups.Event
 
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
 
AbstractService - class org.jgroups.service.AbstractService.
AbstractService is a superclass for all service implementations.
AbstractService(Channel, Channel) - Constructor for class org.jgroups.service.AbstractService
Main constructor to create services.
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[], Protocol) - Constructor for class org.jgroups.stack.AckSenderWindow
This constructor whould be used when we want AckSenderWindow to send the message added by add(), rather then ourselves.
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.
acceptedView(Hot_GroupContext, Object, Hot_ViewState) - Method in class org.jgroups.EnsChannel
 
acceptedView(Hot_GroupContext, Object, Hot_ViewState) - Method in interface org.jgroups.ensemble.Hot_Callbacks
Called to update you with the new view
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.
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(Vector) - 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(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
 
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.
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
 
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
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
 
addNotifier(TransactionalHashtable.Notification) - Method in class org.jgroups.blocks.TransactionalHashtable
 
addPanel(String, JPanel) - Method in class org.jgroups.demos.TotalTokenDemo
 
addPhysicalAddress(SocketAddress) - Method in class org.jgroups.stack.LogicalAddress1_4
For internal use only ! Don't use this method !
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
 
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.
addr - Variable in class org.jgroups.demos.wb.Node
 
adjustNodes(Vector) - Method in class org.jgroups.demos.wb.GraphPanel
 
alloc() - Static method in class org.jgroups.ensemble.Hot_GroupContext
 
arg - Variable in class org.jgroups.protocols.PingHeader
 
args - Variable in class org.jgroups.blocks.MethodCall
the arguments of the method
argv - Variable in class org.jgroups.ensemble.Hot_JoinOps
 
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.
auto_commit - Variable in class org.jgroups.blocks.TransactionalHashtable
 
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
 
BlockEvent - class org.jgroups.BlockEvent.
 
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
 
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.
begin() - Method in class org.jgroups.blocks.TransactionalHashtable
Starts a new transaction and associates it with the current thread.
begin(int) - Method in class org.jgroups.blocks.TransactionalHashtable
Starts a new transaction and associates it with the current thread.
block(Hot_GroupContext, Object) - Method in class org.jgroups.EnsChannel
 
block() - Method in interface org.jgroups.MembershipListener
Block sending and receiving of messages until viewAccepted() is called
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
 
block(Hot_GroupContext, Object) - Method in interface org.jgroups.ensemble.Hot_Callbacks
Called to let you know Ensemble is blocking
block() - Method in class org.jgroups.service.AbstractService
This method is called when service is supposed to stop sending messages to channel until new view is installed.
blockMonitor - Variable in class org.jgroups.service.AbstractService
 
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.EnsChannel
 
blockOk() - Method in class org.jgroups.JChannel
Called to acknowledge a block() (callback in MembershipListener or BlockEvent received from call to receive()).
blocked - Variable in class org.jgroups.service.AbstractService
 
bottom() - Method in class org.jgroups.util.Stack
 

C

CANCEL_DENIED - Static variable in class org.jgroups.service.lease.DenyResponseHeader
 
CANCEL_LEASE_REQUEST - Static variable in class org.jgroups.service.lease.LeaseRequestHeader
 
CANCEL_LEASE_TYPE - Static variable in class org.jgroups.service.lease.LeaseFactoryService.LeaseInfo
 
CANCEL_LEASE_TYPE - Static variable in class org.jgroups.service.lease.LeaseInfoReplicationHeader
 
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
 
CLEAR - Static variable in class org.jgroups.blocks.TransactionalHashtable.Data
 
CLIENT_CHANNEL_STACK - Static variable in class org.jgroups.service.ServiceRunner
 
CLIENT_GROUP_NAME - Static variable in class org.jgroups.service.ServiceRunner
 
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 - 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.
 
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.
 
ChannelNotConnectedException() - Constructor for class org.jgroups.ChannelNotConnectedException
 
ChannelNotConnectedException(String) - Constructor for class org.jgroups.ChannelNotConnectedException
 
Chat - class org.jgroups.demos.Chat.
Instances of the group can broadcast short messages to the group, and receive them.
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.
The name and the relative path of the magic number map file can be specified as value of the property org.jgroups.conf.magicNumberFile.
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 (se Gamma et al.).
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(int, long, long) - Constructor for class org.jgroups.blocks.ConnectionTable
ConnectionTable including a connection reaper.
ConnectionTable(ConnectionTable.Receiver, InetAddress, int) - Constructor for class org.jgroups.blocks.ConnectionTable
Create a ConnectionTable
ConnectionTable(ConnectionTable.Receiver, InetAddress, 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
ConnectionTable1_4 - class org.jgroups.blocks.ConnectionTable1_4.
Manages incoming and outgoing TCP connections.
ConnectionTable1_4(int) - Constructor for class org.jgroups.blocks.ConnectionTable1_4
 
ConnectionTable1_4(int, long, long) - Constructor for class org.jgroups.blocks.ConnectionTable1_4
 
ConnectionTable1_4(ConnectionTable.Receiver, InetAddress, int) - Constructor for class org.jgroups.blocks.ConnectionTable1_4
 
ConnectionTable1_4(ConnectionTable.Receiver, InetAddress, int, long, long) - Constructor for class org.jgroups.blocks.ConnectionTable1_4
 
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
 
call_stack - Variable in class org.jgroups.blocks.RequestCorrelator.Header
Contains senders (e.g.
call_stack - Variable in class org.jgroups.blocks.RequestCorrelator
This field is used only if deadlock detection is enabled.
call_stack_setter - Variable in class org.jgroups.blocks.RequestCorrelator
This field is used only if deadlock detection is enabled.
cancelLease(Lease) - Method in interface org.jgroups.service.lease.LeaseFactory
Cancels existing lease.
cancelLease(Lease) - Method in class org.jgroups.service.lease.LeaseFactoryClient
Cancel existing lease.
cancelTimeout - Variable in class org.jgroups.service.lease.LeaseFactoryClient
 
cancelled() - Method in interface org.jgroups.util.TimeScheduler.Task
 
cast(Hot_GroupContext, Hot_Message, int[]) - Method in class org.jgroups.ensemble.Hot_Ensemble
Broadcast a Hot_Message to the group specified in the Hot_GroupContext
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) - Method in class org.jgroups.protocols.pbcast.GMS
 
castViewChange(View, Digest) - Method in class org.jgroups.protocols.pbcast.GMS
 
cause - Variable in class org.jgroups.protocols.ring.TokenLostException
 
changeProperties(Hot_GroupContext, String) - Method in class org.jgroups.ensemble.Hot_Ensemble
Change the properties of the group specified by the Hot_GroupContext to the properties specified by the String
changeProtocol(Hot_GroupContext, String) - Method in class org.jgroups.ensemble.Hot_Ensemble
Change the protocol used by the group specified by the Hot_GroupContext to the protocol specified by the String
channel - Variable in class org.jgroups.blocks.DistributedQueue
 
channel - Variable in class org.jgroups.blocks.MessageDispatcher
 
channel - Variable in class org.jgroups.blocks.TransactionalHashtable
 
channelClosed(Channel) - Method in interface org.jgroups.ChannelListener
 
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.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.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.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.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_name - Variable in class org.jgroups.protocols.TunnelHeader
 
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
 
checkResults(RspList) - Method in class org.jgroups.blocks.TransactionalHashtable
Checks whether responses from members contain exceptions or timeouts.
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.blocks.TransactionalHashtable
Replicates the update to all members.
clear(boolean, long) - Method in class org.jgroups.blocks.TransactionalHashtable
Replicates the update to all members.
clear(long, long, long, boolean) - Method in class org.jgroups.blocks.TransactionalHashtable
Replicated the update to all members, and use locks at each member to ensure serializability.
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
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
 
clearStableMessages() - Method in class org.jgroups.stack.AckMcastSenderWindow
 
client - Variable in class org.jgroups.ensemble.Hot_JoinOps
 
clientAdapter - Variable in class org.jgroups.service.lease.LeaseFactoryClient
 
clientAdapter - Variable in class org.jgroups.service.lease.LeaseFactoryService
 
clientChannel - Variable in class org.jgroups.service.AbstractService
 
clientChannel - Variable in class org.jgroups.service.lease.LeaseFactoryClient
 
clients - Variable in class org.jgroups.ensemble.Hot_ViewState
 
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.blocks.TransactionalHashtable
 
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.LogicalAddress1_4
 
clone() - Method in class org.jgroups.util.List
 
close() - Method in class org.jgroups.Channel
Destroys the channel and its associated resources (e.g.
close() - Method in class org.jgroups.EnsChannel
 
close() - Method in class org.jgroups.JChannel
Destroys the channel.
After this method has been called, the channel us unusable.
This operation will disconnect the channel and close the channel receive queue immediately
close(boolean) - Method in class org.jgroups.util.LinkedListQueue
Marks the queues as closed.
close(boolean) - Method in class org.jgroups.util.Queue
Marks the queues as closed.
close(boolean) - Method in class org.jgroups.util.Queue2
Marks the queues as closed.
closed() - Method in class org.jgroups.util.LinkedListQueue
returns true if the Queue has been closed however, this method will return false if the queue has been closed using the close(true) method and the last element has yet not been received.
closed() - Method in class org.jgroups.util.Queue
returns true if the Queue has been closed however, this method will return false if the queue has been closed using the close(true) method and the last element has yet not been received.
closed() - Method in class org.jgroups.util.Queue2
returns true if the Queue has been closed however, this method will return false if the queue has been closed using the close(true) method and the last element has yet not been received.
closer - Variable in class org.jgroups.JChannel
Thread responsible for closing a channel and potentially reconnecting to it (e.g.
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(Xid) - Method in class org.jgroups.blocks.TransactionalHashtable
 
commit() - Method in class org.jgroups.blocks.TransactionalHashtable
Commits all modifications done in the current transaction (kept in temporary storage) to the hashtable.
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(LogicalAddress1_4) - Method in class org.jgroups.stack.LogicalAddress1_4
Establishes an order between 2 addresses.
compareTo(byte[]) - Static method in class org.jgroups.Version
 
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.ensemble.Hot_Endpoint
 
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.LogicalAddress1_4
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).
conf - Variable in class org.jgroups.ensemble.Hot_GroupContext
 
conf - Variable in class org.jgroups.ensemble.Hot_JoinOps
 
connect(String) - Method in class org.jgroups.Channel
Connects the channel to a group.
connect(String) - Method in class org.jgroups.EnsChannel
 
connect(String) - Method in class org.jgroups.JChannel
Connects the channel to a group.
If the channel is already connected, an error message will be printed to the error log
If the channel is closed a ChannelClosed exception will be thrown
This method starts the protocol stack by calling ProtocolStack.start
then it sends an Event.CONNECT event down the stack and waits to receive a CONNECT_OK event
Once the CONNECT_OK event arrives from the protocol stack, any channel listeners are notified
and the channel is considered connected
connect() - Method in class org.jgroups.demos.TotalTokenDemo
 
connect() - Method in class org.jgroups.stack.RouterStub
Establishes a connection to the router.
connectionClosed(Address) - Method in interface org.jgroups.blocks.ConnectionTable.ConnectionListener
 
connectionClosed(Address) - Method in class org.jgroups.protocols.TCP
 
connectionOpened(Address) - Method in interface org.jgroups.blocks.ConnectionTable.ConnectionListener
 
connectionOpened(Address) - Method in class org.jgroups.protocols.TCP
 
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
 
containsKey(Object) - Method in class org.jgroups.blocks.TransactionalHashtable
 
containsMember(Address) - Method in class org.jgroups.View
returns true, if this view contains a certain member
containsValue(Object) - Method in class org.jgroups.blocks.TransactionalHashtable
 
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 - Variable in class org.jgroups.ensemble.Hot_ViewID
 
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.LogicalAddress1_4
 
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
 
count - Static variable in class org.jgroups.stack.LogicalAddress1_4
 
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.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.EnsChannelFactory
 
createChannel() - Method in class org.jgroups.EnsChannelFactory
No-Op implementation of the createChannel() method specified by 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) - Static method in class org.jgroups.util.Util
Finds first available port starting at start_port and returns server socket
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

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_BEST_FIT_DURATION - Static variable in class org.jgroups.service.lease.LeaseFactoryService
 
DEFAULT_CANCEL_TIMEOUT - Static variable in class org.jgroups.service.lease.LeaseFactoryClient
 
DEFAULT_CONNECTION_FACTORY - Static variable in class org.jgroups.protocols.JMS
 
DEFAULT_LEASE_TIMEOUT - Static variable in class org.jgroups.service.lease.LeaseFactoryClient
 
DEFAULT_MESSAGE - Static variable in class org.jgroups.service.lease.LeaseDeniedException
 
DEFAULT_MESSAGE - Static variable in class org.jgroups.service.lease.UnknownLeaseException
 
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.
DISCARD - class org.jgroups.protocols.DISCARD.
Discards up or down messages based on a percentage, e.g.
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
 
DUMP - Static variable in class org.jgroups.stack.GossipRouter
 
DUMP - Static variable in class org.jgroups.stack.Router
 
DURATION_ANY - Static variable in interface org.jgroups.service.lease.LeaseFactory
This constant represents arbitrary duration.
DURATION_FOREVER - Static variable in interface org.jgroups.service.lease.LeaseFactory
This constant represents maximum possible duration.
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
 
DenyResponseHeader - class org.jgroups.service.lease.DenyResponseHeader.
Message header that represents deny response.
DenyResponseHeader() - Constructor for class org.jgroups.service.lease.DenyResponseHeader
Create uninitialized instance of this class.
DenyResponseHeader(int, String, Object) - Constructor for class org.jgroups.service.lease.DenyResponseHeader
Create instance of this class for specified denial type and denial reason.
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 e.g.
Digest() - Constructor for class org.jgroups.protocols.pbcast.Digest
 
Digest(int) - Constructor for class org.jgroups.protocols.pbcast.Digest
 
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.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) - 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.
 
DrawRepl - class org.jgroups.demos.DrawRepl.
NOT SUPPORTED ! 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.
debug - Variable in class org.jgroups.ensemble.Hot_JoinOps
 
debug() - Method in class org.jgroups.util.Queue
Dumps internal state @remove
debug() - Method in class org.jgroups.util.Queue2
Dumps internal state @remove
default_sync_repl - Variable in class org.jgroups.blocks.TransactionalHashtable
 
default_sync_repl_timeout - Variable in class org.jgroups.blocks.TransactionalHashtable
 
defragmentBuffer(byte[][]) - Static method in class org.jgroups.util.Util
Concatenates smaller fragments into entire buffers.
denyLeaseRequest(int, Address, String, Object, Object) - Method in class org.jgroups.service.lease.LeaseFactoryService
Deny lease request.
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.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
 
destroyOutboard() - Method in class org.jgroups.ensemble.Hot_Ensemble
Destroys the associated outboard process.
determineAllBindInterfaces() - Method in class org.jgroups.protocols.UDP1_4
 
determineCoordinator() - Method in class org.jgroups.protocols.GMS
 
determineCoordinator() - Method in class org.jgroups.protocols.pbcast.GMS
 
determineDefaultBindInterface() - Method in class org.jgroups.protocols.UDP1_4
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.
determineMajority(int) - Method in class org.jgroups.blocks.GroupRequest
 
digest_timeout - Variable in class org.jgroups.protocols.pbcast.GMS
 
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.EnsChannel
 
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.stack.RouterStub
Closes the socket and the input and output streams associated with it
disp - Variable in class org.jgroups.blocks.DistributedQueue
 
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
 
doExecute(long) - Method in class org.jgroups.blocks.GroupRequest
This method runs with rsp_mutex locked (called by execute()).
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).
doubleWriteBuffer(ByteBuffer, WritableByteChannel) - Static method in class org.jgroups.util.Util1_4
 
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.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.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.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.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.PING
An event is to be sent down the stack.
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.TCP
Sent to destination(s) using the ConnectionTable class.
down(Event) - Method in class org.jgroups.protocols.TCPGOSSIP
 
down(Event) - Method in class org.jgroups.protocols.TCPPING
 
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.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
Caller by the layer above this layer.
down(Event) - Method in class org.jgroups.protocols.UDP1_4
Caller by the layer above this layer.
down(Event) - Method in class org.jgroups.protocols.UNICAST
 
down(Event) - Method in class org.jgroups.protocols.WANPING
 
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
 
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
 
dumpRoutingTable() - Method in class org.jgroups.stack.GossipRouter
 
dumpStack(boolean) - Static method in class org.jgroups.util.Util
 
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
 
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
 
EnsChannel - class org.jgroups.EnsChannel.
EnsChannel is an implementation of Channel based on Ensemble.
EnsChannel() - Constructor for class org.jgroups.EnsChannel
 
EnsChannel(Object) - Constructor for class org.jgroups.EnsChannel
Creates a new EnsChannel, which spawns an outboard process and connects to it.
EnsChannel(Object, String, int) - Constructor for class org.jgroups.EnsChannel
Creates a new EnsChannel.
EnsChannelFactory - class org.jgroups.EnsChannelFactory.
 
EnsChannelFactory() - Constructor for class org.jgroups.EnsChannelFactory
 
EnsChannelFactory(String, int) - Constructor for class org.jgroups.EnsChannelFactory
 
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.
 
ExitEvent() - Constructor for class org.jgroups.ExitEvent
 
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
 
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 interface org.jgroups.blocks.TransactionalHashtable.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 interface org.jgroups.blocks.TransactionalHashtable.Notification
 
entrySet() - Method in class org.jgroups.blocks.TransactionalHashtable
 
entrySet(Object, Object) - Method in class org.jgroups.demos.DistributedHashtableDemo
 
env - Variable in class org.jgroups.ensemble.Hot_GroupContext
 
env - Variable in class org.jgroups.ensemble.Hot_JoinOps
 
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.ensemble.Hot_Endpoint
 
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.WanPipeAddress
 
equals(Gossip) - 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.LogicalAddress1_4
 
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
exit(Hot_GroupContext, Object) - Method in class org.jgroups.EnsChannel
 
exit(Hot_GroupContext, Object) - Method in interface org.jgroups.ensemble.Hot_Callbacks
Called upon an Exit
expected_mbrs - Variable in class org.jgroups.blocks.GroupRequest
 
expiresAt() - Method in class org.jgroups.service.lease.LeaseFactoryService.LeaseInfo
Get information when lease expires.
extendLease(long) - Method in class org.jgroups.service.lease.LeaseFactoryService.LeaseInfo
Extend lease to new expiration term.

F

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(int, long) - Constructor for class org.jgroups.protocols.FC.FcHeader
 
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_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.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(int) - Constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
 
FIND_INITIAL_MBRS - 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.protocols.FRAG.
Fragmentation layer.
FRAG() - Constructor for class org.jgroups.protocols.FRAG
 
FRAG.FragHeader - class org.jgroups.protocols.FRAG.FragHeader.
 
FRAG.FragHeader() - Constructor for class org.jgroups.protocols.FRAG.FragHeader
 
FRAG.FragHeader(long, int, int) - Constructor for class org.jgroups.protocols.FRAG.FragHeader
 
FRAG2 - class org.jgroups.protocols.FRAG2.
Fragmentation layer.
FRAG2() - Constructor for class org.jgroups.protocols.FRAG2
 
FRAG2.FragHeader - class org.jgroups.protocols.FRAG2.FragHeader.
 
FRAG2.FragHeader() - Constructor for class org.jgroups.protocols.FRAG2.FragHeader
 
FRAG2.FragHeader(long, int, int) - Constructor for class org.jgroups.protocols.FRAG2.FragHeader
 
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
 
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
Subclasses should override this method to convert the incoming map of string/string key/value pairs into the types they want.
findComponent(Container, String) - Method in class org.jgroups.demos.DrawRepl
 
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
Flushes all events currently in the down queues and returns when done.
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.FRAG.FragHeader
 
frag_id - Variable in class org.jgroups.protocols.FRAG2.FragHeader
 
fragmentBuffer(byte[], int) - Static method in class org.jgroups.util.Util
Fragments a byte buffer into smaller fragments of (max.) frag_size.

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_DIGEST - 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.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(int) - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
GMS.GmsHeader(int, View) - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
Used for VIEW header
GMS.GmsHeader(int, Address) - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
Used for JOIN_REQ or LEAVE_REQ header
GMS.GmsHeader(int, JoinRsp) - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
Used for JOIN_RSP header
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
 
GetNetworkInterfaces1_4 - class org.jgroups.util.GetNetworkInterfaces1_4.
Lists all network interfaces on a system
GetNetworkInterfaces1_4() - Constructor for class org.jgroups.util.GetNetworkInterfaces1_4
 
GetStateEvent - class org.jgroups.GetStateEvent.
 
GetStateEvent(Object) - Constructor for class org.jgroups.GetStateEvent
 
Global - class org.jgroups.Global.
 
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
 
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.
Maintains a cache of member addresses for each group.
GossipServer(int) - Constructor for class org.jgroups.stack.GossipServer
 
GossipServer(int, long) - Constructor for class org.jgroups.stack.GossipServer
 
GossipServer(int, long, InetAddress) - Constructor for class org.jgroups.stack.GossipServer
 
GraphPanel - class org.jgroups.demos.wb.GraphPanel.
 
GraphPanel(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(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(Object) - Method in class org.jgroups.blocks.TransactionalHashtable
 
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(String) - Method in class org.jgroups.stack.RouterStub
Retrieves the membership (list of Addresses) for a given group.
get(Address) - Method in class org.jgroups.util.RspList
 
getAdditionalData() - Method in class org.jgroups.stack.IpAddress
Returns the additional_data.
getAdditionalData() - Method in class org.jgroups.stack.LogicalAddress1_4
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
 
getAddress() - Method in class org.jgroups.service.AbstractService
Get address of this service in service group.
getAddress() - Method in class org.jgroups.service.lease.LeaseFactoryClient
Get address of this client in group.
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.EnsChannel
 
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
 
getAutoCommit() - Method in class org.jgroups.blocks.TransactionalHashtable
 
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
 
getBestFitDuration() - Method in class org.jgroups.service.lease.LeaseFactoryService
Get best-fit duration leases with duration LeaseFactory.DURATION_ANY.
getBindAddress() - Method in class org.jgroups.stack.GossipRouter
 
getBindInterface() - Method in class org.jgroups.protocols.UDP1_4.Connector
 
getBottommostProtocol(Protocol) - Method in class org.jgroups.stack.Configurator
 
getBuffer() - Method in class org.jgroups.Message
Returns a copy of the buffer if offset and length are used, otherwise a reference
getBytes() - Method in class org.jgroups.ensemble.Hot_Buffer
 
getBytes() - Method in class org.jgroups.ensemble.Hot_ObjectMessage
Serializes the contained object into a byte array
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.
getCause() - Method in class org.jgroups.ChannelException
Retrieves the cause of this exception as passed to the constructor.
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.NotificationBus
Used to operate on the underlying channel directly, e.g.
getChannel() - Method in class org.jgroups.blocks.ReplicatedHashtable
 
getChannel() - Method in class org.jgroups.blocks.ReplicatedTree
Returns the Channel the DistributedTree is connected to
getChannel() - Method in class org.jgroups.demos.TotalTokenDemo
 
getChannelName() - Method in class org.jgroups.Channel
Returns the group address of the group of which the channel is a member.
getChannelName() - Method in class org.jgroups.EnsChannel
 
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
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
 
getCombinedResults() - Method in class org.jgroups.protocols.DEADLOCK
Mcasts getResult() to all members (including itself).
getConcurrentProcessing() - Method in class org.jgroups.util.Scheduler
 
getConnectionTable(long, long, InetAddress, int) - Method in class org.jgroups.protocols.TCP
 
getConnectionTable1_4(long, long, InetAddress, int) - Method in class org.jgroups.protocols.TCP1_4
 
getConnectorAddresses() - Method in class org.jgroups.protocols.UDP1_4.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.Queue
returns a vector with all the objects currently in the queue
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
 
getCurrentTransaction() - Static method in class org.jgroups.blocks.TransactionalHashtable
Returns the transaction associated with the current thread.
getData() - Method in class org.jgroups.blocks.ReplicationData
 
getDecree() - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
 
getDefaultSyncReplTimeout() - Method in class org.jgroups.blocks.TransactionalHashtable
 
getDenialReason() - Method in class org.jgroups.service.lease.DenyResponseHeader
Get reason why lease was denied.
getDescription() - Method in class org.jgroups.conf.ClassMap
 
getDescription() - Method in class org.jgroups.conf.ProtocolData
 
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
 
getDownProtocol() - Method in class org.jgroups.stack.Protocol
 
getDownQueue() - Method in class org.jgroups.stack.Protocol
 
getDownVector() - Method in class org.jgroups.protocols.QUEUE
 
getDuration() - Method in interface org.jgroups.service.lease.Lease
Get lease duration.
getDuration() - Method in class org.jgroups.service.lease.LeaseRequestHeader
Get requested duration of a lease.
getDuration() - Method in class org.jgroups.service.lease.LeaseResponseHeader
Get requested duration of a lease.
getExpiration() - Method in interface org.jgroups.service.lease.Lease
Get lease expiration time.
getExpiryTime() - Method in class org.jgroups.stack.GossipRouter
 
getFactory() - Method in interface org.jgroups.service.lease.Lease
Get instance of LeaseFactory that created this lease.
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
 
getFirstQueuedSeqID() - Method in class org.jgroups.protocols.TOTAL_OLD
returns the sequence id of the "first" queued message (i.e.
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
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.
getHighestSeen() - Method in class org.jgroups.stack.NakReceiverWindow
Returns the highest deliverable seqno, e.g.
getHighestSequence() - Method in class org.jgroups.protocols.ring.RingToken
 
getHost() - Method in class org.jgroups.stack.LogicalAddress1_4
 
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.Xid
 
getId() - Method in class org.jgroups.stack.LogicalAddress1_4
 
getIdentifier() - Method in class org.jgroups.blocks.PullPushAdapter.PullHeader
 
getImpl() - Method in class org.jgroups.protocols.pbcast.GMS
 
getIndex(Address) - Method in class org.jgroups.protocols.pbcast.Digest
 
getInputStream(String) - Method in class org.jgroups.conf.ClassPathEntityResolver
 
getInputStream(String) - Static method in class org.jgroups.conf.XmlValidator
 
getInstance() - Static method in class org.jgroups.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
 
getIpAddress(byte[]) - Static method in class org.jgroups.stack.IpAddress
 
getKey() - Method in class org.jgroups.blocks.DistributedLockManager.LockDecree
Returns the key that should be used for Map lookup.
getKey() - Method in class org.jgroups.blocks.TransactionalHashtable.Data
 
getKeys(String) - Method in class org.jgroups.blocks.ReplicatedTree
Gets the keys of the data map.
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
 
getLeaseInfo() - Method in class org.jgroups.service.lease.LeaseInfoReplicationHeader
Get lease info from this header.
getLeaseTarget() - Method in interface org.jgroups.service.lease.Lease
Get target of this lease.
getLeaseTarget() - Method in class org.jgroups.service.lease.LeaseDeniedException
 
getLength() - Method in class org.jgroups.Message
Returns the number of bytes in the buffer
getLength() - Static method in class org.jgroups.Version
 
getLength() - Method in class org.jgroups.ensemble.Hot_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.EnsChannel
 
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.protocols.UDP1_4.Connector
 
getLocalPort() - Method in class org.jgroups.blocks.Link
 
getLockAcquisitionTimeout() - Method in class org.jgroups.blocks.ReplicationData
 
getLockAcquisitionTimeout() - Method in class org.jgroups.blocks.TransactionalHashtable
 
getLockInfo() - Method in class org.jgroups.blocks.ReplicationData
 
getLockLeaseTimeout() - Method in class org.jgroups.blocks.ReplicationData
 
getLockLeaseTimeout() - Method in class org.jgroups.blocks.TransactionalHashtable
 
getLowestSeen() - Method in class org.jgroups.stack.NakReceiverWindow
 
getMagicNumber(Class) - Method in class org.jgroups.conf.ClassConfigurator
Returns the magic number for the class.
getMagicNumber() - Method in class org.jgroups.conf.ClassMap
 
getMap() - Method in class org.jgroups.blocks.TransactionalHashtable.Data
 
getMarshaller() - Method in class org.jgroups.blocks.RpcDispatcher
 
getMaximumDuration() - Method in class org.jgroups.service.lease.LeaseFactoryService
Get best-fit duration leases with duration LeaseFactory.DURATION_FOREVER.
getMbr() - Method in class org.jgroups.stack.GossipData
 
getMbrs() - Method in class org.jgroups.stack.GossipData
 
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.protocols.VectorTime
Returns Collection containing addresses of other group members from this Vector clock
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.
getMessage() - Method in class org.jgroups.demos.wb.SendDialog
 
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).
getMethod() - Method in class org.jgroups.blocks.MethodCall
 
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.
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.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.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.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.MERGEFAST
 
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.TCP
 
getName() - Method in class org.jgroups.protocols.TCP1_4
 
getName() - Method in class org.jgroups.protocols.TCPGOSSIP
 
getName() - Method in class org.jgroups.protocols.TCPPING
 
getName() - Method in class org.jgroups.protocols.TOTAL
 
getName() - Method in class org.jgroups.protocols.TOTAL_OLD
returns the unique name of this protocol
getName() - Method in class org.jgroups.protocols.TOTAL_TOKEN
 
getName() - Method in class org.jgroups.protocols.TRACE
 
getName() - Method in class org.jgroups.protocols.TUNNEL
 
getName() - Method in class org.jgroups.protocols.UDP
 
getName() - Method in class org.jgroups.protocols.UDP1_4
 
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.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.service.AbstractService
Get name of this service.
getName() - Method in class org.jgroups.service.lease.LeaseFactoryService
Get name of this service.
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
returns the next sequence id expected to be received in this view
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
 
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.protocols.PERF_TP
 
getNumSuspects() - Method in class org.jgroups.blocks.GroupRequest
 
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
getObject() - Method in class org.jgroups.Message
 
getObject() - Method in class org.jgroups.ensemble.Hot_ObjectMessage
Get the contained Object
getOffset() - Method in class org.jgroups.Message
Returns the offset into the buffer at which the data starts
getOpt(int) - Method in class org.jgroups.Channel
Gets an option.
getOpt(int) - Method in class org.jgroups.EnsChannel
 
getOpt(int) - Method in class org.jgroups.JChannel
returns the value of an option.
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
 
getPersistent() - Method in class org.jgroups.blocks.DistributedHashtable
 
getPhysicalAddresses() - Method in class org.jgroups.stack.LogicalAddress1_4
Returns a copy of the list of physical addresses.
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.LogicalAddress1_4
 
getProperties() - Method in class org.jgroups.JChannel
returns the protocol stack configuration in string format.
getProperties() - Method in class org.jgroups.stack.Configurator.ProtocolConfiguration
 
getProperties() - Method in class org.jgroups.stack.Protocol
 
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).
getReason() - Method in class org.jgroups.blocks.VotingAdapter.FailureVoteResult
 
getReceiveBufferSize() - Method in class org.jgroups.blocks.ConnectionTable
 
getReceiver() - Method in class org.jgroups.protocols.UDP1_4.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
 
getRequestType() - Method in class org.jgroups.blocks.TransactionalHashtable.Data
 
getRequestor() - Method in class org.jgroups.GetStateEvent
 
getResponses() - Method in class org.jgroups.blocks.GroupRequest
 
getResult() - Method in class org.jgroups.protocols.DEADLOCK
Returns a random integer value between 1 and 10
getResult(long) - Method in class org.jgroups.util.Promise
Gets result.
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
 
getSender() - Method in class org.jgroups.protocols.pbcast.MergeData
 
getSender() - Method in class org.jgroups.util.Rsp
 
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
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 at the specified URL.
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
 
getState(Address, long) - Method in class org.jgroups.Channel
Retrieve the state of the group.
getState(Address, long) - Method in class org.jgroups.EnsChannel
 
getState(Address, long) - Method in class org.jgroups.JChannel
Retrieves the current group state.
getState() - Method in interface org.jgroups.MessageListener
 
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.TransactionalHashtable
TODO: use read lock on entire hashmap while making copy
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
 
getSubgroups() - Method in class org.jgroups.MergeView
 
getSuspectedMembers() - Method in class org.jgroups.util.RspList
 
getSuspects() - Method in class org.jgroups.blocks.GroupRequest
 
getTenant() - Method in class org.jgroups.service.lease.DenyResponseHeader
Get tenant to which this response is addressed to
getTenant() - Method in interface org.jgroups.service.lease.Lease
Get tenant that was granted this lease.
getTenant() - Method in class org.jgroups.service.lease.LeaseFactoryService.LeaseInfo
Get tenant that owns this lease.
getTenant() - Method in class org.jgroups.service.lease.LeaseRequestHeader
Get identifier of an object that requests the lease.
getTenant() - Method in class org.jgroups.service.lease.LeaseResponseHeader
Get tenant, to which this request is addressed to.
getTenant() - Method in class org.jgroups.service.lease.RecursiveLeaseRequestException
 
getThread() - Method in class org.jgroups.util.ThreadPool
 
getTimestamp() - Method in class org.jgroups.stack.LogicalAddress1_4
 
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
 
getTransaction() - Method in class org.jgroups.blocks.ReplicationData
 
getTransactionMode() - Method in class org.jgroups.blocks.TransactionalHashtable
 
getTransport() - Method in class org.jgroups.blocks.PullPushAdapter
 
getTransportedVectorTime() - Method in class org.jgroups.protocols.VectorTime
Returns minimal lightweigth 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.pbcast.STATE_TRANSFER.StateHeader
 
getType() - Method in class org.jgroups.protocols.ring.RingToken
 
getType() - Method in class org.jgroups.service.lease.DenyResponseHeader
Get type of lease request.
getType() - Method in class org.jgroups.service.lease.LeaseInfoReplicationHeader
Get header type.
getType() - Method in class org.jgroups.service.lease.LeaseRequestHeader
Get type of lease request.
getType() - Method in class org.jgroups.service.lease.LeaseResponseHeader
Get type of lease request.
getType() - Method in class org.jgroups.stack.GossipData
 
getUnknownLease() - Method in class org.jgroups.service.lease.UnknownLeaseException
 
getUpProtocol() - Method in class org.jgroups.stack.Protocol
 
getUpQueue() - Method in class org.jgroups.stack.Protocol
 
getUpVector() - Method in class org.jgroups.protocols.QUEUE
 
getUserName() - Method in class org.jgroups.demos.wb.UserInfoDialog
 
getValue() - Method in class org.jgroups.blocks.TransactionalHashtable.Data
 
getValue() - Method in class org.jgroups.conf.ProtocolParameter
 
getValue() - Method in class org.jgroups.util.Rsp
 
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
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.EnsChannel
 
getView() - Method in class org.jgroups.JChannel
returns the current view.
if the channel is not connected or if it is closed it will return null
getView() - Method in class org.jgroups.protocols.pbcast.MergeData
 
getWindowSize() - Method in class org.jgroups.protocols.ring.RingToken
 
getWindowThreshold() - Method in class org.jgroups.protocols.ring.RingToken
 
gms - Variable in class org.jgroups.protocols.GmsImpl
 
gms - Variable in class org.jgroups.protocols.pbcast.GmsImpl
 
go() - Method in class org.jgroups.demos.Chat
 
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.UdpHeader
 
group_addr - Variable in class org.jgroups.protocols.WANPIPE.WanPipeHeader
 
group_addr - Variable in class org.jgroups.protocols.pbcast.GMS
 
group_blocked - Variable in class org.jgroups.ensemble.Hot_GroupContext
 
group_name - Variable in class org.jgroups.ensemble.Hot_JoinOps
 
group_name - Variable in class org.jgroups.ensemble.Hot_ViewState
 
groupd - Variable in class org.jgroups.ensemble.Hot_JoinOps
 
groupd - Variable in class org.jgroups.ensemble.Hot_ViewState
 
groupname - Variable in class org.jgroups.blocks.DistributedQueue
 
groupname - Variable in class org.jgroups.blocks.TransactionalHashtable
 
groupname - 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
 
HEADER_KEY - Static variable in class org.jgroups.service.lease.DenyResponseHeader
 
HEADER_KEY - Static variable in class org.jgroups.service.lease.LeaseInfoReplicationHeader
 
HEADER_KEY - Static variable in class org.jgroups.service.lease.LeaseRequestHeader
 
HEADER_KEY - Static variable in class org.jgroups.service.lease.LeaseResponseHeader
 
HEARD_FROM - Static variable in class org.jgroups.Event
 
HELLO - Static variable in class org.jgroups.protocols.MERGE.MergeHeader
 
HELP_SWITCH - Static variable in class org.jgroups.service.ServiceRunner
 
HOT_ENS_MSG_SEND_CURRENT_VIEW - Variable in class org.jgroups.ensemble.Hot_Ensemble
 
HOT_ENS_MSG_SEND_NEXT_VIEW - Variable in class org.jgroups.ensemble.Hot_Ensemble
 
HOT_ENS_MSG_SEND_UNSPECIFIED_VIEW - Variable in class org.jgroups.ensemble.Hot_Ensemble
 
Header - class org.jgroups.Header.
Abstract base class for all headers to be added to a Message.
Header() - Constructor for class org.jgroups.Header
 
Hot_Buffer - class org.jgroups.ensemble.Hot_Buffer.
 
Hot_Buffer() - Constructor for class org.jgroups.ensemble.Hot_Buffer
 
Hot_Callbacks - interface org.jgroups.ensemble.Hot_Callbacks.
 
Hot_Endpoint - class org.jgroups.ensemble.Hot_Endpoint.
 
Hot_Endpoint() - Constructor for class org.jgroups.ensemble.Hot_Endpoint
 
Hot_Ensemble - class org.jgroups.ensemble.Hot_Ensemble.
 
Hot_Ensemble() - Constructor for class org.jgroups.ensemble.Hot_Ensemble
Constructs a Hot_Ensemble object starting the Ensemble Outboard process on a random port between 5000 and 8000
Hot_Ensemble(int) - Constructor for class org.jgroups.ensemble.Hot_Ensemble
Constructs a Hot_Ensemble object starting the Ensemble Outboard process on the specified port.
Hot_Error - class org.jgroups.ensemble.Hot_Error.
 
Hot_Error(int, String) - Constructor for class org.jgroups.ensemble.Hot_Error
 
Hot_GroupContext - class org.jgroups.ensemble.Hot_GroupContext.
 
Hot_JoinOps - class org.jgroups.ensemble.Hot_JoinOps.
 
Hot_JoinOps() - Constructor for class org.jgroups.ensemble.Hot_JoinOps
 
Hot_Message - class org.jgroups.ensemble.Hot_Message.
 
Hot_Message() - Constructor for class org.jgroups.ensemble.Hot_Message
 
Hot_ObjectMessage - class org.jgroups.ensemble.Hot_ObjectMessage.
This HOT Message class is a mechanism to transmit Java objects over ensemble.
Hot_ObjectMessage() - Constructor for class org.jgroups.ensemble.Hot_ObjectMessage
 
Hot_ObjectMessage(Object) - Constructor for class org.jgroups.ensemble.Hot_ObjectMessage
 
Hot_ObjectMessage(Hot_Message) - Constructor for class org.jgroups.ensemble.Hot_ObjectMessage
Takes the bytes contained within a Hot_Message object (usually gotten from a standard ReceiveCast/Send upcall) and interprets them as a serialized object.
Hot_ObjectMessage(byte[]) - Constructor for class org.jgroups.ensemble.Hot_ObjectMessage
Interprets the bytes as a serialized object
Hot_ViewID - class org.jgroups.ensemble.Hot_ViewID.
 
Hot_ViewID() - Constructor for class org.jgroups.ensemble.Hot_ViewID
 
Hot_ViewState - class org.jgroups.ensemble.Hot_ViewState.
 
Hot_ViewState() - Constructor for class org.jgroups.ensemble.Hot_ViewState
 
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.
handleClear(Xid, long, long, boolean) - Method in class org.jgroups.blocks.TransactionalHashtable
 
handleCommit(Xid) - Method in class org.jgroups.blocks.ReplicationManager
 
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.TOTAL_TOKEN
 
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.
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(Object) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
 
handleMergeCancelled(Object) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
handleMergeRequest(Address, Object) - 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, Object) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
handleMergeResponse(MergeData, Object) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
 
handleMergeResponse(MergeData, Object) - Method in class org.jgroups.protocols.pbcast.GmsImpl
 
handleMergeView(MergeData, Object) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
If merge_id != this.merge_id --> discard Else cast the view/digest to all members of this group.
handleMergeView(MergeData, Object) - 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
 
handlePut(Serializable, Serializable, Xid, long, long, boolean) - Method in class org.jgroups.blocks.TransactionalHashtable
 
handlePutAll(Map, Xid, long, long, boolean) - Method in class org.jgroups.blocks.TransactionalHashtable
 
handleRemove(Serializable, Xid, long, long, boolean) - Method in class org.jgroups.blocks.TransactionalHashtable
 
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.
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.LogicalAddress1_4
 
head - Variable in class org.jgroups.util.List
 
headers - Variable in class org.jgroups.Message
 
heartbeat(Hot_GroupContext, Object, int) - Method in class org.jgroups.EnsChannel
 
heartbeat(Hot_GroupContext, Object, int) - Method in interface org.jgroups.ensemble.Hot_Callbacks
Called to issue you a heartbeat
heartbeat_rate - Variable in class org.jgroups.ensemble.Hot_JoinOps
 
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(int) - Method in class org.jgroups.protocols.pbcast.Digest
 
highSeqnoAt(Address) - Method in class org.jgroups.protocols.pbcast.Digest
 
highSeqnoSeenAt(int) - Method in class org.jgroups.protocols.pbcast.Digest
 
highSeqnoSeenAt(Address) - Method in class org.jgroups.protocols.pbcast.Digest
 
highest_seqnos - Variable in class org.jgroups.protocols.Digest
 
host - Variable in class org.jgroups.stack.LogicalAddress1_4
 

I

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
 
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
 
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.ensemble.Hot_GroupContext
 
id - Variable in class org.jgroups.protocols.FRAG.FragHeader
 
id - Variable in class org.jgroups.protocols.FRAG2.FragHeader
 
id - Variable in class org.jgroups.stack.LogicalAddress1_4
 
impl_mutex - Variable in class org.jgroups.protocols.GMS
 
impl_mutex - Variable in class org.jgroups.protocols.pbcast.GMS
 
incorrectStateReceived(Object) - Method in class org.jgroups.service.lease.LeaseFactoryService
This method is called when service queries new state but received state contains incorrect entries.
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
Increment 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(long) - Method in class org.jgroups.blocks.DistributedHashtable
 
init() - Method in class org.jgroups.blocks.DistributedQueue
 
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.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.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.TCPGOSSIP
 
init() - Method in class org.jgroups.protocols.UDP
 
init() - Method in class org.jgroups.protocols.UDP1_4
 
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.STATE_TRANSFER
 
init(String, List) - Method in class org.jgroups.stack.LogicalAddress1_4
 
init() - Method in class org.jgroups.stack.Protocol
Called after instance has been created (null constructor) and before protocol is started.
initChannel(String, String, long) - Method in class org.jgroups.blocks.TransactionalHashtable
 
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
 
isAbsolute() - Method in class org.jgroups.service.lease.LeaseRequestHeader
Check if duration is relative or absolute.
isAbsolute() - Method in class org.jgroups.service.lease.LeaseResponseHeader
Check if duration is relative or absolute.
isBlocked() - Method in class org.jgroups.service.AbstractService
This method returns true if inter-service communication processes should temporarily stop sending messages to service channel.
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.EnsChannel
 
isConnected() - Method in class org.jgroups.JChannel
returns true if the Connect operation has been called successfully
isCoord() - Method in class org.jgroups.protocols.PingRsp
 
isCoordinator() - Method in class org.jgroups.blocks.NotificationBus
 
isCoordinator() - Method in class org.jgroups.service.AbstractService
Check if this service is a coordinator of service group.
isDefaultSyncRepl() - Method in class org.jgroups.blocks.TransactionalHashtable
 
isDone() - Method in class org.jgroups.blocks.GroupRequest
 
isExpired() - Method in interface org.jgroups.service.lease.Lease
Check if lease has expired.
isExpired() - Method in class org.jgroups.service.lease.LeaseFactoryService.LeaseInfo
Check if lease is expired.
isMulticastAddress() - Method in interface org.jgroups.Address
Checks whether this is an address that represents multiple destinations, e.g.
isMulticastAddress() - Method in class org.jgroups.ensemble.Hot_Endpoint
 
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.LogicalAddress1_4
 
isOpen() - Method in class org.jgroups.Channel
Determines whether the channel is open, ie.
isOpen() - Method in class org.jgroups.EnsChannel
 
isOpen() - Method in class org.jgroups.JChannel
returns true if the Open operation has been called successfully
isOverride() - Method in class org.jgroups.conf.ProtocolData
 
isPrepare() - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
 
isReceived(Address) - Method in class org.jgroups.util.RspList
 
isStarted() - Method in class org.jgroups.stack.GossipRouter
 
isSuspected(Address) - Method in class org.jgroups.util.RspList
 
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.

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 When a JChannel object is instantiated it automatically sets up the protocol stack
JChannel() - Constructor for class org.jgroups.JChannel
Constructs a JChannel instance with the protocol stack specified by the DEFAULT_PROTOCOL_STACK member.
JChannel(File) - Constructor for class org.jgroups.JChannel
Constructs a JChannel instance with the protocol stack configuration contained by the specified file.
JChannel(Element) - Constructor for class org.jgroups.JChannel
Constructs a JChannel instance with the protocol stack configuration contained by the specified XML element.
JChannel(URL) - Constructor for class org.jgroups.JChannel
Constructs a JChannel instance with the protocol stack configuration indicated by the specified URL.
JChannel(String) - Constructor for class org.jgroups.JChannel
Constructs a JChannel instance with the protocol stack configuration based upon the specified properties parameter.
JChannel(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.
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.
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.
JMS.JMSAddress(String, boolean) - Constructor for class org.jgroups.protocols.JMS.JMSAddress
Create instance of this class for given address string.
JMS.JMSAddress() - Constructor for class org.jgroups.protocols.JMS.JMSAddress
Empty constructor to allow externalization work.
JMS.JMSAddress(String) - Constructor for class org.jgroups.protocols.JMS.JMSAddress
Reconstruct the address from the string representation.
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
 
JoinRsp - class org.jgroups.protocols.pbcast.JoinRsp.
 
JoinRsp(View, Digest) - Constructor for class org.jgroups.protocols.pbcast.JoinRsp
 
join(Hot_JoinOps, Hot_GroupContext[]) - Method in class org.jgroups.ensemble.Hot_Ensemble
Join the Ensemble group specified in the Hot_JoinOps structure
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_retry_timeout - Variable in class org.jgroups.protocols.pbcast.GMS
 
join_timeout - Variable in class org.jgroups.protocols.GMS
 
join_timeout - Variable in class org.jgroups.protocols.pbcast.GMS
 
joining - Variable in class org.jgroups.ensemble.Hot_GroupContext
 
joining - Variable in class org.jgroups.protocols.pbcast.GMS
Members joined but for which no view has been received yet

K

keySet() - Method in class org.jgroups.blocks.TransactionalHashtable
 

L

LEASE_CANCELED - Static variable in class org.jgroups.service.lease.LeaseResponseHeader
 
LEASE_DENIED - Static variable in class org.jgroups.service.lease.DenyResponseHeader
 
LEASE_GRANTED - Static variable in class org.jgroups.service.lease.LeaseResponseHeader
 
LEASE_RENEWED - Static variable in class org.jgroups.service.lease.LeaseResponseHeader
 
LEASE_SERVICE_NAME - Static variable in class org.jgroups.service.lease.LeaseFactoryService
 
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
 
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
 
Lease - interface org.jgroups.service.lease.Lease.
Lease interface represents a token granted by lease manager that allows access to some resource for a limited period of time.
LeaseDeniedException - exception org.jgroups.service.lease.LeaseDeniedException.
 
LeaseDeniedException(Object) - Constructor for class org.jgroups.service.lease.LeaseDeniedException
 
LeaseDeniedException(String, Object) - Constructor for class org.jgroups.service.lease.LeaseDeniedException
 
LeaseException - exception org.jgroups.service.lease.LeaseException.
 
LeaseException() - Constructor for class org.jgroups.service.lease.LeaseException
 
LeaseException(String) - Constructor for class org.jgroups.service.lease.LeaseException
 
LeaseFactory - interface org.jgroups.service.lease.LeaseFactory.
LeaseFactory is responsible for granting new leases, renewing existing leases and canceling leases when it is no longer needed.
LeaseFactoryClient - class org.jgroups.service.lease.LeaseFactoryClient.
LeaseFactoryClient is an implementation of LeaseFactory interface that delegates lease granting to group containing one or more LeaseFactoryService instances.
LeaseFactoryClient(Channel) - Constructor for class org.jgroups.service.lease.LeaseFactoryClient
Create instance of this class for specified client channel with default timeouts.
LeaseFactoryClient(Channel, int, int) - Constructor for class org.jgroups.service.lease.LeaseFactoryClient
Create instance of this class for the specified channel with specified timeouts.
LeaseFactoryService - class org.jgroups.service.lease.LeaseFactoryService.
LeaseFactoryService is service that is able to lease resources to clients.
LeaseFactoryService(Channel, Channel) - Constructor for class org.jgroups.service.lease.LeaseFactoryService
Create instance of this class.
LeaseFactoryService.LeaseInfo - class org.jgroups.service.lease.LeaseFactoryService.LeaseInfo.
This class represents granted lease that is replicated between services.
LeaseFactoryService.LeaseInfo() - Constructor for class org.jgroups.service.lease.LeaseFactoryService.LeaseInfo
Create uninitialized instance of this object.
LeaseFactoryService.LeaseInfo(Object, long) - Constructor for class org.jgroups.service.lease.LeaseFactoryService.LeaseInfo
Create instance of this class.
LeaseFactoryService.LeaseInfo(LeaseRequestHeader) - Constructor for class org.jgroups.service.lease.LeaseFactoryService.LeaseInfo
Create instance of this class using request header.
LeaseInfoReplicationHeader - class org.jgroups.service.lease.LeaseInfoReplicationHeader.
 
LeaseInfoReplicationHeader() - Constructor for class org.jgroups.service.lease.LeaseInfoReplicationHeader
Construct uninitialized instance of this object.
LeaseInfoReplicationHeader(int, LeaseFactoryService.LeaseInfo) - Constructor for class org.jgroups.service.lease.LeaseInfoReplicationHeader
Create instance of this object for a specified lease info object.
LeaseRequestHeader - class org.jgroups.service.lease.LeaseRequestHeader.
Message header that represents lease request.
LeaseRequestHeader() - Constructor for class org.jgroups.service.lease.LeaseRequestHeader
Constructs empty header.
LeaseRequestHeader(int, long, boolean, Object) - Constructor for class org.jgroups.service.lease.LeaseRequestHeader
Create lease request header of the specified type with specified duration.
LeaseResponseHeader - class org.jgroups.service.lease.LeaseResponseHeader.
Message header representing service response.
LeaseResponseHeader() - Constructor for class org.jgroups.service.lease.LeaseResponseHeader
Create uninitialized instance of this class.
LeaseResponseHeader(int, Object) - Constructor for class org.jgroups.service.lease.LeaseResponseHeader
Create instance of this class of type LEASE_CANCELED or LEASE_RENEWED.
LeaseResponseHeader(int, long, boolean, Object) - Constructor for class org.jgroups.service.lease.LeaseResponseHeader
Create instance of this class of type either LEASE_GRANTED or LEASE_RENEWED.
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.
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
 
LogicalAddress1_4 - class org.jgroups.stack.LogicalAddress1_4.
Logical address that spans the lifetime of a member.
LogicalAddress1_4() - Constructor for class org.jgroups.stack.LogicalAddress1_4
 
LogicalAddress1_4(String, List) - Constructor for class org.jgroups.stack.LogicalAddress1_4
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
 
lclear() - Method in class org.jgroups.blocks.TransactionalHashtable
 
leaseTarget - Variable in class org.jgroups.service.lease.LeaseDeniedException
 
leaseTimeout - Variable in class org.jgroups.service.lease.LeaseFactoryClient
 
leases - Variable in class org.jgroups.service.lease.LeaseFactoryService
 
leave(Hot_GroupContext) - Method in class org.jgroups.ensemble.Hot_Ensemble
Leave the Ensemble group specified in the Hot_GroupContext
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
 
leave_timeout - Variable in class org.jgroups.protocols.pbcast.GMS
 
leaving - Variable in class org.jgroups.ensemble.Hot_GroupContext
 
leaving - Variable in class org.jgroups.protocols.pbcast.GMS
Members excluded from group, but for which no view has been received yet
length - Variable in class org.jgroups.Message
The number of bytes in the buffer (usually buf.length is buf != null)
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.UDP1_4.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
 
localSeqID - 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.blocks.TransactionalHashtable
 
local_addr - Variable in class org.jgroups.protocols.GMS
 
local_addr - Variable in class org.jgroups.protocols.pbcast.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
 
lock_acquisition_timeout - Variable in class org.jgroups.blocks.TransactionalHashtable
 
lock_lease_timeout - Variable in class org.jgroups.blocks.TransactionalHashtable
 
log - Variable in class org.jgroups.EnsChannel
 
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 - Static variable in class org.jgroups.blocks.GroupRequest
 
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.TransactionalHashtable
 
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 - Variable in class org.jgroups.persistence.PersistenceFactory
 
log - Variable in class org.jgroups.protocols.GmsImpl
 
log - Static variable in class org.jgroups.protocols.UDP1_4
 
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 - Variable in class org.jgroups.service.AbstractService
 
log - Variable in class org.jgroups.service.lease.LeaseFactoryClient
 
log - Static variable in class org.jgroups.stack.AckMcastReceiverWindow
 
log - Static variable in class org.jgroups.stack.AckMcastSenderWindow
 
log - Static variable in class org.jgroups.stack.AckSenderWindow
 
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
 
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
 
log - Static variable in class org.jgroups.util.Util
 
lookup(int) - Static method in class org.jgroups.ensemble.Hot_GroupContext
 
low - Variable in class org.jgroups.util.Range
 
lowSeqnoAt(int) - Method in class org.jgroups.protocols.pbcast.Digest
 
lput(Object, Object) - Method in class org.jgroups.blocks.TransactionalHashtable
 
lputAll(Map) - Method in class org.jgroups.blocks.TransactionalHashtable
 
lremove(Object, Object) - Method in class org.jgroups.blocks.TransactionalHashtable
 
ltime - Variable in class org.jgroups.ensemble.Hot_ViewID
 
ltime - Variable in class org.jgroups.protocols.GMS
 
ltime - Variable in class org.jgroups.protocols.pbcast.GMS
 

M

MAGIC_NUMBER_FILE - Static variable in class org.jgroups.conf.MagicNumberReader
 
MAXIMUM_DURATION - Static variable in class org.jgroups.service.lease.LeaseFactoryService
 
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.protocols.MERGE2.
Protocol to discover subgroups, e.g.
MERGE2() - Constructor for class org.jgroups.protocols.MERGE2
 
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
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
 
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(Vector) - Constructor for class org.jgroups.Membership
Creates a member ship object with the initial members.
MembershipListener - interface org.jgroups.MembershipListener.
 
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 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
Only used for Externalization (creating an initial object)
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.
Used on top of channel to implement group requests.
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.
 
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 JavaGroup 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(String, Object[], Class[]) - Constructor for class org.jgroups.blocks.MethodCall
 
MethodCall(String, Object[], String[]) - Constructor for class org.jgroups.blocks.MethodCall
 
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
 
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.blocks.TransactionalHashtable
 
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.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.UDP1_4
 
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.service.ServiceRunner
Main entry to run this class.
main(String[]) - Static method in class org.jgroups.stack.AckMcastReceiverWindow
 
main(String[]) - Static method in class org.jgroups.stack.AckReceiverWindow
 
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
 
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.GetNetworkInterfaces1_4
 
main(String[]) - Static method in class org.jgroups.util.List
 
main(String[]) - Static method in class org.jgroups.util.Proxy1_4
 
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.GMS
 
makeView(Vector, ViewId) - 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
 
max(TransportedVectorTime) - Method in class org.jgroups.protocols.VectorTime
Updates this VectorTime as follows:
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.ensemble.Hot_ViewState
 
members - Variable in class org.jgroups.protocols.GMS
 
members - Variable in class org.jgroups.protocols.pbcast.GMS
 
members - Variable in class org.jgroups.service.AbstractService
 
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(Vector, Vector) - 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
merge_timeout - Variable in class org.jgroups.protocols.pbcast.GMS
 
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_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
 
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
 
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.LogicalAddress1_4
 
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.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
 
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
 
NBMessageForm1_4 - class org.jgroups.blocks.NBMessageForm1_4.
NBMessageForm - Message form for non-blocking message reads.
NBMessageForm1_4(int, SocketChannel) - Constructor for class org.jgroups.blocks.NBMessageForm1_4
 
NEW_LEASE_REQUEST - Static variable in class org.jgroups.service.lease.LeaseRequestHeader
 
NEW_LEASE_TYPE - Static variable in class org.jgroups.service.lease.LeaseFactoryService.LeaseInfo
 
NEW_LEASE_TYPE - Static variable in class org.jgroups.service.lease.LeaseInfoReplicationHeader
 
NONE - Static variable in class org.jgroups.service.lease.DenyResponseHeader
 
NONE - Static variable in class org.jgroups.service.lease.LeaseInfoReplicationHeader
 
NONE - Static variable in class org.jgroups.service.lease.LeaseResponseHeader
 
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(int, long) - Constructor for class org.jgroups.protocols.pbcast.NakAckHeader
Constructor for regular messages
NakAckHeader(int, long, long) - Constructor for class org.jgroups.protocols.pbcast.NakAckHeader
Constructor for retransmit requests/responses (low and high define the range of msgs)
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
Node - class org.jgroups.demos.wb.Node.
 
Node() - Constructor for class org.jgroups.demos.wb.Node
 
NotificationBus - class org.jgroups.blocks.NotificationBus.
Class for dissemination of notifications.
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
 
name - Variable in class org.jgroups.blocks.RequestCorrelator.Header
The unique name of the associated RequestCorrelator
name - Variable in class org.jgroups.blocks.RequestCorrelator
makes the instance unique (together with IDs)
name - Variable in class org.jgroups.ensemble.Hot_Endpoint
 
newLease(Object, Object, long, boolean) - Method in interface org.jgroups.service.lease.LeaseFactory
Obtain new lease.
newLease(Object, Object, long, boolean) - Method in class org.jgroups.service.lease.LeaseFactoryClient
Get new lease.
next - Variable in class org.jgroups.ensemble.Hot_GroupContext
 
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
 
nmembers - Variable in class org.jgroups.ensemble.Hot_ViewState
 
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
 
notifs - Variable in class org.jgroups.blocks.TransactionalHashtable
 
notifyBlock() - Method in class org.jgroups.blocks.PullPushAdapter
 
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.FRAG.FragHeader
 
num_frags - Variable in class org.jgroups.protocols.FRAG2.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(javax.jms.Message) - Method in class org.jgroups.protocols.JMS
Implementation of the javax.jms.MessageListener interface.
open() - Method in class org.jgroups.Channel
Re-opens a closed channel.
open() - Method in class org.jgroups.JChannel
Opens the channel.
this does the following actions
1.
option2String(int) - Static method in class org.jgroups.Channel
 
org.jgroups - package org.jgroups
 
org.jgroups.blocks - package org.jgroups.blocks
 
org.jgroups.conf - package org.jgroups.conf
 
org.jgroups.debug - package org.jgroups.debug
 
org.jgroups.demos - package org.jgroups.demos
 
org.jgroups.demos.applets - package org.jgroups.demos.applets
 
org.jgroups.demos.wb - package org.jgroups.demos.wb
 
org.jgroups.ensemble - package org.jgroups.ensemble
 
org.jgroups.persistence - package org.jgroups.persistence
 
org.jgroups.protocols - package org.jgroups.protocols
 
org.jgroups.protocols.pbcast - package org.jgroups.protocols.pbcast
 
org.jgroups.protocols.ring - package org.jgroups.protocols.ring
 
org.jgroups.service - package org.jgroups.service
 
org.jgroups.service.lease - package org.jgroups.service.lease
 
org.jgroups.stack - package org.jgroups.stack
 
org.jgroups.util - package org.jgroups.util
 
outboard - Variable in class org.jgroups.ensemble.Hot_JoinOps
 
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.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
 
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
 
PUT - Static variable in class org.jgroups.blocks.TransactionalHashtable.Data
 
PUT_ALL - Static variable in class org.jgroups.blocks.TransactionalHashtable.Data
 
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(int, Object) - Constructor for class org.jgroups.protocols.PingHeader
 
PingRsp - class org.jgroups.protocols.PingRsp.
 
PingRsp(Address, Address) - Constructor for class org.jgroups.protocols.PingRsp
 
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.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
 
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
 
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
 
Proxy1_4 - class org.jgroups.util.Proxy1_4.
Redirects incoming TCP connections to other hosts/ports.
Proxy1_4(InetAddress, int, InetAddress, int, boolean, boolean) - Constructor for class org.jgroups.util.Proxy1_4
 
Proxy1_4(InetAddress, int, InetAddress, int, boolean, boolean, String) - Constructor for class org.jgroups.util.Proxy1_4
 
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
 
panic(String) - Static method in class org.jgroups.ensemble.Hot_Ensemble
Halts the application with the error specified by the String
params - Variable in class org.jgroups.ensemble.Hot_JoinOps
 
params - Variable in class org.jgroups.ensemble.Hot_ViewState
 
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
E.g.
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.
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.EnsChannel
 
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() - 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.
pendingCancels - Variable in class org.jgroups.service.lease.LeaseFactoryClient
 
pendingLeases - Variable in class org.jgroups.service.lease.LeaseFactoryClient
 
pendingRenewals - Variable in class org.jgroups.service.lease.LeaseFactoryClient
 
physical_addrs - Variable in class org.jgroups.stack.LogicalAddress1_4
List of physical addresses
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
 
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.
primary - Variable in class org.jgroups.ensemble.Hot_ViewState
 
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
 
printClassMap() - Method in class org.jgroups.conf.ClassConfigurator
 
printContents(boolean) - Method in class org.jgroups.protocols.PerfHeader
 
printContents(boolean, Vector) - Method in class org.jgroups.protocols.PerfHeader
 
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
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
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
 
printProtocolSpec(boolean) - Method in class org.jgroups.JChannel
Returns a pretty-printed form of all the protocols.
printProtocolSpec(boolean) - Method in class org.jgroups.stack.ProtocolStack
Prints the names of the protocols, from the bottom to top.
printStackTrace() - Method in class org.jgroups.ChannelException
Prints this exception's stack trace to standard error.
printStackTrace(PrintStream) - Method in class org.jgroups.ChannelException
Prints this exception's stack trace to the provided stream.
printStackTrace(PrintWriter) - Method in class org.jgroups.ChannelException
Prints this exception's stack trace to the provided writer.
printStackTrace(Throwable) - Static method in class org.jgroups.util.Util
Use with caution: lots of overhead
printStackTrace() - Static method in class org.jgroups.util.Util
Use with caution: lots of overhead
printThreads() - Static method in class org.jgroups.util.Util
 
printVersionId(byte[], int) - Static method in class org.jgroups.Version
 
printVersionId(byte[]) - Static method in class org.jgroups.Version
 
processCancelLeaseRequest(LeaseRequestHeader, Object, Address) - Method in class org.jgroups.service.lease.LeaseFactoryService
Process request to cancel lease.
processEvent(String, AWTEvent) - Method in class org.jgroups.demos.DrawRepl
 
processNewLeaseRequest(LeaseRequestHeader, Object, Address) - Method in class org.jgroups.service.lease.LeaseFactoryService
Process new lease request.
processRenewLeaseRequest(LeaseRequestHeader, Object, Address) - Method in class org.jgroups.service.lease.LeaseFactoryService
Process request to renew a lease.
prompt(String) - Static method in class org.jgroups.util.Util
 
propagateStateChange(int, LeaseFactoryService.LeaseInfo, Object) - Method in class org.jgroups.service.lease.LeaseFactoryService
Propagate state change to other members.
properties - Variable in class org.jgroups.blocks.TransactionalHashtable
 
properties - Variable in class org.jgroups.ensemble.Hot_JoinOps
 
props - Variable in class org.jgroups.protocols.GMS
 
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
 
protocol - Variable in class org.jgroups.ensemble.Hot_JoinOps
 
protocol - Variable in class org.jgroups.ensemble.Hot_ViewState
 
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.FLUSH
 
providedUpServices() - Method in class org.jgroups.protocols.NAKACK
 
providedUpServices() - Method in class org.jgroups.protocols.PING
 
providedUpServices() - Method in class org.jgroups.protocols.QUEUE
 
providedUpServices() - Method in class org.jgroups.protocols.TCPGOSSIP
 
providedUpServices() - Method in class org.jgroups.protocols.TCPPING
 
providedUpServices() - Method in class org.jgroups.protocols.TOTAL_TOKEN
 
providedUpServices() - Method in class org.jgroups.protocols.WANPING
 
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.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.
put(Object, Object) - Method in class org.jgroups.blocks.TransactionalHashtable
Replicates the update to all members.
put(Object, Object, boolean, long) - Method in class org.jgroups.blocks.TransactionalHashtable
Replicates the update to all members.
put(Object, Object, long, long, long, boolean) - Method in class org.jgroups.blocks.TransactionalHashtable
Replicates the update to all members, and use locks at each member to ensure serializability.
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.
putAll(Map) - Method in class org.jgroups.blocks.TransactionalHashtable
Replicates the update to all members.
putAll(Map, boolean, long) - Method in class org.jgroups.blocks.TransactionalHashtable
Replicates the update to all members.
putAll(Map, long, long, long, boolean) - Method in class org.jgroups.blocks.TransactionalHashtable
Replicated the update to all members, and use locks at each member to ensure serializability.
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
 
REMOVE - Static variable in class org.jgroups.blocks.TransactionalHashtable.Data
 
RENEW_DENIED - Static variable in class org.jgroups.service.lease.DenyResponseHeader
 
RENEW_LEASE_REQUEST - Static variable in class org.jgroups.service.lease.LeaseRequestHeader
 
RENEW_LEASE_TYPE - Static variable in class org.jgroups.service.lease.LeaseFactoryService.LeaseInfo
 
RENEW_LEASE_TYPE - Static variable in class org.jgroups.service.lease.LeaseInfoReplicationHeader
 
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.
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
RESOURCE_SWITCH - Static variable in class org.jgroups.service.ServiceRunner
 
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
 
RWLock - class org.jgroups.util.RWLock.
Lock allowing multiple reads or a single write.
RWLock() - Constructor for class org.jgroups.util.RWLock
 
RWLock.BlockException - exception org.jgroups.util.RWLock.BlockException.
Exception thrown when a lock request would block the caller
RWLock.BlockException() - Constructor for class org.jgroups.util.RWLock.BlockException
 
RWLock.BlockException(String) - Constructor for class org.jgroups.util.RWLock.BlockException
 
RWLock.IntException - exception org.jgroups.util.RWLock.IntException.
Interrupted exception wrapped in a RuntimeException
RWLock.IntException() - Constructor for class org.jgroups.util.RWLock.IntException
 
RWLock.IntException(String) - Constructor for class org.jgroups.util.RWLock.IntException
 
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
 
RecursiveLeaseRequestException - exception org.jgroups.service.lease.RecursiveLeaseRequestException.
This exception indicates that lease factory has undecided lease request for the specified lease target and from specified tenant.
RecursiveLeaseRequestException(Object, Object) - Constructor for class org.jgroups.service.lease.RecursiveLeaseRequestException
 
RecursiveLeaseRequestException(String, Object, Object) - Constructor for class org.jgroups.service.lease.RecursiveLeaseRequestException
 
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() - 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(int, 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.
Dispatches and receives remote group method calls.
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
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
 
random(long) - Static method in class org.jgroups.util.Util
Returns a random value in the range [1 - range]
rank - Variable in class org.jgroups.ensemble.Hot_ViewState
 
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.
readCompleteMsgBuffer() - Method in class org.jgroups.blocks.NBMessageForm1_4
 
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
Read the header from the given stream
readExternal(ObjectInput) - Method in class org.jgroups.blocks.TransactionalHashtable.Data
 
readExternal(ObjectInput) - Method in class org.jgroups.blocks.Xid
 
readExternal(ObjectInput) - Method in class org.jgroups.ensemble.Hot_Endpoint
 
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.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.FRAG.FragHeader
 
readExternal(ObjectInput) - Method in class org.jgroups.protocols.FRAG2.FragHeader
 
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.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.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.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.service.lease.DenyResponseHeader
Read state of this object from object input.
readExternal(ObjectInput) - Method in class org.jgroups.service.lease.LeaseFactoryService.LeaseInfo
 
readExternal(ObjectInput) - Method in class org.jgroups.service.lease.LeaseInfoReplicationHeader
Read state of this object from ObjectInput
readExternal(ObjectInput) - Method in class org.jgroups.service.lease.LeaseRequestHeader
Read state of this object from object input stream.
readExternal(ObjectInput) - Method in class org.jgroups.service.lease.LeaseResponseHeader
Read state of this object from object input.
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.LogicalAddress1_4
 
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
 
readLock() - Method in class org.jgroups.util.RWLock
Obtain a read lock
readLockNoBlock() - Method in class org.jgroups.util.RWLock
Obtain the read lock immediatelly or throw an exception if an attempt to get the read lock would block this call
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)
readUnlock() - Method in class org.jgroups.util.RWLock
Revoke the read lock
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.EnsChannel
 
receive(long) - Method in class org.jgroups.JChannel
Blocking receive method.
receive(Message) - Method in interface org.jgroups.MessageListener
 
receive(long) - Method in interface org.jgroups.Transport
 
receive(Message) - Method in interface org.jgroups.blocks.ConnectionTable.Receiver
 
receive(Message) - 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(Xid, byte[], byte[], long, long, boolean) - Method in class org.jgroups.blocks.TransactionalHashtable
Receives an update.
receive(Message) - Method in class org.jgroups.blocks.TransactionalHashtable
 
receive(Message) - Method in class org.jgroups.blocks.VotingAdapter
Receive the message.
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(Message) - Method in class org.jgroups.protocols.TCP
ConnectionTable.Receiver interface
receive(DatagramPacket) - Method in class org.jgroups.protocols.UDP1_4.ConnectorTable
 
receive(DatagramPacket) - Method in class org.jgroups.protocols.UDP1_4.MyReceiver
 
receive(DatagramPacket) - Method in class org.jgroups.protocols.UDP1_4
 
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).
receiveCast(Hot_GroupContext, Object, Hot_Endpoint, Hot_Message) - Method in class org.jgroups.EnsChannel
 
receiveCast(Hot_GroupContext, Object, Hot_Endpoint, Hot_Message) - Method in interface org.jgroups.ensemble.Hot_Callbacks
Called when Ensemble receives a Cast from your group
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.UDP1_4.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
 
receiveSend(Hot_GroupContext, Object, Hot_Endpoint, Hot_Message) - Method in class org.jgroups.EnsChannel
 
receiveSend(Hot_GroupContext, Object, Hot_Endpoint, Hot_Message) - Method in interface org.jgroups.ensemble.Hot_Callbacks
Called when Ensemble receives a point-to-point message for you
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 PBCAST layer.
receiveUpEvent(Event) - Method in class org.jgroups.protocols.pbcast.STABLE
We need to receive this event out-of-band, otherwise we would block.
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.UDP1_4.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
 
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() - Method in class org.jgroups.stack.RouterStub
Tries to establish connection to router.
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.
registerListener(Serializable, MessageListener) - Method in class org.jgroups.blocks.PullPushAdapter
sets a listener to messages with a given identifier messages sent with this identifier in there header will be routed to this listener note: there could be only one listener for one identifier, if you want to register a different listener to an already registered identifier then unregister first
registerManager(PersistenceManager) - Method in class org.jgroups.persistence.PersistenceFactory
Register a custom persistence manager as opposed to the FilePersistenceManager or DBPersistenceManager.
release(Hot_GroupContext) - Static method in class org.jgroups.ensemble.Hot_GroupContext
 
remove(Address) - Method in class org.jgroups.Membership
removes an member from the membership.
remove(Vector) - 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(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(Object) - Method in class org.jgroups.blocks.TransactionalHashtable
Replicates the update to all members.
remove(Object, boolean, long) - Method in class org.jgroups.blocks.TransactionalHashtable
Replicates the update to all members.
remove(Object, long, long, long, boolean) - Method in class org.jgroups.blocks.TransactionalHashtable
Replicated the update to all members, and use locks at each member to ensure serializability.
remove(Serializable) - Method in class org.jgroups.persistence.DBPersistenceManager
Used to remove 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
Returns the first entry (with the lowest seqno) from the received_msgs map if its associated message is not null, otherwise returns null.
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.LogicalAddress1_4
For internal use only ! Don't use this method !
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.
removeFile(String) - Static method in class org.jgroups.util.Util
 
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.
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.LogicalAddress1_4
For internal use only ! Don't use this method !
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.
renewLease(Lease, long, boolean) - Method in interface org.jgroups.service.lease.LeaseFactory
Renew existing lease.
renewLease(Lease, long, boolean) - Method in class org.jgroups.service.lease.LeaseFactoryClient
Renew existing lease.
repaint() - Method in class org.jgroups.demos.wb.Whiteboard
 
repl_mgr - Variable in class org.jgroups.blocks.TransactionalHashtable
 
replace(String, String, String) - Static method in class org.jgroups.conf.XmlConfigurator
 
req_handler - Variable in class org.jgroups.blocks.MessageDispatcher
 
req_id - Variable in class org.jgroups.blocks.GroupRequest
 
requestNewView(Hot_GroupContext) - Method in class org.jgroups.ensemble.Hot_Ensemble
Request a new view in the group specified by the Hot_GroupContext
requestToString(int) - Method in class org.jgroups.blocks.TransactionalHashtable.Data
 
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(Message, int, long) - Method in class org.jgroups.blocks.GroupRequest
Resets the group request, so it can be reused for another execution.
reset(Message, Vector, int, long, int) - Method in class org.jgroups.blocks.GroupRequest
 
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.NBMessageForm1_4
 
reset() - 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.ENCRYPT1_4
Just remove if you don't need to reset any state
reset() - 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.FRAG
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(int) - Method in class org.jgroups.protocols.pbcast.Digest
 
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() - 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(int) - Method in class org.jgroups.protocols.pbcast.Digest
Resets the seqnos for the sender at 'index' to 0.
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.util.ReusableThread
Resumes the thread.
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.EnsChannel
 
returnState(byte[]) - Method in class org.jgroups.JChannel
Called by the application is response to receiving a getState() object when calling receive().
When the application receives a getState() message on the receive() method, it should call returnState() to reply with the state of the application
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.
rollback(Xid) - Method in class org.jgroups.blocks.TransactionalHashtable
 
rollback() - Method in class org.jgroups.blocks.TransactionalHashtable
Discards all changes done within the current transaction.
row_locks - Variable in class org.jgroups.blocks.TransactionalHashtable
 
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
 
rsp_mutex - Variable in class org.jgroups.blocks.GroupRequest
 
run() - Method in class org.jgroups.blocks.ConnectionTable
Acceptor thread.
run() - Method in class org.jgroups.blocks.ConnectionTable1_4
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.ensemble.Hot_Ensemble
Mainloop of the process
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.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.UDP1_4.Connector
 
run() - Method in class org.jgroups.protocols.UDP1_4.ConnectorTable
 
run() - Method in class org.jgroups.protocols.UDP1_4.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
 
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
runThread - Variable in class org.jgroups.service.AbstractService
 

S

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.
SERVICE_CHANNEL_STACK - Static variable in class org.jgroups.service.ServiceRunner
 
SERVICE_CLASS - Static variable in class org.jgroups.service.ServiceRunner
 
SERVICE_GROUP_NAME - Static variable in class org.jgroups.service.ServiceRunner
 
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
 
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
 
STABLE - Static variable in class org.jgroups.Event
 
STABLE - class org.jgroups.protocols.STABLE.
Computes the broadcast messages that are stable, i.e.
STABLE() - Constructor for class org.jgroups.protocols.STABLE
 
STABLE - class org.jgroups.protocols.pbcast.STABLE.
Computes the broadcast messages that are stable, i.e.
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
 
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_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(int, Address, long, Digest) - Constructor for class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
 
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
 
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.
 
SendDialog - class org.jgroups.demos.wb.SendDialog.
 
SendDialog(Frame, Node, String, RpcDispatcher, String) - Constructor for class org.jgroups.demos.wb.SendDialog
 
ServiceRunner - class org.jgroups.service.ServiceRunner.
ServiceRunner is utility class that runs services in standalone mode.
ServiceRunner() - Constructor for class org.jgroups.service.ServiceRunner
 
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
 
Size() - Method in class org.jgroups.protocols.TunnelHeader
 
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
 
SuspectEvent - class org.jgroups.SuspectEvent.
 
SuspectEvent(Object) - Constructor for class org.jgroups.SuspectEvent
 
SuspectedException - exception org.jgroups.SuspectedException.
 
SuspectedException() - Constructor for class org.jgroups.SuspectedException
 
SuspectedException(Object) - Constructor for class org.jgroups.SuspectedException
 
sAddrCache - Static variable in class org.jgroups.stack.IpAddress
 
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
Save new NV pair as serializable objects or if already exist; store new state
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
Used to save all row entries for the map in 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.EnsChannel
 
send(Address, Address, Serializable) - Method in class org.jgroups.EnsChannel
 
send(Message) - Method in class org.jgroups.JChannel
implementation of the Transport interface.
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(Message) - Method in class org.jgroups.blocks.ConnectionTable
Sends a message to a unicast destination.
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(Hot_GroupContext, Hot_Endpoint, Hot_Message, int[]) - Method in class org.jgroups.ensemble.Hot_Ensemble
Send a Hot_Message to member specified by the Hot_Endpoint in the group specified by the Hot_GroupContext
send(DatagramPacket) - Method in class org.jgroups.protocols.UDP1_4.Connector
Sends a message using mcast_sock
send(DatagramPacket) - Method in class org.jgroups.protocols.UDP1_4.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
 
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
 
senderAt(int) - Method in class org.jgroups.protocols.pbcast.Digest
 
sender_thread - Variable in class org.jgroups.protocols.UDP1_4.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.
senseMaxFragSizeStatic() - Static method in class org.jgroups.protocols.AUTOCONF
 
seqID - Variable in class org.jgroups.protocols.TOTAL.Header
The ID imposing the total order of messages
seq_id - Variable in class org.jgroups.protocols.TOTAL_OLD.TotalHeader
seq_id for TOTAL_BCAST messages, seq_id is used to determine the order of messages in the view.
server_obj - Variable in class org.jgroups.blocks.RpcDispatcher
 
serviceAdapter - Variable in class org.jgroups.service.AbstractService
 
serviceChannel - Variable in class org.jgroups.service.AbstractService
 
set(Vector) - 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
 
setAdditionalData(byte[]) - Method in class org.jgroups.stack.IpAddress
Sets the additional_data.
setAdditionalData(byte[]) - Method in class org.jgroups.stack.LogicalAddress1_4
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
 
setAutoCommit(boolean) - Method in class org.jgroups.blocks.TransactionalHashtable
 
setBacklog(int) - Method in class org.jgroups.protocols.ring.RingNodeFlowControl
 
setBindAddress(String) - Method in class org.jgroups.stack.GossipRouter
 
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
setBytes(byte[]) - Method in class org.jgroups.ensemble.Hot_Buffer
 
setBytes(byte[]) - Method in class org.jgroups.ensemble.Hot_ObjectMessage
Interprets the bytes as a serialized object and sets the contained reference to the unserialized version of the serialized object
setChannel(JChannel) - Method in class org.jgroups.debug.Debugger
 
setChannelListener(ChannelListener) - Method in class org.jgroups.Channel
Allows to be notified when a channel event such as connect, disconnect or close occurs.
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
 
setConnectorTable(UDP1_4.ConnectorTable) - Method in class org.jgroups.protocols.UDP1_4.MyReceiver
 
setConsumer(NotificationBus.Consumer) - Method in class org.jgroups.blocks.NotificationBus
 
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
setDebug(boolean) - Method in class org.jgroups.ensemble.Hot_Ensemble
Set whether or not to display lots of debug information.
setDecree(Object) - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
 
setDefaultSyncRepl(boolean) - Method in class org.jgroups.blocks.TransactionalHashtable
Sets the default replication mode.
setDefaultSyncReplTimeout(long) - Method in class org.jgroups.blocks.TransactionalHashtable
 
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
 
setDone(String, int) - Method in class org.jgroups.protocols.PerfHeader
 
setDownProtocol(Protocol) - Method in class org.jgroups.stack.Protocol
 
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
 
setGossipRequestTimeout(long) - Method in class org.jgroups.stack.GossipRouter
 
setHighSeqnoAt(int, long) - Method in class org.jgroups.protocols.pbcast.Digest
 
setHighSeqnoAt(Address, long) - Method in class org.jgroups.protocols.pbcast.Digest
 
setHighSeqnoSeenAt(int, long) - Method in class org.jgroups.protocols.pbcast.Digest
 
setHighSeqnoSeenAt(Address, long) - Method in class org.jgroups.protocols.pbcast.Digest
 
setHighestSequence(long) - Method in class org.jgroups.protocols.ring.RingToken
 
setImpl(GmsImpl) - Method in class org.jgroups.protocols.GMS
 
setImpl(GmsImpl) - Method in class org.jgroups.protocols.pbcast.GMS
 
setListener(MessageListener) - Method in class org.jgroups.blocks.PullPushAdapter
 
setListener(SchedulerListener) - Method in class org.jgroups.util.Scheduler
 
setLocalAddress(Address) - Method in class org.jgroups.blocks.RequestCorrelator
 
setLockAcquisitionTimeout(long) - Method in class org.jgroups.blocks.TransactionalHashtable
 
setLockLeaseTimeout(long) - Method in class org.jgroups.blocks.TransactionalHashtable
 
setLowSeqnoAt(int, long) - Method in class org.jgroups.protocols.pbcast.Digest
 
setMarshaller(RpcDispatcher.Marshaller) - Method in class org.jgroups.blocks.RpcDispatcher
 
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
 
setMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.TransactionalHashtable
 
setMessageListener(MessageListener) - Method in class org.jgroups.blocks.MessageDispatcher
 
setMessageListener(MessageListener) - Method in class org.jgroups.service.AbstractService
Set message listener for service message channel.
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
 
setObject(Serializable) - Method in class org.jgroups.Message
 
setObject(Object) - Method in class org.jgroups.ensemble.Hot_ObjectMessage
Set the contained Object
setObserver(QUEUE.Observer) - Method in class org.jgroups.protocols.QUEUE
Only 1 observer is allowed.
setObserver(ProtocolObserver) - Method in class org.jgroups.stack.Protocol
 
setOpt(int, Object) - Method in class org.jgroups.Channel
Sets an option.
setOpt(int, Object) - Method in class org.jgroups.EnsChannel
 
setOpt(int, Object) - Method in class org.jgroups.JChannel
sets a channel option the options can be either
setOutboardPort(int) - Method in class org.jgroups.EnsChannelFactory
 
setPersistent(boolean) - Method in class org.jgroups.blocks.DistributedHashtable
 
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.LogicalAddress1_4
 
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.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.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.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.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.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.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 The following properties are being read by the UDP protocol param mcast_addr - the multicast address to use default is 228.8.8.8 param mcast_port - (int) the port that the multicast is sent on default is 7600 param ip_mcast - (boolean) flag whether to use IP multicast - default is true param ip_ttl - Set the default time-to-live for multicast packets sent out on this socket.
setProperties(Properties) - Method in class org.jgroups.protocols.UDP1_4
Setup the Protocol instance acording to the configuration string The following properties are being read by the UDP protocol param mcast_addr - the multicast address to use default is 224.0.0.200 param mcast_port - (int) the port that the multicast is sent on default is 7500 param ip_mcast - (boolean) flag whether to use IP multicast - default is true param ip_ttl - Set the default time-to-live for multicast packets sent out on this socket.
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.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(ProtocolStack) - Method in class org.jgroups.stack.Protocol
 
setQuote(String, Float) - Method in class org.jgroups.demos.QuoteServer
 
setReceiveBufferSize(int) - Method in class org.jgroups.blocks.ConnectionTable
 
setReceived(String, int) - Method in class org.jgroups.protocols.PerfHeader
 
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(Receiver) - Method in class org.jgroups.protocols.UDP1_4.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
 
setSrc(Address) - Method in class org.jgroups.Message
 
setState(byte[]) - Method in interface org.jgroups.MessageListener
 
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.TransactionalHashtable
TODO: use write lock on entire hashmap to set state
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.
setTrace(boolean) - Method in class org.jgroups.blocks.Link
 
setTransactionMode(int) - Method in class org.jgroups.blocks.TransactionalHashtable
 
setTransport(String) - Method in class org.jgroups.EnsChannelFactory
 
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
 
setVersion(byte[]) - Static method in class org.jgroups.Version
Don't use this method; used by unit testing only.
setView(View) - Method in class org.jgroups.protocols.pbcast.MergeData
 
setVisible(boolean) - Method in class org.jgroups.demos.DistributedTreeDemo
 
setWindowSize(int) - Method in class org.jgroups.protocols.ring.RingToken
 
setWindowSize(int, int) - Method in class org.jgroups.stack.AckSenderWindow
 
setWindowThreshold(int) - Method in class org.jgroups.protocols.ring.RingToken
 
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
 
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.
signature - Variable in class org.jgroups.blocks.MethodCall
the signature, e.g.
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.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.FC.FcHeader
 
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.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.UdpHeader
 
size() - Method in class org.jgroups.protocols.WANPIPE.WanPipeHeader
 
size() - Method in class org.jgroups.protocols.pbcast.Digest
 
size() - Method in class org.jgroups.protocols.pbcast.NakAckHeader
 
size() - Method in class org.jgroups.protocols.pbcast.PbcastHeader
 
size() - Method in class org.jgroups.stack.AckMcastReceiverWindow
 
size() - Method in class org.jgroups.stack.AckMcastSenderWindow
 
size() - Method in class org.jgroups.stack.NakReceiverWindow
 
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
 
sizeOf(String) - Static method in class org.jgroups.util.Util
 
sizeOf(Object) - 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(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) - 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.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.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.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.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.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.UDP1_4.Connector
 
start() - Method in class org.jgroups.protocols.UDP1_4.ConnectorTable
Get all interfaces, create one Connector per interface and call start() on it
start() - Method in class org.jgroups.protocols.UDP1_4
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.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.service.AbstractService
Start standalone thread that will run until explicitly stopped.
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.Proxy1_4
 
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
DON'T REMOVE ! 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
 
startService(ResourceBundle) - Static method in class org.jgroups.service.ServiceRunner
Method to start service.
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
DON'T REMOVE ! This prevents the up-handler thread to be created, which is not needed in the protocol.
startUpHandler() - Method in class org.jgroups.protocols.TCP
DON'T REMOVE ! 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
DON'T REMOVE ! 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.UDP1_4
DON'T REMOVE ! 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
 
state_received - Variable in class org.jgroups.JChannel
Indicates whether the state was retrieved correctly (even a null state if we are the first member)
state_timeout - Variable in class org.jgroups.blocks.TransactionalHashtable
 
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.ConnectionTable1_4
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.blocks.TransactionalHashtable
Leaves the group.
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.demos.wb.GraphPanel
 
stop() - Method in class org.jgroups.protocols.BSH
 
stop() - Method in class org.jgroups.protocols.DEADLOCK
 
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.NAKACK
 
stop() - Method in class org.jgroups.protocols.PIGGYBACK
 
stop() - Method in class org.jgroups.protocols.PING
 
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.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.UDP1_4.Connector
Stops the connector.
stop() - Method in class org.jgroups.protocols.UDP1_4.ConnectorTable
 
stop() - Method in class org.jgroups.protocols.UDP1_4
 
stop() - Method in class org.jgroups.protocols.UNICAST
 
stop() - Method in class org.jgroups.protocols.VERIFY_SUSPECT
 
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.service.AbstractService
Stop standalone thread started with AbstractService.start() method.
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.
stopEnsThread() - Method in class org.jgroups.ensemble.Hot_Ensemble
 
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
 
subgroups - Variable in class org.jgroups.MergeView
 
suspect(Address) - Method in interface org.jgroups.MembershipListener
Called when a member is suspected
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(Hot_GroupContext, Hot_Endpoint[]) - Method in class org.jgroups.ensemble.Hot_Ensemble
NOT SUPPORTED CURRENTLY IN THE ML
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(Address) - Method in class org.jgroups.service.AbstractService
This method is called when a member of service group is suspected to be failed.
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.
suspend() - Method in class org.jgroups.util.ReusableThread
Suspends the thread.
suspended(Runnable) - Method in interface org.jgroups.util.SchedulerListener
 

T

TCP - class org.jgroups.protocols.TCP.
TCP based protocol.
TCP() - Constructor for class org.jgroups.protocols.TCP
 
TCP1_4 - class org.jgroups.protocols.TCP1_4.
 
TCP1_4() - Constructor for class org.jgroups.protocols.TCP1_4
 
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
 
TCPPING - class org.jgroups.protocols.TCPPING.
The TCPPING protocol layer retrieves the initial membership (used by the GMS when started by sending event FIND_INITIAL_MBRS down the stack).
TCPPING() - Constructor for class org.jgroups.protocols.TCPPING
 
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
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
 
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.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.
 
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
 
TransactionalHashtable - class org.jgroups.blocks.TransactionalHashtable.
Hashtable which replicates its contents to all members of the group.
TransactionalHashtable(String, String, long) - Constructor for class org.jgroups.blocks.TransactionalHashtable
 
TransactionalHashtable(String, String, long, Map) - Constructor for class org.jgroups.blocks.TransactionalHashtable
 
TransactionalHashtable(String, String, long, int) - Constructor for class org.jgroups.blocks.TransactionalHashtable
 
TransactionalHashtable(String, String, long, int, float) - Constructor for class org.jgroups.blocks.TransactionalHashtable
 
TransactionalHashtable.Data - class org.jgroups.blocks.TransactionalHashtable.Data.
Class used to transport updates to all replicas
TransactionalHashtable.Data() - Constructor for class org.jgroups.blocks.TransactionalHashtable.Data
Used by externalization
TransactionalHashtable.Data(int) - Constructor for class org.jgroups.blocks.TransactionalHashtable.Data
 
TransactionalHashtable.Data(int, Serializable, Serializable) - Constructor for class org.jgroups.blocks.TransactionalHashtable.Data
 
TransactionalHashtable.Data(int, Serializable) - Constructor for class org.jgroups.blocks.TransactionalHashtable.Data
 
TransactionalHashtable.Data(int, Map) - Constructor for class org.jgroups.blocks.TransactionalHashtable.Data
 
TransactionalHashtable.Data(int, Serializable, Serializable, Map) - Constructor for class org.jgroups.blocks.TransactionalHashtable.Data
 
TransactionalHashtable.Notification - interface org.jgroups.blocks.TransactionalHashtable.Notification.
 
Transport - interface org.jgroups.Transport.
 
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.UDP1_4.Connector
 
tableChanged(TableModelEvent) - Method in class org.jgroups.demos.DistributedTreeDemo
 
table_lock - Variable in class org.jgroups.blocks.TransactionalHashtable
 
tail - Variable in class org.jgroups.util.List
 
target - Variable in class org.jgroups.stack.StateTransferInfo
 
targets - Variable in class org.jgroups.stack.StateTransferInfo
 
tenant - Variable in class org.jgroups.service.lease.RecursiveLeaseRequestException
 
threadMonitor - Variable in class org.jgroups.service.AbstractService
 
timeout - Variable in class org.jgroups.blocks.GroupRequest
 
timer - Variable in class org.jgroups.stack.ProtocolStack
 
timestamp - Variable in class org.jgroups.stack.LogicalAddress1_4
 
tmp_members - Variable in class org.jgroups.protocols.pbcast.GMS
 
toAsciiString(String[]) - Method in class org.jgroups.ensemble.Hot_Buffer
 
toString() - Method in class org.jgroups.BlockEvent
 
toString() - Method in class org.jgroups.ChannelClosedException
 
toString() - Method in class org.jgroups.ChannelException
 
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.TransactionalHashtable.Data
 
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() - Method in class org.jgroups.ensemble.Hot_Endpoint
 
toString() - Method in class org.jgroups.ensemble.Hot_Error
 
toString() - Method in class org.jgroups.ensemble.Hot_GroupContext
 
toString() - Method in class org.jgroups.ensemble.Hot_ViewID
 
toString() - Method in class org.jgroups.ensemble.Hot_ViewState
 
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.Digest
 
toString() - Method in class org.jgroups.protocols.ENCRYPT1_4.EncryptHeader
 
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.FRAG.FragHeader
 
toString() - Method in class org.jgroups.protocols.FRAG2.FragHeader
 
toString() - Method in class org.jgroups.protocols.FlushRsp
 
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.TCP
 
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.TRACE
 
toString() - Method in class org.jgroups.protocols.TUNNEL
 
toString() - Method in class org.jgroups.protocols.TcpHeader
 
toString() - Method in class org.jgroups.protocols.TunnelHeader
 
toString() - Method in class org.jgroups.protocols.UDP
debug only
toString() - Method in class org.jgroups.protocols.UDP1_4.Connector
 
toString() - Method in class org.jgroups.protocols.UDP1_4.ConnectorTable
 
toString() - Method in class org.jgroups.protocols.UDP1_4
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.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
 
toString() - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
 
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.LogicalAddress1_4
 
toString(boolean) - Method in class org.jgroups.stack.LogicalAddress1_4
 
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.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(String) - Static method in class org.jgroups.ensemble.Hot_Ensemble
Prints (or does not print) the specified string to standard error based upon the debug flag
transaction_mode - Variable in class org.jgroups.blocks.TransactionalHashtable
 
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
 
transports - Variable in class org.jgroups.ensemble.Hot_JoinOps
 
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(int) - Method in class org.jgroups.protocols.UNICAST.UnicastHeader
 
type2Str(int) - 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(int) - 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.

U

UCAST - Static variable in class org.jgroups.protocols.TOTAL.Header
Unicast message
UDP - class org.jgroups.protocols.UDP.
IP multicast transport based on UDP.
UDP() - Constructor for class org.jgroups.protocols.UDP
public constructor.
UDP.UcastReceiver - class org.jgroups.protocols.UDP.UcastReceiver.
 
UDP.UcastReceiver() - Constructor for class org.jgroups.protocols.UDP.UcastReceiver
 
UDP1_4 - class org.jgroups.protocols.UDP1_4.
Multicast transport.
UDP1_4() - Constructor for class org.jgroups.protocols.UDP1_4
Public constructor.
UDP1_4.Connector - class org.jgroups.protocols.UDP1_4.Connector.
Manages a multicast and unicast socket on a given interface (NIC).
UDP1_4.Connector(NetworkInterface, int, int, int, int, int, int, Receiver) - Constructor for class org.jgroups.protocols.UDP1_4.Connector
 
UDP1_4.ConnectorTable - class org.jgroups.protocols.UDP1_4.ConnectorTable.
Manages a bunch of Connectors
UDP1_4.ConnectorTable(InetSocketAddress, int, int, boolean, Receiver) - Constructor for class org.jgroups.protocols.UDP1_4.ConnectorTable
 
UDP1_4.Mailman - class org.jgroups.protocols.UDP1_4.Mailman.
 
UDP1_4.Mailman() - Constructor for class org.jgroups.protocols.UDP1_4.Mailman
 
UDP1_4.MulticastReceiver - class org.jgroups.protocols.UDP1_4.MulticastReceiver.
 
UDP1_4.MulticastReceiver() - Constructor for class org.jgroups.protocols.UDP1_4.MulticastReceiver
 
UDP1_4.MyReceiver - class org.jgroups.protocols.UDP1_4.MyReceiver.
 
UDP1_4.MyReceiver() - Constructor for class org.jgroups.protocols.UDP1_4.MyReceiver
 
UDP1_4.Unmarshaller - class org.jgroups.protocols.UDP1_4.Unmarshaller.
 
UDP1_4.Unmarshaller() - Constructor for class org.jgroups.protocols.UDP1_4.Unmarshaller
 
UNBLOCK_SEND - Static variable in class org.jgroups.Event
 
UNDEFINED - Static variable in class org.jgroups.protocols.ring.TokenLostException
 
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(int, long) - Constructor for class org.jgroups.protocols.UNICAST.UnicastHeader
 
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
 
UnknownLeaseException - exception org.jgroups.service.lease.UnknownLeaseException.
 
UnknownLeaseException(Lease) - Constructor for class org.jgroups.service.lease.UnknownLeaseException
 
UnknownLeaseException(String, Lease) - Constructor for class org.jgroups.service.lease.UnknownLeaseException
 
UpHandler - interface org.jgroups.UpHandler.
 
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
 
Util1_4 - class org.jgroups.util.Util1_4.
Util1_4
Util1_4() - Constructor for class org.jgroups.util.Util1_4
 
unknownLease - Variable in class org.jgroups.service.lease.UnknownLeaseException
 
unlock(Object, Object) - Method in class org.jgroups.blocks.DistributedLockManager
Unlocks an object with lockId on behalf of the specified owner.
unlock(Object, Object) - Method in interface org.jgroups.blocks.LockManager
Release lock on obj owned by specified owner.
unlock() - Method in class org.jgroups.util.ReentrantLatch
Unlock the latch.
unregisterListener(Serializable) - Method in class org.jgroups.blocks.PullPushAdapter
removes a listener to a given identifier from the listeners map
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
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
 
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.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.MERGE
 
up(Event) - Method in class org.jgroups.protocols.MERGE2
 
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.PIGGYBACK
 
up(Event) - Method in class org.jgroups.protocols.PING
An event was received from the layer below.
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.TCPGOSSIP
 
up(Event) - Method in class org.jgroups.protocols.TCPPING
 
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.TRACE
 
up(Event) - Method in class org.jgroups.protocols.UDP
handle the UP event.
up(Event) - Method in class org.jgroups.protocols.UDP1_4
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.WANPING
 
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
 
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
 
use_properties - Variable in class org.jgroups.ensemble.Hot_JoinOps
 

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_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
 
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.
 
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 Only one view is installed in a channel at a time Views contain the address of its creator, an ID and a list of member addresses These adresses are ordered, and the first address is always the coordinator of the view This way, each member of the group knows who the new coordinator will be if the current one crashes or leaves the 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
 
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.blocks.TransactionalHashtable
 
version - Static variable in class org.jgroups.Version
 
version - Variable in class org.jgroups.ensemble.Hot_ViewState
 
version_id - Static variable in class org.jgroups.Version
 
vid - Variable in class org.jgroups.View
 
viewAccepted(View) - Method in interface org.jgroups.MembershipListener
Called by JGroups to notify the target object of a change of membership.
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
 
viewAccepted(View) - Method in class org.jgroups.service.AbstractService
This method is called when new view is installed.
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 interface org.jgroups.blocks.TransactionalHashtable.Notification
 
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
 
view_id - Variable in class org.jgroups.ensemble.Hot_ViewState
 
view_id - Variable in class org.jgroups.protocols.GMS
 
view_id - Variable in class org.jgroups.protocols.pbcast.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, int, long) - 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) - 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
 
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
 
waitOnBlocked() - Method in class org.jgroups.service.AbstractService
Stop current thread's execution until inter-service channel is unblocked.
waitUntilAllAcksReceived(long) - Method in class org.jgroups.stack.AckMcastSenderWindow
Waits until all outstanding messages have been ACKed by all receivers.
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.
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
 
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
Write out the header to the given stream
writeExternal(ObjectOutput) - Method in class org.jgroups.blocks.TransactionalHashtable.Data
 
writeExternal(ObjectOutput) - Method in class org.jgroups.blocks.Xid
 
writeExternal(ObjectOutput) - Method in class org.jgroups.ensemble.Hot_Endpoint
 
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.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.FRAG.FragHeader
 
writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.FRAG2.FragHeader
 
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.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.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.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.service.lease.DenyResponseHeader
Write state of this object into object output.
writeExternal(ObjectOutput) - Method in class org.jgroups.service.lease.LeaseFactoryService.LeaseInfo
 
writeExternal(ObjectOutput) - Method in class org.jgroups.service.lease.LeaseInfoReplicationHeader
Write state of this header into ObjectOutput.
writeExternal(ObjectOutput) - Method in class org.jgroups.service.lease.LeaseRequestHeader
Write state of this object into object output stream.
writeExternal(ObjectOutput) - Method in class org.jgroups.service.lease.LeaseResponseHeader
Write state of this object into object output.
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.LogicalAddress1_4
 
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.Util1_4
 
writeLock() - Method in class org.jgroups.util.RWLock
Obtain a write lock
writeLockNoBlock() - Method in class org.jgroups.util.RWLock
Obtain the write lock immediatelly or throw an exception if an attempt to get the write lock would block this call
writeUnlock() - Method in class org.jgroups.util.RWLock
Revoke the write lock
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
 
xfer_view - Variable in class org.jgroups.ensemble.Hot_ViewState
 
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
 
_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 ? 2001,2002 www.jgroups.com . All Rights Reserved.